public final class TaskDeploymentDescriptor extends Object implements Serializable
Modifier and Type | Class and Description |
---|---|
static class |
TaskDeploymentDescriptor.MaybeOffloaded<T>
Wrapper class for serialized values which may be offloaded to the
BlobServer or not. |
static class |
TaskDeploymentDescriptor.NonOffloaded<T>
A serialized value that is not offloaded to the
BlobServer . |
static class |
TaskDeploymentDescriptor.Offloaded<T>
Reference to a serialized value that was offloaded to the
BlobServer . |
Constructor and Description |
---|
TaskDeploymentDescriptor(JobID jobId,
TaskDeploymentDescriptor.MaybeOffloaded<JobInformation> serializedJobInformation,
TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation> serializedTaskInformation,
ExecutionAttemptID executionAttemptId,
AllocationID allocationId,
JobManagerTaskRestore taskRestore,
List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors,
List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors) |
public TaskDeploymentDescriptor(JobID jobId, TaskDeploymentDescriptor.MaybeOffloaded<JobInformation> serializedJobInformation, TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation> serializedTaskInformation, ExecutionAttemptID executionAttemptId, AllocationID allocationId, @Nullable JobManagerTaskRestore taskRestore, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors)
public JobInformation getJobInformation() throws IOException, ClassNotFoundException
IllegalStateException
if loadBigData(org.apache.flink.runtime.blob.PermanentBlobService, org.apache.flink.runtime.util.GroupCache<org.apache.flink.api.common.JobID, org.apache.flink.runtime.blob.PermanentBlobKey, org.apache.flink.runtime.executiongraph.JobInformation>, org.apache.flink.runtime.util.GroupCache<org.apache.flink.api.common.JobID, org.apache.flink.runtime.blob.PermanentBlobKey, org.apache.flink.runtime.executiongraph.TaskInformation>, org.apache.flink.runtime.util.GroupCache<org.apache.flink.api.common.JobID, org.apache.flink.runtime.blob.PermanentBlobKey, org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>)
is
not called beforehand).IllegalStateException
- If job information is offloaded to BLOB store.IOException
ClassNotFoundException
public TaskInformation getTaskInformation() throws IOException, ClassNotFoundException
IllegalStateException
if loadBigData(org.apache.flink.runtime.blob.PermanentBlobService, org.apache.flink.runtime.util.GroupCache<org.apache.flink.api.common.JobID, org.apache.flink.runtime.blob.PermanentBlobKey, org.apache.flink.runtime.executiongraph.JobInformation>, org.apache.flink.runtime.util.GroupCache<org.apache.flink.api.common.JobID, org.apache.flink.runtime.blob.PermanentBlobKey, org.apache.flink.runtime.executiongraph.TaskInformation>, org.apache.flink.runtime.util.GroupCache<org.apache.flink.api.common.JobID, org.apache.flink.runtime.blob.PermanentBlobKey, org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>)
is
not called beforehand)).IllegalStateException
- If job information is offloaded to BLOB store.IOException
ClassNotFoundException
public JobID getJobId()
public ExecutionAttemptID getExecutionAttemptId()
public int getSubtaskIndex()
public int getAttemptNumber()
public List<ResultPartitionDeploymentDescriptor> getProducedPartitions()
public List<InputGateDeploymentDescriptor> getInputGates()
@Nullable public JobManagerTaskRestore getTaskRestore()
public AllocationID getAllocationId()
public void loadBigData(@Nullable PermanentBlobService blobService, GroupCache<JobID,PermanentBlobKey,JobInformation> jobInformationCache, GroupCache<JobID,PermanentBlobKey,TaskInformation> taskInformationCache, GroupCache<JobID,PermanentBlobKey,TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup> shuffleDescriptorsCache) throws IOException, ClassNotFoundException
blobService
- the blob store to use (may be null if serializedJobInformation
and serializedTaskInformation
are non-null)shuffleDescriptorsCache
- cache of shuffle descriptors to reduce the cost of
deserializationIOException
- during errors retrieving or reading the BLOBsClassNotFoundException
- Class of a serialized object cannot be found.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.