Class TaskManagerServicesConfiguration


  • public class TaskManagerServicesConfiguration
    extends Object
    Configuration for the task manager services such as the memory manager, the io manager and the metric registry.
    • Method Detail

      • getConfiguration

        public org.apache.flink.configuration.Configuration getConfiguration()
      • getResourceID

        public ResourceID getResourceID()
      • getTmpDirPaths

        public String[] getTmpDirPaths()
      • getNumberOfSlots

        public int getNumberOfSlots()
      • getPageSize

        public int getPageSize()
      • getNetworkMemorySize

        public org.apache.flink.configuration.MemorySize getNetworkMemorySize()
      • getManagedMemorySize

        public org.apache.flink.configuration.MemorySize getManagedMemorySize()
      • getSystemResourceMetricsProbingInterval

        public Optional<Duration> getSystemResourceMetricsProbingInterval()
      • getClassLoaderResolveOrder

        public org.apache.flink.util.FlinkUserCodeClassLoaders.ResolveOrder getClassLoaderResolveOrder()
      • getAlwaysParentFirstLoaderPatterns

        public String[] getAlwaysParentFirstLoaderPatterns()
      • getNumIoThreads

        public int getNumIoThreads()
      • getNodeId

        public String getNodeId()
      • fromConfiguration

        public static TaskManagerServicesConfiguration fromConfiguration​(org.apache.flink.configuration.Configuration configuration,
                                                                         ResourceID resourceID,
                                                                         String externalAddress,
                                                                         boolean localCommunicationOnly,
                                                                         TaskExecutorResourceSpec taskExecutorResourceSpec,
                                                                         WorkingDirectory workingDirectory)
                                                                  throws Exception
        Utility method to extract TaskManager config parameters from the configuration and to sanity check them.
        Parameters:
        configuration - The configuration.
        resourceID - resource ID of the task manager
        externalAddress - identifying the IP address under which the TaskManager will be accessible
        localCommunicationOnly - True if only local communication is possible. Use only in cases where only one task manager runs.
        taskExecutorResourceSpec - resource specification of the TaskManager to start
        workingDirectory - working directory of the TaskManager
        Returns:
        configuration of task manager services used to create them
        Throws:
        Exception