Class ProcTimeMiniBatchDeduplicateKeepLastRowFunction
- java.lang.Object
-
- org.apache.flink.table.runtime.operators.bundle.MapBundleFunction<K,V,IN,OUT>
-
- org.apache.flink.table.runtime.operators.deduplicate.ProcTimeMiniBatchDeduplicateKeepLastRowFunction
-
- All Implemented Interfaces:
Serializable
,Function
public class ProcTimeMiniBatchDeduplicateKeepLastRowFunction extends MapBundleFunction<K,V,IN,OUT>
This function is used to get the last row for every key partition in miniBatch mode.- See Also:
- Serialized Form
-
-
Field Summary
Fields Modifier and Type Field Description protected long
minRetentionTime
protected ValueState<T>
state
protected TypeInformation<T>
stateType
-
Fields inherited from class org.apache.flink.table.runtime.operators.bundle.MapBundleFunction
ctx
-
-
Constructor Summary
Constructors Constructor Description ProcTimeMiniBatchDeduplicateKeepLastRowFunction(InternalTypeInfo<RowData> typeInfo, TypeSerializer<RowData> serializer, long stateRetentionTime, boolean generateUpdateBefore, boolean generateInsert, boolean inputInsertOnly, GeneratedRecordEqualiser genRecordEqualiser)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description RowData
addInput(RowData value, RowData input)
Adds the given input to the given value, returning the new bundle value.void
finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
Called when a bundle is finished.void
open(ExecutionContext ctx)
-
Methods inherited from class org.apache.flink.table.runtime.operators.bundle.MapBundleFunction
close
-
-
-
-
Field Detail
-
stateType
protected final TypeInformation<T> stateType
-
minRetentionTime
protected final long minRetentionTime
-
state
protected ValueState<T> state
-
-
Constructor Detail
-
ProcTimeMiniBatchDeduplicateKeepLastRowFunction
public ProcTimeMiniBatchDeduplicateKeepLastRowFunction(InternalTypeInfo<RowData> typeInfo, TypeSerializer<RowData> serializer, long stateRetentionTime, boolean generateUpdateBefore, boolean generateInsert, boolean inputInsertOnly, GeneratedRecordEqualiser genRecordEqualiser)
-
-
Method Detail
-
open
public void open(ExecutionContext ctx) throws Exception
- Throws:
Exception
-
addInput
public RowData addInput(@Nullable RowData value, RowData input)
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
-
-