Uses of Class
org.apache.flink.table.runtime.generated.GeneratedProjection
-
Packages that use GeneratedProjection Package Description org.apache.flink.table.runtime.keyselector org.apache.flink.table.runtime.operators.join org.apache.flink.table.runtime.operators.runtimefilter -
-
Uses of GeneratedProjection in org.apache.flink.table.runtime.keyselector
Constructors in org.apache.flink.table.runtime.keyselector with parameters of type GeneratedProjection Constructor Description BinaryRowDataKeySelector(InternalTypeInfo<org.apache.flink.table.data.RowData> keyRowType, GeneratedProjection generatedProjection)
GenericRowDataKeySelector(InternalTypeInfo<org.apache.flink.table.data.RowData> keyRowType, RowDataSerializer keySerializer, GeneratedProjection generatedProjection)
-
Uses of GeneratedProjection in org.apache.flink.table.runtime.operators.join
Methods in org.apache.flink.table.runtime.operators.join with parameters of type GeneratedProjection Modifier and Type Method Description static HashJoinOperator
HashJoinOperator. newHashJoinOperator(HashJoinType type, boolean leftIsBuild, boolean compressionEnable, int compressionBlockSize, GeneratedJoinCondition condFuncCode, boolean reverseJoinFunction, boolean[] filterNullKeys, GeneratedProjection buildProjectionCode, GeneratedProjection probeProjectionCode, boolean tryDistinctBuildRow, int buildRowSize, long buildRowCount, long probeRowCount, org.apache.flink.table.types.logical.RowType keyType, SortMergeJoinFunction sortMergeJoinFunction)
Constructors in org.apache.flink.table.runtime.operators.join with parameters of type GeneratedProjection Constructor Description SortMergeJoinFunction(double externalBufferMemRatio, FlinkJoinType type, boolean leftIsSmaller, int maxNumFileHandles, boolean compressionEnabled, int compressionBlockSize, boolean asyncMergeEnabled, GeneratedJoinCondition condFuncCode, GeneratedProjection projectionCode1, GeneratedProjection projectionCode2, GeneratedNormalizedKeyComputer computer1, GeneratedRecordComparator comparator1, GeneratedNormalizedKeyComputer computer2, GeneratedRecordComparator comparator2, GeneratedRecordComparator genKeyComparator, boolean[] filterNulls)
-
Uses of GeneratedProjection in org.apache.flink.table.runtime.operators.runtimefilter
Constructors in org.apache.flink.table.runtime.operators.runtimefilter with parameters of type GeneratedProjection Constructor Description LocalRuntimeFilterBuilderOperator(GeneratedProjection buildProjectionCode, int estimatedRowCount, int maxRowCount)
-