Class OperatorSubtaskStateReducer
- java.lang.Object
-
- org.apache.flink.api.common.functions.AbstractRichFunction
-
- org.apache.flink.api.common.functions.RichGroupReduceFunction<TaggedOperatorSubtaskState,OperatorState>
-
- org.apache.flink.state.api.output.OperatorSubtaskStateReducer
-
- All Implemented Interfaces:
Serializable
,Function
,GroupReduceFunction<TaggedOperatorSubtaskState,OperatorState>
,RichFunction
@Internal public class OperatorSubtaskStateReducer extends RichGroupReduceFunction<TaggedOperatorSubtaskState,OperatorState>
A reducer that aggregates allOperatorSubtaskState
's for a particular operator into a singleOperatorState
.- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description OperatorSubtaskStateReducer(OperatorIdentifier operatorIdentifier, int maxParallelism)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
open(OpenContext openContext)
Initialization method for the function.void
reduce(Iterable<TaggedOperatorSubtaskState> values, Collector<OperatorState> out)
The reduce method.-
Methods inherited from class org.apache.flink.api.common.functions.AbstractRichFunction
close, getIterationRuntimeContext, getRuntimeContext, setRuntimeContext
-
-
-
-
Constructor Detail
-
OperatorSubtaskStateReducer
public OperatorSubtaskStateReducer(OperatorIdentifier operatorIdentifier, int maxParallelism)
-
-
Method Detail
-
open
public void open(OpenContext openContext) throws Exception
Description copied from interface:RichFunction
Initialization method for the function. It is called before the actual working methods (like map or join) and thus suitable for one time setup work. For functions that are part of an iteration, this method will be invoked at the beginning of each iteration superstep.The openContext object passed to the function can be used for configuration and initialization. The openContext contains some necessary information that were configured on the function in the program composition.
public class MyFilter extends RichFilterFunction<String> { private String searchString; public void open(OpenContext openContext) { // initialize the value of searchString } public boolean filter(String value) { return value.equals(searchString); } }
- Specified by:
open
in interfaceRichFunction
- Overrides:
open
in classAbstractRichFunction
- Parameters:
openContext
- The context containing information about the context in which the function is opened.- Throws:
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.
-
reduce
public void reduce(Iterable<TaggedOperatorSubtaskState> values, Collector<OperatorState> out)
Description copied from interface:GroupReduceFunction
The reduce method. The function receives one call per group of elements.- Specified by:
reduce
in interfaceGroupReduceFunction<TaggedOperatorSubtaskState,OperatorState>
- Specified by:
reduce
in classRichGroupReduceFunction<TaggedOperatorSubtaskState,OperatorState>
- Parameters:
values
- All records that belong to the given input key.out
- The collector to hand results to.
-
-