K
- Type of the keyT
- Type of the data@Internal public class CustomPartitionerWrapper<K,T> extends StreamPartitioner<T>
构造器和说明 |
---|
CustomPartitionerWrapper(org.apache.flink.api.common.functions.Partitioner<K> partitioner,
org.apache.flink.api.java.functions.KeySelector<T,K> keySelector) |
限定符和类型 | 方法和说明 |
---|---|
StreamPartitioner<T> |
copy() |
int[] |
selectChannels(org.apache.flink.runtime.plugable.SerializationDelegate<StreamRecord<T>> record,
int numberOfOutputChannels) |
String |
toString() |
public int[] selectChannels(org.apache.flink.runtime.plugable.SerializationDelegate<StreamRecord<T>> record, int numberOfOutputChannels)
public StreamPartitioner<T> copy()
copy
在类中 StreamPartitioner<T>
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.