Package | Description |
---|---|
org.apache.flink.runtime.io.network | |
org.apache.flink.runtime.io.network.netty |
Modifier and Type | Method and Description |
---|---|
void |
NetworkClientHandler.addInputChannel(RemoteInputChannel inputChannel) |
void |
NetworkClientHandler.notifyCreditAvailable(RemoteInputChannel inputChannel)
The credit begins to announce after receiving the sender's backlog from buffer response.
|
void |
NetworkClientHandler.removeInputChannel(RemoteInputChannel inputChannel) |
Modifier and Type | Method and Description |
---|---|
void |
PartitionRequestClient.close(RemoteInputChannel inputChannel) |
void |
PartitionRequestClient.notifyCreditAvailable(RemoteInputChannel inputChannel) |
org.apache.flink.shaded.netty4.io.netty.channel.ChannelFuture |
PartitionRequestClient.requestSubpartition(ResultPartitionID partitionId,
int subpartitionIndex,
RemoteInputChannel inputChannel,
int delayMs)
Requests a remote intermediate result partition queue.
|
void |
PartitionRequestClient.sendTaskEvent(ResultPartitionID partitionId,
TaskEvent event,
RemoteInputChannel inputChannel)
Sends a task event backwards to an intermediate result partition producer.
|
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.