Package | Description |
---|---|
org.apache.flink.runtime.io.network | |
org.apache.flink.runtime.io.network.partition.consumer | |
org.apache.flink.runtime.taskmanager |
Modifier and Type | Method and Description |
---|---|
void |
NetworkEnvironment.setupInputGate(SingleInputGate gate) |
Modifier and Type | Field and Description |
---|---|
protected SingleInputGate |
InputChannel.inputGate |
Modifier and Type | Method and Description |
---|---|
static SingleInputGate |
SingleInputGate.create(String owningTaskName,
JobID jobId,
ExecutionAttemptID executionId,
InputGateDeploymentDescriptor igdd,
NetworkEnvironment networkEnvironment,
TaskActions taskActions,
TaskIOMetricGroup metrics)
Creates an input gate and all of its input channels.
|
Modifier and Type | Method and Description |
---|---|
static void |
InputGateMetrics.registerQueueLengthMetrics(MetricGroup group,
SingleInputGate gate) |
Constructor and Description |
---|
InputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
int initialBackoff,
int maxBackoff,
Counter numBytesIn,
Counter numBuffersIn) |
LocalInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
ResultPartitionManager partitionManager,
TaskEventDispatcher taskEventDispatcher,
int initialBackoff,
int maxBackoff,
TaskIOMetricGroup metrics) |
LocalInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
ResultPartitionManager partitionManager,
TaskEventDispatcher taskEventDispatcher,
TaskIOMetricGroup metrics) |
RemoteInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
ConnectionID connectionId,
ConnectionManager connectionManager,
int initialBackOff,
int maxBackoff,
TaskIOMetricGroup metrics) |
RemoteInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
ConnectionID connectionId,
ConnectionManager connectionManager,
TaskIOMetricGroup metrics) |
Modifier and Type | Method and Description |
---|---|
SingleInputGate[] |
Task.getAllInputGates() |
SingleInputGate |
Task.getInputGateById(IntermediateDataSetID id) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.