Modifier and Type | Method and Description |
---|---|
ResourceManagerId |
ResourceManagerAddress.getResourceManagerId() |
ResourceManagerId |
JobMasterRegistrationSuccess.getResourceManagerId() |
Modifier and Type | Method and Description |
---|---|
void |
JobMaster.disconnectResourceManager(ResourceManagerId resourceManagerId,
Exception cause) |
void |
JobMasterGateway.disconnectResourceManager(ResourceManagerId resourceManagerId,
Exception cause)
Disconnects the resource manager from the job manager because of the given cause.
|
Constructor and Description |
---|
JobMasterRegistrationSuccess(ResourceManagerId resourceManagerId,
ResourceID resourceManagerResourceId) |
ResourceManagerAddress(String address,
ResourceManagerId resourceManagerId) |
Modifier and Type | Method and Description |
---|---|
static ResourceManagerId |
ResourceManagerId.fromUuid(UUID uuid)
Creates a ResourceManagerId that corresponds to the given UUID.
|
static ResourceManagerId |
ResourceManagerId.fromUuidOrNull(UUID uuid)
If the given uuid is null, this returns null, otherwise a ResourceManagerId that corresponds
to the UUID, via
ResourceManagerId(UUID) . |
static ResourceManagerId |
ResourceManagerId.generate()
Generates a new random ResourceManagerId.
|
Modifier and Type | Method and Description |
---|---|
void |
SlotStatusSyncer.initialize(org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerTracker taskManagerTracker,
ResourceTracker resourceTracker,
ResourceManagerId resourceManagerId,
Executor mainThreadExecutor)
Initialize this syncer.
|
void |
DefaultSlotStatusSyncer.initialize(org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerTracker taskManagerTracker,
ResourceTracker resourceTracker,
ResourceManagerId resourceManagerId,
Executor mainThreadExecutor) |
void |
SlotManager.start(ResourceManagerId newResourceManagerId,
Executor newMainThreadExecutor,
ResourceAllocator newResourceAllocator,
ResourceEventListener resourceEventListener,
BlockedTaskManagerChecker newBlockedTaskManagerChecker)
Starts the slot manager with the given leader id and resource manager actions.
|
void |
FineGrainedSlotManager.start(ResourceManagerId newResourceManagerId,
Executor newMainThreadExecutor,
ResourceAllocator newResourceAllocator,
ResourceEventListener newResourceEventListener,
BlockedTaskManagerChecker newBlockedTaskManagerChecker)
Starts the slot manager with the given leader id and resource manager actions.
|
Modifier and Type | Method and Description |
---|---|
protected RetryingRegistration<ResourceManagerId,ResourceManagerGateway,TaskExecutorRegistrationSuccess,TaskExecutorRegistrationRejection> |
TaskExecutorToResourceManagerConnection.generateRegistration() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
TaskExecutor.requestSlot(SlotID slotId,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
String targetAddress,
ResourceManagerId resourceManagerId,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.requestSlot(SlotID slotId,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
String targetAddress,
ResourceManagerId resourceManagerId,
Time timeout)
Requests a slot from the TaskManager.
|
CompletableFuture<Acknowledge> |
TaskExecutorGatewayDecoratorBase.requestSlot(SlotID slotId,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
String targetAddress,
ResourceManagerId resourceManagerId,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutor.updateDelegationTokens(ResourceManagerId resourceManagerId,
byte[] tokens) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.updateDelegationTokens(ResourceManagerId resourceManagerId,
byte[] tokens)
Sends new delegation tokens to this TaskManager.
|
CompletableFuture<Acknowledge> |
TaskExecutorGatewayDecoratorBase.updateDelegationTokens(ResourceManagerId resourceManagerId,
byte[] tokens) |
Constructor and Description |
---|
TaskExecutorToResourceManagerConnection(org.slf4j.Logger log,
RpcService rpcService,
RetryingRegistrationConfiguration retryingRegistrationConfiguration,
String resourceManagerAddress,
ResourceManagerId resourceManagerId,
Executor executor,
RegistrationConnectionListener<TaskExecutorToResourceManagerConnection,TaskExecutorRegistrationSuccess,TaskExecutorRegistrationRejection> registrationListener,
TaskExecutorRegistration taskExecutorRegistration) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.