Package | Description |
---|---|
org.apache.flink.runtime.jobmaster.slotpool |
Modifier and Type | Method and Description |
---|---|
PhysicalSlot |
PhysicalSlotRequest.Result.getPhysicalSlot() |
PhysicalSlot |
SlotAndLocality.getSlot() |
Modifier and Type | Method and Description |
---|---|
Optional<PhysicalSlot> |
SlotPool.allocateAvailableSlot(SlotRequestId slotRequestId,
AllocationID allocationID)
Allocates the available slot with the given allocation id under the given request id.
|
Optional<PhysicalSlot> |
SlotPoolImpl.allocateAvailableSlot(SlotRequestId slotRequestId,
AllocationID allocationID) |
CompletableFuture<PhysicalSlot> |
SlotPool.requestNewAllocatedBatchSlot(SlotRequestId slotRequestId,
ResourceProfile resourceProfile)
Requests the allocation of a new batch slot from the resource manager.
|
CompletableFuture<PhysicalSlot> |
SlotPoolImpl.requestNewAllocatedBatchSlot(SlotRequestId slotRequestId,
ResourceProfile resourceProfile) |
CompletableFuture<PhysicalSlot> |
SlotPool.requestNewAllocatedSlot(SlotRequestId slotRequestId,
ResourceProfile resourceProfile,
Time timeout)
Request the allocation of a new slot from the resource manager.
|
CompletableFuture<PhysicalSlot> |
SlotPoolImpl.requestNewAllocatedSlot(SlotRequestId slotRequestId,
ResourceProfile resourceProfile,
Time timeout) |
Modifier and Type | Method and Description |
---|---|
static SingleLogicalSlot |
SingleLogicalSlot.allocateFromPhysicalSlot(SlotRequestId slotRequestId,
PhysicalSlot physicalSlot,
Locality locality,
SlotOwner slotOwner,
boolean slotWillBeOccupiedIndefinitely) |
Constructor and Description |
---|
Result(SlotRequestId slotRequestId,
PhysicalSlot physicalSlot) |
SlotAndLocality(PhysicalSlot slot,
Locality locality) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.