Modifier and Type | Method and Description |
---|---|
static JobMasterId |
JobMasterId.fromUuidOrNull(UUID uuid)
If the given uuid is null, this returns null, otherwise a JobMasterId that corresponds to the
UUID, via
JobMasterId(UUID) . |
static JobMasterId |
JobMasterId.generate()
Generates a new random JobMasterId.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
JobMaster.start(JobMasterId newJobMasterId)
Start the rpc service and begin to run the job.
|
CompletableFuture<Acknowledge> |
JobMasterService.start(JobMasterId jobMasterId)
Start the JobMaster service with the given
JobMasterId . |
Constructor and Description |
---|
RpcTaskManagerGateway(TaskExecutorGateway taskExecutorGateway,
JobMasterId jobMasterId) |
Modifier and Type | Method and Description |
---|---|
void |
SlotPool.start(JobMasterId jobMasterId,
String newJobManagerAddress,
ComponentMainThreadExecutor jmMainThreadScheduledExecutor) |
void |
SlotPoolImpl.start(JobMasterId jobMasterId,
String newJobManagerAddress,
ComponentMainThreadExecutor componentMainThreadExecutor)
Start the slot pool to accept RPC calls.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobMasterId> |
JobLeaderIdService.getLeaderId(JobID jobId) |
Modifier and Type | Method and Description |
---|---|
void |
JobLeaderIdActions.jobLeaderLostLeadership(JobID jobId,
JobMasterId oldJobMasterId)
Callback when a monitored job leader lost its leadership.
|
protected void |
ResourceManager.jobLeaderLostLeadership(JobID jobId,
JobMasterId oldJobMasterId) |
CompletableFuture<RegistrationResponse> |
ResourceManagerGateway.registerJobManager(JobMasterId jobMasterId,
ResourceID jobMasterResourceId,
String jobMasterAddress,
JobID jobId,
Time timeout)
Register a
JobMaster at the resource manager. |
CompletableFuture<RegistrationResponse> |
ResourceManager.registerJobManager(JobMasterId jobMasterId,
ResourceID jobManagerResourceId,
String jobManagerAddress,
JobID jobId,
Time timeout) |
CompletableFuture<Acknowledge> |
ResourceManagerGateway.requestSlot(JobMasterId jobMasterId,
SlotRequest slotRequest,
Time timeout)
Requests a slot from the resource manager.
|
CompletableFuture<Acknowledge> |
ResourceManager.requestSlot(JobMasterId jobMasterId,
SlotRequest slotRequest,
Time timeout) |
Modifier and Type | Method and Description |
---|---|
JobMasterId |
JobManagerRegistration.getJobMasterId() |
Modifier and Type | Method and Description |
---|---|
JobMasterId |
JobTable.Connection.getJobMasterId() |
Modifier and Type | Method and Description |
---|---|
void |
JobLeaderListener.jobManagerLostLeadership(JobID jobId,
JobMasterId jobMasterId)
Callback if the job leader for the job with the given job id lost its leadership.
|
CompletableFuture<Acknowledge> |
TaskExecutor.submitTask(TaskDeploymentDescriptor tdd,
JobMasterId jobMasterId,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.submitTask(TaskDeploymentDescriptor tdd,
JobMasterId jobMasterId,
Time timeout)
Submit a
Task to the TaskExecutor . |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.