Class ReducingStateDescriptor<T>

    • Constructor Detail

      • ReducingStateDescriptor

        public ReducingStateDescriptor​(String name,
                                       org.apache.flink.api.common.functions.ReduceFunction<T> reduceFunction,
                                       org.apache.flink.api.common.typeinfo.TypeInformation<T> typeInfo)
        Creates a new ReducingStateDescriptor with the given name and default value.
        Parameters:
        name - The (unique) name for the state.
        reduceFunction - The ReduceFunction used to aggregate the state.
        typeInfo - The type of the values in the state.
      • ReducingStateDescriptor

        public ReducingStateDescriptor​(String name,
                                       org.apache.flink.api.common.functions.ReduceFunction<T> reduceFunction,
                                       org.apache.flink.api.common.typeinfo.TypeInformation<T> typeInfo,
                                       org.apache.flink.api.common.serialization.SerializerConfig serializerConfig)
        Creates a new ReducingStateDescriptor with the given name and default value.
        Parameters:
        name - The (unique) name for the state.
        reduceFunction - The ReduceFunction used to aggregate the state.
        typeInfo - The type of the values in the state.
    • Method Detail

      • getReduceFunction

        public org.apache.flink.api.common.functions.ReduceFunction<T> getReduceFunction()
        Returns the reduce function to be used for the reducing state.