Class ResultPartitionDeploymentDescriptor
- java.lang.Object
-
- org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- All Implemented Interfaces:
Serializable
public class ResultPartitionDeploymentDescriptor extends Object implements Serializable
Deployment descriptor for a result partition.- See Also:
ResultPartition, Serialized Form
-
-
Constructor Summary
Constructors Constructor Description ResultPartitionDeploymentDescriptor(PartitionDescriptor partitionDescriptor, ShuffleDescriptor shuffleDescriptor, int maxParallelism)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description intgetMaxParallelism()intgetNumberOfSubpartitions()IntermediateResultPartitionIDgetPartitionId()ResultPartitionTypegetPartitionType()IntermediateDataSetIDgetResultId()ShuffleDescriptorgetShuffleDescriptor()intgetTotalNumberOfPartitions()booleanisBroadcast()Whether the resultPartition is a broadcast edge.booleanisNumberOfPartitionConsumerUndefined()StringtoString()
-
-
-
Constructor Detail
-
ResultPartitionDeploymentDescriptor
public ResultPartitionDeploymentDescriptor(PartitionDescriptor partitionDescriptor, ShuffleDescriptor shuffleDescriptor, int maxParallelism)
-
-
Method Detail
-
getResultId
public IntermediateDataSetID getResultId()
-
getPartitionId
public IntermediateResultPartitionID getPartitionId()
-
isBroadcast
public boolean isBroadcast()
Whether the resultPartition is a broadcast edge.
-
getPartitionType
public ResultPartitionType getPartitionType()
-
getTotalNumberOfPartitions
public int getTotalNumberOfPartitions()
-
getNumberOfSubpartitions
public int getNumberOfSubpartitions()
-
isNumberOfPartitionConsumerUndefined
public boolean isNumberOfPartitionConsumerUndefined()
-
getMaxParallelism
public int getMaxParallelism()
-
getShuffleDescriptor
public ShuffleDescriptor getShuffleDescriptor()
-
-