Class ReduceApplyAllWindowFunction<W extends Window,T,R>
- java.lang.Object
-
- org.apache.flink.api.common.functions.AbstractRichFunction
-
- org.apache.flink.api.common.functions.WrappingFunction<AllWindowFunction<T,R,W>>
-
- org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction<W,T,R>
-
- All Implemented Interfaces:
Serializable,org.apache.flink.api.common.functions.Function,org.apache.flink.api.common.functions.RichFunction,AllWindowFunction<T,R,W>
@Internal public class ReduceApplyAllWindowFunction<W extends Window,T,R> extends org.apache.flink.api.common.functions.WrappingFunction<AllWindowFunction<T,R,W>> implements AllWindowFunction<T,R,W>
InternalAllWindowFunctionthat is used for implementing a fold on a window configuration that only allowsAllWindowFunctionand cannot directly execute aReduceFunction.- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description ReduceApplyAllWindowFunction(org.apache.flink.api.common.functions.ReduceFunction<T> reduceFunction, AllWindowFunction<T,R,W> windowFunction)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidapply(W window, Iterable<T> input, org.apache.flink.util.Collector<R> out)Evaluates the window and outputs none or several elements.-
Methods inherited from class org.apache.flink.api.common.functions.WrappingFunction
close, getWrappedFunction, open, setRuntimeContext
-
-
-
-
Constructor Detail
-
ReduceApplyAllWindowFunction
public ReduceApplyAllWindowFunction(org.apache.flink.api.common.functions.ReduceFunction<T> reduceFunction, AllWindowFunction<T,R,W> windowFunction)
-
-
Method Detail
-
apply
public void apply(W window, Iterable<T> input, org.apache.flink.util.Collector<R> out) throws Exception
Description copied from interface:AllWindowFunctionEvaluates the window and outputs none or several elements.- Specified by:
applyin interfaceAllWindowFunction<W extends Window,T,R>- Parameters:
window- The window that 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.
-
-