Interface InternalReducingState<K,​N,​T>

  • Type Parameters:
    K - The type of key the state is associated to
    N - The type of the namespace
    T - The type of elements in the aggregated by the ReduceFunction
    All Superinterfaces:
    org.apache.flink.api.common.state.AppendingState<T,​T>, InternalAppendingState<K,​N,​T,​T,​T>, InternalKvState<K,​N,​T>, InternalMergingState<K,​N,​T,​T,​T>, org.apache.flink.api.common.state.MergingState<T,​T>, org.apache.flink.api.common.state.ReducingState<T>, org.apache.flink.api.common.state.State

    public interface InternalReducingState<K,​N,​T>
    extends InternalMergingState<K,​N,​T,​T,​T>, org.apache.flink.api.common.state.ReducingState<T>
    The peer to the ReducingState in the internal state type hierarchy.

    See InternalKvState for a description of the internal state hierarchy.