Package | Description |
---|---|
org.apache.hadoop.yarn.server.resourcemanager.reservation | |
org.apache.hadoop.yarn.server.resourcemanager.reservation.planning |
Modifier and Type | Class and Description |
---|---|
class |
PeriodicRLESparseResourceAllocation
This data structure stores a periodic
RLESparseResourceAllocation . |
Modifier and Type | Method and Description |
---|---|
RLESparseResourceAllocation |
SharingPolicy.availableResources(RLESparseResourceAllocation available,
Plan plan,
String user,
org.apache.hadoop.yarn.api.records.ReservationId oldId,
long start,
long end)
This method provide a (partial) instantaneous validation by applying
business rules (such as max number of parallel containers allowed for a
user).
|
RLESparseResourceAllocation |
CapacityOverTimePolicy.availableResources(RLESparseResourceAllocation available,
Plan plan,
String user,
org.apache.hadoop.yarn.api.records.ReservationId oldId,
long start,
long end) |
RLESparseResourceAllocation |
NoOverCommitPolicy.availableResources(RLESparseResourceAllocation available,
Plan plan,
String user,
org.apache.hadoop.yarn.api.records.ReservationId oldId,
long start,
long end) |
RLESparseResourceAllocation |
InMemoryPlan.getAvailableResourceOverTime(String user,
org.apache.hadoop.yarn.api.records.ReservationId oldId,
long start,
long end,
long period) |
RLESparseResourceAllocation |
InMemoryPlan.getConsumptionForUserOverTime(String user,
long start,
long end) |
RLESparseResourceAllocation |
InMemoryPlan.getCumulativeLoadOverTime(long start,
long end) |
RLESparseResourceAllocation |
RLESparseResourceAllocation.getRangeOverlapping(long start,
long end)
Get a
RLESparseResourceAllocation view of the Resource
allocations between the specified start and end times. |
RLESparseResourceAllocation |
PeriodicRLESparseResourceAllocation.getRangeOverlapping(long start,
long end) |
RLESparseResourceAllocation |
InMemoryPlan.getReservationCountForUserOverTime(String user,
long start,
long end) |
RLESparseResourceAllocation |
ReservationAllocation.getResourcesOverTime()
Return a RLE representation of used resources.
|
RLESparseResourceAllocation |
InMemoryReservationAllocation.getResourcesOverTime() |
RLESparseResourceAllocation |
ReservationAllocation.getResourcesOverTime(long start,
long end)
Return a RLE representation of used resources.
|
RLESparseResourceAllocation |
InMemoryReservationAllocation.getResourcesOverTime(long start,
long end) |
static RLESparseResourceAllocation |
RLESparseResourceAllocation.merge(org.apache.hadoop.yarn.util.resource.ResourceCalculator resCalc,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
RLESparseResourceAllocation a,
RLESparseResourceAllocation b,
RLESparseResourceAllocation.RLEOperator operator,
long start,
long end)
Merges the range start to end of two
RLESparseResourceAllocation
using a given RLEOperator . |
Modifier and Type | Method and Description |
---|---|
RLESparseResourceAllocation |
SharingPolicy.availableResources(RLESparseResourceAllocation available,
Plan plan,
String user,
org.apache.hadoop.yarn.api.records.ReservationId oldId,
long start,
long end)
This method provide a (partial) instantaneous validation by applying
business rules (such as max number of parallel containers allowed for a
user).
|
RLESparseResourceAllocation |
CapacityOverTimePolicy.availableResources(RLESparseResourceAllocation available,
Plan plan,
String user,
org.apache.hadoop.yarn.api.records.ReservationId oldId,
long start,
long end) |
RLESparseResourceAllocation |
NoOverCommitPolicy.availableResources(RLESparseResourceAllocation available,
Plan plan,
String user,
org.apache.hadoop.yarn.api.records.ReservationId oldId,
long start,
long end) |
static RLESparseResourceAllocation |
RLESparseResourceAllocation.merge(org.apache.hadoop.yarn.util.resource.ResourceCalculator resCalc,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
RLESparseResourceAllocation a,
RLESparseResourceAllocation b,
RLESparseResourceAllocation.RLEOperator operator,
long start,
long end)
Merges the range start to end of two
RLESparseResourceAllocation
using a given RLEOperator . |
Constructor and Description |
---|
PeriodicRLESparseResourceAllocation(RLESparseResourceAllocation rleVector,
Long timePeriod)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
abstract RLESparseResourceAllocation |
PlanningAlgorithm.computeJobAllocation(Plan plan,
org.apache.hadoop.yarn.api.records.ReservationId reservationId,
org.apache.hadoop.yarn.api.records.ReservationDefinition reservation,
String user) |
RLESparseResourceAllocation |
IterativePlanner.computeJobAllocation(Plan plan,
org.apache.hadoop.yarn.api.records.ReservationId reservationId,
org.apache.hadoop.yarn.api.records.ReservationDefinition reservation,
String user) |
Modifier and Type | Method and Description |
---|---|
protected double |
StageAllocatorLowCostAligned.calcCostOfInterval(long startTime,
long endTime,
RLESparseResourceAllocation planLoads,
RLESparseResourceAllocation planModifications,
org.apache.hadoop.yarn.api.records.Resource capacity,
org.apache.hadoop.yarn.util.resource.ResourceCalculator resCalc,
long step) |
protected double |
StageAllocatorLowCostAligned.calcCostOfTimeSlot(long t,
RLESparseResourceAllocation planLoads,
RLESparseResourceAllocation planModifications,
org.apache.hadoop.yarn.api.records.Resource capacity,
org.apache.hadoop.yarn.util.resource.ResourceCalculator resCalc) |
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) |
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) |
protected static StageAllocatorLowCostAligned.DurationInterval |
StageAllocatorLowCostAligned.getDurationInterval(long startTime,
long endTime,
RLESparseResourceAllocation planLoads,
RLESparseResourceAllocation planModifications,
org.apache.hadoop.yarn.api.records.Resource capacity,
RLESparseResourceAllocation netRLERes,
org.apache.hadoop.yarn.util.resource.ResourceCalculator resCalc,
long step,
org.apache.hadoop.yarn.api.records.Resource requestedResources) |
protected static int |
StageAllocatorLowCostAligned.getDurationIntervalGangsCanFit(long startTime,
long endTime,
RLESparseResourceAllocation planModifications,
org.apache.hadoop.yarn.api.records.Resource capacity,
RLESparseResourceAllocation netRLERes,
org.apache.hadoop.yarn.util.resource.ResourceCalculator resCalc,
org.apache.hadoop.yarn.api.records.Resource requestedResources) |
protected static double |
StageAllocatorLowCostAligned.getDurationIntervalTotalCost(long startTime,
long endTime,
RLESparseResourceAllocation planLoads,
RLESparseResourceAllocation planModifications,
org.apache.hadoop.yarn.api.records.Resource capacity,
org.apache.hadoop.yarn.util.resource.ResourceCalculator resCalc,
long step) |
protected org.apache.hadoop.yarn.api.records.Resource |
StageAllocatorLowCostAligned.getLoadAtTime(long t,
RLESparseResourceAllocation planLoads,
RLESparseResourceAllocation planModifications) |
protected ReservationInterval |
IterativePlanner.setStageExecutionInterval(Plan plan,
org.apache.hadoop.yarn.api.records.ReservationDefinition reservation,
org.apache.hadoop.yarn.api.records.ReservationRequest currentReservationStage,
RLESparseResourceAllocation allocations) |
protected static boolean |
IterativePlanner.validateOrderNoGap(RLESparseResourceAllocation allocations,
Map<ReservationInterval,org.apache.hadoop.yarn.api.records.Resource> curAlloc,
boolean allocateLeft) |
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.