public abstract class ProcessWindowFunction.Context extends Object implements Serializable
Constructor and Description |
---|
Context() |
Modifier and Type | Method and 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 the
OutputTag . |
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.
|
public abstract W window()
public abstract long currentProcessingTime()
public abstract long currentWatermark()
public abstract org.apache.flink.api.common.state.KeyedStateStore windowState()
NOTE:If you use per-window state you have to ensure that you clean it up by
implementing ProcessWindowFunction.clear(Context)
.
public abstract org.apache.flink.api.common.state.KeyedStateStore globalState()
public abstract <X> void output(org.apache.flink.util.OutputTag<X> outputTag, X value)
OutputTag
.outputTag
- the OutputTag
that identifies the side output to emit to.value
- The record to emit.Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.