Package org.apache.flink.api.common

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


    return executor.executePlan(p);
  }
 
  @Override
  public String getExecutionPlan() throws Exception {
    Plan p = createProgramPlan();
   
    PlanExecutor executor = PlanExecutor.createLocalExecutor();
    return executor.getOptimizerPlanAsJSON(p);
  }
View Full Code Here


  private boolean mutableObjectSafeMode = true;
 
  @Override
  public JobExecutionResult execute(String jobName) throws Exception {
    Plan p = createProgramPlan(jobName);
   
    CollectionExecutor exec = new CollectionExecutor(mutableObjectSafeMode);
    return exec.execute(p);
  }
View Full Code Here

    this.userCodeClassLoader = userCodeClassLoader;
  }

  @Override
  public JobExecutionResult execute(String jobName) throws Exception {
    Plan p = createProgramPlan(jobName);
    JobWithJars toRun = new JobWithJars(p, this.jarFilesToAttach, this.userCodeClassLoader);
   
    return this.client.run(toRun, getDegreeOfParallelism(), true);
  }
View Full Code Here

    return this.client.run(toRun, getDegreeOfParallelism(), true);
  }

  @Override
  public String getExecutionPlan() throws Exception {
    Plan p = createProgramPlan("unnamed job");
   
    OptimizedPlan op = this.client.getOptimizedPlan(p, getDegreeOfParallelism());
   
    PlanJSONDumpGenerator gen = new PlanJSONDumpGenerator();
    return gen.getOptimizerPlanAsJSON(op);
View Full Code Here

    globalRed.addInput(redB);
   
    FileDataSink sink = new FileDataSink(new DummyOutputFormat(), OUT_FILE, globalRed);
   
    // return the plan
    Plan plan = new Plan(sink, "Union Property Propagation");
   
    OptimizedPlan oPlan = compileNoStats(plan);
   
    NepheleJobGraphGenerator jobGen = new NepheleJobGraphGenerator();
   
View Full Code Here

   
    DataSet<Tuple2<String, Integer>> result = lastUnion.groupBy(0).aggregate(Aggregations.SUM, 1);
    result.writeAsText(OUT_FILE);
 
    // return the plan
    Plan plan = env.createProgramPlan("Test union on new java-api");
    OptimizedPlan oPlan = compileNoStats(plan);
    NepheleJobGraphGenerator jobGen = new NepheleJobGraphGenerator();
   
    // Compile plan to verify that no error is thrown
    jobGen.compileJobGraph(oPlan);
View Full Code Here

      this.compiler = compiler;
    }
   
    @Override
    public JobExecutionResult execute(String jobName) throws Exception {
      Plan plan = createProgramPlan(jobName);
      this.optimizerPlan = compiler.compile(plan);
     
      // do not go on with anything now!
      throw new ProgramAbortException();
    }
View Full Code Here

      throw new ProgramAbortException();
    }

    @Override
    public String getExecutionPlan() throws Exception {
      Plan plan = createProgramPlan();
      this.optimizerPlan = compiler.compile(plan);
     
      // do not go on with anything now!
      throw new ProgramAbortException();
    }
View Full Code Here

    DataSet<Tuple1<Integer>> feedback = iteration.getWorkset().map(new SimpleMap());
    DataSet<Tuple1<Integer>> result = iteration.closeWith(delta, feedback);

    result.print();

    Plan plan = env.createProgramPlan();
    OptimizedPlan oPlan = null;
    try {
      oPlan = compileNoStats(plan);
    } catch(CompilerException e) {
      Assert.fail(e.getMessage());
View Full Code Here

    closeTriads.setParameter("INPUT_SHIP_STRATEGY", "SHIP_REPARTITION_HASH");
    closeTriads.setParameter("LOCAL_STRATEGY", "LOCAL_STRATEGY_HASH_BUILD_SECOND");

    FileDataSink triangles = new FileDataSink(new TriangleOutputFormat(), output, closeTriads, "Triangles");

    Plan p = new Plan(triangles, "Enumerate Triangles");
    p.setDefaultParallelism(numSubTasks);
    return 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.