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

    • 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.
      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.
      • Methods inherited from interface org.apache.flink.api.common.state.v2.AppendingState

        add, asyncAdd, asyncGet, get
      • Methods inherited from interface org.apache.flink.api.common.state.v2.State

        asyncClear, clear
    • 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.