Uses of Interface
org.apache.flink.table.runtime.generated.NamespaceAggsHandleFunctionBase
-
-
Uses of NamespaceAggsHandleFunctionBase in org.apache.flink.table.runtime.generated
Subinterfaces of NamespaceAggsHandleFunctionBase in org.apache.flink.table.runtime.generated Modifier and Type Interface Description interface
NamespaceAggsHandleFunction<N>
The base class for handling aggregate functions with namespace.interface
NamespaceTableAggsHandleFunction<N>
The base class for handling table aggregate functions with namespace. -
Uses of NamespaceAggsHandleFunctionBase in org.apache.flink.table.runtime.operators.window.groupwindow.internal
Fields in org.apache.flink.table.runtime.operators.window.groupwindow.internal declared as NamespaceAggsHandleFunctionBase Modifier and Type Field Description protected NamespaceAggsHandleFunctionBase<W>
InternalWindowProcessFunction. windowAggregator
Constructors in org.apache.flink.table.runtime.operators.window.groupwindow.internal with parameters of type NamespaceAggsHandleFunctionBase Constructor Description DefaultAccMergingConsumer(InternalWindowProcessFunction.Context<?,W> ctx, NamespaceAggsHandleFunctionBase<W> windowAggregator)
GeneralWindowProcessFunction(GroupWindowAssigner<W> windowAssigner, NamespaceAggsHandleFunctionBase<W> windowAggregator, long allowedLateness)
InternalWindowProcessFunction(GroupWindowAssigner<W> windowAssigner, NamespaceAggsHandleFunctionBase<W> windowAggregator, long allowedLateness)
MergingWindowProcessFunction(MergingWindowAssigner<W> windowAssigner, NamespaceAggsHandleFunctionBase<W> windowAggregator, org.apache.flink.api.common.typeutils.TypeSerializer<W> windowSerializer, long allowedLateness)
PanedWindowProcessFunction(PanedWindowAssigner<W> windowAssigner, NamespaceAggsHandleFunctionBase<W> windowAggregator, long allowedLateness)
-
Uses of NamespaceAggsHandleFunctionBase in org.apache.flink.table.runtime.operators.window.groupwindow.operator
Fields in org.apache.flink.table.runtime.operators.window.groupwindow.operator declared as NamespaceAggsHandleFunctionBase Modifier and Type Field Description protected NamespaceAggsHandleFunctionBase<W>
WindowOperator. windowAggregator
-