Modifier and Type | Class and Description |
---|---|
class |
RoundRobinChannelSelector<T extends IOReadableWritable>
This is the default implementation of the
ChannelSelector interface. |
Modifier and Type | Method and Description |
---|---|
ChannelSelector<T> |
ChannelSelectorRecordWriter.getChannelSelector() |
Modifier and Type | Method and Description |
---|---|
RecordWriterBuilder<T> |
RecordWriterBuilder.setChannelSelector(ChannelSelector<T> selector) |
Modifier and Type | Class and Description |
---|---|
class |
OutputEmitter<T>
The output emitter decides to which of the possibly multiple output channels a record is sent.
|
Modifier and Type | Class and Description |
---|---|
class |
BroadcastPartitioner<T>
Partitioner that selects all the output channels.
|
class |
CustomPartitionerWrapper<K,T>
Partitioner that selects the channel with a user defined partitioner function on a key.
|
class |
ForwardForConsecutiveHashPartitioner<T>
If there are multiple consecutive and the same hash shuffles, SQL planner will change them except
the first one to use forward partitioner, so that these operators can be chained to reduce
unnecessary shuffles.
|
class |
ForwardForUnspecifiedPartitioner<T>
When the parallelism of both upstream and downstream is
ExecutionConfig.PARALLELISM_DEFAULT and the edge's partitioner is not specified
(partitioner==null), the edge's partitioner will be set to FORWARD by default(See StreamGraph.createActualEdge(java.lang.Integer, java.lang.Integer, int, org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<?>, org.apache.flink.util.OutputTag, org.apache.flink.streaming.api.transformations.StreamExchangeMode, org.apache.flink.runtime.jobgraph.IntermediateDataSetID) method for details). |
class |
ForwardPartitioner<T>
Partitioner that forwards elements only to the locally running downstream operation.
|
class |
GlobalPartitioner<T>
Partitioner that sends all elements to the downstream operator with subtask ID=0.
|
class |
KeyGroupStreamPartitioner<T,K>
Partitioner selects the target channel based on the key group index.
|
class |
RebalancePartitioner<T>
Partitioner that distributes the data equally by cycling through the output channels.
|
class |
RescalePartitioner<T>
Partitioner that distributes the data equally by cycling through the output channels.
|
class |
ShufflePartitioner<T>
Partitioner that distributes the data equally by selecting one output channel randomly.
|
class |
StreamPartitioner<T>
A special
ChannelSelector for use in streaming programs. |
Modifier and Type | Class and Description |
---|---|
class |
BinaryHashPartitioner
Hash partitioner for
BinaryRowData . |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.