Examples of OptimizedPlan


Examples of org.apache.flink.compiler.plan.OptimizedPlan

  public void testWorksetConnectedComponentsWithSolutionSetAsFirstInput() {

    Plan plan = getPlanForWorksetConnectedComponentsWithSolutionSetAsFirstInput(DEFAULT_PARALLELISM,
        IN_FILE, IN_FILE, OUT_FILE, 100);

    OptimizedPlan optPlan = compileNoStats(plan);
    OptimizerPlanNodeResolver or = getOptimizerPlanNodeResolver(optPlan);
   
    if (PRINT_PLAN) {
      PlanJSONDumpGenerator dumper = new PlanJSONDumpGenerator();
      String json = dumper.getOptimizerPlanAsJSON(optPlan);
View Full Code Here

Examples of org.apache.flink.compiler.plan.OptimizedPlan

    ConnectedComponentsWithCoGroup cc = new ConnectedComponentsWithCoGroup();

    Plan plan = cc.getPlan(String.valueOf(DEFAULT_PARALLELISM),
        IN_FILE, IN_FILE, OUT_FILE, String.valueOf(100));

    OptimizedPlan optPlan = compileNoStats(plan);
    OptimizerPlanNodeResolver or = getOptimizerPlanNodeResolver(optPlan);
   
    if (PRINT_PLAN) {
      PlanJSONDumpGenerator dumper = new PlanJSONDumpGenerator();
      String json = dumper.getOptimizerPlanAsJSON(optPlan);
View Full Code Here

Examples of org.apache.flink.compiler.plan.OptimizedPlan

 
      finalPageRanks.print();
 
      // get the plan and compile it
      Plan p = env.createProgramPlan();
      OptimizedPlan op = compileNoStats(p);
     
      SinkPlanNode sinkPlanNode = (SinkPlanNode) op.getDataSinks().iterator().next();
      BulkIterationPlanNode iterPlanNode = (BulkIterationPlanNode) sinkPlanNode.getInput().getSource();
     
      // check that the partitioning is pushed out of the first loop
      Assert.assertEquals(ShipStrategyType.PARTITION_HASH, iterPlanNode.getInput().getShipStrategy());
      Assert.assertEquals(LocalStrategy.NONE, iterPlanNode.getInput().getLocalStrategy());
View Full Code Here

Examples of org.apache.flink.compiler.plan.OptimizedPlan

    FileDataSource pointsSource = cr.getNode(DATAPOINTS);
    FileDataSource centersSource = cr.getNode(CENTERS);
    setSourceStatistics(pointsSource, 100l*1024*1024*1024, 32f);
    setSourceStatistics(centersSource, 1024*1024, 32f);
   
    OptimizedPlan plan = compileWithStats(p);
    checkPlan(plan);
   
    new NepheleJobGraphGenerator().compileJobGraph(plan);
  }
View Full Code Here

Examples of org.apache.flink.compiler.plan.OptimizedPlan

  public void testCompileKMeansSingleStepWithOutStats() {
   
    KMeansBroadcast kmi = new KMeansBroadcast();
    Plan p = kmi.getPlan(String.valueOf(DEFAULT_PARALLELISM), IN_FILE, IN_FILE, OUT_FILE, String.valueOf(20));
   
    OptimizedPlan plan = compileNoStats(p);
    checkPlan(plan);
   
    new NepheleJobGraphGenerator().compileJobGraph(plan);
  }
View Full Code Here

Examples of org.apache.flink.compiler.plan.OptimizedPlan

       
        result.print();
      }
     
      Plan p = env.createProgramPlan("Spargel Connected Components");
      OptimizedPlan op = compileNoStats(p);
     
      // check the sink
      SinkPlanNode sink = op.getDataSinks().iterator().next();
      assertEquals(ShipStrategyType.FORWARD, sink.getInput().getShipStrategy());
      assertEquals(DEFAULT_PARALLELISM, sink.getDegreeOfParallelism());
     
      // check the iteration
      WorksetIterationPlanNode iteration = (WorksetIterationPlanNode) sink.getInput().getSource();
View Full Code Here

Examples of org.apache.flink.compiler.plan.OptimizedPlan

       
        result.print();
      }
     
      Plan p = env.createProgramPlan("Spargel Connected Components");
      OptimizedPlan op = compileNoStats(p);
     
      // check the sink
      SinkPlanNode sink = op.getDataSinks().iterator().next();
      assertEquals(ShipStrategyType.FORWARD, sink.getInput().getShipStrategy());
      assertEquals(DEFAULT_PARALLELISM, sink.getDegreeOfParallelism());
     
      // check the iteration
      WorksetIterationPlanNode iteration = (WorksetIterationPlanNode) sink.getInput().getSource();
View Full Code Here

Examples of org.apache.flink.compiler.plan.OptimizedPlan

    Plan plan = new Plan(output);
    plan.setDefaultParallelism(DOP);

    // optimize and compile plan
    PactCompiler pc = new PactCompiler(new DataStatistics());
    OptimizedPlan op = pc.compile(plan);
   
    // return job graph of failing job
    NepheleJobGraphGenerator jgg = new NepheleJobGraphGenerator();
    return jgg.compileJobGraph(op);
  }
View Full Code Here

Examples of org.apache.flink.compiler.plan.OptimizedPlan

    Plan plan = new Plan(output);
    plan.setDefaultParallelism(4);

    // optimize and compile plan
    PactCompiler pc = new PactCompiler(new DataStatistics());
    OptimizedPlan op = pc.compile(plan);

    // return job graph of working job
    NepheleJobGraphGenerator jgg = new NepheleJobGraphGenerator();
    return jgg.compileJobGraph(op);
  }
View Full Code Here

Examples of org.apache.flink.compiler.plan.OptimizedPlan

              }
            }
          }
        }
      }
      return new OptimizedPlan(this.sources, this.sinks, this.allNodes, jobName, originalPlan);
    }
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. 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.