- 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
- ACLable<T> - Interface in org.apache.curator.framework.api
-
- ACLBackgroundPathable<T> - Interface in org.apache.curator.framework.api
-
- ACLBackgroundPathAndBytesable<T> - Interface in org.apache.curator.framework.api
-
- ACLCreateModeBackgroundPathAndBytesable<T> - Interface in org.apache.curator.framework.api
-
- ACLCreateModePathAndBytesable<T> - Interface in org.apache.curator.framework.api
-
- ACLPathAndBytesable<T> - Interface in org.apache.curator.framework.api
-
- ACLProvider - Interface in org.apache.curator.framework.api
-
- aclProvider(ACLProvider) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- ACLVersionBackgroundPathable<T> - Interface in org.apache.curator.framework.api
-
- 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.
- acquireSemaphore(Semaphore) - Method in class org.apache.curator.test.Timing
-
Wait on the given semaphore
- acquireSemaphore(Semaphore, int) - Method in class org.apache.curator.test.Timing
-
Wait on the given semaphore
- 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.
- add(UriSpec.Part) - Method in class org.apache.curator.x.discovery.UriSpec
-
Add a part to the end of the list
- addCount(String, int) - Method in interface org.apache.curator.drivers.TracerDriver
-
Add to a named counter
- addCount(String, int) - Method in class org.apache.curator.utils.DefaultTracerDriver
-
- addCreateToTransaction(CuratorTransaction) - Static method in class framework.TransactionExamples
-
- addDeleteToTransaction(CuratorTransaction) - Static method in class framework.TransactionExamples
-
- additionalFilter(InstanceFilter<T>) - Method in interface org.apache.curator.x.discovery.ServiceProviderBuilder
-
Add an instance filter.
- addListener(T) - Method in interface org.apache.curator.framework.listen.Listenable
-
Add the given listener.
- addListener(T, Executor) - Method in interface org.apache.curator.framework.listen.Listenable
-
Add the given listener.
- addListener(T) - Method in class org.apache.curator.framework.listen.ListenerContainer
-
- addListener(T, Executor) - Method in class org.apache.curator.framework.listen.ListenerContainer
-
- 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
-
- addListener(ServiceCacheListener) - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
-
- addListener(ServiceCacheListener, Executor) - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
-
- addPath(String) - Method in class org.apache.curator.framework.recipes.locks.ChildReaper
-
Deprecated.
Add a path to reap children from
- addPath(String) - Method in class org.apache.curator.framework.recipes.locks.Reaper
-
Deprecated.
Add a path (using Mode.REAP_INDEFINITELY) to be checked by the reaper.
- addPath(String, Reaper.Mode) - Method in class org.apache.curator.framework.recipes.locks.Reaper
-
Deprecated.
Add a path to be checked by the reaper.
- address(String) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
- addStateChange(ConnectionState) - Method in class org.apache.curator.framework.state.ConnectionStateManager
-
Post a state change.
- addTrace(String, long, TimeUnit) - Method in interface org.apache.curator.drivers.TracerDriver
-
Record the given trace event
- addTrace(String, long, TimeUnit) - Method in class org.apache.curator.utils.DefaultTracerDriver
-
- AfterConnectionEstablished - Class in org.apache.curator.framework.recipes
-
Utility class to allow execution of logic once a ZooKeeper connection becomes available.
- allocateQueue(CuratorFramework, String) - Method in interface org.apache.curator.framework.recipes.queue.QueueAllocator
-
- allowRetry(int, long, RetrySleeper) - Method in class org.apache.curator.retry.RetryForever
-
- allowRetry(int, long, RetrySleeper) - Method in class org.apache.curator.retry.RetryUntilElapsed
-
- allowRetry(int, long, RetrySleeper) - Method in interface org.apache.curator.RetryPolicy
-
Called when an operation has failed for some reason.
- and() - Method in interface org.apache.curator.framework.api.transaction.CuratorTransactionBridge
-
Syntactic sugar to make the fluent interface more readable
- apply() - Static method in class org.apache.curator.test.ByteCodeRewrite
-
- asContainers() - Method in class org.apache.curator.utils.EnsurePath
-
Deprecated.
- 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.
- AuthInfo - Class in org.apache.curator.framework
-
- AuthInfo(String, byte[]) - Constructor for class org.apache.curator.framework.AuthInfo
-
- authorization(String, byte[]) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Add connection authorization
Subsequent calls to this method overwrite the prior calls.
- authorization(List<AuthInfo>) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Add connection authorization.
- autoRequeue() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
- 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.
- awaitLatch(CountDownLatch) - Method in class org.apache.curator.test.Timing
-
Wait on the given latch
- awaitTermination(long, TimeUnit) - Method in class org.apache.curator.test.DelegatingExecutorService
-
- cache - package cache
-
- cacheChanged() - Method in interface org.apache.curator.x.discovery.details.ServiceCacheListener
-
Called when the cache has changed (instances added/deleted, etc.)
- CachedAtomicInteger - Class in org.apache.curator.framework.recipes.atomic
-
- CachedAtomicInteger(DistributedAtomicInteger, int) - Constructor for class org.apache.curator.framework.recipes.atomic.CachedAtomicInteger
-
- CachedAtomicLong - Class in org.apache.curator.framework.recipes.atomic
-
- CachedAtomicLong(DistributedAtomicLong, int) - Constructor for class org.apache.curator.framework.recipes.atomic.CachedAtomicLong
-
- callWithRetry(CuratorZookeeperClient, Callable<T>) - Static method in class org.apache.curator.RetryLoop
-
Convenience utility: creates a retry loop calling the given proc and retrying if needed
- callWithRetry(CuratorZookeeperClient, SessionFailRetryLoop.Mode, Callable<T>) - Static method in class org.apache.curator.SessionFailRetryLoop
-
Convenience utility: creates a "session fail" retry loop calling the given proc
- canBeReadOnly(boolean) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- canBeReadOnly() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- cancel(boolean) - Method in class org.apache.curator.utils.CloseableExecutorService.InternalScheduledFutureTask
-
- CancelLeadershipException - Exception in org.apache.curator.framework.recipes.leader
-
- 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
-
- check() - Method in interface org.apache.curator.framework.api.transaction.CuratorTransaction
-
Start a check builder in the transaction
ChildData
- checkExists() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start an exists builder
- checkExists() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- checkInterrupted(Throwable) - Static method in class org.apache.curator.utils.ThreadUtils
-
- 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
- childEvent(CuratorFramework, PathChildrenCacheEvent) - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
-
- ChildReaper - Class in org.apache.curator.framework.recipes.locks
-
- ChildReaper(CuratorFramework, String, Reaper.Mode) - Constructor for class org.apache.curator.framework.recipes.locks.ChildReaper
-
Deprecated.
- ChildReaper(CuratorFramework, String, Reaper.Mode, int) - Constructor for class org.apache.curator.framework.recipes.locks.ChildReaper
-
Deprecated.
- ChildReaper(CuratorFramework, String, Reaper.Mode, ScheduledExecutorService, int) - Constructor for class org.apache.curator.framework.recipes.locks.ChildReaper
-
Deprecated.
- ChildReaper(CuratorFramework, String, Reaper.Mode, ScheduledExecutorService, int, String) - Constructor for class org.apache.curator.framework.recipes.locks.ChildReaper
-
Deprecated.
- ChildReaper(CuratorFramework, String, Reaper.Mode, ScheduledExecutorService, int, String, Set<String>) - Constructor for class org.apache.curator.framework.recipes.locks.ChildReaper
-
Deprecated.
- ChildrenDeletable - Interface in org.apache.curator.framework.api
-
- 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 class org.apache.curator.framework.listen.ListenerContainer
-
Remove all listeners
- clear() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
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
-
Clear out current data and begin a new query on the path
- clearDataBytes(String) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
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
-
As a memory optimization, you can clear the cached data bytes for a node.
- clearWatcherReferences(Watcher) - Method in interface org.apache.curator.framework.CuratorFramework
-
Curator can hold internal references to watchers that may inhibit garbage collection.
- clearWatcherReferences(Watcher) - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- client(CuratorFramework) - Method in class org.apache.curator.x.discovery.ServiceDiscoveryBuilder
-
Required - set the client to use
- close() - Method in class discovery.ExampleServer
-
- close() - Method in class leader.ExampleClient
-
- close() - Method in class org.apache.curator.CuratorZookeeperClient
-
Close the client
- close() - Method in interface org.apache.curator.ensemble.EnsembleProvider
-
- close() - Method in class org.apache.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
-
- close() - Method in class org.apache.curator.ensemble.fixed.FixedEnsembleProvider
-
- close() - Method in interface org.apache.curator.framework.CuratorFramework
-
Stop the client
- close() - Method in interface org.apache.curator.framework.CuratorTempFramework
-
Stop the client
- close() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- close() - Method in class org.apache.curator.framework.imps.CuratorTempFrameworkImpl
-
- close() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
- close() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Close/end the cache
- close() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
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 class org.apache.curator.framework.recipes.locks.ChildReaper
-
Deprecated.
- 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.Reaper
-
Deprecated.
- 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.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.state.ConnectionStateManager
-
- close() - Method in class org.apache.curator.SessionFailRetryLoop
-
Must be called in a finally handler when done with the loop
- close() - Method in class org.apache.curator.test.TestingCluster
-
Shutdown the ensemble, free resources, etc.
- close() - Method in class org.apache.curator.test.TestingServer
-
Close the server and any open clients and delete the temp directory
- close() - Method in class org.apache.curator.test.TestingZooKeeperMain
-
- close() - Method in class org.apache.curator.test.TestingZooKeeperServer
-
- close() - Method in class org.apache.curator.utils.CloseableExecutorService
-
Closes any tasks currently in progress
- close() - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
-
- close() - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
- close() - Method in class org.apache.curator.x.discovery.details.ServiceProviderImpl
- close() - Method in class org.apache.curator.x.discovery.server.rest.InstanceCleanup
-
- CloseableExecutorService - Class in org.apache.curator.utils
-
Decoration on an ExecutorService that tracks created futures and provides
a method to close futures created via this class
- CloseableExecutorService(ExecutorService) - Constructor for class org.apache.curator.utils.CloseableExecutorService
-
- CloseableExecutorService(ExecutorService, boolean) - Constructor for class org.apache.curator.utils.CloseableExecutorService
-
- CloseableExecutorService.InternalFutureTask<T> - Class in org.apache.curator.utils
-
- CloseableExecutorService.InternalScheduledFutureTask - Class in org.apache.curator.utils
-
- CloseableScheduledExecutorService - Class in org.apache.curator.utils
-
Decoration on an ScheduledExecutorService that tracks created futures and provides
a method to close futures created via this class
- CloseableScheduledExecutorService(ScheduledExecutorService) - Constructor for class org.apache.curator.utils.CloseableScheduledExecutorService
-
- CloseableScheduledExecutorService(ScheduledExecutorService, boolean) - Constructor for class org.apache.curator.utils.CloseableScheduledExecutorService
-
- CloseableUtils - Class in org.apache.curator.utils
-
This class adds back functionality that was removed in Guava v16.0.
- CloseableUtils() - Constructor for class org.apache.curator.utils.CloseableUtils
-
- closeQuietly(Closeable) - Static method in class org.apache.curator.utils.CloseableUtils
-
This method has been added because Guava has removed the
closeQuietly()
method from Closeables
in v16.0.
- commit() - Method in interface org.apache.curator.framework.api.transaction.CuratorTransactionFinal
-
Commit all added operations as an atomic unit and return results
for the operations.
- commit() - Method in class org.apache.curator.TimeTrace
-
Record the elapsed time
- commitTransaction(CuratorTransactionFinal) - Static method in class framework.TransactionExamples
-
- 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.
- compress(String, byte[]) - Method in interface org.apache.curator.framework.api.CompressionProvider
-
- compress(String, byte[]) - Method in class org.apache.curator.framework.imps.GzipCompressionProvider
-
- compressed() - Method in interface org.apache.curator.framework.api.Compressible
-
Cause the data to be compressed using the configured compression provider
- Compressible<T> - Interface in org.apache.curator.framework.api
-
- CompressionProvider - Interface in org.apache.curator.framework.api
-
- compressionProvider(CompressionProvider) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- connection() - Method in class org.apache.curator.test.Timing
-
Return the value to use for ZK connection timeout
- ConnectionState - Enum in org.apache.curator.framework.state
-
Represents state changes in the connection to ZK
- ConnectionStateListener - Interface in org.apache.curator.framework.state
-
- ConnectionStateManager - Class in org.apache.curator.framework.state
-
Used internally to manage connection state
- ConnectionStateManager(CuratorFramework, ThreadFactory) - Constructor for class org.apache.curator.framework.state.ConnectionStateManager
-
- connectionTimeoutMs(int) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- connectString(String) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Set the list of servers to connect to.
- 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
- create(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
-
- create() - Method in interface org.apache.curator.framework.api.transaction.CuratorTransaction
-
Start a create builder in the transaction
- create() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a create builder
- create() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- CreateBackgroundModeACLable - Interface in org.apache.curator.framework.api
-
- CreateBuilder - Interface in org.apache.curator.framework.api
-
- CreateClientExamples - Class in framework
-
- CreateClientExamples() - Constructor for class framework.CreateClientExamples
-
- createContainers(String) - Method in interface org.apache.curator.framework.CuratorFramework
-
Create all nodes in the specified path as containers if they don't
already exist
- createContainers(String) - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- createEphemeral(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
-
- createEphemeralSequential(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
-
- CreateModable<T> - Interface in org.apache.curator.framework.api
-
- CreateModalPathAndBytesable<T> - Interface in org.apache.curator.framework.api
-
- createSimple(String) - Static method in class framework.CreateClientExamples
-
- 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
-
- createWithOptions(String, RetryPolicy, int, int) - Static method in class framework.CreateClientExamples
-
- creatingParentContainersIfNeeded() - Method in interface org.apache.curator.framework.api.CreateBackgroundModeACLable
-
Causes any parent nodes to get created using CreateMode#CONTAINER
if they haven't already been.
- creatingParentContainersIfNeeded() - Method in interface org.apache.curator.framework.api.CreateBuilder
-
Causes any parent nodes to get created using CreateMode#CONTAINER
if they haven't already been.
- creatingParentContainersIfNeeded() - Method in interface org.apache.curator.framework.api.ExistsBuilder
-
Causes any parent nodes to get created using CreateMode#CONTAINER
if they haven't already been.
- creatingParentsIfNeeded() - Method in interface org.apache.curator.framework.api.CreateBackgroundModeACLable
-
Causes any parent nodes to get created if they haven't already been
- creatingParentsIfNeeded() - Method in interface org.apache.curator.framework.api.CreateBuilder
-
Causes any parent nodes to get created if they haven't already been
- CrudExamples - Class in framework
-
- CrudExamples() - Constructor for class framework.CrudExamples
-
- CuratorConnectionLossException - Exception in org.apache.curator
-
This is needed to differentiate between ConnectionLossException thrown by ZooKeeper
and ConnectionLossException thrown by ConnectionState.checkTimeouts()
- CuratorConnectionLossException() - Constructor for exception org.apache.curator.CuratorConnectionLossException
-
- CuratorEvent - Interface in org.apache.curator.framework.api
-
A super set of all the various Zookeeper events/background methods.
- CuratorEventType - Enum in org.apache.curator.framework.api
-
- CuratorFramework - Interface in org.apache.curator.framework
-
Zookeeper framework-style client
- CuratorFrameworkFactory - Class in org.apache.curator.framework
-
Factory methods for creating framework-style clients
- CuratorFrameworkFactory.Builder - Class in org.apache.curator.framework
-
- CuratorFrameworkImpl - Class in org.apache.curator.framework.imps
-
- CuratorFrameworkImpl(CuratorFrameworkFactory.Builder) - Constructor for class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- CuratorFrameworkImpl(CuratorFrameworkImpl) - Constructor for class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- CuratorFrameworkState - Enum in org.apache.curator.framework.imps
-
- CuratorListener - Interface in org.apache.curator.framework.api
-
Receives notifications about errors and background events
- CuratorTempFramework - Interface in org.apache.curator.framework
-
Temporary CuratorFramework instances are meant for single requests to ZooKeeper ensembles
over a failure prone network such as a WAN.
- CuratorTempFrameworkImpl - Class in org.apache.curator.framework.imps
-
- CuratorTempFrameworkImpl(CuratorFrameworkFactory.Builder, long) - Constructor for class org.apache.curator.framework.imps.CuratorTempFrameworkImpl
-
- CuratorTransaction - Interface in org.apache.curator.framework.api.transaction
-
Transactional/atomic operations.
- CuratorTransactionBridge - Interface in org.apache.curator.framework.api.transaction
-
- CuratorTransactionFinal - Interface in org.apache.curator.framework.api.transaction
-
Adds commit to the transaction interface
- CuratorTransactionResult - Class in org.apache.curator.framework.api.transaction
-
Holds the result of one transactional operation
- CuratorTransactionResult(OperationType, String, String, Stat) - Constructor for class org.apache.curator.framework.api.transaction.CuratorTransactionResult
-
- CuratorWatcher - Interface in org.apache.curator.framework.api
-
A version of Watcher
that can throw an exception
- CuratorZookeeperClient - Class in org.apache.curator
-
A wrapper around Zookeeper that takes care of some low-level housekeeping
- CuratorZookeeperClient(String, int, int, Watcher, RetryPolicy) - Constructor for class org.apache.curator.CuratorZookeeperClient
-
- CuratorZookeeperClient(EnsembleProvider, int, int, Watcher, RetryPolicy) - Constructor for class org.apache.curator.CuratorZookeeperClient
-
- CuratorZookeeperClient(ZookeeperFactory, EnsembleProvider, int, int, Watcher, RetryPolicy, boolean) - Constructor for class org.apache.curator.CuratorZookeeperClient
-
- debugUnhandledErrorListener - Variable in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- DebugUtils - Class in org.apache.curator.utils
-
- decompress(String, byte[]) - Method in interface org.apache.curator.framework.api.CompressionProvider
-
- decompress(String, byte[]) - Method in class org.apache.curator.framework.imps.GzipCompressionProvider
-
- decompressed() - Method in interface org.apache.curator.framework.api.Decompressible
-
Cause the data to be de-compressed using the configured compression provider
- Decompressible<T> - Interface in org.apache.curator.framework.api
-
- 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.
- DefaultACLProvider - Class in org.apache.curator.framework.imps
-
- DefaultACLProvider() - Constructor for class org.apache.curator.framework.imps.DefaultACLProvider
-
- defaultData(byte[]) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- DefaultExhibitorRestClient - Class in org.apache.curator.ensemble.exhibitor
-
- DefaultExhibitorRestClient() - Constructor for class org.apache.curator.ensemble.exhibitor.DefaultExhibitorRestClient
-
- DefaultExhibitorRestClient(boolean) - Constructor for class org.apache.curator.ensemble.exhibitor.DefaultExhibitorRestClient
-
- DefaultTracerDriver - Class in org.apache.curator.utils
-
Default tracer driver
- DefaultTracerDriver() - Constructor for class org.apache.curator.utils.DefaultTracerDriver
-
- 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
-
- DefaultZookeeperFactory - Class in org.apache.curator.utils
-
- DefaultZookeeperFactory() - Constructor for class org.apache.curator.utils.DefaultZookeeperFactory
-
- DelegatingExecutorService - Class in org.apache.curator.test
-
- DelegatingExecutorService(ExecutorService) - Constructor for class org.apache.curator.test.DelegatingExecutorService
-
- delete(CuratorFramework, String) - Static method in class framework.CrudExamples
-
- delete() - Method in interface org.apache.curator.framework.api.transaction.CuratorTransaction
-
Start a delete builder in the transaction
- delete() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a delete builder
- delete() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- DeleteBuilder - Interface in org.apache.curator.framework.api
-
- deleteChildren(ZooKeeper, String, boolean) - Static method in class org.apache.curator.utils.ZKPaths
-
Recursively deletes children of a node.
- deleteDataDirectoryOnClose() - Method in class org.apache.curator.test.InstanceSpec
-
- deleteDirectoryContents(File) - Static method in class org.apache.curator.test.DirectoryUtils
-
- deleteRecursively(File) - Static method in class org.apache.curator.test.DirectoryUtils
-
- deletingChildrenIfNeeded() - Method in interface org.apache.curator.framework.api.ChildrenDeletable
-
Will also delete children if they exist.
- deserialize(byte[]) - Method in interface org.apache.curator.framework.recipes.queue.QueueSerializer
-
Deserialize bytes into a queue item
- deserialize(byte[]) - Method in interface org.apache.curator.x.discovery.details.InstanceSerializer
-
Deserialize a byte array into an instance
- deserialize(byte[]) - Method in class org.apache.curator.x.discovery.details.JsonInstanceSerializer
-
- DirectoryUtils - Class in org.apache.curator.test
-
- DirectoryUtils() - Constructor for class org.apache.curator.test.DirectoryUtils
-
- discovery - package discovery
-
- DiscoveryContext<T> - Interface in org.apache.curator.x.discovery.server.rest
-
Bridge between the specifics of your needs and the generic implementation
- DiscoveryExample - Class in discovery
-
- DiscoveryExample() - Constructor for class discovery.DiscoveryExample
-
- DiscoveryResource<T> - Class in org.apache.curator.x.discovery.server.rest
-
The JAX-RS web service.
- DiscoveryResource(DiscoveryContext<T>) - Constructor for class org.apache.curator.x.discovery.server.rest.DiscoveryResource
-
- 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
-
- done() - Method in class org.apache.curator.utils.CloseableExecutorService.InternalFutureTask
-
- dontUseContainerParents() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- DownInstancePolicy - Class in org.apache.curator.x.discovery
-
Abstraction for values that determine when an instance is down
- DownInstancePolicy() - Constructor for class org.apache.curator.x.discovery.DownInstancePolicy
-
Policy with default values
- DownInstancePolicy(long, TimeUnit, int) - Constructor for class org.apache.curator.x.discovery.DownInstancePolicy
-
- downInstancePolicy(DownInstancePolicy) - Method in interface org.apache.curator.x.discovery.ServiceProviderBuilder
-
Set the down instance policy
- doWork(long, TimeUnit) - Method in class locking.ExampleClientThatLocks
-
- 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.
- GenericDiscoveryContext<T> - Class in org.apache.curator.x.discovery.server.contexts
-
For convenience, a version of
DiscoveryContext
that uses any generic type as the payload
- GenericDiscoveryContext(ServiceDiscovery<T>, ProviderStrategy<T>, int, Class<T>) - Constructor for class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
-
- GenericDiscoveryContext(ServiceDiscovery<T>, ProviderStrategy<T>, int, TypeToken<T>) - Constructor for class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
-
- 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() - Method in class org.apache.curator.utils.CloseableExecutorService.InternalScheduledFutureTask
-
- get(long, TimeUnit) - Method in class org.apache.curator.utils.CloseableExecutorService.InternalScheduledFutureTask
-
- get(String, String) - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
-
- getACL() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a get ACL builder
- getACL() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- GetACLBuilder - Interface in org.apache.curator.framework.api
-
- getAclForPath(String) - Method in interface org.apache.curator.framework.api.ACLProvider
-
Return the ACL list to use for the given path
- getAclForPath(String) - Method in class org.apache.curator.framework.imps.DefaultACLProvider
-
- getAclForPath(String) - Method in interface org.apache.curator.utils.InternalACLProvider
-
Return the ACL list to use for the given path
- getACLList() - Method in interface org.apache.curator.framework.api.CuratorEvent
-
- getAclProvider() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- getActualPath() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
-
Returns the currently set path or null if the node does not exist
- getAddress() - Method in class org.apache.curator.x.discovery.ServiceInstance
-
- getAll(String) - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
-
- getAllInstances() - Method in class org.apache.curator.x.discovery.details.ServiceProviderImpl
-
Return the current available set of instances IMPORTANT: users
should not hold on to the instance returned.
- getAllInstances() - Method in interface org.apache.curator.x.discovery.ServiceProvider
-
Return the current available set of instances IMPORTANT: users
should not hold on to the instance returned.
- getAllLocalIPs() - Static method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
based on http://pastebin.com/5X073pUc
- getAllNames() - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
-
- getAny(String) - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
-
- getAuth() - Method in class org.apache.curator.framework.AuthInfo
-
- getAuthInfos() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- getAuthScheme() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Deprecated.
- getAuthValue() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Deprecated.
- getBackupConnectionString() - Method in interface org.apache.curator.ensemble.exhibitor.Exhibitors.BackupConnectionStringProvider
-
- getBackupConnectionString() - Method in class org.apache.curator.ensemble.exhibitor.Exhibitors
-
- getBaseSleepTimeMs() - Method in class org.apache.curator.retry.ExponentialBackoffRetry
-
- getChildren() - Method in interface org.apache.curator.framework.api.CuratorEvent
-
- getChildren() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a get children builder
- getChildren() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- getChildren() - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
-
- GetChildrenBuilder - Interface in org.apache.curator.framework.api
-
- getChildrenForEntering() - Method in class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
-
- getCompressionProvider() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- getConnectionStateListenable() - Method in interface org.apache.curator.framework.CuratorFramework
-
Returns the listenable interface for the Connect State
- getConnectionStateListenable() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- getConnectionString() - Method in interface org.apache.curator.ensemble.EnsembleProvider
-
Return the current connection string to use.
- getConnectionString() - Method in class org.apache.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
-
- getConnectionString() - Method in class org.apache.curator.ensemble.fixed.FixedEnsembleProvider
-
- getConnectionTimeoutMs() - Method in class org.apache.curator.CuratorZookeeperClient
-
Return the configured connection timeout
- getConnectionTimeoutMs() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- getConnectString() - Method in class org.apache.curator.test.InstanceSpec
-
- getConnectString() - Method in class org.apache.curator.test.TestingCluster
-
Returns the connection string to pass to the ZooKeeper constructor
- getConnectString() - Method in class org.apache.curator.test.TestingServer
-
Returns the connection string to use
- getContainerCreateMode() - Static method in class org.apache.curator.utils.ZKPaths
-
- getContext() - Method in interface org.apache.curator.framework.api.CuratorEvent
-
- getContext(Class<?>) - Method in class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
-
- getContext(Class<?>) - Method in class org.apache.curator.x.discovery.server.contexts.IntegerDiscoveryContext
-
- getContext(Class<?>) - Method in class org.apache.curator.x.discovery.server.contexts.StringDiscoveryContext
-
- 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.
- getCuratorListenable() - Method in interface org.apache.curator.framework.CuratorFramework
-
Returns the listenable interface for events
- getCuratorListenable() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- getCurrentChildren(String) - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
Return the current set of children at the given path, mapped by child name.
- getCurrentConnectionString() - Method in class org.apache.curator.CuratorZookeeperClient
-
Returns the current known connection string - not guaranteed to be correct
value at any point in the future.
- getCurrentData() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
Return the current data.
- getCurrentData() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Return the current data.
- getCurrentData(String) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Return the current data for the given path.
- getCurrentData(String) - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
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 interface org.apache.curator.framework.api.CuratorEvent
-
- getData() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a get data builder
- getData() - Method in interface org.apache.curator.framework.CuratorTempFramework
-
Start a get data builder
- getData() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- getData() - Method in class org.apache.curator.framework.imps.CuratorTempFrameworkImpl
-
- 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
- GetDataBuilder - Interface in org.apache.curator.framework.api
-
- getDataDirectory() - Method in class org.apache.curator.test.InstanceSpec
-
- GetDataWatchBackgroundStatable - Interface in org.apache.curator.framework.api
-
- getDefaultAcl() - Method in interface org.apache.curator.framework.api.ACLProvider
-
Return the ACL list to use by default (usually ZooDefs.Ids#OPEN_ACL_UNSAFE
).
- getDefaultAcl() - Method in class org.apache.curator.framework.imps.DefaultACLProvider
-
- getDefaultAcl() - Method in interface org.apache.curator.utils.InternalACLProvider
-
Return the ACL list to use by default (usually ZooDefs.Ids#OPEN_ACL_UNSAFE
).
- getDefaultData() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- getDefaultRetrySleeper() - Static method in class org.apache.curator.RetryLoop
-
Returns the default retry sleeper
- getDelay(String) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
-
- getDeprecated(String, String) - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
-
Deprecated.
- getDescription() - Method in class discovery.InstanceDetails
-
- getElectionPort() - Method in class org.apache.curator.test.InstanceSpec
-
- getEnsembleProvider() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- getErrorThreshold() - Method in class org.apache.curator.x.discovery.DownInstancePolicy
-
- getForPath() - Method in class org.apache.curator.framework.api.transaction.CuratorTransactionResult
-
Returns the path that was passed to the operation when added
- getHostnames() - Method in class org.apache.curator.ensemble.exhibitor.Exhibitors
-
- 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
-
- getId() - Method in class org.apache.curator.framework.recipes.leader.Participant
-
- getId() - Method in class org.apache.curator.x.discovery.ServiceInstance
-
- getInitialData() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent
-
Special purpose method.
- getInstance() - Method in class org.apache.curator.x.discovery.details.ServiceProviderImpl
-
Return an instance for a single use.
- getInstance(InstanceProvider<T>) - Method in interface org.apache.curator.x.discovery.ProviderStrategy
-
Given a source of instances, return one of them for a single use.
- getInstance() - Method in interface org.apache.curator.x.discovery.ServiceProvider
-
Return an instance for a single use.
- getInstance(InstanceProvider<T>) - Method in class org.apache.curator.x.discovery.strategies.RandomStrategy
-
- getInstance(InstanceProvider<T>) - Method in class org.apache.curator.x.discovery.strategies.RoundRobinStrategy
-
- getInstance(InstanceProvider<T>) - Method in class org.apache.curator.x.discovery.strategies.StickyStrategy
-
- getInstanceIndex() - Method in class org.apache.curator.CuratorZookeeperClient
-
Every time a new ZooKeeper
instance is allocated, the "instance index"
is incremented.
- getInstanceNumber() - Method in class org.apache.curator.x.discovery.strategies.StickyStrategy
-
Each time a new instance is picked, an internal counter is incremented.
- getInstanceRefreshMs() - Method in class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
-
- getInstanceRefreshMs() - Method in class org.apache.curator.x.discovery.server.contexts.IntegerDiscoveryContext
-
- getInstanceRefreshMs() - Method in class org.apache.curator.x.discovery.server.contexts.StringDiscoveryContext
-
- getInstanceRefreshMs() - Method in interface org.apache.curator.x.discovery.server.rest.DiscoveryContext
-
Return the threshold in milliseconds to consider a registration stale
- getInstances() - Method in class org.apache.curator.test.TestingCluster
-
Returns the set of servers in the ensemble
- getInstances() - Method in interface org.apache.curator.x.discovery.details.InstanceProvider
-
Return the current available set of instances
- getInstances() - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
-
- getInstances() - Method in interface org.apache.curator.x.discovery.ServiceCache
-
Return the current list of instances.
- getInstanceSpec(int) - Method in class org.apache.curator.test.QuorumConfigBuilder
-
- getInstanceSpec() - Method in class org.apache.curator.test.TestingZooKeeperServer
-
- getInstanceSpecs() - Method in class org.apache.curator.test.QuorumConfigBuilder
-
- getInstanceSpecs() - Method in class org.apache.curator.test.TestingZooKeeperServer
-
- 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.
- 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
-
Return the cache listenable
- getListenable() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Return the cache listenable
- getListenable() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
Return the cache 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.state.ConnectionStateManager
-
Return the listenable
- getLocalAddress() - Static method in class org.apache.curator.framework.CuratorFrameworkFactory
-
Return the local address as bytes that can be used as a node payload
- getLocalIpFilter() - Static method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
- getLockNodeBytes() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
-
- getLockPath() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
-
- getMaxClientCnxns() - Method in class org.apache.curator.test.InstanceSpec
-
- getMaxCloseWaitMs() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- getMaxSleepTimeMs() - Method in class org.apache.curator.retry.BoundedExponentialBackoffRetry
-
- getName() - Method in interface org.apache.curator.framework.api.CuratorEvent
-
- getName() - Method in class org.apache.curator.x.discovery.ServiceInstance
-
- getNames() - Method in class org.apache.curator.x.discovery.server.entity.ServiceNames
-
- getNamespace() - Method in interface org.apache.curator.framework.CuratorFramework
-
Return the current namespace or "" if none
- getNamespace() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- getNamespace() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- getNode() - Method in class org.apache.curator.utils.ZKPaths.PathAndNode
-
- getNodeFromPath(String) - Static method in class org.apache.curator.utils.ZKPaths
-
Given a full path, return the node name.
- 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
- 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
- getParts() - Method in class org.apache.curator.x.discovery.UriSpec
-
- getPath() - Method in interface org.apache.curator.framework.api.CuratorEvent
-
- 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.utils.EnsurePath
-
Deprecated.
Returns the path being Ensured
- getPath() - Method in class org.apache.curator.utils.ZKPaths.PathAndNode
-
- getPathAndNode(String) - Static method in class org.apache.curator.utils.ZKPaths
-
Given a full path, return the node name and its path.
- getPathToWatch() - Method in class org.apache.curator.framework.recipes.locks.PredicateResults
-
- getPayload() - Method in class org.apache.curator.x.discovery.ServiceInstance
-
- getPort() - Method in class org.apache.curator.test.InstanceSpec
-
- getPort() - Method in class org.apache.curator.test.TestingServer
-
Return the port being used
- getPort() - Method in class org.apache.curator.x.discovery.ServiceInstance
-
- getProcessName(Class<?>) - Static method in class org.apache.curator.utils.ThreadUtils
-
- 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
- getProviderStrategy() - Method in class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
-
- getProviderStrategy() - Method in class org.apache.curator.x.discovery.server.contexts.IntegerDiscoveryContext
-
- getProviderStrategy() - Method in class org.apache.curator.x.discovery.server.contexts.StringDiscoveryContext
-
- getProviderStrategy() - Method in interface org.apache.curator.x.discovery.server.rest.DiscoveryContext
-
- 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
- getQuorumPeer() - Method in class org.apache.curator.test.TestingZooKeeperMain
-
- getQuorumPeer() - Method in class org.apache.curator.test.TestingZooKeeperServer
-
- getQuorumPeer() - Method in interface org.apache.curator.test.ZooKeeperMainFace
-
- getQuorumPort() - Method in class org.apache.curator.test.InstanceSpec
-
- getRandomPort() - Static method in class org.apache.curator.test.InstanceSpec
-
- getRaw(String, int, String, String) - Method in class org.apache.curator.ensemble.exhibitor.DefaultExhibitorRestClient
-
- getRaw(String, int, String, String) - Method in interface org.apache.curator.ensemble.exhibitor.ExhibitorRestClient
-
Connect to the given Exhibitor and return the raw result
- getRegistrationTimeUTC() - Method in class org.apache.curator.x.discovery.ServiceInstance
-
- getRestPort() - Method in class org.apache.curator.ensemble.exhibitor.Exhibitors
-
- getResultCode() - Method in interface org.apache.curator.framework.api.CuratorEvent
-
- getResultPath() - Method in class org.apache.curator.framework.api.transaction.CuratorTransactionResult
-
Returns the operation generated path or null
.
- getResultStat() - Method in class org.apache.curator.framework.api.transaction.CuratorTransactionResult
-
Returns the operation generated stat or null
.
- getRetryPolicy() - Method in class org.apache.curator.CuratorZookeeperClient
-
Return the current retry policy
- getRetryPolicy() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- getScheme() - Method in class org.apache.curator.framework.AuthInfo
-
- getServerId() - Method in class org.apache.curator.test.InstanceSpec
-
- getServers() - Method in class org.apache.curator.test.TestingCluster
-
- getServiceDiscovery() - Method in class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
-
- getServiceDiscovery() - Method in class org.apache.curator.x.discovery.server.contexts.IntegerDiscoveryContext
-
- getServiceDiscovery() - Method in class org.apache.curator.x.discovery.server.contexts.StringDiscoveryContext
-
- getServiceDiscovery() - Method in interface org.apache.curator.x.discovery.server.rest.DiscoveryContext
-
Return the service singleton
- getServices() - Method in class org.apache.curator.x.discovery.server.entity.ServiceInstances
-
- getServiceType() - Method in class org.apache.curator.x.discovery.ServiceInstance
-
- getSessionTimeoutMs() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- getShardQty() - Method in class org.apache.curator.framework.recipes.queue.QueueSharder
-
Return the current number of mananged queues
- getSize(ServiceInstance<T>, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
-
- getSize(ServiceInstances<T>, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
-
- getSize(ServiceNames, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
-
- getSleepTimeMs(int, long) - Method in class org.apache.curator.retry.BoundedExponentialBackoffRetry
-
- getSleepTimeMs(int, long) - Method in class org.apache.curator.retry.ExponentialBackoffRetry
-
- getSleepTimeMs(int, long) - Method in class org.apache.curator.retry.RetryNTimes
-
- getSleepTimeMs(int, long) - Method in class org.apache.curator.retry.RetryUntilElapsed
-
- 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
-
- getSortedChildren(ZooKeeper, String) - Static method in class org.apache.curator.utils.ZKPaths
-
Return the children of the given path sorted by sequence number
- getSslPort() - Method in class org.apache.curator.x.discovery.ServiceInstance
-
- getStat() - Method in interface org.apache.curator.framework.api.CuratorEvent
-
- getStat() - Method in class org.apache.curator.framework.recipes.cache.ChildData
-
Returns the stat data for this child
- getState() - Method in interface org.apache.curator.framework.CuratorFramework
-
Returns the state of this instance
- getState() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- 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
-
- getTempDirectory() - Method in class org.apache.curator.test.TestingServer
-
Returns the temp directory being used
- getThisInstance() - Method in class discovery.ExampleServer
-
- getThreadFactory() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- getTickTime() - Method in class org.apache.curator.test.InstanceSpec
-
- getTimeoutMs() - Method in class org.apache.curator.x.discovery.DownInstancePolicy
-
- getTracerDriver() - Method in class org.apache.curator.CuratorZookeeperClient
-
Return the current tracing driver
- getType() - Method in interface org.apache.curator.framework.api.CuratorEvent
-
check here first - this value determines the type of event and which methods will have
valid values
- getType() - Method in class org.apache.curator.framework.api.transaction.CuratorTransactionResult
-
Returns the operation type
- 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 interface org.apache.curator.framework.CuratorFramework
-
Returns the listenable interface for unhandled errors
- getUnhandledErrorListenable() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- getUriSpec() - Method in class org.apache.curator.x.discovery.ServiceInstance
-
- 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
-
- getValue() - Method in class org.apache.curator.x.discovery.UriSpec.Part
-
- 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
- getWatchedEvent() - Method in interface org.apache.curator.framework.api.CuratorEvent
-
- getZooKeeper() - Method in class org.apache.curator.CuratorZookeeperClient
-
Return the managed ZK instance.
- getZookeeperClient() - Method in interface org.apache.curator.framework.CuratorFramework
-
Return the managed zookeeper client
- getZookeeperClient() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- getZookeeperFactory() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- 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
-
- Guaranteeable - Interface in org.apache.curator.framework.api
-
- guaranteed() - Method in interface org.apache.curator.framework.api.Guaranteeable
-
Solves this edge case: deleting a node can fail due to connection issues.
- guaranteedDelete(CuratorFramework, String) - Static method in class framework.CrudExamples
-
- GzipCompressionProvider - Class in org.apache.curator.framework.imps
-
- GzipCompressionProvider() - Constructor for class org.apache.curator.framework.imps.GzipCompressionProvider
-
- id(String) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
- idFromPath(String) - Method in class org.apache.curator.framework.recipes.nodes.GroupMember
-
Given a full ZNode path, return the member ID
- inBackground() - Method in interface org.apache.curator.framework.api.Backgroundable
-
Perform the action in the background
- inBackground(Object) - Method in interface org.apache.curator.framework.api.Backgroundable
-
Perform the action in the background
- inBackground(BackgroundCallback) - Method in interface org.apache.curator.framework.api.Backgroundable
-
Perform the action in the background
- inBackground(BackgroundCallback, Object) - Method in interface org.apache.curator.framework.api.Backgroundable
-
Perform the action in the background
- inBackground(BackgroundCallback, Executor) - Method in interface org.apache.curator.framework.api.Backgroundable
-
Perform the action in the background
- inBackground(BackgroundCallback, Object, Executor) - Method in interface org.apache.curator.framework.api.Backgroundable
-
Perform the action in the background
- inBackground() - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
-
- inBackground(Object) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
-
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
-
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
-
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
-
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
-
- 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.
- InstanceCleanup - Class in org.apache.curator.x.discovery.server.rest
-
A background task that purges stale registrations.
- InstanceCleanup(ServiceDiscovery<?>, int) - Constructor for class org.apache.curator.x.discovery.server.rest.InstanceCleanup
-
- InstanceDetails - Class in discovery
-
In a real application, the Service payload will most likely
be more detailed than this.
- InstanceDetails() - Constructor for class discovery.InstanceDetails
-
- InstanceDetails(String) - Constructor for class discovery.InstanceDetails
-
- InstanceFilter<T> - Interface in org.apache.curator.x.discovery
-
Typedef for an Instance predicate
- InstanceProvider<T> - Interface in org.apache.curator.x.discovery.details
-
Provides a set of available instances for a service so that a strategy can pick one of them
- InstanceSerializer<T> - Interface in org.apache.curator.x.discovery.details
-
Injectable serializer for service instances
- InstanceSpec - Class in org.apache.curator.test
-
Abstracts one of the servers in the ensemble
- InstanceSpec(File, int, int, int, boolean, int) - Constructor for class org.apache.curator.test.InstanceSpec
-
- InstanceSpec(File, int, int, int, boolean, int, int, int) - Constructor for class org.apache.curator.test.InstanceSpec
-
- IntegerDiscoveryContext - Class in org.apache.curator.x.discovery.server.contexts
-
- IntegerDiscoveryContext(ServiceDiscovery<Integer>, ProviderStrategy<Integer>, int) - Constructor for class org.apache.curator.x.discovery.server.contexts.IntegerDiscoveryContext
-
- InternalACLProvider - Interface in org.apache.curator.utils
-
- internalRegisterService(ServiceInstance<T>) - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
- InternalScheduledFutureTask(ScheduledFuture<?>) - Constructor for class org.apache.curator.utils.CloseableExecutorService.InternalScheduledFutureTask
-
- internalSync(CuratorFrameworkImpl, String, Object) - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- InterProcessLock - Interface in org.apache.curator.framework.recipes.locks
-
- 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
-
- 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
-
- InterProcessSemaphore - Class in org.apache.curator.framework.recipes.locks
-
- 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
- inTransaction() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a transaction builder
- inTransaction() - Method in interface org.apache.curator.framework.CuratorTempFramework
-
Start a transaction builder
- inTransaction() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- inTransaction() - Method in class org.apache.curator.framework.imps.CuratorTempFrameworkImpl
-
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.curator.test.DelegatingExecutorService
-
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.curator.test.DelegatingExecutorService
-
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.curator.test.DelegatingExecutorService
-
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.curator.test.DelegatingExecutorService
-
- 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
-
- isCancelled() - Method in class org.apache.curator.utils.CloseableExecutorService.InternalScheduledFutureTask
-
- isConnected() - Method in class org.apache.curator.CuratorZookeeperClient
-
Returns true if the client is current connected
- isConnected() - Method in enum org.apache.curator.framework.state.ConnectionState
-
Check if this state indicates that Curator has a connection to ZooKeeper
- isConnected() - Method in class org.apache.curator.framework.state.ConnectionStateManager
-
- isDone() - Method in class org.apache.curator.utils.CloseableExecutorService.InternalScheduledFutureTask
-
- isExecuteCalled() - Method in class org.apache.curator.test.ExecuteCalledWatchingExecutorService
-
- isFromRandom() - Method in class org.apache.curator.test.QuorumConfigBuilder
-
- 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
- isOpen - Variable in class org.apache.curator.utils.CloseableExecutorService
-
- isProtected() - Method in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
-
Deprecated.
- isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
-
- isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
-
- isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
-
- isRetryException(Throwable) - Static method in class org.apache.curator.RetryLoop
-
Utility - return true if the given exception is retry-able
- isShutdown() - Method in class org.apache.curator.test.DelegatingExecutorService
-
- isShutdown() - Method in class org.apache.curator.utils.CloseableExecutorService
-
Returns true if this executor has been shut down.
- isStarted() - Method in interface org.apache.curator.framework.CuratorFramework
-
- isStarted() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
Deprecated.
- isTerminated() - Method in class org.apache.curator.test.DelegatingExecutorService
-
- isVariable() - Method in class org.apache.curator.x.discovery.UriSpec.Part
-
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
-
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
-
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
-
- iterator() - Method in class org.apache.curator.x.discovery.UriSpec
-
- Part(String, boolean) - Constructor for class org.apache.curator.x.discovery.UriSpec.Part
-
- Part() - Constructor for class org.apache.curator.x.discovery.UriSpec.Part
-
- 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
-
- PATH_SEPARATOR - Static variable in class org.apache.curator.utils.ZKPaths
-
Zookeeper's path separator character.
- Pathable<T> - Interface in org.apache.curator.framework.api
-
- PathAndBytesable<T> - Interface in org.apache.curator.framework.api
-
- PathAndNode(String, String) - Constructor for class org.apache.curator.utils.ZKPaths.PathAndNode
-
- PathCacheExample - Class in cache
-
An example of the PathChildrenCache.
- PathCacheExample() - Constructor for class cache.PathCacheExample
-
- PathChildrenCache - Class in org.apache.curator.framework.recipes.cache
-
A utility that attempts to keep all data from all children of a ZK path locally cached.
- 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
-
- PathChildrenCache(CuratorFramework, String, boolean, ThreadFactory) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
- PathChildrenCache(CuratorFramework, String, boolean, boolean, ThreadFactory) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
- PathChildrenCache(CuratorFramework, String, boolean, boolean, ExecutorService) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
- PathChildrenCache(CuratorFramework, String, boolean, boolean, CloseableExecutorService) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
- PathChildrenCache.StartMode - Enum in org.apache.curator.framework.recipes.cache
-
- 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
-
- PathUtils - Class in org.apache.curator.utils
-
This class is copied from Apache ZooKeeper.
- PathUtils() - Constructor for class org.apache.curator.utils.PathUtils
-
- payload(T) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
- 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.
- performBackgroundOperation(OperationAndData<String>) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
-
- PersistentEphemeralNode - Class in org.apache.curator.framework.recipes.nodes
-
- 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
-
- 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
-
- poll() - Method in class org.apache.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
-
- 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.
- pollForInitialEnsemble() - Method in class org.apache.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
-
Can be called prior to starting the Curator instance to set the current connection string
- port(int) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
- 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
- process(WatchedEvent) - Method in interface org.apache.curator.framework.api.CuratorWatcher
-
Same as Watcher.process(WatchedEvent)
.
- processResult(CuratorFramework, CuratorEvent) - Method in interface org.apache.curator.framework.api.BackgroundCallback
-
Called when the async background operation completes
- 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
-
- PROPERTY_DONT_LOG_CONNECTION_ISSUES - Static variable in class org.apache.curator.utils.DebugUtils
-
- PROPERTY_LOG_EVENTS - Static variable in class org.apache.curator.utils.DebugUtils
-
- PROPERTY_LOG_ONLY_FIRST_CONNECTION_ISSUE_AS_ERROR_LEVEL - Static variable in class org.apache.curator.utils.DebugUtils
-
- PROPERTY_RETRY_FAILED_TESTS - Static variable in class org.apache.curator.utils.DebugUtils
-
- ProtectACLCreateModePathAndBytesable<T> - Interface in org.apache.curator.framework.api
-
- ProviderStrategy<T> - Interface in org.apache.curator.x.discovery
-
A strategy for picking one from a set of instances
- providerStrategy(ProviderStrategy<T>) - Method in interface org.apache.curator.x.discovery.ServiceProviderBuilder
-
optional - set the provider strategy.
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- putMultiCompleted(MultiItem<T>) - Method in interface org.apache.curator.framework.recipes.queue.QueuePutListener
-
Notification that a multi item put has completed
- putService(ServiceInstance<T>, String, String) - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
-
- RandomStrategy<T> - Class in org.apache.curator.x.discovery.strategies
-
This strategy always picks a random instance from the list
- RandomStrategy() - Constructor for class org.apache.curator.x.discovery.strategies.RandomStrategy
-
- readFrom(Class<ServiceInstance<T>>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
-
- readFrom(Class<ServiceInstances<T>>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
-
- readFrom(Class<ServiceNames>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
-
- readLock() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock
-
Returns the lock used for reading.
- reap(Reaper.PathHolder) - Method in class org.apache.curator.framework.recipes.locks.Reaper
-
Deprecated.
- Reaper - Class in org.apache.curator.framework.recipes.locks
-
- Reaper(CuratorFramework) - Constructor for class org.apache.curator.framework.recipes.locks.Reaper
-
Deprecated.
Uses the default reaping threshold of 5 minutes and creates an internal thread pool
- Reaper(CuratorFramework, int) - Constructor for class org.apache.curator.framework.recipes.locks.Reaper
-
Deprecated.
Uses the given reaping threshold and creates an internal thread pool
- Reaper(CuratorFramework, ScheduledExecutorService, int) - Constructor for class org.apache.curator.framework.recipes.locks.Reaper
-
Deprecated.
- Reaper(CuratorFramework, ScheduledExecutorService, int, String) - Constructor for class org.apache.curator.framework.recipes.locks.Reaper
-
Deprecated.
- Reaper(CuratorFramework, ScheduledExecutorService, int, LeaderLatch) - Constructor for class org.apache.curator.framework.recipes.locks.Reaper
-
Deprecated.
- Reaper.Mode - Enum in org.apache.curator.framework.recipes.locks
-
Deprecated.
- rebuild() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
NOTE: this is a BLOCKING method.
- rebuild() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
NOTE: this is a BLOCKING method.
- rebuildNode(String) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
NOTE: this is a BLOCKING method.
- registerService(ServiceInstance<T>) - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
Register/re-register/update a service instance
- registerService(ServiceInstance<T>) - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
Register/re-register a service
- registrationTimeUTC(long) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
- 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
-
- remove(String) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
- 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.
- remove(UriSpec.Part) - Method in class org.apache.curator.x.discovery.UriSpec
-
Remove the given part
- removeBarrier() - Method in class org.apache.curator.framework.recipes.barriers.DistributedBarrier
-
Utility to remove the barrier node
- removeListener(T) - Method in interface org.apache.curator.framework.listen.Listenable
-
Remove the given listener
- removeListener(T) - Method in class org.apache.curator.framework.listen.ListenerContainer
-
- 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
-
- removeListener(ServiceCacheListener) - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
-
- removePath(String) - Method in class org.apache.curator.framework.recipes.locks.ChildReaper
-
Deprecated.
Remove a path from reaping
- removePath(String) - Method in class org.apache.curator.framework.recipes.locks.Reaper
-
Deprecated.
Stop reaping the given path
- removeService(String, String) - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
-
- requeue() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
Re-queue an attempt for leadership.
- restart() - Method in class org.apache.curator.test.TestingServer
-
Restart the server.
- restart() - Method in class org.apache.curator.test.TestingZooKeeperServer
-
Restart the server.
- restartServer(InstanceSpec) - Method in class org.apache.curator.test.TestingCluster
-
Restart the given server of the cluster
- RetryForever - Class in org.apache.curator.retry
-
- RetryForever(int) - Constructor for class org.apache.curator.retry.RetryForever
-
- RetryLoop - Class in org.apache.curator
-
Mechanism to perform an operation on Zookeeper that is safe against
disconnections and "recoverable" errors.
- RetryNTimes - Class in org.apache.curator.retry
-
Retry policy that retries a max number of times
- RetryNTimes(int, int) - Constructor for class org.apache.curator.retry.RetryNTimes
-
- RetryOneTime - Class in org.apache.curator.retry
-
A retry policy that retries only once
- RetryOneTime(int) - Constructor for class org.apache.curator.retry.RetryOneTime
-
- retryPolicy(RetryPolicy) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- 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
- RetryPolicy - Interface in org.apache.curator
-
Abstracts the policy to use when retrying connections
- RetrySleeper - Interface in org.apache.curator
-
Abstraction for retry policies to sleep
- RetryUntilElapsed - Class in org.apache.curator.retry
-
A retry policy that retries until a given amount of time elapses
- RetryUntilElapsed(int, int) - Constructor for class org.apache.curator.retry.RetryUntilElapsed
-
- 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
-
- RoundRobinStrategy<T> - Class in org.apache.curator.x.discovery.strategies
-
This strategy rotates sequentially through the list of instances
- RoundRobinStrategy() - Constructor for class org.apache.curator.x.discovery.strategies.RoundRobinStrategy
-
- runFromConfig(QuorumPeerConfig) - Method in class org.apache.curator.test.TestingZooKeeperMain
-
- runFromConfig(QuorumPeerConfig) - Method in interface org.apache.curator.test.ZooKeeperMainFace
-
- schedule(Reaper.PathHolder, int) - Method in class org.apache.curator.framework.recipes.locks.Reaper
-
Deprecated.
- schedule(Runnable, long, TimeUnit) - Method in class org.apache.curator.utils.CloseableScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled
after the given delay.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.curator.utils.CloseableScheduledExecutorService
-
Creates and executes a periodic action that becomes enabled first
after the given initial delay, and subsequently with the
given delay between the termination of one execution and the
commencement of the next.
- seconds() - Method in class org.apache.curator.test.Timing
-
Return the base time in seconds
- serialize(T) - Method in interface org.apache.curator.framework.recipes.queue.QueueSerializer
-
Turn a queue item into bytes
- serialize(ServiceInstance<T>) - Method in interface org.apache.curator.x.discovery.details.InstanceSerializer
-
Serialize an instance into bytes
- serialize(ServiceInstance<T>) - Method in class org.apache.curator.x.discovery.details.JsonInstanceSerializer
-
- serializer(InstanceSerializer<T>) - Method in class org.apache.curator.x.discovery.ServiceDiscoveryBuilder
-
- server - Variable in class org.apache.curator.test.BaseClassForTests
-
- ServiceCache<T> - Interface in org.apache.curator.x.discovery
-
- serviceCacheBuilder() - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
Allocate a new service cache builder.
- ServiceCacheBuilder<T> - Interface in org.apache.curator.x.discovery
-
- serviceCacheBuilder() - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
Allocate a new service cache builder.
- ServiceCacheImpl<T> - Class in org.apache.curator.x.discovery.details
-
- ServiceCacheListener - Interface in org.apache.curator.x.discovery.details
-
Listener for changes to a service cache
- ServiceDiscovery<T> - Interface in org.apache.curator.x.discovery
-
- ServiceDiscoveryBuilder<T> - Class in org.apache.curator.x.discovery
-
- ServiceDiscoveryImpl<T> - Class in org.apache.curator.x.discovery.details
-
A mechanism to register and query service instances using ZooKeeper
- ServiceDiscoveryImpl(CuratorFramework, String, InstanceSerializer<T>, ServiceInstance<T>, boolean) - Constructor for class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
- ServiceInstance<T> - Class in org.apache.curator.x.discovery
-
POJO that represents a service instance
- ServiceInstance(String, String, String, Integer, Integer, T, long, ServiceType, UriSpec) - Constructor for class org.apache.curator.x.discovery.ServiceInstance
-
- ServiceInstanceBuilder<T> - Class in org.apache.curator.x.discovery
-
Builder for service instances
- ServiceInstances<T> - Class in org.apache.curator.x.discovery.server.entity
-
Raw generic lists don't work well in JAX-RS.
- ServiceInstances() - Constructor for class org.apache.curator.x.discovery.server.entity.ServiceInstances
-
- ServiceInstances(Collection<? extends ServiceInstance<T>>) - Constructor for class org.apache.curator.x.discovery.server.entity.ServiceInstances
-
- serviceName(String) - Method in interface org.apache.curator.x.discovery.ServiceProviderBuilder
-
required - set the name of the service to be provided
- ServiceNames - Class in org.apache.curator.x.discovery.server.entity
-
Raw generic lists don't work well in JAX-RS.
- ServiceNames() - Constructor for class org.apache.curator.x.discovery.server.entity.ServiceNames
-
- ServiceNames(Collection<? extends String>) - Constructor for class org.apache.curator.x.discovery.server.entity.ServiceNames
-
- ServiceProvider<T> - Interface in org.apache.curator.x.discovery
-
The main API for Discovery.
- serviceProviderBuilder() - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
Allocate a new builder.
- serviceProviderBuilder() - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
Allocate a new builder.
- ServiceProviderBuilder<T> - Interface in org.apache.curator.x.discovery
-
- ServiceProviderImpl<T> - Class in org.apache.curator.x.discovery.details
-
The main interface for Service Discovery.
- ServiceProviderImpl(ServiceDiscoveryImpl<T>, String, ProviderStrategy<T>, ThreadFactory, List<InstanceFilter<T>>, DownInstancePolicy) - Constructor for class org.apache.curator.x.discovery.details.ServiceProviderImpl
-
- serviceType(ServiceType) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
- ServiceType - Enum in org.apache.curator.x.discovery
-
- session() - Method in class org.apache.curator.test.Timing
-
Return the value to use for ZK session timeout
- SessionFailedException() - Constructor for exception org.apache.curator.SessionFailRetryLoop.SessionFailedException
-
- SessionFailRetryLoop - Class in org.apache.curator
-
See
RetryLoop
for the main details on retry loops.
- SessionFailRetryLoop.Mode - Enum in org.apache.curator
-
- SessionFailRetryLoop.SessionFailedException - Exception in org.apache.curator
-
- sessionTimeoutMs(int) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- setACL() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a set ACL builder
- setACL() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- SetACLBuilder - Interface in org.apache.curator.framework.api
-
- 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
-
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
-
By default, TreeCache does not auto-create parent nodes for the cached path.
- setData(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
-
- setData() - Method in interface org.apache.curator.framework.api.transaction.CuratorTransaction
-
Start a setData builder in the transaction
- setData() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a set data builder
- setData() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- 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
- setDataAsync(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
-
- setDataAsyncWithCallback(CuratorFramework, BackgroundCallback, String, byte[]) - Static method in class framework.CrudExamples
-
- SetDataBackgroundVersionable - Interface in org.apache.curator.framework.api
-
- SetDataBuilder - Interface in org.apache.curator.framework.api
-
- setDataIsCompressed(boolean) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
Sets whether or to decompress node data; default false
.
- setDescription(String) - Method in class discovery.InstanceDetails
-
- 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
-
- setErrorMode(ErrorMode) - Method in interface org.apache.curator.framework.recipes.queue.QueueBase
-
- setExecuteCalled(boolean) - Method in class org.apache.curator.test.ExecuteCalledWatchingExecutorService
-
- setExecutor(ThreadFactory) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
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
-
Sets the executor to publish events; a default executor will be created if not specified.
- setExecutor(CloseableExecutorService) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
Sets the executor to publish events; a default executor will be created if not specified.
- setExhibitors(Exhibitors) - Method in class org.apache.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
-
Change the set of exhibitors to poll
- setId(String) - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
Sets the ID to store for this leader.
- setLocalIpFilter(LocalIpFilter) - Static method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
- setMaxChildren(int) - Method in class org.apache.curator.framework.recipes.locks.ChildReaper
-
Deprecated.
- setMaxDepth(int) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
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.
- setRetryPolicy(RetryPolicy) - Method in class org.apache.curator.CuratorZookeeperClient
-
Change the retry policy
- setSelector(TreeCacheSelector) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
- setThisData(byte[]) - Method in class org.apache.curator.framework.recipes.nodes.GroupMember
-
Change the data stored in this instance's node
- setToSuspended() - Method in class org.apache.curator.framework.state.ConnectionStateManager
-
- setTracerDriver(TracerDriver) - Method in class org.apache.curator.CuratorZookeeperClient
-
Change the tracing driver
- setup() - Method in class org.apache.curator.test.BaseClassForTests
-
- 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
-
- 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
-
- 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
- shouldContinue() - Method in class org.apache.curator.RetryLoop
-
If true is returned, make an attempt at the operation
- shouldContinue() - Method in class org.apache.curator.SessionFailRetryLoop
-
If true is returned, make an attempt at the set of operations
- shouldRetry(int) - Static method in class org.apache.curator.RetryLoop
-
Utility - return true if the given Zookeeper result code is retry-able
- shutdown() - Method in class org.apache.curator.test.DelegatingExecutorService
-
- shutdownNow() - Method in class org.apache.curator.test.DelegatingExecutorService
-
- 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 class org.apache.curator.framework.listen.ListenerContainer
-
Return the number of listeners
- size() - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
-
Returns the number of currently queue items
- size() - Method in class org.apache.curator.test.QuorumConfigBuilder
-
- sleepABit() - Method in class org.apache.curator.test.Timing
-
Sleep for a small amount of time
- sleepFor(long, TimeUnit) - Method in interface org.apache.curator.RetrySleeper
-
Sleep for the given time
- sortChildren(List<String>) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
-
- split(String) - Static method in class org.apache.curator.utils.ZKPaths
-
Given a full path, return the the individual parts, without slashes.
- sslPort(int) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
- 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 class discovery.ExampleServer
-
- start() - Method in class leader.ExampleClient
-
- start() - Method in class org.apache.curator.CuratorZookeeperClient
-
Must be called after construction
- start() - Method in interface org.apache.curator.ensemble.EnsembleProvider
-
- start() - Method in class org.apache.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
-
- start() - Method in class org.apache.curator.ensemble.fixed.FixedEnsembleProvider
-
- start() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start the client.
- start() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- start() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
Start the cache.
- start(boolean) - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
- start() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
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
-
Start the cache.
- start() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
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.locks.ChildReaper
-
Deprecated.
The reaper must be started
- start() - Method in class org.apache.curator.framework.recipes.locks.Reaper
-
Deprecated.
The reaper must be started
- 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.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.state.ConnectionStateManager
-
Start the manager
- start() - Method in class org.apache.curator.SessionFailRetryLoop
-
SessionFailRetryLoop must be started
- start() - Method in class org.apache.curator.test.TestingCluster
-
Start the ensemble.
- start() - Method in class org.apache.curator.test.TestingServer
-
Start the server
- start() - Method in class org.apache.curator.test.TestingZooKeeperServer
-
- start() - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
-
- start() - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
The discovery must be started before use
- start() - Method in class org.apache.curator.x.discovery.details.ServiceProviderImpl
-
The provider must be started before use
- start() - Method in class org.apache.curator.x.discovery.server.rest.InstanceCleanup
-
Start the task
- start() - Method in interface org.apache.curator.x.discovery.ServiceCache
-
The cache must be started before use
- start() - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
The discovery must be started before use
- start() - Method in interface org.apache.curator.x.discovery.ServiceProvider
-
The provider must be started before use
- startTracer(String) - Method in class org.apache.curator.CuratorZookeeperClient
-
Start a new tracer
- startTransaction(CuratorFramework) - Static method in class framework.TransactionExamples
-
- Statable<T> - Interface in org.apache.curator.framework.api
-
- 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
-
- stateChanged(CuratorFramework, ConnectionState) - Method in interface org.apache.curator.framework.state.ConnectionStateListener
-
Called when there is a state change in the connection
- StatPathable<T> - Interface in org.apache.curator.framework.api
-
- StickyStrategy<T> - Class in org.apache.curator.x.discovery.strategies
-
This strategy uses a master strategy to pick the initial instance.
- StickyStrategy(ProviderStrategy<T>) - Constructor for class org.apache.curator.x.discovery.strategies.StickyStrategy
-
- stop() - Method in class org.apache.curator.test.TestingCluster
-
Shutdown the ensemble WITHOUT freeing resources, etc.
- stop() - Method in class org.apache.curator.test.TestingServer
-
Stop the server without deleting the temp directory
- stop() - Method in class org.apache.curator.test.TestingZooKeeperServer
-
- storingStatIn(Stat) - Method in interface org.apache.curator.framework.api.Statable
-
Have the operation fill the provided stat object
- StringDiscoveryContext - Class in org.apache.curator.x.discovery.server.contexts
-
For convenience, a version of
DiscoveryContext
that uses a string as the
payload
- StringDiscoveryContext(ServiceDiscovery<String>, ProviderStrategy<String>, int) - Constructor for class org.apache.curator.x.discovery.server.contexts.StringDiscoveryContext
-
- submit(Callable<T>) - Method in class org.apache.curator.test.DelegatingExecutorService
-
- submit(Runnable, T) - Method in class org.apache.curator.test.DelegatingExecutorService
-
- submit(Runnable) - Method in class org.apache.curator.test.DelegatingExecutorService
-
- submit(Callable<V>) - Method in class org.apache.curator.utils.CloseableExecutorService
-
Submits a value-returning task for execution and returns a Future
representing the pending results of the task.
- submit(Runnable) - Method in class org.apache.curator.utils.CloseableExecutorService
-
Submits a Runnable task for execution and returns a Future
representing that task.
- 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.
- sync(String, Object) - Method in interface org.apache.curator.framework.CuratorFramework
-
- sync() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a sync builder.
- sync(String, Object) - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- sync() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
- SyncBuilder - Interface in org.apache.curator.framework.api
-
- SyncBuilderImpl - Class in org.apache.curator.framework.imps
-
- SyncBuilderImpl(CuratorFrameworkImpl) - Constructor for class org.apache.curator.framework.imps.SyncBuilderImpl
-
- 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.
- takeException(Exception) - Method in class org.apache.curator.RetryLoop
-
Pass any caught exceptions here
- takeException(Exception) - Method in class org.apache.curator.SessionFailRetryLoop
-
Pass any caught exceptions here
- takeLeadership(CuratorFramework) - Method in class leader.ExampleClient
-
- takeLeadership(CuratorFramework) - Method in interface org.apache.curator.framework.recipes.leader.LeaderSelectorListener
-
Called when your instance has been granted leadership.
- teardown() - Method in class org.apache.curator.test.BaseClassForTests
-
- TempGetDataBuilder - Interface in org.apache.curator.framework.api
-
- TestingCluster - Class in org.apache.curator.test
-
manages an internally running ensemble of ZooKeeper servers.
- TestingCluster(int) - Constructor for class org.apache.curator.test.TestingCluster
-
Creates an ensemble comprised of n
servers.
- TestingCluster(InstanceSpec...) - Constructor for class org.apache.curator.test.TestingCluster
-
Creates an ensemble using the given server specs
- TestingCluster(Collection<InstanceSpec>) - Constructor for class org.apache.curator.test.TestingCluster
-
Creates an ensemble using the given server specs
- TestingCluster(Map<InstanceSpec, Collection<InstanceSpec>>) - Constructor for class org.apache.curator.test.TestingCluster
-
Creates an ensemble using the given server specs
- TestingServer - Class in org.apache.curator.test
-
manages an internally running ZooKeeper server.
- TestingServer() - Constructor for class org.apache.curator.test.TestingServer
-
Create the server using a random port
- TestingServer(boolean) - Constructor for class org.apache.curator.test.TestingServer
-
Create the server using a random port
- TestingServer(int) - Constructor for class org.apache.curator.test.TestingServer
-
Create and start the server using the given port
- TestingServer(int, boolean) - Constructor for class org.apache.curator.test.TestingServer
-
Create the server using the given port
- TestingServer(int, File) - Constructor for class org.apache.curator.test.TestingServer
-
Create and start the server using the given port
- TestingServer(int, File, boolean) - Constructor for class org.apache.curator.test.TestingServer
-
Create the server using the given port
- TestingServer(InstanceSpec, boolean) - Constructor for class org.apache.curator.test.TestingServer
-
Create the server using the given port
- TestingZooKeeperMain - Class in org.apache.curator.test
-
- TestingZooKeeperMain() - Constructor for class org.apache.curator.test.TestingZooKeeperMain
-
- TestingZooKeeperServer - Class in org.apache.curator.test
-
Thanks to Jeremie BORDIER (ahfeel) for this code
- TestingZooKeeperServer(QuorumConfigBuilder) - Constructor for class org.apache.curator.test.TestingZooKeeperServer
-
- TestingZooKeeperServer(QuorumConfigBuilder, int) - Constructor for class org.apache.curator.test.TestingZooKeeperServer
-
- thisInstance(ServiceInstance<T>) - Method in class org.apache.curator.x.discovery.ServiceDiscoveryBuilder
-
Optional - instance that represents the service that is running.
- threadFactory(ThreadFactory) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
- 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
- threadFactory(ThreadFactory) - Method in interface org.apache.curator.x.discovery.ServiceCacheBuilder
-
Optional thread factory to use for the cache's internal thread.
- threadFactory(ThreadFactory) - Method in interface org.apache.curator.x.discovery.ServiceProviderBuilder
-
optional - the thread factory to use for creating internal threads
- ThreadUtils - Class in org.apache.curator.utils
-
- ThreadUtils() - Constructor for class org.apache.curator.utils.ThreadUtils
-
- 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)
- TimeTrace - Class in org.apache.curator
-
Utility to time a method or portion of code
- TimeTrace(String, TracerDriver) - Constructor for class org.apache.curator.TimeTrace
-
Create and start a timer
- Timing - Class in org.apache.curator.test
-
Utility to get various testing times
- Timing() - Constructor for class org.apache.curator.test.Timing
-
Use the default base time
- Timing(double) - Constructor for class org.apache.curator.test.Timing
-
Use a multiple of the default base time
- Timing(double, int) - Constructor for class org.apache.curator.test.Timing
-
Use a multiple of the default base time
- Timing(long, TimeUnit) - Constructor for class org.apache.curator.test.Timing
-
- Timing(long, TimeUnit, int) - Constructor for class org.apache.curator.test.Timing
-
- toString() - Method in class org.apache.curator.framework.AuthInfo
-
- 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
-
- toString() - Method in class org.apache.curator.test.InstanceSpec
-
- toString() - Method in class org.apache.curator.x.discovery.ServiceInstance
-
- TracerDriver - Interface in org.apache.curator.drivers
-
Mechanism for timing methods and recording counters
- transaction(CuratorFramework) - Static method in class framework.TransactionExamples
-
- TransactionCheckBuilder - Interface in org.apache.curator.framework.api.transaction
-
- TransactionCreateBuilder - Interface in org.apache.curator.framework.api.transaction
-
- TransactionDeleteBuilder - Interface in org.apache.curator.framework.api.transaction
-
- TransactionExamples - Class in framework
-
- TransactionExamples() - Constructor for class framework.TransactionExamples
-
- TransactionSetDataBuilder - Interface in org.apache.curator.framework.api.transaction
-
- 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
-
A utility that attempts to keep all data from all children of a ZK path locally cached.
- TreeCache(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.cache.TreeCache
-
Create a TreeCache for the given client and path with default options.
- TreeCache.Builder - Class in org.apache.curator.framework.recipes.cache
-
- 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.Type - Enum in org.apache.curator.framework.recipes.cache
-
Type of change
- TreeCacheListener - Interface in org.apache.curator.framework.recipes.cache
-
- 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
-
- 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
-
- 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.
- validatePath(String, boolean) - Static method in class org.apache.curator.utils.PathUtils
-
validate the provided znode path string
- validatePath(String) - Static method in class org.apache.curator.utils.PathUtils
-
Validate the provided znode path string
- 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.api.CuratorEventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.api.transaction.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.imps.CuratorFrameworkState
-
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
-
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.locks.Reaper.Mode
-
Deprecated.
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.
- valueOf(String) - Static method in enum org.apache.curator.framework.state.ConnectionState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.SessionFailRetryLoop.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.x.discovery.ServiceType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.curator.framework.api.CuratorEventType
-
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.api.transaction.OperationType
-
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.imps.CuratorFrameworkState
-
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
-
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.locks.Reaper.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.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.
- values() - Static method in enum org.apache.curator.framework.state.ConnectionState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.curator.SessionFailRetryLoop.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.curator.x.discovery.ServiceType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- Versionable<T> - Interface in org.apache.curator.framework.api
-
- VersionedValue<T> - Class in org.apache.curator.framework.recipes.shared
-
POJO for a version and a value
- VersionPathAndBytesable<T> - Interface in org.apache.curator.framework.api
-