Modifier and Type | Method and Description |
---|---|
static FlinkFnApi.UserDefinedFunction |
PythonOperatorUtils.getUserDefinedFunctionProto(PythonFunctionInfo pythonFunctionInfo) |
Modifier and Type | Class and Description |
---|---|
class |
PythonAggregateFunctionInfo
PythonAggregateFunctionInfo contains the execution information of a Python aggregate function,
such as: the actual Python aggregation function, the input arguments, the filter arg, the
distinct flag, etc.
|
Modifier and Type | Field and Description |
---|---|
PythonFunctionInfo[] |
AbstractPythonScalarFunctionFlatMap.scalarFunctions
The Python
ScalarFunction s to be executed. |
Constructor and Description |
---|
AbstractPythonScalarFunctionFlatMap(Configuration config,
PythonFunctionInfo[] scalarFunctions,
RowType inputType,
RowType outputType,
int[] udfInputOffsets,
int[] forwardedFields) |
PythonScalarFunctionFlatMap(Configuration config,
PythonFunctionInfo[] scalarFunctions,
RowType inputType,
RowType outputType,
int[] udfInputOffsets,
int[] forwardedFields) |
PythonTableFunctionFlatMap(Configuration config,
PythonFunctionInfo tableFunction,
RowType inputType,
RowType outputType,
int[] udtfInputOffsets,
org.apache.calcite.rel.core.JoinRelType joinType) |
Constructor and Description |
---|
ArrowPythonScalarFunctionFlatMap(Configuration config,
PythonFunctionInfo[] scalarFunctions,
RowType inputType,
RowType outputType,
int[] udfInputOffsets,
int[] forwardedFields) |
Modifier and Type | Field and Description |
---|---|
protected PythonFunctionInfo[] |
AbstractArrowPythonAggregateFunctionOperator.pandasAggFunctions
The Pandas
AggregateFunction s to be executed. |
Constructor and Description |
---|
AbstractArrowPythonAggregateFunctionOperator(Configuration config,
PythonFunctionInfo[] pandasAggFunctions,
RowType inputType,
RowType outputType,
int[] groupingSet,
int[] udafInputOffsets) |
Constructor and Description |
---|
BatchArrowPythonGroupAggregateFunctionOperator(Configuration config,
PythonFunctionInfo[] pandasAggFunctions,
RowType inputType,
RowType outputType,
int[] groupKey,
int[] groupingSet,
int[] udafInputOffsets) |
BatchArrowPythonGroupWindowAggregateFunctionOperator(Configuration config,
PythonFunctionInfo[] pandasAggFunctions,
RowType inputType,
RowType outputType,
int inputTimeFieldIndex,
int maxLimitSize,
long windowSize,
long slideSize,
int[] namedProperties,
int[] groupKey,
int[] groupingSet,
int[] udafInputOffsets) |
BatchArrowPythonOverWindowAggregateFunctionOperator(Configuration config,
PythonFunctionInfo[] pandasAggFunctions,
RowType inputType,
RowType outputType,
long[] lowerBoundary,
long[] upperBoundary,
boolean[] isRangeWindows,
int[] aggWindowIndex,
int[] groupKey,
int[] groupingSet,
int[] udafInputOffsets,
int inputTimeFieldIndex,
boolean asc) |
Constructor and Description |
---|
AbstractStreamArrowPythonBoundedRangeOperator(Configuration config,
PythonFunctionInfo[] pandasAggFunctions,
RowType inputType,
RowType outputType,
int inputTimeFieldIndex,
long lowerBoundary,
int[] groupingSet,
int[] udafInputOffsets) |
AbstractStreamArrowPythonBoundedRowsOperator(Configuration config,
long minRetentionTime,
long maxRetentionTime,
PythonFunctionInfo[] pandasAggFunctions,
RowType inputType,
RowType outputType,
int inputTimeFieldIndex,
long lowerBoundary,
int[] groupingSet,
int[] udafInputOffsets) |
AbstractStreamArrowPythonOverWindowAggregateFunctionOperator(Configuration config,
PythonFunctionInfo[] pandasAggFunctions,
RowType inputType,
RowType outputType,
int inputTimeFieldIndex,
long lowerBoundary,
int[] groupingSet,
int[] udafInputOffsets) |
StreamArrowPythonGroupWindowAggregateFunctionOperator(Configuration config,
PythonFunctionInfo[] pandasAggFunctions,
RowType inputType,
RowType outputType,
int inputTimeFieldIndex,
WindowAssigner<W> windowAssigner,
Trigger<W> trigger,
long allowedLateness,
int[] namedProperties,
int[] groupingSet,
int[] udafInputOffsets) |
StreamArrowPythonProcTimeBoundedRangeOperator(Configuration config,
PythonFunctionInfo[] pandasAggFunctions,
RowType inputType,
RowType outputType,
int inputTimeFieldIndex,
long lowerBoundary,
int[] groupingSet,
int[] udafInputOffsets) |
StreamArrowPythonProcTimeBoundedRowsOperator(Configuration config,
long minRetentionTime,
long maxRetentionTime,
PythonFunctionInfo[] pandasAggFunctions,
RowType inputType,
RowType outputType,
int inputTimeFieldIndex,
long lowerBoundary,
int[] groupingSet,
int[] udafInputOffsets) |
StreamArrowPythonRowTimeBoundedRangeOperator(Configuration config,
PythonFunctionInfo[] pandasAggFunctions,
RowType inputType,
RowType outputType,
int inputTimeFieldIndex,
long lowerBoundary,
int[] groupingSet,
int[] udafInputOffsets) |
StreamArrowPythonRowTimeBoundedRowsOperator(Configuration config,
long minRetentionTime,
long maxRetentionTime,
PythonFunctionInfo[] pandasAggFunctions,
RowType inputType,
RowType outputType,
int inputTimeFieldIndex,
long lowerBoundary,
int[] groupingSet,
int[] udafInputOffsets) |
Modifier and Type | Field and Description |
---|---|
protected PythonFunctionInfo[] |
AbstractPythonScalarFunctionOperator.scalarFunctions
The Python
ScalarFunction s to be executed. |
Constructor and Description |
---|
AbstractRowDataPythonScalarFunctionOperator(Configuration config,
PythonFunctionInfo[] scalarFunctions,
RowType inputType,
RowType outputType,
int[] udfInputOffsets,
int[] forwardedFields) |
AbstractRowPythonScalarFunctionOperator(Configuration config,
PythonFunctionInfo[] scalarFunctions,
RowType inputType,
RowType outputType,
int[] udfInputOffsets,
int[] forwardedFields) |
PythonScalarFunctionOperator(Configuration config,
PythonFunctionInfo[] scalarFunctions,
RowType inputType,
RowType outputType,
int[] udfInputOffsets,
int[] forwardedFields) |
RowDataPythonScalarFunctionOperator(Configuration config,
PythonFunctionInfo[] scalarFunctions,
RowType inputType,
RowType outputType,
int[] udfInputOffsets,
int[] forwardedFields) |
Constructor and Description |
---|
ArrowPythonScalarFunctionOperator(Configuration config,
PythonFunctionInfo[] scalarFunctions,
RowType inputType,
RowType outputType,
int[] udfInputOffsets,
int[] forwardedFields) |
RowDataArrowPythonScalarFunctionOperator(Configuration config,
PythonFunctionInfo[] scalarFunctions,
RowType inputType,
RowType outputType,
int[] udfInputOffsets,
int[] forwardedFields) |
Modifier and Type | Field and Description |
---|---|
protected PythonFunctionInfo |
AbstractPythonTableFunctionOperator.tableFunction
The Python
TableFunction to be executed. |
Constructor and Description |
---|
AbstractPythonTableFunctionOperator(Configuration config,
PythonFunctionInfo tableFunction,
RowType inputType,
RowType outputType,
int[] udtfInputOffsets,
org.apache.calcite.rel.core.JoinRelType joinType) |
PythonTableFunctionOperator(Configuration config,
PythonFunctionInfo tableFunction,
RowType inputType,
RowType outputType,
int[] udtfInputOffsets,
org.apache.calcite.rel.core.JoinRelType joinType) |
RowDataPythonTableFunctionOperator(Configuration config,
PythonFunctionInfo tableFunction,
RowType inputType,
RowType outputType,
int[] udtfInputOffsets,
org.apache.calcite.rel.core.JoinRelType joinType) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.