Skip navigation links
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 

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
 
AbstractFourLetterCommand - Class in org.apache.zookeeper.server.command
Set of threads for command ports.
AbstractFourLetterCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.AbstractFourLetterCommand
 
accept() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket
 
ACCEPTED_EPOCH_FILENAME - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
ACK_LATENCY - Variable in class org.apache.zookeeper.server.ServerMetrics
 
ACKEPOCH - Static variable in class org.apache.zookeeper.server.quorum.Leader
This message is used by the follow to ack a proposed epoch.
ackSetsToString() - Method in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker
 
acl - Variable in class org.apache.zookeeper.Op.Create
 
aclCacheSize() - Method in class org.apache.zookeeper.server.DataTree
 
aclForNode(DataNode) - Method in class org.apache.zookeeper.server.ZKDatabase
 
AclParser - Class in org.apache.zookeeper.cli
a parser for ACL strings
AclParser() - Constructor for class org.apache.zookeeper.cli.AclParser
 
aclToString(List<ACL>) - Static method in class org.apache.zookeeper.ZKUtil
 
add(long) - Method in interface org.apache.zookeeper.metrics.Counter
Increment the value by a given amount.
add(String, long) - Method in interface org.apache.zookeeper.metrics.CounterSet
Increment the value by a given amount for the given key
add(long) - Method in interface org.apache.zookeeper.metrics.Summary
Register a value.
add(String, long) - Method in interface org.apache.zookeeper.metrics.SummarySet
Register a value.
add(Op) - Method in class org.apache.zookeeper.MultiOperationRecord
 
add(OpResult) - Method in class org.apache.zookeeper.MultiResponse
 
