Class KeyedCoProcessFunction.Context

  • Direct Known Subclasses:
    KeyedCoProcessFunction.OnTimerContext
    Enclosing class:
    KeyedCoProcessFunction<K,​IN1,​IN2,​OUT>

    public abstract class KeyedCoProcessFunction.Context
    extends Object
    Information available in an invocation of #processElement1(Object, Context, Collector)/ #processElement2(Object, Context, Collector) or #onTimer(long, OnTimerContext, Collector).
    • Constructor Detail

      • Context

        public Context()
    • Method Detail

      • 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.
      • getCurrentKey

        public abstract K getCurrentKey()
        Get key of the element being processed.