Skip navigation links
A B C D E F G H I L M N O P Q R S T V W 

A

acceptChild(String) - Method in class org.apache.curator.framework.recipes.cache.DefaultTreeCacheSelector
 
acceptChild(String) - Method in interface org.apache.curator.framework.recipes.cache.TreeCacheSelector
Return true if this node should be returned from the cache
acquire() - Method in interface org.apache.curator.framework.recipes.locks.InterProcessLock
Acquire the mutex - blocking until it's available.
acquire(long, TimeUnit) - Method in interface org.apache.curator.framework.recipes.locks.InterProcessLock
Acquire the mutex - blocks until it's available or the given time expires.
acquire() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMultiLock
Acquire the mutex - blocking until it's available.
acquire(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessMultiLock
Acquire the mutex - blocks until it's available or the given time expires.
acquire() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
Acquire the mutex - blocking until it's available.
acquire(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
Acquire the mutex - blocks until it's available or the given time expires.
acquire() - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
Acquire a lease.
acquire(int) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
Acquire qty leases.
acquire(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
Acquire a lease.
acquire(int, long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
Acquire qty leases.
acquire() - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreMutex
 
acquire(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreMutex
 
acquire() - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
Acquire a lease.
acquire(int) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
Acquire qty leases.
acquire(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
Acquire a lease.
acquire(int, long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
Acquire qty leases.
acquireLock(InterProcessLock) - Method in class org.apache.curator.framework.recipes.locks.Locker
 
acquireLock(InterProcessLock, long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.Locker
 
add(Integer) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
Add delta to the current value and return the new value information.
add(Long) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
Add delta to the current value and return the new value information.
add(T) - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
Add delta to the current value and return the new value information.
addListener(LeaderLatchListener) - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Attaches a listener to this LeaderLatch
addListener(LeaderLatchListener, Executor) - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Attaches a listener to this LeaderLatch
addListener(SharedCountListener) - Method in class org.apache.curator.framework.recipes.shared.SharedCount
 
addListener(SharedCountListener, Executor) - Method in class org.apache.curator.framework.recipes.shared.SharedCount
 
AfterConnectionEstablished - Class in org.apache.curator.framework.recipes
Utility class to allow execution of logic once a ZooKeeper connection becomes available.
afterInitialized() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
Make the built listener so that it only becomes active once CuratorCacheListener.initialized() has been called.
allocateQueue(CuratorFramework, String) - Method in interface org.apache.curator.framework.recipes.queue.QueueAllocator
 
AtomicStats - Class in org.apache.curator.framework.recipes.atomic
Debugging stats about operations
AtomicStats() - Constructor for class org.apache.curator.framework.recipes.atomic.AtomicStats
 
AtomicValue<T> - Interface in org.apache.curator.framework.recipes.atomic
Abstracts a value returned from one of the Atomics
attemptRevoke(CuratorFramework, String) - Static method in class org.apache.curator.framework.recipes.locks.Revoker
Utility to mark a lock for revocation.
autoRequeue() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
By default, when LeaderSelectorListener.takeLeadership(CuratorFramework) returns, this instance is not requeued.
await() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Causes the current thread to wait until this instance acquires leadership unless the thread is interrupted or closed.
await(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Causes the current thread to wait until this instance acquires leadership unless the thread is interrupted, the specified waiting time elapses or the instance is closed.

B

BlockingQueueConsumer<T> - Class in org.apache.curator.framework.recipes.queue
Utility - a queue consumer that provides behavior similar to a BlockingQueue
BlockingQueueConsumer(ConnectionStateListener) - Constructor for class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
Creates with capacity of Integer.MAX_VALUE
BlockingQueueConsumer(ConnectionStateListener, int) - Constructor for class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
 
BlockingQueueConsumer(ConnectionStateListener, BlockingQueue<T>) - Constructor for class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
Wrap the given blocking queue
bridgeBuilder(CuratorFramework, String) - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCache
Start a Curator Cache Bridge builder.
build() - Method in class org.apache.curator.framework.recipes.atomic.PromotedToLock.Builder
Build the argument block
build(CuratorFramework, String, CuratorCache.Options...) - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCache
Return a Curator Cache for the given path with the given options using a standard storage instance
build() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBridgeBuilder
Return a new Curator Cache Bridge based on the builder methods that have been called
build() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBuilder
Return a new Curator Cache based on the builder methods that have been called
build() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
Build and return a new listener based on the methods that have been previously called
build() - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
Deprecated.
Builds the TreeCache based on configured values.
build() - Method in class org.apache.curator.framework.recipes.queue.QueueSharderPolicies.Builder
 
buildDelayQueue() - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
Build a DistributedDelayQueue from the current builder values.
builder() - Static method in class org.apache.curator.framework.recipes.atomic.PromotedToLock
Allocate a new builder
builder(CuratorFramework, String) - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCache
Start a Curator Cache builder
builder() - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListener
Returns a builder allowing type specific, and special purpose listeners.
builder(CuratorFramework, QueueConsumer<T>, QueueSerializer<T>, String) - Static method in class org.apache.curator.framework.recipes.queue.QueueBuilder
Allocate a new builder
builder() - Static method in class org.apache.curator.framework.recipes.queue.QueueSharderPolicies
Allocate a new builder
buildIdQueue() - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
Build a DistributedIdQueue from the current builder values
buildPriorityQueue(int) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
Build a DistributedPriorityQueue from the current builder values.
buildQueue() - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
Build a DistributedQueue from the current builder values

C

CachedAtomicInteger - Class in org.apache.curator.framework.recipes.atomic
Uses an DistributedAtomicNumber and allocates values in chunks for better performance
CachedAtomicInteger(DistributedAtomicInteger, int) - Constructor for class org.apache.curator.framework.recipes.atomic.CachedAtomicInteger
 
CachedAtomicLong - Class in org.apache.curator.framework.recipes.atomic
Uses an DistributedAtomicNumber and allocates values in chunks for better performance
CachedAtomicLong(DistributedAtomicLong, int) - Constructor for class org.apache.curator.framework.recipes.atomic.CachedAtomicLong
 
CancelLeadershipException - Exception in org.apache.curator.framework.recipes.leader
When thrown from ConnectionStateListener.stateChanged(CuratorFramework, ConnectionState), will cause LeaderSelector.interruptLeadership() to get called.
CancelLeadershipException() - Constructor for exception org.apache.curator.framework.recipes.leader.CancelLeadershipException
 
CancelLeadershipException(String) - Constructor for exception org.apache.curator.framework.recipes.leader.CancelLeadershipException
 
CancelLeadershipException(String, Throwable) - Constructor for exception org.apache.curator.framework.recipes.leader.CancelLeadershipException
 
CancelLeadershipException(Throwable) - Constructor for exception org.apache.curator.framework.recipes.leader.CancelLeadershipException
 
cancelStartTask() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
 
ChildData - Class in org.apache.curator.framework.recipes.cache
 
ChildData(String, Stat, byte[]) - Constructor for class org.apache.curator.framework.recipes.cache.ChildData
 
childEvent(CuratorFramework, PathChildrenCacheEvent) - Method in interface org.apache.curator.framework.recipes.cache.PathChildrenCacheListener
Called when a change has occurred
childEvent(CuratorFramework, TreeCacheEvent) - Method in interface org.apache.curator.framework.recipes.cache.TreeCacheListener
Called when a change has occurred
clean() - Method in class org.apache.curator.framework.recipes.locks.LockInternals
Attempt to delete the lock node so that sequence numbers get reset
clear() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
Reset the storage to zero entries
clear() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
Clears the current data without beginning a new query and without generating any events for listeners.
clearAndRefresh() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
Clear out current data and begin a new query on the path
clearDataBytes(String) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
As a memory optimization, you can clear the cached data bytes for a node.
clearDataBytes(String, int) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
As a memory optimization, you can clear the cached data bytes for a node.
close() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCache
Close the cache, stop responding to events, etc.
close() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
Deprecated.
 
close() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
Close/end the cache
close() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
Deprecated.
Close/end the cache.
close() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Remove this instance from the leadership election.
close(LeaderLatch.CloseMode) - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Remove this instance from the leadership election.
close() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
Shutdown this selector and remove yourself from the leadership group
close() - Method in interface org.apache.curator.framework.recipes.locks.Lease
Releases the lease so that other clients/processes can acquire it
close() - Method in class org.apache.curator.framework.recipes.locks.Locker
 
close() - Method in class org.apache.curator.framework.recipes.nodes.GroupMember
Have thisId leave the group and stop caching membership
close() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
 
close() - Method in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
Call when you are done with the PersistentTtlNode.
close() - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
 
close() - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
 
close() - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
 
close() - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
 
close() - Method in class org.apache.curator.framework.recipes.queue.QueueSharder
 
close() - Method in class org.apache.curator.framework.recipes.shared.SharedCount
 
close() - Method in class org.apache.curator.framework.recipes.shared.SharedValue
 
close() - Method in class org.apache.curator.framework.recipes.watch.PersistentWatcher
Remove the watcher
compareAndSet(Integer, Integer) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
 
compareAndSet(Long, Long) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
 
compareAndSet(T, T) - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
Atomically sets the value to the given updated value if the current value == the expected value.
compareAndSet(byte[], byte[]) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
Atomically sets the value to the given updated value if the current value == the expected value.
compareTo(ChildData) - Method in class org.apache.curator.framework.recipes.cache.ChildData
Note: this class has a natural ordering that is inconsistent with equals.
consumeMessage(T) - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
 
consumeMessage(T) - Method in interface org.apache.curator.framework.recipes.queue.QueueConsumer
Process a message from the queue
countHasChanged(SharedCountReader, int) - Method in interface org.apache.curator.framework.recipes.shared.SharedCountListener
Called when the shared value has changed
createsTheLock(CuratorFramework, String, byte[]) - Method in interface org.apache.curator.framework.recipes.locks.LockInternalsDriver
 
createsTheLock(CuratorFramework, String, byte[]) - Method in class org.apache.curator.framework.recipes.locks.StandardLockInternalsDriver
 
CuratorCache - Interface in org.apache.curator.framework.recipes.cache
A utility that attempts to keep the data from a node locally cached.
CuratorCache.Options - Enum in org.apache.curator.framework.recipes.cache
cache build options
CuratorCacheAccessor - Interface in org.apache.curator.framework.recipes.cache
Methods to access the underlying storage
CuratorCacheBridge - Interface in org.apache.curator.framework.recipes.cache
A facade that uses CuratorCache if persistent watches are available or a TreeCache otherwise
CuratorCacheBridgeBuilder - Interface in org.apache.curator.framework.recipes.cache
 
CuratorCacheBuilder - Interface in org.apache.curator.framework.recipes.cache
 
CuratorCacheListener - Interface in org.apache.curator.framework.recipes.cache
Listener for CuratorCache events.
CuratorCacheListener.Type - Enum in org.apache.curator.framework.recipes.cache
An enumerated type that describes a change
CuratorCacheListenerBuilder - Interface in org.apache.curator.framework.recipes.cache
 
CuratorCacheListenerBuilder.ChangeListener - Interface in org.apache.curator.framework.recipes.cache
 
CuratorCacheStorage - Interface in org.apache.curator.framework.recipes.cache
Interface for maintaining data in a CuratorCache

D

dataNotCached() - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
Return a new storage instance that does not retain the data bytes.
decrement() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
Subtract 1 from the current value and return the new value information.
decrement() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
Subtract 1 from the current value and return the new value information.
decrement() - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
Subtract 1 from the current value and return the new value information.
DEFAULT_CHILD_NODE_NAME - Static variable in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
 
DEFAULT_TOUCH_SCHEDULE_FACTOR - Static variable in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
 
DEFAULT_USE_PARENT_CREATION - Static variable in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
 
defaultThreadFactorySupplier - Static variable in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
 
DefaultTreeCacheSelector - Class in org.apache.curator.framework.recipes.cache
Default TreeCache selector - returns true for all methods
DefaultTreeCacheSelector() - Constructor for class org.apache.curator.framework.recipes.cache.DefaultTreeCacheSelector
 
deleteNode() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
 
deserialize(byte[]) - Method in interface org.apache.curator.framework.recipes.queue.QueueSerializer
Deserialize bytes into a queue item
disableZkWatches(boolean) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
Deprecated.
By default, TreeCache creates ZooKeeper watches for every created path.
DistributedAtomicInteger - Class in org.apache.curator.framework.recipes.atomic
A counter that attempts atomic increments.
DistributedAtomicInteger(CuratorFramework, String, RetryPolicy) - Constructor for class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
Creates in optimistic mode only - i.e.
DistributedAtomicInteger(CuratorFramework, String, RetryPolicy, PromotedToLock) - Constructor for class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
Creates in mutex promotion mode.
DistributedAtomicLong - Class in org.apache.curator.framework.recipes.atomic
A counter that attempts atomic increments.
DistributedAtomicLong(CuratorFramework, String, RetryPolicy) - Constructor for class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
Creates in optimistic mode only - i.e.
DistributedAtomicLong(CuratorFramework, String, RetryPolicy, PromotedToLock) - Constructor for class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
Creates in mutex promotion mode.
DistributedAtomicNumber<T> - Interface in org.apache.curator.framework.recipes.atomic
 
DistributedAtomicValue - Class in org.apache.curator.framework.recipes.atomic
A distributed value that attempts atomic sets.
DistributedAtomicValue(CuratorFramework, String, RetryPolicy) - Constructor for class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
Creates in optimistic mode only - i.e.
DistributedAtomicValue(CuratorFramework, String, RetryPolicy, PromotedToLock) - Constructor for class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
Creates in mutex promotion mode.
DistributedBarrier - Class in org.apache.curator.framework.recipes.barriers
A barrier as described in the ZK recipes.
DistributedBarrier(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.barriers.DistributedBarrier
 
DistributedDelayQueue<T> - Class in org.apache.curator.framework.recipes.queue
A variation of the DistributedPriorityQueue that uses time as the priority.
DistributedDoubleBarrier - Class in org.apache.curator.framework.recipes.barriers
A double barrier as described in the ZK recipes.
DistributedDoubleBarrier(CuratorFramework, String, int) - Constructor for class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
Creates the barrier abstraction.
DistributedIdQueue<T> - Class in org.apache.curator.framework.recipes.queue
A version of DistributedQueue that allows IDs to be associated with queue items.
DistributedPriorityQueue<T> - Class in org.apache.curator.framework.recipes.queue
An implementation of the Distributed Priority Queue ZK recipe.
DistributedQueue<T> - Class in org.apache.curator.framework.recipes.queue
An implementation of the Distributed Queue ZK recipe.
DistributedQueue.ProcessType - Enum in org.apache.curator.framework.recipes.queue
 
drainTo(Collection<? super T>) - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
Removes all available elements from this queue and adds them to the given collection.

E

element() - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
Return the head of the queue without modifying the queue.
ensurePath() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
 
ensurePath() - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
 
enter() - Method in class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
Enter the barrier and block until all members have entered
enter(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
Enter the barrier and block until all members have entered or the timeout has elapsed
equals(Object) - Method in class org.apache.curator.framework.recipes.cache.ChildData
 
equals(Object) - Method in class org.apache.curator.framework.recipes.leader.Participant
 
ErrorMode - Enum in org.apache.curator.framework.recipes.queue
Used when the queue is created with a QueueBuilder.lockPath(String).
event(CuratorCacheListener.Type, ChildData, ChildData) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListener
Called when a data is created, changed or deleted.
event(ChildData, ChildData) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder.ChangeListener
 
execute(CuratorFramework, Runnable) - Static method in class org.apache.curator.framework.recipes.AfterConnectionEstablished
Spawns a new new background thread that will block until a connection is available and then execute the 'runAfterConnection' logic
executor(Executor) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
Change the executor used.

F

finalFlushTime(int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
Sets an amount of time to call DistributedQueue.flushPuts(long, TimeUnit) when the queue is closed.
fixForSorting(String, String) - Method in interface org.apache.curator.framework.recipes.locks.LockInternalsSorter
 
fixForSorting(String, String) - Method in class org.apache.curator.framework.recipes.locks.StandardLockInternalsDriver
 
flushPuts(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
 
flushPuts(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
 
flushPuts(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
 
flushPuts(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
Wait until any pending puts are committed
flushPuts(long, TimeUnit) - Method in interface org.apache.curator.framework.recipes.queue.QueueBase
Wait until any pending puts are committed
forAll(CuratorCacheListener) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
Add a standard listener
forceSet(Integer) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
 
forceSet(Long) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
 
forceSet(T) - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
Forcibly sets the value of the counter without any guarantees of atomicity.
forceSet(byte[]) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
Forcibly sets the value any guarantees of atomicity.
forChanges(CuratorCacheListenerBuilder.ChangeListener) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
forCreates(Consumer<ChildData>) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
forCreatesAndChanges(CuratorCacheListenerBuilder.ChangeListener) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
forDeletes(Consumer<ChildData>) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
forInitialized(Runnable) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
Add a listener only for CuratorCacheListener.initialized()
forNodeCache(NodeCacheListener) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
Bridge listener.
forPathChildrenCache(String, CuratorFramework, PathChildrenCacheListener) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
Bridge listener.
forTreeCache(CuratorFramework, TreeCacheListener) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
Bridge listener.

G

get() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
 
get() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
 
get() - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
Returns the current value of the counter.
get() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
Returns the current value of the counter.
get(String) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCache
Return an entry from storage
get(String) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheAccessor
Return an entry from storage
get(String) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
Return an entry from storage
getActualPath() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
Returns the currently set path or null if the node does not exist
getChildren() - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
 
getChildrenForEntering() - Method in class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
 
getClient() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
Deprecated.
 
getCount() - Method in class org.apache.curator.framework.recipes.shared.SharedCount
 
getCount() - Method in interface org.apache.curator.framework.recipes.shared.SharedCountReader
Return the current value of the count
getCreateMode(boolean) - Method in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
Deprecated.
 
getCurrentChildren(String) - Method in class org.apache.curator.framework.recipes.cache.TreeCache
Deprecated.
Return the current set of children at the given path, mapped by child name.
getCurrentData() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
Deprecated.
Return the current data.
getCurrentData() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
Return the current data.
getCurrentData(String) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
Return the current data for the given path.
getCurrentData(String) - Method in class org.apache.curator.framework.recipes.cache.TreeCache
Deprecated.
Return the current data for the given path.
getCurrentMembers() - Method in class org.apache.curator.framework.recipes.nodes.GroupMember
Return the current view of membership.
getData() - Method in class org.apache.curator.framework.recipes.cache.ChildData
Returns the node data for this child when the cache mode is set to cache data.
getData() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent
 
getData() - Method in class org.apache.curator.framework.recipes.cache.TreeCacheEvent
 
getData() - Method in interface org.apache.curator.framework.recipes.locks.Lease
Return the data stored in the node for this lease
getData() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
Return the current value of our data
getData() - Method in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
Return the current value of our data
getDelay(String) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
 
getId() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Return this instance's participant Id
getId() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
Return the ID that was set via LeaderSelector.setId(String)
getId() - Method in class org.apache.curator.framework.recipes.leader.Participant
Returns the ID set via LeaderSelector.setId(String)
getInitialData() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent
Special purpose method.
getItems() - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
Return any currently queued items without removing them from the queue
getLastMessageCount() - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
Return the most recent message count from the queue.
getLastMessageCount() - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
 
getLastMessageCount() - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
Return the most recent message count from the queue.
getLastMessageCount() - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
Return the most recent message count from the queue.
getLastMessageCount() - Method in interface org.apache.curator.framework.recipes.queue.QueueBase
Return the most recent message count from the queue.
getLastPathIsLeader() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Return last of this instance's lock node path that was leader ever.
getLeader() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Return the id for the current leader.
getLeader() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
Return the id for the current leader.
getListenable() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
Deprecated.
Return the cache listenable
getListenable() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
Return the cache listenable
getListenable() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
Deprecated.
Return the cache listenable
getListenable() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
Returns the listenable
getListenable() - Method in class org.apache.curator.framework.recipes.shared.SharedValue
Returns the listenable
getListenable() - Method in interface org.apache.curator.framework.recipes.shared.SharedValueReader
Returns the listenable
getListenable() - Method in class org.apache.curator.framework.recipes.watch.PersistentWatcher
Container for setting listeners
getLockNodeBytes() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
 
getLockPath() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
 
getLockPath() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock.ReadLock
 
getLockPath() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock.WriteLock
 
getNodeName() - Method in interface org.apache.curator.framework.recipes.locks.Lease
Return the the node for this lease
getOldData() - Method in class org.apache.curator.framework.recipes.cache.TreeCacheEvent
 
getOptimisticTimeMs() - Method in class org.apache.curator.framework.recipes.atomic.AtomicStats
Returns the time spent trying the operation with optimistic locks
getOptimisticTries() - Method in class org.apache.curator.framework.recipes.atomic.AtomicStats
Returns the number of optimistic locks used to perform the operation
getOurPath() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Return this instance's lock node path.
getParticipantNodes() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
Return a sorted list of all current nodes participating in the lock
getParticipantNodes() - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
Return a list of all current nodes participating in the semaphore
getParticipantNodes(CuratorFramework, String, String, LockInternalsSorter) - Static method in class org.apache.curator.framework.recipes.locks.LockInternals
 
getParticipants() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Returns the set of current participants in the leader selection
getParticipants() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
Returns the set of current participants in the leader selection
getPath() - Method in class org.apache.curator.framework.recipes.cache.ChildData
Returns the full path of the this child
getPath() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
Deprecated.
Return the path this cache is watching
getPathToWatch() - Method in class org.apache.curator.framework.recipes.locks.PredicateResults
 
getPromotedLockTries() - Method in class org.apache.curator.framework.recipes.atomic.AtomicStats
Returns the number of mutex locks used to perform the operation
getPromotedTimeMs() - Method in class org.apache.curator.framework.recipes.atomic.AtomicStats
Returns the time spent trying the operation with mutex locks
getPutListenerContainer() - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
Return the manager for put listeners
getPutListenerContainer() - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
 
getPutListenerContainer() - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
Return the manager for put listeners
getPutListenerContainer() - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
Return the manager for put listeners
getPutListenerContainer() - Method in interface org.apache.curator.framework.recipes.queue.QueueBase
Return the manager for put listeners
getQueue() - Method in class org.apache.curator.framework.recipes.queue.QueueSharder
Return one of the managed queues - the selection method cannot be relied on.
getQueuePaths() - Method in class org.apache.curator.framework.recipes.queue.QueueSharder
Return the current set of shard paths
getResetListenable() - Method in class org.apache.curator.framework.recipes.watch.PersistentWatcher
Listeners are called when the persistent watcher has been successfully registered or re-registered after a connection disruption
getShardQty() - Method in class org.apache.curator.framework.recipes.queue.QueueSharder
Return the current number of mananged queues
getSortedChildren(CuratorFramework, String, String, LockInternalsSorter) - Static method in class org.apache.curator.framework.recipes.locks.LockInternals
 
getSortedChildren(String, LockInternalsSorter, List<String>) - Static method in class org.apache.curator.framework.recipes.locks.LockInternals
 
getSortingSequence() - Method in class org.apache.curator.framework.recipes.locks.StandardLockInternalsDriver
 
getStat() - Method in class org.apache.curator.framework.recipes.cache.ChildData
Returns the stat data for this child
getState() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Returns this instances current state, this is the only way to verify that the object has been closed before closing again.
getStats() - Method in interface org.apache.curator.framework.recipes.atomic.AtomicValue
Returns debugging stats about the operation
getsTheLock(CuratorFramework, List<String>, String, int) - Method in interface org.apache.curator.framework.recipes.locks.LockInternalsDriver
 
getsTheLock() - Method in class org.apache.curator.framework.recipes.locks.PredicateResults
 
getsTheLock(CuratorFramework, List<String>, String, int) - Method in class org.apache.curator.framework.recipes.locks.StandardLockInternalsDriver
 
getType() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent
 
getType() - Method in class org.apache.curator.framework.recipes.cache.TreeCacheEvent
 
getUnhandledErrorListenable() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
Deprecated.
Allows catching unhandled errors in asynchronous operations.
getValue() - Method in class org.apache.curator.framework.recipes.shared.SharedValue
 
getValue() - Method in interface org.apache.curator.framework.recipes.shared.SharedValueReader
Return the current value of the count
getValue() - Method in class org.apache.curator.framework.recipes.shared.VersionedValue
 
getVersion() - Method in class org.apache.curator.framework.recipes.shared.VersionedValue
 
getVersionedValue() - Method in class org.apache.curator.framework.recipes.shared.SharedCount
 
getVersionedValue() - Method in interface org.apache.curator.framework.recipes.shared.SharedCountReader
Return the current count and version
getVersionedValue() - Method in class org.apache.curator.framework.recipes.shared.SharedValue
 
getVersionedValue() - Method in interface org.apache.curator.framework.recipes.shared.SharedValueReader
Return the current version and value
GroupMember - Class in org.apache.curator.framework.recipes.nodes
Group membership management.
GroupMember(CuratorFramework, String, String) - Constructor for class org.apache.curator.framework.recipes.nodes.GroupMember
 
GroupMember(CuratorFramework, String, String, byte[]) - Constructor for class org.apache.curator.framework.recipes.nodes.GroupMember
 

H

handleException(Throwable) - Method in class org.apache.curator.framework.recipes.cache.NodeCache
Deprecated.
Default behavior is just to log the exception
handleException(Throwable) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
Default behavior is just to log the exception
handleStateChange(ConnectionState) - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
 
hashCode() - Method in class org.apache.curator.framework.recipes.cache.ChildData
 
hashCode() - Method in class org.apache.curator.framework.recipes.leader.Participant
 
hasLeadership() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Return true if leadership is currently held by this instance
hasLeadership() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
Return true if leadership is currently held by this instance

I

idFromPath(String) - Method in class org.apache.curator.framework.recipes.nodes.GroupMember
Given a full ZNode path, return the member ID
increment() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
Add 1 to the current value and return the new value information.
increment() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
Add 1 to the current value and return the new value information.
increment() - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
Add 1 to the current value and return the new value information.
initialize(Integer) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
 
initialize(Long) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
 
initialize(T) - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
Atomic values are initially set to the equivalent of NULL in a database.
initialize(byte[]) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
Atomic values are initially set to the equivalent of NULL in a database.
initialized() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListener
When the cache is started, the initial nodes are tracked and when they are finished loading into the cache this method is called.
InterProcessLock - Interface in org.apache.curator.framework.recipes.locks
NOTE: depending on its implementation, InterProcessLock.release() may throw an exception if the current thread does not own the lock
InterProcessMultiLock - Class in org.apache.curator.framework.recipes.locks
A container that manages multiple locks as a single entity.
InterProcessMultiLock(CuratorFramework, List<String>) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessMultiLock
Creates a multi lock of InterProcessMutexs
InterProcessMultiLock(List<InterProcessLock>) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessMultiLock
Creates a multi lock of any type of inter process lock
InterProcessMutex - Class in org.apache.curator.framework.recipes.locks
A re-entrant mutex that works across JVMs.
InterProcessMutex(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessMutex
 
InterProcessMutex(CuratorFramework, String, LockInternalsDriver) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessMutex
 
InterProcessReadWriteLock - Class in org.apache.curator.framework.recipes.locks
A re-entrant read/write mutex that works across JVMs.
InterProcessReadWriteLock(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock
 
InterProcessReadWriteLock(CuratorFramework, String, byte[]) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock
 
InterProcessReadWriteLock(InterProcessReadWriteLock.WriteLock, InterProcessReadWriteLock.ReadLock) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock
 
InterProcessReadWriteLock.ReadLock - Class in org.apache.curator.framework.recipes.locks
 
InterProcessReadWriteLock.WriteLock - Class in org.apache.curator.framework.recipes.locks
 
InterProcessSemaphore - Class in org.apache.curator.framework.recipes.locks
Deprecated.
Use InterProcessSemaphoreV2 instead of this class. It uses a better algorithm.
InterProcessSemaphore(CuratorFramework, String, int) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
 
InterProcessSemaphore(CuratorFramework, String, SharedCountReader) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
 
InterProcessSemaphoreMutex - Class in org.apache.curator.framework.recipes.locks
A NON re-entrant mutex that works across JVMs.
InterProcessSemaphoreMutex(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreMutex
 
InterProcessSemaphoreV2 - Class in org.apache.curator.framework.recipes.locks
A counting semaphore that works across JVMs.
InterProcessSemaphoreV2(CuratorFramework, String, int) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
 
InterProcessSemaphoreV2(CuratorFramework, String, SharedCountReader) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
 
interruptLeadership() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
Attempt to cancel and interrupt the current leadership if this instance has leadership
isAcquiredInThisProcess() - Method in interface org.apache.curator.framework.recipes.locks.InterProcessLock
Returns true if the mutex is acquired by a thread in this JVM
isAcquiredInThisProcess() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMultiLock
 
isAcquiredInThisProcess() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
Returns true if the mutex is acquired by a thread in this JVM
isAcquiredInThisProcess() - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreMutex
 
isCuratorCache() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBridge
Returns true if the underlying cache is CuratorCache (i.e.
isLeader() - Method in interface org.apache.curator.framework.recipes.leader.LeaderLatchListener
This is called when the LeaderLatch's state goes from hasLeadership = false to hasLeadership = true.
isLeader() - Method in class org.apache.curator.framework.recipes.leader.Participant
Returns true if this participant is the current leader
isOwnedByCurrentThread() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
Returns true if the mutex is acquired by the calling thread
isProtected() - Method in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
Deprecated.
 
iterator() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
Deprecated.
Return an iterator over all nodes in the cache.

L

LeaderLatch - Class in org.apache.curator.framework.recipes.leader
Abstraction to select a "leader" amongst multiple contenders in a group of JVMs connected to a Zookeeper cluster.
LeaderLatch(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderLatch
 
LeaderLatch(CuratorFramework, String, String) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderLatch
 
LeaderLatch(CuratorFramework, String, String, LeaderLatch.CloseMode) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderLatch
 
LeaderLatch.CloseMode - Enum in org.apache.curator.framework.recipes.leader
How to handle listeners when the latch is closed
LeaderLatch.State - Enum in org.apache.curator.framework.recipes.leader
 
LeaderLatchListener - Interface in org.apache.curator.framework.recipes.leader
A LeaderLatchListener can be used to be notified asynchronously about when the state of the LeaderLatch has changed.
LeaderSelector - Class in org.apache.curator.framework.recipes.leader
Abstraction to select a "leader" amongst multiple contenders in a group of JMVs connected to a Zookeeper cluster.
LeaderSelector(CuratorFramework, String, LeaderSelectorListener) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderSelector
 
LeaderSelector(CuratorFramework, String, ThreadFactory, Executor, LeaderSelectorListener) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderSelector
Deprecated.
This constructor was poorly thought out. Custom executor is useless. Use this version instead: LeaderSelector(CuratorFramework, String, ExecutorService, LeaderSelectorListener)
LeaderSelector(CuratorFramework, String, ExecutorService, LeaderSelectorListener) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderSelector
 
LeaderSelector(CuratorFramework, String, CloseableExecutorService, LeaderSelectorListener) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderSelector
 
LeaderSelectorListener - Interface in org.apache.curator.framework.recipes.leader
Notification for leadership
LeaderSelectorListenerAdapter - Class in org.apache.curator.framework.recipes.leader
An implementation of LeaderSelectorListener that adds the recommended handling for connection state problems
LeaderSelectorListenerAdapter() - Constructor for class org.apache.curator.framework.recipes.leader.LeaderSelectorListenerAdapter
 
Lease - Interface in org.apache.curator.framework.recipes.locks
Represents an acquired lease from an InterProcessSemaphore.
leave() - Method in class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
Leave the barrier and block until all members have left
leave(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
Leave the barrier and block until all members have left or the timeout has elapsed
listenable() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCache
Return the listener container so that listeners can be registered to be notified of changes to the cache
LOCK_SCHEMA - Static variable in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
 
Locker - Class in org.apache.curator.framework.recipes.locks
Utility for safely acquiring a lock and releasing it using Java 7's try-with-resource feature.
Locker(InterProcessLock, long, TimeUnit) - Constructor for class org.apache.curator.framework.recipes.locks.Locker
 
Locker(InterProcessLock) - Constructor for class org.apache.curator.framework.recipes.locks.Locker
 
LockInternals - Class in org.apache.curator.framework.recipes.locks
 
LockInternalsDriver - Interface in org.apache.curator.framework.recipes.locks
 
LockInternalsSorter - Interface in org.apache.curator.framework.recipes.locks
 
lockPath(String) - Method in class org.apache.curator.framework.recipes.atomic.PromotedToLock.Builder
Set the path for the mutex lock (required)
lockPath(String) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
Without a lock set, queue items are removed before being sent to the queue consumer.

M

makeRequeueItemPath(String) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
 
makeRevocable(RevocationListener<InterProcessMutex>) - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
 
makeRevocable(RevocationListener<InterProcessMutex>, Executor) - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
 
makeRevocable(RevocationListener<T>) - Method in interface org.apache.curator.framework.recipes.locks.Revocable
Make the lock revocable.
makeRevocable(RevocationListener<T>, Executor) - Method in interface org.apache.curator.framework.recipes.locks.Revocable
Make the lock revocable.
maxItems(int) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
By default, the various queues are unbounded.
maxQueues(int) - Method in class org.apache.curator.framework.recipes.queue.QueueSharderPolicies.Builder
Change the maximum number of queues to create.
MultiItem<T> - Interface in org.apache.curator.framework.recipes.queue
Abstraction for multiple items.

N

newBuilder(CuratorFramework, String) - Static method in class org.apache.curator.framework.recipes.cache.TreeCache
Deprecated.
Create a TreeCache builder for the given client and path to configure advanced options.
newQueueThreshold(int) - Method in class org.apache.curator.framework.recipes.queue.QueueSharderPolicies.Builder
Change the queue threshold.
next() - Method in class org.apache.curator.framework.recipes.atomic.CachedAtomicInteger
Returns the next value (incrementing by 1).
next() - Method in class org.apache.curator.framework.recipes.atomic.CachedAtomicLong
Returns the next value (incrementing by 1).
nextItem() - Method in interface org.apache.curator.framework.recipes.queue.MultiItem
Called repeatedly to get the items to add to the queue.
NodeCache - Class in org.apache.curator.framework.recipes.cache
Deprecated.
replace by CuratorCache
NodeCache(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.cache.NodeCache
Deprecated.
 
NodeCache(CuratorFramework, String, boolean) - Constructor for class org.apache.curator.framework.recipes.cache.NodeCache
Deprecated.
 
NodeCacheListener - Interface in org.apache.curator.framework.recipes.cache
 
nodeChanged() - Method in interface org.apache.curator.framework.recipes.cache.NodeCacheListener
Called when a change has occurred
nodeCreated(String) - Method in interface org.apache.curator.framework.recipes.nodes.PersistentNodeListener
Called on a persistentNode event when node is created
notLeader() - Method in interface org.apache.curator.framework.recipes.leader.LeaderLatchListener
This is called when the LeaderLatch's state goes from hasLeadership = true to hasLeadership = false.

O

offer(byte[]) - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
Inserts data into queue.
org.apache.curator.framework.recipes - package org.apache.curator.framework.recipes
 
org.apache.curator.framework.recipes.atomic - package org.apache.curator.framework.recipes.atomic
 
org.apache.curator.framework.recipes.barriers - package org.apache.curator.framework.recipes.barriers
 
org.apache.curator.framework.recipes.cache - package org.apache.curator.framework.recipes.cache
 
org.apache.curator.framework.recipes.leader - package org.apache.curator.framework.recipes.leader
 
org.apache.curator.framework.recipes.locks - package org.apache.curator.framework.recipes.locks
 
org.apache.curator.framework.recipes.nodes - package org.apache.curator.framework.recipes.nodes
 
org.apache.curator.framework.recipes.queue - package org.apache.curator.framework.recipes.queue
 
org.apache.curator.framework.recipes.shared - package org.apache.curator.framework.recipes.shared
 
org.apache.curator.framework.recipes.watch - package org.apache.curator.framework.recipes.watch
 

P

parentPathFilter(String) - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCacheAccessor
Filter for a ChildData stream.
Participant - Class in org.apache.curator.framework.recipes.leader
Describes a participant in a leadership selection
Participant(String, boolean) - Constructor for class org.apache.curator.framework.recipes.leader.Participant
 
PathChildrenCache - Class in org.apache.curator.framework.recipes.cache
Deprecated.
replace by CuratorCache
PathChildrenCache(CuratorFramework, String, PathChildrenCacheMode) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
PathChildrenCache(CuratorFramework, String, PathChildrenCacheMode, ThreadFactory) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
PathChildrenCache(CuratorFramework, String, boolean) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
 
PathChildrenCache(CuratorFramework, String, boolean, ThreadFactory) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
 
PathChildrenCache(CuratorFramework, String, boolean, boolean, ThreadFactory) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
 
PathChildrenCache(CuratorFramework, String, boolean, boolean, ExecutorService) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
 
PathChildrenCache(CuratorFramework, String, boolean, boolean, CloseableExecutorService) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
 
PathChildrenCache.StartMode - Enum in org.apache.curator.framework.recipes.cache
Deprecated.
Method of priming cache on PathChildrenCache.start(StartMode)
PathChildrenCacheEvent - Class in org.apache.curator.framework.recipes.cache
POJO that abstracts a change to a path
PathChildrenCacheEvent(PathChildrenCacheEvent.Type, ChildData) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent
 
PathChildrenCacheEvent.Type - Enum in org.apache.curator.framework.recipes.cache
Type of change
PathChildrenCacheListener - Interface in org.apache.curator.framework.recipes.cache
Listener for PathChildrenCache changes
PathChildrenCacheMode - Enum in org.apache.curator.framework.recipes.cache
peek() - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
Returns the data at the first element of the queue, or null if the queue is empty.
PersistentEphemeralNode - Class in org.apache.curator.framework.recipes.nodes
Deprecated.
This has been replaced with the more general PersistentNode
PersistentEphemeralNode(CuratorFramework, PersistentEphemeralNode.Mode, String, byte[]) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode
Deprecated.
 
PersistentEphemeralNode.Mode - Enum in org.apache.curator.framework.recipes.nodes
Deprecated.
This has been replaced with the more general PersistentNode
PersistentNode - Class in org.apache.curator.framework.recipes.nodes
A persistent node is a node that attempts to stay present in ZooKeeper, even through connection and session interruptions.
PersistentNode(CuratorFramework, CreateMode, boolean, String, byte[]) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentNode
 
PersistentNode(CuratorFramework, CreateMode, boolean, String, byte[], boolean) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentNode
 
PersistentNode(CuratorFramework, CreateMode, boolean, String, byte[], long, boolean) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentNode
 
PersistentNodeListener - Interface in org.apache.curator.framework.recipes.nodes
Listener for changes to a PersistentNode
PersistentTtlNode - Class in org.apache.curator.framework.recipes.nodes
Manages a PersistentNode that uses CreateMode.CONTAINER.
PersistentTtlNode(CuratorFramework, String, long, byte[]) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
 
PersistentTtlNode(CuratorFramework, String, long, byte[], boolean) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
 
PersistentTtlNode(CuratorFramework, ScheduledExecutorService, String, long, byte[], String, int) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
 
PersistentTtlNode(CuratorFramework, ScheduledExecutorService, String, long, byte[], String, int, boolean) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
 
PersistentWatcher - Class in org.apache.curator.framework.recipes.watch
A managed persistent watcher.
PersistentWatcher(CuratorFramework, String, boolean) - Constructor for class org.apache.curator.framework.recipes.watch.PersistentWatcher
 
poll(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
poll() - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
Attempts to remove the head of the queue and return it.
postValue() - Method in interface org.apache.curator.framework.recipes.atomic.AtomicValue
Returns the value of the counter after to the operation
PredicateResults - Class in org.apache.curator.framework.recipes.locks
 
PredicateResults(String, boolean) - Constructor for class org.apache.curator.framework.recipes.locks.PredicateResults
 
preValue() - Method in interface org.apache.curator.framework.recipes.atomic.AtomicValue
Returns the value of the counter prior to the operation
processWithLockSafety(String, DistributedQueue.ProcessType) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
 
PromotedToLock - Class in org.apache.curator.framework.recipes.atomic
Abstraction of arguments for mutex promotion.
PromotedToLock.Builder - Class in org.apache.curator.framework.recipes.atomic
 
put(ChildData) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
Add an entry to storage and return any previous entry at that path
put(T, long) - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
Add an item into the queue.
put(T, long, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
Same as DistributedDelayQueue.put(Object, long) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
put(T, String) - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
Put an item into the queue with the given Id

NOTE: if an upper bound was set via QueueBuilder.maxItems, this method will block until there is available space in the queue.
put(T, String, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
Same as DistributedIdQueue.put(Object, String) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
put(T, int) - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
Add an item into the queue.
put(T, int, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
Same as DistributedPriorityQueue.put(Object, int) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
put(T) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
Add an item into the queue.
put(T, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
Same as DistributedQueue.put(Object) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
putCompleted(T) - Method in interface org.apache.curator.framework.recipes.queue.QueuePutListener
Notification that a single item put has completed
putInBackground(boolean) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
By default, messages are added in the background.
putMulti(MultiItem<T>, long) - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
Add a set of items with the same priority into the queue.
putMulti(MultiItem<T>, long, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
Same as DistributedDelayQueue.putMulti(MultiItem, long) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
putMulti(MultiItem<T>, int) - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
Add a set of items with the same priority into the queue.
putMulti(MultiItem<T>, int, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
Same as DistributedPriorityQueue.putMulti(MultiItem, int) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
putMulti(MultiItem<T>) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
Add a set of items into the queue.
putMulti(MultiItem<T>, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
Same as DistributedQueue.putMulti(MultiItem) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
putMultiCompleted(MultiItem<T>) - Method in interface org.apache.curator.framework.recipes.queue.QueuePutListener
Notification that a multi item put has completed

Q

QueueAllocator<U,T extends QueueBase<U>> - Interface in org.apache.curator.framework.recipes.queue
 
QueueBase<T> - Interface in org.apache.curator.framework.recipes.queue
 
QueueBuilder<T> - Class in org.apache.curator.framework.recipes.queue
QueueConsumer<T> - Interface in org.apache.curator.framework.recipes.queue
Message Consumer
QueuePutListener<T> - Interface in org.apache.curator.framework.recipes.queue
Queue puts are done in the background.
QueueSafety<T> - Class in org.apache.curator.framework.recipes.queue
Parameter block for specifying queue safety with either DistributedQueue or DistributedPriorityQueue
QueueSafety(String, QueueConsumer<T>) - Constructor for class org.apache.curator.framework.recipes.queue.QueueSafety
 
QueueSerializer<T> - Interface in org.apache.curator.framework.recipes.queue
Helper to serialize/deserialize queue items
QueueSharder<U,T extends QueueBase<U>> - Class in org.apache.curator.framework.recipes.queue
A utility for shard a distributed queue.
QueueSharder(CuratorFramework, QueueAllocator<U, T>, String, String, QueueSharderPolicies) - Constructor for class org.apache.curator.framework.recipes.queue.QueueSharder
 
QueueSharderPolicies - Class in org.apache.curator.framework.recipes.queue
Various policies/options for sharding.
QueueSharderPolicies.Builder - Class in org.apache.curator.framework.recipes.queue
 

R

readLock() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock
Returns the lock used for reading.
ReadLock(CuratorFramework, String, byte[], InterProcessReadWriteLock.WriteLock) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock.ReadLock
 
rebuild() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
Deprecated.
NOTE: this is a BLOCKING method.
rebuild() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
NOTE: this is a BLOCKING method.
rebuildNode(String) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
NOTE: this is a BLOCKING method.
release() - Method in interface org.apache.curator.framework.recipes.locks.InterProcessLock
Perform one release of the mutex.
release() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMultiLock
Perform one release of the mutex.
release() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
Perform one release of the mutex if the calling thread is the same thread that acquired it.
release() - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreMutex
Perform one release of the mutex.
releaseLock() - Method in class org.apache.curator.framework.recipes.locks.Locker
 
remove(String) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
Remove the entry from storage and return any previous entry at that path
remove(String) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
 
remove(String) - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
Remove any items with the given Id
remove() - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
Attempts to remove the head of the queue and return it.
removeBarrier() - Method in class org.apache.curator.framework.recipes.barriers.DistributedBarrier
Utility to remove the barrier node
removeListener(LeaderLatchListener) - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Removes a given listener from this LeaderLatch
removeListener(SharedCountListener) - Method in class org.apache.curator.framework.recipes.shared.SharedCount
 
requeue() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
Re-queue an attempt for leadership.
retryPolicy(RetryPolicy) - Method in class org.apache.curator.framework.recipes.atomic.PromotedToLock.Builder
Set the retry policy to use when an operation does not succeed
returnAll(Collection<Lease>) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
Convenience method.
returnAll(Collection<Lease>) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
Convenience method.
returnLease(Lease) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
Convenience method.
returnLease(Lease) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
Convenience method.
Revocable<T> - Interface in org.apache.curator.framework.recipes.locks
Specifies locks that can be revoked
RevocationListener<T> - Interface in org.apache.curator.framework.recipes.locks
 
revocationRequested(T) - Method in interface org.apache.curator.framework.recipes.locks.RevocationListener
Called when a revocation request has been received.
Revoker - Class in org.apache.curator.framework.recipes.locks
 

S

serialize(T) - Method in interface org.apache.curator.framework.recipes.queue.QueueSerializer
Turn a queue item into bytes
setBarrier() - Method in class org.apache.curator.framework.recipes.barriers.DistributedBarrier
Utility to set the barrier node
setCacheData(boolean) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
Deprecated.
Sets whether or not to cache byte data per node; default true.
setCount(int) - Method in class org.apache.curator.framework.recipes.shared.SharedCount
Change the shared count value irrespective of its previous state
setCreateParentNodes(boolean) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
Deprecated.
By default, TreeCache does not auto-create parent nodes for the cached path.
setData(byte[]) - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
Set data that node should set in ZK also writes the data to the node.
setData(byte[]) - Method in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
Set data that node should set in ZK also writes the data to the node.
setDataIsCompressed(boolean) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
Deprecated.
Sets whether or to decompress node data; default false.
setErrorMode(ErrorMode) - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
 
setErrorMode(ErrorMode) - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
 
setErrorMode(ErrorMode) - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
 
setErrorMode(ErrorMode) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
Used when the queue is created with a QueueBuilder.lockPath(String).
setErrorMode(ErrorMode) - Method in interface org.apache.curator.framework.recipes.queue.QueueBase
Used when the queue is created with a QueueBuilder.lockPath(String).
setExecutor(ThreadFactory) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
Deprecated.
Sets the executor to publish events; a default executor will be created if not specified.
setExecutor(ExecutorService) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
Deprecated.
Sets the executor to publish events; a default executor will be created if not specified.
setId(String) - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
Sets the ID to store for this leader.
setMaxDepth(int) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
Deprecated.
Sets the maximum depth to explore/watch.
setNodeData(byte[]) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
Set the data to put for the node created by this semaphore.
setSelector(TreeCacheSelector) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
Deprecated.
By default, DefaultTreeCacheSelector is used.
setThisData(byte[]) - Method in class org.apache.curator.framework.recipes.nodes.GroupMember
Change the data stored in this instance's node
setValue(byte[]) - Method in class org.apache.curator.framework.recipes.shared.SharedValue
Change the shared value value irrespective of its previous state
SharedCount - Class in org.apache.curator.framework.recipes.shared
Manages a shared integer.
SharedCount(CuratorFramework, String, int) - Constructor for class org.apache.curator.framework.recipes.shared.SharedCount
 
SharedCount(CuratorFramework, String, SharedValue) - Constructor for class org.apache.curator.framework.recipes.shared.SharedCount
 
SharedCountListener - Interface in org.apache.curator.framework.recipes.shared
Listener for changes to a shared count
SharedCountReader - Interface in org.apache.curator.framework.recipes.shared
Abstracts a shared integer and allows listening for changes to its value
SharedValue - Class in org.apache.curator.framework.recipes.shared
Manages a shared value.
SharedValue(CuratorFramework, String, byte[]) - Constructor for class org.apache.curator.framework.recipes.shared.SharedValue
 
SharedValue(WatcherRemoveCuratorFramework, String, byte[], CuratorWatcher) - Constructor for class org.apache.curator.framework.recipes.shared.SharedValue
 
SharedValueListener - Interface in org.apache.curator.framework.recipes.shared
Listener for changes to a shared value
SharedValueReader - Interface in org.apache.curator.framework.recipes.shared
Abstracts a shared value and allows listening for changes to the value
SimpleDistributedQueue - Class in org.apache.curator.framework.recipes.queue
Drop in replacement for: org.apache.zookeeper.recipes.queue.DistributedQueue that is part of the ZooKeeper distribution
SimpleDistributedQueue(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
 
size() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCache
Return the current number of entries in storage
size() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheAccessor
Return the current number of entries in storage
size() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
Return the current number of entries in storage
size() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
Deprecated.
Return the number of nodes in the cache.
size() - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
Returns the number of currently queue items
sortChildren(List<String>) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
 
standard() - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
Return a new standard storage instance
standardFixForSorting(String, String) - Static method in class org.apache.curator.framework.recipes.locks.StandardLockInternalsDriver
 
StandardLockInternalsDriver - Class in org.apache.curator.framework.recipes.locks
 
StandardLockInternalsDriver() - Constructor for class org.apache.curator.framework.recipes.locks.StandardLockInternalsDriver
 
start() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCache
Start the cache.
start() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
Deprecated.
Start the cache.
start(boolean) - Method in class org.apache.curator.framework.recipes.cache.NodeCache
Deprecated.
Same as NodeCache.start() but gives the option of doing an initial build
start() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
Start the cache.
start(boolean) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
start(PathChildrenCache.StartMode) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
Deprecated.
Start the cache.
start() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
Deprecated.
Start the cache.
start() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
Add this instance to the leadership election and attempt to acquire leadership.
start() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
Attempt leadership.
start() - Method in class org.apache.curator.framework.recipes.nodes.GroupMember
Start the group membership.
start() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
You must call start() to initiate the persistent node.
start() - Method in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
You must call start() to initiate the persistent ttl node
start() - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
Start the queue.
start() - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
 
start() - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
Start the queue.
start() - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
Start the queue.
start() - Method in interface org.apache.curator.framework.recipes.queue.QueueBase
Start the queue.
start() - Method in class org.apache.curator.framework.recipes.queue.QueueSharder
The sharder must be started
start() - Method in class org.apache.curator.framework.recipes.shared.SharedCount
The shared count must be started before it can be used.
start() - Method in class org.apache.curator.framework.recipes.shared.SharedValue
The shared value must be started before it can be used.
start() - Method in class org.apache.curator.framework.recipes.watch.PersistentWatcher
Start watching
stateChanged(CuratorFramework, ConnectionState) - Method in class org.apache.curator.framework.recipes.leader.LeaderSelectorListenerAdapter
 
stateChanged(CuratorFramework, ConnectionState) - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
 
stream() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCache
Return a stream over the storage entries.
stream() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheAccessor
Return a stream over the storage entries.
stream() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
Return a stream over the storage entries.
subtract(Integer) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
Subtract delta from the current value and return the new value information.
subtract(Long) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
Subtract delta from the current value and return the new value information.
subtract(T) - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
Subtract delta from the current value and return the new value information.
succeeded() - Method in interface org.apache.curator.framework.recipes.atomic.AtomicValue
MUST be checked. Returns true if the operation succeeded.

T

take() - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
Take the next item from the queue, blocking until there is an item available
take(int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
Take the next item from the queue, waiting up to the specified time for an available item.
take() - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
Removes the head of the queue and returns it, blocks until it succeeds.
takeLeadership(CuratorFramework) - Method in interface org.apache.curator.framework.recipes.leader.LeaderSelectorListener
Called when your instance has been granted leadership.
threadFactory(ThreadFactory) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
Change the thread factory used.
threadFactory(ThreadFactory) - Method in class org.apache.curator.framework.recipes.queue.QueueSharderPolicies.Builder
Change the thread factory that's used to create the sharder's thread
thresholdCheckMs(int) - Method in class org.apache.curator.framework.recipes.queue.QueueSharderPolicies.Builder
Change the threshold check.
timeout(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.atomic.PromotedToLock.Builder
Set the timeout to use when locking (optional)
toString() - Method in class org.apache.curator.framework.recipes.cache.ChildData
 
toString() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent
 
toString() - Method in class org.apache.curator.framework.recipes.cache.TreeCacheEvent
 
toString() - Method in class org.apache.curator.framework.recipes.leader.Participant
 
traverseChildren(String) - Method in class org.apache.curator.framework.recipes.cache.DefaultTreeCacheSelector
 
traverseChildren(String) - Method in interface org.apache.curator.framework.recipes.cache.TreeCacheSelector
Return true if children of this path should be cached.
TreeCache - Class in org.apache.curator.framework.recipes.cache
Deprecated.
replace by CuratorCache
TreeCache(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.cache.TreeCache
Deprecated.
Create a TreeCache for the given client and path with default options.
TreeCache.Builder - Class in org.apache.curator.framework.recipes.cache
Deprecated.
 
TreeCacheEvent - Class in org.apache.curator.framework.recipes.cache
POJO that abstracts a change to a path
TreeCacheEvent(TreeCacheEvent.Type, ChildData) - Constructor for class org.apache.curator.framework.recipes.cache.TreeCacheEvent
 
TreeCacheEvent(TreeCacheEvent.Type, ChildData, ChildData) - Constructor for class org.apache.curator.framework.recipes.cache.TreeCacheEvent
 
TreeCacheEvent.Type - Enum in org.apache.curator.framework.recipes.cache
Type of change
TreeCacheListener - Interface in org.apache.curator.framework.recipes.cache
Listener for TreeCache changes
TreeCacheSelector - Interface in org.apache.curator.framework.recipes.cache
Controls which nodes a TreeCache processes.
tryRemove(String) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
 
trySet(Integer) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
 
trySet(Long) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
 
trySet(T) - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
Attempt to atomically set the value to the given value.
trySet(byte[]) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
Attempt to atomically set the value to the given value.
trySetCount(int) - Method in class org.apache.curator.framework.recipes.shared.SharedCount
Deprecated.
use SharedCount.trySetCount(VersionedValue, int) for stronger atomicity guarantees. Even if this object's internal state is up-to-date, the caller has no way to ensure that they've read the most recently seen count.
trySetCount(VersionedValue<Integer>, int) - Method in class org.apache.curator.framework.recipes.shared.SharedCount
Changes the shared count only if its value has not changed since the version specified by newCount.
trySetValue(byte[]) - Method in class org.apache.curator.framework.recipes.shared.SharedValue
Deprecated.
use SharedValue.trySetValue(VersionedValue, byte[]) for stronger atomicity guarantees. Even if this object's internal state is up-to-date, the caller has no way to ensure that they've read the most recently seen value.
trySetValue(VersionedValue<byte[]>, byte[]) - Method in class org.apache.curator.framework.recipes.shared.SharedValue
Changes the shared value only if its value has not changed since the version specified by newValue.

V

valueHasChanged(SharedValueReader, byte[]) - Method in interface org.apache.curator.framework.recipes.shared.SharedValueListener
Called when the shared value has changed
valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.CuratorCache.Options
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.CuratorCacheListener.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.PathChildrenCache.StartMode
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheMode
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.TreeCacheEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.curator.framework.recipes.leader.LeaderLatch.CloseMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.curator.framework.recipes.leader.LeaderLatch.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.curator.framework.recipes.queue.DistributedQueue.ProcessType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.curator.framework.recipes.queue.ErrorMode
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.curator.framework.recipes.cache.CuratorCache.Options
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.curator.framework.recipes.cache.CuratorCacheListener.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.curator.framework.recipes.cache.PathChildrenCache.StartMode
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheMode
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.curator.framework.recipes.cache.TreeCacheEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.curator.framework.recipes.leader.LeaderLatch.CloseMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.curator.framework.recipes.leader.LeaderLatch.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.curator.framework.recipes.queue.DistributedQueue.ProcessType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.curator.framework.recipes.queue.ErrorMode
Returns an array containing the constants of this enum type, in the order they are declared.
VersionedValue<T> - Class in org.apache.curator.framework.recipes.shared
POJO for a version and a value

W

waitForInitialCreate(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
Block until the either initial node creation initiated by PersistentNode.start() succeeds or the timeout elapses.
waitForInitialCreate(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
Block until the either initial node creation initiated by PersistentTtlNode.start() succeeds or the timeout elapses.
waitOnBarrier() - Method in class org.apache.curator.framework.recipes.barriers.DistributedBarrier
Blocks until the barrier node comes into existence
waitOnBarrier(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.barriers.DistributedBarrier
Blocks until the barrier no longer exists or the timeout elapses
withDataNotCached() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBridgeBuilder
The bridge cache will not retain the data bytes.
withExceptionHandler(Consumer<Exception>) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBuilder
By default any unexpected exception is handled by logging the exception.
withExecutorService(ExecutorService) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBridgeBuilder
If the old TreeCache is used by the bridge (i.e.
withOptions(CuratorCache.Options...) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBridgeBuilder
 
withOptions(CuratorCache.Options...) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBuilder
 
withStorage(CuratorCacheStorage) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBuilder
Alternate storage to use.
writeLock() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock
Returns the lock used for writing.
WriteLock(CuratorFramework, String, byte[]) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock.WriteLock
 
A B C D E F G H I L M N O P Q R S T V W 
Skip navigation links

Copyright © 2011–2023 The Apache Software Foundation. All rights reserved.