add(long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
 
add(String, long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounterSet
 
add(long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounter
 
add(String, long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounterSet
 
add(long) - Method in class org.apache.zookeeper.server.metric.Metric
 
add(int, long) - Method in class org.apache.zookeeper.server.metric.Metric
 
add(String, long) - Method in class org.apache.zookeeper.server.metric.Metric
 
add(long) - Method in class org.apache.zookeeper.server.metric.SimpleCounter
 
add(String, long) - Method in class org.apache.zookeeper.server.metric.SimpleCounterSet
 
add(Integer) - Method in class org.apache.zookeeper.server.util.BitHashSet
 
add(T) - Method in class org.apache.zookeeper.server.util.BitMap
 
add(E) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
ADD_DEAD_WATCHER_STALL_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
addAcceptedConnection(SocketChannel) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory.SelectorThread
Place new accepted connection onto a queue for adding.
addAck(Long) - Method in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker
 
addAddress(InetSocketAddress) - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
 
addAll(Collection<? extends E>) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
addAuditLog(Request, DataTree.ProcessTxnResult) - Static method in class org.apache.zookeeper.audit.AuditHelper
 
addAuditLog(Request, DataTree.ProcessTxnResult, boolean) - Static method in class org.apache.zookeeper.audit.AuditHelper
Add audit log if audit log is enabled and operation is of type which to be audit logged.
AddAuthCommand - Class in org.apache.zookeeper.cli
addAuth command for cli
AddAuthCommand() - Constructor for class org.apache.zookeeper.cli.AddAuthCommand
 
addAuthInfo(String, byte[]) - Method in class org.apache.zookeeper.ClientCnxn
 
addAuthInfo(Id) - Method in class org.apache.zookeeper.server.ServerCnxn
 
addAuthInfo(String, byte[]) - Method in class org.apache.zookeeper.ZooKeeper
Add the specified scheme:auth information to this connection.
addChangeRecord(ZooKeeperServer.ChangeRecord) - Method in class org.apache.zookeeper.server.PrepRequestProcessor
 
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.
addConfigNode() - Method in class org.apache.zookeeper.server.DataTree
create a /zookeeper/config node for maintaining the configuration (membership and quorum system) info for zookeeper
addConfiguration(File) - Method in class org.apache.zookeeper.common.ZKConfig
Add a configuration resource.
addConfiguration(String) - Method in class org.apache.zookeeper.common.ZKConfig
Add a configuration resource.
addDataPoint(long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
 
addDataPoint(String, long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounterSet
 
addDataPoint(long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounter
 
addDataPoint(String, long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounterSet
 
addDeadWatcher(int) - Method in class org.apache.zookeeper.server.watch.WatcherCleaner
 
addDigest(long) - Method in class org.apache.zookeeper.server.util.AdHash
Add new digest to the hash value maintained in this class.
addDigestWatcher(DigestWatcher) - Method in class org.apache.zookeeper.server.DataTree
Add digest mismatch event handler.
addInterestOpsUpdateRequest(SelectionKey) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory.SelectorThread
Place interest op update requests onto a queue so that only the selector thread modifies interest ops, because interest ops reads/sets are potentially blocking operations if other select operations are happening.
addLearnerHandler(LearnerHandler) - Method in class org.apache.zookeeper.server.quorum.Leader
Adds peer to the leader.
addLearnerHandler(LearnerHandler) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
addPath(String) - Method in class org.apache.zookeeper.common.PathTrie
Add a path to the path trie.
addQuorumVerifier(QuorumVerifier) - Method in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker
 
addr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
AddressTuple(MultipleAddresses, MultipleAddresses, InetSocketAddress) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer.AddressTuple
 
addServerStartFailureAuditLog() - Static method in class org.apache.zookeeper.audit.ZKAuditProvider
Add audit log for server start fail.
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 /
addToMap(Map<String, CliCommand>) - Method in class org.apache.zookeeper.cli.CliCommand
add this command to a map.
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, int) - Method in class org.apache.zookeeper.server.DataTree
 
addWatch(String, Watcher) - Method in interface org.apache.zookeeper.server.watch.IWatchManager
Add watch to specific path.
addWatch(String, Watcher, WatcherMode) - Method in interface org.apache.zookeeper.server.watch.IWatchManager
Add watch to specific path.
addWatch(String, Watcher) - Method in class org.apache.zookeeper.server.watch.WatchManager
 
addWatch(String, Watcher, WatcherMode) - Method in class org.apache.zookeeper.server.watch.WatchManager
 
addWatch(String, Watcher) - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
 
addWatch(String, Watcher, int) - Method in class org.apache.zookeeper.server.ZKDatabase
Add a watch
addWatch - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
addWatch(String, Watcher, AddWatchMode) - Method in class org.apache.zookeeper.ZooKeeper
Add a watch to the given znode using the given mode.
addWatch(String, AddWatchMode) - Method in class org.apache.zookeeper.ZooKeeper
Add a watch to the given znode using the given mode.
addWatch(String, Watcher, AddWatchMode, AsyncCallback.VoidCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
Async version of ZooKeeper.addWatch(String, Watcher, AddWatchMode) (see it for details)
addWatch(String, AddWatchMode, AsyncCallback.VoidCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
Async version of ZooKeeper.addWatch(String, AddWatchMode) (see it for details)
AddWatchCommand - Class in org.apache.zookeeper.cli
addWatch command for cli.
AddWatchCommand() - Constructor for class org.apache.zookeeper.cli.AddWatchCommand
 
AddWatchMode - Enum in org.apache.zookeeper
addZKStartStopAuditLog() - Static method in class org.apache.zookeeper.audit.ZKAuditProvider
Add audit log for server start and register server stop log.
AdHash - Class in org.apache.zookeeper.server.util
This incremental hash is used to keep track of the hash of the data tree to that we can quickly validate that things are in sync.
AdHash() - Constructor for class org.apache.zookeeper.server.util.AdHash
 
ADMIN - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
 
AdminServer - Interface in org.apache.zookeeper.server.admin
Interface for an embedded admin server that runs Commands.
AdminServer.AdminServerException - Exception in org.apache.zookeeper.server.admin
 
AdminServerException(String, Throwable) - Constructor for exception org.apache.zookeeper.server.admin.AdminServer.AdminServerException
 
AdminServerException(Throwable) - Constructor for exception org.apache.zookeeper.server.admin.AdminServer.AdminServerException
 
AdminServerFactory - Class in org.apache.zookeeper.server.admin
Factory class for creating an AdminServer.
AdminServerFactory() - Constructor for class org.apache.zookeeper.server.admin.AdminServerFactory
 
ALL - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
 
ALLOW_SASL_FAILED_CLIENTS - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
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
APIErrorException() - Constructor for exception org.apache.zookeeper.KeeperException.APIErrorException
 
append(TxnHeader, Record) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
append an entry to the transaction log
append(TxnHeader, Record, TxnDigest) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
 
append(Request) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
append the request to the transaction logs
append(TxnHeader, Record) - Method in interface org.apache.zookeeper.server.persistence.TxnLog
Append a request to the transaction log
append(TxnHeader, Record, TxnDigest) - Method in interface org.apache.zookeeper.server.persistence.TxnLog
Append a request to the transaction log with a digset
append(Request) - Method in class org.apache.zookeeper.server.ZKDatabase
append to the underlying 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
 
areLocalSessionsEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Whether local sessions are enabled
areLocalSessionsEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
asIterable() - Method in class org.apache.zookeeper.server.watch.PathParentIterator
Return an Iterable view so that this Iterator can be used in for each statements.
askOracle() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
 
askOracle() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
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.AllChildrenNumberCallback - Interface in org.apache.zookeeper
This callback is used to get all children node number 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.Create2Callback - Interface in org.apache.zookeeper
This callback is used to retrieve the name and stat of the node.
AsyncCallback.DataCallback - Interface in org.apache.zookeeper
This callback is used to retrieve the data and stat of the node.
AsyncCallback.EphemeralsCallback - Interface in org.apache.zookeeper
This callback is used to process the getEphemerals results from a single getEphemerals call.
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
 
AtomicFileWritingIdiom - Class in org.apache.zookeeper.common
 
AtomicFileWritingIdiom(File, AtomicFileWritingIdiom.OutputStreamStatement) - Constructor for class org.apache.zookeeper.common.AtomicFileWritingIdiom
 
AtomicFileWritingIdiom(File, AtomicFileWritingIdiom.WriterStatement) - Constructor for class org.apache.zookeeper.common.AtomicFileWritingIdiom
 
AtomicFileWritingIdiom.OutputStreamStatement - Interface in org.apache.zookeeper.common
 
AtomicFileWritingIdiom.WriterStatement - Interface in org.apache.zookeeper.common
 
atParentPath() - Method in class org.apache.zookeeper.server.watch.PathParentIterator
Returns true if this iterator is currently at a parent path as opposed to the initial path given to the constructor
AuditConstants - Class in org.apache.zookeeper.audit
 
AuditEvent - Class in org.apache.zookeeper.audit
 
AuditEvent.FieldName - Enum in org.apache.zookeeper.audit
 
AuditEvent.Result - Enum in org.apache.zookeeper.audit
 
AuditHelper - Class in org.apache.zookeeper.audit
Helper class to decouple audit log code.
AuditHelper() - Constructor for class org.apache.zookeeper.audit.AuditHelper
 
AuditLogger - Interface in org.apache.zookeeper.audit
 
auth - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
AUTH_IDS - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
This Id is only usable to set ACLs.
authenticate(Socket, String) - Method in class org.apache.zookeeper.server.quorum.auth.NullQuorumAuthLearner
 
authenticate(Socket, DataInputStream) - Method in class org.apache.zookeeper.server.quorum.auth.NullQuorumAuthServer
 
authenticate(Socket, String) - Method in interface org.apache.zookeeper.server.quorum.auth.QuorumAuthLearner
Performs an authentication step for the given socket connection.
authenticate(Socket, DataInputStream) - Method in interface org.apache.zookeeper.server.quorum.auth.QuorumAuthServer
Performs an authentication step for the given socket connection.
authenticate(Socket, String) - Method in class org.apache.zookeeper.server.quorum.auth.SaslQuorumAuthLearner
 
authenticate(Socket, DataInputStream) - Method in class org.apache.zookeeper.server.quorum.auth.SaslQuorumAuthServer
 
AuthenticationHelper - Class in org.apache.zookeeper.server
Contains helper methods to enforce authentication
AuthenticationHelper() - Constructor for class org.apache.zookeeper.server.AuthenticationHelper
 
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 - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.AUTHFAILED instead
AuthFailedException() - Constructor for exception org.apache.zookeeper.KeeperException.AuthFailedException
 
authInfo - Variable in class org.apache.zookeeper.server.Request
 
AUTHPACKET_XID - Static variable in class org.apache.zookeeper.ClientCnxn
 
AUTHPROVIDER_PROPERTY_PREFIX - Static variable in class org.apache.zookeeper.server.auth.ProviderRegistry
 
AuthUtil - Class in org.apache.zookeeper.server.util
 
authWriteRequest(Request) - Method in class org.apache.zookeeper.server.ZooKeeperServer
Check Write Requests for Potential Access Restrictions

Before a request is being proposed to the quorum, lets check it against local ACLs.

available() - Method in class org.apache.zookeeper.server.ByteBufferInputStream
 
AvgMinMaxCounter - Class in org.apache.zookeeper.server.metric
Generic long counter that keep track of min/max/avg.
AvgMinMaxCounter(String) - Constructor for class org.apache.zookeeper.server.metric.AvgMinMaxCounter
 
AvgMinMaxCounterSet - Class in org.apache.zookeeper.server.metric
Generic set of long counters that keep track of min/max/avg for different keys.
AvgMinMaxCounterSet(String) - Constructor for class org.apache.zookeeper.server.metric.AvgMinMaxCounterSet
 
AvgMinMaxPercentileCounter - Class in org.apache.zookeeper.server.metric
Generic long counter that keep track of min/max/avg/percentiles.
AvgMinMaxPercentileCounter(String) - Constructor for class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounter
 
AvgMinMaxPercentileCounterSet - Class in org.apache.zookeeper.server.metric
Generic set of long counters that keep track of min/max/avg for different keys.
AvgMinMaxPercentileCounterSet(String) - Constructor for class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounterSet
 

B

BadArguments - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.BADARGUMENTS instead
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
BadVersionException() - Constructor for exception org.apache.zookeeper.KeeperException.BadVersionException
 
BadVersionException(String) - Constructor for exception org.apache.zookeeper.KeeperException.BadVersionException
 
baseDir(Path) - Method in class org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded.ZookKeeperServerEmbeddedBuilder
Base directory of the server.
BATCH_SIZE - Variable in class org.apache.zookeeper.server.ServerMetrics
 
beginSync(boolean) - Method in class org.apache.zookeeper.server.quorum.LearnerSyncThrottler
Indicates that a new sync is about to be sent.
bind(SocketAddress) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
BitHashSet - Class in org.apache.zookeeper.server.util
Using BitSet to store all the elements, and use HashSet to cache limited number of elements to find a balance between memory and time complexity.
BitHashSet() - Constructor for class org.apache.zookeeper.server.util.BitHashSet
 
BitHashSet(int) - Constructor for class org.apache.zookeeper.server.util.BitHashSet
 
BitMap<T> - Class in org.apache.zookeeper.server.util
This is a helper class to maintain the bit to specific value and the reversed value to bit mapping.
BitMap() - Constructor for class org.apache.zookeeper.server.util.BitMap
 
BlueThrottle - Class in org.apache.zookeeper.server
Implements a token-bucket based rate limiting mechanism with optional probabilistic dropping inspired by the BLUE queue management algorithm [1].
BlueThrottle() - Constructor for class org.apache.zookeeper.server.BlueThrottle
 
BUFFERED_MESSAGE_SIZE - Static variable in class org.apache.zookeeper.server.util.MessageTracker
 
bufferedOutput - Variable in class org.apache.zookeeper.server.quorum.Learner
 
BufferStats - Class in org.apache.zookeeper.server.quorum
Provides live statistics about Jute buffer usage in term of proposal and client request size.
BufferStats() - Constructor for class org.apache.zookeeper.server.quorum.BufferStats
 
build() - Method in class org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded.ZookKeeperServerEmbeddedBuilder
Validate the configuration and create the server, without starting it.
build() - Method in class org.apache.zookeeper.server.util.VerifyingFileFactory.Builder
 
BUILD_DATE - Static variable in interface org.apache.zookeeper.version.Info
 
builder() - Static method in interface org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded
 
Builder(Logger) - Constructor for class org.apache.zookeeper.server.util.VerifyingFileFactory.Builder
 
buildInformAndActivePacket(long, long, byte[]) - Static method in class org.apache.zookeeper.server.quorum.Leader
 
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
 
BYTES_RECEIVED_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 

C

cachedApproximateDataSize() - Method in class org.apache.zookeeper.server.DataTree
 
cachedSize() - Method in class org.apache.zookeeper.server.util.BitHashSet
 
calculateFileSizeWithPadding(long, long, long) - Static method in class org.apache.zookeeper.server.persistence.FilePadding
Calculates a new file size with padding.
calculateTxnLogSizeLimit() - Method in class org.apache.zookeeper.server.ZKDatabase
 
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(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
 
check - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
checkACL(ServerCnxn, List<ACL>, int, List<Id>, String, List<ACL>) - Method in class org.apache.zookeeper.server.ZooKeeperServer
Grant or deny authorization to an operation on a node as a function of:
checkAddressDuplicate(QuorumPeer.QuorumServer) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
checkBlue(long) - Method in class org.apache.zookeeper.server.BlueThrottle
 
checkClientTrusted(X509Certificate[], String, Socket) - Method in class org.apache.zookeeper.common.ZKTrustManager
 
checkClientTrusted(X509Certificate[], String, SSLEngine) - Method in class org.apache.zookeeper.common.ZKTrustManager
 
checkClientTrusted(X509Certificate[], String) - Method in class org.apache.zookeeper.common.ZKTrustManager
 
checkContainers() - Method in class org.apache.zookeeper.server.ContainerManager
Manually check the containers.
checkGlobalSession(long, Object) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
checkGlobalSession(long, Object) - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
checkGlobalSession(long, Object) - Method in interface org.apache.zookeeper.server.SessionTracker
Strictly check that a given session is a global session or not
checkGlobalSession(long, Object) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
checkIfValidGlobalSession(long, int) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
checkLeader(Map<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.
checkLimit(int) - Method in class org.apache.zookeeper.server.BlueThrottle
 
checkPasswd(long, byte[]) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
checkQuota(String, byte[], byte[], int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
check a path whether exceeded the quota.
checkRequestSizeWhenReceivingMessage(int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
CheckResult() - Constructor for class org.apache.zookeeper.OpResult.CheckResult
 
checkServerTrusted(X509Certificate[], String, Socket) - Method in class org.apache.zookeeper.common.ZKTrustManager
 
checkServerTrusted(X509Certificate[], String, SSLEngine) - Method in class org.apache.zookeeper.common.ZKTrustManager
 
checkServerTrusted(X509Certificate[], String) - Method in class org.apache.zookeeper.common.ZKTrustManager
 
checkSession(long, Object) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
checkSession(long, Object) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
 
checkSession(long, Object) - Method in interface org.apache.zookeeper.server.SessionTracker
Checks whether the SessionTracker is aware of this session, the session is still active, and the owner matches.
checkSession(long, Object) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
checkUpgradeSession(Request) - Method in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
 
checkValidity() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
checkWatches - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
chop() - Method in class org.apache.zookeeper.server.persistence.TxnLogToolkit
 
chop(InputStream, OutputStream, long) - Static method in class org.apache.zookeeper.server.util.LogChopper
 
CircularBlockingQueue<E> - Class in org.apache.zookeeper.util
A bounded blocking queue backed by an array.
CircularBlockingQueue(int) - Constructor for class org.apache.zookeeper.util.CircularBlockingQueue
 
CircularBuffer<T> - Class in org.apache.zookeeper.server.util
Thread safe FIFO CircularBuffer implementation.
CircularBuffer(Class<T>, int) - Constructor for class org.apache.zookeeper.server.util.CircularBuffer
 
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.
cleanup() - Method in class org.apache.zookeeper.server.controller.ControllerService
 
cleanup() - Method in class org.apache.zookeeper.server.WorkerService.WorkRequest
(Optional) If implemented, is called if the service is stopped or unable to schedule the request.
cleanupWriterSocket(PrintWriter) - Method in class org.apache.zookeeper.server.ServerCnxn
clean up the socket related to a command and also make sure we flush the data before we do that
clear() - Method in class org.apache.zookeeper.common.PathTrie
Clear all nodes in the trie.
clear() - Method in interface org.apache.zookeeper.server.NodeHashMap
Clear all the items stored inside this map.
clear() - Method in class org.apache.zookeeper.server.NodeHashMapImpl
 
clear() - Method in class org.apache.zookeeper.server.util.AdHash
 
clear() - Method in class org.apache.zookeeper.server.ZKDatabase
clear the zkdatabase.
clear() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
CliCommand - Class in org.apache.zookeeper.cli
base class for all CLI commands
CliCommand(String, String) - Constructor for class org.apache.zookeeper.cli.CliCommand
a CLI command with command string and options.
CLIENT_DATA_PACKET_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
Deprecated.
CLIENT_MAX_PACKET_LENGTH_DEFAULT - Static variable in class org.apache.zookeeper.client.ZKClientConfig
 
CLIENT_PING_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
CLIENT_PORT_KEY - Static variable in class org.apache.zookeeper.server.controller.ControllerServerConfig
 
CLIENT_REQUEST_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
clientAddr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.AddressTuple
 
clientAddr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
ClientCnxn - Class in org.apache.zookeeper
This class manages the socket i/o for the client.
ClientCnxn(String, HostProvider, int, ZKClientConfig, Watcher, ClientCnxnSocket, boolean) - Constructor for class org.apache.zookeeper.ClientCnxn
Creates a connection object.
ClientCnxn(String, HostProvider, int, ZKClientConfig, Watcher, ClientCnxnSocket, long, byte[], boolean) - Constructor for class org.apache.zookeeper.ClientCnxn
Creates a connection object.
ClientCnxnLimitException - Exception in org.apache.zookeeper.server
Indicates that the number of client connections has exceeded some limit.
ClientCnxnLimitException() - Constructor for exception org.apache.zookeeper.server.ClientCnxnLimitException
 
ClientCnxnSocketNetty - Class in org.apache.zookeeper
ClientCnxnSocketNetty implements ClientCnxnSocket abstract methods.
ClientCnxnSocketNIO - Class in org.apache.zookeeper
 
clientId - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
 
clientPortAddress - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
clientPortAddress - Variable in class org.apache.zookeeper.server.ServerConfig
 
clientPortListenBacklog - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
The ZooKeeper server's socket backlog length.
clientPortListenBacklog - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
defaults to -1 if not set explicitly
clientTunneledAuthenticationInProgress() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
 
ClientWatchManager - Interface in org.apache.zookeeper
 
ClientX509Util - Class in org.apache.zookeeper.common
 
ClientX509Util() - Constructor for class org.apache.zookeeper.common.ClientX509Util
 
CliException - Exception in org.apache.zookeeper.cli
 
CliException(String) - Constructor for exception org.apache.zookeeper.cli.CliException
 
CliException(String, int) - Constructor for exception org.apache.zookeeper.cli.CliException
 
CliException(Throwable) - Constructor for exception org.apache.zookeeper.cli.CliException
 
CliException(Throwable, int) - Constructor for exception org.apache.zookeeper.cli.CliException
 
CliException(String, Throwable) - Constructor for exception org.apache.zookeeper.cli.CliException
 
CliException(String, Throwable, int) - Constructor for exception org.apache.zookeeper.cli.CliException
 
CliParseException - Exception in org.apache.zookeeper.cli
 
CliParseException(ParseException) - Constructor for exception org.apache.zookeeper.cli.CliParseException
 
CliParseException(String) - Constructor for exception org.apache.zookeeper.cli.CliParseException
 
CliWrapperException - Exception in org.apache.zookeeper.cli
 
CliWrapperException(Throwable) - Constructor for exception org.apache.zookeeper.cli.CliWrapperException
 
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.common.X509Util
Disables automatic reloading of the trust store and key store files when they change on disk.
close() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
close() - Method in class org.apache.zookeeper.server.controller.CommandClient
 
close() - Method in class org.apache.zookeeper.server.controller.CommandListener
 
close(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.DumbWatcher
 
close() - Method in interface org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded
Shutdown gracefully the server and wait for resources to be released.
close(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.NettyServerCnxn
Close the cnxn and remove it from the factory cnxns list.
close() - Method in class org.apache.zookeeper.server.NettyServerCnxn
 
close(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.NIOServerCnxn
Close the cnxn and remove it from the factory cnxns list.
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.quorum.QuorumPeerMain
Shutdowns properly the service, this method is not a public API.
close() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
close(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.ServerCnxn
 
close() - Method in class org.apache.zookeeper.server.TxnLogProposalIterator
Close the files and release the resources which are used for iterating transaction records
close() - Method in class org.apache.zookeeper.server.ZKDatabase
close this database.
close() - Method in class org.apache.zookeeper.server.ZooKeeperServerMain
Shutdowns properly the service, this method is not a public API.
close() - Method in class org.apache.zookeeper.ZooKeeper
Close this client object.
close(int) - Method in class org.apache.zookeeper.ZooKeeper
Close this client object as the ZooKeeper.close() method.
CLOSE_SESSION_PREP_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
CLOSE_SESSION_TXN_ENABLED - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
closeAll(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
closeAll(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
clear all the connections in the selector
closeAll(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
closeAllConnections() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
CloseCommand - Class in org.apache.zookeeper.cli
close command for cli
CloseCommand() - Constructor for class org.apache.zookeeper.cli.CloseCommand
 
CloseRequestException(String, ServerCnxn.DisconnectReason) - Constructor for exception org.apache.zookeeper.server.ServerCnxn.CloseRequestException
 
closeSession(long, ServerCnxn.DisconnectReason) - 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
 
closeSession - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
closeSock(SocketChannel) - Static method in class org.apache.zookeeper.server.NIOServerCnxn
Close resources associated with a sock.
closeSocketAsync - Static variable in class org.apache.zookeeper.server.quorum.Learner
 
closeSocketAsync - Static variable in class org.apache.zookeeper.server.quorum.LearnerHandler
 
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
 
CNXN_CLOSED_WITHOUT_ZK_SERVER_RUNNING - Variable in class org.apache.zookeeper.server.ServerMetrics
 
cnxns - Variable in class org.apache.zookeeper.server.ServerCnxnFactory
 
CnxnStatResetCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.CnxnStatResetCommand
 
CnxnStatResetCommand - Class in org.apache.zookeeper.server.command
 
CnxnStatResetCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.CnxnStatResetCommand
 
code() - Method in exception org.apache.zookeeper.KeeperException
Read the error Code for this exception
Command - Interface in org.apache.zookeeper.server.admin
Interface implemented by all commands runnable by JettyAdminServer.
CommandBase - Class in org.apache.zookeeper.server.admin
 
CommandBase(List<String>) - Constructor for class org.apache.zookeeper.server.admin.CommandBase
 
CommandBase(List<String>, boolean) - Constructor for class org.apache.zookeeper.server.admin.CommandBase
 
CommandBase(List<String>, boolean, String) - Constructor for class org.apache.zookeeper.server.admin.CommandBase
 
CommandClient - Class in org.apache.zookeeper.server.controller
A convenient helper to send controller command to ControllerService.
CommandClient(int, int) - Constructor for class org.apache.zookeeper.server.controller.CommandClient
Instantiate a client configured to send requests to localhost.
CommandClient(InetSocketAddress, int) - Constructor for class org.apache.zookeeper.server.controller.CommandClient
Instantiate a client configured to send requests to the specified host address.
CommandClient(int) - Constructor for class org.apache.zookeeper.server.controller.CommandClient
 
commandCount - Variable in class org.apache.zookeeper.ZooKeeperMain
 
CommandExecutor - Class in org.apache.zookeeper.server.command
 
CommandExecutor() - Constructor for class org.apache.zookeeper.server.command.CommandExecutor
 
CommandFactory - Class in org.apache.zookeeper.cli
Factory class for creating instances of CliCommand.
CommandFactory() - Constructor for class org.apache.zookeeper.cli.CommandFactory
 
CommandFactory.Command - Enum in org.apache.zookeeper.cli
All Cli Commands.
CommandListener - Class in org.apache.zookeeper.server.controller
An HTTP server listening to incoming controller commands sent from CommandClient (or any of your favorite REST client ) and dispatching the command to the ZooKeeperServerController for execution.
CommandListener(ZooKeeperServerController, ControllerServerConfig) - Constructor for class org.apache.zookeeper.server.controller.CommandListener
 
CommandNotFoundException - Exception in org.apache.zookeeper.cli
 
CommandNotFoundException(String) - Constructor for exception org.apache.zookeeper.cli.CommandNotFoundException
 
CommandOutputter - Interface in org.apache.zookeeper.server.admin
CommandOutputters are used to format the responses from Commands.
CommandResponse - Class in org.apache.zookeeper.server.admin
A response from running a Command.
CommandResponse(String) - Constructor for class org.apache.zookeeper.server.admin.CommandResponse
Creates a new response with no error string.
CommandResponse(String, String) - Constructor for class org.apache.zookeeper.server.admin.CommandResponse
Creates a new response.
commandRun() - Method in class org.apache.zookeeper.server.command.AbstractFourLetterCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.CnxnStatResetCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.ConfCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.ConsCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.DigestCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.DirsCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.DumpCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.EnvCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.IsroCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.MonitorCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.NopCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.RuokCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.SetTraceMaskCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.StatCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.StatResetCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.TraceMaskCommand
 
commandRun() - Method in class org.apache.zookeeper.server.command.WatchCommand
 
Commands - Class in org.apache.zookeeper.server.admin
Class containing static methods for registering and running Commands, as well as default Command definitions.
Commands.CnxnStatResetCommand - Class in org.apache.zookeeper.server.admin
Reset all connection statistics.
Commands.ConfCommand - Class in org.apache.zookeeper.server.admin
Server configuration parameters.
Commands.ConsCommand - Class in org.apache.zookeeper.server.admin
Information on client connections to server.
Commands.DigestCommand - Class in org.apache.zookeeper.server.admin
Digest histories for every specific number of txns.
Commands.DirsCommand - Class in org.apache.zookeeper.server.admin
Information on ZK datadir and snapdir size in bytes
Commands.DumpCommand - Class in org.apache.zookeeper.server.admin
Information on session expirations and ephemerals.
Commands.EnvCommand - Class in org.apache.zookeeper.server.admin
All defined environment variables.
Commands.GetTraceMaskCommand - Class in org.apache.zookeeper.server.admin
The current trace mask.
Commands.InitialConfigurationCommand - Class in org.apache.zookeeper.server.admin
 
Commands.IsroCommand - Class in org.apache.zookeeper.server.admin
Is this server in read-only mode.
Commands.LastSnapshotCommand - Class in org.apache.zookeeper.server.admin
Command returns information of the last snapshot that zookeeper server has finished saving to disk.
Commands.LeaderCommand - Class in org.apache.zookeeper.server.admin
Returns the leader status of this instance and the leader host string.
Commands.MonitorCommand - Class in org.apache.zookeeper.server.admin
Some useful info for monitoring.
Commands.ObserverCnxnStatResetCommand - Class in org.apache.zookeeper.server.admin
Reset all observer connection statistics.
Commands.RuokCommand - Class in org.apache.zookeeper.server.admin
No-op command, check if the server is running
Commands.SetTraceMaskCommand - Class in org.apache.zookeeper.server.admin
Sets the trace mask.
Commands.SrvrCommand - Class in org.apache.zookeeper.server.admin
Server information.
Commands.StatCommand - Class in org.apache.zookeeper.server.admin
Same as SrvrCommand but has extra "connections" entry.
Commands.StatResetCommand - Class in org.apache.zookeeper.server.admin
Resets server statistics.
Commands.SyncedObserverConsCommand - Class in org.apache.zookeeper.server.admin
Information on observer connections to server.
Commands.SystemPropertiesCommand - Class in org.apache.zookeeper.server.admin
All defined system properties.
Commands.VotingViewCommand - Class in org.apache.zookeeper.server.admin
Returns the current ensemble configuration information.
Commands.WatchCommand - Class in org.apache.zookeeper.server.admin
Watch information aggregated by session.
Commands.WatchesByPathCommand - Class in org.apache.zookeeper.server.admin
Watch information aggregated by path.
Commands.WatchSummaryCommand - Class in org.apache.zookeeper.server.admin
Summarized watch information.
Commands.ZabStateCommand - Class in org.apache.zookeeper.server.admin
Returns the current phase of Zab protocol that peer is running.
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
commit the transaction and make sure they are persisted
commit(Request) - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
 
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() - Method in class org.apache.zookeeper.server.ZKDatabase
commit to the underlying transaction log
commit() - Method in class org.apache.zookeeper.Transaction
 
commit(AsyncCallback.MultiCallback, Object) - Method in class org.apache.zookeeper.Transaction
 
COMMIT_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
COMMIT_LOG_COUNT - Static variable in class org.apache.zookeeper.server.ZKDatabase
 
COMMIT_PROCESS_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
COMMIT_PROPAGATION_LATENCY - Variable in class org.apache.zookeeper.server.ServerMetrics
 
commitAndActivate(long, long) - Method in class org.apache.zookeeper.server.quorum.Leader
 
commitLogCount - 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
 
commitProcessor - Variable in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
 
commitProcQueueStartTime - Variable in class org.apache.zookeeper.server.Request
 
commitRecvTime - Variable in class org.apache.zookeeper.server.Request
 
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.
COMMITS_QUEUED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
COMMITS_QUEUED_IN_COMMIT_PROCESSOR - Variable in class org.apache.zookeeper.server.ServerMetrics
 
commitSession(long, int) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
Synchronized on this to avoid race condition of adding a local session after committed global session, which may cause the same session being tracked on this server and leader.
commitSession(long, int) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
Synchronized on this to avoid race condition of adding a local session after committed global session, which may cause the same session being tracked on this server and leader.
commitSession(long, int) - Method in interface org.apache.zookeeper.server.SessionTracker
Add the session to the local session map or global one in zkDB.
commitSession(long, int) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
committedLog - Variable in class org.apache.zookeeper.server.ZKDatabase
 
committedRequests - Variable in class org.apache.zookeeper.server.quorum.CommitProcessor
Requests that have been committed.
compareDigest(TxnHeader, Record, TxnDigest) - Method in class org.apache.zookeeper.server.DataTree
Compares the digest of the tree with the digest present in transaction digest.
compareDigest(TxnHeader, Record, TxnDigest) - Method in class org.apache.zookeeper.server.ZKDatabase
 
compareSnapshotDigests(long) - Method in class org.apache.zookeeper.server.DataTree
Compares the actual tree's digest with that in the snapshot.
CONCURRENT_REQUEST_PROCESSING_IN_COMMIT_PROCESSOR - Variable in class org.apache.zookeeper.server.ServerMetrics
 
confCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
ConfCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.ConfCommand
 
ConfCommand - Class in org.apache.zookeeper.server.command
 
config - Variable in class org.apache.zookeeper.server.controller.ControllerService
 
CONFIG_DEFAULT_KERBEROS_CANONICALIZE_HOST_NAMES - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
CONFIG_DEFAULT_MULTI_ADDRESS_ENABLED - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
CONFIG_KEY_KERBEROS_CANONICALIZE_HOST_NAMES - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
CONFIG_KEY_MULTI_ADDRESS_ENABLED - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
CONFIG_KEY_MULTI_ADDRESS_REACHABILITY_CHECK_ENABLED - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
CONFIG_KEY_MULTI_ADDRESS_REACHABILITY_CHECK_TIMEOUT_MS - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
CONFIG_NODE - Static variable in class org.apache.zookeeper.ZooDefs
 
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
 
configFileStr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
configFromString(String) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
configuration(Properties) - Method in class org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded.ZookKeeperServerEmbeddedBuilder
Set the contents of the main configuration as it would be in zk_server.conf file.
configure(Properties) - Method in class org.apache.zookeeper.metrics.impl.DefaultMetricsProvider
 
configure(Properties) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider
 
configure(Properties) - Method in interface org.apache.zookeeper.metrics.MetricsProvider
Configure the provider.
configure(InetSocketAddress, int, int, boolean) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
configure(InetSocketAddress, int, int, boolean) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
 
configure(InetSocketAddress, int) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
configure(InetSocketAddress, int, int) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
configure(InetSocketAddress, int, int, boolean) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
configureSaslLogin() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
Initialize the server SASL if specified.
configureSSLAuth() - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
Configure SSL authentication only if it is not configured.
ConfigUtils - Class in org.apache.zookeeper.server.util
 
ConfigUtils() - Constructor for class org.apache.zookeeper.server.util.ConfigUtils
 
connect(SocketAddress) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
connect(SocketAddress, int) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
connectAll() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
Try to establish a connection with each server if one doesn't exist.
connectedToPeer(long) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
 
connectingFollowers - Variable in class org.apache.zookeeper.server.quorum.Leader
 
CONNECTION_DROP_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
CONNECTION_REJECTED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
CONNECTION_REQUEST_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
CONNECTION_REVALIDATE_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
CONNECTION_THROTTLE_DECREASE_RATIO - Static variable in class org.apache.zookeeper.server.BlueThrottle
 
CONNECTION_THROTTLE_DROP_DECREASE - Static variable in class org.apache.zookeeper.server.BlueThrottle
 
CONNECTION_THROTTLE_DROP_INCREASE - Static variable in class org.apache.zookeeper.server.BlueThrottle
 
CONNECTION_THROTTLE_FILL_COUNT - Static variable in class org.apache.zookeeper.server.BlueThrottle
 
CONNECTION_THROTTLE_FILL_TIME - Static variable in class org.apache.zookeeper.server.BlueThrottle
 
CONNECTION_THROTTLE_FREEZE_TIME - Static variable in class org.apache.zookeeper.server.BlueThrottle
 
CONNECTION_THROTTLE_TOKENS - Static variable in class org.apache.zookeeper.server.BlueThrottle
 
CONNECTION_TOKEN_DEFICIT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
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
ConnectionLossException() - Constructor for exception org.apache.zookeeper.KeeperException.ConnectionLossException
 
ConnectionMXBean - Interface in org.apache.zookeeper.server
This MBean represents a client connection.
ConnectStringParser - Class in org.apache.zookeeper.client
A parser for ZooKeeper Client connect strings.
ConnectStringParser(String) - Constructor for class org.apache.zookeeper.client.ConnectStringParser
Parse host and port by spliting client connectString with support for IPv6 literals
connectToLeader(MultipleAddresses, String) - Method in class org.apache.zookeeper.server.quorum.Learner
Establish a connection with the LearnerMaster found by findLearnerMaster.
connectToLearnerMasterLimit - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
The number of ticks that can pass before retrying to connect to learner master
connectToLearnerMasterLimit - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
connectToZK(String) - Method in class org.apache.zookeeper.ZooKeeperMain
 
connThrottle() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
consCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
ConsCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.ConsCommand
 
ConsCommand - Class in org.apache.zookeeper.server.command
 
ConsCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.ConsCommand
 
CONTAINER_EPHEMERAL_OWNER - Static variable in enum org.apache.zookeeper.server.EphemeralType
 
CONTAINER_EPHEMERAL_OWNER - Static variable in enum org.apache.zookeeper.server.EphemeralTypeEmulate353
 
ContainerManager - Class in org.apache.zookeeper.server
Manages cleanup of container ZNodes.
ContainerManager(ZKDatabase, RequestProcessor, int, int) - Constructor for class org.apache.zookeeper.server.ContainerManager
 
ContainerManager(ZKDatabase, RequestProcessor, int, int, long) - Constructor for class org.apache.zookeeper.server.ContainerManager
 
contains(Integer) - Method in class org.apache.zookeeper.server.util.BitHashSet
 
contains(Watcher) - Method in class org.apache.zookeeper.server.watch.WatcherOrBitSet
 
contains(int) - Method in class org.apache.zookeeper.server.watch.WatcherOrBitSet
 
contains(Object) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
containsAll(Collection<?>) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
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 class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
 
containsQuorum(Set<Long>) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
containsWatcher(String, Watcher.WatcherType, Watcher) - Method in class org.apache.zookeeper.server.DataTree
 
containsWatcher(String, Watcher) - Method in interface org.apache.zookeeper.server.watch.IWatchManager
Checks the specified watcher exists for the given path.
containsWatcher(String, Watcher) - Method in class org.apache.zookeeper.server.watch.WatchManager
 
containsWatcher(String, Watcher) - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
Used in the OpCode.checkWatches, which is a read operation, since read and write requests are exclusively processed, we don't need to hold lock here.
containsWatcher(String, Watcher.WatcherType, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
Check whether the given watcher exists in datatree
ControlCommand - Class in org.apache.zookeeper.server.controller
Set of commands that this controller can execute.
ControlCommand(ControlCommand.Action) - Constructor for class org.apache.zookeeper.server.controller.ControlCommand
 
ControlCommand(ControlCommand.Action, String) - Constructor for class org.apache.zookeeper.server.controller.ControlCommand
 
ControlCommand.Action - Enum in org.apache.zookeeper.server.controller
Actions available to the controller
ControllableConnection - Class in org.apache.zookeeper.server.controller
Extension of NIOServerCnxn which can inject changes per controller commands.
ControllableConnection(ZooKeeperServer, SocketChannel, SelectionKey, NIOServerCnxnFactory, NIOServerCnxnFactory.SelectorThread) - Constructor for class org.apache.zookeeper.server.controller.ControllableConnection
 
ControllableConnectionFactory - Class in org.apache.zookeeper.server.controller
Extension of NIOServerCnxnFactory which can inject changes per controller commands.
ControllableConnectionFactory() - Constructor for class org.apache.zookeeper.server.controller.ControllableConnectionFactory
 
CONTROLLER_PORT_KEY - Static variable in class org.apache.zookeeper.server.controller.ControllerServerConfig
 
ControllerServerConfig - Class in org.apache.zookeeper.server.controller
Config for the ControllerService.
ControllerServerConfig(String) - Constructor for class org.apache.zookeeper.server.controller.ControllerServerConfig
Instantiate a new config via a zk config file.
ControllerServerConfig(InetAddress, int, int, String) - Constructor for class org.apache.zookeeper.server.controller.ControllerServerConfig
Instantiate a config object with required parameters.
ControllerServerConfig(int, int, String) - Constructor for class org.apache.zookeeper.server.controller.ControllerServerConfig
Instantiate a config object with required parameters.
ControllerService - Class in org.apache.zookeeper.server.controller
Main class which starts a ZooKeeperServer, a ZooKeeperServerController and the ControllerService.
ControllerService() - Constructor for class org.apache.zookeeper.server.controller.ControllerService
 
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, boolean) - Static method in class org.apache.zookeeper.common.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream, int) - 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, Stat) - Static method in class org.apache.zookeeper.server.DataTree
 
copyStatPersisted(StatPersisted, StatPersisted) - Static method in class org.apache.zookeeper.server.DataTree
 
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
 
Counter - Interface in org.apache.zookeeper.metrics
A counter refers to a value which can only increase.
CounterSet - Interface in org.apache.zookeeper.metrics
A counter refers to a value which can only increase.
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.
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(int, String) - Static method in exception org.apache.zookeeper.KeeperException
Deprecated.
deprecated in 3.1.0, use KeeperException.create(Code, String) instead
create(int) - Static method in exception org.apache.zookeeper.KeeperException
Deprecated.
deprecated in 3.1.0, use KeeperException.create(Code) instead
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(String, byte[], List<ACL>, int) - Static method in class org.apache.zookeeper.Op
Constructs a create operation.
create(String, byte[], List<ACL>, int, long) - 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, long) - Static method in class org.apache.zookeeper.Op
Constructs a create operation.
create(String) - Method in class org.apache.zookeeper.server.util.VerifyingFileFactory
 
create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.zookeeper.Transaction
 
create - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
CREATE - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
 
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, Stat) - Method in class org.apache.zookeeper.ZooKeeper
Create a node with the given path and returns the Stat of that node.
create(String, byte[], List<ACL>, CreateMode, Stat, long) - Method in class org.apache.zookeeper.ZooKeeper
create(String, byte[], List<ACL>, CreateMode, AsyncCallback.StringCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of create.
create(String, byte[], List<ACL>, CreateMode, AsyncCallback.Create2Callback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of create.
create(String, byte[], List<ACL>, CreateMode, AsyncCallback.Create2Callback, Object, long) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of create with ttl.
create2 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
createAdminServer() - Static method in class org.apache.zookeeper.server.admin.AdminServerFactory
This method encapsulates the logic for whether we should use a JettyAdminServer (i.e., the AdminServer is enabled) or a DummyAdminServer (i.e., the AdminServer is disabled).
createCnxnManager() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
CreateCommand - Class in org.apache.zookeeper.cli
create command for cli
CreateCommand() - Constructor for class org.apache.zookeeper.cli.CreateCommand
 
createCommandUri(ControlCommand.Action, String) - Static method in class org.apache.zookeeper.server.controller.ControlCommand
Create a REST command uri.
createConnection(SocketChannel, SelectionKey, NIOServerCnxnFactory.SelectorThread) - Method in class org.apache.zookeeper.server.controller.ControllableConnectionFactory
 
createConnection(SocketChannel, SelectionKey, NIOServerCnxnFactory.SelectorThread) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
 
createContainer - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
createDataTree() - Method in class org.apache.zookeeper.server.ZKDatabase
 
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(int, int, int) - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
 
createFactory(InetSocketAddress, int) - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
 
createFactory(InetSocketAddress, int, int) - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
 
createFromConfig(QuorumPeerConfig) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeer
Create a new QuorumPeer and apply all the values per the already-parsed config.
createInputArchive(File) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
Invoked to indicate that the input stream has been created.
createKeyManager(String, String, String) - Static method in class org.apache.zookeeper.common.X509Util
Creates a key manager by loading the key store from the given file of the given type, optionally decrypting it using the given password.
createLocalSessionTracker(SessionTracker.SessionExpirer, int, long, ZooKeeperServerListener) - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
CreateMode - Enum in org.apache.zookeeper
CreateMode value determines how the znode is created on ZooKeeper.
createNettyJdkSslContext(SSLContext, boolean) - Method in class org.apache.zookeeper.common.SSLContextAndOptions
 
createNode(String, byte[], List<ACL>, long, int, long, long) - Method in class org.apache.zookeeper.server.DataTree
Add a new node to the DataTree.
createNode(String, byte[], List<ACL>, long, int, long, long, Stat) - Method in class org.apache.zookeeper.server.DataTree
Add a new node to the DataTree.
createPacket(QuorumAuth.Status, byte[]) - Static method in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
 
createQuota(ZooKeeper, String, StatsTrack) - Static method in class org.apache.zookeeper.cli.SetQuotaCommand
this method creates a quota node for the path
createRequestThrottler() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
CreateResult(String) - Constructor for class org.apache.zookeeper.OpResult.CreateResult
 
CreateResult(String, Stat) - 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(int) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
createSession(int) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
 
createSession(int) - Method in class org.apache.zookeeper.server.quorum.LocalSessionTracker
 
createSession(int) - Method in interface org.apache.zookeeper.server.SessionTracker
 
createSession(int) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
createSession - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
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.quorum.ReadOnlyZooKeeperServer
 
createSessionTracker() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
createSocket() - Method in class org.apache.zookeeper.server.quorum.Learner
Creating a simple or and SSL socket.
createSSLContext(ZKConfig) - Method in class org.apache.zookeeper.common.X509Util
 
createSSLContextAndOptions(ZKConfig) - Method in class org.apache.zookeeper.common.X509Util
 
createSSLContextAndOptionsFromConfig(ZKConfig) - Method in class org.apache.zookeeper.common.X509Util
 
createSSLServerSocket() - Method in class org.apache.zookeeper.common.SSLContextAndOptions
 
createSSLServerSocket(int) - Method in class org.apache.zookeeper.common.SSLContextAndOptions
 
createSSLServerSocket() - Method in class org.apache.zookeeper.common.X509Util
 
createSSLServerSocket(int) - Method in class org.apache.zookeeper.common.X509Util
 
createSSLSocket() - Method in class org.apache.zookeeper.common.SSLContextAndOptions
 
createSSLSocket(Socket, byte[]) - Method in class org.apache.zookeeper.common.SSLContextAndOptions
 
createSSLSocket() - Method in class org.apache.zookeeper.common.X509Util
 
createSSLSocket(Socket, byte[]) - Method in class org.apache.zookeeper.common.X509Util
 
createStat(long, long, long) - Static method in class org.apache.zookeeper.server.DataTree
Create a node stat from the given params.
createTime - Variable in class org.apache.zookeeper.server.Request
 
createTrustManager(String, String, String, boolean, boolean, boolean, boolean) - Static method in class org.apache.zookeeper.common.X509Util
Creates a trust manager by loading the trust store from the given file of the given type, optionally decrypting it using the given password.
createTTL - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
createWatchManager() - Static method in class org.apache.zookeeper.server.watch.WatchManagerFactory
 
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.command.FourLetterCommands
 
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
 

D

data - Variable in class org.apache.zookeeper.Op.Create
 
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(File, File, 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
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(byte[], Long, StatPersisted) - Constructor for class org.apache.zookeeper.server.DataNode
create a DataNode with parent, data, acls and stat
DataTree - Class in org.apache.zookeeper.server
This class maintains the tree data structure.
DataTree() - Constructor for class org.apache.zookeeper.server.DataTree
 
dataTree - Variable in class org.apache.zookeeper.server.ZKDatabase
make sure on a clear you take care of all these members.
DataTree.ProcessTxnResult - Class in org.apache.zookeeper.server
 
DataTree.ZxidDigest - Class in org.apache.zookeeper.server
A helper class to maintain the digest meta associated with specific zxid.
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.
DB_INIT_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
Db init time (snapshot loading + txnlog replay)
DEAD_WATCHERS_CLEANER_LATENCY - Variable in class org.apache.zookeeper.server.ServerMetrics
 
DEAD_WATCHERS_CLEARED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
DEAD_WATCHERS_QUEUED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
decInProcess() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
decrOutstandingAndCheckThrottle(ReplyHeader) - Method in class org.apache.zookeeper.server.ServerCnxn
 
DEFAULT_COMMAND_URL - Static variable in class org.apache.zookeeper.server.admin.JettyAdminServer
 
DEFAULT_COMMIT_LOG_COUNT - Static variable in class org.apache.zookeeper.server.ZKDatabase
 
DEFAULT_EXCEPTION_EXIT_CODE - Static variable in exception org.apache.zookeeper.cli.CliException
 
DEFAULT_HANDSHAKE_DETECTION_TIMEOUT_MILLIS - Static variable in class org.apache.zookeeper.common.X509Util
 
DEFAULT_HTTP_VERSION - Static variable in class org.apache.zookeeper.server.admin.JettyAdminServer
 
DEFAULT_IDLE_TIMEOUT - Static variable in class org.apache.zookeeper.server.admin.JettyAdminServer
 
DEFAULT_LOGIN_CONTEXT_NAME - Static variable in class org.apache.zookeeper.server.ZooKeeperSaslServer
 
DEFAULT_METRICS_FOR_TESTS - Static variable in class org.apache.zookeeper.server.ServerMetrics
Dummy instance useful for tests.
DEFAULT_MODE - Static variable in enum org.apache.zookeeper.server.persistence.SnapStream.StreamMode
 
DEFAULT_PORT - Static variable in class org.apache.zookeeper.server.admin.JettyAdminServer
 
DEFAULT_PROTOCOL - Static variable in class org.apache.zookeeper.common.X509Util
 
DEFAULT_RESPONSE_CACHE_SIZE - Static variable in class org.apache.zookeeper.server.ResponseCache
 
DEFAULT_SNAPSHOT_SIZE_FACTOR - Static variable in class org.apache.zookeeper.server.ZKDatabase
 
DEFAULT_STARTING_BUFFER_SIZE - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
DEFAULT_STS_MAX_AGE - Static variable in class org.apache.zookeeper.server.admin.JettyAdminServer
 
DEFAULT_THROTTLED_OP_WAIT_TIME - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
DEFAULT_TICK_TIME - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
DEFAULT_TIMEOUT - Static variable in class org.apache.zookeeper.server.quorum.MultipleAddresses
 
DEFAULT_WATCHER_MODE - Static variable in enum org.apache.zookeeper.server.watch.WatcherMode
 
DefaultMetricsProvider - Class in org.apache.zookeeper.metrics.impl
Default implementation of MetricsProvider.
It does not implement a real hierarchy of contexts, but metrics are flattened in a single namespace.
It is mostly useful to make the legacy 4 letter words interface work as expected.
DefaultMetricsProvider() - Constructor for class org.apache.zookeeper.metrics.impl.DefaultMetricsProvider
 
delayRequestIfNeeded() - Method in class org.apache.zookeeper.server.controller.ControllableConnectionFactory
Called by the connection to delay processing requests from the client.
delayResponses(long) - Method in class org.apache.zookeeper.server.controller.ControllableConnectionFactory
 
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 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
DELETE - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
 
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.
DeleteAllCommand - Class in org.apache.zookeeper.cli
deleteAll command for cli
DeleteAllCommand() - Constructor for class org.apache.zookeeper.cli.DeleteAllCommand
 
DeleteAllCommand(String) - Constructor for class org.apache.zookeeper.cli.DeleteAllCommand
 
DeleteCommand - Class in org.apache.zookeeper.cli
delete command for cli
DeleteCommand() - Constructor for class org.apache.zookeeper.cli.DeleteCommand
 
deleteContainer - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
deleteFile(String) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
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, int) - Static method in class org.apache.zookeeper.ZKUtil
Recursively delete the node with the given path.
deleteRecursive(ZooKeeper, String) - Static method in class org.apache.zookeeper.ZKUtil
Same as ZKUtil.deleteRecursive(org.apache.zookeeper.ZooKeeper, java.lang.String, int) kept here for compatibility with 3.5 clients.
deleteRecursive(ZooKeeper, String, AsyncCallback.VoidCallback, Object) - Static method in class org.apache.zookeeper.ZKUtil
Recursively delete the node with the given path.
DeleteResult() - Constructor for class org.apache.zookeeper.OpResult.DeleteResult
 
delimitedHostString(InetSocketAddress) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
delQuota(ZooKeeper, String, StatsTrack) - Static method in class org.apache.zookeeper.cli.DelQuotaCommand
this method deletes quota for a node.
DelQuotaCommand - Class in org.apache.zookeeper.cli
delQuota command for cli
DelQuotaCommand() - Constructor for class org.apache.zookeeper.cli.DelQuotaCommand
 
deserialize(InputArchive, String) - Method in class org.apache.zookeeper.MultiOperationRecord
 
deserialize(InputArchive, String) - Method in class org.apache.zookeeper.MultiResponse
 
deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.DataNode
 
deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.DataTree
 
deserialize(InputArchive) - Method in class org.apache.zookeeper.server.DataTree.ZxidDigest
 
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>, InputArchive) - Method in class org.apache.zookeeper.server.persistence.FileSnap
deserialize the datatree from an inputarchive
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(InputArchive) - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
 
deserializeSnapshot(DataTree, InputArchive, Map<Long, Integer>) - Static method in class org.apache.zookeeper.server.util.SerializeUtils
 
deserializeSnapshot(InputArchive) - Method in class org.apache.zookeeper.server.ZKDatabase
deserialize a snapshot from an input archive
deserializeTxn(byte[]) - Static method in class org.apache.zookeeper.server.util.SerializeUtils
 
deserializeZxidDigest(InputArchive, long) - Method in class org.apache.zookeeper.server.DataTree
Deserializing the zxid digest from the input stream and update the digestFromLoadedSnapshot.
DIFF_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
digest(String) - Static method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
DIGEST_ALGORITHM_KEY - Static variable in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
DIGEST_LOG_INTERVAL - Static variable in class org.apache.zookeeper.server.DataTree
 
DIGEST_LOG_LIMIT - Static variable in class org.apache.zookeeper.server.DataTree
 
DIGEST_MISMATCHES_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
DigestAuthenticationProvider - Class in org.apache.zookeeper.server.auth
 
DigestAuthenticationProvider() - Constructor for class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
DigestCalculator - Class in org.apache.zookeeper.server
Defines how to calculate the digest for a given node.
DigestCalculator() - Constructor for class org.apache.zookeeper.server.DigestCalculator
 
DigestCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.DigestCommand
 
DigestCommand - Class in org.apache.zookeeper.server.command
Command used to dump the latest digest histories.
DigestCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.DigestCommand
 
DigestLoginModule - Class in org.apache.zookeeper.server.auth
 
DigestLoginModule() - Constructor for class org.apache.zookeeper.server.auth.DigestLoginModule
 
DigestWatcher - Interface in org.apache.zookeeper
This interface is used to notify the digest mismatch event.
dirsCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
DirsCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.DirsCommand
 
DirsCommand - Class in org.apache.zookeeper.server.command
 
DirsCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.DirsCommand
 
DISABLE_AUTO_WATCH_RESET - Static variable in class org.apache.zookeeper.client.ZKClientConfig
This controls whether automatic watch resetting is enabled.
disableDigest() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
 
disableDigest() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
 
disableRecv(boolean) - Method in class org.apache.zookeeper.server.NettyServerCnxn
Note that the netty implementation ignores the waitDisableRecv parameter and is always asynchronous.
disableRecv(boolean) - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
disableSelectable() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
disconnect() - Method in class org.apache.zookeeper.ClientCnxn
Shutdown the send/event threads.
disconnectReason - Variable in class org.apache.zookeeper.server.ServerCnxn
 
DOMAIN - Static variable in class org.apache.zookeeper.jmx.MBeanRegistry
 
doStart() - Method in class org.apache.zookeeper.server.admin.UnifiedConnectionFactory
 
doWork() - Method in class org.apache.zookeeper.server.WorkerService.WorkRequest
Must be implemented.
drainTo(Collection<? super E>) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
drainTo(Collection<? super E>, int) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
DumbWatcher - Class in org.apache.zookeeper.server
A empty watcher implementation used in bench and unit test.
DumbWatcher() - Constructor for class org.apache.zookeeper.server.DumbWatcher
 
DumbWatcher(long) - Constructor for class org.apache.zookeeper.server.DumbWatcher
 
DummyAdminServer - Class in org.apache.zookeeper.server.admin
An AdminServer that does nothing.
DummyAdminServer() - Constructor for class org.apache.zookeeper.server.admin.DummyAdminServer
 
dump(BiConsumer<String, Object>) - Method in class org.apache.zookeeper.metrics.impl.DefaultMetricsProvider
 
dump(BiConsumer<String, Object>) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider
 
dump(BiConsumer<String, Object>) - Method in interface org.apache.zookeeper.metrics.MetricsProvider
Dumps all metrics as a key-value pair.
dump(PrintWriter) - Method in class org.apache.zookeeper.server.ExpiryQueue
 
dump(Scanner) - Method in class org.apache.zookeeper.server.persistence.TxnLogToolkit
 
dump(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
 
dumpCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
DumpCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.DumpCommand
 
DumpCommand - Class in org.apache.zookeeper.server.command
 
DumpCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.DumpCommand
 
dumpConf(PrintWriter) - Method in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
 
dumpConf(PrintWriter) - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
 
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.
dumpConnections(PrintWriter) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
 
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
 
dumpMonitorValues(BiConsumer<String, Object>) - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
 
dumpMonitorValues(BiConsumer<String, Object>) - Method in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
 
dumpMonitorValues(BiConsumer<String, Object>) - Method in class org.apache.zookeeper.server.ZooKeeperServer
Hook into admin server, useful to expose additional data that do not represent metrics.
dumpSessions(PrintWriter) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
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
 
dumpToLog(String) - Method in class org.apache.zookeeper.server.util.MessageTracker
 
dumpTopPaths(PrintWriter, int) - Method in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
dumpTopReadPaths(PrintWriter, int) - Method in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
dumpTopRequestPath(PrintWriter, String, int) - Method in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
dumpTopWritePaths(PrintWriter, int) - Method in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
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 interface org.apache.zookeeper.server.watch.IWatchManager
String representation of watches.
dumpWatches(PrintWriter, boolean) - Method in class org.apache.zookeeper.server.watch.WatchManager
 
dumpWatches(PrintWriter, boolean) - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
 
dumpWatchesSummary(PrintWriter) - Method in class org.apache.zookeeper.server.DataTree
Summary of the watches on the datatree.
dynamicConfigFileStr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 

E

EARLY_DROP_SECURE_CONNECTION_HANDSHAKES - Static variable in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
editStaticConfig(String, String, boolean) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
Edit static config file.
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
 
ELECTION_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
electionAddr - Variable in class org.apache.zookeeper.server.quorum.QuorumCnxManager.InitialMessage
 
electionAddr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.AddressTuple
 
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.QuorumPeerConfig
 
element() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
EMPTY_ITERATOR - Static variable in class org.apache.zookeeper.server.TxnLogProposalIterator
 
ENABLE_CLIENT_SASL_DEFAULT - Static variable in class org.apache.zookeeper.client.ZKClientConfig
 
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.ZKClientConfig
 
ENABLE_CLIENT_SASL_KEY - Static variable in class org.apache.zookeeper.client.ZooKeeperSaslClient
Deprecated.
ENABLE_EAGER_ACL_CHECK - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
enableCertFileReloading() - Method in class org.apache.zookeeper.common.X509Util
Enables automatic reloading of the trust store and key store files when they change on disk.
enableLocalSessions(boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Whether to enable local sessions
enableLocalSessionsUpgrading(boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Whether to allow local sessions to upgrade to global sessions
enableRecv() - Method in class org.apache.zookeeper.server.NettyServerCnxn
 
enableRecv() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
enableSelectable() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
end_fle - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
endOfIteration() - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
 
EndOfStreamException(String, ServerCnxn.DisconnectReason) - Constructor for exception org.apache.zookeeper.server.ServerCnxn.EndOfStreamException
 
ENDPOINT - Static variable in class org.apache.zookeeper.server.controller.ControlCommand
 
ENDPOINT_PREFIX - Static variable in class org.apache.zookeeper.server.controller.ControlCommand
 
endSync() - Method in class org.apache.zookeeper.server.quorum.LearnerSyncThrottler
Indicates that a sync has been completed.
ENFORCE_AUTH_ENABLED - Static variable in class org.apache.zookeeper.server.AuthenticationHelper
 
ENFORCE_AUTH_SCHEMES - Static variable in class org.apache.zookeeper.server.AuthenticationHelper
 
ENFORCE_QUOTA - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
enforceAuthentication(ServerCnxn, int) - Method in class org.apache.zookeeper.server.AuthenticationHelper
Returns true when authentication enforcement was success otherwise returns false also closes the connection
enforceQuota - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
enqueueRequest(Request) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
ENSEMBLE_AUTH_FAIL - Variable in class org.apache.zookeeper.server.ServerMetrics
 
ENSEMBLE_AUTH_SKIP - Variable in class org.apache.zookeeper.server.ServerMetrics
 
ENSEMBLE_AUTH_SUCCESS - Variable in class org.apache.zookeeper.server.ServerMetrics
 
ENSEMBLE_PROPERTY - Static variable in class org.apache.zookeeper.server.auth.EnsembleAuthenticationProvider
 
EnsembleAuthenticationProvider - Class in org.apache.zookeeper.server.auth
This is not a true AuthenticationProvider in the strict sense.
EnsembleAuthenticationProvider() - Constructor for class org.apache.zookeeper.server.auth.EnsembleAuthenticationProvider
 
ensureComplete() - Method in class org.apache.zookeeper.server.controller.ControllerServerConfig
Ensure config is acceptable by filling in default values for any missing quorum configuration (specifically in the case of a single machine ensemble)
Entry(String, String) - Constructor for class org.apache.zookeeper.Environment.Entry
 
entrySet() - Method in interface org.apache.zookeeper.server.NodeHashMap
Return all the entries inside this map.
entrySet() - Method in class org.apache.zookeeper.server.NodeHashMapImpl
 
EnvCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.EnvCommand
 
EnvCommand - Class in org.apache.zookeeper.server.command
 
enviCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
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
 
EphemeralOnLocalSession - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
EphemeralOnLocalSessionException() - Constructor for exception org.apache.zookeeper.KeeperException.EphemeralOnLocalSessionException
 
EphemeralType - Enum in org.apache.zookeeper.server
Abstraction that interprets the ephemeralOwner field of a ZNode.
EphemeralTypeEmulate353 - Enum in org.apache.zookeeper.server
See https://issues.apache.org/jira/browse/ZOOKEEPER-2901 version 3.5.3 introduced bugs associated with how TTL nodes were implemented.
equals(Object) - Method in class org.apache.zookeeper.MultiOperationRecord
 
equals(Object) - Method in class org.apache.zookeeper.MultiResponse
 
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.CreateTTL
 
equals(Object) - Method in class org.apache.zookeeper.Op.Delete
 
equals(Object) - Method in class org.apache.zookeeper.Op.GetChildren
 
equals(Object) - Method in class org.apache.zookeeper.Op.GetData
 
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.GetChildrenResult
 
equals(Object) - Method in class org.apache.zookeeper.OpResult.GetDataResult
 
equals(Object) - Method in class org.apache.zookeeper.OpResult.SetDataResult
 
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.quorum.flexible.QuorumHierarchical
 
equals(Object) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
 
equals(Object) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
 
equals(Object) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
equals(Object) - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
 
equals(Object) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
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.util.AdHash
 
equals(Object) - Method in class org.apache.zookeeper.StatsTrack
 
err - Variable in class org.apache.zookeeper.cli.CliCommand
 
err - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
 
error - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
ERROR_RESPONSE - Static variable in class org.apache.zookeeper.server.admin.JsonOutputter
 
ErrorResult(int) - Constructor for class org.apache.zookeeper.OpResult.ErrorResult
 
established - Variable in class org.apache.zookeeper.server.quorum.LearnerHandler
 
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
 
exec() - Method in class org.apache.zookeeper.cli.AddAuthCommand
 
exec() - Method in class org.apache.zookeeper.cli.AddWatchCommand
 
exec() - Method in class org.apache.zookeeper.cli.CliCommand
 
exec() - Method in class org.apache.zookeeper.cli.CloseCommand
 
exec() - Method in class org.apache.zookeeper.cli.CreateCommand
 
exec() - Method in class org.apache.zookeeper.cli.DeleteAllCommand
 
exec() - Method in class org.apache.zookeeper.cli.DeleteCommand
 
exec() - Method in class org.apache.zookeeper.cli.DelQuotaCommand
 
exec() - Method in class org.apache.zookeeper.cli.GetAclCommand
 
exec() - Method in class org.apache.zookeeper.cli.GetAllChildrenNumberCommand
 
exec() - Method in class org.apache.zookeeper.cli.GetCommand
 
exec() - Method in class org.apache.zookeeper.cli.GetConfigCommand
 
exec() - Method in class org.apache.zookeeper.cli.GetEphemeralsCommand
 
exec() - Method in class org.apache.zookeeper.cli.ListQuotaCommand
 
exec() - Method in class org.apache.zookeeper.cli.LsCommand
 
exec() - Method in class org.apache.zookeeper.cli.ReconfigCommand
 
exec() - Method in class org.apache.zookeeper.cli.RemoveWatchesCommand
 
exec() - Method in class org.apache.zookeeper.cli.SetAclCommand
 
exec() - Method in class org.apache.zookeeper.cli.SetCommand
 
exec() - Method in class org.apache.zookeeper.cli.SetQuotaCommand
 
exec() - Method in class org.apache.zookeeper.cli.StatCommand
 
exec() - Method in class org.apache.zookeeper.cli.SyncCommand
 
exec() - Method in class org.apache.zookeeper.cli.VersionCommand
 
exec() - Method in class org.apache.zookeeper.cli.WhoAmICommand
 
execCommand(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.
execCommand(Map<String, String>, String...) - Static method in class org.apache.zookeeper.Shell
Static method to execute a shell command.
execute(ServerCnxn, PrintWriter, int, ZooKeeperServer, ServerCnxnFactory) - Method in class org.apache.zookeeper.server.command.CommandExecutor
This class decides which command to be executed and then executes
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, Watcher) - Method in class org.apache.zookeeper.ZooKeeper
Return the stat of the node of the given path.
exists(String, boolean) - 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.
exists(String, boolean, AsyncCallback.StatCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of exists.
existsNode(String) - Method in class org.apache.zookeeper.common.PathTrie
Return true if the given path exists in the trie, otherwise return false; All paths are relative to the root node.
exitCode - Variable in exception org.apache.zookeeper.cli.CliException
 
ExitCode - Enum in org.apache.zookeeper.server
Exit code used to exit server
exitCode - Variable in class org.apache.zookeeper.ZooKeeperMain
 
ExitCodeException(int, String) - Constructor for exception org.apache.zookeeper.Shell.ExitCodeException
 
ExitHandler - Enum in org.apache.zookeeper.server.embedded
Behaviour of the server in case of internal error.
exitHandler(ExitHandler) - Method in class org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded.ZookKeeperServerEmbeddedBuilder
Set the behaviour in case of hard system errors, see ExitHandler.
expire(SessionTracker.Session) - Method in interface org.apache.zookeeper.server.SessionTracker.SessionExpirer
 
expire(SessionTracker.Session) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
expire(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
ExpiryQueue<E> - Class in org.apache.zookeeper.server
ExpiryQueue tracks elements in time sorted fixed duration buckets.
ExpiryQueue(int) - Constructor for class org.apache.zookeeper.server.ExpiryQueue
 
extendedEphemeralTypesEnabled() - Static method in enum org.apache.zookeeper.server.EphemeralType
Return true if extended ephemeral types are enabled

F

factory - Variable in class org.apache.zookeeper.server.command.AbstractFourLetterCommand
 
failAllFutureRequests() - Method in class org.apache.zookeeper.server.controller.ControllableConnectionFactory
 
failForNonExistingPath() - Method in class org.apache.zookeeper.server.util.VerifyingFileFactory.Builder
 
failFutureRequests(long) - Method in class org.apache.zookeeper.server.controller.ControllableConnectionFactory
 
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.
FileChangeWatcher - Class in org.apache.zookeeper.common
Instances of this class can be used to watch a directory for file changes.
FileChangeWatcher(Path, Consumer<WatchEvent<?>>) - Constructor for class org.apache.zookeeper.common.FileChangeWatcher
Creates a watcher that watches dirPath and invokes callback on changes.
FileChangeWatcher.State - Enum in org.apache.zookeeper.common
 
FileKeyStoreLoaderBuilderProvider - Class in org.apache.zookeeper.common
 
FileKeyStoreLoaderBuilderProvider() - Constructor for class org.apache.zookeeper.common.FileKeyStoreLoaderBuilderProvider
 
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, boolean) - Constructor for class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
create an iterator over a transaction database directory
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
 
fill(ByteBuffer) - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
fillInterested(Callback) - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
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
findNValidSnapshots(int) - Method in class org.apache.zookeeper.server.persistence.FileSnap
find the last (maybe) valid n snapshots.
findNValidSnapshots(int) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
the n recent valid snapshots
finishedUpgrading(long) - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
finishPacket(ClientCnxn.Packet) - Method in class org.apache.zookeeper.ClientCnxn
 
finishSessionInit(ServerCnxn, boolean) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
firstProcessor - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
fixupACL(String, List<Id>, List<ACL>) - Static method in class org.apache.zookeeper.server.PrepRequestProcessor
This method checks out the acl making sure it isn't null or empty, it has valid schemes and ids, and expanding any relative ids that depend on the requestor's authentication information.
flags - Variable in class org.apache.zookeeper.Op.Create
 
FLE_TIME_UNIT - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
flush(ByteBuffer...) - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
flush() - Method in class org.apache.zookeeper.server.quorum.SendAckRequestProcessor
 
flush() - Method in class org.apache.zookeeper.server.RateLogger
 
Follower - Class in org.apache.zookeeper.server.quorum
This class has the control logic for the Follower.
follower - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
FOLLOWER_SYNC_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
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_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
 
forAll(String) - Static method in class org.apache.zookeeper.server.watch.PathParentIterator
Return a new PathParentIterator that iterates from the given path to all parents.
FORCE_SNAP_SYNC - Static variable in class org.apache.zookeeper.server.quorum.LearnerHandler
For testing purpose, force learnerMaster to use snapshot to sync with followers
formatInetAddr(InetSocketAddress) - Static method in class org.apache.zookeeper.common.NetUtils
 
forPathOnly(String) - Static method in class org.apache.zookeeper.server.watch.PathParentIterator
Return a new PathParentIterator that only returns the given path - i.e.
FORWARD_LEARNER_REQUESTS_TO_COMMIT_PROCESSOR_DISABLED - Static variable in class org.apache.zookeeper.server.quorum.ProposalRequestProcessor
 
FourLetterCommands - Class in org.apache.zookeeper.server.command
This class contains constants for all the four letter commands
FourLetterCommands() - Constructor for class org.apache.zookeeper.server.command.FourLetterCommands
 
FourLetterWordMain - Class in org.apache.zookeeper.client
 
FourLetterWordMain() - Constructor for class org.apache.zookeeper.client.FourLetterWordMain
 
fromFilename(String) - Static method in enum org.apache.zookeeper.common.KeyStoreFileType
Detects the type of KeyStore / TrustStore file from the file extension.
fromFlag(int) - Static method in enum org.apache.zookeeper.CreateMode
Map an integer value to a CreateMode value
fromFlag(int, CreateMode) - 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
 
fromInt(int) - Static method in enum org.apache.zookeeper.Watcher.WatcherType
 
fromPropertyValue(String) - Static method in enum org.apache.zookeeper.common.KeyStoreFileType
Converts a property value to a StoreFileType enum.
fromPropertyValue(String) - Static method in enum org.apache.zookeeper.common.X509Util.ClientAuth
Converts a property value to a ClientAuth enum.
fromPropertyValueOrFileName(String, String) - Static method in enum org.apache.zookeeper.common.KeyStoreFileType
If propertyValue is not null or empty, returns the result of KeyStoreFileType.fromPropertyValue(propertyValue).
fromString(String) - Static method in enum org.apache.zookeeper.server.persistence.SnapStream.StreamMode
 
fromZooDef(int) - Static method in enum org.apache.zookeeper.server.watch.WatcherMode
 
FSYNC_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
Txnlog fsync time

G

Gauge - Interface in org.apache.zookeeper.metrics
A Gauge is an application provided object which will be called by the framework in order to sample the value of an integer value.
GaugeSet - Interface in org.apache.zookeeper.metrics
A Gauge is an application provided object which will be called by the metrics framework to sample a numeric value.
generateDigest(String) - Static method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
get(int) - Static method in enum org.apache.zookeeper.KeeperException.Code
Get the Code value for a particular integer error code
get() - Method in interface org.apache.zookeeper.metrics.Counter
Get the current value held by the counter.
get() - Method in interface org.apache.zookeeper.metrics.Gauge
Returns the current value associated with this gauge.
get(long) - Static method in enum org.apache.zookeeper.server.EphemeralType
Convert a ZNode ephemeral owner to an ephemeral type.
get(long) - Static method in enum org.apache.zookeeper.server.EphemeralTypeEmulate353
 
get() - Method in class org.apache.zookeeper.server.metric.SimpleCounter
 
get(String) - Method in interface org.apache.zookeeper.server.NodeHashMap
Return the data node associated with the path.
get(String) - Method in class org.apache.zookeeper.server.NodeHashMapImpl
 
get(String, Stat) - Method in class org.apache.zookeeper.server.ResponseCache
 
get(int) - Method in class org.apache.zookeeper.server.util.BitMap
 
GET_CHILDREN_RESPONSE_CACHE_SIZE - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
GET_DATA_RESPONSE_CACHE_SIZE - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
getAcceptedEpoch() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getAcceptedIssuers() - Method in class org.apache.zookeeper.common.ZKTrustManager
 
getAckLoggingFrequency() - Static method in class org.apache.zookeeper.server.quorum.Leader
 
getAckset() - Method in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker.QuorumVerifierAcksetPair
 
getACL(String, Stat) - Method in class org.apache.zookeeper.server.DataTree
 
getACL(DataNode) - Method in class org.apache.zookeeper.server.DataTree
 
getACL(String, Stat) - Method in class org.apache.zookeeper.server.ZKDatabase
get acl for a path
getACL - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
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.
GetAclCommand - Class in org.apache.zookeeper.cli
getAcl command for cli
GetAclCommand() - Constructor for class org.apache.zookeeper.cli.GetAclCommand
 
getAclExpr() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.MatchValues
 
getAclSize() - Method in class org.apache.zookeeper.server.ZKDatabase
get the acl size of the datatree
getAction() - Method in class org.apache.zookeeper.server.controller.ControlCommand
 
getActiveObservers() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
getActiveServer() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getAllAddresses() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
Returns all addresses in an unmodifiable set.
getAllByName(String) - Method in interface org.apache.zookeeper.client.StaticHostProvider.Resolver
 
getAllChildrenNumber(String) - Method in class org.apache.zookeeper.server.DataTree
 
getAllChildrenNumber(String) - Method in class org.apache.zookeeper.server.ZKDatabase
 
getAllChildrenNumber - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
getAllChildrenNumber(String) - Method in class org.apache.zookeeper.ZooKeeper
Synchronously gets all numbers of children nodes under a specific path
getAllChildrenNumber(String, AsyncCallback.AllChildrenNumberCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
Asynchronously gets all numbers of children nodes under a specific path
GetAllChildrenNumberCommand - Class in org.apache.zookeeper.cli
getAllChildrenNumber command for CLI
GetAllChildrenNumberCommand() - Constructor for class org.apache.zookeeper.cli.GetAllChildrenNumberCommand
 
getAllConnectionInfo(boolean) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
getAllConnectionInfo(boolean) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
 
getAllConnectionInfo(boolean) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
getAllHostStrings() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
Returns distinct list of all host strings
getAllMembers() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
 
getAllMembers() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
 
getAllMembers() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
getAllPorts() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
Returns all ports
getAllReachableAddresses() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
Returns a set of all reachable addresses.
getAllReachableAddressesOrAll() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
Returns a set of all reachable addresses.
getAndDecrementFollowerCounter() - Method in class org.apache.zookeeper.server.quorum.Leader
 
getAndDecrementFollowerCounter() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
getAsyncSending() - Static method in class org.apache.zookeeper.server.quorum.Learner
 
getAuthFailedCount() - Method in class org.apache.zookeeper.server.ServerStats
 
getAuthFailedCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getAuthFailedCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
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
 
getAvg() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
 
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
 
getBit(T) - Method in class org.apache.zookeeper.server.util.BitMap
 
getBoolean(String) - Method in class org.apache.zookeeper.common.ZKConfig
Returns true if and only if the property named by the argument exists and is equal to the string "true".
getBoolean(String, boolean) - Method in class org.apache.zookeeper.common.ZKConfig
Get the value of the key property as a boolean.
getBuildDate() - Static method in class org.apache.zookeeper.Version
 
getByteHardLimit() - Method in class org.apache.zookeeper.StatsTrack
get the count of bytes allowed as part of quota (hard limit)
getBytes() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
getBytes() - Method in class org.apache.zookeeper.StatsTrack
get the count of bytes allowed as part of quota
getCacheSize() - Method in class org.apache.zookeeper.server.ResponseCache
 
getCandidates() - Method in class org.apache.zookeeper.server.ContainerManager
 
getChannel() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getChildren(String) - Static method in class org.apache.zookeeper.Op
 
getChildren() - Method in class org.apache.zookeeper.OpResult.GetChildrenResult
 
getChildren() - Method in class org.apache.zookeeper.server.DataNode
convenience methods to get the children
getChildren(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.DataTree
 
getChildren(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
get children list for this path
getChildren - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
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, boolean) - Method in class org.apache.zookeeper.ZooKeeper
Return the list of the children of the node of the given path.
getChildren(String, Watcher, AsyncCallback.ChildrenCallback, 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, Watcher, Stat) - Method in class org.apache.zookeeper.ZooKeeper
For the given znode path return the stat and children list.
getChildren(String, boolean, Stat) - Method in class org.apache.zookeeper.ZooKeeper
For the given znode path return the stat and children list.
getChildren(String, Watcher, AsyncCallback.Children2Callback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of getChildren.
getChildren(String, boolean, AsyncCallback.Children2Callback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of getChildren.
getChildren2 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
GetChildrenResult(List<String>) - Constructor for class org.apache.zookeeper.OpResult.GetChildrenResult
 
getChildWatches() - Method in class org.apache.zookeeper.ZooKeeper
 
getChrootPath() - Method in class org.apache.zookeeper.client.ConnectStringParser
 
getCipherSuitesProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getClientAddress() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
getClientAddress() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
 
getClientAddress() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getClientAddress() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
 
getClientAddress() - Method in interface org.apache.zookeeper.server.quorum.RemotePeerMXBean
 
getClientCertificateChain() - Method in class org.apache.zookeeper.server.DumbWatcher
 
getClientCertificateChain() - Method in class org.apache.zookeeper.server.NettyServerCnxn
 
getClientCertificateChain() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
getClientCertificateChain() - Method in class org.apache.zookeeper.server.ServerCnxn
 
getClientConfig() - Method in class org.apache.zookeeper.ZooKeeper
 
getClientConfigStr(String) - Static method in class org.apache.zookeeper.server.util.ConfigUtils
 
getClientId(X509Certificate) - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
Determine the string to be used as the remote host session Id for authorization purposes.
getClientInfos(List<Id>) - Static method in class org.apache.zookeeper.server.util.AuthUtil
Gets user from id to prepare ClientInfo.
getClientPath() - Method in class org.apache.zookeeper.WatchDeregistration
Returns client path which has specified for unregistering its watcher
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 class org.apache.zookeeper.server.ZooKeeperServerConf
Gets the client port.
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
 
getClientPortListenBacklog() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
The server socket's listen backlog length
getClientPortListenBacklog() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getClientPortListenBacklog() - Method in class org.apache.zookeeper.server.ServerConfig
Maximum number of pending socket connections to read, -1 if unset
getClientPortListenBacklog() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getClientPortListenBacklog() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
Returns the server socket listen backlog length.
getClientReachableLocalInetAddressCount() - Static method in class org.apache.zookeeper.common.NettyUtils
Attempts to detect and return the number of local network addresses that could be used by a client to reach this server.
getClientResponseStats() - Method in class org.apache.zookeeper.server.ServerStats
 
getCmdStr() - Method in class org.apache.zookeeper.cli.CliCommand
get the string used to call this command
getCnxManager() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
 
getCnxn() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.ServerObjs
 
getCnxnFactory() - Method in class org.apache.zookeeper.server.controller.ZooKeeperServerController
 
getCode() - Method in exception org.apache.zookeeper.KeeperException
Deprecated.
deprecated in 3.1.0, use KeeperException.code() instead
GetCommand - Class in org.apache.zookeeper.cli
get command for cli
GetCommand() - Constructor for class org.apache.zookeeper.cli.GetCommand
 
getCommand() - Method in class org.apache.zookeeper.server.admin.CommandResponse
Gets the command name.
getCommand(String) - Static method in class org.apache.zookeeper.server.admin.Commands
Returns the commands registered under cmdName with registerCommand, or null if no command is registered with that name.
getCommands() - Static method in class org.apache.zookeeper.ZooKeeperMain
 
getCommandString(int) - Static method in class org.apache.zookeeper.server.command.FourLetterCommands
Return the string representation of the specified command code.
getCommitProcMaxCommitBatchSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getCommitProcMaxCommitBatchSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getCommitProcMaxReadBatchSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getCommitProcMaxReadBatchSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getCommittedLog() - Method in class org.apache.zookeeper.server.ZKDatabase
 
getConf() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getConfig(Watcher, Stat) - Method in class org.apache.zookeeper.ZooKeeper
Return the last committed configuration (as known to the server to which the client is connected) and the stat of the configuration.
getConfig(Watcher, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of getConfig.
getConfig(boolean, Stat) - Method in class org.apache.zookeeper.ZooKeeper
Return the last committed configuration (as known to the server to which the client is connected) and the stat of the configuration.
getConfig(boolean, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The Asynchronous version of getConfig.
GetConfigCommand - Class in org.apache.zookeeper.cli
get command for cli
GetConfigCommand() - Constructor for class org.apache.zookeeper.cli.GetConfigCommand
 
getConfigFilename() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getConfigPrefix() - Method in class org.apache.zookeeper.common.ClientX509Util
 
getConfigPrefix() - Method in class org.apache.zookeeper.common.QuorumX509Util
 
getConfigPrefix() - Method in class org.apache.zookeeper.common.X509Util
 
getConfigStatus() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
 
getConfigVersion() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
getConfigVersion() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
 
getConnection() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
getConnection() - Method in class org.apache.zookeeper.server.Request
 
getConnectionDecreaseRatio() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getConnectionDecreaseRatio() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getConnectionDropChance() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getConnectionDropDecrease() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getConnectionDropDecrease() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getConnectionDropIncrease() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getConnectionDropIncrease() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getConnectionFreezeTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getConnectionFreezeTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getConnectionInfo(boolean) - Method in class org.apache.zookeeper.server.ServerCnxn
 
getConnectionMaxTokens() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getConnectionMaxTokens() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
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
 
getConnectionString() - Method in interface org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded
Get a connection string useful for the client.
getConnectionThreadCount() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
Return number of connection processing threads.
getConnectionTokenFillCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getConnectionTokenFillCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getConnectionTokenFillTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getConnectionTokenFillTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getConnectToLearnerMasterLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Get the connectToLearnerMasterLimit
getConnectToLearnerMasterLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getContainers() - Method in class org.apache.zookeeper.server.DataTree
 
getContentType() - Method in interface org.apache.zookeeper.server.admin.CommandOutputter
The MIME type of this output (e.g., "application/json")
getContentType() - Method in class org.apache.zookeeper.server.admin.JsonOutputter
 
getContext(String) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
 
getContext(String) - Method in interface org.apache.zookeeper.metrics.MetricsContext
Returns a sub context.
getControllerAddress() - Method in class org.apache.zookeeper.server.controller.ControllerServerConfig
 
getCount() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
 
getCount() - Method in class org.apache.zookeeper.StatsTrack
get the count of nodes allowed as part of quota
getCounter(String) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
 
getCounter(String) - Method in interface org.apache.zookeeper.metrics.MetricsContext
Returns a counter.
getCounterFromZxid(long) - Static method in class org.apache.zookeeper.server.util.ZxidUtils
 
getCounterSet(String) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
 
getCounterSet(String) - Method in interface org.apache.zookeeper.metrics.MetricsContext
Returns the CounterSet identified by the given name Null name is not allowed
getCountHardLimit() - Method in class org.apache.zookeeper.StatsTrack
get the count of nodes allowed as part of quota (hard limit)
getCreatedTimeStamp() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
getCurrentAndNextConfigVoters() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getCurrentEpoch() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getCurrentEpoch() - Method in class org.apache.zookeeper.server.quorum.StateSummary
 
getCurrentLearnerMaster() - Method in class org.apache.zookeeper.server.quorum.Observer
 
getCurrentLogSize() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
Return the current on-disk size of log size.
getCurrentTick() - Method in class org.apache.zookeeper.server.quorum.Leader
 
getCurrentTick() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
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.
getData(String) - Static method in class org.apache.zookeeper.Op
 
getData() - Method in class org.apache.zookeeper.OpResult.GetDataResult
 
getData() - Method in class org.apache.zookeeper.server.DataNode
 
getData(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.DataTree
 
getData(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
get data and stat for a path
getData - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
getData(String, Watcher, Stat) - Method in class org.apache.zookeeper.ZooKeeper
Return the data and the stat of the node of the given path.
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, Watcher, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of getData.
getData(String, boolean, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of getData.
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
 
getDataDir() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
Gets the data directory.
getDataDirSize() - Method in class org.apache.zookeeper.server.ServerStats
 
getDataDirSize() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
 
getDataDirSize() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getDataDirSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getDataDirSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
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
 
getDataLogDir() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
Gets the data log directory.
GetDataResult(byte[], Stat) - Constructor for class org.apache.zookeeper.OpResult.GetDataResult
 
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.ZooKeeper
 
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.
getDecreasePoint() - Method in class org.apache.zookeeper.server.BlueThrottle
 
getDefaultFileExtension() - Method in enum org.apache.zookeeper.common.KeyStoreFileType
The file extension that is associated with this file type.
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
 
getDefaultSSLContext() - Method in class org.apache.zookeeper.common.X509Util
 
getDefaultSSLContextAndOptions() - Method in class org.apache.zookeeper.common.X509Util
 
getDeficit() - Method in class org.apache.zookeeper.server.BlueThrottle
 
getDetailedPeerState() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getDigest() - Method in class org.apache.zookeeper.server.DataNode
 
getDigest() - Method in class org.apache.zookeeper.server.DataTree.ZxidDigest
 
getDigest() - Method in interface org.apache.zookeeper.server.NodeHashMap
Return the digest value.
getDigest() - Method in class org.apache.zookeeper.server.NodeHashMapImpl
 
getDigest() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
 
getDigest() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
 
getDigest() - Method in class org.apache.zookeeper.server.TxnLogEntry
 
getDigestEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
 
getDigestEnabled() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
 
getDigestFromLoadedSnapshot() - Method in class org.apache.zookeeper.server.DataTree
 
getDigestLog() - Method in class org.apache.zookeeper.server.DataTree
Return all the digests in the historical digest list.
getDigestVersion() - Method in class org.apache.zookeeper.server.DataTree.ZxidDigest
 
getDirectBuffer() - Static method in class org.apache.zookeeper.server.NIOServerCnxnFactory
 
getDoc() - Method in interface org.apache.zookeeper.server.admin.Command
A string documenting this command (e.g., what it does, any arguments it takes).
getDoc() - Method in class org.apache.zookeeper.server.admin.CommandBase
 
getDropChance() - Method in class org.apache.zookeeper.server.BlueThrottle
 
getDropDecrease() - Method in class org.apache.zookeeper.server.BlueThrottle
 
getDropIncrease() - Method in class org.apache.zookeeper.server.BlueThrottle
 
getDroppedCount() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
Returns the number of elements that were dropped from the queue because the queue was full when a new element was offered.
getDropStaleRequests() - Static method in class org.apache.zookeeper.server.RequestThrottler
 
getElapsed(DataNode) - Method in class org.apache.zookeeper.server.ContainerManager
 
getElectionAddress() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
getElectionAddress() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
 
getElectionAddress() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getElectionAddress() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
 
getElectionAddress() - Method in interface org.apache.zookeeper.server.quorum.RemotePeerMXBean
 
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
getEphemeralNodes() - Method in class org.apache.zookeeper.server.ConnectionBean
 
getEphemeralNodes() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
 
getEphemerals(long) - Method in class org.apache.zookeeper.server.DataTree
 
getEphemerals() - Method in class org.apache.zookeeper.server.DataTree
Returns a mapping of session ID to ephemeral znodes.
getEphemerals() - Method in class org.apache.zookeeper.server.ZKDatabase
 
getEphemerals(long) - Method in class org.apache.zookeeper.server.ZKDatabase
the paths for ephemeral session id
getEphemerals() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getEphemerals - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
getEphemerals() - Method in class org.apache.zookeeper.ZooKeeper
Synchronously gets all the ephemeral nodes created by this session.
getEphemerals(String) - Method in class org.apache.zookeeper.ZooKeeper
Synchronously gets all the ephemeral nodes matching prefixPath created by this session.
getEphemerals(String, AsyncCallback.EphemeralsCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
Asynchronously gets all the ephemeral nodes matching prefixPath created by this session.
getEphemerals(AsyncCallback.EphemeralsCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
Asynchronously gets all the ephemeral nodes created by this session.
GetEphemeralsCommand - Class in org.apache.zookeeper.cli
getEphemerals command for CLI
GetEphemeralsCommand() - Constructor for class org.apache.zookeeper.cli.GetEphemeralsCommand
 
getEphemeralsCount() - Method in class org.apache.zookeeper.server.DataTree
 
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
 
getEpochToPropose(long, long) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
getErr() - Method in class org.apache.zookeeper.OpResult.ErrorResult
 
getError() - Method in class org.apache.zookeeper.server.admin.CommandResponse
Gets the error string (may be null).
getEstablished() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
 
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 and its parameters
getExecString() - Method in class org.apache.zookeeper.Shell.ShellCommandExecutor
 
getExistWatches() - Method in class org.apache.zookeeper.ZooKeeper
 
getExitCode() - Method in exception org.apache.zookeeper.cli.CliException
 
getExitCode() - Method in exception org.apache.zookeeper.Shell.ExitCodeException
 
getExitCode() - Method in class org.apache.zookeeper.Shell
get the exit code
getExpiryMap() - Method in class org.apache.zookeeper.server.ExpiryQueue
Returns an unmodifiable view of the expiration time -> elements mapping.
getFileExtension() - Method in enum org.apache.zookeeper.server.persistence.SnapStream.StreamMode
 
getFillCount() - Method in class org.apache.zookeeper.server.BlueThrottle
 
getFillTime() - Method in class org.apache.zookeeper.server.BlueThrottle
 
getFlushDelay() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getFlushDelay() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
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
getFreezeTime() - Method in class org.apache.zookeeper.server.BlueThrottle
 
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.
getGetChildrenResponseCache() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
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
getHandshakeDetectionTimeoutMillis() - Method in class org.apache.zookeeper.common.SSLContextAndOptions
 
getHandshakeState() - Method in class org.apache.zookeeper.server.NettyServerCnxn
 
getHash() - Method in class org.apache.zookeeper.server.util.AdHash
Return the long value of the hash.
getHdr() - Method in class org.apache.zookeeper.server.Request
 
getHeader() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
return the current header
getHeader() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
return the transaction header.
getHeader() - Method in class org.apache.zookeeper.server.TxnLogEntry
 
getHostAddress() - Method in class org.apache.zookeeper.server.ServerCnxn
Returns the IP address or empty string.
getHostAndPort(String) - Static method in class org.apache.zookeeper.server.util.ConfigUtils
Gets host and port by splitting server config with support for IPv6 literals
getHostName() - Method in class org.apache.zookeeper.server.auth.KerberosName
Get the second component of the name.
getId() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.MatchValues
 
getId() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
getId() - Method in class org.apache.zookeeper.server.quorum.Vote
 
getIdleTimeout() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
getInetAddress() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getInflight() - Method in class org.apache.zookeeper.server.RequestThrottler
 
getInflight() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getInitialConfig() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getInitialConfig() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getInitialConfig() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
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.QuorumBean
 
getInitLimit() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
 
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
 
getInputStream(File) - Static method in class org.apache.zookeeper.server.persistence.SnapStream
Return the CheckedInputStream based on the extension of the fileName.
getInputStream() - Method in class org.apache.zookeeper.server.quorum.PrependableSocket
 
getInputStream() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getInstance(CommandFactory.Command) - Static method in class org.apache.zookeeper.cli.CommandFactory
Creates a new CliCommand instance.
getInstance() - Static method in class org.apache.zookeeper.jmx.MBeanRegistry
 
getInt(String, int) - Method in class org.apache.zookeeper.common.ZKConfig
Get the value of the key property as an int.
getInterestOps() - Method in class org.apache.zookeeper.server.DumbWatcher
 
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
 
getIntValue() - Method in enum org.apache.zookeeper.Watcher.WatcherType
 
getIPV6HostAndPort(String) - Static method in class org.apache.zookeeper.common.NetUtils
Separates host and port from given host port string if host port string is enclosed within square bracket.
getJaasConfKey() - Method in class org.apache.zookeeper.common.ZKConfig
Return the value of "java.security.auth.login.config" system property
getJuteMaxBufferSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getJuteMaxBufferSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getJvmPauseInfoThresholdMs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getJvmPauseInfoThresholdMs() - Method in class org.apache.zookeeper.server.ServerConfig
 
getJvmPauseSleepTimeMs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getJvmPauseSleepTimeMs() - Method in class org.apache.zookeeper.server.ServerConfig
 
getJvmPauseWarnThresholdMs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getJvmPauseWarnThresholdMs() - Method in class org.apache.zookeeper.server.ServerConfig
 
getKeepAlive() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getKeeperState() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
 
getKey() - Method in class org.apache.zookeeper.Environment.Entry
 
getKeyManager() - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
Get the X509KeyManager implementation used for certificate management.
getKind() - Method in class org.apache.zookeeper.Op
Gets the kind of an Op.
getLargeRequestBytes() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getLargeRequestMaxBytes() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getLargeRequestMaxBytes() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getLargeRequestMaxBytes() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getLargeRequestSize() - Method in class org.apache.zookeeper.server.Request
 
getLargeRequestThreshold() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getLargeRequestThreshold() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getLargeRequestThreshold() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getLastBufferSize() - Method in class org.apache.zookeeper.server.quorum.BufferStats
Size of the last buffer usage.
getLastClientResponseSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getLastClientResponseSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
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
getLastLogin() - Method in class org.apache.zookeeper.Login
Get the time of the last login (ticket initialization or last ticket renewal).
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 processed id from the datatree
getLastProcessedZxidDigest() - Method in class org.apache.zookeeper.server.DataTree
 
getLastProposalSize() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
 
getLastProposalSize() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
 
getLastProposed() - Method in class org.apache.zookeeper.server.quorum.Leader
 
getLastProposed() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
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
 
getLastSeenQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Return QuorumVerifier object for the last proposed configuration.
getLastSeenQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getLastSnapshotInfo() - Method in class org.apache.zookeeper.server.persistence.FileSnap
get information of the last saved/restored snapshot
getLastSnapshotInfo() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
get information of the last saved/restored snapshot
getLastSnapshotInfo() - Method in interface org.apache.zookeeper.server.persistence.SnapShot
get information of the last saved/restored snapshot
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.LearnerHandler
 
getLastZxid() - Method in class org.apache.zookeeper.server.quorum.StateSummary
 
getLastZxid() - Method in class org.apache.zookeeper.server.ServerCnxn
 
getLeader() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
getLeaderAddress() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getLeaderId() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
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
 
getLearnerDiffSyncThrottler() - Method in class org.apache.zookeeper.server.quorum.LearnerMaster
diff sync throttler
getLearnerHandlerInfo() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
 
getLearnerMaster() - Method in class org.apache.zookeeper.server.ObserverBean
 
getLearnerMaster() - Method in interface org.apache.zookeeper.server.quorum.ObserverMXBean
 
getLearnerMasterId() - Method in class org.apache.zookeeper.server.quorum.Observer
 
getLearners() - Method in class org.apache.zookeeper.server.quorum.Leader
Returns a copy of the current learner snapshot
getLearnerSnapSyncThrottler() - Method in class org.apache.zookeeper.server.quorum.LearnerMaster
snap sync throttler
getLearnerType() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
 
getLearnerType() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
getLearnerType() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
 
getLearnerType() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getLearnerType() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
 
getLearnerType() - Method in interface org.apache.zookeeper.server.quorum.RemotePeerMXBean
 
getLocalAddress() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
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.quorum.UnifiedServerSocket.UnifiedSocket
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.quorum.UnifiedServerSocket.UnifiedSocket
getLocalPort() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
getLocalSessionCount() - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
getLocalSessionCount() - Method in interface org.apache.zookeeper.server.SessionTracker
If this session tracker supports local sessions, return how many.
getLocalSessionCount() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
getLocalSocketAddress() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getLogDir(Properties) - Static method in class org.apache.zookeeper.server.persistence.Util
Extracts transaction log directory property value from the container.
getLogDirSize() - Method in class org.apache.zookeeper.server.ServerStats
 
getLogDirSize() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
 
getLogDirSize() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getLogDirSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getLogDirSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getLogEntries() - Method in class org.apache.zookeeper.audit.AuditEvent
Gives all entries to be logged.
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 value 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.
getLong(String, long) - Method in class org.apache.zookeeper.client.ZKClientConfig
Get the value of the key property as an long.
getMax() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
 
getMaxBatchSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getMaxBatchSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getMaxBufferSize() - Method in class org.apache.zookeeper.server.quorum.BufferStats
Size of the largest buffer usage.
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.ZooKeeperServer
Maximum number of connections allowed from particular host (ip)
getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
Gets the maximum client connections per host.
getMaxClientCnxnsPerHost() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
Current maxClientCnxns allowed from a particular host
getMaxClientResponseSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getMaxClientResponseSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getMaxCnxns() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
getMaxCnxns() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
 
getMaxCnxns() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
Maximum number of connections allowed in the ZooKeeper system
getMaxCnxns(ServerCnxnFactory, ServerCnxnFactory) - Static method in class org.apache.zookeeper.server.ServerCnxnHelper
gets maximum number of connections in ZooKeeper
getMaxCnxns() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getMaxCnxns() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getMaxCommitBatchSize() - Static method in class org.apache.zookeeper.server.quorum.CommitProcessor
 
getmaxCommittedLog() - Method in class org.apache.zookeeper.server.ZKDatabase
the committed log for this zk database
getMaxConcurrentDiffSyncs() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
 
getMaxConcurrentDiffSyncs() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
 
getMaxConcurrentDiffSyncs() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
 
getMaxConcurrentDiffSyncs() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
 
getMaxConcurrentDiffSyncs() - Method in class org.apache.zookeeper.server.quorum.LearnerMaster
 
getMaxConcurrentSnapSyncs() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
 
getMaxConcurrentSnapSyncs() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
 
getMaxConcurrentSnapSyncs() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
 
getMaxConcurrentSnapSyncs() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
 
getMaxConcurrentSnapSyncs() - Method in class org.apache.zookeeper.server.quorum.LearnerMaster
 
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
 
getMaxReadBatchSize() - Static method in class org.apache.zookeeper.server.quorum.CommitProcessor
 
getMaxRequestLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getMaxRequestLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getMaxRequests() - Static method in class org.apache.zookeeper.server.RequestThrottler
 
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 class org.apache.zookeeper.server.ZooKeeperServerConf
Gets the maximum session timeout.
getMaxSessionTimeout() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
Current maxSessionTimeout of the server in milliseconds
getMaxTokens() - Method in class org.apache.zookeeper.server.BlueThrottle
 
getMaxWriteQueuePollTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getMaxWriteQueuePollTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getMessage() - Method in exception org.apache.zookeeper.KeeperException
 
getMetrics() - Static method in class org.apache.zookeeper.server.ServerMetrics
Access current ServerMetrics.
getMetricsProvider() - Method in class org.apache.zookeeper.server.ServerMetrics
 
getMetricsProviderClassName() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getMetricsProviderClassName() - Method in class org.apache.zookeeper.server.ServerConfig
 
getMetricsProviderConfiguration() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getMetricsProviderConfiguration() - Method in class org.apache.zookeeper.server.ServerConfig
 
getMin() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
 
getMinBufferSize() - Method in class org.apache.zookeeper.server.quorum.BufferStats
Size of the smallest buffer usage.
getMinClientResponseSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getMinClientResponseSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getminCommittedLog() - Method in class org.apache.zookeeper.server.ZKDatabase
the minimum committed transaction log available in memory
getMinIntervalMs() - Method in class org.apache.zookeeper.server.ContainerManager
 
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
 
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 class org.apache.zookeeper.server.ZooKeeperServerConf
Gets the minimum session timeout.
getMinSessionTimeout() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
Current minSessionTimeout of the server in milliseconds
getMode() - Method in enum org.apache.zookeeper.AddWatchMode
 
getMultiAddressReachabilityCheckTimeoutMs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getMultiAddressReachabilityCheckTimeoutMs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getMyId() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
get the id of this quorum peer.
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 enum org.apache.zookeeper.server.persistence.SnapStream.StreamMode
 
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.LearnerHandlerBean
 
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
 
getNames() - Method in interface org.apache.zookeeper.server.admin.Command
The set of all names that can be used to refer to this command (e.g., "configuration", "config", and "conf").
getNames() - Method in class org.apache.zookeeper.server.admin.CommandBase
 
getNeedOracle() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
 
getNeedOracle() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
getNextDynamicConfigFilename() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getNode(String) - Method in class org.apache.zookeeper.server.DataTree
 
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
getNonMTLSLocalConnCount() - Method in class org.apache.zookeeper.server.ServerStats
 
getNonMTLSLocalConnCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getNonMTLSLocalConnCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getNonMTLSRemoteConnCount() - Method in class org.apache.zookeeper.server.ServerStats
 
getNonMTLSRemoteConnCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getNonMTLSRemoteConnCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getNonVotingFollowers() - Method in class org.apache.zookeeper.server.quorum.Leader
 
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
 
getNumConnections() - Method in class org.apache.zookeeper.server.watch.WatchesSummary
Gets the number of connections (sessions) that have set watches.
getNumGcInfoThresholdExceeded() - Method in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
getNumGcWarnThresholdExceeded() - Method in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
getNumPaths() - Method in class org.apache.zookeeper.server.watch.WatchesSummary
Gets the number of paths that have watches set on them.
getNumPendingSyncs() - Method in class org.apache.zookeeper.server.quorum.Leader
 
getObserver() - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
 
getObserverElectionDelayMs() - Static method in class org.apache.zookeeper.server.quorum.Observer
 
getObserverElectionDelayMS() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
 
getObserverElectionDelayMS() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
 
getObserverMasterPacketSizeLimit() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
 
getObserverMasterPacketSizeLimit() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
 
getObserverMasterPort() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getObserverMasterPort() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getObservingLearners() - Method in class org.apache.zookeeper.server.quorum.Leader
Returns a copy of the current observer snapshot
getObservingLearnersInfo() - Method in class org.apache.zookeeper.server.quorum.Leader
 
getObservingMembers() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
 
getObservingMembers() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
 
getObservingMembers() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
getObservingView() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Returns only observers, no followers.
getOne() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
Returns an address from the set.
getOOBInline() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getOpenFileDescriptorCount() - Method in class org.apache.zookeeper.server.util.OSMXBean
Get the number of opened filed descriptor for the runtime jvm.
getOpKind() - Method in class org.apache.zookeeper.MultiOperationRecord
Returns the kind of the operations contained by the record.
getOptionStr() - Method in class org.apache.zookeeper.cli.CliCommand
get the option string
getOraclePath() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
 
getOraclePath() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
getOutput() - Method in class org.apache.zookeeper.Shell.ShellCommandExecutor
Get the output of the shell command.
getOutputStream(File, boolean) - Static method in class org.apache.zookeeper.server.persistence.SnapStream
Return the OutputStream based on predefined stream mode.
getOutputStream() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getOutstandingHandshakeNum() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
getOutstandingHandshakeNum() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
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.DumbWatcher
 
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 haven't 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
getParameter() - Method in class org.apache.zookeeper.server.controller.ControlCommand
 
getParentChannel() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
getPasswordFromConfigPropertyOrFile(ZKConfig, String, String) - Method in class org.apache.zookeeper.common.X509Util
Returns the password specified by the given property or from the file specified by the given path property.
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.server.auth.ServerAuthenticationProvider.MatchValues
 
getPath() - Method in class org.apache.zookeeper.WatchedEvent
 
getPaths(long) - Method in class org.apache.zookeeper.server.watch.WatchesReport
Gets the paths that the given session has set watches on.
getPeerEpoch() - Method in class org.apache.zookeeper.server.quorum.Vote
 
getPeerInfo(long) - Method in class org.apache.zookeeper.server.quorum.Leader
 
getPeerInfo(long) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
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
 
getPerm() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.MatchValues
 
getPermString(int) - Static method in class org.apache.zookeeper.ZKUtil
 
getPersistentRecursiveWatches() - Method in class org.apache.zookeeper.ZooKeeper
 
getPersistentWatches() - Method in class org.apache.zookeeper.ZooKeeper
 
getPlatformMBeanServer() - Method in class org.apache.zookeeper.jmx.MBeanRegistry
Return the underlying MBeanServer that is being used to register MBean's.
getPort() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getPreAllocSize() - Static method in class org.apache.zookeeper.server.persistence.FilePadding
Getter of preAllocSize has been added for testing
getPrimaryName() - Method in interface org.apache.zookeeper.server.admin.Command
The name that is returned with the command response and that appears in the list of all commands.
getPrimaryName() - Method in class org.apache.zookeeper.server.admin.CommandBase
 
getPrimaryNames() - Static method in class org.apache.zookeeper.server.admin.Commands
Returns the primary names of all registered commands.
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
 
getProperty(String) - Method in class org.apache.zookeeper.common.ZKConfig
Get the property value
getProperty(String, String) - Method in class org.apache.zookeeper.common.ZKConfig
Get the property value, if it is null return default value
getPropertyBackwardCompatibleWay(String) - Static method in class org.apache.zookeeper.server.util.ConfigUtils
Some old configuration properties are not configurable in zookeeper configuration file zoo.cfg.
getPropertyValue() - Method in enum org.apache.zookeeper.common.KeyStoreFileType
The property string that specifies that a key store or trust store should use this store file type.
getProposalsFromTxnLog(long, long) - Method in class org.apache.zookeeper.server.ZKDatabase
Get proposals from txnlog.
getProposalStats() - Method in class org.apache.zookeeper.server.quorum.Leader
 
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.
getQueuedPackets() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
For testing, return packet queue
getQueuedReadableBytes() - Method in class org.apache.zookeeper.server.NettyServerCnxn
 
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
 
getQuorumAuthServer() - Method in class org.apache.zookeeper.server.quorum.Leader
 
getQuorumAuthServer() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
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
 
getQuorumSystemInfo() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
getQuorumSystemInfo() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
 
getQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Return QuorumVerifier object for the last committed configuration.
getQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker.QuorumVerifierAcksetPair
 
getQuorumVerifierBytes() - Method in class org.apache.zookeeper.server.quorum.Leader
 
getQuorumVerifierBytes() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
getQuorumVerifierVersion() - Method in class org.apache.zookeeper.server.quorum.Leader
 
getQuorumVerifierVersion() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
getQuotaBytesLimit(DataTree) - Static method in class org.apache.zookeeper.server.util.QuotaMetricsUtils
Traverse the quota subtree and return per namespace quota bytes limit `
getQuotaBytesUsage(DataTree) - Static method in class org.apache.zookeeper.server.util.QuotaMetricsUtils
Traverse the quota subtree and return per namespace quota bytes usage
getQuotaCountLimit(DataTree) - Static method in class org.apache.zookeeper.server.util.QuotaMetricsUtils
Traverse the quota subtree and return per namespace quota count limit
getQuotaCountUsage(DataTree) - Static method in class org.apache.zookeeper.server.util.QuotaMetricsUtils
Traverse the quota subtree and return per namespace quota count usage
getReachableAddress() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
Returns a reachable address.
getReachableOrOne() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
Returns a reachable address or an arbitrary one, if none is reachable.
getReadResponseCache() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getRealm() - Method in class org.apache.zookeeper.server.auth.KerberosName
Get the realm of the name.
getReason() - Method in exception org.apache.zookeeper.server.ServerCnxn.CloseRequestException
 
getReason() - Method in exception org.apache.zookeeper.server.ServerCnxn.EndOfStreamException
 
getReceiveBufferSize() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getRecursiveWatchQty() - Method in interface org.apache.zookeeper.server.watch.IWatchManager
Return the current number of recursive watchers
getRecursiveWatchQty() - Method in class org.apache.zookeeper.server.watch.WatchManager
 
getReferenceCountedAclCache() - Method in class org.apache.zookeeper.server.DataTree
 
getRegisteredBeans() - Method in class org.apache.zookeeper.jmx.MBeanRegistry
 
getRemoteAddress() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
getRemoteSocketAddress() - Method in class org.apache.zookeeper.server.DumbWatcher
 
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.quorum.UnifiedServerSocket.UnifiedSocket
getRemoteSocketAddress() - Method in class org.apache.zookeeper.server.ServerCnxn
 
getRequestPathMetricsCollector() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getRequestStaleConnectionCheck() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getRequestStaleConnectionCheck() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getRequestStaleLatencyCheck() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getRequestStaleLatencyCheck() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getRequestThrottleDropStale() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getRequestThrottleDropStale() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getRequestThrottleLimit() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getRequestThrottleLimit() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getRequestThrottleStallTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getRequestThrottleStallTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getRequiredTokensForGlobal() - Method in class org.apache.zookeeper.server.BlueThrottle
 
getRequiredTokensForLocal() - Method in class org.apache.zookeeper.server.BlueThrottle
 
getRequiredTokensForRenew() - Method in class org.apache.zookeeper.server.BlueThrottle
 
getResponseCachingEnabled() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getResponseCachingEnabled() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getResult() - Method in class org.apache.zookeeper.audit.AuditEvent
 
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.
getReuseAddress() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getRevision() - Static method in class org.apache.zookeeper.Version
Deprecated.
getRevisionHash() - Static method in class org.apache.zookeeper.Version
 
getRootContext() - Method in class org.apache.zookeeper.metrics.impl.DefaultMetricsProvider
 
getRootContext() - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider
 
getRootContext() - Method in interface org.apache.zookeeper.metrics.MetricsProvider
Provides access to the root context.
getSaslClient() - Method in class org.apache.zookeeper.ZooKeeper
 
getSaslState() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
 
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.EnsembleAuthenticationProvider
 
getScheme() - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
 
getScheme() - Method in class org.apache.zookeeper.server.auth.KeyAuthenticationProvider
 
getScheme() - Method in class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
 
getScheme() - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
 
getSecureClientAddress() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getSecureClientAddress() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getSecureClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getSecureClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getSecureClientPort() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getSecureClientPortAddress() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getSecureClientPortAddress() - Method in class org.apache.zookeeper.server.ServerConfig
 
getSecureConnectionString() - Method in interface org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded
 
getSecureServerCnxnFactory() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getSendBufferSize() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getServerAddresses() - Method in class org.apache.zookeeper.client.ConnectStringParser
 
getServerAtCurrentIndex() - Method in class org.apache.zookeeper.client.StaticHostProvider
 
getServerAtIndex(int) - Method in class org.apache.zookeeper.client.StaticHostProvider
 
getServerCnxnFactory() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
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
 
getServerId() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
Gets the server ID.
getServerIdFromSessionId(long) - Static method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
getServerPrincipal(String, String) - Static method in class org.apache.zookeeper.util.SecurityUtils
Convert Kerberos principal name pattern to valid Kerberos principal name.
getServerProvider(String) - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
 
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.
getSessionCount() - Method in class org.apache.zookeeper.server.ZKDatabase
 
getSessionExpiryMap() - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
getSessionExpiryMap() - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
 
getSessionExpiryMap() - Method in interface org.apache.zookeeper.server.SessionTracker
Returns a mapping of time to session IDs that expire at that time.
getSessionExpiryMap() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
Returns a mapping from time to session IDs of sessions expiring at that time.
getSessionExpiryMap() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getSessionId() - Method in class org.apache.zookeeper.ClientCnxn
 
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.DumbWatcher
 
getSessionId() - Method in class org.apache.zookeeper.server.NettyServerCnxn
 
getSessionId() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
getSessionId() - Method in class org.apache.zookeeper.server.ServerCnxn
 
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.
getSessionIdHex() - Method in class org.apache.zookeeper.server.ServerCnxn
Get session id in hexadecimal notation.
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(String) - Method in class org.apache.zookeeper.server.watch.WatchesPathReport
Gets the session IDs of sessions that have set watches on the given path.
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(long) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
getSessionTimeout() - Method in class org.apache.zookeeper.ZooKeeper
The negotiated session timeout for this ZooKeeper client instance.
getSessionTracker() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getSessionWithTimeOuts() - Method in class org.apache.zookeeper.server.ZKDatabase
get sessions with timeouts
getSetAcls() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.MatchValues
 
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.
getSnapSizeInBytes() - Static method in class org.apache.zookeeper.server.ZooKeeperServer
 
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.NIOServerCnxn
 
getSocketListenBacklog() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
The maximum queue length of the ZooKeeper server's socket
getSocketListenBacklog() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
The maximum queue length of the ZooKeeper server's socket
getSocketListenBacklog() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
The maximum queue length of the ZooKeeper server's socket
getSoLinger() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getSoTimeout() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getSourceIP() - Method in class org.apache.zookeeper.server.ConnectionBean
 
getSourceIP() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
 
getSslAuthProviderProperty() - Method in class org.apache.zookeeper.common.ClientX509Util
 
getSslCipherSuitesProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslClientAuthProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSSLContext() - Method in class org.apache.zookeeper.common.SSLContextAndOptions
 
getSslContextSupplierClassProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslCrlEnabledProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslEnabledProtocolsProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslHandshakeDetectionTimeoutMillisProperty() - Method in class org.apache.zookeeper.common.X509Util
Returns the config property key that controls the amount of time, in milliseconds, that the first UnifiedServerSocket read operation will block for when trying to detect the client mode (TLS or PLAINTEXT).
getSslHandshakeTimeoutMillis() - Method in class org.apache.zookeeper.common.X509Util
Returns the max amount of time, in milliseconds, that the first UnifiedServerSocket read() operation should block for when trying to detect the client mode (TLS or PLAINTEXT).
getSslHostnameVerificationEnabledProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslKeystoreLocationProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslKeystorePasswdPathProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslKeystorePasswdProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslKeystoreTypeProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslOcspEnabledProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslProtocolProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslSocket() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
Returns the underlying SSLSocket if the mode is TLS.
getSslTruststoreLocationProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslTruststorePasswdPathProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslTruststorePasswdProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getSslTruststoreTypeProperty() - Method in class org.apache.zookeeper.common.X509Util
 
getStaleConnectionCheck() - Static method in class org.apache.zookeeper.server.Request
 
getStaleLatencyCheck() - Static method in class org.apache.zookeeper.server.Request
 
getStallTime() - Static method in class org.apache.zookeeper.server.RequestThrottler
 
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.CreateResult
 
getStat() - Method in class org.apache.zookeeper.OpResult.GetDataResult
 
getStat() - Method in class org.apache.zookeeper.OpResult.SetDataResult
 
getState() - Method in class org.apache.zookeeper.common.FileChangeWatcher
Returns the current FileChangeWatcher.State.
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
 
getStatsBytes() - Method in class org.apache.zookeeper.StatsTrack
 
getStorageSize() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
Return total storage size of txnlog that will return by this iterator.
getStorageSize() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
Get an estimated storage space used to store transaction records that will return by this iterator
getStreamMode() - Static method in class org.apache.zookeeper.server.persistence.SnapStream
 
getStreamMode(String) - Static method in class org.apache.zookeeper.server.persistence.SnapStream
Detect the stream mode from file name extension
getSubject() - Method in class org.apache.zookeeper.Login
 
getSummary(String, MetricsContext.DetailLevel) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
 
getSummary(String, MetricsContext.DetailLevel) - Method in interface org.apache.zookeeper.metrics.MetricsContext
Returns a summary.
getSummarySet(String, MetricsContext.DetailLevel) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
 
getSummarySet(String, MetricsContext.DetailLevel) - Method in interface org.apache.zookeeper.metrics.MetricsContext
Returns a set of summaries.
getSynced_observers_metric() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getSyncedObserversInfo() - Method in class org.apache.zookeeper.server.quorum.Follower
 
getSyncedObserverSize() - Method in class org.apache.zookeeper.server.quorum.Follower
 
getSyncEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Return syncEnabled.
getSyncEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getSyncInProgress() - Method in class org.apache.zookeeper.server.quorum.LearnerSyncThrottler
 
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.QuorumBean
 
getSyncLimit() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
 
getSyncLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Get the synclimit
getSyncLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getSyncMode() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getTcpNoDelay() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
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
getThrottledOpWaitTime() - Static method in class org.apache.zookeeper.server.ZooKeeperServer
 
getThrottledOpWaitTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getThrottledOpWaitTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
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
getTickOfInitialAckDeadline() - Method in class org.apache.zookeeper.server.quorum.Leader
 
getTickOfInitialAckDeadline() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
getTickOfNextAckDeadline() - Method in class org.apache.zookeeper.server.quorum.Leader
 
getTickOfNextAckDeadline() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
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 class org.apache.zookeeper.server.ZooKeeperServerConf
Gets the tick time.
getTickTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
Current TickTime of server in milliseconds
getTimeout() - Method in interface org.apache.zookeeper.server.SessionTracker.Session
 
getTimeout() - Method in class org.apache.zookeeper.server.SessionTrackerImpl.SessionImpl
 
getTopNamespace(String) - Static method in class org.apache.zookeeper.common.PathUtils
return the top namespace of a znode path
getTotal() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
 
getTotalGcExtraSleepTime() - Method in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
getTotalLogSize() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
 
getTotalLogSize() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
 
getTotalLogSize() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
Gets the total size of all log files
getTotalWatches() - Method in class org.apache.zookeeper.server.watch.WatchesSummary
Gets the total number of watches set.
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.command.FourLetterCommands
 
GetTraceMaskCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.GetTraceMaskCommand
 
getTrafficClass() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
getTransport() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
getTreeDigest() - Method in class org.apache.zookeeper.server.DataTree
 
getTrustManager() - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
Get the X509TrustManager implementation used for remote host authentication.
getTtls() - Method in class org.apache.zookeeper.server.DataTree
 
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.
getTxn() - Method in class org.apache.zookeeper.server.Request
 
getTxn() - Method in class org.apache.zookeeper.server.TxnLogEntry
 
getTxnCount() - Method in class org.apache.zookeeper.server.ZKDatabase
Get the number of txn since last snapshot
getTxnDigest() - Method in class org.apache.zookeeper.server.Request
 
getTxnFactory() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getTxnLogElapsedSyncTime() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
 
getTxnLogElapsedSyncTime() - Method in class org.apache.zookeeper.server.ZooKeeperServer
Returns the elapsed sync of time of transaction log in milliseconds.
getTxnLogElapsedSyncTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getTxnLogElapsedSyncTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
Returns the elapsed sync of time of transaction log in milliseconds.
getTxnLogFactory() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getTxnLogSyncElapsedTime() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
 
getTxnLogSyncElapsedTime() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
 
getTxnSize() - Method in class org.apache.zookeeper.server.ZKDatabase
Get the size of txn since last snapshot
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.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.
getUptime() - Method in class org.apache.zookeeper.server.quorum.Leader
 
getUptime() - Method in class org.apache.zookeeper.server.ServerStats
 
getUsageStr() - Method in class org.apache.zookeeper.cli.CliCommand
get a usage string, contains the command and the options
getUser(Id) - Static method in class org.apache.zookeeper.server.util.AuthUtil
Gives user name
getUserName() - Method in class org.apache.zookeeper.Login
 
getUserName(String) - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
id represents the authentication info which is set in server connection.
getUserName(String) - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
getUserName() - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
User who has started the ZooKeeper server user, it will be the logged-in user.
getUsers(List<Id>) - Static method in class org.apache.zookeeper.server.util.AuthUtil
Returns a formatted, comma-separated list of the user IDs held in authInfo, or null if no user IDs were found.
getUsersForAudit() - Method in class org.apache.zookeeper.server.Request
Returns a formatted, comma-separated list of the user IDs associated with this Request, or null if no user IDs were found.
getValue(AuditEvent.FieldName) - Method in class org.apache.zookeeper.audit.AuditEvent
 
getValue() - Method in class org.apache.zookeeper.Environment.Entry
 
getValue(long) - Method in enum org.apache.zookeeper.server.EphemeralType
For types that support it, return the extended value from an extended ephemeral owner
getValue() - Method in enum org.apache.zookeeper.server.ExitCode
 
getVersion() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
 
getVersion() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
 
getVersion() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
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() - Static method in class org.apache.zookeeper.Version
 
getVersionFromFilename(String) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
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.
getVote() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
 
getVoteTracker(Map<Long, Vote>, Vote) - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
Given a set of votes, return the SyncedLearnerTracker which is used to determines if have sufficient to declare the end of the election round.
getVotingMembers() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
 
getVotingMembers() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
 
getVotingMembers() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
getVotingView() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Observers are not contained in this view, only nodes with PeerType=PARTICIPANT.
getWaitTime() - Method in class org.apache.zookeeper.server.ExpiryQueue
 
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
 
getWatcher2PathesMap() - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
May cause OOM if there are lots of watches, might better to forbid it in this class.
getWatches() - Method in class org.apache.zookeeper.server.DataTree
Returns a watch report.
getWatches() - Method in interface org.apache.zookeeper.server.watch.IWatchManager
Returns a watch report.
getWatches() - Method in class org.apache.zookeeper.server.watch.WatchManager
 
getWatches() - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
 
getWatches(int) - Method in class org.apache.zookeeper.ZooKeeper.WatchRegistration
 
getWatchesByPath() - Method in class org.apache.zookeeper.server.DataTree
Returns a watch report by path.
getWatchesByPath() - Method in interface org.apache.zookeeper.server.watch.IWatchManager
Returns a watch report by path.
getWatchesByPath() - Method in class org.apache.zookeeper.server.watch.WatchManager
 
getWatchesByPath() - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
Iterate through ConcurrentHashMap is 'safe', it will reflect the state of the map at the time iteration began, may miss update while iterating, given this is used in the commands to get a general idea of the watches state, we don't care about missing some update.
getWatchesSummary() - Method in class org.apache.zookeeper.server.DataTree
Returns a watch summary.
getWatchesSummary() - Method in interface org.apache.zookeeper.server.watch.IWatchManager
Returns a watch summary.
getWatchesSummary() - Method in class org.apache.zookeeper.server.watch.WatchManager
 
getWatchesSummary() - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
 
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
 
getWildcardAddresses() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
Returns wildcard addresses for all ports
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
 
getZabState() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getZKDatabase() - Method in class org.apache.zookeeper.server.quorum.Leader
 
getZKDatabase() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
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
 
getZks() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.ServerObjs
 
getZkShutdownHandler() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getZKUser() - Static method in class org.apache.zookeeper.audit.ZKAuditProvider
User who has started the ZooKeeper server user, it will be the logged-in user.
getZooKeeperSaslClient() - Method in class org.apache.zookeeper.ClientCnxn
 
getZooKeeperServer() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
getZooKeeperServerConfig() - Method in class org.apache.zookeeper.server.controller.ControllerServerConfig
 
getZooKeeperServerListener() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getZxid() - Method in class org.apache.zookeeper.server.DataTree.ZxidDigest
 
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.Vote
 
getZxid() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getZxidFromName(String, String) - Static method in class org.apache.zookeeper.server.persistence.Util
Extracts zxid from the file name.
GLOBAL_OUTSTANDING_LIMIT - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
GLOBAL_SESSION_WEIGHT - Static variable in class org.apache.zookeeper.server.BlueThrottle
 
globalSessions() - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
globalSessions() - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
 
globalSessions() - Method in interface org.apache.zookeeper.server.SessionTracker
Get a set of global session IDs
globalSessions() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 

H

half - Variable in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
 
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
 
handle(ZooKeeperServer.State) - Method in class org.apache.zookeeper.server.ZooKeeperServerShutdownHandler
This will be invoked when the server transition to a new server state.
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.EnsembleAuthenticationProvider
 
handleAuthentication(ServerCnxn, byte[]) - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
 
handleAuthentication(ServerAuthenticationProvider.ServerObjs, byte[]) - Method in class org.apache.zookeeper.server.auth.KeyAuthenticationProvider
 
handleAuthentication(ServerCnxn, byte[]) - Method in class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
 
handleAuthentication(ServerAuthenticationProvider.ServerObjs, byte[]) - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider
This method is called when a client passes authentication data for this scheme.
handleAuthentication(ServerCnxn, byte[]) - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider
 
handleAuthentication(ServerCnxn, byte[]) - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
 
handleBackwardCompatibility() - Method in class org.apache.zookeeper.client.ZKClientConfig
 
handleBackwardCompatibility() - Method in class org.apache.zookeeper.common.ZKConfig
Now onwards client code will use properties from this class but older clients still be setting properties through system properties.
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.
hasAllQuorums() - Method in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker
 
hashCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
hashCode() - Method in class org.apache.zookeeper.MultiOperationRecord
 
hashCode() - Method in class org.apache.zookeeper.MultiResponse
 
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.CreateTTL
 
hashCode() - Method in class org.apache.zookeeper.Op.Delete
 
hashCode() - Method in class org.apache.zookeeper.Op.GetChildren
 
hashCode() - Method in class org.apache.zookeeper.Op.GetData
 
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.GetChildrenResult
 
hashCode() - Method in class org.apache.zookeeper.OpResult.GetDataResult
 
hashCode() - Method in class org.apache.zookeeper.OpResult.SetDataResult
 
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.quorum.flexible.QuorumHierarchical
 
hashCode() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
 
hashCode() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
 
hashCode() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
 
hashCode() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
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.util.AdHash
 
hashCode() - Method in class org.apache.zookeeper.StatsTrack
 
hasNext() - Method in class org.apache.zookeeper.server.TxnLogProposalIterator
 
hasNext() - Method in class org.apache.zookeeper.server.watch.PathParentIterator
 
hasPaths(long) - Method in class org.apache.zookeeper.server.watch.WatchesReport
Checks if the given session has watches set.
hasSessions(String) - Method in class org.apache.zookeeper.server.watch.WatchesPathReport
Checks if the given path has watches set.
hasSid(long) - Method in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker
 
history - Variable in class org.apache.zookeeper.ZooKeeperMain
 
holdAllFutureResponses() - Method in class org.apache.zookeeper.server.controller.ControllableConnectionFactory
 
holdFutureResponses(long) - Method in class org.apache.zookeeper.server.controller.ControllableConnectionFactory
 
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.
hostProvider - Variable in class org.apache.zookeeper.ZooKeeper
 

I

id - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
IDeadWatcherListener - Interface in org.apache.zookeeper.server.watch
Interface used to process the dead watchers related to closed cnxns.
inc() - Method in interface org.apache.zookeeper.metrics.Counter
Increment the value by one.
inc(String) - Method in interface org.apache.zookeeper.metrics.CounterSet
Increment the value by one for the given key
incInProcess() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
incomingBuffer - Variable in class org.apache.zookeeper.server.NIOServerCnxn
 
incrementAuthFailedCount() - Method in class org.apache.zookeeper.server.ServerStats
 
incrementFsyncThresholdExceedCount() - Method in class org.apache.zookeeper.server.ServerStats
 
incrementNonMTLSLocalConnCount() - Method in class org.apache.zookeeper.server.ServerStats
 
incrementNonMTLSRemoteConnCount() - 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
 
incrOutstandingAndCheckThrottle(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
 
INFLIGHT_DIFF_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
INFLIGHT_SNAP_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
Info - Interface in org.apache.zookeeper.version
 
INFO_THRESHOLD_DEFAULT - Static variable in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
INFO_THRESHOLD_KEY - Static variable in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
inform(Leader.Proposal) - Method in class org.apache.zookeeper.server.quorum.Leader
Create an inform packet and send it to all observers.
informAndActivate(Leader.Proposal, long) - Method in class org.apache.zookeeper.server.quorum.Leader
Create an inform and activate packet and send it to all observers.
infoThresholdMs - Variable in class org.apache.zookeeper.server.util.JvmPauseMonitor
log INFO if we detect a pause longer than this threshold
INIT_VALUE - Static variable in class org.apache.zookeeper.server.quorum.BufferStats
 
initConfig(String[]) - Method in class org.apache.zookeeper.server.controller.ControllerService
Derived classes may override to do custom initialization of command line args.
initConfigInZKDatabase() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
initConfigInZKDatabase(QuorumVerifier) - Method in class org.apache.zookeeper.server.ZKDatabase
 
initialConfig - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
initialConfig - Variable in class org.apache.zookeeper.server.ServerConfig
 
initialConfig - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
InitialConfigurationCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.InitialConfigurationCommand
 
initialize() - Method in interface org.apache.zookeeper.audit.AuditLogger
Called during initialization of the logger.
initialize(ClientCnxn) - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.zookeeper.server.auth.DigestLoginModule
 
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
 
initializeAndRun(String[]) - Method in class org.apache.zookeeper.server.controller.ControllerService
Runs the main loop for this application but does not exit the process.
initializeAndRun(String[]) - Method in class org.apache.zookeeper.server.quorum.QuorumPeerMain
 
initializeAndRun(String[]) - Method in class org.apache.zookeeper.server.ZooKeeperServerMain
 
initializeNextSessionId(long) - Static method in class org.apache.zookeeper.server.SessionTrackerImpl
Generates an initial sessionId.
initializeResponse() - Method in class org.apache.zookeeper.server.admin.CommandBase
 
initiateConnection(MultipleAddresses, Long) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
First we create the socket, perform SSL handshake and authentication if needed.
initiateConnectionAsync(MultipleAddresses, 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
 
initMaxCnxns() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
initService() - Method in class org.apache.zookeeper.server.controller.ControllerService
Initializes an instance of the ZooKeeperServer, the ZooKeeperServerController, and a new Http listener (CommandListener) for the controller.
injectSessionExpiration() - Method in interface org.apache.zookeeper.Testable
Cause the ZooKeeper instance to behave as if the session expired
INSECURE_ADMIN - Variable in class org.apache.zookeeper.server.ServerMetrics
 
INSTANCE - Static variable in class org.apache.zookeeper.metrics.impl.NullMetricsProvider
Instance of NullMetricsProvider useful for tests.
INSTANCE - Static variable in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
 
inStreamCreated(InputArchive, InputStream) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
read the header from the inputarchive
INT_BUFFER_STARTING_SIZE_BYTES - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
Starting size of read and write ByteArroyOuputBuffers.
intBufferStartingSizeBytes - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
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
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
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
 
isAuditEnabled() - Static method in class org.apache.zookeeper.audit.ZKAuditProvider
 
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.EnsembleAuthenticationProvider
 
isAuthenticated() - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
 
isAuthenticated() - Method in class org.apache.zookeeper.server.auth.KeyAuthenticationProvider
 
isAuthenticated() - Method in class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
 
isAuthenticated() - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
 
isBlank(String) - Static method in class org.apache.zookeeper.common.StringUtils
Returns true if the string is null or it does not contain any non space characters.
isBound() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
isClientAddrFromStatic - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
isClosed() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
isCloseSessionTxnEnabled() - Static method in class org.apache.zookeeper.server.ZooKeeperServer
 
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 class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
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)
isConnectionWeightEnabled() - Method in class org.apache.zookeeper.server.BlueThrottle
 
isContainer() - Method in enum org.apache.zookeeper.CreateMode
 
isDigestCached() - Method in class org.apache.zookeeper.server.DataNode
 
isDigestEnabled() - Static method in class org.apache.zookeeper.server.ZooKeeperServer
 
isDistributed() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
isDumpMode() - Method in class org.apache.zookeeper.server.persistence.TxnLogToolkit
 
isEmpty(String) - Static method in class org.apache.zookeeper.common.StringUtils
Checks if a String is empty ("") or null.
isEmpty() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
 
isEmpty() - Method in class org.apache.zookeeper.server.util.BitHashSet
 
isEmpty() - Method in class org.apache.zookeeper.server.util.CircularBuffer
 
isEmpty() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
isEnabled() - Static method in class org.apache.zookeeper.client.ZooKeeperSaslClient
Deprecated.
isEnabled() - Static method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
isEnabled(String) - Static method in class org.apache.zookeeper.server.command.FourLetterCommands
Check if the specified command is enabled.
isEnabled() - Method in class org.apache.zookeeper.server.ResponseCache
 
isEnableEagerACLCheck() - Static method in class org.apache.zookeeper.server.ZooKeeperServer
 
isEnforceAuthEnabled() - Method in class org.apache.zookeeper.server.AuthenticationHelper
 
isEphemeral() - Method in enum org.apache.zookeeper.CreateMode
 
isFailed() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
 
isFillInterested() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
isForceSync() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
the forceSync value.
isFromLearner() - Method in class org.apache.zookeeper.server.Request
 
isFull() - Method in class org.apache.zookeeper.server.util.CircularBuffer
 
isGlobalSession(long) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
isGlobalSession(long) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
 
isGlobalSession(long) - Method in class org.apache.zookeeper.server.quorum.LocalSessionTracker
 
isGlobalSession(long) - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
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.LearnerHandlerBean
 
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
 
isInEventThread() - Static method in class org.apache.zookeeper.ClientCnxn
Tests that current thread is the main event loop.
isInitialized() - Method in class org.apache.zookeeper.server.ZKDatabase
checks to see if the zk database has been initialized or not.
isInputShutdown() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
isInputShutdown() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
isInvalid() - Method in class org.apache.zookeeper.server.ServerCnxn
 
isJvmPauseMonitorToRun() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
isJvmPauseMonitorToRun() - Method in class org.apache.zookeeper.server.ServerConfig
 
isKnown(int) - Static method in class org.apache.zookeeper.server.command.FourLetterCommands
Check if the specified command code is from a known command.
isLeader() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
isLeader() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
 
isLeader() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
 
isLeader() - Method in interface org.apache.zookeeper.server.quorum.RemotePeerMXBean
 
isLocalSession(long) - Method in class org.apache.zookeeper.server.quorum.LocalSessionTracker
 
isLocalSession(long) - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
isLocalSession() - Method in class org.apache.zookeeper.server.Request
 
isLocalSessionsEnabled() - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
isLocalSessionsEnabled() - Method in interface org.apache.zookeeper.server.SessionTracker
 
isLocalSessionsEnabled() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
isLocalSessionsUpgradingEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Whether local sessions are allowed to upgrade to global sessions
isLocalSessionsUpgradingEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
isLogFileName(String) - Static method in class org.apache.zookeeper.server.persistence.Util
Returns true if fileName is a log file name.
isModeKnown() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
Returns true if the socket mode is not yet known.
isMoreRecentThan(StateSummary) - Method in class org.apache.zookeeper.server.quorum.StateSummary
 
isMultiAddressEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
isMultiAddressEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
isMultiAddressReachabilityCheckEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
isMultiAddressReachabilityCheckEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
isOpen() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
isOptimizedForDirectBuffers() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
isOutputShutdown() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
isOutputShutdown() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
isPartOfEnsemble() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
isPartOfEnsemble() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
 
isPersistent() - Method in enum org.apache.zookeeper.server.watch.WatcherMode
 
isPlaintextSocket() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
Returns true if the socket mode has been determined to be PLAINTEXT.
isPortUnification() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
 
isPortUnification() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
 
isProviderNull() - Method in class org.apache.zookeeper.server.ServerStats
 
isQuorum() - Method in class org.apache.zookeeper.server.Request
 
isQuorumSynced(QuorumVerifier) - Method in class org.apache.zookeeper.server.quorum.Leader
Returns true if a quorum in qv is connected and synced with the leader and false otherwise
isReady() - Method in class org.apache.zookeeper.server.controller.ControllerService
Is the service up with all necessary initialization and port opening complete?
isReady() - Method in class org.apache.zookeeper.server.controller.ZooKeeperServerController
 
isReconfigEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
 
isReconfigEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
isReconfigEnabled() - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
isReconfigEnabled() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
isReconfigStateChange() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
isRecursive() - Method in enum org.apache.zookeeper.server.watch.WatcherMode
 
isResponseCachingEnabled() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
isroCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
IsroCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.IsroCommand
 
IsroCommand - Class in org.apache.zookeeper.server.command
 
IsroCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.IsroCommand
 
isRunning() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
isRunning() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
isSaslAuthRequired() - Method in class org.apache.zookeeper.server.AuthenticationHelper
 
isSaslClientEnabled() - Method in class org.apache.zookeeper.client.ZKClientConfig
Returns true if the SASL client is enabled.
isSecure() - Method in class org.apache.zookeeper.server.DumbWatcher
 
isSecure() - Method in class org.apache.zookeeper.server.NettyServerCnxn
 
isSecure() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
isSecure() - Method in class org.apache.zookeeper.server.ServerCnxn
 
isSecure() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
isSecureSocket() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
Returns true if the socket mode has been determined to be TLS.
isSelectable() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
isSequential() - Method in enum org.apache.zookeeper.CreateMode
 
isServerRequired() - Method in interface org.apache.zookeeper.server.admin.Command
 
isServerRequired() - Method in class org.apache.zookeeper.server.admin.CommandBase
 
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
isSslQuorum() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
 
isSslQuorum() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
 
isSslQuorum() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
isSslQuorum() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
isStale() - Method in class org.apache.zookeeper.server.Request
 
isStale() - Method in class org.apache.zookeeper.server.ServerCnxn
 
isStandaloneEnabled() - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
isStarted() - Method in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
isThrottlable() - Method in class org.apache.zookeeper.server.Request
 
isThrottled() - Method in class org.apache.zookeeper.server.Request
 
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
 
isTrackingSession(long) - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
isTrackingSession(long) - Method in interface org.apache.zookeeper.server.SessionTracker
 
isTrackingSession(long) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
isTTL() - Method in enum org.apache.zookeeper.CreateMode
 
isTxnLogSyncEnabled() - Method in class org.apache.zookeeper.server.ZKDatabase
 
isUpgradingSession(long) - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
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.EnsembleAuthenticationProvider
 
isValid(String) - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
 
isValid(String) - Method in class org.apache.zookeeper.server.auth.KeyAuthenticationProvider
 
isValid(String) - Method in class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
 
isValid(String) - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
 
isValidSnapshot(File) - Static method in class org.apache.zookeeper.server.persistence.SnapStream
Verifies that the file is a valid snapshot.
isZKServerRunning() - Method in class org.apache.zookeeper.server.ServerCnxn
 
iterator() - Method in class org.apache.zookeeper.MultiOperationRecord
 
iterator() - Method in class org.apache.zookeeper.MultiResponse
 
iterator() - Method in class org.apache.zookeeper.server.util.BitHashSet
This function is not thread-safe, need to synchronized when iterate through this set.
iterator() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
IWatchManager - Interface in org.apache.zookeeper.server.watch
 

J

JAAS_CONF_KEY - Static variable in class org.apache.zookeeper.Environment
 
JettyAdminServer - Class in org.apache.zookeeper.server.admin
This class encapsulates a Jetty server for running Commands.
JettyAdminServer() - Constructor for class org.apache.zookeeper.server.admin.JettyAdminServer
 
JettyAdminServer(String, int, int, String, int, boolean, boolean) - Constructor for class org.apache.zookeeper.server.admin.JettyAdminServer
 
JGSS_NATIVE - Static variable in class org.apache.zookeeper.common.ZKConfig
 
JMX_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
Deprecated.
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
 
join(long) - Method in class org.apache.zookeeper.server.WorkerService
 
joinStrings(List<String>, String) - Static method in class org.apache.zookeeper.common.StringUtils
This method takes a List<String> and a delimiter and joins the strings into a single string, where the original strings are separated using the given delimiter.
JsonOutputter - Class in org.apache.zookeeper.server.admin
 
JsonOutputter() - Constructor for class org.apache.zookeeper.server.admin.JsonOutputter
 
JUTE_MAXBUFFER - Static variable in class org.apache.zookeeper.common.ZKConfig
 
JVM_PAUSE_MONITOR_FEATURE_SWITCH_KEY - Static variable in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
JVM_PAUSE_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
jvmPauseInfoThresholdMs - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
JVM Pause Monitor info threshold in ms
jvmPauseInfoThresholdMs - Variable in class org.apache.zookeeper.server.ServerConfig
JVM Pause Monitor info threshold in ms
JvmPauseMonitor - Class in org.apache.zookeeper.server.util
This code is originally from hadoop-common, see: https://github.com/apache/hadoop/blob/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/util/JvmPauseMonitor.java Class which sets up a simple thread which runs in a loop sleeping for a short interval of time.
JvmPauseMonitor(QuorumPeerConfig) - Constructor for class org.apache.zookeeper.server.util.JvmPauseMonitor
 
JvmPauseMonitor(ServerConfig) - Constructor for class org.apache.zookeeper.server.util.JvmPauseMonitor
 
jvmPauseMonitor - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
jvmPauseMonitorToRun - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
JVM Pause Monitor feature switch
jvmPauseMonitorToRun - Variable in class org.apache.zookeeper.server.ServerConfig
JVM Pause Monitor feature switch
jvmPauseSleepTimeMs - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
JVM Pause Monitor sleep time in ms
jvmPauseSleepTimeMs - Variable in class org.apache.zookeeper.server.ServerConfig
JVM Pause Monitor sleep time in ms
jvmPauseWarnThresholdMs - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
JVM Pause Monitor warn threshold in ms
jvmPauseWarnThresholdMs - Variable in class org.apache.zookeeper.server.ServerConfig
JVM Pause Monitor warn threshold in ms

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.EphemeralOnLocalSessionException - 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.NewConfigNoQuorum - 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.NoWatcherException - Exception in org.apache.zookeeper
 
KeeperException.OperationTimeoutException - Exception in org.apache.zookeeper
 
KeeperException.QuotaExceededException - Exception in org.apache.zookeeper
 
KeeperException.ReconfigDisabledException - Exception in org.apache.zookeeper
 
KeeperException.ReconfigInProgress - Exception in org.apache.zookeeper
 
KeeperException.RequestTimeoutException - Exception in org.apache.zookeeper
 
KeeperException.RuntimeInconsistencyException - Exception in org.apache.zookeeper
 
KeeperException.SessionClosedRequireAuthException - 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.ThrottledOpException - Exception in org.apache.zookeeper
 
KeeperException.UnimplementedException - Exception in org.apache.zookeeper
 
KeeperException.UnknownSessionException - 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
 
KEY_CLIENT_PORT - Static variable in class org.apache.zookeeper.server.ZooKeeperServerConf
The key in the map returned by ZooKeeperServerConf.toMap() for the client port.
KEY_CLIENT_PORT_LISTEN_BACKLOG - Static variable in class org.apache.zookeeper.server.ZooKeeperServerConf
The key in the map returned by ZooKeeperServerConf.toMap() for the server socket listen backlog.
KEY_COMMAND - Static variable in class org.apache.zookeeper.server.admin.CommandResponse
The key in the map returned by CommandResponse.toMap() for the command name.
KEY_DATA_DIR - Static variable in class org.apache.zookeeper.server.ZooKeeperServerConf
The key in the map returned by ZooKeeperServerConf.toMap() for the data directory.
KEY_DATA_LOG_DIR - Static variable in class org.apache.zookeeper.server.ZooKeeperServerConf
The key in the map returned by ZooKeeperServerConf.toMap() for the data log directory.
KEY_ERROR - Static variable in class org.apache.zookeeper.server.admin.CommandResponse
The key in the map returned by CommandResponse.toMap() for the error string.
KEY_MAX_CLIENT_CNXNS - Static variable in class org.apache.zookeeper.server.ZooKeeperServerConf
The key in the map returned by ZooKeeperServerConf.toMap() for the maximum client connections per host.
KEY_MAX_SESSION_TIMEOUT - Static variable in class org.apache.zookeeper.server.ZooKeeperServerConf
The key in the map returned by ZooKeeperServerConf.toMap() for the maximum session timeout.
KEY_MIN_SESSION_TIMEOUT - Static variable in class org.apache.zookeeper.server.ZooKeeperServerConf
The key in the map returned by ZooKeeperServerConf.toMap() for the minimum session timeout.
KEY_NUM_CONNECTIONS - Static variable in class org.apache.zookeeper.server.watch.WatchesSummary
The key in the map returned by WatchesSummary.toMap() for the number of connections.
KEY_NUM_PATHS - Static variable in class org.apache.zookeeper.server.watch.WatchesSummary
The key in the map returned by WatchesSummary.toMap() for the number of paths.
KEY_NUM_TOTAL_WATCHES - Static variable in class org.apache.zookeeper.server.watch.WatchesSummary
The key in the map returned by WatchesSummary.toMap() for the total number of watches.
KEY_SERVER_ID - Static variable in class org.apache.zookeeper.server.ZooKeeperServerConf
The key in the map returned by ZooKeeperServerConf.toMap() for the server ID.
KEY_TICK_TIME - Static variable in class org.apache.zookeeper.server.ZooKeeperServerConf
The key in the map returned by ZooKeeperServerConf.toMap() for the tick time.
KeyAuthenticationProvider - Class in org.apache.zookeeper.server.auth
 
KeyAuthenticationProvider() - Constructor for class org.apache.zookeeper.server.auth.KeyAuthenticationProvider
 
KeyManagerException(String) - Constructor for exception org.apache.zookeeper.common.X509Exception.KeyManagerException
 
KeyManagerException(Throwable) - Constructor for exception org.apache.zookeeper.common.X509Exception.KeyManagerException
 
KeyStoreFileType - Enum in org.apache.zookeeper.common
This enum represents the file type of a KeyStore or TrustStore.
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
 
KINIT_COMMAND - Static variable in class org.apache.zookeeper.common.ZKConfig
Path to a kinit binary: "zookeeper.kinit".

L

LARGE_REQUESTS_REJECTED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
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
 
lastResponseTime - Variable in class org.apache.zookeeper.server.ServerCnxn
 
lastSeenQuorumVerifier - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
LastSnapshotCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.LastSnapshotCommand
 
lastZxid - Variable in class org.apache.zookeeper.server.quorum.LearnerHandler
 
lastZxid - Variable in class org.apache.zookeeper.server.ServerCnxn
 
Leader - Class in org.apache.zookeeper.server.quorum
This class has the control logic for the Leader.
Leader(QuorumPeer, LeaderZooKeeperServer) - Constructor for class org.apache.zookeeper.server.quorum.Leader
 
leader - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
Leader.Proposal - Class in org.apache.zookeeper.server.quorum
 
Leader.XidRolloverException - Exception in org.apache.zookeeper.server.quorum
 
LEADER_CLOSE_SOCKET_ASYNC - Static variable in class org.apache.zookeeper.server.quorum.LearnerHandler
 
LEADER_UNAVAILABLE_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
leaderAddr - Variable in class org.apache.zookeeper.server.quorum.Learner
 
LeaderBean - Class in org.apache.zookeeper.server.quorum
Leader MBean interface implementation.
LeaderBean(Leader, ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.quorum.LeaderBean
 
LeaderCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.LeaderCommand
 
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
LeaderRequestProcessor - Class in org.apache.zookeeper.server.quorum
Responsible for performing local session upgrade.
LeaderRequestProcessor(LeaderZooKeeperServer, RequestProcessor) - Constructor for class org.apache.zookeeper.server.quorum.LeaderRequestProcessor
 
LeaderSessionTracker - Class in org.apache.zookeeper.server.quorum
The leader session tracker tracks local and global sessions on the leader.
LeaderSessionTracker(SessionTracker.SessionExpirer, ConcurrentMap<Long, Integer>, int, long, boolean, ZooKeeperServerListener) - Constructor for class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
LeaderZooKeeperServer - Class in org.apache.zookeeper.server.quorum
Just like the standard ZooKeeperServer.
LeaderZooKeeperServer(FileTxnSnapLog, QuorumPeer, ZKDatabase) - Constructor for class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
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
 
LEARNER_ASYNC_SENDING - Static variable in class org.apache.zookeeper.server.quorum.Learner
 
LEARNER_CLOSE_SOCKET_ASYNC - Static variable in class org.apache.zookeeper.server.quorum.Learner
 
LEARNER_COMMIT_RECEIVED_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
LEARNER_HANDLER_QP_SIZE - Variable in class org.apache.zookeeper.server.ServerMetrics
Learner handler quorum packet metrics.
LEARNER_HANDLER_QP_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
LEARNER_PROPOSAL_RECEIVED_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
LEARNER_REQUEST_PROCESSOR_QUEUE_SIZE - Variable in class org.apache.zookeeper.server.ServerMetrics
 
LearnerHandler - Class in org.apache.zookeeper.server.quorum
There will be an instance of this class created by the Leader for each learner.
LearnerHandlerBean - Class in org.apache.zookeeper.server.quorum
 
LearnerHandlerBean(LearnerHandler, Socket) - Constructor for class org.apache.zookeeper.server.quorum.LearnerHandlerBean
 
LearnerHandlerMXBean - Interface in org.apache.zookeeper.server.quorum
This MBean represents a server connection for a learner.
LearnerMaster - Class in org.apache.zookeeper.server.quorum
interface for keeping Observers in sync
LearnerMaster() - Constructor for class org.apache.zookeeper.server.quorum.LearnerMaster
 
LearnerSender - Class in org.apache.zookeeper.server.quorum
 
LearnerSender(Learner) - Constructor for class org.apache.zookeeper.server.quorum.LearnerSender
 
LearnerSessionTracker - Class in org.apache.zookeeper.server.quorum
The learner session tracker is used by learners (followers and observers) to track zookeeper sessions which may or may not be echoed to the leader.
LearnerSessionTracker(SessionTracker.SessionExpirer, ConcurrentMap<Long, Integer>, int, long, boolean, 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
 
LearnerSyncThrottler - Class in org.apache.zookeeper.server.quorum
Utility class to limit the number of concurrent syncs from a leader to observers and followers or from a follower to observers.
LearnerSyncThrottler(int, LearnerSyncThrottler.SyncType) - Constructor for class org.apache.zookeeper.server.quorum.LearnerSyncThrottler
Constructs a new instance limiting the concurrent number of syncs to maxConcurrentSyncs.
LearnerSyncThrottler.SyncType - Enum in org.apache.zookeeper.server.quorum
 
LearnerZooKeeperServer - Class in org.apache.zookeeper.server.quorum
Parent class for all ZooKeeperServers for Learners
LearnerZooKeeperServer(FileTxnSnapLog, int, int, int, int, 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
limitPath(String) - Static method in class org.apache.zookeeper.Quotas
return the limit quota path associated with this prefix
limitTotalNumberOfCnxns() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
Ensure total number of connections are less than the maxCnxns
list() - Static method in class org.apache.zookeeper.Environment
 
listenBacklog - Variable in class org.apache.zookeeper.server.ServerConfig
defaults to -1 if not set explicitly
listenBacklog - Variable in class org.apache.zookeeper.server.ZooKeeperServer
Socket listen backlog.
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
 
listQuota(ZooKeeper, String) - Static method in class org.apache.zookeeper.cli.ListQuotaCommand
 
ListQuotaCommand - Class in org.apache.zookeeper.cli
listQuota command for cli
ListQuotaCommand() - Constructor for class org.apache.zookeeper.cli.ListQuotaCommand
 
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.
loadKeyStore(String, String, String) - Static method in class org.apache.zookeeper.common.X509Util
 
loadKeyStore(File, File, Optional<String>) - Static method in class org.apache.zookeeper.util.PemReader
 
loadPrivateKey(File, Optional<String>) - Static method in class org.apache.zookeeper.util.PemReader
 
loadPrivateKey(String, Optional<String>) - Static method in class org.apache.zookeeper.util.PemReader
 
loadPublicKey(File) - Static method in class org.apache.zookeeper.util.PemReader
 
loadPublicKey(String) - Static method in class org.apache.zookeeper.util.PemReader
 
loadTrustStore(String, String, String) - Static method in class org.apache.zookeeper.common.X509Util
 
loadTrustStore(File) - Static method in class org.apache.zookeeper.util.PemReader
 
LOCAL_SESSION_WEIGHT - Static variable in class org.apache.zookeeper.server.BlueThrottle
 
LOCAL_WRITE_COMMITTED_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
Time spent by a committed request, for a locally issued write, in the commit processor.
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.
localSessions() - Method in class org.apache.zookeeper.server.quorum.LocalSessionTracker
 
localSessions() - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
localSessions() - Method in interface org.apache.zookeeper.server.SessionTracker
Get a set of local session IDs
localSessions() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
localSessionsEnabled - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
Whether learners in this quorum should create new sessions as local.
localSessionsEnabled - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
localSessionsEnabled - Variable in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
localSessionsUpgradingEnabled - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
Whether learners in this quorum should upgrade local sessions to global.
localSessionsUpgradingEnabled - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
LocalSessionTracker - Class in org.apache.zookeeper.server.quorum
Local session tracker.
LocalSessionTracker(SessionTracker.SessionExpirer, ConcurrentMap<Long, Integer>, int, long, ZooKeeperServerListener) - Constructor for class org.apache.zookeeper.server.quorum.LocalSessionTracker
 
localSessionTracker - Variable in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
log(String, String, String, String, String, String, String, AuditEvent.Result) - Static method in class org.apache.zookeeper.audit.ZKAuditProvider
 
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
 
LOG_ONLY - Static variable in class org.apache.zookeeper.util.ServiceUtils
No-op strategy, useful for tests.
logAuditEvent(AuditEvent) - Method in interface org.apache.zookeeper.audit.AuditLogger
Called to log an audit event.
logAuditEvent(AuditEvent) - Method in class org.apache.zookeeper.audit.Slf4jAuditLogger
 
LogChopper - Class in org.apache.zookeeper.server.util
this class will chop the log at the specified zxid
LogChopper() - Constructor for class org.apache.zookeeper.server.util.LogChopper
 
LogDirContentCheckException(String) - Constructor for exception org.apache.zookeeper.server.persistence.FileTxnSnapLog.LogDirContentCheckException
 
logEnv(String, Logger) - Static method in class org.apache.zookeeper.Environment
 
Login - Class in org.apache.zookeeper
 
Login(String, CallbackHandler, ZKConfig) - Constructor for class org.apache.zookeeper.Login
LoginThread constructor.
login() - Method in class org.apache.zookeeper.server.auth.DigestLoginModule
 
login - Variable in class org.apache.zookeeper.server.ServerCnxnFactory
 
LOGIN_CONTEXT_NAME_KEY - Static variable in class org.apache.zookeeper.client.ZKClientConfig
 
LOGIN_CONTEXT_NAME_KEY - Static variable in class org.apache.zookeeper.client.ZooKeeperSaslClient
Deprecated.
LOGIN_CONTEXT_NAME_KEY - Static variable in class org.apache.zookeeper.server.ZooKeeperSaslServer
 
LOGIN_CONTEXT_NAME_KEY_DEFAULT - Static variable in class org.apache.zookeeper.client.ZKClientConfig
 
logLatency(Summary) - Method in class org.apache.zookeeper.server.Request
 
logLatency(Summary, long) - Method in class org.apache.zookeeper.server.Request
 
logLatency(SummarySet, String, long) - Method in class org.apache.zookeeper.server.Request
 
logLatency(SummarySet, String) - Method in class org.apache.zookeeper.server.Request
 
logLock - Variable in class org.apache.zookeeper.server.ZKDatabase
 
logout() - Method in class org.apache.zookeeper.Login
 
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, TxnDigest) - 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 interface org.apache.zookeeper.server.quorum.Election
 
lookForLeader() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
Starts a new round of leader election.
LOOKING_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
LOOKING_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
 
LsCommand - Class in org.apache.zookeeper.cli
ls command for cli
LsCommand() - Constructor for class org.apache.zookeeper.cli.LsCommand
 

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.controller.ControllerService
Starts the ControllerService as a stand alone app.
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.SnapshotComparer
 
main(String[]) - Static method in class org.apache.zookeeper.server.SnapshotFormatter
USAGE: SnapshotFormatter snapshot_file or the ready-made script: zkSnapShotToolkit.sh
main(String[]) - Static method in class org.apache.zookeeper.server.TraceFormatter
 
main(String[]) - Static method in class org.apache.zookeeper.server.util.LogChopper
 
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.VersionInfoMain
 
main(String[]) - Static method in class org.apache.zookeeper.ZooKeeperMain
 
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
 
MalformedCommandException - Exception in org.apache.zookeeper.cli
 
MalformedCommandException(String) - Constructor for exception org.apache.zookeeper.cli.MalformedCommandException
 
MalformedPathException - Exception in org.apache.zookeeper.cli
 
MalformedPathException(String) - Constructor for exception org.apache.zookeeper.cli.MalformedPathException
 
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
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.
marshallTxnEntry(TxnHeader, Record, TxnDigest) - Static method in class org.apache.zookeeper.server.persistence.Util
 
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.EnsembleAuthenticationProvider
 
matches(String, String) - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
 
matches(ServerAuthenticationProvider.ServerObjs, ServerAuthenticationProvider.MatchValues) - Method in class org.apache.zookeeper.server.auth.KeyAuthenticationProvider
 
matches(String, String) - Method in class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
 
matches(ServerAuthenticationProvider.ServerObjs, ServerAuthenticationProvider.MatchValues) - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider
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.ServerAuthenticationProvider
 
matches(String, String) - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
 
MatchValues(String, String, String, int, List<ACL>) - Constructor for class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.MatchValues
 
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.
MAX_EXTENDED_SERVER_ID - Static variable in enum org.apache.zookeeper.server.EphemeralType
 
MAX_NOTIFICATION_INTERVAL - Static variable in class org.apache.zookeeper.server.quorum.FastLeaderElection
Maximum notification interval, default is 60s
MAX_TIME_TO_WAIT_FOR_EPOCH - Static variable in class org.apache.zookeeper.server.quorum.Leader
 
MAX_TTL - Static variable in enum org.apache.zookeeper.server.EphemeralTypeEmulate353
 
maxBuffer - Static variable in class org.apache.zookeeper.server.quorum.QuorumCnxManager
 
maxClientCnxns - Variable in class org.apache.zookeeper.server.NIOServerCnxnFactory
 
maxClientCnxns - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
maxClientCnxns - Variable in class org.apache.zookeeper.server.ServerConfig
 
maxCnxns - Variable in class org.apache.zookeeper.server.ServerCnxnFactory
 
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
maxValue() - Method in enum org.apache.zookeeper.server.EphemeralType
For types that support it, the maximum extended value
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
 
MESSAGE_TRACKER_BUFFER_SIZE - Static variable in class org.apache.zookeeper.server.util.MessageTracker
 
MESSAGE_TRACKER_ENABLED - Static variable in class org.apache.zookeeper.server.util.MessageTracker
 
messageTracker - Variable in class org.apache.zookeeper.server.quorum.Learner
 
messageTracker - Variable in class org.apache.zookeeper.server.quorum.LearnerHandler
 
MessageTracker - Class in org.apache.zookeeper.server.util
This class provides a way of buffering sentBuffer and receivedBuffer messages in order.
MessageTracker(int) - Constructor for class org.apache.zookeeper.server.util.MessageTracker
 
Metric - Class in org.apache.zookeeper.server.metric
 
Metric() - Constructor for class org.apache.zookeeper.server.metric.Metric
 
MetricsContext - Interface in org.apache.zookeeper.metrics
A MetricsContext is like a namespace for metrics.
MetricsContext.DetailLevel - Enum in org.apache.zookeeper.metrics
 
MetricsProvider - Interface in org.apache.zookeeper.metrics
A MetricsProvider is a system which collects Metrics and publishes current values to external facilities.
MetricsProviderBootstrap - Class in org.apache.zookeeper.metrics.impl
Utility for bootstrap process of MetricsProviders
MetricsProviderBootstrap() - Constructor for class org.apache.zookeeper.metrics.impl.MetricsProviderBootstrap
 
metricsProviderClassName - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
metricsProviderClassName - Variable in class org.apache.zookeeper.server.ServerConfig
 
metricsProviderConfiguration - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
metricsProviderConfiguration - Variable in class org.apache.zookeeper.server.ServerConfig
 
metricsProviderInitialized(MetricsProvider) - Static method in class org.apache.zookeeper.server.ServerMetrics
 
MetricsProviderLifeCycleException - Exception in org.apache.zookeeper.metrics
A generic exception thrown during the licecycle of a MetricsProvider.
MetricsProviderLifeCycleException() - Constructor for exception org.apache.zookeeper.metrics.MetricsProviderLifeCycleException
 
MetricsProviderLifeCycleException(String) - Constructor for exception org.apache.zookeeper.metrics.MetricsProviderLifeCycleException
 
MetricsProviderLifeCycleException(String, Throwable) - Constructor for exception org.apache.zookeeper.metrics.MetricsProviderLifeCycleException
 
MetricsProviderLifeCycleException(Throwable) - Constructor for exception org.apache.zookeeper.metrics.MetricsProviderLifeCycleException
 
MICRO - Static variable in interface org.apache.zookeeper.version.Info
 
MIN_NOTIFICATION_INTERVAL - Static variable in class org.apache.zookeeper.server.quorum.FastLeaderElection
Minimum notification interval, default is equal to finalizeWait
MIN_TIME_BEFORE_RELOGIN_CONFIG_KEY - Static variable in class org.apache.zookeeper.Login
 
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.command.FourLetterCommands
 
MonitorCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.MonitorCommand
 
MonitorCommand - Class in org.apache.zookeeper.server.command
 
multi - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
multi(Iterable<Op>) - Method in class org.apache.zookeeper.ZooKeeper
Executes multiple ZooKeeper operations.
multi(Iterable<Op>, AsyncCallback.MultiCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of multi.
multiInternal(MultiOperationRecord, AsyncCallback.MultiCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
 
multiInternal(MultiOperationRecord) - Method in class org.apache.zookeeper.ZooKeeper
 
MultiOperationRecord - Class in org.apache.zookeeper
Encodes a composite operation.
MultiOperationRecord() - Constructor for class org.apache.zookeeper.MultiOperationRecord
 
MultiOperationRecord(Iterable<Op>) - Constructor for class org.apache.zookeeper.MultiOperationRecord
 
MultipleAddresses - Class in org.apache.zookeeper.server.quorum
This class allows to store several quorum and electing addresses.
MultipleAddresses() - Constructor for class org.apache.zookeeper.server.quorum.MultipleAddresses
 
MultipleAddresses(Collection<InetSocketAddress>) - Constructor for class org.apache.zookeeper.server.quorum.MultipleAddresses
 
MultipleAddresses(InetSocketAddress) - Constructor for class org.apache.zookeeper.server.quorum.MultipleAddresses
 
MultipleAddresses(Collection<InetSocketAddress>, Duration) - Constructor for class org.apache.zookeeper.server.quorum.MultipleAddresses
 
multiRead - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
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
 
mustDrop() - Method in class org.apache.zookeeper.server.Request
A prior request was dropped on this request's connection and therefore this request must also be dropped to ensure correct ordering semantics.

N

nanoTime() - Method in class org.apache.zookeeper.server.quorum.Learner
Overridable helper method to return the System.nanoTime().
needCommit(Request) - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
 
NETTY_ADVANCED_FLOW_CONTROL - Static variable in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
NETTY_QUEUED_BUFFER - Variable in class org.apache.zookeeper.server.ServerMetrics
 
NettyServerCnxn - Class in org.apache.zookeeper.server
 
NettyServerCnxn.HandshakeState - Enum in org.apache.zookeeper.server
 
NettyServerCnxnFactory - Class in org.apache.zookeeper.server
 
NettyUtils - Class in org.apache.zookeeper.common
Helper methods for netty code.
NettyUtils() - Constructor for class org.apache.zookeeper.common.NettyUtils
 
NetUtils - Class in org.apache.zookeeper.common
This class contains common utilities for netstuff.
NetUtils() - Constructor for class org.apache.zookeeper.common.NetUtils
 
NewConfigNoQuorum - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.NEWCONFIGNOQUORUM instead
NewConfigNoQuorum() - Constructor for exception org.apache.zookeeper.KeeperException.NewConfigNoQuorum
 
newConnection(Connector, EndPoint) - Method in class org.apache.zookeeper.server.admin.UnifiedConnectionFactory
 
newLeaderProposal - Variable in class org.apache.zookeeper.server.quorum.Leader
 
newNioOrEpollEventLoopGroup() - Static method in class org.apache.zookeeper.common.NettyUtils
If Epoll.isAvailable() == true, returns a new EpollEventLoopGroup, otherwise returns a new NioEventLoopGroup.
newNioOrEpollEventLoopGroup(int) - Static method in class org.apache.zookeeper.common.NettyUtils
If Epoll.isAvailable() == true, returns a new EpollEventLoopGroup, otherwise returns a new NioEventLoopGroup.
newSslConnection(Connector, EndPoint, SSLEngine) - Method in class org.apache.zookeeper.server.admin.UnifiedConnectionFactory
 
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
 
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() - Method in class org.apache.zookeeper.server.TxnLogProposalIterator
Proposal returned by this iterator has request part set to null, since it is not used for follower sync-up.
next() - Method in class org.apache.zookeeper.server.watch.PathParentIterator
 
nextDynamicConfigFileSuffix - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
nextPacketIsAuth(DataInputStream) - Static method in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
 
nioOrEpollServerSocketChannel() - Static method in class org.apache.zookeeper.common.NettyUtils
If Epoll.isAvailable() == true, returns EpollServerSocketChannel, otherwise returns NioServerSocketChannel.
nioOrEpollSocketChannel() - Static method in class org.apache.zookeeper.common.NettyUtils
If Epoll.isAvailable() == true, returns EpollSocketChannel, otherwise returns NioSocketChannel.
NIOServerCnxn - Class in org.apache.zookeeper.server
This class handles communication with clients using NIO.
NIOServerCnxn(ZooKeeperServer, SocketChannel, SelectionKey, NIOServerCnxnFactory, NIOServerCnxnFactory.SelectorThread) - Constructor for class org.apache.zookeeper.server.NIOServerCnxn
 
NIOServerCnxnFactory - Class in org.apache.zookeeper.server
NIOServerCnxnFactory implements a multi-threaded ServerCnxnFactory using NIO non-blocking socket calls.
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).
NIOServerCnxnFactory.SelectorThread - Class in org.apache.zookeeper.server
The SelectorThread receives newly accepted connections from the AcceptThread and is responsible for selecting for I/O readiness across the connections.
NoAuth - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.NOAUTH instead
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
NoChildrenForEphemeralsException() - Constructor for exception org.apache.zookeeper.KeeperException.NoChildrenForEphemeralsException
 
NoChildrenForEphemeralsException(String) - Constructor for exception org.apache.zookeeper.KeeperException.NoChildrenForEphemeralsException
 
NODE_CHANGED_WATCHER - Variable in class org.apache.zookeeper.server.ServerMetrics
 
NODE_CHILDREN_WATCHER - Variable in class org.apache.zookeeper.server.ServerMetrics
 
NODE_CREATED_WATCHER - Variable in class org.apache.zookeeper.server.ServerMetrics
Fired watcher stats.
NODE_DELETED_WATCHER - Variable in class org.apache.zookeeper.server.ServerMetrics
 
NodeExists - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.NODEEXISTS instead
NodeExistsException() - Constructor for exception org.apache.zookeeper.KeeperException.NodeExistsException
 
NodeExistsException(String) - Constructor for exception org.apache.zookeeper.KeeperException.NodeExistsException
 
NodeHashMap - Interface in org.apache.zookeeper.server
The interface defined to manage the hash based on the entries in the nodes map.
NodeHashMapImpl - Class in org.apache.zookeeper.server
a simple wrapper to ConcurrentHashMap that recalculates a digest after each mutation.
NodeHashMapImpl(DigestCalculator) - Constructor for class org.apache.zookeeper.server.NodeHashMapImpl
 
NoNode - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.NONODE instead
NoNodeException() - Constructor for exception org.apache.zookeeper.KeeperException.NoNodeException
 
NoNodeException(String) - Constructor for exception org.apache.zookeeper.KeeperException.NoNodeException
 
nonVotingFollowerInfo() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
 
nonVotingFollowerInfo() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
 
NopCommand - Class in org.apache.zookeeper.server.command
A command that does not do anything except reply to client with predefined message.
NopCommand(PrintWriter, ServerCnxn, String) - Constructor for class org.apache.zookeeper.server.command.NopCommand
 
normalizeFileSystemPath(String) - Static method in class org.apache.zookeeper.common.PathUtils
Convert Windows path to Unix
NotEmpty - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.NOTEMPTY instead
NotEmptyException() - Constructor for exception org.apache.zookeeper.KeeperException.NotEmptyException
 
NotEmptyException(String) - Constructor for exception org.apache.zookeeper.KeeperException.NotEmptyException
 
Notification() - Constructor for class org.apache.zookeeper.server.quorum.FastLeaderElection.Notification
 
notification - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
NOTIFICATION_XID - Static variable in class org.apache.zookeeper.ClientCnxn
 
notifyStopping(String, int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerListener
This will notify the server that some critical thread has stopped.
NotReadOnlyException() - Constructor for exception org.apache.zookeeper.KeeperException.NotReadOnlyException
 
NoWatcherException() - Constructor for exception org.apache.zookeeper.KeeperException.NoWatcherException
 
NoWatcherException(String) - Constructor for exception org.apache.zookeeper.KeeperException.NoWatcherException
 
NULL_METRICS - Static variable in class org.apache.zookeeper.server.ServerMetrics
Dummy instance useful for tests.
NullMetricsContext() - Constructor for class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
 
NullMetricsProvider - Class in org.apache.zookeeper.metrics.impl
This is a dummy MetricsProvider which does nothing.
NullMetricsProvider() - Constructor for class org.apache.zookeeper.metrics.impl.NullMetricsProvider
 
NullMetricsProvider.NullMetricsContext - Class in org.apache.zookeeper.metrics.impl
 
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
 
numRequestsProcessing - Variable in class org.apache.zookeeper.server.quorum.CommitProcessor
The number of requests currently being processed

O

Observer - Class in org.apache.zookeeper.server.quorum
Observers are peers that do not take part in the atomic broadcast protocol.
observer - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
OBSERVER_ELECTION_DELAY_MS - Static variable in class org.apache.zookeeper.server.quorum.Observer
Delay the Observer's participation in a leader election upon disconnect so as to prevent unexpected additional load on the voting peers during the process.
OBSERVER_RECONNECT_DELAY_MS - Static variable in class org.apache.zookeeper.server.quorum.Observer
When observer lost its connection with the leader, it waits for 0 to the specified value before trying to reconnect with the leader.
OBSERVER_SYNC_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
ObserverBean - Class in org.apache.zookeeper.server
ObserverBean
ObserverBean(Observer, ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.ObserverBean
 
ObserverCnxnStatResetCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.ObserverCnxnStatResetCommand
 
ObserverMaster - Class in org.apache.zookeeper.server.quorum
Used by Followers to host Observers.
observerMasterPort - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
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.
ObserverZooKeeperServer - Class in org.apache.zookeeper.server.quorum
A ZooKeeperServer for the Observer node type.
OBSERVING_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
 
offer(E) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
This method differs from BlockingQueue.offer(Object) in that it will remove the oldest queued element (the element at the front of the queue) in order to make room for any new elements if the queue is full.
offer(E, long, TimeUnit) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
Ok - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.OK instead
ok - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
OM_COMMIT_PROCESS_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
OM_PROPOSAL_PROCESS_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
Observer Master processing metrics.
onClose() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
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
 
onConnecting(InetSocketAddress) - Method in class org.apache.zookeeper.ClientCnxn
 
onOpen() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
onTxnLoaded(TxnHeader, Record, TxnDigest) - Method in interface org.apache.zookeeper.server.persistence.FileTxnSnapLog.PlayBackListener
 
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.CreateTTL - Class in org.apache.zookeeper
 
Op.Delete - Class in org.apache.zookeeper
 
Op.GetChildren - Class in org.apache.zookeeper
 
Op.GetData - Class in org.apache.zookeeper
 
Op.OpKind - Enum in org.apache.zookeeper
 
Op.SetData - Class in org.apache.zookeeper
 
op2String(int) - Static method in class org.apache.zookeeper.server.Request
 
OP_CREATE - Static variable in class org.apache.zookeeper.audit.AuditConstants
 
OP_DEL_EZNODE_EXP - Static variable in class org.apache.zookeeper.audit.AuditConstants
 
OP_DELETE - Static variable in class org.apache.zookeeper.audit.AuditConstants
 
OP_MULTI_OP - Static variable in class org.apache.zookeeper.audit.AuditConstants
 
OP_RECONFIG - Static variable in class org.apache.zookeeper.audit.AuditConstants
 
OP_SETACL - Static variable in class org.apache.zookeeper.audit.AuditConstants
 
OP_SETDATA - Static variable in class org.apache.zookeeper.audit.AuditConstants
 
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
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.GetChildrenResult - Class in org.apache.zookeeper
A result from a getChildren operation.
OpResult.GetDataResult - Class in org.apache.zookeeper
A result from a getData operation.
OpResult.SetDataResult - Class in org.apache.zookeeper
A result from a setData operation.
oraclePath - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
org.apache.zookeeper - package org.apache.zookeeper
 
org.apache.zookeeper.admin - package org.apache.zookeeper.admin
 
org.apache.zookeeper.audit - package org.apache.zookeeper.audit
 
org.apache.zookeeper.cli - package org.apache.zookeeper.cli
 
org.apache.zookeeper.client - package org.apache.zookeeper.client
 
org.apache.zookeeper.common - package org.apache.zookeeper.common
 
org.apache.zookeeper.jmx - package org.apache.zookeeper.jmx
 
org.apache.zookeeper.metrics - package org.apache.zookeeper.metrics
 
org.apache.zookeeper.metrics.impl - package org.apache.zookeeper.metrics.impl
 
org.apache.zookeeper.server - package org.apache.zookeeper.server
ZooKeeper server theory of operation
org.apache.zookeeper.server.admin - package org.apache.zookeeper.server.admin
 
org.apache.zookeeper.server.auth - package org.apache.zookeeper.server.auth
 
org.apache.zookeeper.server.command - package org.apache.zookeeper.server.command
 
org.apache.zookeeper.server.controller - package org.apache.zookeeper.server.controller
 
org.apache.zookeeper.server.embedded - package org.apache.zookeeper.server.embedded
 
org.apache.zookeeper.server.metric - package org.apache.zookeeper.server.metric
 
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.util - package org.apache.zookeeper.server.util
 
org.apache.zookeeper.server.watch - package org.apache.zookeeper.server.watch
 
org.apache.zookeeper.util - package org.apache.zookeeper.util
 
org.apache.zookeeper.version - package org.apache.zookeeper.version
 
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.
out - Variable in class org.apache.zookeeper.cli.CliCommand
 
out - Variable in class org.apache.zookeeper.cli.StatPrinter
 
output(CommandResponse, PrintWriter) - Method in interface org.apache.zookeeper.server.admin.CommandOutputter
 
output(CommandResponse, PrintWriter) - Method in class org.apache.zookeeper.server.admin.JsonOutputter
 
OUTSTANDING_CHANGES_QUEUED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
OUTSTANDING_CHANGES_REMOVED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
OUTSTANDING_HANDSHAKE_LIMIT - Static variable in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
overrideQuorumDecision(List<LearnerHandler>) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
 
overrideQuorumDecision(List<LearnerHandler>) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 

P

packet - Variable in class org.apache.zookeeper.server.quorum.Leader.Proposal
 
packetReceived(long) - 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.quorum.LearnerHandler
 
packetsReceived - Variable in class org.apache.zookeeper.server.ServerCnxn
 
packetsSent - Variable in class org.apache.zookeeper.server.quorum.LearnerHandler
 
packetsSent - Variable in class org.apache.zookeeper.server.ServerCnxn
 
packetToString(QuorumPacket) - Static method in class org.apache.zookeeper.server.quorum.LearnerHandler
 
parse(String) - Static method in class org.apache.zookeeper.cli.AclParser
parse string into list of ACL
parse(String[]) - Method in class org.apache.zookeeper.cli.AddAuthCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.AddWatchCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.CliCommand
parse the command arguments
parse(String[]) - Method in class org.apache.zookeeper.cli.CloseCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.CreateCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.DeleteAllCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.DeleteCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.DelQuotaCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.GetAclCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.GetAllChildrenNumberCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.GetCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.GetConfigCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.GetEphemeralsCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.ListQuotaCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.LsCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.ReconfigCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.RemoveWatchesCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.SetAclCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.SetCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.SetQuotaCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.StatCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.SyncCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.VersionCommand
 
parse(String[]) - Method in class org.apache.zookeeper.cli.WhoAmICommand
 
parse(String) - Method in class org.apache.zookeeper.server.controller.ControllerServerConfig
 
parse(Long, DataInputStream) - Static method in class org.apache.zookeeper.server.quorum.QuorumCnxManager.InitialMessage
 
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 arguments for server configuration
parse(String) - Method in class org.apache.zookeeper.server.ServerConfig
Parse a ZooKeeper configuration file
parseDynamicConfig(Properties, int, boolean, boolean, String) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
Parse dynamic configuration file and return quorumVerifier for new 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.
parseUri(String) - Static method in class org.apache.zookeeper.server.controller.ControlCommand
Parse a Uri into the required Command action and parameter.
path - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
 
PATH_STATS_COLLECTOR_DELAY - Static variable in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
PATH_STATS_COLLECTOR_INITIAL_DELAY - Static variable in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
PATH_STATS_ENABLED - Static variable in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
PATH_STATS_MAX_DEPTH - Static variable in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
PATH_STATS_SAMPLE_RATE - Static variable in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
PATH_STATS_SLOT_CAPACITY - Static variable in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
PATH_STATS_SLOT_DURATION - Static variable in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
PATH_STATS_TOP_PATH_MAX - Static variable in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
PathParentIterator - Class in org.apache.zookeeper.server.watch
Iterates over a ZooKeeper path.
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.
PathUtils - Class in org.apache.zookeeper.common
Path related utilities
PathUtils() - Constructor for class org.apache.zookeeper.common.PathUtils
 
peek() - Method in class org.apache.zookeeper.server.util.CircularBuffer
 
peek() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
peekReceived() - Method in class org.apache.zookeeper.server.util.MessageTracker
 
peekReceivedTimestamp() - Method in class org.apache.zookeeper.server.util.MessageTracker
 
peekSent() - Method in class org.apache.zookeeper.server.util.MessageTracker
 
peekSentTimestamp() - Method in class org.apache.zookeeper.server.util.MessageTracker
 
peerType - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
PemReader - Class in org.apache.zookeeper.util
Note: this class is copied from io.airlift.security.pem.PemReader (see https://github.com/airlift/airlift/blob/master/security/src/main/java/io/airlift/security/pem/PemReader.java) with permission of the authors, to avoid adding an extra library dependency to Zookeeper.
PENDING_SESSION_QUEUE_SIZE - Variable in class org.apache.zookeeper.server.ServerMetrics
 
pendingRequests - Variable in class org.apache.zookeeper.server.quorum.CommitProcessor
Requests that we are holding until commit comes in.
persistent - Static variable in interface org.apache.zookeeper.ZooDefs.AddWatchModes
 
persistentRecursive - Static variable in interface org.apache.zookeeper.ZooDefs.AddWatchModes
 
ping(QuorumPacket) - Method in class org.apache.zookeeper.server.quorum.Learner
 
ping() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
ping calls from the learnerMaster to the peers
ping - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
PING_XID - Static variable in class org.apache.zookeeper.ClientCnxn
 
poll() - Method in class org.apache.zookeeper.server.ExpiryQueue
Remove the next expired set of elements from expireMap.
poll(long, TimeUnit) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
poll() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
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_UNIFICATION_KEY - Static variable in class org.apache.zookeeper.server.NettyServerCnxnFactory
Allow client-server sockets to accept both SSL and plaintext connections
postChange(String, DataNode) - Method in interface org.apache.zookeeper.server.NodeHashMap
Called after making the changes on the node, which will update the digest.
postChange(String, DataNode) - Method in class org.apache.zookeeper.server.NodeHashMapImpl
 
postDeleteRequest(Request) - Method in class org.apache.zookeeper.server.ContainerManager
 
preChange(String, DataNode) - Method in interface org.apache.zookeeper.server.NodeHashMap
Called before we made the change on the node, which will clear the digest associated with it.
preChange(String, DataNode) - Method in class org.apache.zookeeper.server.NodeHashMapImpl
 
PREP_PROCESS_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
PREP_PROCESSOR_QUEUE_SIZE - Variable in class org.apache.zookeeper.server.ServerMetrics
 
PREP_PROCESSOR_QUEUE_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
PREP_PROCESSOR_QUEUED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
PrependableSocket - Class in org.apache.zookeeper.server.quorum
 
PrependableSocket(SocketImpl) - Constructor for class org.apache.zookeeper.server.quorum.PrependableSocket
 
prependToInputStream(byte[], int, int) - Method in class org.apache.zookeeper.server.quorum.PrependableSocket
Prepend some bytes that have already been read back to the socket's input stream.
prepQueueStartTime - Variable in class org.apache.zookeeper.server.Request
 
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
 
PrepRequestProcessor.DigestOpCode - Enum in org.apache.zookeeper.server
 
prepStartTime - Variable in class org.apache.zookeeper.server.Request
 
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.
print(Stat) - Method in class org.apache.zookeeper.cli.StatPrinter
 
printBanner(Logger) - Static method in class org.apache.zookeeper.ZookeeperBanner
 
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(long) - Method in interface org.apache.zookeeper.DigestWatcher
Called when the digest mismatch is found on a given zxid.
process(WatchedEvent) - Method in class org.apache.zookeeper.server.DumbWatcher
 
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
processAck(long, long, SocketAddress) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
processCmd(ZooKeeperMain.MyCommandOptions) - Method in class org.apache.zookeeper.ZooKeeperMain
 
processCommand(ControlCommand) - Method in class org.apache.zookeeper.server.controller.ZooKeeperServerController
Process the command.
processConnectRequest(ServerCnxn, ByteBuffer) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
processDeadWatchers(Set<Integer>) - Method in interface org.apache.zookeeper.server.watch.IDeadWatcherListener
Process the given dead watchers.
processDeadWatchers(Set<Integer>) - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
Entry for WatcherCleaner to remove dead watchers
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
 
processReconfig(QuorumVerifier, Long, Long, boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
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.LeaderRequestProcessor
 
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, List<ACL>, Stat) - Method in interface org.apache.zookeeper.AsyncCallback.ACLCallback
Process the result of the asynchronous call.
processResult(int, String, Object, int) - Method in interface org.apache.zookeeper.AsyncCallback.AllChildrenNumberCallback
 
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<String>) - Method in interface org.apache.zookeeper.AsyncCallback.ChildrenCallback
Process the result of the asynchronous call.
processResult(int, String, Object, String, Stat) - Method in interface org.apache.zookeeper.AsyncCallback.Create2Callback
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 asynchronous calls.
processResult(int, Object, List<String>) - Method in interface org.apache.zookeeper.AsyncCallback.EphemeralsCallback
 
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.
processResult(int, String, Object, String) - Method in interface org.apache.zookeeper.AsyncCallback.StringCallback
Process the result of the asynchronous call.
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 class org.apache.zookeeper.client.ZooKeeperSaslClient.ServerSaslResponseCallback
 
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, TxnDigest) - Method in class org.apache.zookeeper.server.DataTree
 
processTxn(TxnHeader, Record) - Method in class org.apache.zookeeper.server.DataTree
 
processTxn(TxnHeader, Record, boolean) - Method in class org.apache.zookeeper.server.DataTree
 
processTxn(TxnHeader, Record, TxnDigest) - Method in class org.apache.zookeeper.server.ZKDatabase
the process txn on the data and perform digest comparision.
processTxn(TxnHeader, Record) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
processTxn(Request) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
ProcessTxnResult() - Constructor for class org.apache.zookeeper.server.DataTree.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
PROPAGATION_LATENCY - Variable in class org.apache.zookeeper.server.ServerMetrics
Stats for all quorum request.
PROPOSAL - Static variable in class org.apache.zookeeper.server.quorum.Leader
This message type is sent by a leader to propose a mutation.
Proposal() - Constructor for class org.apache.zookeeper.server.quorum.Leader.Proposal
 
PROPOSAL_ACK_CREATION_LATENCY - Variable in class org.apache.zookeeper.server.ServerMetrics
 
PROPOSAL_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
PROPOSAL_LATENCY - Variable in class org.apache.zookeeper.server.ServerMetrics
 
PROPOSAL_PROCESS_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
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
 
propose(Request) - Method in class org.apache.zookeeper.server.quorum.Leader
create a proposal and send it out to all the members
PROTOCOL_VERSION_V1 - Static variable in class org.apache.zookeeper.server.quorum.QuorumCnxManager
 
PROTOCOL_VERSION_V2 - Static variable in class org.apache.zookeeper.server.quorum.QuorumCnxManager
 
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
 
put(String, Object) - Method in class org.apache.zookeeper.server.admin.CommandResponse
Adds a key/value pair to this response.
put(String, DataNode) - Method in interface org.apache.zookeeper.server.NodeHashMap
Add the node into the map and update the digest with the new node.
put(String, DataNode) - Method in class org.apache.zookeeper.server.NodeHashMapImpl
 
put(String, byte[], Stat) - Method in class org.apache.zookeeper.server.ResponseCache
 
put(E) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
putAll(Map<? extends String, ?>) - Method in class org.apache.zookeeper.server.admin.CommandResponse
Adds all key/value pairs in the given map to this response.
putWithoutDigest(String, DataNode) - Method in interface org.apache.zookeeper.server.NodeHashMap
Add the node into the map without update the digest.
putWithoutDigest(String, DataNode) - Method in class org.apache.zookeeper.server.NodeHashMapImpl
 
pw - Variable in class org.apache.zookeeper.server.command.AbstractFourLetterCommand
 

Q

QUALIFIER - Static variable in interface org.apache.zookeeper.version.Info
 
queueCommittedProposals(Iterator<Leader.Proposal>, long, Long, Long) - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
Queue committed proposals into packet queue.
queuedRequests - Variable in class org.apache.zookeeper.server.quorum.CommitProcessor
Incoming requests.
queuedWriteRequests - Variable in class org.apache.zookeeper.server.quorum.CommitProcessor
Incoming requests that are waiting on a commit, contained in order of arrival
queueEvent(WatchedEvent) - Method in interface org.apache.zookeeper.Testable
Allow an event to be inserted into the event queue
queuePacket(RequestHeader, ReplyHeader, Record, Record, AsyncCallback, String, String, Object, ZooKeeper.WatchRegistration) - Method in class org.apache.zookeeper.ClientCnxn
 
queuePacket(RequestHeader, ReplyHeader, Record, Record, AsyncCallback, String, String, Object, ZooKeeper.WatchRegistration, WatchDeregistration) - Method in class org.apache.zookeeper.ClientCnxn
 
queuePacket(QuorumPacket) - Method in class org.apache.zookeeper.server.quorum.LearnerSender
 
QUIT_LEADING_DUE_TO_DISLOYAL_VOTER - Variable in class org.apache.zookeeper.server.ServerMetrics
 
QUORUM_ACK_LATENCY - Variable in class org.apache.zookeeper.server.ServerMetrics
 
QUORUM_AUTH_MAGIC_NUMBER - Static variable in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
 
QUORUM_CNXN_TIMEOUT_MS - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
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
 
quorumAddr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.AddressTuple
 
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.
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(QuorumPeer, long, Map<Long, QuorumPeer.QuorumServer>, QuorumAuthServer, QuorumAuthLearner, int, boolean, int, boolean) - Constructor for class org.apache.zookeeper.server.quorum.QuorumCnxManager
 
QuorumCnxManager.InitialMessage - Class in org.apache.zookeeper.server.quorum
 
QuorumCnxManager.InitialMessage.InitialMessageException - Exception in org.apache.zookeeper.server.quorum
 
QuorumCnxManager.Listener - Class in org.apache.zookeeper.server.quorum
Thread to listen on some ports
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(String) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
This constructor 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(Map<Long, QuorumPeer.QuorumServer>) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
Defines a majority to avoid computing it every time.
QuorumMaj(Properties) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
 
QuorumMXBean - Interface in org.apache.zookeeper.server.quorum
An MBean representing a zookeeper cluster nodes (aka quorum peers)
QuorumOracleMaj - Class in org.apache.zookeeper.server.quorum.flexible
 
QuorumOracleMaj(Map<Long, QuorumPeer.QuorumServer>, String) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
 
QuorumOracleMaj(Properties, String) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
 
quorumPeer - Variable in class org.apache.zookeeper.server.controller.ControllerService
 
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, long, int, int, int, int, ServerCnxnFactory) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
For backward compatibility purposes, we instantiate QuorumMaj by default.
QuorumPeer(Map<Long, QuorumPeer.QuorumServer>, File, File, int, long, int, int, int, int, boolean, ServerCnxnFactory, QuorumVerifier) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
 
QuorumPeer(Map<Long, QuorumPeer.QuorumServer>, File, File, int, int, long, int, 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, int, String) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
 
QuorumPeer(Map<Long, QuorumPeer.QuorumServer>, File, File, int, int, long, int, 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 - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerMain
 
QuorumPeer.AddressTuple - Class in org.apache.zookeeper.server.quorum
 
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
 
QuorumPeer.SyncMode - Enum in org.apache.zookeeper.server.quorum
(Used for monitoring) When peer is in synchronization phase, this shows which synchronization mechanism is being used
QuorumPeer.ZabState - Enum in org.apache.zookeeper.server.quorum
(Used for monitoring) shows the current phase of Zab protocol that peer is running.
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
 
quorumSaslEnableAuth - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
Enable/Disables quorum authentication using sasl.
QuorumServer(long, InetSocketAddress, InetSocketAddress, InetSocketAddress) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
QuorumServer(long, InetSocketAddress, InetSocketAddress) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
QuorumServer(long, InetSocketAddress) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
QuorumServer(long, String) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
QuorumServer(long, InetSocketAddress, InetSocketAddress, QuorumPeer.LearnerType) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
QuorumServer(long, InetSocketAddress, InetSocketAddress, InetSocketAddress, QuorumPeer.LearnerType) - 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 - Interface in org.apache.zookeeper.server.quorum.flexible
All quorum validators have to implement a method called containsQuorum, which verifies if a HashSet of server identifiers constitutes a quorum.
quorumVerifier - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
QuorumVerifierAcksetPair(QuorumVerifier, HashSet<Long>) - Constructor for class org.apache.zookeeper.server.quorum.SyncedLearnerTracker.QuorumVerifierAcksetPair
 
QuorumX509Util - Class in org.apache.zookeeper.common
 
QuorumX509Util() - Constructor for class org.apache.zookeeper.common.QuorumX509Util
 
QuorumZooKeeperServer - Class in org.apache.zookeeper.server.quorum
Abstract base class for all ZooKeeperServers that participate in a quorum.
QuorumZooKeeperServer(FileTxnSnapLog, int, int, int, int, ZKDatabase, QuorumPeer) - Constructor for class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
 
QUOTA_BYTES_LIMIT_PER_NAMESPACE - Static variable in class org.apache.zookeeper.server.util.QuotaMetricsUtils
 
QUOTA_BYTES_USAGE_PER_NAMESPACE - Static variable in class org.apache.zookeeper.server.util.QuotaMetricsUtils
 
QUOTA_COUNT_LIMIT_PER_NAMESPACE - Static variable in class org.apache.zookeeper.server.util.QuotaMetricsUtils
 
QUOTA_COUNT_USAGE_PER_NAMESPACE - Static variable in class org.apache.zookeeper.server.util.QuotaMetricsUtils
 
QUOTA_EXCEEDED_ERROR_PER_NAMESPACE - Variable in class org.apache.zookeeper.server.ServerMetrics
 
QUOTA_EXCEEDED_ERROR_PER_NAMESPACE - Static variable in class org.apache.zookeeper.server.util.QuotaMetricsUtils
 
QuotaExceededException() - Constructor for exception org.apache.zookeeper.KeeperException.QuotaExceededException
 
QuotaExceededException(String) - Constructor for exception org.apache.zookeeper.KeeperException.QuotaExceededException
 
QuotaMetricsUtils - Class in org.apache.zookeeper.server.util
 
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
qv - Variable in class org.apache.zookeeper.server.Request
 
qvAcksetPairs - Variable in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker
 

R

rateLimitLog(String) - Method in class org.apache.zookeeper.server.RateLogger
 
rateLimitLog(String, String) - Method in class org.apache.zookeeper.server.RateLogger
In addition to the message, it also takes a value.
RateLogger - Class in org.apache.zookeeper.server
This logs the message once in the beginning and once every LOG_INTERVAL.
RateLogger(Logger) - Constructor for class org.apache.zookeeper.server.RateLogger
 
RateLogger(Logger, long) - Constructor for class org.apache.zookeeper.server.RateLogger
 
read() - Method in class org.apache.zookeeper.server.ByteBufferInputStream
 
read(byte[], int, int) - Method in class org.apache.zookeeper.server.ByteBufferInputStream
 
read(byte[]) - 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, boolean) - 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.
READ_COMMITPROC_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
Time spent by a read request in the commit processor.
READ_FINAL_PROC_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
Time spent by the final processor.
READ_ISSUED_FROM_SESSION_QUEUE - Variable in class org.apache.zookeeper.server.ServerMetrics
 
READ_LATENCY - Variable in class org.apache.zookeeper.server.ServerMetrics
Stats for read request.
READ_PER_NAMESPACE - Variable in class org.apache.zookeeper.server.ServerMetrics
 
ReadAheadEndpoint - Class in org.apache.zookeeper.server.admin
 
ReadAheadEndpoint(EndPoint, int) - Constructor for class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
readCertificateChain(File) - Static method in class org.apache.zookeeper.util.PemReader
 
readCertificateChain(String) - Static method in class org.apache.zookeeper.util.PemReader
 
readFrom(QuorumPeerConfig) - Method in class org.apache.zookeeper.server.ServerConfig
Read attributes from a QuorumPeerConfig.
readIssuedAfterReadComplete - Variable in class org.apache.zookeeper.server.NettyServerCnxn
 
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.
readRequest() - Method in class org.apache.zookeeper.server.controller.ControllableConnection
 
readRequest() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
READS_AFTER_WRITE_IN_SESSION_QUEUE - Variable in class org.apache.zookeeper.server.ServerMetrics
 
READS_ISSUED_IN_COMMIT_PROC - Variable in class org.apache.zookeeper.server.ServerMetrics
 
READS_QUEUED_IN_COMMIT_PROCESSOR - Variable in class org.apache.zookeeper.server.ServerMetrics
 
readSecret(String) - Static method in class org.apache.zookeeper.common.SecretUtils
 
readTxnBytes(InputArchive) - Static method in class org.apache.zookeeper.server.persistence.Util
Reads a transaction entry from the input archive.
readTxnLog(long) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
Get TxnIterator for iterating through txnlog starting at a given zxid
readTxnLog(long, boolean) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
Get TxnIterator for iterating through txnlog starting at a given zxid
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.
reconfig - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
ReconfigCommand - Class in org.apache.zookeeper.cli
reconfig command for cli
ReconfigCommand() - Constructor for class org.apache.zookeeper.cli.ReconfigCommand
 
ReconfigDisabledException() - Constructor for exception org.apache.zookeeper.KeeperException.ReconfigDisabledException
 
ReconfigDisabledException(String) - Constructor for exception org.apache.zookeeper.KeeperException.ReconfigDisabledException
 
reconfigEnabled - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
reconfigFlagClear() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
reconfigFlagSet() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
ReconfigInProgress - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.RECONFIGINPROGRESS instead
ReconfigInProgress() - Constructor for exception org.apache.zookeeper.KeeperException.ReconfigInProgress
 
reconfigure(String, String, String, long, Stat) - Method in class org.apache.zookeeper.admin.ZooKeeperAdmin
Reconfigure - add/remove servers.
reconfigure(List<String>, List<String>, List<String>, long, Stat) - Method in class org.apache.zookeeper.admin.ZooKeeperAdmin
Convenience wrapper around reconfig that takes Lists of strings instead of comma-separated servers.
reconfigure(String, String, String, long, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.admin.ZooKeeperAdmin
The Asynchronous version of reconfig.
reconfigure(List<String>, List<String>, List<String>, long, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.admin.ZooKeeperAdmin
Convenience wrapper around asynchronous reconfig that takes Lists of strings instead of comma-separated servers.
reconfigure(InetSocketAddress) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
reconfigure(InetSocketAddress) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
 
reconfigure(InetSocketAddress) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
record2ByteBuffer(Record, ByteBuffer) - Static method in class org.apache.zookeeper.server.ByteBufferOutputStream
 
recreateSocketAddresses() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
Performs a parallel DNS lookup for all addresses.
recreateSocketAddresses() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
Performs a DNS lookup for server address and election address.
recreateSocketAddresses(long) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Resolves hostname for a given server ID.
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).
register(int) - Method in class org.apache.zookeeper.ZooKeeper.WatchRegistration
Register the watcher with the set of watches on path.
registerCommand(Command) - Static method in class org.apache.zookeeper.server.admin.Commands
Registers the given command.
registerConnection(ServerCnxn) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
registerGauge(String, Gauge) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
 
registerGauge(String, Gauge) - Method in interface org.apache.zookeeper.metrics.MetricsContext
Registers an user provided Gauge which will be called by the MetricsProvider in order to sample an integer value.
registerGaugeSet(String, GaugeSet) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
 
registerGaugeSet(String, GaugeSet) - Method in interface org.apache.zookeeper.metrics.MetricsContext
Registers a user provided GaugeSet which will be called by the MetricsProvider in order to sample number values.
registerJMX() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
registerJMX(LeaderBean, LocalPeerBean) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
registerJMX() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
 
registerJMX(ZooKeeperServerBean, LocalPeerBean) - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
 
registerJMX() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
 
registerJMX(ZooKeeperServerBean, LocalPeerBean) - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
 
registerJMX() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
registerLearnerHandlerBean(LearnerHandler, Socket) - Method in class org.apache.zookeeper.server.quorum.Leader
 
registerLearnerHandlerBean(LearnerHandler, Socket) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
registerLog4jMBeans() - Static method in class org.apache.zookeeper.jmx.ManagedUtil
Register the log4j JMX mbeans.
registerMetrics() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
registerMetrics() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
registerMetrics() - Method in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
 
registerMetrics() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
registerRequest(int, String) - Method in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
The public interface of the buffer.
registerWithLeader(int) - Method in class org.apache.zookeeper.server.quorum.Learner
Once connected to the leader or learner master, perform the handshake protocol to establish a following / observing connection.
remainingCapacity() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
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, 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.
remove(E) - Method in class org.apache.zookeeper.server.ExpiryQueue
Removes element from the queue.
remove(String) - Method in interface org.apache.zookeeper.server.NodeHashMap
Remove the path from the internal nodes map.
remove(String) - Method in class org.apache.zookeeper.server.NodeHashMapImpl
 
remove() - Method in class org.apache.zookeeper.server.TxnLogProposalIterator
 
remove(Set<Integer>, BitSet) - Method in class org.apache.zookeeper.server.util.BitHashSet
Remove the watches, and return the number of watches being removed.
remove(Integer) - Method in class org.apache.zookeeper.server.util.BitHashSet
 
remove(T) - Method in class org.apache.zookeeper.server.util.BitMap
 
remove(int) - Method in class org.apache.zookeeper.server.util.BitMap
 
remove() - Method in class org.apache.zookeeper.server.watch.PathParentIterator
 
remove() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
remove(Object) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
removeAll(Collection<?>) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
removeAllWatches(String, Watcher.WatcherType, boolean) - Method in class org.apache.zookeeper.ZooKeeper
For the given znode path, removes all the registered watchers of given watcherType.
removeAllWatches(String, Watcher.WatcherType, boolean, AsyncCallback.VoidCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of removeAllWatches.
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(Watcher) - Method in class org.apache.zookeeper.server.DataTree
 
removeCnxn(NIOServerCnxn) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
De-registers the connection from the various mappings maintained by the factory.
removeCnxn(ServerCnxn) - Method in class org.apache.zookeeper.server.ZKDatabase
remove a cnxn from the datatree
removeCnxnFromSessionMap(ServerCnxn) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
removeDigest(long) - Method in class org.apache.zookeeper.server.util.AdHash
Remove the digest from the hash value.
removeLearnerHandler(LearnerHandler) - Method in class org.apache.zookeeper.server.quorum.Leader
Remove the learner from the learner list
removeLearnerHandler(LearnerHandler) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
removeLocalSession(long) - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
removeProvider(String) - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
 
removeSession(long) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
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
 
removeWatch(String, Watcher.WatcherType, Watcher) - Method in class org.apache.zookeeper.server.DataTree
 
removeWatch(String, Watcher.WatcherType, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
Remove watch from the datatree
removeWatcher(String, Watcher) - Method in interface org.apache.zookeeper.server.watch.IWatchManager
Removes the specified watcher for the given path.
removeWatcher(Watcher) - Method in interface org.apache.zookeeper.server.watch.IWatchManager
The entry to remove the watcher when the cnxn is closed.
removeWatcher(Watcher) - Method in class org.apache.zookeeper.server.watch.WatchManager
 
removeWatcher(String, Watcher) - Method in class org.apache.zookeeper.server.watch.WatchManager
 
removeWatcher(String, Watcher) - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
 
removeWatcher(Watcher) - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
 
removeWatches - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
removeWatches(String, Watcher, Watcher.WatcherType, boolean) - Method in class org.apache.zookeeper.ZooKeeper
For the given znode path, removes the specified watcher of given watcherType.
removeWatches(String, Watcher, Watcher.WatcherType, boolean, AsyncCallback.VoidCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of removeWatches.
RemoveWatchesCommand - Class in org.apache.zookeeper.cli
Remove watches command for cli
RemoveWatchesCommand() - Constructor for class org.apache.zookeeper.cli.RemoveWatchesCommand
 
RENEW_SESSION_WEIGHT - Static variable in class org.apache.zookeeper.server.BlueThrottle
 
reopenSession(ServerCnxn, long, byte[], int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
reportDigestMismatch(long) - Method in class org.apache.zookeeper.server.DataTree
Reports any mismatch in the transaction digest.
reportLookingSid(long) - Method in class org.apache.zookeeper.server.quorum.Leader
 
request - Variable in class org.apache.zookeeper.server.quorum.Leader.Proposal
 
Request - Class in org.apache.zookeeper.server
This is the structure that represents a request moving through a chain of RequestProcessors.
Request(ServerCnxn, long, int, int, ByteBuffer, List<Id>) - Constructor for class org.apache.zookeeper.server.Request
 
Request(long, int, int, TxnHeader, Record, long) - Constructor for class org.apache.zookeeper.server.Request
 
request - Variable in class org.apache.zookeeper.server.Request
 
REQUEST_THROTTLE_QUEUE_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
REQUEST_THROTTLE_WAIT_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
requestFinished(Request) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
requestOfDeath - Static variable in class org.apache.zookeeper.server.Request
 
RequestPathMetricsCollector - Class in org.apache.zookeeper.server.util
This class holds the requests path ( up till a certain depth) stats per request type
RequestPathMetricsCollector() - Constructor for class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
RequestPathMetricsCollector(boolean) - Constructor for class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
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
 
REQUESTS_IN_SESSION_QUEUE - Variable in class org.apache.zookeeper.server.ServerMetrics
 
REQUESTS_NOT_FORWARDED_TO_COMMIT_PROCESSOR - Variable in class org.apache.zookeeper.server.ServerMetrics
 
requestsReceived - Variable in class org.apache.zookeeper.server.quorum.LearnerHandler
 
requestSystemExit(int) - Static method in class org.apache.zookeeper.util.ServiceUtils
Force shutdown of the JVM using System.exit.
requestThrottleQueueTime - Variable in class org.apache.zookeeper.server.Request
 
RequestThrottler - Class in org.apache.zookeeper.server
When enabled, the RequestThrottler limits the number of outstanding requests currently submitted to the request processor pipeline.
RequestThrottler(ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.RequestThrottler
 
RequestTimeoutException() - Constructor for exception org.apache.zookeeper.KeeperException.RequestTimeoutException
 
reset() - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
 
reset() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
 
reset() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounterSet
 
reset() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounter
 
reset() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounterSet
 
reset() - Method in class org.apache.zookeeper.server.metric.Metric
 
reset() - Method in class org.apache.zookeeper.server.metric.SimpleCounter
 
reset() - Method in class org.apache.zookeeper.server.metric.SimpleCounterSet
 
reset() - Method in class org.apache.zookeeper.server.quorum.BufferStats
Reset statistics.
reset() - Method in class org.apache.zookeeper.server.ServerStats
 
reset() - Method in class org.apache.zookeeper.server.util.CircularBuffer
 
resetAll() - Method in class org.apache.zookeeper.server.ServerMetrics
 
resetAllConnectionStats() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
resetAllConnectionStats() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
 
resetAllConnectionStats() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
resetAllValues() - Method in class org.apache.zookeeper.metrics.impl.DefaultMetricsProvider
 
resetAllValues() - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider
 
resetAllValues() - Method in interface org.apache.zookeeper.metrics.MetricsProvider
Reset all values.
resetAuthFailedCount() - Method in class org.apache.zookeeper.server.ServerStats
 
resetAuthFailedCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
resetAuthFailedCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
Reset AuthFailedCount statistics only.
resetBadBehavior() - Method in class org.apache.zookeeper.server.controller.ControllableConnectionFactory
 
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
resetMax() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
 
resetMax() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounterSet
 
resetMax() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounter
 
resetMax() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounterSet
 
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.
resetNonMTLSConnCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
resetNonMTLSConnCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
Reset NonMTLS(Local+Remote)ConnCount statistics only.
resetNonMTLSLocalConnCount() - Method in class org.apache.zookeeper.server.ServerStats
 
resetNonMTLSRemoteConnCount() - Method in class org.apache.zookeeper.server.ServerStats
 
resetObserverConnectionStats() - Method in class org.apache.zookeeper.server.quorum.Follower
 
resetObserverConnectionStats() - Method in class org.apache.zookeeper.server.quorum.Leader
 
resetObserverConnectionStats() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
 
resetObserverConnectionStats() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
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
 
resetTxnCount() - Method in class org.apache.zookeeper.server.ZKDatabase
Reset the number of txn since last rollLog
resetWhiteList() - Static method in class org.apache.zookeeper.server.command.FourLetterCommands
 
respondToServer(byte[], ClientCnxn) - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
 
RESPONSE_BYTES - Variable in class org.apache.zookeeper.server.ServerMetrics
Number of response/watch bytes written to clients.
RESPONSE_PACKET_CACHE_HITS - Variable in class org.apache.zookeeper.server.ServerMetrics
 
RESPONSE_PACKET_CACHE_MISSING - Variable in class org.apache.zookeeper.server.ServerMetrics
 
RESPONSE_PACKET_GET_CHILDREN_CACHE_HITS - Variable in class org.apache.zookeeper.server.ServerMetrics
 
RESPONSE_PACKET_GET_CHILDREN_CACHE_MISSING - Variable in class org.apache.zookeeper.server.ServerMetrics
 
ResponseCache - Class in org.apache.zookeeper.server
 
ResponseCache(int, String) - Constructor for class org.apache.zookeeper.server.ResponseCache
 
restartLeaderElection(QuorumVerifier, QuorumVerifier) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
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
retainAll(Collection<?>) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
revalidate(QuorumPacket) - Method in class org.apache.zookeeper.server.quorum.Learner
 
REVALIDATE_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
revalidateOutstandingProp(Leader, ArrayList<Leader.Proposal>, long) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
 
revalidateOutstandingProp(Leader, ArrayList<Leader.Proposal>, long) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
revalidateSession(QuorumPacket, LearnerHandler) - Method in class org.apache.zookeeper.server.quorum.Leader
 
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(QuorumPacket, LearnerHandler) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
revalidateSession(ServerCnxn, long, int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
revalidateVoteset(SyncedLearnerTracker, boolean) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
 
revalidateVoteset(SyncedLearnerTracker, boolean) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
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(ZooKeeperServer, Map<String, String>) - Method in interface org.apache.zookeeper.server.admin.Command
Run this command.
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.CnxnStatResetCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.ConfCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.ConsCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.DigestCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.DirsCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.DumpCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.EnvCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.GetTraceMaskCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.InitialConfigurationCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.IsroCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.LastSnapshotCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.LeaderCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.MonitorCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.ObserverCnxnStatResetCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.RuokCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.SetTraceMaskCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.SrvrCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.StatCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.StatResetCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.SyncedObserverConsCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.SystemPropertiesCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.VotingViewCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.WatchCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.WatchesByPathCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.WatchSummaryCommand
 
run(ZooKeeperServer, Map<String, String>) - Method in class org.apache.zookeeper.server.admin.Commands.ZabStateCommand
 
run() - Method in class org.apache.zookeeper.server.command.AbstractFourLetterCommand
 
run() - Method in class org.apache.zookeeper.server.controller.ControllerService
 
run() - Method in class org.apache.zookeeper.server.controller.ZooKeeperServerController
 
run() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory.SelectorThread
The main loop for the thread selects() on the connections and dispatches ready I/O work requests, then registers all pending newly accepted connections and updates any interest ops on the queue.
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.LearnerSender
 
run() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
run() - Method in class org.apache.zookeeper.server.quorum.ObserverRequestProcessor
 
run() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager.Listener
 
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.RequestThrottler
 
run() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
run(String, boolean, boolean) - Method in class org.apache.zookeeper.server.SnapshotFormatter
 
run() - Method in class org.apache.zookeeper.server.SyncRequestProcessor
 
run() - Method in class org.apache.zookeeper.server.watch.WatcherCleaner
 
run() - Method in class org.apache.zookeeper.Shell
check to see if a command needs to be executed and execute if needed
runCommand(String, ZooKeeperServer, Map<String, String>) - Static method in class org.apache.zookeeper.server.admin.Commands
Run the registered command with name cmdName.
runFromConfig(QuorumPeerConfig) - Method in class org.apache.zookeeper.server.controller.ControllerService
Run the app given a QuorumPeerConfig.
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.
runServices() - Method in class org.apache.zookeeper.server.controller.ControllerService
 
RuntimeInconsistency - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.RUNTIMEINCONSISTENCY instead
RuntimeInconsistencyException() - Constructor for exception org.apache.zookeeper.KeeperException.RuntimeInconsistencyException
 
ruok(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
 
ruokCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
RuokCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.RuokCommand
 
RuokCommand - Class in org.apache.zookeeper.server.command
 
RuokCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.RuokCommand
 

S

sasl - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
SASL_AUTH_SCHEME - Static variable in class org.apache.zookeeper.server.AuthenticationHelper
 
SASL_SUPER_USER - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
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
 
saslCompleted() - Method in class org.apache.zookeeper.ClientCnxn
 
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 - Class in org.apache.zookeeper.server.auth
 
SaslServerCallbackHandler(Configuration) - Constructor for class org.apache.zookeeper.server.auth.SaslServerCallbackHandler
 
saslServerCallbackHandler - Variable in class org.apache.zookeeper.server.ServerCnxnFactory
 
SaslServerPrincipal - Class in org.apache.zookeeper
Computes the Server Principal for a SASL client.
SaslServerPrincipal() - Constructor for class org.apache.zookeeper.SaslServerPrincipal
 
save(DataTree, ConcurrentHashMap<Long, Integer>, boolean) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
save the datatree and the sessions into a snapshot
schedule(WorkerService.WorkRequest) - Method in class org.apache.zookeeper.server.WorkerService
Schedule work to be done.
schedule(WorkerService.WorkRequest, long) - Method in class org.apache.zookeeper.server.WorkerService
Schedule work to be done by the thread assigned to this id.
sealStream(CheckedOutputStream, OutputArchive) - Static method in class org.apache.zookeeper.server.persistence.SnapStream
Write specific seal to the OutputArchive and close the OutputStream.
SecretUtils - Class in org.apache.zookeeper.common
Utility class for handling secret such as key/trust store password
secure - Variable in class org.apache.zookeeper.server.ServerCnxnFactory
 
SECURE_CLIENT - Static variable in class org.apache.zookeeper.client.ZKClientConfig
Setting this to "true" will enable encrypted client-server communication.
SECURE_CLIENT - Static variable in class org.apache.zookeeper.ZooKeeper
Deprecated.
secureClientPortAddress - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
secureClientPortAddress - Variable in class org.apache.zookeeper.server.ServerConfig
 
secureServerCnxnFactory - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
SecurityUtils - Class in org.apache.zookeeper.util
 
SecurityUtils() - Constructor for class org.apache.zookeeper.util.SecurityUtils
 
SelectorThread(int) - Constructor for class org.apache.zookeeper.server.NIOServerCnxnFactory.SelectorThread
 
self - Variable in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
 
self - Variable in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
 
send4LetterWord(String, int, String) - Static method in class org.apache.zookeeper.client.FourLetterWordMain
Send the 4letterword
send4LetterWord(String, int, String, boolean) - Static method in class org.apache.zookeeper.client.FourLetterWordMain
Send the 4letterword
send4LetterWord(String, int, String, boolean, 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
sendBuffer pushes a byte buffer onto the outgoing buffer queue for asynchronous writes.
sendCloseSession() - Method in class org.apache.zookeeper.server.DumbWatcher
 
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
 
sendCloseSession() - Method in class org.apache.zookeeper.server.ServerCnxn
 
sendCommand(ControlCommand.Action, String) - Method in class org.apache.zookeeper.server.controller.CommandClient
Send a command and optional command parameter to the server and block until receiving a response.
sendPacket(Record, Record, AsyncCallback, int) - Method in class org.apache.zookeeper.ClientCnxn
 
sendResponse(ReplyHeader, Record, String) - Method in class org.apache.zookeeper.server.controller.ControllableConnection
 
sendResponse(ReplyHeader, Record, String, String, Stat, int) - Method in class org.apache.zookeeper.server.DumbWatcher
 
sendResponse(ReplyHeader, Record, String, String, Stat, int) - Method in class org.apache.zookeeper.server.NettyServerCnxn
 
sendResponse(ReplyHeader, Record, String, String, Stat, int) - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
sendResponse(ReplyHeader, Record, String, String, Stat, int) - Method in class org.apache.zookeeper.server.ServerCnxn
Serializes a ZooKeeper response and enqueues it for sending.
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
sendUrgentData(int) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
serialize(OutputArchive, String) - Method in class org.apache.zookeeper.MultiOperationRecord
 
serialize(OutputArchive, String) - Method in class org.apache.zookeeper.MultiResponse
 
serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.DataNode
 
serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.DataTree
 
serialize(OutputArchive) - Method in class org.apache.zookeeper.server.DataTree.ZxidDigest
 
serialize(DataTree, Map<Long, Integer>, OutputArchive, FileHeader) - Method in class org.apache.zookeeper.server.persistence.FileSnap
serialize the datatree and sessions
serialize(DataTree, Map<Long, Integer>, File, boolean) - Method in class org.apache.zookeeper.server.persistence.FileSnap
serialize the datatree and session into the file snapshot
serialize(DataTree, Map<Long, Integer>, File, boolean) - Method in interface org.apache.zookeeper.server.persistence.SnapShot
persist the datatree and the sessions into a persistence storage
serialize(OutputArchive) - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
 
serialize(ReplyHeader, Record, String, String, Stat, int) - Method in class org.apache.zookeeper.server.ServerCnxn
 
serializeAcls(OutputArchive) - Method in class org.apache.zookeeper.server.DataTree
 
serializeNodeData(OutputArchive, String, DataNode) - Method in class org.apache.zookeeper.server.DataTree
 
serializeNodes(OutputArchive) - Method in class org.apache.zookeeper.server.DataTree
 
serializeRecord(Record) - Method in class org.apache.zookeeper.server.ServerCnxn
 
serializeRequest(Request) - Static method in class org.apache.zookeeper.server.util.SerializeUtils
 
serializeSnapshot(DataTree, OutputArchive, Map<Long, Integer>) - Static method in class org.apache.zookeeper.server.util.SerializeUtils
 
serializeSnapshot(OutputArchive) - Method in class org.apache.zookeeper.server.ZKDatabase
serialize the snapshot
SerializeUtils - Class in org.apache.zookeeper.server.util
 
SerializeUtils() - Constructor for class org.apache.zookeeper.server.util.SerializeUtils
 
serializeZxidDigest(OutputArchive) - Method in class org.apache.zookeeper.server.DataTree
Serializing the digest to snapshot, this is done after the data tree is being serialized, so when we replay the txns and it hits this zxid we know we should be in a non-fuzzy state, and have the same digest.
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
 
SERVER_WRITE_COMMITTED_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
Time spent by a committed request for a write, issued by other server, in the commit processor.
ServerAdminClient - Class in org.apache.zookeeper
 
ServerAdminClient() - Constructor for class org.apache.zookeeper.ServerAdminClient
 
ServerAuthenticationProvider - Class in org.apache.zookeeper.server.auth
A variation on AuthenticationProvider that provides additional parameters for more detailed authentication
ServerAuthenticationProvider() - Constructor for class org.apache.zookeeper.server.auth.ServerAuthenticationProvider
 
ServerAuthenticationProvider.MatchValues - Class in org.apache.zookeeper.server.auth
 
ServerAuthenticationProvider.ServerObjs - Class in org.apache.zookeeper.server.auth
 
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 - Variable in class org.apache.zookeeper.server.command.AbstractFourLetterCommand
 
ServerCnxn - Class in org.apache.zookeeper.server
Interface to a Server connection - represents a connection from a client to the server.
ServerCnxn(ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.ServerCnxn
 
ServerCnxn.CloseRequestException - Exception in org.apache.zookeeper.server
 
ServerCnxn.DisconnectReason - Enum 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 - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
ServerCnxnHelper - Class in org.apache.zookeeper.server
 
ServerCnxnHelper() - Constructor for class org.apache.zookeeper.server.ServerCnxnHelper
 
ServerConfig - Class in org.apache.zookeeper.server
Server configuration storage.
ServerConfig() - Constructor for class org.apache.zookeeper.server.ServerConfig
 
serverId - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
ServerMetrics - Class in org.apache.zookeeper.server
 
ServerMXBean - Interface in org.apache.zookeeper.server.quorum
A quorum server MBean.
ServerObjs(ZooKeeperServer, ServerCnxn) - Constructor for class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.ServerObjs
 
ServerSaslResponseCallback() - Constructor for class org.apache.zookeeper.client.ZooKeeperSaslClient.ServerSaslResponseCallback
 
serverStarted() - Method in class org.apache.zookeeper.server.ZooKeeperServerMain
 
serverStats() - Method in class org.apache.zookeeper.server.DumbWatcher
 
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 - Class in org.apache.zookeeper.server
Basic Server Statistics
ServerStats(ServerStats.Provider) - Constructor for class org.apache.zookeeper.server.ServerStats
 
serverStats() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
ServerStats.Provider - Interface in org.apache.zookeeper.server
 
serviceStart() - Method in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
serviceStop() - Method in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
ServiceUtils - Class in org.apache.zookeeper.util
Utilities for service management.
SESSION_QUEUES_DRAINED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
SESSION_REQUIRE_CLIENT_SASL_AUTH - Static variable in class org.apache.zookeeper.server.AuthenticationHelper
 
SESSION_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
SessionClosedRequireAuthException() - Constructor for exception org.apache.zookeeper.KeeperException.SessionClosedRequireAuthException
 
SessionClosedRequireAuthException(String) - Constructor for exception org.apache.zookeeper.KeeperException.SessionClosedRequireAuthException
 
SessionExpired - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.SESSIONEXPIRED instead
SessionExpiredException() - Constructor for exception org.apache.zookeeper.KeeperException.SessionExpiredException
 
sessionId - Variable in class org.apache.zookeeper.server.Request
 
SESSIONLESS_CONNECTIONS_EXPIRED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
SessionMovedException() - Constructor for exception org.apache.zookeeper.KeeperException.SessionMovedException
 
sessionsById - Variable in class org.apache.zookeeper.server.SessionTrackerImpl
 
sessionsWithTimeout - Variable in class org.apache.zookeeper.server.SessionTrackerImpl
 
sessionsWithTimeouts - Variable in class org.apache.zookeeper.server.ZKDatabase
 
SessionTracker - Interface in org.apache.zookeeper.server
This is the basic interface that ZooKeeperServer uses to track sessions.
sessionTracker - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
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, ConcurrentMap<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
SET_WATCHES_XID - Static variable in class org.apache.zookeeper.ClientCnxn
 
setAcceptedEpoch(long) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setAckLoggingFrequency(int) - Static method in class org.apache.zookeeper.server.quorum.Leader
 
setACL(String, List<ACL>, int) - Method in class org.apache.zookeeper.server.DataTree
 
setACL - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
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.
SetAclCommand - Class in org.apache.zookeeper.cli
setAcl command for cli.
SetAclCommand() - Constructor for class org.apache.zookeeper.cli.SetAclCommand
 
setAdvancedFlowControlEnabled(boolean) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
setAsyncSending(boolean) - Static method in class org.apache.zookeeper.server.quorum.Learner
 
setBufferedOutput(BufferedOutputStream) - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
 
setByteHardLimit(long) - Method in class org.apache.zookeeper.StatsTrack
set the byte hard limit
setBytes(long) - Method in class org.apache.zookeeper.StatsTrack
set the 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
setClientCertificateChain(Certificate[]) - Method in class org.apache.zookeeper.server.DumbWatcher
 
setClientCertificateChain(Certificate[]) - Method in class org.apache.zookeeper.server.NettyServerCnxn
 
setClientCertificateChain(Certificate[]) - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
setClientCertificateChain(Certificate[]) - Method in class org.apache.zookeeper.server.ServerCnxn
 
setClientPortListenBacklog(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Sets the server socket's listen backlog length.
setClientPortListenBacklog(int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
setCloseSessionTxnEnabled(boolean) - Static method in class org.apache.zookeeper.server.ZooKeeperServer
 
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
SetCommand - Class in org.apache.zookeeper.cli
set command for cli
SetCommand() - Constructor for class org.apache.zookeeper.cli.SetCommand
 
setCommitProcMaxCommitBatchSize(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setCommitProcMaxCommitBatchSize(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setCommitProcMaxReadBatchSize(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setCommitProcMaxReadBatchSize(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setConfigFileName(String) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setConfiguration() - Static method in class org.apache.zookeeper.server.auth.KerberosName
Set the static configuration to get the rules.
setConnection(Connection) - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
setConnectionDecreaseRatio(double) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setConnectionDecreaseRatio(double) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setConnectionDropDecrease(double) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setConnectionDropDecrease(double) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setConnectionDropIncrease(double) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setConnectionDropIncrease(double) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setConnectionFreezeTime(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setConnectionFreezeTime(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setConnectionMaxTokens(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setConnectionMaxTokens(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setConnectionTokenFillCount(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setConnectionTokenFillCount(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setConnectionTokenFillTime(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setConnectionTokenFillTime(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setConnectionWeightEnabled(boolean) - Static method in class org.apache.zookeeper.server.BlueThrottle
 
setConnectToLearnerMasterLimit(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Set the connectToLearnerMasterLimit
setCount(long) - Method in class org.apache.zookeeper.StatsTrack
set the count for this stat tracker.
setCountHardLimit(long) - Method in class org.apache.zookeeper.StatsTrack
set the count hard limit
setCreateSessionTrackerServerId(int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
Change the server ID used by ZooKeeperServer.createSessionTracker().
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
 
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.
setData(String, byte[], int) - Static method in class org.apache.zookeeper.Op
Constructs an update operation.
setData(String, byte[], int, long, long) - Method in class org.apache.zookeeper.server.DataTree
 
setData(String, byte[], int) - Method in class org.apache.zookeeper.Transaction
 
setData - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
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, AsyncCallback.StatCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The asynchronous version of setData.
SetDataResult(Stat) - Constructor for class org.apache.zookeeper.OpResult.SetDataResult
 
setDecreasePoint(double) - Method in class org.apache.zookeeper.server.BlueThrottle
 
setDigest(long) - Method in class org.apache.zookeeper.server.DataNode
 
setDigestCached(boolean) - Method in class org.apache.zookeeper.server.DataNode
 
setDigestEnabled(boolean) - Static method in class org.apache.zookeeper.server.ZooKeeperServer
 
setDropDecrease(double) - Method in class org.apache.zookeeper.server.BlueThrottle
 
setDropIncrease(double) - Method in class org.apache.zookeeper.server.BlueThrottle
 
setDropStaleRequests(boolean) - Static method in class org.apache.zookeeper.server.RequestThrottler
 
setElectionType(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Sets the election type
setEnableEagerACLCheck(boolean) - Static method in class org.apache.zookeeper.server.ZooKeeperServer
 
setEnsembleNames(String) - Method in class org.apache.zookeeper.server.auth.EnsembleAuthenticationProvider
 
setEnvironment(Map<String, String>) - Method in class org.apache.zookeeper.Shell
set the environment for the command
setErr(PrintStream) - Method in class org.apache.zookeeper.cli.CliCommand
Set err printStream (usable for testing)
setException(KeeperException) - Method in class org.apache.zookeeper.server.Request
 
setFactory(ServerCnxnFactory) - Method in class org.apache.zookeeper.server.command.AbstractFourLetterCommand
 
setFailCreate(boolean) - Static method in class org.apache.zookeeper.server.PrepRequestProcessor
method for tests to set failCreate
setFillCount(int) - Method in class org.apache.zookeeper.server.BlueThrottle
 
setFillTime(int) - Method in class org.apache.zookeeper.server.BlueThrottle
 
setFirstPacket(boolean) - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
For testing, we need to reset this value
setFlushDelay(long) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setFlushDelay(long) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setFollower(Follower) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setFreezeTime(int) - Method in class org.apache.zookeeper.server.BlueThrottle
 
setHandshakeState(NettyServerCnxn.HandshakeState) - Method in class org.apache.zookeeper.server.NettyServerCnxn
 
setHdr(TxnHeader) - Method in class org.apache.zookeeper.server.Request
 
setIdleTimeout(long) - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
setInitialConfig(String) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setInitLimit(int) - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
setInitLimit(int) - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
Set the number of ticks that the initial sync phase can take
setInitLimit(int) - Method in class org.apache.zookeeper.server.quorum.QuorumBean
 
setInitLimit(int) - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
 
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
Useful for unit tests.
setInvalid() - Method in class org.apache.zookeeper.server.ServerCnxn
 
setIsThrottled(boolean) - Method in class org.apache.zookeeper.server.Request
 
setJvmPauseMonitor(JvmPauseMonitor) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setKeepAlive(boolean) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
setLargeRequestMaxBytes(int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
setLargeRequestMaxBytes(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setLargeRequestMaxBytes(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setLargeRequestSize(int) - Method in class org.apache.zookeeper.server.Request
 
setLargeRequestThreshold(int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
setLargeRequestThreshold(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setLargeRequestThreshold(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setLastBufferSize(int) - Method in class org.apache.zookeeper.server.quorum.BufferStats
Updates statistics by setting the last buffer usage size.
setlastProcessedZxid(long) - Method in class org.apache.zookeeper.server.ZKDatabase
the last processed zxid in the datatree
setLastSeenQuorumVerifier(QuorumVerifier, boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setLeader(Leader) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setLeaderAddressAndId(MultipleAddresses, long) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setLeadingVoteSet(SyncedLearnerTracker) - Method in class org.apache.zookeeper.server.quorum.Leader
 
setLearnerMaster(String) - Method in class org.apache.zookeeper.server.ObserverBean
 
setLearnerMaster(String) - Method in class org.apache.zookeeper.server.quorum.Observer
Prompts the Observer to disconnect from its current learner master and reconnect to the specified server.
setLearnerMaster(String) - Method in interface org.apache.zookeeper.server.quorum.ObserverMXBean
requests the Observer switch to a new learner master
setLearnerType(QuorumPeer.LearnerType) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Sets the LearnerType
setLocalSession(boolean) - Method in class org.apache.zookeeper.server.Request
 
setLocalSessionFlag(Request) - Method in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
 
setLocalSessionFlag(Request) - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
 
setLocalSessionFlag(Request) - Method in class org.apache.zookeeper.server.ZooKeeperServer
If the underlying Zookeeper server support local session, this method will set a isLocalSession to true if a request is associated with a local session.
setMaxBatchSize(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setMaxBatchSize(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
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
setMaxCommitBatchSize(int) - Static method in class org.apache.zookeeper.server.quorum.CommitProcessor
 
setMaxConcurrentDiffSyncs(int) - Method in class org.apache.zookeeper.server.quorum.FollowerBean
 
setMaxConcurrentDiffSyncs(int) - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
 
setMaxConcurrentDiffSyncs(int) - Method in class org.apache.zookeeper.server.quorum.LeaderBean
 
setMaxConcurrentDiffSyncs(int) - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
 
setMaxConcurrentDiffSyncs(int) - Method in class org.apache.zookeeper.server.quorum.LearnerMaster
 
setMaxConcurrentSnapSyncs(int) - Method in class org.apache.zookeeper.server.quorum.FollowerBean
 
setMaxConcurrentSnapSyncs(int) - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
 
setMaxConcurrentSnapSyncs(int) - Method in class org.apache.zookeeper.server.quorum.LeaderBean
 
setMaxConcurrentSnapSyncs(int) - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
 
setMaxConcurrentSnapSyncs(int) - Method in class org.apache.zookeeper.server.quorum.LearnerMaster
 
setMaxConcurrentSyncs(int) - Method in class org.apache.zookeeper.server.quorum.LearnerSyncThrottler
 
setMaxReadBatchSize(int) - Static method in class org.apache.zookeeper.server.quorum.CommitProcessor
 
setMaxRequests(int) - Static method in class org.apache.zookeeper.server.RequestThrottler
 
setMaxSessionTimeout(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
maximum 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
setMaxTimeToWaitForEpoch(int) - Static method in class org.apache.zookeeper.server.quorum.Leader
 
setMaxTokens(int) - Method in class org.apache.zookeeper.server.BlueThrottle
 
setMaxWriteQueuePollTime(long) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setMaxWriteQueuePollTime(long) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
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
setMultiAddressEnabled(boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setMultiAddressReachabilityCheckEnabled(boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setMultiAddressReachabilityCheckTimeoutMs(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setMyid(long) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
set the id of this quorum peer.
setObserver(Observer) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setObserverElectionDelayMs(long) - Static method in class org.apache.zookeeper.server.quorum.Observer
 
setObserverElectionDelayMS(long) - Method in class org.apache.zookeeper.server.quorum.QuorumBean
 
setObserverElectionDelayMS(long) - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
Set the Observer Leader Election Reconnect Delay time in MS
setObserverMasterPacketSizeLimit(int) - Method in class org.apache.zookeeper.server.quorum.FollowerBean
 
setObserverMasterPacketSizeLimit(int) - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
set the size limit in bytes for the observer master commit packet queue
setObserverMasterPort(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setOOBInline(boolean) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
setOut(PrintStream) - Method in class org.apache.zookeeper.cli.CliCommand
Set out printStream (usable for testing)
setOutputArchive(BinaryOutputArchive) - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
 
setOutstandingHandshakeLimit(int) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
setOwner(long, Object) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
setOwner(long, Object) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
 
setOwner(Object) - Method in class org.apache.zookeeper.server.Request
 
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
setPeerState(QuorumPeer.ServerState) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setPerformancePreferences(int, int, int) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
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.
setProperty(String, String) - Method in class org.apache.zookeeper.common.ZKConfig
Maps the specified key to the specified value.
setQuorumListenOnAllIPs(boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setQuorumServer(QuorumPeer.QuorumServer) - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
 
setQuorumVerifier(QuorumVerifier, boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
SetQuotaCommand - Class in org.apache.zookeeper.cli
setQuota command for cli
SetQuotaCommand() - Constructor for class org.apache.zookeeper.cli.SetQuotaCommand
 
setReceiveBufferSize(int) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
setReconfigEnabled(boolean) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
setRequestStaleConnectionCheck(boolean) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setRequestStaleConnectionCheck(boolean) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setRequestStaleLatencyCheck(boolean) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setRequestStaleLatencyCheck(boolean) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setRequestThrottleDropStale(boolean) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setRequestThrottleDropStale(boolean) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setRequestThrottleLimit(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setRequestThrottleLimit(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setRequestThrottleStallTime(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setRequestThrottleStallTime(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setResponseCachingEnabled(boolean) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
setResponseCachingEnabled(boolean) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setResponseCachingEnabled(boolean) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
setReuseAddress(boolean) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
setSecure(boolean) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
setSecureCnxnFactory(ServerCnxnFactory) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setSecureServerCnxnFactory(ServerCnxnFactory) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
setSendBufferSize(int) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
setServerCnxnFactory(ServerCnxnFactory) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
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
setSessionClosing(long) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
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.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
setSnapshotSizeFactor(double) - Method in class org.apache.zookeeper.server.ZKDatabase
Use for unit testing, so we can turn this feature on/off
setSnapSizeInBytes(long) - Static method in class org.apache.zookeeper.server.SyncRequestProcessor
used by tests to check for changing snapcounts
setSoLinger(boolean, int) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
setSoTimeout(int) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
setSslQuorum(boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setStale() - Method in class org.apache.zookeeper.server.ServerCnxn
 
setStaleConnectionCheck(boolean) - Static method in class org.apache.zookeeper.server.Request
 
setStaleLatencyCheck(boolean) - Static method in class org.apache.zookeeper.server.Request
 
setStallTime(int) - Static method in class org.apache.zookeeper.server.RequestThrottler
 
setStandaloneEnabled(boolean) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
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.
setStreamMode(SnapStream.StreamMode) - Static method in class org.apache.zookeeper.server.persistence.SnapStream
 
setSyncEnabled(boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Set syncEnabled.
setSyncLimit(int) - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
setSyncLimit(int) - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
Set the number of ticks that can pass between sending a request and getting a acknowledgment
setSyncLimit(int) - Method in class org.apache.zookeeper.server.quorum.QuorumBean
 
setSyncLimit(int) - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
 
setSyncLimit(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Set the synclimit
setSyncMode(QuorumPeer.SyncMode) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setSystemExitProcedure(Consumer<Integer>) - Static method in class org.apache.zookeeper.util.ServiceUtils
Override system callback.
setTcpNoDelay(boolean) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
setTextTraceLevel(long) - Static method in class org.apache.zookeeper.server.ZooTrace
 
setThrottledOpWaitTime(int) - Static method in class org.apache.zookeeper.server.ZooKeeperServer
 
setThrottledOpWaitTime(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setThrottledOpWaitTime(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
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
setTotalLogSize(long) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
 
setTotalLogSize(long) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
 
setTotalLogSize(long) - Method in interface org.apache.zookeeper.server.persistence.TxnLog
Sets the total size of all log files
setTraceMask(String, int, String) - Static method in class org.apache.zookeeper.ServerAdminClient
 
setTraceMaskCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
SetTraceMaskCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.SetTraceMaskCommand
 
SetTraceMaskCommand - Class in org.apache.zookeeper.server.command
 
SetTraceMaskCommand(PrintWriter, ServerCnxn, long) - Constructor for class org.apache.zookeeper.server.command.SetTraceMaskCommand
 
setTrafficClass(int) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
setTxn(Record) - Method in class org.apache.zookeeper.server.Request
 
setTxnDigest(TxnDigest) - Method in class org.apache.zookeeper.server.Request
 
setTxnFactory(FileTxnSnapLog) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setTxnLogFactory(FileTxnSnapLog) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
setTxnLogSizeLimit(long) - Static method in class org.apache.zookeeper.server.persistence.FileTxnLog
Set log size limit
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
 
setUsePortUnification(boolean) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setVersion(long) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
 
setVersion(long) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
 
setVersion(long) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
setWatches(long, List<String>, List<String>, List<String>, List<String>, List<String>, Watcher) - Method in class org.apache.zookeeper.server.DataTree
 
setWatches(long, List<String>, List<String>, List<String>, List<String>, List<String>, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
set watches on the datatree
setWatches - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
setWatches2 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
setWorkingDirectory(File) - Method in class org.apache.zookeeper.Shell
set the working directory
setZabState(QuorumPeer.ZabState) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setZk(ZooKeeper) - Method in class org.apache.zookeeper.cli.CliCommand
set the zookeeper instance
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
setZkServer(ZooKeeperServer) - Method in class org.apache.zookeeper.server.command.AbstractFourLetterCommand
 
setZooKeeperServer(ZooKeeperServer) - Method in interface org.apache.zookeeper.server.admin.AdminServer
 
setZooKeeperServer(ZooKeeperServer) - Method in class org.apache.zookeeper.server.admin.DummyAdminServer
 
setZooKeeperServer(ZooKeeperServer) - Method in class org.apache.zookeeper.server.admin.JettyAdminServer
Set the ZooKeeperServer that will be used to run Commands.
setZooKeeperServer(ZooKeeperServer) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setZooKeeperServer(ZooKeeperServer) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
setZxid(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
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.
shouldAddWatch(int) - Method in class org.apache.zookeeper.ZooKeeper.WatchRegistration
Determine whether the watch should be added based on return code.
shouldFailNextRequest() - Method in class org.apache.zookeeper.server.controller.ControllableConnectionFactory
Check if we should fail the next incoming request.
shouldForceWriteInitialSnapshotAfterLeaderElection() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
whether to force the write of an initial snapshot after a leader election, to address ZOOKEEPER-3781 after upgrading from Zookeeper 3.4.x.
shouldForceWriteInitialSnapshotAfterLeaderElection() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
shouldSendMarkerPacketForLogging() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
Tests need not send marker packets as they are only needed to log quorum packet delays
shouldSendResponse() - Method in class org.apache.zookeeper.server.controller.ControllableConnectionFactory
Check if we should send a response to the latest processed request (true), or eat the response to mess with the client (false).
shouldThrottle(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
shouldThrottleOp(Request, long) - Method in class org.apache.zookeeper.server.RequestThrottler
 
shouldUsePortUnification() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
shouldUsePortUnification - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
shouldUsePortUnification() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
shouldVerifyClientHostname() - Method in class org.apache.zookeeper.common.ClientX509Util
 
shouldVerifyClientHostname() - Method in class org.apache.zookeeper.common.QuorumX509Util
 
shouldVerifyClientHostname() - Method in class org.apache.zookeeper.common.X509Util
 
shutdown() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
close login thread if running
shutdown() - Method in class org.apache.zookeeper.Login
 
shutdown() - Method in interface org.apache.zookeeper.server.admin.AdminServer
 
shutdown() - Method in class org.apache.zookeeper.server.admin.DummyAdminServer
 
shutdown() - Method in class org.apache.zookeeper.server.admin.JettyAdminServer
Stop the embedded Jetty server.
shutdown() - Method in class org.apache.zookeeper.server.controller.ControllerService
 
shutdown() - Method in class org.apache.zookeeper.server.controller.ZooKeeperServerController
 
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.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.LeaderRequestProcessor
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
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.LearnerSender
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
 
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.RequestThrottler
 
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.util.RequestPathMetricsCollector
 
shutdown() - Method in interface org.apache.zookeeper.server.watch.IWatchManager
Clean up the watch manager.
shutdown() - Method in class org.apache.zookeeper.server.watch.WatcherCleaner
 
shutdown() - Method in class org.apache.zookeeper.server.watch.WatchManager
 
shutdown() - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
 
shutdown() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
shutdown(boolean) - Method in class org.apache.zookeeper.server.ZooKeeperServer
Shut down the server instance
shutdown() - Method in class org.apache.zookeeper.server.ZooKeeperServerMain
Shutdown the serving instance
shutdownInput() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
shutdownOutput() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
shutdownOutput() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
shutdownWatcher() - Method in class org.apache.zookeeper.server.DataTree
 
sid - Variable in class org.apache.zookeeper.server.quorum.LearnerHandler
ZooKeeper server identifier of this learner
sid - Variable in class org.apache.zookeeper.server.quorum.QuorumCnxManager.InitialMessage
 
SimpleCounter - Class in org.apache.zookeeper.server.metric
 
SimpleCounter(String) - Constructor for class org.apache.zookeeper.server.metric.SimpleCounter
 
SimpleCounterSet - Class in org.apache.zookeeper.server.metric
Represent a set of counters identified by different keys.
SimpleCounterSet(String) - Constructor for class org.apache.zookeeper.server.metric.SimpleCounterSet
 
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.MultiOperationRecord
 
size() - Method in class org.apache.zookeeper.MultiResponse
 
size() - Method in interface org.apache.zookeeper.server.NodeHashMap
Return the size of the nodes stored in this map.
size() - Method in class org.apache.zookeeper.server.NodeHashMapImpl
 
size() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
Returns the number of addresses in the set.
size() - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
 
size() - Method in class org.apache.zookeeper.server.util.BitHashSet
 
size() - Method in class org.apache.zookeeper.server.util.BitMap
 
size() - Method in class org.apache.zookeeper.server.util.CircularBuffer
 
size() - Method in interface org.apache.zookeeper.server.watch.IWatchManager
Get the size of watchers.
size() - Method in class org.apache.zookeeper.server.watch.WatcherOrBitSet
 
size() - Method in class org.apache.zookeeper.server.watch.WatchManager
 
size() - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
 
size() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
skip(long) - Method in class org.apache.zookeeper.server.ByteBufferInputStream
 
SKIP_ACL - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
SKIP_LEARNER_REQUEST_TO_NEXT_PROCESSOR - Static variable in class org.apache.zookeeper.server.quorum.FollowerRequestProcessor
 
SKIP_LEARNER_REQUEST_TO_NEXT_PROCESSOR_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
SLEEP_TIME_MS_DEFAULT - Static variable in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
SLEEP_TIME_MS_KEY - Static variable in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
sleepBeforeRetryFailedRefresh() - Method in class org.apache.zookeeper.Login
 
sleepTimeMs - Variable in class org.apache.zookeeper.server.util.JvmPauseMonitor
The target sleep time
Slf4jAuditLogger - Class in org.apache.zookeeper.audit
Slf4j based audit logger
Slf4jAuditLogger() - Constructor for class org.apache.zookeeper.audit.Slf4jAuditLogger
 
SNAP_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
SNAP_COUNT - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
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() - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
 
SNAPSHOT_FILE_PREFIX - Static variable in class org.apache.zookeeper.server.persistence.FileSnap
 
SNAPSHOT_SIZE_FACTOR - Static variable in class org.apache.zookeeper.server.ZKDatabase
Default value is to use snapshot if txnlog size exceeds 1/3 the size of snapshot
SNAPSHOT_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
Snapshot writing time
SnapshotComparer - Class in org.apache.zookeeper.server
SnapshotComparer is a tool that loads and compares two snapshots with configurable threshold and various filters, and outputs information about the delta.
SnapshotFormatter - Class in org.apache.zookeeper.server
Dump a snapshot file to stdout.
SnapshotFormatter() - Constructor for class org.apache.zookeeper.server.SnapshotFormatter
 
SnapshotInfo - Class in org.apache.zookeeper.server.persistence
stores the zxid (as in its file name) and the last modified timestamp of a snapshot file
SnapStream - Class in org.apache.zookeeper.server.persistence
Represent the Stream used in serialize and deserialize the Snapshot.
SnapStream() - Constructor for class org.apache.zookeeper.server.persistence.SnapStream
 
SnapStream.StreamMode - Enum in org.apache.zookeeper.server.persistence
 
sock - Variable in class org.apache.zookeeper.server.quorum.Learner
 
sock - Variable in class org.apache.zookeeper.server.quorum.LearnerHandler
 
sockBeingClosed - Variable in class org.apache.zookeeper.server.quorum.Learner
 
sockConnect(Socket, InetSocketAddress, int) - Method in class org.apache.zookeeper.server.quorum.Learner
Overridable helper method to simply call sock.connect().
SOCKET_CLOSING_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
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.
split(String, String) - Static method in class org.apache.zookeeper.common.StringUtils
This method returns an immutable List<String>, but different from String's split() it trims the results in the input String, and removes any empty string from the resulting List.
srstCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
srvrCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
SrvrCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.SrvrCommand
 
SrvrCommand(List<String>) - Constructor for class org.apache.zookeeper.server.admin.Commands.SrvrCommand
 
SSLContextAndOptions - Class in org.apache.zookeeper.common
Wrapper class for an SSLContext + some config options that can't be set on the context when it is created but must be set on a secure socket created by the context after the socket creation.
SSLContextException(String) - Constructor for exception org.apache.zookeeper.common.X509Exception.SSLContextException
 
SSLContextException(Throwable) - Constructor for exception org.apache.zookeeper.common.X509Exception.SSLContextException
 
SSLContextException(String, Throwable) - Constructor for exception org.apache.zookeeper.common.X509Exception.SSLContextException
 
sslQuorum - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
sslQuorumReloadCertFiles - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
STALE_REPLIES - Variable in class org.apache.zookeeper.server.ServerMetrics
 
STALE_REQUESTS - Variable in class org.apache.zookeeper.server.ServerMetrics
 
STALE_REQUESTS_DROPPED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
STALE_SESSIONS_EXPIRED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
start() - Method in class org.apache.zookeeper.ClientCnxn
 
start() - Method in class org.apache.zookeeper.common.FileChangeWatcher
Tells the background thread to start.
start() - Method in class org.apache.zookeeper.metrics.impl.DefaultMetricsProvider
 
start() - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider
 
start() - Method in interface org.apache.zookeeper.metrics.MetricsProvider
Start the provider.
start() - Method in interface org.apache.zookeeper.server.admin.AdminServer
 
start() - Method in class org.apache.zookeeper.server.admin.DummyAdminServer
 
start() - Method in class org.apache.zookeeper.server.admin.JettyAdminServer
Start the embedded Jetty server.
start() - Method in class org.apache.zookeeper.server.command.AbstractFourLetterCommand
 
start() - Method in class org.apache.zookeeper.server.ContainerManager
start/restart the timer the runs the check.
start(ControllerServerConfig) - Method in class org.apache.zookeeper.server.controller.ControllerService
Starts a new thread to run the controller (useful when this service is hosted in process - such as during unit testing).
start() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
Validates the purge configuration and schedules the purge task.
start() - Method in interface org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded
Start the server.
start(long) - Method in interface org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded
Start the server
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.CommitProcessor
 
start() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
This method starts the sender and receiver threads.
start() - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
start() - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
 
start() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
start() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
start() - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
start() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
start() - Method in class org.apache.zookeeper.server.util.RequestPathMetricsCollector
 
start() - Method in class org.apache.zookeeper.server.WorkerService
 
start_fle - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
startdata() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
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
startForwarding(LearnerHandler, long) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
startJvmPauseMonitor() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
startLeaderElection() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
startMetricsProvider(String, Properties) - Static method in class org.apache.zookeeper.metrics.impl.MetricsProviderBootstrap
 
startRequestThrottler() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
startSendingPackets() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
Start thread that will forward any packet in the queue to the follower
startSendingThread() - Method in class org.apache.zookeeper.server.quorum.Learner
Start thread that will forward any packet in the queue to the leader
startServing() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
startSessionTracker() - Method in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
 
startSessionTracker() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
 
startSessionTracker() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
startThreadIfNeeded() - Method in class org.apache.zookeeper.Login
 
startup(ZooKeeperServer, boolean) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
 
startup(ZooKeeperServer, boolean) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
 
startup() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
startup() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
 
startup(ZooKeeperServer) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
startup(ZooKeeperServer, boolean) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
startup() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
STARTUP_SNAP_LOAD_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
STARTUP_TXNS_LOAD_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
STARTUP_TXNS_LOADED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
startupWithoutServing() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
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(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
 
STAT_OVERHEAD_BYTES - Static variable in class org.apache.zookeeper.server.DataTree
over-the-wire size of znode's stat.
statCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
StatCommand - Class in org.apache.zookeeper.cli
stat command for cli
StatCommand() - Constructor for class org.apache.zookeeper.cli.StatCommand
 
StatCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.StatCommand
 
StatCommand - Class in org.apache.zookeeper.server.command
 
StatCommand(PrintWriter, ServerCnxn, int) - Constructor for class org.apache.zookeeper.server.command.StatCommand
 
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
Constructs a SimpleHostSet.
StaticHostProvider(Collection<InetSocketAddress>, long) - Constructor for class org.apache.zookeeper.client.StaticHostProvider
Constructs a SimpleHostSet.
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, Watcher) - Method in class org.apache.zookeeper.server.DataTree
 
statNode(String, ServerCnxn) - Method in class org.apache.zookeeper.server.ZKDatabase
stat the path
statPath(String) - Static method in class org.apache.zookeeper.Quotas
return the stat quota path associated with this prefix.
StatPrinter - Class in org.apache.zookeeper.cli
utility for printing stat values s
StatPrinter(PrintStream) - Constructor for class org.apache.zookeeper.cli.StatPrinter
 
StatResetCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.StatResetCommand
 
StatResetCommand - Class in org.apache.zookeeper.server.command
 
StatResetCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.StatResetCommand
 
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(byte[]) - Constructor for class org.apache.zookeeper.StatsTrack
 
StatsTrack(String) - Constructor for class org.apache.zookeeper.StatsTrack
the stat string should be of the form key1str=long,key2str=long,..
stop() - Method in class org.apache.zookeeper.common.FileChangeWatcher
Tells the background thread to stop.
stop() - Method in class org.apache.zookeeper.metrics.impl.DefaultMetricsProvider
 
stop() - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider
 
stop() - Method in interface org.apache.zookeeper.metrics.MetricsProvider
Releases resources held by the provider.
This method must not throw exceptions.
This method can be called more than once.
stop() - Method in class org.apache.zookeeper.server.ContainerManager
stop the timer if necessary.
stop() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
 
stop() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
stop() - Method in class org.apache.zookeeper.server.WorkerService
 
stopLeaderElection() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
stopped - Variable in class org.apache.zookeeper.server.quorum.CommitProcessor
 
stoppedMainLoop - Variable in class org.apache.zookeeper.server.quorum.CommitProcessor
For testing purposes, we use a separated stopping condition for the outer loop.
StringUtils - Class in org.apache.zookeeper.common
 
submitLearnerRequest(Request) - Method in class org.apache.zookeeper.server.quorum.Leader
 
submitLearnerRequest(Request) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
Requests coming from the learner should go directly to PrepRequestProcessor
submitLearnerRequest(Request) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
submitRequest(RequestHeader, Record, Record, ZooKeeper.WatchRegistration) - Method in class org.apache.zookeeper.ClientCnxn
 
submitRequest(RequestHeader, Record, Record, ZooKeeper.WatchRegistration, WatchDeregistration) - Method in class org.apache.zookeeper.ClientCnxn
 
submitRequest(Request) - Method in class org.apache.zookeeper.server.RequestThrottler
 
submitRequest(Request) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
submitRequestNow(Request) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
Summary - Interface in org.apache.zookeeper.metrics
Summaries track the size and number of events.
SummarySet - Interface in org.apache.zookeeper.metrics
Summaries track the size and number of events.
sync() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
sync() - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
 
sync - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
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.
SYNC_PROCESS_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
SYNC_PROCESSOR_FLUSH_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
SYNC_PROCESSOR_QUEUE_AND_FLUSH_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
SYNC_PROCESSOR_QUEUE_SIZE - Variable in class org.apache.zookeeper.server.ServerMetrics
 
SYNC_PROCESSOR_QUEUE_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
SYNC_PROCESSOR_QUEUED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
SYNC_TIMEOUT - Static variable in class org.apache.zookeeper.cli.SyncCommand
 
SyncCommand - Class in org.apache.zookeeper.cli
sync command for cli
SyncCommand() - Constructor for class org.apache.zookeeper.cli.SyncCommand
 
synced() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
 
SyncedLearnerTracker - Class in org.apache.zookeeper.server.quorum
 
SyncedLearnerTracker() - Constructor for class org.apache.zookeeper.server.quorum.SyncedLearnerTracker
 
SyncedLearnerTracker.QuorumVerifierAcksetPair - Class in org.apache.zookeeper.server.quorum
 
SyncedObserverConsCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.SyncedObserverConsCommand
 
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
 
syncProcessor - Variable in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
 
syncQueueStartTime - Variable in class org.apache.zookeeper.server.Request
 
SyncRequestProcessor - Class in org.apache.zookeeper.server
This RequestProcessor logs requests to disk.
SyncRequestProcessor(ZooKeeperServer, RequestProcessor) - Constructor for class org.apache.zookeeper.server.SyncRequestProcessor
 
SyncThrottleException - Exception in org.apache.zookeeper.server.quorum
Thrown when a Leader has too many concurrent syncs being sent to observers.
SyncThrottleException(int, int, LearnerSyncThrottler.SyncType) - Constructor for exception org.apache.zookeeper.server.quorum.SyncThrottleException
 
syncTimeout() - Method in class org.apache.zookeeper.server.quorum.Leader
 
syncTimeout() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
syncWithLeader(long) - Method in class org.apache.zookeeper.server.quorum.Learner
Finally, synchronize our history with the Leader (if Follower) or the LearnerMaster (if Observer).
SYSTEM_EXIT - Static variable in class org.apache.zookeeper.util.ServiceUtils
Default strategy for shutting down the JVM.
SYSTEM_USER - Static variable in class org.apache.zookeeper.Login
 
SystemError - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.SYSTEMERROR instead
SystemErrorException() - Constructor for exception org.apache.zookeeper.KeeperException.SystemErrorException
 
SystemPropertiesCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.SystemPropertiesCommand
 

T

take() - Method in class org.apache.zookeeper.server.util.CircularBuffer
Reads from the buffer in a FIFO manner.
take() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
takeSnapshot() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
takeSnapshot(boolean) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
telnetCloseCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
terminateConnection() - Method in class org.apache.zookeeper.server.ConnectionBean
 
terminateConnection() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
Terminate thei client connection.
terminateConnection() - Method in class org.apache.zookeeper.server.quorum.LearnerHandlerBean
 
terminateConnection() - Method in interface org.apache.zookeeper.server.quorum.LearnerHandlerMXBean
Terminate the connection.
terminateSession() - Method in class org.apache.zookeeper.server.ConnectionBean
 
terminateSession() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
Terminate this client session.
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
THROTTLED_OPS - Variable in class org.apache.zookeeper.server.ServerMetrics
 
ThrottledOpException() - Constructor for exception org.apache.zookeeper.KeeperException.ThrottledOpException
 
throttledOpWaitTime - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
throttleWake() - Method in class org.apache.zookeeper.server.RequestThrottler
 
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
 
TIME_WAITING_EMPTY_POOL_IN_COMMIT_PROCESSOR_READ - Variable in class org.apache.zookeeper.server.ServerMetrics
 
timeOutInterval - Variable in class org.apache.zookeeper.Shell
Time after which the executing script would be timedout
timestamp - Variable in class org.apache.zookeeper.server.persistence.SnapshotInfo
 
TLS_HANDSHAKE_EXCEEDED - Variable in class org.apache.zookeeper.server.ServerMetrics
 
TMP_EXTENSION - Static variable in class org.apache.zookeeper.common.AtomicFileOutputStream
 
toArray() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
toArray(T[]) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
 
toDisconnectReasonString() - Method in enum org.apache.zookeeper.server.ServerCnxn.DisconnectReason
 
toEphemeralOwner(long) - Method in enum org.apache.zookeeper.server.EphemeralType
For types that support it, convert a value to an extended ephemeral owner
toFlag() - Method in enum org.apache.zookeeper.CreateMode
 
toMap() - Method in class org.apache.zookeeper.server.admin.CommandResponse
Converts this response to a map.
toMap() - Method in class org.apache.zookeeper.server.watch.WatchesPathReport
Converts this report to a map.
toMap() - Method in class org.apache.zookeeper.server.watch.WatchesReport
Converts this report to a map.
toMap() - Method in class org.apache.zookeeper.server.watch.WatchesSummary
Converts this summary to a map.
toMap() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
Converts this configuration to a map.
toNettyClientAuth() - Method in enum org.apache.zookeeper.common.X509Util.ClientAuth
 
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.CreateTTL
 
toRequestRecord() - Method in class org.apache.zookeeper.Op.Delete
 
toRequestRecord() - Method in class org.apache.zookeeper.Op.GetChildren
 
toRequestRecord() - Method in class org.apache.zookeeper.Op.GetData
 
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.admin.ZooKeeperAdmin
String representation of this ZooKeeperAdmin client.
toString() - Method in class org.apache.zookeeper.audit.AuditEvent
Gives the string to be logged, ignores fields with null values
toString() - Method in class org.apache.zookeeper.ClientCnxn
 
toString() - Method in class org.apache.zookeeper.Environment.Entry
 
toString() - Method in class org.apache.zookeeper.server.admin.UnifiedConnectionFactory
 
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
Used by "dump" 4-letter command to list all connection in cnxnExpiryMap
toString() - Method in class org.apache.zookeeper.server.quorum.BufferStats
 
toString() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
 
toString() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
 
toString() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
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.LearnerHandlerBean
 
toString() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
 
toString() - Method in class org.apache.zookeeper.server.quorum.Observer
 
toString() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager.InitialMessage
 
toString() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
toString() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerMain
 
toString() - Method in class org.apache.zookeeper.server.quorum.QuorumStats
 
toString() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
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.SessionImpl
 
toString() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
toString() - Method in class org.apache.zookeeper.server.util.AdHash
 
toString() - Method in class org.apache.zookeeper.server.watch.WatchManager
 
toString() - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
 
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.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.Leader
 
touch(long, int) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
touch(long, int) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
touchCnxn(NIOServerCnxn) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
Add or update cnxn in our cnxnExpiryQueue
touchSession(long, int) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
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
 
TraceMaskCommand - Class in org.apache.zookeeper.server.command
 
trackReceived(long) - Method in class org.apache.zookeeper.server.util.MessageTracker
 
trackReceived(int) - Method in class org.apache.zookeeper.server.util.MessageTracker
 
trackSent(long) - Method in class org.apache.zookeeper.server.util.MessageTracker
 
trackSent(int) - Method in class org.apache.zookeeper.server.util.MessageTracker
 
trackSession(long, int) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
 
trackSession(long, int) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
 
trackSession(long, int) - Method in interface org.apache.zookeeper.server.SessionTracker
Track the session expire, not add to ZkDb.
trackSession(long, int) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
Transaction - Class in org.apache.zookeeper
Provides a builder style interface for doing multiple updates.
Transaction(ZooKeeper) - Constructor for class org.apache.zookeeper.Transaction
 
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.
triggerWatch(String, Watcher.Event.EventType) - Method in interface org.apache.zookeeper.server.watch.IWatchManager
Distribute the watch event for the given path.
triggerWatch(String, Watcher.Event.EventType, WatcherOrBitSet) - Method in interface org.apache.zookeeper.server.watch.IWatchManager
Distribute the watch event for the given path, but ignore those suppressed ones.
triggerWatch(String, Watcher.Event.EventType) - Method in class org.apache.zookeeper.server.watch.WatchManager
 
triggerWatch(String, Watcher.Event.EventType, WatcherOrBitSet) - Method in class org.apache.zookeeper.server.watch.WatchManager
 
triggerWatch(String, Watcher.Event.EventType) - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
 
triggerWatch(String, Watcher.Event.EventType, WatcherOrBitSet) - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
 
trimQuotaPath(String) - Static method in class org.apache.zookeeper.Quotas
return the real path associated with this quotaPath.
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
truncate the log to get in sync with others if in a quorum
TrustManagerException(String) - Constructor for exception org.apache.zookeeper.common.X509Exception.TrustManagerException
 
TrustManagerException(Throwable) - Constructor for exception org.apache.zookeeper.common.X509Exception.TrustManagerException
 
tryFillInterested(Callback) - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
trySendCommand(ControlCommand.Action) - Method in class org.apache.zookeeper.server.controller.CommandClient
Send a command with no parameters to the server and wait for a response.
trySendCommand(ControlCommand.Action, String) - Method in class org.apache.zookeeper.server.controller.CommandClient
Send a command with an optional command parameter to the server and wait for a response.
tryToCommit(Leader.Proposal, long, SocketAddress) - Method in class org.apache.zookeeper.server.quorum.Leader
 
TTL_MASK - Static variable in enum org.apache.zookeeper.server.EphemeralTypeEmulate353
 
ttlToEphemeralOwner(long) - Static method in enum org.apache.zookeeper.server.EphemeralTypeEmulate353
 
TxnLog - Interface in org.apache.zookeeper.server.persistence
Interface for reading transaction logs.
TxnLog.TxnIterator - Interface in org.apache.zookeeper.server.persistence
an iterating interface for reading transaction logs.
TXNLOG_MAGIC - Static variable in class org.apache.zookeeper.server.persistence.FileTxnLog
 
TxnLogEntry - Class in org.apache.zookeeper.server
A helper class to represent the txn entry.
TxnLogEntry(Record, TxnHeader, TxnDigest) - Constructor for class org.apache.zookeeper.server.TxnLogEntry
 
TxnLogProposalIterator - Class in org.apache.zookeeper.server
This class provides an iterator interface to access Proposal deserialized from on-disk txnlog.
TxnLogProposalIterator(TxnLog.TxnIterator) - Constructor for class org.apache.zookeeper.server.TxnLogProposalIterator
 
TxnLogToolkit - Class in org.apache.zookeeper.server.persistence
 
TxnLogToolkit(boolean, boolean, String, boolean) - Constructor for class org.apache.zookeeper.server.persistence.TxnLogToolkit
 
TxnLogToolkit(String, String) - 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.
UNAVAILABLE_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
UnifiedConnectionFactory - Class in org.apache.zookeeper.server.admin
The purpose of this class is to dynamically determine whether to create a plaintext or SSL connection whenever newConnection() is called.
UnifiedConnectionFactory(String) - Constructor for class org.apache.zookeeper.server.admin.UnifiedConnectionFactory
 
UnifiedConnectionFactory(SslContextFactory, String) - Constructor for class org.apache.zookeeper.server.admin.UnifiedConnectionFactory
 
UnifiedServerSocket - Class in org.apache.zookeeper.server.quorum
A ServerSocket that can act either as a regular ServerSocket, as a SSLServerSocket, or as both, depending on the constructor parameters and on the type of client (TLS or plaintext) that connects to it.
UnifiedServerSocket(X509Util, boolean) - Constructor for class org.apache.zookeeper.server.quorum.UnifiedServerSocket
Creates an unbound unified server socket by calling ServerSocket().
UnifiedServerSocket(X509Util, boolean, int) - Constructor for class org.apache.zookeeper.server.quorum.UnifiedServerSocket
Creates a unified server socket bound to the specified port by calling ServerSocket(int).
UnifiedServerSocket(X509Util, boolean, int, int) - Constructor for class org.apache.zookeeper.server.quorum.UnifiedServerSocket
Creates a unified server socket bound to the specified port, with the specified backlog, by calling ServerSocket(int, int).
UnifiedServerSocket(X509Util, boolean, int, int, InetAddress) - Constructor for class org.apache.zookeeper.server.quorum.UnifiedServerSocket
Creates a unified server socket bound to the specified port, with the specified backlog, and local IP address to bind to, by calling ServerSocket(int, int, InetAddress).
UnifiedServerSocket.UnifiedSocket - Class in org.apache.zookeeper.server.quorum
The result of calling accept() on a UnifiedServerSocket.
Unimplemented - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
deprecated in 3.1.0, use KeeperException.Code.UNIMPLEMENTED instead
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_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
 
UnknownSession - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated.
UnknownSessionException() - Constructor for exception org.apache.zookeeper.KeeperException.UnknownSessionException
 
UNRECOVERABLE_ERROR_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
 
unregister(ZKMBeanInfo) - Method in class org.apache.zookeeper.jmx.MBeanRegistry
Unregister MBean.
unregister(int) - Method in class org.apache.zookeeper.WatchDeregistration
Unregistering watcher that was added on path.
unregisterConnection(ServerCnxn) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
 
unregisterGauge(String) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
 
unregisterGauge(String) - Method in interface org.apache.zookeeper.metrics.MetricsContext
Unregisters the user provided Gauge bound to the given name.
unregisterGaugeSet(String) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
 
unregisterGaugeSet(String) - Method in interface org.apache.zookeeper.metrics.MetricsContext
Unregisters the user provided GaugeSet bound to the given name.
unregisterJMX() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
unregisterJMX(Leader) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
unregisterJMX() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
 
unregisterJMX(Learner) - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
 
unregisterJMX() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
 
unregisterJMX(ZooKeeperServer) - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
 
unregisterJMX() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
unregisterLearnerHandlerBean(LearnerHandler) - Method in class org.apache.zookeeper.server.quorum.Leader
 
unregisterLearnerHandlerBean(LearnerHandler) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
unregisterMetrics() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
unregisterMetrics() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
unregisterMetrics() - Method in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
 
unregisterMetrics() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
UNSUCCESSFUL_HANDSHAKE - Variable in class org.apache.zookeeper.server.ServerMetrics
 
update(E, int) - Method in class org.apache.zookeeper.server.ExpiryQueue
Adds or updates expiration time for element in queue, rounding the timeout to the expiry interval bucketed used by this queue.
UPDATE_LATENCY - Variable in class org.apache.zookeeper.server.ServerMetrics
Stats for request that need quorum voting.
updateClientResponseSize(int) - Method in class org.apache.zookeeper.server.ServerStats
 
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.
updateLatency(Request, long) - Method in class org.apache.zookeeper.server.ServerStats
Update request statistic.
updateNeedOracle(List<LearnerHandler>) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
 
updateNeedOracle(List<LearnerHandler>) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
updateQuotaStat(String, long, int) - Method in class org.apache.zookeeper.server.DataTree
update the count/bytes of this stat data node
updateServerList(Collection<InetSocketAddress>, InetSocketAddress) - Method in interface org.apache.zookeeper.client.HostProvider
Update the list of servers.
updateServerList(Collection<InetSocketAddress>, InetSocketAddress) - Method in class org.apache.zookeeper.client.StaticHostProvider
Update the list of servers.
updateServerList(String) - Method in class org.apache.zookeeper.ZooKeeper
This function allows a client to update the connection string by providing a new comma separated list of host:port pairs, each corresponding to a ZooKeeper server.
updateStatsForResponse(long, long, String, long, long) - Method in class org.apache.zookeeper.server.ServerCnxn
 
upgrade(Connection) - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
upgrade(long) - Method in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
Implements the SessionUpgrader interface,
upgradeableSessionTracker - Variable in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
 
UpgradeableSessionTracker - Class in org.apache.zookeeper.server.quorum
A session tracker that supports upgradeable local sessions.
UpgradeableSessionTracker() - Constructor for class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
 
upgradeSession(long) - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
Upgrades the session to a global session.
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

validate(File) - Method in class org.apache.zookeeper.server.util.VerifyingFileFactory
 
validateFileInput(String) - Static method in class org.apache.zookeeper.ZKUtil
 
validatePath(String, boolean) - Static method in class org.apache.zookeeper.common.PathUtils
validate the provided znode path string
validatePath(String) - Static method in class org.apache.zookeeper.common.PathUtils
Validate the provided znode path string
validateServerId(long) - Static method in enum org.apache.zookeeper.server.EphemeralType
Make sure the given server ID is compatible with the current extended ephemeral setting
validateSession(ServerCnxn, long) - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
 
validateSession(ServerCnxn, long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
Validate if a particular session can be reestablished.
validateTTL(CreateMode, long) - Static method in enum org.apache.zookeeper.server.EphemeralType
Utility to validate a create mode and a ttl
valueOf(String) - Static method in enum org.apache.zookeeper.AddWatchMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.audit.AuditEvent.FieldName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.audit.AuditEvent.Result
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.cli.CommandFactory.Command
Returns the enum constant of this type with the specified name.
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.common.FileChangeWatcher.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.common.KeyStoreFileType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.common.X509Util.ClientAuth
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.metrics.MetricsContext.DetailLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.Op.OpKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.server.controller.ControlCommand.Action
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.embedded.ExitHandler
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.server.EphemeralType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.server.EphemeralTypeEmulate353
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.server.ExitCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.server.NettyServerCnxn.HandshakeState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.server.persistence.SnapStream.StreamMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.server.PrepRequestProcessor.DigestOpCode
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.LearnerSyncThrottler.SyncType
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.quorum.QuorumPeer.SyncMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.server.quorum.QuorumPeer.ZabState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.server.ServerCnxn.DisconnectReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.server.watch.WatcherMode
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.Watcher.WatcherType
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.AddWatchMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.zookeeper.audit.AuditEvent.FieldName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.zookeeper.audit.AuditEvent.Result
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.zookeeper.cli.CommandFactory.Command
Returns an array containing the constants of this enum type, in the order they are declared.
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.common.FileChangeWatcher.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.common.KeyStoreFileType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.zookeeper.common.X509Util.ClientAuth
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() - Method in interface org.apache.zookeeper.metrics.GaugeSet
Returns all values and the associated keys of the GaugeSet.
values() - Static method in enum org.apache.zookeeper.metrics.MetricsContext.DetailLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.zookeeper.Op.OpKind
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.controller.ControlCommand.Action
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.embedded.ExitHandler
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.EphemeralType
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.EphemeralTypeEmulate353
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.ExitCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
 
values() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounterSet
 
values() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounter
 
values() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounterSet
 
values() - Method in class org.apache.zookeeper.server.metric.Metric
 
values() - Method in class org.apache.zookeeper.server.metric.SimpleCounter
 
values() - Method in class org.apache.zookeeper.server.metric.SimpleCounterSet
 
values() - Static method in enum org.apache.zookeeper.server.NettyServerCnxn.HandshakeState
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.persistence.SnapStream.StreamMode
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.PrepRequestProcessor.DigestOpCode
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.LearnerSyncThrottler.SyncType
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.quorum.QuorumPeer.SyncMode
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.ZabState
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.ServerCnxn.DisconnectReason
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.watch.WatcherMode
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.Watcher.WatcherType
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.
VerifyingFileFactory - Class in org.apache.zookeeper.server.util
 
VerifyingFileFactory(VerifyingFileFactory.Builder) - Constructor for class org.apache.zookeeper.server.util.VerifyingFileFactory
 
VerifyingFileFactory.Builder - Class in org.apache.zookeeper.server.util
 
VERSION - Static variable in class org.apache.zookeeper.server.persistence.FileTxnLog
 
VERSION - Static variable in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
 
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
 
VersionCommand - Class in org.apache.zookeeper.cli
version command for cli
VersionCommand() - Constructor for class org.apache.zookeeper.cli.VersionCommand
 
VersionInfoMain - Class in org.apache.zookeeper.version
 
VersionInfoMain() - Constructor for class org.apache.zookeeper.version.VersionInfoMain
 
viewContains(Long) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Check if a node is in the current view.
visitSubTreeDFS(ZooKeeper, String, boolean, AsyncCallback.StringCallback) - Static method in class org.apache.zookeeper.ZKUtil
Visits the subtree with root as given path and calls the passed callback with each znode found during the search.
Vote - Class in org.apache.zookeeper.server.quorum
 
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(int, long, long, long, long, QuorumPeer.ServerState) - 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
 
VotingViewCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.VotingViewCommand
 

W

waitForEmptyPool() - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
 
waitForEpochAck(long, StateSummary) - Method in class org.apache.zookeeper.server.quorum.Leader
 
waitForEpochAck(long, StateSummary) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
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.
waitForNewLeaderAck(long, long) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
waitForStartup() - Method in class org.apache.zookeeper.server.quorum.Leader
 
waitForStartup() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
 
WARN_THRESHOLD_DEFAULT - Static variable in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
WARN_THRESHOLD_KEY - Static variable in class org.apache.zookeeper.server.util.JvmPauseMonitor
 
warnForRelativePath() - Method in class org.apache.zookeeper.server.util.VerifyingFileFactory.Builder
 
WARNING_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
warnThresholdMs - Variable in class org.apache.zookeeper.server.util.JvmPauseMonitor
log WARN if we detect a pause longer than this threshold
WATCH_BYTES - Variable in class org.apache.zookeeper.server.ServerMetrics
 
WatchCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.WatchCommand
 
WatchCommand - Class in org.apache.zookeeper.server.command
 
WatchCommand(PrintWriter, ServerCnxn, int) - Constructor for class org.apache.zookeeper.server.command.WatchCommand
 
WatchDeregistration - Class in org.apache.zookeeper
Handles the special case of removing watches which has registered for a client path
WatchDeregistration(String, Watcher, Watcher.WatcherType, boolean, ZKWatchManager) - Constructor for class org.apache.zookeeper.WatchDeregistration
 
WatchedEvent - Class in org.apache.zookeeper
A WatchedEvent represents a change on the ZooKeeper that a Watcher is able to respond to.
WatchedEvent(Watcher.Event.EventType, Watcher.Event.KeeperState, String) - Constructor for class org.apache.zookeeper.WatchedEvent
Create a WatchedEvent with specified type, state and path
WatchedEvent(WatcherEvent) - Constructor for class org.apache.zookeeper.WatchedEvent
Convert a WatcherEvent sent over the wire into a full-fledged WatcherEvent
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
Watcher.WatcherType - Enum in org.apache.zookeeper
Enumeration of types of watchers
WatcherCleaner - Class in org.apache.zookeeper.server.watch
Thread used to lazily clean up the closed watcher, it will trigger the clean up when the dead watchers get certain number or some number of seconds has elapsed since last clean up.
WatcherCleaner(IDeadWatcherListener) - Constructor for class org.apache.zookeeper.server.watch.WatcherCleaner
 
WatcherCleaner(IDeadWatcherListener, int, int, int, int) - Constructor for class org.apache.zookeeper.server.watch.WatcherCleaner
 
WatcherMode - Enum in org.apache.zookeeper.server.watch
 
WatcherOrBitSet - Class in org.apache.zookeeper.server.watch
 
WatcherOrBitSet(Set<Watcher>) - Constructor for class org.apache.zookeeper.server.watch.WatcherOrBitSet
 
WatcherOrBitSet(BitHashSet) - Constructor for class org.apache.zookeeper.server.watch.WatcherOrBitSet
 
WatchesByPathCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.WatchesByPathCommand
 
WatchesPathReport - Class in org.apache.zookeeper.server.watch
A watch report, essentially a mapping of path to session IDs of sessions that have set a watch on that path.
WatchesReport - Class in org.apache.zookeeper.server.watch
A watch report, essentially a mapping of session ID to paths that the session has set a watch on.
WatchesSummary - Class in org.apache.zookeeper.server.watch
A summary of watch information.
WatchManager - Class in org.apache.zookeeper.server.watch
This class manages watches.
WatchManager() - Constructor for class org.apache.zookeeper.server.watch.WatchManager
 
WatchManagerFactory - Class in org.apache.zookeeper.server.watch
A factory used to produce the actual watch manager based on the zookeeper.watchManagerName option.
WatchManagerFactory() - Constructor for class org.apache.zookeeper.server.watch.WatchManagerFactory
 
WatchManagerOptimized - Class in org.apache.zookeeper.server.watch
Optimized in memory and time complexity, compared to WatchManager, both the memory consumption and time complexity improved a lot, but it cannot efficiently remove the watcher when the session or socket is closed, for majority use case this is not a problem.
WatchManagerOptimized() - Constructor for class org.apache.zookeeper.server.watch.WatchManagerOptimized
 
WatchRegistration(Watcher, String) - Constructor for class org.apache.zookeeper.ZooKeeper.WatchRegistration
 
WatchSummaryCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.WatchSummaryCommand
 
wchcCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
wchpCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
wchsCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
 
WEIGHED_CONNECTION_THROTTLE - Static variable in class org.apache.zookeeper.server.BlueThrottle
 
whoAmI - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
whoAmI() - Method in class org.apache.zookeeper.ZooKeeper
Gives all authentication information added into the current session.
WhoAmICommand - Class in org.apache.zookeeper.cli
WhoAmI command for cli
WhoAmICommand() - Constructor for class org.apache.zookeeper.cli.WhoAmICommand
 
WINDOWS - Static variable in class org.apache.zookeeper.Shell
Set to true on Windows platforms
workerPool - Variable in class org.apache.zookeeper.server.NIOServerCnxnFactory
 
workerPool - Variable in class org.apache.zookeeper.server.quorum.CommitProcessor
 
WorkerService - Class in org.apache.zookeeper.server
WorkerService is a worker thread pool for running tasks and is implemented using one or more ExecutorServices.
WorkerService(String, int, boolean) - Constructor for class org.apache.zookeeper.server.WorkerService
 
WorkerService.WorkRequest - Class in org.apache.zookeeper.server
Callers should implement a class extending WorkRequest in order to schedule work with the service.
WorkRequest() - Constructor for class org.apache.zookeeper.server.WorkerService.WorkRequest
 
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(OutputStream) - Method in interface org.apache.zookeeper.common.AtomicFileWritingIdiom.OutputStreamStatement
 
write(Writer) - Method in interface org.apache.zookeeper.common.AtomicFileWritingIdiom.WriterStatement
 
write(Callback, ByteBuffer...) - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
 
write(int) - Method in class org.apache.zookeeper.server.ByteBufferOutputStream
 
write(byte[]) - Method in class org.apache.zookeeper.server.ByteBufferOutputStream
 
write(byte[], int, int) - Method in class org.apache.zookeeper.server.ByteBufferOutputStream
 
write(T) - Method in class org.apache.zookeeper.server.util.CircularBuffer
Puts elements in the next available index in the array.
WRITE - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
 
WRITE_BATCH_TIME_IN_COMMIT_PROCESSOR - Variable in class org.apache.zookeeper.server.ServerMetrics
 
WRITE_COMMITPROC_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
Time spent by a write request in the commit processor.
WRITE_FINAL_PROC_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
 
WRITE_PER_NAMESPACE - Variable in class org.apache.zookeeper.server.ServerMetrics
 
writeDynamicConfig(String, QuorumVerifier, boolean) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
Writes dynamic configuration file
WRITES_ISSUED_IN_COMMIT_PROC - Variable in class org.apache.zookeeper.server.ServerMetrics
 
WRITES_QUEUED_IN_COMMIT_PROCESSOR - Variable in class org.apache.zookeeper.server.ServerMetrics
 
writeTxnBytes(OutputArchive, byte[]) - Static method in class org.apache.zookeeper.server.persistence.Util
Write the serialized transaction record to the output archive.

X

X509AuthenticationProvider - Class in org.apache.zookeeper.server.auth
An AuthenticationProvider backed by an X509TrustManager and an X509KeyManager to perform remote host certificate authentication.
X509AuthenticationProvider() - Constructor for class org.apache.zookeeper.server.auth.X509AuthenticationProvider
Initialize the X509AuthenticationProvider with a JKS KeyStore and JKS TrustStore according to the following system properties:
zookeeper.ssl.keyStore.location
zookeeper.ssl.trustStore.location
zookeeper.ssl.keyStore.password
zookeeper.ssl.keyStore.passwordPath
zookeeper.ssl.trustStore.password
zookeeper.ssl.trustStore.passwordPath
X509AuthenticationProvider(X509TrustManager, X509KeyManager) - Constructor for class org.apache.zookeeper.server.auth.X509AuthenticationProvider
Initialize the X509AuthenticationProvider with the provided X509TrustManager and X509KeyManager.
X509Exception - Exception in org.apache.zookeeper.common
 
X509Exception(String) - Constructor for exception org.apache.zookeeper.common.X509Exception
 
X509Exception(Throwable) - Constructor for exception org.apache.zookeeper.common.X509Exception
 
X509Exception(String, Throwable) - Constructor for exception org.apache.zookeeper.common.X509Exception
 
X509Exception.KeyManagerException - Exception in org.apache.zookeeper.common
 
X509Exception.SSLContextException - Exception in org.apache.zookeeper.common
 
X509Exception.TrustManagerException - Exception in org.apache.zookeeper.common
 
X509Util - Class in org.apache.zookeeper.common
Utility code for X509 handling Default cipher suites: Performance testing done by Facebook engineers shows that on Intel x86_64 machines, Java9 performs better with GCM and Java8 performs better with CBC, so these seem like reasonable defaults.
X509Util() - Constructor for class org.apache.zookeeper.common.X509Util
 
X509Util(ZKConfig) - Constructor for class org.apache.zookeeper.common.X509Util
 
X509Util.ClientAuth - Enum in org.apache.zookeeper.common
Enum specifying the client auth requirement of server-side TLS sockets created by this X509Util.
xid - Variable in class org.apache.zookeeper.ClientCnxn
 
XidRolloverException(String) - Constructor for exception org.apache.zookeeper.server.quorum.Leader.XidRolloverException
 

Z

ZabStateCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.ZabStateCommand
 
zk - Variable in class org.apache.zookeeper.cli.CliCommand
 
zk - Variable in class org.apache.zookeeper.ZooKeeperMain
 
ZK_NOT_SERVING - Static variable in class org.apache.zookeeper.server.command.AbstractFourLetterCommand
 
ZK_SASL_CLIENT_CANONICALIZE_HOSTNAME - Static variable in class org.apache.zookeeper.client.ZKClientConfig
 
ZK_SASL_CLIENT_CANONICALIZE_HOSTNAME_DEFAULT - Static variable in class org.apache.zookeeper.client.ZKClientConfig
 
ZK_SASL_CLIENT_USERNAME - Static variable in class org.apache.zookeeper.client.ZKClientConfig
 
ZK_SASL_CLIENT_USERNAME_DEFAULT - Static variable in class org.apache.zookeeper.client.ZKClientConfig
 
ZKAuditProvider - Class in org.apache.zookeeper.audit
 
ZKAuditProvider() - Constructor for class org.apache.zookeeper.audit.ZKAuditProvider
 
ZKClientConfig - Class in org.apache.zookeeper.client
Handles client specific properties
ZKClientConfig() - Constructor for class org.apache.zookeeper.client.ZKClientConfig
 
ZKClientConfig(File) - Constructor for class org.apache.zookeeper.client.ZKClientConfig
 
ZKClientConfig(String) - Constructor for class org.apache.zookeeper.client.ZKClientConfig
 
ZKConfig - Class in org.apache.zookeeper.common
This class is a base class for the configurations of both client and server.
ZKConfig() - Constructor for class org.apache.zookeeper.common.ZKConfig
properties, which are common to both client and server, are initialized from system properties
ZKConfig(String) - Constructor for class org.apache.zookeeper.common.ZKConfig
 
ZKConfig(File) - Constructor for class org.apache.zookeeper.common.ZKConfig
 
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.command.AbstractFourLetterCommand
 
zkServer - Variable in class org.apache.zookeeper.server.ServerCnxnFactory
 
ZKTrustManager - Class in org.apache.zookeeper.common
A custom TrustManager that supports hostname verification via org.apache.http.conn.ssl.DefaultHostnameVerifier.
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.AddWatchModes - Interface in org.apache.zookeeper
 
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, ZKClientConfig) - 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, HostProvider) - 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, HostProvider, ZKClientConfig) - 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, boolean, ZKClientConfig) - 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, HostProvider) - 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, HostProvider, ZKClientConfig) - 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.States - Enum in org.apache.zookeeper
 
ZooKeeper.WatchRegistration - Class in org.apache.zookeeper
Register a watcher for a particular path.
ZOOKEEPER_CLIENT_CNXN_SOCKET - Static variable in class org.apache.zookeeper.client.ZKClientConfig
 
ZOOKEEPER_CLIENT_CNXN_SOCKET - Static variable in class org.apache.zookeeper.ZooKeeper
ZOOKEEPER_COMMIT_PROC_MAX_COMMIT_BATCH_SIZE - Static variable in class org.apache.zookeeper.server.quorum.CommitProcessor
Default max commit batch size: 1
ZOOKEEPER_COMMIT_PROC_MAX_READ_BATCH_SIZE - Static variable in class org.apache.zookeeper.server.quorum.CommitProcessor
Default max read batch size: -1 to disable the feature
ZOOKEEPER_COMMIT_PROC_NUM_WORKER_THREADS - Static variable in class org.apache.zookeeper.server.quorum.CommitProcessor
Default: numCores
ZOOKEEPER_COMMIT_PROC_SHUTDOWN_TIMEOUT - Static variable in class org.apache.zookeeper.server.quorum.CommitProcessor
Default worker pool shutdown timeout in ms: 5000 (5s)
ZOOKEEPER_DATADIR_AUTOCREATE - Static variable in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
 
ZOOKEEPER_DATADIR_AUTOCREATE_DEFAULT - Static variable in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
 
ZOOKEEPER_DIGEST_ENABLED - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
ZOOKEEPER_MAX_CONNECTION_DEFAULT - Static variable in class org.apache.zookeeper.server.ServerCnxnFactory
 
ZOOKEEPER_NIO_DIRECT_BUFFER_BYTES - Static variable in class org.apache.zookeeper.server.NIOServerCnxnFactory
Default: 64kB
ZOOKEEPER_NIO_NUM_SELECTOR_THREADS - Static variable in class org.apache.zookeeper.server.NIOServerCnxnFactory
With 500 connections to an observer with watchers firing on each, is unable to exceed 1GigE rates with only 1 selector.
ZOOKEEPER_NIO_NUM_WORKER_THREADS - Static variable in class org.apache.zookeeper.server.NIOServerCnxnFactory
Default: 2 * numCores
ZOOKEEPER_NIO_SESSIONLESS_CNXN_TIMEOUT - Static variable in class org.apache.zookeeper.server.NIOServerCnxnFactory
Default sessionless connection timeout in ms: 10000 (10s)
ZOOKEEPER_NIO_SHUTDOWN_TIMEOUT - Static variable in class org.apache.zookeeper.server.NIOServerCnxnFactory
Default worker pool shutdown timeout in ms: 5000 (5s)
ZOOKEEPER_NODE_SUBTREE - Static variable in class org.apache.zookeeper.ZooDefs
 
ZOOKEEPER_REQUEST_TIMEOUT - Static variable in class org.apache.zookeeper.client.ZKClientConfig
 
ZOOKEEPER_REQUEST_TIMEOUT_DEFAULT - Static variable in class org.apache.zookeeper.client.ZKClientConfig
Feature is disabled by default.
ZOOKEEPER_SERVER_CNXN_FACTORY - Static variable in class org.apache.zookeeper.server.ServerCnxnFactory
 
ZOOKEEPER_SERVER_PRINCIPAL - Static variable in class org.apache.zookeeper.client.ZKClientConfig
 
ZOOKEEPER_SERVER_REALM - Static variable in class org.apache.zookeeper.client.ZKClientConfig
 
ZOOKEEPER_SHAPSHOT_STREAM_MODE - Static variable in class org.apache.zookeeper.server.persistence.SnapStream
 
ZOOKEEPER_SNAPSHOT_TRUST_EMPTY - Static variable in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
 
ZOOKEEPER_WATCH_MANAGER_NAME - Static variable in class org.apache.zookeeper.server.watch.WatchManagerFactory
 
ZooKeeperAdmin - Class in org.apache.zookeeper.admin
This is the main class for ZooKeeperAdmin client library.
ZooKeeperAdmin(String, int, Watcher) - Constructor for class org.apache.zookeeper.admin.ZooKeeperAdmin
Create a ZooKeeperAdmin object which is used to perform dynamic reconfiguration operations.
ZooKeeperAdmin(String, int, Watcher, ZKClientConfig) - Constructor for class org.apache.zookeeper.admin.ZooKeeperAdmin
Create a ZooKeeperAdmin object which is used to perform dynamic reconfiguration operations.
ZooKeeperAdmin(String, int, Watcher, boolean, ZKClientConfig) - Constructor for class org.apache.zookeeper.admin.ZooKeeperAdmin
Create a ZooKeeperAdmin object which is used to perform dynamic reconfiguration operations.
ZooKeeperAdmin(String, int, Watcher, boolean) - Constructor for class org.apache.zookeeper.admin.ZooKeeperAdmin
Create a ZooKeeperAdmin object which is used to perform dynamic reconfiguration operations.
ZookeeperBanner - Class in org.apache.zookeeper
ZookeeperBanner which writes the 'Zookeeper' banner at the start of zk server.
ZookeeperBanner() - Constructor for class org.apache.zookeeper.ZookeeperBanner
 
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 - Class in org.apache.zookeeper.client
This class manages SASL authentication for the client.
ZooKeeperSaslClient(String, ZKClientConfig) - 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(FileTxnSnapLog, int, int, int, int, ZKDatabase, String) - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
Keeping this constructor for backward compatibility
ZooKeeperServer(FileTxnSnapLog, int, int, int, int, ZKDatabase, String, boolean) - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
* Creates a ZooKeeperServer instance.
ZooKeeperServer(JvmPauseMonitor, FileTxnSnapLog, int, int, int, int, ZKDatabase, String) - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
ZooKeeperServer(FileTxnSnapLog, int, String) - 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) - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
Default constructor, relies on the config for its argument values
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
 
ZooKeeperServerConf - Class in org.apache.zookeeper.server
Configuration data for a ZooKeeperServer.
ZooKeeperServerController - Class in org.apache.zookeeper.server.controller
Class which accepts commands to modify ZooKeeperServer state or Connection state at runtime for the purpose of single machine integration testing.
ZooKeeperServerController(QuorumPeerConfig) - Constructor for class org.apache.zookeeper.server.controller.ZooKeeperServerController
 
ZooKeeperServerEmbedded - Interface in org.apache.zookeeper.server.embedded
This API allows you to start a ZooKeeper server node from Java code
ZooKeeperServerEmbedded.ZookKeeperServerEmbeddedBuilder - Class in org.apache.zookeeper.server.embedded
Builder for ZooKeeperServerEmbedded.
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.
ZooKeeperServerShutdownHandler - Class in org.apache.zookeeper.server
ZooKeeper server shutdown handler which will be used to handle ERROR or SHUTDOWN server state transitions, which in turn releases the associated shutdown latch.
ZooKeeperThread - Class in org.apache.zookeeper.server
This is the main class for catching all the uncaught exceptions thrown by the threads.
ZooKeeperThread(String) - Constructor for class org.apache.zookeeper.server.ZooKeeperThread
 
ZookKeeperServerEmbeddedBuilder() - Constructor for class org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded.ZookKeeperServerEmbeddedBuilder
 
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.persistence.SnapshotInfo
 
zxid - Variable in class org.apache.zookeeper.server.Request
 
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
 
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 
Skip navigation links

Copyright © 2008–2023 The Apache Software Foundation. All rights reserved.