A B C D E F G H I J K L M N O P Q R S T U V W Z

A

ackSet - Variable in class org.apache.zookeeper.server.quorum.Leader.Proposal
 
aclIndex - Variable in class org.apache.zookeeper.server.DataTree
these are the number of acls that we have in the datatree
aclKeyMap - Variable in class org.apache.zookeeper.server.DataTree
this a map from acls to long.
ADD - Static variable in class org.apache.bookkeeper.client.QuorumEngine.Operation
 
addAuthInfo(String, byte[]) - Method in class org.apache.zookeeper.ClientCnxn
 
addAuthInfo(String, byte[]) - Method in class org.apache.zookeeper.ZooKeeper
Add the specified scheme:auth information to this connection.
addCommittedProposal(Request) - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
Do not do anything in the follower.
addCommittedProposal(Request) - Method in class org.apache.zookeeper.server.ZooKeeperServer
maintains a list of last 500 or so committed requests.
addComplete(int, LedgerHandle, long, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.AddCallback
Callback declaration
addComplete(int, LedgerHandle, long, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Implementation of callback interface for synchronous read method.
addDataNode(String, DataNode) - Method in class org.apache.zookeeper.server.DataTree
just an accessor method to allow raw creation of datatree's from a bunch of datanodes
addEntry(ByteBuffer, WriteCallback, Object, byte[]) - Method in class org.apache.bookkeeper.bookie.Bookie
 
addEntry(byte[]) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry synchronously to an open ledger.
addEntry(long, byte[], long, ByteBuffer, WriteCallback, Object) - Method in class org.apache.bookkeeper.proto.BookieClient
Send addEntry operation to bookie.
ADDENTRY - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The Add entry request payload will be a ledger entry exactly as it should be logged.
addEscapes(String) - Static method in error org.apache.jute.compiler.generated.TokenMgrError
Replaces unprintable characters by their escaped (or unicode escaped) equivalents in the given string
addPath(String) - Method in class org.apache.zookeeper.common.PathTrie
add a path to the path trie
addr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
addSession(long, int) - Method in class org.apache.zookeeper.server.quorum.FollowerSessionTracker
 
addSession(long, int) - Method in interface org.apache.zookeeper.server.SessionTracker
 
addSession(long, int) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
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 /
addWatch(String, Watcher) - Method in class org.apache.zookeeper.server.WatchManager
 
adjustBeginLineColumn(int, int) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Method to adjust line and column numbers for the start of a token.
ADMIN - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
 
ALL - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
 
ANYONE_ID_UNSAFE - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
This Id represents anyone.
APIError - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.APIERROR instead
append(TxnHeader, Record) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
append an entry to the transaction log
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
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
 
asyncAddEntry(byte[], AsyncCallback.AddCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Add entry asynchronously to an open ledger.
AsyncCallback - Interface in org.apache.bookkeeper.client
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
AsyncCallback - Interface in org.apache.zookeeper
 
AsyncCallback.ACLCallback - Interface in org.apache.zookeeper
 
AsyncCallback.AddCallback - Interface in org.apache.bookkeeper.client
 
AsyncCallback.ChildrenCallback - Interface in org.apache.zookeeper
 
AsyncCallback.CloseCallback - Interface in org.apache.bookkeeper.client
 
AsyncCallback.CreateCallback - Interface in org.apache.bookkeeper.client
 
AsyncCallback.DataCallback - Interface in org.apache.zookeeper
 
AsyncCallback.OpenCallback - Interface in org.apache.bookkeeper.client
 
AsyncCallback.ReadCallback - Interface in org.apache.bookkeeper.client
 
AsyncCallback.StatCallback - Interface in org.apache.zookeeper
 
AsyncCallback.StringCallback - Interface in org.apache.zookeeper
 
AsyncCallback.VoidCallback - Interface in org.apache.zookeeper
 
asyncClose(AsyncCallback.CloseCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Asynchronous close
asyncCreateLedger(int, int, LedgerHandle.QMode, byte[], AsyncCallback.CreateCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeper
Asychronous call to create ledger
asyncOpenLedger(long, byte[], AsyncCallback.OpenCallback, Object) - Method in class org.apache.bookkeeper.client.BookKeeper
 
asyncReadEntries(long, long, AsyncCallback.ReadCallback, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Read a sequence of entries asynchronously.
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.
AuthenticationProvider - Interface in org.apache.zookeeper.server.auth
This interface is implemented by authentication providers to add new kinds of authentication schemes to ZooKeeper.
AuthFailed - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.AUTHFAILED instead
AuthFastLeaderElection - Class in org.apache.zookeeper.server.quorum
 
AuthFastLeaderElection(QuorumPeer, boolean) - Constructor for class org.apache.zookeeper.server.quorum.AuthFastLeaderElection
 
AuthFastLeaderElection(QuorumPeer) - Constructor for class org.apache.zookeeper.server.quorum.AuthFastLeaderElection
 
AuthFastLeaderElection.Notification - Class in org.apache.zookeeper.server.quorum
 
AuthFastLeaderElection.Notification() - Constructor for class org.apache.zookeeper.server.quorum.AuthFastLeaderElection.Notification
 
AuthFastLeaderElection.ToSend - Class in org.apache.zookeeper.server.quorum
 
authInfo - Variable in class org.apache.zookeeper.server.Request
 
available() - Method in class org.apache.zookeeper.server.ByteBufferInputStream
 

B

backup(int) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Backup a number of characters.
BadArguments - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.BADARGUMENTS instead
BadVersion - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.BADVERSION instead
beginColumn - Variable in class org.apache.jute.compiler.generated.Token
The column number of the first character of this Token.
beginLine - Variable in class org.apache.jute.compiler.generated.Token
The line number of the first character of this Token.
BeginToken() - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Start.
BinaryInputArchive - Class in org.apache.jute
 
BinaryInputArchive(DataInput) - Constructor for class org.apache.jute.BinaryInputArchive
Creates a new instance of BinaryInputArchive
BinaryOutputArchive - Class in org.apache.jute
 
BinaryOutputArchive(DataOutput) - Constructor for class org.apache.jute.BinaryOutputArchive
Creates a new instance of BinaryOutputArchive
BKDefs - Interface in org.apache.bookkeeper.client
 
BKException - Exception in org.apache.bookkeeper.client
Implements BookKeeper exceptions.
BKException(int) - Constructor for exception org.apache.bookkeeper.client.BKException
 
BKException.BKBookieException - Exception in org.apache.bookkeeper.client
 
BKException.BKBookieException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKBookieException
 
BKException.BKBookieHandleNotAvailableException - Exception in org.apache.bookkeeper.client
 
BKException.BKBookieHandleNotAvailableException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKBookieHandleNotAvailableException
 
BKException.BKDigestMatchException - Exception in org.apache.bookkeeper.client
 
BKException.BKDigestMatchException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKDigestMatchException
 
BKException.BKDigestNotInitializedException - Exception in org.apache.bookkeeper.client
 
BKException.BKDigestNotInitializedException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKDigestNotInitializedException
 
BKException.BKIllegalOpException - Exception in org.apache.bookkeeper.client
 
BKException.BKIllegalOpException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKIllegalOpException
 
BKException.BKNoSuchLedgerExistsException - Exception in org.apache.bookkeeper.client
 
BKException.BKNoSuchLedgerExistsException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKNoSuchLedgerExistsException
 
BKException.BKNotEnoughBookiesException - Exception in org.apache.bookkeeper.client
 
BKException.BKNotEnoughBookiesException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKNotEnoughBookiesException
 
BKException.BKQuorumException - Exception in org.apache.bookkeeper.client
 
BKException.BKQuorumException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKQuorumException
 
BKException.BKReadException - Exception in org.apache.bookkeeper.client
 
BKException.BKReadException() - Constructor for exception org.apache.bookkeeper.client.BKException.BKReadException
 
BKException.Code - Interface in org.apache.bookkeeper.client
 
Bookie - Class in org.apache.bookkeeper.bookie
Implements a bookie.
Bookie(File, File[]) - Constructor for class org.apache.bookkeeper.bookie.Bookie
 
Bookie.NoEntryException - Exception in org.apache.bookkeeper.bookie
 
Bookie.NoEntryException(long, long) - Constructor for exception org.apache.bookkeeper.bookie.Bookie.NoEntryException
 
Bookie.NoLedgerException - Exception in org.apache.bookkeeper.bookie
 
Bookie.NoLedgerException(long) - Constructor for exception org.apache.bookkeeper.bookie.Bookie.NoLedgerException
 
BookieClient - Class in org.apache.bookkeeper.proto
Implements the client-side part of the BookKeeper protocol.
BookieClient(InetSocketAddress, int) - Constructor for class org.apache.bookkeeper.proto.BookieClient
 
BookieClient(String, int, int) - Constructor for class org.apache.bookkeeper.proto.BookieClient
 
BookieException - Exception in org.apache.bookkeeper.bookie
 
BookieException(int) - Constructor for exception org.apache.bookkeeper.bookie.BookieException
 
BookieException.BookieIllegalOpException - Exception in org.apache.bookkeeper.bookie
 
BookieException.BookieIllegalOpException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.BookieIllegalOpException
 
BookieException.BookieUnauthorizedAccessException - Exception in org.apache.bookkeeper.bookie
 
BookieException.BookieUnauthorizedAccessException() - Constructor for exception org.apache.bookkeeper.bookie.BookieException.BookieUnauthorizedAccessException
 
BookieException.Code - Interface in org.apache.bookkeeper.bookie
 
BookieHandle - Class in org.apache.bookkeeper.client
Maintains a queue of request to a given bookie.
BookieHandleNotAvailableException - Static variable in interface org.apache.bookkeeper.client.BKException.Code
 
BookieProtocol - Interface in org.apache.bookkeeper.proto
The packets of the Bookie protocol all have a 4-byte integer indicating the type of request or response at the very beginning of the packet followed by a payload.
BookieServer - Class in org.apache.bookkeeper.proto
Implements the server-side part of the BookKeeper protocol.
BookieServer(int, File, File[]) - Constructor for class org.apache.bookkeeper.proto.BookieServer
 
BookKeeper - Class in org.apache.bookkeeper.client
BookKeeper client.
BookKeeper(String) - Constructor for class org.apache.bookkeeper.client.BookKeeper
 
BOOLEAN_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
bufcolumn - Variable in class org.apache.jute.compiler.generated.SimpleCharStream
 
bufEquals(byte[], byte[]) - Static method in class org.apache.jute.Utils
equals function that actually compares two buffers.
buffer - Variable in class org.apache.jute.compiler.generated.SimpleCharStream
 
BUFFER_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
bufline - Variable in class org.apache.jute.compiler.generated.SimpleCharStream
 
bufpos - Variable in class org.apache.jute.compiler.generated.SimpleCharStream
Position in buffer.
build() - Method in class org.apache.zookeeper.server.ZooKeeperServer.BasicDataTreeBuilder
 
build() - Method in interface org.apache.zookeeper.server.ZooKeeperServer.DataTreeBuilder
 
BYTE_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
byteBuffer2Record(ByteBuffer, Record) - Static method in class org.apache.zookeeper.server.ZooKeeperServer
 
ByteBufferInputStream - Class in org.apache.zookeeper.server
 
ByteBufferInputStream(ByteBuffer) - Constructor for class org.apache.zookeeper.server.ByteBufferInputStream
 

C

checkPasswd(long, byte[]) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
checkSession(long, Object) - Method in class org.apache.zookeeper.server.quorum.FollowerSessionTracker
 
checkSession(long, Object) - Method in interface org.apache.zookeeper.server.SessionTracker
 
checkSession(long, Object) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
cl - Variable in class org.apache.zookeeper.ZooKeeperMain
 
clear() - Method in class org.apache.bookkeeper.proto.NIOServerFactory
clear all the connections in the selector
clear() - Method in class org.apache.zookeeper.server.DataTree
 
clear() - Method in class org.apache.zookeeper.server.NIOServerCnxn.Factory
clear all the connections in the selector
clear() - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
CLIENT_DATA_PACKET_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
CLIENT_PING_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
CLIENT_REQUEST_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
ClientBase - Class in org.apache.bookkeeper.util
Base class for tests.
ClientBase() - Constructor for class org.apache.bookkeeper.util.ClientBase
 
ClientBase(String) - Constructor for class org.apache.bookkeeper.util.ClientBase
 
ClientBase.CountdownWatcher - Class in org.apache.bookkeeper.util
 
ClientBase.CountdownWatcher() - Constructor for class org.apache.bookkeeper.util.ClientBase.CountdownWatcher
 
ClientBase.NullWatcher - Class in org.apache.bookkeeper.util
In general don't use this.
ClientBase.NullWatcher() - Constructor for class org.apache.bookkeeper.util.ClientBase.NullWatcher
 
ClientCnxn - Class in org.apache.zookeeper
This class manages the socket i/o for the client.
ClientCnxn(String, int, ZooKeeper, ClientWatchManager) - Constructor for class org.apache.zookeeper.ClientCnxn
Creates a connection object.
ClientCnxn(String, int, ZooKeeper, ClientWatchManager, long, byte[]) - Constructor for class org.apache.zookeeper.ClientCnxn
Creates a connection object.
clientId - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
 
clientId - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
 
clientPort - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
clientPort - Variable in class org.apache.zookeeper.server.ServerConfig
 
ClientWatchManager - Interface in org.apache.zookeeper
 
close - Static variable in interface org.apache.bookkeeper.client.BKDefs
 
close() - Method in class org.apache.bookkeeper.client.LedgerHandle
Close ledger.
close() - Method in class org.apache.bookkeeper.proto.NIOServerFactory.Cnxn
 
close() - Method in class org.apache.bookkeeper.streaming.LedgerInputStream
 
close() - Method in class org.apache.bookkeeper.streaming.LedgerOutputStream
 
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.server.NIOServerCnxn
 
close() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
close the iterator and release the resources.
close() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
close files and release the resources
close() - Method in interface org.apache.zookeeper.server.ServerCnxn
 
close() - Method in class org.apache.zookeeper.ZooKeeper
Close this client object.
closeComplete(int, LedgerHandle, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.CloseCallback
Callback definition
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
 
cnxn - Variable in class org.apache.zookeeper.server.Request
 
cnxn - Variable in class org.apache.zookeeper.ZooKeeper
 
code() - Method in exception org.apache.zookeeper.KeeperException
Read the error Code for this exception
column - Variable in class org.apache.jute.compiler.generated.SimpleCharStream
 
COMMA_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
commandCount - Variable in class org.apache.zookeeper.ZooKeeperMain
 
commandMap - Static variable in class org.apache.zookeeper.ZooKeeperMain
 
commit() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
commit the logs.
commit() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
commit the transaction of logs
commit() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
commmit the trasaction and make sure they are persisted
commit(Request) - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
 
commit(long) - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
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
commitLogBuffer - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
commitLogCount - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
CommitProcessor - Class in org.apache.zookeeper.server.quorum
This RequestProcessor matches the incoming committed requests with the locally submitted requests.
CommitProcessor(RequestProcessor, String, boolean) - Constructor for class org.apache.zookeeper.server.quorum.CommitProcessor
 
committedLog - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
CommonNames - Class in org.apache.zookeeper.jmx
A bunch of constants.
CommonNames() - Constructor for class org.apache.zookeeper.jmx.CommonNames
 
compareBytes(byte[], int, int, byte[], int, int) - Static method in class org.apache.jute.Utils
 
connectAll() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
Try to establish a connection with each server if one doesn't exist.
CONNECTION_TIMEOUT - Static variable in class org.apache.bookkeeper.util.ClientBase
 
ConnectionBean - Class in org.apache.zookeeper.server
Implementation of connection MBean interface.
ConnectionBean(ServerCnxn, ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.ConnectionBean
 
ConnectionLoss - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.CONNECTIONLOSS instead
ConnectionMXBean - Interface in org.apache.zookeeper.server
This MBean represents a client connection.
connectToZK(String) - Method in class org.apache.zookeeper.ZooKeeperMain
 
containsQuorum(HashSet<Long>) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
Verifies if a given set is a quorum.
containsQuorum(HashSet<Long>) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
Verifies if a set is a majority.
containsQuorum(HashSet<Long>) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
convertAcls(List<ACL>) - Method in class org.apache.zookeeper.server.DataTree
converts the list of acls to a list of longs.
convertLong(Long) - Method in class org.apache.zookeeper.server.DataTree
converts a list of longs to a list of acls.
copyStat(Stat) - Method in class org.apache.zookeeper.server.DataNode
 
copyStat(Stat, Stat) - Static method in class org.apache.zookeeper.server.DataTree
 
copyStat(Stat) - Method in class org.apache.zookeeper.server.upgrade.DataNodeV1
 
copyStat(Stat, Stat) - Static method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
copyStatPersisted(StatPersisted, StatPersisted) - Static method in class org.apache.zookeeper.server.DataTree
 
copyStatPersisted(StatPersistedV1, StatPersistedV1) - Static method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
count - Variable in class org.apache.zookeeper.server.quorum.LeaderElection.ElectionResult
 
countEphemerals() - Method in class org.apache.zookeeper.server.DataTreeBean
 
countEphemerals() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
 
create(int) - Static method in exception org.apache.bookkeeper.bookie.BookieException
 
create(int) - Static method in exception org.apache.bookkeeper.client.BKException
 
create(KeeperException.Code, String) - Static method in exception org.apache.zookeeper.KeeperException
All non-specific keeper exceptions should be constructed via this factory method in order to guarantee consistency in error codes and such.
create(int, String) - Static method in exception org.apache.zookeeper.KeeperException
Deprecated. deprecated in 3.1.0, use KeeperException.create(Code, String) instead
create(int) - Static method in exception org.apache.zookeeper.KeeperException
Deprecated. deprecated in 3.1.0, use KeeperException.create(Code) instead
create(KeeperException.Code) - Static method in exception org.apache.zookeeper.KeeperException
All non-specific keeper exceptions should be constructed via this factory method in order to guarantee consistency in error codes and such.
create(NIOServerCnxn.Factory) - Method in interface org.apache.zookeeper.server.quorum.QuorumPeer.Factory
 
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, AsyncCallback.StringCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The Asynchronous version of create.
createClient() - Method in class org.apache.bookkeeper.util.ClientBase
 
createClient(String) - Method in class org.apache.bookkeeper.util.ClientBase
 
createClient(ClientBase.CountdownWatcher, String) - Method in class org.apache.bookkeeper.util.ClientBase
 
createComplete(int, LedgerHandle, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.CreateCallback
Declaration of callback method
createConnection(SocketChannel, SelectionKey) - Method in class org.apache.zookeeper.server.NIOServerCnxn.Factory
 
createConnectionFactory() - Method in interface org.apache.zookeeper.server.quorum.QuorumPeer.Factory
 
createConnectionFactory() - Method in interface org.apache.zookeeper.server.ZooKeeperServer.Factory
 
createInputArchive(File) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
Invoked to indicate that the input stream has been created.
createLedger(int, int, LedgerHandle.QMode, byte[]) - Method in class org.apache.bookkeeper.client.BookKeeper
Creates a new ledger.
createLedger(byte[]) - Method in class org.apache.bookkeeper.client.BookKeeper
Creates a new ledger.
CreateMode - Enum in org.apache.zookeeper
CreateMode value determines how the znode is created on ZooKeeper.
createNode(String, byte[], List<ACL>, long, long, long) - Method in class org.apache.zookeeper.server.DataTree
 
createNode(String, byte[], List<ACL>, long, long, long) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
createQuota(ZooKeeper, String, long, int) - Static method in class org.apache.zookeeper.ZooKeeperMain
this method creates a quota node for the path
createServer() - Method in interface org.apache.zookeeper.server.ZooKeeperServer.Factory
 
createSession(int) - Method in class org.apache.zookeeper.server.quorum.FollowerSessionTracker
 
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.FollowerZooKeeperServer
 
createSessionTracker() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
createSessionTracker() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
createTime - Variable in class org.apache.zookeeper.server.Request
 
createTmpDir() - Static method in class org.apache.bookkeeper.util.ClientBase
 
CREATOR_ALL_ACL - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
This ACL gives the creators authentication id's all permissions.
CSTRING_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
CsvOutputArchive - Class in org.apache.jute
 
CsvOutputArchive(OutputStream) - Constructor for class org.apache.jute.CsvOutputArchive
Creates a new instance of CsvOutputArchive
curChar - Variable in class org.apache.jute.compiler.generated.RccTokenManager
 
currentToken - Variable in exception org.apache.jute.compiler.generated.ParseException
This is the last token that has been consumed successfully.
cxid - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
 
cxid - Variable in class org.apache.zookeeper.server.Request
 
cxid - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
 

D

DATA_TREE_KEY - Static variable in class org.apache.zookeeper.jmx.CommonNames
 
dataDir - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
dataDir - Variable in class org.apache.zookeeper.server.ServerConfig
 
DataInconsistency - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.DATAINCONSISTENCY instead
dataLogDir - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
dataLogDir - Variable in class org.apache.zookeeper.server.ServerConfig
 
DataNode - Class in org.apache.zookeeper.server
This class contains the data for a node in the data tree.
DataNode(DataNode, byte[], Long, StatPersisted) - Constructor for class org.apache.zookeeper.server.DataNode
create a DataNode with parent, data, acls and stat
DataNodeV1 - Class in org.apache.zookeeper.server.upgrade
This class contains the data for a node in the data tree.
DataTree - Class in org.apache.zookeeper.server
This class maintains the tree data structure.
DataTree() - Constructor for class org.apache.zookeeper.server.DataTree
 
dataTree - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
DataTree.ProcessTxnResult - Class in org.apache.zookeeper.server
 
DataTree.ProcessTxnResult() - Constructor for class org.apache.zookeeper.server.DataTree.ProcessTxnResult
 
DataTreeBean - Class in org.apache.zookeeper.server
This class implements the data tree MBean.
DataTreeBean(DataTree) - Constructor for class org.apache.zookeeper.server.DataTreeBean
 
DataTreeMXBean - Interface in org.apache.zookeeper.server
Zookeeper data tree MBean.
DataTreeV1 - Class in org.apache.zookeeper.server.upgrade
This class maintains the tree data structure.
DataTreeV1() - Constructor for class org.apache.zookeeper.server.upgrade.DataTreeV1
 
DataTreeV1.ProcessTxnResult - Class in org.apache.zookeeper.server.upgrade
 
DataTreeV1.ProcessTxnResult() - Constructor for class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
 
debugStream - Variable in class org.apache.jute.compiler.generated.RccTokenManager
Debug output.
decInProcess() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
decRef() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
DEFAULT - Static variable in interface org.apache.jute.compiler.generated.RccConstants
Lexical state.
DEFAULT_TICK_TIME - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
delete - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
DELETE - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
 
delete(String, int) - Method in class org.apache.zookeeper.ZooKeeper
Delete the node with the given path.
delete(String, int, AsyncCallback.VoidCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The Asynchronous version of delete.
deleteNode(String, long) - Method in class org.apache.zookeeper.server.DataTree
remove the path from the datatree
deleteNode(String) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
deletePath(String) - Method in class org.apache.zookeeper.common.PathTrie
delete a path from the trie
delQuota(ZooKeeper, String, boolean, boolean) - Static method in class org.apache.zookeeper.ZooKeeperMain
this method deletes quota for a node.
deserialize(InputArchive, String) - Method in interface org.apache.jute.Record
 
deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.DataNode
 
deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.DataTree
 
deserialize(DataTree, Map<Long, Integer>) - Method in class org.apache.zookeeper.server.persistence.FileSnap
deserialize a data tree from the most recent snapshot
deserialize(DataTree, Map<Long, Integer>, InputArchive) - Method in class org.apache.zookeeper.server.persistence.FileSnap
deserialize the datatree from an inputarchive
deserialize(DataTree, Map<Long, Integer>) - Method in interface org.apache.zookeeper.server.persistence.SnapShot
deserialize a data tree from the last valid snapshot and return the last zxid that was deserialized
deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.upgrade.DataNodeV1
 
deserialize(InputArchive, String) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
deserializeSnapshot(DataTree, InputArchive, Map<Long, Integer>) - Static method in class org.apache.zookeeper.server.util.SerializeUtils
 
deserializeSnapshot(InputArchive) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
deserializeTxn(InputArchive, TxnHeader) - Static method in class org.apache.zookeeper.server.util.SerializeUtils
 
DigestAuthenticationProvider - Class in org.apache.zookeeper.server.auth
 
DigestAuthenticationProvider() - Constructor for class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
DigestMatchException - Static variable in interface org.apache.bookkeeper.client.BKException.Code
 
DigestNotInitializedException - Static variable in interface org.apache.bookkeeper.client.BKException.Code
 
disable_tracing() - Method in class org.apache.jute.compiler.generated.Rcc
Disable tracing.
disableRecv() - Method in class org.apache.bookkeeper.proto.NIOServerFactory.Cnxn
 
disableRecv() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
disconnect() - Method in class org.apache.zookeeper.ClientCnxn
Shutdown the send/event threads.
DOMAIN - Static variable in class org.apache.zookeeper.jmx.CommonNames
 
Done() - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Reset buffer when finished.
done() - Method in interface org.apache.jute.Index
 
DOT_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
DOUBLE_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
dump(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
 
dumpCmd - Static variable in interface org.apache.zookeeper.server.ServerCnxn
 
dumpEphemerals() - Method in class org.apache.zookeeper.server.DataTree
 
dumpEphemerals() - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 

E

EBADREQ - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The error code that indicates an invalid request type
EIB - Static variable in interface org.apache.bookkeeper.client.BKDefs
Insufficient bookies
EIO - Static variable in interface org.apache.bookkeeper.client.BKDefs
IO error, typically when trying to connect to a bookie
EIO - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
General error occurred at the server
Election - Interface in org.apache.zookeeper.server.quorum
 
electionAddr - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
electionAlg - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
electionPort - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
enable_tracing() - Method in class org.apache.jute.compiler.generated.Rcc
Enable tracing.
enableRecv() - Method in class org.apache.bookkeeper.proto.NIOServerFactory.Cnxn
 
enableRecv() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
endColumn - Variable in class org.apache.jute.compiler.generated.Token
The column number of the last character of this Token.
endLine - Variable in class org.apache.jute.compiler.generated.Token
The line number of the last character of this Token.
endMap(String) - Method in class org.apache.jute.BinaryInputArchive
 
endMap(TreeMap, String) - Method in class org.apache.jute.BinaryOutputArchive
 
endMap(TreeMap, String) - Method in class org.apache.jute.CsvOutputArchive
 
endMap(String) - Method in interface org.apache.jute.InputArchive
 
endMap(TreeMap, String) - Method in interface org.apache.jute.OutputArchive
 
endRecord(String) - Method in class org.apache.jute.BinaryInputArchive
 
endRecord(Record, String) - Method in class org.apache.jute.BinaryOutputArchive
 
endRecord(Record, String) - Method in class org.apache.jute.CsvOutputArchive
 
endRecord(String) - Method in interface org.apache.jute.InputArchive
 
endRecord(Record, String) - Method in interface org.apache.jute.OutputArchive
 
endVector(String) - Method in class org.apache.jute.BinaryInputArchive
 
endVector(List, String) - Method in class org.apache.jute.BinaryOutputArchive
 
endVector(List, String) - Method in class org.apache.jute.CsvOutputArchive
 
endVector(String) - Method in interface org.apache.jute.InputArchive
 
endVector(List, String) - Method in interface org.apache.jute.OutputArchive
 
ENL - Static variable in interface org.apache.bookkeeper.client.BKDefs
No such a ledger
ENOENTRY - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The error code that indicates that the requested entry does not exist
ENOLEDGER - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The error code that indicates that the ledger does not exist
ENR - Static variable in interface org.apache.bookkeeper.client.BKDefs
Exceeded number of retries
ensemble - Static variable in interface org.apache.bookkeeper.client.BKDefs
 
enviCmd - Static variable in interface org.apache.zookeeper.server.ServerCnxn
 
Environment - Class in org.apache.zookeeper
Provide insight into the runtime environment.
Environment() - Constructor for class org.apache.zookeeper.Environment
 
Environment.Entry - Class in org.apache.zookeeper
 
Environment.Entry(String, String) - Constructor for class org.apache.zookeeper.Environment.Entry
 
EOF - Static variable in interface org.apache.jute.compiler.generated.RccConstants
End of File.
EOK - Static variable in interface org.apache.bookkeeper.client.BKDefs
Status ok
EOK - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The error code that indicates success
eol - Variable in exception org.apache.jute.compiler.generated.ParseException
The end of line string for this machine.
epoch - Variable in class org.apache.zookeeper.server.quorum.Vote
 
equals(Object) - Method in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
Equality is defined as the clientId and the cxid being the same.
equals(Object) - Method in class org.apache.zookeeper.server.quorum.Vote
 
equals(Object) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
Equality is defined as the clientId and the cxid being the same.
ERL - Static variable in interface org.apache.bookkeeper.client.BKDefs
Error while recovering ledger
err - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
 
err - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
 
error - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
errorOut() - Method in class org.apache.bookkeeper.proto.BookieClient
Errors out pending entries.
EUA - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
Unauthorized access to ledger
EVENT_DELIVERY_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
execute() - Method in interface org.apache.zookeeper.server.util.Profiler.Operation
 
executeLine(String) - Method in class org.apache.zookeeper.ZooKeeperMain
 
exists - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
exists(String, Watcher) - Method in class org.apache.zookeeper.ZooKeeper
Return the stat of the node of the given path.
exists(String, boolean) - Method in class org.apache.zookeeper.ZooKeeper
Return the stat of the node of the given path.
exists(String, Watcher, AsyncCallback.StatCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The Asynchronous version of exists.
exists(String, boolean, AsyncCallback.StatCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The Asynchronous version of exists.
ExpandBuff(boolean) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
 
expectedTokenSequences - Variable in exception org.apache.jute.compiler.generated.ParseException
Each entry in this array is an array of integers.
expire(long) - Method in interface org.apache.zookeeper.server.SessionTracker.SessionExpirer
 
expire(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
extractVectorName(JType) - Static method in class org.apache.jute.compiler.JVector
 
EZK - Static variable in interface org.apache.bookkeeper.client.BKDefs
Error while reading from zookeeper or writing to zookeeper

F

FastLeaderElection - Class in org.apache.zookeeper.server.quorum
Implementation of leader election using TCP.
FastLeaderElection(QuorumPeer, QuorumCnxManager) - Constructor for class org.apache.zookeeper.server.quorum.FastLeaderElection
Constructor of FastLeaderElection.
FastLeaderElection.Notification - Class in org.apache.zookeeper.server.quorum
Notifications are messages that let other peers know that a given peer has changed its vote, either because it has joined leader election or because it learned of another peer with higher zxid or same zxid and higher server id
FastLeaderElection.Notification() - Constructor for class org.apache.zookeeper.server.quorum.FastLeaderElection.Notification
 
FastLeaderElection.ToSend - Class in org.apache.zookeeper.server.quorum
Messages that a peer wants to send to other peers.
Field() - Method in class org.apache.jute.compiler.generated.Rcc
 
FileSnap - Class in org.apache.zookeeper.server.persistence
This class implements the snapshot interface.
FileSnap(File) - Constructor for class org.apache.zookeeper.server.persistence.FileSnap
 
FileTxnLog - Class in org.apache.zookeeper.server.persistence
This class implements the TxnLog interface.
FileTxnLog(File) - Constructor for class org.apache.zookeeper.server.persistence.FileTxnLog
constructor for FileTxnLog.
FileTxnLog.FileTxnIterator - Class in org.apache.zookeeper.server.persistence
this class implements the txnlog iterator interface which is used for reading the transaction logs
FileTxnLog.FileTxnIterator(File, long) - Constructor for class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
create an iterator over a transaction database directory
FileTxnSnapLog - Class in org.apache.zookeeper.server.persistence
This is a helper class above the implementations of txnlog and snapshot classes
FileTxnSnapLog(File, File) - Constructor for class org.apache.zookeeper.server.persistence.FileTxnSnapLog
the constructor which takes the datadir and snapdir.
FileTxnSnapLog.PlayBackListener - Interface in org.apache.zookeeper.server.persistence
This listener helps the external apis calling restore to gather information while the data is being restored.
FillBuff() - Method in class org.apache.jute.compiler.generated.SimpleCharStream
 
FinalRequestProcessor - Class in org.apache.zookeeper.server
This Request processor actually applies any transaction associated with a request and services any queries.
FinalRequestProcessor(ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.FinalRequestProcessor
 
findMaxPrefix(String) - Method in class org.apache.zookeeper.common.PathTrie
return the largest prefix for the input path.
findMostRecentSnapshot() - Method in class org.apache.zookeeper.server.persistence.FileSnap
find the most recent snapshot in the database.
findMostRecentSnapshot() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
the most recent snapshot in the snapshot directory
findMostRecentSnapshot() - Method in interface org.apache.zookeeper.server.persistence.SnapShot
find the most recent snapshot file
findNRecentSnapshots(int) - Method in class org.apache.zookeeper.server.persistence.FileSnap
find the last n snapshots.
findNRecentSnapshots(int) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
the n most recent snapshots
finishSessionInit(boolean) - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
finishSessionInit(boolean) - Method in interface org.apache.zookeeper.server.ServerCnxn
 
firstProcessor - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
FLOAT_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
flush() - Method in class org.apache.bookkeeper.streaming.LedgerOutputStream
 
flush() - Method in class org.apache.zookeeper.server.quorum.SendAckRequestProcessor
 
Follower - Class in org.apache.zookeeper.server.quorum
This class has the control logic for the Follower.
follower - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
FollowerBean - Class in org.apache.zookeeper.server.quorum
Follower MBean inteface implementation
FollowerBean(Follower, ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.quorum.FollowerBean
 
FollowerHandler - Class in org.apache.zookeeper.server.quorum
There will be an instance of this class created by the Leader for each follower.All communication for a given Follower will be handled by this class.
followerInfo() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
 
followerInfo() - Method in interface org.apache.zookeeper.server.quorum.LeaderMXBean
 
FollowerMXBean - Interface in org.apache.zookeeper.server.quorum
Follower MBean
FollowerRequestProcessor - Class in org.apache.zookeeper.server.quorum
This RequestProcessor forwards any requests that modify the state of the system to the Leader.
FollowerRequestProcessor(FollowerZooKeeperServer, RequestProcessor) - Constructor for class org.apache.zookeeper.server.quorum.FollowerRequestProcessor
 
followers - Variable in class org.apache.zookeeper.server.quorum.Leader
 
FollowerSessionTracker - Class in org.apache.zookeeper.server.quorum
This is really just a shell of a SessionTracker that tracks session activity to be forwarded to the Leader using a PING.
FollowerSessionTracker(SessionTracker.SessionExpirer, ConcurrentHashMap<Long, Integer>, long) - Constructor for class org.apache.zookeeper.server.quorum.FollowerSessionTracker
 
FollowerSyncRequest - Class in org.apache.zookeeper.server.quorum
 
FollowerSyncRequest(FollowerHandler, long, int, int, ByteBuffer, List<Id>) - Constructor for class org.apache.zookeeper.server.quorum.FollowerSyncRequest
 
FollowerZooKeeperServer - Class in org.apache.zookeeper.server.quorum
Just like the standard ZooKeeperServer.
FOLLOWING_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
 
forwardingFollowers - Variable in class org.apache.zookeeper.server.quorum.Leader
 
fromFlag(int) - Static method in enum org.apache.zookeeper.CreateMode
Map an integer value to a CreateMode value
fromInt(int) - Static method in enum org.apache.zookeeper.Watcher.Event.EventType
 
fromInt(int) - Static method in enum org.apache.zookeeper.Watcher.Event.KeeperState
 

G

genCCode(FileWriter, FileWriter) - Method in class org.apache.jute.compiler.JRecord
 
genCDecl() - Method in class org.apache.jute.compiler.JField
 
genCode(String, File) - Method in class org.apache.jute.compiler.JFile
Generate record code in given language.
genCppCode(FileWriter, FileWriter) - Method in class org.apache.jute.compiler.JRecord
 
genCppDecl() - Method in class org.apache.jute.compiler.JField
 
genCppDecl(String) - Method in class org.apache.jute.compiler.JRecord
 
genCppGetSet(String, int) - Method in class org.apache.jute.compiler.JBuffer
 
genCppGetSet(int) - Method in class org.apache.jute.compiler.JField
 
generateDigest(String) - Static method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
generateParseException() - Method in class org.apache.jute.compiler.generated.Rcc
Generate ParseException.
genJavaCode(File) - Method in class org.apache.jute.compiler.JRecord
 
genJavaCompareBytes() - Method in class org.apache.jute.compiler.JBuffer
 
genJavaCompareTo(String) - Method in class org.apache.jute.compiler.JBoolean
 
genJavaCompareTo(String, String) - Method in class org.apache.jute.compiler.JBuffer
 
genJavaCompareTo(String) - Method in class org.apache.jute.compiler.JBuffer
 
genJavaCompareTo() - Method in class org.apache.jute.compiler.JField
 
genJavaCompareTo(String) - Method in class org.apache.jute.compiler.JMap
 
genJavaCompareTo(String) - Method in class org.apache.jute.compiler.JVector
 
genJavaCompareToWrapper(String, String) - Method in class org.apache.jute.compiler.JBuffer
 
genJavaConstructorParam(String) - Method in class org.apache.jute.compiler.JField
 
genJavaConstructorSet(String) - Method in class org.apache.jute.compiler.JField
 
genJavaDecl() - Method in class org.apache.jute.compiler.JField
 
genJavaEquals(String, String) - Method in class org.apache.jute.compiler.JBuffer
 
genJavaEquals() - Method in class org.apache.jute.compiler.JField
 
genJavaGetSet(int) - Method in class org.apache.jute.compiler.JField
 
genJavaHashCode(String) - Method in class org.apache.jute.compiler.JBoolean
 
genJavaHashCode(String) - Method in class org.apache.jute.compiler.JBuffer
 
genJavaHashCode(String) - Method in class org.apache.jute.compiler.JDouble
 
genJavaHashCode() - Method in class org.apache.jute.compiler.JField
 
genJavaHashCode(String) - Method in class org.apache.jute.compiler.JFloat
 
genJavaHashCode(String) - Method in class org.apache.jute.compiler.JLong
 
genJavaReadMethod(String, String) - Method in class org.apache.jute.compiler.JMap
 
genJavaReadMethod(String, String) - Method in class org.apache.jute.compiler.JRecord
 
genJavaReadMethod(String, String) - Method in class org.apache.jute.compiler.JVector
 
genJavaReadMethodName() - Method in class org.apache.jute.compiler.JField
 
genJavaReadWrapper(String, String, boolean) - Method in class org.apache.jute.compiler.JBuffer
 
genJavaReadWrapper(String, String, boolean) - Method in class org.apache.jute.compiler.JMap
 
genJavaReadWrapper(String, String, boolean) - Method in class org.apache.jute.compiler.JRecord
 
genJavaReadWrapper(String, String, boolean) - Method in class org.apache.jute.compiler.JString
 
genJavaReadWrapper(String, String, boolean) - Method in class org.apache.jute.compiler.JVector
 
genJavaSlurpBytes(String, String, String) - Method in class org.apache.jute.compiler.JBuffer
 
genJavaWriteMethod(String, String) - Method in class org.apache.jute.compiler.JMap
 
genJavaWriteMethod(String, String) - Method in class org.apache.jute.compiler.JVector
 
genJavaWriteMethodName() - Method in class org.apache.jute.compiler.JField
 
genJavaWriteWrapper(String, String) - Method in class org.apache.jute.compiler.JBuffer
 
genJavaWriteWrapper(String, String) - Method in class org.apache.jute.compiler.JMap
 
genJavaWriteWrapper(String, String) - Method in class org.apache.jute.compiler.JRecord
 
genJavaWriteWrapper(String, String) - Method in class org.apache.jute.compiler.JString
 
genJavaWriteWrapper(String, String) - Method in class org.apache.jute.compiler.JVector
 
get(int) - Static method in enum org.apache.zookeeper.KeeperException.Code
Get the Code value for a particular integer error code
getACL(String, Stat) - Method in class org.apache.zookeeper.server.DataTree
 
getACL(String, Stat) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
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.
getActiveServer() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getArchive(InputStream) - Static method in class org.apache.jute.BinaryInputArchive
 
getArchive(OutputStream) - Static method in class org.apache.jute.BinaryOutputArchive
 
getAuthInfo() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
getAuthInfo() - Method in interface org.apache.zookeeper.server.ServerCnxn
 
getAvgLatency() - Method in class org.apache.bookkeeper.proto.ServerStats
 
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
 
getBeginColumn() - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Get token beginning column number.
getBeginLine() - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Get token beginning line number.
getBuildDate() - Static method in class org.apache.zookeeper.Version
 
getBytes() - Method in class org.apache.zookeeper.StatsTrack
get the count of bytes allowed as part of quota
getChildren() - 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() - Method in class org.apache.zookeeper.server.upgrade.DataNodeV1
convenience methods to get the children
getChildren(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
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.
getClientPort() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getClientPort() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getClientPort() - Method in class org.apache.zookeeper.server.ServerConfig
 
getClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getClientPort() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getClientPort() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getCnxManager() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
 
getCnxnFactory() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getCode() - Method in exception org.apache.bookkeeper.bookie.BookieException
 
getCode() - Method in exception org.apache.bookkeeper.client.BKException
 
getCode() - Method in exception org.apache.zookeeper.KeeperException
Deprecated. deprecated in 3.1.0, use KeeperException.code() instead
getColumn() - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Deprecated. 
getCommands() - Static method in class org.apache.zookeeper.ZooKeeperMain
 
getCount() - Method in class org.apache.zookeeper.StatsTrack
get the count of nodes allowed as part of quota
getCppFQName() - Method in class org.apache.jute.compiler.JRecord
 
getCppNameSpace() - Method in class org.apache.jute.compiler.JRecord
 
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, Stat, Watcher) - Method in class org.apache.zookeeper.server.DataTree
 
getData(String, Stat, Watcher) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
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
 
getDataLogDir() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getDataLogDir() - Method in class org.apache.zookeeper.server.ServerConfig
 
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.
getDigestInstance(String) - Method in class org.apache.bookkeeper.proto.BookieClient
Get digest instance if there is none.
getDisableAutoResetWatch() - Static method in class org.apache.zookeeper.ClientCnxn
tests use this to check on reset of watches
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
 
getElectionPort() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
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
getElementType() - Method in class org.apache.jute.compiler.JVector
 
getEndColumn() - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Get token end column number.
getEndLine() - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Get token end line number.
getEntry() - Method in exception org.apache.bookkeeper.bookie.Bookie.NoEntryException
 
getEntry() - Method in class org.apache.bookkeeper.client.LedgerEntry
 
getEntryId() - Method in class org.apache.bookkeeper.client.LedgerEntry
 
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(long) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
getEphemeralsMap() - Method in class org.apache.zookeeper.server.DataTree
 
getEphemeralsMap() - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
return the ephemerals for this tree
getException() - Method in class org.apache.zookeeper.server.Request
 
getFields() - Method in class org.apache.jute.compiler.JRecord
 
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.
getFullVersion() - Static method in class org.apache.zookeeper.Version
 
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
 
getHeader() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
reutrn the current header
getHeader() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
return the transaction header.
getId() - Method in class org.apache.bookkeeper.client.LedgerHandle
Returns the ledger identifier
getId() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
get the id of this quorum peer.
GetImage() - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Get token literal value.
getInitLimit() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
getInitLimit() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
 
getInitLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Get the number of ticks that the initial synchronization phase can take
getInitLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getInProcess() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getInstance() - Static method in class org.apache.bookkeeper.proto.ServerStats
 
getInstance() - Static method in class org.apache.zookeeper.jmx.MBeanRegistry
 
getIntValue() - Method in enum org.apache.zookeeper.Watcher.Event.EventType
 
getIntValue() - Method in enum org.apache.zookeeper.Watcher.Event.KeeperState
 
getJavaFQName() - Method in class org.apache.jute.compiler.JRecord
 
getJavaPackage() - Method in class org.apache.jute.compiler.JRecord
 
getKey() - Method in class org.apache.zookeeper.Environment.Entry
 
getLast() - Method in class org.apache.bookkeeper.client.LedgerHandle
Returns the last entry identifier submitted
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
getLastProcessedZxid() - Method in class org.apache.bookkeeper.proto.ServerStats
 
getLastProcessedZxid() - Method in interface org.apache.bookkeeper.proto.ServerStats.Provider
 
getLastProcessedZxid() - Method in class org.apache.zookeeper.server.ServerStats
 
getLastProcessedZxid() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
 
getLastProcessedZxid() - Method in class org.apache.zookeeper.server.ZooKeeperServer
return the last proceesed id from the datatree
getLastQueued() - Method in class org.apache.zookeeper.server.quorum.Follower
 
getLastQueuedZxid() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
 
getLastQueuedZxid() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
 
getLastZxid() - Method in class org.apache.zookeeper.server.DataTreeBean
 
getLastZxid() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
 
getLeader() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
getLedger() - Method in exception org.apache.bookkeeper.bookie.Bookie.NoEntryException
 
getLedgerId() - Method in exception org.apache.bookkeeper.bookie.Bookie.NoLedgerException
 
getLedgerId() - Method in class org.apache.bookkeeper.client.LedgerEntry
 
getLine() - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Deprecated. 
getLocalAddress() - Method in class org.apache.bookkeeper.proto.NIOServerFactory
 
getLocalAddress() - Method in class org.apache.zookeeper.server.NIOServerCnxn.Factory
 
getLocalPort() - Method in class org.apache.zookeeper.server.NIOServerCnxn.Factory
 
getLogDir(Properties) - Static method in class org.apache.zookeeper.server.persistence.Util
Extracts transaction log directory property value from the container.
getLogFiles(File[], long) - Static method in class org.apache.zookeeper.server.persistence.FileTxnLog
Find the log file that starts at, or just before, the snapshot.
getLogicalClock() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
Returns the current vlue of the logical clock counter
getLogWriter() - Method in class org.apache.zookeeper.server.ZooKeeperServer
the snapshot and logwriter for this instance
getMac(String, byte[]) - Method in class org.apache.bookkeeper.proto.BookieClient
 
getMaxClientCnxns() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getMaxClientCnxns() - Method in class org.apache.zookeeper.server.ServerConfig
 
getMaxLatency() - Method in class org.apache.bookkeeper.proto.ServerStats
 
getMaxLatency() - Method in class org.apache.zookeeper.server.ServerStats
 
getMaxRequestLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getMaxRequestLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getMessage(int) - Method in exception org.apache.bookkeeper.bookie.BookieException
 
getMessage(int) - Method in exception org.apache.bookkeeper.client.BKException
 
getMessage() - Method in error org.apache.jute.compiler.generated.TokenMgrError
You can also modify the body of this method to customize your error messages.
getMessage() - Method in exception org.apache.zookeeper.KeeperException
 
getMinLatency() - Method in class org.apache.bookkeeper.proto.ServerStats
 
getMinLatency() - Method in class org.apache.zookeeper.server.ServerStats
 
getMinRequestLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getMinRequestLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getMyid() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
get the id of this quorum peer.
getName() - Method in class org.apache.jute.compiler.JField
 
getName() - Method in class org.apache.jute.compiler.JRecord
 
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.quorum.FollowerBean
 
getName() - Method in class org.apache.zookeeper.server.quorum.LeaderBean
 
getName() - Method in class org.apache.zookeeper.server.quorum.LeaderElectionBean
 
getName() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
getName() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
 
getName() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
 
getName() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
 
getName() - Method in interface org.apache.zookeeper.server.quorum.RemotePeerMXBean
 
getName() - Method in interface org.apache.zookeeper.server.quorum.ServerMXBean
 
getName() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getNewDataTree() - Method in interface org.apache.zookeeper.server.upgrade.UpgradeSnapShot
 
getNewDataTree() - Method in class org.apache.zookeeper.server.upgrade.UpgradeSnapShotV1
 
getNextToken() - Method in class org.apache.jute.compiler.generated.Rcc
Get the next Token.
getNextToken() - Method in class org.apache.jute.compiler.generated.RccTokenManager
Get the next Token.
getNode(String) - Method in class org.apache.zookeeper.server.DataTree
 
getNode(String) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
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
 
getOutstandingRequests() - Method in class org.apache.bookkeeper.proto.ServerStats
 
getOutstandingRequests() - Method in interface org.apache.bookkeeper.proto.ServerStats.Provider
 
getOutstandingRequests() - Method in class org.apache.zookeeper.server.ConnectionBean
 
getOutstandingRequests() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
 
getOutstandingRequests() - Method in interface org.apache.zookeeper.server.ServerCnxn.Stats
 
getOutstandingRequests() - Method in class org.apache.zookeeper.server.ServerStats
 
getOutstandingRequests() - Method in interface org.apache.zookeeper.server.ServerStats.Provider
 
getOutstandingRequests() - Method in class org.apache.zookeeper.server.ZooKeeperServer
return the outstanding requests in the queue, which havent been processed yet
getOutstandingRequests() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getOutstandingRequests() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
getOwner() - Method in class org.apache.zookeeper.server.Request
 
getPacketsReceived() - Method in class org.apache.bookkeeper.proto.ServerStats
 
getPacketsReceived() - Method in class org.apache.zookeeper.server.ConnectionBean
 
getPacketsReceived() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
 
getPacketsReceived() - Method in interface org.apache.zookeeper.server.ServerCnxn.Stats
 
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.bookkeeper.proto.ServerStats
 
getPacketsSent() - Method in class org.apache.zookeeper.server.ConnectionBean
 
getPacketsSent() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
 
getPacketsSent() - Method in interface org.apache.zookeeper.server.ServerCnxn.Stats
 
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
 
getPath() - Method in exception org.apache.zookeeper.KeeperException
Read the path for this exception
getPath() - Method in class org.apache.zookeeper.WatchedEvent
 
getPeerState() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getPendingRevalidationCount() - Method in class org.apache.zookeeper.server.quorum.FollowerBean
 
getPendingRevalidationCount() - Method in interface org.apache.zookeeper.server.quorum.FollowerMXBean
 
getPendingRevalidationsCount() - Method in class org.apache.zookeeper.server.quorum.Follower
 
getPrintWatches() - Method in class org.apache.zookeeper.ZooKeeperMain
 
getPrompt() - Method in class org.apache.zookeeper.ZooKeeperMain
 
getProvider(String) - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
 
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 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
 
getQuorumPeers() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getQuorumPeers() - Method in class org.apache.zookeeper.server.quorum.QuorumStats
 
getQuorumPeers() - Method in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
 
getQuorumSize() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
 
getQuorumSize() - Method in interface org.apache.zookeeper.server.quorum.QuorumMXBean
 
getQuorumSize() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Return QuorumVerifier object
getQuorumVerifier() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getRefCnt() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
getRemoteAddress() - Method in class org.apache.bookkeeper.proto.NIOServerFactory.Cnxn
 
getRemoteAddress() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
getRemoteAddress() - Method in interface org.apache.zookeeper.server.ServerCnxn
 
getRevision() - Static method in class org.apache.zookeeper.Version
 
getScheme() - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
The String used to represent this provider.
getScheme() - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
getScheme() - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
 
getServerCnxnFactory() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getServerId() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
getServerId() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getServerId() - Method in interface org.apache.zookeeper.server.SessionTracker.SessionExpirer
 
getServerId() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getServers() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getServerState() - Method in class org.apache.bookkeeper.proto.ServerStats
 
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
 
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.NIOServerCnxn
 
getSessionId() - Method in interface org.apache.zookeeper.server.ServerCnxn
 
getSessionId() - Method in class org.apache.zookeeper.ZooKeeper
The session id for this ZooKeeper client instance.
getSessionPasswd() - Method in class org.apache.zookeeper.ClientCnxn
 
getSessionPasswd() - Method in class org.apache.zookeeper.ZooKeeper
The session password for this ZooKeeper client instance.
getSessions() - Method in class org.apache.zookeeper.server.DataTree
 
getSessions() - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
getSessionTimeout() - Method in class org.apache.bookkeeper.proto.NIOServerFactory.Cnxn
 
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.NIOServerCnxn
 
getSessionTimeout() - Method in interface org.apache.zookeeper.server.ServerCnxn
 
getSessionWithTimeOuts() - Method in interface org.apache.zookeeper.server.upgrade.UpgradeSnapShot
 
getSessionWithTimeOuts() - Method in class org.apache.zookeeper.server.upgrade.UpgradeSnapShotV1
 
getSignature() - Method in class org.apache.jute.compiler.JBoolean
 
getSignature() - Method in class org.apache.jute.compiler.JBuffer
 
getSignature() - Method in class org.apache.jute.compiler.JByte
 
getSignature() - Method in class org.apache.jute.compiler.JDouble
 
getSignature() - Method in class org.apache.jute.compiler.JField
 
getSignature() - Method in class org.apache.jute.compiler.JFloat
 
getSignature() - Method in class org.apache.jute.compiler.JInt
 
getSignature() - Method in class org.apache.jute.compiler.JLong
 
getSignature() - Method in class org.apache.jute.compiler.JMap
 
getSignature() - Method in class org.apache.jute.compiler.JRecord
 
getSignature() - Method in class org.apache.jute.compiler.JString
 
getSignature() - Method in class org.apache.jute.compiler.JVector
 
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.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.
getSnapshotLogs(long) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
get the snapshot logs that are greater than the given zxid
getSourceIP() - Method in class org.apache.zookeeper.server.ConnectionBean
 
getSourceIP() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
 
getStartedTime() - Method in class org.apache.zookeeper.server.ConnectionBean
 
getStartedTime() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
 
getStartTime() - Method in class org.apache.zookeeper.server.quorum.LeaderElectionBean
 
getStartTime() - Method in interface org.apache.zookeeper.server.quorum.LeaderElectionMXBean
 
getStartTime() - Method in class org.apache.zookeeper.server.quorum.ServerBean
 
getStartTime() - Method in interface org.apache.zookeeper.server.quorum.ServerMXBean
 
getStartTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getStartTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
 
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 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
 
getStats() - Method in class org.apache.bookkeeper.proto.NIOServerFactory.Cnxn
 
getStats() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
getStats() - Method in interface org.apache.zookeeper.server.ServerCnxn
 
GetSuffix(int) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Get the suffix.
getSyncLimit() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
getSyncLimit() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
 
getSyncLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Get the number of ticks that can pass between sending a request and getting an acknowledgement
getSyncLimit() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getTabSize(int) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
 
getTag() - Method in class org.apache.jute.compiler.JField
 
getTextTraceLevel() - Static method in class org.apache.zookeeper.server.ZooTrace
 
getThreshold() - Method in class org.apache.bookkeeper.client.LedgerHandle
 
getTick() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
getTick() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
 
getTick() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Get the current tick
getTickTime() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
getTickTime() - Method in interface org.apache.zookeeper.server.quorum.LocalPeerMXBean
 
getTickTime() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Get the number of milliseconds of each tick
getTickTime() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
getTickTime() - Method in class org.apache.zookeeper.server.ServerConfig
 
getTickTime() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getTickTime() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
getTickTime() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
Current TickTime of server
getToken(int) - Method in class org.apache.jute.compiler.generated.Rcc
Get the specific Token.
getTouchSnapshot() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
getTraceMask(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
 
getTraceMaskCmd - Static variable in interface org.apache.zookeeper.server.ServerCnxn
 
getTreeBuilder() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getTxn() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
return the current transaction
getTxn() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
return the transaction record.
getTxnFactory() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
getTxnLogFactory() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
getType() - Method in class org.apache.jute.compiler.JField
 
getType() - Method in class org.apache.zookeeper.WatchedEvent
 
getValue() - Method in class org.apache.jute.compiler.generated.Token
An optional attribute value of the Token.
getValue() - Method in class org.apache.zookeeper.Environment.Entry
 
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
 
getVersionRevision() - Static method in class org.apache.zookeeper.Version
 
getWatchCount() - Method in class org.apache.zookeeper.server.DataTree
 
getWatchCount() - Method in class org.apache.zookeeper.server.DataTreeBean
 
getWatchCount() - Method in interface org.apache.zookeeper.server.DataTreeMXBean
 
getWeight(long) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
Returns the weight of a server.
getWeight(long) - Method in class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
Returns weight of 1 by default.
getWeight(long) - Method in interface org.apache.zookeeper.server.quorum.flexible.QuorumVerifier
 
getWrapper() - Method in class org.apache.zookeeper.WatchedEvent
Convert WatchedEvent to type that can be sent over network
getZooKeeperServer() - Method in class org.apache.zookeeper.server.NIOServerCnxn.Factory
 
getZxid() - Method in class org.apache.zookeeper.server.quorum.Follower
 
getZxid() - Method in class org.apache.zookeeper.server.ZooKeeperServer
This should be called from a synchronized block on this!
getZxidFromName(String, String) - Static method in class org.apache.zookeeper.server.persistence.Util
Extracts zxid from the file name.
GT_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.

H

halt() - Method in class org.apache.bookkeeper.client.BookieHandle
Halt this bookie handle independent of the number of ledgers using it.
halt() - Method in class org.apache.bookkeeper.client.BookKeeper
Halts all bookie handles
halt() - Method in class org.apache.bookkeeper.proto.BookieClient
Halts client.
halt() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
Flag that it is time to wrap up all activities and interrupt the listener.
handleAuthentication(ServerCnxn, byte[]) - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
This method is called when a client passes authentication data for this scheme.
handleAuthentication(ServerCnxn, byte[]) - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
handleAuthentication(ServerCnxn, byte[]) - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
 
hasClosed(long) - Method in class org.apache.bookkeeper.client.BookKeeper
Check if close node exists.
hashCode() - Method in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
See equals() to find the rational for how this hashcode is generated.
hashCode() - Method in class org.apache.zookeeper.server.quorum.Vote
 
hashCode() - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
See equals() to find the rational for how this hashcode is generated.
hasMoreElements() - Method in class org.apache.bookkeeper.client.LedgerSequence
 
hdr - Variable in class org.apache.zookeeper.server.Request
 
history - Variable in class org.apache.zookeeper.ZooKeeperMain
 
host - Variable in class org.apache.zookeeper.ZooKeeperMain
 
hostPort - Variable in class org.apache.bookkeeper.util.ClientBase
 
hzxid - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 

I

id - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
id - Variable in class org.apache.zookeeper.server.quorum.Vote
 
IDENT_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
IllegalOpException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
IllegalOpException - Static variable in interface org.apache.bookkeeper.client.BKException.Code
 
image - Variable in class org.apache.jute.compiler.generated.Token
The string image of the token.
imok - Static variable in interface org.apache.zookeeper.server.ServerCnxn
 
inBuf - Variable in class org.apache.jute.compiler.generated.SimpleCharStream
 
incInProcess() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
Include() - Method in class org.apache.jute.compiler.generated.Rcc
 
INCLUDE_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
incr() - Method in interface org.apache.jute.Index
 
incRef() - Method in class org.apache.bookkeeper.bookie.LedgerDescriptor
 
incrementPacketsReceived() - Method in class org.apache.bookkeeper.proto.ServerStats
 
incrementPacketsReceived() - Method in class org.apache.zookeeper.server.ServerStats
 
incrementPacketsSent() - Method in class org.apache.bookkeeper.proto.ServerStats
 
incrementPacketsSent() - Method in class org.apache.zookeeper.server.ServerStats
 
Index - Interface in org.apache.jute
Interface that acts as an iterator for deserializing maps.
initialize() - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
 
initialize() - Method in class org.apache.zookeeper.server.quorum.ProposalRequestProcessor
initialize this processor
initializeAndRun(String[]) - Method in class org.apache.zookeeper.server.quorum.QuorumPeerMain
 
initializeAndRun(String[]) - Method in class org.apache.zookeeper.server.ZooKeeperServerMain
 
initialized - Variable in class org.apache.zookeeper.server.DataTree
 
initialized - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
initializeNextSession(long) - Static method in class org.apache.zookeeper.server.SessionTrackerImpl
 
initiateConnection(SocketChannel, Long) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
If this server has initiated the connection, then it gives up on the connection if it loses challenge.
initLimit - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
Input() - Method in class org.apache.jute.compiler.generated.Rcc
 
input_stream - Variable in class org.apache.jute.compiler.generated.RccTokenManager
 
InputArchive - Interface in org.apache.jute
Interface that all the Deserializers have to implement.
inputStream - Variable in class org.apache.jute.compiler.generated.SimpleCharStream
 
inStreamCreated(InputArchive, InputStream) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
read the header fomr the inputarchive
INT_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
intValue() - Method in enum org.apache.zookeeper.KeeperException.Code
Get the int value for a particular Code.
InvalidACL - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.INVALIDACL instead
InvalidCallback - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.INVALIDCALLBACK instead
IPAuthenticationProvider - Class in org.apache.zookeeper.server.auth
 
IPAuthenticationProvider() - Constructor for class org.apache.zookeeper.server.auth.IPAuthenticationProvider
 
isAlive() - Method in enum org.apache.zookeeper.ZooKeeper.States
 
isAuthenticated() - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
This method is used to check if the authentication done by this provider should be used to identify the creator of a node.
isAuthenticated() - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
isAuthenticated() - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
 
isConnected() - Method in class org.apache.bookkeeper.proto.BookieClient
Returns the status of the socket of this bookie client.
isDistributed() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
isDown() - Method in class org.apache.bookkeeper.proto.BookieServer
 
isEphemeral() - Method in enum org.apache.zookeeper.CreateMode
 
isHidden() - Method in interface org.apache.zookeeper.jmx.ZKMBeanInfo
If isHidden returns true, the MBean won't be registered with MBean server, and thus won't be available for management tools.
isHidden() - Method in class org.apache.zookeeper.server.ConnectionBean
 
isHidden() - Method in class org.apache.zookeeper.server.DataTreeBean
 
isHidden() - Method in class org.apache.zookeeper.server.quorum.LeaderElectionBean
 
isHidden() - Method in class org.apache.zookeeper.server.quorum.LocalPeerBean
 
isHidden() - Method in class org.apache.zookeeper.server.quorum.QuorumBean
 
isHidden() - Method in class org.apache.zookeeper.server.quorum.RemotePeerBean
 
isHidden() - Method in class org.apache.zookeeper.server.quorum.ServerBean
 
isHidden() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
isRunning() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
isSequential() - Method in enum org.apache.zookeeper.CreateMode
 
isTraceEnabled(Logger, long) - Static method in class org.apache.zookeeper.server.ZooTrace
 
isValid(String) - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
Validates the syntax of an id.
isValid(String) - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
isValid(String) - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
 
isValidSnapshot(File) - Static method in class org.apache.zookeeper.server.persistence.Util
Verifies that the file is a valid snapshot.

J

JBoolean - Class in org.apache.jute.compiler
 
JBoolean() - Constructor for class org.apache.jute.compiler.JBoolean
Creates a new instance of JBoolean
JBuffer - Class in org.apache.jute.compiler
 
JBuffer() - Constructor for class org.apache.jute.compiler.JBuffer
Creates a new instance of JBuffer
JByte - Class in org.apache.jute.compiler
 
JByte() - Constructor for class org.apache.jute.compiler.JByte
Creates a new instance of JByte
JDouble - Class in org.apache.jute.compiler
 
JDouble() - Constructor for class org.apache.jute.compiler.JDouble
Creates a new instance of JDouble
JField - Class in org.apache.jute.compiler
 
JField(JType, String) - Constructor for class org.apache.jute.compiler.JField
Creates a new instance of JField
JFile - Class in org.apache.jute.compiler
Container for the Hadoop Record DDL.
JFile(String, ArrayList<JFile>, ArrayList<JRecord>) - Constructor for class org.apache.jute.compiler.JFile
Creates a new instance of JFile
JFloat - Class in org.apache.jute.compiler
 
JFloat() - Constructor for class org.apache.jute.compiler.JFloat
Creates a new instance of JFloat
JInt - Class in org.apache.jute.compiler
 
JInt() - Constructor for class org.apache.jute.compiler.JInt
Creates a new instance of JInt
jj_nt - Variable in class org.apache.jute.compiler.generated.Rcc
Next token.
jjFillToken() - Method in class org.apache.jute.compiler.generated.RccTokenManager
 
jjnewLexState - Static variable in class org.apache.jute.compiler.generated.RccTokenManager
Lex State array.
jjstrLiteralImages - Static variable in class org.apache.jute.compiler.generated.RccTokenManager
Token literal values.
JLong - Class in org.apache.jute.compiler
 
JLong() - Constructor for class org.apache.jute.compiler.JLong
Creates a new instance of JLong
JMap - Class in org.apache.jute.compiler
 
JMap(JType, JType) - Constructor for class org.apache.jute.compiler.JMap
Creates a new instance of JMap
JMX_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
jmxDataTreeBean - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
jmxServerBean - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
join() - Method in class org.apache.bookkeeper.proto.BookieServer
 
JRecord - Class in org.apache.jute.compiler
 
JRecord(String, ArrayList<JField>) - Constructor for class org.apache.jute.compiler.JRecord
Creates a new instance of JRecord
JString - Class in org.apache.jute.compiler
 
JString() - Constructor for class org.apache.jute.compiler.JString
Creates a new instance of JString
JType - Class in org.apache.jute.compiler
Abstract Base class for all types supported by Hadoop Record I/O.
JVector - Class in org.apache.jute.compiler
 
JVector(JType) - Constructor for class org.apache.jute.compiler.JVector
Creates a new instance of JVector

K

KeeperException - Exception in org.apache.zookeeper
 
KeeperException(KeeperException.Code) - Constructor for exception org.apache.zookeeper.KeeperException
 
KeeperException.APIErrorException - Exception in org.apache.zookeeper
 
KeeperException.APIErrorException() - Constructor for exception org.apache.zookeeper.KeeperException.APIErrorException
 
KeeperException.AuthFailedException - Exception in org.apache.zookeeper
 
KeeperException.AuthFailedException() - Constructor for exception org.apache.zookeeper.KeeperException.AuthFailedException
 
KeeperException.BadArgumentsException - Exception in org.apache.zookeeper
 
KeeperException.BadArgumentsException() - Constructor for exception org.apache.zookeeper.KeeperException.BadArgumentsException
 
KeeperException.BadVersionException - Exception in org.apache.zookeeper
 
KeeperException.BadVersionException() - Constructor for exception org.apache.zookeeper.KeeperException.BadVersionException
 
KeeperException.Code - Enum in org.apache.zookeeper
Codes which represent the various KeeperException types.
KeeperException.CodeDeprecated - Interface in org.apache.zookeeper
Deprecated. 
KeeperException.ConnectionLossException - Exception in org.apache.zookeeper
 
KeeperException.ConnectionLossException() - Constructor for exception org.apache.zookeeper.KeeperException.ConnectionLossException
 
KeeperException.DataInconsistencyException - Exception in org.apache.zookeeper
 
KeeperException.DataInconsistencyException() - Constructor for exception org.apache.zookeeper.KeeperException.DataInconsistencyException
 
KeeperException.InvalidACLException - Exception in org.apache.zookeeper
 
KeeperException.InvalidACLException() - Constructor for exception org.apache.zookeeper.KeeperException.InvalidACLException
 
KeeperException.InvalidCallbackException - Exception in org.apache.zookeeper
 
KeeperException.InvalidCallbackException() - Constructor for exception org.apache.zookeeper.KeeperException.InvalidCallbackException
 
KeeperException.MarshallingErrorException - Exception in org.apache.zookeeper
 
KeeperException.MarshallingErrorException() - Constructor for exception org.apache.zookeeper.KeeperException.MarshallingErrorException
 
KeeperException.NoAuthException - Exception in org.apache.zookeeper
 
KeeperException.NoAuthException() - Constructor for exception org.apache.zookeeper.KeeperException.NoAuthException
 
KeeperException.NoChildrenForEphemeralsException - Exception in org.apache.zookeeper
 
KeeperException.NoChildrenForEphemeralsException() - Constructor for exception org.apache.zookeeper.KeeperException.NoChildrenForEphemeralsException
 
KeeperException.NodeExistsException - Exception in org.apache.zookeeper
 
KeeperException.NodeExistsException() - Constructor for exception org.apache.zookeeper.KeeperException.NodeExistsException
 
KeeperException.NoNodeException - Exception in org.apache.zookeeper
 
KeeperException.NoNodeException() - Constructor for exception org.apache.zookeeper.KeeperException.NoNodeException
 
KeeperException.NotEmptyException - Exception in org.apache.zookeeper
 
KeeperException.NotEmptyException() - Constructor for exception org.apache.zookeeper.KeeperException.NotEmptyException
 
KeeperException.OperationTimeoutException - Exception in org.apache.zookeeper
 
KeeperException.OperationTimeoutException() - Constructor for exception org.apache.zookeeper.KeeperException.OperationTimeoutException
 
KeeperException.RuntimeInconsistencyException - Exception in org.apache.zookeeper
 
KeeperException.RuntimeInconsistencyException() - Constructor for exception org.apache.zookeeper.KeeperException.RuntimeInconsistencyException
 
KeeperException.SessionExpiredException - Exception in org.apache.zookeeper
 
KeeperException.SessionExpiredException() - Constructor for exception org.apache.zookeeper.KeeperException.SessionExpiredException
 
KeeperException.SessionMovedException - Exception in org.apache.zookeeper
 
KeeperException.SessionMovedException() - Constructor for exception org.apache.zookeeper.KeeperException.SessionMovedException
 
KeeperException.SystemErrorException - Exception in org.apache.zookeeper
 
KeeperException.SystemErrorException() - Constructor for exception org.apache.zookeeper.KeeperException.SystemErrorException
 
KeeperException.UnimplementedException - Exception in org.apache.zookeeper
 
KeeperException.UnimplementedException() - Constructor for exception org.apache.zookeeper.KeeperException.UnimplementedException
 
kill(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
 
killSession(long, long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
kind - Variable in class org.apache.jute.compiler.generated.Token
An integer that describes the kind of this token.

L

lastProcessedZxid - Variable in class org.apache.zookeeper.server.DataTree
 
lastProcessedZxid - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
LBRACE_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
Leader - Class in org.apache.zookeeper.server.quorum
This class has the control logic for the Leader.
leader - Variable in class org.apache.zookeeper.server.quorum.QuorumPeer
 
Leader.Proposal - Class in org.apache.zookeeper.server.quorum
 
Leader.Proposal() - Constructor for class org.apache.zookeeper.server.quorum.Leader.Proposal
 
LeaderBean - Class in org.apache.zookeeper.server.quorum
Leader MBean interface implementation.
LeaderBean(Leader, ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.quorum.LeaderBean
 
LeaderElection - Class in org.apache.zookeeper.server.quorum
 
LeaderElection(QuorumPeer) - Constructor for class org.apache.zookeeper.server.quorum.LeaderElection
 
LeaderElection.ElectionResult - Class in org.apache.zookeeper.server.quorum
 
LeaderElection.ElectionResult() - Constructor for class org.apache.zookeeper.server.quorum.LeaderElection.ElectionResult
 
LeaderElectionBean - Class in org.apache.zookeeper.server.quorum
Leader election MBean interface implementation
LeaderElectionBean() - Constructor for class org.apache.zookeeper.server.quorum.LeaderElectionBean
 
LeaderElectionMXBean - Interface in org.apache.zookeeper.server.quorum
Leader election protocol MBean.
LeaderMXBean - Interface in org.apache.zookeeper.server.quorum
Leader MBean.
LeaderZooKeeperServer - Class in org.apache.zookeeper.server.quorum
Just like the standard ZooKeeperServer.
LEADING_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
 
LedgerDescriptor - Class in org.apache.bookkeeper.bookie
Implements a ledger inside a bookie.
LedgerEntry - Class in org.apache.bookkeeper.client
Ledger entry.
LedgerHandle - Class in org.apache.bookkeeper.client
Ledger handle on the client side.
LedgerHandle.QMode - Enum in org.apache.bookkeeper.client
 
LedgerInputStream - Class in org.apache.bookkeeper.streaming
 
LedgerInputStream(LedgerHandle) - Constructor for class org.apache.bookkeeper.streaming.LedgerInputStream
construct a outputstream from a ledger handle
LedgerInputStream(LedgerHandle, int) - Constructor for class org.apache.bookkeeper.streaming.LedgerInputStream
construct a outputstream from a ledger handle
LedgerManagementProcessor - Class in org.apache.bookkeeper.client
 
LedgerOutputStream - Class in org.apache.bookkeeper.streaming
this class provides a streaming api to get an output stream from a ledger handle and write to it as a stream of bytes.
LedgerOutputStream(LedgerHandle) - Constructor for class org.apache.bookkeeper.streaming.LedgerOutputStream
construct a outputstream from a ledger handle
LedgerOutputStream(LedgerHandle, int) - Constructor for class org.apache.bookkeeper.streaming.LedgerOutputStream
construct a outputstream from a ledger handle
LedgerSequence - Class in org.apache.bookkeeper.client
Sequence of entries of a ledger.
LexicalError(boolean, int, int, int, String, char) - Static method in error org.apache.jute.compiler.generated.TokenMgrError
Returns a detailed message for the Error when it is thrown by the token manager to indicate a lexical error.
lexStateNames - Static variable in class org.apache.jute.compiler.generated.RccTokenManager
Lexer state names.
limitNode - Static variable in class org.apache.zookeeper.Quotas
the limit node that has the limit of a subtree
line - Variable in class org.apache.jute.compiler.generated.SimpleCharStream
 
list() - Static method in class org.apache.zookeeper.Environment
 
listener - Variable in class org.apache.zookeeper.server.quorum.QuorumCnxManager
 
listProviders() - Static method in class org.apache.zookeeper.server.auth.ProviderRegistry
 
loadData() - Method in class org.apache.zookeeper.server.ZooKeeperServer
Restore sessions and data
LocalBookKeeper - Class in org.apache.bookkeeper.util
 
LocalBookKeeper() - Constructor for class org.apache.bookkeeper.util.LocalBookKeeper
 
LocalBookKeeper(int) - Constructor for class org.apache.bookkeeper.util.LocalBookKeeper
 
LocalPeerBean - Class in org.apache.zookeeper.server.quorum
Implementation of the local peer MBean interface.
LocalPeerBean(QuorumPeer) - Constructor for class org.apache.zookeeper.server.quorum.LocalPeerBean
 
LocalPeerMXBean - Interface in org.apache.zookeeper.server.quorum
A local zookeeper server MBean interface.
LOG - Static variable in class org.apache.bookkeeper.util.ClientBase
 
LOG - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
logEnv(String, Logger) - Static method in class org.apache.zookeeper.Environment
 
LogFormatter - Class in org.apache.zookeeper.server
 
LogFormatter() - Constructor for class org.apache.zookeeper.server.LogFormatter
 
logQuorumPacket(Logger, long, char, QuorumPacket) - Static method in class org.apache.zookeeper.server.ZooTrace
 
logRequest(TxnHeader, Record) - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
logRequest(Logger, long, char, Request, String) - Static method in class org.apache.zookeeper.server.ZooTrace
 
logTraceMessage(Logger, long, String) - Static method in class org.apache.zookeeper.server.ZooTrace
 
LONG_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
longKeyMap - Variable in class org.apache.zookeeper.server.DataTree
this is map from longs to acl's.
lookForLeader() - Method in class org.apache.zookeeper.server.quorum.AuthFastLeaderElection
 
lookForLeader() - Method in interface org.apache.zookeeper.server.quorum.Election
 
lookForLeader() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
Starts a new round of leader election.
lookForLeader() - Method in class org.apache.zookeeper.server.quorum.LeaderElection
 
LOOKING_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
 
LT_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.

M

main(String[]) - Static method in class org.apache.bookkeeper.bookie.Bookie
 
main(String[]) - Static method in class org.apache.bookkeeper.proto.BookieClient
 
main(String[]) - Static method in class org.apache.bookkeeper.proto.BookieServer
 
main(String[]) - Static method in class org.apache.bookkeeper.util.LocalBookKeeper
 
Main - Class in org.apache.bookkeeper.util
 
Main() - Constructor for class org.apache.bookkeeper.util.Main
 
main(String[]) - Static method in class org.apache.bookkeeper.util.Main
 
main(String[]) - Static method in class org.apache.jute.compiler.generated.Rcc
 
main(String[]) - Static method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
Call with a single argument of user:pass to generate authdata.
main(String[]) - Static method in class org.apache.zookeeper.server.LogFormatter
 
main(String[]) - Static method in class org.apache.zookeeper.server.PurgeTxnLog
 
main(String[]) - Static method in class org.apache.zookeeper.server.quorum.QuorumPeerMain
To start the replicated server specify the configuration file name on the command line.
main(String[]) - Static method in class org.apache.zookeeper.server.TraceFormatter
 
main(String[]) - Static method in class org.apache.zookeeper.server.upgrade.UpgradeMain
 
main(String[]) - Static method in class org.apache.zookeeper.server.ZooKeeperServerMain
 
main(String[]) - Static method in class org.apache.zookeeper.ServerAdminClient
 
main(String[]) - Static method in class org.apache.zookeeper.Version
Prints the current version, revision and build date to the standard out.
main(String[]) - Static method in class org.apache.zookeeper.version.util.VerGen
Emits a org.apache.zookeeper.version.Info interface file with version and revision information constants set to the values passed in as command line parameters.
main(String[]) - Static method in class org.apache.zookeeper.ZooKeeperMain
 
makeChecksumAlgorithm() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
create a checksum algorithm
makeChecksumAlgorithm() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
creates a checksum alogrithm to be used
makeFileLoggerURL(File, File) - Static method in class org.apache.zookeeper.server.persistence.Util
Given two directory files the method returns a well-formed logfile provider URI.
makeFileLoggerURL(File, File, String) - Static method in class org.apache.zookeeper.server.persistence.Util
 
makeFollower(FileTxnSnapLog) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
makeFullPath(String, String...) - Method in class org.apache.zookeeper.jmx.MBeanRegistry
Generate a filesystem-like path.
makeFullPath(String, ZKMBeanInfo) - Method in class org.apache.zookeeper.jmx.MBeanRegistry
 
makeLeader(FileTxnSnapLog) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
makeLEStrategy() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
makeLogName(long) - Static method in class org.apache.zookeeper.server.persistence.Util
Creates a valid transaction log file name.
makeObjectName(String, ZKMBeanInfo) - Method in class org.apache.zookeeper.jmx.MBeanRegistry
Builds an MBean path and creates an ObjectName instance using the path.
makeSnapshotName(long) - Static method in class org.apache.zookeeper.server.persistence.Util
Creates a snapshot file name.
makeURIString(String, String, String) - Static method in class org.apache.zookeeper.server.persistence.Util
 
ManagedUtil - Class in org.apache.zookeeper.jmx
Shared utilities
ManagedUtil() - Constructor for class org.apache.zookeeper.jmx.ManagedUtil
 
Map() - Method in class org.apache.jute.compiler.generated.Rcc
 
MAP_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
MarshallingError - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.MARSHALLINGERROR instead
marshallTxnEntry(TxnHeader, Record) - Static method in class org.apache.zookeeper.server.persistence.Util
Serializes transaction header and transaction data into a byte buffer.
matches(String, String) - Method in interface org.apache.zookeeper.server.auth.AuthenticationProvider
This method is called to see if the given id matches the given id expression in the ACL.
matches(String, String) - Method in class org.apache.zookeeper.server.auth.DigestAuthenticationProvider
 
matches(String, String) - Method in class org.apache.zookeeper.server.auth.IPAuthenticationProvider
 
materialize(Watcher.Event.KeeperState, Watcher.Event.EventType, String) - Method in interface org.apache.zookeeper.ClientWatchManager
Return a set of watchers that should be notified of the event.
maxBuffer - Static variable in class org.apache.jute.BinaryInputArchive
 
maxClientCnxns - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
maxClientCnxns - Variable in class org.apache.zookeeper.server.ServerConfig
 
maxCommittedLog - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
maxNextCharInd - Variable in class org.apache.jute.compiler.generated.SimpleCharStream
 
MBeanRegistry - Class in org.apache.zookeeper.jmx
This class provides a unified interface for registering/unregistering of zookeeper MBeans with the platform MBean server.
MBeanRegistry() - Constructor for class org.apache.zookeeper.jmx.MBeanRegistry
 
me - Static variable in interface org.apache.zookeeper.server.ServerCnxn
 
minCommittedLog - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
Module() - Method in class org.apache.jute.compiler.generated.Rcc
 
MODULE_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
ModuleName() - Method in class org.apache.jute.compiler.generated.Rcc
 

N

newToken(int, String) - Static method in class org.apache.jute.compiler.generated.Token
Returns a new Token object, by default.
newToken(int) - Static method in class org.apache.jute.compiler.generated.Token
 
next - Variable in class org.apache.jute.compiler.generated.Token
A reference to the next regular (non-special) token from the input stream.
next() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog.FileTxnIterator
the iterator that moves to the next transaction
next() - Method in interface org.apache.zookeeper.server.persistence.TxnLog.TxnIterator
go to the next transaction record.
nextElement() - Method in class org.apache.bookkeeper.client.LedgerSequence
 
NIOServerCnxn - Class in org.apache.zookeeper.server
This class handles communication with clients using NIO.
NIOServerCnxn(ZooKeeperServer, SocketChannel, SelectionKey, NIOServerCnxn.Factory) - Constructor for class org.apache.zookeeper.server.NIOServerCnxn
 
NIOServerCnxn.Factory - Class in org.apache.zookeeper.server
 
NIOServerCnxn.Factory(int) - Constructor for class org.apache.zookeeper.server.NIOServerCnxn.Factory
Construct a new server connection factory which will accept an unlimited number of concurrent connections from each client (up to the file descriptor limits of the operating system).
NIOServerCnxn.Factory(int, int) - Constructor for class org.apache.zookeeper.server.NIOServerCnxn.Factory
Constructs a new server connection factory where the number of concurrent connections from a single IP address is limited to maxcc (or unlimited if 0).
NIOServerFactory - Class in org.apache.bookkeeper.proto
This class handles communication with clients using NIO.
NIOServerFactory(int, NIOServerFactory.PacketProcessor) - Constructor for class org.apache.bookkeeper.proto.NIOServerFactory
 
NIOServerFactory.Cnxn - Class in org.apache.bookkeeper.proto
 
NIOServerFactory.Cnxn(SocketChannel, SelectionKey) - Constructor for class org.apache.bookkeeper.proto.NIOServerFactory.Cnxn
 
NIOServerFactory.PacketProcessor - Interface in org.apache.bookkeeper.proto
 
NoAuth - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.NOAUTH instead
NoBookieAvailableException - Static variable in interface org.apache.bookkeeper.client.BKException.Code
 
NoChildrenForEphemerals - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.NOCHILDRENFOREPHEMERALS instead
NodeExists - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.NODEEXISTS instead
NoNode - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.NONODE instead
NoSuchLedgerExistsException - Static variable in interface org.apache.bookkeeper.client.BKException.Code
 
NotEmpty - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.NOTEMPTY instead
NotEnoughBookiesException - Static variable in interface org.apache.bookkeeper.client.BKException.Code
 
notification - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
numGroups - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 

O

OK - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
OK - Static variable in interface org.apache.bookkeeper.client.BKException.Code
 
Ok - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.OK instead
ok - Static variable in class org.apache.zookeeper.server.ZooKeeperServer
 
onTxnLoaded(TxnHeader, Record) - Method in interface org.apache.zookeeper.server.persistence.FileTxnSnapLog.PlayBackListener
 
OPEN_ACL_UNSAFE - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
This is a completely open ACL .
openComplete(int, LedgerHandle, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.OpenCallback
Callback for asynchronous call to open ledger
openLedger(long, byte[]) - Method in class org.apache.bookkeeper.client.BookKeeper
Open existing ledger for reading.
OperationTimeout - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.OPERATIONTIMEOUT instead
opNames - Static variable in class org.apache.zookeeper.ZooDefs
 
org.apache.bookkeeper.bookie - package org.apache.bookkeeper.bookie
 
org.apache.bookkeeper.client - package org.apache.bookkeeper.client
 
org.apache.bookkeeper.proto - package org.apache.bookkeeper.proto
 
org.apache.bookkeeper.streaming - package org.apache.bookkeeper.streaming
 
org.apache.bookkeeper.util - package org.apache.bookkeeper.util
 
org.apache.jute - package org.apache.jute
Hadoop record I/O contains classes and a record description language translator for simplifying serialization and deserialization of records in a language-neutral manner.
org.apache.jute.compiler - package org.apache.jute.compiler
This package contains classes needed for code generation from the hadoop record compiler.
org.apache.jute.compiler.generated - package org.apache.jute.compiler.generated
This package contains code generated by JavaCC from the Hadoop record syntax file rcc.jj.
org.apache.zookeeper - package org.apache.zookeeper
 
org.apache.zookeeper.common - package org.apache.zookeeper.common
 
org.apache.zookeeper.data - package org.apache.zookeeper.data
 
org.apache.zookeeper.jmx - package org.apache.zookeeper.jmx
 
org.apache.zookeeper.proto - package org.apache.zookeeper.proto
 
org.apache.zookeeper.server - package org.apache.zookeeper.server
ZooKeeper server theory of operation
org.apache.zookeeper.server.auth - package org.apache.zookeeper.server.auth
 
org.apache.zookeeper.server.persistence - package org.apache.zookeeper.server.persistence
 
org.apache.zookeeper.server.quorum - package org.apache.zookeeper.server.quorum
 
org.apache.zookeeper.server.quorum.flexible - package org.apache.zookeeper.server.quorum.flexible
 
org.apache.zookeeper.server.upgrade - package org.apache.zookeeper.server.upgrade
 
org.apache.zookeeper.server.util - package org.apache.zookeeper.server.util
 
org.apache.zookeeper.txn - package org.apache.zookeeper.txn
 
org.apache.zookeeper.version - package org.apache.zookeeper.version
 
org.apache.zookeeper.version.util - package org.apache.zookeeper.version.util
 
OutputArchive - Interface in org.apache.jute
Interface that alll the serializers have to implement.

P

packet - Variable in class org.apache.zookeeper.server.quorum.Leader.Proposal
 
packetLen - Static variable in class org.apache.zookeeper.ClientCnxn
 
packetToString(QuorumPacket) - Static method in class org.apache.zookeeper.server.quorum.FollowerHandler
 
padLogFile(FileOutputStream, long, long) - Static method in class org.apache.zookeeper.server.persistence.Util
Grows the file to the specified number of bytes.
parse(String) - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
Parse a ZooKeeper configuration file
parse(String[]) - Method in class org.apache.zookeeper.server.ServerConfig
Parse arguments for server configuration
parse(String) - Method in class org.apache.zookeeper.server.ServerConfig
Parse a ZooKeeper configuration file
ParseException - Exception in org.apache.jute.compiler.generated
This exception is thrown when parse errors are encountered.
ParseException(Token, int[][], String[]) - Constructor for exception org.apache.jute.compiler.generated.ParseException
This constructor is used by the method "generateParseException" in the generated parser.
ParseException() - Constructor for exception org.apache.jute.compiler.generated.ParseException
The following constructors are for use by you for whatever purpose you can think of.
ParseException(String) - Constructor for exception org.apache.jute.compiler.generated.ParseException
Constructor with message.
parseFile(File) - Static method in class org.apache.jute.compiler.generated.Rcc
 
parseProperties(Properties) - Method in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
Parse config from a Properties.
path - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
 
path - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
 
PathTrie - Class in org.apache.zookeeper.common
a class that implements prefix matching for components of a filesystem path.
PathTrie() - Constructor for class org.apache.zookeeper.common.PathTrie
construct a new PathTrie with a root node of /
PathUtils - Class in org.apache.zookeeper.common
Path related utilities
PathUtils() - Constructor for class org.apache.zookeeper.common.PathUtils
 
pendingSyncs - Variable in class org.apache.zookeeper.server.quorum.Leader
 
ping() - Method in class org.apache.zookeeper.server.quorum.FollowerHandler
ping calls from the leader to the followers
ping - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
playLog(InputArchive) - Method in class org.apache.zookeeper.server.upgrade.UpgradeSnapShotV1
play the log from this logstream into the datatree
preAllocSize - Static variable in class org.apache.bookkeeper.bookie.Bookie
 
prefix - Static variable in interface org.apache.bookkeeper.client.BKDefs
String used to construct znode paths.
PrepRequestProcessor - Class in org.apache.zookeeper.server
This request processor is generally at the start of a RequestProcessor change.
PrepRequestProcessor(ZooKeeperServer, RequestProcessor) - Constructor for class org.apache.zookeeper.server.PrepRequestProcessor
 
pRequest(Request) - Method in class org.apache.zookeeper.server.PrepRequestProcessor
This method will be called inside the ProcessRequestThread, which is a singleton, so there will be a single thread calling this code.
prevCharIsCR - Variable in class org.apache.jute.compiler.generated.SimpleCharStream
 
prevCharIsLF - Variable in class org.apache.jute.compiler.generated.SimpleCharStream
 
printMessage(String) - Static method in class org.apache.zookeeper.ZooKeeperMain
 
printUsage() - Static method in class org.apache.zookeeper.Version
 
printWatches - Variable in class org.apache.zookeeper.ZooKeeperMain
 
process(WatchedEvent) - Method in class org.apache.bookkeeper.client.BookKeeper
Watcher method.
process(WatchedEvent) - Method in class org.apache.bookkeeper.util.ClientBase.CountdownWatcher
 
process(WatchedEvent) - Method in class org.apache.bookkeeper.util.ClientBase.NullWatcher
 
process(WatchedEvent) - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
process(WatchedEvent) - Method in interface org.apache.zookeeper.server.ServerCnxn
 
process(WatchedEvent) - Method in interface org.apache.zookeeper.Watcher
 
processAck(long, long, SocketAddress) - Method in class org.apache.zookeeper.server.quorum.Leader
Keep a count of acks that are received by the leader for a particular proposal
processCmd(ZooKeeperMain.MyCommandOptions) - Method in class org.apache.zookeeper.ZooKeeperMain
 
processPacket(ByteBuffer, NIOServerFactory.Cnxn) - Method in class org.apache.bookkeeper.proto.BookieServer
 
processPacket(ByteBuffer, NIOServerFactory.Cnxn) - Method in interface org.apache.bookkeeper.proto.NIOServerFactory.PacketProcessor
 
processRequest(Request) - Method in class org.apache.zookeeper.server.FinalRequestProcessor
 
processRequest(Request) - Method in class org.apache.zookeeper.server.PrepRequestProcessor
 
processRequest(Request) - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
 
processRequest(Request) - Method in class org.apache.zookeeper.server.quorum.FollowerRequestProcessor
 
processRequest(Request) - Method in class org.apache.zookeeper.server.quorum.ProposalRequestProcessor
 
processRequest(Request) - Method in class org.apache.zookeeper.server.quorum.SendAckRequestProcessor
 
processRequest(Request) - Method in interface org.apache.zookeeper.server.RequestProcessor
 
processRequest(Request) - Method in class org.apache.zookeeper.server.SyncRequestProcessor
 
processResult(int, String, Object, Stat) - Method in class org.apache.bookkeeper.client.LedgerManagementProcessor
Implements org.apache.zookeeper.AsyncCallback.StatCallback
processResult(int, String, Object, String) - Method in class org.apache.bookkeeper.client.LedgerManagementProcessor
Implements org.apache.zookeeper.AsyncCallback.StringCallback
processResult(int, String, Object, List<String>) - Method in class org.apache.bookkeeper.client.LedgerManagementProcessor
Implement org.apache.zookeeper.AsyncCallback.ChildrenCallback
processResult(int, String, Object, byte[], Stat) - Method in class org.apache.bookkeeper.client.LedgerManagementProcessor
Implement org.apache.zookeeper.AsyncCallback.DataCallback
processResult(int, String, Object, List<ACL>, Stat) - Method in interface org.apache.zookeeper.AsyncCallback.ACLCallback
 
processResult(int, String, Object, List<String>) - Method in interface org.apache.zookeeper.AsyncCallback.ChildrenCallback
 
processResult(int, String, Object, byte[], Stat) - Method in interface org.apache.zookeeper.AsyncCallback.DataCallback
 
processResult(int, String, Object, Stat) - Method in interface org.apache.zookeeper.AsyncCallback.StatCallback
 
processResult(int, String, Object, String) - Method in interface org.apache.zookeeper.AsyncCallback.StringCallback
 
processResult(int, String, Object) - Method in interface org.apache.zookeeper.AsyncCallback.VoidCallback
 
processSync(FollowerSyncRequest) - Method in class org.apache.zookeeper.server.quorum.Leader
Process sync requests
processTxn(TxnHeader, Record) - Method in class org.apache.zookeeper.server.DataTree
 
processTxn(TxnHeader, Record) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
processZKCmd(ZooKeeperMain.MyCommandOptions) - Method in class org.apache.zookeeper.ZooKeeperMain
 
procZookeeper - Static variable in class org.apache.zookeeper.Quotas
the zookeeper nodes that acts as the management and status node
profile(Profiler.Operation<T>, long, String) - Static method in class org.apache.zookeeper.server.util.Profiler
 
Profiler - Class in org.apache.zookeeper.server.util
 
Profiler() - Constructor for class org.apache.zookeeper.server.util.Profiler
 
Profiler.Operation<T> - Interface in org.apache.zookeeper.server.util
 
PROPOSAL - Static variable in class org.apache.zookeeper.server.quorum.Leader
This message type is sent by a leader to propose a mutation.
ProposalRequestProcessor - Class in org.apache.zookeeper.server.quorum
This RequestProcessor simply forwards requests to an AckRequestProcessor and SyncRequestProcessor.
ProposalRequestProcessor(LeaderZooKeeperServer, RequestProcessor) - Constructor for class org.apache.zookeeper.server.quorum.ProposalRequestProcessor
 
propose(Request) - Method in class org.apache.zookeeper.server.quorum.Leader
create a proposal and send it out to all the members
ProviderRegistry - Class in org.apache.zookeeper.server.auth
 
ProviderRegistry() - Constructor for class org.apache.zookeeper.server.auth.ProviderRegistry
 
purge(File, File, int) - Static method in class org.apache.zookeeper.server.PurgeTxnLog
purges the snapshot and logs keeping the last num snapshots and the corresponding logs.
PurgeTxnLog - Class in org.apache.zookeeper.server
this class is used to clean up the snapshot and data log dir's.
PurgeTxnLog() - Constructor for class org.apache.zookeeper.server.PurgeTxnLog
 

Q

QuorumBean - Class in org.apache.zookeeper.server.quorum
 
QuorumBean(QuorumPeer) - Constructor for class org.apache.zookeeper.server.quorum.QuorumBean
 
QuorumCnxManager - Class in org.apache.zookeeper.server.quorum
This class implements a connection manager for leader election using TCP.
QuorumCnxManager(QuorumPeer) - Constructor for class org.apache.zookeeper.server.quorum.QuorumCnxManager
 
QuorumCnxManager.Listener - Class in org.apache.zookeeper.server.quorum
Thread to listen on some port
QuorumCnxManager.Listener() - Constructor for class org.apache.zookeeper.server.quorum.QuorumCnxManager.Listener
 
QuorumCnxManager.Message - Class in org.apache.zookeeper.server.quorum
 
QuorumEngine - Class in org.apache.bookkeeper.client
Implements the quorum protocol.It basically handles requests coming from BookKeeper and forward to the appropriate BookieHandle objects.
QuorumEngine(LedgerHandle) - Constructor for class org.apache.bookkeeper.client.QuorumEngine
 
QuorumEngine.Operation - Class in org.apache.bookkeeper.client
 
QuorumEngine.Operation() - Constructor for class org.apache.bookkeeper.client.QuorumEngine.Operation
 
QuorumEngine.Operation.AddOp - Class in org.apache.bookkeeper.client
 
QuorumEngine.Operation.AddOp(LedgerHandle, byte[], AsyncCallback.AddCallback, Object) - Constructor for class org.apache.bookkeeper.client.QuorumEngine.Operation.AddOp
 
QuorumEngine.Operation.ReadOp - Class in org.apache.bookkeeper.client
 
QuorumEngine.Operation.ReadOp(LedgerHandle, long, long, AsyncCallback.ReadCallback, Object) - Constructor for class org.apache.bookkeeper.client.QuorumEngine.Operation.ReadOp
 
QuorumEngine.Operation.StopOp - Class in org.apache.bookkeeper.client
 
QuorumEngine.Operation.StopOp() - Constructor for class org.apache.bookkeeper.client.QuorumEngine.Operation.StopOp
 
QuorumEngine.SubOp - Class in org.apache.bookkeeper.client
 
QuorumEngine.SubOp() - Constructor for class org.apache.bookkeeper.client.QuorumEngine.SubOp
 
QuorumEngine.SubOp.SubAddOp - Class in org.apache.bookkeeper.client
 
QuorumEngine.SubOp.SubReadOp - Class in org.apache.bookkeeper.client
 
QuorumEngine.SubOp.SubStopOp - Class in org.apache.bookkeeper.client
 
quorumEvolution - Static variable in interface org.apache.bookkeeper.client.BKDefs
 
QuorumException - Static variable in interface org.apache.bookkeeper.client.BKException.Code
 
QuorumHierarchical - Class in org.apache.zookeeper.server.quorum.flexible
This class implements a validator for hierarchical quorums.
QuorumHierarchical(String) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
This contructor requires the quorum configuration to be declared in a separate file, and it takes the file as an input parameter.
QuorumHierarchical(Properties) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
This constructor takes a set of properties.
QuorumHierarchical(int, HashMap<Long, Long>, HashMap<Long, Long>) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumHierarchical
This contructor takes the two hash maps needed to enable validating quorums.
QuorumMaj - Class in org.apache.zookeeper.server.quorum.flexible
This class implements a validator for majority quorums.
QuorumMaj(int) - Constructor for class org.apache.zookeeper.server.quorum.flexible.QuorumMaj
Defines a majority to avoid computing it every time.
quorumMode - Static variable in interface org.apache.bookkeeper.client.BKDefs
 
QuorumMXBean - Interface in org.apache.zookeeper.server.quorum
An MBean representing a zookeeper cluster nodes (aka quorum peers)
QuorumOpMonitor - Class in org.apache.bookkeeper.client
Monitors reponses from bookies to requests of a client.
QuorumOpMonitor.PendingOp - Class in org.apache.bookkeeper.client
 
QuorumOpMonitor.PendingReadOp - Class in org.apache.bookkeeper.client
Objects of this type are used to keep track of the status of a given read request.
QuorumPeer - Class in org.apache.zookeeper.server.quorum
This class manages the quorum protocol.
QuorumPeer() - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
 
QuorumPeer(Map<Long, QuorumPeer.QuorumServer>, File, File, int, long, int, int, int, NIOServerCnxn.Factory) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
For backward compatibility purposes, we instantiate QuorumMaj by default.
QuorumPeer(Map<Long, QuorumPeer.QuorumServer>, File, File, int, long, int, int, int, NIOServerCnxn.Factory, QuorumVerifier) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
 
QuorumPeer(Map<Long, QuorumPeer.QuorumServer>, File, File, int, int, long, int, int, int) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
This constructor is only used by the existing unit test code.
QuorumPeer(Map<Long, QuorumPeer.QuorumServer>, File, File, int, int, long, int, int, int, QuorumVerifier) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer
This constructor is only used by the existing unit test code.
QuorumPeer.Factory - Interface in org.apache.zookeeper.server.quorum
Create an instance of a quorum peer
QuorumPeer.QuorumServer - Class in org.apache.zookeeper.server.quorum
 
QuorumPeer.QuorumServer(long, InetSocketAddress, InetSocketAddress) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
QuorumPeer.QuorumServer(long, InetSocketAddress) - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeer.QuorumServer
 
QuorumPeer.ServerState - Enum in org.apache.zookeeper.server.quorum
 
QuorumPeerConfig - Class in org.apache.zookeeper.server.quorum
 
QuorumPeerConfig() - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
QuorumPeerConfig.ConfigException - Exception in org.apache.zookeeper.server.quorum
 
QuorumPeerConfig.ConfigException(String) - Constructor for exception org.apache.zookeeper.server.quorum.QuorumPeerConfig.ConfigException
 
QuorumPeerConfig.ConfigException(String, Exception) - Constructor for exception org.apache.zookeeper.server.quorum.QuorumPeerConfig.ConfigException
 
QuorumPeerMain - Class in org.apache.zookeeper.server.quorum
Configuration file
QuorumPeerMain() - Constructor for class org.apache.zookeeper.server.quorum.QuorumPeerMain
 
quorumSize - Static variable in interface org.apache.bookkeeper.client.BKDefs
 
QuorumStats - Class in org.apache.zookeeper.server.quorum
 
QuorumStats(QuorumStats.Provider) - Constructor for class org.apache.zookeeper.server.quorum.QuorumStats
 
QuorumStats.Provider - Interface in org.apache.zookeeper.server.quorum
 
QuorumVerifier - Interface in org.apache.zookeeper.server.quorum.flexible
All quorum validators have to implement a method called containsQuorum, which verifies if a HashSet of server identifiers constitutes a quorum.
quorumVerifier - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
quotaPath(String) - Static method in class org.apache.zookeeper.Quotas
return the quota path associated with this prefix
Quotas - Class in org.apache.zookeeper
this class manages quotas and has many other utils for quota
Quotas() - Constructor for class org.apache.zookeeper.Quotas
 
quotaZookeeper - Static variable in class org.apache.zookeeper.Quotas
the zookeeper quota node that acts as the quota management node for zookeeper

R

RBRACE_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
Rcc - Class in org.apache.jute.compiler.generated
 
Rcc(InputStream) - Constructor for class org.apache.jute.compiler.generated.Rcc
Constructor with InputStream.
Rcc(InputStream, String) - Constructor for class org.apache.jute.compiler.generated.Rcc
Constructor with InputStream and supplied encoding
Rcc(Reader) - Constructor for class org.apache.jute.compiler.generated.Rcc
Constructor.
Rcc(RccTokenManager) - Constructor for class org.apache.jute.compiler.generated.Rcc
Constructor with generated Token Manager.
RccConstants - Interface in org.apache.jute.compiler.generated
Token literal values and constants.
RccTokenManager - Class in org.apache.jute.compiler.generated
Token Manager.
RccTokenManager(SimpleCharStream) - Constructor for class org.apache.jute.compiler.generated.RccTokenManager
Constructor.
RccTokenManager(SimpleCharStream, int) - Constructor for class org.apache.jute.compiler.generated.RccTokenManager
Constructor.
READ - Static variable in interface org.apache.bookkeeper.client.BKDefs
 
READ - Static variable in class org.apache.bookkeeper.client.QuorumEngine.Operation
 
read() - Method in class org.apache.bookkeeper.streaming.LedgerInputStream
 
read(byte[]) - Method in class org.apache.bookkeeper.streaming.LedgerInputStream
 
read(byte[], int, int) - Method in class org.apache.bookkeeper.streaming.LedgerInputStream
 
read(Record) - Method in class org.apache.jute.RecordReader
Deserialize a record
read() - Method in class org.apache.zookeeper.server.ByteBufferInputStream
 
read(byte[], int, int) - Method in class org.apache.zookeeper.server.ByteBufferInputStream
 
read(byte[]) - Method in class org.apache.zookeeper.server.ByteBufferInputStream
 
read(long) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
start reading all the transactions from the given zxid
read(long) - Method in interface org.apache.zookeeper.server.persistence.TxnLog
Start reading the transaction logs from a given zxid
READ - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
 
READ_ACL_UNSAFE - Static variable in interface org.apache.zookeeper.ZooDefs.Ids
This ACL gives the world the ability to read.
readBool(String) - Method in class org.apache.jute.BinaryInputArchive
 
readBool(String) - Method in interface org.apache.jute.InputArchive
 
readBuffer(String) - Method in class org.apache.jute.BinaryInputArchive
 
readBuffer(String) - Method in interface org.apache.jute.InputArchive
 
readByte(String) - Method in class org.apache.jute.BinaryInputArchive
 
readByte(String) - Method in interface org.apache.jute.InputArchive
 
readChar() - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Read a character.
readComplete(int, LedgerHandle, LedgerSequence, Object) - Method in interface org.apache.bookkeeper.client.AsyncCallback.ReadCallback
Callback declaration
readComplete(int, LedgerHandle, LedgerSequence, Object) - Method in class org.apache.bookkeeper.client.LedgerHandle
Implementation of callback interface for synchronous read method.
readDouble(String) - Method in class org.apache.jute.BinaryInputArchive
 
readDouble(String) - Method in interface org.apache.jute.InputArchive
 
readEntries(long, long) - Method in class org.apache.bookkeeper.client.LedgerHandle
Read a sequence of entries synchronously.
readEntry(long, long) - Method in class org.apache.bookkeeper.bookie.Bookie
 
readEntry(long, long, ReadEntryCallback, Object) - Method in class org.apache.bookkeeper.proto.BookieClient
Send readEntry operation to bookie.
READENTRY - Static variable in interface org.apache.bookkeeper.proto.BookieProtocol
The Read entry request payload will be the ledger number and entry number to read.
ReadEntryCallback - Interface in org.apache.bookkeeper.proto
Declaration of a callback implementation for calls from BookieClient objects.
readEntryComplete(int, long, long, ByteBuffer, Object) - Method in class org.apache.bookkeeper.client.QuorumOpMonitor
Callback method for read operations.
readEntryComplete(int, long, long, ByteBuffer, Object) - Method in interface org.apache.bookkeeper.proto.ReadEntryCallback
 
ReadException - Static variable in interface org.apache.bookkeeper.client.BKException.Code
 
readFloat(String) - Method in class org.apache.jute.BinaryInputArchive
 
readFloat(String) - Method in interface org.apache.jute.InputArchive
 
readFrom(QuorumPeerConfig) - Method in class org.apache.zookeeper.server.ServerConfig
Read attributes from a QuorumPeerConfig.
readInt(String) - Method in class org.apache.jute.BinaryInputArchive
 
readInt(String) - Method in interface org.apache.jute.InputArchive
 
readLong(String) - Method in class org.apache.jute.BinaryInputArchive
 
readLong(String) - Method in interface org.apache.jute.InputArchive
 
readRecord(Record, String) - Method in class org.apache.jute.BinaryInputArchive
 
readRecord(Record, String) - Method in interface org.apache.jute.InputArchive
 
readString(String) - Method in class org.apache.jute.BinaryInputArchive
 
readString(String) - Method in interface org.apache.jute.InputArchive
 
readTxnBytes(InputArchive) - Static method in class org.apache.zookeeper.server.persistence.Util
Reads a transaction entry from the input archive.
Record() - Method in class org.apache.jute.compiler.generated.Rcc
 
Record - Interface in org.apache.jute
Interface that is implemented by generated classes.
RECORD_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
RecordList() - Method in class org.apache.jute.compiler.generated.Rcc
 
RecordReader - Class in org.apache.jute
Front-end interface to deserializers.
RecordReader(InputStream, String) - Constructor for class org.apache.jute.RecordReader
Creates a new instance of RecordReader.
RecordWriter - Class in org.apache.jute
Front-end for serializers.
RecordWriter(OutputStream, String) - Constructor for class org.apache.jute.RecordWriter
Creates a new instance of RecordWriter
recvQueue - Variable in class org.apache.zookeeper.server.quorum.QuorumCnxManager
 
register(ZKMBeanInfo, ZKMBeanInfo) - Method in class org.apache.zookeeper.jmx.MBeanRegistry
Registers a new MBean with the platform MBean server.
register(Watcher) - Method in class org.apache.zookeeper.ZooKeeper
Specify the default watcher for the connection (overrides the one specified during construction).
registerAsConcrete() - Static method in class org.apache.bookkeeper.proto.ServerStats
 
registerJMX() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
registerJMX(FollowerBean, LocalPeerBean) - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
registerJMX() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
registerJMX(LeaderBean, LocalPeerBean) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
registerJMX() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
registerLog4jMBeans() - Static method in class org.apache.zookeeper.jmx.ManagedUtil
Register the log4j JMX mbeans.
ReInit(InputStream) - Method in class org.apache.jute.compiler.generated.Rcc
Reinitialise.
ReInit(InputStream, String) - Method in class org.apache.jute.compiler.generated.Rcc
Reinitialise.
ReInit(Reader) - Method in class org.apache.jute.compiler.generated.Rcc
Reinitialise.
ReInit(RccTokenManager) - Method in class org.apache.jute.compiler.generated.Rcc
Reinitialise.
ReInit(SimpleCharStream) - Method in class org.apache.jute.compiler.generated.RccTokenManager
Reinitialise parser.
ReInit(SimpleCharStream, int) - Method in class org.apache.jute.compiler.generated.RccTokenManager
Reinitialise parser.
ReInit(Reader, int, int, int) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Reinitialise.
ReInit(Reader, int, int) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Reinitialise.
ReInit(Reader) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Reinitialise.
ReInit(InputStream, String, int, int, int) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Reinitialise.
ReInit(InputStream, int, int, int) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Reinitialise.
ReInit(InputStream, String) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Reinitialise.
ReInit(InputStream) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Reinitialise.
ReInit(InputStream, String, int, int) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Reinitialise.
ReInit(InputStream, int, int) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
Reinitialise.
RemotePeerBean - Class in org.apache.zookeeper.server.quorum
A remote peer bean only provides limited information about the remote peer, and the peer cannot be managed remotely.
RemotePeerBean(QuorumPeer.QuorumServer) - Constructor for class org.apache.zookeeper.server.quorum.RemotePeerBean
 
RemotePeerMXBean - Interface in org.apache.zookeeper.server.quorum
A proxy for a remote quorum peer.
removeCnxn(Watcher) - Method in class org.apache.zookeeper.server.DataTree
 
removeCnxn(Watcher) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
removeSession(long) - Method in class org.apache.zookeeper.server.quorum.FollowerSessionTracker
 
removeSession(long) - Method in interface org.apache.zookeeper.server.SessionTracker
 
removeSession(long) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
removeWatcher(Watcher) - Method in class org.apache.zookeeper.server.WatchManager
 
reopenSession(ServerCnxn, long, byte[], int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
reqsCmd - Static variable in interface org.apache.zookeeper.server.ServerCnxn
 
request - Variable in class org.apache.zookeeper.server.quorum.Leader.Proposal
 
Request - Class in org.apache.zookeeper.server
This is the structure that represents a request moving through a chain of RequestProcessors.
Request(ServerCnxn, long, int, int, ByteBuffer, List<Id>) - Constructor for class org.apache.zookeeper.server.Request
 
request - Variable in class org.apache.zookeeper.server.Request
 
requestOfDeath - Static variable in class org.apache.zookeeper.server.Request
 
RequestProcessor - Interface in org.apache.zookeeper.server
RequestProcessors are chained together to process transactions.
reset() - Method in class org.apache.zookeeper.server.ServerStats
 
resetLatency() - Method in class org.apache.bookkeeper.proto.ServerStats
 
resetLatency() - Method in class org.apache.zookeeper.server.ServerStats
 
resetLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
resetLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
Reset min/avg/max latency statistics
resetMaxLatency() - Method in class org.apache.bookkeeper.proto.ServerStats
 
resetMaxLatency() - Method in class org.apache.zookeeper.server.ServerStats
 
resetMaxLatency() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
resetMaxLatency() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
Reset max latency statistics only.
resetRequestCounters() - Method in class org.apache.bookkeeper.proto.ServerStats
 
resetRequestCounters() - Method in class org.apache.zookeeper.server.ServerStats
 
resetStatistics() - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
resetStatistics() - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
Reset packet and latency statistics
restore(DataTree, Map<Long, Integer>, FileTxnSnapLog.PlayBackListener) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
this function restors the server database after reading from the snapshots and transaction logs
revalidateSession(ServerCnxn, long, int) - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
revalidateSession(ServerCnxn, long, int) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
revalidateSession(ServerCnxn, long, int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
rollLog() - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
rollover the current log file to a new one.
rollLog() - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
roll the transaction logs
rollLog() - Method in interface org.apache.zookeeper.server.persistence.TxnLog
roll the current log being appended to
run() - Method in class org.apache.bookkeeper.bookie.Bookie
 
run() - Method in class org.apache.bookkeeper.client.BookieHandle
 
run() - Method in class org.apache.bookkeeper.client.LedgerManagementProcessor
Run method
run() - Method in class org.apache.bookkeeper.proto.BookieClient
 
run() - Method in class org.apache.bookkeeper.proto.NIOServerFactory
 
run() - Method in class org.apache.zookeeper.server.NIOServerCnxn.Factory
 
run() - Method in class org.apache.zookeeper.server.PrepRequestProcessor
 
run() - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
 
run() - Method in class org.apache.zookeeper.server.quorum.FollowerHandler
This thread will receive packets from the follower and process them and also listen to new connections from new followers.
run() - Method in class org.apache.zookeeper.server.quorum.FollowerRequestProcessor
 
run() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager.Listener
Sleeps on accept().
run() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
run() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
run() - Method in class org.apache.zookeeper.server.SyncRequestProcessor
 
runFromConfig(QuorumPeerConfig) - Method in class org.apache.zookeeper.server.quorum.QuorumPeerMain
 
runFromConfig(ServerConfig) - Method in class org.apache.zookeeper.server.ZooKeeperServerMain
Run from a ServerConfig.
running - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
RuntimeInconsistency - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.RUNTIMEINCONSISTENCY instead
runUpgrade() - Method in class org.apache.zookeeper.server.upgrade.UpgradeMain
run the upgrade
ruok(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
 
ruokCmd - Static variable in interface org.apache.zookeeper.server.ServerCnxn
See Zk Admin.

S

save(DataTree, ConcurrentHashMap<Long, Integer>) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
save the datatree and the sessions into a snapshot
SEMICOLON_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
SendAckRequestProcessor - Class in org.apache.zookeeper.server.quorum
 
sendAdd(LedgerHandle, QuorumEngine.SubOp.SubAddOp, long) - Method in class org.apache.bookkeeper.client.BookieHandle
Sending add operation to bookie.
sendRead(LedgerHandle, QuorumEngine.SubOp.SubReadOp, long) - Method in class org.apache.bookkeeper.client.BookieHandle
Sending read operation to bookie
sendResponse(ByteBuffer[]) - Method in class org.apache.bookkeeper.proto.NIOServerFactory.Cnxn
 
sendResponse(ReplyHeader, Record, String) - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
sendResponse(ReplyHeader, Record, String) - Method in interface org.apache.zookeeper.server.ServerCnxn
 
sendSync(FollowerSyncRequest) - Method in class org.apache.zookeeper.server.quorum.Leader
Sends a sync message to the appropriate server
serialize(OutputArchive, String) - Method in interface org.apache.jute.Record
 
serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.DataNode
 
serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.DataTree
 
serialize(DataTree, Map<Long, Integer>, OutputArchive, FileHeader) - Method in class org.apache.zookeeper.server.persistence.FileSnap
serialize the datatree and sessions
serialize(DataTree, Map<Long, Integer>, File) - Method in class org.apache.zookeeper.server.persistence.FileSnap
serialize the datatree and session into the file snapshot
serialize(DataTree, Map<Long, Integer>, File) - Method in interface org.apache.zookeeper.server.persistence.SnapShot
persist the datatree and the sessions into a persistence storage
serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.upgrade.DataNodeV1
 
serialize(OutputArchive, String) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
serializeSnapshot(DataTree, OutputArchive, Map<Long, Integer>) - Static method in class org.apache.zookeeper.server.util.SerializeUtils
 
serializeSnapshot(OutputArchive) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
SerializeUtils - Class in org.apache.zookeeper.server.util
 
SerializeUtils() - Constructor for class org.apache.zookeeper.server.util.SerializeUtils
 
SERVER_PACKET_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
SERVER_PING_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
ServerAdminClient - Class in org.apache.zookeeper
 
ServerAdminClient() - Constructor for class org.apache.zookeeper.ServerAdminClient
 
ServerBean - Class in org.apache.zookeeper.server.quorum
An abstract base class for the leader and follower MBeans.
ServerBean() - Constructor for class org.apache.zookeeper.server.quorum.ServerBean
 
ServerCnxn - Interface in org.apache.zookeeper.server
 
ServerCnxn.Stats - Interface in org.apache.zookeeper.server
 
ServerConfig - Class in org.apache.zookeeper.server
Server configuration storage.
ServerConfig() - Constructor for class org.apache.zookeeper.server.ServerConfig
 
serverFactory - Variable in class org.apache.bookkeeper.util.ClientBase
 
serverGroup - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
serverId - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
ServerMXBean - Interface in org.apache.zookeeper.server.quorum
A quorum server MBean.
servers - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
ServerStats - Class in org.apache.bookkeeper.proto
 
ServerStats() - Constructor for class org.apache.bookkeeper.proto.ServerStats
 
ServerStats - Class in org.apache.zookeeper.server
Basic Server Statistics
ServerStats(ServerStats.Provider) - Constructor for class org.apache.zookeeper.server.ServerStats
 
serverStats() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
ServerStats.Provider - Interface in org.apache.bookkeeper.proto
 
ServerStats.Provider - Interface in org.apache.zookeeper.server
 
serverWeight - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
SESSION_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
SessionExpired - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.SESSIONEXPIRED instead
sessionId - Variable in class org.apache.zookeeper.server.Request
 
sessionsWithTimeouts - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
SessionTracker - Interface in org.apache.zookeeper.server
This is the basic interface that ZooKeeperServer uses to track sessions.
sessionTracker - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
SessionTracker.SessionExpirer - Interface in org.apache.zookeeper.server
 
SessionTrackerImpl - Class in org.apache.zookeeper.server
This is a full featured SessionTracker.
SessionTrackerImpl(SessionTracker.SessionExpirer, ConcurrentHashMap<Long, Integer>, int, long) - Constructor for class org.apache.zookeeper.server.SessionTrackerImpl
 
SessionTrackerImpl.Session - Class in org.apache.zookeeper.server
 
setACL(String, List<ACL>, int) - Method in class org.apache.zookeeper.server.DataTree
 
setACL(String, List<ACL>, int) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
setACL - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
setACL(String, List<ACL>, int) - Method in class org.apache.zookeeper.ZooKeeper
Set the ACL for the node of the given path if such a node exists and the given version matches the version of the node.
setACL(String, List<ACL>, int, AsyncCallback.StatCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The Asynchronous version of setACL.
setBytes(long) - Method in class org.apache.zookeeper.StatsTrack
set teh bytes for this stat tracker.
setChildren(HashSet<String>) - Method in class org.apache.zookeeper.server.DataNode
convenience method for creating DataNode fully
setChildren(HashSet<String>) - Method in class org.apache.zookeeper.server.upgrade.DataNodeV1
convenience method for creating DataNode fully
setClientPort(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setCnxnFactory(NIOServerCnxn.Factory) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setCode(int) - Method in exception org.apache.bookkeeper.bookie.BookieException
 
setCode(int) - Method in exception org.apache.bookkeeper.client.BKException
 
setCode(int) - Method in exception org.apache.zookeeper.KeeperException
Deprecated. deprecated in 3.1.0, exceptions should be immutable, this method should not be used
setCount(int) - Method in class org.apache.zookeeper.StatsTrack
set the count for this stat tracker.
setCurrentVote(Vote) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setData(String, byte[], int, long, long) - Method in class org.apache.zookeeper.server.DataTree
 
setData(String, byte[], int, long, long) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
setData - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
setData(String, byte[], int) - Method in class org.apache.zookeeper.ZooKeeper
Set the data for the node of the given path if such a node exists and the given version matches the version of the node (if the given version is -1, it matches any node's versions).
setData(String, byte[], int, AsyncCallback.StatCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
The Asynchronous version of setData.
setDebugStream(PrintStream) - Method in class org.apache.jute.compiler.generated.RccTokenManager
Set debug output.
setDisableAutoResetWatch(boolean) - Static method in class org.apache.zookeeper.ClientCnxn
tests use this to set the auto reset
setElectionType(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Sets the election type
setEphemerals(Map<Long, HashSet<String>>) - Method in class org.apache.zookeeper.server.DataTree
 
setEphemeralsMap(Map<Long, HashSet<String>>) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
setException(KeeperException) - Method in class org.apache.zookeeper.server.Request
 
setFailCreate(boolean) - Static method in class org.apache.zookeeper.server.PrepRequestProcessor
method for tests to set failCreate
setFollower(Follower) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setInitLimit(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Set the number of ticks that the initial synchronization phase can take
setInstance(ServerStats) - Static method in class org.apache.bookkeeper.proto.ServerStats
 
setLeader(Leader) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setMyid(long) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
set the id of this quorum peer.
setOwner(long, Object) - Method in class org.apache.zookeeper.server.quorum.FollowerSessionTracker
 
setOwner(Object) - Method in class org.apache.zookeeper.server.Request
 
setOwner(long, Object) - Method in interface org.apache.zookeeper.server.SessionTracker
 
setOwner(long, Object) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
setOwner(long, Object) - Method in class org.apache.zookeeper.server.ZooKeeperServer
set the owner of this session as owner
setPeerState(QuorumPeer.ServerState) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setPreallocSize(long) - Static method in class org.apache.zookeeper.server.persistence.FileTxnLog
method to allow setting preallocate size of log file to pad the file.
setQuorumPeers(Map<Long, QuorumPeer.QuorumServer>) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setQuorumVerifier(QuorumVerifier) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setServerCnxnFactory(NIOServerCnxn.Factory) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
setSessionId(long) - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
setSessionId(long) - Method in interface org.apache.zookeeper.server.ServerCnxn
 
setSnapCount(int) - Static method in class org.apache.zookeeper.server.SyncRequestProcessor
used by tests to check for changing snapcounts
setStatsProvider(ServerStats.Provider) - Method in class org.apache.bookkeeper.proto.ServerStats
 
setSyncLimit(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Set the number of ticks that can pass between sending a request and getting an acknowledgement
setTabSize(int) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
 
setTextTraceLevel(long) - Static method in class org.apache.zookeeper.server.ZooTrace
 
setTickTime(int) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
Set the number of milliseconds of each tick
setTickTime(int) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
setTickTime(int) - Method in class org.apache.zookeeper.server.ZooKeeperServerBean
 
setTickTime(int) - Method in interface org.apache.zookeeper.server.ZooKeeperServerMXBean
Set TickTime of server
setTraceMask(String, int, String) - Static method in class org.apache.zookeeper.ServerAdminClient
 
setTraceMaskCmd - Static variable in interface org.apache.zookeeper.server.ServerCnxn
 
setTreeBuilder(ZooKeeperServer.DataTreeBuilder) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
setTxnFactory(FileTxnSnapLog) - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
setTxnLogFactory(FileTxnSnapLog) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
setUp() - Method in class org.apache.bookkeeper.util.ClientBase
 
setupRequestProcessors() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
setupRequestProcessors() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
setupRequestProcessors() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
setupTestEnv() - Static method in class org.apache.bookkeeper.util.ClientBase
Test specific setup
setWatches(long, List<String>, List<String>, List<String>, Watcher) - Method in class org.apache.zookeeper.server.DataTree
 
setWatches - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
setZooKeeperServer(ZooKeeperServer) - Method in class org.apache.zookeeper.server.NIOServerCnxn.Factory
 
setZxid(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
shutdown() - Method in class org.apache.bookkeeper.bookie.Bookie
 
shutdown() - Method in class org.apache.bookkeeper.client.BookieHandle
Stop this bookie handle completely.
shutdown() - Method in class org.apache.bookkeeper.proto.BookieServer
 
shutdown() - Method in class org.apache.bookkeeper.proto.NIOServerFactory
 
shutdown() - Method in class org.apache.zookeeper.server.FinalRequestProcessor
 
shutdown() - Method in class org.apache.zookeeper.server.NIOServerCnxn.Factory
 
shutdown() - Method in class org.apache.zookeeper.server.PrepRequestProcessor
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.CommitProcessor
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.FastLeaderElection
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.Follower
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.FollowerHandler
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.FollowerRequestProcessor
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.FollowerSessionTracker
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.ProposalRequestProcessor
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.QuorumPeerMain
 
shutdown() - Method in class org.apache.zookeeper.server.quorum.SendAckRequestProcessor
 
shutdown() - Method in interface org.apache.zookeeper.server.RequestProcessor
 
shutdown() - Method in interface org.apache.zookeeper.server.SessionTracker
 
shutdown() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
shutdown() - Method in class org.apache.zookeeper.server.SyncRequestProcessor
 
shutdown() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
shutdown() - Method in class org.apache.zookeeper.server.ZooKeeperServerMain
Shutdown the serving instance
sid - Variable in class org.apache.zookeeper.server.quorum.FollowerHandler
ZooKeeper server identifier of this follower
SimpleCharStream - Class in org.apache.jute.compiler.generated
An implementation of interface CharStream, where the stream is assumed to contain only ASCII characters (without unicode processing).
SimpleCharStream(Reader, int, int, int) - Constructor for class org.apache.jute.compiler.generated.SimpleCharStream
Constructor.
SimpleCharStream(Reader, int, int) - Constructor for class org.apache.jute.compiler.generated.SimpleCharStream
Constructor.
SimpleCharStream(Reader) - Constructor for class org.apache.jute.compiler.generated.SimpleCharStream
Constructor.
SimpleCharStream(InputStream, String, int, int, int) - Constructor for class org.apache.jute.compiler.generated.SimpleCharStream
Constructor.
SimpleCharStream(InputStream, int, int, int) - Constructor for class org.apache.jute.compiler.generated.SimpleCharStream
Constructor.
SimpleCharStream(InputStream, String, int, int) - Constructor for class org.apache.jute.compiler.generated.SimpleCharStream
Constructor.
SimpleCharStream(InputStream, int, int) - Constructor for class org.apache.jute.compiler.generated.SimpleCharStream
Constructor.
SimpleCharStream(InputStream, String) - Constructor for class org.apache.jute.compiler.generated.SimpleCharStream
Constructor.
SimpleCharStream(InputStream) - Constructor for class org.apache.jute.compiler.generated.SimpleCharStream
Constructor.
size() - Method in class org.apache.bookkeeper.client.LedgerSequence
 
size() - Method in class org.apache.zookeeper.server.WatchManager
 
skip(long) - Method in class org.apache.zookeeper.server.ByteBufferInputStream
 
SNAP_MAGIC - Static variable in class org.apache.zookeeper.server.persistence.FileSnap
 
SnapShot - Interface in org.apache.zookeeper.server.persistence
snapshot interface for the persistence layer.
sock - Variable in class org.apache.zookeeper.server.quorum.Follower
 
sock - Variable in class org.apache.zookeeper.server.quorum.FollowerHandler
 
softHalt() - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
A soft halt simply finishes workers.
sortDataDir(File[], String, boolean) - Static method in class org.apache.zookeeper.server.persistence.Util
Sort the list of files.
specialToken - Variable in class org.apache.jute.compiler.generated.Token
This field is used to access special tokens that occur prior to this token, but after the immediately preceding regular (non-special) token.
srstCmd - Static variable in interface org.apache.zookeeper.server.ServerCnxn
 
STANDALONE_SERVER_KEY - Static variable in class org.apache.zookeeper.jmx.CommonNames
 
start() - Method in class org.apache.bookkeeper.proto.BookieServer
 
start() - Method in class org.apache.zookeeper.ClientCnxn
 
start() - Method in class org.apache.zookeeper.server.NIOServerCnxn.Factory
 
start() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
startConnection(InetSocketAddress, int) - Method in class org.apache.bookkeeper.proto.BookieClient
 
startForwarding(FollowerHandler, long) - Method in class org.apache.zookeeper.server.quorum.Leader
lets the leader know that a follower is capable of following and is done syncing
startLeaderElection() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
startMap(String) - Method in class org.apache.jute.BinaryInputArchive
 
startMap(TreeMap, String) - Method in class org.apache.jute.BinaryOutputArchive
 
startMap(TreeMap, String) - Method in class org.apache.jute.CsvOutputArchive
 
startMap(String) - Method in interface org.apache.jute.InputArchive
 
startMap(TreeMap, String) - Method in interface org.apache.jute.OutputArchive
 
startRecord(String) - Method in class org.apache.jute.BinaryInputArchive
 
startRecord(Record, String) - Method in class org.apache.jute.BinaryOutputArchive
 
startRecord(Record, String) - Method in class org.apache.jute.CsvOutputArchive
 
startRecord(String) - Method in interface org.apache.jute.InputArchive
 
startRecord(Record, String) - Method in interface org.apache.jute.OutputArchive
 
startup(ZooKeeperServer) - Method in class org.apache.zookeeper.server.NIOServerCnxn.Factory
 
startup() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
startVector(String) - Method in class org.apache.jute.BinaryInputArchive
 
startVector(List, String) - Method in class org.apache.jute.BinaryOutputArchive
 
startVector(List, String) - Method in class org.apache.jute.CsvOutputArchive
 
startVector(String) - Method in interface org.apache.jute.InputArchive
 
startVector(List, String) - Method in interface org.apache.jute.OutputArchive
 
stat - Variable in class org.apache.zookeeper.server.DataNode
the stat for this node that is persisted to disk.
stat - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
 
stat - Variable in class org.apache.zookeeper.server.upgrade.DataNodeV1
 
stat - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
 
stat(String, int) - Static method in class org.apache.zookeeper.ServerAdminClient
 
statCmd - Static variable in interface org.apache.zookeeper.server.ServerCnxn
 
state - Variable in class org.apache.zookeeper.server.quorum.Vote
 
staticFlag - Static variable in class org.apache.jute.compiler.generated.SimpleCharStream
Whether parser is static.
statNode - Static variable in class org.apache.zookeeper.Quotas
the stat node that monitors the limit of a subtree.
statNode(String, Watcher) - Method in class org.apache.zookeeper.server.DataTree
 
statNode(String, Watcher) - Method in class org.apache.zookeeper.server.upgrade.DataTreeV1
 
statPath(String) - Static method in class org.apache.zookeeper.Quotas
return the stat quota path associated with this prefix.
StatsTrack - Class in org.apache.zookeeper
a class that represents the stats associated with quotas
StatsTrack() - Constructor for class org.apache.zookeeper.StatsTrack
a default constructor for stats
StatsTrack(String) - Constructor for class org.apache.zookeeper.StatsTrack
the stat string should be of the form count=int,bytes=long if stats is called with null the count and bytes are initialized to -1.
STOP - Static variable in class org.apache.bookkeeper.client.QuorumEngine.Operation
 
stopLeaderElection() - Method in class org.apache.zookeeper.server.quorum.QuorumPeer
 
submitRequest(RequestHeader, Record, Record, ZooKeeper.WatchRegistration) - Method in class org.apache.zookeeper.ClientCnxn
 
submitRequest(Request) - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
SwitchTo(int) - Method in class org.apache.jute.compiler.generated.RccTokenManager
Switch to specified lex state.
sync() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
sync - Static variable in interface org.apache.zookeeper.ZooDefs.OpCode
 
sync(String, AsyncCallback.VoidCallback, Object) - Method in class org.apache.zookeeper.ZooKeeper
Asynchronous sync.
synced() - Method in class org.apache.zookeeper.server.quorum.FollowerHandler
 
syncLimit - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
SyncRequestProcessor - Class in org.apache.zookeeper.server
This RequestProcessor logs requests to disk.
SyncRequestProcessor(ZooKeeperServer, RequestProcessor) - Constructor for class org.apache.zookeeper.server.SyncRequestProcessor
 
SystemError - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.SYSTEMERROR instead

T

tabSize - Variable in class org.apache.jute.compiler.generated.SimpleCharStream
 
takeSnapshot() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
tearDown() - Method in class org.apache.bookkeeper.util.ClientBase
 
terminateConnection() - Method in class org.apache.zookeeper.server.ConnectionBean
 
terminateConnection() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
Terminate thei client connection.
terminateSession() - Method in class org.apache.zookeeper.server.ConnectionBean
 
terminateSession() - Method in interface org.apache.zookeeper.server.ConnectionMXBean
Terminate this client session.
testInitiateConnection(long) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
Invokes initiateConnection for testing purposes
tickOfLastAck() - Method in class org.apache.zookeeper.server.quorum.FollowerHandler
 
tickTime - Variable in class org.apache.zookeeper.server.quorum.QuorumPeerConfig
 
tickTime - Variable in class org.apache.zookeeper.server.ServerConfig
 
tickTime - Variable in class org.apache.zookeeper.server.ZooKeeperServer
 
tmpDir - Variable in class org.apache.bookkeeper.util.ClientBase
 
toFlag() - Method in enum org.apache.zookeeper.CreateMode
 
token - Variable in class org.apache.jute.compiler.generated.Rcc
Current token.
Token - Class in org.apache.jute.compiler.generated
Describes the input token stream.
Token() - Constructor for class org.apache.jute.compiler.generated.Token
No-argument constructor
Token(int) - Constructor for class org.apache.jute.compiler.generated.Token
Constructs a new token for the specified Image.
Token(int, String) - Constructor for class org.apache.jute.compiler.generated.Token
Constructs a new token for the specified Image and Kind.
token_source - Variable in class org.apache.jute.compiler.generated.Rcc
Generated Token Manager.
tokenImage - Variable in exception org.apache.jute.compiler.generated.ParseException
This is a reference to the "tokenImage" array of the generated parser within which the parse error occurred.
tokenImage - Static variable in interface org.apache.jute.compiler.generated.RccConstants
Literal token values.
TokenMgrError - Error in org.apache.jute.compiler.generated
Token Manager Error.
TokenMgrError() - Constructor for error org.apache.jute.compiler.generated.TokenMgrError
No arg constructor.
TokenMgrError(String, int) - Constructor for error org.apache.jute.compiler.generated.TokenMgrError
Constructor with message and reason.
TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.jute.compiler.generated.TokenMgrError
Full Constructor.
toSend(Long, ByteBuffer) - Method in class org.apache.zookeeper.server.quorum.QuorumCnxManager
Processes invoke this message to queue a message to send.
toString() - Method in class org.apache.bookkeeper.proto.NIOServerFactory.Cnxn
 
toString() - Method in class org.apache.bookkeeper.proto.ServerStats
 
toString() - Method in class org.apache.jute.compiler.generated.Token
Returns the image.
toString() - Method in class org.apache.zookeeper.ClientCnxn
 
toString() - Method in class org.apache.zookeeper.Environment.Entry
 
toString() - Method in class org.apache.zookeeper.server.ConnectionBean
 
toString() - Method in class org.apache.zookeeper.server.NIOServerCnxn
 
toString() - Method in class org.apache.zookeeper.server.quorum.Follower
 
toString() - Method in class org.apache.zookeeper.server.quorum.FollowerHandler
 
toString() - Method in class org.apache.zookeeper.server.quorum.Leader.Proposal
 
toString() - Method in class org.apache.zookeeper.server.quorum.QuorumStats
 
toString() - Method in class org.apache.zookeeper.server.quorum.Vote
 
toString() - Method in class org.apache.zookeeper.server.Request
 
toString() - Method in class org.apache.zookeeper.server.ServerStats
 
toString() - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
toString() - Method in class org.apache.zookeeper.StatsTrack
 
toString() - Method in class org.apache.zookeeper.WatchedEvent
 
touch(long, int) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
touchSession(long, int) - Method in class org.apache.zookeeper.server.quorum.FollowerSessionTracker
 
touchSession(long, int) - Method in interface org.apache.zookeeper.server.SessionTracker
 
touchSession(long, int) - Method in class org.apache.zookeeper.server.SessionTrackerImpl
 
TraceFormatter - Class in org.apache.zookeeper.server
 
TraceFormatter() - Constructor for class org.apache.zookeeper.server.TraceFormatter
 
triggerWatch(String, Watcher.Event.EventType) - Method in class org.apache.zookeeper.server.WatchManager
 
triggerWatch(String, Watcher.Event.EventType, Set<Watcher>) - Method in class org.apache.zookeeper.server.WatchManager
 
truncate(long) - Method in class org.apache.zookeeper.server.persistence.FileTxnLog
truncate the current transaction logs
truncate(long) - Method in interface org.apache.zookeeper.server.persistence.TxnLog
truncate the log to get in sync with the leader.
truncateLog(long) - Method in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
truncate the transaction logs the zxid specified
truncateLog(long) - Method in class org.apache.zookeeper.server.ZooKeeperServer
trunccate the log to get in sync with others if in a quorum
txn - Variable in class org.apache.zookeeper.server.Request
 
TxnLog - Interface in org.apache.zookeeper.server.persistence
Interface for reading transaction logs.
TxnLog.TxnIterator - Interface in org.apache.zookeeper.server.persistence
an iterating interface for reading transaction logs.
TXNLOG_MAGIC - Static variable in class org.apache.zookeeper.server.persistence.FileTxnLog
 
Type() - Method in class org.apache.jute.compiler.generated.Rcc
 
type - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
 
type - Variable in class org.apache.zookeeper.server.Request
 
type - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
 

U

UnauthorizedAccessException - Static variable in interface org.apache.bookkeeper.bookie.BookieException.Code
 
Unimplemented - Static variable in interface org.apache.zookeeper.KeeperException.CodeDeprecated
Deprecated. deprecated in 3.1.0, use KeeperException.Code.UNIMPLEMENTED instead
UNKNOWN_STATE - Static variable in interface org.apache.zookeeper.server.quorum.QuorumStats.Provider
 
unregister() - Static method in class org.apache.bookkeeper.proto.ServerStats
 
unregister(ZKMBeanInfo) - Method in class org.apache.zookeeper.jmx.MBeanRegistry
Unregister MBean.
unregisterAll() - Method in class org.apache.zookeeper.jmx.MBeanRegistry
Unregister all currently registered MBeans
unregisterJMX() - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
unregisterJMX(Follower) - Method in class org.apache.zookeeper.server.quorum.FollowerZooKeeperServer
 
unregisterJMX() - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
unregisterJMX(Leader) - Method in class org.apache.zookeeper.server.quorum.LeaderZooKeeperServer
 
unregisterJMX() - Method in class org.apache.zookeeper.server.ZooKeeperServer
 
updateBytes(String, long) - Method in class org.apache.zookeeper.server.DataTree
update the count of bytes of this stat datanode
updateCount(String, int) - Method in class org.apache.zookeeper.server.DataTree
update the count of this stat datanode
UpdateLineColumn(char) - Method in class org.apache.jute.compiler.generated.SimpleCharStream
 
UpgradeMain - Class in org.apache.zookeeper.server.upgrade
This class upgrades the older database to a new database for the zookeeper servers.
UpgradeMain(File, File) - Constructor for class org.apache.zookeeper.server.upgrade.UpgradeMain
upgrade class that takes the two file directories.
UpgradeSnapShot - Interface in org.apache.zookeeper.server.upgrade
interface for snapshot conversion.
UpgradeSnapShotV1 - Class in org.apache.zookeeper.server.upgrade
This class gets the old snapshot and the old dataDir and creates an brand new snapshot that is then converted to the new snapshot for upgrading.
UpgradeSnapShotV1(File, File) - Constructor for class org.apache.zookeeper.server.upgrade.UpgradeSnapShotV1
upgrade from version 1 to version 2
USTRING_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
Util - Class in org.apache.zookeeper.server.persistence
A collection of utility methods for dealing with file name parsing, low level I/O file operations and marshalling/unmarshalling.
Util() - Constructor for class org.apache.zookeeper.server.persistence.Util
 
Utils - Class in org.apache.jute
Various utility functions for Hadoop record I/O runtime.

V

validatePath(String, boolean) - Static method in class org.apache.zookeeper.common.PathUtils
validate the provided znode path string
validatePath(String) - Static method in class org.apache.zookeeper.common.PathUtils
Validate the provided znode path string
valueOf(String) - Static method in enum org.apache.bookkeeper.client.LedgerHandle.QMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.CreateMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.KeeperException.Code
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.server.quorum.QuorumPeer.ServerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.Watcher.Event.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.Watcher.Event.KeeperState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.zookeeper.ZooKeeper.States
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.bookkeeper.client.LedgerHandle.QMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.zookeeper.CreateMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.zookeeper.KeeperException.Code
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.zookeeper.server.quorum.QuorumPeer.ServerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.zookeeper.Watcher.Event.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.zookeeper.Watcher.Event.KeeperState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.zookeeper.ZooKeeper.States
Returns an array containing the constants of this enum type, in the order they are declared.
Vector() - Method in class org.apache.jute.compiler.generated.Rcc
 
VECTOR_TKN - Static variable in interface org.apache.jute.compiler.generated.RccConstants
RegularExpression Id.
VerGen - Class in org.apache.zookeeper.version.util
 
VerGen() - Constructor for class org.apache.zookeeper.version.util.VerGen
 
VERSION - Static variable in class org.apache.zookeeper.server.persistence.FileTxnLog
 
VERSION - Static variable in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
 
version - Static variable in class org.apache.zookeeper.server.persistence.FileTxnSnapLog
 
Version - Class in org.apache.zookeeper
 
Version() - Constructor for class org.apache.zookeeper.Version
 
vote - Variable in class org.apache.zookeeper.server.quorum.LeaderElection.ElectionResult
 
Vote - Class in org.apache.zookeeper.server.quorum
 
Vote(long, long) - Constructor for class org.apache.zookeeper.server.quorum.Vote
 
Vote(long, long, long) - Constructor for class org.apache.zookeeper.server.quorum.Vote
 
Vote(long, long, long, QuorumPeer.ServerState) - Constructor for class org.apache.zookeeper.server.quorum.Vote
 

W

waitForServerDown(String, long) - Static method in class org.apache.bookkeeper.util.ClientBase
 
waitForServerUp(String, long) - Static method in class org.apache.bookkeeper.util.ClientBase
 
WARNING_TRACE_MASK - Static variable in class org.apache.zookeeper.server.ZooTrace
 
WatchedEvent - Class in org.apache.zookeeper
A WatchedEvent represents a change on the ZooKeeper that a Watcher is able to respond to.
WatchedEvent(Watcher.Event.EventType, Watcher.Event.KeeperState, String) - Constructor for class org.apache.zookeeper.WatchedEvent
Create a WatchedEvent with specified type, state and path
WatchedEvent(WatcherEvent) - Constructor for class org.apache.zookeeper.WatchedEvent
Convert a WatcherEvent sent over the wire into a full-fledged WatcherEvent
Watcher - Interface in org.apache.zookeeper
This interface specifies the public interface an event handler class must implement.
Watcher.Event - Interface in org.apache.zookeeper
This interface defines the possible states an Event may represent
Watcher.Event.EventType - Enum in org.apache.zookeeper
Enumeration of types of events that may occur on the ZooKeeper
Watcher.Event.KeeperState - Enum in org.apache.zookeeper
Enumeration of states the ZooKeeper may be at the event
WatchManager - Class in org.apache.zookeeper.server
This class manages watches.
WatchManager() - Constructor for class org.apache.zookeeper.server.WatchManager
 
winner - Variable in class org.apache.zookeeper.server.quorum.LeaderElection.ElectionResult
 
winningCount - Variable in class org.apache.zookeeper.server.quorum.LeaderElection.ElectionResult
 
WithinMultiLineComment - Static variable in interface org.apache.jute.compiler.generated.RccConstants
Lexical state.
WithinOneLineComment - Static variable in interface org.apache.jute.compiler.generated.RccConstants
Lexical state.
WRITE - Static variable in interface org.apache.bookkeeper.client.BKDefs
 
write(byte[]) - Method in class org.apache.bookkeeper.streaming.LedgerOutputStream
 
write(byte[], int, int) - Method in class org.apache.bookkeeper.streaming.LedgerOutputStream
 
write(int) - Method in class org.apache.bookkeeper.streaming.LedgerOutputStream
 
write(Record) - Method in class org.apache.jute.RecordWriter
Serialize a record
WRITE - Static variable in interface org.apache.zookeeper.ZooDefs.Perms
 
writeBool(boolean, String) - Method in class org.apache.jute.BinaryOutputArchive
 
writeBool(boolean, String) - Method in class org.apache.jute.CsvOutputArchive
 
writeBool(boolean, String) - Method in interface org.apache.jute.OutputArchive
 
writeBuffer(byte[], String) - Method in class org.apache.jute.BinaryOutputArchive
 
writeBuffer(byte[], String) - Method in class org.apache.jute.CsvOutputArchive
 
writeBuffer(byte[], String) - Method in interface org.apache.jute.OutputArchive
 
writeByte(byte, String) - Method in class org.apache.jute.BinaryOutputArchive
 
writeByte(byte, String) - Method in class org.apache.jute.CsvOutputArchive
 
writeByte(byte, String) - Method in interface org.apache.jute.OutputArchive
 
WriteCallback - Interface in org.apache.bookkeeper.proto
Declaration of a callback implementation for calls from BookieClient objects.
writeComplete(int, long, long, Object) - Method in class org.apache.bookkeeper.client.QuorumOpMonitor
Callback method for write operations.
writeComplete(int, long, long, Object) - Method in class org.apache.bookkeeper.proto.BookieServer
 
writeComplete(int, long, long, Object) - Method in interface org.apache.bookkeeper.proto.WriteCallback
 
writeDouble(double, String) - Method in class org.apache.jute.BinaryOutputArchive
 
writeDouble(double, String) - Method in class org.apache.jute.CsvOutputArchive
 
writeDouble(double, String) - Method in interface org.apache.jute.OutputArchive
 
writeFloat(float, String) - Method in class org.apache.jute.BinaryOutputArchive
 
writeFloat(float, String) - Method in class org.apache.jute.CsvOutputArchive
 
writeFloat(float, String) - Method in interface org.apache.jute.OutputArchive
 
writeInt(int, String) - Method in class org.apache.jute.BinaryOutputArchive
 
writeInt(int, String) - Method in class org.apache.jute.CsvOutputArchive
 
writeInt(int, String) - Method in interface org.apache.jute.OutputArchive
 
writeLong(long, String) - Method in class org.apache.jute.BinaryOutputArchive
 
writeLong(long, String) - Method in class org.apache.jute.CsvOutputArchive
 
writeLong(long, String) - Method in interface org.apache.jute.OutputArchive
 
writeRecord(Record, String) - Method in class org.apache.jute.BinaryOutputArchive
 
writeRecord(Record, String) - Method in class org.apache.jute.CsvOutputArchive
 
writeRecord(Record, String) - Method in interface org.apache.jute.OutputArchive
 
writeString(String, String) - Method in class org.apache.jute.BinaryOutputArchive
 
writeString(String, String) - Method in class org.apache.jute.CsvOutputArchive
 
writeString(String, String) - Method in interface org.apache.jute.OutputArchive
 
writeTxnBytes(OutputArchive, byte[]) - Static method in class org.apache.zookeeper.server.persistence.Util
Write the serialized transaction record to the output archive.

Z

zeros - Static variable in class org.apache.bookkeeper.bookie.Bookie
 
zk - Variable in class org.apache.zookeeper.ZooKeeperMain
 
ZKMBeanInfo - Interface in org.apache.zookeeper.jmx
Zookeeper MBean info interface.
zks - Variable in class org.apache.zookeeper.server.ZooKeeperServerBean
 
ZooDefs - Class in org.apache.zookeeper
 
ZooDefs() - Constructor for class org.apache.zookeeper.ZooDefs
 
ZooDefs.Ids - Interface in org.apache.zookeeper
 
ZooDefs.OpCode - Interface in org.apache.zookeeper
 
ZooDefs.Perms - Interface in org.apache.zookeeper
 
ZooKeeper - Class in org.apache.zookeeper
This is the main class of ZooKeeper client library.
ZooKeeper(String, int, Watcher) - Constructor for class org.apache.zookeeper.ZooKeeper
To create a ZooKeeper client object, the application needs to pass a connection string containing a comma separated list of host:port pairs, each corresponding to a ZooKeeper server.
ZooKeeper(String, int, Watcher, long, byte[]) - Constructor for class org.apache.zookeeper.ZooKeeper
To create a ZooKeeper client object, the application needs to pass a connection string containing a comma separated list of host:port pairs, each corresponding to a ZooKeeper server.
ZooKeeper.States - Enum in org.apache.zookeeper
 
ZooKeeperMain - Class in org.apache.zookeeper
The command line client to ZooKeeper.
ZooKeeperMain(String[]) - Constructor for class org.apache.zookeeper.ZooKeeperMain
 
ZooKeeperMain(ZooKeeper) - Constructor for class org.apache.zookeeper.ZooKeeperMain
 
ZooKeeperServer - Class in org.apache.zookeeper.server
This class implements a simple standalone ZooKeeperServer.
ZooKeeperServer() - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
Creates a ZooKeeperServer instance.
ZooKeeperServer(FileTxnSnapLog, int, ZooKeeperServer.DataTreeBuilder) - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
Creates a ZooKeeperServer instance.
ZooKeeperServer(File, File, int) - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
This constructor is for backward compatibility with the existing unit test code.
ZooKeeperServer(FileTxnSnapLog, ZooKeeperServer.DataTreeBuilder) - Constructor for class org.apache.zookeeper.server.ZooKeeperServer
Default constructor, relies on the config for its agrument values
ZooKeeperServer.BasicDataTreeBuilder - Class in org.apache.zookeeper.server
 
ZooKeeperServer.BasicDataTreeBuilder() - Constructor for class org.apache.zookeeper.server.ZooKeeperServer.BasicDataTreeBuilder
 
ZooKeeperServer.DataTreeBuilder - Interface in org.apache.zookeeper.server
The server delegates loading of the tree to an instance of the interface
ZooKeeperServer.Factory - Interface in org.apache.zookeeper.server
Create an instance of ZooKeeper server
ZooKeeperServerBean - Class in org.apache.zookeeper.server
This class implements the ZooKeeper server MBean interface.
ZooKeeperServerBean(ZooKeeperServer) - Constructor for class org.apache.zookeeper.server.ZooKeeperServerBean
 
ZooKeeperServerMain - Class in org.apache.zookeeper.server
This class starts and runs a standalone ZooKeeperServer.
ZooKeeperServerMain() - Constructor for class org.apache.zookeeper.server.ZooKeeperServerMain
 
ZooKeeperServerMXBean - Interface in org.apache.zookeeper.server
ZooKeeper server MBean.
ZooTrace - Class in org.apache.zookeeper.server
This class encapsulates and centralizes tracing for the ZooKeeper server.
ZooTrace() - Constructor for class org.apache.zookeeper.server.ZooTrace
 
zxid - Variable in class org.apache.zookeeper.server.DataTree.ProcessTxnResult
 
zxid - Variable in class org.apache.zookeeper.server.quorum.Vote
 
zxid - Variable in class org.apache.zookeeper.server.Request
 
zxid - Variable in class org.apache.zookeeper.server.upgrade.DataTreeV1.ProcessTxnResult
 

A B C D E F G H I J K L M N O P Q R S T U V W Z