Index

_ | A | B | C | D | E | F | G | H | I | J | 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)
(kazoo.retry.KazooRetry 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)
(kazoo.retry.KazooRetry 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)
acquire() (kazoo.recipe.lock.Lock method)
(kazoo.recipe.lock.Semaphore method)
ACQUIRED (kazoo.recipe.partitioner.PartitionState attribute)
acquired (kazoo.recipe.partitioner.SetPartitioner attribute)
add_auth() (kazoo.client.KazooClient method)
add_auth_async() (kazoo.client.KazooClient method)
add_listener() (kazoo.client.KazooClient method)
ALLOCATING (kazoo.recipe.partitioner.PartitionState attribute)
allocating (kazoo.recipe.partitioner.SetPartitioner attribute)
APIError
async_result() (kazoo.handlers.gevent.SequentialGeventHandler method)
(kazoo.handlers.threading.SequentialThreadingHandler method)
AsyncResult (class in kazoo.handlers.gevent)
(class in kazoo.handlers.threading)
AUTH_FAILED (kazoo.protocol.states.KeeperState attribute)
AuthFailedError

B

BadArgumentsError
BadVersionError
Barrier (class in kazoo.recipe.barrier)

C

Callback (class in kazoo.protocol.states)
cancel() (kazoo.recipe.election.Election method)
(kazoo.recipe.lock.Lock method)
(kazoo.recipe.lock.Semaphore method)
CancelledError
capture_exceptions() (in module kazoo.handlers.utils)
CHANGED (kazoo.protocol.states.EventType attribute)
check() (kazoo.client.TransactionRequest method)
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)
close() (kazoo.client.KazooClient method)
command() (kazoo.client.KazooClient method)
commit() (kazoo.client.TransactionRequest method)
commit_async() (kazoo.client.TransactionRequest method)
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
consume() (kazoo.recipe.queue.LockingQueue method)
contenders() (kazoo.recipe.election.Election method)
(kazoo.recipe.lock.Lock method)
copy() (kazoo.retry.KazooRetry method)
Counter (class in kazoo.recipe.counter)
create() (kazoo.client.KazooClient method)
(kazoo.client.TransactionRequest method)
(kazoo.recipe.barrier.Barrier method)
create_async() (kazoo.client.KazooClient method)
create_pipe() (in module kazoo.handlers.utils)
create_tcp_socket() (in module kazoo.handlers.utils)
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)
delete() (kazoo.client.KazooClient method)
(kazoo.client.TransactionRequest method)
delete_async() (kazoo.client.KazooClient method)
DELETED (kazoo.protocol.states.EventType attribute)
dispatch_callback() (kazoo.handlers.gevent.SequentialGeventHandler method)
(kazoo.handlers.threading.SequentialThreadingHandler method)
DoubleBarrier (class in kazoo.recipe.barrier)

E

Election (class in kazoo.recipe.election)
ensure_path() (kazoo.client.KazooClient method)
ensure_path_async() (kazoo.client.KazooClient method)
enter() (kazoo.recipe.barrier.DoubleBarrier method)
event_object() (kazoo.handlers.gevent.SequentialGeventHandler method)
(kazoo.handlers.threading.SequentialThreadingHandler method)
EventType (class in kazoo.protocol.states)
exception (kazoo.handlers.gevent.AsyncResult attribute)
exists() (kazoo.client.KazooClient method)
exists_async() (kazoo.client.KazooClient method)
EXPIRED_SESSION (kazoo.protocol.states.KeeperState attribute)

F

failed (kazoo.recipe.partitioner.SetPartitioner attribute)
FAILURE (kazoo.recipe.partitioner.PartitionState attribute)
finish() (kazoo.recipe.partitioner.SetPartitioner method)
ForceRetryError

G

get() (kazoo.client.KazooClient method)
(kazoo.handlers.gevent.AsyncResult method)
(kazoo.handlers.threading.AsyncResult method)
(kazoo.recipe.queue.LockingQueue method)
(kazoo.recipe.queue.Queue method)
get_acls() (kazoo.client.KazooClient method)
get_acls_async() (kazoo.client.KazooClient method)
get_async() (kazoo.client.KazooClient method)
get_children() (kazoo.client.KazooClient method)
get_children_async() (kazoo.client.KazooClient method)
get_nowait() (kazoo.handlers.gevent.AsyncResult method)
(kazoo.handlers.threading.AsyncResult method)

H

handler (kazoo.client.KazooClient attribute)
holds_lock() (kazoo.recipe.queue.LockingQueue method)

I

Id (class in kazoo.security)
InterruptedError
InvalidACLError
InvalidCallbackError

J

join() (kazoo.recipe.party.Party method)
(kazoo.recipe.party.ShallowParty method)

K

