Package | Description |
---|---|
org.apache.flink.runtime.instance | |
org.apache.flink.runtime.jobmanager.scheduler | |
org.apache.flink.runtime.jobmaster | |
org.apache.flink.runtime.jobmaster.slotpool |
Modifier and Type | Field and Description |
---|---|
protected static SlotRequestId |
Slot.NO_SLOT_REQUEST_ID |
Modifier and Type | Method and Description |
---|---|
SlotRequestId |
SharedSlot.getSlotRequestId() |
SlotRequestId |
SimpleSlot.getSlotRequestId() |
Modifier and Type | Method and Description |
---|---|
SlotRequestId |
CoLocationConstraint.getSlotRequestId()
Returns the currently assigned slot request id identifying the slot to which tasks
belonging to this co-location constraint will be deployed to.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<LogicalSlot> |
Scheduler.allocateSlot(SlotRequestId slotRequestId,
ScheduledUnit task,
boolean allowQueued,
SlotProfile slotProfile,
Time allocationTimeout) |
CompletableFuture<Acknowledge> |
Scheduler.cancelSlotRequest(SlotRequestId slotRequestId,
SlotSharingGroupId slotSharingGroupId,
Throwable cause) |
void |
CoLocationConstraint.setSlotRequestId(SlotRequestId slotRequestId)
Sets the slot request id of the currently assigned slot to the co-location constraint.
|
Modifier and Type | Method and Description |
---|---|
SlotRequestId |
LogicalSlot.getSlotRequestId()
Gets the slot request id uniquely identifying the request with which this
slot has been allocated.
|
Modifier and Type | Method and Description |
---|---|
SlotRequestId |
SingleLogicalSlot.getSlotRequestId() |
SlotRequestId |
SlotSharingManager.TaskSlot.getSlotRequestId() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<LogicalSlot> |
SlotProvider.allocateSlot(SlotRequestId slotRequestId,
ScheduledUnit task,
boolean allowQueued,
SlotProfile slotProfile,
Time timeout)
Allocating slot with specific requirement.
|
CompletableFuture<LogicalSlot> |
SlotPoolGateway.allocateSlot(SlotRequestId slotRequestId,
ScheduledUnit scheduledUnit,
SlotProfile slotProfile,
boolean allowQueuedScheduling,
Time timeout)
Requests to allocate a slot for the given
ScheduledUnit . |
CompletableFuture<LogicalSlot> |
SlotPool.allocateSlot(SlotRequestId slotRequestId,
ScheduledUnit task,
SlotProfile slotProfile,
boolean allowQueuedScheduling,
Time allocationTimeout) |
CompletableFuture<Acknowledge> |
SlotProvider.cancelSlotRequest(SlotRequestId slotRequestId,
SlotSharingGroupId slotSharingGroupId,
Throwable cause)
Cancels the slot request with the given
SlotRequestId and SlotSharingGroupId . |
boolean |
SlotSharingManager.contains(SlotRequestId slotRequestId) |
CompletableFuture<Acknowledge> |
SlotPool.releaseSlot(SlotRequestId slotRequestId,
SlotSharingGroupId slotSharingGroupId,
Throwable cause) |
CompletableFuture<Acknowledge> |
AllocatedSlotActions.releaseSlot(SlotRequestId slotRequestId,
SlotSharingGroupId slotSharingGroupId,
Throwable cause)
Releases the slot with the given
SlotRequestId . |
protected void |
SlotPool.timeoutPendingSlotRequest(SlotRequestId slotRequestId) |
Constructor and Description |
---|
SingleLogicalSlot(SlotRequestId slotRequestId,
SlotContext slotContext,
SlotSharingGroupId slotSharingGroupId,
Locality locality,
SlotOwner slotOwner) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.