Class TtlAggregateFunction<IN,ACC,OUT>
- java.lang.Object
-
- org.apache.flink.runtime.state.ttl.AbstractTtlDecorator<org.apache.flink.api.common.functions.AggregateFunction<IN,ACC,OUT>>
-
- org.apache.flink.runtime.state.v2.ttl.TtlAggregateFunction<IN,ACC,OUT>
-
- Type Parameters:
IN
- The type of the values that are aggregated (input values)ACC
- The type of the accumulator (intermediate aggregate state).OUT
- The type of the aggregated result
- All Implemented Interfaces:
Serializable
,org.apache.flink.api.common.functions.AggregateFunction<IN,TtlValue<ACC>,OUT>
,org.apache.flink.api.common.functions.Function
public class TtlAggregateFunction<IN,ACC,OUT> extends AbstractTtlDecorator<org.apache.flink.api.common.functions.AggregateFunction<IN,ACC,OUT>> implements org.apache.flink.api.common.functions.AggregateFunction<IN,TtlValue<ACC>,OUT>
This class wraps aggregating function with TTL logic.- See Also:
- Serialized Form
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.state.ttl.AbstractTtlDecorator
config, original, returnExpired, timeProvider, ttl, updateTsOnRead
-
-
Constructor Summary
Constructors Constructor Description TtlAggregateFunction(org.apache.flink.api.common.functions.AggregateFunction<IN,ACC,OUT> aggFunction, org.apache.flink.api.common.state.StateTtlConfig config, TtlTimeProvider timeProvider)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description TtlValue<ACC>
add(IN value, TtlValue<ACC> accumulator)
TtlValue<ACC>
createAccumulator()
OUT
getResult(TtlValue<ACC> accumulator)
TtlValue<ACC>
merge(TtlValue<ACC> a, TtlValue<ACC> b)
-
Methods inherited from class org.apache.flink.runtime.state.ttl.AbstractTtlDecorator
expired, getElementWithTtlCheck, getUnexpired, getWithTtlCheckAndUpdate, getWrappedWithTtlCheckAndUpdate, rewrapWithNewTs, wrapWithTs
-
-
-
-
Constructor Detail
-
TtlAggregateFunction
public TtlAggregateFunction(org.apache.flink.api.common.functions.AggregateFunction<IN,ACC,OUT> aggFunction, org.apache.flink.api.common.state.StateTtlConfig config, TtlTimeProvider timeProvider)
-
-