public class ZooKeeperMultipleComponentLeaderElectionDriverFactory extends Object implements MultipleComponentLeaderElectionDriverFactory
ZooKeeperMultipleComponentLeaderElectionDriver
.Constructor and Description |
---|
ZooKeeperMultipleComponentLeaderElectionDriverFactory(org.apache.flink.shaded.curator5.org.apache.curator.framework.CuratorFramework curatorFramework) |
Modifier and Type | Method and Description |
---|---|
ZooKeeperMultipleComponentLeaderElectionDriver |
create(MultipleComponentLeaderElectionDriver.Listener leaderElectionListener)
Creates a
MultipleComponentLeaderElectionDriver for the given leader contender
description. |
public ZooKeeperMultipleComponentLeaderElectionDriverFactory(org.apache.flink.shaded.curator5.org.apache.curator.framework.CuratorFramework curatorFramework)
public ZooKeeperMultipleComponentLeaderElectionDriver create(MultipleComponentLeaderElectionDriver.Listener leaderElectionListener) throws Exception
MultipleComponentLeaderElectionDriverFactory
MultipleComponentLeaderElectionDriver
for the given leader contender
description. Moreover, it registers the given leader election listener with the service.create
in interface MultipleComponentLeaderElectionDriverFactory
leaderElectionListener
- listener for the callbacks of the MultipleComponentLeaderElectionDriver
MultipleComponentLeaderElectionDriver
instanceException
- if the creation failsCopyright © 2014–2024 The Apache Software Foundation. All rights reserved.