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 ResourceCounter
BlocklistDeclarativeSlotPool. freeReservedSlot(AllocationID allocationId, Throwable cause, long currentTime)
ResourceCounter
DeclarativeSlotPool. freeReservedSlot(AllocationID allocationId, Throwable cause, long currentTime)
Frees the reserved slot identified by the given allocationId.ResourceCounter
DefaultDeclarativeSlotPool. freeReservedSlot(AllocationID allocationId, Throwable cause, long currentTime)
ResourceCounter
DeclarativeSlotPool. releaseSlot(AllocationID allocationId, Exception cause)
Releases the slot specified by allocationId if one exists.ResourceCounter
DefaultDeclarativeSlotPool. releaseSlot(AllocationID allocationId, Exception cause)
ResourceCounter
DeclarativeSlotPool. releaseSlots(ResourceID owner, Exception cause)
Releases all slots belonging to the owning TaskExecutor if it has been registered.ResourceCounter
DefaultDeclarativeSlotPool. releaseSlots(ResourceID owner, Exception cause)
Methods in org.apache.flink.runtime.jobmaster.slotpool with parameters of type ResourceCounter Modifier and Type Method Description void
DeclarativeSlotPool. decreaseResourceRequirementsBy(ResourceCounter decrement)
Decreases the resource requirements by decrement.void
DefaultDeclarativeSlotPool. decreaseResourceRequirementsBy(ResourceCounter decrement)
void
DeclarativeSlotPool. increaseResourceRequirementsBy(ResourceCounter increment)
Increases the resource requirements by increment.void
DefaultDeclarativeSlotPool. increaseResourceRequirementsBy(ResourceCounter increment)
protected void
DeclarativeSlotPoolBridge. onFailAllocation(ResourceCounter previouslyFulfilledRequirements)
protected void
DeclarativeSlotPoolService. onFailAllocation(ResourceCounter previouslyFulfilledRequirements)
This method is called when an allocation fails.protected void
DeclarativeSlotPoolBridge. onReleaseTaskManager(ResourceCounter previouslyFulfilledRequirement)
protected void
DeclarativeSlotPoolService. onReleaseTaskManager(ResourceCounter previouslyFulfilledRequirement)
This method is called when a TaskManager is released.void
DeclarativeSlotPool. setResourceRequirements(ResourceCounter resourceRequirements)
Sets the resource requirements to the given resourceRequirements.void
DefaultDeclarativeSlotPool. 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 void
FineGrainedTaskManagerTracker. replaceAllPendingAllocations(Map<PendingTaskManagerId,Map<org.apache.flink.api.common.JobID,ResourceCounter>> pendingSlotAllocations)
void
PendingTaskManager. 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 ResourceCounter
SlotAllocator. calculateRequiredSlots(Iterable<JobInformation.VertexInformation> vertices)
Calculates the total resources required for scheduling the given vertices.ResourceCounter
SlotSharingSlotAllocator. 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 ResourceCounter
ResourceCounter. add(Map<ResourceProfile,Integer> increment)
Adds the given increment to this resource counter value and returns the resulting value.ResourceCounter
ResourceCounter. add(ResourceProfile resourceProfile, int increment)
Adds increment to the count of resourceProfile and returns the new value.ResourceCounter
ResourceCounter. add(ResourceCounter increment)
Adds increment to this resource counter value and returns the resulting value.static ResourceCounter
ResourceCounter. empty()
Creates an empty resource counter.ResourceCounter
ResourceCounter. subtract(Map<ResourceProfile,Integer> decrement)
Subtracts decrement from this resource counter value and returns the new value.ResourceCounter
ResourceCounter. subtract(ResourceProfile resourceProfile, int decrement)
Subtracts decrement from the count of the given resourceProfile and returns the new value.ResourceCounter
ResourceCounter. subtract(ResourceCounter decrement)
Subtracts decrement from this resource counter value and returns the new value.static ResourceCounter
ResourceCounter. withResource(ResourceProfile resourceProfile, int count)
Creates a resource counter with the given resourceProfile and its count.static ResourceCounter
ResourceCounter. 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 ResourceCounter
ResourceCounter. add(ResourceCounter increment)
Adds increment to this resource counter value and returns the resulting value.ResourceCounter
ResourceCounter. subtract(ResourceCounter decrement)
Subtracts decrement from this resource counter value and returns the new value.
-