Uses of Interface
org.apache.flink.table.runtime.generated.NamespaceAggsHandleFunction
-
-
Uses of NamespaceAggsHandleFunction in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.combines
Constructors in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.combines with parameters of type NamespaceAggsHandleFunction Constructor Description AsyncStateAggCombiner(WindowTimerService<Long> timerService, WindowAsyncValueState<Long> accState, NamespaceAggsHandleFunction<Long> aggregator, boolean isEventTime)
-
Uses of NamespaceAggsHandleFunction in org.apache.flink.table.runtime.operators.aggregate.window.combines
Constructors in org.apache.flink.table.runtime.operators.aggregate.window.combines with parameters of type NamespaceAggsHandleFunction Constructor Description AggCombiner(WindowTimerService<Long> timerService, StateKeyContext keyContext, WindowValueState<Long> accState, NamespaceAggsHandleFunction<Long> aggregator, boolean isEventTime)
GlobalAggCombiner(WindowTimerService<Long> timerService, StateKeyContext keyContext, WindowValueState<Long> accState, NamespaceAggsHandleFunction<Long> localAggregator, NamespaceAggsHandleFunction<Long> globalAggregator)
LocalAggCombiner(NamespaceAggsHandleFunction<Long> aggregator, org.apache.flink.util.Collector<org.apache.flink.table.data.RowData> collector)
-
Uses of NamespaceAggsHandleFunction in org.apache.flink.table.runtime.operators.aggregate.window.processors
Fields in org.apache.flink.table.runtime.operators.aggregate.window.processors declared as NamespaceAggsHandleFunction Modifier and Type Field Description protected NamespaceAggsHandleFunction<W>
WindowAggProcessorBase. aggregator
-
Uses of NamespaceAggsHandleFunction in org.apache.flink.table.runtime.operators.window.groupwindow.operator
Methods in org.apache.flink.table.runtime.operators.window.groupwindow.operator with parameters of type NamespaceAggsHandleFunction Modifier and Type Method Description WindowOperatorBuilder.AggregateWindowOperatorBuilder
WindowOperatorBuilder. aggregate(NamespaceAggsHandleFunction<?> aggregateFunction, RecordEqualiser equaliser, org.apache.flink.table.types.logical.LogicalType[] accumulatorTypes, org.apache.flink.table.types.logical.LogicalType[] aggResultTypes, org.apache.flink.table.types.logical.LogicalType[] windowPropertyTypes)
Constructors in org.apache.flink.table.runtime.operators.window.groupwindow.operator with parameters of type NamespaceAggsHandleFunction Constructor Description AggregateWindowOperatorBuilder(NamespaceAggsHandleFunction<?> aggregateFunction, RecordEqualiser equaliser, WindowOperatorBuilder windowOperatorBuilder)
-