Uses of Class
org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
-
-
Uses of AbstractStatelessFunctionOperator in org.apache.flink.table.runtime.operators.python.aggregate.arrow
Subclasses of AbstractStatelessFunctionOperator in org.apache.flink.table.runtime.operators.python.aggregate.arrow Modifier and Type Class Description class
AbstractArrowPythonAggregateFunctionOperator
The Abstract class of Arrow Aggregate Operator for PandasAggregateFunction
. -
Uses of AbstractStatelessFunctionOperator in org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch
Subclasses of AbstractStatelessFunctionOperator in org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch Modifier and Type Class Description class
BatchArrowPythonGroupAggregateFunctionOperator
The Batch Arrow PythonAggregateFunction
Operator for Group Aggregation.class
BatchArrowPythonGroupWindowAggregateFunctionOperator
The Batch Arrow PythonAggregateFunction
Operator for Group Window Aggregation.class
BatchArrowPythonOverWindowAggregateFunctionOperator
The Batch Arrow PythonAggregateFunction
Operator for Over Window Aggregation. -
Uses of AbstractStatelessFunctionOperator in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
Subclasses of AbstractStatelessFunctionOperator in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream Modifier and Type Class Description class
AbstractStreamArrowPythonBoundedRangeOperator<K>
The Abstract class of Stream Arrow PythonAggregateFunction
Operator for RANGE clause bounded Over Window Aggregation.class
AbstractStreamArrowPythonBoundedRowsOperator<K>
The Abstract class of Stream Arrow PythonAggregateFunction
Operator for ROWS clause bounded Over Window Aggregation.class
AbstractStreamArrowPythonOverWindowAggregateFunctionOperator<K>
The Abstract class of Stream Arrow PythonAggregateFunction
Operator for Over Window Aggregation.class
StreamArrowPythonGroupWindowAggregateFunctionOperator<K,W extends Window>
The Stream Arrow PythonAggregateFunction
Operator for Group Window Aggregation.class
StreamArrowPythonProcTimeBoundedRangeOperator<K>
The Stream Arrow PythonAggregateFunction
Operator for ROWS clause proc-time bounded OVER window.class
StreamArrowPythonProcTimeBoundedRowsOperator<K>
The Stream Arrow PythonAggregateFunction
Operator for ROWS clause proc-time bounded OVER window.class
StreamArrowPythonRowTimeBoundedRangeOperator<K>
The Stream Arrow PythonAggregateFunction
Operator for RANGE clause event-time bounded OVER window.class
StreamArrowPythonRowTimeBoundedRowsOperator<K>
The Stream Arrow PythonAggregateFunction
Operator for RANGE clause event-time bounded OVER window. -
Uses of AbstractStatelessFunctionOperator in org.apache.flink.table.runtime.operators.python.scalar
Subclasses of AbstractStatelessFunctionOperator in org.apache.flink.table.runtime.operators.python.scalar Modifier and Type Class Description class
AbstractPythonScalarFunctionOperator
Base class for all stream operators to execute PythonScalarFunction
s.class
PythonScalarFunctionOperator
The PythonScalarFunction
operator. -
Uses of AbstractStatelessFunctionOperator in org.apache.flink.table.runtime.operators.python.scalar.arrow
Subclasses of AbstractStatelessFunctionOperator in org.apache.flink.table.runtime.operators.python.scalar.arrow Modifier and Type Class Description class
ArrowPythonScalarFunctionOperator
Arrow PythonScalarFunction
operator. -
Uses of AbstractStatelessFunctionOperator in org.apache.flink.table.runtime.operators.python.table
Subclasses of AbstractStatelessFunctionOperator in org.apache.flink.table.runtime.operators.python.table Modifier and Type Class Description class
PythonTableFunctionOperator
The PythonTableFunction
operator.
-