Uses of Class
org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
-
Uses of TaskDeploymentDescriptor in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment that return TaskDeploymentDescriptor Modifier and Type Method Description TaskDeploymentDescriptorTaskDeploymentDescriptorFactory. createDeploymentDescriptor(Execution execution, AllocationID allocationID, JobManagerTaskRestore taskRestore, Collection<ResultPartitionDeploymentDescriptor> producedPartitions) -
Uses of TaskDeploymentDescriptor in org.apache.flink.runtime.jobmanager.slots
Methods in org.apache.flink.runtime.jobmanager.slots with parameters of type TaskDeploymentDescriptor Modifier and Type Method Description CompletableFuture<Acknowledge>TaskManagerGateway. submitTask(TaskDeploymentDescriptor tdd, Duration timeout)Submit a task to the task manager. -
Uses of TaskDeploymentDescriptor in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster with parameters of type TaskDeploymentDescriptor Modifier and Type Method Description CompletableFuture<Acknowledge>RpcTaskManagerGateway. submitTask(TaskDeploymentDescriptor tdd, Duration timeout) -
Uses of TaskDeploymentDescriptor in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor with parameters of type TaskDeploymentDescriptor Modifier and Type Method Description CompletableFuture<Acknowledge>TaskExecutor. submitTask(TaskDeploymentDescriptor tdd, JobMasterId jobMasterId, Duration timeout)CompletableFuture<Acknowledge>TaskExecutorGateway. submitTask(TaskDeploymentDescriptor tdd, JobMasterId jobMasterId, Duration timeout)Submit aTaskto theTaskExecutor.CompletableFuture<Acknowledge>TaskExecutorGatewayDecoratorBase. submitTask(TaskDeploymentDescriptor tdd, JobMasterId jobMasterId, Duration timeout)
-