Uses of Class
org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.MaybeOffloaded
-
Packages that use TaskDeploymentDescriptor.MaybeOffloaded Package Description org.apache.flink.runtime.deployment -
-
Uses of TaskDeploymentDescriptor.MaybeOffloaded in org.apache.flink.runtime.deployment
Subclasses of TaskDeploymentDescriptor.MaybeOffloaded in org.apache.flink.runtime.deployment Modifier and Type Class Description static class
TaskDeploymentDescriptor.NonOffloaded<T>
A serialized value that is not offloaded to theBlobServer
.static class
TaskDeploymentDescriptor.Offloaded<T>
Reference to a serialized value that was offloaded to theBlobServer
.Methods in org.apache.flink.runtime.deployment that return TaskDeploymentDescriptor.MaybeOffloaded Modifier and Type Method Description TaskDeploymentDescriptor.MaybeOffloaded<JobInformation>
TaskDeploymentDescriptorFactory. getSerializedJobInformation()
Methods in org.apache.flink.runtime.deployment that return types with arguments of type TaskDeploymentDescriptor.MaybeOffloaded Modifier and Type Method Description List<TaskDeploymentDescriptor.MaybeOffloaded<TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>>
CachedShuffleDescriptors. getAllSerializedShuffleDescriptorGroups()
Constructors in org.apache.flink.runtime.deployment with parameters of type TaskDeploymentDescriptor.MaybeOffloaded Constructor Description TaskDeploymentDescriptor(org.apache.flink.api.common.JobID jobId, TaskDeploymentDescriptor.MaybeOffloaded<JobInformation> serializedJobInformation, TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation> serializedTaskInformation, ExecutionAttemptID executionAttemptId, AllocationID allocationId, JobManagerTaskRestore taskRestore, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors)
Constructor parameters in org.apache.flink.runtime.deployment with type arguments of type TaskDeploymentDescriptor.MaybeOffloaded Constructor Description InputGateDeploymentDescriptor(IntermediateDataSetID consumedResultId, ResultPartitionType consumedPartitionType, org.apache.flink.runtime.deployment.ConsumedSubpartitionContext consumedSubpartitionContext, int numberOfInputChannels, List<TaskDeploymentDescriptor.MaybeOffloaded<TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>> serializedInputChannels)
InputGateDeploymentDescriptor(IntermediateDataSetID consumedResultId, ResultPartitionType consumedPartitionType, IndexRange consumedSubpartitionIndexRange, int numberOfInputChannels, List<TaskDeploymentDescriptor.MaybeOffloaded<TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>> serializedInputChannels)
-