Class TaskDeploymentDescriptorFactory
- java.lang.Object
-
- org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory
-
public class TaskDeploymentDescriptorFactory extends Object
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static class
TaskDeploymentDescriptorFactory.PartitionLocationConstraint
Defines whether the partition's location must be known at deployment time or can be unknown and, therefore, updated later.static class
TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex
This class represents the shuffle descriptor with it index inConsumedPartitionGroup
.static class
TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup
A set of shuffle descriptors that will be serialized together.
-
Field Summary
Fields Modifier and Type Field Description static ConfigOption<Integer>
OFFLOAD_SHUFFLE_DESCRIPTORS_THRESHOLD
This is an expert option, that we do not want to expose in the documentation.
-
Constructor Summary
Constructors Constructor Description TaskDeploymentDescriptorFactory(Either<SerializedValue<JobInformation>,PermanentBlobKey> jobInformationOrBlobKey, JobID jobID, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionDeploymentConstraint, BlobWriter blobWriter, boolean nonFinishedHybridPartitionShouldBeUnknown, int offloadShuffleDescriptorsThreshold)
-
Method Summary
All Methods Static Methods Instance Methods Concrete Methods Modifier and Type Method Description TaskDeploymentDescriptor
createDeploymentDescriptor(Execution execution, AllocationID allocationID, JobManagerTaskRestore taskRestore, Collection<ResultPartitionDeploymentDescriptor> producedPartitions)
static ShuffleDescriptor
getConsumedPartitionShuffleDescriptor(IntermediateResultPartition consumedPartition, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionDeploymentConstraint, boolean nonFinishedHybridPartitionShouldBeUnknown)
TaskDeploymentDescriptor.MaybeOffloaded<JobInformation>
getSerializedJobInformation()
-
-
-
Field Detail
-
OFFLOAD_SHUFFLE_DESCRIPTORS_THRESHOLD
@Experimental public static final ConfigOption<Integer> OFFLOAD_SHUFFLE_DESCRIPTORS_THRESHOLD
This is an expert option, that we do not want to expose in the documentation. The default value is good enough for almost all cases
-
-
Constructor Detail
-
TaskDeploymentDescriptorFactory
public TaskDeploymentDescriptorFactory(Either<SerializedValue<JobInformation>,PermanentBlobKey> jobInformationOrBlobKey, JobID jobID, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionDeploymentConstraint, BlobWriter blobWriter, boolean nonFinishedHybridPartitionShouldBeUnknown, int offloadShuffleDescriptorsThreshold)
-
-
Method Detail
-
getSerializedJobInformation
public TaskDeploymentDescriptor.MaybeOffloaded<JobInformation> getSerializedJobInformation()
-
createDeploymentDescriptor
public TaskDeploymentDescriptor createDeploymentDescriptor(Execution execution, AllocationID allocationID, @Nullable JobManagerTaskRestore taskRestore, Collection<ResultPartitionDeploymentDescriptor> producedPartitions) throws IOException, ClusterDatasetCorruptedException
-
getConsumedPartitionShuffleDescriptor
public static ShuffleDescriptor getConsumedPartitionShuffleDescriptor(IntermediateResultPartition consumedPartition, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionDeploymentConstraint, boolean nonFinishedHybridPartitionShouldBeUnknown)
-
-