Uses of Class
org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
-
Packages that use WorkerResourceSpec Package Description org.apache.flink.runtime.clusterframework This package contains the cluster resource management functionality.org.apache.flink.runtime.resourcemanager org.apache.flink.runtime.resourcemanager.active org.apache.flink.runtime.resourcemanager.slotmanager -
-
Uses of WorkerResourceSpec in org.apache.flink.runtime.clusterframework
Methods in org.apache.flink.runtime.clusterframework with parameters of type WorkerResourceSpec Modifier and Type Method Description static TaskExecutorProcessSpecTaskExecutorProcessUtils. processSpecFromWorkerResourceSpec(org.apache.flink.configuration.Configuration config, WorkerResourceSpec workerResourceSpec) -
Uses of WorkerResourceSpec in org.apache.flink.runtime.resourcemanager
Fields in org.apache.flink.runtime.resourcemanager declared as WorkerResourceSpec Modifier and Type Field Description static WorkerResourceSpecWorkerResourceSpec. ZEROMethods in org.apache.flink.runtime.resourcemanager that return WorkerResourceSpec Modifier and Type Method Description WorkerResourceSpecWorkerResourceSpec.Builder. build()WorkerResourceSpecArbitraryWorkerResourceSpecFactory. createDefaultWorkerResourceSpec(org.apache.flink.configuration.Configuration configuration)abstract WorkerResourceSpecWorkerResourceSpecFactory. createDefaultWorkerResourceSpec(org.apache.flink.configuration.Configuration configuration)static WorkerResourceSpecWorkerResourceSpec. fromTaskExecutorProcessSpec(TaskExecutorProcessSpec taskExecutorProcessSpec)static WorkerResourceSpecWorkerResourceSpec. fromTotalResourceProfile(ResourceProfile resourceProfile, int numSlots)protected WorkerResourceSpecWorkerResourceSpecFactory. workerResourceSpecFromConfigAndCpu(org.apache.flink.configuration.Configuration configuration, org.apache.flink.api.common.resources.CPUResource cpuResource)Methods in org.apache.flink.runtime.resourcemanager with parameters of type WorkerResourceSpec Modifier and Type Method Description protected voidResourceManager. onWorkerRegistered(WorkerType worker, WorkerResourceSpec workerResourceSpec) -
Uses of WorkerResourceSpec in org.apache.flink.runtime.resourcemanager.active
Methods in org.apache.flink.runtime.resourcemanager.active with parameters of type WorkerResourceSpec Modifier and Type Method Description protected voidActiveResourceManager. onWorkerRegistered(WorkerType worker, WorkerResourceSpec workerResourceSpec)voidActiveResourceManager. requestNewWorker(WorkerResourceSpec workerResourceSpec)Allocates a resource using the worker resource specification. -
Uses of WorkerResourceSpec in org.apache.flink.runtime.resourcemanager.slotmanager
Methods in org.apache.flink.runtime.resourcemanager.slotmanager that return WorkerResourceSpec Modifier and Type Method Description WorkerResourceSpecSlotManagerConfiguration. getDefaultWorkerResourceSpec()WorkerResourceSpecResourceDeclaration. getSpec()Methods in org.apache.flink.runtime.resourcemanager.slotmanager that return types with arguments of type WorkerResourceSpec Modifier and Type Method Description Map<InstanceID,WorkerResourceSpec>FineGrainedTaskManagerTracker. getUnWantedTaskManager()Methods in org.apache.flink.runtime.resourcemanager.slotmanager with parameters of type WorkerResourceSpec Modifier and Type Method Description static SlotManagerConfigurationSlotManagerConfiguration. fromConfiguration(org.apache.flink.configuration.Configuration configuration, WorkerResourceSpec defaultWorkerResourceSpec)static ResourceProfileSlotManagerUtils. generateDefaultSlotResourceProfile(WorkerResourceSpec workerResourceSpec, int numSlotsPerWorker)static ResourceProfileSlotManagerUtils. generateTaskManagerTotalResourceProfile(WorkerResourceSpec workerResourceSpec)Constructors in org.apache.flink.runtime.resourcemanager.slotmanager with parameters of type WorkerResourceSpec Constructor Description ResourceDeclaration(WorkerResourceSpec spec, int numNeeded, Collection<InstanceID> unwantedWorkers)SlotManagerConfiguration(Duration taskManagerRequestTimeout, Duration taskManagerTimeout, Duration requirementCheckDelay, Duration declareNeededResourceDelay, org.apache.flink.configuration.TaskManagerOptions.TaskManagerLoadBalanceMode taskManagerLoadBalanceMode, WorkerResourceSpec defaultWorkerResourceSpec, int numSlotsPerWorker, int minSlotNum, int maxSlotNum, org.apache.flink.api.common.resources.CPUResource minTotalCpu, org.apache.flink.api.common.resources.CPUResource maxTotalCpu, org.apache.flink.configuration.MemorySize minTotalMem, org.apache.flink.configuration.MemorySize maxTotalMem, int redundantTaskManagerNum)
-