Class KeyedProcessFunction.Context
- java.lang.Object
-
- org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
- Direct Known Subclasses:
KeyedProcessFunction.OnTimerContext
- Enclosing class:
- KeyedProcessFunction<K,I,O>
public abstract class KeyedProcessFunction.Context extends Object
Information available in an invocation of#processElement(Object, Context, Collector)or#onTimer(long, OnTimerContext, Collector).
-
-
Constructor Summary
Constructors Constructor Description Context()
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description abstract KgetCurrentKey()Get key of the element being processed.abstract <X> voidoutput(org.apache.flink.util.OutputTag<X> outputTag, X value)Emits a record to the side output identified by theOutputTag.abstract TimerServicetimerService()ATimerServicefor querying time and registering timers.abstract Longtimestamp()Timestamp of the element currently being processed or timestamp of a firing timer.
-
-
-
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.
-
timerService
public abstract TimerService timerService()
ATimerServicefor querying time and registering timers.
-
output
public abstract <X> void output(org.apache.flink.util.OutputTag<X> outputTag, X value)Emits a record to the side output identified by theOutputTag.- Parameters:
outputTag- theOutputTagthat identifies the side output to emit to.value- The record to emit.
-
getCurrentKey
public abstract K getCurrentKey()
Get key of the element being processed.
-
-