public class ZooKeeperLeaderElectionDriverFactory extends Object implements LeaderElectionDriverFactory
LeaderElectionDriverFactory
implementation for Zookeeper.Constructor and Description |
---|
ZooKeeperLeaderElectionDriverFactory(org.apache.flink.shaded.curator5.org.apache.curator.framework.CuratorFramework client,
String path)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
ZooKeeperLeaderElectionDriver |
createLeaderElectionDriver(LeaderElectionEventHandler leaderEventHandler,
FatalErrorHandler fatalErrorHandler)
Deprecated.
Create a specific
LeaderElectionDriver and start the necessary services. |
public ZooKeeperLeaderElectionDriverFactory(org.apache.flink.shaded.curator5.org.apache.curator.framework.CuratorFramework client, String path)
public ZooKeeperLeaderElectionDriver createLeaderElectionDriver(LeaderElectionEventHandler leaderEventHandler, FatalErrorHandler fatalErrorHandler) throws Exception
LeaderElectionDriverFactory
LeaderElectionDriver
and start the necessary services. For example,
LeaderLatch and NodeCache in Zookeeper, KubernetesLeaderElector and ConfigMap watcher in
Kubernetes.createLeaderElectionDriver
in interface LeaderElectionDriverFactory
leaderEventHandler
- handler for the leader election driver to process leader events.fatalErrorHandler
- fatal error handlerException
- when create a specific LeaderElectionDriver
implementation and
start the necessary services.Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.