Modifier and Type | Method and Description |
---|---|
static FlinkFnApi.UserDefinedFunction |
ProtoUtils.createUserDefinedFunctionProto(PythonFunctionInfo pythonFunctionInfo) |
static FlinkFnApi.UserDefinedFunctions |
ProtoUtils.createUserDefinedFunctionsProto(PythonFunctionInfo[] userDefinedFunctions,
boolean isMetricEnabled,
boolean isProfileEnabled) |
Modifier and Type | Class and Description |
---|---|
class |
DataStreamPythonFunctionInfo
DataStreamPythonFunctionInfo holds a PythonFunction and its function type. |
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 | Method and Description |
---|---|
static PythonFunctionInfo |
CommonPythonUtil.createPythonFunctionInfo(org.apache.calcite.rex.RexCall pythonRexCall,
Map<org.apache.calcite.rex.RexNode,Integer> inputNodes,
ClassLoader classLoader) |
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 udfInputType,
RowType udfOutputType,
GeneratedProjection udafInputGeneratedProjection) |
Constructor and 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) |
Constructor and 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,
WindowAssigner<W> windowAssigner,
Trigger<W> trigger,
long allowedLateness,
NamedWindowProperty[] namedProperties,
java.time.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) |
Modifier and Type | Field and Description |
---|---|
protected PythonFunctionInfo[] |
AbstractPythonScalarFunctionOperator.scalarFunctions
The Python
ScalarFunction s to be executed. |
Constructor and 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) |
Constructor and Description |
---|
ArrowPythonScalarFunctionOperator(Configuration config,
PythonFunctionInfo[] scalarFunctions,
RowType inputType,
RowType udfInputType,
RowType udfOutputType,
GeneratedProjection udfInputGeneratedProjection,
GeneratedProjection forwardedFieldGeneratedProjection) |
Constructor and Description |
---|
EmbeddedPythonTableFunctionOperator(Configuration config,
PythonFunctionInfo tableFunction,
RowType inputType,
RowType udfInputType,
RowType udfOutputType,
FlinkJoinType joinType,
int[] udfInputOffsets) |
PythonTableFunctionOperator(Configuration config,
PythonFunctionInfo tableFunction,
RowType inputType,
RowType udfInputType,
RowType udfOutputType,
FlinkJoinType joinType,
GeneratedProjection udtfInputGeneratedProjection) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.