Class KeyedStateBootstrapFunction<K,​IN>

  • Type Parameters:
    K - Type of the keys.
    IN - Type of the input.
    All Implemented Interfaces:
    Serializable, org.apache.flink.api.common.functions.Function, org.apache.flink.api.common.functions.RichFunction

    @PublicEvolving
    public abstract class KeyedStateBootstrapFunction<K,​IN>
    extends org.apache.flink.api.common.functions.AbstractRichFunction
    A function that writes keyed state to a new operator.

    For every element #processElement(Object, Context) is invoked. This can write data to state and set timers.

    NOTE: A KeyedStateBootstrapFunction is always a RichFunction. Therefore, access to the RuntimeContext is always available and setup and teardown methods can be implemented. See RichFunction.open(OpenContext) and RichFunction.close().

    See Also:
    Serialized Form
    • Constructor Detail

      • KeyedStateBootstrapFunction

        public KeyedStateBootstrapFunction()
    • Method Detail

      • processElement

        public abstract void processElement​(IN value,
                                            KeyedStateBootstrapFunction.Context ctx)
                                     throws Exception
        Process one element from the input stream.

        This function can update internal state or set timers using the KeyedStateBootstrapFunction.Context parameter.

        Parameters:
        value - The input value.
        ctx - A KeyedStateBootstrapFunction.Context that allows querying the timestamp of the element and getting a TimerService for registering timers and querying the time. The context is only valid during the invocation of this method, do not store it.
        Throws:
        Exception - This method may throw exceptions. Throwing an exception will cause the operation to fail and may trigger recovery.