Class InputGateDeploymentDescriptor
- java.lang.Object
-
- org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- All Implemented Interfaces:
Serializable
public class InputGateDeploymentDescriptor extends Object implements Serializable
Deployment descriptor for a single input gate instance.Each input gate consumes partitions of a single intermediate result. The consumed subpartition index range is the same for each consumed partition.
- See Also:
SingleInputGate
, Serialized Form
-
-
Constructor Summary
Constructors Constructor Description InputGateDeploymentDescriptor(IntermediateDataSetID consumedResultId, ResultPartitionType consumedPartitionType, int consumedSubpartitionIndex, TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex[] inputChannels)
InputGateDeploymentDescriptor(IntermediateDataSetID consumedResultId, ResultPartitionType consumedPartitionType, IndexRange consumedSubpartitionIndexRange, int numberOfInputChannels, List<TaskDeploymentDescriptor.MaybeOffloaded<TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>> serializedInputChannels)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description ResultPartitionType
getConsumedPartitionType()
Returns the type of this input channel's consumed result partition.IntermediateDataSetID
getConsumedResultId()
int
getConsumedSubpartitionIndex()
IndexRange
getConsumedSubpartitionIndexRange()
Return the index range of the consumed subpartitions.ShuffleDescriptor[]
getShuffleDescriptors()
String
toString()
void
tryLoadAndDeserializeShuffleDescriptors(PermanentBlobService blobService, JobID jobId, GroupCache<JobID,PermanentBlobKey,TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup> shuffleDescriptorsCache)
-
-
-
Constructor Detail
-
InputGateDeploymentDescriptor
@VisibleForTesting public InputGateDeploymentDescriptor(IntermediateDataSetID consumedResultId, ResultPartitionType consumedPartitionType, @Nonnegative int consumedSubpartitionIndex, TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex[] inputChannels) throws IOException
- Throws:
IOException
-
InputGateDeploymentDescriptor
public InputGateDeploymentDescriptor(IntermediateDataSetID consumedResultId, ResultPartitionType consumedPartitionType, IndexRange consumedSubpartitionIndexRange, int numberOfInputChannels, List<TaskDeploymentDescriptor.MaybeOffloaded<TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>> serializedInputChannels)
-
-
Method Detail
-
getConsumedResultId
public IntermediateDataSetID getConsumedResultId()
-
getConsumedPartitionType
public ResultPartitionType getConsumedPartitionType()
Returns the type of this input channel's consumed result partition.- Returns:
- consumed result partition type
-
getConsumedSubpartitionIndex
@Nonnegative public int getConsumedSubpartitionIndex()
-
getConsumedSubpartitionIndexRange
public IndexRange getConsumedSubpartitionIndexRange()
Return the index range of the consumed subpartitions.
-
getShuffleDescriptors
public ShuffleDescriptor[] getShuffleDescriptors()
-
tryLoadAndDeserializeShuffleDescriptors
public void tryLoadAndDeserializeShuffleDescriptors(@Nullable PermanentBlobService blobService, JobID jobId, GroupCache<JobID,PermanentBlobKey,TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup> shuffleDescriptorsCache) throws IOException
- Throws:
IOException
-
-