Package | Description |
---|---|
org.apache.flink.runtime.io.network | |
org.apache.flink.runtime.io.network.netty | |
org.apache.flink.runtime.io.network.partition |
Modifier and Type | Method and Description |
---|---|
void |
NetworkSequenceViewReader.requestSubpartitionViewOrRegisterListener(ResultPartitionProvider partitionProvider,
ResultPartitionID resultPartitionId,
ResultSubpartitionIndexSet subpartitionIndexSet)
When the netty server receives the downstream task's partition request and the upstream task
has registered its partition, it will process the partition request immediately, otherwise it
will create a
PartitionRequestListener for given ResultPartitionID in ResultPartitionManager and notify the listener when the upstream task registers its
partition. |
Constructor and Description |
---|
NettyConnectionManager(NettyBufferPool bufferPool,
ResultPartitionProvider partitionProvider,
TaskEventPublisher taskEventPublisher,
NettyConfig nettyConfig,
int maxNumberOfConnections,
boolean connectionReuseEnabled) |
NettyConnectionManager(ResultPartitionProvider partitionProvider,
TaskEventPublisher taskEventPublisher,
NettyConfig nettyConfig,
int maxNumberOfConnections,
boolean connectionReuseEnabled) |
NettyPartitionRequestListener(ResultPartitionProvider resultPartitionProvider,
NetworkSequenceViewReader reader,
ResultSubpartitionIndexSet subpartitionIndexSet,
ResultPartitionID resultPartitionId) |
NettyPartitionRequestListener(ResultPartitionProvider resultPartitionProvider,
NetworkSequenceViewReader reader,
ResultSubpartitionIndexSet subpartitionIndexSet,
ResultPartitionID resultPartitionId,
long createTimestamp) |
Modifier and Type | Class and Description |
---|---|
class |
ResultPartitionManager
The result partition manager keeps track of all currently produced/consumed partitions of a task
manager.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.