Class BroadcastStateBootstrapFunction<IN>

  • Type Parameters:
    IN - The 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 BroadcastStateBootstrapFunction<IN>
    extends org.apache.flink.api.common.functions.AbstractRichFunction
    Interface for writing elements to broadcast state.
    See Also:
    Serialized Form
    • Constructor Detail

      • BroadcastStateBootstrapFunction

        public BroadcastStateBootstrapFunction()
    • Method Detail

      • processElement

        public abstract void processElement​(IN value,
                                            BroadcastStateBootstrapFunction.Context ctx)
                                     throws Exception
        Writes the given value to operator state. This function is called for every record.
        Parameters:
        value - The input record.
        Throws:
        Exception - This method may throw exceptions. Throwing an exception will cause the operation to fail and may trigger recovery.