Class KeyedBroadcastProcessFunction.Context

    • Constructor Detail

      • Context

        public Context()
    • Method Detail

      • applyToKeyedState

        public abstract <VS,​S extends org.apache.flink.api.common.state.State> void applyToKeyedState​(org.apache.flink.api.common.state.StateDescriptor<S,​VS> stateDescriptor,
                                                                                                            KeyedStateFunction<KS,​S> function)
                                                                                                     throws Exception
        Applies the provided function to the state associated with the provided state descriptor.
        Parameters:
        stateDescriptor - the descriptor of the state to be processed.
        function - the function to be applied.
        Throws:
        Exception
      • timestamp

        public abstract Long timestamp()
        Timestamp of the element currently being processed or timestamp of a firing timer.

        This might be null, depending on the stream's watermark strategy.

      • output

        public abstract <X> void output​(org.apache.flink.util.OutputTag<X> outputTag,
                                        X value)
        Emits a record to the side output identified by the OutputTag.
        Parameters:
        outputTag - the OutputTag that identifies the side output to emit to.
        value - The record to emit.
      • currentProcessingTime

        public abstract long currentProcessingTime()
        Returns the current processing time.
      • currentWatermark

        public abstract long currentWatermark()
        Returns the current event-time watermark.