Class SerializedUpdateBuffer

  • All Implemented Interfaces:
    DataOutput, org.apache.flink.core.memory.DataOutputView, org.apache.flink.core.memory.MemorySegmentWritable

    public class SerializedUpdateBuffer
    extends AbstractPagedOutputView
    AbstractPagedOutputView used by the BlockingBackChannel for transmitting superstep results.
    • Constructor Detail

      • SerializedUpdateBuffer

        public SerializedUpdateBuffer()
      • SerializedUpdateBuffer

        public SerializedUpdateBuffer​(List<org.apache.flink.core.memory.MemorySegment> memSegments,
                                      int segmentSize,
                                      IOManager ioManager)
    • Method Detail

      • nextSegment

        protected org.apache.flink.core.memory.MemorySegment nextSegment​(org.apache.flink.core.memory.MemorySegment current,
                                                                         int positionInCurrent)
                                                                  throws IOException
        Description copied from class: AbstractPagedOutputView
        This method must return a segment. If no more segments are available, it must throw an EOFException.
        Specified by:
        nextSegment in class AbstractPagedOutputView
        Parameters:
        current - The current memory segment
        positionInCurrent - The position in the segment, one after the last valid byte.
        Returns:
        The next memory segment.
        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()