Package | Description |
---|---|
org.apache.flink.runtime.operators | |
org.apache.flink.runtime.operators.shipping | |
org.apache.flink.streaming.runtime.io |
Modifier and Type | Field and Description |
---|---|
protected List<RecordWriter<?>> |
BatchTask.eventualOutputs
The output writers for the data that this task forwards to the next task.
|
Modifier and Type | Method and Description |
---|---|
static void |
BatchTask.clearWriters(List<RecordWriter<?>> writers) |
static <T> Collector<T> |
BatchTask.getOutputCollector(AbstractInvokable task,
TaskConfig config,
ClassLoader cl,
List<RecordWriter<?>> eventualOutputs,
int outputOffset,
int numOutputs,
AccumulatorRegistry.Reporter reporter)
Creates the
Collector for the given task, as described by the given configuration. |
static <T> Collector<T> |
BatchTask.initOutputs(AbstractInvokable nepheleTask,
ClassLoader cl,
TaskConfig config,
List<ChainedDriver<?,?>> chainedTasksTarget,
List<RecordWriter<?>> eventualOutputs,
ExecutionConfig executionConfig,
AccumulatorRegistry.Reporter reporter,
Map<String,Accumulator<?,?>> accumulatorMap)
Creates a writer for each output.
|
Modifier and Type | Method and Description |
---|---|
List<RecordWriter<SerializationDelegate<T>>> |
OutputCollector.getWriters()
List of writers that are associated with this output collector
|
Constructor and Description |
---|
OutputCollector(List<RecordWriter<SerializationDelegate<T>>> writers,
TypeSerializer<T> serializer)
Initializes the output collector with a set of writers.
|
Modifier and Type | Class and Description |
---|---|
class |
StreamRecordWriter<T extends IOReadableWritable>
This record writer keeps data in buffers at most for a certain timeout.
|
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.