public class ProxyStreamPartitioner<T> extends org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<IterationRecord<T>>
| 构造器和说明 |
|---|
ProxyStreamPartitioner(org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<T> wrappedStreamPartitioner) |
| 限定符和类型 | 方法和说明 |
|---|---|
org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<IterationRecord<T>> |
copy() |
org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper |
getDownstreamSubtaskStateMapper() |
boolean |
isPointwise() |
int |
selectChannel(org.apache.flink.runtime.plugable.SerializationDelegate<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<T>>> record) |
void |
setup(int numberOfChannels) |
String |
toString() |
public ProxyStreamPartitioner(org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<T> wrappedStreamPartitioner)
public void setup(int numberOfChannels)
setup 在接口中 org.apache.flink.runtime.io.network.api.writer.ChannelSelector<org.apache.flink.runtime.plugable.SerializationDelegate<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<T>>>>setup 在类中 org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<IterationRecord<T>>public org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<IterationRecord<T>> copy()
copy 在类中 org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<IterationRecord<T>>public org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper getDownstreamSubtaskStateMapper()
getDownstreamSubtaskStateMapper 在类中 org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<IterationRecord<T>>public boolean isPointwise()
isPointwise 在类中 org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<IterationRecord<T>>public int selectChannel(org.apache.flink.runtime.plugable.SerializationDelegate<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<T>>> record)
Copyright © 2019–2022 The Apache Software Foundation. All rights reserved.