Package | Description |
---|---|
org.apache.flink.runtime.jobgraph | |
org.apache.flink.runtime.operators | |
org.apache.flink.runtime.operators.chaining | |
org.apache.flink.runtime.operators.util |
Modifier and Type | Method and Description |
---|---|
void |
InputOutputFormatContainer.write(TaskConfig config) |
Constructor and Description |
---|
InputOutputFormatContainer(TaskConfig config,
ClassLoader classLoader) |
Modifier and Type | Field and Description |
---|---|
protected TaskConfig |
BatchTask.config
The task configuration with the setup parameters.
|
Modifier and Type | Method and Description |
---|---|
TaskConfig |
BatchTask.getLastTasksConfig() |
TaskConfig |
TaskContext.getTaskConfig() |
TaskConfig |
BatchTask.getTaskConfig() |
Modifier and Type | Method and Description |
---|---|
static <T> Collector<T> |
BatchTask.getOutputCollector(AbstractInvokable task,
TaskConfig config,
ClassLoader cl,
List<RecordWriter<?>> eventualOutputs,
int outputOffset,
int numOutputs)
Creates the
Collector for the given task, as described by the given configuration. |
static <T> Collector<T> |
BatchTask.initOutputs(AbstractInvokable containingTask,
ClassLoader cl,
TaskConfig config,
List<ChainedDriver<?,?>> chainedTasksTarget,
List<RecordWriter<?>> eventualOutputs,
ExecutionConfig executionConfig,
Map<String,Accumulator<?,?>> accumulatorMap)
Creates a writer for each output.
|
static <T> T |
BatchTask.instantiateUserCode(TaskConfig config,
ClassLoader cl,
Class<? super T> superClass)
Instantiates a user code class from is definition in the task configuration.
|
Modifier and Type | Field and Description |
---|---|
protected TaskConfig |
ChainedDriver.config |
Modifier and Type | Method and Description |
---|---|
TaskConfig |
ChainedDriver.getTaskConfig() |
Modifier and Type | Method and Description |
---|---|
void |
ChainedDriver.setup(TaskConfig config,
String taskName,
Collector<OT> outputCollector,
AbstractInvokable parent,
ClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
Map<String,Accumulator<?,?>> accumulatorMap) |
Modifier and Type | Method and Description |
---|---|
TaskConfig |
TaskConfig.getChainedStubConfig(int chainPos) |
TaskConfig |
TaskConfig.getIterationHeadFinalOutputConfig() |
Modifier and Type | Method and Description |
---|---|
void |
TaskConfig.addChainedTask(Class<? extends ChainedDriver> chainedTaskClass,
TaskConfig conf,
String taskName) |
void |
TaskConfig.setIterationHeadFinalOutputConfig(TaskConfig conf) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.