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 longcurrentProcessingTime()Returns the current processing time.longcurrentWatermark()Returns the current event-time watermark.org.apache.flink.api.common.state.KeyedStateStoreglobalState()State accessor for per-key global state.<X> voidoutput(org.apache.flink.util.OutputTag<X> outputTag, X value)Emits a record to the side output identified by theOutputTag.Wwindow()Returns the window that is being evaluated.org.apache.flink.api.common.state.KeyedStateStorewindowState()State accessor for per-key and per-window state.
-
-
-
Method Detail
-
window
public W window()
Description copied from class:ProcessWindowFunction.ContextReturns the window that is being evaluated.- Specified by:
windowin classProcessWindowFunction.Context
-
currentProcessingTime
public long currentProcessingTime()
Description copied from class:ProcessWindowFunction.ContextReturns the current processing time.- Specified by:
currentProcessingTimein classProcessWindowFunction.Context
-
currentWatermark
public long currentWatermark()
Description copied from class:ProcessWindowFunction.ContextReturns the current event-time watermark.- Specified by:
currentWatermarkin classProcessWindowFunction.Context
-
windowState
public org.apache.flink.api.common.state.KeyedStateStore windowState()
Description copied from class:ProcessWindowFunction.ContextState 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:
windowStatein classProcessWindowFunction.Context
-
globalState
public org.apache.flink.api.common.state.KeyedStateStore globalState()
Description copied from class:ProcessWindowFunction.ContextState accessor for per-key global state.- Specified by:
globalStatein classProcessWindowFunction.Context
-
output
public <X> void output(org.apache.flink.util.OutputTag<X> outputTag, X value)Description copied from class:ProcessWindowFunction.ContextEmits a record to the side output identified by theOutputTag.- Specified by:
outputin classProcessWindowFunction.Context- Parameters:
outputTag- theOutputTagthat identifies the side output to emit to.value- The record to emit.
-
-