Interface InternalMergingState<K,​N,​IN,​SV,​OUT>

  • Type Parameters:
    K - The type of key the state is associated to
    N - The type of the namespace
    IN - The type of elements added to the state
    SV - The type of elements in the state
    OUT - The type of elements
    All Superinterfaces:
    org.apache.flink.api.common.state.AppendingState<IN,​OUT>, InternalAppendingState<K,​N,​IN,​SV,​OUT>, InternalKvState<K,​N,​SV>, org.apache.flink.api.common.state.MergingState<IN,​OUT>, org.apache.flink.api.common.state.State
    All Known Subinterfaces:
    InternalAggregatingState<K,​N,​IN,​SV,​OUT>, InternalListState<K,​N,​T>, InternalReducingState<K,​N,​T>

    public interface InternalMergingState<K,​N,​IN,​SV,​OUT>
    extends InternalAppendingState<K,​N,​IN,​SV,​OUT>, org.apache.flink.api.common.state.MergingState<IN,​OUT>
    The peer to the MergingState in the internal state type hierarchy.

    See InternalKvState for a description of the internal state hierarchy.

    • Method Detail

      • mergeNamespaces

        void mergeNamespaces​(N target,
                             Collection<N> sources)
                      throws Exception
        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.
        Throws:
        Exception - The method may forward exception thrown internally (by I/O or functions).