- abort() - Method in class org.apache.zookeeper.common.AtomicFileOutputStream
-
Close the atomic file, but do not "commit" the temporary file on top of
the destination.
- abort() - Method in class org.apache.zookeeper.server.auth.DigestLoginModule
-
- AbstractFourLetterCommand - Class in org.apache.zookeeper.server.command
-
Set of threads for command ports.
- AbstractFourLetterCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.AbstractFourLetterCommand
-
- accept() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket
-
- ACCEPTED_EPOCH_FILENAME - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- ACK_LATENCY - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- ACKEPOCH - Static variable in class org.apache.zookeeper.server.quorum.Leader
-
This message is used by the follow to ack a proposed epoch.
- ackSetsToString() - Method in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker
-
- acl - Variable in class org.apache.zookeeper.Op.Create
-
- aclCacheSize() - Method in class org.apache.zookeeper.server.DataTree
-
- aclForNode(DataNode) - Method in class org.apache.zookeeper.server.ZKDatabase
-
- AclParser - Class in org.apache.zookeeper.cli
-
a parser for ACL strings
- AclParser() - Constructor for class org.apache.zookeeper.cli.AclParser
-
- aclToString(List<ACL>) - Static method in class org.apache.zookeeper.ZKUtil
-
- add(long) - Method in interface org.apache.zookeeper.metrics.Counter
-
Increment the value by a given amount.
- add(String, long) - Method in interface org.apache.zookeeper.metrics.CounterSet
-
Increment the value by a given amount for the given key
- add(long) - Method in interface org.apache.zookeeper.metrics.Summary
-
Register a value.
- add(String, long) - Method in interface org.apache.zookeeper.metrics.SummarySet
-
Register a value.
- add(Op) - Method in class org.apache.zookeeper.MultiOperationRecord
-
- add(OpResult) - Method in class org.apache.zookeeper.MultiResponse
-
- add(long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
-
- add(String, long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounterSet
-
- add(long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounter
-
- add(String, long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounterSet
-
- add(long) - Method in class org.apache.zookeeper.server.metric.Metric
-
- add(int, long) - Method in class org.apache.zookeeper.server.metric.Metric
-
- add(String, long) - Method in class org.apache.zookeeper.server.metric.Metric
-
- add(long) - Method in class org.apache.zookeeper.server.metric.SimpleCounter
-
- add(String, long) - Method in class org.apache.zookeeper.server.metric.SimpleCounterSet
-
- add(Integer) - Method in class org.apache.zookeeper.server.util.BitHashSet
-
- add(T) - Method in class org.apache.zookeeper.server.util.BitMap
-
- add(E) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
-
- ADD_DEAD_WATCHER_STALL_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- addAcceptedConnection(SocketChannel) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory.SelectorThread
-
Place new accepted connection onto a queue for adding.
- addAck(Long) - Method in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker
-
- addAddress(InetSocketAddress) - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
-
- addAll(Collection<? extends E>) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
-
- addAuditLog(Request, DataTree.ProcessTxnResult) - Static method in class org.apache.zookeeper.audit.AuditHelper
-
- addAuditLog(Request, DataTree.ProcessTxnResult, boolean) - Static method in class org.apache.zookeeper.audit.AuditHelper
-
Add audit log if audit log is enabled and operation is of type which to be audit logged.
- AddAuthCommand - Class in org.apache.zookeeper.cli
-
addAuth command for cli
- AddAuthCommand() - Constructor for class org.apache.zookeeper.cli.AddAuthCommand
-
- addAuthInfo(String, byte[]) - Method in class org.apache.zookeeper.ClientCnxn
-
- addAuthInfo(Id) - Method in class org.apache.zookeeper.server.ServerCnxn
-
- addAuthInfo(String, byte[]) - Method in class org.apache.zookeeper.ZooKeeper
-
Add the specified scheme:auth information to this connection.
- addChangeRecord(ZooKeeperServer.ChangeRecord) - Method in class org.apache.zookeeper.server.PrepRequestProcessor
-
- addChild(String) - Method in class org.apache.zookeeper.server.DataNode
-
Method that inserts a child into the children set
- addCommittedProposal(Request) - Method in class org.apache.zookeeper.server.ZKDatabase
-
maintains a list of last committedLog
or so committed requests.
- addConfigNode() - Method in class org.apache.zookeeper.server.DataTree
-
create a /zookeeper/config node for maintaining the configuration (membership and quorum system) info for
zookeeper
- addConfiguration(File) - Method in class org.apache.zookeeper.common.ZKConfig
-
Add a configuration resource.
- addConfiguration(String) - Method in class org.apache.zookeeper.common.ZKConfig
-
Add a configuration resource.
- addDataPoint(long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
-
- addDataPoint(String, long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounterSet
-
- addDataPoint(long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounter
-
- addDataPoint(String, long) - Method in class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounterSet
-
- addDeadWatcher(int) - Method in class org.apache.zookeeper.server.watch.WatcherCleaner
-
- addDigest(long) - Method in class org.apache.zookeeper.server.util.AdHash
-
Add new digest to the hash value maintained in this class.
- addDigestWatcher(DigestWatcher) - Method in class org.apache.zookeeper.server.DataTree
-
Add digest mismatch event handler.
- addInterestOpsUpdateRequest(SelectionKey) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory.SelectorThread
-
Place interest op update requests onto a queue so that only the
selector thread modifies interest ops, because interest ops
reads/sets are potentially blocking operations if other select
operations are happening.
- addLearnerHandler(LearnerHandler) - Method in class org.apache.zookeeper.server.quorum.Leader
-
Adds peer to the leader.
- addLearnerHandler(LearnerHandler) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- addPath(String) - Method in class org.apache.zookeeper.common.PathTrie
-
Add a path to the path trie.
- addQuorumVerifier(QuorumVerifier) - Method in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker
-
- addr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
-
- AddressTuple(MultipleAddresses, MultipleAddresses, InetSocketAddress) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer.AddressTuple
-
- addServerStartFailureAuditLog() - Static method in class org.apache.zookeeper.audit.ZKAuditProvider
-
Add audit log for server start fail.
- addSession(long, ServerCnxn) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- addToHistory(int, String) - Method in class org.apache.zookeeper.ZooKeeperMain
-
Makes a list of possible completions, either for commands
or for zk nodes if the token to complete begins with /
- addToMap(Map<String, CliCommand>) - Method in class org.apache.zookeeper.cli.CliCommand
-
add this command to a map.
- addToRecvQueue(QuorumCnxManager.Message) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
- addUsage(Long) - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
-
- addWatch(String, Watcher, int) - Method in class org.apache.zookeeper.server.DataTree
-
- addWatch(String, Watcher) - Method in interface org.apache.zookeeper.server.watch.IWatchManager
-
Add watch to specific path.
- addWatch(String, Watcher, WatcherMode) - Method in interface org.apache.zookeeper.server.watch.IWatchManager
-
Add watch to specific path.
- addWatch(String, Watcher) - Method in class org.apache.zookeeper.server.watch.WatchManager
-
- addWatch(String, Watcher, WatcherMode) - Method in class org.apache.zookeeper.server.watch.WatchManager
-
- addWatch(String, Watcher) - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
-
- addWatch(String, Watcher, int) - Method in class org.apache.zookeeper.server.ZKDatabase
-
Add a watch
- addWatch - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- addWatch(String, Watcher, AddWatchMode) - Method in class org.apache.zookeeper.ZooKeeper
-
Add a watch to the given znode using the given mode.
- addWatch(String, AddWatchMode) - Method in class org.apache.zookeeper.ZooKeeper
-
Add a watch to the given znode using the given mode.
- addWatch(String, Watcher, AddWatchMode, AsyncCallback.VoidCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
- addWatch(String, AddWatchMode, AsyncCallback.VoidCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
- AddWatchCommand - Class in org.apache.zookeeper.cli
-
addWatch command for cli.
- AddWatchCommand() - Constructor for class org.apache.zookeeper.cli.AddWatchCommand
-
- AddWatchMode - Enum in org.apache.zookeeper
-
- addZKStartStopAuditLog() - Static method in class org.apache.zookeeper.audit.ZKAuditProvider
-
Add audit log for server start and register server stop log.
- AdHash - Class in org.apache.zookeeper.server.util
-
This incremental hash is used to keep track of the hash of
the data tree to that we can quickly validate that things
are in sync.
- AdHash() - Constructor for class org.apache.zookeeper.server.util.AdHash
-
- ADMIN - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
-
- AdminServer - Interface in org.apache.zookeeper.server.admin
-
Interface for an embedded admin server that runs Commands.
- AdminServer.AdminServerException - Exception in org.apache.zookeeper.server.admin
-
- AdminServerException(String, Throwable) - Constructor for exception org.apache.zookeeper.server.admin.AdminServer.AdminServerException
-
- AdminServerException(Throwable) - Constructor for exception org.apache.zookeeper.server.admin.AdminServer.AdminServerException
-
- AdminServerFactory - Class in org.apache.zookeeper.server.admin
-
Factory class for creating an AdminServer.
- AdminServerFactory() - Constructor for class org.apache.zookeeper.server.admin.AdminServerFactory
-
- ALL - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
-
- ALLOW_SASL_FAILED_CLIENTS - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
-
- ANYONE_ID_UNSAFE - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
-
This Id represents anyone.
- APIError - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
- APIErrorException() - Constructor for exception org.apache.zookeeper.KeeperException.APIErrorException
-
- append(TxnHeader, Record) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
append an entry to the transaction log
- append(TxnHeader, Record, TxnDigest) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
- append(Request) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
append the request to the transaction logs
- append(TxnHeader, Record) - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
Append a request to the transaction log
- append(TxnHeader, Record, TxnDigest) - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
Append a request to the transaction log with a digset
- append(Request) - Method in class org.apache.zookeeper.server.ZKDatabase
-
append to the underlying transaction log
- approximateDataSize() - Method in class org.apache.zookeeper.server.DataTree
-
Get the size of the nodes based on path and data length.
- approximateDataSize() - Method in class org.apache.zookeeper.server.DataTreeBean
-
- approximateDataSize() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
-
- areLocalSessionsEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Whether local sessions are enabled
- areLocalSessionsEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- asIterable() - Method in class org.apache.zookeeper.server.watch.PathParentIterator
-
Return an Iterable view so that this Iterator can be used in for each
statements.
- askOracle() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
-
- askOracle() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
-
- AsyncCallback - Interface in org.apache.zookeeper
-
Interface definitions of asynchronous callbacks.
- AsyncCallback.ACLCallback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the ACL and stat of the node.
- AsyncCallback.AllChildrenNumberCallback - Interface in org.apache.zookeeper
-
This callback is used to get all children node number of the node.
- AsyncCallback.Children2Callback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the children and stat of the node.
- AsyncCallback.ChildrenCallback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the children of the node.
- AsyncCallback.Create2Callback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the name and stat of the node.
- AsyncCallback.DataCallback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the data and stat of the node.
- AsyncCallback.EphemeralsCallback - Interface in org.apache.zookeeper
-
This callback is used to process the getEphemerals results from a single getEphemerals call.
- AsyncCallback.MultiCallback - Interface in org.apache.zookeeper
-
This callback is used to process the multiple results from a single multi call.
- AsyncCallback.StatCallback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the stat of the node.
- AsyncCallback.StringCallback - Interface in org.apache.zookeeper
-
This callback is used to retrieve the name of the node.
- AsyncCallback.VoidCallback - Interface in org.apache.zookeeper
-
This callback doesn't retrieve anything from the node.
- AtomicFileOutputStream - Class in org.apache.zookeeper.common
-
A FileOutputStream that has the property that it will only show up at its
destination once it has been entirely written and flushed to disk.
- AtomicFileOutputStream(File) - Constructor for class org.apache.zookeeper.common.AtomicFileOutputStream
-
- AtomicFileWritingIdiom - Class in org.apache.zookeeper.common
-
- AtomicFileWritingIdiom(File, AtomicFileWritingIdiom.OutputStreamStatement) - Constructor for class org.apache.zookeeper.common.AtomicFileWritingIdiom
-
- AtomicFileWritingIdiom(File, AtomicFileWritingIdiom.WriterStatement) - Constructor for class org.apache.zookeeper.common.AtomicFileWritingIdiom
-
- AtomicFileWritingIdiom.OutputStreamStatement - Interface in org.apache.zookeeper.common
-
- AtomicFileWritingIdiom.WriterStatement - Interface in org.apache.zookeeper.common
-
- atParentPath() - Method in class org.apache.zookeeper.server.watch.PathParentIterator
-
Returns true if this iterator is currently at a parent path as opposed
to the initial path given to the constructor
- AuditConstants - Class in org.apache.zookeeper.audit
-
- AuditEvent - Class in org.apache.zookeeper.audit
-
- AuditEvent.FieldName - Enum in org.apache.zookeeper.audit
-
- AuditEvent.Result - Enum in org.apache.zookeeper.audit
-
- AuditHelper - Class in org.apache.zookeeper.audit
-
Helper class to decouple audit log code.
- AuditHelper() - Constructor for class org.apache.zookeeper.audit.AuditHelper
-
- AuditLogger - Interface in org.apache.zookeeper.audit
-
- auth - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- AUTH_IDS - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
-
This Id is only usable to set ACLs.
- authenticate(Socket, String) - Method in class org.apache.zookeeper.server.quorum.auth.NullQuorumAuthLearner
-
- authenticate(Socket, DataInputStream) - Method in class org.apache.zookeeper.server.quorum.auth.NullQuorumAuthServer
-
- authenticate(Socket, String) - Method in interface org.apache.zookeeper.server.quorum.auth.QuorumAuthLearner
-
Performs an authentication step for the given socket connection.
- authenticate(Socket, DataInputStream) - Method in interface org.apache.zookeeper.server.quorum.auth.QuorumAuthServer
-
Performs an authentication step for the given socket connection.
- authenticate(Socket, String) - Method in class org.apache.zookeeper.server.quorum.auth.SaslQuorumAuthLearner
-
- authenticate(Socket, DataInputStream) - Method in class org.apache.zookeeper.server.quorum.auth.SaslQuorumAuthServer
-
- AuthenticationHelper - Class in org.apache.zookeeper.server
-
Contains helper methods to enforce authentication
- AuthenticationHelper() - Constructor for class org.apache.zookeeper.server.AuthenticationHelper
-
- AuthenticationProvider - Interface in org.apache.zookeeper.server.auth
-
This interface is implemented by authentication providers to add new kinds of
authentication schemes to ZooKeeper.
- AuthFailed - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
- AuthFailedException() - Constructor for exception org.apache.zookeeper.KeeperException.AuthFailedException
-
- authInfo - Variable in class org.apache.zookeeper.server.Request
-
- AUTHPACKET_XID - Static variable in class org.apache.zookeeper.ClientCnxn
-
- AUTHPROVIDER_PROPERTY_PREFIX - Static variable in class org.apache.zookeeper.server.auth.ProviderRegistry
-
- AuthUtil - Class in org.apache.zookeeper.server.util
-
- authWriteRequest(Request) - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
Check Write Requests for Potential Access Restrictions
Before a request is being proposed to the quorum, lets check it
against local ACLs.
- available() - Method in class org.apache.zookeeper.server.ByteBufferInputStream
-
- AvgMinMaxCounter - Class in org.apache.zookeeper.server.metric
-
Generic long counter that keep track of min/max/avg.
- AvgMinMaxCounter(String) - Constructor for class org.apache.zookeeper.server.metric.AvgMinMaxCounter
-
- AvgMinMaxCounterSet - Class in org.apache.zookeeper.server.metric
-
Generic set of long counters that keep track of min/max/avg
for different keys.
- AvgMinMaxCounterSet(String) - Constructor for class org.apache.zookeeper.server.metric.AvgMinMaxCounterSet
-
- AvgMinMaxPercentileCounter - Class in org.apache.zookeeper.server.metric
-
Generic long counter that keep track of min/max/avg/percentiles.
- AvgMinMaxPercentileCounter(String) - Constructor for class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounter
-
- AvgMinMaxPercentileCounterSet - Class in org.apache.zookeeper.server.metric
-
Generic set of long counters that keep track of min/max/avg
for different keys.
- AvgMinMaxPercentileCounterSet(String) - Constructor for class org.apache.zookeeper.server.metric.AvgMinMaxPercentileCounterSet
-
- cachedApproximateDataSize() - Method in class org.apache.zookeeper.server.DataTree
-
- cachedSize() - Method in class org.apache.zookeeper.server.util.BitHashSet
-
- calculateFileSizeWithPadding(long, long, long) - Static method in class org.apache.zookeeper.server.persistence.FilePadding
-
Calculates a new file size with padding.
- calculateTxnLogSizeLimit() - Method in class org.apache.zookeeper.server.ZKDatabase
-
- callbackHandler - Variable in class org.apache.zookeeper.Login
-
- canShutdown() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
This can be used while shutting down the server to see whether the server
is already shutdown or not.
- check(String, int) - Static method in class org.apache.zookeeper.Op
-
Constructs an version check operation.
- check(String, int) - Method in class org.apache.zookeeper.Transaction
-
- check - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- checkACL(ServerCnxn, List<ACL>, int, List<Id>, String, List<ACL>) - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
Grant or deny authorization to an operation on a node as a function of:
- checkAddressDuplicate(QuorumPeer.QuorumServer) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
-
- checkBlue(long) - Method in class org.apache.zookeeper.server.BlueThrottle
-
- checkClientTrusted(X509Certificate[], String, Socket) - Method in class org.apache.zookeeper.common.ZKTrustManager
-
- checkClientTrusted(X509Certificate[], String, SSLEngine) - Method in class org.apache.zookeeper.common.ZKTrustManager
-
- checkClientTrusted(X509Certificate[], String) - Method in class org.apache.zookeeper.common.ZKTrustManager
-
- checkContainers() - Method in class org.apache.zookeeper.server.ContainerManager
-
Manually check the containers.
- checkGlobalSession(long, Object) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
-
- checkGlobalSession(long, Object) - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
-
- checkGlobalSession(long, Object) - Method in interface org.apache.zookeeper.server.SessionTracker
-
Strictly check that a given session is a global session or not
- checkGlobalSession(long, Object) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
-
- checkIfValidGlobalSession(long, int) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
-
- checkLeader(Map<Long, Vote>, long, long) - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
-
In the case there is a leader elected, and a quorum supporting
this leader, we have to check if the leader has voted and acked
that it is leading.
- checkLimit(int) - Method in class org.apache.zookeeper.server.BlueThrottle
-
- checkPasswd(long, byte[]) - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- checkQuota(String, byte[], byte[], int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
check a path whether exceeded the quota.
- checkRequestSizeWhenReceivingMessage(int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- CheckResult() - Constructor for class org.apache.zookeeper.OpResult.CheckResult
-
- checkServerTrusted(X509Certificate[], String, Socket) - Method in class org.apache.zookeeper.common.ZKTrustManager
-
- checkServerTrusted(X509Certificate[], String, SSLEngine) - Method in class org.apache.zookeeper.common.ZKTrustManager
-
- checkServerTrusted(X509Certificate[], String) - Method in class org.apache.zookeeper.common.ZKTrustManager
-
- checkSession(long, Object) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
-
- checkSession(long, Object) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
-
- checkSession(long, Object) - Method in interface org.apache.zookeeper.server.SessionTracker
-
Checks whether the SessionTracker is aware of this session, the session
is still active, and the owner matches.
- checkSession(long, Object) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
-
- checkUpgradeSession(Request) - Method in class org.apache.zookeeper.server.quorum.QuorumZooKeeperServer
-
- checkValidity() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- checkWatches - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- chop() - Method in class org.apache.zookeeper.server.persistence.TxnLogToolkit
-
- chop(InputStream, OutputStream, long) - Static method in class org.apache.zookeeper.server.util.LogChopper
-
- CircularBlockingQueue<E> - Class in org.apache.zookeeper.util
-
A bounded blocking queue backed by an array.
- CircularBlockingQueue(int) - Constructor for class org.apache.zookeeper.util.CircularBlockingQueue
-
- CircularBuffer<T> - Class in org.apache.zookeeper.server.util
-
Thread safe FIFO CircularBuffer implementation.
- CircularBuffer(Class<T>, int) - Constructor for class org.apache.zookeeper.server.util.CircularBuffer
-
- cl - Variable in class org.apache.zookeeper.ZooKeeperMain
-
- cleanup(Logger, Closeable...) - Static method in class org.apache.zookeeper.common.IOUtils
-
Close the Closeable objects and
ignore any
IOException
or
null pointers.
- cleanup() - Method in class org.apache.zookeeper.server.controller.ControllerService
-
- cleanup() - Method in class org.apache.zookeeper.server.WorkerService.WorkRequest
-
(Optional) If implemented, is called if the service is stopped
or unable to schedule the request.
- cleanupWriterSocket(PrintWriter) - Method in class org.apache.zookeeper.server.ServerCnxn
-
clean up the socket related to a command and also make sure we flush the
data before we do that
- clear() - Method in class org.apache.zookeeper.common.PathTrie
-
Clear all nodes in the trie.
- clear() - Method in interface org.apache.zookeeper.server.NodeHashMap
-
Clear all the items stored inside this map.
- clear() - Method in class org.apache.zookeeper.server.NodeHashMapImpl
-
- clear() - Method in class org.apache.zookeeper.server.util.AdHash
-
- clear() - Method in class org.apache.zookeeper.server.ZKDatabase
-
clear the zkdatabase.
- clear() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
-
- CliCommand - Class in org.apache.zookeeper.cli
-
base class for all CLI commands
- CliCommand(String, String) - Constructor for class org.apache.zookeeper.cli.CliCommand
-
a CLI command with command string and options.
- CLIENT_DATA_PACKET_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
-
Deprecated.
- CLIENT_MAX_PACKET_LENGTH_DEFAULT - Static variable in class org.apache.zookeeper.client.ZKClientConfig
-
- CLIENT_PING_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
-
- CLIENT_PORT_KEY - Static variable in class org.apache.zookeeper.server.controller.ControllerServerConfig
-
- CLIENT_REQUEST_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
-
- clientAddr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.AddressTuple
-
- clientAddr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
-
- ClientCnxn - Class in org.apache.zookeeper
-
This class manages the socket i/o for the client.
- ClientCnxn(String, HostProvider, int, ZKClientConfig, Watcher, ClientCnxnSocket, boolean) - Constructor for class org.apache.zookeeper.ClientCnxn
-
Creates a connection object.
- ClientCnxn(String, HostProvider, int, ZKClientConfig, Watcher, ClientCnxnSocket, long, byte[], boolean) - Constructor for class org.apache.zookeeper.ClientCnxn
-
Creates a connection object.
- ClientCnxnLimitException - Exception in org.apache.zookeeper.server
-
Indicates that the number of client connections has exceeded some limit.
- ClientCnxnLimitException() - Constructor for exception org.apache.zookeeper.server.ClientCnxnLimitException
-
- ClientCnxnSocketNetty - Class in org.apache.zookeeper
-
ClientCnxnSocketNetty implements ClientCnxnSocket abstract methods.
- ClientCnxnSocketNIO - Class in org.apache.zookeeper
-
- clientId - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
-
- clientPortAddress - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- clientPortAddress - Variable in class org.apache.zookeeper.server.ServerConfig
-
- clientPortListenBacklog - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
The ZooKeeper server's socket backlog length.
- clientPortListenBacklog - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
defaults to -1 if not set explicitly
- clientTunneledAuthenticationInProgress() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
-
- ClientWatchManager - Interface in org.apache.zookeeper
-
- ClientX509Util - Class in org.apache.zookeeper.common
-
- ClientX509Util() - Constructor for class org.apache.zookeeper.common.ClientX509Util
-
- CliException - Exception in org.apache.zookeeper.cli
-
- CliException(String) - Constructor for exception org.apache.zookeeper.cli.CliException
-
- CliException(String, int) - Constructor for exception org.apache.zookeeper.cli.CliException
-
- CliException(Throwable) - Constructor for exception org.apache.zookeeper.cli.CliException
-
- CliException(Throwable, int) - Constructor for exception org.apache.zookeeper.cli.CliException
-
- CliException(String, Throwable) - Constructor for exception org.apache.zookeeper.cli.CliException
-
- CliException(String, Throwable, int) - Constructor for exception org.apache.zookeeper.cli.CliException
-
- CliParseException - Exception in org.apache.zookeeper.cli
-
- CliParseException(ParseException) - Constructor for exception org.apache.zookeeper.cli.CliParseException
-
- CliParseException(String) - Constructor for exception org.apache.zookeeper.cli.CliParseException
-
- CliWrapperException - Exception in org.apache.zookeeper.cli
-
- CliWrapperException(Throwable) - Constructor for exception org.apache.zookeeper.cli.CliWrapperException
-
- close() - Method in class org.apache.zookeeper.ClientCnxn
-
Close the connection, which includes; send session disconnect to the
server, shutdown the send/event threads.
- close() - Method in class org.apache.zookeeper.common.AtomicFileOutputStream
-
- close() - Method in class org.apache.zookeeper.common.X509Util
-
Disables automatic reloading of the trust store and key store files when they change on disk.
- close() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
-
- close() - Method in class org.apache.zookeeper.server.controller.CommandClient
-
- close() - Method in class org.apache.zookeeper.server.controller.CommandListener
-
- close(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.DumbWatcher
-
- close() - Method in interface org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded
-
Shutdown gracefully the server and wait for resources to be released.
- close(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.NettyServerCnxn
-
Close the cnxn and remove it from the factory cnxns list.
- close() - Method in class org.apache.zookeeper.server.NettyServerCnxn
-
- close(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.NIOServerCnxn
-
Close the cnxn and remove it from the factory cnxns list.
- close() - Method in class org.apache.zookeeper.server.persistence.FileSnap
-
synchronized close just so that if serialize is in place
the close operation will block and will wait till serialize
is done and will set the close flag
- close() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
close all the open file handles
- close() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
close the iterator
and release the resources.
- close() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
close the transaction log files
- close() - Method in interface org.apache.zookeeper.server.persistence.SnapShot
-
free resources from this snapshot immediately
- close() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
close the transactions logs
- close() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
-
close files and release the
resources
- close() - Method in class org.apache.zookeeper.server.persistence.TxnLogToolkit
-
- close() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerMain
-
Shutdowns properly the service, this method is not a public API.
- close() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- close(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.ServerCnxn
-
- close() - Method in class org.apache.zookeeper.server.TxnLogProposalIterator
-
Close the files and release the resources which are used for iterating
transaction records
- close() - Method in class org.apache.zookeeper.server.ZKDatabase
-
close this database.
- close() - Method in class org.apache.zookeeper.server.ZooKeeperServerMain
-
Shutdowns properly the service, this method is not a public API.
- close() - Method in class org.apache.zookeeper.ZooKeeper
-
Close this client object.
- close(int) - Method in class org.apache.zookeeper.ZooKeeper
-
- CLOSE_SESSION_PREP_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- CLOSE_SESSION_TXN_ENABLED - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
-
- closeAll(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
-
- closeAll(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
clear all the connections in the selector
- closeAll(ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- closeAllConnections() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- CloseCommand - Class in org.apache.zookeeper.cli
-
close command for cli
- CloseCommand() - Constructor for class org.apache.zookeeper.cli.CloseCommand
-
- CloseRequestException(String, ServerCnxn.DisconnectReason) - Constructor for exception org.apache.zookeeper.server.ServerCnxn.CloseRequestException
-
- closeSession(long, ServerCnxn.DisconnectReason) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- closeSession(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- closeSession(ServerCnxn, RequestHeader) - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- closeSession - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- closeSock(SocketChannel) - Static method in class org.apache.zookeeper.server.NIOServerCnxn
-
Close resources associated with a sock.
- closeSocketAsync - Static variable in class org.apache.zookeeper.server.quorum.Learner
-
- closeSocketAsync - Static variable in class org.apache.zookeeper.server.quorum.LearnerHandler
-
- closeStream(Closeable) - Static method in class org.apache.zookeeper.common.IOUtils
-
- cnxn - Variable in class org.apache.zookeeper.server.Request
-
- cnxn - Variable in class org.apache.zookeeper.ZooKeeper
-
- CNXN_CLOSED_WITHOUT_ZK_SERVER_RUNNING - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- cnxns - Variable in class org.apache.zookeeper.server.ServerCnxnFactory
-
- CnxnStatResetCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.CnxnStatResetCommand
-
- CnxnStatResetCommand - Class in org.apache.zookeeper.server.command
-
- CnxnStatResetCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.CnxnStatResetCommand
-
- code() - Method in exception org.apache.zookeeper.KeeperException
-
Read the error Code for this exception
- Command - Interface in org.apache.zookeeper.server.admin
-
Interface implemented by all commands runnable by JettyAdminServer.
- CommandBase - Class in org.apache.zookeeper.server.admin
-
- CommandBase(List<String>) - Constructor for class org.apache.zookeeper.server.admin.CommandBase
-
- CommandBase(List<String>, boolean) - Constructor for class org.apache.zookeeper.server.admin.CommandBase
-
- CommandBase(List<String>, boolean, String) - Constructor for class org.apache.zookeeper.server.admin.CommandBase
-
- CommandClient - Class in org.apache.zookeeper.server.controller
-
A convenient helper to send controller command to ControllerService.
- CommandClient(int, int) - Constructor for class org.apache.zookeeper.server.controller.CommandClient
-
Instantiate a client configured to send requests to localhost.
- CommandClient(InetSocketAddress, int) - Constructor for class org.apache.zookeeper.server.controller.CommandClient
-
Instantiate a client configured to send requests to the specified host address.
- CommandClient(int) - Constructor for class org.apache.zookeeper.server.controller.CommandClient
-
- commandCount - Variable in class org.apache.zookeeper.ZooKeeperMain
-
- CommandExecutor - Class in org.apache.zookeeper.server.command
-
- CommandExecutor() - Constructor for class org.apache.zookeeper.server.command.CommandExecutor
-
- CommandFactory - Class in org.apache.zookeeper.cli
-
Factory class for creating instances of
CliCommand
.
- CommandFactory() - Constructor for class org.apache.zookeeper.cli.CommandFactory
-
- CommandFactory.Command - Enum in org.apache.zookeeper.cli
-
All Cli Commands.
- CommandListener - Class in org.apache.zookeeper.server.controller
-
An HTTP server listening to incoming controller commands sent from CommandClient (or any of your favorite REST client
) and dispatching the command to the ZooKeeperServerController for execution.
- CommandListener(ZooKeeperServerController, ControllerServerConfig) - Constructor for class org.apache.zookeeper.server.controller.CommandListener
-
- CommandNotFoundException - Exception in org.apache.zookeeper.cli
-
- CommandNotFoundException(String) - Constructor for exception org.apache.zookeeper.cli.CommandNotFoundException
-
- CommandOutputter - Interface in org.apache.zookeeper.server.admin
-
CommandOutputters are used to format the responses from Commands.
- CommandResponse - Class in org.apache.zookeeper.server.admin
-
- CommandResponse(String) - Constructor for class org.apache.zookeeper.server.admin.CommandResponse
-
Creates a new response with no error string.
- CommandResponse(String, String) - Constructor for class org.apache.zookeeper.server.admin.CommandResponse
-
Creates a new response.
- commandRun() - Method in class org.apache.zookeeper.server.command.AbstractFourLetterCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.CnxnStatResetCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.ConfCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.ConsCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.DigestCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.DirsCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.DumpCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.EnvCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.IsroCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.MonitorCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.NopCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.RuokCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.SetTraceMaskCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.StatCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.StatResetCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.TraceMaskCommand
-
- commandRun() - Method in class org.apache.zookeeper.server.command.WatchCommand
-
- Commands - Class in org.apache.zookeeper.server.admin
-
Class containing static methods for registering and running Commands, as well
as default Command definitions.
- Commands.CnxnStatResetCommand - Class in org.apache.zookeeper.server.admin
-
Reset all connection statistics.
- Commands.ConfCommand - Class in org.apache.zookeeper.server.admin
-
Server configuration parameters.
- Commands.ConsCommand - Class in org.apache.zookeeper.server.admin
-
Information on client connections to server.
- Commands.DigestCommand - Class in org.apache.zookeeper.server.admin
-
Digest histories for every specific number of txns.
- Commands.DirsCommand - Class in org.apache.zookeeper.server.admin
-
Information on ZK datadir and snapdir size in bytes
- Commands.DumpCommand - Class in org.apache.zookeeper.server.admin
-
Information on session expirations and ephemerals.
- Commands.EnvCommand - Class in org.apache.zookeeper.server.admin
-
All defined environment variables.
- Commands.GetTraceMaskCommand - Class in org.apache.zookeeper.server.admin
-
The current trace mask.
- Commands.InitialConfigurationCommand - Class in org.apache.zookeeper.server.admin
-
- Commands.IsroCommand - Class in org.apache.zookeeper.server.admin
-
Is this server in read-only mode.
- Commands.LastSnapshotCommand - Class in org.apache.zookeeper.server.admin
-
Command returns information of the last snapshot that zookeeper server
has finished saving to disk.
- Commands.LeaderCommand - Class in org.apache.zookeeper.server.admin
-
Returns the leader status of this instance and the leader host string.
- Commands.MonitorCommand - Class in org.apache.zookeeper.server.admin
-
Some useful info for monitoring.
- Commands.ObserverCnxnStatResetCommand - Class in org.apache.zookeeper.server.admin
-
Reset all observer connection statistics.
- Commands.RuokCommand - Class in org.apache.zookeeper.server.admin
-
No-op command, check if the server is running
- Commands.SetTraceMaskCommand - Class in org.apache.zookeeper.server.admin
-
Sets the trace mask.
- Commands.SrvrCommand - Class in org.apache.zookeeper.server.admin
-
Server information.
- Commands.StatCommand - Class in org.apache.zookeeper.server.admin
-
Same as SrvrCommand but has extra "connections" entry.
- Commands.StatResetCommand - Class in org.apache.zookeeper.server.admin
-
Resets server statistics.
- Commands.SyncedObserverConsCommand - Class in org.apache.zookeeper.server.admin
-
Information on observer connections to server.
- Commands.SystemPropertiesCommand - Class in org.apache.zookeeper.server.admin
-
All defined system properties.
- Commands.VotingViewCommand - Class in org.apache.zookeeper.server.admin
-
Returns the current ensemble configuration information.
- Commands.WatchCommand - Class in org.apache.zookeeper.server.admin
-
Watch information aggregated by session.
- Commands.WatchesByPathCommand - Class in org.apache.zookeeper.server.admin
-
Watch information aggregated by path.
- Commands.WatchSummaryCommand - Class in org.apache.zookeeper.server.admin
-
Summarized watch information.
- Commands.ZabStateCommand - Class in org.apache.zookeeper.server.admin
-
Returns the current phase of Zab protocol that peer is running.
- commit() - Method in class org.apache.zookeeper.server.auth.DigestLoginModule
-
- commit() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
commit the logs.
- commit() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
commit the transaction of logs
- commit() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
commit the transaction and make sure
they are persisted
- commit(Request) - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
-
- commit(long) - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
-
When a COMMIT message is received, eventually this method is called,
which matches up the zxid from the COMMIT with (hopefully) the head of
the pendingTxns queue and hands it to the commitProcessor to commit.
- commit(long) - Method in class org.apache.zookeeper.server.quorum.Leader
-
Create a commit packet and send it to all the members of the quorum
- commit() - Method in class org.apache.zookeeper.server.ZKDatabase
-
commit to the underlying transaction log
- commit() - Method in class org.apache.zookeeper.Transaction
-
- commit(AsyncCallback.MultiCallback, Object) - Method in class org.apache.zookeeper.Transaction
-
- COMMIT_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- COMMIT_LOG_COUNT - Static variable in class org.apache.zookeeper.server.ZKDatabase
-
- COMMIT_PROCESS_TIME - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- COMMIT_PROPAGATION_LATENCY - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- commitAndActivate(long, long) - Method in class org.apache.zookeeper.server.quorum.Leader
-
- commitLogCount - Variable in class org.apache.zookeeper.server.ZKDatabase
-
- CommitProcessor - Class in org.apache.zookeeper.server.quorum
-
This RequestProcessor matches the incoming committed requests with the
locally submitted requests.
- CommitProcessor(RequestProcessor, String, boolean, ZooKeeperServerListener) - Constructor for class org.apache.zookeeper.server.quorum.CommitProcessor
-
- commitProcessor - Variable in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
-
- commitProcQueueStartTime - Variable in class org.apache.zookeeper.server.Request
-
- commitRecvTime - Variable in class org.apache.zookeeper.server.Request
-
- commitRequest(Request) - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
-
Unlike a Follower, which sees a full request only during the PROPOSAL
phase, Observers get all the data required with the INFORM packet.
- COMMITS_QUEUED - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- COMMITS_QUEUED_IN_COMMIT_PROCESSOR - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- commitSession(long, int) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
-
Synchronized on this to avoid race condition of adding a local session
after committed global session, which may cause the same session being
tracked on this server and leader.
- commitSession(long, int) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
-
Synchronized on this to avoid race condition of adding a local session
after committed global session, which may cause the same session being
tracked on this server and leader.
- commitSession(long, int) - Method in interface org.apache.zookeeper.server.SessionTracker
-
Add the session to the local session map or global one in zkDB.
- commitSession(long, int) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
-
- committedLog - Variable in class org.apache.zookeeper.server.ZKDatabase
-
- committedRequests - Variable in class org.apache.zookeeper.server.quorum.CommitProcessor
-
Requests that have been committed.
- compareDigest(TxnHeader, Record, TxnDigest) - Method in class org.apache.zookeeper.server.DataTree
-
Compares the digest of the tree with the digest present in transaction digest.
- compareDigest(TxnHeader, Record, TxnDigest) - Method in class org.apache.zookeeper.server.ZKDatabase
-
- compareSnapshotDigests(long) - Method in class org.apache.zookeeper.server.DataTree
-
Compares the actual tree's digest with that in the snapshot.
- CONCURRENT_REQUEST_PROCESSING_IN_COMMIT_PROCESSOR - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- confCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
-
- ConfCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.ConfCommand
-
- ConfCommand - Class in org.apache.zookeeper.server.command
-
- config - Variable in class org.apache.zookeeper.server.controller.ControllerService
-
- CONFIG_DEFAULT_KERBEROS_CANONICALIZE_HOST_NAMES - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- CONFIG_DEFAULT_MULTI_ADDRESS_ENABLED - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- CONFIG_KEY_KERBEROS_CANONICALIZE_HOST_NAMES - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- CONFIG_KEY_MULTI_ADDRESS_ENABLED - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- CONFIG_KEY_MULTI_ADDRESS_REACHABILITY_CHECK_ENABLED - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- CONFIG_KEY_MULTI_ADDRESS_REACHABILITY_CHECK_TIMEOUT_MS - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- CONFIG_NODE - Static variable in class org.apache.zookeeper.ZooDefs
-
- ConfigException(String) - Constructor for exception org.apache.zookeeper.server.quorum.QuorumPeerConfig.ConfigException
-
- ConfigException(String, Exception) - Constructor for exception org.apache.zookeeper.server.quorum.QuorumPeerConfig.ConfigException
-
- configFileStr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- configFromString(String) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- configuration(Properties) - Method in class org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded.ZookKeeperServerEmbeddedBuilder
-
Set the contents of the main configuration as it would be in zk_server.conf file.
- configure(Properties) - Method in class org.apache.zookeeper.metrics.impl.DefaultMetricsProvider
-
- configure(Properties) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider
-
- configure(Properties) - Method in interface org.apache.zookeeper.metrics.MetricsProvider
-
Configure the provider.
- configure(InetSocketAddress, int, int, boolean) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
-
- configure(InetSocketAddress, int, int, boolean) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
- configure(InetSocketAddress, int) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- configure(InetSocketAddress, int, int) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- configure(InetSocketAddress, int, int, boolean) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- configureSaslLogin() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
Initialize the server SASL if specified.
- configureSSLAuth() - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
Configure SSL authentication only if it is not configured.
- ConfigUtils - Class in org.apache.zookeeper.server.util
-
- ConfigUtils() - Constructor for class org.apache.zookeeper.server.util.ConfigUtils
-
- connect(SocketAddress) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- connect(SocketAddress, int) - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- connectAll() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Try to establish a connection with each server if one
doesn't exist.
- connectedToPeer(long) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
- connectingFollowers - Variable in class org.apache.zookeeper.server.quorum.Leader
-
- CONNECTION_DROP_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- CONNECTION_REJECTED - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- CONNECTION_REQUEST_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- CONNECTION_REVALIDATE_COUNT - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- CONNECTION_THROTTLE_DECREASE_RATIO - Static variable in class org.apache.zookeeper.server.BlueThrottle
-
- CONNECTION_THROTTLE_DROP_DECREASE - Static variable in class org.apache.zookeeper.server.BlueThrottle
-
- CONNECTION_THROTTLE_DROP_INCREASE - Static variable in class org.apache.zookeeper.server.BlueThrottle
-
- CONNECTION_THROTTLE_FILL_COUNT - Static variable in class org.apache.zookeeper.server.BlueThrottle
-
- CONNECTION_THROTTLE_FILL_TIME - Static variable in class org.apache.zookeeper.server.BlueThrottle
-
- CONNECTION_THROTTLE_FREEZE_TIME - Static variable in class org.apache.zookeeper.server.BlueThrottle
-
- CONNECTION_THROTTLE_TOKENS - Static variable in class org.apache.zookeeper.server.BlueThrottle
-
- CONNECTION_TOKEN_DEFICIT - Variable in class org.apache.zookeeper.server.ServerMetrics
-
- ConnectionBean - Class in org.apache.zookeeper.server
-
Implementation of connection MBean interface.
- ConnectionBean(ServerCnxn, ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.ConnectionBean
-
- ConnectionLoss - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
-
- ConnectionLossException() - Constructor for exception org.apache.zookeeper.KeeperException.ConnectionLossException
-
- ConnectionMXBean - Interface in org.apache.zookeeper.server
-
This MBean represents a client connection.
- ConnectStringParser - Class in org.apache.zookeeper.client
-
A parser for ZooKeeper Client connect strings.
- ConnectStringParser(String) - Constructor for class org.apache.zookeeper.client.ConnectStringParser
-
Parse host and port by spliting client connectString
with support for IPv6 literals
- connectToLeader(MultipleAddresses, String) - Method in class org.apache.zookeeper.server.quorum.Learner
-
Establish a connection with the LearnerMaster found by findLearnerMaster.
- connectToLearnerMasterLimit - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
The number of ticks that can pass before retrying to connect to learner master
- connectToLearnerMasterLimit - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- connectToZK(String) - Method in class org.apache.zookeeper.ZooKeeperMain
-
- connThrottle() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- consCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
-
- ConsCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.ConsCommand
-
- ConsCommand - Class in org.apache.zookeeper.server.command
-
- ConsCommand(PrintWriter, ServerCnxn) - Constructor for class org.apache.zookeeper.server.command.ConsCommand
-
- CONTAINER_EPHEMERAL_OWNER - Static variable in enum org.apache.zookeeper.server.EphemeralType
-
- CONTAINER_EPHEMERAL_OWNER - Static variable in enum org.apache.zookeeper.server.EphemeralTypeEmulate353
-
- ContainerManager - Class in org.apache.zookeeper.server
-
Manages cleanup of container ZNodes.
- ContainerManager(ZKDatabase, RequestProcessor, int, int) - Constructor for class org.apache.zookeeper.server.ContainerManager
-
- ContainerManager(ZKDatabase, RequestProcessor, int, int, long) - Constructor for class org.apache.zookeeper.server.ContainerManager
-
- contains(Integer) - Method in class org.apache.zookeeper.server.util.BitHashSet
-
- contains(Watcher) - Method in class org.apache.zookeeper.server.watch.WatcherOrBitSet
-
- contains(int) - Method in class org.apache.zookeeper.server.watch.WatcherOrBitSet
-
- contains(Object) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
-
- containsAll(Collection<?>) - Method in class org.apache.zookeeper.util.CircularBlockingQueue
-
- containsQuorum(Set<Long>) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
-
Verifies if a given set is a quorum.
- containsQuorum(Set<Long>) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
-
Verifies if a set is a majority.
- containsQuorum(Set<Long>) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
-
- containsQuorum(Set<Long>) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
-
- containsWatcher(String, Watcher.WatcherType, Watcher) - Method in class org.apache.zookeeper.server.DataTree
-
- containsWatcher(String, Watcher) - Method in interface org.apache.zookeeper.server.watch.IWatchManager
-
Checks the specified watcher exists for the given path.
- containsWatcher(String, Watcher) - Method in class org.apache.zookeeper.server.watch.WatchManager
-
- containsWatcher(String, Watcher) - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
-
Used in the OpCode.checkWatches, which is a read operation, since read
and write requests are exclusively processed, we don't need to hold
lock here.
- containsWatcher(String, Watcher.WatcherType, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
-
Check whether the given watcher exists in datatree
- ControlCommand - Class in org.apache.zookeeper.server.controller
-
Set of commands that this controller can execute.
- ControlCommand(ControlCommand.Action) - Constructor for class org.apache.zookeeper.server.controller.ControlCommand
-
- ControlCommand(ControlCommand.Action, String) - Constructor for class org.apache.zookeeper.server.controller.ControlCommand
-
- ControlCommand.Action - Enum in org.apache.zookeeper.server.controller
-
Actions available to the controller
- ControllableConnection - Class in org.apache.zookeeper.server.controller
-
Extension of NIOServerCnxn which can inject changes per controller commands.
- ControllableConnection(ZooKeeperServer, SocketChannel, SelectionKey, NIOServerCnxnFactory, NIOServerCnxnFactory.SelectorThread) - Constructor for class org.apache.zookeeper.server.controller.ControllableConnection
-
- ControllableConnectionFactory - Class in org.apache.zookeeper.server.controller
-
Extension of NIOServerCnxnFactory which can inject changes per controller commands.
- ControllableConnectionFactory() - Constructor for class org.apache.zookeeper.server.controller.ControllableConnectionFactory
-
- CONTROLLER_PORT_KEY - Static variable in class org.apache.zookeeper.server.controller.ControllerServerConfig
-
- ControllerServerConfig - Class in org.apache.zookeeper.server.controller
-
Config for the ControllerService.
- ControllerServerConfig(String) - Constructor for class org.apache.zookeeper.server.controller.ControllerServerConfig
-
Instantiate a new config via a zk config file.
- ControllerServerConfig(InetAddress, int, int, String) - Constructor for class org.apache.zookeeper.server.controller.ControllerServerConfig
-
Instantiate a config object with required parameters.
- ControllerServerConfig(int, int, String) - Constructor for class org.apache.zookeeper.server.controller.ControllerServerConfig
-
Instantiate a config object with required parameters.
- ControllerService - Class in org.apache.zookeeper.server.controller
-
Main class which starts a ZooKeeperServer, a ZooKeeperServerController and the ControllerService.
- ControllerService() - Constructor for class org.apache.zookeeper.server.controller.ControllerService
-
- convertAcls(List<ACL>) - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
-
converts the list of acls to a long.
- convertLong(Long) - Method in class org.apache.zookeeper.server.ReferenceCountedACLCache
-
converts a long to a list of acls.
- copyBytes(InputStream, OutputStream, int, boolean) - Static method in class org.apache.zookeeper.common.IOUtils
-
Copies from one stream to another.
- copyBytes(InputStream, OutputStream, int) - Static method in class org.apache.zookeeper.common.IOUtils
-
Copies from one stream to another.
- copyStat(Stat) - Method in class org.apache.zookeeper.server.DataNode
-
- copyStat(Stat, Stat) - Static method in class org.apache.zookeeper.server.DataTree
-
- copyStatPersisted(StatPersisted, StatPersisted) - Static method in class org.apache.zookeeper.server.DataTree
-
- count - Variable in class org.apache.zookeeper.server.ServerCnxn
-
- countEphemerals() - Method in class org.apache.zookeeper.server.DataTreeBean
-
- countEphemerals() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
-
- Counter - Interface in org.apache.zookeeper.metrics
-
A counter refers to a value which can only increase.
- CounterSet - Interface in org.apache.zookeeper.metrics
-
A counter refers to a value which can only increase.
- countParticipants(Map<Long, QuorumPeer.QuorumServer>) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Count the number of nodes in the map that could be followers.
- create(KeeperException.Code, String) - Static method in exception org.apache.zookeeper.KeeperException
-
All non-specific keeper exceptions should be constructed via
this factory method in order to guarantee consistency in error
codes and such.
- create(int, String) - Static method in exception org.apache.zookeeper.KeeperException
-
- create(int) - Static method in exception org.apache.zookeeper.KeeperException
-
- create(KeeperException.Code) - Static method in exception org.apache.zookeeper.KeeperException
-
All non-specific keeper exceptions should be constructed via
this factory method in order to guarantee consistency in error
codes and such.
- create(String, byte[], List<ACL>, int) - Static method in class org.apache.zookeeper.Op
-
Constructs a create operation.
- create(String, byte[], List<ACL>, int, long) - Static method in class org.apache.zookeeper.Op
-
Constructs a create operation.
- create(String, byte[], List<ACL>, CreateMode) - Static method in class org.apache.zookeeper.Op
-
Constructs a create operation.
- create(String, byte[], List<ACL>, CreateMode, long) - Static method in class org.apache.zookeeper.Op
-
Constructs a create operation.
- create(String) - Method in class org.apache.zookeeper.server.util.VerifyingFileFactory
-
- create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.zookeeper.Transaction
-
- create - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- CREATE - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
-
- create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.zookeeper.ZooKeeper
-
Create a node with the given path.
- create(String, byte[], List<ACL>, CreateMode, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
Create a node with the given path and returns the Stat of that node.
- create(String, byte[], List<ACL>, CreateMode, Stat, long) - Method in class org.apache.zookeeper.ZooKeeper
-
- create(String, byte[], List<ACL>, CreateMode, AsyncCallback.StringCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of create.
- create(String, byte[], List<ACL>, CreateMode, AsyncCallback.Create2Callback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of create.
- create(String, byte[], List<ACL>, CreateMode, AsyncCallback.Create2Callback, Object, long) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of create with ttl.
- create2 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- createAdminServer() - Static method in class org.apache.zookeeper.server.admin.AdminServerFactory
-
This method encapsulates the logic for whether we should use a
JettyAdminServer (i.e., the AdminServer is enabled) or a DummyAdminServer
(i.e., the AdminServer is disabled).
- createCnxnManager() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- CreateCommand - Class in org.apache.zookeeper.cli
-
create command for cli
- CreateCommand() - Constructor for class org.apache.zookeeper.cli.CreateCommand
-
- createCommandUri(ControlCommand.Action, String) - Static method in class org.apache.zookeeper.server.controller.ControlCommand
-
Create a REST command uri.
- createConnection(SocketChannel, SelectionKey, NIOServerCnxnFactory.SelectorThread) - Method in class org.apache.zookeeper.server.controller.ControllableConnectionFactory
-
- createConnection(SocketChannel, SelectionKey, NIOServerCnxnFactory.SelectorThread) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
- createContainer - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- createDataTree() - Method in class org.apache.zookeeper.server.ZKDatabase
-
- createElectionAlgorithm(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- createFactory() - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- createFactory(int, int) - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- createFactory(int, int, int) - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- createFactory(InetSocketAddress, int) - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- createFactory(InetSocketAddress, int, int) - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- createFromConfig(QuorumPeerConfig) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Create a new QuorumPeer and apply all the values per the already-parsed config.
- createInputArchive(File) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
Invoked to indicate that the input stream has been created.
- createKeyManager(String, String, String) - Static method in class org.apache.zookeeper.common.X509Util
-
Creates a key manager by loading the key store from the given file of
the given type, optionally decrypting it using the given password.
- createLocalSessionTracker(SessionTracker.SessionExpirer, int, long, ZooKeeperServerListener) - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
-
- CreateMode - Enum in org.apache.zookeeper
-
CreateMode value determines how the znode is created on ZooKeeper.
- createNettyJdkSslContext(SSLContext, boolean) - Method in class org.apache.zookeeper.common.SSLContextAndOptions
-
- createNode(String, byte[], List<ACL>, long, int, long, long) - Method in class org.apache.zookeeper.server.DataTree
-
Add a new node to the DataTree.
- createNode(String, byte[], List<ACL>, long, int, long, long, Stat) - Method in class org.apache.zookeeper.server.DataTree
-
Add a new node to the DataTree.
- createPacket(QuorumAuth.Status, byte[]) - Static method in class org.apache.zookeeper.server.quorum.auth.QuorumAuth
-
- createQuota(ZooKeeper, String, StatsTrack) - Static method in class org.apache.zookeeper.cli.SetQuotaCommand
-
this method creates a quota node for the path
- createRequestThrottler() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- CreateResult(String) - Constructor for class org.apache.zookeeper.OpResult.CreateResult
-
- CreateResult(String, Stat) - Constructor for class org.apache.zookeeper.OpResult.CreateResult
-
- createSaslClient(Subject, String, String, String, Logger, String) - Static method in class org.apache.zookeeper.util.SecurityUtils
-
Create an instance of a SaslClient.
- createSaslServer(Subject, String, String, CallbackHandler, Logger) - Static method in class org.apache.zookeeper.util.SecurityUtils
-
Create an instance of a SaslServer.
- createSession(int) - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
-
- createSession(int) - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
-
- createSession(int) - Method in class org.apache.zookeeper.server.quorum.LocalSessionTracker
-
- createSession(int) - Method in interface org.apache.zookeeper.server.SessionTracker
-
- createSession(int) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
-
- createSession - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- createSessionTracker() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
-
- createSessionTracker() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
-
- createSessionTracker() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
-
- createSessionTracker() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- createSocket() - Method in class org.apache.zookeeper.server.quorum.Learner
-
Creating a simple or and SSL socket.
- createSSLContext(ZKConfig) - Method in class org.apache.zookeeper.common.X509Util
-
- createSSLContextAndOptions(ZKConfig) - Method in class org.apache.zookeeper.common.X509Util
-
- createSSLContextAndOptionsFromConfig(ZKConfig) - Method in class org.apache.zookeeper.common.X509Util
-
- createSSLServerSocket() - Method in class org.apache.zookeeper.common.SSLContextAndOptions
-
- createSSLServerSocket(int) - Method in class org.apache.zookeeper.common.SSLContextAndOptions
-
- createSSLServerSocket() - Method in class org.apache.zookeeper.common.X509Util
-
- createSSLServerSocket(int) - Method in class org.apache.zookeeper.common.X509Util
-
- createSSLSocket() - Method in class org.apache.zookeeper.common.SSLContextAndOptions
-
- createSSLSocket(Socket, byte[]) - Method in class org.apache.zookeeper.common.SSLContextAndOptions
-
- createSSLSocket() - Method in class org.apache.zookeeper.common.X509Util
-
- createSSLSocket(Socket, byte[]) - Method in class org.apache.zookeeper.common.X509Util
-
- createStat(long, long, long) - Static method in class org.apache.zookeeper.server.DataTree
-
Create a node stat from the given params.
- createTime - Variable in class org.apache.zookeeper.server.Request
-
- createTrustManager(String, String, String, boolean, boolean, boolean, boolean) - Static method in class org.apache.zookeeper.common.X509Util
-
Creates a trust manager by loading the trust store from the given file
of the given type, optionally decrypting it using the given password.
- createTTL - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- createWatchManager() - Static method in class org.apache.zookeeper.server.watch.WatchManagerFactory
-
- CREATOR_ALL_ACL - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
-
This ACL gives the creators authentication id's all permissions.
- crstCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
-
- CURRENT_EPOCH_FILENAME - Static variable in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- currentElapsedTime() - Static method in class org.apache.zookeeper.common.Time
-
Returns time in milliseconds as does System.currentTimeMillis(),
but uses elapsed time from an arbitrary epoch more like System.nanoTime().
- CURRENTVERSION - Static variable in class org.apache.zookeeper.server.quorum.FastLeaderElection.Notification
-
- currentWallTime() - Static method in class org.apache.zookeeper.common.Time
-
Explicitly returns system dependent current wall time.
- cxid - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
-
- cxid - Variable in class org.apache.zookeeper.server.Request
-
- Gauge - Interface in org.apache.zookeeper.metrics
-
A Gauge is an application provided object which will be called by the framework in order to sample the value
of an integer value.
- GaugeSet - Interface in org.apache.zookeeper.metrics
-
A Gauge is an application provided object which will be called by the metrics framework to sample a numeric value.
- generateDigest(String) - Static method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
-
- get(int) - Static method in enum org.apache.zookeeper.KeeperException.Code
-
Get the Code value for a particular integer error code
- get() - Method in interface org.apache.zookeeper.metrics.Counter
-
Get the current value held by the counter.
- get() - Method in interface org.apache.zookeeper.metrics.Gauge
-
Returns the current value associated with this gauge.
- get(long) - Static method in enum org.apache.zookeeper.server.EphemeralType
-
Convert a ZNode ephemeral owner to an ephemeral type.
- get(long) - Static method in enum org.apache.zookeeper.server.EphemeralTypeEmulate353
-
- get() - Method in class org.apache.zookeeper.server.metric.SimpleCounter
-
- get(String) - Method in interface org.apache.zookeeper.server.NodeHashMap
-
Return the data node associated with the path.
- get(String) - Method in class org.apache.zookeeper.server.NodeHashMapImpl
-
- get(String, Stat) - Method in class org.apache.zookeeper.server.ResponseCache
-
- get(int) - Method in class org.apache.zookeeper.server.util.BitMap
-
- GET_CHILDREN_RESPONSE_CACHE_SIZE - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
-
- GET_DATA_RESPONSE_CACHE_SIZE - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
-
- getAcceptedEpoch() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getAcceptedIssuers() - Method in class org.apache.zookeeper.common.ZKTrustManager
-
- getAckLoggingFrequency() - Static method in class org.apache.zookeeper.server.quorum.Leader
-
- getAckset() - Method in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker.QuorumVerifierAcksetPair
-
- getACL(String, Stat) - Method in class org.apache.zookeeper.server.DataTree
-
- getACL(DataNode) - Method in class org.apache.zookeeper.server.DataTree
-
- getACL(String, Stat) - Method in class org.apache.zookeeper.server.ZKDatabase
-
get acl for a path
- getACL - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- getACL(String, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the ACL and stat of the node of the given path.
- getACL(String, Stat, AsyncCallback.ACLCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getACL.
- GetAclCommand - Class in org.apache.zookeeper.cli
-
getAcl command for cli
- GetAclCommand() - Constructor for class org.apache.zookeeper.cli.GetAclCommand
-
- getAclExpr() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.MatchValues
-
- getAclSize() - Method in class org.apache.zookeeper.server.ZKDatabase
-
get the acl size of the datatree
- getAction() - Method in class org.apache.zookeeper.server.controller.ControlCommand
-
- getActiveObservers() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- getActiveServer() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getAllAddresses() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
-
Returns all addresses in an unmodifiable set.
- getAllByName(String) - Method in interface org.apache.zookeeper.client.StaticHostProvider.Resolver
-
- getAllChildrenNumber(String) - Method in class org.apache.zookeeper.server.DataTree
-
- getAllChildrenNumber(String) - Method in class org.apache.zookeeper.server.ZKDatabase
-
- getAllChildrenNumber - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- getAllChildrenNumber(String) - Method in class org.apache.zookeeper.ZooKeeper
-
Synchronously gets all numbers of children nodes under a specific path
- getAllChildrenNumber(String, AsyncCallback.AllChildrenNumberCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
Asynchronously gets all numbers of children nodes under a specific path
- GetAllChildrenNumberCommand - Class in org.apache.zookeeper.cli
-
getAllChildrenNumber command for CLI
- GetAllChildrenNumberCommand() - Constructor for class org.apache.zookeeper.cli.GetAllChildrenNumberCommand
-
- getAllConnectionInfo(boolean) - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
-
- getAllConnectionInfo(boolean) - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
- getAllConnectionInfo(boolean) - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- getAllHostStrings() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
-
Returns distinct list of all host strings
- getAllMembers() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
-
- getAllMembers() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
-
- getAllMembers() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
-
- getAllPorts() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
-
Returns all ports
- getAllReachableAddresses() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
-
Returns a set of all reachable addresses.
- getAllReachableAddressesOrAll() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
-
Returns a set of all reachable addresses.
- getAndDecrementFollowerCounter() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getAndDecrementFollowerCounter() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- getAsyncSending() - Static method in class org.apache.zookeeper.server.quorum.Learner
-
- getAuthFailedCount() - Method in class org.apache.zookeeper.server.ServerStats
-
- getAuthFailedCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getAuthFailedCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getAuthInfo() - Method in class org.apache.zookeeper.server.ServerCnxn
-
auth info for the cnxn, returns an unmodifyable list
- getAuthorizationID() - Method in class org.apache.zookeeper.server.ZooKeeperSaslServer
-
- getAvg() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
-
- getAvgLatency() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getAvgLatency() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Average latency in ms
- getAvgLatency() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getAvgLatency() - Method in class org.apache.zookeeper.server.ServerStats
-
- getAvgRequestLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getAvgRequestLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getBit(T) - Method in class org.apache.zookeeper.server.util.BitMap
-
- getBoolean(String) - Method in class org.apache.zookeeper.common.ZKConfig
-
Returns true
if and only if the property named by the argument
exists and is equal to the string "true"
.
- getBoolean(String, boolean) - Method in class org.apache.zookeeper.common.ZKConfig
-
Get the value of the key
property as a boolean
.
- getBuildDate() - Static method in class org.apache.zookeeper.Version
-
- getByteHardLimit() - Method in class org.apache.zookeeper.StatsTrack
-
get the count of bytes allowed as part of quota (hard limit)
- getBytes() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
-
- getBytes() - Method in class org.apache.zookeeper.StatsTrack
-
get the count of bytes allowed as part of quota
- getCacheSize() - Method in class org.apache.zookeeper.server.ResponseCache
-
- getCandidates() - Method in class org.apache.zookeeper.server.ContainerManager
-
- getChannel() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getChildren(String) - Static method in class org.apache.zookeeper.Op
-
- getChildren() - Method in class org.apache.zookeeper.OpResult.GetChildrenResult
-
- getChildren() - Method in class org.apache.zookeeper.server.DataNode
-
convenience methods to get the children
- getChildren(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.DataTree
-
- getChildren(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
-
get children list for this path
- getChildren - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- getChildren(String, Watcher) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the list of the children of the node of the given path.
- getChildren(String, boolean) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the list of the children of the node of the given path.
- getChildren(String, Watcher, AsyncCallback.ChildrenCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getChildren.
- getChildren(String, boolean, AsyncCallback.ChildrenCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getChildren.
- getChildren(String, Watcher, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
For the given znode path return the stat and children list.
- getChildren(String, boolean, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
For the given znode path return the stat and children list.
- getChildren(String, Watcher, AsyncCallback.Children2Callback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getChildren.
- getChildren(String, boolean, AsyncCallback.Children2Callback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getChildren.
- getChildren2 - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- GetChildrenResult(List<String>) - Constructor for class org.apache.zookeeper.OpResult.GetChildrenResult
-
- getChildWatches() - Method in class org.apache.zookeeper.ZooKeeper
-
- getChrootPath() - Method in class org.apache.zookeeper.client.ConnectStringParser
-
- getCipherSuitesProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getClientAddress() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getClientAddress() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getClientAddress() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getClientAddress() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
-
- getClientAddress() - Method in interface org.apache.zookeeper.server.quorum.RemotePeerMXBean
-
- getClientCertificateChain() - Method in class org.apache.zookeeper.server.DumbWatcher
-
- getClientCertificateChain() - Method in class org.apache.zookeeper.server.NettyServerCnxn
-
- getClientCertificateChain() - Method in class org.apache.zookeeper.server.NIOServerCnxn
-
- getClientCertificateChain() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getClientConfig() - Method in class org.apache.zookeeper.ZooKeeper
-
- getClientConfigStr(String) - Static method in class org.apache.zookeeper.server.util.ConfigUtils
-
- getClientId(X509Certificate) - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
-
Determine the string to be used as the remote host session Id for
authorization purposes.
- getClientInfos(List<Id>) - Static method in class org.apache.zookeeper.server.util.AuthUtil
-
Gets user from id to prepare ClientInfo.
- getClientPath() - Method in class org.apache.zookeeper.WatchDeregistration
-
Returns client path which has specified for unregistering its watcher
- getClientPort() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
-
Gets the client port.
- getClientPort() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getClientPortAddress() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getClientPortAddress() - Method in class org.apache.zookeeper.server.ServerConfig
-
- getClientPortListenBacklog() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
The server socket's listen backlog length
- getClientPortListenBacklog() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getClientPortListenBacklog() - Method in class org.apache.zookeeper.server.ServerConfig
-
Maximum number of pending socket connections to read, -1 if unset
- getClientPortListenBacklog() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getClientPortListenBacklog() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
-
Returns the server socket listen backlog length.
- getClientReachableLocalInetAddressCount() - Static method in class org.apache.zookeeper.common.NettyUtils
-
Attempts to detect and return the number of local network addresses that could be
used by a client to reach this server.
- getClientResponseStats() - Method in class org.apache.zookeeper.server.ServerStats
-
- getCmdStr() - Method in class org.apache.zookeeper.cli.CliCommand
-
get the string used to call this command
- getCnxManager() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
-
- getCnxn() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.ServerObjs
-
- getCnxnFactory() - Method in class org.apache.zookeeper.server.controller.ZooKeeperServerController
-
- getCode() - Method in exception org.apache.zookeeper.KeeperException
-
- GetCommand - Class in org.apache.zookeeper.cli
-
get command for cli
- GetCommand() - Constructor for class org.apache.zookeeper.cli.GetCommand
-
- getCommand() - Method in class org.apache.zookeeper.server.admin.CommandResponse
-
Gets the command name.
- getCommand(String) - Static method in class org.apache.zookeeper.server.admin.Commands
-
Returns the commands registered under cmdName with registerCommand, or
null if no command is registered with that name.
- getCommands() - Static method in class org.apache.zookeeper.ZooKeeperMain
-
- getCommandString(int) - Static method in class org.apache.zookeeper.server.command.FourLetterCommands
-
Return the string representation of the specified command code.
- getCommitProcMaxCommitBatchSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getCommitProcMaxCommitBatchSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getCommitProcMaxReadBatchSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getCommitProcMaxReadBatchSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getCommittedLog() - Method in class org.apache.zookeeper.server.ZKDatabase
-
- getConf() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getConfig(Watcher, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the last committed configuration (as known to the server to which the client is connected)
and the stat of the configuration.
- getConfig(Watcher, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getConfig.
- getConfig(boolean, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the last committed configuration (as known to the server to which the client is connected)
and the stat of the configuration.
- getConfig(boolean, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The Asynchronous version of getConfig.
- GetConfigCommand - Class in org.apache.zookeeper.cli
-
get command for cli
- GetConfigCommand() - Constructor for class org.apache.zookeeper.cli.GetConfigCommand
-
- getConfigFilename() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getConfigPrefix() - Method in class org.apache.zookeeper.common.ClientX509Util
-
- getConfigPrefix() - Method in class org.apache.zookeeper.common.QuorumX509Util
-
- getConfigPrefix() - Method in class org.apache.zookeeper.common.X509Util
-
- getConfigStatus() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
-
- getConfigVersion() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getConfigVersion() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getConnection() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
-
- getConnection() - Method in class org.apache.zookeeper.server.Request
-
- getConnectionDecreaseRatio() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getConnectionDecreaseRatio() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getConnectionDropChance() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getConnectionDropDecrease() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getConnectionDropDecrease() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getConnectionDropIncrease() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getConnectionDropIncrease() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getConnectionFreezeTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getConnectionFreezeTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getConnectionInfo(boolean) - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getConnectionMaxTokens() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getConnectionMaxTokens() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getConnections() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
-
- getConnections() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
- getConnections() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- getConnectionString() - Method in interface org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded
-
Get a connection string useful for the client.
- getConnectionThreadCount() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Return number of connection processing threads.
- getConnectionTokenFillCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getConnectionTokenFillCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getConnectionTokenFillTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getConnectionTokenFillTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getConnectToLearnerMasterLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Get the connectToLearnerMasterLimit
- getConnectToLearnerMasterLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getContainers() - Method in class org.apache.zookeeper.server.DataTree
-
- getContentType() - Method in interface org.apache.zookeeper.server.admin.CommandOutputter
-
The MIME type of this output (e.g., "application/json")
- getContentType() - Method in class org.apache.zookeeper.server.admin.JsonOutputter
-
- getContext(String) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
-
- getContext(String) - Method in interface org.apache.zookeeper.metrics.MetricsContext
-
Returns a sub context.
- getControllerAddress() - Method in class org.apache.zookeeper.server.controller.ControllerServerConfig
-
- getCount() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
-
- getCount() - Method in class org.apache.zookeeper.StatsTrack
-
get the count of nodes allowed as part of quota
- getCounter(String) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
-
- getCounter(String) - Method in interface org.apache.zookeeper.metrics.MetricsContext
-
Returns a counter.
- getCounterFromZxid(long) - Static method in class org.apache.zookeeper.server.util.ZxidUtils
-
- getCounterSet(String) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
-
- getCounterSet(String) - Method in interface org.apache.zookeeper.metrics.MetricsContext
-
Returns the CounterSet identified by the given name
Null name is not allowed
- getCountHardLimit() - Method in class org.apache.zookeeper.StatsTrack
-
get the count of nodes allowed as part of quota (hard limit)
- getCreatedTimeStamp() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
-
- getCurrentAndNextConfigVoters() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getCurrentEpoch() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getCurrentEpoch() - Method in class org.apache.zookeeper.server.quorum.StateSummary
-
- getCurrentLearnerMaster() - Method in class org.apache.zookeeper.server.quorum.Observer
-
- getCurrentLogSize() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
Return the current on-disk size of log size.
- getCurrentTick() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getCurrentTick() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- getCurrentVote() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getCurrentZxid() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
-
- getCurrentZxid() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
-
Current zxid of cluster.
- getData(String) - Static method in class org.apache.zookeeper.Op
-
- getData() - Method in class org.apache.zookeeper.OpResult.GetDataResult
-
- getData() - Method in class org.apache.zookeeper.server.DataNode
-
- getData(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.DataTree
-
- getData(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.ZKDatabase
-
get data and stat for a path
- getData - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- getData(String, Watcher, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the data and the stat of the node of the given path.
- getData(String, boolean, Stat) - Method in class org.apache.zookeeper.ZooKeeper
-
Return the data and the stat of the node of the given path.
- getData(String, Watcher, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getData.
- getData(String, boolean, AsyncCallback.DataCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
The asynchronous version of getData.
- getDataDir() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
get the datadir used by this filetxn
snap log
- getDataDir() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getDataDir() - Method in class org.apache.zookeeper.server.ServerConfig
-
- getDataDir() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
-
Gets the data directory.
- getDataDirSize() - Method in class org.apache.zookeeper.server.ServerStats
-
- getDataDirSize() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
-
- getDataDirSize() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getDataDirSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getDataDirSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getDataLogDir() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
-
Returns transaction log directory.
- getDataLogDir() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getDataLogDir() - Method in class org.apache.zookeeper.server.ServerConfig
-
- getDataLogDir() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
-
Gets the data log directory.
- GetDataResult(byte[], Stat) - Constructor for class org.apache.zookeeper.OpResult.GetDataResult
-
- getDataTree() - Method in class org.apache.zookeeper.server.ZKDatabase
-
the datatree for this zkdatabase
- getDataTreeLastProcessedZxid() - Method in class org.apache.zookeeper.server.ZKDatabase
-
get the last processed zxid from a datatree
- getDataWatches() - Method in class org.apache.zookeeper.ZooKeeper
-
- getDbId() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
the dbid of this transaction database
- getDbId() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
the dbid for this transaction log.
- getDecreasePoint() - Method in class org.apache.zookeeper.server.BlueThrottle
-
- getDefaultFileExtension() - Method in enum org.apache.zookeeper.common.KeyStoreFileType
-
The file extension that is associated with this file type.
- getDefaultRealm() - Method in class org.apache.zookeeper.server.auth.KerberosName
-
Get the configured default realm.
- getDefaultRealm() - Static method in class org.apache.zookeeper.server.util.KerberosUtil
-
- getDefaultSSLContext() - Method in class org.apache.zookeeper.common.X509Util
-
- getDefaultSSLContextAndOptions() - Method in class org.apache.zookeeper.common.X509Util
-
- getDeficit() - Method in class org.apache.zookeeper.server.BlueThrottle
-
- getDetailedPeerState() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getDigest() - Method in class org.apache.zookeeper.server.DataNode
-
- getDigest() - Method in class org.apache.zookeeper.server.DataTree.ZxidDigest
-
- getDigest() - Method in interface org.apache.zookeeper.server.NodeHashMap
-
Return the digest value.
- getDigest() - Method in class org.apache.zookeeper.server.NodeHashMapImpl
-
- getDigest() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
- getDigest() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
-
- getDigest() - Method in class org.apache.zookeeper.server.TxnLogEntry
-
- getDigestEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
-
- getDigestEnabled() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
-
- getDigestFromLoadedSnapshot() - Method in class org.apache.zookeeper.server.DataTree
-
- getDigestLog() - Method in class org.apache.zookeeper.server.DataTree
-
Return all the digests in the historical digest list.
- getDigestVersion() - Method in class org.apache.zookeeper.server.DataTree.ZxidDigest
-
- getDirectBuffer() - Static method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
- getDoc() - Method in interface org.apache.zookeeper.server.admin.Command
-
A string documenting this command (e.g., what it does, any arguments it
takes).
- getDoc() - Method in class org.apache.zookeeper.server.admin.CommandBase
-
- getDropChance() - Method in class org.apache.zookeeper.server.BlueThrottle
-
- getDropDecrease() - Method in class org.apache.zookeeper.server.BlueThrottle
-
- getDropIncrease() - Method in class org.apache.zookeeper.server.BlueThrottle
-
- getDroppedCount() - Method in class org.apache.zookeeper.util.CircularBlockingQueue
-
Returns the number of elements that were dropped from the queue because the
queue was full when a new element was offered.
- getDropStaleRequests() - Static method in class org.apache.zookeeper.server.RequestThrottler
-
- getElapsed(DataNode) - Method in class org.apache.zookeeper.server.ContainerManager
-
- getElectionAddress() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getElectionAddress() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getElectionAddress() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getElectionAddress() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
-
- getElectionAddress() - Method in interface org.apache.zookeeper.server.quorum.RemotePeerMXBean
-
- getElectionAlg() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Get an instance of LeaderElection
- getElectionAlg() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getElectionEpoch() - Method in class org.apache.zookeeper.server.quorum.Vote
-
- getElectionPort() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getElectionTimeTaken() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
-
- getElectionTimeTaken() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
-
- getElectionTimeTaken() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
-
- getElectionTimeTaken() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
-
- getElectionType() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getElectionType() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getElectionType() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Gets the election type
- getEphemeralNodes() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getEphemeralNodes() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
- getEphemerals(long) - Method in class org.apache.zookeeper.server.DataTree
-
- getEphemerals() - Method in class org.apache.zookeeper.server.DataTree
-
Returns a mapping of session ID to ephemeral znodes.
- getEphemerals() - Method in class org.apache.zookeeper.server.ZKDatabase
-
- getEphemerals(long) - Method in class org.apache.zookeeper.server.ZKDatabase
-
the paths for ephemeral session id
- getEphemerals() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getEphemerals - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
-
- getEphemerals() - Method in class org.apache.zookeeper.ZooKeeper
-
Synchronously gets all the ephemeral nodes created by this session.
- getEphemerals(String) - Method in class org.apache.zookeeper.ZooKeeper
-
Synchronously gets all the ephemeral nodes matching prefixPath
created by this session.
- getEphemerals(String, AsyncCallback.EphemeralsCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
Asynchronously gets all the ephemeral nodes matching prefixPath
created by this session.
- getEphemerals(AsyncCallback.EphemeralsCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
-
Asynchronously gets all the ephemeral nodes created by this session.
- GetEphemeralsCommand - Class in org.apache.zookeeper.cli
-
getEphemerals command for CLI
- GetEphemeralsCommand() - Constructor for class org.apache.zookeeper.cli.GetEphemeralsCommand
-
- getEphemeralsCount() - Method in class org.apache.zookeeper.server.DataTree
-
- getEpoch() - Method in class org.apache.zookeeper.server.quorum.Leader
-
Returns the current epoch of the leader.
- getEpochFromZxid(long) - Static method in class org.apache.zookeeper.server.util.ZxidUtils
-
- getEpochToPropose(long, long) - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getEpochToPropose(long, long) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- getErr() - Method in class org.apache.zookeeper.OpResult.ErrorResult
-
- getError() - Method in class org.apache.zookeeper.server.admin.CommandResponse
-
Gets the error string (may be null).
- getEstablished() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
-
- getEstablished() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getException() - Method in class org.apache.zookeeper.server.Request
-
- getExecString() - Method in class org.apache.zookeeper.Shell
-
return an array containing the command name and its parameters
- getExecString() - Method in class org.apache.zookeeper.Shell.ShellCommandExecutor
-
- getExistWatches() - Method in class org.apache.zookeeper.ZooKeeper
-
- getExitCode() - Method in exception org.apache.zookeeper.cli.CliException
-
- getExitCode() - Method in exception org.apache.zookeeper.Shell.ExitCodeException
-
- getExitCode() - Method in class org.apache.zookeeper.Shell
-
get the exit code
- getExpiryMap() - Method in class org.apache.zookeeper.server.ExpiryQueue
-
Returns an unmodifiable view of the expiration time -> elements mapping.
- getFileExtension() - Method in enum org.apache.zookeeper.server.persistence.SnapStream.StreamMode
-
- getFillCount() - Method in class org.apache.zookeeper.server.BlueThrottle
-
- getFillTime() - Method in class org.apache.zookeeper.server.BlueThrottle
-
- getFlushDelay() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getFlushDelay() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getFollower() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
-
- getFormatConversionPolicy(Properties) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Extracts the value of the dbFormatConversion attribute.
- getForwardingFollowers() - Method in class org.apache.zookeeper.server.quorum.Leader
-
Returns a copy of the current forwarding follower snapshot
- getFreezeTime() - Method in class org.apache.zookeeper.server.BlueThrottle
-
- getFsyncThresholdExceedCount() - Method in class org.apache.zookeeper.server.ServerStats
-
- getFsyncThresholdExceedCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getFsyncThresholdExceedCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getFullVersion() - Static method in class org.apache.zookeeper.Version
-
- getGET_PERMISSION_COMMAND() - Static method in class org.apache.zookeeper.Shell
-
Return a Unix command to get permission information.
- getGetChildrenResponseCache() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getGlobalOutstandingLimit() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
-
- getGlobalOutstandingLimit() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
-
- getGlobalOutstandingLimit() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getGroupsCommand() - Static method in class org.apache.zookeeper.Shell
-
a Unix command to get the current user's groups list
- getGroupsForUserCommand(String) - Static method in class org.apache.zookeeper.Shell
-
a Unix command to get a given user's groups list
- getHandshakeDetectionTimeoutMillis() - Method in class org.apache.zookeeper.common.SSLContextAndOptions
-
- getHandshakeState() - Method in class org.apache.zookeeper.server.NettyServerCnxn
-
- getHash() - Method in class org.apache.zookeeper.server.util.AdHash
-
Return the long value of the hash.
- getHdr() - Method in class org.apache.zookeeper.server.Request
-
- getHeader() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
return the current header
- getHeader() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
-
return the transaction header.
- getHeader() - Method in class org.apache.zookeeper.server.TxnLogEntry
-
- getHostAddress() - Method in class org.apache.zookeeper.server.ServerCnxn
-
Returns the IP address or empty string.
- getHostAndPort(String) - Static method in class org.apache.zookeeper.server.util.ConfigUtils
-
Gets host and port by splitting server config
with support for IPv6 literals
- getHostName() - Method in class org.apache.zookeeper.server.auth.KerberosName
-
Get the second component of the name.
- getId() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.MatchValues
-
- getId() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
-
- getId() - Method in class org.apache.zookeeper.server.quorum.Vote
-
- getIdleTimeout() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
-
- getInetAddress() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getInflight() - Method in class org.apache.zookeeper.server.RequestThrottler
-
- getInflight() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getInitialConfig() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getInitialConfig() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getInitialConfig() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getInitLimit() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getInitLimit() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getInitLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
-
- getInitLimit() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
-
- getInitLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Get the number of ticks that the initial synchronization phase can take
- getInitLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getInProcess() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getInputStream(File) - Static method in class org.apache.zookeeper.server.persistence.SnapStream
-
Return the CheckedInputStream based on the extension of the fileName.
- getInputStream() - Method in class org.apache.zookeeper.server.quorum.PrependableSocket
-
- getInputStream() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getInstance(CommandFactory.Command) - Static method in class org.apache.zookeeper.cli.CommandFactory
-
- getInstance() - Static method in class org.apache.zookeeper.jmx.MBeanRegistry
-
- getInt(String, int) - Method in class org.apache.zookeeper.common.ZKConfig
-
Get the value of the key
property as an int
.
- getInterestOps() - Method in class org.apache.zookeeper.server.DumbWatcher
-
- getInterestOps() - Method in class org.apache.zookeeper.server.NettyServerCnxn
-
- getInterestOps() - Method in class org.apache.zookeeper.server.NIOServerCnxn
-
- getInterestOps() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getIntValue() - Method in enum org.apache.zookeeper.Watcher.Event.EventType
-
- getIntValue() - Method in enum org.apache.zookeeper.Watcher.Event.KeeperState
-
- getIntValue() - Method in enum org.apache.zookeeper.Watcher.WatcherType
-
- getIPV6HostAndPort(String) - Static method in class org.apache.zookeeper.common.NetUtils
-
Separates host and port from given host port string if host port string is enclosed
within square bracket.
- getJaasConfKey() - Method in class org.apache.zookeeper.common.ZKConfig
-
Return the value of "java.security.auth.login.config" system property
- getJuteMaxBufferSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getJuteMaxBufferSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getJvmPauseInfoThresholdMs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getJvmPauseInfoThresholdMs() - Method in class org.apache.zookeeper.server.ServerConfig
-
- getJvmPauseSleepTimeMs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getJvmPauseSleepTimeMs() - Method in class org.apache.zookeeper.server.ServerConfig
-
- getJvmPauseWarnThresholdMs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getJvmPauseWarnThresholdMs() - Method in class org.apache.zookeeper.server.ServerConfig
-
- getKeepAlive() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getKeeperState() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
-
- getKey() - Method in class org.apache.zookeeper.Environment.Entry
-
- getKeyManager() - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
-
Get the X509KeyManager implementation used for certificate management.
- getKind() - Method in class org.apache.zookeeper.Op
-
Gets the kind of an Op.
- getLargeRequestBytes() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getLargeRequestMaxBytes() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getLargeRequestMaxBytes() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getLargeRequestMaxBytes() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getLargeRequestSize() - Method in class org.apache.zookeeper.server.Request
-
- getLargeRequestThreshold() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getLargeRequestThreshold() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getLargeRequestThreshold() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getLastBufferSize() - Method in class org.apache.zookeeper.server.quorum.BufferStats
-
Size of the last buffer usage.
- getLastClientResponseSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getLastClientResponseSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getLastCxid() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getLastCxid() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Last cxid of this connection
- getLastCxid() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getLastLatency() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getLastLatency() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Latency of last response to client on this connection in ms
- getLastLatency() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getLastLoggedZxid() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
get the last zxid that was logged in the transaction logs
- getLastLoggedZxid() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
the last logged zxid on the transaction logs
- getLastLoggedZxid() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
the last zxid of the logged transactions.
- getLastLoggedZxid() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
returns the highest zxid that this host has seen
- getLastLogin() - Method in class org.apache.zookeeper.Login
-
Get the time of the last login (ticket initialization or last ticket renewal).
- getLastOperation() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getLastOperation() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Last operation performed by this connection
- getLastOperation() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getLastProcessedZxid() - Method in class org.apache.zookeeper.server.ServerStats
-
- getLastProcessedZxid() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
-
- getLastProcessedZxid() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
return the last processed id from the
datatree
- getLastProcessedZxidDigest() - Method in class org.apache.zookeeper.server.DataTree
-
- getLastProposalSize() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
-
- getLastProposalSize() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
-
- getLastProposed() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getLastProposed() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- getLastQueued() - Method in class org.apache.zookeeper.server.quorum.Follower
-
The zxid of the last operation queued
- getLastQueuedZxid() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
-
- getLastQueuedZxid() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
-
- getLastResponseTime() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getLastResponseTime() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Last time server sent a response to client on this connection
- getLastResponseTime() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getLastSeenQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Return QuorumVerifier object for the last proposed configuration.
- getLastSeenQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getLastSnapshotInfo() - Method in class org.apache.zookeeper.server.persistence.FileSnap
-
get information of the last saved/restored snapshot
- getLastSnapshotInfo() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
get information of the last saved/restored snapshot
- getLastSnapshotInfo() - Method in interface org.apache.zookeeper.server.persistence.SnapShot
-
get information of the last saved/restored snapshot
- getLastZxid() - Method in class org.apache.zookeeper.ClientCnxn
-
- getLastZxid() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getLastZxid() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Last zxid of this connection
- getLastZxid() - Method in class org.apache.zookeeper.server.DataTreeBean
-
- getLastZxid() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
-
- getLastZxid() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
-
- getLastZxid() - Method in class org.apache.zookeeper.server.quorum.StateSummary
-
- getLastZxid() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getLeader() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
-
- getLeaderAddress() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getLeaderId() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getLearner() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
-
- getLearner() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
-
Abstract method to return the learner associated with this server.
- getLearner() - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
-
- getLearnerDiffSyncThrottler() - Method in class org.apache.zookeeper.server.quorum.LearnerMaster
-
diff sync throttler
- getLearnerHandlerInfo() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
-
- getLearnerMaster() - Method in class org.apache.zookeeper.server.ObserverBean
-
- getLearnerMaster() - Method in interface org.apache.zookeeper.server.quorum.ObserverMXBean
-
- getLearnerMasterId() - Method in class org.apache.zookeeper.server.quorum.Observer
-
- getLearners() - Method in class org.apache.zookeeper.server.quorum.Leader
-
Returns a copy of the current learner snapshot
- getLearnerSnapSyncThrottler() - Method in class org.apache.zookeeper.server.quorum.LearnerMaster
-
snap sync throttler
- getLearnerType() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
-
- getLearnerType() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getLearnerType() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getLearnerType() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getLearnerType() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
-
- getLearnerType() - Method in interface org.apache.zookeeper.server.quorum.RemotePeerMXBean
-
- getLocalAddress() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
-
- getLocalAddress() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
-
- getLocalAddress() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
- getLocalAddress() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getLocalAddress() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- getLocalPort() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
-
- getLocalPort() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
- getLocalPort() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getLocalPort() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- getLocalSessionCount() - Method in class org.apache.zookeeper.server.quorum.UpgradeableSessionTracker
-
- getLocalSessionCount() - Method in interface org.apache.zookeeper.server.SessionTracker
-
If this session tracker supports local sessions, return how many.
- getLocalSessionCount() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
-
- getLocalSocketAddress() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getLogDir(Properties) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Extracts transaction log directory property value from the container.
- getLogDirSize() - Method in class org.apache.zookeeper.server.ServerStats
-
- getLogDirSize() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
-
- getLogDirSize() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getLogDirSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getLogDirSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getLogEntries() - Method in class org.apache.zookeeper.audit.AuditEvent
-
Gives all entries to be logged.
- getLogFiles(File[], long) - Static method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
Find the log file that starts at, or just before, the snapshot.
- getLogicalClock() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
-
Returns the current value of the logical clock counter
- getLoginContext() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
-
- getLoginContextName() - Method in class org.apache.zookeeper.Login
-
- getLogLock() - Method in class org.apache.zookeeper.server.ZKDatabase
-
Get the lock that controls the committedLog.
- getLong(String, long) - Method in class org.apache.zookeeper.client.ZKClientConfig
-
Get the value of the key
property as an long
.
- getMax() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
-
- getMaxBatchSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getMaxBatchSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getMaxBufferSize() - Method in class org.apache.zookeeper.server.quorum.BufferStats
-
Size of the largest buffer usage.
- getMaxClientCnxns() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getMaxClientCnxns() - Method in class org.apache.zookeeper.server.ServerConfig
-
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
-
Maximum number of connections allowed from particular host (ip)
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
Maximum number of connections allowed from particular host (ip)
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getMaxClientCnxnsPerHost() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
Current maxClientCnxns allowed from a particular host
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Maximum number of connections allowed from particular host (ip)
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
Maximum number of connections allowed from particular host (ip)
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
Maximum number of connections allowed from particular host (ip)
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getMaxClientCnxnsPerHost() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
-
Gets the maximum client connections per host.
- getMaxClientCnxnsPerHost() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Current maxClientCnxns allowed from a particular host
- getMaxClientResponseSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getMaxClientResponseSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getMaxCnxns() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getMaxCnxns() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getMaxCnxns() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
Maximum number of connections allowed in the ZooKeeper system
- getMaxCnxns(ServerCnxnFactory, ServerCnxnFactory) - Static method in class org.apache.zookeeper.server.ServerCnxnHelper
-
gets maximum number of connections in ZooKeeper
- getMaxCnxns() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getMaxCnxns() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getMaxCommitBatchSize() - Static method in class org.apache.zookeeper.server.quorum.CommitProcessor
-
- getmaxCommittedLog() - Method in class org.apache.zookeeper.server.ZKDatabase
-
the committed log for this zk database
- getMaxConcurrentDiffSyncs() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
-
- getMaxConcurrentDiffSyncs() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
-
- getMaxConcurrentDiffSyncs() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
-
- getMaxConcurrentDiffSyncs() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
-
- getMaxConcurrentDiffSyncs() - Method in class org.apache.zookeeper.server.quorum.LearnerMaster
-
- getMaxConcurrentSnapSyncs() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
-
- getMaxConcurrentSnapSyncs() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
-
- getMaxConcurrentSnapSyncs() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
-
- getMaxConcurrentSnapSyncs() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
-
- getMaxConcurrentSnapSyncs() - Method in class org.apache.zookeeper.server.quorum.LearnerMaster
-
- getMaxFileDescriptorCount() - Method in class org.apache.zookeeper.server.util.OSMXBean
-
Get the number of the maximum file descriptors the system can use.
- getMaxLatency() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getMaxLatency() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Max latency in ms
- getMaxLatency() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getMaxLatency() - Method in class org.apache.zookeeper.server.ServerStats
-
- getMaxPrefixWithQuota(String) - Method in class org.apache.zookeeper.server.DataTree
-
If there is a quota set, return the appropriate prefix for that quota
Else return null
- getMaxProposalSize() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
-
- getMaxProposalSize() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
-
- getMaxReadBatchSize() - Static method in class org.apache.zookeeper.server.quorum.CommitProcessor
-
- getMaxRequestLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getMaxRequestLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getMaxRequests() - Static method in class org.apache.zookeeper.server.RequestThrottler
-
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getMaxSessionTimeout() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
maximum session timeout in milliseconds
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.ServerConfig
-
maximum session timeout in milliseconds, -1 if unset
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getMaxSessionTimeout() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
-
Gets the maximum session timeout.
- getMaxSessionTimeout() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Current maxSessionTimeout of the server in milliseconds
- getMaxTokens() - Method in class org.apache.zookeeper.server.BlueThrottle
-
- getMaxWriteQueuePollTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getMaxWriteQueuePollTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getMessage() - Method in exception org.apache.zookeeper.KeeperException
-
- getMetrics() - Static method in class org.apache.zookeeper.server.ServerMetrics
-
Access current ServerMetrics.
- getMetricsProvider() - Method in class org.apache.zookeeper.server.ServerMetrics
-
- getMetricsProviderClassName() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getMetricsProviderClassName() - Method in class org.apache.zookeeper.server.ServerConfig
-
- getMetricsProviderConfiguration() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getMetricsProviderConfiguration() - Method in class org.apache.zookeeper.server.ServerConfig
-
- getMin() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
-
- getMinBufferSize() - Method in class org.apache.zookeeper.server.quorum.BufferStats
-
Size of the smallest buffer usage.
- getMinClientResponseSize() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getMinClientResponseSize() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getminCommittedLog() - Method in class org.apache.zookeeper.server.ZKDatabase
-
the minimum committed transaction log
available in memory
- getMinIntervalMs() - Method in class org.apache.zookeeper.server.ContainerManager
-
- getMinLatency() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getMinLatency() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
Min latency in ms
- getMinLatency() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getMinLatency() - Method in class org.apache.zookeeper.server.ServerStats
-
- getMinProposalSize() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
-
- getMinProposalSize() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
-
- getMinRequestLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getMinRequestLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getMinSessionTimeout() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
minimum session timeout in milliseconds
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.ServerConfig
-
minimum session timeout in milliseconds, -1 if unset
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getMinSessionTimeout() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
-
Gets the minimum session timeout.
- getMinSessionTimeout() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Current minSessionTimeout of the server in milliseconds
- getMode() - Method in enum org.apache.zookeeper.AddWatchMode
-
- getMultiAddressReachabilityCheckTimeoutMs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getMultiAddressReachabilityCheckTimeoutMs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getMyId() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
get the id of this quorum peer.
- getName() - Method in interface org.apache.zookeeper.jmx.ZKMBeanInfo
-
- getName() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getName() - Method in class org.apache.zookeeper.server.DataTreeBean
-
- getName() - Method in class org.apache.zookeeper.server.ObserverBean
-
- getName() - Method in enum org.apache.zookeeper.server.persistence.SnapStream.StreamMode
-
- getName() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
-
- getName() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
-
- getName() - Method in class org.apache.zookeeper.server.quorum.LeaderElectionBean
-
- getName() - Method in class org.apache.zookeeper.server.quorum.LearnerHandlerBean
-
- getName() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getName() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
-
- getName() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
-
- getName() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyBean
-
- getName() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
-
- getName() - Method in interface org.apache.zookeeper.server.quorum.RemotePeerMXBean
-
- getName() - Method in interface org.apache.zookeeper.server.quorum.ServerMXBean
-
- getName() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getNames() - Method in interface org.apache.zookeeper.server.admin.Command
-
The set of all names that can be used to refer to this command (e.g.,
"configuration", "config", and "conf").
- getNames() - Method in class org.apache.zookeeper.server.admin.CommandBase
-
- getNeedOracle() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
-
- getNeedOracle() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
-
- getNextDynamicConfigFilename() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getNode(String) - Method in class org.apache.zookeeper.server.DataTree
-
- getNode(String) - Method in class org.apache.zookeeper.server.ZKDatabase
-
get the datanode for this path
- getNodeCount() - Method in class org.apache.zookeeper.server.DataTree
-
- getNodeCount() - Method in class org.apache.zookeeper.server.DataTreeBean
-
- getNodeCount() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
-
- getNodeCount() - Method in class org.apache.zookeeper.server.ZKDatabase
-
the node count of the datatree
- getNonMTLSLocalConnCount() - Method in class org.apache.zookeeper.server.ServerStats
-
- getNonMTLSLocalConnCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getNonMTLSLocalConnCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getNonMTLSRemoteConnCount() - Method in class org.apache.zookeeper.server.ServerStats
-
- getNonMTLSRemoteConnCount() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getNonMTLSRemoteConnCount() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getNonVotingFollowers() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getNumAliveClientConnections() - Method in class org.apache.zookeeper.server.ServerStats
-
The number of client connections alive to this server
- getNumAliveConnections() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- getNumAliveConnections() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
-
- getNumAliveConnections() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
return the total number of client connections that are alive
to this server
- getNumAliveConnections() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getNumAliveConnections() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getNumConnections() - Method in class org.apache.zookeeper.server.watch.WatchesSummary
-
Gets the number of connections (sessions) that have set watches.
- getNumGcInfoThresholdExceeded() - Method in class org.apache.zookeeper.server.util.JvmPauseMonitor
-
- getNumGcWarnThresholdExceeded() - Method in class org.apache.zookeeper.server.util.JvmPauseMonitor
-
- getNumPaths() - Method in class org.apache.zookeeper.server.watch.WatchesSummary
-
Gets the number of paths that have watches set on them.
- getNumPendingSyncs() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getObserver() - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
-
- getObserverElectionDelayMs() - Static method in class org.apache.zookeeper.server.quorum.Observer
-
- getObserverElectionDelayMS() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
-
- getObserverElectionDelayMS() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
-
- getObserverMasterPacketSizeLimit() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
-
- getObserverMasterPacketSizeLimit() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
-
- getObserverMasterPort() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getObserverMasterPort() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getObservingLearners() - Method in class org.apache.zookeeper.server.quorum.Leader
-
Returns a copy of the current observer snapshot
- getObservingLearnersInfo() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getObservingMembers() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
-
- getObservingMembers() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
-
- getObservingMembers() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
-
- getObservingView() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Returns only observers, no followers.
- getOne() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
-
Returns an address from the set.
- getOOBInline() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getOpenFileDescriptorCount() - Method in class org.apache.zookeeper.server.util.OSMXBean
-
Get the number of opened filed descriptor for the runtime jvm.
- getOpKind() - Method in class org.apache.zookeeper.MultiOperationRecord
-
Returns the kind of the operations contained by the record.
- getOptionStr() - Method in class org.apache.zookeeper.cli.CliCommand
-
get the option string
- getOraclePath() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumOracleMaj
-
- getOraclePath() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
-
- getOutput() - Method in class org.apache.zookeeper.Shell.ShellCommandExecutor
-
Get the output of the shell command.
- getOutputStream(File, boolean) - Static method in class org.apache.zookeeper.server.persistence.SnapStream
-
Return the OutputStream based on predefined stream mode.
- getOutputStream() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getOutstandingHandshakeNum() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
-
- getOutstandingHandshakeNum() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getOutstandingRequests() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.DumbWatcher
-
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.ServerStats
-
- getOutstandingRequests() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
-
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
return the outstanding requests
in the queue, which haven't been
processed yet
- getOutstandingRequests() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getOutstandingRequests() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getOwner() - Method in class org.apache.zookeeper.server.Request
-
- getPacketsReceived() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getPacketsReceived() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
- getPacketsReceived() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getPacketsReceived() - Method in class org.apache.zookeeper.server.ServerStats
-
- getPacketsReceived() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getPacketsReceived() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getPacketsSent() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getPacketsSent() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
- getPacketsSent() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getPacketsSent() - Method in class org.apache.zookeeper.server.ServerStats
-
- getPacketsSent() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getPacketsSent() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getPacketType(int) - Static method in class org.apache.zookeeper.server.quorum.Leader
-
Get string representation of a given packet type
- getParameter() - Method in class org.apache.zookeeper.server.controller.ControlCommand
-
- getParentChannel() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
-
- getPasswordFromConfigPropertyOrFile(ZKConfig, String, String) - Method in class org.apache.zookeeper.common.X509Util
-
Returns the password specified by the given property or from the file specified by the given path property.
- getPath() - Method in exception org.apache.zookeeper.KeeperException
-
Read the path for this exception
- getPath() - Method in class org.apache.zookeeper.Op
-
Gets the path for an Op.
- getPath() - Method in class org.apache.zookeeper.OpResult.CreateResult
-
- getPath() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.MatchValues
-
- getPath() - Method in class org.apache.zookeeper.WatchedEvent
-
- getPaths(long) - Method in class org.apache.zookeeper.server.watch.WatchesReport
-
Gets the paths that the given session has set watches on.
- getPeerEpoch() - Method in class org.apache.zookeeper.server.quorum.Vote
-
- getPeerInfo(long) - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getPeerInfo(long) - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- getPeerState() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getPeerType() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getPendingRevalidationCount() - Method in class org.apache.zookeeper.server.ObserverBean
-
- getPendingRevalidationCount() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
-
- getPendingRevalidationCount() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
-
- getPendingRevalidationCount() - Method in interface org.apache.zookeeper.server.quorum.ObserverMXBean
-
- getPendingRevalidationsCount() - Method in class org.apache.zookeeper.server.quorum.Learner
-
- getPerm() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.MatchValues
-
- getPermString(int) - Static method in class org.apache.zookeeper.ZKUtil
-
- getPersistentRecursiveWatches() - Method in class org.apache.zookeeper.ZooKeeper
-
- getPersistentWatches() - Method in class org.apache.zookeeper.ZooKeeper
-
- getPlatformMBeanServer() - Method in class org.apache.zookeeper.jmx.MBeanRegistry
-
Return the underlying MBeanServer that is being
used to register MBean's.
- getPort() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getPreAllocSize() - Static method in class org.apache.zookeeper.server.persistence.FilePadding
-
Getter of preAllocSize has been added for testing
- getPrimaryName() - Method in interface org.apache.zookeeper.server.admin.Command
-
The name that is returned with the command response and that appears in
the list of all commands.
- getPrimaryName() - Method in class org.apache.zookeeper.server.admin.CommandBase
-
- getPrimaryNames() - Static method in class org.apache.zookeeper.server.admin.Commands
-
Returns the primary names of all registered commands.
- getPrintWatches() - Method in class org.apache.zookeeper.ZooKeeperMain
-
- getProcess() - Method in class org.apache.zookeeper.Shell
-
get the current sub-process executing the given command
- getPrompt() - Method in class org.apache.zookeeper.ZooKeeperMain
-
- getProperty(String) - Method in class org.apache.zookeeper.common.ZKConfig
-
Get the property value
- getProperty(String, String) - Method in class org.apache.zookeeper.common.ZKConfig
-
Get the property value, if it is null return default value
- getPropertyBackwardCompatibleWay(String) - Static method in class org.apache.zookeeper.server.util.ConfigUtils
-
Some old configuration properties are not configurable in zookeeper configuration file
zoo.cfg.
- getPropertyValue() - Method in enum org.apache.zookeeper.common.KeyStoreFileType
-
The property string that specifies that a key store or trust store
should use this store file type.
- getProposalsFromTxnLog(long, long) - Method in class org.apache.zookeeper.server.ZKDatabase
-
Get proposals from txnlog.
- getProposalStats() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getProvider(String) - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
-
- getPurgeInterval() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
-
Returns purge interval in hours.
- getPurgeInterval() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getPurgeTaskStatus() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
-
Returns the status of the purge task.
- getQueuedPackets() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
-
For testing, return packet queue
- getQueuedReadableBytes() - Method in class org.apache.zookeeper.server.NettyServerCnxn
-
- getQuorumAddress() - Method in class org.apache.zookeeper.server.ObserverBean
-
- getQuorumAddress() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
-
- getQuorumAddress() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
-
- getQuorumAddress() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getQuorumAddress() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getQuorumAddress() - Method in interface org.apache.zookeeper.server.quorum.ObserverMXBean
-
- getQuorumAddress() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getQuorumAddress() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
-
- getQuorumAddress() - Method in interface org.apache.zookeeper.server.quorum.RemotePeerMXBean
-
- getQuorumAuthServer() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getQuorumAuthServer() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- getQuorumCnxManager() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
get reference to QuorumCnxManager
- getQuorumListenOnAllIPs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getQuorumListenOnAllIPs() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getQuorumPeer() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerMain
-
- getQuorumPeers() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Only used by QuorumStats at the moment
- getQuorumPeers() - Method in class org.apache.zookeeper.server.quorum.QuorumStats
-
- getQuorumPeers() - Method in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
-
- getQuorumSize() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
-
- getQuorumSize() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
-
- getQuorumSize() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getQuorumSystemInfo() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getQuorumSystemInfo() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Return QuorumVerifier object for the last committed configuration.
- getQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.SyncedLearnerTracker.QuorumVerifierAcksetPair
-
- getQuorumVerifierBytes() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getQuorumVerifierBytes() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- getQuorumVerifierVersion() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getQuorumVerifierVersion() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- getQuotaBytesLimit(DataTree) - Static method in class org.apache.zookeeper.server.util.QuotaMetricsUtils
-
Traverse the quota subtree and return per namespace quota bytes limit
`
- getQuotaBytesUsage(DataTree) - Static method in class org.apache.zookeeper.server.util.QuotaMetricsUtils
-
Traverse the quota subtree and return per namespace quota bytes usage
- getQuotaCountLimit(DataTree) - Static method in class org.apache.zookeeper.server.util.QuotaMetricsUtils
-
Traverse the quota subtree and return per namespace quota count limit
- getQuotaCountUsage(DataTree) - Static method in class org.apache.zookeeper.server.util.QuotaMetricsUtils
-
Traverse the quota subtree and return per namespace quota count usage
- getReachableAddress() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
-
Returns a reachable address.
- getReachableOrOne() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
-
Returns a reachable address or an arbitrary one, if none is reachable.
- getReadResponseCache() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getRealm() - Method in class org.apache.zookeeper.server.auth.KerberosName
-
Get the realm of the name.
- getReason() - Method in exception org.apache.zookeeper.server.ServerCnxn.CloseRequestException
-
- getReason() - Method in exception org.apache.zookeeper.server.ServerCnxn.EndOfStreamException
-
- getReceiveBufferSize() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getRecursiveWatchQty() - Method in interface org.apache.zookeeper.server.watch.IWatchManager
-
Return the current number of recursive watchers
- getRecursiveWatchQty() - Method in class org.apache.zookeeper.server.watch.WatchManager
-
- getReferenceCountedAclCache() - Method in class org.apache.zookeeper.server.DataTree
-
- getRegisteredBeans() - Method in class org.apache.zookeeper.jmx.MBeanRegistry
-
- getRemoteAddress() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
-
- getRemoteSocketAddress() - Method in class org.apache.zookeeper.server.DumbWatcher
-
- getRemoteSocketAddress() - Method in class org.apache.zookeeper.server.NettyServerCnxn
-
- getRemoteSocketAddress() - Method in class org.apache.zookeeper.server.NIOServerCnxn
-
- getRemoteSocketAddress() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getRemoteSocketAddress() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getRequestPathMetricsCollector() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getRequestStaleConnectionCheck() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getRequestStaleConnectionCheck() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getRequestStaleLatencyCheck() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getRequestStaleLatencyCheck() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getRequestThrottleDropStale() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getRequestThrottleDropStale() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getRequestThrottleLimit() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getRequestThrottleLimit() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getRequestThrottleStallTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getRequestThrottleStallTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getRequiredTokensForGlobal() - Method in class org.apache.zookeeper.server.BlueThrottle
-
- getRequiredTokensForLocal() - Method in class org.apache.zookeeper.server.BlueThrottle
-
- getRequiredTokensForRenew() - Method in class org.apache.zookeeper.server.BlueThrottle
-
- getResponseCachingEnabled() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getResponseCachingEnabled() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getResult() - Method in class org.apache.zookeeper.audit.AuditEvent
-
- getResultList() - Method in class org.apache.zookeeper.MultiResponse
-
- getResults() - Method in exception org.apache.zookeeper.KeeperException
-
If this exception was thrown by a multi-request then the (partial) results
and error codes can be retrieved using this getter.
- getReuseAddress() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getRevision() - Static method in class org.apache.zookeeper.Version
-
Deprecated.
- getRevisionHash() - Static method in class org.apache.zookeeper.Version
-
- getRootContext() - Method in class org.apache.zookeeper.metrics.impl.DefaultMetricsProvider
-
- getRootContext() - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider
-
- getRootContext() - Method in interface org.apache.zookeeper.metrics.MetricsProvider
-
Provides access to the root context.
- getSaslClient() - Method in class org.apache.zookeeper.ZooKeeper
-
- getSaslState() - Method in class org.apache.zookeeper.client.ZooKeeperSaslClient
-
- getScheme() - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
-
The String used to represent this provider.
- getScheme() - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
-
- getScheme() - Method in class org.apache.zookeeper.server.auth.EnsembleAuthenticationProvider
-
- getScheme() - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
-
- getScheme() - Method in class org.apache.zookeeper.server.auth.KeyAuthenticationProvider
-
- getScheme() - Method in class org.apache.zookeeper.server.auth.SASLAuthenticationProvider
-
- getScheme() - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
-
- getSecureClientAddress() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getSecureClientAddress() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getSecureClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getSecureClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getSecureClientPort() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getSecureClientPortAddress() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getSecureClientPortAddress() - Method in class org.apache.zookeeper.server.ServerConfig
-
- getSecureConnectionString() - Method in interface org.apache.zookeeper.server.embedded.ZooKeeperServerEmbedded
-
- getSecureServerCnxnFactory() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getSendBufferSize() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getServerAddresses() - Method in class org.apache.zookeeper.client.ConnectStringParser
-
- getServerAtCurrentIndex() - Method in class org.apache.zookeeper.client.StaticHostProvider
-
- getServerAtIndex(int) - Method in class org.apache.zookeeper.client.StaticHostProvider
-
- getServerCnxnFactory() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getServerId() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
-
Returns the id of the associated QuorumPeer, which will do for a unique
id of this server.
- getServerId() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
-
Returns the id of the associated QuorumPeer, which will do for a unique
id of this server.
- getServerId() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getServerId() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
-
Returns the id of the associated QuorumPeer, which will do for a unique
id of this server.
- getServerId() - Method in interface org.apache.zookeeper.server.SessionTracker.SessionExpirer
-
- getServerId() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getServerId() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
-
Gets the server ID.
- getServerIdFromSessionId(long) - Static method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
-
- getServerPrincipal(String, String) - Static method in class org.apache.zookeeper.util.SecurityUtils
-
Convert Kerberos principal name pattern to valid Kerberos principal name.
- getServerProvider(String) - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
-
- getServers() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getServerState() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getServerState() - Method in class org.apache.zookeeper.server.quorum.QuorumStats
-
- getServerState() - Method in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
-
- getServerState() - Method in class org.apache.zookeeper.server.ServerStats
-
- getServiceName() - Method in class org.apache.zookeeper.server.auth.KerberosName
-
Get the first component of the name.
- getSessionCount() - Method in class org.apache.zookeeper.server.ZKDatabase
-
- getSessionExpiryMap() - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
-
- getSessionExpiryMap() - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
-
- getSessionExpiryMap() - Method in interface org.apache.zookeeper.server.SessionTracker
-
Returns a mapping of time to session IDs that expire at that time.
- getSessionExpiryMap() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
-
Returns a mapping from time to session IDs of sessions expiring at that time.
- getSessionExpiryMap() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getSessionId() - Method in class org.apache.zookeeper.ClientCnxn
-
- getSessionId() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getSessionId() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
- getSessionId() - Method in class org.apache.zookeeper.server.DumbWatcher
-
- getSessionId() - Method in class org.apache.zookeeper.server.NettyServerCnxn
-
- getSessionId() - Method in class org.apache.zookeeper.server.NIOServerCnxn
-
- getSessionId() - Method in class org.apache.zookeeper.server.ServerCnxn
-
- getSessionId() - Method in interface org.apache.zookeeper.server.SessionTracker.Session
-
- getSessionId() - Method in class org.apache.zookeeper.server.SessionTrackerImpl.SessionImpl
-
- getSessionId() - Method in class org.apache.zookeeper.ZooKeeper
-
The session id for this ZooKeeper client instance.
- getSessionIdHex() - Method in class org.apache.zookeeper.server.ServerCnxn
-
Get session id in hexadecimal notation.
- getSessionPasswd() - Method in class org.apache.zookeeper.ClientCnxn
-
- getSessionPasswd() - Method in class org.apache.zookeeper.ZooKeeper
-
The session password for this ZooKeeper client instance.
- getSessions() - Method in class org.apache.zookeeper.server.DataTree
-
- getSessions(String) - Method in class org.apache.zookeeper.server.watch.WatchesPathReport
-
Gets the session IDs of sessions that have set watches on the given path.
- getSessions() - Method in class org.apache.zookeeper.server.ZKDatabase
-
return the sessions in the datatree
- getSessionTimeout() - Method in class org.apache.zookeeper.ClientCnxn
-
- getSessionTimeout() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getSessionTimeout() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
- getSessionTimeout() - Method in class org.apache.zookeeper.server.NettyServerCnxn
-
- getSessionTimeout() - Method in class org.apache.zookeeper.server.NIOServerCnxn
-
- getSessionTimeout(long) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
-
- getSessionTimeout() - Method in class org.apache.zookeeper.ZooKeeper
-
The negotiated session timeout for this ZooKeeper client instance.
- getSessionTracker() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getSessionWithTimeOuts() - Method in class org.apache.zookeeper.server.ZKDatabase
-
get sessions with timeouts
- getSetAcls() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.MatchValues
-
- getShortName() - Method in class org.apache.zookeeper.server.auth.KerberosName
-
Get the translation of the principal name into an operating system
user name.
- getSnapCount() - Static method in class org.apache.zookeeper.server.SyncRequestProcessor
-
used by tests to get the snapcount
- getSnapCount() - Static method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getSnapDir() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
-
Returns the snapshot directory.
- getSnapDir() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
get the snap dir used by this
filetxn snap log
- getSnapDir(Properties) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Extracts snapshot directory property value from the container.
- getSnapRetainCount() - Method in class org.apache.zookeeper.server.DatadirCleanupManager
-
Returns the number of snapshots to be retained after purge.
- getSnapRetainCount() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getSnapshotLogs(long) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
get the snapshot logs which may contain transactions newer than the given zxid.
- getSnapSizeInBytes() - Static method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getSocket() - Method in class org.apache.zookeeper.server.quorum.Learner
-
Socket getter
- getSocket() - Method in class org.apache.zookeeper.server.quorum.LearnerHandler
-
- getSocketAddress() - Method in class org.apache.zookeeper.server.NIOServerCnxn
-
- getSocketListenBacklog() - Method in class org.apache.zookeeper.server.NettyServerCnxnFactory
-
The maximum queue length of the ZooKeeper server's socket
- getSocketListenBacklog() - Method in class org.apache.zookeeper.server.NIOServerCnxnFactory
-
The maximum queue length of the ZooKeeper server's socket
- getSocketListenBacklog() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
The maximum queue length of the ZooKeeper server's socket
- getSoLinger() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getSoTimeout() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getSourceIP() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getSourceIP() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
- getSslAuthProviderProperty() - Method in class org.apache.zookeeper.common.ClientX509Util
-
- getSslCipherSuitesProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslClientAuthProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSSLContext() - Method in class org.apache.zookeeper.common.SSLContextAndOptions
-
- getSslContextSupplierClassProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslCrlEnabledProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslEnabledProtocolsProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslHandshakeDetectionTimeoutMillisProperty() - Method in class org.apache.zookeeper.common.X509Util
-
Returns the config property key that controls the amount of time, in milliseconds, that the first
UnifiedServerSocket read operation will block for when trying to detect the client mode (TLS or PLAINTEXT).
- getSslHandshakeTimeoutMillis() - Method in class org.apache.zookeeper.common.X509Util
-
Returns the max amount of time, in milliseconds, that the first UnifiedServerSocket read() operation should
block for when trying to detect the client mode (TLS or PLAINTEXT).
- getSslHostnameVerificationEnabledProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslKeystoreLocationProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslKeystorePasswdPathProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslKeystorePasswdProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslKeystoreTypeProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslOcspEnabledProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslProtocolProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslSocket() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
Returns the underlying SSLSocket if the mode is TLS.
- getSslTruststoreLocationProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslTruststorePasswdPathProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslTruststorePasswdProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getSslTruststoreTypeProperty() - Method in class org.apache.zookeeper.common.X509Util
-
- getStaleConnectionCheck() - Static method in class org.apache.zookeeper.server.Request
-
- getStaleLatencyCheck() - Static method in class org.apache.zookeeper.server.Request
-
- getStallTime() - Static method in class org.apache.zookeeper.server.RequestThrottler
-
- getStartedTime() - Method in class org.apache.zookeeper.server.ConnectionBean
-
- getStartedTime() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
-
- getStartTime() - Method in class org.apache.zookeeper.server.quorum.LeaderElectionBean
-
- getStartTime() - Method in interface org.apache.zookeeper.server.quorum.LeaderElectionMXBean
-
- getStartTime() - Method in class org.apache.zookeeper.server.quorum.ServerBean
-
- getStartTime() - Method in interface org.apache.zookeeper.server.quorum.ServerMXBean
-
- getStartTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getStartTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getStat() - Method in class org.apache.zookeeper.OpResult.CreateResult
-
- getStat() - Method in class org.apache.zookeeper.OpResult.GetDataResult
-
- getStat() - Method in class org.apache.zookeeper.OpResult.SetDataResult
-
- getState() - Method in class org.apache.zookeeper.common.FileChangeWatcher
-
- getState() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
-
- getState() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
-
- getState() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getState() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getState() - Method in class org.apache.zookeeper.server.quorum.ObserverZooKeeperServer
-
- getState() - Method in class org.apache.zookeeper.server.quorum.ReadOnlyZooKeeperServer
-
- getState() - Method in class org.apache.zookeeper.server.quorum.Vote
-
- getState() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
-
- getState() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getState() - Method in class org.apache.zookeeper.WatchedEvent
-
- getState() - Method in class org.apache.zookeeper.ZooKeeper
-
- getStatsBytes() - Method in class org.apache.zookeeper.StatsTrack
-
- getStorageSize() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
Return total storage size of txnlog that will return by this iterator.
- getStorageSize() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
-
Get an estimated storage space used to store transaction records
that will return by this iterator
- getStreamMode() - Static method in class org.apache.zookeeper.server.persistence.SnapStream
-
- getStreamMode(String) - Static method in class org.apache.zookeeper.server.persistence.SnapStream
-
Detect the stream mode from file name extension
- getSubject() - Method in class org.apache.zookeeper.Login
-
- getSummary(String, MetricsContext.DetailLevel) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
-
- getSummary(String, MetricsContext.DetailLevel) - Method in interface org.apache.zookeeper.metrics.MetricsContext
-
Returns a summary.
- getSummarySet(String, MetricsContext.DetailLevel) - Method in class org.apache.zookeeper.metrics.impl.NullMetricsProvider.NullMetricsContext
-
- getSummarySet(String, MetricsContext.DetailLevel) - Method in interface org.apache.zookeeper.metrics.MetricsContext
-
Returns a set of summaries.
- getSynced_observers_metric() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getSyncedObserversInfo() - Method in class org.apache.zookeeper.server.quorum.Follower
-
- getSyncedObserverSize() - Method in class org.apache.zookeeper.server.quorum.Follower
-
- getSyncEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Return syncEnabled.
- getSyncEnabled() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getSyncInProgress() - Method in class org.apache.zookeeper.server.quorum.LearnerSyncThrottler
-
- getSyncLimit() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getSyncLimit() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getSyncLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
-
- getSyncLimit() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
-
- getSyncLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Get the synclimit
- getSyncLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getSyncMode() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getTcpNoDelay() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getTestable() - Method in class org.apache.zookeeper.ZooKeeper
-
- getTextTraceLevel() - Static method in class org.apache.zookeeper.server.ZooTrace
-
- getThreadCount() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
-
Return number of worker threads
- getThrottledOpWaitTime() - Static method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getThrottledOpWaitTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getThrottledOpWaitTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getTick() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getTick() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getTick() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Get the current tick
- getTickOfInitialAckDeadline() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getTickOfInitialAckDeadline() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- getTickOfNextAckDeadline() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getTickOfNextAckDeadline() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- getTickTime() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
-
- getTickTime() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
-
- getTickTime() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Get the number of milliseconds of each tick
- getTickTime() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getTickTime() - Method in class org.apache.zookeeper.server.ServerConfig
-
- getTickTime() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getTickTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getTickTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerConf
-
Gets the tick time.
- getTickTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Current TickTime of server in milliseconds
- getTimeout() - Method in interface org.apache.zookeeper.server.SessionTracker.Session
-
- getTimeout() - Method in class org.apache.zookeeper.server.SessionTrackerImpl.SessionImpl
-
- getTopNamespace(String) - Static method in class org.apache.zookeeper.common.PathUtils
-
return the top namespace of a znode path
- getTotal() - Method in class org.apache.zookeeper.server.metric.AvgMinMaxCounter
-
- getTotalGcExtraSleepTime() - Method in class org.apache.zookeeper.server.util.JvmPauseMonitor
-
- getTotalLogSize() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
- getTotalLogSize() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
- getTotalLogSize() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
Gets the total size of all log files
- getTotalWatches() - Method in class org.apache.zookeeper.server.watch.WatchesSummary
-
Gets the total number of watches set.
- getTouchSnapshot() - Method in class org.apache.zookeeper.server.quorum.LearnerZooKeeperServer
-
Returns the current state of the session tracker.
- getTraceMask(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
-
- getTraceMaskCmd - Static variable in class org.apache.zookeeper.server.command.FourLetterCommands
-
- GetTraceMaskCommand() - Constructor for class org.apache.zookeeper.server.admin.Commands.GetTraceMaskCommand
-
- getTrafficClass() - Method in class org.apache.zookeeper.server.quorum.UnifiedServerSocket.UnifiedSocket
-
- getTransport() - Method in class org.apache.zookeeper.server.admin.ReadAheadEndpoint
-
- getTreeDigest() - Method in class org.apache.zookeeper.server.DataTree
-
- getTrustManager() - Method in class org.apache.zookeeper.server.auth.X509AuthenticationProvider
-
Get the X509TrustManager implementation used for remote host
authentication.
- getTtls() - Method in class org.apache.zookeeper.server.DataTree
-
- getTxn() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
-
return the current transaction
- getTxn() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
-
return the transaction record.
- getTxn() - Method in class org.apache.zookeeper.server.Request
-
- getTxn() - Method in class org.apache.zookeeper.server.TxnLogEntry
-
- getTxnCount() - Method in class org.apache.zookeeper.server.ZKDatabase
-
Get the number of txn since last snapshot
- getTxnDigest() - Method in class org.apache.zookeeper.server.Request
-
- getTxnFactory() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getTxnLogElapsedSyncTime() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
-
- getTxnLogElapsedSyncTime() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
Returns the elapsed sync of time of transaction log in milliseconds.
- getTxnLogElapsedSyncTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getTxnLogElapsedSyncTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
Returns the elapsed sync of time of transaction log in milliseconds.
- getTxnLogFactory() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getTxnLogSyncElapsedTime() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
-
- getTxnLogSyncElapsedTime() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
-
- getTxnSize() - Method in class org.apache.zookeeper.server.ZKDatabase
-
Get the size of txn since last snapshot
- getType() - Method in class org.apache.zookeeper.Op
-
Gets the integer type code for an Op.
- getType() - Method in class org.apache.zookeeper.OpResult
-
Encodes the return type as from ZooDefs.OpCode.
- getType() - Method in class org.apache.zookeeper.WatchedEvent
-
- getUlimitMemoryCommand(int) - Static method in class org.apache.zookeeper.Shell
-
Get the Unix command for setting the maximum virtual memory available
to a given child process.
- getUnix() - Method in class org.apache.zookeeper.server.util.OSMXBean
-
Check if the OS is unix.
- getUptime() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getUptime() - Method in class org.apache.zookeeper.server.ServerStats
-
- getUsageStr() - Method in class org.apache.zookeeper.cli.CliCommand
-
get a usage string, contains the command and the options
- getUser(Id) - Static method in class org.apache.zookeeper.server.util.AuthUtil
-
Gives user name
- getUserName() - Method in class org.apache.zookeeper.Login
-
- getUserName(String) - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
-
id represents the authentication info which is set in server connection.
- getUserName(String) - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
-
- getUserName() - Static method in class org.apache.zookeeper.server.ServerCnxnFactory
-
User who has started the ZooKeeper server user, it will be the logged-in
user.
- getUsers(List<Id>) - Static method in class org.apache.zookeeper.server.util.AuthUtil
-
Returns a formatted, comma-separated list of the user IDs held
in authInfo
, or null
if no user IDs were found.
- getUsersForAudit() - Method in class org.apache.zookeeper.server.Request
-
Returns a formatted, comma-separated list of the user IDs
associated with this Request
, or null
if no
user IDs were found.
- getValue(AuditEvent.FieldName) - Method in class org.apache.zookeeper.audit.AuditEvent
-
- getValue() - Method in class org.apache.zookeeper.Environment.Entry
-
- getValue(long) - Method in enum org.apache.zookeeper.server.EphemeralType
-
For types that support it, return the extended value from an extended ephemeral owner
- getValue() - Method in enum org.apache.zookeeper.server.ExitCode
-
- getVersion() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
-
- getVersion() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
-
- getVersion() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
-
- getVersion() - Method in class org.apache.zookeeper.server.quorum.Vote
-
- getVersion() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
-
- getVersion() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
-
- getVersion() - Static method in class org.apache.zookeeper.Version
-
- getVersionFromFilename(String) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
-
- getVersionRevision() - Static method in class org.apache.zookeeper.Version
-
- getView() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
A 'view' is a node's current opinion of the membership of the entire
ensemble.
- getVote() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
-
- getVoteTracker(Map<Long, Vote>, Vote) - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
-
Given a set of votes, return the SyncedLearnerTracker which is used to
determines if have sufficient to declare the end of the election round.
- getVotingMembers() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
-
- getVotingMembers() - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
-
- getVotingMembers() - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
-
- getVotingView() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
Observers are not contained in this view, only nodes with
PeerType=PARTICIPANT.
- getWaitTime() - Method in class org.apache.zookeeper.server.ExpiryQueue
-
- getWatchCount() - Method in class org.apache.zookeeper.server.DataTree
-
- getWatchCount() - Method in class org.apache.zookeeper.server.DataTreeBean
-
- getWatchCount() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
-
- getWatcher2PathesMap() - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
-
May cause OOM if there are lots of watches, might better to forbid
it in this class.
- getWatches() - Method in class org.apache.zookeeper.server.DataTree
-
Returns a watch report.
- getWatches() - Method in interface org.apache.zookeeper.server.watch.IWatchManager
-
Returns a watch report.
- getWatches() - Method in class org.apache.zookeeper.server.watch.WatchManager
-
- getWatches() - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
-
- getWatches(int) - Method in class org.apache.zookeeper.ZooKeeper.WatchRegistration
-
- getWatchesByPath() - Method in class org.apache.zookeeper.server.DataTree
-
Returns a watch report by path.
- getWatchesByPath() - Method in interface org.apache.zookeeper.server.watch.IWatchManager
-
Returns a watch report by path.
- getWatchesByPath() - Method in class org.apache.zookeeper.server.watch.WatchManager
-
- getWatchesByPath() - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
-
Iterate through ConcurrentHashMap is 'safe', it will reflect the state
of the map at the time iteration began, may miss update while iterating,
given this is used in the commands to get a general idea of the watches
state, we don't care about missing some update.
- getWatchesSummary() - Method in class org.apache.zookeeper.server.DataTree
-
Returns a watch summary.
- getWatchesSummary() - Method in interface org.apache.zookeeper.server.watch.IWatchManager
-
Returns a watch summary.
- getWatchesSummary() - Method in class org.apache.zookeeper.server.watch.WatchManager
-
- getWatchesSummary() - Method in class org.apache.zookeeper.server.watch.WatchManagerOptimized
-
- getWeight(long) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
-
Returns the weight of a server.
- getWeight(long) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
-
Returns weight of 1 by default.
- getWeight(long) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
-
- getWildcardAddresses() - Method in class org.apache.zookeeper.server.quorum.MultipleAddresses
-
Returns wildcard addresses for all ports
- getWrapper() - Method in class org.apache.zookeeper.WatchedEvent
-
Convert WatchedEvent to type that can be sent over network
- getXid() - Method in class org.apache.zookeeper.ClientCnxn
-
- getZabState() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getZKDatabase() - Method in class org.apache.zookeeper.server.quorum.Leader
-
- getZKDatabase() - Method in class org.apache.zookeeper.server.quorum.ObserverMaster
-
- getZKDatabase() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
get the zookeeper database for this server
- getZkDb() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
-
- getZks() - Method in class org.apache.zookeeper.server.auth.ServerAuthenticationProvider.ServerObjs
-
- getZkShutdownHandler() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getZKUser() - Static method in class org.apache.zookeeper.audit.ZKAuditProvider
-
User who has started the ZooKeeper server user, it will be the logged-in
user.
- getZooKeeperSaslClient() - Method in class org.apache.zookeeper.ClientCnxn
-
- getZooKeeperServer() - Method in class org.apache.zookeeper.server.ServerCnxnFactory
-
- getZooKeeperServerConfig() - Method in class org.apache.zookeeper.server.controller.ControllerServerConfig
-
- getZooKeeperServerListener() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getZxid() - Method in class org.apache.zookeeper.server.DataTree.ZxidDigest
-
- getZxid() - Method in class org.apache.zookeeper.server.quorum.Follower
-
The zxid of the last operation seen
- getZxid() - Method in class org.apache.zookeeper.server.quorum.Vote
-
- getZxid() - Method in class org.apache.zookeeper.server.ZooKeeperServer
-
- getZxidFromName(String, String) - Static method in class org.apache.zookeeper.server.persistence.Util
-
Extracts zxid from the file name.
- GLOBAL_OUTSTANDING_LIMIT - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
-
- GLOBAL_SESSION_WEIGHT - Static variable in class org.apache.zookeeper.server.BlueThrottle
-
- globalSessions() - Method in class org.apache.zookeeper.server.quorum.LeaderSessionTracker
-
- globalSessions() - Method in class org.apache.zookeeper.server.quorum.LearnerSessionTracker
-
- globalSessions() - Method in interface org.apache.zookeeper.server.SessionTracker
-
Get a set of global session IDs
- globalSessions() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
-