Class ReduceApplyProcessAllWindowFunction<W extends Window,T,R>
- java.lang.Object
-
- org.apache.flink.api.common.functions.AbstractRichFunction
-
- org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction<T,R,W>
-
- org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction<W,T,R>
-
- All Implemented Interfaces:
Serializable,org.apache.flink.api.common.functions.Function,org.apache.flink.api.common.functions.RichFunction
@Internal public class ReduceApplyProcessAllWindowFunction<W extends Window,T,R> extends ProcessAllWindowFunction<T,R,W>
InternalProcessAllWindowFunctionthat is used for implementing a fold on a window configuration that only allowsAllWindowFunctionand cannot directly execute aReduceFunction.- See Also:
- Serialized Form
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
ProcessAllWindowFunction.Context
-
-
Constructor Summary
Constructors Constructor Description ReduceApplyProcessAllWindowFunction(org.apache.flink.api.common.functions.ReduceFunction<T> reduceFunction, ProcessAllWindowFunction<T,R,W> windowFunction)
-
Method Summary
All Methods Instance 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).voidclose()voidopen(org.apache.flink.api.common.functions.OpenContext openContext)voidprocess(ProcessAllWindowFunction.Context context, Iterable<T> input, org.apache.flink.util.Collector<R> out)Evaluates the window and outputs none or several elements.voidsetRuntimeContext(org.apache.flink.api.common.functions.RuntimeContext t)
-
-
-
Constructor Detail
-
ReduceApplyProcessAllWindowFunction
public ReduceApplyProcessAllWindowFunction(org.apache.flink.api.common.functions.ReduceFunction<T> reduceFunction, ProcessAllWindowFunction<T,R,W> windowFunction)
-
-
Method Detail
-
process
public void process(ProcessAllWindowFunction.Context context, Iterable<T> input, org.apache.flink.util.Collector<R> out) throws Exception
Description copied from class:ProcessAllWindowFunctionEvaluates the window and outputs none or several elements.- Specified by:
processin classProcessAllWindowFunction<T,R,W extends Window>- Parameters:
context- The context in which the window is being evaluated.input- 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
Description copied from class:ProcessAllWindowFunctionDeletes any state in theContextwhen the Window expires (the watermark passes itsmaxTimestamp+allowedLateness).
-
open
public void open(org.apache.flink.api.common.functions.OpenContext openContext) throws Exception- Specified by:
openin interfaceorg.apache.flink.api.common.functions.RichFunction- Overrides:
openin classorg.apache.flink.api.common.functions.AbstractRichFunction- Throws:
Exception
-
close
public void close() throws Exception- Specified by:
closein interfaceorg.apache.flink.api.common.functions.RichFunction- Overrides:
closein classorg.apache.flink.api.common.functions.AbstractRichFunction- Throws:
Exception
-
setRuntimeContext
public void setRuntimeContext(org.apache.flink.api.common.functions.RuntimeContext t)
- Specified by:
setRuntimeContextin interfaceorg.apache.flink.api.common.functions.RichFunction- Overrides:
setRuntimeContextin classorg.apache.flink.api.common.functions.AbstractRichFunction
-
-