IN
- The type of the input value.OUT
- The type of the output value.W
- The type of Window
that this window function can be applied on.@PublicEvolving public abstract class ProcessAllWindowFunction<IN,OUT,W extends Window> extends AbstractRichFunction
Modifier and Type | Class and Description |
---|---|
class |
ProcessAllWindowFunction.Context
The context holding window metadata.
|
Constructor and Description |
---|
ProcessAllWindowFunction() |
Modifier and Type | Method and Description |
---|---|
void |
clear(ProcessAllWindowFunction.Context context)
Deletes any state in the
Context when the Window expires (the watermark passes its
maxTimestamp + allowedLateness ). |
abstract void |
process(ProcessAllWindowFunction.Context context,
Iterable<IN> elements,
Collector<OUT> out)
Evaluates the window and outputs none or several elements.
|
close, getIterationRuntimeContext, getRuntimeContext, open, setRuntimeContext
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
open
public abstract void process(ProcessAllWindowFunction.Context context, Iterable<IN> elements, Collector<OUT> out) throws Exception
context
- The context in which the window is being evaluated.elements
- The elements in the window being evaluated.out
- A collector for emitting elements.Exception
- The function may throw exceptions to fail the program and trigger recovery.public void clear(ProcessAllWindowFunction.Context context) throws Exception
Context
when the Window expires (the watermark passes its
maxTimestamp
+ allowedLateness
).context
- The context to which the window is being evaluatedException
- The function may throw exceptions to fail the program and trigger recovery.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.