Package org.apache.flink.runtime.iterative.io

Examples of org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer


  public void multiThreaded() throws InterruptedException {

    BlockingQueue<Integer> dataChannel = new ArrayBlockingQueue<Integer>(1);
    List<String> actionLog = Lists.newArrayList();

    SerializedUpdateBuffer buffer = Mockito.mock(SerializedUpdateBuffer.class);
    BlockingBackChannel channel = new BlockingBackChannel(buffer);

    Thread head = new Thread(new IterationHead(channel, dataChannel, actionLog));
    Thread tail = new Thread(new IterationTail(channel, dataChannel, actionLog));
View Full Code Here


    List<MemorySegment> segments = new ArrayList<MemorySegment>();
    int segmentSize = getMemoryManager().getPageSize();
    getMemoryManager().allocatePages(this, segments, backChannelMemoryPages);

    /* instantiate the backchannel */
    BlockingBackChannel backChannel = new BlockingBackChannel(new SerializedUpdateBuffer(segments, segmentSize,
      getIOManager()));

    /* hand the backchannel over to the iteration tail */
    Broker<BlockingBackChannel> broker = BlockingBackChannelBroker.instance();
    broker.handIn(brokerKey(), backChannel);
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer

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.