Package org.apache.flink.compiler.plan

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


      DataSet<Tuple2<Long, Long>> depResult = doDeltaIteration(mappedBulk, edges);
     
      depResult.print();
     
      Plan p = env.createProgramPlan();
      OptimizedPlan op = compileNoStats(p);
     
      assertEquals(1, op.getDataSinks().size());
      assertTrue(op.getDataSinks().iterator().next().getInput().getSource() instanceof WorksetIterationPlanNode);
     
      WorksetIterationPlanNode wipn = (WorksetIterationPlanNode) op.getDataSinks().iterator().next().getInput().getSource();
     
      assertEquals(ShipStrategyType.PARTITION_HASH, wipn.getInput1().getShipStrategy());
      assertTrue(wipn.getInput2().getTempMode().breaksPipeline());
    }
    catch (Exception e) {
View Full Code Here


      DataSet<Tuple2<Long, Long>> depResult = doDeltaIteration(bulkResult, edges);
     
      depResult.print();
     
      Plan p = env.createProgramPlan();
      OptimizedPlan op = compileNoStats(p);
     
      assertEquals(1, op.getDataSinks().size());
      assertTrue(op.getDataSinks().iterator().next().getInput().getSource() instanceof WorksetIterationPlanNode);
     
      WorksetIterationPlanNode wipn = (WorksetIterationPlanNode) op.getDataSinks().iterator().next().getInput().getSource();
     
      assertEquals(ShipStrategyType.PARTITION_HASH, wipn.getInput1().getShipStrategy());
      assertTrue(wipn.getInput2().getTempMode().breaksPipeline());
    }
    catch (Exception e) {
View Full Code Here

      DataSet<Tuple2<Long, Long>> secondResult = doDeltaIteration(firstResult, edges);
     
      secondResult.print();
     
      Plan p = env.createProgramPlan();
      OptimizedPlan op = compileNoStats(p);
     
      assertEquals(1, op.getDataSinks().size());
      assertTrue(op.getDataSinks().iterator().next().getInput().getSource() instanceof WorksetIterationPlanNode);
     
      WorksetIterationPlanNode wipn = (WorksetIterationPlanNode) op.getDataSinks().iterator().next().getInput().getSource();
     
      assertEquals(ShipStrategyType.FORWARD, wipn.getInput1().getShipStrategy());
      assertTrue(wipn.getInput2().getTempMode().breaksPipeline());
    }
    catch (Exception e) {
View Full Code Here

      DataSet<Tuple2<Long, Long>> input2 = env.readCsvFile("/some/file/path").types(Long.class, Long.class);
     
      doBulkIteration(input1, input2).print();
     
      Plan p = env.createProgramPlan();
      OptimizedPlan op = compileNoStats(p);
     
      assertEquals(1, op.getDataSinks().size());
      assertTrue(op.getDataSinks().iterator().next().getInput().getSource() instanceof BulkIterationPlanNode);
     
      BulkIterationPlanNode bipn = (BulkIterationPlanNode) op.getDataSinks().iterator().next().getInput().getSource();
     
      // check that work has not! been pushed out, as the end of the step function does not produce the necessary properties
      for (Channel c : bipn.getPartialSolutionPlanNode().getOutgoingChannels()) {
        assertEquals(ShipStrategyType.PARTITION_HASH, c.getShipStrategy());
      }
View Full Code Here

     
      IterativeDataSet<Long> iteration = env.generateSequence(-4, 1000).iterate(100);
      iteration.closeWith(iteration).print();
     
      Plan p = env.createProgramPlan();
      OptimizedPlan op = compileNoStats(p);
     
      new NepheleJobGraphGenerator().compileJobGraph(op);
    }
    catch (Exception e) {
      e.printStackTrace();
View Full Code Here

      DeltaIteration<Tuple2<Long, Long>, Tuple2<Long, Long>> iter = input.iterateDelta(input, 100, 0);
      iter.closeWith(iter.getWorkset(), iter.getWorkset())
        .print();
     
      Plan p = env.createProgramPlan();
      OptimizedPlan op = compileNoStats(p);
     
      new NepheleJobGraphGenerator().compileJobGraph(op);
    }
    catch (Exception e) {
      e.printStackTrace();
View Full Code Here

      iteration.closeWith(
          iteration.map(new IdentityMapper<Long>()).union(iteration.map(new IdentityMapper<Long>())))
          .print();
     
      Plan p = env.createProgramPlan();
      OptimizedPlan op = compileNoStats(p);
     
      new NepheleJobGraphGenerator().compileJobGraph(op);
    }
    catch (Exception e) {
      e.printStackTrace();
View Full Code Here

            iter.getWorkset().map(new IdentityMapper<Tuple2<Long,Long>>()))
        )
      .print();
     
      Plan p = env.createProgramPlan();
      OptimizedPlan op = compileNoStats(p);
     
      new NepheleJobGraphGenerator().compileJobGraph(op);
    }
    catch (Exception e) {
      e.printStackTrace();
View Full Code Here

   
   
    Plan plan = new Plan(sink, "Test Temp Task");
    plan.setDefaultParallelism(DEFAULT_PARALLELISM);
   
    OptimizedPlan oPlan;
    try {
      oPlan = compileNoStats(plan);
    } catch(CompilerException ce) {
      ce.printStackTrace();
      fail("The pact compiler is unable to compile this plan correctly.");
View Full Code Here

    FileDataSink sink = new FileDataSink(new DummyOutputFormat(), OUT_FILE, coGroup, "Sink");
   
    Plan plan = new Plan(sink, "Reduce Group Order Test");
    plan.setDefaultParallelism(DEFAULT_PARALLELISM);
   
    OptimizedPlan oPlan;
    try {
      oPlan = compileNoStats(plan);
    } catch(CompilerException ce) {
      ce.printStackTrace();
      fail("The pact compiler is unable to compile this plan correctly.");
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.