| Package | Description | 
|---|---|
| org.apache.hadoop.yarn.server.resourcemanager.scheduler.common | 
| Modifier and Type | Method and Description | 
|---|---|
| SchedulerContainer<A,N> | ContainerAllocationProposal. getAllocatedOrReservedContainer() | 
| SchedulerContainer<A,N> | ContainerAllocationProposal. getAllocateFromReservedContainer() | 
| Modifier and Type | Method and Description | 
|---|---|
| List<SchedulerContainer<A,N>> | ResourceCommitRequest. getContainersToRelease() | 
| List<SchedulerContainer<A,N>> | ContainerAllocationProposal. getToRelease() | 
| 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) | 
| 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) | 
| 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) | 
| ResourceCommitRequest(List<ContainerAllocationProposal<A,N>> containersToAllocate,
                     List<ContainerAllocationProposal<A,N>> containersToReserve,
                     List<SchedulerContainer<A,N>> toReleaseContainers) | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.