Package org.apache.flink.runtime.io.network.gates

Examples of org.apache.flink.runtime.io.network.gates.GateID


  private static class MockInputGate extends InputGate<Record> {
   
    private MutableObjectIterator<Record> it;

    public MockInputGate(int id, MutableObjectIterator<Record> it) {
      super(new JobID(), new GateID(), id);
      this.it = it;
    }
View Full Code Here


    private RecordDeserializer<Record> deserializer;

    private Record record;

    public MockOutputGate(int index, List<Record> outList) {
      super(new JobID(), new GateID(), index);
      this.out = outList;
      this.deserializer = new AdaptiveSpanningRecordDeserializer<Record>();
      this.record = new Record();
    }
View Full Code Here

    return this.unboundInputGateIDs.poll();
  }

  @Override
  public OutputGate createAndRegisterOutputGate() {
    OutputGate gate = new OutputGate(getJobID(), new GateID(), getNumberOfOutputGates());
    this.outputGates.add(gate);

    return gate;
  }
View Full Code Here

    }
  }

  @Override
  public <T extends IOReadableWritable> InputGate<T> createAndRegisterInputGate() {
    InputGate<T> gate = new InputGate<T>(getJobID(), new GateID(), getNumberOfInputGates());
    this.inputGates.add(gate);

    return gate;
  }
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.io.network.gates.GateID

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.