Package | Description |
---|---|
org.apache.flink.runtime.operators.shipping | |
org.apache.flink.streaming.runtime.io | |
org.apache.flink.streaming.runtime.partitioner |
Modifier and Type | Method and Description |
---|---|
List<RecordWriter<SerializationDelegate<T>>> |
OutputCollector.getWriters()
List of writers that are associated with this output collector
|
Modifier and Type | Method and Description |
---|---|
int[] |
OutputEmitter.selectChannels(SerializationDelegate<T> record,
int numberOfChannels) |
Constructor and Description |
---|
OutputCollector(List<RecordWriter<SerializationDelegate<T>>> writers,
TypeSerializer<T> serializer)
Initializes the output collector with a set of writers.
|
Constructor and Description |
---|
RecordWriterOutput(StreamRecordWriter<SerializationDelegate<StreamRecord<OUT>>> recordWriter,
TypeSerializer<OUT> outSerializer,
OutputTag outputTag,
StreamStatusProvider streamStatusProvider) |
Modifier and Type | Method and Description |
---|---|
int[] |
RebalancePartitioner.selectChannels(SerializationDelegate<StreamRecord<T>> record,
int numberOfOutputChannels) |
int[] |
BroadcastPartitioner.selectChannels(SerializationDelegate<StreamRecord<T>> record,
int numberOfOutputChannels) |
int[] |
KeyGroupStreamPartitioner.selectChannels(SerializationDelegate<StreamRecord<T>> record,
int numberOfOutputChannels) |
int[] |
ShufflePartitioner.selectChannels(SerializationDelegate<StreamRecord<T>> record,
int numberOfOutputChannels) |
int[] |
GlobalPartitioner.selectChannels(SerializationDelegate<StreamRecord<T>> record,
int numberOfOutputChannels) |
int[] |
RescalePartitioner.selectChannels(SerializationDelegate<StreamRecord<T>> record,
int numberOfOutputChannels) |
int[] |
ForwardPartitioner.selectChannels(SerializationDelegate<StreamRecord<T>> record,
int numberOfOutputChannels) |
int[] |
CustomPartitionerWrapper.selectChannels(SerializationDelegate<StreamRecord<T>> record,
int numberOfOutputChannels) |
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.