Uses of Interface
org.apache.flink.table.runtime.generated.JoinCondition
-
Packages that use JoinCondition Package Description org.apache.flink.table.runtime.hashtable org.apache.flink.table.runtime.operators.join org.apache.flink.table.runtime.operators.join.stream.utils -
-
Uses of JoinCondition in org.apache.flink.table.runtime.hashtable
Constructors in org.apache.flink.table.runtime.hashtable with parameters of type JoinCondition Constructor Description BinaryHashTable(Object owner, boolean compressionEnabled, int compressionBlockSize, AbstractRowDataSerializer buildSideSerializer, AbstractRowDataSerializer probeSideSerializer, Projection<org.apache.flink.table.data.RowData,org.apache.flink.table.data.binary.BinaryRowData> buildSideProjection, Projection<org.apache.flink.table.data.RowData,org.apache.flink.table.data.binary.BinaryRowData> probeSideProjection, org.apache.flink.runtime.memory.MemoryManager memManager, long reservedMemorySize, org.apache.flink.runtime.io.disk.iomanager.IOManager ioManager, int avgRecordLen, long buildRowCount, boolean useBloomFilters, HashJoinType type, JoinCondition condFunc, boolean reverseJoin, boolean[] filterNulls, boolean tryDistinctBuildRow)
-
Uses of JoinCondition in org.apache.flink.table.runtime.operators.join
Classes in org.apache.flink.table.runtime.operators.join that implement JoinCondition Modifier and Type Class Description class
JoinConditionWithNullFilters
Utility to take null filters into consideration when apply join condition.Constructors in org.apache.flink.table.runtime.operators.join with parameters of type JoinCondition Constructor Description JoinConditionWithNullFilters(JoinCondition backingJoinCondition, boolean[] filterNullKeys, org.apache.flink.streaming.api.operators.KeyContext keyContext)
-
Uses of JoinCondition in org.apache.flink.table.runtime.operators.join.stream.utils
Methods in org.apache.flink.table.runtime.operators.join.stream.utils with parameters of type JoinCondition Modifier and Type Method Description static org.apache.flink.api.common.state.v2.StateFuture<AssociatedRecords>
AssociatedRecords. fromAsyncStateView(org.apache.flink.table.data.RowData input, boolean inputIsLeft, JoinRecordAsyncStateView otherSideAsyncStateView, JoinCondition joinCondition)
Creates anAssociatedRecords
which represents the records associated to the input row.static AssociatedRecords
AssociatedRecords. fromSyncStateView(org.apache.flink.table.data.RowData input, boolean inputIsLeft, JoinRecordStateView otherSideStateView, JoinCondition condition)
Creates anAssociatedRecords
which represents the records associated to the input row.
-