A B C D E F G H I J K L M N O P Q R S T U V W X Z
All Classes All Packages
All Classes All Packages
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
- ACL - org.apache.zookeeper.audit.AuditEvent.FieldName
- 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(int, long) - Method in class org.apache.zookeeper.server.metric.Metric
- add(long) - Method in interface org.apache.zookeeper.metrics.Counter
-
Increment the value by a given amount.
- add(long) - Method in interface org.apache.zookeeper.metrics.Summary
-
Register a value.
- add(long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
- add(long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounter
- add(long) - Method in class org.apache.zookeeper.server.metric.Metric
- add(long) - Method in class org.apache.zookeeper.server.metric.SimpleCounter
- add(E) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
- add(Integer) - Method in class org.apache.zookeeper.server.util.BitHashSet
- add(String, long) - Method in interface org.apache.zookeeper.metrics.CounterSet
-
Increment the value by a given amount for the given key
- add(String, long) - Method in interface org.apache.zookeeper.metrics.SummarySet
-
Register a value.
- add(String, long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounterSet
- add(String, long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounterSet
- add(String, long) - Method in class org.apache.zookeeper.server.metric.Metric
- add(String, long) - Method in class org.apache.zookeeper.server.metric.SimpleCounterSet
- add(Op) - Method in class org.apache.zookeeper.MultiOperationRecord
- add(OpResult) - Method in class org.apache.zookeeper.MultiResponse
- add(T) - Method in class org.apache.zookeeper.server.util.BitMap
- ADD - org.apache.zookeeper.server.PrepRequestProcessor.DigestOpCode
- ADD_AUTH - org.apache.zookeeper.cli.CommandFactory.Command
- ADD_DEAD_WATCHER_STALL_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
- ADD_WATCH - org.apache.zookeeper.cli.CommandFactory.Command
- 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(String, byte[]) - Method in class org.apache.zookeeper.ZooKeeper
-
Add the specified scheme:auth information to this connection.
- addAuthInfo(Id) - Method in class org.apache.zookeeper.server.ServerCnxn
- 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(long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounter
- addDataPoint(String, long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounterSet
- addDataPoint(String, long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounterSet
- addDeadWatcher(int) - Method in class org.apache.zookeeper.server.watch.WatcherCleaner
- ADDDELAY - org.apache.zookeeper.server.controller.ControlCommand.Action
- 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.
- addHeader(String, String) - Method in class org.apache.zookeeper.server.admin.CommandResponse
-
Adds a header to this response.
- 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
- addMode(WatcherMode) - Method in class org.apache.zookeeper.server.watch.WatchStats
-
Compute stats after given mode attached to node.
- addOrUpdateProvider(String) - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
- 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 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- addWatch(String, AddWatchMode) - Method in class org.apache.zookeeper.ZooKeeper
-
Add a watch to the given znode using the given mode.
- addWatch(String, AddWatchMode, AsyncCallback.VoidCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
Async version of
ZooKeeper.addWatch(String, AddWatchMode)
(see it for details) - addWatch(String, Watcher) - 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) - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
- addWatch(String, Watcher, int) - Method in class org.apache.zookeeper.server.DataTree
- addWatch(String, Watcher, int) - Method in class org.apache.zookeeper.server.ZKDatabase
-
Add a watch
- addWatch(String, Watcher, 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, Watcher, WatcherMode) - Method in interface org.apache.zookeeper.server.watch.IWatchManager
-
Add watch to specific path.
- addWatch(String, Watcher, WatcherMode) - Method in class org.apache.zookeeper.server.watch.WatchManager
- 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
-
Modes available to
ZooKeeper.addWatch(String, Watcher, AddWatchMode)
- 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
- ADVANCED - org.apache.zookeeper.metrics.MetricsContext.DetailLevel
-
It is expected that the returned Summary performs expensive aggregations, like percentiles.
- ALL - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
- allow() - Method in class org.apache.zookeeper.server.util.RateLimiter
- ALLOW_SASL_FAILED_CLIENTS - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
- Any - org.apache.zookeeper.Watcher.WatcherType
- ANYONE_ID_UNSAFE - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
-
This Id represents anyone.
- APIError - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.APIERROR
instead - APIERROR - org.apache.zookeeper.KeeperException.Code
-
API errors.
- APIErrorException() - Constructor for exception org.apache.zookeeper.KeeperException.APIErrorException
- append(Request) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
- append(Request) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
append the request to the transaction logs
- append(Request) - 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
- appendRequest(TxnHeader, Record, TxnDigest) - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
-
Build a request for the txn and append it to the transaction log
- approximateDataSize() - Method in class org.apache.zookeeper.server.DataTree
-
Get the size of the nodes based on path and data length.
- approximateDataSize() - Method in class org.apache.zookeeper.server.DataTreeBean
- approximateDataSize() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
- 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
- ASSOCIATING - org.apache.zookeeper.ZooKeeper.States
- AsyncCallback - Interface in org.apache.zookeeper
-
Interface definitions of asynchronous callbacks.
- AsyncCallback.ACLCallback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the ACL and stat of the node.
- AsyncCallback.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_FAILED - org.apache.zookeeper.ZooKeeper.States
- AUTH_IDS - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
-
This Id is only usable to set ACLs.
- AUTH_PROVIDER_NOT_FOUND - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- authenticate(Socket, DataInputStream) - Method in class org.apache.zookeeper.server.quorum.auth.NullQuorumAuthServer
- authenticate(Socket, DataInputStream) - Method in interface org.apache.zookeeper.server.quorum.auth.QuorumAuthServer
-
Performs an authentication step for the given socket connection.
- authenticate(Socket, DataInputStream) - Method in class org.apache.zookeeper.server.quorum.auth.SaslQuorumAuthServer
- authenticate(Socket, String) - Method in class org.apache.zookeeper.server.quorum.auth.NullQuorumAuthLearner
- authenticate(Socket, String) - Method in interface org.apache.zookeeper.server.quorum.auth.QuorumAuthLearner
-
Performs an authentication step for the given socket connection.
- authenticate(Socket, String) - Method in class org.apache.zookeeper.server.quorum.auth.SaslQuorumAuthLearner
- 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 - org.apache.zookeeper.Watcher.Event.KeeperState
-
Auth failed state
- AuthFailed - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.AUTHFAILED
instead - AUTHFAILED - org.apache.zookeeper.KeeperException.Code
-
Client authentication failed
- AuthFailedException() - Constructor for exception org.apache.zookeeper.KeeperException.AuthFailedException
- 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
- AuthRequest - Class in org.apache.zookeeper.server.admin
-
Class representing auth data for performing ACL check on admin server commands.
- AuthRequest(int, String) - Constructor for class org.apache.zookeeper.server.admin.AuthRequest
- 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
- 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 - BADARGUMENTS - org.apache.zookeeper.KeeperException.Code
-
Invalid arguments
- BadArgumentsException() - Constructor for exception org.apache.zookeeper.KeeperException.BadArgumentsException
- BadArgumentsException(String) - Constructor for exception org.apache.zookeeper.KeeperException.BadArgumentsException
- BadVersion - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.BADVERSION
instead - BADVERSION - org.apache.zookeeper.KeeperException.Code
-
Version conflict In case of reconfiguration: reconfig requested from config version X but last seen config has a different version Y
- BadVersionException() - Constructor for exception org.apache.zookeeper.KeeperException.BadVersionException
- BadVersionException(String) - Constructor for exception org.apache.zookeeper.KeeperException.BadVersionException
- Base64OutputFormatter - Class in org.apache.zookeeper.cli
- Base64OutputFormatter() - Constructor for class org.apache.zookeeper.cli.Base64OutputFormatter
- baseDir(Path) - Method in class org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded.ZookKeeperServerEmbeddedBuilder
-
Base directory of the server.
- BASIC - org.apache.zookeeper.metrics.MetricsContext.DetailLevel
-
The returned Summary is expected to track only simple aggregated values, like min/max/avg
- BATCH_SIZE - Variable in class org.apache.zookeeper.server.ServerMetrics
- BCFKS - org.apache.zookeeper.common.KeyStoreFileType
- 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
- BROADCAST - org.apache.zookeeper.server.quorum.QuorumPeer.ZabState
- BUFFER_UNDERFLOW_EXCEPTION - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- 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.CreateOptions.Builder
- 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
- ByteBufferRequestRecord - Class in org.apache.zookeeper.server
- ByteBufferRequestRecord(ByteBuffer) - Constructor for class org.apache.zookeeper.server.ByteBufferRequestRecord
- 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
- CANCELLED_KEY_EXCEPTION - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- CHANNEL_CLOSED_EXCEPTION - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- CHANNEL_DISCONNECTED - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- check - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- check(String, int) - Static method in class org.apache.zookeeper.Op
-
Constructs an version check operation.
- check(String, int) - Method in class org.apache.zookeeper.Transaction
- 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) - Method in class org.apache.zookeeper.common.ZKTrustManager
- checkClientTrusted(X509Certificate[], String, Socket) - Method in class org.apache.zookeeper.common.ZKTrustManager
- checkClientTrusted(X509Certificate[], String, SSLEngine) - Method in class org.apache.zookeeper.common.ZKTrustManager
- checkContainers() - Method in class org.apache.zookeeper.server.ContainerManager
-
Manually check the containers.
- CHECKED - org.apache.zookeeper.server.persistence.SnapStream.StreamMode
- 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
- checkSealIntegrity(CheckedInputStream, InputArchive) - Static method in class org.apache.zookeeper.server.persistence.SnapStream
-
Verify the integrity of the seal, only CheckedInputStream will verify the checkSum of the content.
- checkServerTrusted(X509Certificate[], String) - Method in class org.apache.zookeeper.common.ZKTrustManager
- checkServerTrusted(X509Certificate[], String, Socket) - Method in class org.apache.zookeeper.common.ZKTrustManager
- checkServerTrusted(X509Certificate[], String, SSLEngine) - 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
- Children - org.apache.zookeeper.Watcher.WatcherType
- ChildWatchRemoved - org.apache.zookeeper.Watcher.Event.EventType
- 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
- CLEAN_UP - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- 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.
- cleanup(Logger, Closeable...) - Static method in class org.apache.zookeeper.common.IOUtils
-
Close the Closeable objects and ignore any
IOException
or null pointers. - 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.
- CliCommand(String, String, Options) - Constructor for class org.apache.zookeeper.cli.CliCommand
-
a CLI command with command string and options.
- CLIENT_CERT_RELOAD_KEY - Static variable in class org.apache.zookeeper.server.NettyServerCnxnFactory
- CLIENT_CLOSED_CONNECTION - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- CLIENT_CLOSED_SESSION - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- CLIENT_CNX_LIMIT - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- 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_RATE_LIMIT - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- CLIENT_RECONNECT - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- CLIENT_REQUEST_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
- CLIENT_ZXID_AHEAD - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- 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
-
X509 utilities specific for client-server communication framework.
- 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(String, Throwable) - Constructor for exception org.apache.zookeeper.cli.CliException
- CliException(String, Throwable, 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
- CliParseException - Exception in org.apache.zookeeper.cli
- CliParseException(String) - Constructor for exception org.apache.zookeeper.cli.CliParseException
- CliParseException(ParseException) - 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() - Method in interface org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded
-
Shutdown gracefully the server and wait for resources to be released.
- close() - Method in class org.apache.zookeeper.server.NettyServerCnxn
- 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
-
See
Socket.close()
. - 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(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.DumbWatcher
- close(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.NettyServerCnxn
-
Close the cnxn and remove it from the factory cnxns list.
- close(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.NIOServerCnxn
-
Close the cnxn and remove it from the factory cnxns list.
- close(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.ServerCnxn
- CLOSE - org.apache.zookeeper.cli.CommandFactory.Command
- CLOSE_ALL_CONNECTIONS_FORCED - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- CLOSE_CONNECTION_COMMAND - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- 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
- CLOSECONNECTION - org.apache.zookeeper.server.controller.ControlCommand.Action
- Closed - org.apache.zookeeper.Watcher.Event.KeeperState
-
The client has been closed.
- CLOSED - org.apache.zookeeper.ZooKeeper.States
- CloseRequestException(String, ServerCnxn.DisconnectReason) - Constructor for exception org.apache.zookeeper.server.ServerCnxn.CloseRequestException
- closeSession - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- closeSession(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- closeSession(long, ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- closeSession(ServerCnxn, RequestHeader) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- closeSock(SocketChannel) - Static method in class org.apache.zookeeper.server.NIOServerCnxn
-
Close resources associated with a sock.
- closeSocket() - Method in interface org.apache.zookeeper.Testable
-
Close the ClientCnxn socket for testing purposes
- 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 - Class in org.apache.zookeeper.server.command
- CnxnStatResetCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.CnxnStatResetCommand
- 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, AuthRequest) - 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) - Constructor for class org.apache.zookeeper.server.controller.CommandClient
- 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.
- 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, int) - Constructor for class org.apache.zookeeper.server.admin.CommandResponse
-
Creates a new response.
- CommandResponse(String, String, int, InputStream) - 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.RestoreCommand - Class in org.apache.zookeeper.server.admin
-
Restore from snapshot on the current server.
- 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.SnapshotCommand - Class in org.apache.zookeeper.server.admin
-
Take a snapshot of current server and stream out the data.
- 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.
- CommandUsageHelper - Class in org.apache.zookeeper.cli
- CommandUsageHelper() - Constructor for class org.apache.zookeeper.cli.CommandUsageHelper
- 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() - Method in class org.apache.zookeeper.server.ZKDatabase
-
commit to the underlying transaction log
- commit() - Method in class org.apache.zookeeper.Transaction
- commit(long) - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
-
When a COMMIT message is received, eventually this method is called, which matches up the zxid from the COMMIT with (hopefully) the head of the pendingTxns queue and hands it to the commitProcessor to commit.
- commit(long) - Method in class org.apache.zookeeper.server.quorum.Leader
-
Create a commit packet and send it to all the members of the quorum
- commit(AsyncCallback.MultiCallback, Object) - Method in class org.apache.zookeeper.Transaction
- commit(Request) - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
- 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 - Variable in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
- 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
- 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.
- COMPLETE - org.apache.zookeeper.client.ZooKeeperSaslClient.SaslState
- COMPLETED - org.apache.zookeeper.server.DatadirCleanupManager.PurgeTaskStatus
- 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 - Class in org.apache.zookeeper.server.command
- ConfCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.ConfCommand
- 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(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.NettyServerCnxnFactory
- configure(InetSocketAddress, int, int, boolean) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
- configure(InetSocketAddress, int, int, boolean) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
- 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.
- 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.
- CONNECTED - org.apache.zookeeper.ZooKeeper.States
- ConnectedReadOnly - org.apache.zookeeper.Watcher.Event.KeeperState
-
The client is connected to a read-only server, that is the server which is not currently connected to the majority.
- CONNECTEDREADONLY - org.apache.zookeeper.ZooKeeper.States
- connectedToPeer(long) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
- CONNECTING - org.apache.zookeeper.ZooKeeper.States
- connectingFollowers - Variable in class org.apache.zookeeper.server.quorum.Leader
- CONNECTION_CLOSE_FORCED - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- CONNECTION_DROP_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
- CONNECTION_EXPIRED - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- CONNECTION_MODE_CHANGED - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- 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 - CONNECTIONLOSS - org.apache.zookeeper.KeeperException.Code
-
Connection to the server has been lost
- ConnectionLossException() - Constructor for exception org.apache.zookeeper.KeeperException.ConnectionLossException
- ConnectionMXBean - Interface in org.apache.zookeeper.server
-
This MBean represents a client connection.
- 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 - Class in org.apache.zookeeper.server.command
- ConsCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.ConsCommand
- ConsCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.ConsCommand
- CONTAINER - org.apache.zookeeper.CreateMode
-
The znode will be a container node.
- CONTAINER - org.apache.zookeeper.server.EphemeralType
-
Container node
- CONTAINER - org.apache.zookeeper.server.EphemeralTypeEmulate353
-
Container node
- 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(int) - Method in class org.apache.zookeeper.server.watch.WatcherOrBitSet
- contains(Integer) - Method in class org.apache.zookeeper.server.util.BitHashSet
- contains(Object) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
- contains(Watcher) - Method in class org.apache.zookeeper.server.watch.WatcherOrBitSet
- 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) - 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.DataTree
- containsWatcher(String, Watcher.WatcherType, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
-
Check whether the given watcher exists in datatree
- containsWatcher(String, Watcher, WatcherMode) - Method in interface org.apache.zookeeper.server.watch.IWatchManager
-
Checks the specified watcher exists for the given path and mode.
- containsWatcher(String, Watcher, WatcherMode) - Method in class org.apache.zookeeper.server.watch.WatchManager
- 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(int, int, String) - Constructor for class org.apache.zookeeper.server.controller.ControllerServerConfig
-
Instantiate a config object with required parameters.
- 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.
- 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) - Static method in class org.apache.zookeeper.common.IOUtils
-
Copies from one stream to another.
- copyBytes(InputStream, OutputStream, int, boolean) - Static method in class org.apache.zookeeper.common.IOUtils
-
Copies from one stream to another.
- copyStat(Stat) - Method in class org.apache.zookeeper.server.DataNode
- copyStat(Stat, 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 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- create(int) - Static method in exception org.apache.zookeeper.KeeperException
-
Deprecated.deprecated in 3.1.0, use
KeeperException.create(Code)
instead - create(int, String) - Static method in exception org.apache.zookeeper.KeeperException
-
Deprecated.deprecated in 3.1.0, use
KeeperException.create(Code, String)
instead - create(String) - Method in class org.apache.zookeeper.server.util.VerifyingFileFactory
- 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) - Method in class org.apache.zookeeper.Transaction
- create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.zookeeper.ZooKeeper
-
Create a node with the given path.
- create(String, byte[], List<ACL>, CreateMode, long) - Static method in class org.apache.zookeeper.Op
-
Constructs a create operation.
- 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.
- 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, 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
-
same as
ZooKeeper.create(String, byte[], List, CreateMode, Stat)
but allows for specifying a TTL when mode isCreateMode.PERSISTENT_WITH_TTL
orCreateMode.PERSISTENT_SEQUENTIAL_WITH_TTL
. - create(String, byte[], CreateOptions) - Static method in class org.apache.zookeeper.Op
-
Constructs a create operation which uses
ZooDefs.OpCode.create2
if no one is inferred from create mode. - create(KeeperException.Code) - Static method in exception org.apache.zookeeper.KeeperException
-
All non-specific keeper exceptions should be constructed via this factory method in order to guarantee consistency in error codes and such.
- create(KeeperException.Code, String) - Static method in exception org.apache.zookeeper.KeeperException
-
All non-specific keeper exceptions should be constructed via this factory method in order to guarantee consistency in error codes and such.
- CREATE - org.apache.zookeeper.cli.CommandFactory.Command
- CREATE - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
- 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.
- createNettySslContextForClient(ZKConfig) - Method in class org.apache.zookeeper.common.ClientX509Util
- createNettySslContextForServer(ZKConfig) - Method in class org.apache.zookeeper.common.ClientX509Util
- createNettySslContextForServer(ZKConfig, KeyManager, TrustManager) - Method in class org.apache.zookeeper.common.ClientX509Util
- 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.
- CreateOptions - Class in org.apache.zookeeper
-
Options for creating znode in ZooKeeper data tree.
- CreateOptions.Builder - Class in org.apache.zookeeper
-
Builder for
CreateOptions
. - 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 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- 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
- 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() - Method in class org.apache.zookeeper.common.X509Util
- createSSLServerSocket(int) - Method in class org.apache.zookeeper.common.SSLContextAndOptions
- createSSLServerSocket(int) - Method in class org.apache.zookeeper.common.X509Util
- createSSLSocket() - 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.SSLContextAndOptions
- 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, 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
- Data - org.apache.zookeeper.Watcher.WatcherType
- 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 - DATAINCONSISTENCY - org.apache.zookeeper.KeeperException.Code
-
A data inconsistency was found
- DataInconsistencyException() - Constructor for exception org.apache.zookeeper.KeeperException.DataInconsistencyException
- dataLogDir - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
- dataLogDir - Variable in class org.apache.zookeeper.server.ServerConfig
- DataNode - Class in org.apache.zookeeper.server
-
This class contains the data for a node in the data tree.
- DataNode(byte[], Long, StatPersisted) - Constructor for class org.apache.zookeeper.server.DataNode
-
create a DataNode with parent, data, acls and stat
- dataTree - Variable in class org.apache.zookeeper.server.ZKDatabase
-
make sure on a clear you take care of all these members.
- DataTree - Class in org.apache.zookeeper.server
-
This class maintains the tree data structure.
- DataTree() - Constructor for class org.apache.zookeeper.server.DataTree
- DataTree.ProcessTxnResult - Class in org.apache.zookeeper.server
- 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.
- DataWatchRemoved - org.apache.zookeeper.Watcher.Event.EventType
- 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
- DEL_QUOTA - org.apache.zookeeper.cli.CommandFactory.Command
- 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 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- delete(String, int) - Static method in class org.apache.zookeeper.Op
-
Constructs a delete operation.
- delete(String, int) - Method in class org.apache.zookeeper.Transaction
- delete(String, int) - Method in class org.apache.zookeeper.ZooKeeper
-
Delete the node with the given path.
- delete(String, int, AsyncCallback.VoidCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of delete.
- DELETE - org.apache.zookeeper.cli.CommandFactory.Command
- DELETE - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
- DELETE_ALL - org.apache.zookeeper.cli.CommandFactory.Command
- 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
- DeleteContainerRequest - Class in org.apache.zookeeper
- DeleteContainerRequest() - Constructor for class org.apache.zookeeper.DeleteContainerRequest
- DeleteContainerRequest(String) - Constructor for class org.apache.zookeeper.DeleteContainerRequest
- 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) - 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, int) - Static method in class org.apache.zookeeper.ZKUtil
-
Recursively delete the node with the given path.
- deleteRecursive(ZooKeeper, String, AsyncCallback.VoidCallback, Object) - Static method in class org.apache.zookeeper.ZKUtil
-
Recursively delete the node with the given path.
- 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) - Method in class org.apache.zookeeper.server.DataTree.ZxidDigest
- deserialize(InputArchive) - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
- deserialize(InputArchive, String) - Method in class org.apache.zookeeper.DeleteContainerRequest
- 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(DataTree, Map<Long, Integer>) - Method in class org.apache.zookeeper.server.persistence.FileSnap
-
deserialize a data tree from the most recent snapshot
- deserialize(DataTree, Map<Long, Integer>) - Method in interface org.apache.zookeeper.server.persistence.SnapShot
-
deserialize a data tree from the last valid snapshot and return the last zxid that was deserialized
- deserialize(DataTree, Map<Long, Integer>, InputArchive) - Static method in class org.apache.zookeeper.server.persistence.FileSnap
-
deserialize the datatree from an inputarchive
- deserializeConnectRequest(InputArchive) - Method in class org.apache.zookeeper.compat.ProtocolManager
-
Deserializing
ConnectRequest
should be specially handled for request from client version before and including ZooKeeper 3.3 which doesn't understand readOnly field. - deserializeConnectResponse(InputArchive) - Method in class org.apache.zookeeper.compat.ProtocolManager
-
Deserializing
ConnectResponse
should be specially handled for response from server version before and including ZooKeeper 3.3 which doesn't understand readOnly field. - deserializeLastProcessedZxid(InputArchive) - Method in class org.apache.zookeeper.server.DataTree
-
Deserializes the lastProcessedZxid from the input stream and updates the lastProcessedZxid field.
- deserializeSnapshot(InputArchive) - Method in class org.apache.zookeeper.server.ZKDatabase
-
deserialize a snapshot from an input archive
- deserializeSnapshot(InputArchive, CheckedInputStream) - Method in class org.apache.zookeeper.server.ZKDatabase
-
Deserialize a snapshot that contains FileHeader from an input archive.
- deserializeSnapshot(DataTree, InputArchive, Map<Long, Integer>) - Static method in class org.apache.zookeeper.server.util.SerializeUtils
- 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 - org.apache.zookeeper.server.quorum.LearnerSyncThrottler.SyncType
- DIFF - org.apache.zookeeper.server.quorum.QuorumPeer.SyncMode
- 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 - Class in org.apache.zookeeper.server.command
-
Command used to dump the latest digest histories.
- DigestCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.DigestCommand
- 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 - Class in org.apache.zookeeper.server.command
- DirsCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.DirsCommand
- 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.
- Disconnected - org.apache.zookeeper.Watcher.Event.KeeperState
-
The client is in the disconnected state - it is not connected to any server in the ensemble.
- disconnectReason - Variable in class org.apache.zookeeper.server.ServerCnxn
- DISCOVERY - org.apache.zookeeper.server.quorum.QuorumPeer.ZabState
- 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(PrintWriter) - Method in class org.apache.zookeeper.server.ExpiryQueue
- dump(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
- 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(Scanner) - Method in class org.apache.zookeeper.server.persistence.TxnLogToolkit
- dumpCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
- DumpCommand - Class in org.apache.zookeeper.server.command
- DumpCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.DumpCommand
- 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 - org.apache.zookeeper.server.quorum.QuorumPeer.ZabState
- 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
- ELECTNEWLEADER - org.apache.zookeeper.server.controller.ControlCommand.Action
- 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
-
Deprecated.Use
ZKClientConfig.ENABLE_CLIENT_SASL_DEFAULT
instead. - 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.Use
ZKClientConfig.ENABLE_CLIENT_SASL_KEY
instead. - 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 - Class in org.apache.zookeeper.server.command
- EnvCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.EnvCommand
- 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
- EPHEMERAL - org.apache.zookeeper.CreateMode
-
The znode will be deleted upon the client's disconnect.
- EPHEMERAL_SEQUENTIAL - org.apache.zookeeper.CreateMode
-
The znode will be deleted upon the client's disconnect, and its name will be appended with a monotonically increasing number.
- EphemeralOnLocalSession - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.
- EPHEMERALONLOCALSESSION - org.apache.zookeeper.KeeperException.Code
-
Attempt to create ephemeral node on a local session
- 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 - org.apache.zookeeper.server.quorum.auth.QuorumAuth.Status
- ERROR - org.apache.zookeeper.server.ZooKeeperServer.State
- ERROR_RESPONSE - Static variable in class org.apache.zookeeper.server.admin.JsonOutputter
- ERROR_STARTING_ADMIN_SERVER - org.apache.zookeeper.server.ExitCode
-
Unable to start admin server at ZooKeeper startup
- 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...) - Static method in class org.apache.zookeeper.Shell
-
Static method to execute a shell command.
- execCommand(Map<String, String>, String[], long) - Static method in class org.apache.zookeeper.Shell
-
Static method to execute a shell command.
- execute() - Method in class org.apache.zookeeper.Shell.ShellCommandExecutor
-
Execute the 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
- executeLine(String) - Method in class org.apache.zookeeper.ZooKeeperMain
- EXECUTION_FINISHED - org.apache.zookeeper.server.ExitCode
-
Execution finished normally
- exists - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- exists(String, boolean) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the stat of the node of the given path.
- exists(String, boolean, AsyncCallback.StatCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of exists.
- exists(String, Watcher) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the stat of the node of the given path.
- exists(String, Watcher, AsyncCallback.StatCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of exists.
- 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.
- EXIT - org.apache.zookeeper.server.embedded.ExitHandler
-
Exit the Java process.
- exitCode - Variable in exception org.apache.zookeeper.cli.CliException
- exitCode - Variable in class org.apache.zookeeper.ZooKeeperMain
- ExitCode - Enum in org.apache.zookeeper.server
-
Exit code used to exit server
- ExitCodeException(int, String) - Constructor for exception org.apache.zookeeper.Shell.ExitCodeException
- exitHandler(ExitHandler) - Method in class org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded.ZookKeeperServerEmbeddedBuilder
-
Set the behaviour in case of hard system errors, see
ExitHandler
. - ExitHandler - Enum in org.apache.zookeeper.server.embedded
-
Behaviour of the server in case of internal error.
- expire(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- expire(SessionTracker.Session) - Method in interface org.apache.zookeeper.server.SessionTracker.SessionExpirer
- expire(SessionTracker.Session) - Method in class org.apache.zookeeper.server.ZooKeeperServer
- Expired - org.apache.zookeeper.Watcher.Event.KeeperState
-
The serving cluster has expired this session.
- EXPIRESESSION - org.apache.zookeeper.server.controller.ControlCommand.Action
- 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
- FAILED - org.apache.zookeeper.client.ZooKeeperSaslClient.SaslState
- FAILED_HANDSHAKE - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- failForNonExistingPath() - Method in class org.apache.zookeeper.server.util.VerifyingFileFactory.Builder
- failFutureRequests(long) - Method in class org.apache.zookeeper.server.controller.ControllableConnectionFactory
- FAILREQUESTS - org.apache.zookeeper.server.controller.ControlCommand.Action
- FAILURE - org.apache.zookeeper.audit.AuditEvent.Result
- 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 invokescallback
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) - Constructor for class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
create an iterator over a transaction database directory
- FileTxnIterator(File, long, boolean) - 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
- FINISHED - org.apache.zookeeper.server.NettyServerCnxn.HandshakeState
- 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() - Method in class org.apache.zookeeper.server.quorum.SendAckRequestProcessor
- flush() - Method in class org.apache.zookeeper.server.RateLogger
- flush(ByteBuffer...) - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
- follower - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
- Follower - Class in org.apache.zookeeper.server.quorum
-
This class has the control logic for the Follower.
- 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 - org.apache.zookeeper.server.quorum.QuorumPeer.ServerState
- 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
- format(byte[]) - Method in class org.apache.zookeeper.cli.Base64OutputFormatter
- format(byte[]) - Method in class org.apache.zookeeper.cli.HexDumpOutputFormatter
- format(byte[]) - Method in interface org.apache.zookeeper.cli.OutputFormatter
- format(byte[]) - Method in class org.apache.zookeeper.cli.PlainOutputFormatter
- formatInetAddr(InetSocketAddress) - Static method in class org.apache.zookeeper.common.NetUtils
-
Prefer using the hostname for formatting, but without requesting reverse DNS lookup.
- 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
- fromBytes(byte[]) - Static method in interface org.apache.zookeeper.server.RequestRecord
- fromBytes(ByteBuffer) - Static method in interface org.apache.zookeeper.server.RequestRecord
- 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 ofKeyStoreFileType.fromPropertyValue(propertyValue)
. - fromRecord(Record) - Static method in interface org.apache.zookeeper.server.RequestRecord
- 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() - 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() - Method in class org.apache.zookeeper.server.metric.SimpleCounter
- get(int) - Static method in enum org.apache.zookeeper.KeeperException.Code
-
Get the Code value for a particular integer error code
- get(int) - Method in class org.apache.zookeeper.server.util.BitMap
- 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(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 - org.apache.zookeeper.cli.CommandFactory.Command
- GET_ACL - org.apache.zookeeper.cli.CommandFactory.Command
- GET_ALL_CHILDREN_NUMBER - org.apache.zookeeper.cli.CommandFactory.Command
- GET_CHILDREN_RESPONSE_CACHE_SIZE - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
- GET_CONFIG - org.apache.zookeeper.cli.CommandFactory.Command
- GET_DATA_RESPONSE_CACHE_SIZE - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
- GET_EPHEMERALS - org.apache.zookeeper.cli.CommandFactory.Command
- 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() - Method in class org.apache.zookeeper.CreateOptions
- getACL - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- getACL(String, Stat) - Method in class org.apache.zookeeper.server.DataTree
- getACL(String, Stat) - Method in class org.apache.zookeeper.server.ZKDatabase
-
get acl for a path
- getACL(String, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the ACL and stat of the node of the given path.
- getACL(String, Stat, AsyncCallback.ACLCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getACL.
- getACL(DataNode) - Method in class org.apache.zookeeper.server.DataTree
- 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 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- getAllChildrenNumber(String) - Method in class org.apache.zookeeper.server.DataTree
- getAllChildrenNumber(String) - Method in class org.apache.zookeeper.server.ZKDatabase
- 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
- getAuthRequest() - Method in interface org.apache.zookeeper.server.admin.Command
- getAuthRequest() - Method in class org.apache.zookeeper.server.admin.CommandBase
- 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 aboolean
. - 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
-
See
Socket.getChannel()
. - getChildren - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- 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) - Static method in class org.apache.zookeeper.Op
- getChildren(String, boolean) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the list of the children of the node of the given path.
- getChildren(String, boolean, AsyncCallback.Children2Callback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getChildren.
- getChildren(String, boolean, AsyncCallback.ChildrenCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getChildren.
- getChildren(String, boolean, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
For the given znode path return the stat and children list.
- getChildren(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.DataTree
- getChildren(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
-
get children list for this path
- getChildren(String, Watcher) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the list of the children of the node of the given path.
- getChildren(String, Watcher, AsyncCallback.Children2Callback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getChildren.
- getChildren(String, Watcher, AsyncCallback.ChildrenCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getChildren.
- getChildren(String, Watcher, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
For the given znode path return the stat and children list.
- getChildren2 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- 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.
- getClientIPAddress(HttpServletRequest) - Static method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
-
Returns the HTTP(s) client IP address
- 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 class org.apache.zookeeper.server.ZooKeeperServerMain
- 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() - 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.
- GetCommand - Class in org.apache.zookeeper.cli
-
get command for cli
- GetCommand - Class in org.apache.zookeeper.server.admin
-
Command that represents HTTP GET request
- GetCommand() - Constructor for class org.apache.zookeeper.cli.GetCommand
- GetCommand(List<String>) - Constructor for class org.apache.zookeeper.server.admin.GetCommand
- GetCommand(List<String>, boolean) - Constructor for class org.apache.zookeeper.server.admin.GetCommand
- GetCommand(List<String>, boolean, AuthRequest) - Constructor for class org.apache.zookeeper.server.admin.GetCommand
- 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(boolean, 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(Watcher, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getConfig.
- 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.
- 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
- getContentType() - Method in class org.apache.zookeeper.server.admin.StreamOutputter
- 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
- getCreateMode() - Method in class org.apache.zookeeper.CreateOptions
- 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 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- getData() - Method in class org.apache.zookeeper.OpResult.GetDataResult
- getData() - Method in class org.apache.zookeeper.server.DataNode
- getData(String) - Static method in class org.apache.zookeeper.Op
- getData(String, boolean, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getData.
- getData(String, boolean, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the data and the stat of the node of the given path.
- getData(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.DataTree
- getData(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
-
get data and stat for a path
- getData(String, Watcher, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getData.
- getData(String, Watcher, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the data and the stat of the node of the given path.
- getDataDir() - Method in class org.apache.zookeeper.server.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.persistence.FileTxnSnapLog
-
get the data log dir used by this filetxn snap log
- 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
- 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 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
- 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() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getEphemerals() - Method in class org.apache.zookeeper.ZooKeeper
-
Synchronously gets all the ephemeral nodes created by this session.
- getEphemerals(long) - Method in class org.apache.zookeeper.server.DataTree
- getEphemerals(long) - Method in class org.apache.zookeeper.server.ZKDatabase
-
the paths for ephemeral session id
- 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
- getFipsMode(ZKConfig) - Method in class org.apache.zookeeper.common.X509Util
- getFipsModeProperty() - Method in class org.apache.zookeeper.common.X509Util
- 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
- getHeaders() - Method in class org.apache.zookeeper.server.admin.CommandResponse
-
Returns all headers
- 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() - Method in class org.apache.zookeeper.server.admin.CommandResponse
-
Gets the InputStream (may be null).
- getInputStream() - Method in class org.apache.zookeeper.server.quorum.PrependableSocket
- getInputStream() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
- getInputStream(File) - Static method in class org.apache.zookeeper.server.persistence.SnapStream
-
Return the CheckedInputStream based on the extension of the fileName.
- getInstance() - Static method in class org.apache.zookeeper.jmx.MBeanRegistry
- getInstance(CommandFactory.Command) - Static method in class org.apache.zookeeper.cli.CommandFactory
-
Creates a new
CliCommand
instance. - getInt(String, int) - Method in class org.apache.zookeeper.common.ZKConfig
-
Get the value of the
key
property as anint
. - 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 anlong
. - 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() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getMaxCnxns() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
- getMaxCnxns(ServerCnxnFactory, ServerCnxnFactory) - Static method in class org.apache.zookeeper.server.ServerCnxnHelper
-
gets maximum number of connections in ZooKeeper
- 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
- getMostRecentEventType() - Method in class org.apache.zookeeper.server.DumbWatcher
- getMostRecentPath() - Method in class org.apache.zookeeper.server.DumbWatcher
- getMostRecentZxid() - Method in class org.apache.zookeeper.server.DumbWatcher
- 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() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
- getOutputStream(File, boolean) - Static method in class org.apache.zookeeper.server.persistence.SnapStream
-
Return the OutputStream based on predefined stream mode.
- 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 class org.apache.zookeeper.DeleteContainerRequest
- 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.admin.AuthRequest
- 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
- getPermission() - Method in class org.apache.zookeeper.server.admin.AuthRequest
- 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
-
See
Socket.getPort()
. - 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
- getQuorumPacket() - Method in class org.apache.zookeeper.server.quorum.Leader.Proposal
- getQuorumPacket() - Method in class org.apache.zookeeper.server.quorum.Leader.PureRequestProposal
- 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
- 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
- getRequest() - Method in class org.apache.zookeeper.server.quorum.Leader.Proposal
- 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.quorum.QuorumPeer
- getSecureClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getSecureClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
- getSecureClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServerMain
- 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
- getSerializeData() - Method in class org.apache.zookeeper.server.Request
- 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() - Method in class org.apache.zookeeper.server.ZKDatabase
-
return the sessions in the 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.
- getSessionTimeout() - Method in class org.apache.zookeeper.ClientCnxn
- getSessionTimeout() - Method in class org.apache.zookeeper.server.ConnectionBean
- getSessionTimeout() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
- getSessionTimeout() - Method in class org.apache.zookeeper.server.NettyServerCnxn
- getSessionTimeout() - Method in class org.apache.zookeeper.server.NIOServerCnxn
- getSessionTimeout() - Method in class org.apache.zookeeper.ZooKeeper
-
The negotiated session timeout for this ZooKeeper client instance.
- getSessionTimeout(long) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
- 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
-
See
Socket.getSoLinger()
. - 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
- getSslProvider(ZKConfig) - Method in class org.apache.zookeeper.common.ClientX509Util
- getSslProviderProperty() - Method in class org.apache.zookeeper.common.ClientX509Util
- 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
- getStatusCode() - Method in class org.apache.zookeeper.server.admin.CommandResponse
-
Gets the http status code
- 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.
- getTtl() - Method in class org.apache.zookeeper.CreateOptions
- 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
- getTxnLogSizeLimit() - Static method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
Get log size limit
- 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
- getUsage() - Static method in class org.apache.zookeeper.server.SnapshotRecursiveSummary
- getUsage(String, Options) - Static method in class org.apache.zookeeper.cli.CommandUsageHelper
- 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() - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
-
User who has started the ZooKeeper server user, it will be the logged-in user.
- 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
- 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
, ornull
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
, ornull
if no user IDs were found. - getValue() - Method in class org.apache.zookeeper.Environment.Entry
- getValue() - Method in enum org.apache.zookeeper.server.ExitCode
- 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(AuditEvent.FieldName) - Method in class org.apache.zookeeper.audit.AuditEvent
- 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.Leader.Proposal
- getZxid() - Method in class org.apache.zookeeper.server.quorum.Leader.PureRequestProposal
- getZxid() - Method in class org.apache.zookeeper.server.quorum.Vote
- getZxid() - Method in class org.apache.zookeeper.server.ZooKeeperServer
- getZxid() - Method in class org.apache.zookeeper.WatchedEvent
-
Returns the zxid of the transaction that triggered this watch if it is of one of the following types:
Watcher.Event.EventType.NodeCreated
Watcher.Event.EventType.NodeDeleted
Watcher.Event.EventType.NodeDataChanged
Watcher.Event.EventType.NodeChildrenChanged
Otherwise, returns -1L. - 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
- GZIP - org.apache.zookeeper.server.persistence.SnapStream.StreamMode
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(HttpServletRequest, byte[]) - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
-
This method is called when admin server command passes authentication data for this scheme.
- handleAuthentication(HttpServletRequest, byte[]) - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
- handleAuthentication(HttpServletRequest, byte[]) - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
- handleAuthentication(HttpServletRequest, byte[]) - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
- handleAuthentication(ServerAuthenticationProvider.ServerObjs, byte[]) - Method in class org.apache.zookeeper.server.auth.KeyAuthenticationProvider
- 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 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(ServerCnxn, byte[]) - Method in class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
- 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 rationale 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
- hasMode(WatcherMode) - Method in class org.apache.zookeeper.server.watch.WatchStats
-
Check whether given mode is attached to this node.
- 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
- HexDumpOutputFormatter - Class in org.apache.zookeeper.cli
- HexDumpOutputFormatter() - Constructor for class org.apache.zookeeper.cli.HexDumpOutputFormatter
- 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 - Variable in class org.apache.zookeeper.ZooKeeper
- HostProvider - Interface in org.apache.zookeeper.client
-
A set of hosts a ZooKeeper client should connect to.
I
- id - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
- IDeadWatcherListener - Interface in org.apache.zookeeper.server.watch
-
Interface used to process the dead watchers related to closed cnxns.
- IN_PROGRESS - org.apache.zookeeper.server.quorum.auth.QuorumAuth.Status
- 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_PROBE - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- 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
- INITIAL - org.apache.zookeeper.client.ZooKeeperSaslClient.SaslState
- INITIAL - org.apache.zookeeper.server.ZooKeeperServer.State
- 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() - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
- initialize() - Method in class org.apache.zookeeper.server.quorum.ProposalRequestProcessor
-
initialize this processor
- initialize() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
- initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.zookeeper.server.auth.DigestLoginModule
- initialize(ClientCnxn) - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
- initializeAndRun(String[]) - Method in class org.apache.zookeeper.server.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.cli.Base64OutputFormatter
- INSTANCE - Static variable in class org.apache.zookeeper.cli.HexDumpOutputFormatter
- INSTANCE - Static variable in class org.apache.zookeeper.cli.PlainOutputFormatter
- 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 ByteArrayOutputBuffers.
- intBufferStartingSizeBytes - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
- INTERMEDIATE - org.apache.zookeeper.client.ZooKeeperSaslClient.SaslState
- intValue() - Method in enum org.apache.zookeeper.KeeperException.Code
-
Get the int value for a particular Code.
- INVALID_INVOCATION - org.apache.zookeeper.server.ExitCode
-
Invalid arguments during invocations
- InvalidACL - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.INVALIDACL
instead - INVALIDACL - org.apache.zookeeper.KeeperException.Code
-
Invalid ACL specified
- InvalidACLException() - Constructor for exception org.apache.zookeeper.KeeperException.InvalidACLException
- InvalidACLException(String) - Constructor for exception org.apache.zookeeper.KeeperException.InvalidACLException
- InvalidCallback - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
Deprecated.deprecated in 3.1.0, use
KeeperException.Code.INVALIDCALLBACK
instead - INVALIDCALLBACK - org.apache.zookeeper.KeeperException.Code
-
Invalid callback specified
- InvalidCallbackException() - Constructor for exception org.apache.zookeeper.KeeperException.InvalidCallbackException
- INVOKED - org.apache.zookeeper.audit.AuditEvent.Result
- IO_EXCEPTION - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- IO_EXCEPTION_IN_SESSION_INIT - org.apache.zookeeper.server.ServerCnxn.DisconnectReason
- IOUtils - Class in org.apache.zookeeper.common
- IOUtils() - Constructor for class org.apache.zookeeper.common.IOUtils
- IP - org.apache.zookeeper.audit.AuditEvent.FieldName
- 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
-
See
Socket.isBound()
. - isClientAddrFromStatic - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
- isClientHostnameVerificationEnabled(ZKConfig) - Method in class org.apache.zookeeper.common.X509Util
- isClosed() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
See
Socket.isClosed()
. - 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
-
See
Socket.isConnected()
. - 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() - 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
- isEmpty(String) - Static method in class org.apache.zookeeper.common.StringUtils
-
Checks if a String is empty ("") or null.
- isEnabled() - Static method in class org.apache.zookeeper.client.ZooKeeperSaslClient
-
Deprecated.Use
ZKClientConfig.isSaslClientEnabled()
instead - isEnabled() - Static method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
- isEnabled() - Method in class org.apache.zookeeper.server.ResponseCache
- isEnabled(String) - Static method in class org.apache.zookeeper.server.command.FourLetterCommands
-
Check if the specified command is enabled.
- 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() - Method in class org.apache.zookeeper.server.Request
- isLocalSession(long) - Method in class org.apache.zookeeper.server.quorum.LocalSessionTracker
- isLocalSession(long) - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
- 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
- isReadonlyAvailable() - Method in class org.apache.zookeeper.compat.ProtocolManager
- 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 - Class in org.apache.zookeeper.server.command
- IsroCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.IsroCommand
- 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
- isSerializeLastProcessedZxidEnabled() - Static method in class org.apache.zookeeper.server.ZooKeeperServer
- isServerHostnameVerificationEnabled(ZKConfig) - Method in class org.apache.zookeeper.common.X509Util
- 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, boolean) - Constructor for class org.apache.zookeeper.server.admin.JettyAdminServer
- JGSS_NATIVE - Static variable in class org.apache.zookeeper.common.ZKConfig
- JKS - org.apache.zookeeper.common.KeyStoreFileType
- 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(String) - 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 - Variable in class org.apache.zookeeper.server.ZooKeeperServer
- 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
- 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 - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
- Leader - Class in org.apache.zookeeper.server.quorum
-
This class has the control logic for the Leader.
- Leader(QuorumPeer, LeaderZooKeeperServer) - Constructor for class org.apache.zookeeper.server.quorum.Leader
- 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
- Leader.Proposal - Class in org.apache.zookeeper.server.quorum
- Leader.PureRequestProposal - Class in org.apache.zookeeper.server.quorum
- Leader.XidRolloverException - Exception in org.apache.zookeeper.server.quorum
- 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 - org.apache.zookeeper.server.quorum.QuorumPeer.ServerState
- LEADING_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
- Learner - Class in org.apache.zookeeper.server.quorum
-
This class is the superclass of two of the three main actors in a ZK ensemble: Followers and Observers.
- Learner() - Constructor for class org.apache.zookeeper.server.quorum.Learner
- 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, RequestRecord, 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
- limit() - Method in class org.apache.zookeeper.server.ByteBufferRequestRecord
- limit() - Method in interface org.apache.zookeeper.server.RequestRecord
- limit() - Method in class org.apache.zookeeper.server.SimpleRequestRecord
- 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
- LIST_QUOTA - org.apache.zookeeper.cli.CommandFactory.Command