Class TaskManagerServices
- java.lang.Object
-
- org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
public class TaskManagerServices extends Object
Container forTaskExecutor
services such as theMemoryManager
,IOManager
,ShuffleEnvironment
. All services are exclusive to a singleTaskExecutor
. Consequently, the respectiveTaskExecutor
is responsible for closing them.
-
-
Method Summary
-
-
-
Method Detail
-
getManagedMemorySize
public long getManagedMemorySize()
-
getIOManager
public IOManager getIOManager()
-
getShuffleEnvironment
public ShuffleEnvironment<?,?> getShuffleEnvironment()
-
getKvStateService
public KvStateService getKvStateService()
-
getUnresolvedTaskManagerLocation
public UnresolvedTaskManagerLocation getUnresolvedTaskManagerLocation()
-
getBroadcastVariableManager
public BroadcastVariableManager getBroadcastVariableManager()
-
getTaskSlotTable
public TaskSlotTable<Task> getTaskSlotTable()
-
getJobTable
public JobTable getJobTable()
-
getJobLeaderService
public JobLeaderService getJobLeaderService()
-
getTaskManagerStateStore
public TaskExecutorLocalStateStoresManager getTaskManagerStateStore()
-
getTaskManagerFileMergingManager
public TaskExecutorFileMergingManager getTaskManagerFileMergingManager()
-
getTaskManagerChangelogManager
public TaskExecutorStateChangelogStoragesManager getTaskManagerChangelogManager()
-
getTaskManagerChannelStateManager
public TaskExecutorChannelStateExecutorFactoryManager getTaskManagerChannelStateManager()
-
getTaskEventDispatcher
public TaskEventDispatcher getTaskEventDispatcher()
-
getIOExecutor
public Executor getIOExecutor()
-
getLibraryCacheManager
public LibraryCacheManager getLibraryCacheManager()
-
getSharedResources
public SharedResources getSharedResources()
-
getJobInformationCache
public GroupCache<JobID,PermanentBlobKey,JobInformation> getJobInformationCache()
-
getTaskInformationCache
public GroupCache<JobID,PermanentBlobKey,TaskInformation> getTaskInformationCache()
-
getShuffleDescriptorCache
public GroupCache<JobID,PermanentBlobKey,TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup> getShuffleDescriptorCache()
-
shutDown
public void shutDown() throws FlinkException
Shuts theTaskExecutor
services down.- Throws:
FlinkException
-
fromConfiguration
public static TaskManagerServices fromConfiguration(TaskManagerServicesConfiguration taskManagerServicesConfiguration, PermanentBlobService permanentBlobService, MetricGroup taskManagerMetricGroup, ExecutorService ioExecutor, ScheduledExecutor scheduledExecutor, FatalErrorHandler fatalErrorHandler, WorkingDirectory workingDirectory) throws Exception
Creates and returns the task manager services.- Parameters:
taskManagerServicesConfiguration
- task manager configurationpermanentBlobService
- permanentBlobService used by the servicestaskManagerMetricGroup
- metric group of the task managerioExecutor
- executor for async IO operationsscheduledExecutor
- scheduled executor in rpc servicefatalErrorHandler
- to handle class loading OOMsworkingDirectory
- the working directory of the process- Returns:
- task manager components
- Throws:
Exception
-
getSlotAllocationSnapshotPersistenceService
public SlotAllocationSnapshotPersistenceService getSlotAllocationSnapshotPersistenceService()
-
-