Package | Description |
---|---|
org.apache.hadoop.yarn.server.resourcemanager.reservation | |
org.apache.hadoop.yarn.server.resourcemanager.reservation.planning | |
org.apache.hadoop.yarn.server.resourcemanager.webapp.dao |
This package contains the web data access objects (DAO) for the RM.
|
Modifier and Type | Method and Description |
---|---|
Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> |
ReservationAllocation.getAllocationRequests()
Returns the map of resources requested against the time interval for which
they were.
|
Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> |
InMemoryReservationAllocation.getAllocationRequests() |
static Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> |
ReservationSystemUtil.toAllocations(List<org.apache.hadoop.yarn.proto.YarnProtos.ResourceAllocationRequestProto> allocationRequestsList) |
Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> |
RLESparseResourceAllocation.toIntervalMap()
Returns the representation of the current resources allocated over time as
an interval map (in the defined non-null range).
|
static Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> |
ReservationSystemUtil.toResources(Map<ReservationInterval,org.apache.hadoop.yarn.api.records.ReservationRequest> allocations) |
Modifier and Type | Method and Description |
---|---|
boolean |
RLESparseResourceAllocation.addInterval(ReservationInterval reservationInterval,
org.apache.hadoop.yarn.api.records.Resource totCap)
Add a resource for the specified interval.
|
boolean |
PeriodicRLESparseResourceAllocation.addInterval(ReservationInterval interval,
org.apache.hadoop.yarn.api.records.Resource resource)
Add resource for the specified interval.
|
int |
ReservationInterval.compareTo(ReservationInterval anotherInterval) |
org.apache.hadoop.yarn.api.records.Resource |
RLESparseResourceAllocation.getMinimumCapacityInInterval(ReservationInterval interval)
Get the minimum capacity in the specified time range.
|
Set<ReservationAllocation> |
InMemoryPlan.getReservations(org.apache.hadoop.yarn.api.records.ReservationId reservationID,
ReservationInterval interval) |
Set<ReservationAllocation> |
InMemoryPlan.getReservations(org.apache.hadoop.yarn.api.records.ReservationId reservationID,
ReservationInterval interval,
String user) |
boolean |
RLESparseResourceAllocation.removeInterval(ReservationInterval reservationInterval,
org.apache.hadoop.yarn.api.records.Resource totCap)
Removes a resource for the specified interval.
|
boolean |
PeriodicRLESparseResourceAllocation.removeInterval(ReservationInterval interval,
org.apache.hadoop.yarn.api.records.Resource resource)
Removes a resource for the specified interval.
|
Modifier and Type | Method and Description |
---|---|
static Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> |
ReservationSystemUtil.toResources(Map<ReservationInterval,org.apache.hadoop.yarn.api.records.ReservationRequest> allocations) |
Constructor and Description |
---|
InMemoryReservationAllocation(org.apache.hadoop.yarn.api.records.ReservationId reservationID,
org.apache.hadoop.yarn.api.records.ReservationDefinition contract,
String user,
String planName,
long startTime,
long endTime,
Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> allocations,
org.apache.hadoop.yarn.util.resource.ResourceCalculator calculator,
org.apache.hadoop.yarn.api.records.Resource minAlloc) |
InMemoryReservationAllocation(org.apache.hadoop.yarn.api.records.ReservationId reservationID,
org.apache.hadoop.yarn.api.records.ReservationDefinition contract,
String user,
String planName,
long startTime,
long endTime,
Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> allocations,
org.apache.hadoop.yarn.util.resource.ResourceCalculator calculator,
org.apache.hadoop.yarn.api.records.Resource minAlloc,
boolean hasGang) |
Modifier and Type | Method and Description |
---|---|
ReservationInterval |
StageExecutionIntervalByDemand.computeExecutionInterval(Plan plan,
org.apache.hadoop.yarn.api.records.ReservationDefinition reservation,
org.apache.hadoop.yarn.api.records.ReservationRequest currentReservationStage,
boolean allocateLeft,
RLESparseResourceAllocation allocations) |
ReservationInterval |
StageExecutionInterval.computeExecutionInterval(Plan plan,
org.apache.hadoop.yarn.api.records.ReservationDefinition reservation,
org.apache.hadoop.yarn.api.records.ReservationRequest currentReservationStage,
boolean allocateLeft,
RLESparseResourceAllocation allocations)
Computes the earliest allowed starting time for a given stage.
|
ReservationInterval |
StageExecutionIntervalUnconstrained.computeExecutionInterval(Plan plan,
org.apache.hadoop.yarn.api.records.ReservationDefinition reservation,
org.apache.hadoop.yarn.api.records.ReservationRequest currentReservationStage,
boolean allocateLeft,
RLESparseResourceAllocation allocations) |
protected ReservationInterval |
IterativePlanner.setStageExecutionInterval(Plan plan,
org.apache.hadoop.yarn.api.records.ReservationDefinition reservation,
org.apache.hadoop.yarn.api.records.ReservationRequest currentReservationStage,
RLESparseResourceAllocation allocations) |
Modifier and Type | Method and Description |
---|---|
protected Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> |
IterativePlanner.computeStageAllocation(Plan plan,
org.apache.hadoop.yarn.api.records.ReservationRequest rr,
long stageArrivalTime,
long stageDeadline,
long period,
String user,
org.apache.hadoop.yarn.api.records.ReservationId oldId) |
Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> |
StageAllocator.computeStageAllocation(Plan plan,
RLESparseResourceAllocation planLoads,
RLESparseResourceAllocation planModifications,
org.apache.hadoop.yarn.api.records.ReservationRequest rr,
long stageArrival,
long stageDeadline,
long period,
String user,
org.apache.hadoop.yarn.api.records.ReservationId oldId)
Computes the allocation of a stage inside a defined time interval.
|
Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> |
StageAllocatorGreedy.computeStageAllocation(Plan plan,
RLESparseResourceAllocation planLoads,
RLESparseResourceAllocation planModifications,
org.apache.hadoop.yarn.api.records.ReservationRequest rr,
long stageEarliestStart,
long stageDeadline,
long period,
String user,
org.apache.hadoop.yarn.api.records.ReservationId oldId) |
Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> |
StageAllocatorLowCostAligned.computeStageAllocation(Plan plan,
RLESparseResourceAllocation planLoads,
RLESparseResourceAllocation planModifications,
org.apache.hadoop.yarn.api.records.ReservationRequest rr,
long stageArrival,
long stageDeadline,
long period,
String user,
org.apache.hadoop.yarn.api.records.ReservationId oldId) |
Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> |
StageAllocatorGreedyRLE.computeStageAllocation(Plan plan,
RLESparseResourceAllocation planLoads,
RLESparseResourceAllocation planModifications,
org.apache.hadoop.yarn.api.records.ReservationRequest rr,
long stageEarliestStart,
long stageDeadline,
long period,
String user,
org.apache.hadoop.yarn.api.records.ReservationId oldId) |
Modifier and Type | Method and Description |
---|---|
protected static long |
PlanningAlgorithm.findEarliestTime(Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> sesInt) |
protected static long |
PlanningAlgorithm.findLatestTime(Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> sesInt) |
protected static boolean |
IterativePlanner.validateOrderNoGap(RLESparseResourceAllocation allocations,
Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> curAlloc,
boolean allocateLeft) |
Constructor and Description |
---|
ResourceAllocationInfo(ReservationInterval interval,
org.apache.hadoop.yarn.api.records.Resource res) |
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.