Class LookupBucketIterator

  • All Implemented Interfaces:
    RowIterator<org.apache.flink.table.data.binary.BinaryRowData>

    public class LookupBucketIterator
    extends Object
    implements RowIterator<org.apache.flink.table.data.binary.BinaryRowData>
    Build iterator from bucket to match probe row.
    • Method Detail

      • set

        public void set​(org.apache.flink.core.memory.MemorySegment bucket,
                        org.apache.flink.core.memory.MemorySegment[] overflowSegments,
                        BinaryHashPartition partition,
                        int searchHashCode,
                        int bucketInSegmentOffset)
      • advanceNext

        public boolean advanceNext()
        Description copied from interface: RowIterator
        Advance this iterator by a single row. Returns `false` if this iterator has no more rows and `true` otherwise. If this returns `true`, then the new row can be retrieved by calling RowIterator.getRow().
        Specified by:
        advanceNext in interface RowIterator<org.apache.flink.table.data.binary.BinaryRowData>
      • getRow

        public org.apache.flink.table.data.binary.BinaryRowData getRow()
        Description copied from interface: RowIterator
        Retrieve the row from this iterator. This method is idempotent. It is illegal to call this method after [[advanceNext()]] has returned `false`.
        Specified by:
        getRow in interface RowIterator<org.apache.flink.table.data.binary.BinaryRowData>