Class PassThroughWindowFunction<K,W extends Window,T>
- java.lang.Object
-
- org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction<K,W,T>
-
- All Implemented Interfaces:
Serializable,org.apache.flink.api.common.functions.Function,WindowFunction<T,T,K,W>
@Internal public class PassThroughWindowFunction<K,W extends Window,T> extends Object implements WindowFunction<T,T,K,W>
AWindowFunctionthat just emits each input element.- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description PassThroughWindowFunction()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidapply(K k, W window, Iterable<T> input, org.apache.flink.util.Collector<T> out)Evaluates the window and outputs none or several elements.
-
-
-
Method Detail
-
apply
public void apply(K k, W window, Iterable<T> input, org.apache.flink.util.Collector<T> out) throws Exception
Description copied from interface:WindowFunctionEvaluates the window and outputs none or several elements.- Specified by:
applyin interfaceWindowFunction<T,T,K,W extends Window>- Parameters:
k- The key for which this window is evaluated.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.
-
-