Uses of Class
org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
-
Uses of ResultPartitionDeploymentDescriptor in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment that return types with arguments of type ResultPartitionDeploymentDescriptor Modifier and Type Method Description List<ResultPartitionDeploymentDescriptor>TaskDeploymentDescriptor. getProducedPartitions()Method parameters in org.apache.flink.runtime.deployment with type arguments of type ResultPartitionDeploymentDescriptor Modifier and Type Method Description TaskDeploymentDescriptorTaskDeploymentDescriptorFactory. createDeploymentDescriptor(Execution execution, AllocationID allocationID, JobManagerTaskRestore taskRestore, Collection<ResultPartitionDeploymentDescriptor> producedPartitions)Constructor parameters in org.apache.flink.runtime.deployment with type arguments of type ResultPartitionDeploymentDescriptor 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) -
Uses of ResultPartitionDeploymentDescriptor in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return ResultPartitionDeploymentDescriptor Modifier and Type Method Description static ResultPartitionDeploymentDescriptorExecution. createResultPartitionDeploymentDescriptor(IntermediateResultPartition partition, ShuffleDescriptor shuffleDescriptor)Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type ResultPartitionDeploymentDescriptor Modifier and Type Method Description Optional<ResultPartitionDeploymentDescriptor>Execution. getResultPartitionDeploymentDescriptor(IntermediateResultPartitionID id)Method parameters in org.apache.flink.runtime.executiongraph with type arguments of type ResultPartitionDeploymentDescriptor Modifier and Type Method Description voidExecution. recoverProducedPartitions(Map<IntermediateResultPartitionID,ResultPartitionDeploymentDescriptor> producedPartitions) -
Uses of ResultPartitionDeploymentDescriptor in org.apache.flink.runtime.io.network
Method parameters in org.apache.flink.runtime.io.network with type arguments of type ResultPartitionDeploymentDescriptor Modifier and Type Method Description List<ResultPartition>NettyShuffleEnvironment. createResultPartitionWriters(ShuffleIOOwnerContext ownerContext, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors) -
Uses of ResultPartitionDeploymentDescriptor in org.apache.flink.runtime.io.network.partition
Methods in org.apache.flink.runtime.io.network.partition that return types with arguments of type ResultPartitionDeploymentDescriptor Modifier and Type Method Description default Collection<ResultPartitionDeploymentDescriptor>JobMasterPartitionTracker. getAllTrackedClusterPartitions()Gets all the cluster partitions under tracking.default Collection<ResultPartitionDeploymentDescriptor>JobMasterPartitionTracker. getAllTrackedNonClusterPartitions()Gets all the non-cluster partitions under tracking.Collection<ResultPartitionDeploymentDescriptor>JobMasterPartitionTracker. getAllTrackedPartitions()Gets all the partitions under tracking.Collection<ResultPartitionDeploymentDescriptor>JobMasterPartitionTrackerImpl. getAllTrackedPartitions()Methods in org.apache.flink.runtime.io.network.partition with parameters of type ResultPartitionDeploymentDescriptor Modifier and Type Method Description ResultPartitionResultPartitionFactory. create(String taskNameWithSubtaskAndId, int partitionIndex, ResultPartitionDeploymentDescriptor desc)static TaskExecutorPartitionInfoTaskExecutorPartitionInfo. from(ResultPartitionDeploymentDescriptor resultPartitionDeploymentDescriptor)voidJobMasterPartitionTracker. startTrackingPartition(ResourceID producingTaskExecutorId, ResultPartitionDeploymentDescriptor resultPartitionDeploymentDescriptor)Starts the tracking of the given partition for the given task executor ID.voidJobMasterPartitionTrackerImpl. startTrackingPartition(ResourceID producingTaskExecutorId, ResultPartitionDeploymentDescriptor resultPartitionDeploymentDescriptor) -
Uses of ResultPartitionDeploymentDescriptor in org.apache.flink.runtime.shuffle
Method parameters in org.apache.flink.runtime.shuffle with type arguments of type ResultPartitionDeploymentDescriptor Modifier and Type Method Description List<P>ShuffleEnvironment. createResultPartitionWriters(ShuffleIOOwnerContext ownerContext, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors)Factory method for theResultPartitionWritersto produce result partitions. -
Uses of ResultPartitionDeploymentDescriptor in org.apache.flink.runtime.taskmanager
Constructor parameters in org.apache.flink.runtime.taskmanager with type arguments of type ResultPartitionDeploymentDescriptor Constructor Description Task(JobInformation jobInformation, TaskInformation taskInformation, ExecutionAttemptID executionAttemptID, AllocationID slotAllocationId, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors, MemoryManager memManager, SharedResources sharedResources, IOManager ioManager, ShuffleEnvironment<?,?> shuffleEnvironment, KvStateService kvStateService, BroadcastVariableManager bcVarManager, TaskEventDispatcher taskEventDispatcher, ExternalResourceInfoProvider externalResourceInfoProvider, TaskStateManager taskStateManager, TaskManagerActions taskManagerActions, InputSplitProvider inputSplitProvider, CheckpointResponder checkpointResponder, TaskOperatorEventGateway operatorCoordinatorEventGateway, GlobalAggregateManager aggregateManager, LibraryCacheManager.ClassLoaderHandle classLoaderHandle, FileCache fileCache, TaskManagerRuntimeInfo taskManagerConfig, TaskMetricGroup metricGroup, PartitionProducerStateChecker partitionProducerStateChecker, Executor executor, ChannelStateWriteRequestExecutorFactory channelStateExecutorFactory)IMPORTANT: This constructor may not start any work that would need to be undone in the case of a failing task deployment.
-