Uses of Class
org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
-
Uses of InputGateDeploymentDescriptor in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment that return types with arguments of type InputGateDeploymentDescriptor Modifier and Type Method Description List<InputGateDeploymentDescriptor>
TaskDeploymentDescriptor. getInputGates()
-
Uses of InputGateDeploymentDescriptor in org.apache.flink.runtime.io.network
Method parameters in org.apache.flink.runtime.io.network with type arguments of type InputGateDeploymentDescriptor Modifier and Type Method Description List<SingleInputGate>
NettyShuffleEnvironment. createInputGates(ShuffleIOOwnerContext ownerContext, PartitionProducerStateProvider partitionProducerStateProvider, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors)
-
Uses of InputGateDeploymentDescriptor in org.apache.flink.runtime.io.network.partition.consumer
Methods in org.apache.flink.runtime.io.network.partition.consumer with parameters of type InputGateDeploymentDescriptor Modifier and Type Method Description SingleInputGate
SingleInputGateFactory. create(ShuffleIOOwnerContext owner, int gateIndex, InputGateDeploymentDescriptor igdd, PartitionProducerStateProvider partitionProducerStateProvider, InputChannelMetrics metrics)
Creates an input gate and all of its input channels. -
Uses of InputGateDeploymentDescriptor in org.apache.flink.runtime.shuffle
Method parameters in org.apache.flink.runtime.shuffle with type arguments of type InputGateDeploymentDescriptor Modifier and Type Method Description List<G>
ShuffleEnvironment. createInputGates(ShuffleIOOwnerContext ownerContext, PartitionProducerStateProvider partitionProducerStateProvider, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors)
Factory method for theInputGates
to consume result partitions.
-