Index

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

_

__add__() (kazoo.recipe.counter.Counter method)
__call__() (kazoo.recipe.watchers.ChildrenWatch method)
(kazoo.recipe.watchers.DataWatch method)
__init__() (kazoo.client.KazooClient method)
(kazoo.recipe.barrier.Barrier method)
(kazoo.recipe.barrier.DoubleBarrier method)
(kazoo.recipe.counter.Counter method)
(kazoo.recipe.election.Election method)
(kazoo.recipe.lock.Lock method)
(kazoo.recipe.lock.Semaphore method)
(kazoo.recipe.partitioner.SetPartitioner method)
(kazoo.recipe.party.Party method)
(kazoo.recipe.party.ShallowParty method)
(kazoo.recipe.queue.LockingQueue method)
(kazoo.recipe.queue.Queue method)
(kazoo.recipe.watchers.ChildrenWatch method)
(kazoo.recipe.watchers.DataWatch method)
(kazoo.recipe.watchers.PatientChildrenWatch method)
__iter__() (kazoo.recipe.party.Party method)
(kazoo.recipe.party.ShallowParty method)
__len__() (kazoo.recipe.party.Party method)
(kazoo.recipe.party.ShallowParty method)
(kazoo.recipe.queue.LockingQueue method)
(kazoo.recipe.queue.Queue method)
__sub__() (kazoo.recipe.counter.Counter method)

A

ACL (class in kazoo.security)
acl_version (kazoo.protocol.states.ZnodeStat attribute)
ACQUIRED (kazoo.recipe.partitioner.PartitionState attribute)
acquired (kazoo.recipe.partitioner.SetPartitioner attribute)
ALLOCATING (kazoo.recipe.partitioner.PartitionState attribute)
allocating (kazoo.recipe.partitioner.SetPartitioner attribute)
APIError
AsyncResult (class in kazoo.handlers.threading)
AsyncResult.get() (in module kazoo.handlers.threading)
AsyncResult.get_nowait() (in module kazoo.handlers.threading)
AsyncResult.rawlink() (in module kazoo.handlers.threading)
AsyncResult.ready() (in module kazoo.handlers.threading)
AsyncResult.set() (in module kazoo.handlers.threading)
AsyncResult.set_exception() (in module kazoo.handlers.threading)
AsyncResult.successful() (in module kazoo.handlers.threading)
AsyncResult.unlink() (in module kazoo.handlers.threading)
AsyncResult.wait() (in module kazoo.handlers.threading)
AUTH_FAILED (kazoo.protocol.states.KeeperState attribute)
AuthFailedError

B

BadArgumentsError
BadVersionError
Barrier (class in kazoo.recipe.barrier)
Barrier.create() (in module kazoo.recipe.barrier)
Barrier.remove() (in module kazoo.recipe.barrier)
Barrier.wait() (in module kazoo.recipe.barrier)

C

Callback (class in kazoo.protocol.states)
CancelledError
CHANGED (kazoo.protocol.states.EventType attribute)
CHILD (kazoo.protocol.states.EventType attribute)
children_count (kazoo.protocol.states.ZnodeStat attribute)
ChildrenWatch (class in kazoo.recipe.watchers)
client_id (kazoo.client.KazooClient attribute)
client_state (kazoo.client.KazooClient attribute)
ConfigurationError
connected (kazoo.client.KazooClient attribute)
CONNECTED (kazoo.protocol.states.KazooState attribute)
(kazoo.protocol.states.KeeperState attribute)
CONNECTED_RO (kazoo.protocol.states.KeeperState attribute)
CONNECTING (kazoo.protocol.states.KeeperState attribute)
ConnectionClosedError
ConnectionDropped
ConnectionLoss
Counter (class in kazoo.recipe.counter)
CREATED (kazoo.protocol.states.EventType attribute)
created (kazoo.protocol.states.ZnodeStat attribute)
creation_transaction_id (kazoo.protocol.states.ZnodeStat attribute)

D

data_length (kazoo.protocol.states.ZnodeStat attribute)
DataInconsistency
DataWatch (class in kazoo.recipe.watchers)
DELETED (kazoo.protocol.states.EventType attribute)
DoubleBarrier (class in kazoo.recipe.barrier)
DoubleBarrier.enter() (in module kazoo.recipe.barrier)
DoubleBarrier.leave() (in module kazoo.recipe.barrier)

E

Election (class in kazoo.recipe.election)
Election.cancel() (in module kazoo.recipe.election)
Election.contenders() (in module kazoo.recipe.election)
Election.run() (in module kazoo.recipe.election)
EventType (class in kazoo.protocol.states)
exception (kazoo.interfaces.IAsyncResult attribute)
EXPIRED_SESSION (kazoo.protocol.states.KeeperState attribute)

