Class TtlReduceFunction<T>
- java.lang.Object
-
- org.apache.flink.runtime.state.ttl.AbstractTtlDecorator<org.apache.flink.api.common.functions.ReduceFunction<T>>
-
- org.apache.flink.runtime.state.ttl.TtlReduceFunction<T>
-
- Type Parameters:
T
- Type of the user value of state with TTL
- All Implemented Interfaces:
Serializable
,org.apache.flink.api.common.functions.Function
,org.apache.flink.api.common.functions.ReduceFunction<TtlValue<T>>
public class TtlReduceFunction<T> extends AbstractTtlDecorator<org.apache.flink.api.common.functions.ReduceFunction<T>> implements org.apache.flink.api.common.functions.ReduceFunction<TtlValue<T>>
This class wraps reducing 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 TtlReduceFunction(org.apache.flink.api.common.functions.ReduceFunction<T> originalReduceFunction, org.apache.flink.api.common.state.StateTtlConfig config, TtlTimeProvider timeProvider)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description TtlValue<T>
reduce(TtlValue<T> value1, TtlValue<T> value2)
-
Methods inherited from class org.apache.flink.runtime.state.ttl.AbstractTtlDecorator
expired, getElementWithTtlCheck, getUnexpired, getWithTtlCheckAndUpdate, getWrappedWithTtlCheckAndUpdate, rewrapWithNewTs, wrapWithTs
-
-
-
-
Constructor Detail
-
TtlReduceFunction
public TtlReduceFunction(org.apache.flink.api.common.functions.ReduceFunction<T> originalReduceFunction, org.apache.flink.api.common.state.StateTtlConfig config, TtlTimeProvider timeProvider)
-
-