public class StandaloneHaServices extends AbstractNonHaServices
HighAvailabilityServices
for the non-high-availability case.
This implementation can be used for testing, and for cluster setups that do not tolerate failures
of the master processes (JobManager, ResourceManager).
This implementation has no dependencies on any external services. It returns a fix pre-configured ResourceManager and JobManager, and stores checkpoints and metadata simply on the heap or on a local file system and therefore in a storage without guarantees.
lock
DEFAULT_JOB_ID, DEFAULT_LEADER_ID
Constructor and Description |
---|
StandaloneHaServices(String resourceManagerAddress,
String dispatcherAddress,
String clusterRestEndpointAddress)
Creates a new services class for the fix pre-defined leaders.
|
Modifier and Type | Method and Description |
---|---|
LeaderElectionService |
getClusterRestEndpointLeaderElectionService()
Gets the leader election service for the cluster's rest endpoint.
|
LeaderRetrievalService |
getClusterRestEndpointLeaderRetriever()
Get the leader retriever for the cluster's rest endpoint.
|
LeaderElectionService |
getDispatcherLeaderElectionService()
Gets the leader election service for the cluster's dispatcher.
|
LeaderRetrievalService |
getDispatcherLeaderRetriever()
Gets the leader retriever for the dispatcher.
|
LeaderElectionService |
getJobManagerLeaderElectionService(JobID jobID)
Gets the leader election service for the given job.
|
LeaderRetrievalService |
getJobManagerLeaderRetriever(JobID jobID)
Gets the leader retriever for the job JobMaster which is responsible for the given job.
|
LeaderRetrievalService |
getJobManagerLeaderRetriever(JobID jobID,
String defaultJobManagerAddress)
Gets the leader retriever for the job JobMaster which is responsible for the given job.
|
LeaderElectionService |
getResourceManagerLeaderElectionService()
Gets the leader election service for the cluster's resource manager.
|
LeaderRetrievalService |
getResourceManagerLeaderRetriever()
Gets the leader retriever for the cluster's resource manager.
|
checkNotShutdown, close, closeAndCleanupAllData, createBlobStore, getCheckpointRecoveryFactory, getJobGraphStore, getRunningJobsRegistry, isShutDown
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
cleanupJobData, getWebMonitorLeaderElectionService, getWebMonitorLeaderRetriever
public StandaloneHaServices(String resourceManagerAddress, String dispatcherAddress, String clusterRestEndpointAddress)
resourceManagerAddress
- The fix address of the ResourceManagerclusterRestEndpointAddress
- public LeaderRetrievalService getResourceManagerLeaderRetriever()
HighAvailabilityServices
public LeaderRetrievalService getDispatcherLeaderRetriever()
HighAvailabilityServices
public LeaderElectionService getResourceManagerLeaderElectionService()
HighAvailabilityServices
public LeaderElectionService getDispatcherLeaderElectionService()
HighAvailabilityServices
public LeaderRetrievalService getJobManagerLeaderRetriever(JobID jobID)
HighAvailabilityServices
jobID
- The identifier of the job.public LeaderRetrievalService getJobManagerLeaderRetriever(JobID jobID, String defaultJobManagerAddress)
HighAvailabilityServices
jobID
- The identifier of the job.defaultJobManagerAddress
- JobManager address which will be returned by a static leader
retrieval service.public LeaderElectionService getJobManagerLeaderElectionService(JobID jobID)
HighAvailabilityServices
jobID
- The identifier of the job running the election.public LeaderRetrievalService getClusterRestEndpointLeaderRetriever()
ClientHighAvailabilityServices
public LeaderElectionService getClusterRestEndpointLeaderElectionService()
HighAvailabilityServices
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.