Class HashPartition.BuildSideBuffer

  • All Implemented Interfaces:
    DataOutput, org.apache.flink.core.memory.DataOutputView, org.apache.flink.core.memory.MemorySegmentWritable
    Enclosing class:
    HashPartition<BT,​PT>

    protected static final class HashPartition.BuildSideBuffer
    extends AbstractPagedOutputView
    • Method Detail

      • nextSegment

        protected org.apache.flink.core.memory.MemorySegment nextSegment​(org.apache.flink.core.memory.MemorySegment current,
                                                                         int bytesUsed)
                                                                  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
        bytesUsed - The position in the segment, one after the last valid byte.
        Returns:
        The next memory segment.
        Throws:
        IOException