Package org.apache.flink.compiler.util

Examples of org.apache.flink.compiler.util.DummyOutputFormat


   
    ReduceOperator globalRed = ReduceOperator.builder(new IdentityReduce(), IntValue.class, 0).build();
    globalRed.addInput(redA);
    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);
View Full Code Here


    Ordering groupOrder2 = new Ordering(1, StringValue.class, Order.DESCENDING);
    groupOrder2.appendOrdering(4, DoubleValue.class, Order.ASCENDING);
    coGroup.setGroupOrderForInputOne(groupOrder1);
    coGroup.setGroupOrderForInputTwo(groupOrder2);
   
    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;
View Full Code Here

      iteration.setSolutionSetDelta(joinWithSolutionSet);
    }
   
    iteration.setNextWorkset(nextWorkset);

    FileDataSink sink = new FileDataSink(new DummyOutputFormat(), OUT_FILE, iteration, "Sink");
   
    Plan plan = new Plan(sink);
    plan.setDefaultParallelism(DEFAULT_PARALLELISM);
    return plan;
  }
View Full Code Here

   
    CrossOperator cross = CrossWithSmallOperator.builder(new DummyCrossStub())
        .input1(source1).input2(source2)
        .name("Cross").build();
 
    FileDataSink sink = new FileDataSink(new DummyOutputFormat(), OUT_FILE, cross, "Sink");
   
    Plan plan = new Plan(sink);
    plan.setDefaultParallelism(DEFAULT_PARALLELISM);
   
   
View Full Code Here

   
    CrossOperator cross= CrossWithLargeOperator.builder(new DummyCrossStub())
        .input1(source1).input2(source2)
        .name("Cross").build();
 
    FileDataSink sink = new FileDataSink(new DummyOutputFormat(), OUT_FILE, cross, "Sink");
   
    Plan plan = new Plan(sink);
    plan.setDefaultParallelism(DEFAULT_PARALLELISM);
   
   
View Full Code Here

      CoGroupOperator co = CoGroupOperator.builder(new DummyCoGroupStub(), IntValue.class, 0, 0)
        .input1(mat5)
        .input2(mat10)
        .build();
 
      FileDataSink sink = new FileDataSink(new DummyOutputFormat(), OUT_FILE, co);
     
      // return the PACT plan
      Plan plan = new Plan(sink, "Branching Source Multiple Times");
     
      OptimizedPlan oPlan = compileNoStats(plan);
View Full Code Here

      CrossOperator c = CrossOperator.builder(new DummyCrossStub())
        .input1(r)
        .input2(mat2)
        .build();
     
      FileDataSink sinkA = new FileDataSink(new DummyOutputFormat(), out1Path, c);
      FileDataSink sinkB = new FileDataSink(new DummyOutputFormat(), out2Path, mat2);
      FileDataSink sinkC = new FileDataSink(new DummyOutputFormat(), out3Path, mat2);
     
      List<FileDataSink> sinks = new ArrayList<FileDataSink>();
      sinks.add(sinkA);
      sinks.add(sinkB);
      sinks.add(sinkC);
View Full Code Here

        .input1(cogroup5)
        .input2(cogroup6)
        .name("CoGroup 7")
        .build();
     
      FileDataSink sink = new FileDataSink(new DummyOutputFormat(), OUT_FILE, cogroup7);
      sink.addInput(sourceA);
      sink.addInput(cogroup3);
      sink.addInput(cogroup4);
      sink.addInput(cogroup1);
     
View Full Code Here

        .input2(ma2)
        .name("Match 2")
        .build();
      mat2.setParameter(PactCompiler.HINT_LOCAL_STRATEGY, PactCompiler.HINT_LOCAL_STRATEGY_MERGE);
     
      FileDataSink sink = new FileDataSink(new DummyOutputFormat(), OUT_FILE, mat2);
     
     
      // return the PACT plan
      Plan plan = new Plan(sink, "Branching Union");
     
View Full Code Here

   
    ReduceOperator reduce = ReduceOperator.builder(new IdentityReduce()).keyField(IntValue.class, 2).name("Reduce").input(source).build();
    Ordering groupOrder = new Ordering(5, StringValue.class, Order.DESCENDING);
    reduce.setGroupOrder(groupOrder);
   
    FileDataSink sink = new FileDataSink(new DummyOutputFormat(), OUT_FILE, reduce, "Sink");
   
   
    Plan plan = new Plan(sink, "Test Temp Task");
    plan.setDefaultParallelism(DEFAULT_PARALLELISM);
   
View Full Code Here

TOP

Related Classes of org.apache.flink.compiler.util.DummyOutputFormat

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.