Package org.apache.flink.api.common

Examples of org.apache.flink.api.common.Plan


    if (args.length < 3) {
      System.err.println(wc.getDescription());
      System.exit(1);
    }

    Plan plan = wc.getPlan(args);

    // This will execute the word-count embedded in a local context. replace this line by the commented
    // succeeding line to send the job to a local installation or to a cluster for execution
    LocalExecutor.execute(plan);
//    PlanExecutor ex = new RemoteExecutor("localhost", 6123, "target/pact-examples-0.4-SNAPSHOT-WordCount.jar");
View Full Code Here


      .field(IntValue.class, 1)
      .field(StringValue.class, 0)
      .field(IntValue.class, 2);

    // Return the PACT plan
    Plan p = new Plan(result, "Weblog Analysis");
    p.setDefaultParallelism(numSubTasks);
    return p;
  }
View Full Code Here

    Assert.assertEquals(new Integer(NUM_ITERATIONS * 6), res);
  }

  @Override
  protected Plan getTestJob() {
    Plan plan = getTestPlanPlan(config.getInteger("IterationAllReducer#NoSubtasks", 1), dataPath, resultPath);
    return plan;
  }
View Full Code Here

    iteration.setNextPartialSolution(sumReduce);

    @SuppressWarnings("unchecked")
    FileDataSink finalResult = new FileDataSink(new CsvOutputFormat("\n"" ", StringValue.class), output, iteration, "Output");

    Plan plan = new Plan(finalResult, "Iteration with AllReducer (keyless Reducer)");
    plan.setDefaultParallelism(numSubTasks);
    return plan;
  }
View Full Code Here

    CsvOutputFormat.configureRecordFormat(finalResult)
      .recordDelimiter('\n')
      .fieldDelimiter(' ')
      .field(StringValue.class, 0);

    Plan plan = new Plan(finalResult, "Iteration with AllReducer (keyless Reducer)");
    plan.setDefaultParallelism(4);
    Assert.assertTrue(plan.getDefaultParallelism() > 1);
    return plan;
  }
View Full Code Here

      .name("Join Counts")
      .build();

    FileDataSink triangles = new FileDataSink(new EdgeWithDegreesOutputFormat(), output, countJoiner, "Unique Edges With Degrees");

    Plan p = new Plan(triangles, "Normalize Edges and compute Vertex Degrees");
    p.setDefaultParallelism(numSubTasks);
    return p;
  }
View Full Code Here

    output.setInput(testCoGrouper);
    testCoGrouper.setFirstInput(input_left);
    testCoGrouper.setSecondInput(input_right);

    return new Plan(output);
  }
View Full Code Here

        .recordDelimiter('\n')
        .fieldDelimiter(' ')
        .field(StringValue.class, 0)
        .field(IntValue.class, 1);

      Plan plan = new Plan(sink, "WordCount Union Reduce");
      plan.setDefaultParallelism(numSubtasks);

      return plan;
    }
View Full Code Here

    // create DataSinkContract for writing the new cluster positions
    FileDataSink newClusterPoints = new FileDataSink(new PointOutFormat(), output, recomputeClusterCenter, "New Center Positions");

    // return the plan
    Plan plan = new Plan(newClusterPoints, "KMeans Iteration");
    plan.setDefaultParallelism(numSubTasks);
    return plan;
  }
View Full Code Here

    join.setSecondInput(lineFilter);
    aggregation.setInput(join);
    result.setInput(aggregation);
   
     
    return new Plan(result, "TPC-H 4");
  }
View Full Code Here

TOP

Related Classes of org.apache.flink.api.common.Plan

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.