- Type Parameters:
 
IN - The type of the input value. 
OUT - The type of the output value. 
KEY - The type of the key. 
W - The type of Window that 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, org.apache.flink.streaming.api.functions.windowing.WindowFunction<IN,OUT,KEY,W> 
@Public
public abstract class RichWindowFunction<IN,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window>
extends org.apache.flink.api.common.functions.AbstractRichFunction
implements org.apache.flink.streaming.api.functions.windowing.WindowFunction<IN,OUT,KEY,W>
Rich variant of the WindowFunction. As a RichFunction, it gives access to the
 RuntimeContext and provides setup and tear-down
 methods: RichFunction.open(OpenContext) and RichFunction.close().
- See Also:
 
- Serialized Form