Uses of Class
org.apache.flink.runtime.taskmanager.Task
-
Packages that use Task Package Description org.apache.flink.runtime.taskexecutor org.apache.flink.runtime.taskmanager -
-
Uses of Task in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return types with arguments of type Task Modifier and Type Method Description TaskSlotTable<Task>
TaskManagerServices. getTaskSlotTable()
-
Uses of Task in org.apache.flink.runtime.taskmanager
Constructors in org.apache.flink.runtime.taskmanager with parameters of type Task Constructor Description RuntimeEnvironment(org.apache.flink.api.common.JobID jobId, JobType jobType, JobVertexID jobVertexId, ExecutionAttemptID executionId, org.apache.flink.api.common.ExecutionConfig executionConfig, org.apache.flink.api.common.JobInfo jobInfo, org.apache.flink.api.common.TaskInfo taskInfo, org.apache.flink.configuration.Configuration jobConfiguration, org.apache.flink.configuration.Configuration taskConfiguration, org.apache.flink.util.UserCodeClassLoader userCodeClassLoader, MemoryManager memManager, SharedResources sharedResources, IOManager ioManager, BroadcastVariableManager bcVarManager, TaskStateManager taskStateManager, GlobalAggregateManager aggregateManager, AccumulatorRegistry accumulatorRegistry, TaskKvStateRegistry kvStateRegistry, InputSplitProvider splitProvider, Map<String,Future<org.apache.flink.core.fs.Path>> distCacheEntries, ResultPartitionWriter[] writers, IndexedInputGate[] inputGates, TaskEventDispatcher taskEventDispatcher, CheckpointResponder checkpointResponder, TaskOperatorEventGateway operatorEventGateway, TaskManagerRuntimeInfo taskManagerInfo, TaskMetricGroup metrics, Task containingTask, ExternalResourceInfoProvider externalResourceInfoProvider, ChannelStateWriteRequestExecutorFactory channelStateExecutorFactory, TaskManagerActions taskManagerActions)
-