Class KeyedBroadcastProcessFunction.OnTimerContext
- java.lang.Object
-
- org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.ReadOnlyContext
-
- org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
-
- org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
-
- Enclosing class:
- KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT>
public abstract class KeyedBroadcastProcessFunction.OnTimerContext extends KeyedBroadcastProcessFunction.ReadOnlyContext
Information available in an invocation of#onTimer(long, OnTimerContext, Collector)
.
-
-
Constructor Summary
Constructors Constructor Description OnTimerContext()
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description abstract long
currentProcessingTime()
Returns the current processing time.abstract long
currentWatermark()
Returns the current event-time watermark.abstract KS
getCurrentKey()
Get the key of the firing timer.abstract <X> void
output(org.apache.flink.util.OutputTag<X> outputTag, X value)
Emits a record to the side output identified by theOutputTag
.abstract TimeDomain
timeDomain()
TheTimeDomain
of the firing timer, i.e. if it is event or processing time timer.abstract Long
timestamp()
Timestamp of the element currently being processed or timestamp of a firing timer.-
Methods inherited from class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
timerService
-
Methods inherited from class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.ReadOnlyContext
getBroadcastState
-
-
-
-
Method Detail
-
timeDomain
public abstract TimeDomain timeDomain()
TheTimeDomain
of the firing timer, i.e. if it is event or processing time timer.
-
getCurrentKey
public abstract KS getCurrentKey()
Get the key of the firing timer.- Specified by:
getCurrentKey
in classKeyedBroadcastProcessFunction.ReadOnlyContext
-
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 theOutputTag
.- Parameters:
outputTag
- theOutputTag
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.
-
-