public class SerializedUpdateBuffer extends AbstractPagedOutputView
AbstractPagedOutputView used by the BlockingBackChannel for
 transmitting superstep results.headerLength, segmentSize| Constructor and Description | 
|---|
SerializedUpdateBuffer()  | 
SerializedUpdateBuffer(List<org.apache.flink.core.memory.MemorySegment> memSegments,
                      int segmentSize,
                      IOManager ioManager)  | 
| Modifier and Type | Method and Description | 
|---|---|
List<org.apache.flink.core.memory.MemorySegment> | 
close()  | 
void | 
flush()  | 
protected org.apache.flink.core.memory.MemorySegment | 
nextSegment(org.apache.flink.core.memory.MemorySegment current,
           int positionInCurrent)
This method must return a segment. 
 | 
org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer.ReadEnd | 
switchBuffers()  | 
advance, clear, getCurrentPositionInSegment, getCurrentSegment, getHeaderLength, getSegmentSize, seekOutput, skipBytesToWrite, write, write, write, write, write, writeBoolean, writeByte, writeBytes, writeChar, writeChars, writeDouble, writeFloat, writeInt, writeLong, writeShort, writeUTFprotected org.apache.flink.core.memory.MemorySegment nextSegment(org.apache.flink.core.memory.MemorySegment current,
                                                                 int positionInCurrent)
                                                          throws IOException
AbstractPagedOutputViewEOFException.nextSegment in class AbstractPagedOutputViewcurrent - The current memory segmentpositionInCurrent - The position in the segment, one after the last valid byte.IOExceptionpublic void flush()
           throws IOException
IOExceptionpublic org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer.ReadEnd switchBuffers()
                                                                                   throws IOException
IOExceptionpublic List<org.apache.flink.core.memory.MemorySegment> close()
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.