Class SerializedUpdateBuffer
- java.lang.Object
-
- org.apache.flink.runtime.memory.AbstractPagedOutputView
-
- org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
-
- All Implemented Interfaces:
DataOutput,org.apache.flink.core.memory.DataOutputView,org.apache.flink.core.memory.MemorySegmentWritable
public class SerializedUpdateBuffer extends AbstractPagedOutputView
AbstractPagedOutputViewused by theBlockingBackChannelfor transmitting superstep results.
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.memory.AbstractPagedOutputView
headerLength, segmentSize
-
-
Constructor Summary
Constructors Constructor Description SerializedUpdateBuffer()SerializedUpdateBuffer(List<org.apache.flink.core.memory.MemorySegment> memSegments, int segmentSize, IOManager ioManager)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description List<org.apache.flink.core.memory.MemorySegment>close()voidflush()protected org.apache.flink.core.memory.MemorySegmentnextSegment(org.apache.flink.core.memory.MemorySegment current, int positionInCurrent)This method must return a segment.org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer.ReadEndswitchBuffers()-
Methods inherited from class org.apache.flink.runtime.memory.AbstractPagedOutputView
advance, clear, getCurrentPositionInSegment, getCurrentSegment, getHeaderLength, getSegmentSize, seekOutput, skipBytesToWrite, write, write, write, write, write, writeBoolean, writeByte, writeBytes, writeChar, writeChars, writeDouble, writeFloat, writeInt, writeLong, writeShort, writeUTF
-
-
-
-
Method Detail
-
nextSegment
protected org.apache.flink.core.memory.MemorySegment nextSegment(org.apache.flink.core.memory.MemorySegment current, int positionInCurrent) throws IOExceptionDescription copied from class:AbstractPagedOutputViewThis method must return a segment. If no more segments are available, it must throw anEOFException.- Specified by:
nextSegmentin classAbstractPagedOutputView- Parameters:
current- The current memory segmentpositionInCurrent- The position in the segment, one after the last valid byte.- Returns:
- The next memory segment.
- Throws:
IOException
-
flush
public void flush() throws IOException- Throws:
IOException
-
switchBuffers
public org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer.ReadEnd switchBuffers() throws IOException- Throws:
IOException
-
close
public List<org.apache.flink.core.memory.MemorySegment> close()
-
-