public class YarnResourceManagerDriver extends AbstractResourceManagerDriver<YarnWorkerNode>
ResourceManagerDriver
for Yarn deployment.flinkClientConfig, flinkConfig, log
Constructor and Description |
---|
YarnResourceManagerDriver(Configuration flinkConfig,
YarnResourceManagerDriverConfiguration configuration,
YarnResourceManagerClientFactory yarnResourceManagerClientFactory,
YarnNodeManagerClientFactory yarnNodeManagerClientFactory) |
Modifier and Type | Method and Description |
---|---|
void |
deregisterApplication(ApplicationStatus finalStatus,
String optionalDiagnostics)
The deployment specific code to deregister the application.
|
static String |
getContainerCompletedCause(org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus) |
protected void |
initializeInternal()
Initialize the deployment specific components.
|
void |
releaseResource(YarnWorkerNode workerNode)
Release resource to the external resource manager.
|
CompletableFuture<YarnWorkerNode> |
requestResource(TaskExecutorProcessSpec taskExecutorProcessSpec)
Request resource from the external resource manager.
|
void |
terminate()
Terminate the deployment specific components.
|
getBlockedNodeRetriever, getIoExecutor, getMainThreadExecutor, getResourceEventHandler, initialize
public YarnResourceManagerDriver(Configuration flinkConfig, YarnResourceManagerDriverConfiguration configuration, YarnResourceManagerClientFactory yarnResourceManagerClientFactory, YarnNodeManagerClientFactory yarnNodeManagerClientFactory)
protected void initializeInternal() throws Exception
AbstractResourceManagerDriver
initializeInternal
in class AbstractResourceManagerDriver<YarnWorkerNode>
Exception
public void terminate() throws Exception
ResourceManagerDriver
Exception
public void deregisterApplication(ApplicationStatus finalStatus, @Nullable String optionalDiagnostics)
ResourceManagerDriver
This method also needs to make sure all pending containers that are not registered yet are returned.
finalStatus
- The application status to report.optionalDiagnostics
- A diagnostics message or null
.public CompletableFuture<YarnWorkerNode> requestResource(TaskExecutorProcessSpec taskExecutorProcessSpec)
ResourceManagerDriver
This method request a new resource from the external resource manager, and tries to launch a task manager inside the allocated resource, with respect to the provided taskExecutorProcessSpec. The returned future will be completed with a worker node in the deployment specific type, or exceptionally if the allocation has failed.
Note: The returned future could be cancelled by ResourceManager. This means ResourceManager don't need this resource anymore, Driver should try to cancel this request from the external resource manager.
Note: Completion of the returned future does not necessarily mean the success of resource
allocation and task manager launching. Allocation and launching failures can still happen
after the future completion. In such cases, ResourceEventHandler.onWorkerTerminated(org.apache.flink.runtime.clusterframework.types.ResourceID, java.lang.String)
will be called.
The future is guaranteed to be completed in the rpc main thread, before trying to launch
the task manager, thus before the task manager registration. It is also guaranteed that
ResourceEventHandler.onWorkerTerminated(org.apache.flink.runtime.clusterframework.types.ResourceID, java.lang.String)
will not be called on the requested worker,
until the returned future is completed successfully.
taskExecutorProcessSpec
- Resource specification of the requested worker.public void releaseResource(YarnWorkerNode workerNode)
ResourceManagerDriver
workerNode
- Worker node to be released, in the deployment specific type.public static String getContainerCompletedCause(org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.