Class ProcessWindowFunction.Context
- java.lang.Object
-
- org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
- All Implemented Interfaces:
Serializable
- Direct Known Subclasses:
InternalProcessApplyWindowContext
,InternalProcessWindowContext
,InternalProcessWindowContext
public abstract class ProcessWindowFunction.Context extends Object implements Serializable
The context holding window metadata.- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description Context()
-
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 org.apache.flink.api.common.state.KeyedStateStore
globalState()
State accessor for per-key global state.abstract <X> void
output(org.apache.flink.util.OutputTag<X> outputTag, X value)
Emits a record to the side output identified by theOutputTag
.abstract W
window()
Returns the window that is being evaluated.abstract org.apache.flink.api.common.state.KeyedStateStore
windowState()
State accessor for per-key and per-window state.
-
-
-
Method Detail
-
window
public abstract W window()
Returns the window that is being evaluated.
-
currentProcessingTime
public abstract long currentProcessingTime()
Returns the current processing time.
-
currentWatermark
public abstract long currentWatermark()
Returns the current event-time watermark.
-
windowState
public abstract org.apache.flink.api.common.state.KeyedStateStore windowState()
State accessor for per-key and per-window state.NOTE:If you use per-window state you have to ensure that you clean it up by implementing
ProcessWindowFunction#clear(Context)
.
-
globalState
public abstract org.apache.flink.api.common.state.KeyedStateStore globalState()
State accessor for per-key global state.
-
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.
-
-