T
- Type of the elements in the Stream being partitioned@Internal public class KeyGroupStreamPartitioner<T,K> extends StreamPartitioner<T> implements ConfigurableStreamPartitioner
Constructor and Description |
---|
KeyGroupStreamPartitioner(org.apache.flink.api.java.functions.KeySelector<T,K> keySelector,
int maxParallelism) |
Modifier and Type | Method and Description |
---|---|
void |
configure(int maxParallelism)
Configure the
StreamPartitioner with the maximum parallelism of the down stream
operator. |
StreamPartitioner<T> |
copy() |
int |
getMaxParallelism() |
int[] |
selectChannels(org.apache.flink.runtime.plugable.SerializationDelegate<StreamRecord<T>> record,
int numberOfOutputChannels) |
String |
toString() |
public int getMaxParallelism()
public int[] selectChannels(org.apache.flink.runtime.plugable.SerializationDelegate<StreamRecord<T>> record, int numberOfOutputChannels)
selectChannels
in interface org.apache.flink.runtime.io.network.api.writer.ChannelSelector<org.apache.flink.runtime.plugable.SerializationDelegate<StreamRecord<T>>>
public StreamPartitioner<T> copy()
copy
in class StreamPartitioner<T>
public void configure(int maxParallelism)
ConfigurableStreamPartitioner
StreamPartitioner
with the maximum parallelism of the down stream
operator.configure
in interface ConfigurableStreamPartitioner
maxParallelism
- Maximum parallelism of the down stream operator.Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.