Class SortMergeJoinIterator
- java.lang.Object
-
- org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
-
- All Implemented Interfaces:
Closeable
,AutoCloseable
- Direct Known Subclasses:
SortMergeInnerJoinIterator
,SortMergeOneSideOuterJoinIterator
public abstract class SortMergeJoinIterator extends Object implements Closeable
Gets probeRow and match rows for inner/left/right join.
-
-
Field Summary
Fields Modifier and Type Field Description protected BinaryRowData
bufferedKey
protected BinaryRowData
bufferedRow
protected RecordComparator
keyComparator
protected ResettableExternalBuffer
matchBuffer
protected BinaryRowData
matchKey
protected BinaryRowData
probeKey
-
Constructor Summary
Constructors Constructor Description SortMergeJoinIterator(BinaryRowDataSerializer probeSerializer, BinaryRowDataSerializer bufferedSerializer, Projection<RowData,BinaryRowData> probeProjection, Projection<RowData,BinaryRowData> bufferedProjection, RecordComparator keyComparator, MutableObjectIterator<RowData> probeIterator, MutableObjectIterator<BinaryRowData> bufferedIterator, ResettableExternalBuffer buffer, boolean[] filterNulls)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected boolean
advanceNextSuitableBufferedRow()
protected boolean
advanceNextSuitableProbeRow()
protected void
bufferMatchingRows()
void
close()
ResettableExternalBuffer
getMatchBuffer()
BinaryRowData
getMatchKey()
RowData
getProbeRow()
protected boolean
nextProbe()
-
-
-
Field Detail
-
keyComparator
protected final RecordComparator keyComparator
-
probeKey
protected BinaryRowData probeKey
-
bufferedRow
protected BinaryRowData bufferedRow
-
bufferedKey
protected BinaryRowData bufferedKey
-
matchKey
protected BinaryRowData matchKey
-
matchBuffer
protected ResettableExternalBuffer matchBuffer
-
-
Constructor Detail
-
SortMergeJoinIterator
public SortMergeJoinIterator(BinaryRowDataSerializer probeSerializer, BinaryRowDataSerializer bufferedSerializer, Projection<RowData,BinaryRowData> probeProjection, Projection<RowData,BinaryRowData> bufferedProjection, RecordComparator keyComparator, MutableObjectIterator<RowData> probeIterator, MutableObjectIterator<BinaryRowData> bufferedIterator, ResettableExternalBuffer buffer, boolean[] filterNulls) throws IOException
- Throws:
IOException
-
-
Method Detail
-
advanceNextSuitableProbeRow
protected boolean advanceNextSuitableProbeRow() throws IOException
- Throws:
IOException
-
advanceNextSuitableBufferedRow
protected boolean advanceNextSuitableBufferedRow() throws IOException
- Throws:
IOException
-
nextProbe
protected boolean nextProbe() throws IOException
- Throws:
IOException
-
bufferMatchingRows
protected void bufferMatchingRows() throws IOException
- Throws:
IOException
-
getProbeRow
public RowData getProbeRow()
-
getMatchKey
public BinaryRowData getMatchKey()
-
getMatchBuffer
public ResettableExternalBuffer getMatchBuffer()
-
close
public void close()
- Specified by:
close
in interfaceAutoCloseable
- Specified by:
close
in interfaceCloseable
-
-