IN
- The data type consumed by the combiner.OUT
- The data type produced by the combiner.public class SynchronousChainedCombineDriver<IN,OUT> extends ChainedDriver<IN,OUT>
GroupReduceCombineDriver
config, executionConfig, objectReuseEnabled, outputCollector, taskName, userCodeClassLoader
Constructor and Description |
---|
SynchronousChainedCombineDriver() |
Modifier and Type | Method and Description |
---|---|
void |
cancelTask() |
void |
close() |
void |
closeTask() |
void |
collect(IN record) |
org.apache.flink.api.common.functions.Function |
getStub() |
String |
getTaskName() |
void |
openTask() |
void |
setup(AbstractInvokable parent) |
getOutputCollector, getTaskConfig, getUdfRuntimeContext, setOutputCollector, setup
public void setup(AbstractInvokable parent)
setup
in class ChainedDriver<IN,OUT>
public void openTask() throws Exception
openTask
in class ChainedDriver<IN,OUT>
Exception
public void closeTask() throws Exception
closeTask
in class ChainedDriver<IN,OUT>
Exception
public void cancelTask()
cancelTask
in class ChainedDriver<IN,OUT>
public org.apache.flink.api.common.functions.Function getStub()
getStub
in class ChainedDriver<IN,OUT>
public String getTaskName()
getTaskName
in class ChainedDriver<IN,OUT>
public void collect(IN record)
collect
in interface org.apache.flink.util.Collector<IN>
collect
in class ChainedDriver<IN,OUT>
public void close()
Copyright © 2014–2015 The Apache Software Foundation. All rights reserved.