Uses of Class
org.apache.flink.runtime.executiongraph.TaskInformation
-
-
Uses of TaskInformation in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment that return TaskInformation Modifier and Type Method Description TaskInformation
TaskDeploymentDescriptor. getTaskInformation()
Return the sub task's task information. -
Uses of TaskInformation in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return TaskInformation Modifier and Type Method Description TaskInformation
TaskInformation. deepCopy()
TaskInformation
ExecutionJobVertex. getTaskInformation()
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type TaskInformation Modifier and Type Method Description org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<TaskInformation>,PermanentBlobKey>
ExecutionJobVertex. getTaskInformationOrBlobKey()
-
Uses of TaskInformation in org.apache.flink.runtime.operators.coordination
Methods in org.apache.flink.runtime.operators.coordination with parameters of type TaskInformation Modifier and Type Method Description static OperatorCoordinatorHolder
OperatorCoordinatorHolder. create(org.apache.flink.util.SerializedValue<OperatorCoordinator.Provider> serializedProvider, ExecutionJobVertex jobVertex, ClassLoader classLoader, CoordinatorStore coordinatorStore, boolean supportsConcurrentExecutionAttempts, TaskInformation taskInformation, JobManagerJobMetricGroup metricGroup)
-
Uses of TaskInformation in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return types with arguments of type TaskInformation Modifier and Type Method Description GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskInformation>
TaskManagerServices. getTaskInformationCache()
-
Uses of TaskInformation in org.apache.flink.runtime.taskmanager
Constructors in org.apache.flink.runtime.taskmanager with parameters of type TaskInformation 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.
-