A B C D E F G H I J K L M N O P Q R S T U V W X Z
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- abort() - Method in class org.apache.zookeeper.common.AtomicFileOutputStream
-
Close the atomic file, but do not "commit" the temporary file on top of the destination.
- abort() - Method in class org.apache.zookeeper.server.auth.DigestLoginModule
- ACCEPTED_EPOCH_FILENAME - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
- ACKEPOCH - Static variable in class org.apache.zookeeper.server.quorum.Leader
-
This message is used by the follow to ack a proposed epoch.
- ackSet - Variable in class org.apache.zookeeper.server.quorum.Leader.Proposal
- acl - Variable in class org.apache.zookeeper.server.upgrade.DataNodeV1
- ACL - Class in org.apache.zookeeper.data
- ACL() - Constructor for class org.apache.zookeeper.data.ACL
- ACL(int, Id) - Constructor for class org.apache.zookeeper.data.ACL
- aclCacheSize() - Method in class org.apache.zookeeper.server.DataTree
- aclForNode(DataNode) - Method in class org.apache.zookeeper.server.ZKDatabase
- add(Op) - Method in class org.apache.zookeeper.MultiTransactionRecord
- add(OpResult) - Method in class org.apache.zookeeper.MultiResponse
- addAuthInfo(String, byte[]) - Method in class org.apache.zookeeper.ClientCnxn
- addAuthInfo(String, byte[]) - Method in class org.apache.zookeeper.ZooKeeper
-
Add the specified scheme:auth information to this connection.
- addAuthInfo(Id) - Method in class org.apache.zookeeper.server.ServerCnxn
- addChild(String) - Method in class org.apache.zookeeper.server.DataNode
-
Method that inserts a child into the children set
- addCommittedProposal(Request) - Method in class org.apache.zookeeper.server.ZKDatabase
-
maintains a list of last committedLog or so committed requests.
- addDataNode(String, DataNode) - Method in class org.apache.zookeeper.server.DataTree
-
just an accessor method to allow raw creation of datatree's from a bunch of datanodes
- addPath(String) - Method in class org.apache.zookeeper.common.PathTrie
-
add a path to the path trie
- addr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
- addSession(long, int) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
- addSession(long, int) - Method in interface org.apache.zookeeper.server.SessionTracker
- addSession(long, int) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
- addSession(long, ServerCnxn) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- addToHistory(int, String) - Method in class org.apache.zookeeper.ZooKeeperMain
-
Makes a list of possible completions, either for commands or for zk nodes if the token to complete begins with /
- addToRecvQueue(QuorumCnxManager.Message) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Inserts an element in the
QuorumCnxManager.recvQueue
. - addUsage(Long) - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
- addWatch(String, Watcher) - Method in class org.apache.zookeeper.server.WatchManager
- ADMIN - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
- ALL - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
- ANYONE_ID_UNSAFE - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
-
This Id represents anyone.
- APIError - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.APIERROR
instead - APIERROR - org.apache.zookeeper.KeeperException.Code
-
API errors.
- APIErrorException() - Constructor for exception org.apache.zookeeper.KeeperException.APIErrorException
- append(Request) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
append the request to the transaction logs
- append(Request) - Method in class org.apache.zookeeper.server.ZKDatabase
-
append to the underlying transaction log
- append(TxnHeader, Record) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
append an entry to the transaction log
- append(TxnHeader, Record) - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
Append a request to the transaction log
- approximateDataSize() - Method in class org.apache.zookeeper.server.DataTree
-
Get the size of the nodes based on path and data length.
- approximateDataSize() - Method in class org.apache.zookeeper.server.DataTreeBean
- approximateDataSize() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
- ASSOCIATING - org.apache.zookeeper.ZooKeeper.States
- AsyncCallback - Interface in org.apache.zookeeper
-
Interface definitions of asynchronous callbacks.
- AsyncCallback.ACLCallback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the ACL and stat of the node.
- AsyncCallback.Children2Callback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the children and stat of the node.
- AsyncCallback.ChildrenCallback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the children of the node.
- AsyncCallback.DataCallback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the data and stat of the node.
- AsyncCallback.MultiCallback - Interface in org.apache.zookeeper
-
This callback is used to process the multiple results from a single multi call.
- AsyncCallback.StatCallback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the stat of the node.
- AsyncCallback.StringCallback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the name of the node.
- AsyncCallback.VoidCallback - Interface in org.apache.zookeeper
-
This callback doesn't retrieve anything from the node.
- AtomicFileOutputStream - Class in org.apache.zookeeper.common
-
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.
- AtomicFileOutputStream(File) - Constructor for class org.apache.zookeeper.common.AtomicFileOutputStream
- auth - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- AUTH_FAILED - org.apache.zookeeper.ZooKeeper.States
- AUTH_IDS - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
-
This Id is only usable to set ACLs.
- authenticate(Socket, DataInputStream) - Method in class org.apache.zookeeper.server.quorum.auth.NullQuorumAuthServer
- authenticate(Socket, DataInputStream) - Method in interface org.apache.zookeeper.server.quorum.auth.QuorumAuthServer
-
Performs an authentication step for the given socket connection.
- authenticate(Socket, DataInputStream) - Method in class org.apache.zookeeper.server.quorum.auth.SaslQuorumAuthServer
- authenticate(Socket, String) - Method in class org.apache.zookeeper.server.quorum.auth.NullQuorumAuthLearner
- authenticate(Socket, String) - Method in interface org.apache.zookeeper.server.quorum.auth.QuorumAuthLearner
-
Performs an authentication step for the given socket connection.
- authenticate(Socket, String) - Method in class org.apache.zookeeper.server.quorum.auth.SaslQuorumAuthLearner
- AuthenticationProvider - Interface in org.apache.zookeeper.server.auth
-
This interface is implemented by authentication providers to add new kinds of authentication schemes to ZooKeeper.
- AuthFailed - org.apache.zookeeper.Watcher.Event.KeeperState
-
Auth failed state
- AuthFailed - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.AUTHFAILED
instead - AUTHFAILED - org.apache.zookeeper.KeeperException.Code
-
Client authentication failed
- AuthFailedException() - Constructor for exception org.apache.zookeeper.KeeperException.AuthFailedException
- AuthFastLeaderElection - Class in org.apache.zookeeper.server.quorum
-
Deprecated.This class has been deprecated as of release 3.4.0.
- AuthFastLeaderElection(QuorumPeer) - Constructor for class org.apache.zookeeper.server.quorum.AuthFastLeaderElection
-
Deprecated.
- AuthFastLeaderElection(QuorumPeer, boolean) - Constructor for class org.apache.zookeeper.server.quorum.AuthFastLeaderElection
-
Deprecated.
- AuthFastLeaderElection.Notification - Class in org.apache.zookeeper.server.quorum
-
Deprecated.
- AuthFastLeaderElection.ToSend - Class in org.apache.zookeeper.server.quorum
-
Deprecated.
- authInfo - Variable in class org.apache.zookeeper.server.Request
- authInfo - Variable in class org.apache.zookeeper.server.ServerCnxn
- AuthPacket - Class in org.apache.zookeeper.proto
- AuthPacket() - Constructor for class org.apache.zookeeper.proto.AuthPacket
- AuthPacket(int, String, byte[]) - Constructor for class org.apache.zookeeper.proto.AuthPacket
- available() - Method in class org.apache.zookeeper.server.ByteBufferInputStream
B
- BadArguments - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.BADARGUMENTS
instead - BADARGUMENTS - org.apache.zookeeper.KeeperException.Code
-
Invalid arguments
- BadArgumentsException() - Constructor for exception org.apache.zookeeper.KeeperException.BadArgumentsException
- BadArgumentsException(String) - Constructor for exception org.apache.zookeeper.KeeperException.BadArgumentsException
- BadVersion - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.BADVERSION
instead - BADVERSION - org.apache.zookeeper.KeeperException.Code
-
Version conflict
- BadVersionException() - Constructor for exception org.apache.zookeeper.KeeperException.BadVersionException
- BadVersionException(String) - Constructor for exception org.apache.zookeeper.KeeperException.BadVersionException
- BasicDataTreeBuilder() - Constructor for class org.apache.zookeeper.server.ZooKeeperServer.BasicDataTreeBuilder
- bufferedOutput - Variable in class org.apache.zookeeper.server.quorum.Learner
- build() - Method in class org.apache.zookeeper.server.ZooKeeperServer.BasicDataTreeBuilder
- build() - Method in interface org.apache.zookeeper.server.ZooKeeperServer.DataTreeBuilder
- BUILD_DATE - Static variable in interface org.apache.zookeeper.version.Info
- byteBuffer2Record(ByteBuffer, Record) - Static method in class org.apache.zookeeper.server.ByteBufferInputStream
- ByteBufferInputStream - Class in org.apache.zookeeper.server
- ByteBufferInputStream(ByteBuffer) - Constructor for class org.apache.zookeeper.server.ByteBufferInputStream
- ByteBufferOutputStream - Class in org.apache.zookeeper.server
- ByteBufferOutputStream(ByteBuffer) - Constructor for class org.apache.zookeeper.server.ByteBufferOutputStream
C
- calculateFileSizeWithPadding(long, long, long) - Static method in class org.apache.zookeeper.server.persistence.FilePadding
-
Calculates a new file size with padding.
- callbackHandler - Variable in class org.apache.zookeeper.Login
- canShutdown() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
This can be used while shutting down the server to see whether the server is already shutdown or not.
- check - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- check(String, int) - Static method in class org.apache.zookeeper.Op
-
Constructs an version check operation.
- check(String, int) - Method in class org.apache.zookeeper.Transaction
- checkLeader(HashMap<Long, Vote>, long, long) - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
-
In the case there is a leader elected, and a quorum supporting this leader, we have to check if the leader has voted and acked that it is leading.
- checkPasswd(long, byte[]) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- CheckResult() - Constructor for class org.apache.zookeeper.OpResult.CheckResult
- checkSession(long, Object) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
- checkSession(long, Object) - Method in interface org.apache.zookeeper.server.SessionTracker
- checkSession(long, Object) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
- CheckVersionRequest - Class in org.apache.zookeeper.proto
- CheckVersionRequest() - Constructor for class org.apache.zookeeper.proto.CheckVersionRequest
- CheckVersionRequest(String, int) - Constructor for class org.apache.zookeeper.proto.CheckVersionRequest
- CheckVersionTxn - Class in org.apache.zookeeper.txn
- CheckVersionTxn() - Constructor for class org.apache.zookeeper.txn.CheckVersionTxn
- CheckVersionTxn(String, int) - Constructor for class org.apache.zookeeper.txn.CheckVersionTxn
- cl - Variable in class org.apache.zookeeper.ZooKeeperMain
- cleanup(Logger, Closeable...) - Static method in class org.apache.zookeeper.common.IOUtils
-
Close the Closeable objects and ignore any
IOException
or null pointers. - clear() - Method in class org.apache.zookeeper.common.PathTrie
-
clear all nodes
- clear() - Method in class org.apache.zookeeper.server.DataTree
- clear() - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- clear() - Method in class org.apache.zookeeper.server.ZKDatabase
-
clear the zkdatabase.
- CLIENT_DATA_PACKET_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
- CLIENT_PING_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
- CLIENT_REQUEST_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
- ClientCnxn - Class in org.apache.zookeeper
-
This class manages the socket i/o for the client.
- ClientCnxn(String, HostProvider, int, ZooKeeper, ClientWatchManager, ClientCnxnSocket, boolean) - Constructor for class org.apache.zookeeper.ClientCnxn
-
Creates a connection object.
- ClientCnxn(String, HostProvider, int, ZooKeeper, ClientWatchManager, ClientCnxnSocket, long, byte[], boolean) - Constructor for class org.apache.zookeeper.ClientCnxn
-
Creates a connection object.
- ClientCnxnSocketNIO - Class in org.apache.zookeeper
- clientId - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
- clientId - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
- clientPortAddress - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- clientPortAddress - Variable in class org.apache.zookeeper.server.ServerConfig
- clientTunneledAuthenticationInProgress() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
- ClientWatchManager - Interface in org.apache.zookeeper
- close() - Method in class org.apache.zookeeper.ClientCnxn
-
Close the connection, which includes; send session disconnect to the server, shutdown the send/event threads.
- close() - Method in class org.apache.zookeeper.common.AtomicFileOutputStream
- close() - Method in class org.apache.zookeeper.server.NettyServerCnxn
- close() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- close() - Method in class org.apache.zookeeper.server.persistence.FileSnap
-
synchronized close just so that if serialize is in place the close operation will block and will wait till serialize is done and will set the close flag
- close() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
close all the open file handles
- close() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
close the iterator and release the resources.
- close() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
close the transaction log files
- close() - Method in interface org.apache.zookeeper.server.persistence.SnapShot
-
free resources from this snapshot immediately
- close() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
close the transactions logs
- close() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
-
close files and release the resources
- close() - Method in class org.apache.zookeeper.server.persistence.TxnLogToolkit
- close() - Method in class org.apache.zookeeper.server.ZKDatabase
-
close this database.
- close() - Method in class org.apache.zookeeper.ZooKeeper
-
Close this client object.
- closeAll() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
- closeAll() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
clear all the connections in the selector
- closeAll() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- CLOSED - org.apache.zookeeper.ZooKeeper.States
- CloseRequestException(String) - Constructor for exception org.apache.zookeeper.server.ServerCnxn.CloseRequestException
- closeSession - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- closeSession(long) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
- closeSession(long) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- closeSession(long) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- closeSession(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- closeSession(ServerCnxn, RequestHeader) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- closeStream(Closeable) - Static method in class org.apache.zookeeper.common.IOUtils
-
Closes the stream ignoring
IOException
. - cnxn - Variable in class org.apache.zookeeper.server.Request
- cnxn - Variable in class org.apache.zookeeper.ZooKeeper
- cnxns - Variable in class org.apache.zookeeper.server.ServerCnxnFactory
- code() - Method in exception org.apache.zookeeper.KeeperException
-
Read the error Code for this exception
- commandCount - Variable in class org.apache.zookeeper.ZooKeeperMain
- commit() - Method in class org.apache.zookeeper.server.auth.DigestLoginModule
- commit() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
commit the logs.
- commit() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
commit the transaction of logs
- commit() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
commmit the trasaction and make sure they are persisted
- commit() - Method in class org.apache.zookeeper.server.ZKDatabase
-
commit to the underlying transaction log
- commit() - Method in class org.apache.zookeeper.Transaction
- commit(long) - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
-
When a COMMIT message is received, eventually this method is called, which matches up the zxid from the COMMIT with (hopefully) the head of the pendingTxns queue and hands it to the commitProcessor to commit.
- commit(long) - Method in class org.apache.zookeeper.server.quorum.Leader
-
Create a commit packet and send it to all the members of the quorum
- commit(AsyncCallback.MultiCallback, Object) - Method in class org.apache.zookeeper.Transaction
- commit(Request) - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
- commitLogBuffer - Static variable in class org.apache.zookeeper.server.ZKDatabase
- commitLogCount - Static variable in class org.apache.zookeeper.server.ZKDatabase
- CommitProcessor - Class in org.apache.zookeeper.server.quorum
-
This RequestProcessor matches the incoming committed requests with the locally submitted requests.
- CommitProcessor(RequestProcessor, String, boolean, ZooKeeperServerListener) - Constructor for class org.apache.zookeeper.server.quorum.CommitProcessor
- commitRequest(Request) - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
-
Unlike a Follower, which sees a full request only during the PROPOSAL phase, Observers get all the data required with the INFORM packet.
- committedLog - Variable in class org.apache.zookeeper.server.ZKDatabase
- CommonNames - Class in org.apache.zookeeper.jmx
-
A bunch of constants.
- CommonNames() - Constructor for class org.apache.zookeeper.jmx.CommonNames
- compareTo(Object) - Method in class org.apache.zookeeper.data.ACL
- compareTo(Object) - Method in class org.apache.zookeeper.data.Id
- compareTo(Object) - Method in class org.apache.zookeeper.data.Stat
- compareTo(Object) - Method in class org.apache.zookeeper.data.StatPersisted
- compareTo(Object) - Method in class org.apache.zookeeper.data.StatPersistedV1
- compareTo(Object) - Method in class org.apache.zookeeper.proto.AuthPacket
- compareTo(Object) - Method in class org.apache.zookeeper.proto.CheckVersionRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.ConnectRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.ConnectResponse
- compareTo(Object) - Method in class org.apache.zookeeper.proto.CreateRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.CreateResponse
- compareTo(Object) - Method in class org.apache.zookeeper.proto.DeleteRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.ErrorResponse
- compareTo(Object) - Method in class org.apache.zookeeper.proto.ExistsRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.ExistsResponse
- compareTo(Object) - Method in class org.apache.zookeeper.proto.GetACLRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.GetACLResponse
- compareTo(Object) - Method in class org.apache.zookeeper.proto.GetChildren2Request
- compareTo(Object) - Method in class org.apache.zookeeper.proto.GetChildren2Response
- compareTo(Object) - Method in class org.apache.zookeeper.proto.GetChildrenRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.GetChildrenResponse
- compareTo(Object) - Method in class org.apache.zookeeper.proto.GetDataRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.GetDataResponse
- compareTo(Object) - Method in class org.apache.zookeeper.proto.GetMaxChildrenRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.GetMaxChildrenResponse
- compareTo(Object) - Method in class org.apache.zookeeper.proto.GetSASLRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.MultiHeader
- compareTo(Object) - Method in class org.apache.zookeeper.proto.ReplyHeader
- compareTo(Object) - Method in class org.apache.zookeeper.proto.RequestHeader
- compareTo(Object) - Method in class org.apache.zookeeper.proto.SetACLRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.SetACLResponse
- compareTo(Object) - Method in class org.apache.zookeeper.proto.SetDataRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.SetDataResponse
- compareTo(Object) - Method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.SetSASLRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.SetSASLResponse
- compareTo(Object) - Method in class org.apache.zookeeper.proto.SetWatches
- compareTo(Object) - Method in class org.apache.zookeeper.proto.SyncRequest
- compareTo(Object) - Method in class org.apache.zookeeper.proto.SyncResponse
- compareTo(Object) - Method in class org.apache.zookeeper.proto.WatcherEvent
- compareTo(Object) - Method in class org.apache.zookeeper.server.persistence.FileHeader
- compareTo(Object) - Method in class org.apache.zookeeper.server.quorum.LearnerInfo
- compareTo(Object) - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- compareTo(Object) - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- compareTo(Object) - Method in class org.apache.zookeeper.txn.CheckVersionTxn
- compareTo(Object) - Method in class org.apache.zookeeper.txn.CreateSessionTxn
- compareTo(Object) - Method in class org.apache.zookeeper.txn.CreateTxn
- compareTo(Object) - Method in class org.apache.zookeeper.txn.CreateTxnV0
- compareTo(Object) - Method in class org.apache.zookeeper.txn.DeleteTxn
- compareTo(Object) - Method in class org.apache.zookeeper.txn.ErrorTxn
- compareTo(Object) - Method in class org.apache.zookeeper.txn.MultiTxn
- compareTo(Object) - Method in class org.apache.zookeeper.txn.SetACLTxn
- compareTo(Object) - Method in class org.apache.zookeeper.txn.SetDataTxn
- compareTo(Object) - Method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- compareTo(Object) - Method in class org.apache.zookeeper.txn.Txn
- compareTo(Object) - Method in class org.apache.zookeeper.txn.TxnHeader
- COMPLETE - org.apache.zookeeper.client.ZooKeeperSaslClient.SaslState
- COMPLETED - org.apache.zookeeper.server.DatadirCleanupManager.PurgeTaskStatus
- confCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- ConfigException(String) - Constructor for exception org.apache.zookeeper.server.quorum.QuorumPeerConfig.ConfigException
- ConfigException(String, Exception) - Constructor for exception org.apache.zookeeper.server.quorum.QuorumPeerConfig.ConfigException
- configure(InetSocketAddress, int) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
- configure(InetSocketAddress, int) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- configure(InetSocketAddress, int) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- configureSaslLogin() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
Initialize the server SASL if specified.
- connectAll() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Try to establish a connection with each server if one doesn't exist.
- CONNECTED - org.apache.zookeeper.ZooKeeper.States
- ConnectedReadOnly - org.apache.zookeeper.Watcher.Event.KeeperState
-
The client is connected to a read-only server, that is the server which is not currently connected to the majority.
- CONNECTEDREADONLY - org.apache.zookeeper.ZooKeeper.States
- connectedToPeer(long) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
- CONNECTING - org.apache.zookeeper.ZooKeeper.States
- connectingFollowers - Variable in class org.apache.zookeeper.server.quorum.Leader
- ConnectionBean - Class in org.apache.zookeeper.server
-
Implementation of connection MBean interface.
- ConnectionBean(ServerCnxn, ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.ConnectionBean
- ConnectionLoss - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.CONNECTIONLOSS
instead - CONNECTIONLOSS - org.apache.zookeeper.KeeperException.Code
-
Connection to the server has been lost
- ConnectionLossException() - Constructor for exception org.apache.zookeeper.KeeperException.ConnectionLossException
- ConnectionMXBean - Interface in org.apache.zookeeper.server
-
This MBean represents a client connection.
- connectOne(long) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Try to establish a connection to server with id sid.
- ConnectRequest - Class in org.apache.zookeeper.proto
- ConnectRequest() - Constructor for class org.apache.zookeeper.proto.ConnectRequest
- ConnectRequest(int, long, int, long, byte[]) - Constructor for class org.apache.zookeeper.proto.ConnectRequest
- ConnectResponse - Class in org.apache.zookeeper.proto
- ConnectResponse() - Constructor for class org.apache.zookeeper.proto.ConnectResponse
- ConnectResponse(int, int, long, byte[]) - Constructor for class org.apache.zookeeper.proto.ConnectResponse
- ConnectStringParser - Class in org.apache.zookeeper.client
-
A parser for ZooKeeper Client connect strings.
- ConnectStringParser(String) - Constructor for class org.apache.zookeeper.client.ConnectStringParser
- connectToLeader(InetSocketAddress, String) - Method in class org.apache.zookeeper.server.quorum.Learner
-
Establish a connection with the Leader found by findLeader.
- connectToZK(String) - Method in class org.apache.zookeeper.ZooKeeperMain
- consCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- containsQuorum(Set<Long>) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
-
Verifies if a given set is a quorum.
- containsQuorum(Set<Long>) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
-
Verifies if a set is a majority.
- containsQuorum(Set<Long>) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
- convertAcls(List<ACL>) - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
-
converts the list of acls to a long.
- convertLong(Long) - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
-
converts a long to a list of acls.
- copyBytes(InputStream, OutputStream, int) - Static method in class org.apache.zookeeper.common.IOUtils
-
Copies from one stream to another.
- copyBytes(InputStream, OutputStream, int, boolean) - Static method in class org.apache.zookeeper.common.IOUtils
-
Copies from one stream to another.
- copyStat(Stat) - Method in class org.apache.zookeeper.server.DataNode
- copyStat(Stat) - Method in class org.apache.zookeeper.server.upgrade.DataNodeV1
- copyStat(Stat, Stat) - Static method in class org.apache.zookeeper.server.DataTree
- copyStat(Stat, Stat) - Static method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- copyStatPersisted(StatPersisted, StatPersisted) - Static method in class org.apache.zookeeper.server.DataTree
- copyStatPersisted(StatPersistedV1, StatPersistedV1) - Static method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- count - Variable in class org.apache.zookeeper.server.quorum.LeaderElection.ElectionResult
-
Deprecated.
- count - Variable in class org.apache.zookeeper.server.ServerCnxn
- countEphemerals() - Method in class org.apache.zookeeper.server.DataTreeBean
- countEphemerals() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
- countParticipants(Map<Long, QuorumPeer.QuorumServer>) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Count the number of nodes in the map that could be followers.
- countVotes(HashMap<InetSocketAddress, Vote>, HashSet<Long>) - Method in class org.apache.zookeeper.server.quorum.LeaderElection
-
Deprecated.
- create - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- create(int) - Static method in exception org.apache.zookeeper.KeeperException
-
Deprecated.deprecated in 3.1.0, use
KeeperException.create(Code)
instead - create(int, String) - Static method in exception org.apache.zookeeper.KeeperException
-
Deprecated.deprecated in 3.1.0, use
KeeperException.create(Code, String)
instead - create(String, byte[], List<ACL>, int) - Static method in class org.apache.zookeeper.Op
-
Constructs a create operation.
- create(String, byte[], List<ACL>, CreateMode) - Static method in class org.apache.zookeeper.Op
-
Constructs a create operation.
- create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.zookeeper.Transaction
- create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.zookeeper.ZooKeeper
-
Create a node with the given path.
- create(String, byte[], List<ACL>, CreateMode, AsyncCallback.StringCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of create.
- create(KeeperException.Code) - Static method in exception org.apache.zookeeper.KeeperException
-
All non-specific keeper exceptions should be constructed via this factory method in order to guarantee consistency in error codes and such.
- create(KeeperException.Code, String) - Static method in exception org.apache.zookeeper.KeeperException
-
All non-specific keeper exceptions should be constructed via this factory method in order to guarantee consistency in error codes and such.
- CREATE - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
- createCnxnManager() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- createConnection(SocketChannel, SelectionKey) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- createElectionAlgorithm(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- createFactory() - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
- createFactory(int, int) - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
- createFactory(InetSocketAddress, int) - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
- createInputArchive(File) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
Invoked to indicate that the input stream has been created.
- CreateMode - Enum in org.apache.zookeeper
-
CreateMode value determines how the znode is created on ZooKeeper.
- createNode(String, byte[], List<ACL>, long, int, long, long) - Method in class org.apache.zookeeper.server.DataTree
- createNode(String, byte[], List<ACL>, long, long, long) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- createPacket(QuorumAuth.Status, byte[]) - Static method in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- createQuota(ZooKeeper, String, long, int) - Static method in class org.apache.zookeeper.ZooKeeperMain
-
this method creates a quota node for the path
- CreateRequest - Class in org.apache.zookeeper.proto
- CreateRequest() - Constructor for class org.apache.zookeeper.proto.CreateRequest
- CreateRequest(String, byte[], List<ACL>, int) - Constructor for class org.apache.zookeeper.proto.CreateRequest
- CreateResponse - Class in org.apache.zookeeper.proto
- CreateResponse() - Constructor for class org.apache.zookeeper.proto.CreateResponse
- CreateResponse(String) - Constructor for class org.apache.zookeeper.proto.CreateResponse
- CreateResult(String) - Constructor for class org.apache.zookeeper.OpResult.CreateResult
- createSaslClient(Subject, String, String, String, Logger, String) - Static method in class org.apache.zookeeper.util.SecurityUtils
-
Create an instance of a SaslClient.
- createSaslServer(Subject, String, String, CallbackHandler, Logger) - Static method in class org.apache.zookeeper.util.SecurityUtils
-
Create an instance of a SaslServer.
- createSession - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- createSession(int) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
- createSession(int) - Method in interface org.apache.zookeeper.server.SessionTracker
- createSession(int) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
- createSessionTracker() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
- createSessionTracker() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
- createSessionTracker() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- CreateSessionTxn - Class in org.apache.zookeeper.txn
- CreateSessionTxn() - Constructor for class org.apache.zookeeper.txn.CreateSessionTxn
- CreateSessionTxn(int) - Constructor for class org.apache.zookeeper.txn.CreateSessionTxn
- createTime - Variable in class org.apache.zookeeper.server.Request
- CreateTxn - Class in org.apache.zookeeper.txn
- CreateTxn() - Constructor for class org.apache.zookeeper.txn.CreateTxn
- CreateTxn(String, byte[], List<ACL>, boolean, int) - Constructor for class org.apache.zookeeper.txn.CreateTxn
- CreateTxnV0 - Class in org.apache.zookeeper.txn
- CreateTxnV0() - Constructor for class org.apache.zookeeper.txn.CreateTxnV0
- CreateTxnV0(String, byte[], List<ACL>, boolean) - Constructor for class org.apache.zookeeper.txn.CreateTxnV0
- CREATOR_ALL_ACL - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
-
This ACL gives the creators authentication id's all permissions.
- crstCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- CURRENT_EPOCH_FILENAME - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
- currentElapsedTime() - Static method in class org.apache.zookeeper.common.Time
-
Returns time in milliseconds as does System.currentTimeMillis(), but uses elapsed time from an arbitrary epoch more like System.nanoTime().
- CURRENTVERSION - Static variable in class org.apache.zookeeper.server.quorum.FastLeaderElection.Notification
- currentWallTime() - Static method in class org.apache.zookeeper.common.Time
-
Explicitly returns system dependent current wall time.
- cxid - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
- cxid - Variable in class org.apache.zookeeper.server.Request
- cxid - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
D
- DATA_TREE_KEY - Static variable in class org.apache.zookeeper.jmx.CommonNames
- dataDir - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- dataDir - Variable in class org.apache.zookeeper.server.ServerConfig
- DatadirCleanupManager - Class in org.apache.zookeeper.server
-
This class manages the cleanup of snapshots and corresponding transaction logs by scheduling the auto purge task with the specified 'autopurge.purgeInterval'.
- DatadirCleanupManager(String, String, int, int) - Constructor for class org.apache.zookeeper.server.DatadirCleanupManager
-
Constructor of DatadirCleanupManager.
- DatadirCleanupManager.PurgeTaskStatus - Enum in org.apache.zookeeper.server
-
Status of the dataDir purge task
- DatadirException(String) - Constructor for exception org.apache.zookeeper.server.persistence.FileTxnSnapLog.DatadirException
- DatadirException(String, Exception) - Constructor for exception org.apache.zookeeper.server.persistence.FileTxnSnapLog.DatadirException
- DataInconsistency - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.DATAINCONSISTENCY
instead - DATAINCONSISTENCY - org.apache.zookeeper.KeeperException.Code
-
A data inconsistency was found
- DataInconsistencyException() - Constructor for exception org.apache.zookeeper.KeeperException.DataInconsistencyException
- dataLogDir - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- dataLogDir - Variable in class org.apache.zookeeper.server.ServerConfig
- DataNode - Class in org.apache.zookeeper.server
-
This class contains the data for a node in the data tree.
- DataNode(DataNode, byte[], Long, StatPersisted) - Constructor for class org.apache.zookeeper.server.DataNode
-
create a DataNode with parent, data, acls and stat
- DataNodeV1 - Class in org.apache.zookeeper.server.upgrade
-
This class contains the data for a node in the data tree.
- dataTree - Variable in class org.apache.zookeeper.server.ZKDatabase
-
make sure on a clear you take care of all these members.
- DataTree - Class in org.apache.zookeeper.server
-
This class maintains the tree data structure.
- DataTree() - Constructor for class org.apache.zookeeper.server.DataTree
- DataTree.ProcessTxnResult - Class in org.apache.zookeeper.server
- DataTreeBean - Class in org.apache.zookeeper.server
-
This class implements the data tree MBean.
- DataTreeBean(DataTree) - Constructor for class org.apache.zookeeper.server.DataTreeBean
- DataTreeMXBean - Interface in org.apache.zookeeper.server
-
Zookeeper data tree MBean.
- DataTreeV1 - Class in org.apache.zookeeper.server.upgrade
-
This class maintains the tree data structure.
- DataTreeV1() - Constructor for class org.apache.zookeeper.server.upgrade.DataTreeV1
- DataTreeV1.ProcessTxnResult - Class in org.apache.zookeeper.server.upgrade
- decInProcess() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- DEFAULT_LOGIN_CONTEXT_NAME - Static variable in class org.apache.zookeeper.server.ZooKeeperSaslServer
- DEFAULT_TICK_TIME - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
- delete - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- delete(String, int) - Static method in class org.apache.zookeeper.Op
-
Constructs a delete operation.
- delete(String, int) - Method in class org.apache.zookeeper.Transaction
- delete(String, int) - Method in class org.apache.zookeeper.ZooKeeper
-
Delete the node with the given path.
- delete(String, int, AsyncCallback.VoidCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of delete.
- DELETE - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
- deleteNode(String) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- deleteNode(String, long) - Method in class org.apache.zookeeper.server.DataTree
-
remove the path from the datatree
- deletePath(String) - Method in class org.apache.zookeeper.common.PathTrie
-
delete a path from the trie
- deleteRecursive(ZooKeeper, String) - Static method in class org.apache.zookeeper.ZKUtil
-
Recursively delete the node with the given path.
- deleteRecursive(ZooKeeper, String, AsyncCallback.VoidCallback, Object) - Static method in class org.apache.zookeeper.ZKUtil
-
Recursively delete the node with the given path.
- DeleteRequest - Class in org.apache.zookeeper.proto
- DeleteRequest() - Constructor for class org.apache.zookeeper.proto.DeleteRequest
- DeleteRequest(String, int) - Constructor for class org.apache.zookeeper.proto.DeleteRequest
- DeleteResult() - Constructor for class org.apache.zookeeper.OpResult.DeleteResult
- DeleteTxn - Class in org.apache.zookeeper.txn
- DeleteTxn() - Constructor for class org.apache.zookeeper.txn.DeleteTxn
- DeleteTxn(String) - Constructor for class org.apache.zookeeper.txn.DeleteTxn
- delQuota(ZooKeeper, String, boolean, boolean) - Static method in class org.apache.zookeeper.ZooKeeperMain
-
this method deletes quota for a node.
- deserialize(InputArchive) - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.data.ACL
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.data.Id
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.data.Stat
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.data.StatPersisted
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.data.StatPersistedV1
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.MultiResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.MultiTransactionRecord
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.AuthPacket
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.CheckVersionRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.ConnectRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.ConnectResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.CreateRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.CreateResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.DeleteRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.ErrorResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.ExistsRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.ExistsResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.GetACLRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.GetACLResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.GetChildren2Request
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.GetChildren2Response
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.GetChildrenRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.GetChildrenResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.GetDataRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.GetDataResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.GetMaxChildrenRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.GetMaxChildrenResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.GetSASLRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.MultiHeader
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.ReplyHeader
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.RequestHeader
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.SetACLRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.SetACLResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.SetDataRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.SetDataResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.SetSASLRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.SetSASLResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.SetWatches
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.SyncRequest
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.SyncResponse
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.proto.WatcherEvent
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.DataNode
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.DataTree
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.persistence.FileHeader
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.quorum.LearnerInfo
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.upgrade.DataNodeV1
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.txn.CheckVersionTxn
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.txn.CreateSessionTxn
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.txn.CreateTxn
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.txn.CreateTxnV0
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.txn.DeleteTxn
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.txn.ErrorTxn
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.txn.MultiTxn
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.txn.SetACLTxn
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.txn.SetDataTxn
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.txn.Txn
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.txn.TxnHeader
- deserialize(DataTree, Map<Long, Integer>) - Method in class org.apache.zookeeper.server.persistence.FileSnap
-
deserialize a data tree from the most recent snapshot
- deserialize(DataTree, Map<Long, Integer>) - Method in interface org.apache.zookeeper.server.persistence.SnapShot
-
deserialize a data tree from the last valid snapshot and return the last zxid that was deserialized
- deserialize(DataTree, Map<Long, Integer>, InputArchive) - Method in class org.apache.zookeeper.server.persistence.FileSnap
-
deserialize the datatree from an inputarchive
- deserializeSnapshot(InputArchive) - Method in class org.apache.zookeeper.server.ZKDatabase
-
deserialize a snapshot from an input archive
- deserializeSnapshot(DataTree, InputArchive, Map<Long, Integer>) - Static method in class org.apache.zookeeper.server.util.SerializeUtils
- deserializeTxn(byte[], TxnHeader) - Static method in class org.apache.zookeeper.server.util.SerializeUtils
- DigestAuthenticationProvider - Class in org.apache.zookeeper.server.auth
- DigestAuthenticationProvider() - Constructor for class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
- DigestLoginModule - Class in org.apache.zookeeper.server.auth
- DigestLoginModule() - Constructor for class org.apache.zookeeper.server.auth.DigestLoginModule
- disableRecv() - Method in class org.apache.zookeeper.server.NettyServerCnxn
- disableRecv() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- disableWrite() - Method in class org.apache.zookeeper.ClientCnxnSocketNIO
- disconnect() - Method in class org.apache.zookeeper.ClientCnxn
-
Shutdown the send/event threads.
- Disconnected - org.apache.zookeeper.Watcher.Event.KeeperState
-
The client is in the disconnected state - it is not connected to any server in the ensemble.
- DOMAIN - Static variable in class org.apache.zookeeper.jmx.CommonNames
- dump(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
- dump(Scanner) - Method in class org.apache.zookeeper.server.persistence.TxnLogToolkit
- dumpCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- dumpConf(PrintWriter) - Method in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
- dumpConf(PrintWriter) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- dumpConnectionInfo(PrintWriter, boolean) - Method in class org.apache.zookeeper.server.ServerCnxn
-
Print information about the connection.
- dumpEphemerals() - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- dumpEphemerals(PrintWriter) - Method in class org.apache.zookeeper.server.DataTree
-
Write a text dump of all the ephemerals in the datatree.
- dumpEphemerals(PrintWriter) - Method in class org.apache.zookeeper.server.ZKDatabase
-
write a text dump of all the ephemerals in the datatree
- dumpEphemerals(PrintWriter) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- dumpSessions(PrintWriter) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
- dumpSessions(PrintWriter) - Method in interface org.apache.zookeeper.server.SessionTracker
-
Text dump of session information, suitable for debugging.
- dumpSessions(PrintWriter) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
- dumpWatches(PrintWriter, boolean) - Method in class org.apache.zookeeper.server.DataTree
-
Write a text dump of all the watches on the datatree.
- dumpWatches(PrintWriter, boolean) - Method in class org.apache.zookeeper.server.WatchManager
-
String representation of watches.
- dumpWatchesSummary(PrintWriter) - Method in class org.apache.zookeeper.server.DataTree
-
Summary of the watches on the datatree.
E
- elapsedTimeToDate(long) - Static method in class org.apache.zookeeper.common.Time
-
This is to convert the elapsedTime to a Date.
- electingFollowers - Variable in class org.apache.zookeeper.server.quorum.Leader
- Election - Interface in org.apache.zookeeper.server.quorum
- electionAddr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
- electionAlg - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- electionFinished - Variable in class org.apache.zookeeper.server.quorum.Leader
- electionPort - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
- electionPort - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- ElectionResult() - Constructor for class org.apache.zookeeper.server.quorum.LeaderElection.ElectionResult
-
Deprecated.
- ENABLE_CLIENT_SASL_DEFAULT - Static variable in class org.apache.zookeeper.client.ZooKeeperSaslClient
- ENABLE_CLIENT_SASL_KEY - Static variable in class org.apache.zookeeper.client.ZooKeeperSaslClient
- enableRecv() - Method in class org.apache.zookeeper.server.NettyServerCnxn
- enableRecv() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- enableWrite() - Method in class org.apache.zookeeper.ClientCnxn
- end_fle - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
- EndOfStreamException(String) - Constructor for exception org.apache.zookeeper.server.ServerCnxn.EndOfStreamException
- Entry(String, String) - Constructor for class org.apache.zookeeper.Environment.Entry
- enviCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- Environment - Class in org.apache.zookeeper
-
Provide insight into the runtime environment.
- Environment() - Constructor for class org.apache.zookeeper.Environment
- Environment.Entry - Class in org.apache.zookeeper
- EPHEMERAL - org.apache.zookeeper.CreateMode
-
The znode will be deleted upon the client's disconnect.
- EPHEMERAL_SEQUENTIAL - org.apache.zookeeper.CreateMode
-
The znode will be deleted upon the client's disconnect, and its name will be appended with a monotonically increasing number.
- epochGen - Static variable in class org.apache.zookeeper.server.quorum.LeaderElection
-
Deprecated.
- equals(Object) - Method in class org.apache.zookeeper.data.ACL
- equals(Object) - Method in class org.apache.zookeeper.data.Id
- equals(Object) - Method in class org.apache.zookeeper.data.Stat
- equals(Object) - Method in class org.apache.zookeeper.data.StatPersisted
- equals(Object) - Method in class org.apache.zookeeper.data.StatPersistedV1
- equals(Object) - Method in class org.apache.zookeeper.MultiResponse
- equals(Object) - Method in class org.apache.zookeeper.MultiTransactionRecord
- equals(Object) - Method in class org.apache.zookeeper.Op.Check
- equals(Object) - Method in class org.apache.zookeeper.Op.Create
- equals(Object) - Method in class org.apache.zookeeper.Op.Delete
- equals(Object) - Method in class org.apache.zookeeper.Op.SetData
- equals(Object) - Method in class org.apache.zookeeper.OpResult.CheckResult
- equals(Object) - Method in class org.apache.zookeeper.OpResult.CreateResult
- equals(Object) - Method in class org.apache.zookeeper.OpResult.DeleteResult
- equals(Object) - Method in class org.apache.zookeeper.OpResult.ErrorResult
- equals(Object) - Method in class org.apache.zookeeper.OpResult.SetDataResult
- equals(Object) - Method in class org.apache.zookeeper.proto.AuthPacket
- equals(Object) - Method in class org.apache.zookeeper.proto.CheckVersionRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.ConnectRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.ConnectResponse
- equals(Object) - Method in class org.apache.zookeeper.proto.CreateRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.CreateResponse
- equals(Object) - Method in class org.apache.zookeeper.proto.DeleteRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.ErrorResponse
- equals(Object) - Method in class org.apache.zookeeper.proto.ExistsRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.ExistsResponse
- equals(Object) - Method in class org.apache.zookeeper.proto.GetACLRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.GetACLResponse
- equals(Object) - Method in class org.apache.zookeeper.proto.GetChildren2Request
- equals(Object) - Method in class org.apache.zookeeper.proto.GetChildren2Response
- equals(Object) - Method in class org.apache.zookeeper.proto.GetChildrenRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.GetChildrenResponse
- equals(Object) - Method in class org.apache.zookeeper.proto.GetDataRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.GetDataResponse
- equals(Object) - Method in class org.apache.zookeeper.proto.GetMaxChildrenRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.GetMaxChildrenResponse
- equals(Object) - Method in class org.apache.zookeeper.proto.GetSASLRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.MultiHeader
- equals(Object) - Method in class org.apache.zookeeper.proto.ReplyHeader
- equals(Object) - Method in class org.apache.zookeeper.proto.RequestHeader
- equals(Object) - Method in class org.apache.zookeeper.proto.SetACLRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.SetACLResponse
- equals(Object) - Method in class org.apache.zookeeper.proto.SetDataRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.SetDataResponse
- equals(Object) - Method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.SetSASLRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.SetSASLResponse
- equals(Object) - Method in class org.apache.zookeeper.proto.SetWatches
- equals(Object) - Method in class org.apache.zookeeper.proto.SyncRequest
- equals(Object) - Method in class org.apache.zookeeper.proto.SyncResponse
- equals(Object) - Method in class org.apache.zookeeper.proto.WatcherEvent
- equals(Object) - Method in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
-
Equality is defined as the clientId and the cxid being the same.
- equals(Object) - Method in class org.apache.zookeeper.server.persistence.FileHeader
- equals(Object) - Method in class org.apache.zookeeper.server.quorum.LearnerInfo
- equals(Object) - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- equals(Object) - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- equals(Object) - Method in class org.apache.zookeeper.server.quorum.StateSummary
- equals(Object) - Method in class org.apache.zookeeper.server.quorum.Vote
- equals(Object) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
-
Equality is defined as the clientId and the cxid being the same.
- equals(Object) - Method in class org.apache.zookeeper.txn.CheckVersionTxn
- equals(Object) - Method in class org.apache.zookeeper.txn.CreateSessionTxn
- equals(Object) - Method in class org.apache.zookeeper.txn.CreateTxn
- equals(Object) - Method in class org.apache.zookeeper.txn.CreateTxnV0
- equals(Object) - Method in class org.apache.zookeeper.txn.DeleteTxn
- equals(Object) - Method in class org.apache.zookeeper.txn.ErrorTxn
- equals(Object) - Method in class org.apache.zookeeper.txn.MultiTxn
- equals(Object) - Method in class org.apache.zookeeper.txn.SetACLTxn
- equals(Object) - Method in class org.apache.zookeeper.txn.SetDataTxn
- equals(Object) - Method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- equals(Object) - Method in class org.apache.zookeeper.txn.Txn
- equals(Object) - Method in class org.apache.zookeeper.txn.TxnHeader
- err - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
- error - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- ERROR - org.apache.zookeeper.server.quorum.auth.QuorumAuth.Status
- ERROR - org.apache.zookeeper.server.ZooKeeperServer.State
- ErrorResponse - Class in org.apache.zookeeper.proto
- ErrorResponse() - Constructor for class org.apache.zookeeper.proto.ErrorResponse
- ErrorResponse(int) - Constructor for class org.apache.zookeeper.proto.ErrorResponse
- ErrorResult(int) - Constructor for class org.apache.zookeeper.OpResult.ErrorResult
- ErrorTxn - Class in org.apache.zookeeper.txn
- ErrorTxn() - Constructor for class org.apache.zookeeper.txn.ErrorTxn
- ErrorTxn(int) - Constructor for class org.apache.zookeeper.txn.ErrorTxn
- established - Variable in class org.apache.zookeeper.server.ServerCnxn
- evaluateResponse(byte[]) - Method in class org.apache.zookeeper.server.ZooKeeperSaslServer
- EVENT_DELIVERY_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
- execCommand(String...) - Static method in class org.apache.zookeeper.Shell
-
Static method to execute a shell command.
- execCommand(Map<String, String>, String...) - Static method in class org.apache.zookeeper.Shell
-
Static method to execute a shell command.
- execCommand(Map<String, String>, String[], long) - Static method in class org.apache.zookeeper.Shell
-
Static method to execute a shell command.
- execute() - Method in interface org.apache.zookeeper.server.util.Profiler.Operation
- execute() - Method in class org.apache.zookeeper.Shell.ShellCommandExecutor
-
Execute the shell command.
- executeLine(String) - Method in class org.apache.zookeeper.ZooKeeperMain
- exists - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- exists(String, boolean) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the stat of the node of the given path.
- exists(String, boolean, AsyncCallback.StatCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of exists.
- exists(String, Watcher) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the stat of the node of the given path.
- exists(String, Watcher, AsyncCallback.StatCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of exists.
- ExistsRequest - Class in org.apache.zookeeper.proto
- ExistsRequest() - Constructor for class org.apache.zookeeper.proto.ExistsRequest
- ExistsRequest(String, boolean) - Constructor for class org.apache.zookeeper.proto.ExistsRequest
- ExistsResponse - Class in org.apache.zookeeper.proto
- ExistsResponse() - Constructor for class org.apache.zookeeper.proto.ExistsResponse
- ExistsResponse(Stat) - Constructor for class org.apache.zookeeper.proto.ExistsResponse
- ExitCode - Class in org.apache.zookeeper.server
-
Exit code used to exit server
- ExitCode() - Constructor for class org.apache.zookeeper.server.ExitCode
- ExitCodeException(int, String) - Constructor for exception org.apache.zookeeper.Shell.ExitCodeException
- expire(SessionTracker.Session) - Method in interface org.apache.zookeeper.server.SessionTracker.SessionExpirer
- expire(SessionTracker.Session) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- Expired - org.apache.zookeeper.Watcher.Event.KeeperState
-
The serving cluster has expired this session.
F
- FAILED - org.apache.zookeeper.client.ZooKeeperSaslClient.SaslState
- fastForwardDataBase() - Method in class org.apache.zookeeper.server.ZKDatabase
-
Fast forward the database adding transactions from the committed log into memory.
- fastForwardFromEdits(DataTree, Map<Long, Integer>, FileTxnSnapLog.PlayBackListener) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
This function will fast forward the server database to have the latest transactions in it.
- FastLeaderElection - Class in org.apache.zookeeper.server.quorum
-
Implementation of leader election using TCP.
- FastLeaderElection(QuorumPeer, QuorumCnxManager) - Constructor for class org.apache.zookeeper.server.quorum.FastLeaderElection
-
Constructor of FastLeaderElection.
- FastLeaderElection.Messenger - Class in org.apache.zookeeper.server.quorum
-
Multi-threaded implementation of message handler.
- FastLeaderElection.Notification - Class in org.apache.zookeeper.server.quorum
-
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 - Class in org.apache.zookeeper.server.quorum
-
Messages that a peer wants to send to other peers.
- FileHeader - Class in org.apache.zookeeper.server.persistence
- FileHeader() - Constructor for class org.apache.zookeeper.server.persistence.FileHeader
- FileHeader(int, int, long) - Constructor for class org.apache.zookeeper.server.persistence.FileHeader
- FilePadding - Class in org.apache.zookeeper.server.persistence
- FilePadding() - Constructor for class org.apache.zookeeper.server.persistence.FilePadding
- FileSnap - Class in org.apache.zookeeper.server.persistence
-
This class implements the snapshot interface.
- FileSnap(File) - Constructor for class org.apache.zookeeper.server.persistence.FileSnap
- FileTxnIterator(File, long) - Constructor for class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
create an iterator over a transaction database directory
- FileTxnLog - Class in org.apache.zookeeper.server.persistence
-
This class implements the TxnLog interface.
- FileTxnLog(File) - Constructor for class org.apache.zookeeper.server.persistence.FileTxnLog
-
constructor for FileTxnLog.
- FileTxnLog.FileTxnIterator - Class in org.apache.zookeeper.server.persistence
-
this class implements the txnlog iterator interface which is used for reading the transaction logs
- FileTxnSnapLog - Class in org.apache.zookeeper.server.persistence
-
This is a helper class above the implementations of txnlog and snapshot classes
- FileTxnSnapLog(File, File) - Constructor for class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
the constructor which takes the datadir and snapdir.
- FileTxnSnapLog.DatadirException - Exception in org.apache.zookeeper.server.persistence
- FileTxnSnapLog.LogDirContentCheckException - Exception in org.apache.zookeeper.server.persistence
- FileTxnSnapLog.PlayBackListener - Interface in org.apache.zookeeper.server.persistence
-
This listener helps the external apis calling restore to gather information while the data is being restored.
- FileTxnSnapLog.SnapDirContentCheckException - Exception in org.apache.zookeeper.server.persistence
- FinalRequestProcessor - Class in org.apache.zookeeper.server
-
This Request processor actually applies any transaction associated with a request and services any queries.
- FinalRequestProcessor(ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.FinalRequestProcessor
- findLeader() - Method in class org.apache.zookeeper.server.quorum.Learner
-
Returns the address of the node we think is the leader.
- findMaxPrefix(String) - Method in class org.apache.zookeeper.common.PathTrie
-
return the largest prefix for the input path.
- findMostRecentSnapshot() - Method in class org.apache.zookeeper.server.persistence.FileSnap
-
find the most recent snapshot in the database.
- findMostRecentSnapshot() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
the most recent snapshot in the snapshot directory
- findMostRecentSnapshot() - Method in interface org.apache.zookeeper.server.persistence.SnapShot
-
find the most recent snapshot file
- findNRecentSnapshots(int) - Method in class org.apache.zookeeper.server.persistence.FileSnap
-
find the last n snapshots.
- findNRecentSnapshots(int) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
the n most recent snapshots
- finishSessionInit(ServerCnxn, boolean) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- firstProcessor - Variable in class org.apache.zookeeper.server.ZooKeeperServer
- flush() - Method in class org.apache.zookeeper.server.quorum.SendAckRequestProcessor
- follower - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
- Follower - Class in org.apache.zookeeper.server.quorum
-
This class has the control logic for the Follower.
- FollowerBean - Class in org.apache.zookeeper.server.quorum
-
Follower MBean interface implementation.
- FollowerBean(Follower, ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.quorum.FollowerBean
- followerInfo() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
- followerInfo() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
- FollowerMXBean - Interface in org.apache.zookeeper.server.quorum
-
Follower MBean
- FollowerRequestProcessor - Class in org.apache.zookeeper.server.quorum
-
This RequestProcessor forwards any requests that modify the state of the system to the Leader.
- FollowerRequestProcessor(FollowerZooKeeperServer, RequestProcessor) - Constructor for class org.apache.zookeeper.server.quorum.FollowerRequestProcessor
- FollowerZooKeeperServer - Class in org.apache.zookeeper.server.quorum
-
Just like the standard ZooKeeperServer.
- FOLLOWING - org.apache.zookeeper.server.quorum.QuorumPeer.ServerState
- FOLLOWING_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
- FourLetterWordMain - Class in org.apache.zookeeper.client
- FourLetterWordMain() - Constructor for class org.apache.zookeeper.client.FourLetterWordMain
- fromFlag(int) - Static method in enum org.apache.zookeeper.CreateMode
-
Map an integer value to a CreateMode value
- fromInt(int) - Static method in enum org.apache.zookeeper.Watcher.Event.EventType
- fromInt(int) - Static method in enum org.apache.zookeeper.Watcher.Event.KeeperState
G
- generateDigest(String) - Static method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
- generateFile(File, VerGen.Version, String, String) - Static method in class org.apache.zookeeper.version.util.VerGen
- get(int) - Static method in enum org.apache.zookeeper.KeeperException.Code
-
Get the Code value for a particular integer error code
- getAcceptedEpoch() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getAcl() - Method in class org.apache.zookeeper.proto.CreateRequest
- getAcl() - Method in class org.apache.zookeeper.proto.GetACLResponse
- getAcl() - Method in class org.apache.zookeeper.proto.SetACLRequest
- getAcl() - Method in class org.apache.zookeeper.txn.CreateTxn
- getAcl() - Method in class org.apache.zookeeper.txn.CreateTxnV0
- getAcl() - Method in class org.apache.zookeeper.txn.SetACLTxn
- getACL - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- getACL(String, Stat) - Method in class org.apache.zookeeper.server.DataTree
- getACL(String, Stat) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- getACL(String, Stat) - Method in class org.apache.zookeeper.server.ZKDatabase
-
get acl for a path
- getACL(String, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the ACL and stat of the node of the given path.
- getACL(String, Stat, AsyncCallback.ACLCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getACL.
- getACL(DataNode) - Method in class org.apache.zookeeper.server.DataTree
- getACL(DataNodeV1) - Method in class org.apache.zookeeper.server.DataTree
- GetACLRequest - Class in org.apache.zookeeper.proto
- GetACLRequest() - Constructor for class org.apache.zookeeper.proto.GetACLRequest
- GetACLRequest(String) - Constructor for class org.apache.zookeeper.proto.GetACLRequest
- GetACLResponse - Class in org.apache.zookeeper.proto
- GetACLResponse() - Constructor for class org.apache.zookeeper.proto.GetACLResponse
- GetACLResponse(List<ACL>, Stat) - Constructor for class org.apache.zookeeper.proto.GetACLResponse
- getAclSize() - Method in class org.apache.zookeeper.server.ZKDatabase
-
get the acl size of the datatree
- getActiveServer() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getAllByName(String) - Method in interface org.apache.zookeeper.client.StaticHostProvider.Resolver
- getAuth() - Method in class org.apache.zookeeper.proto.AuthPacket
- getAuthinfo() - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- getAuthInfo() - Method in class org.apache.zookeeper.server.ServerCnxn
-
auth info for the cnxn, returns an unmodifyable list
- getAuthorizationID() - Method in class org.apache.zookeeper.server.ZooKeeperSaslServer
- getAversion() - Method in class org.apache.zookeeper.data.Stat
- getAversion() - Method in class org.apache.zookeeper.data.StatPersisted
- getAversion() - Method in class org.apache.zookeeper.data.StatPersistedV1
- getAvgLatency() - Method in class org.apache.zookeeper.server.ConnectionBean
- getAvgLatency() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Average latency in ms
- getAvgLatency() - Method in class org.apache.zookeeper.server.ServerCnxn
- getAvgLatency() - Method in class org.apache.zookeeper.server.ServerStats
- getAvgRequestLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getAvgRequestLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getBuildDate() - Static method in class org.apache.zookeeper.Version
- getBytes() - Method in class org.apache.zookeeper.StatsTrack
-
get the count of bytes allowed as part of quota
- getChildren - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- getChildren() - Method in class org.apache.zookeeper.proto.GetChildren2Response
- getChildren() - Method in class org.apache.zookeeper.proto.GetChildrenResponse
- getChildren() - Method in class org.apache.zookeeper.server.DataNode
-
convenience methods to get the children
- getChildren() - Method in class org.apache.zookeeper.server.upgrade.DataNodeV1
-
convenience methods to get the children
- getChildren(String, boolean) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the list of the children of the node of the given path.
- getChildren(String, boolean, AsyncCallback.Children2Callback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getChildren.
- getChildren(String, boolean, AsyncCallback.ChildrenCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getChildren.
- getChildren(String, boolean, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
For the given znode path return the stat and children list.
- getChildren(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.DataTree
- getChildren(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- getChildren(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
-
get children list for this path
- getChildren(String, Watcher) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the list of the children of the node of the given path.
- getChildren(String, Watcher, AsyncCallback.Children2Callback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getChildren.
- getChildren(String, Watcher, AsyncCallback.ChildrenCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getChildren.
- getChildren(String, Watcher, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
For the given znode path return the stat and children list.
- getChildren2 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- GetChildren2Request - Class in org.apache.zookeeper.proto
- GetChildren2Request() - Constructor for class org.apache.zookeeper.proto.GetChildren2Request
- GetChildren2Request(String, boolean) - Constructor for class org.apache.zookeeper.proto.GetChildren2Request
- GetChildren2Response - Class in org.apache.zookeeper.proto
- GetChildren2Response() - Constructor for class org.apache.zookeeper.proto.GetChildren2Response
- GetChildren2Response(List<String>, Stat) - Constructor for class org.apache.zookeeper.proto.GetChildren2Response
- GetChildrenRequest - Class in org.apache.zookeeper.proto
- GetChildrenRequest() - Constructor for class org.apache.zookeeper.proto.GetChildrenRequest
- GetChildrenRequest(String, boolean) - Constructor for class org.apache.zookeeper.proto.GetChildrenRequest
- GetChildrenResponse - Class in org.apache.zookeeper.proto
- GetChildrenResponse() - Constructor for class org.apache.zookeeper.proto.GetChildrenResponse
- GetChildrenResponse(List<String>) - Constructor for class org.apache.zookeeper.proto.GetChildrenResponse
- getChildWatches() - Method in class org.apache.zookeeper.proto.SetWatches
- getChrootPath() - Method in class org.apache.zookeeper.client.ConnectStringParser
- getClientId() - Method in class org.apache.zookeeper.txn.TxnHeader
- getClientPort() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getClientPort() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getClientPortAddress() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getClientPortAddress() - Method in class org.apache.zookeeper.server.ServerConfig
- getCnxManager() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
- getCnxnFactory() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getCode() - Method in exception org.apache.zookeeper.KeeperException
-
Deprecated.deprecated in 3.1.0, use
KeeperException.code()
instead - getCommands() - Static method in class org.apache.zookeeper.ZooKeeperMain
- getCommandString(int) - Static method in class org.apache.zookeeper.server.ServerCnxn
-
Return the string representation of the specified command code.
- getCommittedLog() - Method in class org.apache.zookeeper.server.ZKDatabase
- getConfigStatus() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
- getConnections() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
- getConnections() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- getConnections() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- getConnectionThreadCount() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Return number of connection processing threads.
- getCount() - Method in class org.apache.zookeeper.StatsTrack
-
get the count of nodes allowed as part of quota
- getCounterFromZxid(long) - Static method in class org.apache.zookeeper.server.util.ZxidUtils
- getCtime() - Method in class org.apache.zookeeper.data.Stat
- getCtime() - Method in class org.apache.zookeeper.data.StatPersisted
- getCtime() - Method in class org.apache.zookeeper.data.StatPersistedV1
- getCurrentEpoch() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getCurrentEpoch() - Method in class org.apache.zookeeper.server.quorum.StateSummary
- getCurrentVote() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getCurrentZxid() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
- getCurrentZxid() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
-
Current zxid of cluster.
- getCversion() - Method in class org.apache.zookeeper.data.Stat
- getCversion() - Method in class org.apache.zookeeper.data.StatPersisted
- getCversion() - Method in class org.apache.zookeeper.data.StatPersistedV1
- getCxid() - Method in class org.apache.zookeeper.txn.TxnHeader
- getCzxid() - Method in class org.apache.zookeeper.data.Stat
- getCzxid() - Method in class org.apache.zookeeper.data.StatPersisted
- getCzxid() - Method in class org.apache.zookeeper.data.StatPersistedV1
- getData - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- getData() - Method in class org.apache.zookeeper.proto.CreateRequest
- getData() - Method in class org.apache.zookeeper.proto.GetDataResponse
- getData() - Method in class org.apache.zookeeper.proto.SetDataRequest
- getData() - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- getData() - Method in class org.apache.zookeeper.txn.CreateTxn
- getData() - Method in class org.apache.zookeeper.txn.CreateTxnV0
- getData() - Method in class org.apache.zookeeper.txn.SetDataTxn
- getData() - Method in class org.apache.zookeeper.txn.Txn
- getData(String, boolean, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getData.
- getData(String, boolean, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the data and the stat of the node of the given path.
- getData(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.DataTree
- getData(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- getData(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
-
get data and stat for a path
- getData(String, Watcher, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getData.
- getData(String, Watcher, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the data and the stat of the node of the given path.
- getDataDir() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
get the datadir used by this filetxn snap log
- getDataDir() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getDataDir() - Method in class org.apache.zookeeper.server.ServerConfig
- getDataLength() - Method in class org.apache.zookeeper.data.Stat
- getDataLogDir() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
-
Returns transaction log directory.
- getDataLogDir() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getDataLogDir() - Method in class org.apache.zookeeper.server.ServerConfig
- GetDataRequest - Class in org.apache.zookeeper.proto
- GetDataRequest() - Constructor for class org.apache.zookeeper.proto.GetDataRequest
- GetDataRequest(String, boolean) - Constructor for class org.apache.zookeeper.proto.GetDataRequest
- GetDataResponse - Class in org.apache.zookeeper.proto
- GetDataResponse() - Constructor for class org.apache.zookeeper.proto.GetDataResponse
- GetDataResponse(byte[], Stat) - Constructor for class org.apache.zookeeper.proto.GetDataResponse
- getDataTree() - Method in class org.apache.zookeeper.server.ZKDatabase
-
the datatree for this zkdatabase
- getDataTreeLastProcessedZxid() - Method in class org.apache.zookeeper.server.ZKDatabase
-
get the last processed zxid from a datatree
- getDataWatches() - Method in class org.apache.zookeeper.proto.SetWatches
- getDbid() - Method in class org.apache.zookeeper.server.persistence.FileHeader
- getDbId() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
the dbid of this transaction database
- getDbId() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
the dbid for this transaction log.
- getDefaultRealm() - Method in class org.apache.zookeeper.server.auth.KerberosName
-
Get the configured default realm.
- getDefaultRealm() - Static method in class org.apache.zookeeper.server.util.KerberosUtil
- getDisableAutoResetWatch() - Static method in class org.apache.zookeeper.ClientCnxn
-
tests use this to check on reset of watches
- getDone() - Method in class org.apache.zookeeper.proto.MultiHeader
- getElectionAlg() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Get an instance of LeaderElection
- getElectionAlg() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getElectionEpoch() - Method in class org.apache.zookeeper.server.quorum.Vote
- getElectionPort() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getElectionTimeTaken() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
- getElectionTimeTaken() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
- getElectionTimeTaken() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
- getElectionTimeTaken() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
- getElectionType() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
- getElectionType() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
- getElectionType() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Gets the election type
- getEphemeral() - Method in class org.apache.zookeeper.txn.CreateTxn
- getEphemeral() - Method in class org.apache.zookeeper.txn.CreateTxnV0
- getEphemeralNodes() - Method in class org.apache.zookeeper.server.ConnectionBean
- getEphemeralNodes() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
- getEphemeralOwner() - Method in class org.apache.zookeeper.data.Stat
- getEphemeralOwner() - Method in class org.apache.zookeeper.data.StatPersisted
- getEphemeralOwner() - Method in class org.apache.zookeeper.data.StatPersistedV1
- getEphemerals(long) - Method in class org.apache.zookeeper.server.DataTree
- getEphemerals(long) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- getEphemerals(long) - Method in class org.apache.zookeeper.server.ZKDatabase
-
the paths for ephemeral session id
- getEphemeralsCount() - Method in class org.apache.zookeeper.server.DataTree
- getEphemeralsMap() - Method in class org.apache.zookeeper.server.DataTree
- getEphemeralsMap() - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
-
return the ephemerals for this tree
- getEpoch() - Method in class org.apache.zookeeper.server.quorum.Leader
-
Returns the current epoch of the leader.
- getEpochFromZxid(long) - Static method in class org.apache.zookeeper.server.util.ZxidUtils
- getEpochToPropose(long, long) - Method in class org.apache.zookeeper.server.quorum.Leader
- getErr() - Method in class org.apache.zookeeper.OpResult.ErrorResult
- getErr() - Method in class org.apache.zookeeper.proto.ErrorResponse
- getErr() - Method in class org.apache.zookeeper.proto.MultiHeader
- getErr() - Method in class org.apache.zookeeper.proto.ReplyHeader
- getErr() - Method in class org.apache.zookeeper.txn.ErrorTxn
- getEstablished() - Method in class org.apache.zookeeper.server.ServerCnxn
- getException() - Method in class org.apache.zookeeper.server.Request
- getExecString() - Method in class org.apache.zookeeper.Shell
-
return an array containing the command name & its parameters
- getExecString() - Method in class org.apache.zookeeper.Shell.ShellCommandExecutor
- getExistWatches() - Method in class org.apache.zookeeper.proto.SetWatches
- getExitCode() - Method in exception org.apache.zookeeper.Shell.ExitCodeException
- getExitCode() - Method in class org.apache.zookeeper.Shell
-
get the exit code
- getFlags() - Method in class org.apache.zookeeper.proto.CreateRequest
- getFollower() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
- getFormatConversionPolicy(Properties) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Extracts the value of the dbFormatConversion attribute.
- getForwardingFollowers() - Method in class org.apache.zookeeper.server.quorum.Leader
-
Returns a copy of the current forwarding follower snapshot
- getFsyncThresholdExceedCount() - Method in class org.apache.zookeeper.server.ServerStats
- getFsyncThresholdExceedCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getFsyncThresholdExceedCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getFullVersion() - Static method in class org.apache.zookeeper.Version
- getGET_PERMISSION_COMMAND() - Static method in class org.apache.zookeeper.Shell
-
Return a Unix command to get permission information.
- getGlobalOutstandingLimit() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
- getGlobalOutstandingLimit() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
- getGlobalOutstandingLimit() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getGroupsCommand() - Static method in class org.apache.zookeeper.Shell
-
a Unix command to get the current user's groups list
- getGroupsForUserCommand(String) - Static method in class org.apache.zookeeper.Shell
-
a Unix command to get a given user's groups list
- getHeader() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
reutrn the current header
- getHeader() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
-
return the transaction header.
- getHostName() - Method in class org.apache.zookeeper.server.auth.KerberosName
-
Get the second component of the name.
- getId() - Method in class org.apache.zookeeper.data.ACL
- getId() - Method in class org.apache.zookeeper.data.Id
- getId() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
get the id of this quorum peer.
- getId() - Method in class org.apache.zookeeper.server.quorum.Vote
- getInitLimit() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
- getInitLimit() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
- getInitLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Get the number of ticks that the initial synchronization phase can take
- getInitLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getInProcess() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getInstance() - Static method in class org.apache.zookeeper.jmx.MBeanRegistry
- getInterestOps() - Method in class org.apache.zookeeper.server.NettyServerCnxn
- getInterestOps() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- getInterestOps() - Method in class org.apache.zookeeper.server.ServerCnxn
- getIntValue() - Method in enum org.apache.zookeeper.Watcher.Event.EventType
- getIntValue() - Method in enum org.apache.zookeeper.Watcher.Event.KeeperState
- getJuteMaxBufferSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getJuteMaxBufferSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getKeeperState() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
- getKey() - Method in class org.apache.zookeeper.Environment.Entry
- getLastCxid() - Method in class org.apache.zookeeper.server.ConnectionBean
- getLastCxid() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Last cxid of this connection
- getLastCxid() - Method in class org.apache.zookeeper.server.ServerCnxn
- getLastLatency() - Method in class org.apache.zookeeper.server.ConnectionBean
- getLastLatency() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Latency of last response to client on this connection in ms
- getLastLatency() - Method in class org.apache.zookeeper.server.ServerCnxn
- getLastLoggedZxid() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
get the last zxid that was logged in the transaction logs
- getLastLoggedZxid() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
the last logged zxid on the transaction logs
- getLastLoggedZxid() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
the last zxid of the logged transactions.
- getLastLoggedZxid() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
returns the highest zxid that this host has seen
- getLastOperation() - Method in class org.apache.zookeeper.server.ConnectionBean
- getLastOperation() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Last operation performed by this connection
- getLastOperation() - Method in class org.apache.zookeeper.server.ServerCnxn
- getLastProcessedZxid() - Method in class org.apache.zookeeper.server.ServerStats
- getLastProcessedZxid() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
- getLastProcessedZxid() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
return the last proceesed id from the datatree
- getLastProposalSize() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
- getLastProposalSize() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
- getLastProposalSize() - Method in class org.apache.zookeeper.server.quorum.ProposalStats
- getLastQueued() - Method in class org.apache.zookeeper.server.quorum.Follower
-
The zxid of the last operation queued
- getLastQueuedZxid() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
- getLastQueuedZxid() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
- getLastResponseTime() - Method in class org.apache.zookeeper.server.ConnectionBean
- getLastResponseTime() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Last time server sent a response to client on this connection
- getLastResponseTime() - Method in class org.apache.zookeeper.server.ServerCnxn
- getLastZxid() - Method in class org.apache.zookeeper.ClientCnxn
- getLastZxid() - Method in class org.apache.zookeeper.server.ConnectionBean
- getLastZxid() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Last zxid of this connection
- getLastZxid() - Method in class org.apache.zookeeper.server.DataTreeBean
- getLastZxid() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
- getLastZxid() - Method in class org.apache.zookeeper.server.quorum.StateSummary
- getLastZxid() - Method in class org.apache.zookeeper.server.ServerCnxn
- getLastZxidSeen() - Method in class org.apache.zookeeper.proto.ConnectRequest
- getLeader() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
- getLearner() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
- getLearner() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
-
Abstract method to return the learner associated with this server.
- getLearner() - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
- getLearners() - Method in class org.apache.zookeeper.server.quorum.Leader
-
Returns a copy of the current learner snapshot
- getLearnerType() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
- getLearnerType() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getLocalAddress() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
- getLocalAddress() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- getLocalAddress() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- getLocalPort() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
- getLocalPort() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- getLocalPort() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- getLogDir(Properties) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Extracts transaction log directory property value from the container.
- getLogFiles(File[], long) - Static method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
Find the log file that starts at, or just before, the snapshot.
- getLogicalClock() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
-
Returns the current vlue of the logical clock counter
- getLoginContext() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
- getLoginContextName() - Method in class org.apache.zookeeper.Login
- getLogLock() - Method in class org.apache.zookeeper.server.ZKDatabase
-
Get the lock that controls the committedLog.
- getMagic() - Method in class org.apache.zookeeper.server.persistence.FileHeader
- getMagic() - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- getMax() - Method in class org.apache.zookeeper.proto.GetMaxChildrenResponse
- getMax() - Method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- getMax() - Method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- GetMaxChildrenRequest - Class in org.apache.zookeeper.proto
- GetMaxChildrenRequest() - Constructor for class org.apache.zookeeper.proto.GetMaxChildrenRequest
- GetMaxChildrenRequest(String) - Constructor for class org.apache.zookeeper.proto.GetMaxChildrenRequest
- GetMaxChildrenResponse - Class in org.apache.zookeeper.proto
- GetMaxChildrenResponse() - Constructor for class org.apache.zookeeper.proto.GetMaxChildrenResponse
- GetMaxChildrenResponse(int) - Constructor for class org.apache.zookeeper.proto.GetMaxChildrenResponse
- getMaxClientCnxns() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getMaxClientCnxns() - Method in class org.apache.zookeeper.server.ServerConfig
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
-
Maximum number of connections allowed from particular host (ip)
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
Maximum number of connections allowed from particular host (ip)
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
- getMaxClientCnxnsPerHost() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
Current maxClientCnxns allowed from a particular host
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Maximum number of connections allowed from particular host (ip)
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
Maximum number of connections allowed from particular host (ip)
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getMaxClientCnxnsPerHost() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Current maxClientCnxns allowed from a particular host
- getmaxCommittedLog() - Method in class org.apache.zookeeper.server.ZKDatabase
-
the committed log for this zk database
- getMaxFileDescriptorCount() - Method in class org.apache.zookeeper.server.util.OSMXBean
-
Get the number of the maximum file descriptors the system can use.
- getMaxLatency() - Method in class org.apache.zookeeper.server.ConnectionBean
- getMaxLatency() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Max latency in ms
- getMaxLatency() - Method in class org.apache.zookeeper.server.ServerCnxn
- getMaxLatency() - Method in class org.apache.zookeeper.server.ServerStats
- getMaxPrefixWithQuota(String) - Method in class org.apache.zookeeper.server.DataTree
-
If there is a quota set, return the appropriate prefix for that quota Else return null
- getMaxProposalSize() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
- getMaxProposalSize() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
- getMaxProposalSize() - Method in class org.apache.zookeeper.server.quorum.ProposalStats
- getMaxRequestLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getMaxRequestLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
- getMaxSessionTimeout() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
maximum session timeout in milliseconds
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.ServerConfig
-
maximum session timeout in milliseconds, -1 if unset
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getMaxSessionTimeout() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Current maxSessionTimeout of the server in milliseconds
- getMessage() - Method in exception org.apache.zookeeper.KeeperException
- getminCommittedLog() - Method in class org.apache.zookeeper.server.ZKDatabase
-
the minimum committed transaction log available in memory
- getMinLatency() - Method in class org.apache.zookeeper.server.ConnectionBean
- getMinLatency() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Min latency in ms
- getMinLatency() - Method in class org.apache.zookeeper.server.ServerCnxn
- getMinLatency() - Method in class org.apache.zookeeper.server.ServerStats
- getMinProposalSize() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
- getMinProposalSize() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
- getMinProposalSize() - Method in class org.apache.zookeeper.server.quorum.ProposalStats
- getMinRequestLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getMinRequestLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
- getMinSessionTimeout() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
minimum session timeout in milliseconds
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.ServerConfig
-
minimum session timeout in milliseconds, -1 if unset
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getMinSessionTimeout() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Current minSessionTimeout of the server in milliseconds
- getMtime() - Method in class org.apache.zookeeper.data.Stat
- getMtime() - Method in class org.apache.zookeeper.data.StatPersisted
- getMtime() - Method in class org.apache.zookeeper.data.StatPersistedV1
- getMyid() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
get the id of this quorum peer.
- getMzxid() - Method in class org.apache.zookeeper.data.Stat
- getMzxid() - Method in class org.apache.zookeeper.data.StatPersisted
- getMzxid() - Method in class org.apache.zookeeper.data.StatPersistedV1
- getName() - Method in interface org.apache.zookeeper.jmx.ZKMBeanInfo
- getName() - Method in class org.apache.zookeeper.server.ConnectionBean
- getName() - Method in class org.apache.zookeeper.server.DataTreeBean
- getName() - Method in class org.apache.zookeeper.server.ObserverBean
- getName() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
- getName() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
- getName() - Method in class org.apache.zookeeper.server.quorum.LeaderElectionBean
- getName() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
- getName() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
- getName() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
- getName() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyBean
- getName() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
- getName() - Method in interface org.apache.zookeeper.server.quorum.RemotePeerMXBean
- getName() - Method in interface org.apache.zookeeper.server.quorum.ServerMXBean
- getName() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getNewDataTree() - Method in interface org.apache.zookeeper.server.upgrade.UpgradeSnapShot
- getNewDataTree() - Method in class org.apache.zookeeper.server.upgrade.UpgradeSnapShotV1
- getNode(String) - Method in class org.apache.zookeeper.server.DataTree
- getNode(String) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- getNode(String) - Method in class org.apache.zookeeper.server.ZKDatabase
-
get the datanode for this path
- getNodeCount() - Method in class org.apache.zookeeper.server.DataTree
- getNodeCount() - Method in class org.apache.zookeeper.server.DataTreeBean
- getNodeCount() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
- getNodeCount() - Method in class org.apache.zookeeper.server.ZKDatabase
-
the node count of the datatree
- getNumAliveClientConnections() - Method in class org.apache.zookeeper.server.ServerStats
-
The number of client connections alive to this server
- getNumAliveConnections() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- getNumAliveConnections() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
- getNumAliveConnections() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
return the total number of client connections that are alive to this server
- getNumAliveConnections() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getNumAliveConnections() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getNumChildren() - Method in class org.apache.zookeeper.data.Stat
- getNumPendingSyncs() - Method in class org.apache.zookeeper.server.quorum.Leader
- getObserver() - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
- getObservingLearners() - Method in class org.apache.zookeeper.server.quorum.Leader
-
Returns a copy of the current observer snapshot
- getObservingView() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Returns only observers, no followers.
- getOpenFileDescriptorCount() - Method in class org.apache.zookeeper.server.util.OSMXBean
-
Get the number of opened filed descriptor for the runtime jvm.
- getOutput() - Method in class org.apache.zookeeper.Shell.ShellCommandExecutor
-
Get the output of the shell command.
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.ConnectionBean
- getOutstandingRequests() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.NettyServerCnxn
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.ServerCnxn
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.ServerStats
- getOutstandingRequests() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
return the outstanding requests in the queue, which havent been processed yet
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getOutstandingRequests() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getOwner() - Method in class org.apache.zookeeper.server.Request
- getPacketsReceived() - Method in class org.apache.zookeeper.server.ConnectionBean
- getPacketsReceived() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
- getPacketsReceived() - Method in class org.apache.zookeeper.server.ServerCnxn
- getPacketsReceived() - Method in class org.apache.zookeeper.server.ServerStats
- getPacketsReceived() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getPacketsReceived() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getPacketsSent() - Method in class org.apache.zookeeper.server.ConnectionBean
- getPacketsSent() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
- getPacketsSent() - Method in class org.apache.zookeeper.server.ServerCnxn
- getPacketsSent() - Method in class org.apache.zookeeper.server.ServerStats
- getPacketsSent() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getPacketsSent() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getPacketType(int) - Static method in class org.apache.zookeeper.server.quorum.Leader
-
Get string representation of a given packet type
- getParentCVersion() - Method in class org.apache.zookeeper.txn.CreateTxn
- getPasswd() - Method in class org.apache.zookeeper.proto.ConnectRequest
- getPasswd() - Method in class org.apache.zookeeper.proto.ConnectResponse
- getPath() - Method in exception org.apache.zookeeper.KeeperException
-
Read the path for this exception
- getPath() - Method in class org.apache.zookeeper.Op
-
Gets the path for an Op.
- getPath() - Method in class org.apache.zookeeper.OpResult.CreateResult
- getPath() - Method in class org.apache.zookeeper.proto.CheckVersionRequest
- getPath() - Method in class org.apache.zookeeper.proto.CreateRequest
- getPath() - Method in class org.apache.zookeeper.proto.CreateResponse
- getPath() - Method in class org.apache.zookeeper.proto.DeleteRequest
- getPath() - Method in class org.apache.zookeeper.proto.ExistsRequest
- getPath() - Method in class org.apache.zookeeper.proto.GetACLRequest
- getPath() - Method in class org.apache.zookeeper.proto.GetChildren2Request
- getPath() - Method in class org.apache.zookeeper.proto.GetChildrenRequest
- getPath() - Method in class org.apache.zookeeper.proto.GetDataRequest
- getPath() - Method in class org.apache.zookeeper.proto.GetMaxChildrenRequest
- getPath() - Method in class org.apache.zookeeper.proto.SetACLRequest
- getPath() - Method in class org.apache.zookeeper.proto.SetDataRequest
- getPath() - Method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- getPath() - Method in class org.apache.zookeeper.proto.SyncRequest
- getPath() - Method in class org.apache.zookeeper.proto.SyncResponse
- getPath() - Method in class org.apache.zookeeper.proto.WatcherEvent
- getPath() - Method in class org.apache.zookeeper.txn.CheckVersionTxn
- getPath() - Method in class org.apache.zookeeper.txn.CreateTxn
- getPath() - Method in class org.apache.zookeeper.txn.CreateTxnV0
- getPath() - Method in class org.apache.zookeeper.txn.DeleteTxn
- getPath() - Method in class org.apache.zookeeper.txn.SetACLTxn
- getPath() - Method in class org.apache.zookeeper.txn.SetDataTxn
- getPath() - Method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- getPath() - Method in class org.apache.zookeeper.WatchedEvent
- getPeerEpoch() - Method in class org.apache.zookeeper.server.quorum.Vote
- getPeerState() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getPeerType() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getPendingRevalidationCount() - Method in class org.apache.zookeeper.server.ObserverBean
- getPendingRevalidationCount() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
- getPendingRevalidationCount() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
- getPendingRevalidationCount() - Method in interface org.apache.zookeeper.server.quorum.ObserverMXBean
- getPendingRevalidationsCount() - Method in class org.apache.zookeeper.server.quorum.Learner
- getPerms() - Method in class org.apache.zookeeper.data.ACL
- getPlatformMBeanServer() - Method in class org.apache.zookeeper.jmx.MBeanRegistry
-
Return the underlying MBeanServer that is being used to register MBean's.
- getPreAllocSize() - Static method in class org.apache.zookeeper.server.persistence.FilePadding
-
Getter of preAllocSize has been added for testing
- getPrintWatches() - Method in class org.apache.zookeeper.ZooKeeperMain
- getProcess() - Method in class org.apache.zookeeper.Shell
-
get the current sub-process executing the given command
- getPrompt() - Method in class org.apache.zookeeper.ZooKeeperMain
- getProposalStats() - Method in class org.apache.zookeeper.server.quorum.Leader
- getProtocolVersion() - Method in class org.apache.zookeeper.proto.ConnectRequest
- getProtocolVersion() - Method in class org.apache.zookeeper.proto.ConnectResponse
- getProtocolVersion() - Method in class org.apache.zookeeper.server.quorum.LearnerInfo
- getProvider(String) - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
- getPurgeInterval() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
-
Returns purge interval in hours.
- getPurgeInterval() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getPurgeTaskStatus() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
-
Returns the status of the purge task.
- getPzxid() - Method in class org.apache.zookeeper.data.Stat
- getPzxid() - Method in class org.apache.zookeeper.data.StatPersisted
- getQuorumAddress() - Method in class org.apache.zookeeper.server.ObserverBean
- getQuorumAddress() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
- getQuorumAddress() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
- getQuorumAddress() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
- getQuorumAddress() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
- getQuorumAddress() - Method in interface org.apache.zookeeper.server.quorum.ObserverMXBean
- getQuorumAddress() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getQuorumAddress() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
- getQuorumAddress() - Method in interface org.apache.zookeeper.server.quorum.RemotePeerMXBean
- getQuorumCnxManager() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
get reference to QuorumCnxManager
- getQuorumListenOnAllIPs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getQuorumListenOnAllIPs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getQuorumPeer() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerMain
- getQuorumPeers() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Only used by QuorumStats at the moment
- getQuorumPeers() - Method in class org.apache.zookeeper.server.quorum.QuorumStats
- getQuorumPeers() - Method in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
- getQuorumSize() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
- getQuorumSize() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
- getQuorumSize() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Return QuorumVerifier object
- getQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getReachableAddress(String, int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
-
Resolve the hostname to IP addresses, and find one reachable address.
- getRealm() - Method in class org.apache.zookeeper.server.auth.KerberosName
-
Get the realm of the name.
- getRelativeZxid() - Method in class org.apache.zookeeper.proto.SetWatches
- getRemoteSocketAddress() - Method in class org.apache.zookeeper.server.NettyServerCnxn
- getRemoteSocketAddress() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- getRemoteSocketAddress() - Method in class org.apache.zookeeper.server.ServerCnxn
- getResultList() - Method in class org.apache.zookeeper.MultiResponse
- getResults() - Method in exception org.apache.zookeeper.KeeperException
-
If this exception was thrown by a multi-request then the (partial) results and error codes can be retrieved using this getter.
- getRevision() - Static method in class org.apache.zookeeper.Version
-
Deprecated.
- getRevisionHash() - Static method in class org.apache.zookeeper.Version
- getSaslClient() - Method in class org.apache.zookeeper.ZooKeeper
- GetSASLRequest - Class in org.apache.zookeeper.proto
- GetSASLRequest() - Constructor for class org.apache.zookeeper.proto.GetSASLRequest
- GetSASLRequest(byte[]) - Constructor for class org.apache.zookeeper.proto.GetSASLRequest
- getSaslState() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
- getScheme() - Method in class org.apache.zookeeper.data.Id
- getScheme() - Method in class org.apache.zookeeper.proto.AuthPacket
- getScheme() - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
-
The String used to represent this provider.
- getScheme() - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
- getScheme() - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
- getScheme() - Method in class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
- getServerAddresses() - Method in class org.apache.zookeeper.client.ConnectStringParser
- getServerCnxnFactory() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getServerid() - Method in class org.apache.zookeeper.server.quorum.LearnerInfo
- getServerId() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
-
Returns the id of the associated QuorumPeer, which will do for a unique id of this server.
- getServerId() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
-
Returns the id of the associated QuorumPeer, which will do for a unique id of this server.
- getServerId() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getServerId() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
-
Returns the id of the associated QuorumPeer, which will do for a unique id of this server.
- getServerId() - Method in interface org.apache.zookeeper.server.SessionTracker.SessionExpirer
- getServerId() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getServerPrincipal(String, String) - Static method in class org.apache.zookeeper.util.SecurityUtils
-
Convert Kerberos principal name pattern to valid Kerberos principal name.
- getServers() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getServerState() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getServerState() - Method in class org.apache.zookeeper.server.quorum.QuorumStats
- getServerState() - Method in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
- getServerState() - Method in class org.apache.zookeeper.server.ServerStats
- getServiceName() - Method in class org.apache.zookeeper.server.auth.KerberosName
-
Get the first component of the name.
- getSessionId() - Method in class org.apache.zookeeper.ClientCnxn
- getSessionId() - Method in class org.apache.zookeeper.proto.ConnectRequest
- getSessionId() - Method in class org.apache.zookeeper.proto.ConnectResponse
- getSessionId() - Method in class org.apache.zookeeper.server.ConnectionBean
- getSessionId() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
- getSessionId() - Method in class org.apache.zookeeper.server.NettyServerCnxn
- getSessionId() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- getSessionId() - Method in interface org.apache.zookeeper.server.SessionTracker.Session
- getSessionId() - Method in class org.apache.zookeeper.server.SessionTrackerImpl.SessionImpl
- getSessionId() - Method in class org.apache.zookeeper.ZooKeeper
-
The session id for this ZooKeeper client instance.
- getSessionPasswd() - Method in class org.apache.zookeeper.ClientCnxn
- getSessionPasswd() - Method in class org.apache.zookeeper.ZooKeeper
-
The session password for this ZooKeeper client instance.
- getSessions() - Method in class org.apache.zookeeper.server.DataTree
- getSessions() - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- getSessions() - Method in class org.apache.zookeeper.server.ZKDatabase
-
return the sessions in the datatree
- getSessionTimeout() - Method in class org.apache.zookeeper.ClientCnxn
- getSessionTimeout() - Method in class org.apache.zookeeper.server.ConnectionBean
- getSessionTimeout() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
- getSessionTimeout() - Method in class org.apache.zookeeper.server.NettyServerCnxn
- getSessionTimeout() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- getSessionTimeout() - Method in class org.apache.zookeeper.ZooKeeper
-
The negotiated session timeout for this ZooKeeper client instance.
- getSessionWithTimeOuts() - Method in interface org.apache.zookeeper.server.upgrade.UpgradeSnapShot
- getSessionWithTimeOuts() - Method in class org.apache.zookeeper.server.upgrade.UpgradeSnapShotV1
- getSessionWithTimeOuts() - Method in class org.apache.zookeeper.server.ZKDatabase
-
get sessions with timeouts
- getShortName() - Method in class org.apache.zookeeper.server.auth.KerberosName
-
Get the translation of the principal name into an operating system user name.
- getSnapCount() - Static method in class org.apache.zookeeper.server.SyncRequestProcessor
-
used by tests to get the snapcount
- getSnapCount() - Static method in class org.apache.zookeeper.server.ZooKeeperServer
- getSnapDir() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
-
Returns the snapshot directory.
- getSnapDir() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
get the snap dir used by this filetxn snap log
- getSnapDir(Properties) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Extracts snapshot directory property value from the container.
- getSnapRetainCount() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
-
Returns the number of snapshots to be retained after purge.
- getSnapRetainCount() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getSnapshotLogs(long) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
get the snapshot logs which may contain transactions newer than the given zxid.
- getSocket() - Method in class org.apache.zookeeper.server.quorum.Learner
-
Socket getter
- getSocket() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
- getSocketAddress() - Method in class org.apache.zookeeper.server.NettyServerCnxn
- getSocketAddress() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- getSocketAddress() - Method in class org.apache.zookeeper.server.ServerCnxn
-
Wrapper method to return the socket address
- getSourceIP() - Method in class org.apache.zookeeper.server.ConnectionBean
- getSourceIP() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
- getStartedTime() - Method in class org.apache.zookeeper.server.ConnectionBean
- getStartedTime() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
- getStartTime() - Method in class org.apache.zookeeper.server.quorum.LeaderElectionBean
- getStartTime() - Method in interface org.apache.zookeeper.server.quorum.LeaderElectionMXBean
- getStartTime() - Method in class org.apache.zookeeper.server.quorum.ServerBean
- getStartTime() - Method in interface org.apache.zookeeper.server.quorum.ServerMXBean
- getStartTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getStartTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getStat() - Method in class org.apache.zookeeper.OpResult.SetDataResult
- getStat() - Method in class org.apache.zookeeper.proto.ExistsResponse
- getStat() - Method in class org.apache.zookeeper.proto.GetACLResponse
- getStat() - Method in class org.apache.zookeeper.proto.GetChildren2Response
- getStat() - Method in class org.apache.zookeeper.proto.GetDataResponse
- getStat() - Method in class org.apache.zookeeper.proto.SetACLResponse
- getStat() - Method in class org.apache.zookeeper.proto.SetDataResponse
- getState() - Method in class org.apache.zookeeper.proto.WatcherEvent
- getState() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
- getState() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
- getState() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
- getState() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
- getState() - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
- getState() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
- getState() - Method in class org.apache.zookeeper.server.quorum.Vote
- getState() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
- getState() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getState() - Method in class org.apache.zookeeper.WatchedEvent
- getState() - Method in class org.apache.zookeeper.ZooKeeper
- getStatus() - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- getSubject() - Method in class org.apache.zookeeper.Login
- getSyncEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Return syncEnabled.
- getSyncEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getSyncLimit() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
- getSyncLimit() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
- getSyncLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Get the synclimit
- getSyncLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getTestable() - Method in class org.apache.zookeeper.ZooKeeper
- getTextTraceLevel() - Static method in class org.apache.zookeeper.server.ZooTrace
- getThreadCount() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Return number of worker threads
- getTick() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
- getTick() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
- getTick() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Get the current tick
- getTickTime() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
- getTickTime() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
- getTickTime() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Get the number of milliseconds of each tick
- getTickTime() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- getTickTime() - Method in class org.apache.zookeeper.server.ServerConfig
- getTickTime() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getTickTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getTickTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Current TickTime of server in milliseconds
- getTime() - Method in class org.apache.zookeeper.txn.TxnHeader
- getTimeout() - Method in interface org.apache.zookeeper.server.SessionTracker.Session
- getTimeout() - Method in class org.apache.zookeeper.server.SessionTrackerImpl.SessionImpl
- getTimeOut() - Method in class org.apache.zookeeper.proto.ConnectRequest
- getTimeOut() - Method in class org.apache.zookeeper.proto.ConnectResponse
- getTimeOut() - Method in class org.apache.zookeeper.txn.CreateSessionTxn
- getToken() - Method in class org.apache.zookeeper.proto.GetSASLRequest
- getToken() - Method in class org.apache.zookeeper.proto.SetSASLRequest
- getToken() - Method in class org.apache.zookeeper.proto.SetSASLResponse
- getToken() - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- getTouchSnapshot() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
-
Returns the current state of the session tracker.
- getTraceMask(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
- getTraceMaskCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- getTxn() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
return the current transaction
- getTxn() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
-
return the transaction record.
- getTxnFactory() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getTxnLogFactory() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getTxns() - Method in class org.apache.zookeeper.txn.MultiTxn
- getType() - Method in class org.apache.zookeeper.Op
-
Gets the integer type code for an Op.
- getType() - Method in class org.apache.zookeeper.OpResult
-
Encodes the return type as from ZooDefs.OpCode.
- getType() - Method in class org.apache.zookeeper.proto.AuthPacket
- getType() - Method in class org.apache.zookeeper.proto.MultiHeader
- getType() - Method in class org.apache.zookeeper.proto.RequestHeader
- getType() - Method in class org.apache.zookeeper.proto.WatcherEvent
- getType() - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- getType() - Method in class org.apache.zookeeper.txn.Txn
- getType() - Method in class org.apache.zookeeper.txn.TxnHeader
- getType() - Method in class org.apache.zookeeper.WatchedEvent
- getUlimitMemoryCommand(int) - Static method in class org.apache.zookeeper.Shell
-
Get the Unix command for setting the maximum virtual memory available to a given child process.
- getUnix() - Method in class org.apache.zookeeper.server.util.OSMXBean
-
Check if the OS is unix.
- getValue() - Method in class org.apache.zookeeper.Environment.Entry
- getVersion() - Method in class org.apache.zookeeper.data.Stat
- getVersion() - Method in class org.apache.zookeeper.data.StatPersisted
- getVersion() - Method in class org.apache.zookeeper.data.StatPersistedV1
- getVersion() - Method in class org.apache.zookeeper.proto.CheckVersionRequest
- getVersion() - Method in class org.apache.zookeeper.proto.DeleteRequest
- getVersion() - Method in class org.apache.zookeeper.proto.SetACLRequest
- getVersion() - Method in class org.apache.zookeeper.proto.SetDataRequest
- getVersion() - Method in class org.apache.zookeeper.server.persistence.FileHeader
- getVersion() - Method in class org.apache.zookeeper.server.quorum.Vote
- getVersion() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getVersion() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getVersion() - Method in class org.apache.zookeeper.txn.CheckVersionTxn
- getVersion() - Method in class org.apache.zookeeper.txn.SetACLTxn
- getVersion() - Method in class org.apache.zookeeper.txn.SetDataTxn
- getVersion() - Static method in class org.apache.zookeeper.Version
- getVersionRevision() - Static method in class org.apache.zookeeper.Version
- getView() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
A 'view' is a node's current opinion of the membership of the entire ensemble.
- getVotingView() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Observers are not contained in this view, only nodes with PeerType=PARTICIPANT.
- getWatch() - Method in class org.apache.zookeeper.proto.ExistsRequest
- getWatch() - Method in class org.apache.zookeeper.proto.GetChildren2Request
- getWatch() - Method in class org.apache.zookeeper.proto.GetChildrenRequest
- getWatch() - Method in class org.apache.zookeeper.proto.GetDataRequest
- getWatchCount() - Method in class org.apache.zookeeper.server.DataTree
- getWatchCount() - Method in class org.apache.zookeeper.server.DataTreeBean
- getWatchCount() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
- getWeight(long) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
-
Returns the weight of a server.
- getWeight(long) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
-
Returns weight of 1 by default.
- getWeight(long) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
- getWrapper() - Method in class org.apache.zookeeper.WatchedEvent
-
Convert WatchedEvent to type that can be sent over network
- getXid() - Method in class org.apache.zookeeper.ClientCnxn
- getXid() - Method in class org.apache.zookeeper.proto.ReplyHeader
- getXid() - Method in class org.apache.zookeeper.proto.RequestHeader
- getZKDatabase() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
get the zookeeper database for this server
- getZkDb() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- getZooKeeperServerListener() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getZxid() - Method in class org.apache.zookeeper.proto.ReplyHeader
- getZxid() - Method in class org.apache.zookeeper.server.quorum.Follower
-
The zxid of the last operation seen
- getZxid() - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- getZxid() - Method in class org.apache.zookeeper.server.quorum.Vote
- getZxid() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
This should be called from a synchronized block on this!
- getZxid() - Method in class org.apache.zookeeper.txn.TxnHeader
- getZxidFromName(String, String) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Extracts zxid from the file name.
H
- halt() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Flag that it is time to wrap up all activities and interrupt the listener.
- handle(Callback[]) - Method in class org.apache.zookeeper.SaslClientCallbackHandler
- handle(Callback[]) - Method in class org.apache.zookeeper.server.auth.SaslServerCallbackHandler
- handle(Callback[]) - Method in class org.apache.zookeeper.server.quorum.auth.SaslQuorumServerCallbackHandler
- handleAuthentication(ServerCnxn, byte[]) - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
-
This method is called when a client passes authentication data for this scheme.
- handleAuthentication(ServerCnxn, byte[]) - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
- handleAuthentication(ServerCnxn, byte[]) - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
- handleAuthentication(ServerCnxn, byte[]) - Method in class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
- handleException(String, Throwable) - Method in class org.apache.zookeeper.server.ZooKeeperCriticalThread
-
This will be used by the uncaught exception handler and make the system exit.
- handleException(String, Throwable) - Method in class org.apache.zookeeper.server.ZooKeeperThread
-
This will be used by the uncaught exception handler and just log a warning message and return.
- hasAuthInitialized() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- hashCode() - Method in class org.apache.zookeeper.data.ACL
- hashCode() - Method in class org.apache.zookeeper.data.Id
- hashCode() - Method in class org.apache.zookeeper.data.Stat
- hashCode() - Method in class org.apache.zookeeper.data.StatPersisted
- hashCode() - Method in class org.apache.zookeeper.data.StatPersistedV1
- hashCode() - Method in class org.apache.zookeeper.MultiResponse
- hashCode() - Method in class org.apache.zookeeper.MultiTransactionRecord
- hashCode() - Method in class org.apache.zookeeper.Op.Check
- hashCode() - Method in class org.apache.zookeeper.Op.Create
- hashCode() - Method in class org.apache.zookeeper.Op.Delete
- hashCode() - Method in class org.apache.zookeeper.Op.SetData
- hashCode() - Method in class org.apache.zookeeper.OpResult.CheckResult
- hashCode() - Method in class org.apache.zookeeper.OpResult.CreateResult
- hashCode() - Method in class org.apache.zookeeper.OpResult.DeleteResult
- hashCode() - Method in class org.apache.zookeeper.OpResult.ErrorResult
- hashCode() - Method in class org.apache.zookeeper.OpResult.SetDataResult
- hashCode() - Method in class org.apache.zookeeper.proto.AuthPacket
- hashCode() - Method in class org.apache.zookeeper.proto.CheckVersionRequest
- hashCode() - Method in class org.apache.zookeeper.proto.ConnectRequest
- hashCode() - Method in class org.apache.zookeeper.proto.ConnectResponse
- hashCode() - Method in class org.apache.zookeeper.proto.CreateRequest
- hashCode() - Method in class org.apache.zookeeper.proto.CreateResponse
- hashCode() - Method in class org.apache.zookeeper.proto.DeleteRequest
- hashCode() - Method in class org.apache.zookeeper.proto.ErrorResponse
- hashCode() - Method in class org.apache.zookeeper.proto.ExistsRequest
- hashCode() - Method in class org.apache.zookeeper.proto.ExistsResponse
- hashCode() - Method in class org.apache.zookeeper.proto.GetACLRequest
- hashCode() - Method in class org.apache.zookeeper.proto.GetACLResponse
- hashCode() - Method in class org.apache.zookeeper.proto.GetChildren2Request
- hashCode() - Method in class org.apache.zookeeper.proto.GetChildren2Response
- hashCode() - Method in class org.apache.zookeeper.proto.GetChildrenRequest
- hashCode() - Method in class org.apache.zookeeper.proto.GetChildrenResponse
- hashCode() - Method in class org.apache.zookeeper.proto.GetDataRequest
- hashCode() - Method in class org.apache.zookeeper.proto.GetDataResponse
- hashCode() - Method in class org.apache.zookeeper.proto.GetMaxChildrenRequest
- hashCode() - Method in class org.apache.zookeeper.proto.GetMaxChildrenResponse
- hashCode() - Method in class org.apache.zookeeper.proto.GetSASLRequest
- hashCode() - Method in class org.apache.zookeeper.proto.MultiHeader
- hashCode() - Method in class org.apache.zookeeper.proto.ReplyHeader
- hashCode() - Method in class org.apache.zookeeper.proto.RequestHeader
- hashCode() - Method in class org.apache.zookeeper.proto.SetACLRequest
- hashCode() - Method in class org.apache.zookeeper.proto.SetACLResponse
- hashCode() - Method in class org.apache.zookeeper.proto.SetDataRequest
- hashCode() - Method in class org.apache.zookeeper.proto.SetDataResponse
- hashCode() - Method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- hashCode() - Method in class org.apache.zookeeper.proto.SetSASLRequest
- hashCode() - Method in class org.apache.zookeeper.proto.SetSASLResponse
- hashCode() - Method in class org.apache.zookeeper.proto.SetWatches
- hashCode() - Method in class org.apache.zookeeper.proto.SyncRequest
- hashCode() - Method in class org.apache.zookeeper.proto.SyncResponse
- hashCode() - Method in class org.apache.zookeeper.proto.WatcherEvent
- hashCode() - Method in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
-
See equals() to find the rational for how this hashcode is generated.
- hashCode() - Method in class org.apache.zookeeper.server.persistence.FileHeader
- hashCode() - Method in class org.apache.zookeeper.server.quorum.LearnerInfo
- hashCode() - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- hashCode() - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- hashCode() - Method in class org.apache.zookeeper.server.quorum.StateSummary
- hashCode() - Method in class org.apache.zookeeper.server.quorum.Vote
- hashCode() - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
-
See equals() to find the rational for how this hashcode is generated.
- hashCode() - Method in class org.apache.zookeeper.txn.CheckVersionTxn
- hashCode() - Method in class org.apache.zookeeper.txn.CreateSessionTxn
- hashCode() - Method in class org.apache.zookeeper.txn.CreateTxn
- hashCode() - Method in class org.apache.zookeeper.txn.CreateTxnV0
- hashCode() - Method in class org.apache.zookeeper.txn.DeleteTxn
- hashCode() - Method in class org.apache.zookeeper.txn.ErrorTxn
- hashCode() - Method in class org.apache.zookeeper.txn.MultiTxn
- hashCode() - Method in class org.apache.zookeeper.txn.SetACLTxn
- hashCode() - Method in class org.apache.zookeeper.txn.SetDataTxn
- hashCode() - Method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- hashCode() - Method in class org.apache.zookeeper.txn.Txn
- hashCode() - Method in class org.apache.zookeeper.txn.TxnHeader
- hdr - Variable in class org.apache.zookeeper.server.Request
- history - Variable in class org.apache.zookeeper.ZooKeeperMain
- host - Variable in class org.apache.zookeeper.ZooKeeperMain
- hostname - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
- HostProvider - Interface in org.apache.zookeeper.client
-
A set of hosts a ZooKeeper client should connect to.
I
- id - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
- Id - Class in org.apache.zookeeper.data
- Id() - Constructor for class org.apache.zookeeper.data.Id
- Id(String, String) - Constructor for class org.apache.zookeeper.data.Id
- IN_PROGRESS - org.apache.zookeeper.server.quorum.auth.QuorumAuth.Status
- incInProcess() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- incrementFsyncThresholdExceedCount() - Method in class org.apache.zookeeper.server.ServerStats
- incrementPacketsReceived() - Method in class org.apache.zookeeper.server.ServerStats
- incrementPacketsSent() - Method in class org.apache.zookeeper.server.ServerStats
- incrOutstandingRequests(RequestHeader) - Method in class org.apache.zookeeper.server.NIOServerCnxn
- incrOutstandingRequests(RequestHeader) - Method in class org.apache.zookeeper.server.ServerCnxn
- incrPacketsReceived() - Method in class org.apache.zookeeper.server.ServerCnxn
- incrPacketsSent() - Method in class org.apache.zookeeper.server.ServerCnxn
- Info - Interface in org.apache.zookeeper.version
- inform(Leader.Proposal) - Method in class org.apache.zookeeper.server.quorum.Leader
-
Create an inform packet and send it to all observers.
- INITIAL - org.apache.zookeeper.client.ZooKeeperSaslClient.SaslState
- INITIAL - org.apache.zookeeper.server.ZooKeeperServer.State
- initialize() - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
- initialize() - Method in class org.apache.zookeeper.server.quorum.ProposalRequestProcessor
-
initialize this processor
- initialize() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.zookeeper.server.auth.DigestLoginModule
- initialize(ClientCnxn) - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
- initializeAndRun(String[]) - Method in class org.apache.zookeeper.server.quorum.QuorumPeerMain
- initializeAndRun(String[]) - Method in class org.apache.zookeeper.server.ZooKeeperServerMain
- initialized - Variable in class org.apache.zookeeper.server.DataTree
- initialized - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1
- initializeNextSession(long) - Static method in class org.apache.zookeeper.server.SessionTrackerImpl
- initiateConnection(Socket, Long) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
If this server has initiated the connection, then it gives up on the connection if it loses challenge.
- initiateConnectionAsync(Socket, Long) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Server will initiate the connection request to its peer server asynchronously via separate connection thread.
- initLimit - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
The number of ticks that the initial synchronization phase can take
- initLimit - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- injectSessionExpiration() - Method in interface org.apache.zookeeper.Testable
-
Cause the ZooKeeper instance to behave as if the session expired
- inStreamCreated(InputArchive, InputStream) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
read the header from the inputarchive
- InterfaceAudience - Class in org.apache.yetus.audience
-
Annotation to inform users of a package, class or method's intended audience.
- InterfaceAudience.LimitedPrivate - Annotation Type in org.apache.yetus.audience
-
Intended only for the project(s) specified in the annotation.
- InterfaceAudience.Private - Annotation Type in org.apache.yetus.audience
-
Intended for use only within a given project.
- InterfaceAudience.Public - Annotation Type in org.apache.yetus.audience
-
Intended for use by any project or application.
- InterfaceStability - Class in org.apache.yetus.audience
-
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
- InterfaceStability() - Constructor for class org.apache.yetus.audience.InterfaceStability
- InterfaceStability.Evolving - Annotation Type in org.apache.yetus.audience
-
Evolving, but can break compatibility at minor release (i.e.
- InterfaceStability.Stable - Annotation Type in org.apache.yetus.audience
-
Can evolve while retaining compatibility for minor release boundaries.; can break compatibility only at major release (ie.
- InterfaceStability.Unstable - Annotation Type in org.apache.yetus.audience
-
No guarantee is provided as to reliability or stability across any level of release granularity.
- INTERMEDIATE - org.apache.zookeeper.client.ZooKeeperSaslClient.SaslState
- internalSendBuffer(ByteBuffer) - Method in class org.apache.zookeeper.server.NIOServerCnxn
-
This method implements the internals of sendBuffer.
- intValue() - Method in enum org.apache.zookeeper.KeeperException.Code
-
Get the int value for a particular Code.
- InvalidACL - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.INVALIDACL
instead - INVALIDACL - org.apache.zookeeper.KeeperException.Code
-
Invalid ACL specified
- InvalidACLException() - Constructor for exception org.apache.zookeeper.KeeperException.InvalidACLException
- InvalidACLException(String) - Constructor for exception org.apache.zookeeper.KeeperException.InvalidACLException
- InvalidCallback - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.INVALIDCALLBACK
instead - INVALIDCALLBACK - org.apache.zookeeper.KeeperException.Code
-
Invalid callback specified
- InvalidCallbackException() - Constructor for exception org.apache.zookeeper.KeeperException.InvalidCallbackException
- IOUtils - Class in org.apache.zookeeper.common
- IOUtils() - Constructor for class org.apache.zookeeper.common.IOUtils
- IPAuthenticationProvider - Class in org.apache.zookeeper.server.auth
- IPAuthenticationProvider() - Constructor for class org.apache.zookeeper.server.auth.IPAuthenticationProvider
- isAlive() - Method in enum org.apache.zookeeper.ZooKeeper.States
- isAuthenticated() - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
-
This method is used to check if the authentication done by this provider should be used to identify the creator of a node.
- isAuthenticated() - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
- isAuthenticated() - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
- isAuthenticated() - Method in class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
- isClosing() - Method in interface org.apache.zookeeper.server.SessionTracker.Session
- isClosing() - Method in class org.apache.zookeeper.server.SessionTrackerImpl.SessionImpl
- isComplete() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
- isComplete() - Method in class org.apache.zookeeper.server.ZooKeeperSaslServer
- isConnected() - Method in enum org.apache.zookeeper.ZooKeeper.States
-
Returns whether we are connected to a server (which could possibly be read-only, if this client is allowed to go to read-only mode)
- isDistributed() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- isEnabled() - Static method in class org.apache.zookeeper.client.ZooKeeperSaslClient
-
Returns true if the SASL client is enabled.
- isEnabled(String) - Static method in class org.apache.zookeeper.server.ServerCnxn
-
Check if the specified command is enabled.
- isEphemeral() - Method in enum org.apache.zookeeper.CreateMode
- isFailed() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
- isForceSync() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
the forceSync value.
- isHidden() - Method in interface org.apache.zookeeper.jmx.ZKMBeanInfo
-
If isHidden returns true, the MBean won't be registered with MBean server, and thus won't be available for management tools.
- isHidden() - Method in class org.apache.zookeeper.server.ConnectionBean
- isHidden() - Method in class org.apache.zookeeper.server.DataTreeBean
- isHidden() - Method in class org.apache.zookeeper.server.quorum.LeaderElectionBean
- isHidden() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
- isHidden() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
- isHidden() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
- isHidden() - Method in class org.apache.zookeeper.server.quorum.ServerBean
- isHidden() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- isInitialized() - Method in class org.apache.zookeeper.server.ZKDatabase
-
checks to see if the zk database has been initialized or not.
- isKnown(int) - Static method in class org.apache.zookeeper.server.ServerCnxn
-
Check if the specified command code is from a known command.
- isLogFileName(String) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Returns true if fileName is a log file name.
- isMoreRecentThan(StateSummary) - Method in class org.apache.zookeeper.server.quorum.StateSummary
- isroCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- isRunning() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- isRunning() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- isSequential() - Method in enum org.apache.zookeeper.CreateMode
- isSnapshotFileName(String) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Returns true if fileName is a snapshot file name.
- isSocketOpen() - Method in class org.apache.zookeeper.server.NIOServerCnxn
-
Only used in order to allow testing
- isSpecialPath(String) - Method in class org.apache.zookeeper.server.ZKDatabase
-
check if the path is special or not
- isTimedOut() - Method in class org.apache.zookeeper.Shell
-
To check if the passed script to shell command executor timed out or not.
- isTraceEnabled(Logger, long) - Static method in class org.apache.zookeeper.server.ZooTrace
- isValid(String) - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
-
Validates the syntax of an id.
- isValid(String) - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
- isValid(String) - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
- isValid(String) - Method in class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
- isValidSnapshot(File) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Verifies that the file is a valid snapshot.
- iterator() - Method in class org.apache.zookeeper.MultiResponse
- iterator() - Method in class org.apache.zookeeper.MultiTransactionRecord
J
- JAAS_CONF_KEY - Static variable in class org.apache.zookeeper.Environment
- JMX_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
- jmxDataTreeBean - Variable in class org.apache.zookeeper.server.ZooKeeperServer
- jmxServerBean - Variable in class org.apache.zookeeper.server.ZooKeeperServer
- join() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
- join() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- join() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
K
- KeeperException - Exception in org.apache.zookeeper
- KeeperException(KeeperException.Code) - Constructor for exception org.apache.zookeeper.KeeperException
- KeeperException.APIErrorException - Exception in org.apache.zookeeper
- KeeperException.AuthFailedException - Exception in org.apache.zookeeper
- KeeperException.BadArgumentsException - Exception in org.apache.zookeeper
- KeeperException.BadVersionException - Exception in org.apache.zookeeper
- KeeperException.Code - Enum in org.apache.zookeeper
-
Codes which represent the various KeeperException types.
- KeeperException.CodeDeprecated - Interface in org.apache.zookeeper
-
Deprecated.
- KeeperException.ConnectionLossException - Exception in org.apache.zookeeper
- KeeperException.DataInconsistencyException - Exception in org.apache.zookeeper
- KeeperException.InvalidACLException - Exception in org.apache.zookeeper
- KeeperException.InvalidCallbackException - Exception in org.apache.zookeeper
- KeeperException.MarshallingErrorException - Exception in org.apache.zookeeper
- KeeperException.NoAuthException - Exception in org.apache.zookeeper
- KeeperException.NoChildrenForEphemeralsException - Exception in org.apache.zookeeper
- KeeperException.NodeExistsException - Exception in org.apache.zookeeper
- KeeperException.NoNodeException - Exception in org.apache.zookeeper
- KeeperException.NotEmptyException - Exception in org.apache.zookeeper
- KeeperException.NotReadOnlyException - Exception in org.apache.zookeeper
- KeeperException.OperationTimeoutException - Exception in org.apache.zookeeper
- KeeperException.RuntimeInconsistencyException - Exception in org.apache.zookeeper
- KeeperException.SessionExpiredException - Exception in org.apache.zookeeper
- KeeperException.SessionMovedException - Exception in org.apache.zookeeper
- KeeperException.SystemErrorException - Exception in org.apache.zookeeper
- KeeperException.UnimplementedException - Exception in org.apache.zookeeper
- KerberosName - Class in org.apache.zookeeper.server.auth
-
This class implements parsing and handling of Kerberos principal names.
- KerberosName(String) - Constructor for class org.apache.zookeeper.server.auth.KerberosName
-
Create a name from the full Kerberos principal name.
- KerberosName.BadFormatString - Exception in org.apache.zookeeper.server.auth
- KerberosName.NoMatchingRule - Exception in org.apache.zookeeper.server.auth
- KerberosUtil - Class in org.apache.zookeeper.server.util
- KerberosUtil() - Constructor for class org.apache.zookeeper.server.util.KerberosUtil
- kill(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
- killSession(long, long) - Method in class org.apache.zookeeper.server.ZKDatabase
-
kill a given session in the datatree
- killSession(long, long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
L
- lastCxid - Variable in class org.apache.zookeeper.server.ServerCnxn
- lastLatency - Variable in class org.apache.zookeeper.server.ServerCnxn
- lastOp - Variable in class org.apache.zookeeper.server.ServerCnxn
- lastProcessedZxid - Variable in class org.apache.zookeeper.server.DataTree
- lastProcessedZxid - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1
- lastResponseTime - Variable in class org.apache.zookeeper.server.ServerCnxn
- lastZxid - Variable in class org.apache.zookeeper.server.ServerCnxn
- leader - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
- Leader - Class in org.apache.zookeeper.server.quorum
-
This class has the control logic for the Leader.
- Leader.Proposal - Class in org.apache.zookeeper.server.quorum
- Leader.XidRolloverException - Exception in org.apache.zookeeper.server.quorum
- LeaderBean - Class in org.apache.zookeeper.server.quorum
-
Leader MBean interface implementation.
- LeaderBean(Leader, ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.quorum.LeaderBean
- LeaderElection - Class in org.apache.zookeeper.server.quorum
-
Deprecated.This class has been deprecated as of release 3.4.0.
- LeaderElection(QuorumPeer) - Constructor for class org.apache.zookeeper.server.quorum.LeaderElection
-
Deprecated.
- LeaderElection.ElectionResult - Class in org.apache.zookeeper.server.quorum
-
Deprecated.
- LeaderElectionBean - Class in org.apache.zookeeper.server.quorum
-
Leader election MBean interface implementation
- LeaderElectionBean() - Constructor for class org.apache.zookeeper.server.quorum.LeaderElectionBean
- LeaderElectionMXBean - Interface in org.apache.zookeeper.server.quorum
-
Leader election protocol MBean.
- LEADERINFO - Static variable in class org.apache.zookeeper.server.quorum.Leader
-
This message is the first that a follower receives from the leader.
- leaderIs - Variable in class org.apache.zookeeper.server.quorum.Learner
- LeaderMXBean - Interface in org.apache.zookeeper.server.quorum
-
Leader MBean.
- leaderOs - Variable in class org.apache.zookeeper.server.quorum.Learner
- leaderProtocolVersion - Variable in class org.apache.zookeeper.server.quorum.Learner
-
the protocol version of the leader
- LeaderZooKeeperServer - Class in org.apache.zookeeper.server.quorum
-
Just like the standard ZooKeeperServer.
- LEADING - org.apache.zookeeper.server.quorum.QuorumPeer.ServerState
- LEADING_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
- Learner - Class in org.apache.zookeeper.server.quorum
-
This class is the superclass of two of the three main actors in a ZK ensemble: Followers and Observers.
- Learner() - Constructor for class org.apache.zookeeper.server.quorum.Learner
- LearnerHandler - Class in org.apache.zookeeper.server.quorum
-
There will be an instance of this class created by the Leader for each learner.
- LearnerInfo - Class in org.apache.zookeeper.server.quorum
- LearnerInfo() - Constructor for class org.apache.zookeeper.server.quorum.LearnerInfo
- LearnerInfo(long, int) - Constructor for class org.apache.zookeeper.server.quorum.LearnerInfo
- LearnerSessionTracker - Class in org.apache.zookeeper.server.quorum
-
This is really just a shell of a SessionTracker that tracks session activity to be forwarded to the Leader using a PING.
- LearnerSessionTracker(SessionTracker.SessionExpirer, ConcurrentHashMap<Long, Integer>, long, ZooKeeperServerListener) - Constructor for class org.apache.zookeeper.server.quorum.LearnerSessionTracker
- LearnerSyncRequest - Class in org.apache.zookeeper.server.quorum
- LearnerSyncRequest(LearnerHandler, long, int, int, ByteBuffer, List<Id>) - Constructor for class org.apache.zookeeper.server.quorum.LearnerSyncRequest
- LearnerZooKeeperServer - Class in org.apache.zookeeper.server.quorum
-
Parent class for all ZooKeeperServers for Learners
- LearnerZooKeeperServer(FileTxnSnapLog, int, int, int, ZooKeeperServer.DataTreeBuilder, ZKDatabase, QuorumPeer) - Constructor for class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
- limitNode - Static variable in class org.apache.zookeeper.Quotas
-
the limit node that has the limit of a subtree
- list() - Static method in class org.apache.zookeeper.Environment
- listener - Variable in class org.apache.zookeeper.server.quorum.QuorumCnxManager
- Listener() - Constructor for class org.apache.zookeeper.server.quorum.QuorumCnxManager.Listener
- listProviders() - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
- listSubTreeBFS(ZooKeeper, String) - Static method in class org.apache.zookeeper.ZKUtil
-
BFS Traversal of the system under pathRoot, with the entries in the list, in the same order as that of the traversal.
- loadData() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
Restore sessions and data
- loadDataBase() - Method in class org.apache.zookeeper.server.ZKDatabase
-
load the database from the disk onto memory and also add the transactions to the committedlog in memory.
- LocalPeerBean - Class in org.apache.zookeeper.server.quorum
-
Implementation of the local peer MBean interface.
- LocalPeerBean(QuorumPeer) - Constructor for class org.apache.zookeeper.server.quorum.LocalPeerBean
- LocalPeerMXBean - Interface in org.apache.zookeeper.server.quorum
-
A local zookeeper server MBean interface.
- LOG - Static variable in class org.apache.zookeeper.client.FourLetterWordMain
- LOG - Static variable in class org.apache.zookeeper.server.quorum.Learner
- LOG - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
- LOG_FILE_PREFIX - Static variable in class org.apache.zookeeper.server.persistence.FileTxnLog
- LogDirContentCheckException(String) - Constructor for exception org.apache.zookeeper.server.persistence.FileTxnSnapLog.LogDirContentCheckException
- logEnv(String, Logger) - Static method in class org.apache.zookeeper.Environment
- LogFormatter - Class in org.apache.zookeeper.server
- LogFormatter() - Constructor for class org.apache.zookeeper.server.LogFormatter
- login - Variable in class org.apache.zookeeper.server.ServerCnxnFactory
- login() - Method in class org.apache.zookeeper.server.auth.DigestLoginModule
- Login - Class in org.apache.zookeeper
- Login(String, CallbackHandler) - Constructor for class org.apache.zookeeper.Login
-
LoginThread constructor.
- LOGIN_CONTEXT_NAME_KEY - Static variable in class org.apache.zookeeper.client.ZooKeeperSaslClient
- LOGIN_CONTEXT_NAME_KEY - Static variable in class org.apache.zookeeper.server.ZooKeeperSaslServer
- logLock - Variable in class org.apache.zookeeper.server.ZKDatabase
- logout() - Method in class org.apache.zookeeper.server.auth.DigestLoginModule
- logQuorumPacket(Logger, long, char, QuorumPacket) - Static method in class org.apache.zookeeper.server.ZooTrace
- logRequest(TxnHeader, Record) - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
- logRequest(Logger, long, char, Request, String) - Static method in class org.apache.zookeeper.server.ZooTrace
- logTraceMessage(Logger, long, String) - Static method in class org.apache.zookeeper.server.ZooTrace
- lookForLeader() - Method in class org.apache.zookeeper.server.quorum.AuthFastLeaderElection
-
Deprecated.Invoked in QuorumPeer to find or elect a new leader.
- lookForLeader() - Method in interface org.apache.zookeeper.server.quorum.Election
- lookForLeader() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
-
Starts a new round of leader election.
- lookForLeader() - Method in class org.apache.zookeeper.server.quorum.LeaderElection
-
Deprecated.Invoked in QuorumPeer to find or elect a new leader.
- LOOKING - org.apache.zookeeper.server.quorum.QuorumPeer.ServerState
- LOOKING_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
M
- main(String[]) - Static method in class org.apache.zookeeper.client.FourLetterWordMain
- main(String[]) - Static method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
-
Call with a single argument of user:pass to generate authdata.
- main(String[]) - Static method in class org.apache.zookeeper.server.auth.KerberosName
- main(String[]) - Static method in class org.apache.zookeeper.server.LogFormatter
- main(String[]) - Static method in class org.apache.zookeeper.server.persistence.TxnLogToolkit
- main(String[]) - Static method in class org.apache.zookeeper.server.PurgeTxnLog
- main(String[]) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerMain
-
To start the replicated server specify the configuration file name on the command line.
- main(String[]) - Static method in class org.apache.zookeeper.server.SnapshotFormatter
-
USAGE: SnapshotFormatter snapshot_file
- main(String[]) - Static method in class org.apache.zookeeper.server.TraceFormatter
- main(String[]) - Static method in class org.apache.zookeeper.server.upgrade.UpgradeMain
- main(String[]) - Static method in class org.apache.zookeeper.server.ZooKeeperServerMain
- main(String[]) - Static method in class org.apache.zookeeper.ServerAdminClient
- main(String[]) - Static method in class org.apache.zookeeper.Version
-
Prints the current version, revision and build date to the standard out.
- main(String[]) - Static method in class org.apache.zookeeper.version.util.VerGen
-
Emits a org.apache.zookeeper.version.Info interface file with version and revision information constants set to the values passed in as command line parameters.
- main(String[]) - Static method in class org.apache.zookeeper.ZooKeeperMain
- maj - Variable in class org.apache.zookeeper.version.util.VerGen.Version
- MAJOR - Static variable in interface org.apache.zookeeper.version.Info
- makeChecksumAlgorithm() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
create a checksum algorithm
- makeChecksumAlgorithm() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
creates a checksum algorithm to be used
- makeFileLoggerURL(File, File) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Given two directory files the method returns a well-formed logfile provider URI.
- makeFileLoggerURL(File, File, String) - Static method in class org.apache.zookeeper.server.persistence.Util
- makeFollower(FileTxnSnapLog) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- makeFullPath(String, String...) - Method in class org.apache.zookeeper.jmx.MBeanRegistry
-
Generate a filesystem-like path.
- makeFullPath(String, ZKMBeanInfo) - Method in class org.apache.zookeeper.jmx.MBeanRegistry
- makeLeader(FileTxnSnapLog) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- makeLEStrategy() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- makeLogName(long) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Creates a valid transaction log file name.
- makeObjectName(String, ZKMBeanInfo) - Method in class org.apache.zookeeper.jmx.MBeanRegistry
-
Builds an MBean path and creates an ObjectName instance using the path.
- makeObserver(FileTxnSnapLog) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- makeSnapshotName(long) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Creates a snapshot file name.
- makeURIString(String, String, String) - Static method in class org.apache.zookeeper.server.persistence.Util
- makeZxid(long, long) - Static method in class org.apache.zookeeper.server.util.ZxidUtils
- ManagedUtil - Class in org.apache.zookeeper.jmx
-
Shared utilities
- ManagedUtil() - Constructor for class org.apache.zookeeper.jmx.ManagedUtil
- MarshallingError - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.MARSHALLINGERROR
instead - MARSHALLINGERROR - org.apache.zookeeper.KeeperException.Code
-
Error while marshalling or unmarshalling data
- MarshallingErrorException() - Constructor for exception org.apache.zookeeper.KeeperException.MarshallingErrorException
- marshallTxnEntry(TxnHeader, Record) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Serializes transaction header and transaction data into a byte buffer.
- matches(String, String) - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
-
This method is called to see if the given id matches the given id expression in the ACL.
- matches(String, String) - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
- matches(String, String) - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
- matches(String, String) - Method in class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
- materialize(Watcher.Event.KeeperState, Watcher.Event.EventType, String) - Method in interface org.apache.zookeeper.ClientWatchManager
-
Return a set of watchers that should be notified of the event.
- maxBuffer - Static variable in class org.apache.zookeeper.server.quorum.QuorumCnxManager
- maxClientCnxns - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- maxClientCnxns - Variable in class org.apache.zookeeper.server.ServerConfig
- maxCommittedLog - Variable in class org.apache.zookeeper.server.ZKDatabase
- maxLatency - Variable in class org.apache.zookeeper.server.ServerCnxn
- maxSessionTimeout - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Maximum number of milliseconds to allow for session timeout.
- maxSessionTimeout - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
defaults to -1 if not set explicitly
- maxSessionTimeout - Variable in class org.apache.zookeeper.server.ServerConfig
-
defaults to -1 if not set explicitly
- maxSessionTimeout - Variable in class org.apache.zookeeper.server.ZooKeeperServer
-
value of -1 indicates unset, use default
- MBeanRegistry - Class in org.apache.zookeeper.jmx
-
This class provides a unified interface for registering/unregistering of zookeeper MBeans with the platform MBean server.
- MBeanRegistry() - Constructor for class org.apache.zookeeper.jmx.MBeanRegistry
- me - Static variable in class org.apache.zookeeper.server.ServerCnxn
- micro - Variable in class org.apache.zookeeper.version.util.VerGen.Version
- MICRO - Static variable in interface org.apache.zookeeper.version.Info
- min - Variable in class org.apache.zookeeper.version.util.VerGen.Version
- minCommittedLog - Variable in class org.apache.zookeeper.server.ZKDatabase
- minLatency - Variable in class org.apache.zookeeper.server.ServerCnxn
- MINOR - Static variable in interface org.apache.zookeeper.version.Info
- minSessionTimeout - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Minimum number of milliseconds to allow for session timeout.
- minSessionTimeout - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
defaults to -1 if not set explicitly
- minSessionTimeout - Variable in class org.apache.zookeeper.server.ServerConfig
-
defaults to -1 if not set explicitly
- minSessionTimeout - Variable in class org.apache.zookeeper.server.ZooKeeperServer
-
value of -1 indicates unset, use default
- MissingSessionException(String) - Constructor for exception org.apache.zookeeper.server.ZooKeeperServer.MissingSessionException
- mntrCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- multi - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- multi(Iterable<Op>) - Method in class org.apache.zookeeper.ZooKeeper
-
Executes multiple ZooKeeper operations or none of them.
- multi(Iterable<Op>, AsyncCallback.MultiCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of multi.
- MultiHeader - Class in org.apache.zookeeper.proto
- MultiHeader() - Constructor for class org.apache.zookeeper.proto.MultiHeader
- MultiHeader(int, boolean, int) - Constructor for class org.apache.zookeeper.proto.MultiHeader
- multiInternal(MultiTransactionRecord) - Method in class org.apache.zookeeper.ZooKeeper
- multiInternal(MultiTransactionRecord, AsyncCallback.MultiCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
- MultiResponse - Class in org.apache.zookeeper
-
Handles the response from a multi request.
- MultiResponse() - Constructor for class org.apache.zookeeper.MultiResponse
- multiResult - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
- MultiTransactionRecord - Class in org.apache.zookeeper
-
Encodes a composite transaction.
- MultiTransactionRecord() - Constructor for class org.apache.zookeeper.MultiTransactionRecord
- MultiTransactionRecord(Iterable<Op>) - Constructor for class org.apache.zookeeper.MultiTransactionRecord
- MultiTxn - Class in org.apache.zookeeper.txn
- MultiTxn() - Constructor for class org.apache.zookeeper.txn.MultiTxn
- MultiTxn(List<Txn>) - Constructor for class org.apache.zookeeper.txn.MultiTxn
N
- NettyServerCnxn - Class in org.apache.zookeeper.server
- NettyServerCnxnFactory - Class in org.apache.zookeeper.server
- next() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
the iterator that moves to the next transaction
- next() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
-
go to the next transaction record.
- next(long) - Method in interface org.apache.zookeeper.client.HostProvider
-
The next host to try to connect to.
- next(long) - Method in class org.apache.zookeeper.client.StaticHostProvider
- nextPacketIsAuth(DataInputStream) - Static method in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- NIOServerCnxn - Class in org.apache.zookeeper.server
-
This class handles communication with clients using NIO.
- NIOServerCnxn(ZooKeeperServer, SocketChannel, SelectionKey, NIOServerCnxnFactory) - Constructor for class org.apache.zookeeper.server.NIOServerCnxn
- NIOServerCnxnFactory - Class in org.apache.zookeeper.server
- NIOServerCnxnFactory() - Constructor for class org.apache.zookeeper.server.NIOServerCnxnFactory
-
Construct a new server connection factory which will accept an unlimited number of concurrent connections from each client (up to the file descriptor limits of the operating system).
- NoAuth - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.NOAUTH
instead - NOAUTH - org.apache.zookeeper.KeeperException.Code
-
Not authenticated
- NoAuthException() - Constructor for exception org.apache.zookeeper.KeeperException.NoAuthException
- NoChildrenForEphemerals - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.NOCHILDRENFOREPHEMERALS
instead - NOCHILDRENFOREPHEMERALS - org.apache.zookeeper.KeeperException.Code
-
Ephemeral nodes may not have children
- NoChildrenForEphemeralsException() - Constructor for exception org.apache.zookeeper.KeeperException.NoChildrenForEphemeralsException
- NoChildrenForEphemeralsException(String) - Constructor for exception org.apache.zookeeper.KeeperException.NoChildrenForEphemeralsException
- NodeChildrenChanged - org.apache.zookeeper.Watcher.Event.EventType
- NodeCreated - org.apache.zookeeper.Watcher.Event.EventType
- NodeDataChanged - org.apache.zookeeper.Watcher.Event.EventType
- NodeDeleted - org.apache.zookeeper.Watcher.Event.EventType
- NodeExists - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.NODEEXISTS
instead - NODEEXISTS - org.apache.zookeeper.KeeperException.Code
-
The node already exists
- NodeExistsException() - Constructor for exception org.apache.zookeeper.KeeperException.NodeExistsException
- NodeExistsException(String) - Constructor for exception org.apache.zookeeper.KeeperException.NodeExistsException
- None - org.apache.zookeeper.Watcher.Event.EventType
- NoNode - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.NONODE
instead - NONODE - org.apache.zookeeper.KeeperException.Code
-
Node does not exist
- NoNodeException() - Constructor for exception org.apache.zookeeper.KeeperException.NoNodeException
- NoNodeException(String) - Constructor for exception org.apache.zookeeper.KeeperException.NoNodeException
- NoSyncConnected - org.apache.zookeeper.Watcher.Event.KeeperState
-
Deprecated.
- NOT_CONNECTED - org.apache.zookeeper.ZooKeeper.States
- NOT_STARTED - org.apache.zookeeper.server.DatadirCleanupManager.PurgeTaskStatus
- NotEmpty - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.NOTEMPTY
instead - NOTEMPTY - org.apache.zookeeper.KeeperException.Code
-
The node has children
- NotEmptyException() - Constructor for exception org.apache.zookeeper.KeeperException.NotEmptyException
- NotEmptyException(String) - Constructor for exception org.apache.zookeeper.KeeperException.NotEmptyException
- notification - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- Notification() - Constructor for class org.apache.zookeeper.server.quorum.AuthFastLeaderElection.Notification
-
Deprecated.
- Notification() - Constructor for class org.apache.zookeeper.server.quorum.FastLeaderElection.Notification
- notifyStopping(String, int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerListener
-
This will notify the server that some critical thread has stopped.
- NOTREADONLY - org.apache.zookeeper.KeeperException.Code
-
State-changing request is passed to read-only server
- NotReadOnlyException() - Constructor for exception org.apache.zookeeper.KeeperException.NotReadOnlyException
- NullQuorumAuthLearner - Class in org.apache.zookeeper.server.quorum.auth
-
This class represents no authentication learner, it just return without performing any authentication.
- NullQuorumAuthLearner() - Constructor for class org.apache.zookeeper.server.quorum.auth.NullQuorumAuthLearner
- NullQuorumAuthServer - Class in org.apache.zookeeper.server.quorum.auth
-
This class represents no authentication server, it just return without performing any authentication.
- NullQuorumAuthServer() - Constructor for class org.apache.zookeeper.server.quorum.auth.NullQuorumAuthServer
- numGroups - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- numValidVotes - Variable in class org.apache.zookeeper.server.quorum.LeaderElection.ElectionResult
-
Deprecated.
O
- observer - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
- Observer - Class in org.apache.zookeeper.server.quorum
-
Observers are peers that do not take part in the atomic broadcast protocol.
- OBSERVER - org.apache.zookeeper.server.quorum.QuorumPeer.LearnerType
- ObserverBean - Class in org.apache.zookeeper.server
-
ObserverBean
- ObserverBean(Observer, ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.ObserverBean
- ObserverMXBean - Interface in org.apache.zookeeper.server.quorum
-
Observer MX Bean interface, implemented by ObserverBean
- ObserverRequestProcessor - Class in org.apache.zookeeper.server.quorum
-
This RequestProcessor forwards any requests that modify the state of the system to the Leader.
- ObserverRequestProcessor(ObserverZooKeeperServer, RequestProcessor) - Constructor for class org.apache.zookeeper.server.quorum.ObserverRequestProcessor
-
Constructor - takes an ObserverZooKeeperServer to associate with and the next processor to pass requests to after we're finished.
- observers - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- ObserverZooKeeperServer - Class in org.apache.zookeeper.server.quorum
-
A ZooKeeperServer for the Observer node type.
- OBSERVING - org.apache.zookeeper.server.quorum.QuorumPeer.ServerState
- OBSERVING_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
- ok - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
- Ok - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.OK
instead - OK - org.apache.zookeeper.KeeperException.Code
-
Everything is OK
- onConnected() - Method in interface org.apache.zookeeper.client.HostProvider
-
Notify the HostProvider of a successful connection.
- onConnected() - Method in class org.apache.zookeeper.client.StaticHostProvider
- onTxnLoaded(TxnHeader, Record) - Method in interface org.apache.zookeeper.server.persistence.FileTxnSnapLog.PlayBackListener
- ooePredicate(HashMap<Long, Vote>, HashMap<Long, Vote>, FastLeaderElection.Notification) - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
-
This predicate checks that a leader has been elected.
- Op - Class in org.apache.zookeeper
-
Represents a single operation in a multi-operation transaction.
- Op.Check - Class in org.apache.zookeeper
- Op.Create - Class in org.apache.zookeeper
- Op.Delete - Class in org.apache.zookeeper
- Op.SetData - Class in org.apache.zookeeper
- op2String(int) - Static method in class org.apache.zookeeper.server.TraceFormatter
- OPEN_ACL_UNSAFE - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
-
This is a completely open ACL .
- OperationTimeout - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.OPERATIONTIMEOUT
instead - OPERATIONTIMEOUT - org.apache.zookeeper.KeeperException.Code
-
Operation timeout
- OperationTimeoutException() - Constructor for exception org.apache.zookeeper.KeeperException.OperationTimeoutException
- opNames - Static variable in class org.apache.zookeeper.ZooDefs
- OpResult - Class in org.apache.zookeeper
-
Encodes the result of a single part of a multiple operation commit.
- OpResult.CheckResult - Class in org.apache.zookeeper
-
A result from a version check operation.
- OpResult.CreateResult - Class in org.apache.zookeeper
-
A result from a create operation.
- OpResult.DeleteResult - Class in org.apache.zookeeper
-
A result from a delete operation.
- OpResult.ErrorResult - Class in org.apache.zookeeper
-
An error result from any kind of operation.
- OpResult.SetDataResult - Class in org.apache.zookeeper
-
A result from a setData operation.
- org.apache.yetus.audience - package org.apache.yetus.audience
- org.apache.zookeeper - package org.apache.zookeeper
- org.apache.zookeeper.client - package org.apache.zookeeper.client
- org.apache.zookeeper.common - package org.apache.zookeeper.common
- org.apache.zookeeper.data - package org.apache.zookeeper.data
- org.apache.zookeeper.jmx - package org.apache.zookeeper.jmx
- org.apache.zookeeper.proto - package org.apache.zookeeper.proto
- org.apache.zookeeper.server - package org.apache.zookeeper.server
-
ZooKeeper server theory of operation
- org.apache.zookeeper.server.auth - package org.apache.zookeeper.server.auth
- org.apache.zookeeper.server.persistence - package org.apache.zookeeper.server.persistence
- org.apache.zookeeper.server.quorum - package org.apache.zookeeper.server.quorum
- org.apache.zookeeper.server.quorum.auth - package org.apache.zookeeper.server.quorum.auth
- org.apache.zookeeper.server.quorum.flexible - package org.apache.zookeeper.server.quorum.flexible
- org.apache.zookeeper.server.upgrade - package org.apache.zookeeper.server.upgrade
- org.apache.zookeeper.server.util - package org.apache.zookeeper.server.util
- org.apache.zookeeper.txn - package org.apache.zookeeper.txn
- org.apache.zookeeper.util - package org.apache.zookeeper.util
- org.apache.zookeeper.version - package org.apache.zookeeper.version
- org.apache.zookeeper.version.util - package org.apache.zookeeper.version.util
- OSMXBean - Class in org.apache.zookeeper.server.util
-
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.
- OSMXBean() - Constructor for class org.apache.zookeeper.server.util.OSMXBean
-
Constructor.
P
- packet - Variable in class org.apache.zookeeper.server.quorum.Leader.Proposal
- packetLen - Static variable in class org.apache.zookeeper.ClientCnxn
- packetReceived() - Method in class org.apache.zookeeper.server.ServerCnxn
- packetSent() - Method in class org.apache.zookeeper.server.ServerCnxn
- packetsReceived - Variable in class org.apache.zookeeper.server.ServerCnxn
- packetsSent - Variable in class org.apache.zookeeper.server.ServerCnxn
- packetToString(QuorumPacket) - Static method in class org.apache.zookeeper.server.quorum.LearnerHandler
- parse(String) - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
Parse a ZooKeeper configuration file
- parse(String) - Method in class org.apache.zookeeper.server.ServerConfig
-
Parse a ZooKeeper configuration file
- parse(String[]) - Method in class org.apache.zookeeper.server.ServerConfig
-
Parse arguments for server configuration
- parseExecResult(BufferedReader) - Method in class org.apache.zookeeper.Shell
-
Parse the execution result
- parseExecResult(BufferedReader) - Method in class org.apache.zookeeper.Shell.ShellCommandExecutor
- parseProperties(Properties) - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
Parse config from a Properties.
- parseVersionString(String) - Static method in class org.apache.zookeeper.version.util.VerGen
- PARTICIPANT - org.apache.zookeeper.server.quorum.QuorumPeer.LearnerType
- path - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
- PathTrie - Class in org.apache.zookeeper.common
-
a class that implements prefix matching for components of a filesystem path.
- PathTrie() - Constructor for class org.apache.zookeeper.common.PathTrie
-
construct a new PathTrie with a root node of /
- PathUtils - Class in org.apache.zookeeper.common
-
Path related utilities
- PathUtils() - Constructor for class org.apache.zookeeper.common.PathUtils
- peerType - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- PERSISTENT - org.apache.zookeeper.CreateMode
-
The znode will not be automatically deleted upon client's disconnect.
- PERSISTENT_SEQUENTIAL - org.apache.zookeeper.CreateMode
-
The znode will not be automatically deleted upon client's disconnect, and its name will be appended with a monotonically increasing number.
- ping - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- ping() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
-
ping calls from the leader to the peers
- ping(QuorumPacket) - Method in class org.apache.zookeeper.server.quorum.Learner
- playLog(InputArchive) - Method in class org.apache.zookeeper.server.upgrade.UpgradeSnapShotV1
-
play the log from this logstream into the datatree
- pollRecvQueue(long, TimeUnit) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Retrieves and removes a message at the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
- port - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
- PrepRequestProcessor - Class in org.apache.zookeeper.server
-
This request processor is generally at the start of a RequestProcessor change.
- PrepRequestProcessor(ZooKeeperServer, RequestProcessor) - Constructor for class org.apache.zookeeper.server.PrepRequestProcessor
- pRequest(Request) - Method in class org.apache.zookeeper.server.PrepRequestProcessor
-
This method will be called inside the ProcessRequestThread, which is a singleton, so there will be a single thread calling this code.
- pRequest2Txn(int, long, Request, Record, boolean) - Method in class org.apache.zookeeper.server.PrepRequestProcessor
-
This method will be called inside the ProcessRequestThread, which is a singleton, so there will be a single thread calling this code.
- printMessage(String) - Static method in class org.apache.zookeeper.ZooKeeperMain
- printUsage() - Static method in class org.apache.zookeeper.Version
- printWatches - Variable in class org.apache.zookeeper.ZooKeeperMain
- process(WatchedEvent) - Method in class org.apache.zookeeper.server.NettyServerCnxn
- process(WatchedEvent) - Method in class org.apache.zookeeper.server.NIOServerCnxn
- process(WatchedEvent) - Method in class org.apache.zookeeper.server.ServerCnxn
- process(WatchedEvent) - Method in interface org.apache.zookeeper.Watcher
- processAck(long, long, SocketAddress) - Method in class org.apache.zookeeper.server.quorum.Leader
-
Keep a count of acks that are received by the leader for a particular proposal
- processCmd(ZooKeeperMain.MyCommandOptions) - Method in class org.apache.zookeeper.ZooKeeperMain
- processConnectRequest(ServerCnxn, ByteBuffer) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- processPacket(ByteBuffer, ServerCnxn) - Method in interface org.apache.zookeeper.server.ServerCnxnFactory.PacketProcessor
- processPacket(QuorumPacket) - Method in class org.apache.zookeeper.server.quorum.Follower
-
Examine the packet received in qp and dispatch based on its contents.
- processPacket(QuorumPacket) - Method in class org.apache.zookeeper.server.quorum.Observer
-
Controls the response of an observer to the receipt of a quorumpacket
- processPacket(ServerCnxn, ByteBuffer) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- processRequest(Request) - Method in class org.apache.zookeeper.server.FinalRequestProcessor
- processRequest(Request) - Method in class org.apache.zookeeper.server.PrepRequestProcessor
- processRequest(Request) - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
- processRequest(Request) - Method in class org.apache.zookeeper.server.quorum.FollowerRequestProcessor
- processRequest(Request) - Method in class org.apache.zookeeper.server.quorum.ObserverRequestProcessor
-
Simply queue the request, which will be processed in FIFO order.
- processRequest(Request) - Method in class org.apache.zookeeper.server.quorum.ProposalRequestProcessor
- processRequest(Request) - Method in class org.apache.zookeeper.server.quorum.ReadOnlyRequestProcessor
- processRequest(Request) - Method in class org.apache.zookeeper.server.quorum.SendAckRequestProcessor
- processRequest(Request) - Method in interface org.apache.zookeeper.server.RequestProcessor
- processRequest(Request) - Method in class org.apache.zookeeper.server.SyncRequestProcessor
- processRequest(Request) - Method in class org.apache.zookeeper.server.UnimplementedRequestProcessor
- processResult(int, String, Object) - Method in interface org.apache.zookeeper.AsyncCallback.VoidCallback
-
Process the result of the asynchronous call.
- processResult(int, String, Object, byte[], Stat) - Method in interface org.apache.zookeeper.AsyncCallback.DataCallback
-
Process the result of the asynchronous call.
- processResult(int, String, Object, byte[], Stat) - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient.ServerSaslResponseCallback
- processResult(int, String, Object, String) - Method in interface org.apache.zookeeper.AsyncCallback.StringCallback
-
Process the result of the asynchronous call.
- processResult(int, String, Object, List<String>) - Method in interface org.apache.zookeeper.AsyncCallback.ChildrenCallback
-
Process the result of the asynchronous call.
- processResult(int, String, Object, List<String>, Stat) - Method in interface org.apache.zookeeper.AsyncCallback.Children2Callback
-
Process the result of the asynchronous call.
- processResult(int, String, Object, List<ACL>, Stat) - Method in interface org.apache.zookeeper.AsyncCallback.ACLCallback
-
Process the result of the asynchronous call.
- processResult(int, String, Object, List<OpResult>) - Method in interface org.apache.zookeeper.AsyncCallback.MultiCallback
-
Process the result of the asynchronous call.
- processResult(int, String, Object, Stat) - Method in interface org.apache.zookeeper.AsyncCallback.StatCallback
-
Process the result of the asynchronous call.
- processSync(LearnerSyncRequest) - Method in class org.apache.zookeeper.server.quorum.Leader
-
Process sync requests
- processTransaction(TxnHeader, DataTree, Map<Long, Integer>, Record) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
process the transaction on the datatree
- processTxn(TxnHeader, Record) - Method in class org.apache.zookeeper.server.DataTree
- processTxn(TxnHeader, Record) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- processTxn(TxnHeader, Record) - Method in class org.apache.zookeeper.server.ZKDatabase
-
the process txn on the data
- processTxn(TxnHeader, Record) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- ProcessTxnResult() - Constructor for class org.apache.zookeeper.server.DataTree.ProcessTxnResult
- ProcessTxnResult() - Constructor for class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
- processZKCmd(ZooKeeperMain.MyCommandOptions) - Method in class org.apache.zookeeper.ZooKeeperMain
- procZookeeper - Static variable in class org.apache.zookeeper.Quotas
-
the zookeeper nodes that acts as the management and status node
- profile(Profiler.Operation<T>, long, String) - Static method in class org.apache.zookeeper.server.util.Profiler
- Profiler - Class in org.apache.zookeeper.server.util
- Profiler() - Constructor for class org.apache.zookeeper.server.util.Profiler
- Profiler.Operation<T> - Interface in org.apache.zookeeper.server.util
- Proposal() - Constructor for class org.apache.zookeeper.server.quorum.Leader.Proposal
- PROPOSAL - Static variable in class org.apache.zookeeper.server.quorum.Leader
-
This message type is sent by a leader to propose a mutation.
- ProposalRequestProcessor - Class in org.apache.zookeeper.server.quorum
-
This RequestProcessor simply forwards requests to an AckRequestProcessor and SyncRequestProcessor.
- ProposalRequestProcessor(LeaderZooKeeperServer, RequestProcessor) - Constructor for class org.apache.zookeeper.server.quorum.ProposalRequestProcessor
- ProposalStats - Class in org.apache.zookeeper.server.quorum
-
Provides live statistics about a running Leader.
- ProposalStats() - Constructor for class org.apache.zookeeper.server.quorum.ProposalStats
- propose(Request) - Method in class org.apache.zookeeper.server.quorum.Leader
-
create a proposal and send it out to all the members
- ProviderRegistry - Class in org.apache.zookeeper.server.auth
- ProviderRegistry() - Constructor for class org.apache.zookeeper.server.auth.ProviderRegistry
- purge(File, File, int) - Static method in class org.apache.zookeeper.server.PurgeTxnLog
-
Purges the snapshot and logs keeping the last num snapshots and the corresponding logs.
- purgeInterval - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- PurgeTxnLog - Class in org.apache.zookeeper.server
-
this class is used to clean up the snapshot and data log dir's.
- PurgeTxnLog() - Constructor for class org.apache.zookeeper.server.PurgeTxnLog
- purgeUnused() - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
Q
- qualifier - Variable in class org.apache.zookeeper.version.util.VerGen.Version
- QUALIFIER - Static variable in interface org.apache.zookeeper.version.Info
- QUORUM_AUTH_MAGIC_NUMBER - Static variable in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- QUORUM_HOSTNAME_PATTERN - Static variable in class org.apache.zookeeper.util.SecurityUtils
- QUORUM_KERBEROS_SERVICE_PRINCIPAL - Static variable in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- QUORUM_KERBEROS_SERVICE_PRINCIPAL_DEFAULT_VALUE - Static variable in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- QUORUM_LEARNER_SASL_AUTH_REQUIRED - Static variable in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- QUORUM_LEARNER_SASL_LOGIN_CONTEXT - Static variable in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- QUORUM_LEARNER_SASL_LOGIN_CONTEXT_DFAULT_VALUE - Static variable in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- QUORUM_SASL_AUTH_ENABLED - Static variable in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- QUORUM_SERVER_SASL_AUTH_REQUIRED - Static variable in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- QUORUM_SERVER_SASL_LOGIN_CONTEXT - Static variable in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- QUORUM_SERVER_SASL_LOGIN_CONTEXT_DFAULT_VALUE - Static variable in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- QuorumAuth - Class in org.apache.zookeeper.server.quorum.auth
- QuorumAuth() - Constructor for class org.apache.zookeeper.server.quorum.auth.QuorumAuth
- QuorumAuth.Status - Enum in org.apache.zookeeper.server.quorum.auth
- QuorumAuthLearner - Interface in org.apache.zookeeper.server.quorum.auth
-
Interface for quorum learner authentication mechanisms.
- QuorumAuthPacket - Class in org.apache.zookeeper.server.quorum
- QuorumAuthPacket() - Constructor for class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- QuorumAuthPacket(long, int, byte[]) - Constructor for class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- QuorumAuthServer - Interface in org.apache.zookeeper.server.quorum.auth
-
Interface for quorum server authentication mechanisms.
- QuorumBean - Class in org.apache.zookeeper.server.quorum
- QuorumBean(QuorumPeer) - Constructor for class org.apache.zookeeper.server.quorum.QuorumBean
- QuorumCnxManager - Class in org.apache.zookeeper.server.quorum
-
This class implements a connection manager for leader election using TCP.
- QuorumCnxManager(long, Map<Long, QuorumPeer.QuorumServer>, QuorumAuthServer, QuorumAuthLearner, int, boolean, int, boolean) - Constructor for class org.apache.zookeeper.server.quorum.QuorumCnxManager
- QuorumCnxManager(long, Map<Long, QuorumPeer.QuorumServer>, QuorumAuthServer, QuorumAuthLearner, int, boolean, int, boolean, ConcurrentHashMap<Long, QuorumCnxManager.SendWorker>) - Constructor for class org.apache.zookeeper.server.quorum.QuorumCnxManager
- QuorumCnxManager.Listener - Class in org.apache.zookeeper.server.quorum
-
Thread to listen on some port
- QuorumCnxManager.Message - Class in org.apache.zookeeper.server.quorum
- quorumCnxnThreadsSize - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
The maximum number of threads to allow in the connectionExecutors thread pool which will be used to initiate quorum server connections.
- quorumCnxnThreadsSize - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- quorumEnableSasl - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- quorumFormed - Variable in class org.apache.zookeeper.server.quorum.Leader
- QuorumHierarchical - Class in org.apache.zookeeper.server.quorum.flexible
-
This class implements a validator for hierarchical quorums.
- QuorumHierarchical(int, HashMap<Long, Long>, HashMap<Long, Long>) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
-
This contructor takes the two hash maps needed to enable validating quorums.
- QuorumHierarchical(String) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
-
This contructor requires the quorum configuration to be declared in a separate file, and it takes the file as an input parameter.
- QuorumHierarchical(Properties) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
-
This constructor takes a set of properties.
- quorumLearnerLoginContext - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Quorum learner login context name in jaas-conf file to read the kerberos security details.
- quorumLearnerLoginContext - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- quorumLearnerRequireSasl - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- quorumLearnerSaslAuthRequired - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
If this is false, quorum peer learner will talk to quorum peer server without authentication.
- quorumListenOnAllIPs - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Whether or not to listen on all IPs for the two quorum ports (broadcast and fast leader election).
- quorumListenOnAllIPs - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- QuorumMaj - Class in org.apache.zookeeper.server.quorum.flexible
-
This class implements a validator for majority quorums.
- QuorumMaj(int) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
-
Defines a majority to avoid computing it every time.
- QuorumMXBean - Interface in org.apache.zookeeper.server.quorum
-
An MBean representing a zookeeper cluster nodes (aka quorum peers)
- QuorumPacket - Class in org.apache.zookeeper.server.quorum
- QuorumPacket() - Constructor for class org.apache.zookeeper.server.quorum.QuorumPacket
- QuorumPacket(int, long, byte[], List<Id>) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPacket
- quorumPeer - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerMain
- QuorumPeer - Class in org.apache.zookeeper.server.quorum
-
This class manages the quorum protocol.
- QuorumPeer() - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
- QuorumPeer(Map<Long, QuorumPeer.QuorumServer>, File, File, int, int, long, int, int, int) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
-
This constructor is only used by the existing unit test code.
- QuorumPeer(Map<Long, QuorumPeer.QuorumServer>, File, File, int, int, long, int, int, int, QuorumVerifier) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
-
This constructor is only used by the existing unit test code.
- QuorumPeer(Map<Long, QuorumPeer.QuorumServer>, File, File, int, long, int, int, int, boolean, ServerCnxnFactory, QuorumVerifier) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
- QuorumPeer(Map<Long, QuorumPeer.QuorumServer>, File, File, int, long, int, int, int, ServerCnxnFactory) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
-
For backward compatibility purposes, we instantiate QuorumMaj by default.
- QuorumPeer.LearnerType - Enum in org.apache.zookeeper.server.quorum
- QuorumPeer.QuorumServer - Class in org.apache.zookeeper.server.quorum
- QuorumPeer.ServerState - Enum in org.apache.zookeeper.server.quorum
- QuorumPeerConfig - Class in org.apache.zookeeper.server.quorum
- QuorumPeerConfig() - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- QuorumPeerConfig.ConfigException - Exception in org.apache.zookeeper.server.quorum
- QuorumPeerMain - Class in org.apache.zookeeper.server.quorum
-
Configuration file
- QuorumPeerMain() - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeerMain
- quorumPeers - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
The servers that make up the cluster
- quorumSaslEnableAuth - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Enable/Disables quorum authentication using sasl.
- QuorumServer(long, String, Integer, Integer, QuorumPeer.LearnerType) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
- QuorumServer(long, InetSocketAddress) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
- quorumServerLoginContext - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Quorum server login context name in jaas-conf file to read the kerberos security details.
- quorumServerLoginContext - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- quorumServerRequireSasl - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
Configurations for the quorumpeer-to-quorumpeer sasl authentication
- quorumServerSaslAuthRequired - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
If this is false, quorum peer server will accept another quorum peer client connection even if the authentication did not succeed.
- quorumServicePrincipal - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Kerberos quorum service principal.
- quorumServicePrincipal - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- QuorumStats - Class in org.apache.zookeeper.server.quorum
- QuorumStats(QuorumStats.Provider) - Constructor for class org.apache.zookeeper.server.quorum.QuorumStats
- QuorumStats.Provider - Interface in org.apache.zookeeper.server.quorum
- quorumVerifier - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- QuorumVerifier - Interface in org.apache.zookeeper.server.quorum.flexible
-
All quorum validators have to implement a method called containsQuorum, which verifies if a Set of server identifiers constitutes a quorum.
- QuorumZooKeeperServer - Class in org.apache.zookeeper.server.quorum
-
Abstract base class for all ZooKeeperServers that participate in a quorum.
- QuorumZooKeeperServer(FileTxnSnapLog, int, int, int, ZooKeeperServer.DataTreeBuilder, ZKDatabase, QuorumPeer) - Constructor for class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
- quotaPath(String) - Static method in class org.apache.zookeeper.Quotas
-
return the quota path associated with this prefix
- Quotas - Class in org.apache.zookeeper
-
this class manages quotas and has many other utils for quota
- Quotas() - Constructor for class org.apache.zookeeper.Quotas
- quotaZookeeper - Static variable in class org.apache.zookeeper.Quotas
-
the zookeeper quota node that acts as the quota management node for zookeeper
R
- read() - Method in class org.apache.zookeeper.server.ByteBufferInputStream
- read(byte[]) - Method in class org.apache.zookeeper.server.ByteBufferInputStream
- read(byte[], int, int) - Method in class org.apache.zookeeper.server.ByteBufferInputStream
- read(long) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
start reading all the transactions from the given zxid
- read(long) - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
Start reading the transaction logs from a given zxid
- READ - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
- READ_ACL_UNSAFE - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
-
This ACL gives the world the ability to read.
- readFields(DataInput) - Method in class org.apache.zookeeper.data.ACL
- readFields(DataInput) - Method in class org.apache.zookeeper.data.Id
- readFields(DataInput) - Method in class org.apache.zookeeper.data.Stat
- readFields(DataInput) - Method in class org.apache.zookeeper.data.StatPersisted
- readFields(DataInput) - Method in class org.apache.zookeeper.data.StatPersistedV1
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.AuthPacket
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.CheckVersionRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.ConnectRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.ConnectResponse
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.CreateRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.CreateResponse
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.DeleteRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.ErrorResponse
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.ExistsRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.ExistsResponse
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.GetACLRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.GetACLResponse
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.GetChildren2Request
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.GetChildren2Response
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.GetChildrenRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.GetChildrenResponse
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.GetDataRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.GetDataResponse
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.GetMaxChildrenRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.GetMaxChildrenResponse
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.GetSASLRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.MultiHeader
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.ReplyHeader
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.RequestHeader
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.SetACLRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.SetACLResponse
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.SetDataRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.SetDataResponse
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.SetSASLRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.SetSASLResponse
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.SetWatches
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.SyncRequest
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.SyncResponse
- readFields(DataInput) - Method in class org.apache.zookeeper.proto.WatcherEvent
- readFields(DataInput) - Method in class org.apache.zookeeper.server.persistence.FileHeader
- readFields(DataInput) - Method in class org.apache.zookeeper.server.quorum.LearnerInfo
- readFields(DataInput) - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- readFields(DataInput) - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- readFields(DataInput) - Method in class org.apache.zookeeper.txn.CheckVersionTxn
- readFields(DataInput) - Method in class org.apache.zookeeper.txn.CreateSessionTxn
- readFields(DataInput) - Method in class org.apache.zookeeper.txn.CreateTxn
- readFields(DataInput) - Method in class org.apache.zookeeper.txn.CreateTxnV0
- readFields(DataInput) - Method in class org.apache.zookeeper.txn.DeleteTxn
- readFields(DataInput) - Method in class org.apache.zookeeper.txn.ErrorTxn
- readFields(DataInput) - Method in class org.apache.zookeeper.txn.MultiTxn
- readFields(DataInput) - Method in class org.apache.zookeeper.txn.SetACLTxn
- readFields(DataInput) - Method in class org.apache.zookeeper.txn.SetDataTxn
- readFields(DataInput) - Method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- readFields(DataInput) - Method in class org.apache.zookeeper.txn.Txn
- readFields(DataInput) - Method in class org.apache.zookeeper.txn.TxnHeader
- readFrom(QuorumPeerConfig) - Method in class org.apache.zookeeper.server.ServerConfig
-
Read attributes from a QuorumPeerConfig.
- ReadOnlyBean - Class in org.apache.zookeeper.server.quorum
-
ReadOnly MX Bean interface, implemented by ReadOnlyBean
- ReadOnlyBean(ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.quorum.ReadOnlyBean
- ReadOnlyRequestProcessor - Class in org.apache.zookeeper.server.quorum
-
This processor is at the beginning of the ReadOnlyZooKeeperServer's processors chain.
- ReadOnlyRequestProcessor(ZooKeeperServer, RequestProcessor) - Constructor for class org.apache.zookeeper.server.quorum.ReadOnlyRequestProcessor
- ReadOnlyZooKeeperServer - Class in org.apache.zookeeper.server.quorum
-
A ZooKeeperServer which comes into play when peer is partitioned from the majority.
- readTxnBytes(InputArchive) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Reads a transaction entry from the input archive.
- receiveConnection(Socket) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
If this server receives a connection request, then it gives up on the new connection if it wins.
- receiveConnectionAsync(Socket) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Server receives a connection request and handles it asynchronously via separate thread.
- receiveMessage(ChannelBuffer) - Method in class org.apache.zookeeper.server.NettyServerCnxn
- record2ByteBuffer(Record, ByteBuffer) - Static method in class org.apache.zookeeper.server.ByteBufferOutputStream
- recreateSocketAddresses() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
-
Performs a DNS lookup of hostname and (re)creates the this.addr and this.electionAddr InetSocketAddress objects as appropriate If the DNS lookup fails, this.addr and electionAddr remain unmodified, unless they were never set.
- recvQueue - Variable in class org.apache.zookeeper.server.quorum.QuorumCnxManager
- ReferenceCountedACLCache - Class in org.apache.zookeeper.server
- ReferenceCountedACLCache() - Constructor for class org.apache.zookeeper.server.ReferenceCountedACLCache
- register(ZKMBeanInfo, ZKMBeanInfo) - Method in class org.apache.zookeeper.jmx.MBeanRegistry
-
Registers a new MBean with the platform MBean server.
- register(Watcher) - Method in class org.apache.zookeeper.ZooKeeper
-
Specify the default watcher for the connection (overrides the one specified during construction).
- registerConnection(ServerCnxn) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- registerJMX() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
- registerJMX() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
- registerJMX() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
- registerJMX() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- registerJMX(LeaderBean, LocalPeerBean) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
- registerJMX(ZooKeeperServerBean, LocalPeerBean) - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
- registerJMX(ZooKeeperServerBean, LocalPeerBean) - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
- registerLog4jMBeans() - Static method in class org.apache.zookeeper.jmx.ManagedUtil
-
Register the log4j JMX mbeans.
- registerWithLeader(int) - Method in class org.apache.zookeeper.server.quorum.Learner
-
Once connected to the leader, perform the handshake protocol to establish a following / observing connection.
- RemotePeerBean - Class in org.apache.zookeeper.server.quorum
-
A remote peer bean only provides limited information about the remote peer, and the peer cannot be managed remotely.
- RemotePeerBean(QuorumPeer.QuorumServer) - Constructor for class org.apache.zookeeper.server.quorum.RemotePeerBean
- RemotePeerMXBean - Interface in org.apache.zookeeper.server.quorum
-
A proxy for a remote quorum peer.
- removeAuthInfo(Id) - Method in class org.apache.zookeeper.server.ServerCnxn
- removeChild(String) - Method in class org.apache.zookeeper.server.DataNode
-
Method that removes a child from the children set
- removeCnxn(NIOServerCnxn) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- removeCnxn(ServerCnxn) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
- removeCnxn(ServerCnxn) - Method in class org.apache.zookeeper.server.ZKDatabase
-
remove a cnxn from the datatree
- removeCnxn(Watcher) - Method in class org.apache.zookeeper.server.DataTree
- removeCnxn(Watcher) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- removeSession(long) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
- removeSession(long) - Method in interface org.apache.zookeeper.server.SessionTracker
- removeSession(long) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
- removeUsage(Long) - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
- removeWatcher(Watcher) - Method in class org.apache.zookeeper.server.WatchManager
- reopenSession(ServerCnxn, long, byte[], int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- ReplyHeader - Class in org.apache.zookeeper.proto
- ReplyHeader() - Constructor for class org.apache.zookeeper.proto.ReplyHeader
- ReplyHeader(int, long, int) - Constructor for class org.apache.zookeeper.proto.ReplyHeader
- request - Variable in class org.apache.zookeeper.server.quorum.Leader.Proposal
- request - Variable in class org.apache.zookeeper.server.Request
- Request - Class in org.apache.zookeeper.server
-
This is the structure that represents a request moving through a chain of RequestProcessors.
- Request(long, int, int, TxnHeader, Record, long) - Constructor for class org.apache.zookeeper.server.Request
- Request(ServerCnxn, long, int, int, ByteBuffer, List<Id>) - Constructor for class org.apache.zookeeper.server.Request
- RequestHeader - Class in org.apache.zookeeper.proto
- RequestHeader() - Constructor for class org.apache.zookeeper.proto.RequestHeader
- RequestHeader(int, int) - Constructor for class org.apache.zookeeper.proto.RequestHeader
- requestOfDeath - Static variable in class org.apache.zookeeper.server.Request
- RequestProcessor - Interface in org.apache.zookeeper.server
-
RequestProcessors are chained together to process transactions.
- RequestProcessor.RequestProcessorException - Exception in org.apache.zookeeper.server
- RequestProcessorException(String, Throwable) - Constructor for exception org.apache.zookeeper.server.RequestProcessor.RequestProcessorException
- reset() - Method in class org.apache.zookeeper.server.quorum.ProposalStats
- reset() - Method in class org.apache.zookeeper.server.ServerStats
- resetCounters() - Method in class org.apache.zookeeper.server.ConnectionBean
- resetCounters() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Reset counters
- resetFsyncThresholdExceedCount() - Method in class org.apache.zookeeper.server.ServerStats
- resetFsyncThresholdExceedCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- resetFsyncThresholdExceedCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Reset Fsync Threshold Exceed Count statistics only.
- resetLatency() - Method in class org.apache.zookeeper.server.ServerStats
- resetLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- resetLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Reset min/avg/max latency statistics
- resetMaxLatency() - Method in class org.apache.zookeeper.server.ServerStats
- resetMaxLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- resetMaxLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Reset max latency statistics only.
- resetProposalStatistics() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
- resetProposalStatistics() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
-
Resets statistics of proposal size (min/max/last)
- resetRequestCounters() - Method in class org.apache.zookeeper.server.ServerStats
- resetStatistics() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- resetStatistics() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Reset packet and latency statistics
- resetStats() - Method in class org.apache.zookeeper.server.ServerCnxn
- resetWhiteList() - Static method in class org.apache.zookeeper.server.ServerCnxn
- respondToServer(byte[], ClientCnxn) - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
- restore(DataTree, Map<Long, Integer>, FileTxnSnapLog.PlayBackListener) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
this function restores the server database after reading from the snapshots and transaction logs
- revalidate(QuorumPacket) - Method in class org.apache.zookeeper.server.quorum.Learner
- revalidateSession(ServerCnxn, long, int) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
- revalidateSession(ServerCnxn, long, int) - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
- revalidateSession(ServerCnxn, long, int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- REVISION - Static variable in interface org.apache.zookeeper.version.Info
- REVISION_HASH - Static variable in interface org.apache.zookeeper.version.Info
- rollLog() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
rollover the current log file to a new one.
- rollLog() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
roll the transaction logs
- rollLog() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
roll the current log being appended to
- rollLog() - Method in class org.apache.zookeeper.server.ZKDatabase
-
roll the underlying log
- run() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- run() - Method in class org.apache.zookeeper.server.PrepRequestProcessor
- run() - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
- run() - Method in class org.apache.zookeeper.server.quorum.FollowerRequestProcessor
- run() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
-
This thread will receive packets from the peer and process them and also listen to new connections from new peers.
- run() - Method in class org.apache.zookeeper.server.quorum.ObserverRequestProcessor
- run() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager.Listener
-
Sleeps on accept().
- run() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- run() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyRequestProcessor
- run() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
- run() - Method in class org.apache.zookeeper.server.SyncRequestProcessor
- run() - Method in class org.apache.zookeeper.Shell
-
check to see if a command needs to be executed and execute if needed
- run(String) - Method in class org.apache.zookeeper.server.SnapshotFormatter
- runFromConfig(QuorumPeerConfig) - Method in class org.apache.zookeeper.server.quorum.QuorumPeerMain
- runFromConfig(ServerConfig) - Method in class org.apache.zookeeper.server.ZooKeeperServerMain
-
Run from a ServerConfig.
- RUNNING - org.apache.zookeeper.server.ZooKeeperServer.State
- RuntimeInconsistency - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.RUNTIMEINCONSISTENCY
instead - RUNTIMEINCONSISTENCY - org.apache.zookeeper.KeeperException.Code
-
A runtime inconsistency was found
- RuntimeInconsistencyException() - Constructor for exception org.apache.zookeeper.KeeperException.RuntimeInconsistencyException
- runUpgrade() - Method in class org.apache.zookeeper.server.upgrade.UpgradeMain
-
run the upgrade
- ruok(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
- ruokCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
S
- sasl - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- SaslAuthenticated - org.apache.zookeeper.Watcher.Event.KeeperState
-
SaslAuthenticated: used to notify clients that they are SASL-authenticated, so that they can perform Zookeeper actions with their SASL-authorized permissions.
- SASLAuthenticationProvider - Class in org.apache.zookeeper.server.auth
- SASLAuthenticationProvider() - Constructor for class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
- SaslClientCallbackHandler - Class in org.apache.zookeeper
-
This is used by the SASL mechanisms to get further information to complete the authentication.
- SaslClientCallbackHandler(String, String) - Constructor for class org.apache.zookeeper.SaslClientCallbackHandler
- SaslQuorumAuthLearner - Class in org.apache.zookeeper.server.quorum.auth
- SaslQuorumAuthLearner(boolean, String, String) - Constructor for class org.apache.zookeeper.server.quorum.auth.SaslQuorumAuthLearner
- SaslQuorumAuthServer - Class in org.apache.zookeeper.server.quorum.auth
- SaslQuorumAuthServer(boolean, String, Set<String>) - Constructor for class org.apache.zookeeper.server.quorum.auth.SaslQuorumAuthServer
- SaslQuorumServerCallbackHandler - Class in org.apache.zookeeper.server.quorum.auth
-
This is used by the SASL mechanisms to get further information to complete the authentication.
- SaslQuorumServerCallbackHandler(Configuration, String, Set<String>) - Constructor for class org.apache.zookeeper.server.quorum.auth.SaslQuorumServerCallbackHandler
- saslServerCallbackHandler - Variable in class org.apache.zookeeper.server.ServerCnxnFactory
- SaslServerCallbackHandler - Class in org.apache.zookeeper.server.auth
- SaslServerCallbackHandler(Configuration) - Constructor for class org.apache.zookeeper.server.auth.SaslServerCallbackHandler
- save(DataTree, ConcurrentHashMap<Long, Integer>) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
save the datatree and the sessions into a snapshot
- SecurityUtils - Class in org.apache.zookeeper.util
- SecurityUtils() - Constructor for class org.apache.zookeeper.util.SecurityUtils
- self - Variable in class org.apache.zookeeper.server.quorum.LeaderElection
-
Deprecated.
- self - Variable in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
- send4LetterWord(String, int, String) - Static method in class org.apache.zookeeper.client.FourLetterWordMain
-
Send the 4letterword
- send4LetterWord(String, int, String, int) - Static method in class org.apache.zookeeper.client.FourLetterWordMain
-
Send the 4letterword
- SendAckRequestProcessor - Class in org.apache.zookeeper.server.quorum
- sendBuffer(ByteBuffer) - Method in class org.apache.zookeeper.server.NettyServerCnxn
- sendBuffer(ByteBuffer) - Method in class org.apache.zookeeper.server.NIOServerCnxn
- sendCloseSession() - Method in class org.apache.zookeeper.server.NettyServerCnxn
-
Send close connection packet to the client.
- sendCloseSession() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- sendPacket(Record, Record, AsyncCallback, int) - Method in class org.apache.zookeeper.ClientCnxn
- sendResponse(ReplyHeader, Record, String) - Method in class org.apache.zookeeper.server.NettyServerCnxn
- sendResponse(ReplyHeader, Record, String) - Method in class org.apache.zookeeper.server.NIOServerCnxn
- sendResponse(ReplyHeader, Record, String) - Method in class org.apache.zookeeper.server.ServerCnxn
- sendSync(LearnerSyncRequest) - Method in class org.apache.zookeeper.server.quorum.Leader
-
Sends a sync message to the appropriate server
- serialize(OutputArchive) - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.data.ACL
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.data.Id
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.data.Stat
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.data.StatPersisted
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.data.StatPersistedV1
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.MultiResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.MultiTransactionRecord
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.AuthPacket
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.CheckVersionRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.ConnectRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.ConnectResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.CreateRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.CreateResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.DeleteRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.ErrorResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.ExistsRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.ExistsResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.GetACLRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.GetACLResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.GetChildren2Request
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.GetChildren2Response
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.GetChildrenRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.GetChildrenResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.GetDataRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.GetDataResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.GetMaxChildrenRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.GetMaxChildrenResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.GetSASLRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.MultiHeader
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.ReplyHeader
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.RequestHeader
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.SetACLRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.SetACLResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.SetDataRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.SetDataResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.SetSASLRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.SetSASLResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.SetWatches
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.SyncRequest
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.SyncResponse
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.proto.WatcherEvent
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.DataNode
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.DataTree
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.persistence.FileHeader
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.quorum.LearnerInfo
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.upgrade.DataNodeV1
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.txn.CheckVersionTxn
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.txn.CreateSessionTxn
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.txn.CreateTxn
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.txn.CreateTxnV0
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.txn.DeleteTxn
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.txn.ErrorTxn
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.txn.MultiTxn
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.txn.SetACLTxn
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.txn.SetDataTxn
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.txn.Txn
- serialize(OutputArchive, String) - Method in class org.apache.zookeeper.txn.TxnHeader
- serialize(DataTree, Map<Long, Integer>, File) - Method in class org.apache.zookeeper.server.persistence.FileSnap
-
serialize the datatree and session into the file snapshot
- serialize(DataTree, Map<Long, Integer>, File) - Method in interface org.apache.zookeeper.server.persistence.SnapShot
-
persist the datatree and the sessions into a persistence storage
- serialize(DataTree, Map<Long, Integer>, OutputArchive, FileHeader) - Method in class org.apache.zookeeper.server.persistence.FileSnap
-
serialize the datatree and sessions
- serializeRequest(Request) - Static method in class org.apache.zookeeper.server.util.SerializeUtils
- serializeSnapshot(OutputArchive) - Method in class org.apache.zookeeper.server.ZKDatabase
-
serialize the snapshot
- serializeSnapshot(DataTree, OutputArchive, Map<Long, Integer>) - Static method in class org.apache.zookeeper.server.util.SerializeUtils
- SerializeUtils - Class in org.apache.zookeeper.server.util
- SerializeUtils() - Constructor for class org.apache.zookeeper.server.util.SerializeUtils
- SERVER_PACKET_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
- SERVER_PING_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
- ServerAdminClient - Class in org.apache.zookeeper
- ServerAdminClient() - Constructor for class org.apache.zookeeper.ServerAdminClient
- ServerBean - Class in org.apache.zookeeper.server.quorum
-
An abstract base class for the leader and follower MBeans.
- ServerBean() - Constructor for class org.apache.zookeeper.server.quorum.ServerBean
- ServerCnxn - Class in org.apache.zookeeper.server
-
Interface to a Server connection - represents a connection from a client to the server.
- ServerCnxn() - Constructor for class org.apache.zookeeper.server.ServerCnxn
- ServerCnxn.CloseRequestException - Exception in org.apache.zookeeper.server
- ServerCnxn.EndOfStreamException - Exception in org.apache.zookeeper.server
- ServerCnxnFactory - Class in org.apache.zookeeper.server
- ServerCnxnFactory() - Constructor for class org.apache.zookeeper.server.ServerCnxnFactory
- ServerCnxnFactory.PacketProcessor - Interface in org.apache.zookeeper.server
- ServerConfig - Class in org.apache.zookeeper.server
-
Server configuration storage.
- ServerConfig() - Constructor for class org.apache.zookeeper.server.ServerConfig
- serverGroup - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- serverId - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- ServerMXBean - Interface in org.apache.zookeeper.server.quorum
-
A quorum server MBean.
- servers - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- ServerSaslResponseCallback() - Constructor for class org.apache.zookeeper.client.ZooKeeperSaslClient.ServerSaslResponseCallback
- serverStats() - Method in class org.apache.zookeeper.server.NettyServerCnxn
- serverStats() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- serverStats() - Method in class org.apache.zookeeper.server.ServerCnxn
- serverStats() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- ServerStats - Class in org.apache.zookeeper.server
-
Basic Server Statistics
- ServerStats(ServerStats.Provider) - Constructor for class org.apache.zookeeper.server.ServerStats
- ServerStats.Provider - Interface in org.apache.zookeeper.server
- serverWeight - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- SESSION_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
- SessionExpired - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.SESSIONEXPIRED
instead - SESSIONEXPIRED - org.apache.zookeeper.KeeperException.Code
-
The session has been expired by the server
- SessionExpiredException() - Constructor for exception org.apache.zookeeper.KeeperException.SessionExpiredException
- sessionId - Variable in class org.apache.zookeeper.server.Request
- sessionMap - Variable in class org.apache.zookeeper.server.ServerCnxnFactory
- SESSIONMOVED - org.apache.zookeeper.KeeperException.Code
-
Session moved to another server, so operation is ignored
- SessionMovedException() - Constructor for exception org.apache.zookeeper.KeeperException.SessionMovedException
- sessionsWithTimeouts - Variable in class org.apache.zookeeper.server.ZKDatabase
- sessionTracker - Variable in class org.apache.zookeeper.server.ZooKeeperServer
- SessionTracker - Interface in org.apache.zookeeper.server
-
This is the basic interface that ZooKeeperServer uses to track sessions.
- SessionTracker.Session - Interface in org.apache.zookeeper.server
- SessionTracker.SessionExpirer - Interface in org.apache.zookeeper.server
- SessionTrackerImpl - Class in org.apache.zookeeper.server
-
This is a full featured SessionTracker.
- SessionTrackerImpl(SessionTracker.SessionExpirer, ConcurrentHashMap<Long, Integer>, int, long, ZooKeeperServerListener) - Constructor for class org.apache.zookeeper.server.SessionTrackerImpl
- SessionTrackerImpl.SessionImpl - Class in org.apache.zookeeper.server
- SET_GROUP_COMMAND - Static variable in class org.apache.zookeeper.Shell
- SET_OWNER_COMMAND - Static variable in class org.apache.zookeeper.Shell
-
a Unix command to set owner
- SET_PERMISSION_COMMAND - Static variable in class org.apache.zookeeper.Shell
-
a Unix command to set permission
- setAcceptedEpoch(long) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setAcl(List<ACL>) - Method in class org.apache.zookeeper.proto.CreateRequest
- setAcl(List<ACL>) - Method in class org.apache.zookeeper.proto.GetACLResponse
- setAcl(List<ACL>) - Method in class org.apache.zookeeper.proto.SetACLRequest
- setAcl(List<ACL>) - Method in class org.apache.zookeeper.txn.CreateTxn
- setAcl(List<ACL>) - Method in class org.apache.zookeeper.txn.CreateTxnV0
- setAcl(List<ACL>) - Method in class org.apache.zookeeper.txn.SetACLTxn
- setACL - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- setACL(String, List<ACL>, int) - Method in class org.apache.zookeeper.server.DataTree
- setACL(String, List<ACL>, int) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- setACL(String, List<ACL>, int) - Method in class org.apache.zookeeper.ZooKeeper
-
Set the ACL for the node of the given path if such a node exists and the given aclVersion matches the acl version of the node.
- setACL(String, List<ACL>, int, AsyncCallback.StatCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of setACL.
- SetACLRequest - Class in org.apache.zookeeper.proto
- SetACLRequest() - Constructor for class org.apache.zookeeper.proto.SetACLRequest
- SetACLRequest(String, List<ACL>, int) - Constructor for class org.apache.zookeeper.proto.SetACLRequest
- SetACLResponse - Class in org.apache.zookeeper.proto
- SetACLResponse() - Constructor for class org.apache.zookeeper.proto.SetACLResponse
- SetACLResponse(Stat) - Constructor for class org.apache.zookeeper.proto.SetACLResponse
- SetACLTxn - Class in org.apache.zookeeper.txn
- SetACLTxn() - Constructor for class org.apache.zookeeper.txn.SetACLTxn
- SetACLTxn(String, List<ACL>, int) - Constructor for class org.apache.zookeeper.txn.SetACLTxn
- setAuth(byte[]) - Method in class org.apache.zookeeper.proto.AuthPacket
- setAuthinfo(List<Id>) - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- setAversion(int) - Method in class org.apache.zookeeper.data.Stat
- setAversion(int) - Method in class org.apache.zookeeper.data.StatPersisted
- setAversion(int) - Method in class org.apache.zookeeper.data.StatPersistedV1
- setBytes(long) - Method in class org.apache.zookeeper.StatsTrack
-
set teh bytes for this stat tracker.
- setChildren(HashSet<String>) - Method in class org.apache.zookeeper.server.DataNode
-
convenience method for setting the children for this datanode
- setChildren(HashSet<String>) - Method in class org.apache.zookeeper.server.upgrade.DataNodeV1
-
convenience method for creating DataNode fully
- setChildren(List<String>) - Method in class org.apache.zookeeper.proto.GetChildren2Response
- setChildren(List<String>) - Method in class org.apache.zookeeper.proto.GetChildrenResponse
- setChildWatches(List<String>) - Method in class org.apache.zookeeper.proto.SetWatches
- setClientId(long) - Method in class org.apache.zookeeper.txn.TxnHeader
- setClientPortAddress(InetSocketAddress) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setCnxnFactory(ServerCnxnFactory) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setCode(int) - Method in exception org.apache.zookeeper.KeeperException
-
Deprecated.deprecated in 3.1.0, exceptions should be immutable, this method should not be used
- setConfiguration() - Static method in class org.apache.zookeeper.server.auth.KerberosName
-
Set the static configuration to get the rules.
- setCount(int) - Method in class org.apache.zookeeper.StatsTrack
-
set the count for this stat tracker.
- setCtime(long) - Method in class org.apache.zookeeper.data.Stat
- setCtime(long) - Method in class org.apache.zookeeper.data.StatPersisted
- setCtime(long) - Method in class org.apache.zookeeper.data.StatPersistedV1
- setCurrentEpoch(long) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setCurrentSize(long) - Method in class org.apache.zookeeper.server.persistence.FilePadding
- setCurrentVote(Vote) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setCversion(int) - Method in class org.apache.zookeeper.data.Stat
- setCversion(int) - Method in class org.apache.zookeeper.data.StatPersisted
- setCversion(int) - Method in class org.apache.zookeeper.data.StatPersistedV1
- setCversionPzxid(String, int, long) - Method in class org.apache.zookeeper.server.DataTree
-
This method sets the Cversion and Pzxid for the specified node to the values passed as arguments.
- setCxid(int) - Method in class org.apache.zookeeper.txn.TxnHeader
- setCzxid(long) - Method in class org.apache.zookeeper.data.Stat
- setCzxid(long) - Method in class org.apache.zookeeper.data.StatPersisted
- setCzxid(long) - Method in class org.apache.zookeeper.data.StatPersistedV1
- setData - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- setData(byte[]) - Method in class org.apache.zookeeper.proto.CreateRequest
- setData(byte[]) - Method in class org.apache.zookeeper.proto.GetDataResponse
- setData(byte[]) - Method in class org.apache.zookeeper.proto.SetDataRequest
- setData(byte[]) - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- setData(byte[]) - Method in class org.apache.zookeeper.txn.CreateTxn
- setData(byte[]) - Method in class org.apache.zookeeper.txn.CreateTxnV0
- setData(byte[]) - Method in class org.apache.zookeeper.txn.SetDataTxn
- setData(byte[]) - Method in class org.apache.zookeeper.txn.Txn
- setData(String, byte[], int) - Static method in class org.apache.zookeeper.Op
-
Constructs an update operation.
- setData(String, byte[], int) - Method in class org.apache.zookeeper.Transaction
- setData(String, byte[], int) - Method in class org.apache.zookeeper.ZooKeeper
-
Set the data for the node of the given path if such a node exists and the given version matches the version of the node (if the given version is -1, it matches any node's versions).
- setData(String, byte[], int, long, long) - Method in class org.apache.zookeeper.server.DataTree
- setData(String, byte[], int, long, long) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- setData(String, byte[], int, AsyncCallback.StatCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of setData.
- setDataLength(int) - Method in class org.apache.zookeeper.data.Stat
- SetDataRequest - Class in org.apache.zookeeper.proto
- SetDataRequest() - Constructor for class org.apache.zookeeper.proto.SetDataRequest
- SetDataRequest(String, byte[], int) - Constructor for class org.apache.zookeeper.proto.SetDataRequest
- SetDataResponse - Class in org.apache.zookeeper.proto
- SetDataResponse() - Constructor for class org.apache.zookeeper.proto.SetDataResponse
- SetDataResponse(Stat) - Constructor for class org.apache.zookeeper.proto.SetDataResponse
- SetDataResult(Stat) - Constructor for class org.apache.zookeeper.OpResult.SetDataResult
- setDataTreeInit(boolean) - Method in class org.apache.zookeeper.server.ZKDatabase
-
set the datatree initialized or not
- SetDataTxn - Class in org.apache.zookeeper.txn
- SetDataTxn() - Constructor for class org.apache.zookeeper.txn.SetDataTxn
- SetDataTxn(String, byte[], int) - Constructor for class org.apache.zookeeper.txn.SetDataTxn
- setDataWatches(List<String>) - Method in class org.apache.zookeeper.proto.SetWatches
- setDbid(long) - Method in class org.apache.zookeeper.server.persistence.FileHeader
- setDisableAutoResetWatch(boolean) - Static method in class org.apache.zookeeper.ClientCnxn
-
tests use this to set the auto reset
- setDone(boolean) - Method in class org.apache.zookeeper.proto.MultiHeader
- setElectionType(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Sets the election type
- setEnvironment(Map<String, String>) - Method in class org.apache.zookeeper.Shell
-
set the environment for the command
- setEphemeral(boolean) - Method in class org.apache.zookeeper.txn.CreateTxn
- setEphemeral(boolean) - Method in class org.apache.zookeeper.txn.CreateTxnV0
- setEphemeralOwner(long) - Method in class org.apache.zookeeper.data.Stat
- setEphemeralOwner(long) - Method in class org.apache.zookeeper.data.StatPersisted
- setEphemeralOwner(long) - Method in class org.apache.zookeeper.data.StatPersistedV1
- setEphemeralsMap(Map<Long, HashSet<String>>) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- setErr(int) - Method in class org.apache.zookeeper.proto.ErrorResponse
- setErr(int) - Method in class org.apache.zookeeper.proto.MultiHeader
- setErr(int) - Method in class org.apache.zookeeper.proto.ReplyHeader
- setErr(int) - Method in class org.apache.zookeeper.txn.ErrorTxn
- setException(KeeperException) - Method in class org.apache.zookeeper.server.Request
- setExistWatches(List<String>) - Method in class org.apache.zookeeper.proto.SetWatches
- setFailCreate(boolean) - Static method in class org.apache.zookeeper.server.PrepRequestProcessor
-
method for tests to set failCreate
- setFlags(int) - Method in class org.apache.zookeeper.proto.CreateRequest
- setFollower(Follower) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setId(String) - Method in class org.apache.zookeeper.data.Id
- setId(Id) - Method in class org.apache.zookeeper.data.ACL
- setInitLimit(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Set the number of ticks that the initial synchronization phase can take
- setInstance(MBeanRegistry) - Static method in class org.apache.zookeeper.jmx.MBeanRegistry
- setlastProcessedZxid(long) - Method in class org.apache.zookeeper.server.ZKDatabase
-
the last processed zxid in the datatree
- setLastZxidSeen(long) - Method in class org.apache.zookeeper.proto.ConnectRequest
- setLeader(Leader) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setLearnerType(QuorumPeer.LearnerType) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Sets the LearnerType both in the QuorumPeer and in the peerMap
- setMagic(int) - Method in class org.apache.zookeeper.server.persistence.FileHeader
- setMagic(long) - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- setMax(int) - Method in class org.apache.zookeeper.proto.GetMaxChildrenResponse
- setMax(int) - Method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- setMax(int) - Method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- SetMaxChildrenRequest - Class in org.apache.zookeeper.proto
- SetMaxChildrenRequest() - Constructor for class org.apache.zookeeper.proto.SetMaxChildrenRequest
- SetMaxChildrenRequest(String, int) - Constructor for class org.apache.zookeeper.proto.SetMaxChildrenRequest
- SetMaxChildrenTxn - Class in org.apache.zookeeper.txn
- SetMaxChildrenTxn() - Constructor for class org.apache.zookeeper.txn.SetMaxChildrenTxn
- SetMaxChildrenTxn(String, int) - Constructor for class org.apache.zookeeper.txn.SetMaxChildrenTxn
- setMaxClientCnxnsPerHost(int) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
-
Maximum number of connections allowed from particular host (ip)
- setMaxClientCnxnsPerHost(int) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
Maximum number of connections allowed from particular host (ip)
- setMaxClientCnxnsPerHost(int) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
Maximum number of connections allowed from particular host (ip)
- setMaxClientCnxnsPerHost(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- setMaxClientCnxnsPerHost(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Set maxClientCnxns allowed from a particular host
- setMaxSessionTimeout(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
minimum session timeout in milliseconds
- setMaxSessionTimeout(int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- setMaxSessionTimeout(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- setMaxSessionTimeout(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Set maxSessionTimeout of server in milliseconds
- setMinSessionTimeout(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
minimum session timeout in milliseconds
- setMinSessionTimeout(int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- setMinSessionTimeout(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- setMinSessionTimeout(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Set minSessionTimeout of server in milliseconds
- setMtime(long) - Method in class org.apache.zookeeper.data.Stat
- setMtime(long) - Method in class org.apache.zookeeper.data.StatPersisted
- setMtime(long) - Method in class org.apache.zookeeper.data.StatPersistedV1
- setMyid(long) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
set the id of this quorum peer.
- setMzxid(long) - Method in class org.apache.zookeeper.data.Stat
- setMzxid(long) - Method in class org.apache.zookeeper.data.StatPersisted
- setMzxid(long) - Method in class org.apache.zookeeper.data.StatPersistedV1
- setNumChildren(int) - Method in class org.apache.zookeeper.data.Stat
- setObserver(Observer) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setOwner(long, Object) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
- setOwner(long, Object) - Method in interface org.apache.zookeeper.server.SessionTracker
- setOwner(long, Object) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
- setOwner(long, Object) - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
set the owner of this session as owner
- setOwner(Object) - Method in class org.apache.zookeeper.server.Request
- setParentCVersion(int) - Method in class org.apache.zookeeper.txn.CreateTxn
- setPasswd(byte[]) - Method in class org.apache.zookeeper.proto.ConnectRequest
- setPasswd(byte[]) - Method in class org.apache.zookeeper.proto.ConnectResponse
- setPath(String) - Method in class org.apache.zookeeper.proto.CheckVersionRequest
- setPath(String) - Method in class org.apache.zookeeper.proto.CreateRequest
- setPath(String) - Method in class org.apache.zookeeper.proto.CreateResponse
- setPath(String) - Method in class org.apache.zookeeper.proto.DeleteRequest
- setPath(String) - Method in class org.apache.zookeeper.proto.ExistsRequest
- setPath(String) - Method in class org.apache.zookeeper.proto.GetACLRequest
- setPath(String) - Method in class org.apache.zookeeper.proto.GetChildren2Request
- setPath(String) - Method in class org.apache.zookeeper.proto.GetChildrenRequest
- setPath(String) - Method in class org.apache.zookeeper.proto.GetDataRequest
- setPath(String) - Method in class org.apache.zookeeper.proto.GetMaxChildrenRequest
- setPath(String) - Method in class org.apache.zookeeper.proto.SetACLRequest
- setPath(String) - Method in class org.apache.zookeeper.proto.SetDataRequest
- setPath(String) - Method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- setPath(String) - Method in class org.apache.zookeeper.proto.SyncRequest
- setPath(String) - Method in class org.apache.zookeeper.proto.SyncResponse
- setPath(String) - Method in class org.apache.zookeeper.proto.WatcherEvent
- setPath(String) - Method in class org.apache.zookeeper.txn.CheckVersionTxn
- setPath(String) - Method in class org.apache.zookeeper.txn.CreateTxn
- setPath(String) - Method in class org.apache.zookeeper.txn.CreateTxnV0
- setPath(String) - Method in class org.apache.zookeeper.txn.DeleteTxn
- setPath(String) - Method in class org.apache.zookeeper.txn.SetACLTxn
- setPath(String) - Method in class org.apache.zookeeper.txn.SetDataTxn
- setPath(String) - Method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- setPeerState(QuorumPeer.ServerState) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setPerms(int) - Method in class org.apache.zookeeper.data.ACL
- setPreallocSize(long) - Static method in class org.apache.zookeeper.server.persistence.FilePadding
-
method to allow setting preallocate size of log file to pad the file.
- setPreallocSize(long) - Static method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
method to allow setting preallocate size of log file to pad the file.
- setProtocolVersion(int) - Method in class org.apache.zookeeper.proto.ConnectRequest
- setProtocolVersion(int) - Method in class org.apache.zookeeper.proto.ConnectResponse
- setProtocolVersion(int) - Method in class org.apache.zookeeper.server.quorum.LearnerInfo
- setPzxid(long) - Method in class org.apache.zookeeper.data.Stat
- setPzxid(long) - Method in class org.apache.zookeeper.data.StatPersisted
- setQuorumListenOnAllIPs(boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setQuorumPeers(Map<Long, QuorumPeer.QuorumServer>) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setQuorumVerifier(QuorumVerifier) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setRelativeZxid(long) - Method in class org.apache.zookeeper.proto.SetWatches
- setRunning(boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- SetSASLRequest - Class in org.apache.zookeeper.proto
- SetSASLRequest() - Constructor for class org.apache.zookeeper.proto.SetSASLRequest
- SetSASLRequest(byte[]) - Constructor for class org.apache.zookeeper.proto.SetSASLRequest
- SetSASLResponse - Class in org.apache.zookeeper.proto
- SetSASLResponse() - Constructor for class org.apache.zookeeper.proto.SetSASLResponse
- SetSASLResponse(byte[]) - Constructor for class org.apache.zookeeper.proto.SetSASLResponse
- setScheme(String) - Method in class org.apache.zookeeper.data.Id
- setScheme(String) - Method in class org.apache.zookeeper.proto.AuthPacket
- setServerCnxnFactory(ServerCnxnFactory) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- setServerid(long) - Method in class org.apache.zookeeper.server.quorum.LearnerInfo
- setServerStats(ServerStats) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
Setter for ServerStats to monitor fsync threshold exceed
- setServerStats(ServerStats) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
- setServerStats(ServerStats) - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
+ * Setter for ServerStats to monitor fsync threshold exceed + * @param serverStats used to update fsyncThresholdExceedCount +
- setSessionClosing(long) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
- setSessionClosing(long) - Method in interface org.apache.zookeeper.server.SessionTracker
-
Mark that the session is in the process of closing.
- setSessionClosing(long) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
- setSessionId(long) - Method in class org.apache.zookeeper.proto.ConnectRequest
- setSessionId(long) - Method in class org.apache.zookeeper.proto.ConnectResponse
- setSessionId(long) - Method in class org.apache.zookeeper.server.NettyServerCnxn
- setSessionId(long) - Method in class org.apache.zookeeper.server.NIOServerCnxn
- setSessionTimeout(int) - Method in class org.apache.zookeeper.server.NettyServerCnxn
- setSessionTimeout(int) - Method in class org.apache.zookeeper.server.NIOServerCnxn
- setSnapCount(int) - Static method in class org.apache.zookeeper.server.SyncRequestProcessor
-
used by tests to check for changing snapcounts
- setStat(Stat) - Method in class org.apache.zookeeper.proto.ExistsResponse
- setStat(Stat) - Method in class org.apache.zookeeper.proto.GetACLResponse
- setStat(Stat) - Method in class org.apache.zookeeper.proto.GetChildren2Response
- setStat(Stat) - Method in class org.apache.zookeeper.proto.GetDataResponse
- setStat(Stat) - Method in class org.apache.zookeeper.proto.SetACLResponse
- setStat(Stat) - Method in class org.apache.zookeeper.proto.SetDataResponse
- setState(int) - Method in class org.apache.zookeeper.proto.WatcherEvent
- setState(ZooKeeperServer.State) - Method in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
- setState(ZooKeeperServer.State) - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
- setState(ZooKeeperServer.State) - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
Sets the state of ZooKeeper server.
- setStatus(int) - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- setSyncEnabled(boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Set syncEnabled.
- setSyncLimit(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Set the synclimit
- setTextTraceLevel(long) - Static method in class org.apache.zookeeper.server.ZooTrace
- setTickTime(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Set the number of milliseconds of each tick
- setTickTime(int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- setTickTime(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- setTickTime(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Set TickTime of server in milliseconds
- setTime(long) - Method in class org.apache.zookeeper.txn.TxnHeader
- setTimeOut(int) - Method in class org.apache.zookeeper.proto.ConnectRequest
- setTimeOut(int) - Method in class org.apache.zookeeper.proto.ConnectResponse
- setTimeOut(int) - Method in class org.apache.zookeeper.txn.CreateSessionTxn
- setToken(byte[]) - Method in class org.apache.zookeeper.proto.GetSASLRequest
- setToken(byte[]) - Method in class org.apache.zookeeper.proto.SetSASLRequest
- setToken(byte[]) - Method in class org.apache.zookeeper.proto.SetSASLResponse
- setToken(byte[]) - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- setTraceMask(String, int, String) - Static method in class org.apache.zookeeper.ServerAdminClient
- setTraceMaskCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- setTxnFactory(FileTxnSnapLog) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- setTxnLogFactory(FileTxnSnapLog) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- setTxns(List<Txn>) - Method in class org.apache.zookeeper.txn.MultiTxn
- setType(int) - Method in class org.apache.zookeeper.proto.AuthPacket
- setType(int) - Method in class org.apache.zookeeper.proto.MultiHeader
- setType(int) - Method in class org.apache.zookeeper.proto.RequestHeader
- setType(int) - Method in class org.apache.zookeeper.proto.WatcherEvent
- setType(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- setType(int) - Method in class org.apache.zookeeper.txn.Txn
- setType(int) - Method in class org.apache.zookeeper.txn.TxnHeader
- setupRequestProcessors() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
- setupRequestProcessors() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
- setupRequestProcessors() - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
-
Set up the request processors for an Observer: firstProcesor->commitProcessor->finalProcessor
- setupRequestProcessors() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
- setupRequestProcessors() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- setVersion(int) - Method in class org.apache.zookeeper.data.Stat
- setVersion(int) - Method in class org.apache.zookeeper.data.StatPersisted
- setVersion(int) - Method in class org.apache.zookeeper.data.StatPersistedV1
- setVersion(int) - Method in class org.apache.zookeeper.proto.CheckVersionRequest
- setVersion(int) - Method in class org.apache.zookeeper.proto.DeleteRequest
- setVersion(int) - Method in class org.apache.zookeeper.proto.SetACLRequest
- setVersion(int) - Method in class org.apache.zookeeper.proto.SetDataRequest
- setVersion(int) - Method in class org.apache.zookeeper.server.persistence.FileHeader
- setVersion(int) - Method in class org.apache.zookeeper.txn.CheckVersionTxn
- setVersion(int) - Method in class org.apache.zookeeper.txn.SetACLTxn
- setVersion(int) - Method in class org.apache.zookeeper.txn.SetDataTxn
- setWatch(boolean) - Method in class org.apache.zookeeper.proto.ExistsRequest
- setWatch(boolean) - Method in class org.apache.zookeeper.proto.GetChildren2Request
- setWatch(boolean) - Method in class org.apache.zookeeper.proto.GetChildrenRequest
- setWatch(boolean) - Method in class org.apache.zookeeper.proto.GetDataRequest
- setWatches - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- setWatches(long, List<String>, List<String>, List<String>, Watcher) - Method in class org.apache.zookeeper.server.DataTree
- setWatches(long, List<String>, List<String>, List<String>, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
-
set watches on the datatree
- SetWatches - Class in org.apache.zookeeper.proto
- SetWatches() - Constructor for class org.apache.zookeeper.proto.SetWatches
- SetWatches(long, List<String>, List<String>, List<String>) - Constructor for class org.apache.zookeeper.proto.SetWatches
- setWorkingDirectory(File) - Method in class org.apache.zookeeper.Shell
-
set the working directory
- setXid(int) - Method in class org.apache.zookeeper.proto.ReplyHeader
- setXid(int) - Method in class org.apache.zookeeper.proto.RequestHeader
- setZKDatabase(ZKDatabase) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
set zk database for this node
- setZKDatabase(ZKDatabase) - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
set the zkdatabase for this zookeeper server
- setZooKeeperServer(ZooKeeperServer) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- setZxid(long) - Method in class org.apache.zookeeper.proto.ReplyHeader
- setZxid(long) - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- setZxid(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- setZxid(long) - Method in class org.apache.zookeeper.txn.TxnHeader
- Shell - Class in org.apache.zookeeper
-
A base class for running a Unix command.
- Shell() - Constructor for class org.apache.zookeeper.Shell
- Shell(long) - Constructor for class org.apache.zookeeper.Shell
- Shell.ExitCodeException - Exception in org.apache.zookeeper
-
This is an IOException with exit code added.
- Shell.ShellCommandExecutor - Class in org.apache.zookeeper
-
A simple shell command executor.
- ShellCommandExecutor(String[]) - Constructor for class org.apache.zookeeper.Shell.ShellCommandExecutor
- ShellCommandExecutor(String[], File) - Constructor for class org.apache.zookeeper.Shell.ShellCommandExecutor
- ShellCommandExecutor(String[], File, Map<String, String>) - Constructor for class org.apache.zookeeper.Shell.ShellCommandExecutor
- ShellCommandExecutor(String[], File, Map<String, String>, long) - Constructor for class org.apache.zookeeper.Shell.ShellCommandExecutor
-
Create a new instance of the ShellCommandExecutor to execute a command.
- shouldThrottle(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- shutdown() - Method in class org.apache.zookeeper.Login
- shutdown() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
-
Shutdown the purge task.
- shutdown() - Method in class org.apache.zookeeper.server.FinalRequestProcessor
- shutdown() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
- shutdown() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- shutdown() - Method in class org.apache.zookeeper.server.PrepRequestProcessor
- shutdown() - Method in class org.apache.zookeeper.server.quorum.AuthFastLeaderElection
-
Deprecated.There is nothing to shutdown in this implementation of leader election, so we simply have an empty method.
- shutdown() - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
- shutdown() - Method in interface org.apache.zookeeper.server.quorum.Election
- shutdown() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
- shutdown() - Method in class org.apache.zookeeper.server.quorum.Follower
- shutdown() - Method in class org.apache.zookeeper.server.quorum.FollowerRequestProcessor
- shutdown() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
- shutdown() - Method in class org.apache.zookeeper.server.quorum.LeaderElection
-
Deprecated.There is nothing to shutdown in this implementation of leader election, so we simply have an empty method.
- shutdown() - Method in class org.apache.zookeeper.server.quorum.Learner
-
Shutdown the Peer
- shutdown() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
- shutdown() - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
- shutdown() - Method in class org.apache.zookeeper.server.quorum.Observer
-
Shutdown the Observer.
- shutdown() - Method in class org.apache.zookeeper.server.quorum.ObserverRequestProcessor
-
Shutdown the processor.
- shutdown() - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
- shutdown() - Method in class org.apache.zookeeper.server.quorum.ProposalRequestProcessor
- shutdown() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- shutdown() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyRequestProcessor
- shutdown() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
- shutdown() - Method in class org.apache.zookeeper.server.quorum.SendAckRequestProcessor
- shutdown() - Method in interface org.apache.zookeeper.server.RequestProcessor
- shutdown() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- shutdown() - Method in interface org.apache.zookeeper.server.SessionTracker
- shutdown() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
- shutdown() - Method in class org.apache.zookeeper.server.SyncRequestProcessor
- shutdown() - Method in class org.apache.zookeeper.server.UnimplementedRequestProcessor
- shutdown() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- shutdown() - Method in class org.apache.zookeeper.server.ZooKeeperServerMain
-
Shutdown the serving instance
- shutdown(boolean) - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
Shut down the server instance
- SHUTDOWN - org.apache.zookeeper.server.ZooKeeperServer.State
- sid - Variable in class org.apache.zookeeper.server.quorum.LearnerHandler
-
ZooKeeper server identifier of this learner
- signature() - Static method in class org.apache.zookeeper.data.ACL
- signature() - Static method in class org.apache.zookeeper.data.Id
- signature() - Static method in class org.apache.zookeeper.data.Stat
- signature() - Static method in class org.apache.zookeeper.data.StatPersisted
- signature() - Static method in class org.apache.zookeeper.data.StatPersistedV1
- signature() - Static method in class org.apache.zookeeper.proto.AuthPacket
- signature() - Static method in class org.apache.zookeeper.proto.CheckVersionRequest
- signature() - Static method in class org.apache.zookeeper.proto.ConnectRequest
- signature() - Static method in class org.apache.zookeeper.proto.ConnectResponse
- signature() - Static method in class org.apache.zookeeper.proto.CreateRequest
- signature() - Static method in class org.apache.zookeeper.proto.CreateResponse
- signature() - Static method in class org.apache.zookeeper.proto.DeleteRequest
- signature() - Static method in class org.apache.zookeeper.proto.ErrorResponse
- signature() - Static method in class org.apache.zookeeper.proto.ExistsRequest
- signature() - Static method in class org.apache.zookeeper.proto.ExistsResponse
- signature() - Static method in class org.apache.zookeeper.proto.GetACLRequest
- signature() - Static method in class org.apache.zookeeper.proto.GetACLResponse
- signature() - Static method in class org.apache.zookeeper.proto.GetChildren2Request
- signature() - Static method in class org.apache.zookeeper.proto.GetChildren2Response
- signature() - Static method in class org.apache.zookeeper.proto.GetChildrenRequest
- signature() - Static method in class org.apache.zookeeper.proto.GetChildrenResponse
- signature() - Static method in class org.apache.zookeeper.proto.GetDataRequest
- signature() - Static method in class org.apache.zookeeper.proto.GetDataResponse
- signature() - Static method in class org.apache.zookeeper.proto.GetMaxChildrenRequest
- signature() - Static method in class org.apache.zookeeper.proto.GetMaxChildrenResponse
- signature() - Static method in class org.apache.zookeeper.proto.GetSASLRequest
- signature() - Static method in class org.apache.zookeeper.proto.MultiHeader
- signature() - Static method in class org.apache.zookeeper.proto.ReplyHeader
- signature() - Static method in class org.apache.zookeeper.proto.RequestHeader
- signature() - Static method in class org.apache.zookeeper.proto.SetACLRequest
- signature() - Static method in class org.apache.zookeeper.proto.SetACLResponse
- signature() - Static method in class org.apache.zookeeper.proto.SetDataRequest
- signature() - Static method in class org.apache.zookeeper.proto.SetDataResponse
- signature() - Static method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- signature() - Static method in class org.apache.zookeeper.proto.SetSASLRequest
- signature() - Static method in class org.apache.zookeeper.proto.SetSASLResponse
- signature() - Static method in class org.apache.zookeeper.proto.SetWatches
- signature() - Static method in class org.apache.zookeeper.proto.SyncRequest
- signature() - Static method in class org.apache.zookeeper.proto.SyncResponse
- signature() - Static method in class org.apache.zookeeper.proto.WatcherEvent
- signature() - Static method in class org.apache.zookeeper.server.persistence.FileHeader
- signature() - Static method in class org.apache.zookeeper.server.quorum.LearnerInfo
- signature() - Static method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- signature() - Static method in class org.apache.zookeeper.server.quorum.QuorumPacket
- signature() - Static method in class org.apache.zookeeper.txn.CheckVersionTxn
- signature() - Static method in class org.apache.zookeeper.txn.CreateSessionTxn
- signature() - Static method in class org.apache.zookeeper.txn.CreateTxn
- signature() - Static method in class org.apache.zookeeper.txn.CreateTxnV0
- signature() - Static method in class org.apache.zookeeper.txn.DeleteTxn
- signature() - Static method in class org.apache.zookeeper.txn.ErrorTxn
- signature() - Static method in class org.apache.zookeeper.txn.MultiTxn
- signature() - Static method in class org.apache.zookeeper.txn.SetACLTxn
- signature() - Static method in class org.apache.zookeeper.txn.SetDataTxn
- signature() - Static method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- signature() - Static method in class org.apache.zookeeper.txn.Txn
- signature() - Static method in class org.apache.zookeeper.txn.TxnHeader
- size() - Method in interface org.apache.zookeeper.client.HostProvider
- size() - Method in class org.apache.zookeeper.client.StaticHostProvider
- size() - Method in class org.apache.zookeeper.MultiResponse
- size() - Method in class org.apache.zookeeper.MultiTransactionRecord
- size() - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
- size() - Method in class org.apache.zookeeper.server.WatchManager
- sk - Variable in class org.apache.zookeeper.server.NIOServerCnxn
- skip(long) - Method in class org.apache.zookeeper.server.ByteBufferInputStream
- SNAP_MAGIC - Static variable in class org.apache.zookeeper.server.persistence.FileSnap
- SnapDirContentCheckException(String) - Constructor for exception org.apache.zookeeper.server.persistence.FileTxnSnapLog.SnapDirContentCheckException
- snapLog - Variable in class org.apache.zookeeper.server.ZKDatabase
- snapRetainCount - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- SnapShot - Interface in org.apache.zookeeper.server.persistence
-
snapshot interface for the persistence layer.
- SNAPSHOT_FILE_PREFIX - Static variable in class org.apache.zookeeper.server.persistence.FileSnap
- SnapshotFormatter - Class in org.apache.zookeeper.server
-
Dump a snapshot file to stdout.
- SnapshotFormatter() - Constructor for class org.apache.zookeeper.server.SnapshotFormatter
- sock - Variable in class org.apache.zookeeper.server.quorum.Learner
- sock - Variable in class org.apache.zookeeper.server.quorum.LearnerHandler
- softHalt() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
A soft halt simply finishes workers.
- sortDataDir(File[], String, boolean) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Sort the list of files.
- srstCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- srvrCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- STANDALONE_SERVER_KEY - Static variable in class org.apache.zookeeper.jmx.CommonNames
- start() - Method in class org.apache.zookeeper.ClientCnxn
- start() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
-
Validates the purge configuration and schedules the purge task.
- start() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
- start() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- start() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- start() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- start_fle - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
- startdata() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- STARTED - org.apache.zookeeper.server.DatadirCleanupManager.PurgeTaskStatus
- startForwarding(LearnerHandler, long) - Method in class org.apache.zookeeper.server.quorum.Leader
-
lets the leader know that a follower is capable of following and is done syncing
- startLeaderElection() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- startSessionTracker() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
- startSessionTracker() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
- startSessionTracker() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- startThreadIfNeeded() - Method in class org.apache.zookeeper.Login
- startup() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
- startup() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- startup(ZooKeeperServer) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
- startup(ZooKeeperServer) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- startup(ZooKeeperServer) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- stat - Variable in class org.apache.zookeeper.server.DataNode
-
the stat for this node that is persisted to disk.
- stat - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
- stat - Variable in class org.apache.zookeeper.server.upgrade.DataNodeV1
- stat(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
- Stat - Class in org.apache.zookeeper.data
- Stat() - Constructor for class org.apache.zookeeper.data.Stat
- Stat(long, long, long, long, int, int, int, long, int, int, long) - Constructor for class org.apache.zookeeper.data.Stat
- statCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- state - Variable in class org.apache.zookeeper.server.ZooKeeperServer
- StateSummary - Class in org.apache.zookeeper.server.quorum
-
This class encapsulates the state comparison logic.
- StateSummary(long, long) - Constructor for class org.apache.zookeeper.server.quorum.StateSummary
- StaticHostProvider - Class in org.apache.zookeeper.client
-
Most simple HostProvider, resolves on every next() call.
- StaticHostProvider(Collection<InetSocketAddress>) - Constructor for class org.apache.zookeeper.client.StaticHostProvider
-
Constructs a SimpleHostSet.
- StaticHostProvider(Collection<InetSocketAddress>, StaticHostProvider.Resolver) - Constructor for class org.apache.zookeeper.client.StaticHostProvider
-
Introduced for testing purposes.
- StaticHostProvider.Resolver - Interface in org.apache.zookeeper.client
- statNode - Static variable in class org.apache.zookeeper.Quotas
-
the stat node that monitors the limit of a subtree.
- statNode(String, ServerCnxn) - Method in class org.apache.zookeeper.server.ZKDatabase
-
stat the path
- statNode(String, Watcher) - Method in class org.apache.zookeeper.server.DataTree
- statNode(String, Watcher) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
- statPath(String) - Static method in class org.apache.zookeeper.Quotas
-
return the stat quota path associated with this prefix.
- StatPersisted - Class in org.apache.zookeeper.data
- StatPersisted() - Constructor for class org.apache.zookeeper.data.StatPersisted
- StatPersisted(long, long, long, long, int, int, int, long, long) - Constructor for class org.apache.zookeeper.data.StatPersisted
- StatPersistedV1 - Class in org.apache.zookeeper.data
- StatPersistedV1() - Constructor for class org.apache.zookeeper.data.StatPersistedV1
- StatPersistedV1(long, long, long, long, int, int, int, long) - Constructor for class org.apache.zookeeper.data.StatPersistedV1
- StatsTrack - Class in org.apache.zookeeper
-
a class that represents the stats associated with quotas
- StatsTrack() - Constructor for class org.apache.zookeeper.StatsTrack
-
a default constructor for stats
- StatsTrack(String) - Constructor for class org.apache.zookeeper.StatsTrack
-
the stat string should be of the form count=int,bytes=long if stats is called with null the count and bytes are initialized to -1.
- stopLeaderElection() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- submitRequest(RequestHeader, Record, Record, ZooKeeper.WatchRegistration) - Method in class org.apache.zookeeper.ClientCnxn
- submitRequest(Request) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- SUCCESS - org.apache.zookeeper.server.quorum.auth.QuorumAuth.Status
- sync - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- sync() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
- sync() - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
- sync(String, AsyncCallback.VoidCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
Asynchronous sync.
- SYNC_ENABLED - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
The syncEnabled can also be set via a system property.
- SyncConnected - org.apache.zookeeper.Watcher.Event.KeeperState
-
The client is in the connected state - it is connected to a server in the ensemble (one of the servers specified in the host connection parameter during ZooKeeper client creation).
- synced() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
- syncEnabled - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Enables/Disables sync request processor.
- syncEnabled - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- syncLimit - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
The number of ticks that can pass between sending a request and getting an acknowledgment
- syncLimit - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- SyncRequest - Class in org.apache.zookeeper.proto
- SyncRequest() - Constructor for class org.apache.zookeeper.proto.SyncRequest
- SyncRequest(String) - Constructor for class org.apache.zookeeper.proto.SyncRequest
- SyncRequestProcessor - Class in org.apache.zookeeper.server
-
This RequestProcessor logs requests to disk.
- SyncRequestProcessor(ZooKeeperServer, RequestProcessor) - Constructor for class org.apache.zookeeper.server.SyncRequestProcessor
- SyncResponse - Class in org.apache.zookeeper.proto
- SyncResponse() - Constructor for class org.apache.zookeeper.proto.SyncResponse
- SyncResponse(String) - Constructor for class org.apache.zookeeper.proto.SyncResponse
- syncWithLeader(long) - Method in class org.apache.zookeeper.server.quorum.Learner
-
Finally, synchronize our history with the Leader.
- SystemError - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.SYSTEMERROR
instead - SYSTEMERROR - org.apache.zookeeper.KeeperException.Code
-
System and server-side errors.
- SystemErrorException() - Constructor for exception org.apache.zookeeper.KeeperException.SystemErrorException
T
- takeSnapshot() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- terminateConnection() - Method in class org.apache.zookeeper.server.ConnectionBean
- terminateConnection() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Terminate thei client connection.
- terminateSession() - Method in class org.apache.zookeeper.server.ConnectionBean
- terminateSession() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Terminate this client session.
- termPredicate(HashMap<Long, Vote>, Vote) - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
-
Termination predicate.
- Testable - Interface in org.apache.zookeeper
-
Abstraction that exposes various methods useful for testing ZooKeeper
- testableLocalSocketAddress() - Method in class org.apache.zookeeper.ZooKeeper
-
Returns the local address to which the socket is bound.
- testableRemoteSocketAddress() - Method in class org.apache.zookeeper.ZooKeeper
-
Returns the address to which the socket is connected.
- testableWaitForShutdown(int) - Method in class org.apache.zookeeper.ZooKeeper
-
Wait up to wait milliseconds for the underlying threads to shutdown.
- testingQuorumPeer() - Static method in class org.apache.zookeeper.server.quorum.QuorumPeer
- testInitiateConnection(long) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Invokes initiateConnection for testing purposes
- tick - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
The current tick
- tickOfNextAckDeadline() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
- tickTime - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
The number of milliseconds of each tick
- tickTime - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- tickTime - Variable in class org.apache.zookeeper.server.ServerConfig
- tickTime - Variable in class org.apache.zookeeper.server.ZooKeeperServer
- Time - Class in org.apache.zookeeper.common
- Time() - Constructor for class org.apache.zookeeper.common.Time
- timeOutInterval - Variable in class org.apache.zookeeper.Shell
-
Time after which the executing script would be timedout
- toFlag() - Method in enum org.apache.zookeeper.CreateMode
- toRequestRecord() - Method in class org.apache.zookeeper.Op.Check
- toRequestRecord() - Method in class org.apache.zookeeper.Op.Create
- toRequestRecord() - Method in class org.apache.zookeeper.Op.Delete
- toRequestRecord() - Method in class org.apache.zookeeper.Op.SetData
- toRequestRecord() - Method in class org.apache.zookeeper.Op
-
Encodes an op for wire transmission.
- toSend(Long, ByteBuffer) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Processes invoke this message to queue a message to send.
- toString() - Method in class org.apache.zookeeper.ClientCnxn
- toString() - Method in class org.apache.zookeeper.data.ACL
- toString() - Method in class org.apache.zookeeper.data.Id
- toString() - Method in class org.apache.zookeeper.data.Stat
- toString() - Method in class org.apache.zookeeper.data.StatPersisted
- toString() - Method in class org.apache.zookeeper.data.StatPersistedV1
- toString() - Method in class org.apache.zookeeper.Environment.Entry
- toString() - Method in class org.apache.zookeeper.proto.AuthPacket
- toString() - Method in class org.apache.zookeeper.proto.CheckVersionRequest
- toString() - Method in class org.apache.zookeeper.proto.ConnectRequest
- toString() - Method in class org.apache.zookeeper.proto.ConnectResponse
- toString() - Method in class org.apache.zookeeper.proto.CreateRequest
- toString() - Method in class org.apache.zookeeper.proto.CreateResponse
- toString() - Method in class org.apache.zookeeper.proto.DeleteRequest
- toString() - Method in class org.apache.zookeeper.proto.ErrorResponse
- toString() - Method in class org.apache.zookeeper.proto.ExistsRequest
- toString() - Method in class org.apache.zookeeper.proto.ExistsResponse
- toString() - Method in class org.apache.zookeeper.proto.GetACLRequest
- toString() - Method in class org.apache.zookeeper.proto.GetACLResponse
- toString() - Method in class org.apache.zookeeper.proto.GetChildren2Request
- toString() - Method in class org.apache.zookeeper.proto.GetChildren2Response
- toString() - Method in class org.apache.zookeeper.proto.GetChildrenRequest
- toString() - Method in class org.apache.zookeeper.proto.GetChildrenResponse
- toString() - Method in class org.apache.zookeeper.proto.GetDataRequest
- toString() - Method in class org.apache.zookeeper.proto.GetDataResponse
- toString() - Method in class org.apache.zookeeper.proto.GetMaxChildrenRequest
- toString() - Method in class org.apache.zookeeper.proto.GetMaxChildrenResponse
- toString() - Method in class org.apache.zookeeper.proto.GetSASLRequest
- toString() - Method in class org.apache.zookeeper.proto.MultiHeader
- toString() - Method in class org.apache.zookeeper.proto.ReplyHeader
- toString() - Method in class org.apache.zookeeper.proto.RequestHeader
- toString() - Method in class org.apache.zookeeper.proto.SetACLRequest
- toString() - Method in class org.apache.zookeeper.proto.SetACLResponse
- toString() - Method in class org.apache.zookeeper.proto.SetDataRequest
- toString() - Method in class org.apache.zookeeper.proto.SetDataResponse
- toString() - Method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- toString() - Method in class org.apache.zookeeper.proto.SetSASLRequest
- toString() - Method in class org.apache.zookeeper.proto.SetSASLResponse
- toString() - Method in class org.apache.zookeeper.proto.SetWatches
- toString() - Method in class org.apache.zookeeper.proto.SyncRequest
- toString() - Method in class org.apache.zookeeper.proto.SyncResponse
- toString() - Method in class org.apache.zookeeper.proto.WatcherEvent
- toString() - Method in class org.apache.zookeeper.server.auth.KerberosName
-
Put the name back together from the parts.
- toString() - Method in class org.apache.zookeeper.server.ConnectionBean
- toString() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- toString() - Method in class org.apache.zookeeper.server.persistence.FileHeader
- toString() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection.Notification
- toString() - Method in class org.apache.zookeeper.server.quorum.Follower
- toString() - Method in class org.apache.zookeeper.server.quorum.Leader.Proposal
- toString() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
- toString() - Method in class org.apache.zookeeper.server.quorum.LearnerInfo
- toString() - Method in class org.apache.zookeeper.server.quorum.Observer
- toString() - Method in class org.apache.zookeeper.server.quorum.ProposalStats
- toString() - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- toString() - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- toString() - Method in class org.apache.zookeeper.server.quorum.QuorumStats
- toString() - Method in class org.apache.zookeeper.server.quorum.Vote
- toString() - Method in class org.apache.zookeeper.server.Request
- toString() - Method in exception org.apache.zookeeper.server.ServerCnxn.EndOfStreamException
- toString() - Method in class org.apache.zookeeper.server.ServerCnxn
-
Prints detailed stats information for the connection.
- toString() - Method in class org.apache.zookeeper.server.ServerStats
- toString() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
- toString() - Method in class org.apache.zookeeper.server.WatchManager
-
Brief description of this object.
- toString() - Method in class org.apache.zookeeper.Shell.ShellCommandExecutor
-
Returns the commands of this instance.
- toString() - Method in class org.apache.zookeeper.StatsTrack
- toString() - Method in class org.apache.zookeeper.txn.CheckVersionTxn
- toString() - Method in class org.apache.zookeeper.txn.CreateSessionTxn
- toString() - Method in class org.apache.zookeeper.txn.CreateTxn
- toString() - Method in class org.apache.zookeeper.txn.CreateTxnV0
- toString() - Method in class org.apache.zookeeper.txn.DeleteTxn
- toString() - Method in class org.apache.zookeeper.txn.ErrorTxn
- toString() - Method in class org.apache.zookeeper.txn.MultiTxn
- toString() - Method in class org.apache.zookeeper.txn.SetACLTxn
- toString() - Method in class org.apache.zookeeper.txn.SetDataTxn
- toString() - Method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- toString() - Method in class org.apache.zookeeper.txn.Txn
- toString() - Method in class org.apache.zookeeper.txn.TxnHeader
- toString() - Method in class org.apache.zookeeper.WatchedEvent
- toString() - Method in class org.apache.zookeeper.ZooKeeper
-
String representation of this ZooKeeper client.
- totalLatency - Variable in class org.apache.zookeeper.server.ServerCnxn
- totalOrderPredicate(long, long, long, long, long, long) - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
-
Check if a pair (server id, zxid) succeeds our current vote.
- touch(long, int) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
- touchSession(long, int) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
- touchSession(long, int) - Method in interface org.apache.zookeeper.server.SessionTracker
- touchSession(long, int) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
- TraceFormatter - Class in org.apache.zookeeper.server
- TraceFormatter() - Constructor for class org.apache.zookeeper.server.TraceFormatter
- transaction() - Method in class org.apache.zookeeper.ZooKeeper
-
A Transaction is a thin wrapper on the
ZooKeeper.multi(java.lang.Iterable<org.apache.zookeeper.Op>)
method which provides a builder object that can be used to construct and commit an atomic set of operations. - Transaction - Class in org.apache.zookeeper
-
Provides a builder style interface for doing multiple updates.
- Transaction(ZooKeeper) - Constructor for class org.apache.zookeeper.Transaction
- triggerWatch(String, Watcher.Event.EventType) - Method in class org.apache.zookeeper.server.WatchManager
- triggerWatch(String, Watcher.Event.EventType, Set<Watcher>) - Method in class org.apache.zookeeper.server.WatchManager
- truncate(long) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
truncate the current transaction logs
- truncate(long) - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
truncate the log to get in sync with the leader.
- truncateLog(long) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
truncate the transaction logs the zxid specified
- truncateLog(long) - Method in class org.apache.zookeeper.server.ZKDatabase
-
Truncate the ZKDatabase to the specified zxid
- truncateLog(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
trunccate the log to get in sync with others if in a quorum
- txn - Variable in class org.apache.zookeeper.server.Request
- Txn - Class in org.apache.zookeeper.txn
- Txn() - Constructor for class org.apache.zookeeper.txn.Txn
- Txn(int, byte[]) - Constructor for class org.apache.zookeeper.txn.Txn
- TxnHeader - Class in org.apache.zookeeper.txn
- TxnHeader() - Constructor for class org.apache.zookeeper.txn.TxnHeader
- TxnHeader(long, int, long, long, int) - Constructor for class org.apache.zookeeper.txn.TxnHeader
- TxnLog - Interface in org.apache.zookeeper.server.persistence
-
Interface for reading transaction logs.
- TXNLOG_MAGIC - Static variable in class org.apache.zookeeper.server.persistence.FileTxnLog
- TxnLog.TxnIterator - Interface in org.apache.zookeeper.server.persistence
-
an iterating interface for reading transaction logs.
- TxnLogToolkit - Class in org.apache.zookeeper.server.persistence
- TxnLogToolkit(boolean, boolean, String, boolean) - Constructor for class org.apache.zookeeper.server.persistence.TxnLogToolkit
- type - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
- type - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
- type - Variable in class org.apache.zookeeper.server.Request
U
- ULIMIT_COMMAND - Static variable in class org.apache.zookeeper.Shell
-
a Unix command to get ulimit of a process.
- UNEXPECTED_ERROR - Static variable in class org.apache.zookeeper.server.ExitCode
- Unimplemented - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.UNIMPLEMENTED
instead - UNIMPLEMENTED - org.apache.zookeeper.KeeperException.Code
-
Operation is unimplemented
- UnimplementedException() - Constructor for exception org.apache.zookeeper.KeeperException.UnimplementedException
- UnimplementedRequestProcessor - Class in org.apache.zookeeper.server
-
Manages the unknown requests (i.e.
- UnimplementedRequestProcessor() - Constructor for class org.apache.zookeeper.server.UnimplementedRequestProcessor
- Unknown - org.apache.zookeeper.Watcher.Event.KeeperState
-
Deprecated.
- UNKNOWN_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
- unregister(ZKMBeanInfo) - Method in class org.apache.zookeeper.jmx.MBeanRegistry
-
Unregister MBean.
- unregisterAll() - Method in class org.apache.zookeeper.jmx.MBeanRegistry
-
Unregister all currently registered MBeans
- unregisterConnection(ServerCnxn) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- unregisterJMX() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
- unregisterJMX() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
- unregisterJMX() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
- unregisterJMX() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- unregisterJMX(Leader) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
- unregisterJMX(Learner) - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
- unregisterJMX(ZooKeeperServer) - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
- updateBytes(String, long) - Method in class org.apache.zookeeper.server.DataTree
-
update the count of bytes of this stat datanode
- updateCount(String, int) - Method in class org.apache.zookeeper.server.DataTree
-
update the count of this stat datanode
- updateElectionVote(long) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Updates leader election info to avoid inconsistencies when a new server tries to join the ensemble.
- updateStatsForResponse(long, long, String, long, long) - Method in class org.apache.zookeeper.server.ServerCnxn
- UPDATING_EPOCH_FILENAME - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
- UpgradeMain - Class in org.apache.zookeeper.server.upgrade
-
This class upgrades the older database to a new database for the zookeeper servers.
- UpgradeMain(File, File) - Constructor for class org.apache.zookeeper.server.upgrade.UpgradeMain
-
upgrade class that takes the two file directories.
- UpgradeSnapShot - Interface in org.apache.zookeeper.server.upgrade
-
interface for snapshot conversion.
- UpgradeSnapShotV1 - Class in org.apache.zookeeper.server.upgrade
-
This class gets the old snapshot and the old dataDir and creates an brand new snapshot that is then converted to the new snapshot for upgrading.
- UpgradeSnapShotV1(File, File) - Constructor for class org.apache.zookeeper.server.upgrade.UpgradeSnapShotV1
-
upgrade from version 1 to version 2
- USER_NAME_COMMAND - Static variable in class org.apache.zookeeper.Shell
-
a Unix command to get the current user's name
- Util - Class in org.apache.zookeeper.server.persistence
-
A collection of utility methods for dealing with file name parsing, low level I/O file operations and marshalling/unmarshalling.
- Util() - Constructor for class org.apache.zookeeper.server.persistence.Util
V
- validatePath(String) - Static method in class org.apache.zookeeper.common.PathUtils
-
Validate the provided znode path string
- validatePath(String, boolean) - Static method in class org.apache.zookeeper.common.PathUtils
-
validate the provided znode path string
- value() - Method in annotation type org.apache.yetus.audience.InterfaceAudience.LimitedPrivate
- valueOf(String) - Static method in enum org.apache.zookeeper.client.ZooKeeperSaslClient.SaslState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.zookeeper.CreateMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.zookeeper.KeeperException.Code
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.zookeeper.server.DatadirCleanupManager.PurgeTaskStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.zookeeper.server.quorum.auth.QuorumAuth.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.zookeeper.server.quorum.QuorumPeer.LearnerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.zookeeper.server.quorum.QuorumPeer.ServerState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.zookeeper.server.ZooKeeperServer.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.zookeeper.Watcher.Event.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.zookeeper.Watcher.Event.KeeperState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.zookeeper.ZooKeeper.States
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.zookeeper.client.ZooKeeperSaslClient.SaslState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.zookeeper.CreateMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.zookeeper.KeeperException.Code
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.zookeeper.server.DatadirCleanupManager.PurgeTaskStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.zookeeper.server.quorum.auth.QuorumAuth.Status
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.zookeeper.server.quorum.QuorumPeer.LearnerType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.zookeeper.server.quorum.QuorumPeer.ServerState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.zookeeper.server.ZooKeeperServer.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.zookeeper.Watcher.Event.EventType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.zookeeper.Watcher.Event.KeeperState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.zookeeper.ZooKeeper.States
-
Returns an array containing the constants of this enum type, in the order they are declared.
- VerGen - Class in org.apache.zookeeper.version.util
- VerGen() - Constructor for class org.apache.zookeeper.version.util.VerGen
- VerGen.Version - Class in org.apache.zookeeper.version.util
- version - Static variable in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
- version - Variable in class org.apache.zookeeper.server.quorum.LearnerHandler
- Version - Class in org.apache.zookeeper
- Version() - Constructor for class org.apache.zookeeper.Version
- Version() - Constructor for class org.apache.zookeeper.version.util.VerGen.Version
- VERSION - Static variable in class org.apache.zookeeper.server.persistence.FileTxnLog
- VERSION - Static variable in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
- viewContains(Long) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Check if a node is in the current view.
- vote - Variable in class org.apache.zookeeper.server.quorum.LeaderElection.ElectionResult
-
Deprecated.
- Vote - Class in org.apache.zookeeper.server.quorum
- Vote(int, long, long, long, long, QuorumPeer.ServerState) - Constructor for class org.apache.zookeeper.server.quorum.Vote
- Vote(long, long) - Constructor for class org.apache.zookeeper.server.quorum.Vote
- Vote(long, long, long) - Constructor for class org.apache.zookeeper.server.quorum.Vote
- Vote(long, long, long, long) - Constructor for class org.apache.zookeeper.server.quorum.Vote
- Vote(long, long, long, long, QuorumPeer.ServerState) - Constructor for class org.apache.zookeeper.server.quorum.Vote
W
- waitForEpochAck(long, StateSummary) - Method in class org.apache.zookeeper.server.quorum.Leader
- waitForNewLeaderAck(long, long) - Method in class org.apache.zookeeper.server.quorum.Leader
-
Process NEWLEADER ack of a given sid and wait until the leader receives sufficient acks.
- WARNING_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
- WatchedEvent - Class in org.apache.zookeeper
-
A WatchedEvent represents a change on the ZooKeeper that a Watcher is able to respond to.
- WatchedEvent(WatcherEvent) - Constructor for class org.apache.zookeeper.WatchedEvent
-
Convert a WatcherEvent sent over the wire into a full-fledged WatcherEvent
- WatchedEvent(Watcher.Event.EventType, Watcher.Event.KeeperState, String) - Constructor for class org.apache.zookeeper.WatchedEvent
-
Create a WatchedEvent with specified type, state and path
- Watcher - Interface in org.apache.zookeeper
-
This interface specifies the public interface an event handler class must implement.
- Watcher.Event - Interface in org.apache.zookeeper
-
This interface defines the possible states an Event may represent
- Watcher.Event.EventType - Enum in org.apache.zookeeper
-
Enumeration of types of events that may occur on the ZooKeeper
- Watcher.Event.KeeperState - Enum in org.apache.zookeeper
-
Enumeration of states the ZooKeeper may be at the event
- WatcherEvent - Class in org.apache.zookeeper.proto
- WatcherEvent() - Constructor for class org.apache.zookeeper.proto.WatcherEvent
- WatcherEvent(int, int, String) - Constructor for class org.apache.zookeeper.proto.WatcherEvent
- WatchManager - Class in org.apache.zookeeper.server
-
This class manages watches.
- WatchManager() - Constructor for class org.apache.zookeeper.server.WatchManager
- wchcCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- wchpCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- wchsCmd - Static variable in class org.apache.zookeeper.server.ServerCnxn
- WINDOWS - Static variable in class org.apache.zookeeper.Shell
-
Set to true on Windows platforms
- winner - Variable in class org.apache.zookeeper.server.quorum.LeaderElection.ElectionResult
-
Deprecated.
- winningCount - Variable in class org.apache.zookeeper.server.quorum.LeaderElection.ElectionResult
-
Deprecated.
- write(byte[]) - Method in class org.apache.zookeeper.server.ByteBufferOutputStream
- write(byte[], int, int) - Method in class org.apache.zookeeper.common.AtomicFileOutputStream
-
The default write method in FilterOutputStream does not call the write method of its underlying input stream with the same arguments.
- write(byte[], int, int) - Method in class org.apache.zookeeper.server.ByteBufferOutputStream
- write(int) - Method in class org.apache.zookeeper.server.ByteBufferOutputStream
- write(DataOutput) - Method in class org.apache.zookeeper.data.ACL
- write(DataOutput) - Method in class org.apache.zookeeper.data.Id
- write(DataOutput) - Method in class org.apache.zookeeper.data.Stat
- write(DataOutput) - Method in class org.apache.zookeeper.data.StatPersisted
- write(DataOutput) - Method in class org.apache.zookeeper.data.StatPersistedV1
- write(DataOutput) - Method in class org.apache.zookeeper.proto.AuthPacket
- write(DataOutput) - Method in class org.apache.zookeeper.proto.CheckVersionRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.ConnectRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.ConnectResponse
- write(DataOutput) - Method in class org.apache.zookeeper.proto.CreateRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.CreateResponse
- write(DataOutput) - Method in class org.apache.zookeeper.proto.DeleteRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.ErrorResponse
- write(DataOutput) - Method in class org.apache.zookeeper.proto.ExistsRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.ExistsResponse
- write(DataOutput) - Method in class org.apache.zookeeper.proto.GetACLRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.GetACLResponse
- write(DataOutput) - Method in class org.apache.zookeeper.proto.GetChildren2Request
- write(DataOutput) - Method in class org.apache.zookeeper.proto.GetChildren2Response
- write(DataOutput) - Method in class org.apache.zookeeper.proto.GetChildrenRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.GetChildrenResponse
- write(DataOutput) - Method in class org.apache.zookeeper.proto.GetDataRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.GetDataResponse
- write(DataOutput) - Method in class org.apache.zookeeper.proto.GetMaxChildrenRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.GetMaxChildrenResponse
- write(DataOutput) - Method in class org.apache.zookeeper.proto.GetSASLRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.MultiHeader
- write(DataOutput) - Method in class org.apache.zookeeper.proto.ReplyHeader
- write(DataOutput) - Method in class org.apache.zookeeper.proto.RequestHeader
- write(DataOutput) - Method in class org.apache.zookeeper.proto.SetACLRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.SetACLResponse
- write(DataOutput) - Method in class org.apache.zookeeper.proto.SetDataRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.SetDataResponse
- write(DataOutput) - Method in class org.apache.zookeeper.proto.SetMaxChildrenRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.SetSASLRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.SetSASLResponse
- write(DataOutput) - Method in class org.apache.zookeeper.proto.SetWatches
- write(DataOutput) - Method in class org.apache.zookeeper.proto.SyncRequest
- write(DataOutput) - Method in class org.apache.zookeeper.proto.SyncResponse
- write(DataOutput) - Method in class org.apache.zookeeper.proto.WatcherEvent
- write(DataOutput) - Method in class org.apache.zookeeper.server.persistence.FileHeader
- write(DataOutput) - Method in class org.apache.zookeeper.server.quorum.LearnerInfo
- write(DataOutput) - Method in class org.apache.zookeeper.server.quorum.QuorumAuthPacket
- write(DataOutput) - Method in class org.apache.zookeeper.server.quorum.QuorumPacket
- write(DataOutput) - Method in class org.apache.zookeeper.txn.CheckVersionTxn
- write(DataOutput) - Method in class org.apache.zookeeper.txn.CreateSessionTxn
- write(DataOutput) - Method in class org.apache.zookeeper.txn.CreateTxn
- write(DataOutput) - Method in class org.apache.zookeeper.txn.CreateTxnV0
- write(DataOutput) - Method in class org.apache.zookeeper.txn.DeleteTxn
- write(DataOutput) - Method in class org.apache.zookeeper.txn.ErrorTxn
- write(DataOutput) - Method in class org.apache.zookeeper.txn.MultiTxn
- write(DataOutput) - Method in class org.apache.zookeeper.txn.SetACLTxn
- write(DataOutput) - Method in class org.apache.zookeeper.txn.SetDataTxn
- write(DataOutput) - Method in class org.apache.zookeeper.txn.SetMaxChildrenTxn
- write(DataOutput) - Method in class org.apache.zookeeper.txn.Txn
- write(DataOutput) - Method in class org.apache.zookeeper.txn.TxnHeader
- WRITE - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
- writeTxnBytes(OutputArchive, byte[]) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Write the serialized transaction record to the output archive.
X
- XidRolloverException(String) - Constructor for exception org.apache.zookeeper.server.quorum.Leader.XidRolloverException
Z
- zk - Variable in class org.apache.zookeeper.ZooKeeperMain
- ZKDatabase - Class in org.apache.zookeeper.server
-
This class maintains the in memory database of zookeeper server states that includes the sessions, datatree and the committed logs.
- ZKDatabase(FileTxnSnapLog) - Constructor for class org.apache.zookeeper.server.ZKDatabase
-
the filetxnsnaplog that this zk database maps to.
- ZKMBeanInfo - Interface in org.apache.zookeeper.jmx
-
Zookeeper MBean info interface.
- zks - Variable in class org.apache.zookeeper.server.ZooKeeperServerBean
- zkServer - Variable in class org.apache.zookeeper.server.NIOServerCnxn
- zkServer - Variable in class org.apache.zookeeper.server.ServerCnxnFactory
- ZKUtil - Class in org.apache.zookeeper
- ZKUtil() - Constructor for class org.apache.zookeeper.ZKUtil
- ZooDefs - Class in org.apache.zookeeper
- ZooDefs() - Constructor for class org.apache.zookeeper.ZooDefs
- ZooDefs.Ids - Interface in org.apache.zookeeper
- ZooDefs.OpCode - Interface in org.apache.zookeeper
- ZooDefs.Perms - Interface in org.apache.zookeeper
- ZooKeeper - Class in org.apache.zookeeper
-
This is the main class of ZooKeeper client library.
- ZooKeeper(String, int, Watcher) - Constructor for class org.apache.zookeeper.ZooKeeper
-
To create a ZooKeeper client object, the application needs to pass a connection string containing a comma separated list of host:port pairs, each corresponding to a ZooKeeper server.
- ZooKeeper(String, int, Watcher, boolean) - Constructor for class org.apache.zookeeper.ZooKeeper
-
To create a ZooKeeper client object, the application needs to pass a connection string containing a comma separated list of host:port pairs, each corresponding to a ZooKeeper server.
- ZooKeeper(String, int, Watcher, long, byte[]) - Constructor for class org.apache.zookeeper.ZooKeeper
-
To create a ZooKeeper client object, the application needs to pass a connection string containing a comma separated list of host:port pairs, each corresponding to a ZooKeeper server.
- ZooKeeper(String, int, Watcher, long, byte[], boolean) - Constructor for class org.apache.zookeeper.ZooKeeper
-
To create a ZooKeeper client object, the application needs to pass a connection string containing a comma separated list of host:port pairs, each corresponding to a ZooKeeper server.
- ZOOKEEPER_CLIENT_CNXN_SOCKET - Static variable in class org.apache.zookeeper.ZooKeeper
- ZOOKEEPER_SERVER_CNXN_FACTORY - Static variable in class org.apache.zookeeper.server.ServerCnxnFactory
- ZooKeeper.States - Enum in org.apache.zookeeper
- ZooKeeperCriticalThread - Class in org.apache.zookeeper.server
-
Represents critical thread.
- ZooKeeperCriticalThread(String, ZooKeeperServerListener) - Constructor for class org.apache.zookeeper.server.ZooKeeperCriticalThread
- ZooKeeperMain - Class in org.apache.zookeeper
-
The command line client to ZooKeeper.
- ZooKeeperMain(String[]) - Constructor for class org.apache.zookeeper.ZooKeeperMain
- ZooKeeperMain(ZooKeeper) - Constructor for class org.apache.zookeeper.ZooKeeperMain
- zooKeeperSaslClient - Variable in class org.apache.zookeeper.ClientCnxn
- ZooKeeperSaslClient - Class in org.apache.zookeeper.client
-
This class manages SASL authentication for the client.
- ZooKeeperSaslClient(String) - Constructor for class org.apache.zookeeper.client.ZooKeeperSaslClient
- ZooKeeperSaslClient.SaslState - Enum in org.apache.zookeeper.client
- ZooKeeperSaslClient.ServerSaslResponseCallback - Class in org.apache.zookeeper.client
- zooKeeperSaslServer - Variable in class org.apache.zookeeper.server.ServerCnxn
- ZooKeeperSaslServer - Class in org.apache.zookeeper.server
- ZooKeeperServer - Class in org.apache.zookeeper.server
-
This class implements a simple standalone ZooKeeperServer.
- ZooKeeperServer() - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
-
Creates a ZooKeeperServer instance.
- ZooKeeperServer(File, File, int) - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
-
This constructor is for backward compatibility with the existing unit test code.
- ZooKeeperServer(FileTxnSnapLog, int, int, int, ZooKeeperServer.DataTreeBuilder, ZKDatabase) - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
-
Creates a ZooKeeperServer instance.
- ZooKeeperServer(FileTxnSnapLog, int, ZooKeeperServer.DataTreeBuilder) - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
-
creates a zookeeperserver instance.
- ZooKeeperServer(FileTxnSnapLog, ZooKeeperServer.DataTreeBuilder) - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
-
Default constructor, relies on the config for its agrument values
- ZooKeeperServer.BasicDataTreeBuilder - Class in org.apache.zookeeper.server
- ZooKeeperServer.DataTreeBuilder - Interface in org.apache.zookeeper.server
-
The server delegates loading of the tree to an instance of the interface
- ZooKeeperServer.MissingSessionException - Exception in org.apache.zookeeper.server
- ZooKeeperServer.State - Enum in org.apache.zookeeper.server
- ZooKeeperServerBean - Class in org.apache.zookeeper.server
-
This class implements the ZooKeeper server MBean interface.
- ZooKeeperServerBean(ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.ZooKeeperServerBean
- ZooKeeperServerListener - Interface in org.apache.zookeeper.server
-
Listener for the critical resource events.
- ZooKeeperServerMain - Class in org.apache.zookeeper.server
-
This class starts and runs a standalone ZooKeeperServer.
- ZooKeeperServerMain() - Constructor for class org.apache.zookeeper.server.ZooKeeperServerMain
- ZooKeeperServerMXBean - Interface in org.apache.zookeeper.server
-
ZooKeeper server MBean.
- ZooKeeperThread - Class in org.apache.zookeeper.server
-
This is the main class for catching all the uncaught exceptions thrown by the threads.
- ZooKeeperThread(Runnable, String) - Constructor for class org.apache.zookeeper.server.ZooKeeperThread
- ZooKeeperThread(String) - Constructor for class org.apache.zookeeper.server.ZooKeeperThread
- ZooTrace - Class in org.apache.zookeeper.server
-
This class encapsulates and centralizes tracing for the ZooKeeper server.
- ZooTrace() - Constructor for class org.apache.zookeeper.server.ZooTrace
- zxid - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
- zxid - Variable in class org.apache.zookeeper.server.Request
- zxid - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
- zxidToString(long) - Static method in class org.apache.zookeeper.server.util.ZxidUtils
- ZxidUtils - Class in org.apache.zookeeper.server.util
- ZxidUtils() - Constructor for class org.apache.zookeeper.server.util.ZxidUtils
All Classes All Packages