Package org.apache.flink.api.common

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


      DeltaIteration<Tuple2<Long, Long>, Tuple2<Long, Long>> iteration = input.iterateDelta(input, 100, 1);
     
      DataSet<Tuple2<Long, Long>> iterEnd = iteration.getWorkset().map(new TestMapper<Tuple2<Long,Long>>());
      iteration.closeWith(iterEnd, iterEnd).print();
     
      Plan p = env.createProgramPlan();
      OptimizedPlan op = compileNoStats(p);
     
      WorksetIterationPlanNode wipn = (WorksetIterationPlanNode) op.getDataSinks().iterator().next().getInput().getSource();
      assertTrue(wipn.getSolutionSetPlanNode().getOutgoingChannels().isEmpty());
     
View Full Code Here


  }
 
 
  @Override
  public JobExecutionResult execute(String jobName) throws Exception {
    Plan p = createProgramPlan(jobName);
   
    PlanExecutor executor = PlanExecutor.createRemoteExecutor(host, port, jarFiles);
    return executor.executePlan(p);
  }
View Full Code Here

    return executor.executePlan(p);
  }
 
  @Override
  public String getExecutionPlan() throws Exception {
    Plan p = createProgramPlan("unnamed");
    p.setDefaultParallelism(getDegreeOfParallelism());
    registerCachedFilesWithPlan(p);
   
    PlanExecutor executor = PlanExecutor.createRemoteExecutor(host, port, jarFiles);
    return executor.getOptimizerPlanAsJSON(p);
  }
View Full Code Here

   */
  @Test
  public void testRightSide() {
    try {
     
      Plan plan = getTestPlanRightStatic(PactCompiler.HINT_LOCAL_STRATEGY_HASH_BUILD_SECOND);
     
      OptimizedPlan oPlan = compileNoStats(plan);
 
      OptimizerPlanNodeResolver resolver = getOptimizerPlanNodeResolver(oPlan);
      DualInputPlanNode innerJoin = resolver.getNode("DummyJoiner");
View Full Code Here

   */
  @Test
  public void testRightSideCountercheck() {
    try {
     
      Plan plan = getTestPlanRightStatic(PactCompiler.HINT_LOCAL_STRATEGY_HASH_BUILD_FIRST);
     
      OptimizedPlan oPlan = compileNoStats(plan);
 
      OptimizerPlanNodeResolver resolver = getOptimizerPlanNodeResolver(oPlan);
      DualInputPlanNode innerJoin = resolver.getNode("DummyJoiner");
View Full Code Here

   */
  @Test
  public void testLeftSide() {
    try {
     
      Plan plan = getTestPlanLeftStatic(PactCompiler.HINT_LOCAL_STRATEGY_HASH_BUILD_FIRST);
     
      OptimizedPlan oPlan = compileNoStats(plan);
 
      OptimizerPlanNodeResolver resolver = getOptimizerPlanNodeResolver(oPlan);
      DualInputPlanNode innerJoin = resolver.getNode("DummyJoiner");
View Full Code Here

   */
  @Test
  public void testLeftSideCountercheck() {
    try {
     
      Plan plan = getTestPlanLeftStatic(PactCompiler.HINT_LOCAL_STRATEGY_HASH_BUILD_SECOND);
     
      OptimizedPlan oPlan = compileNoStats(plan);
 
      OptimizerPlanNodeResolver resolver = getOptimizerPlanNodeResolver(oPlan);
      DualInputPlanNode innerJoin = resolver.getNode("DummyJoiner");
View Full Code Here

   */
  @Test
  public void testCorrectChoosing() {
    try {
     
      Plan plan = getTestPlanRightStatic("");
     
      SourceCollectorVisitor sourceCollector = new SourceCollectorVisitor();
      plan.accept(sourceCollector);
     
      for(GenericDataSourceBase<?, ?> s : sourceCollector.getSources()) {
        if(s.getName().equals("bigFile")) {
          this.setSourceStatistics(s, 10000000, 1000);
        }
View Full Code Here

      throw new Client.ProgramAbortException();
    }

    @Override
    public String getExecutionPlan() throws Exception {
      Plan plan = createProgramPlan("unused");
      this.previewPlan = PactCompiler.createPreOptimizedPlan(plan);
     
      // do not go on with anything now!
      throw new Client.ProgramAbortException();
    }
View Full Code Here

 
  // --------------------------------------------------------------------------------------------
 
  @Override
  public JobExecutionResult execute(String jobName) throws Exception {
    Plan p = createProgramPlan(jobName);
   
    PlanExecutor executor = PlanExecutor.createLocalExecutor();
    return executor.executePlan(p);
  }
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.