Package org.apache.flink.test.recordJobs.kmeans.udfs

Examples of org.apache.flink.test.recordJobs.kmeans.udfs.PointOutFormat


   
    IterativeDataSet<Record> iteration = initialInput.iterate(2);
   
    DataSet<Record> result = iteration.union(iteration).map(new IdentityMapper());
   
    iteration.closeWith(result).write(new PointOutFormat(), this.resultPath);
   
    env.execute();
  }
View Full Code Here


        .name("Reduce something").build();

    MapOperator dummyMap = MapOperator.builder(new IdentityMapper()).input(dummyReduce).build();
    iteration.setNextPartialSolution(dummyMap);

    FileDataSink finalResult = new FileDataSink(new PointOutFormat(), output, iteration, "Output");

    Plan plan = new Plan(finalResult, "Iteration with chained map test");
    plan.setDefaultParallelism(numSubTasks);
    return plan;
  }
View Full Code Here

        .input(computeFinalDistance)
        .name("Find Nearest Final Centers")
        .build();

    // create DataSinkContract for writing the new cluster positions
    FileDataSink finalClusters = new FileDataSink(new PointOutFormat(), output+"/centers", iteration, "Cluster Positions");

    // write assigned clusters
    FileDataSink clusterAssignments = new FileDataSink(new PointOutFormat(), output+"/points", findNearestFinalCluster, "Cluster Assignments");
   
    List<FileDataSink> sinks = new ArrayList<FileDataSink>();
    sinks.add(finalClusters);
    sinks.add(clusterAssignments);
   
View Full Code Here

TOP

Related Classes of org.apache.flink.test.recordJobs.kmeans.udfs.PointOutFormat

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.