Class BinaryHashPartition.BuildSideBuffer

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

    protected static final class BinaryHashPartition.BuildSideBuffer
    extends org.apache.flink.runtime.memory.AbstractPagedOutputView
    Build side buffer.
    • Field Summary

      • Fields inherited from class org.apache.flink.runtime.memory.AbstractPagedOutputView

        headerLength, segmentSize
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      protected org.apache.flink.core.memory.MemorySegment nextSegment​(org.apache.flink.core.memory.MemorySegment current, int bytesUsed)  
      • 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 bytesUsed)
                                                                  throws IOException
        Specified by:
        nextSegment in class org.apache.flink.runtime.memory.AbstractPagedOutputView
        Throws:
        IOException