Package | Description |
---|---|
org.apache.flink.runtime.jobmaster.slotpool | |
org.apache.flink.runtime.scheduler.adaptive.allocator |
Modifier and Type | Method and Description |
---|---|
PhysicalSlot |
PhysicalSlotRequest.Result.getPhysicalSlot() |
PhysicalSlot |
DefaultDeclarativeSlotPool.reserveFreeSlot(AllocationID allocationId,
ResourceProfile requiredSlotProfile) |
PhysicalSlot |
DeclarativeSlotPool.reserveFreeSlot(AllocationID allocationId,
ResourceProfile requiredSlotProfile)
Reserves the free slot identified by the given allocationId and maps it to the given
requiredSlotProfile.
|
Modifier and Type | Method and Description |
---|---|
Optional<PhysicalSlot> |
SlotPool.allocateAvailableSlot(SlotRequestId slotRequestId,
AllocationID allocationID,
ResourceProfile requirementProfile)
Allocates the available slot with the given allocation id under the given request id for the
given requirement profile.
|
Optional<PhysicalSlot> |
DeclarativeSlotPoolBridge.allocateAvailableSlot(SlotRequestId slotRequestId,
AllocationID allocationID,
ResourceProfile requirementProfile) |
default CompletableFuture<PhysicalSlot> |
SlotPool.requestNewAllocatedBatchSlot(SlotRequestId slotRequestId,
ResourceProfile resourceProfile)
Requests the allocation of a new batch slot from the resource manager.
|
CompletableFuture<PhysicalSlot> |
SlotPool.requestNewAllocatedBatchSlot(SlotRequestId slotRequestId,
ResourceProfile resourceProfile,
Collection<AllocationID> preferredAllocations) |
CompletableFuture<PhysicalSlot> |
DeclarativeSlotPoolBridge.requestNewAllocatedBatchSlot(SlotRequestId slotRequestId,
ResourceProfile resourceProfile,
Collection<AllocationID> preferredAllocations) |
CompletableFuture<PhysicalSlot> |
SlotPool.requestNewAllocatedSlot(SlotRequestId slotRequestId,
ResourceProfile resourceProfile,
Collection<AllocationID> preferredAllocations,
Time timeout)
Request the allocation of a new slot from the resource manager.
|
CompletableFuture<PhysicalSlot> |
DeclarativeSlotPoolBridge.requestNewAllocatedSlot(SlotRequestId slotRequestId,
ResourceProfile resourceProfile,
Collection<AllocationID> preferredAllocations,
Time timeout) |
default CompletableFuture<PhysicalSlot> |
SlotPool.requestNewAllocatedSlot(SlotRequestId slotRequestId,
ResourceProfile resourceProfile,
Time timeout)
Request the allocation of a new slot from the resource manager.
|
Modifier and Type | Method and Description |
---|---|
static SingleLogicalSlot |
SingleLogicalSlot.allocateFromPhysicalSlot(SlotRequestId slotRequestId,
PhysicalSlot physicalSlot,
Locality locality,
SlotOwner slotOwner,
boolean slotWillBeOccupiedIndefinitely) |
Modifier and Type | Method and Description |
---|---|
Collection<RequestSlotMatchingStrategy.RequestSlotMatch> |
SimpleRequestSlotMatchingStrategy.matchRequestsAndSlots(Collection<? extends PhysicalSlot> slots,
Collection<org.apache.flink.runtime.jobmaster.slotpool.PendingRequest> pendingRequests) |
Collection<RequestSlotMatchingStrategy.RequestSlotMatch> |
PreferredAllocationRequestSlotMatchingStrategy.matchRequestsAndSlots(Collection<? extends PhysicalSlot> slots,
Collection<org.apache.flink.runtime.jobmaster.slotpool.PendingRequest> pendingRequests) |
Collection<RequestSlotMatchingStrategy.RequestSlotMatch> |
RequestSlotMatchingStrategy.matchRequestsAndSlots(Collection<? extends PhysicalSlot> slots,
Collection<org.apache.flink.runtime.jobmaster.slotpool.PendingRequest> pendingRequests)
Match the given slots with the given collection of pending requests.
|
void |
DeclarativeSlotPool.NewSlotsListener.notifyNewSlotsAreAvailable(Collection<? extends PhysicalSlot> newlyAvailableSlots)
Notifies the listener about newly available slots.
|
void |
DeclarativeSlotPool.NoOpNewSlotsListener.notifyNewSlotsAreAvailable(Collection<? extends PhysicalSlot> newlyAvailableSlots) |
Constructor and Description |
---|
Result(SlotRequestId slotRequestId,
PhysicalSlot physicalSlot) |
Modifier and Type | Method and Description |
---|---|
PhysicalSlot |
ReserveSlotFunction.reserveSlot(AllocationID allocationId,
ResourceProfile resourceProfile)
Reserves the slot identified by the given allocation ID for the given resource profile.
|
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.