Package org.apache.flink.examples.java.graph.ConnectedComponents

Examples of org.apache.flink.examples.java.graph.ConnectedComponents.NeighborWithComponentIDJoin


    DeltaIteration<Tuple2<Long, Long>, Tuple2<Long, Long>> iteration =
        verticesWithInitialId.iterateDelta(verticesWithInitialId, 100, 0);
   
    // apply the step logic: join with the edges, select the minimum neighbor, update if the component of the candidate is smaller
    DataSet<Tuple2<Long, Long>> changes = iteration
        .getWorkset().join(edges).where(0).equalTo(0).with(new NeighborWithComponentIDJoin())
        .coGroup(iteration.getSolutionSet()).where(0).equalTo(0)
        .with(new MinIdAndUpdate());

    // close the delta iteration (delta and new workset are identical)
    DataSet<Tuple2<Long, Long>> result = iteration.closeWith(changes, changes);
View Full Code Here


    DeltaIteration<Tuple2<Long, Long>, Tuple2<Long, Long>> iteration =
        verticesWithInitialId.iterateDelta(verticesWithInitialId, 100, 0);
    iteration.setSolutionSetUnManaged(true);
       
    // apply the step logic: join with the edges, select the minimum neighbor, update if the component of the candidate is smaller
    DataSet<Tuple2<Long, Long>> changes = iteration.getWorkset().join(edges).where(0).equalTo(0).with(new NeighborWithComponentIDJoin())
        .groupBy(0).aggregate(Aggregations.MIN, 1)
        .join(iteration.getSolutionSet()).where(0).equalTo(0)
        .with(new ComponentIdFilter());

    // close the delta iteration (delta and new workset are identical)
View Full Code Here

TOP

Related Classes of org.apache.flink.examples.java.graph.ConnectedComponents.NeighborWithComponentIDJoin

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.