Package | Description |
---|---|
org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.common | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement |
Package org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement
contains classes related to application monitor.
|
Modifier and Type | Method and Description |
---|---|
void |
RMAppAttemptMetrics.incNumAllocatedContainers(NodeType containerType,
NodeType requestType) |
Modifier and Type | Method and Description |
---|---|
static NodeType |
NodeType.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static NodeType[] |
NodeType.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
ContainerRequest |
AppSchedulingInfo.allocate(NodeType type,
SchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
RMContainer containerAllocated) |
boolean |
AppSchedulingInfo.checkAllocation(NodeType type,
SchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey) |
void |
SchedulerApplicationAttempt.incNumAllocatedContainers(NodeType containerType,
NodeType requestType) |
void |
QueueMetrics.incrNodeTypeAggregations(String user,
NodeType type) |
static void |
AppSchedulingInfo.updateMetrics(org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
NodeType type,
SchedulerNode node,
RMContainer containerAllocated,
String user,
Queue queue) |
Modifier and Type | Method and Description |
---|---|
NodeType |
CSAssignment.getRequestLocalityType() |
NodeType |
CSAssignment.getType() |
Modifier and Type | Method and Description |
---|---|
void |
CSAssignment.setRequestLocalityType(NodeType requestLocalityType) |
void |
CSAssignment.setType(NodeType type) |
Constructor and Description |
---|
CSAssignment(org.apache.hadoop.yarn.api.records.Resource resource,
NodeType type) |
CSAssignment(org.apache.hadoop.yarn.api.records.Resource resource,
NodeType type,
RMContainer excessReservation,
FiCaSchedulerApp application,
CSAssignment.SkippedType skipped,
boolean fulfilledReservation) |
Modifier and Type | Method and Description |
---|---|
NodeType |
ContainerAllocation.getContainerNodeType() |
Modifier and Type | Method and Description |
---|---|
NodeType |
ContainerAllocationProposal.getAllocationLocalityType() |
NodeType |
ContainerAllocationProposal.getRequestLocalityType() |
Constructor and Description |
---|
ContainerAllocationProposal(SchedulerContainer<A,N> allocatedOrReservedContainer,
List<SchedulerContainer<A,N>> toRelease,
SchedulerContainer<A,N> allocateFromReservedContainer,
NodeType allocationLocalityType,
NodeType requestLocalityType,
SchedulingMode schedulingMode,
org.apache.hadoop.yarn.api.records.Resource allocatedResource) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
FSAppAttempt.allocate(NodeType type,
FSSchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
PendingAsk pendingAsk,
org.apache.hadoop.yarn.api.records.Container reservedContainer) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
FifoAppAttempt.allocate(NodeType type,
FiCaSchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
org.apache.hadoop.yarn.api.records.Container container) |
Modifier and Type | Method and Description |
---|---|
abstract ContainerRequest |
AppPlacementAllocator.allocate(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
NodeType type,
SchedulerNode node)
Notify container allocated.
|
ContainerRequest |
SingleConstraintAppPlacementAllocator.allocate(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
NodeType type,
SchedulerNode node) |
ContainerRequest |
LocalityAppPlacementAllocator.allocate(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
NodeType type,
SchedulerNode node) |
abstract boolean |
AppPlacementAllocator.canAllocate(NodeType type,
SchedulerNode node)
We can still have pending requirement for a given NodeType and node
|
boolean |
SingleConstraintAppPlacementAllocator.canAllocate(NodeType type,
SchedulerNode node) |
boolean |
LocalityAppPlacementAllocator.canAllocate(NodeType type,
SchedulerNode node) |
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.