Package | Description |
---|---|
org.apache.flink.kubernetes.entrypoint | |
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 | |
org.apache.flink.yarn.entrypoint |
Modifier and Type | Method and Description |
---|---|
WorkerResourceSpec |
KubernetesWorkerResourceSpecFactory.createDefaultWorkerResourceSpec(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
static TaskExecutorProcessSpec |
TaskExecutorProcessUtils.processSpecFromWorkerResourceSpec(Configuration config,
WorkerResourceSpec workerResourceSpec) |
Modifier and Type | Field and Description |
---|---|
static WorkerResourceSpec |
WorkerResourceSpec.ZERO |
Modifier and Type | Method and Description |
---|---|
WorkerResourceSpec |
WorkerResourceSpec.Builder.build() |
abstract WorkerResourceSpec |
WorkerResourceSpecFactory.createDefaultWorkerResourceSpec(Configuration configuration) |
WorkerResourceSpec |
ArbitraryWorkerResourceSpecFactory.createDefaultWorkerResourceSpec(Configuration configuration) |
static WorkerResourceSpec |
WorkerResourceSpec.fromTaskExecutorProcessSpec(TaskExecutorProcessSpec taskExecutorProcessSpec) |
static WorkerResourceSpec |
WorkerResourceSpec.fromTotalResourceProfile(ResourceProfile resourceProfile,
int numSlots) |
protected WorkerResourceSpec |
WorkerResourceSpecFactory.workerResourceSpecFromConfigAndCpu(Configuration configuration,
CPUResource cpuResource) |
Modifier and Type | Method and Description |
---|---|
protected Map<WorkerResourceSpec,Integer> |
ResourceManager.getRequiredResources() |
Modifier and Type | Method and Description |
---|---|
boolean |
StandaloneResourceManager.startNewWorker(WorkerResourceSpec workerResourceSpec) |
abstract boolean |
ResourceManager.startNewWorker(WorkerResourceSpec workerResourceSpec)
Allocates a resource using the worker resource specification.
|
Modifier and Type | Method and Description |
---|---|
boolean |
ActiveResourceManager.startNewWorker(WorkerResourceSpec workerResourceSpec) |
Modifier and Type | Method and Description |
---|---|
WorkerResourceSpec |
SlotManagerConfiguration.getDefaultWorkerResourceSpec() |
Modifier and Type | Method and Description |
---|---|
Map<WorkerResourceSpec,Integer> |
SlotManager.getRequiredResources()
Get number of workers SlotManager requested from
ResourceActions that are not yet
fulfilled. |
Map<WorkerResourceSpec,Integer> |
DeclarativeSlotManager.getRequiredResources() |
Map<WorkerResourceSpec,Integer> |
FineGrainedSlotManager.getRequiredResources() |
Modifier and Type | Method and Description |
---|---|
boolean |
ResourceActions.allocateResource(WorkerResourceSpec workerResourceSpec)
Requests to allocate a resource with the given
WorkerResourceSpec . |
static SlotManagerConfiguration |
SlotManagerConfiguration.fromConfiguration(Configuration configuration,
WorkerResourceSpec defaultWorkerResourceSpec) |
static ResourceProfile |
SlotManagerUtils.generateDefaultSlotResourceProfile(WorkerResourceSpec workerResourceSpec,
int numSlotsPerWorker)
|
static ResourceProfile |
SlotManagerUtils.generateTaskManagerTotalResourceProfile(WorkerResourceSpec workerResourceSpec) |
Constructor and Description |
---|
SlotManagerConfiguration(Time taskManagerRequestTimeout,
Time slotRequestTimeout,
Time taskManagerTimeout,
java.time.Duration requirementCheckDelay,
boolean waitResultConsumedBeforeRelease,
SlotMatchingStrategy slotMatchingStrategy,
WorkerResourceSpec defaultWorkerResourceSpec,
int numSlotsPerWorker,
int maxSlotNum,
CPUResource maxTotalCpu,
MemorySize maxTotalMem,
int redundantTaskManagerNum) |
Modifier and Type | Method and Description |
---|---|
WorkerResourceSpec |
YarnWorkerResourceSpecFactory.createDefaultWorkerResourceSpec(Configuration configuration) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.