Uses of Class
org.apache.flink.runtime.util.ResourceCounter
-
-
Uses of ResourceCounter in org.apache.flink.runtime.jobmaster.slotpool
Methods in org.apache.flink.runtime.jobmaster.slotpool that return ResourceCounter Modifier and Type Method Description ResourceCounterBlocklistDeclarativeSlotPool. freeReservedSlot(AllocationID allocationId, Throwable cause, long currentTime)ResourceCounterDeclarativeSlotPool. freeReservedSlot(AllocationID allocationId, Throwable cause, long currentTime)Frees the reserved slot identified by the given allocationId.ResourceCounterDefaultDeclarativeSlotPool. freeReservedSlot(AllocationID allocationId, Throwable cause, long currentTime)ResourceCounterDeclarativeSlotPool. releaseSlot(AllocationID allocationId, Exception cause)Releases the slot specified by allocationId if one exists.ResourceCounterDefaultDeclarativeSlotPool. releaseSlot(AllocationID allocationId, Exception cause)ResourceCounterDeclarativeSlotPool. releaseSlots(ResourceID owner, Exception cause)Releases all slots belonging to the owning TaskExecutor if it has been registered.ResourceCounterDefaultDeclarativeSlotPool. releaseSlots(ResourceID owner, Exception cause)Methods in org.apache.flink.runtime.jobmaster.slotpool with parameters of type ResourceCounter Modifier and Type Method Description voidDeclarativeSlotPool. decreaseResourceRequirementsBy(ResourceCounter decrement)Decreases the resource requirements by decrement.voidDefaultDeclarativeSlotPool. decreaseResourceRequirementsBy(ResourceCounter decrement)voidDeclarativeSlotPool. increaseResourceRequirementsBy(ResourceCounter increment)Increases the resource requirements by increment.voidDefaultDeclarativeSlotPool. increaseResourceRequirementsBy(ResourceCounter increment)protected voidDeclarativeSlotPoolBridge. onFailAllocation(ResourceCounter previouslyFulfilledRequirements)protected voidDeclarativeSlotPoolService. onFailAllocation(ResourceCounter previouslyFulfilledRequirements)This method is called when an allocation fails.protected voidDeclarativeSlotPoolBridge. onReleaseTaskManager(ResourceCounter previouslyFulfilledRequirement)protected voidDeclarativeSlotPoolService. onReleaseTaskManager(ResourceCounter previouslyFulfilledRequirement)This method is called when a TaskManager is released.voidDeclarativeSlotPool. setResourceRequirements(ResourceCounter resourceRequirements)Sets the resource requirements to the given resourceRequirements.voidDefaultDeclarativeSlotPool. setResourceRequirements(ResourceCounter resourceRequirements) -
Uses of ResourceCounter in org.apache.flink.runtime.resourcemanager.slotmanager
Methods in org.apache.flink.runtime.resourcemanager.slotmanager that return types with arguments of type ResourceCounter Modifier and Type Method Description Map<PendingTaskManagerId,Map<org.apache.flink.api.common.JobID,ResourceCounter>>ResourceAllocationResult. getAllocationsOnPendingResources()Map<org.apache.flink.api.common.JobID,Map<InstanceID,ResourceCounter>>ResourceAllocationResult. getAllocationsOnRegisteredResources()Map<org.apache.flink.api.common.JobID,ResourceCounter>PendingTaskManager. getPendingSlotAllocationRecords()Map<org.apache.flink.api.common.JobID,ResourceCounter>FineGrainedTaskManagerTracker. removePendingTaskManager(PendingTaskManagerId pendingTaskManagerId)Method parameters in org.apache.flink.runtime.resourcemanager.slotmanager with type arguments of type ResourceCounter Modifier and Type Method Description voidFineGrainedTaskManagerTracker. replaceAllPendingAllocations(Map<PendingTaskManagerId,Map<org.apache.flink.api.common.JobID,ResourceCounter>> pendingSlotAllocations)voidPendingTaskManager. replaceAllPendingAllocations(Map<org.apache.flink.api.common.JobID,ResourceCounter> pendingSlotAllocations) -
Uses of ResourceCounter in org.apache.flink.runtime.scheduler.adaptive.allocator
Methods in org.apache.flink.runtime.scheduler.adaptive.allocator that return ResourceCounter Modifier and Type Method Description ResourceCounterSlotAllocator. calculateRequiredSlots(Iterable<JobInformation.VertexInformation> vertices)Calculates the total resources required for scheduling the given vertices.ResourceCounterSlotSharingSlotAllocator. calculateRequiredSlots(Iterable<JobInformation.VertexInformation> vertices) -
Uses of ResourceCounter in org.apache.flink.runtime.slots
Methods in org.apache.flink.runtime.slots with parameters of type ResourceCounter Modifier and Type Method Description Optional<ResourceProfile>DefaultRequirementMatcher. match(ResourceProfile resourceProfile, ResourceCounter totalRequirements, Function<ResourceProfile,Integer> numAssignedResourcesLookup)Optional<ResourceProfile>RequirementMatcher. match(ResourceProfile resourceProfile, ResourceCounter totalRequirements, Function<ResourceProfile,Integer> numAssignedResourcesLookup)Attempts to match the given resource profile with one of the given requirements. -
Uses of ResourceCounter in org.apache.flink.runtime.util
Methods in org.apache.flink.runtime.util that return ResourceCounter Modifier and Type Method Description ResourceCounterResourceCounter. add(Map<ResourceProfile,Integer> increment)Adds the given increment to this resource counter value and returns the resulting value.ResourceCounterResourceCounter. add(ResourceProfile resourceProfile, int increment)Adds increment to the count of resourceProfile and returns the new value.ResourceCounterResourceCounter. add(ResourceCounter increment)Adds increment to this resource counter value and returns the resulting value.static ResourceCounterResourceCounter. empty()Creates an empty resource counter.ResourceCounterResourceCounter. subtract(Map<ResourceProfile,Integer> decrement)Subtracts decrement from this resource counter value and returns the new value.ResourceCounterResourceCounter. subtract(ResourceProfile resourceProfile, int decrement)Subtracts decrement from the count of the given resourceProfile and returns the new value.ResourceCounterResourceCounter. subtract(ResourceCounter decrement)Subtracts decrement from this resource counter value and returns the new value.static ResourceCounterResourceCounter. withResource(ResourceProfile resourceProfile, int count)Creates a resource counter with the given resourceProfile and its count.static ResourceCounterResourceCounter. withResources(Map<ResourceProfile,Integer> resources)Creates a resource counter with the specified set of resources.Methods in org.apache.flink.runtime.util with parameters of type ResourceCounter Modifier and Type Method Description ResourceCounterResourceCounter. add(ResourceCounter increment)Adds increment to this resource counter value and returns the resulting value.ResourceCounterResourceCounter. subtract(ResourceCounter decrement)Subtracts decrement from this resource counter value and returns the new value.
-