Class 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
    • Constructor Detail

      • TtlReduceFunction

        public TtlReduceFunction​(org.apache.flink.api.common.functions.ReduceFunction<T> originalReduceFunction,
                                 org.apache.flink.api.common.state.StateTtlConfig config,
                                 TtlTimeProvider timeProvider)