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 ofWindowthat this window function can be applied on.
- All Implemented Interfaces:
Serializable,org.apache.flink.api.common.functions.Function,org.apache.flink.api.common.functions.RichFunction
- Direct Known Subclasses:
ReduceApplyProcessAllWindowFunction
@PublicEvolving public abstract class ProcessAllWindowFunction<IN,OUT,W extends Window> extends org.apache.flink.api.common.functions.AbstractRichFunctionBase 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 classProcessAllWindowFunction.ContextThe 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 voidclear(ProcessAllWindowFunction.Context context)Deletes any state in theContextwhen the Window expires (the watermark passes itsmaxTimestamp+allowedLateness).abstract voidprocess(ProcessAllWindowFunction.Context context, Iterable<IN> elements, org.apache.flink.util.Collector<OUT> out)Evaluates the window and outputs none or several elements.
-
-
-
Method Detail
-
process
public abstract void process(ProcessAllWindowFunction.Context context, Iterable<IN> elements, org.apache.flink.util.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 theContextwhen 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.
-
-