- Type Parameters:
K - The type of key the state is associated to.
N - The namespace type.
IN - The type of the values that are added into the state.
ACC - The type of the accumulator (intermediate aggregation state).
OUT - The type of the values that are returned from the state.
- All Superinterfaces:
org.apache.flink.api.common.state.v2.AggregatingState<IN,OUT>, org.apache.flink.api.common.state.v2.AppendingState<IN,OUT,OUT>, InternalAppendingState<K,N,IN,ACC,OUT,OUT>, InternalKeyedState<K,N,ACC>, InternalMergingState<K,N,IN,ACC,OUT,OUT>, InternalPartitionedState<N>, InternalStateAccessible<ACC>, org.apache.flink.api.common.state.v2.MergingState<IN,OUT,OUT>, org.apache.flink.api.common.state.v2.State
- All Known Subinterfaces:
InternalReducingState<K,N,T>
- All Known Implementing Classes:
AbstractAggregatingState, AbstractReducingState, AggregatingStateAdaptor, ReducingStateAdaptor
public interface InternalAggregatingState<K,N,IN,ACC,OUT>
extends InternalMergingState<K,N,IN,ACC,OUT,OUT>, org.apache.flink.api.common.state.v2.AggregatingState<IN,OUT>, InternalStateAccessible<ACC>
This class defines the internal interface for aggregating state.