public final class ListAggWithRetractAggFunction extends AggregateFunction<StringData,ListAggWithRetractAggFunction.ListAggWithRetractAccumulator>
Modifier and Type | Class and Description |
---|---|
static class |
ListAggWithRetractAggFunction.ListAggWithRetractAccumulator
The initial accumulator for listagg with retraction aggregate function.
|
Constructor and Description |
---|
ListAggWithRetractAggFunction() |
getKind, getRequirements, getTypeInference, requiresOver
close, functionIdentifier, open, toString
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
isDeterministic
public TypeInformation<StringData> getResultType()
UserDefinedAggregateFunction
TypeInformation
of the UserDefinedAggregateFunction
's result.getResultType
in class UserDefinedAggregateFunction<StringData,ListAggWithRetractAggFunction.ListAggWithRetractAccumulator>
TypeInformation
of the UserDefinedAggregateFunction
's result or
null
if the result type should be automatically inferred.public TypeInformation<ListAggWithRetractAggFunction.ListAggWithRetractAccumulator> getAccumulatorType()
UserDefinedAggregateFunction
TypeInformation
of the UserDefinedAggregateFunction
's
accumulator.getAccumulatorType
in class UserDefinedAggregateFunction<StringData,ListAggWithRetractAggFunction.ListAggWithRetractAccumulator>
TypeInformation
of the UserDefinedAggregateFunction
's accumulator
or null
if the accumulator type should be automatically inferred.public ListAggWithRetractAggFunction.ListAggWithRetractAccumulator createAccumulator()
UserDefinedAggregateFunction
UserDefinedAggregateFunction
. The
accumulator is used to keep the aggregated values which are needed to compute an aggregation
result.createAccumulator
in class UserDefinedAggregateFunction<StringData,ListAggWithRetractAggFunction.ListAggWithRetractAccumulator>
public void accumulate(ListAggWithRetractAggFunction.ListAggWithRetractAccumulator acc, StringData value) throws Exception
Exception
public void retract(ListAggWithRetractAggFunction.ListAggWithRetractAccumulator acc, StringData value) throws Exception
Exception
public void merge(ListAggWithRetractAggFunction.ListAggWithRetractAccumulator acc, Iterable<ListAggWithRetractAggFunction.ListAggWithRetractAccumulator> its) throws Exception
Exception
public StringData getValue(ListAggWithRetractAggFunction.ListAggWithRetractAccumulator acc)
AggregateFunction
getValue
in class AggregateFunction<StringData,ListAggWithRetractAggFunction.ListAggWithRetractAccumulator>
acc
- the accumulator which contains the current aggregated resultspublic void resetAccumulator(ListAggWithRetractAggFunction.ListAggWithRetractAccumulator acc)
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.