Class InternalProcessApplyWindowContext<IN,OUT,KEY,W extends Window>
- java.lang.Object
-
- org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
- org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext<IN,OUT,KEY,W>
-
- Type Parameters:
IN
- The type of the input value.OUT
- The type of the output value.KEY
- The type of the window key.W
- The type of the window.
- All Implemented Interfaces:
Serializable
@Internal public class InternalProcessApplyWindowContext<IN,OUT,KEY,W extends Window> extends ProcessWindowFunction.Context
Internal reusable context wrapper.- See Also:
- Serialized Form
-
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description long
currentProcessingTime()
Returns the current processing time.long
currentWatermark()
Returns the current event-time watermark.org.apache.flink.api.common.state.KeyedStateStore
globalState()
State accessor for per-key global state.<X> void
output(org.apache.flink.util.OutputTag<X> outputTag, X value)
Emits a record to the side output identified by theOutputTag
.W
window()
Returns the window that is being evaluated.org.apache.flink.api.common.state.KeyedStateStore
windowState()
State accessor for per-key and per-window state.
-
-
-
Method Detail
-
window
public W window()
Description copied from class:ProcessWindowFunction.Context
Returns the window that is being evaluated.- Specified by:
window
in classProcessWindowFunction.Context
-
currentProcessingTime
public long currentProcessingTime()
Description copied from class:ProcessWindowFunction.Context
Returns the current processing time.- Specified by:
currentProcessingTime
in classProcessWindowFunction.Context
-
currentWatermark
public long currentWatermark()
Description copied from class:ProcessWindowFunction.Context
Returns the current event-time watermark.- Specified by:
currentWatermark
in classProcessWindowFunction.Context
-
windowState
public org.apache.flink.api.common.state.KeyedStateStore windowState()
Description copied from class:ProcessWindowFunction.Context
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)
.- Specified by:
windowState
in classProcessWindowFunction.Context
-
globalState
public org.apache.flink.api.common.state.KeyedStateStore globalState()
Description copied from class:ProcessWindowFunction.Context
State accessor for per-key global state.- Specified by:
globalState
in classProcessWindowFunction.Context
-
output
public <X> void output(org.apache.flink.util.OutputTag<X> outputTag, X value)
Description copied from class:ProcessWindowFunction.Context
Emits a record to the side output identified by theOutputTag
.- Specified by:
output
in classProcessWindowFunction.Context
- Parameters:
outputTag
- theOutputTag
that identifies the side output to emit to.value
- The record to emit.
-
-