public class ZooKeeperMultipleComponentLeaderElectionHaServices extends AbstractZooKeeperHaServices
/flink +/cluster_id_1/leader/latch | | /resource_manager/connection_info | | /dispatcher/connection_info | | /rest_server/connection_info | | /job-id-1/connection_info | | /job-id-2/connection_info | | | | | +jobgraphs/job-id-1 | | /job-id-2 | +jobs/job-id-1/checkpoints/latest | | /latest-1 | | /latest-2 | | /checkpoint_id_counter
configuration, ioExecutor, logger
DEFAULT_JOB_ID, DEFAULT_LEADER_ID
Constructor and Description |
---|
ZooKeeperMultipleComponentLeaderElectionHaServices(CuratorFrameworkWithUnhandledErrorListener curatorFrameworkWrapper,
Configuration config,
Executor ioExecutor,
BlobStoreService blobStoreService,
FatalErrorHandler fatalErrorHandler) |
Modifier and Type | Method and Description |
---|---|
protected LeaderElectionService |
createLeaderElectionService(String leaderName)
Create leader election service with specified leaderName.
|
protected LeaderRetrievalService |
createLeaderRetrievalService(String leaderPath)
Create leader retrieval service with specified leaderName.
|
protected String |
getLeaderPathForDispatcher()
Get the leader path for Dispatcher.
|
protected String |
getLeaderPathForJobManager(JobID jobID)
Get the leader path for specific JobManager.
|
protected String |
getLeaderPathForResourceManager()
Get the leader path for ResourceManager.
|
protected String |
getLeaderPathForRestServer()
Get the leader path for RestServer.
|
protected void |
internalClose()
Closes the components which is used for external operations(e.g.
|
createCheckpointRecoveryFactory, createJobGraphStore, deleteZNode, getCuratorFramework, internalCleanup, internalCleanupJobData
close, closeAndCleanupAllData, createBlobStore, getCheckpointRecoveryFactory, getClusterRestEndpointLeaderElectionService, getClusterRestEndpointLeaderRetriever, getDispatcherLeaderElectionService, getDispatcherLeaderRetriever, getJobGraphStore, getJobManagerLeaderElectionService, getJobManagerLeaderRetriever, getJobManagerLeaderRetriever, getJobResultStore, getResourceManagerLeaderElectionService, getResourceManagerLeaderRetriever, globalCleanupAsync
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getWebMonitorLeaderElectionService, getWebMonitorLeaderRetriever
public ZooKeeperMultipleComponentLeaderElectionHaServices(CuratorFrameworkWithUnhandledErrorListener curatorFrameworkWrapper, Configuration config, Executor ioExecutor, BlobStoreService blobStoreService, FatalErrorHandler fatalErrorHandler) throws Exception
Exception
protected LeaderElectionService createLeaderElectionService(String leaderName)
AbstractHaServices
createLeaderElectionService
in class AbstractHaServices
leaderName
- ConfigMap name in Kubernetes or child node path in Zookeeper.protected LeaderRetrievalService createLeaderRetrievalService(String leaderPath)
AbstractHaServices
createLeaderRetrievalService
in class AbstractHaServices
leaderPath
- ConfigMap name in Kubernetes or child node path in Zookeeper.protected void internalClose() throws Exception
AbstractHaServices
internalClose
in class AbstractZooKeeperHaServices
Exception
- if the close operation failedprotected String getLeaderPathForResourceManager()
AbstractHaServices
getLeaderPathForResourceManager
in class AbstractHaServices
protected String getLeaderPathForDispatcher()
AbstractHaServices
getLeaderPathForDispatcher
in class AbstractHaServices
protected String getLeaderPathForJobManager(JobID jobID)
AbstractHaServices
getLeaderPathForJobManager
in class AbstractHaServices
jobID
- job idprotected String getLeaderPathForRestServer()
AbstractHaServices
getLeaderPathForRestServer
in class AbstractHaServices
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.