public class SerializedUpdateBuffer extends AbstractPagedOutputView
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, getSegmentSize, seekOutput, skipBytesToWrite, write, write, write, write, writeBoolean, writeByte, writeBytes, writeChar, writeChars, writeDouble, writeFloat, writeInt, writeLong, writeShort, writeUTF
protected org.apache.flink.core.memory.MemorySegment nextSegment(org.apache.flink.core.memory.MemorySegment current, int positionInCurrent) throws IOException
AbstractPagedOutputView
EOFException
.nextSegment
in class AbstractPagedOutputView
current
- The current memory segmentpositionInCurrent
- The position in the segment, one after the last valid byte.IOException
public void flush() throws IOException
IOException
public org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer.ReadEnd switchBuffers() throws IOException
IOException
public List<org.apache.flink.core.memory.MemorySegment> close()
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.