T
- Type of the Tuple@Internal public class ShufflePartitioner<T> extends StreamPartitioner<T>
numberOfChannels
构造器和说明 |
---|
ShufflePartitioner() |
限定符和类型 | 方法和说明 |
---|---|
StreamPartitioner<T> |
copy() |
org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper |
getDownstreamSubtaskStateMapper()
Defines the behavior of this partitioner, when downstream rescaled during recovery of
in-flight data.
|
int |
selectChannel(org.apache.flink.runtime.plugable.SerializationDelegate<StreamRecord<T>> record) |
String |
toString() |
equals, getUpstreamSubtaskStateMapper, hashCode, isBroadcast, setup
public int selectChannel(org.apache.flink.runtime.plugable.SerializationDelegate<StreamRecord<T>> record)
public org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper getDownstreamSubtaskStateMapper()
StreamPartitioner
public StreamPartitioner<T> copy()
copy
在类中 StreamPartitioner<T>
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.