Class ListAggWsWithRetractAggFunction
- java.lang.Object
-
- org.apache.flink.table.functions.UserDefinedFunction
-
- org.apache.flink.table.functions.ImperativeAggregateFunction<T,ACC>
-
- org.apache.flink.table.functions.AggregateFunction<T,ACC>
-
- org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction<StringData,ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator>
-
- org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction
-
- All Implemented Interfaces:
Serializable
,FunctionDefinition
@Internal public final class ListAggWsWithRetractAggFunction extends BuiltInAggregateFunction<StringData,ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator>
Built-in LISTAGGWS with retraction aggregate function.- See Also:
- Serialized Form
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static class
ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator
Accumulator for LISTAGGWS with retraction.
-
Constructor Summary
Constructors Constructor Description ListAggWsWithRetractAggFunction()
-
Method Summary
-
Methods inherited from class org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction
getRequirements, getTypeInference, isDeterministic
-
Methods inherited from class org.apache.flink.table.functions.AggregateFunction
getKind
-
Methods inherited from class org.apache.flink.table.functions.ImperativeAggregateFunction
getAccumulatorType, getResultType
-
Methods inherited from class org.apache.flink.table.functions.UserDefinedFunction
close, functionIdentifier, open, toString
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
-
Methods inherited from interface org.apache.flink.table.functions.FunctionDefinition
supportsConstantFolding
-
-
-
-
Method Detail
-
getAccumulatorDataType
public DataType getAccumulatorDataType()
-
getOutputDataType
public DataType getOutputDataType()
-
createAccumulator
public ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator createAccumulator()
Description copied from class:ImperativeAggregateFunction
Creates and initializes the accumulator for thisImperativeAggregateFunction
.The accumulator is an intermediate data structure that stores the aggregated values until a final aggregation result is computed.
- Specified by:
createAccumulator
in classImperativeAggregateFunction<StringData,ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator>
- Returns:
- the accumulator with the initial value
-
accumulate
public void accumulate(ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator acc, StringData value, StringData lineDelimiter) throws Exception
- Throws:
Exception
-
retract
public void retract(ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator acc, StringData value, StringData lineDelimiter) throws Exception
- Throws:
Exception
-
merge
public void merge(ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator acc, Iterable<ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator> its) throws Exception
- Throws:
Exception
-
getValue
public StringData getValue(ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator acc)
Description copied from class:AggregateFunction
Called every time when an aggregation result should be materialized. The returned value could be either an early and incomplete result (periodically emitted as data arrives) or the final result of the aggregation.- Specified by:
getValue
in classAggregateFunction<StringData,ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator>
- Parameters:
acc
- the accumulator which contains the current intermediate results- Returns:
- the aggregation result
-
resetAccumulator
public void resetAccumulator(ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator acc)
-
-