Class AbstractReducingState<K,​N,​V>

    • Field Detail

      • reduceFunction

        protected final org.apache.flink.api.common.functions.ReduceFunction<V> reduceFunction
    • Constructor Detail

      • AbstractReducingState

        public AbstractReducingState​(StateRequestHandler stateRequestHandler,
                                     org.apache.flink.api.common.state.v2.ReducingStateDescriptor<V> stateDescriptor)
    • Method Detail

      • asyncGet

        public org.apache.flink.api.common.state.v2.StateFuture<V> asyncGet()
        Specified by:
        asyncGet in interface org.apache.flink.api.common.state.v2.AppendingState<K,​N,​V>
      • asyncAdd

        public org.apache.flink.api.common.state.v2.StateFuture<Void> asyncAdd​(V value)
        Specified by:
        asyncAdd in interface org.apache.flink.api.common.state.v2.AppendingState<K,​N,​V>
      • get

        public V get()
        Specified by:
        get in interface org.apache.flink.api.common.state.v2.AppendingState<K,​N,​V>
      • add

        public void add​(V value)
        Specified by:
        add in interface org.apache.flink.api.common.state.v2.AppendingState<K,​N,​V>
      • asyncMergeNamespaces

        public org.apache.flink.api.common.state.v2.StateFuture<Void> asyncMergeNamespaces​(N target,
                                                                                           Collection<N> sources)
        Description copied from interface: InternalMergingState
        Merges the state of the current key for the given source namespaces into the state of the target namespace.
        Specified by:
        asyncMergeNamespaces in interface InternalMergingState<K,​N,​V,​V,​V,​V>
        Parameters:
        target - The target namespace where the merged state should be stored.
        sources - The source namespaces whose state should be merged.
      • mergeNamespaces

        public void mergeNamespaces​(N target,
                                    Collection<N> sources)
        Description copied from interface: InternalMergingState
        Merges the state of the current key for the given source namespaces into the state of the target namespace.
        Specified by:
        mergeNamespaces in interface InternalMergingState<K,​N,​V,​V,​V,​V>
        Parameters:
        target - The target namespace where the merged state should be stored.
        sources - The source namespaces whose state should be merged.