Class SynchronousChainedCombineDriver<IN,OUT>
- java.lang.Object
-
- org.apache.flink.runtime.operators.chaining.ChainedDriver<IN,OUT>
-
- org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver<IN,OUT>
-
- Type Parameters:
IN- The data type consumed by the combiner.OUT- The data type produced by the combiner.
- All Implemented Interfaces:
org.apache.flink.util.Collector<IN>
public class SynchronousChainedCombineDriver<IN,OUT> extends ChainedDriver<IN,OUT>
The chained variant of the combine driver which is also implemented in GroupReduceCombineDriver. In contrast to the GroupReduceCombineDriver, this driver's purpose is only to combine the values received in the chain. It is used by the GroupReduce and the CombineGroup transformation.- See Also:
GroupReduceCombineDriver
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.operators.chaining.ChainedDriver
config, executionConfig, metrics, numRecordsIn, numRecordsOut, objectReuseEnabled, outputCollector, taskName, userCodeClassLoader
-
-
Constructor Summary
Constructors Constructor Description SynchronousChainedCombineDriver()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidcancelTask()voidclose()voidcloseTask()voidcollect(IN record)org.apache.flink.api.common.functions.FunctiongetStub()StringgetTaskName()voidopenTask()voidsetup(AbstractInvokable parent)-
Methods inherited from class org.apache.flink.runtime.operators.chaining.ChainedDriver
getIOMetrics, getOutputCollector, getTaskConfig, getUdfRuntimeContext, setOutputCollector, setup
-
-
-
-
Method Detail
-
setup
public void setup(AbstractInvokable parent)
- Specified by:
setupin classChainedDriver<IN,OUT>
-
openTask
public void openTask() throws Exception- Specified by:
openTaskin classChainedDriver<IN,OUT>- Throws:
Exception
-
closeTask
public void closeTask() throws Exception- Specified by:
closeTaskin classChainedDriver<IN,OUT>- Throws:
Exception
-
cancelTask
public void cancelTask()
- Specified by:
cancelTaskin classChainedDriver<IN,OUT>
-
getStub
public org.apache.flink.api.common.functions.Function getStub()
- Specified by:
getStubin classChainedDriver<IN,OUT>
-
getTaskName
public String getTaskName()
- Specified by:
getTaskNamein classChainedDriver<IN,OUT>
-
collect
public void collect(IN record)
- Specified by:
collectin interfaceorg.apache.flink.util.Collector<IN>- Specified by:
collectin classChainedDriver<IN,OUT>
-
close
public void close()
-
-