Uses of Class
org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonOverWindowAggregateFunctionOperator
-
Packages that use AbstractStreamArrowPythonOverWindowAggregateFunctionOperator Package Description org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream -
-
Uses of AbstractStreamArrowPythonOverWindowAggregateFunctionOperator in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
Subclasses of AbstractStreamArrowPythonOverWindowAggregateFunctionOperator 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
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.
-