F

failed (kazoo.recipe.partitioner.SetPartitioner attribute)
FAILURE (kazoo.recipe.partitioner.PartitionState attribute)

H

handler (kazoo.client.KazooClient attribute)

I

IAsyncResult (class in kazoo.interfaces)
IAsyncResult.get() (in module kazoo.interfaces)
IAsyncResult.get_nowait() (in module kazoo.interfaces)
IAsyncResult.rawlink() (in module kazoo.interfaces)
IAsyncResult.ready() (in module kazoo.interfaces)
IAsyncResult.set() (in module kazoo.interfaces)
IAsyncResult.set_exception() (in module kazoo.interfaces)
IAsyncResult.successful() (in module kazoo.interfaces)
IAsyncResult.unlink() (in module kazoo.interfaces)
IAsyncResult.wait() (in module kazoo.interfaces)
Id (class in kazoo.security)
IHandler (class in kazoo.interfaces)
IHandler.async_result() (in module kazoo.interfaces)
IHandler.create_connection() (in module kazoo.interfaces)
IHandler.dispatch_callback() (in module kazoo.interfaces)
IHandler.event_object() (in module kazoo.interfaces)
IHandler.lock_object() (in module kazoo.interfaces)
IHandler.rlock_object() (in module kazoo.interfaces)
IHandler.select() (in module kazoo.interfaces)
IHandler.socket() (in module kazoo.interfaces)
IHandler.spawn() (in module kazoo.interfaces)
IHandler.start() (in module kazoo.interfaces)
IHandler.stop() (in module kazoo.interfaces)
InvalidACLError
InvalidCallbackError

K

kazoo.client (module)
kazoo.exceptions (module)
kazoo.handlers.threading (module)
kazoo.interfaces (module)
kazoo.protocol.states (module)
kazoo.recipe.barrier (module)
kazoo.recipe.counter (module)
kazoo.recipe.election (module)
kazoo.recipe.lock (module)
kazoo.recipe.partitioner (module)
kazoo.recipe.party (module)
kazoo.recipe.queue (module)
kazoo.recipe.watchers (module)
kazoo.security (module)
kazoo.testing.harness (module)
KazooClient (class in kazoo.client)
KazooClient.add_auth() (in module kazoo.client)
KazooClient.add_auth_async() (in module kazoo.client)
KazooClient.add_listener() (in module kazoo.client)
KazooClient.close() (in module kazoo.client)
KazooClient.command() (in module kazoo.client)
KazooClient.create() (in module kazoo.client)
KazooClient.create_async() (in module kazoo.client)
KazooClient.delete() (in module kazoo.client)
KazooClient.delete_async() (in module kazoo.client)
KazooClient.ensure_path() (in module kazoo.client)
KazooClient.ensure_path_async() (in module kazoo.client)
KazooClient.exists() (in module kazoo.client)
KazooClient.exists_async() (in module kazoo.client)
KazooClient.get() (in module kazoo.client)
KazooClient.get_acls() (in module kazoo.client)
KazooClient.get_acls_async() (in module kazoo.client)
KazooClient.get_async() (in module kazoo.client)
KazooClient.get_children() (in module kazoo.client)
KazooClient.get_children_async() (in module kazoo.client)
KazooClient.remove_listener() (in module kazoo.client)
KazooClient.restart() (in module kazoo.client)
KazooClient.server_version() (in module kazoo.client)
KazooClient.set() (in module kazoo.client)
KazooClient.set_acls() (in module kazoo.client)
KazooClient.set_acls_async() (in module kazoo.client)
KazooClient.set_async() (in module kazoo.client)
KazooClient.set_hosts() (in module kazoo.client)
KazooClient.start() (in module kazoo.client)
KazooClient.start_async() (in module kazoo.client)
KazooClient.stop() (in module kazoo.client)
KazooClient.sync() (in module kazoo.client)
KazooClient.sync_async() (in module kazoo.client)
KazooClient.transaction() (in module kazoo.client)
KazooClient.unchroot() (in module kazoo.client)
KazooException
KazooState (class in kazoo.protocol.states)
KazooTestCase (class in kazoo.testing.harness)
KazooTestHarness (class in kazoo.testing.harness)
KeeperState (class in kazoo.protocol.states)

L