kazoo.client (module)
kazoo.exceptions (module)
kazoo.handlers.gevent (module)
kazoo.handlers.threading (module)
kazoo.handlers.utils (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.retry (module)
kazoo.security (module)
kazoo.testing.harness (module)
KazooClient (class in kazoo.client)
KazooException
KazooRetry (class in kazoo.retry)
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)
lease_holders() (kazoo.recipe.lock.Semaphore method)
leave() (kazoo.recipe.barrier.DoubleBarrier method)
(kazoo.recipe.party.Party method)
(kazoo.recipe.party.ShallowParty method)
Lock (class in kazoo.recipe.lock)
lock_object() (kazoo.handlers.gevent.SequentialGeventHandler method)
(kazoo.handlers.threading.SequentialThreadingHandler method)
LockingQueue (class in 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

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)
path (kazoo.protocol.states.WatchedEvent attribute)
PatientChildrenWatch (class in kazoo.recipe.watchers)
put() (kazoo.recipe.queue.LockingQueue method)
(kazoo.recipe.queue.Queue method)
put_all() (kazoo.recipe.queue.LockingQueue method)

Q

Queue (class in kazoo.recipe.queue)

R

rawlink() (kazoo.handlers.gevent.AsyncResult method)
(kazoo.handlers.threading.AsyncResult method)
ready() (kazoo.handlers.gevent.AsyncResult method)
(kazoo.handlers.threading.AsyncResult method)
RELEASE (kazoo.recipe.partitioner.PartitionState attribute)
release (kazoo.recipe.partitioner.SetPartitioner attribute)
release() (kazoo.recipe.lock.Lock method)
(kazoo.recipe.lock.Semaphore method)
release_set() (kazoo.recipe.partitioner.SetPartitioner method)
remove() (kazoo.recipe.barrier.Barrier method)
remove_listener() (kazoo.client.KazooClient method)
reset() (kazoo.retry.KazooRetry method)
restart() (kazoo.client.KazooClient method)
retry() (kazoo.client.KazooClient method)
RetryFailedError
rlock_object() (kazoo.handlers.gevent.SequentialGeventHandler method)
(kazoo.handlers.threading.SequentialThreadingHandler method)
RolledBackError
run() (kazoo.recipe.election.Election method)
RuntimeInconsistency

S

Semaphore (class in kazoo.recipe.lock)
SequentialGeventHandler (class in kazoo.handlers.gevent)
SequentialThreadingHandler (class in kazoo.handlers.threading)
server_version() (kazoo.client.KazooClient method)
SessionExpiredError
SessionMovedError
set() (kazoo.client.KazooClient method)
(kazoo.handlers.gevent.AsyncResult method)
(kazoo.handlers.threading.AsyncResult method)
set_acls() (kazoo.client.KazooClient method)
set_acls_async() (kazoo.client.KazooClient method)
set_async() (kazoo.client.KazooClient method)
set_data() (kazoo.client.TransactionRequest method)
set_exception() (kazoo.handlers.gevent.AsyncResult method)
(kazoo.handlers.threading.AsyncResult method)
SetPartitioner (class in kazoo.recipe.partitioner)
ShallowParty (class in kazoo.recipe.party)
sleep_func() (kazoo.handlers.gevent.SequentialGeventHandler static method)
(kazoo.handlers.threading.SequentialThreadingHandler method)
spawn() (kazoo.handlers.gevent.SequentialGeventHandler method)
start() (kazoo.client.KazooClient method)
(kazoo.handlers.gevent.SequentialGeventHandler method)
(kazoo.handlers.threading.SequentialThreadingHandler method)
(kazoo.recipe.watchers.PatientChildrenWatch method)
start_async() (kazoo.client.KazooClient method)
state (kazoo.client.KazooClient attribute)
(kazoo.protocol.states.WatchedEvent attribute)
stop() (kazoo.client.KazooClient method)
(kazoo.handlers.gevent.SequentialGeventHandler method)
(kazoo.handlers.threading.SequentialThreadingHandler method)
successful() (kazoo.handlers.gevent.AsyncResult method)
(kazoo.handlers.threading.AsyncResult method)
SUSPENDED (kazoo.protocol.states.KazooState attribute)
sync() (kazoo.client.KazooClient method)
sync_async() (kazoo.client.KazooClient method)
SystemZookeeperError

T

TimeoutError
transaction() (kazoo.client.KazooClient method)
TransactionRequest (class in kazoo.client)
type (kazoo.protocol.states.WatchedEvent attribute)

U

unchroot() (kazoo.client.KazooClient method)
UnimplementedError
unlink() (kazoo.handlers.gevent.AsyncResult method)
(kazoo.handlers.threading.AsyncResult method)

V

version (kazoo.protocol.states.ZnodeStat attribute)

W

wait() (kazoo.handlers.gevent.AsyncResult method)
(kazoo.handlers.threading.AsyncResult method)
(kazoo.recipe.barrier.Barrier method)
wait_for_acquire() (kazoo.recipe.partitioner.SetPartitioner method)
WatchedEvent (class in kazoo.protocol.states)
wrap() (in module kazoo.handlers.utils)
WriterNotClosedException

Z

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