@Internal public class FoldApplyAllWindowFunction<W extends Window,T,ACC> extends WrappingFunction<AllWindowFunction<ACC,ACC,W>> implements AllWindowFunction<T,ACC,W>, OutputTypeConfigurable<ACC>
wrappedFunction
Constructor and Description |
---|
FoldApplyAllWindowFunction(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
AllWindowFunction<ACC,ACC,W> windowFunction) |
Modifier and Type | Method and Description |
---|---|
void |
apply(W window,
Iterable<T> values,
Collector<ACC> out)
Evaluates the window and outputs none or several elements.
|
void |
open(Configuration configuration)
Initialization method for the function.
|
void |
setOutputType(TypeInformation<ACC> outTypeInfo,
ExecutionConfig executionConfig)
Is called by the
org.apache.flink.streaming.api.graph.StreamGraph#addOperator(Integer, StreamOperator, TypeInformation, TypeInformation, String)
method when the StreamGraph is generated. |
close, getWrappedFunction, setRuntimeContext
getIterationRuntimeContext, getRuntimeContext
public FoldApplyAllWindowFunction(ACC initialValue, FoldFunction<T,ACC> foldFunction, AllWindowFunction<ACC,ACC,W> windowFunction)
public void open(Configuration configuration) throws Exception
RichFunction
The configuration object passed to the function can be used for configuration and initialization. The configuration contains all parameters that were configured on the function in the program composition.
public class MyMapper extends FilterFunction<String> {
private String searchString;
public void open(Configuration parameters) {
this.searchString = parameters.getString("foo");
}
public boolean filter(String value) {
return value.equals(searchString);
}
}
By default, this method does nothing.
open
in interface RichFunction
open
in class WrappingFunction<AllWindowFunction<ACC,ACC,W extends Window>>
configuration
- The configuration containing the parameters attached to the contract.Exception
- Implementations may forward exceptions, which are caught by the runtime. When the
runtime catches an exception, it aborts the task and lets the fail-over logic
decide whether to retry the task execution.Configuration
public void apply(W window, Iterable<T> values, Collector<ACC> out) throws Exception
AllWindowFunction
apply
in interface AllWindowFunction<T,ACC,W extends Window>
window
- The window that is being evaluated.values
- 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 setOutputType(TypeInformation<ACC> outTypeInfo, ExecutionConfig executionConfig)
OutputTypeConfigurable
org.apache.flink.streaming.api.graph.StreamGraph#addOperator(Integer, StreamOperator, TypeInformation, TypeInformation, String)
method when the StreamGraph
is generated. The
method is called with the output TypeInformation
which is also used for the
StreamTask
output serializer.setOutputType
in interface OutputTypeConfigurable<ACC>
outTypeInfo
- Output type information of the StreamTask
executionConfig
- Execution configurationCopyright © 2014–2017 The Apache Software Foundation. All rights reserved.