Class ChainedDriver<IT,OT>
- java.lang.Object
-
- org.apache.flink.runtime.operators.chaining.ChainedDriver<IT,OT>
-
- All Implemented Interfaces:
org.apache.flink.util.Collector<IT>
- Direct Known Subclasses:
ChainedAllReduceDriver,ChainedFlatMapDriver,ChainedMapDriver,ChainedReduceCombineDriver,NoOpChainedDriver,SynchronousChainedCombineDriver
public abstract class ChainedDriver<IT,OT> extends Object implements org.apache.flink.util.Collector<IT>
The interface to be implemented by drivers that do not run in an own task context, but are chained to other tasks.
-
-
Field Summary
Fields Modifier and Type Field Description protected TaskConfigconfigprotected org.apache.flink.api.common.ExecutionConfigexecutionConfigprotected InternalOperatorMetricGroupmetricsprotected org.apache.flink.metrics.CounternumRecordsInprotected org.apache.flink.metrics.CounternumRecordsOutprotected booleanobjectReuseEnabledprotected org.apache.flink.util.Collector<OT>outputCollectorprotected StringtaskNameprotected ClassLoaderuserCodeClassLoader
-
Constructor Summary
Constructors Constructor Description ChainedDriver()
-
Method Summary
All Methods Instance Methods Abstract Methods Concrete Methods Modifier and Type Method Description abstract voidcancelTask()abstract voidcloseTask()abstract voidcollect(IT record)InternalOperatorIOMetricGroupgetIOMetrics()org.apache.flink.util.Collector<OT>getOutputCollector()abstract org.apache.flink.api.common.functions.FunctiongetStub()TaskConfiggetTaskConfig()abstract StringgetTaskName()protected org.apache.flink.api.common.functions.RuntimeContextgetUdfRuntimeContext()abstract voidopenTask()voidsetOutputCollector(org.apache.flink.util.Collector<?> outputCollector)abstract voidsetup(AbstractInvokable parent)voidsetup(TaskConfig config, String taskName, org.apache.flink.util.Collector<OT> outputCollector, AbstractInvokable parent, org.apache.flink.util.UserCodeClassLoader userCodeClassLoader, org.apache.flink.api.common.ExecutionConfig executionConfig, Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>> accumulatorMap)
-
-
-
Field Detail
-
config
protected TaskConfig config
-
taskName
protected String taskName
-
outputCollector
protected org.apache.flink.util.Collector<OT> outputCollector
-
userCodeClassLoader
protected ClassLoader userCodeClassLoader
-
executionConfig
protected org.apache.flink.api.common.ExecutionConfig executionConfig
-
objectReuseEnabled
protected boolean objectReuseEnabled
-
metrics
protected InternalOperatorMetricGroup metrics
-
numRecordsIn
protected org.apache.flink.metrics.Counter numRecordsIn
-
numRecordsOut
protected org.apache.flink.metrics.Counter numRecordsOut
-
-
Method Detail
-
setup
public void setup(TaskConfig config, String taskName, org.apache.flink.util.Collector<OT> outputCollector, AbstractInvokable parent, org.apache.flink.util.UserCodeClassLoader userCodeClassLoader, org.apache.flink.api.common.ExecutionConfig executionConfig, Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>> accumulatorMap)
-
setup
public abstract void setup(AbstractInvokable parent)
-
cancelTask
public abstract void cancelTask()
-
getStub
public abstract org.apache.flink.api.common.functions.Function getStub()
-
getTaskName
public abstract String getTaskName()
-
collect
public abstract void collect(IT record)
- Specified by:
collectin interfaceorg.apache.flink.util.Collector<IT>
-
getIOMetrics
public InternalOperatorIOMetricGroup getIOMetrics()
-
getUdfRuntimeContext
protected org.apache.flink.api.common.functions.RuntimeContext getUdfRuntimeContext()
-
setOutputCollector
public void setOutputCollector(org.apache.flink.util.Collector<?> outputCollector)
-
getOutputCollector
public org.apache.flink.util.Collector<OT> getOutputCollector()
-
getTaskConfig
public TaskConfig getTaskConfig()
-
-