Class MiniBatchIncrementalGroupAggFunction
- java.lang.Object
-
- org.apache.flink.table.runtime.operators.bundle.MapBundleFunction<RowData,RowData,RowData,RowData>
-
- org.apache.flink.table.runtime.operators.aggregate.MiniBatchIncrementalGroupAggFunction
-
- All Implemented Interfaces:
Serializable
,Function
public class MiniBatchIncrementalGroupAggFunction extends MapBundleFunction<RowData,RowData,RowData,RowData>
Aggregate Function used for the incremental groupby (without window) aggregate in miniBatch mode.- See Also:
- Serialized Form
-
-
Field Summary
-
Fields inherited from class org.apache.flink.table.runtime.operators.bundle.MapBundleFunction
ctx
-
-
Constructor Summary
Constructors Constructor Description MiniBatchIncrementalGroupAggFunction(GeneratedAggsHandleFunction genPartialAggsHandler, GeneratedAggsHandleFunction genFinalAggsHandler, KeySelector<RowData,RowData> finalKeySelector, long stateRetentionTime)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description RowData
addInput(RowData previousAcc, RowData input)
Adds the given input to the given value, returning the new bundle value.void
close()
void
finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
Called when a bundle is finished.void
open(ExecutionContext ctx)
-
-
-
Constructor Detail
-
MiniBatchIncrementalGroupAggFunction
public MiniBatchIncrementalGroupAggFunction(GeneratedAggsHandleFunction genPartialAggsHandler, GeneratedAggsHandleFunction genFinalAggsHandler, KeySelector<RowData,RowData> finalKeySelector, long stateRetentionTime)
-
-
Method Detail
-
open
public void open(ExecutionContext ctx) throws Exception
-
addInput
public RowData addInput(@Nullable RowData previousAcc, RowData input) throws Exception
Description copied from class:MapBundleFunction
Adds the given input to the given value, returning the new bundle value.
-
finishBundle
public void finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out) throws Exception
Description copied from class:MapBundleFunction
Called when a bundle is finished. Transform a bundle to zero, one, or more output elements.- Specified by:
finishBundle
in classMapBundleFunction<RowData,RowData,RowData,RowData>
- Throws:
Exception
-
-