Uses of Class
org.apache.flink.api.common.resources.CPUResource
-
Packages that use CPUResource Package Description org.apache.flink.api.common.operators org.apache.flink.api.common.resources org.apache.flink.runtime.clusterframework This package contains the cluster resource management functionality.org.apache.flink.runtime.clusterframework.types org.apache.flink.runtime.resourcemanager org.apache.flink.runtime.resourcemanager.slotmanager org.apache.flink.runtime.taskexecutor -
-
Uses of CPUResource in org.apache.flink.api.common.operators
Methods in org.apache.flink.api.common.operators that return CPUResource Modifier and Type Method Description CPUResource
ResourceSpec. getCpuCores()
-
Uses of CPUResource in org.apache.flink.api.common.resources
Methods in org.apache.flink.api.common.resources that return CPUResource Modifier and Type Method Description CPUResource
CPUResource. create(BigDecimal value)
-
Uses of CPUResource in org.apache.flink.runtime.clusterframework
Methods in org.apache.flink.runtime.clusterframework that return CPUResource Modifier and Type Method Description CPUResource
TaskExecutorProcessSpec. getCpuCores()
static CPUResource
TaskExecutorProcessUtils. getCpuCoresWithFallback(Configuration config, double fallback)
Methods in org.apache.flink.runtime.clusterframework with parameters of type CPUResource Modifier and Type Method Description TaskExecutorProcessSpecBuilder
TaskExecutorProcessSpecBuilder. withCpuCores(CPUResource cpuCores)
Constructors in org.apache.flink.runtime.clusterframework with parameters of type CPUResource Constructor Description TaskExecutorProcessSpec(CPUResource cpuCores, MemorySize frameworkHeapSize, MemorySize frameworkOffHeapSize, MemorySize taskHeapSize, MemorySize taskOffHeapSize, MemorySize networkMemSize, MemorySize managedMemorySize, MemorySize jvmMetaspaceSize, MemorySize jvmOverheadSize, Collection<ExternalResource> extendedResources)
TaskExecutorProcessSpec(CPUResource cpuCores, TaskExecutorFlinkMemory flinkMemory, JvmMetaspaceAndOverhead jvmMetaspaceAndOverhead, int numSlots, Collection<ExternalResource> extendedResources)
-
Uses of CPUResource in org.apache.flink.runtime.clusterframework.types
Methods in org.apache.flink.runtime.clusterframework.types that return CPUResource Modifier and Type Method Description CPUResource
ResourceProfile. getCpuCores()
Get the cpu cores needed.Methods in org.apache.flink.runtime.clusterframework.types with parameters of type CPUResource Modifier and Type Method Description ResourceProfile.Builder
ResourceProfile.Builder. setCpuCores(CPUResource cpuCores)
-
Uses of CPUResource in org.apache.flink.runtime.resourcemanager
Methods in org.apache.flink.runtime.resourcemanager that return CPUResource Modifier and Type Method Description CPUResource
WorkerResourceSpec. getCpuCores()
Methods in org.apache.flink.runtime.resourcemanager with parameters of type CPUResource Modifier and Type Method Description protected WorkerResourceSpec
WorkerResourceSpecFactory. workerResourceSpecFromConfigAndCpu(Configuration configuration, CPUResource cpuResource)
-
Uses of CPUResource in org.apache.flink.runtime.resourcemanager.slotmanager
Methods in org.apache.flink.runtime.resourcemanager.slotmanager that return CPUResource Modifier and Type Method Description CPUResource
SlotManagerConfiguration. getMaxTotalCpu()
CPUResource
SlotManagerConfiguration. getMinTotalCpu()
Constructors in org.apache.flink.runtime.resourcemanager.slotmanager with parameters of type CPUResource Constructor Description DefaultResourceAllocationStrategy(ResourceProfile totalResourceProfile, int numSlotsPerWorker, TaskManagerOptions.TaskManagerLoadBalanceMode taskManagerLoadBalanceMode, Duration taskManagerTimeout, int redundantTaskManagerNum, CPUResource minTotalCPU, MemorySize minTotalMemory)
SlotManagerConfiguration(Duration taskManagerRequestTimeout, Duration taskManagerTimeout, Duration requirementCheckDelay, Duration declareNeededResourceDelay, TaskManagerOptions.TaskManagerLoadBalanceMode taskManagerLoadBalanceMode, WorkerResourceSpec defaultWorkerResourceSpec, int numSlotsPerWorker, int minSlotNum, int maxSlotNum, CPUResource minTotalCpu, CPUResource maxTotalCpu, MemorySize minTotalMem, MemorySize maxTotalMem, int redundantTaskManagerNum)
-
Uses of CPUResource in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return CPUResource Modifier and Type Method Description CPUResource
TaskExecutorResourceSpec. getCpuCores()
Constructors in org.apache.flink.runtime.taskexecutor with parameters of type CPUResource Constructor Description TaskExecutorResourceSpec(CPUResource cpuCores, MemorySize taskHeapSize, MemorySize taskOffHeapSize, MemorySize networkMemSize, MemorySize managedMemorySize, Collection<ExternalResource> extendedResources)
-