All Classes Interface Summary Class Summary Enum Summary Exception Summary
Class |
Description |
AbstractFourLetterCommand |
Set of threads for command ports.
|
AclParser |
a parser for ACL strings
|
AddAuthCommand |
addAuth command for cli
|
AdminServer |
Interface for an embedded admin server that runs Commands.
|
AdminServer.AdminServerException |
|
AdminServerFactory |
Factory class for creating an AdminServer.
|
AsyncCallback |
Interface definitions of asynchronous callbacks.
|
AsyncCallback.ACLCallback |
This callback is used to retrieve the ACL and stat of the node.
|
AsyncCallback.Children2Callback |
This callback is used to retrieve the children and stat of the node.
|
AsyncCallback.ChildrenCallback |
This callback is used to retrieve the children of the node.
|
AsyncCallback.Create2Callback |
This callback is used to retrieve the name and stat of the node.
|
AsyncCallback.DataCallback |
This callback is used to retrieve the data and stat of the node.
|
AsyncCallback.MultiCallback |
This callback is used to process the multiple results from
a single multi call.
|
AsyncCallback.StatCallback |
This callback is used to retrieve the stat of the node.
|
AsyncCallback.StringCallback |
This callback is used to retrieve the name of the node.
|
AsyncCallback.VoidCallback |
This callback doesn't retrieve anything from the node.
|
AtomicFileOutputStream |
A FileOutputStream that has the property that it will only show up at its
destination once it has been entirely written and flushed to disk.
|
AtomicFileWritingIdiom |
|
AtomicFileWritingIdiom.OutputStreamStatement |
|
AtomicFileWritingIdiom.WriterStatement |
|
AuthenticationProvider |
This interface is implemented by authentication providers to add new kinds of
authentication schemes to ZooKeeper.
|
AuthFastLeaderElection |
Deprecated.
|
AuthFastLeaderElection.Notification |
|
AuthFastLeaderElection.ToSend |
|
BufferStats |
Provides live statistics about Jute buffer usage in term of proposal and client request size.
|
ByteBufferInputStream |
|
ByteBufferOutputStream |
|
CliCommand |
base class for all CLI commands
|
ClientCnxn |
This class manages the socket i/o for the client.
|
ClientCnxnSocketNetty |
ClientCnxnSocketNetty implements ClientCnxnSocket abstract methods.
|
ClientCnxnSocketNIO |
|
ClientWatchManager |
|
ClientX509Util |
|
CliException |
|
CliParseException |
|
CliWrapperException |
|
CloseCommand |
close command for cli
|
CnxnStatResetCommand |
|
Command |
Interface implemented by all commands runnable by JettyAdminServer.
|
CommandBase |
|
CommandExecutor |
|
CommandNotFoundException |
|
CommandOutputter |
CommandOutputters are used to format the responses from Commands.
|
CommandResponse |
|
Commands |
Class containing static methods for registering and running Commands, as well
as default Command definitions.
|
Commands.CnxnStatResetCommand |
Reset all connection statistics.
|
Commands.ConfCommand |
Server configuration parameters.
|
Commands.ConsCommand |
Information on client connections to server.
|
Commands.DirsCommand |
Information on ZK datadir and snapdir size in bytes
|
Commands.DumpCommand |
Information on session expirations and ephemerals.
|
Commands.EnvCommand |
All defined environment variables.
|
Commands.GetTraceMaskCommand |
The current trace mask.
|
Commands.IsroCommand |
Is this server in read-only mode.
|
Commands.MonitorCommand |
Some useful info for monitoring.
|
Commands.RuokCommand |
No-op command, check if the server is running
|
Commands.SetTraceMaskCommand |
Sets the trace mask.
|
Commands.SrvrCommand |
Server information.
|
Commands.StatCommand |
Same as SrvrCommand but has extra "connections" entry.
|
Commands.StatResetCommand |
Resets server statistics.
|
Commands.WatchCommand |
Watch information aggregated by session.
|
Commands.WatchesByPathCommand |
Watch information aggregated by path.
|
Commands.WatchSummaryCommand |
Summarized watch information.
|
CommitProcessor |
This RequestProcessor matches the incoming committed requests with the
locally submitted requests.
|
CommonNames |
A bunch of constants.
|
ConfCommand |
|
ConfigUtils |
|
ConnectionBean |
Implementation of connection MBean interface.
|
ConnectionMXBean |
This MBean represents a client connection.
|
ConnectStringParser |
A parser for ZooKeeper Client connect strings.
|
ConsCommand |
|
ContainerManager |
Manages cleanup of container ZNodes.
|
CreateCommand |
create command for cli
|
CreateMode |
CreateMode value determines how the znode is created on ZooKeeper.
|
DatadirCleanupManager |
This class manages the cleanup of snapshots and corresponding transaction
logs by scheduling the auto purge task with the specified
'autopurge.purgeInterval'.
|
DatadirCleanupManager.PurgeTaskStatus |
Status of the dataDir purge task
|
DataNode |
This class contains the data for a node in the data tree.
|
DataTree |
This class maintains the tree data structure.
|
DataTree.ProcessTxnResult |
|
DataTreeBean |
This class implements the data tree MBean.
|
DataTreeMXBean |
Zookeeper data tree MBean.
|
DeleteAllCommand |
deleteAll command for cli
|
DeleteCommand |
delete command for cli
|
DelQuotaCommand |
delQuota command for cli
|
DigestAuthenticationProvider |
|
DigestLoginModule |
|
DirsCommand |
|
DummyAdminServer |
An AdminServer that does nothing.
|
DumpCommand |
|
Election |
|
EnvCommand |
|
Environment |
Provide insight into the runtime environment.
|
Environment.Entry |
|
EphemeralType |
Abstraction that interprets the ephemeralOwner field of a ZNode.
|
EphemeralTypeEmulate353 |
See https://issues.apache.org/jira/browse/ZOOKEEPER-2901
version 3.5.3 introduced bugs associated with how TTL nodes were implemented.
|
ExitCode |
Exit code used to exit server
|
ExpiryQueue<E> |
ExpiryQueue tracks elements in time sorted fixed duration buckets.
|
FastLeaderElection |
Implementation of leader election using TCP.
|
FastLeaderElection.Notification |
Notifications are messages that let other peers know that
a given peer has changed its vote, either because it has
joined leader election or because it learned of another
peer with higher zxid or same zxid and higher server id
|
FastLeaderElection.ToSend |
Messages that a peer wants to send to other peers.
|
FileChangeWatcher |
Instances of this class can be used to watch a directory for file changes.
|
FileChangeWatcher.State |
|
FileKeyStoreLoaderBuilderProvider |
|
FilePadding |
|
FileSnap |
This class implements the snapshot interface.
|
FileTxnLog |
This class implements the TxnLog interface.
|
FileTxnLog.FileTxnIterator |
this class implements the txnlog iterator interface
which is used for reading the transaction logs
|
FileTxnSnapLog |
This is a helper class
above the implementations
of txnlog and snapshot
classes
|
FileTxnSnapLog.DatadirException |
|
FileTxnSnapLog.LogDirContentCheckException |
|
FileTxnSnapLog.PlayBackListener |
This listener helps
the external apis calling
restore to gather information
while the data is being
restored.
|
FileTxnSnapLog.SnapDirContentCheckException |
|
FinalRequestProcessor |
This Request processor actually applies any transaction associated with a
request and services any queries.
|
Follower |
This class has the control logic for the Follower.
|
FollowerBean |
Follower MBean interface implementation
|
FollowerMXBean |
Follower MBean
|
FollowerRequestProcessor |
This RequestProcessor forwards any requests that modify the state of the
system to the Leader.
|
FollowerZooKeeperServer |
Just like the standard ZooKeeperServer.
|
FourLetterCommands |
This class contains constants for all the four letter commands
|
FourLetterWordMain |
|
GetAclCommand |
getAcl command for cli
|
GetCommand |
get command for cli
|
GetConfigCommand |
get command for cli
|
HostProvider |
A set of hosts a ZooKeeper client should connect to.
|
Info |
|
IOUtils |
|
IPAuthenticationProvider |
|
IsroCommand |
|
JettyAdminServer |
This class encapsulates a Jetty server for running Commands.
|
JsonOutputter |
|
KeeperException |
|
KeeperException.APIErrorException |
|
KeeperException.AuthFailedException |
|
KeeperException.BadArgumentsException |
|
KeeperException.BadVersionException |
|
KeeperException.Code |
Codes which represent the various KeeperException
types.
|
KeeperException.CodeDeprecated |
Deprecated. |
KeeperException.ConnectionLossException |
|
KeeperException.DataInconsistencyException |
|
KeeperException.EphemeralOnLocalSessionException |
|
KeeperException.InvalidACLException |
|
KeeperException.InvalidCallbackException |
|
KeeperException.MarshallingErrorException |
|
KeeperException.NewConfigNoQuorum |
|
KeeperException.NoAuthException |
|
KeeperException.NoChildrenForEphemeralsException |
|
KeeperException.NodeExistsException |
|
KeeperException.NoNodeException |
|
KeeperException.NotEmptyException |
|
KeeperException.NotReadOnlyException |
|
KeeperException.NoWatcherException |
|
KeeperException.OperationTimeoutException |
|
KeeperException.ReconfigDisabledException |
|
KeeperException.ReconfigInProgress |
|
KeeperException.RequestTimeoutException |
|
KeeperException.RuntimeInconsistencyException |
|
KeeperException.SessionClosedRequireAuthException |
|
KeeperException.SessionExpiredException |
|
KeeperException.SessionMovedException |
|
KeeperException.SystemErrorException |
|
KeeperException.UnimplementedException |
|
KeeperException.UnknownSessionException |
|
KerberosName |
This class implements parsing and handling of Kerberos principal names.
|
KerberosName.BadFormatString |
|
KerberosName.NoMatchingRule |
|
KerberosUtil |
|
KeyStoreFileType |
This enum represents the file type of a KeyStore or TrustStore.
|
Leader |
This class has the control logic for the Leader.
|
Leader.Proposal |
|
Leader.XidRolloverException |
|
LeaderBean |
Leader MBean interface implementation.
|
LeaderElection |
Deprecated.
|
LeaderElection.ElectionResult |
|
LeaderElectionBean |
Leader election MBean interface implementation
|
LeaderElectionMXBean |
Leader election protocol MBean.
|
LeaderMXBean |
Leader MBean.
|
LeaderRequestProcessor |
Responsible for performing local session upgrade.
|
LeaderSessionTracker |
The leader session tracker tracks local and global sessions on the leader.
|
LeaderZooKeeperServer |
Just like the standard ZooKeeperServer.
|
Learner |
This class is the superclass of two of the three main actors in a ZK
ensemble: Followers and Observers.
|
LearnerHandler |
There will be an instance of this class created by the Leader for each
learner.
|
LearnerSessionTracker |
The learner session tracker is used by learners (followers and observers) to
track zookeeper sessions which may or may not be echoed to the leader.
|
LearnerSnapshot |
|
LearnerSnapshotThrottler |
Utility class to limit the number of concurrent snapshots from a leader to
observers and followers.
|
LearnerSyncRequest |
|
LearnerZooKeeperServer |
Parent class for all ZooKeeperServers for Learners
|
ListQuotaCommand |
listQuota command for cli
|
LocalPeerBean |
Implementation of the local peer MBean interface.
|
LocalPeerMXBean |
A local zookeeper server MBean interface.
|
LocalSessionTracker |
Local session tracker.
|
LogFormatter |
|
Login |
|
Ls2Command |
ls2 command for cli
|
LsCommand |
ls command for cli
|
MalformedCommandException |
|
MalformedPathException |
|
ManagedUtil |
Shared utilities
|
MBeanRegistry |
This class provides a unified interface for registering/unregistering of
zookeeper MBeans with the platform MBean server.
|
MonitorCommand |
|
MultiResponse |
Handles the response from a multi request.
|
MultiTransactionRecord |
Encodes a composite transaction.
|
NettyServerCnxn |
|
NettyServerCnxnFactory |
|
NettyUtils |
Helper methods for netty code.
|
NetUtils |
This class contains common utilities for netstuff.
|
NIOServerCnxn |
This class handles communication with clients using NIO.
|
NIOServerCnxnFactory |
NIOServerCnxnFactory implements a multi-threaded ServerCnxnFactory using
NIO non-blocking socket calls.
|
NopCommand |
A command that does not do anything except reply to client with predefined message.
|
NullQuorumAuthLearner |
This class represents no authentication learner, it just return
without performing any authentication.
|
NullQuorumAuthServer |
This class represents no authentication server, it just return
without performing any authentication.
|
Observer |
Observers are peers that do not take part in the atomic broadcast protocol.
|
ObserverBean |
ObserverBean
|
ObserverMXBean |
Observer MX Bean interface, implemented by ObserverBean
|
ObserverRequestProcessor |
This RequestProcessor forwards any requests that modify the state of the
system to the Leader.
|
ObserverZooKeeperServer |
A ZooKeeperServer for the Observer node type.
|
Op |
Represents a single operation in a multi-operation transaction.
|
Op.Check |
|
Op.Create |
|
Op.CreateTTL |
|
Op.Delete |
|
Op.SetData |
|
OpResult |
Encodes the result of a single part of a multiple operation commit.
|
OpResult.CheckResult |
A result from a version check operation.
|
OpResult.CreateResult |
A result from a create operation.
|
OpResult.DeleteResult |
A result from a delete operation.
|
OpResult.ErrorResult |
An error result from any kind of operation.
|
OpResult.SetDataResult |
A result from a setData operation.
|
OSMXBean |
This class is a wrapper for the implementation of
com.sun.management.UnixOperatingSystemMXBean
It will decide to use the sun api or its own implementation
depending on the runtime (vendor) used.
|
PathTrie |
a class that implements prefix matching for
components of a filesystem path.
|
PathUtils |
Path related utilities
|
PemReader |
Note: this class is copied from io.airlift.security.pem.PemReader (see
https://github.com/airlift/airlift/blob/master/security/src/main/java/io/airlift/security/pem/PemReader.java) with
permission of the authors, to avoid adding an extra library dependency to Zookeeper.
|
PrependableSocket |
|
PrepRequestProcessor |
This request processor is generally at the start of a RequestProcessor
change.
|
ProposalRequestProcessor |
This RequestProcessor simply forwards requests to an AckRequestProcessor and
SyncRequestProcessor.
|
ProviderRegistry |
|
PurgeTxnLog |
this class is used to clean up the
snapshot and data log dir's.
|
QuorumAuth |
|
QuorumAuth.Status |
|
QuorumAuthLearner |
Interface for quorum learner authentication mechanisms.
|
QuorumAuthServer |
Interface for quorum server authentication mechanisms.
|
QuorumBean |
|
QuorumCnxManager |
This class implements a connection manager for leader election using TCP.
|
QuorumCnxManager.InitialMessage |
|
QuorumCnxManager.InitialMessage.InitialMessageException |
|
QuorumCnxManager.Message |
|
QuorumHierarchical |
This class implements a validator for hierarchical quorums.
|
QuorumMaj |
This class implements a validator for majority quorums.
|
QuorumMXBean |
An MBean representing a zookeeper cluster nodes (aka quorum peers)
|
QuorumPeer |
This class manages the quorum protocol.
|
QuorumPeer.AddressTuple |
|
QuorumPeer.LearnerType |
|
QuorumPeer.QuorumServer |
|
QuorumPeer.ServerState |
|
QuorumPeerConfig |
|
QuorumPeerConfig.ConfigException |
|
QuorumPeerMain |
Configuration file
|
QuorumStats |
|
QuorumStats.Provider |
|
QuorumVerifier |
All quorum validators have to implement a method called
containsQuorum, which verifies if a HashSet of server
identifiers constitutes a quorum.
|
QuorumX509Util |
|
QuorumZooKeeperServer |
Abstract base class for all ZooKeeperServers that participate in
a quorum.
|
Quotas |
this class manages quotas
and has many other utils
for quota
|
RateLogger |
|
ReadOnlyBean |
ReadOnly MX Bean interface, implemented by ReadOnlyBean
|
ReadOnlyRequestProcessor |
This processor is at the beginning of the ReadOnlyZooKeeperServer's
processors chain.
|
ReadOnlyZooKeeperServer |
A ZooKeeperServer which comes into play when peer is partitioned from the
majority.
|
ReconfigCommand |
reconfig command for cli
|
ReferenceCountedACLCache |
|
RemotePeerBean |
A remote peer bean only provides limited information about the remote peer,
and the peer cannot be managed remotely.
|
RemotePeerMXBean |
A proxy for a remote quorum peer.
|
RemoveWatchesCommand |
Remove watches command for cli
|
Request |
This is the structure that represents a request moving through a chain of
RequestProcessors.
|
RequestProcessor |
RequestProcessors are chained together to process transactions.
|
RequestProcessor.RequestProcessorException |
|
RuokCommand |
|
SASLAuthenticationProvider |
|
SaslClientCallbackHandler |
This is used by the SASL mechanisms to get further information to complete
the authentication.
|
SaslQuorumAuthLearner |
|
SaslQuorumAuthServer |
|
SaslQuorumServerCallbackHandler |
This is used by the SASL mechanisms to get further information to complete
the authentication.
|
SaslServerCallbackHandler |
|
SaslServerPrincipal |
Computes the Server Principal for a SASL client.
|
SecurityUtils |
|
SendAckRequestProcessor |
|
SerializeUtils |
|
ServerAdminClient |
|
ServerBean |
An abstract base class for the leader and follower MBeans.
|
ServerCnxn |
Interface to a Server connection - represents a connection from a client
to the server.
|
ServerCnxn.CloseRequestException |
|
ServerCnxn.EndOfStreamException |
|
ServerCnxnFactory |
|
ServerConfig |
Server configuration storage.
|
ServerMXBean |
A quorum server MBean.
|
ServerStats |
Basic Server Statistics
|
ServerStats.Provider |
|
SessionTracker |
This is the basic interface that ZooKeeperServer uses to track sessions.
|
SessionTracker.Session |
|
SessionTracker.SessionExpirer |
|
SessionTrackerImpl |
This is a full featured SessionTracker.
|
SessionTrackerImpl.SessionImpl |
|
SetAclCommand |
setAcl command for cli.
|
SetCommand |
set command for cli
|
SetQuotaCommand |
setQuota command for cli
|
SetTraceMaskCommand |
|
Shell |
A base class for running a Unix command.
|
Shell.ExitCodeException |
This is an IOException with exit code added.
|
Shell.ShellCommandExecutor |
A simple shell command executor.
|
SnapShot |
snapshot interface for the persistence layer.
|
SnapshotFormatter |
Dump a snapshot file to stdout.
|
SnapshotThrottleException |
Thrown when a Leader has too many concurrent snapshots being sent
to observers.
|
SSLContextAndOptions |
Wrapper class for an SSLContext + some config options that can't be set on the context when it is created but
must be set on a secure socket created by the context after the socket creation.
|
StatCommand |
stat command for cli
|
StatCommand |
|
StateSummary |
This class encapsulates the state comparison logic.
|
StaticHostProvider |
Most simple HostProvider, resolves on every next() call.
|
StaticHostProvider.Resolver |
|
StatPrinter |
utility for printing stat values s
|
StatResetCommand |
|
StatsTrack |
a class that represents the stats associated with quotas
|
StringUtils |
|
SyncCommand |
sync command for cli
|
SyncedLearnerTracker |
|
SyncedLearnerTracker.QuorumVerifierAcksetPair |
|
SyncRequestProcessor |
This RequestProcessor logs requests to disk.
|
Testable |
Abstraction that exposes various methods useful for testing ZooKeeper
|
Time |
|
TraceFormatter |
|
TraceMaskCommand |
|
Transaction |
Provides a builder style interface for doing multiple updates.
|
TxnLog |
Interface for reading transaction logs.
|
TxnLog.TxnIterator |
an iterating interface for reading
transaction logs.
|
TxnLogProposalIterator |
This class provides an iterator interface to access Proposal deserialized
from on-disk txnlog.
|
TxnLogToolkit |
|
UnifiedServerSocket |
A ServerSocket that can act either as a regular ServerSocket, as a SSLServerSocket, or as both, depending on
the constructor parameters and on the type of client (TLS or plaintext) that connects to it.
|
UnifiedServerSocket.UnifiedSocket |
The result of calling accept() on a UnifiedServerSocket.
|
UnimplementedRequestProcessor |
Manages the unknown requests (i.e.
|
UpgradeableSessionTracker |
A session tracker that supports upgradeable local sessions.
|
Util |
A collection of utility methods for dealing with file name parsing,
low level I/O file operations and marshalling/unmarshalling.
|
VerGen |
|
VerGen.Version |
|
VerifyingFileFactory |
|
VerifyingFileFactory.Builder |
|
Version |
|
Vote |
|
WatchCommand |
|
WatchDeregistration |
Handles the special case of removing watches which has registered for a
client path
|
WatchedEvent |
A WatchedEvent represents a change on the ZooKeeper that a Watcher
is able to respond to.
|
Watcher |
This interface specifies the public interface an event handler class must
implement.
|
Watcher.Event |
This interface defines the possible states an Event may represent
|
Watcher.Event.EventType |
Enumeration of types of events that may occur on the ZooKeeper
|
Watcher.Event.KeeperState |
Enumeration of states the ZooKeeper may be at the event
|
Watcher.WatcherType |
Enumeration of types of watchers
|
WatchesPathReport |
A watch report, essentially a mapping of path to session IDs of sessions that
have set a watch on that path.
|
WatchesReport |
A watch report, essentially a mapping of session ID to paths that the session
has set a watch on.
|
WatchesSummary |
A summary of watch information.
|
WorkerService |
WorkerService is a worker thread pool for running tasks and is implemented
using one or more ExecutorServices.
|
WorkerService.WorkRequest |
Callers should implement a class extending WorkRequest in order to
schedule work with the service.
|
X509AuthenticationProvider |
An AuthenticationProvider backed by an X509TrustManager and an X509KeyManager
to perform remote host certificate authentication.
|
X509Exception |
|
X509Exception.KeyManagerException |
|
X509Exception.SSLContextException |
|
X509Exception.TrustManagerException |
|
X509Util |
Utility code for X509 handling
Default cipher suites:
Performance testing done by Facebook engineers shows that on Intel x86_64 machines, Java9 performs better with
GCM and Java8 performs better with CBC, so these seem like reasonable defaults.
|
X509Util.ClientAuth |
Enum specifying the client auth requirement of server-side TLS sockets created by this X509Util.
|
X509Util.CredStore |
|
ZKClientConfig |
Handles client specific properties
|
ZKConfig |
This class is a base class for the configurations of both client and server.
|
ZKDatabase |
This class maintains the in memory database of zookeeper
server states that includes the sessions, datatree and the
committed logs.
|
ZKFipsLoader |
The purpose of this class is to separate the importing of the Bouncy Castle jar
files from the classes where they are (conditionally) needed, as those classes
may also be used where the Bouncy Castle jar files are not in the classpath.
|
ZKMBeanInfo |
Zookeeper MBean info interface.
|
ZKTrustManager |
A custom TrustManager that supports hostname verification via org.apache.http.conn.ssl.DefaultHostnameVerifier.
|
ZKUtil |
|
ZooDefs |
|
ZooDefs.Ids |
|
ZooDefs.OpCode |
|
ZooDefs.Perms |
|
ZooKeeper |
This is the main class of ZooKeeper client library.
|
ZooKeeper.States |
|
ZooKeeperAdmin |
This is the main class for ZooKeeperAdmin client library.
|
ZooKeeperCriticalThread |
Represents critical thread.
|
ZooKeeperMain |
The command line client to ZooKeeper.
|
ZooKeeperSaslClient |
This class manages SASL authentication for the client.
|
ZooKeeperSaslClient.SaslState |
|
ZooKeeperSaslClient.ServerSaslResponseCallback |
|
ZooKeeperSaslServer |
|
ZooKeeperServer |
This class implements a simple standalone ZooKeeperServer.
|
ZooKeeperServer.MissingSessionException |
|
ZooKeeperServer.State |
|
ZooKeeperServerBean |
This class implements the ZooKeeper server MBean interface.
|
ZooKeeperServerConf |
|
ZooKeeperServerListener |
Listener for the critical resource events.
|
ZooKeeperServerMain |
This class starts and runs a standalone ZooKeeperServer.
|
ZooKeeperServerMXBean |
ZooKeeper server MBean.
|
ZooKeeperThread |
This is the main class for catching all the uncaught exceptions thrown by the
threads.
|
ZooTrace |
This class encapsulates and centralizes tracing for the ZooKeeper server.
|
ZxidUtils |
|