Interface OuterJoinRecordAsyncStateView
-
- All Superinterfaces:
JoinRecordAsyncStateView
public interface OuterJoinRecordAsyncStateView extends JoinRecordAsyncStateView
AOuterJoinRecordAsyncStateView
is an extension toJoinRecordAsyncStateView
. TheOuterJoinRecordAsyncStateView
is used to store records for the outer input side of the Join, e.g. the left side of left join, the both side of full join.The additional information we should store with the record is the number of associations which is the number of records associated this record with other side. This is an important information when to send/retract a null padding row, to avoid recompute the associated numbers every time.
- See Also:
JoinRecordAsyncStateView
-
-
Method Summary
All Methods Instance Methods Abstract Methods Default Methods Modifier and Type Method Description default StateFuture<Void>
addRecord(RowData record)
Add a new record to the state view.StateFuture<Void>
addRecord(RowData record, int numOfAssociations)
Adds a new record with the number of associations to the state view.default StateFuture<List<OuterRecord>>
findMatchedRecords(Function<RowData,Boolean> condition)
Find all the records matched the condition under the current context (i.e. join key).StateFuture<List<OuterRecord>>
findMatchedRecordsAndNumOfAssociations(Function<RowData,Boolean> condition)
Find all the records matched the condition and the corresponding number of associations under the current context (i.e. join key).StateFuture<Void>
updateNumOfAssociations(RowData record, int numOfAssociations)
Updates the number of associations belongs to the record.-
Methods inherited from interface org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.JoinRecordAsyncStateView
retractRecord
-
-
-
-
Method Detail
-
addRecord
StateFuture<Void> addRecord(RowData record, int numOfAssociations)
Adds a new record with the number of associations to the state view.- Parameters:
record
- the added recordnumOfAssociations
- the number of records associated with other side
-
updateNumOfAssociations
StateFuture<Void> updateNumOfAssociations(RowData record, int numOfAssociations)
Updates the number of associations belongs to the record.- Parameters:
record
- the record to updatenumOfAssociations
- the new number of records associated with other side
-
findMatchedRecordsAndNumOfAssociations
StateFuture<List<OuterRecord>> findMatchedRecordsAndNumOfAssociations(Function<RowData,Boolean> condition)
Find all the records matched the condition and the corresponding number of associations under the current context (i.e. join key).
-
addRecord
default StateFuture<Void> addRecord(RowData record)
Description copied from interface:JoinRecordAsyncStateView
Add a new record to the state view.- Specified by:
addRecord
in interfaceJoinRecordAsyncStateView
-
findMatchedRecords
default StateFuture<List<OuterRecord>> findMatchedRecords(Function<RowData,Boolean> condition)
Description copied from interface:JoinRecordAsyncStateView
Find all the records matched the condition under the current context (i.e. join key).- Specified by:
findMatchedRecords
in interfaceJoinRecordAsyncStateView
-
-