Interface | Description |
---|---|
LeaderContender |
Interface which has to be implemented to take part in the leader election process of the
LeaderElectionService . |
LeaderElectionDriver |
A
LeaderElectionDriver is responsible for performing the leader election and storing the
leader information. |
LeaderElectionDriverFactory |
Factory for creating
LeaderElectionDriver with different implementation. |
LeaderElectionEventHandler |
Interface which should be implemented to respond to leader changes in
LeaderElectionDriver . |
LeaderElectionService |
Interface for a service which allows to elect a leader among a group of contenders.
|
Class | Description |
---|---|
DefaultLeaderElectionService |
Default implementation for leader election service.
|
LeaderInformation |
Information about leader including the confirmed leader session id and leader address.
|
StandaloneLeaderElectionService |
Standalone implementation of the
LeaderElectionService interface. |
ZooKeeperLeaderElectionDriver |
LeaderElectionDriver implementation for Zookeeper. |
ZooKeeperLeaderElectionDriverFactory |
LeaderElectionDriverFactory implementation for Zookeeper. |
Exception | Description |
---|---|
LeaderElectionException |
This exception is thrown by the
LeaderElectionDriver when LeaderElectionDriver.writeLeaderInformation(org.apache.flink.runtime.leaderelection.LeaderInformation) failed or some unexpected changes to the leader
storage. |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.