@Internal public class ReduceApplyProcessAllWindowFunction<W extends Window,T,R> extends ProcessAllWindowFunction<T,R,W>
ProcessAllWindowFunction
that is used for implementing a fold on a window
configuration that only allows AllWindowFunction
and cannot directly execute a ReduceFunction
.ProcessAllWindowFunction.Context
Constructor and Description |
---|
ReduceApplyProcessAllWindowFunction(org.apache.flink.api.common.functions.ReduceFunction<T> reduceFunction,
ProcessAllWindowFunction<T,R,W> windowFunction) |
Modifier and Type | Method and Description |
---|---|
void |
clear(ProcessAllWindowFunction.Context context)
Deletes any state in the
Context when the Window expires (the watermark passes its
maxTimestamp + allowedLateness ). |
void |
close() |
void |
open(org.apache.flink.configuration.Configuration configuration) |
void |
process(ProcessAllWindowFunction.Context context,
Iterable<T> input,
org.apache.flink.util.Collector<R> out)
Evaluates the window and outputs none or several elements.
|
void |
setRuntimeContext(org.apache.flink.api.common.functions.RuntimeContext t) |
public ReduceApplyProcessAllWindowFunction(org.apache.flink.api.common.functions.ReduceFunction<T> reduceFunction, ProcessAllWindowFunction<T,R,W> windowFunction)
public void process(ProcessAllWindowFunction.Context context, Iterable<T> input, org.apache.flink.util.Collector<R> out) throws Exception
ProcessAllWindowFunction
process
in class ProcessAllWindowFunction<T,R,W extends Window>
context
- The context in which the window is being evaluated.input
- The elements in the window being evaluated.out
- A collector for emitting elements.Exception
- The function may throw exceptions to fail the program and trigger recovery.public void clear(ProcessAllWindowFunction.Context context) throws Exception
ProcessAllWindowFunction
Context
when the Window expires (the watermark passes its
maxTimestamp
+ allowedLateness
).public void open(org.apache.flink.configuration.Configuration configuration) throws Exception
open
in interface org.apache.flink.api.common.functions.RichFunction
open
in class org.apache.flink.api.common.functions.AbstractRichFunction
Exception
public void close() throws Exception
close
in interface org.apache.flink.api.common.functions.RichFunction
close
in class org.apache.flink.api.common.functions.AbstractRichFunction
Exception
public void setRuntimeContext(org.apache.flink.api.common.functions.RuntimeContext t)
setRuntimeContext
in interface org.apache.flink.api.common.functions.RichFunction
setRuntimeContext
in class org.apache.flink.api.common.functions.AbstractRichFunction
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.