- Type Parameters:
K
- The type of key the state is associated to.
N
- The namespace type.
T
- Type of the value in the operator state.
- All Superinterfaces:
org.apache.flink.api.common.state.v2.AggregatingState<T,T>
, org.apache.flink.api.common.state.v2.AppendingState<T,T,T>
, InternalAggregatingState<K,N,T,T,T>
, InternalAppendingState<K,N,T,T,T,T>
, InternalKeyedState<K,N,T>
, InternalMergingState<K,N,T,T,T,T>
, InternalPartitionedState<N>
, InternalStateAccessible<T>
, org.apache.flink.api.common.state.v2.MergingState<T,T,T>
, org.apache.flink.api.common.state.v2.ReducingState<T>
, org.apache.flink.api.common.state.v2.State
- All Known Implementing Classes:
AbstractReducingState
, ReducingStateAdaptor
public interface InternalReducingState<K,N,T>
extends InternalAggregatingState<K,N,T,T,T>, org.apache.flink.api.common.state.v2.ReducingState<T>, InternalStateAccessible<T>
This class defines the internal interface for reducing state.