last_modified (kazoo.protocol.states.ZnodeStat attribute)
last_modified_transaction_id (kazoo.protocol.states.ZnodeStat attribute)
Lock (class in kazoo.recipe.lock)
Lock.acquire() (in module kazoo.recipe.lock)
Lock.cancel() (in module kazoo.recipe.lock)
Lock.contenders() (in module kazoo.recipe.lock)
Lock.release() (in module kazoo.recipe.lock)
LockingQueue (class in kazoo.recipe.queue)
LockingQueue.consume() (in module kazoo.recipe.queue)
LockingQueue.get() (in module kazoo.recipe.queue)
LockingQueue.holds_lock() (in module kazoo.recipe.queue)
LockingQueue.put() (in module kazoo.recipe.queue)
LockingQueue.put_all() (in module kazoo.recipe.queue)
LockTimeout
LOST (kazoo.protocol.states.KazooState attribute)

M

make_acl() (in module kazoo.security)
make_digest_acl() (in module kazoo.security)
make_digest_acl_credential() (in module kazoo.security)
MarshallingError

N

name (kazoo.interfaces.IHandler attribute)
NoAuthError
NoChildrenForEphemeralsError
NodeExistsError
NoNodeError
NotEmptyError
NotReadOnlyCallError

O

OperationTimeoutError
owner_session_id (kazoo.protocol.states.ZnodeStat attribute)

P

PartitionState (class in kazoo.recipe.partitioner)
Party (class in kazoo.recipe.party)
Party.join() (in module kazoo.recipe.party)
Party.leave() (in module kazoo.recipe.party)
path (kazoo.protocol.states.WatchedEvent attribute)
PatientChildrenWatch (class in kazoo.recipe.watchers)
PatientChildrenWatch.start() (in module kazoo.recipe.watchers)

Q

Queue (class in kazoo.recipe.queue)
Queue.get() (in module kazoo.recipe.queue)
Queue.put() (in module kazoo.recipe.queue)
queue_empty (kazoo.handlers.threading.SequentialThreadingHandler attribute)
queue_impl (kazoo.handlers.threading.SequentialThreadingHandler attribute)

R

RELEASE (kazoo.recipe.partitioner.PartitionState attribute)
release (kazoo.recipe.partitioner.SetPartitioner attribute)
retry() (kazoo.client.KazooClient method)
RolledBackError
RuntimeInconsistency

S

Semaphore (class in kazoo.recipe.lock)
Semaphore.acquire() (in module kazoo.recipe.lock)
Semaphore.cancel() (in module kazoo.recipe.lock)
Semaphore.lease_holders() (in module kazoo.recipe.lock)
Semaphore.release() (in module kazoo.recipe.lock)
SequentialThreadingHandler (class in kazoo.handlers.threading)
SequentialThreadingHandler.async_result() (in module kazoo.handlers.threading)
SequentialThreadingHandler.dispatch_callback() (in module kazoo.handlers.threading)
SequentialThreadingHandler.event_object() (in module kazoo.handlers.threading)
SequentialThreadingHandler.lock_object() (in module kazoo.handlers.threading)
SequentialThreadingHandler.rlock_object() (in module kazoo.handlers.threading)
SequentialThreadingHandler.sleep_func() (in module kazoo.handlers.threading)
SequentialThreadingHandler.start() (in module kazoo.handlers.threading)
SequentialThreadingHandler.stop() (in module kazoo.handlers.threading)
SessionExpiredError
SessionMovedError
SetPartitioner (class in kazoo.recipe.partitioner)
SetPartitioner.finish() (in module kazoo.recipe.partitioner)
SetPartitioner.release_set() (in module kazoo.recipe.partitioner)
SetPartitioner.wait_for_acquire() (in module kazoo.recipe.partitioner)
ShallowParty (class in kazoo.recipe.party)
ShallowParty.join() (in module kazoo.recipe.party)
ShallowParty.leave() (in module kazoo.recipe.party)
sleep_func (kazoo.interfaces.IHandler attribute)
state (kazoo.client.KazooClient attribute)
(kazoo.protocol.states.WatchedEvent attribute)
SUSPENDED (kazoo.protocol.states.KazooState attribute)
SystemZookeeperError

T

timeout_exception (kazoo.interfaces.IHandler attribute)
TimeoutError
TransactionRequest (class in kazoo.client)
TransactionRequest.check() (in module kazoo.client)
TransactionRequest.commit() (in module kazoo.client)
TransactionRequest.commit_async() (in module kazoo.client)
TransactionRequest.create() (in module kazoo.client)
TransactionRequest.delete() (in module kazoo.client)
TransactionRequest.set_data() (in module kazoo.client)
type (kazoo.protocol.states.WatchedEvent attribute)

U

UnimplementedError

V

value (kazoo.interfaces.IAsyncResult attribute)
version (kazoo.protocol.states.ZnodeStat attribute)

W

WatchedEvent (class in kazoo.protocol.states)
WriterNotClosedException

Z

ZnodeStat (class in kazoo.protocol.states)
Zookeeper
ZookeeperError
ZookeeperStoppedError