Interface InternalMergingState<K,N,IN,SV,OUT,SYNCOUT>
-
- 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.SV- The type of the intermediate state.OUT- The type of the values that are returned from the state.SYNCOUT- Type of the value that can be retrieved from the state by synchronous interface.
- All Superinterfaces:
org.apache.flink.api.common.state.v2.AppendingState<IN,OUT,SYNCOUT>,InternalAppendingState<K,N,IN,SV,OUT,SYNCOUT>,InternalKeyedState<K,N,SV>,InternalPartitionedState<N>,org.apache.flink.api.common.state.v2.MergingState<IN,OUT,SYNCOUT>,org.apache.flink.api.common.state.v2.State
- All Known Subinterfaces:
InternalAggregatingState<K,N,IN,ACC,OUT>,InternalListState<K,N,V>,InternalReducingState<K,N,T>
- All Known Implementing Classes:
AbstractAggregatingState,AbstractListState,AbstractReducingState,AggregatingStateAdaptor,ListStateAdaptor,MergingStateAdaptor,ReducingStateAdaptor
public interface InternalMergingState<K,N,IN,SV,OUT,SYNCOUT> extends InternalAppendingState<K,N,IN,SV,OUT,SYNCOUT>, org.apache.flink.api.common.state.v2.MergingState<IN,OUT,SYNCOUT>
This class defines the internal interface for merging state.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description org.apache.flink.api.common.state.v2.StateFuture<Void>asyncMergeNamespaces(N target, Collection<N> sources)Merges the state of the current key for the given source namespaces into the state of the target namespace.voidmergeNamespaces(N target, Collection<N> sources)Merges the state of the current key for the given source namespaces into the state of the target namespace.-
Methods inherited from interface org.apache.flink.api.common.state.v2.AppendingState
add, asyncAdd, asyncGet, get
-
Methods inherited from interface org.apache.flink.runtime.state.v2.internal.InternalPartitionedState
setCurrentNamespace
-
-
-
-
Method Detail
-
asyncMergeNamespaces
org.apache.flink.api.common.state.v2.StateFuture<Void> asyncMergeNamespaces(N target, Collection<N> sources)
Merges the state of the current key for the given source namespaces into the state of the target namespace.- Parameters:
target- The target namespace where the merged state should be stored.sources- The source namespaces whose state should be merged.
-
mergeNamespaces
void mergeNamespaces(N target, Collection<N> sources)
Merges the state of the current key for the given source namespaces into the state of the target namespace.- Parameters:
target- The target namespace where the merged state should be stored.sources- The source namespaces whose state should be merged.
-
-