Package | Description |
---|---|
org.apache.flink.runtime.jobmaster | |
org.apache.flink.runtime.jobmaster.slotpool | |
org.apache.flink.runtime.taskexecutor.slot |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Collection<SlotOffer>> |
JobMaster.offerSlots(ResourceID taskManagerId,
Collection<SlotOffer> slots,
Time timeout) |
CompletableFuture<Collection<SlotOffer>> |
JobMasterGateway.offerSlots(ResourceID taskManagerId,
Collection<SlotOffer> slots,
Time timeout)
Offers the given slots to the job manager.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Collection<SlotOffer>> |
JobMaster.offerSlots(ResourceID taskManagerId,
Collection<SlotOffer> slots,
Time timeout) |
CompletableFuture<Collection<SlotOffer>> |
JobMasterGateway.offerSlots(ResourceID taskManagerId,
Collection<SlotOffer> slots,
Time timeout)
Offers the given slots to the job manager.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Collection<SlotOffer>> |
SlotPoolGateway.offerSlots(TaskManagerLocation taskManagerLocation,
TaskManagerGateway taskManagerGateway,
Collection<SlotOffer> offers)
Offers multiple slots to the
SlotPool . |
CompletableFuture<Collection<SlotOffer>> |
SlotPool.offerSlots(TaskManagerLocation taskManagerLocation,
TaskManagerGateway taskManagerGateway,
Collection<SlotOffer> offers) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Boolean> |
SlotPoolGateway.offerSlot(TaskManagerLocation taskManagerLocation,
TaskManagerGateway taskManagerGateway,
SlotOffer slotOffer)
Offers a slot to the
SlotPool . |
CompletableFuture<Boolean> |
SlotPool.offerSlot(TaskManagerLocation taskManagerLocation,
TaskManagerGateway taskManagerGateway,
SlotOffer slotOffer)
Slot offering by TaskExecutor with AllocationID.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Collection<SlotOffer>> |
SlotPoolGateway.offerSlots(TaskManagerLocation taskManagerLocation,
TaskManagerGateway taskManagerGateway,
Collection<SlotOffer> offers)
Offers multiple slots to the
SlotPool . |
CompletableFuture<Collection<SlotOffer>> |
SlotPool.offerSlots(TaskManagerLocation taskManagerLocation,
TaskManagerGateway taskManagerGateway,
Collection<SlotOffer> offers) |
Modifier and Type | Method and Description |
---|---|
SlotOffer |
TaskSlot.generateSlotOffer()
Generate the slot offer from this TaskSlot.
|
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.