T
- Type of the elements in the Stream being broadcast@Internal public class BroadcastPartitioner<T> extends StreamPartitioner<T>
numberOfChannels
Constructor and Description |
---|
BroadcastPartitioner() |
Modifier and Type | Method and Description |
---|---|
StreamPartitioner<T> |
copy() |
boolean |
isBroadcast() |
int |
selectChannel(org.apache.flink.runtime.plugable.SerializationDelegate<StreamRecord<T>> record)
Note: Broadcast mode could be handled directly for all the output channels in record writer,
so it is no need to select channels via this method.
|
String |
toString() |
setup
public int selectChannel(org.apache.flink.runtime.plugable.SerializationDelegate<StreamRecord<T>> record)
public boolean isBroadcast()
isBroadcast
in interface org.apache.flink.runtime.io.network.api.writer.ChannelSelector<org.apache.flink.runtime.plugable.SerializationDelegate<StreamRecord<T>>>
isBroadcast
in class StreamPartitioner<T>
public StreamPartitioner<T> copy()
copy
in class StreamPartitioner<T>
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.