Package org.apache.flink.compiler.plan

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


   * @return JSON dump of the optimized plan.
   * @throws Exception
   */
  public String getOptimizerPlanAsJSON(Plan plan) throws Exception {
    PactCompiler pc = new PactCompiler(new DataStatistics());
    OptimizedPlan op = pc.compile(plan);
    PlanJSONDumpGenerator gen = new PlanJSONDumpGenerator();
 
    return gen.getOptimizerPlanAsJSON(op);
  }
View Full Code Here


  public static String optimizerPlanAsJSON(Plan plan) throws Exception {
    LocalExecutor exec = new LocalExecutor();
    try {
      exec.start();
      PactCompiler pc = new PactCompiler(new DataStatistics());
      OptimizedPlan op = pc.compile(plan);
      PlanJSONDumpGenerator gen = new PlanJSONDumpGenerator();

      return gen.getOptimizerPlanAsJSON(op);
    } finally {
      exec.stop();
View Full Code Here

    if (p == null) {
      Assert.fail("Error: Cannot obtain Pact plan. Did the thest forget to override either 'getPactPlan()' or 'getJobGraph()' ?");
    }
   
    PactCompiler pc = new PactCompiler(new DataStatistics());
    OptimizedPlan op = pc.compile(p);
   
    if (printPlan) {
      System.out.println(new PlanJSONDumpGenerator().getOptimizerPlanAsJSON(op));
    }
View Full Code Here

     
      InetAddress mockAddress = InetAddress.getLocalHost();
      InetSocketAddress mockJmAddress = new InetSocketAddress(mockAddress, 12345);
     
      Client client = new Client(mockJmAddress, new Configuration(), getClass().getClassLoader());
      OptimizedPlan op = client.getOptimizedPlan(prg, -1);
      assertNotNull(op);
     
      PlanJSONDumpGenerator dumper = new PlanJSONDumpGenerator();
      assertNotNull(dumper.getOptimizerPlanAsJSON(op));
     
View Full Code Here

      }

      // create the plan
      String[] options = params.isEmpty() ? new String[0] : (String[]) params.toArray(new String[params.size()]);
      PackagedProgram program;
      OptimizedPlan optPlan;
      Client client;
     
      try {
        if (assemblerClass == null) {
          program = new PackagedProgram(jarFile, options);
View Full Code Here

TOP

Related Classes of org.apache.flink.compiler.plan.OptimizedPlan

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.