Uses of Class
org.apache.flink.table.runtime.generated.GeneratedProjection
-
-
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<RowData> keyRowType, GeneratedProjection generatedProjection)
GenericRowDataKeySelector(InternalTypeInfo<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, 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.python.aggregate.arrow
Constructors in org.apache.flink.table.runtime.operators.python.aggregate.arrow with parameters of type GeneratedProjection Constructor Description AbstractArrowPythonAggregateFunctionOperator(Configuration config, PythonFunctionInfo[] pandasAggFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, GeneratedProjection udafInputGeneratedProjection)
-
Uses of GeneratedProjection in org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch
Constructors in org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch with parameters of type GeneratedProjection Constructor Description BatchArrowPythonGroupAggregateFunctionOperator(Configuration config, PythonFunctionInfo[] pandasAggFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, GeneratedProjection inputGeneratedProjection, GeneratedProjection groupKeyGeneratedProjection, GeneratedProjection groupSetGeneratedProjection)
BatchArrowPythonGroupWindowAggregateFunctionOperator(Configuration config, PythonFunctionInfo[] pandasAggFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, int inputTimeFieldIndex, int maxLimitSize, long windowSize, long slideSize, int[] namedProperties, GeneratedProjection inputGeneratedProjection, GeneratedProjection groupKeyGeneratedProjection, GeneratedProjection groupSetGeneratedProjection)
BatchArrowPythonOverWindowAggregateFunctionOperator(Configuration config, PythonFunctionInfo[] pandasAggFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, long[] lowerBoundary, long[] upperBoundary, boolean[] isRangeWindows, int[] aggWindowIndex, int inputTimeFieldIndex, boolean asc, GeneratedProjection inputGeneratedProjection, GeneratedProjection groupKeyGeneratedProjection, GeneratedProjection groupSetGeneratedProjection)
-
Uses of GeneratedProjection in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
Constructors in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream with parameters of type GeneratedProjection Constructor Description AbstractStreamArrowPythonBoundedRangeOperator(Configuration config, PythonFunctionInfo[] pandasAggFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, int inputTimeFieldIndex, long lowerBoundary, GeneratedProjection inputGeneratedProjection)
AbstractStreamArrowPythonBoundedRowsOperator(Configuration config, long minRetentionTime, long maxRetentionTime, PythonFunctionInfo[] pandasAggFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, int inputTimeFieldIndex, long lowerBoundary, GeneratedProjection inputGeneratedProjection)
AbstractStreamArrowPythonOverWindowAggregateFunctionOperator(Configuration config, PythonFunctionInfo[] pandasAggFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, int inputTimeFieldIndex, long lowerBoundary, GeneratedProjection inputGeneratedProjection)
StreamArrowPythonGroupWindowAggregateFunctionOperator(Configuration config, PythonFunctionInfo[] pandasAggFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, int inputTimeFieldIndex, GroupWindowAssigner<W> windowAssigner, Trigger<W> trigger, long allowedLateness, NamedWindowProperty[] namedProperties, ZoneId shiftTimeZone, GeneratedProjection generatedProjection)
StreamArrowPythonProcTimeBoundedRangeOperator(Configuration config, PythonFunctionInfo[] pandasAggFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, int inputTimeFieldIndex, long lowerBoundary, GeneratedProjection generatedProjection)
StreamArrowPythonProcTimeBoundedRowsOperator(Configuration config, long minRetentionTime, long maxRetentionTime, PythonFunctionInfo[] pandasAggFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, int inputTimeFieldIndex, long lowerBoundary, GeneratedProjection inputGeneratedProjection)
StreamArrowPythonRowTimeBoundedRangeOperator(Configuration config, PythonFunctionInfo[] pandasAggFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, int inputTimeFieldIndex, long lowerBoundary, GeneratedProjection generatedProjection)
StreamArrowPythonRowTimeBoundedRowsOperator(Configuration config, long minRetentionTime, long maxRetentionTime, PythonFunctionInfo[] pandasAggFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, int inputTimeFieldIndex, long lowerBoundary, GeneratedProjection inputGeneratedProjection)
-
Uses of GeneratedProjection in org.apache.flink.table.runtime.operators.python.scalar
Constructors in org.apache.flink.table.runtime.operators.python.scalar with parameters of type GeneratedProjection Constructor Description AbstractPythonScalarFunctionOperator(Configuration config, PythonFunctionInfo[] scalarFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, GeneratedProjection udfInputGeneratedProjection, GeneratedProjection forwardedFieldGeneratedProjection)
EmbeddedPythonScalarFunctionOperator(Configuration config, PythonFunctionInfo[] scalarFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, int[] udfInputOffsets, GeneratedProjection forwardedFieldGeneratedProjection)
PythonScalarFunctionOperator(Configuration config, PythonFunctionInfo[] scalarFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, GeneratedProjection udfInputGeneratedProjection, GeneratedProjection forwardedFieldGeneratedProjection)
-
Uses of GeneratedProjection in org.apache.flink.table.runtime.operators.python.scalar.arrow
Constructors in org.apache.flink.table.runtime.operators.python.scalar.arrow with parameters of type GeneratedProjection Constructor Description ArrowPythonScalarFunctionOperator(Configuration config, PythonFunctionInfo[] scalarFunctions, RowType inputType, RowType udfInputType, RowType udfOutputType, GeneratedProjection udfInputGeneratedProjection, GeneratedProjection forwardedFieldGeneratedProjection)
-
Uses of GeneratedProjection in org.apache.flink.table.runtime.operators.python.table
Constructors in org.apache.flink.table.runtime.operators.python.table with parameters of type GeneratedProjection Constructor Description PythonTableFunctionOperator(Configuration config, PythonFunctionInfo tableFunction, RowType inputType, RowType udfInputType, RowType udfOutputType, FlinkJoinType joinType, GeneratedProjection udtfInputGeneratedProjection)
-
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)
-