Class ProcessAllWindowFunction<IN,OUT,W extends Window>
- java.lang.Object
-
- org.apache.flink.api.common.functions.AbstractRichFunction
-
- org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction<IN,OUT,W>
-
- Type Parameters:
IN
- The type of the input value.OUT
- The type of the output value.W
- The type ofWindow
that this window function can be applied on.
- All Implemented Interfaces:
Serializable
,Function
,RichFunction
- Direct Known Subclasses:
ReduceApplyProcessAllWindowFunction
@PublicEvolving public abstract class ProcessAllWindowFunction<IN,OUT,W extends Window> extends AbstractRichFunction
Base abstract class for functions that are evaluated over non-keyed windows using a context for retrieving extra information.- See Also:
- Serialized Form
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description class
ProcessAllWindowFunction.Context
The context holding window metadata.
-
Constructor Summary
Constructors Constructor Description ProcessAllWindowFunction()
-
Method Summary
All Methods Instance Methods Abstract Methods Concrete Methods Modifier and Type Method Description void
clear(ProcessAllWindowFunction.Context context)
Deletes any state in theContext
when the Window expires (the watermark passes itsmaxTimestamp
+allowedLateness
).abstract void
process(ProcessAllWindowFunction.Context context, Iterable<IN> elements, Collector<OUT> out)
Evaluates the window and outputs none or several elements.-
Methods inherited from class org.apache.flink.api.common.functions.AbstractRichFunction
close, getIterationRuntimeContext, getRuntimeContext, open, setRuntimeContext
-
-
-
-
Method Detail
-
process
public abstract void process(ProcessAllWindowFunction.Context context, Iterable<IN> elements, Collector<OUT> out) throws Exception
Evaluates the window and outputs none or several elements.- Parameters:
context
- The context in which the window is being evaluated.elements
- The elements in the window being evaluated.out
- A collector for emitting elements.- Throws:
Exception
- The function may throw exceptions to fail the program and trigger recovery.
-
clear
public void clear(ProcessAllWindowFunction.Context context) throws Exception
Deletes any state in theContext
when the Window expires (the watermark passes itsmaxTimestamp
+allowedLateness
).- Parameters:
context
- The context to which the window is being evaluated- Throws:
Exception
- The function may throw exceptions to fail the program and trigger recovery.
-
-