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

A

ACLable<T> - Interface in com.netflix.curator.framework.api
 
ACLBackgroundPathable<T> - Interface in com.netflix.curator.framework.api
 
ACLBackgroundPathAndBytesable<T> - Interface in com.netflix.curator.framework.api
 
ACLCreateModeBackgroundPathAndBytesable<T> - Interface in com.netflix.curator.framework.api
 
ACLCreateModePathAndBytesable<T> - Interface in com.netflix.curator.framework.api
 
ACLPathAndBytesable<T> - Interface in com.netflix.curator.framework.api
 
ACLProvider - Interface in com.netflix.curator.framework.api
 
aclProvider(ACLProvider) - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
ACLVersionBackgroundPathable<T> - Interface in com.netflix.curator.framework.api
 
acquire() - Method in interface com.netflix.curator.framework.recipes.locks.InterProcessLock
Acquire the mutex - blocking until it's available.
acquire(long, TimeUnit) - Method in interface com.netflix.curator.framework.recipes.locks.InterProcessLock
Acquire the mutex - blocks until it's available or the given time expires.
acquire() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessMultiLock
Acquire the mutex - blocking until it's available.
acquire(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessMultiLock
Acquire the mutex - blocks until it's available or the given time expires.
acquire() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessMutex
Acquire the mutex - blocking until it's available.
acquire(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessMutex
Acquire the mutex - blocks until it's available or the given time expires.
acquire() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
Acquire a lease.
acquire(int) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
Acquire qty leases.
acquire(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
Acquire a lease.
acquire(int, long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
Acquire qty leases.
acquire() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreMutex
 
acquire(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreMutex
 
acquire() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreV2
Acquire a lease.
acquire(int) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreV2
Acquire qty leases.
acquire(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreV2
Acquire a lease.
acquire(int, long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreV2
Acquire qty leases.
acquireSemaphore(Semaphore) - Method in class com.netflix.curator.test.Timing
Wait on the given semaphore
acquireSemaphore(Semaphore, int) - Method in class com.netflix.curator.test.Timing
Wait on the given semaphore
add(Integer) - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicInteger
Add delta to the current value and return the new value information.
add(Long) - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicLong
Add delta to the current value and return the new value information.
add(T) - Method in interface com.netflix.curator.framework.recipes.atomic.DistributedAtomicNumber
Add delta to the current value and return the new value information.
add(UriSpec.Part) - Method in class com.netflix.curator.x.discovery.UriSpec
Add a part to the end of the list
addCount(String, int) - Method in interface com.netflix.curator.drivers.TracerDriver
Add to a named counter
addCount(String, int) - Method in class com.netflix.curator.utils.DefaultTracerDriver
 
addListener(T) - Method in interface com.netflix.curator.framework.listen.Listenable
Add the given listener.
addListener(T, Executor) - Method in interface com.netflix.curator.framework.listen.Listenable
Add the given listener.
addListener(T) - Method in class com.netflix.curator.framework.listen.ListenerContainer
 
addListener(T, Executor) - Method in class com.netflix.curator.framework.listen.ListenerContainer
 
addListener(SharedCountListener) - Method in class com.netflix.curator.framework.recipes.shared.SharedCount
 
addListener(SharedCountListener, Executor) - Method in class com.netflix.curator.framework.recipes.shared.SharedCount
 
addListener(ServiceCacheListener) - Method in class com.netflix.curator.x.discovery.details.ServiceCacheImpl
 
addListener(ServiceCacheListener, Executor) - Method in class com.netflix.curator.x.discovery.details.ServiceCacheImpl
 
addPath(String) - Method in class com.netflix.curator.framework.recipes.locks.Reaper
Add a path (using Mode.REAP_INDEFINITELY) to be checked by the reaper.
addPath(String, Reaper.Mode) - Method in class com.netflix.curator.framework.recipes.locks.Reaper
Add a path to be checked by the reaper.
address(String) - Method in class com.netflix.curator.x.discovery.ServiceInstanceBuilder
 
addStateChange(ConnectionState) - Method in class com.netflix.curator.framework.state.ConnectionStateManager
Post a state change.
addTrace(String, long, TimeUnit) - Method in interface com.netflix.curator.drivers.TracerDriver
Record the given trace event
addTrace(String, long, TimeUnit) - Method in class com.netflix.curator.utils.DefaultTracerDriver
 
allocateQueue(CuratorFramework, String) - Method in interface com.netflix.curator.framework.recipes.queue.QueueAllocator
 
allowRetry(int, long, RetrySleeper) - Method in class com.netflix.curator.retry.RetryUntilElapsed
 
allowRetry(int, long, RetrySleeper) - Method in interface com.netflix.curator.RetryPolicy
Called when an operation has failed for some reason.
and() - Method in interface com.netflix.curator.framework.api.transaction.CuratorTransactionBridge
Syntactic sugar to make the fluent interface more readable
apply() - Static method in class com.netflix.curator.test.ByteCodeRewrite
 
AtomicStats - Class in com.netflix.curator.framework.recipes.atomic
Debugging stats about operations
AtomicStats() - Constructor for class com.netflix.curator.framework.recipes.atomic.AtomicStats
 
AtomicValue<T> - Interface in com.netflix.curator.framework.recipes.atomic
Abstracts a value returned from one of the Atomics
attemptRevoke(CuratorFramework, String) - Static method in class com.netflix.curator.framework.recipes.locks.Revoker
Utility to mark a lock for revocation.
authorization(String, byte[]) - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
Add connection authorization
autoRequeue() - Method in class com.netflix.curator.framework.recipes.leader.LeaderSelector
By default, when LeaderSelectorListener.takeLeadership(CuratorFramework) returns, this instance is not requeued.
await() - Method in class com.netflix.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 com.netflix.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 com.netflix.curator.test.Timing
Wait on the given latch

B

Backgroundable<T> - Interface in com.netflix.curator.framework.api
 
BackgroundCallback - Interface in com.netflix.curator.framework.api
Functor for an async background operation
BackgroundPathable<T> - Interface in com.netflix.curator.framework.api
 
BackgroundPathAndBytesable<T> - Interface in com.netflix.curator.framework.api
 
basePath(String) - Method in class com.netflix.curator.x.discovery.ServiceDiscoveryBuilder
Required - set the base path to store in ZK
BlockingQueueConsumer<T> - Class in com.netflix.curator.framework.recipes.queue
Utility - a queue consumer that provides behavior similar to a BlockingQueue
BlockingQueueConsumer(ConnectionStateListener) - Constructor for class com.netflix.curator.framework.recipes.queue.BlockingQueueConsumer
Creates with capacity of Integer.MAX_VALUE
BlockingQueueConsumer(ConnectionStateListener, int) - Constructor for class com.netflix.curator.framework.recipes.queue.BlockingQueueConsumer
 
BlockingQueueConsumer(ConnectionStateListener, BlockingQueue<T>) - Constructor for class com.netflix.curator.framework.recipes.queue.BlockingQueueConsumer
Wrap the given blocking queue
blockUntilConnectedOrTimedOut() - Method in class com.netflix.curator.CuratorZookeeperClient
This method blocks until the connection to ZK succeeds.
blockUntilStarted() - Method in class com.netflix.curator.test.TestingZooKeeperMain
 
blockUntilStarted() - Method in interface com.netflix.curator.test.ZooKeeperMainFace
 
BoundedExponentialBackoffRetry - Class in com.netflix.curator.retry
Retry policy that retries a set number of times with an increasing (up to a maximum bound) sleep time between retries
BoundedExponentialBackoffRetry(int, int, int) - Constructor for class com.netflix.curator.retry.BoundedExponentialBackoffRetry
 
build() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
Apply the current values and build a new CuratorFramework
build() - Method in class com.netflix.curator.framework.recipes.atomic.PromotedToLock.Builder
Build the argument block
build() - Method in class com.netflix.curator.framework.recipes.queue.QueueSharderPolicies.Builder
 
build() - Method in interface com.netflix.curator.x.discovery.ServiceCacheBuilder
Return a new service cache with the current settings
build() - Method in class com.netflix.curator.x.discovery.ServiceDiscoveryBuilder
Build a new service discovery with the currently set values
build() - Method in class com.netflix.curator.x.discovery.ServiceInstanceBuilder
Return a new instance with the currently set values
build() - Method in interface com.netflix.curator.x.discovery.ServiceProviderBuilder
Allocate a new service provider based on the current builder settings
build() - Method in class com.netflix.curator.x.discovery.UriSpec
Build into a UriSpec string
build(ServiceInstance<?>) - Method in class com.netflix.curator.x.discovery.UriSpec
Build into a UriSpec string
build(Map<String, Object>) - Method in class com.netflix.curator.x.discovery.UriSpec
Build into a UriSpec string
build(ServiceInstance<?>, Map<String, Object>) - Method in class com.netflix.curator.x.discovery.UriSpec
Build into a UriSpec string
buildConfig() - Method in class com.netflix.curator.test.QuorumConfigBuilder
 
buildConfig(int) - Method in class com.netflix.curator.test.QuorumConfigBuilder
 
buildDelayQueue() - Method in class com.netflix.curator.framework.recipes.queue.QueueBuilder
Build a DistributedDelayQueue from the current builder values.
builder() - Static method in class com.netflix.curator.framework.CuratorFrameworkFactory
Return a new builder that builds a CuratorFramework
builder() - Static method in class com.netflix.curator.framework.recipes.atomic.PromotedToLock
Allocate a new builder
builder(CuratorFramework, QueueConsumer<T>, QueueSerializer<T>, String) - Static method in class com.netflix.curator.framework.recipes.queue.QueueBuilder
Allocate a new builder
builder() - Static method in class com.netflix.curator.framework.recipes.queue.QueueSharderPolicies
Allocate a new builder
builder(Class<T>) - Static method in class com.netflix.curator.x.discovery.ServiceDiscoveryBuilder
Return a new builder.
builder() - Static method in class com.netflix.curator.x.discovery.ServiceInstance
Return a new builder.
buildIdQueue() - Method in class com.netflix.curator.framework.recipes.queue.QueueBuilder
Build a DistributedIdQueue from the current builder values
buildPriorityQueue(int) - Method in class com.netflix.curator.framework.recipes.queue.QueueBuilder
Build a DistributedPriorityQueue from the current builder values.
buildQueue() - Method in class com.netflix.curator.framework.recipes.queue.QueueBuilder
Build a DistributedQueue from the current builder values
buildUriSpec() - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
buildUriSpec(Map<String, Object>) - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
ByteCodeRewrite - Class in com.netflix.curator.test
 
ByteCodeRewrite() - Constructor for class com.netflix.curator.test.ByteCodeRewrite
 

C

cache - package cache
 
cacheChanged() - Method in interface com.netflix.curator.x.discovery.details.ServiceCacheListener
Called when the cache has changed (instances added/deleted, etc.)
CachedAtomicInteger - Class in com.netflix.curator.framework.recipes.atomic
Uses an DistributedAtomicNumber and allocates values in chunks for better performance
CachedAtomicInteger(DistributedAtomicInteger, int) - Constructor for class com.netflix.curator.framework.recipes.atomic.CachedAtomicInteger
 
CachedAtomicLong - Class in com.netflix.curator.framework.recipes.atomic
Uses an DistributedAtomicNumber and allocates values in chunks for better performance
CachedAtomicLong(DistributedAtomicLong, int) - Constructor for class com.netflix.curator.framework.recipes.atomic.CachedAtomicLong
 
callWithRetry(CuratorZookeeperClient, Callable<T>) - Static method in class com.netflix.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 com.netflix.curator.SessionFailRetryLoop
Convenience utility: creates a "session fail" retry loop calling the given proc
check() - Method in interface com.netflix.curator.framework.api.transaction.CuratorTransaction
Start a check builder in the transaction
checkExists() - Method in interface com.netflix.curator.framework.CuratorFramework
Start an exists builder
checkExists() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
ChildData - Class in com.netflix.curator.framework.recipes.cache
 
childEvent(CuratorFramework, PathChildrenCacheEvent) - Method in interface com.netflix.curator.framework.recipes.cache.PathChildrenCacheListener
Called when a change has occurred
ChildReaper - Class in com.netflix.curator.framework.recipes.locks
Utility to reap empty child nodes of a parent node.
ChildReaper(CuratorFramework, String, Reaper.Mode) - Constructor for class com.netflix.curator.framework.recipes.locks.ChildReaper
 
ChildReaper(CuratorFramework, String, Reaper.Mode, int) - Constructor for class com.netflix.curator.framework.recipes.locks.ChildReaper
 
ChildReaper(CuratorFramework, String, Reaper.Mode, ScheduledExecutorService, int) - Constructor for class com.netflix.curator.framework.recipes.locks.ChildReaper
 
clean() - Method in class com.netflix.curator.framework.recipes.locks.LockInternals
Attempt to delete the lock node so that sequence numbers get reset
clear() - Method in class com.netflix.curator.framework.listen.ListenerContainer
Remove all listeners
clear() - Method in class com.netflix.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 com.netflix.curator.framework.recipes.cache.PathChildrenCache
Clear out current data and begin a new query on the path
client(CuratorFramework) - Method in class com.netflix.curator.x.discovery.ServiceDiscoveryBuilder
Required - set the client to use
close() - Method in class com.netflix.curator.CuratorZookeeperClient
Close the client
close() - Method in interface com.netflix.curator.ensemble.EnsembleProvider
Curator will call this method when CuratorZookeeperClient.close() is called
close() - Method in class com.netflix.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
 
close() - Method in class com.netflix.curator.ensemble.fixed.FixedEnsembleProvider
 
close() - Method in interface com.netflix.curator.framework.CuratorFramework
Stop the client
close() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
close() - Method in class com.netflix.curator.framework.recipes.cache.PathChildrenCache
Close/end the cache
close() - Method in class com.netflix.curator.framework.recipes.leader.LeaderLatch
Remove this instance from the leadership election.
close() - Method in class com.netflix.curator.framework.recipes.leader.LeaderSelector
Shutdown this selector and remove yourself from the leadership group
close() - Method in class com.netflix.curator.framework.recipes.locks.ChildReaper
 
close() - Method in interface com.netflix.curator.framework.recipes.locks.Lease
Releases the lease so that other clients/processes can acquire it
close() - Method in class com.netflix.curator.framework.recipes.locks.Reaper
 
close() - Method in class com.netflix.curator.framework.recipes.queue.DistributedDelayQueue
 
close() - Method in class com.netflix.curator.framework.recipes.queue.DistributedIdQueue
 
close() - Method in class com.netflix.curator.framework.recipes.queue.DistributedPriorityQueue
 
close() - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
 
close() - Method in class com.netflix.curator.framework.recipes.queue.QueueSharder
 
close() - Method in class com.netflix.curator.framework.recipes.shared.SharedCount
 
close() - Method in class com.netflix.curator.framework.recipes.shared.SharedValue
 
close() - Method in class com.netflix.curator.framework.state.ConnectionStateManager
 
close() - Method in class com.netflix.curator.SessionFailRetryLoop
Must be called in a finally handler when done with the loop
close() - Method in class com.netflix.curator.test.TestingCluster
Shutdown the ensemble, free resources, etc.
close() - Method in class com.netflix.curator.test.TestingServer
Close the server and any open clients and delete the temp directory
close() - Method in class com.netflix.curator.test.TestingZooKeeperMain
 
close() - Method in class com.netflix.curator.test.TestingZooKeeperServer
 
close() - Method in class com.netflix.curator.x.discovery.details.ServiceCacheImpl
 
close() - Method in class com.netflix.curator.x.discovery.details.ServiceDiscoveryImpl
 
close() - Method in class com.netflix.curator.x.discovery.details.ServiceProviderImpl
close() - Method in class com.netflix.curator.x.discovery.server.rest.InstanceCleanup
 
close() - Method in class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
 
close() - Method in class discovery.ExampleServer
 
close() - Method in class leader.ExampleClient
 
com.netflix.curator - package com.netflix.curator
 
com.netflix.curator.drivers - package com.netflix.curator.drivers
 
com.netflix.curator.ensemble - package com.netflix.curator.ensemble
 
com.netflix.curator.ensemble.exhibitor - package com.netflix.curator.ensemble.exhibitor
 
com.netflix.curator.ensemble.fixed - package com.netflix.curator.ensemble.fixed
 
com.netflix.curator.framework - package com.netflix.curator.framework
 
com.netflix.curator.framework.api - package com.netflix.curator.framework.api
 
com.netflix.curator.framework.api.transaction - package com.netflix.curator.framework.api.transaction
 
com.netflix.curator.framework.imps - package com.netflix.curator.framework.imps
 
com.netflix.curator.framework.listen - package com.netflix.curator.framework.listen
 
com.netflix.curator.framework.recipes.atomic - package com.netflix.curator.framework.recipes.atomic
 
com.netflix.curator.framework.recipes.barriers - package com.netflix.curator.framework.recipes.barriers
 
com.netflix.curator.framework.recipes.cache - package com.netflix.curator.framework.recipes.cache
 
com.netflix.curator.framework.recipes.leader - package com.netflix.curator.framework.recipes.leader
 
com.netflix.curator.framework.recipes.locks - package com.netflix.curator.framework.recipes.locks
 
com.netflix.curator.framework.recipes.queue - package com.netflix.curator.framework.recipes.queue
 
com.netflix.curator.framework.recipes.shared - package com.netflix.curator.framework.recipes.shared
 
com.netflix.curator.framework.state - package com.netflix.curator.framework.state
 
com.netflix.curator.retry - package com.netflix.curator.retry
 
com.netflix.curator.test - package com.netflix.curator.test
 
com.netflix.curator.utils - package com.netflix.curator.utils
 
com.netflix.curator.x.discovery - package com.netflix.curator.x.discovery
 
com.netflix.curator.x.discovery.details - package com.netflix.curator.x.discovery.details
 
com.netflix.curator.x.discovery.server.contexts - package com.netflix.curator.x.discovery.server.contexts
 
com.netflix.curator.x.discovery.server.entity - package com.netflix.curator.x.discovery.server.entity
 
com.netflix.curator.x.discovery.server.rest - package com.netflix.curator.x.discovery.server.rest
 
com.netflix.curator.x.discovery.strategies - package com.netflix.curator.x.discovery.strategies
 
com.netflix.curator.x.zkclientbridge - package com.netflix.curator.x.zkclientbridge
 
commit() - Method in interface com.netflix.curator.framework.api.transaction.CuratorTransactionFinal
Commit all added operations as an atomic unit and return results for the operations.
commit() - Method in class com.netflix.curator.TimeTrace
Record the elapsed time
compareAndSet(Integer, Integer) - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicInteger
 
compareAndSet(Long, Long) - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicLong
 
compareAndSet(T, T) - Method in interface com.netflix.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 com.netflix.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 com.netflix.curator.framework.recipes.cache.ChildData
 
compress(String, byte[]) - Method in interface com.netflix.curator.framework.api.CompressionProvider
 
compress(String, byte[]) - Method in class com.netflix.curator.framework.imps.GzipCompressionProvider
 
compressed() - Method in interface com.netflix.curator.framework.api.Compressible
Cause the data to be compressed using the configured compression provider
Compressible<T> - Interface in com.netflix.curator.framework.api
 
CompressionProvider - Interface in com.netflix.curator.framework.api
 
compressionProvider(CompressionProvider) - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
connect(Watcher) - Method in class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
 
connection() - Method in class com.netflix.curator.test.Timing
Return the value to use for ZK connection timeout
ConnectionState - Enum in com.netflix.curator.framework.state
Represents state changes in the connection to ZK
ConnectionStateListener - Interface in com.netflix.curator.framework.state
 
ConnectionStateManager - Class in com.netflix.curator.framework.state
Used internally to manage connection state
ConnectionStateManager(CuratorFramework, ThreadFactory) - Constructor for class com.netflix.curator.framework.state.ConnectionStateManager
 
connectionTimeoutMs(int) - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
connectString(String) - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
Set the list of servers to connect to.
consumeMessage(T) - Method in class com.netflix.curator.framework.recipes.queue.BlockingQueueConsumer
 
consumeMessage(T) - Method in interface com.netflix.curator.framework.recipes.queue.QueueConsumer
Process a message from the queue
countHasChanged(SharedCountReader, int) - Method in interface com.netflix.curator.framework.recipes.shared.SharedCountListener
Called when the shared value has changed
create() - Method in interface com.netflix.curator.framework.api.transaction.CuratorTransaction
Start a create builder in the transaction
create() - Method in interface com.netflix.curator.framework.CuratorFramework
Start a create builder
create() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
create(String, byte[], CreateMode) - Method in class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
 
create(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
 
CreateBackgroundModeACLable - Interface in com.netflix.curator.framework.api
 
CreateBuilder - Interface in com.netflix.curator.framework.api
 
CreateClientExamples - Class in framework
 
CreateClientExamples() - Constructor for class framework.CreateClientExamples
 
createEphemeral(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
 
createEphemeralSequential(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
 
CreateModable<T> - Interface in com.netflix.curator.framework.api
 
CreateModalPathAndBytesable<T> - Interface in com.netflix.curator.framework.api
 
createSimple(String) - Static method in class framework.CreateClientExamples
 
createWithOptions(String, RetryPolicy, int, int) - Static method in class framework.CreateClientExamples
 
creatingParentsIfNeeded() - Method in interface com.netflix.curator.framework.api.CreateBackgroundModeACLable
Causes any parent nodes to get created if they haven't already been
creatingParentsIfNeeded() - Method in interface com.netflix.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
 
CuratorEvent - Interface in com.netflix.curator.framework.api
A super set of all the various Zookeeper events/background methods.
CuratorEventType - Enum in com.netflix.curator.framework.api
 
CuratorFramework - Interface in com.netflix.curator.framework
Zookeeper framework-style client
CuratorFrameworkFactory - Class in com.netflix.curator.framework
Factory methods for creating framework-style clients
CuratorFrameworkFactory.Builder - Class in com.netflix.curator.framework
 
CuratorFrameworkImpl - Class in com.netflix.curator.framework.imps
 
CuratorFrameworkImpl(CuratorFrameworkFactory.Builder) - Constructor for class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
CuratorFrameworkImpl(CuratorFrameworkImpl) - Constructor for class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
CuratorListener - Interface in com.netflix.curator.framework.api
Receives notifications about errors and background events
CuratorTransaction - Interface in com.netflix.curator.framework.api.transaction
Transactional/atomic operations.
CuratorTransactionBridge - Interface in com.netflix.curator.framework.api.transaction
 
CuratorTransactionFinal - Interface in com.netflix.curator.framework.api.transaction
Adds commit to the transaction interface
CuratorTransactionResult - Class in com.netflix.curator.framework.api.transaction
Holds the result of one transactional operation
CuratorTransactionResult(OperationType, String, String, Stat) - Constructor for class com.netflix.curator.framework.api.transaction.CuratorTransactionResult
 
CuratorWatcher - Interface in com.netflix.curator.framework.api
A version of Watcher that can throw an exception
CuratorZKClientBridge - Class in com.netflix.curator.x.zkclientbridge
Bridge between ZKClient and Curator.
CuratorZKClientBridge(CuratorFramework) - Constructor for class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
 
CuratorZookeeperClient - Class in com.netflix.curator
A wrapper around Zookeeper that takes care of some low-level housekeeping
CuratorZookeeperClient(String, int, int, Watcher, RetryPolicy) - Constructor for class com.netflix.curator.CuratorZookeeperClient
 
CuratorZookeeperClient(EnsembleProvider, int, int, Watcher, RetryPolicy) - Constructor for class com.netflix.curator.CuratorZookeeperClient
 
CuratorZookeeperClient(ZookeeperFactory, EnsembleProvider, int, int, Watcher, RetryPolicy) - Constructor for class com.netflix.curator.CuratorZookeeperClient
 

D

DebugUtils - Class in com.netflix.curator.utils
 
decompress(String, byte[]) - Method in interface com.netflix.curator.framework.api.CompressionProvider
 
decompress(String, byte[]) - Method in class com.netflix.curator.framework.imps.GzipCompressionProvider
 
decompressed() - Method in interface com.netflix.curator.framework.api.Decompressible
Cause the data to be de-compressed using the configured compression provider
Decompressible<T> - Interface in com.netflix.curator.framework.api
 
decrement() - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicInteger
Subtract 1 from the current value and return the new value information.
decrement() - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicLong
Subtract 1 from the current value and return the new value information.
decrement() - Method in interface com.netflix.curator.framework.recipes.atomic.DistributedAtomicNumber
Subtract 1 from the current value and return the new value information.
DEFAULT_REFRESH_PADDING - Static variable in class com.netflix.curator.x.discovery.details.ServiceDiscoveryImpl
 
DefaultACLProvider - Class in com.netflix.curator.framework.imps
 
DefaultACLProvider() - Constructor for class com.netflix.curator.framework.imps.DefaultACLProvider
 
defaultData(byte[]) - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
Sets the data to use when PathAndBytesable.forPath(String) is used.
DefaultExhibitorRestClient - Class in com.netflix.curator.ensemble.exhibitor
 
DefaultExhibitorRestClient() - Constructor for class com.netflix.curator.ensemble.exhibitor.DefaultExhibitorRestClient
 
DefaultExhibitorRestClient(boolean) - Constructor for class com.netflix.curator.ensemble.exhibitor.DefaultExhibitorRestClient
 
DefaultTracerDriver - Class in com.netflix.curator.utils
Default tracer driver
DefaultTracerDriver() - Constructor for class com.netflix.curator.utils.DefaultTracerDriver
 
DefaultZookeeperFactory - Class in com.netflix.curator.utils
 
DefaultZookeeperFactory() - Constructor for class com.netflix.curator.utils.DefaultZookeeperFactory
 
delete() - Method in interface com.netflix.curator.framework.api.transaction.CuratorTransaction
Start a delete builder in the transaction
delete() - Method in interface com.netflix.curator.framework.CuratorFramework
Start a delete builder
delete() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
delete(String) - Method in class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
 
delete(CuratorFramework, String) - Static method in class framework.CrudExamples
 
DeleteBuilder - Interface in com.netflix.curator.framework.api
 
DeleteBuilderBase - Interface in com.netflix.curator.framework.api
 
deleteDataDirectoryOnClose() - Method in class com.netflix.curator.test.InstanceSpec
 
deleteDirectoryContents(File) - Static method in class com.netflix.curator.test.DirectoryUtils
 
deleteRecursively(File) - Static method in class com.netflix.curator.test.DirectoryUtils
 
deserialize(byte[]) - Method in interface com.netflix.curator.framework.recipes.queue.QueueSerializer
Deserialize bytes into a queue item
deserialize(byte[]) - Method in interface com.netflix.curator.x.discovery.details.InstanceSerializer
Deserialize a byte array into an instance
deserialize(byte[]) - Method in class com.netflix.curator.x.discovery.details.JsonInstanceSerializer
 
DirectoryUtils - Class in com.netflix.curator.test
 
DirectoryUtils() - Constructor for class com.netflix.curator.test.DirectoryUtils
 
discovery - package discovery
 
DiscoveryContext<T> - Interface in com.netflix.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 com.netflix.curator.x.discovery.server.rest
The JAX-RS web service.
DiscoveryResource(DiscoveryContext<T>) - Constructor for class com.netflix.curator.x.discovery.server.rest.DiscoveryResource
 
DistributedAtomicInteger - Class in com.netflix.curator.framework.recipes.atomic
A counter that attempts atomic increments.
DistributedAtomicInteger(CuratorFramework, String, RetryPolicy) - Constructor for class com.netflix.curator.framework.recipes.atomic.DistributedAtomicInteger
Creates in optimistic mode only - i.e.
DistributedAtomicInteger(CuratorFramework, String, RetryPolicy, PromotedToLock) - Constructor for class com.netflix.curator.framework.recipes.atomic.DistributedAtomicInteger
Creates in mutex promotion mode.
DistributedAtomicLong - Class in com.netflix.curator.framework.recipes.atomic
A counter that attempts atomic increments.
DistributedAtomicLong(CuratorFramework, String, RetryPolicy) - Constructor for class com.netflix.curator.framework.recipes.atomic.DistributedAtomicLong
Creates in optimistic mode only - i.e.
DistributedAtomicLong(CuratorFramework, String, RetryPolicy, PromotedToLock) - Constructor for class com.netflix.curator.framework.recipes.atomic.DistributedAtomicLong
Creates in mutex promotion mode.
DistributedAtomicNumber<T> - Interface in com.netflix.curator.framework.recipes.atomic
 
DistributedAtomicValue - Class in com.netflix.curator.framework.recipes.atomic
A distributed value that attempts atomic sets.
DistributedAtomicValue(CuratorFramework, String, RetryPolicy) - Constructor for class com.netflix.curator.framework.recipes.atomic.DistributedAtomicValue
Creates in optimistic mode only - i.e.
DistributedAtomicValue(CuratorFramework, String, RetryPolicy, PromotedToLock) - Constructor for class com.netflix.curator.framework.recipes.atomic.DistributedAtomicValue
Creates in mutex promotion mode.
DistributedBarrier - Class in com.netflix.curator.framework.recipes.barriers
A barrier as described in the ZK recipes.
DistributedBarrier(CuratorFramework, String) - Constructor for class com.netflix.curator.framework.recipes.barriers.DistributedBarrier
 
DistributedDelayQueue<T> - Class in com.netflix.curator.framework.recipes.queue
A variation of the DistributedPriorityQueue that uses time as the priority.
DistributedDoubleBarrier - Class in com.netflix.curator.framework.recipes.barriers
A double barrier as described in the ZK recipes.
DistributedDoubleBarrier(CuratorFramework, String, int) - Constructor for class com.netflix.curator.framework.recipes.barriers.DistributedDoubleBarrier
Creates the barrier abstraction.
DistributedIdQueue<T> - Class in com.netflix.curator.framework.recipes.queue
A version of DistributedQueue that allows IDs to be associated with queue items.
DistributedPriorityQueue<T> - Class in com.netflix.curator.framework.recipes.queue
An implementation of the Distributed Priority Queue ZK recipe.
DistributedQueue<T> - Class in com.netflix.curator.framework.recipes.queue
An implementation of the Distributed Queue ZK recipe.
DistributedQueue.ProcessType - Enum in com.netflix.curator.framework.recipes.queue
 
doWork(long, TimeUnit) - Method in class locking.ExampleClientThatLocks
 
drainTo(Collection<? super T>) - Method in class com.netflix.curator.framework.recipes.queue.BlockingQueueConsumer
Removes all available elements from this queue and adds them to the given collection.

E

element() - Method in class com.netflix.curator.framework.recipes.queue.SimpleDistributedQueue
Return the head of the queue without modifying the queue.
EnsembleProvider - Interface in com.netflix.curator.ensemble
Abstraction that provides the ZooKeeper connection string
ensembleProvider(EnsembleProvider) - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
Set the list ensemble provider.
ensure(CuratorZookeeperClient) - Method in class com.netflix.curator.utils.EnsurePath
First time, synchronizes and makes sure all nodes in the path are created.
EnsurePath - Class in com.netflix.curator.utils
Utility to ensure that a particular path is created.
EnsurePath(String) - Constructor for class com.netflix.curator.utils.EnsurePath
 
enter() - Method in class com.netflix.curator.framework.recipes.barriers.DistributedDoubleBarrier
Enter the barrier and block until all members have entered
enter(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.barriers.DistributedDoubleBarrier
Enter the barrier and block until all members have entered or the timeout has elapsed
equals(Object) - Method in class com.netflix.curator.framework.recipes.cache.ChildData
 
equals(Object) - Method in class com.netflix.curator.framework.recipes.leader.Participant
 
equals(Object) - Method in class com.netflix.curator.test.InstanceSpec
 
equals(Object) - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
equals(Object) - Method in class com.netflix.curator.x.discovery.UriSpec
 
equals(Object) - Method in class com.netflix.curator.x.discovery.UriSpec.Part
 
ErrorMode - Enum in com.netflix.curator.framework.recipes.queue
Used when the queue is created with a QueueBuilder.lockPath(String).
eventReceived(CuratorFramework, CuratorEvent) - Method in interface com.netflix.curator.framework.api.CuratorListener
Called when a background task has completed or a watch has triggered
ExampleClient - Class in leader
An example leader selector client
ExampleClient(CuratorFramework, String, String) - Constructor for class leader.ExampleClient
 
ExampleClientThatLocks - Class in locking
 
ExampleClientThatLocks(CuratorFramework, String, FakeLimitedResource, String) - Constructor for class locking.ExampleClientThatLocks
 
ExampleServer - Class in discovery
This shows a very simplified method of registering an instance with the service discovery.
ExampleServer(CuratorFramework, String, String, String) - Constructor for class discovery.ExampleServer
 
executor - Variable in class com.netflix.curator.framework.listen.ListenerEntry
 
executor(Executor) - Method in class com.netflix.curator.framework.recipes.queue.QueueBuilder
Change the executor used.
ExhibitorEnsembleProvider - Class in com.netflix.curator.ensemble.exhibitor
Ensemble provider that polls a cluster of Exhibitor (https://github.com/Netflix/exhibitor) instances for the connection string.
ExhibitorEnsembleProvider(Exhibitors, ExhibitorRestClient, String, int, RetryPolicy) - Constructor for class com.netflix.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
 
ExhibitorRestClient - Interface in com.netflix.curator.ensemble.exhibitor
 
Exhibitors - Class in com.netflix.curator.ensemble.exhibitor
POJO for specifying the cluster of Exhibitor instances
Exhibitors(Collection<String>, int, Exhibitors.BackupConnectionStringProvider) - Constructor for class com.netflix.curator.ensemble.exhibitor.Exhibitors
 
Exhibitors.BackupConnectionStringProvider - Interface in com.netflix.curator.ensemble.exhibitor
 
exists(String, boolean) - Method in class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
 
ExistsBuilder - Interface in com.netflix.curator.framework.api
 
ExponentialBackoffRetry - Class in com.netflix.curator.retry
Retry policy that retries a set number of times with increasing sleep time between retries
ExponentialBackoffRetry(int, int) - Constructor for class com.netflix.curator.retry.ExponentialBackoffRetry
 

F

FakeLimitedResource - Class in locking
Simulates some external resource that can only be access by one process at a time
FakeLimitedResource() - Constructor for class locking.FakeLimitedResource
 
FIELD_ADDRESS - Static variable in class com.netflix.curator.x.discovery.UriSpec
If a ServiceInstance is passed when building, the replacement is ServiceInstance.getAddress()
FIELD_CLOSE_BRACE - Static variable in class com.netflix.curator.x.discovery.UriSpec
Always replaced with '}' - i.e.
FIELD_ID - Static variable in class com.netflix.curator.x.discovery.UriSpec
If a ServiceInstance is passed when building, the replacement is ServiceInstance.getId()
FIELD_NAME - Static variable in class com.netflix.curator.x.discovery.UriSpec
If a ServiceInstance is passed when building, the replacement is ServiceInstance.getName()
FIELD_OPEN_BRACE - Static variable in class com.netflix.curator.x.discovery.UriSpec
Always replaced with '{' - i.e.
FIELD_PORT - Static variable in class com.netflix.curator.x.discovery.UriSpec
If a ServiceInstance is passed when building, the replacement is ServiceInstance.getPort()
FIELD_REGISTRATION_TIME_UTC - Static variable in class com.netflix.curator.x.discovery.UriSpec
If a ServiceInstance is passed when building, the replacement is ServiceInstance.getRegistrationTimeUTC()
FIELD_SCHEME - Static variable in class com.netflix.curator.x.discovery.UriSpec
This defaults to "http".
FIELD_SERVICE_TYPE - Static variable in class com.netflix.curator.x.discovery.UriSpec
If a ServiceInstance is passed when building, the replacement is ServiceInstance.getServiceType()
FIELD_SSL_PORT - Static variable in class com.netflix.curator.x.discovery.UriSpec
If a ServiceInstance is passed when building, the replacement is ServiceInstance.getSslPort()
finalFlushTime(int, TimeUnit) - Method in class com.netflix.curator.framework.recipes.queue.QueueBuilder
Sets an amount of time to call DistributedQueue.flushPuts(long, TimeUnit) when the queue is closed.
findConnectionInstance(ZooKeeper) - Method in class com.netflix.curator.test.TestingCluster
Given a ZooKeeper instance, returns which server it is connected to
FixedEnsembleProvider - Class in com.netflix.curator.ensemble.fixed
Standard ensemble provider that wraps a fixed connection string
FixedEnsembleProvider(String) - Constructor for class com.netflix.curator.ensemble.fixed.FixedEnsembleProvider
The connection string to use
fixForNamespace(String, String) - Static method in class com.netflix.curator.utils.ZKPaths
Apply the namespace to the given path
fixForSorting(String, String) - Method in interface com.netflix.curator.framework.recipes.locks.LockInternalsSorter
 
fixForSorting(String, String) - Method in class com.netflix.curator.framework.recipes.locks.StandardLockInternalsDriver
 
flushPuts(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.queue.DistributedDelayQueue
 
flushPuts(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.queue.DistributedIdQueue
 
flushPuts(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.queue.DistributedPriorityQueue
 
flushPuts(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
Wait until any pending puts are committed
flushPuts(long, TimeUnit) - Method in interface com.netflix.curator.framework.recipes.queue.QueueBase
Wait until any pending puts are committed
forceSet(Integer) - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicInteger
 
forceSet(Long) - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicLong
 
forceSet(T) - Method in interface com.netflix.curator.framework.recipes.atomic.DistributedAtomicNumber
Forcibly sets the value of the counter without any guarantees of atomicity.
forceSet(byte[]) - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicValue
Forcibly sets the value any guarantees of atomicity.
forEach(Function<T, Void>) - Method in class com.netflix.curator.framework.listen.ListenerContainer
Utility - apply the given function to each listener.
forPath(String) - Method in interface com.netflix.curator.framework.api.Pathable
Commit the currently building operation using the given path
forPath(String, byte[]) - Method in interface com.netflix.curator.framework.api.PathAndBytesable
Commit the currently building operation using the given path and data
forPath(String) - Method in interface com.netflix.curator.framework.api.PathAndBytesable
Commit the currently building operation using the given path and the default data for the client (usually a byte[0] unless changed via CuratorFrameworkFactory.Builder#defaultData(byte[])).
forWaiting() - Method in class com.netflix.curator.test.Timing
Return a new timing with the standard multiple for waiting on latches, etc.
framework - package framework
 

G

get() - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicInteger
 
get() - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicLong
 
get() - Method in interface com.netflix.curator.framework.recipes.atomic.DistributedAtomicNumber
Returns the current value of the counter.
get() - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicValue
Returns the current value of the counter.
get(String, String) - Method in class com.netflix.curator.x.discovery.server.rest.DiscoveryResource
 
getACL() - Method in interface com.netflix.curator.framework.CuratorFramework
Start a get ACL builder
getACL() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
GetACLBuilder - Interface in com.netflix.curator.framework.api
 
getAclForPath(String) - Method in interface com.netflix.curator.framework.api.ACLProvider
Return the ACL list to use for the given path
getAclForPath(String) - Method in class com.netflix.curator.framework.imps.DefaultACLProvider
 
getACLList() - Method in interface com.netflix.curator.framework.api.CuratorEvent
 
getAclProvider() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
getAddress() - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
getAll(String) - Method in class com.netflix.curator.x.discovery.server.rest.DiscoveryResource
 
getAllLocalIPs() - Static method in class com.netflix.curator.x.discovery.ServiceInstanceBuilder
based on http://pastebin.com/5X073pUc
getAllNames() - Method in class com.netflix.curator.x.discovery.server.rest.DiscoveryResource
 
getAny(String) - Method in class com.netflix.curator.x.discovery.server.rest.DiscoveryResource
 
getAuthScheme() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
getAuthValue() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
getBackupConnectionString() - Method in interface com.netflix.curator.ensemble.exhibitor.Exhibitors.BackupConnectionStringProvider
 
getBackupConnectionString() - Method in class com.netflix.curator.ensemble.exhibitor.Exhibitors
 
getBaseSleepTimeMs() - Method in class com.netflix.curator.retry.ExponentialBackoffRetry
 
getChildren() - Method in interface com.netflix.curator.framework.api.CuratorEvent
 
getChildren() - Method in interface com.netflix.curator.framework.CuratorFramework
Start a get children builder
getChildren() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
getChildren() - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
 
getChildren(String, boolean) - Method in class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
 
GetChildrenBuilder - Interface in com.netflix.curator.framework.api
 
getChildrenForEntering() - Method in class com.netflix.curator.framework.recipes.barriers.DistributedDoubleBarrier
 
getCompressionProvider() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
getConnectionStateListenable() - Method in interface com.netflix.curator.framework.CuratorFramework
Returns the listenable interface for the Connect State
getConnectionStateListenable() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
getConnectionString() - Method in interface com.netflix.curator.ensemble.EnsembleProvider
Return the current connection string to use.
getConnectionString() - Method in class com.netflix.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
 
getConnectionString() - Method in class com.netflix.curator.ensemble.fixed.FixedEnsembleProvider
 
getConnectionTimeoutMs() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
getConnectString() - Method in class com.netflix.curator.test.InstanceSpec
 
getConnectString() - Method in class com.netflix.curator.test.TestingCluster
Returns the connection string to pass to the ZooKeeper constructor
getConnectString() - Method in class com.netflix.curator.test.TestingServer
Returns the connection string to use
getContext() - Method in interface com.netflix.curator.framework.api.CuratorEvent
 
getContext(Class<?>) - Method in class com.netflix.curator.x.discovery.server.contexts.IntegerDiscoveryContext
 
getContext(Class<?>) - Method in class com.netflix.curator.x.discovery.server.contexts.MapDiscoveryContext
 
getContext(Class<?>) - Method in class com.netflix.curator.x.discovery.server.contexts.StringDiscoveryContext
 
getCount() - Method in class com.netflix.curator.framework.recipes.shared.SharedCount
 
getCount() - Method in interface com.netflix.curator.framework.recipes.shared.SharedCountReader
Return the current value of the count
getCreateTime(String) - Method in class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
 
getCurator() - Method in class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
Return the client
getCuratorListenable() - Method in interface com.netflix.curator.framework.CuratorFramework
Returns the listenable interface for events
getCuratorListenable() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
getCurrentConnectionString() - Method in class com.netflix.curator.CuratorZookeeperClient
Returns the current known connection string - not guaranteed to be correct value at any point in the future.
getCurrentData() - Method in class com.netflix.curator.framework.recipes.cache.PathChildrenCache
Return the current data.
getCurrentData(String) - Method in class com.netflix.curator.framework.recipes.cache.PathChildrenCache
Return the current data for the given path.
getData() - Method in interface com.netflix.curator.framework.api.CuratorEvent
 
getData() - Method in interface com.netflix.curator.framework.CuratorFramework
Start a get data builder
getData() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
getData() - Method in class com.netflix.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 com.netflix.curator.framework.recipes.cache.PathChildrenCacheEvent
 
GetDataBuilder - Interface in com.netflix.curator.framework.api
 
getDataDirectory() - Method in class com.netflix.curator.test.InstanceSpec
 
GetDataWatchBackgroundStatable - Interface in com.netflix.curator.framework.api
 
getDefaultAcl() - Method in interface com.netflix.curator.framework.api.ACLProvider
Return the ACL list to use by default (usually ZooDefs.Ids#OPEN_ACL_UNSAFE).
getDefaultAcl() - Method in class com.netflix.curator.framework.imps.DefaultACLProvider
 
getDefaultData() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
getDefaultRetrySleeper() - Static method in class com.netflix.curator.RetryLoop
Returns the default retry sleeper
getDelay(String) - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
 
getDescription() - Method in class discovery.InstanceDetails
 
getElectionPort() - Method in class com.netflix.curator.test.InstanceSpec
 
getEnsembleProvider() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
getForPath() - Method in class com.netflix.curator.framework.api.transaction.CuratorTransactionResult
Returns the path that was passed to the operation when added
getHostnames() - Method in class com.netflix.curator.ensemble.exhibitor.Exhibitors
 
getId() - Method in class com.netflix.curator.framework.recipes.leader.LeaderLatch
Return this instance's participant Id
getId() - Method in class com.netflix.curator.framework.recipes.leader.LeaderSelector
Return the ID that was set via LeaderSelector.setId(String)
getId() - Method in class com.netflix.curator.framework.recipes.leader.Participant
Returns the ID set via LeaderSelector.setId(String)
getId() - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
getInstance() - Method in class com.netflix.curator.x.discovery.details.ServiceProviderImpl
Return an instance for a single use.
getInstance(InstanceProvider<T>) - Method in interface com.netflix.curator.x.discovery.ProviderStrategy
Given a source of instances, return one of them for a single use.
getInstance() - Method in interface com.netflix.curator.x.discovery.ServiceProvider
Return an instance for a single use.
getInstance(InstanceProvider<T>) - Method in class com.netflix.curator.x.discovery.strategies.RandomStrategy
 
getInstance(InstanceProvider<T>) - Method in class com.netflix.curator.x.discovery.strategies.RoundRobinStrategy
 
getInstance(InstanceProvider<T>) - Method in class com.netflix.curator.x.discovery.strategies.StickyStrategy
 
getInstanceNumber() - Method in class com.netflix.curator.x.discovery.strategies.StickyStrategy
Each time a new instance is picked, an internal counter is incremented.
getInstanceRefreshMs() - Method in class com.netflix.curator.x.discovery.server.contexts.IntegerDiscoveryContext
 
getInstanceRefreshMs() - Method in class com.netflix.curator.x.discovery.server.contexts.MapDiscoveryContext
 
getInstanceRefreshMs() - Method in class com.netflix.curator.x.discovery.server.contexts.StringDiscoveryContext
 
getInstanceRefreshMs() - Method in interface com.netflix.curator.x.discovery.server.rest.DiscoveryContext
Return the threshold in milliseconds to consider a registration stale
getInstances() - Method in class com.netflix.curator.test.TestingCluster
Returns the set of servers in the ensemble
getInstances() - Method in interface com.netflix.curator.x.discovery.details.InstanceProvider
Return the current available set of instances
getInstances() - Method in class com.netflix.curator.x.discovery.details.ServiceCacheImpl
 
getInstances() - Method in interface com.netflix.curator.x.discovery.ServiceCache
Return the current list of instances.
getInstanceSpec(int) - Method in class com.netflix.curator.test.QuorumConfigBuilder
 
getInstanceSpec() - Method in class com.netflix.curator.test.TestingZooKeeperServer
 
getInstanceSpecs() - Method in class com.netflix.curator.test.QuorumConfigBuilder
 
getItems() - Method in class com.netflix.curator.framework.recipes.queue.BlockingQueueConsumer
Return any currently queued items without removing them from the queue
getLastMessageCount() - Method in class com.netflix.curator.framework.recipes.queue.DistributedDelayQueue
Return the most recent message count from the queue.
getLastMessageCount() - Method in class com.netflix.curator.framework.recipes.queue.DistributedIdQueue
 
getLastMessageCount() - Method in class com.netflix.curator.framework.recipes.queue.DistributedPriorityQueue
Return the most recent message count from the queue.
getLastMessageCount() - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
Return the most recent message count from the queue.
getLastMessageCount() - Method in interface com.netflix.curator.framework.recipes.queue.QueueBase
Return the most recent message count from the queue.
getLeader() - Method in class com.netflix.curator.framework.recipes.leader.LeaderLatch
Return the id for the current leader.
getLeader() - Method in class com.netflix.curator.framework.recipes.leader.LeaderSelector
Return the id for the current leader.
getListenable() - Method in class com.netflix.curator.framework.recipes.cache.PathChildrenCache
Return the cache listenable
getListenable() - Method in class com.netflix.curator.framework.recipes.shared.SharedValue
Returns the listenable
getListenable() - Method in interface com.netflix.curator.framework.recipes.shared.SharedValueReader
Returns the listenable
getListenable() - Method in class com.netflix.curator.framework.state.ConnectionStateManager
Return the listenable
getLockNodeBytes() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessMutex
 
getMaxSleepTimeMs() - Method in class com.netflix.curator.retry.BoundedExponentialBackoffRetry
 
getName() - Method in interface com.netflix.curator.framework.api.CuratorEvent
 
getName() - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
getNames() - Method in class com.netflix.curator.x.discovery.server.entity.ServiceNames
 
getNamespace() - Method in interface com.netflix.curator.framework.CuratorFramework
Return the current namespace or "" if none
getNamespace() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
getNamespace() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
getNode() - Method in class com.netflix.curator.utils.ZKPaths.PathAndNode
 
getNodeFromPath(String) - Static method in class com.netflix.curator.utils.ZKPaths
Given a full path, return the node name.
getOptimisticTimeMs() - Method in class com.netflix.curator.framework.recipes.atomic.AtomicStats
Returns the time spent trying the operation with optimistic locks
getOptimisticTries() - Method in class com.netflix.curator.framework.recipes.atomic.AtomicStats
Returns the number of optimistic locks used to perform the operation
getParticipantNodes() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessMutex
Return a sorted list of all current nodes participating in the lock
getParticipantNodes(CuratorFramework, String, String, LockInternalsSorter) - Static method in class com.netflix.curator.framework.recipes.locks.LockInternals
 
getParticipants() - Method in class com.netflix.curator.framework.recipes.leader.LeaderLatch
Returns the set of current participants in the leader selection
getParticipants() - Method in class com.netflix.curator.framework.recipes.leader.LeaderSelector
Returns the set of current participants in the leader selection
getParts() - Method in class com.netflix.curator.x.discovery.UriSpec
 
getPath() - Method in interface com.netflix.curator.framework.api.CuratorEvent
 
getPath() - Method in class com.netflix.curator.framework.recipes.cache.ChildData
Returns the full path of the this child
getPath() - Method in class com.netflix.curator.utils.ZKPaths.PathAndNode
 
getPathAndNode(String) - Static method in class com.netflix.curator.utils.ZKPaths
Given a full path, return the node name and its path.
getPayload() - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
getPort() - Method in class com.netflix.curator.test.InstanceSpec
 
getPort() - Method in class com.netflix.curator.test.TestingServer
Return the port being used
getPort() - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
getPromotedLockTries() - Method in class com.netflix.curator.framework.recipes.atomic.AtomicStats
Returns the number of mutex locks used to perform the operation
getPromotedTimeMs() - Method in class com.netflix.curator.framework.recipes.atomic.AtomicStats
Returns the time spent trying the operation with mutex locks
getProviderStrategy() - Method in class com.netflix.curator.x.discovery.server.contexts.IntegerDiscoveryContext
 
getProviderStrategy() - Method in class com.netflix.curator.x.discovery.server.contexts.MapDiscoveryContext
 
getProviderStrategy() - Method in class com.netflix.curator.x.discovery.server.contexts.StringDiscoveryContext
 
getProviderStrategy() - Method in interface com.netflix.curator.x.discovery.server.rest.DiscoveryContext
Return the provider strategy to use for DiscoveryResource.getAny(String)
getPutListenerContainer() - Method in class com.netflix.curator.framework.recipes.queue.DistributedDelayQueue
Return the manager for put listeners
getPutListenerContainer() - Method in class com.netflix.curator.framework.recipes.queue.DistributedIdQueue
 
getPutListenerContainer() - Method in class com.netflix.curator.framework.recipes.queue.DistributedPriorityQueue
Return the manager for put listeners
getPutListenerContainer() - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
Return the manager for put listeners
getPutListenerContainer() - Method in interface com.netflix.curator.framework.recipes.queue.QueueBase
Return the manager for put listeners
getQueue() - Method in class com.netflix.curator.framework.recipes.queue.QueueSharder
Return one of the managed queues - the selection method cannot be relied on.
getQueuePaths() - Method in class com.netflix.curator.framework.recipes.queue.QueueSharder
Return the current set of shard paths
getQuorumPort() - Method in class com.netflix.curator.test.InstanceSpec
 
getRandomPort() - Static method in class com.netflix.curator.test.InstanceSpec
 
getRaw(String, int, String, String) - Method in class com.netflix.curator.ensemble.exhibitor.DefaultExhibitorRestClient
 
getRaw(String, int, String, String) - Method in interface com.netflix.curator.ensemble.exhibitor.ExhibitorRestClient
Connect to the given Exhibitor and return the raw result
getRegistrationTimeUTC() - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
getRestPort() - Method in class com.netflix.curator.ensemble.exhibitor.Exhibitors
 
getResultCode() - Method in interface com.netflix.curator.framework.api.CuratorEvent
 
getResultPath() - Method in class com.netflix.curator.framework.api.transaction.CuratorTransactionResult
Returns the operation generated path or null.
getResultStat() - Method in class com.netflix.curator.framework.api.transaction.CuratorTransactionResult
Returns the operation generated stat or null.
getRetryPolicy() - Method in class com.netflix.curator.CuratorZookeeperClient
Return the current retry policy
getRetryPolicy() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
getServerId() - Method in class com.netflix.curator.test.InstanceSpec
 
getServers() - Method in class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
 
getServiceDiscovery() - Method in class com.netflix.curator.x.discovery.server.contexts.IntegerDiscoveryContext
 
getServiceDiscovery() - Method in class com.netflix.curator.x.discovery.server.contexts.MapDiscoveryContext
 
getServiceDiscovery() - Method in class com.netflix.curator.x.discovery.server.contexts.StringDiscoveryContext
 
getServiceDiscovery() - Method in interface com.netflix.curator.x.discovery.server.rest.DiscoveryContext
Return the service singleton
getServices() - Method in class com.netflix.curator.x.discovery.server.entity.ServiceInstances
 
getServiceType() - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
getSessionTimeoutMs() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
getShardQty() - Method in class com.netflix.curator.framework.recipes.queue.QueueSharder
Return the current number of mananged queues
getSize(ServiceInstance<T>, Class<?>, Type, Annotation[], MediaType) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
 
getSize(ServiceInstances<T>, Class<?>, Type, Annotation[], MediaType) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
 
getSize(ServiceNames, Class<?>, Type, Annotation[], MediaType) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
 
getSleepTimeMs(int, long) - Method in class com.netflix.curator.retry.BoundedExponentialBackoffRetry
 
getSleepTimeMs(int, long) - Method in class com.netflix.curator.retry.ExponentialBackoffRetry
 
getSleepTimeMs(int, long) - Method in class com.netflix.curator.retry.RetryNTimes
 
getSleepTimeMs(int, long) - Method in class com.netflix.curator.retry.RetryUntilElapsed
 
getSortedChildren(CuratorFramework, String, String, LockInternalsSorter) - Static method in class com.netflix.curator.framework.recipes.locks.LockInternals
 
getSortedChildren(ZooKeeper, String) - Static method in class com.netflix.curator.utils.ZKPaths
Return the children of the given path sorted by sequence number
getSslPort() - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
getStat() - Method in interface com.netflix.curator.framework.api.CuratorEvent
 
getStat() - Method in class com.netflix.curator.framework.recipes.cache.ChildData
Returns the stat data for this child
getStats() - Method in interface com.netflix.curator.framework.recipes.atomic.AtomicValue
Returns debugging stats about the operation
getsTheLock(CuratorFramework, List<String>, String, int) - Method in class com.netflix.curator.framework.recipes.locks.StandardLockInternalsDriver
 
getTempDirectory() - Method in class com.netflix.curator.test.TestingServer
Returns the temp directory being used
getThisInstance() - Method in class discovery.ExampleServer
 
getThreadFactory() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
getTracerDriver() - Method in class com.netflix.curator.CuratorZookeeperClient
Return the current tracing driver
getType() - Method in interface com.netflix.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 com.netflix.curator.framework.api.transaction.CuratorTransactionResult
Returns the operation type
getType() - Method in class com.netflix.curator.framework.recipes.cache.PathChildrenCacheEvent
 
getUnhandledErrorListenable() - Method in interface com.netflix.curator.framework.CuratorFramework
Returns the listenable interface for unhandled errors
getUnhandledErrorListenable() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
getUriSpec() - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
getValue() - Method in class com.netflix.curator.framework.recipes.shared.SharedValue
 
getValue() - Method in interface com.netflix.curator.framework.recipes.shared.SharedValueReader
Return the current value of the count
getValue() - Method in class com.netflix.curator.x.discovery.UriSpec.Part
 
getWatchedEvent() - Method in interface com.netflix.curator.framework.api.CuratorEvent
If CuratorEvent.getType() returns CuratorEventType.WATCHED this will return the WatchedEvent
getZooKeeper() - Method in class com.netflix.curator.CuratorZookeeperClient
Return the managed ZK instance.
getZookeeperClient() - Method in interface com.netflix.curator.framework.CuratorFramework
Return the managed zookeeper client
getZookeeperClient() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
getZookeeperFactory() - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
getZookeeperState() - Method in class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
 
guaranteed() - Method in interface com.netflix.curator.framework.api.DeleteBuilder
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 com.netflix.curator.framework.imps
 
GzipCompressionProvider() - Constructor for class com.netflix.curator.framework.imps.GzipCompressionProvider
 

H

handleException(Throwable) - Method in class com.netflix.curator.framework.recipes.cache.PathChildrenCache
Default behavior is just to log the exception
hashCode() - Method in class com.netflix.curator.framework.recipes.cache.ChildData
 
hashCode() - Method in class com.netflix.curator.framework.recipes.leader.Participant
 
hashCode() - Method in class com.netflix.curator.test.InstanceSpec
 
hashCode() - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
hashCode() - Method in class com.netflix.curator.x.discovery.UriSpec
 
hashCode() - Method in class com.netflix.curator.x.discovery.UriSpec.Part
 
hasLeadership() - Method in class com.netflix.curator.framework.recipes.leader.LeaderLatch
Return true if leadership is currently held by this instance
hasLeadership() - Method in class com.netflix.curator.framework.recipes.leader.LeaderSelector
Return true if leadership is currently held by this instance

I

id(String) - Method in class com.netflix.curator.x.discovery.ServiceInstanceBuilder
 
inBackground() - Method in interface com.netflix.curator.framework.api.Backgroundable
Perform the action in the background
inBackground(Object) - Method in interface com.netflix.curator.framework.api.Backgroundable
Perform the action in the background
inBackground(BackgroundCallback) - Method in interface com.netflix.curator.framework.api.Backgroundable
Perform the action in the background
inBackground(BackgroundCallback, Object) - Method in interface com.netflix.curator.framework.api.Backgroundable
Perform the action in the background
inBackground(BackgroundCallback, Executor) - Method in interface com.netflix.curator.framework.api.Backgroundable
Perform the action in the background
inBackground(BackgroundCallback, Object, Executor) - Method in interface com.netflix.curator.framework.api.Backgroundable
Perform the action in the background
increment() - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicInteger
Add 1 to the current value and return the new value information.
increment() - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicLong
Add 1 to the current value and return the new value information.
increment() - Method in interface com.netflix.curator.framework.recipes.atomic.DistributedAtomicNumber
Add 1 to the current value and return the new value information.
InstanceCleanup - Class in com.netflix.curator.x.discovery.server.rest
A background task that purges stale registrations.
InstanceCleanup(ServiceDiscovery<?>, int) - Constructor for class com.netflix.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
 
InstanceProvider<T> - Interface in com.netflix.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 com.netflix.curator.x.discovery.details
Injectable serializer for service instances
InstanceSpec - Class in com.netflix.curator.test
Abstracts one of the servers in the ensemble
InstanceSpec(File, int, int, int, boolean, int) - Constructor for class com.netflix.curator.test.InstanceSpec
 
IntegerDiscoveryContext - Class in com.netflix.curator.x.discovery.server.contexts
For convenience, a version of DiscoveryContext that uses an int as the payload
IntegerDiscoveryContext(ServiceDiscovery<Integer>, ProviderStrategy<Integer>, int) - Constructor for class com.netflix.curator.x.discovery.server.contexts.IntegerDiscoveryContext
 
internalSync(CuratorFrameworkImpl, String, Object) - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
InterProcessLock - Interface in com.netflix.curator.framework.recipes.locks
 
InterProcessMultiLock - Class in com.netflix.curator.framework.recipes.locks
A container that manages multiple locks as a single entity.
InterProcessMultiLock(CuratorFramework, List<String>) - Constructor for class com.netflix.curator.framework.recipes.locks.InterProcessMultiLock
Creates a multi lock of InterProcessMutexs
InterProcessMultiLock(List<InterProcessLock>) - Constructor for class com.netflix.curator.framework.recipes.locks.InterProcessMultiLock
Creates a multi lock of any type of inter process lock
InterProcessMutex - Class in com.netflix.curator.framework.recipes.locks
A re-entrant mutex that works across JVMs.
InterProcessMutex(CuratorFramework, String) - Constructor for class com.netflix.curator.framework.recipes.locks.InterProcessMutex
 
InterProcessReadWriteLock - Class in com.netflix.curator.framework.recipes.locks
A re-entrant read/write mutex that works across JVMs.
InterProcessReadWriteLock(CuratorFramework, String) - Constructor for class com.netflix.curator.framework.recipes.locks.InterProcessReadWriteLock
 
InterProcessSemaphore - Class in com.netflix.curator.framework.recipes.locks
Deprecated.
Use InterProcessSemaphoreV2 instead of this class. It uses a better algorithm.
InterProcessSemaphore(CuratorFramework, String, int) - Constructor for class com.netflix.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
 
InterProcessSemaphore(CuratorFramework, String, SharedCountReader) - Constructor for class com.netflix.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
 
InterProcessSemaphoreMutex - Class in com.netflix.curator.framework.recipes.locks
A NON re-entrant mutex that works across JVMs.
InterProcessSemaphoreMutex(CuratorFramework, String) - Constructor for class com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreMutex
 
InterProcessSemaphoreV2 - Class in com.netflix.curator.framework.recipes.locks
A counting semaphore that works across JVMs.
InterProcessSemaphoreV2(CuratorFramework, String, int) - Constructor for class com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreV2
 
InterProcessSemaphoreV2(CuratorFramework, String, SharedCountReader) - Constructor for class com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreV2
 
inTransaction() - Method in interface com.netflix.curator.framework.CuratorFramework
Start a transaction builder
inTransaction() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
isAcquiredInThisProcess() - Method in interface com.netflix.curator.framework.recipes.locks.InterProcessLock
Returns true if the mutex is acquired by a thread in this JVM
isAcquiredInThisProcess() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessMultiLock
 
isAcquiredInThisProcess() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessMutex
Returns true if the mutex is acquired by a thread in this JVM
isAcquiredInThisProcess() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreMutex
 
isConnected() - Method in class com.netflix.curator.CuratorZookeeperClient
Returns true if the client is current connected
isFromRandom() - Method in class com.netflix.curator.test.QuorumConfigBuilder
 
isLeader() - Method in class com.netflix.curator.framework.recipes.leader.Participant
Returns true if this participant is the current leader
isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
 
isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
 
isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
 
isRetryException(Throwable) - Static method in class com.netflix.curator.RetryLoop
Utility - return true if the given exception is retry-able
isStarted() - Method in interface com.netflix.curator.framework.CuratorFramework
Return true if the client is started, not closed, etc.
isStarted() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
isVariable() - Method in class com.netflix.curator.x.discovery.UriSpec.Part
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
 
iterator() - Method in class com.netflix.curator.x.discovery.UriSpec
 

J

JsonInstanceSerializer<T> - Class in com.netflix.curator.x.discovery.details
A serializer that uses Jackson to serialize/deserialize as JSON.
JsonInstanceSerializer(Class<T>) - Constructor for class com.netflix.curator.x.discovery.details.JsonInstanceSerializer
 
JsonServiceInstanceMarshaller<T> - Class in com.netflix.curator.x.discovery.server.entity
Message body reader/writer.
JsonServiceInstanceMarshaller(DiscoveryContext<T>) - Constructor for class com.netflix.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
 
JsonServiceInstancesMarshaller<T> - Class in com.netflix.curator.x.discovery.server.entity
Message body reader/writer.
JsonServiceInstancesMarshaller(DiscoveryContext<T>) - Constructor for class com.netflix.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
 
JsonServiceNamesMarshaller - Class in com.netflix.curator.x.discovery.server.entity
Message body reader/writer.
JsonServiceNamesMarshaller() - Constructor for class com.netflix.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
 

K

kill(ZooKeeper, String) - Static method in class com.netflix.curator.test.KillSession
Kill the given ZK session
kill(ZooKeeper, String, int) - Static method in class com.netflix.curator.test.KillSession
Kill the given ZK session
kill() - Method in class com.netflix.curator.test.TestingZooKeeperMain
 
kill() - Method in class com.netflix.curator.test.TestingZooKeeperServer
 
kill() - Method in interface com.netflix.curator.test.ZooKeeperMainFace
 
killServer(InstanceSpec) - Method in class com.netflix.curator.test.TestingCluster
Kills the given server.
KillSession - Class in com.netflix.curator.test
Utility to simulate a ZK session dying.
KillSession() - Constructor for class com.netflix.curator.test.KillSession
 

L

leader - package leader
 
LeaderLatch - Class in com.netflix.curator.framework.recipes.leader
Abstraction to select a "leader" amongst multiple contenders in a group of JMVs connected to a Zookeeper cluster.
LeaderLatch(CuratorFramework, String) - Constructor for class com.netflix.curator.framework.recipes.leader.LeaderLatch
 
LeaderLatch(CuratorFramework, String, String) - Constructor for class com.netflix.curator.framework.recipes.leader.LeaderLatch
 
LeaderSelector - Class in com.netflix.curator.framework.recipes.leader
Abstraction to select a "leader" amongst multiple contenders in a group of JMVs connected to a Zookeeper cluster.
LeaderSelector(CuratorFramework, String, LeaderSelectorListener) - Constructor for class com.netflix.curator.framework.recipes.leader.LeaderSelector
 
LeaderSelector(CuratorFramework, String, ThreadFactory, Executor, LeaderSelectorListener) - Constructor for class com.netflix.curator.framework.recipes.leader.LeaderSelector
 
LeaderSelectorExample - Class in leader
 
LeaderSelectorExample() - Constructor for class leader.LeaderSelectorExample
 
LeaderSelectorListener - Interface in com.netflix.curator.framework.recipes.leader
Notification for leadership
Lease - Interface in com.netflix.curator.framework.recipes.locks
Represents an acquired lease from an InterProcessSemaphore.
leave() - Method in class com.netflix.curator.framework.recipes.barriers.DistributedDoubleBarrier
Leave the barrier and block until all members have left
leave(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.barriers.DistributedDoubleBarrier
Leave the barrier and block until all members have left or the timeout has elapsed
Listenable<T> - Interface in com.netflix.curator.framework.listen
Abstracts a listenable object
listener - Variable in class com.netflix.curator.framework.listen.ListenerEntry
 
ListenerContainer<T> - Class in com.netflix.curator.framework.listen
Abstracts an object that has listeners
ListenerContainer() - Constructor for class com.netflix.curator.framework.listen.ListenerContainer
 
ListenerEntry<T> - Class in com.netflix.curator.framework.listen
Generic holder POJO for a listener and its executor
ListenerEntry(T, Executor) - Constructor for class com.netflix.curator.framework.listen.ListenerEntry
 
locking - package locking
 
LockingExample - Class in locking
 
LockingExample() - Constructor for class locking.LockingExample
 
LockInternals - Class in com.netflix.curator.framework.recipes.locks
 
LockInternalsSorter - Interface in com.netflix.curator.framework.recipes.locks
 
lockPath(String) - Method in class com.netflix.curator.framework.recipes.atomic.PromotedToLock.Builder
Set the path for the mutex lock (required)
lockPath(String) - Method in class com.netflix.curator.framework.recipes.queue.QueueBuilder
Without a lock set, queue items are removed before being sent to the queue consumer.

M

main(String[]) - Static method in class cache.PathCacheExample
 
main(String[]) - Static method in class discovery.DiscoveryExample
 
main(String[]) - Static method in class leader.LeaderSelectorExample
 
main(String[]) - Static method in class locking.LockingExample
 
makePath(String, String) - Static method in class com.netflix.curator.utils.ZKPaths
Given a parent path and a child node, create a combined full path
makeRevocable(RevocationListener<InterProcessMutex>) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessMutex
 
makeRevocable(RevocationListener<InterProcessMutex>, Executor) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessMutex
 
makeRevocable(RevocationListener<T>) - Method in interface com.netflix.curator.framework.recipes.locks.Revocable
Make the lock revocable.
makeRevocable(RevocationListener<T>, Executor) - Method in interface com.netflix.curator.framework.recipes.locks.Revocable
Make the lock revocable.
MapDiscoveryContext - Class in com.netflix.curator.x.discovery.server.contexts
For convenience, a version of DiscoveryContext that uses a String-to-String map as the payload
MapDiscoveryContext(ServiceDiscovery<Map<String, String>>, ProviderStrategy<Map<String, String>>, int) - Constructor for class com.netflix.curator.x.discovery.server.contexts.MapDiscoveryContext
 
markComplete() - Method in class com.netflix.curator.RetryLoop
Call this when your operation has successfully completed
marshallJson(ObjectNode, String, Integer) - Method in class com.netflix.curator.x.discovery.server.contexts.IntegerDiscoveryContext
 
marshallJson(ObjectNode, String, Map<String, String>) - Method in class com.netflix.curator.x.discovery.server.contexts.MapDiscoveryContext
 
marshallJson(ObjectNode, String, String) - Method in class com.netflix.curator.x.discovery.server.contexts.StringDiscoveryContext
 
marshallJson(ObjectNode, String, T) - Method in interface com.netflix.curator.x.discovery.server.rest.DiscoveryContext
Serialize your payload
maxItems(int) - Method in class com.netflix.curator.framework.recipes.queue.QueueBuilder
By default, the various queues are unbounded.
maxQueues(int) - Method in class com.netflix.curator.framework.recipes.queue.QueueSharderPolicies.Builder
Change the maximum number of queues to create.
milliseconds() - Method in class com.netflix.curator.test.Timing
Return the base time in milliseconds
mkdirs(ZooKeeper, String) - Static method in class com.netflix.curator.utils.ZKPaths
Make sure all the nodes in the path are created.
mkdirs(ZooKeeper, String, boolean) - Static method in class com.netflix.curator.utils.ZKPaths
Make sure all the nodes in the path are created.
MultiItem<T> - Interface in com.netflix.curator.framework.recipes.queue
Abstraction for multiple items.
multiple(double) - Method in class com.netflix.curator.test.Timing
Return a new timing that is a multiple of the this timing

N

name(String) - Method in interface com.netflix.curator.x.discovery.ServiceCacheBuilder
The name of the service to cache (required)
name(String) - Method in class com.netflix.curator.x.discovery.ServiceInstanceBuilder
 
namespace(String) - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
As ZooKeeper is a shared space, users of a given cluster should stay within a pre-defined namespace.
newClient(String, RetryPolicy) - Static method in class com.netflix.curator.framework.CuratorFrameworkFactory
Create a new client with default session timeout and default connection timeout
newClient(String, int, int, RetryPolicy) - Static method in class com.netflix.curator.framework.CuratorFrameworkFactory
Create a new client
newFixedThreadPool(int, String) - Static method in class com.netflix.curator.utils.ThreadUtils
 
newFixedThreadScheduledPool(int, String) - Static method in class com.netflix.curator.utils.ThreadUtils
 
newInstanceSpec() - Static method in class com.netflix.curator.test.InstanceSpec
 
newNamespaceAwareEnsurePath(String) - Method in interface com.netflix.curator.framework.CuratorFramework
Allocates an ensure path instance that is namespace aware
newNamespaceAwareEnsurePath(String) - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
newQueueThreshold(int) - Method in class com.netflix.curator.framework.recipes.queue.QueueSharderPolicies.Builder
Change the queue threshold.
newRetryLoop() - Method in class com.netflix.curator.CuratorZookeeperClient
Return a new retry loop.
newSessionFailRetryLoop(SessionFailRetryLoop.Mode) - Method in class com.netflix.curator.CuratorZookeeperClient
Return a new "session fail" retry loop.
newSingleThreadExecutor(String) - Static method in class com.netflix.curator.utils.ThreadUtils
 
newSingleThreadScheduledExecutor(String) - Static method in class com.netflix.curator.utils.ThreadUtils
 
newThreadFactory(String) - Static method in class com.netflix.curator.utils.ThreadUtils
 
newZooKeeper(String, int, Watcher) - Method in class com.netflix.curator.utils.DefaultZookeeperFactory
 
newZooKeeper(String, int, Watcher) - Method in interface com.netflix.curator.utils.ZookeeperFactory
Allocate a new ZooKeeper instance
next() - Method in class com.netflix.curator.framework.recipes.atomic.CachedAtomicInteger
Returns the next value (incrementing by 1).
next() - Method in class com.netflix.curator.framework.recipes.atomic.CachedAtomicLong
Returns the next value (incrementing by 1).
nextItem() - Method in interface com.netflix.curator.framework.recipes.queue.MultiItem
Called repeatedly to get the items to add to the queue.
nonNamespaceView() - Method in interface com.netflix.curator.framework.CuratorFramework
nonNamespaceView() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 

O

offer(byte[]) - Method in class com.netflix.curator.framework.recipes.queue.SimpleDistributedQueue
Inserts data into queue.
ofTypeAndPath(OperationType, String) - Static method in class com.netflix.curator.framework.api.transaction.CuratorTransactionResult
Utility that can be passed to Google Guava to find a particular result.
OperationType - Enum in com.netflix.curator.framework.api.transaction
Transaction operation types

P

Participant - Class in com.netflix.curator.framework.recipes.leader
Describes a participant in a leadership selection
Participant(String, boolean) - Constructor for class com.netflix.curator.framework.recipes.leader.Participant
 
Pathable<T> - Interface in com.netflix.curator.framework.api
 
PathAndBytesable<T> - Interface in com.netflix.curator.framework.api
 
PathCacheExample - Class in cache
An example of the PathChildrenCache.
PathCacheExample() - Constructor for class cache.PathCacheExample
 
PathChildrenCache - Class in com.netflix.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 com.netflix.curator.framework.recipes.cache.PathChildrenCache
PathChildrenCache(CuratorFramework, String, PathChildrenCacheMode, ThreadFactory) - Constructor for class com.netflix.curator.framework.recipes.cache.PathChildrenCache
PathChildrenCache(CuratorFramework, String, boolean) - Constructor for class com.netflix.curator.framework.recipes.cache.PathChildrenCache
 
PathChildrenCache(CuratorFramework, String, boolean, ThreadFactory) - Constructor for class com.netflix.curator.framework.recipes.cache.PathChildrenCache
 
PathChildrenCache(CuratorFramework, String, boolean, boolean, ThreadFactory) - Constructor for class com.netflix.curator.framework.recipes.cache.PathChildrenCache
 
PathChildrenCacheEvent - Class in com.netflix.curator.framework.recipes.cache
POJO that abstracts a change to a path
PathChildrenCacheEvent(PathChildrenCacheEvent.Type, ChildData) - Constructor for class com.netflix.curator.framework.recipes.cache.PathChildrenCacheEvent
 
PathChildrenCacheEvent.Type - Enum in com.netflix.curator.framework.recipes.cache
Type of change
PathChildrenCacheListener - Interface in com.netflix.curator.framework.recipes.cache
Listener for PathChildrenCache changes
PathChildrenCacheMode - Enum in com.netflix.curator.framework.recipes.cache
payload(T) - Method in class com.netflix.curator.x.discovery.ServiceInstanceBuilder
 
peek() - Method in class com.netflix.curator.framework.recipes.queue.SimpleDistributedQueue
Returns the data at the first element of the queue, or null if the queue is empty.
poll() - Method in class com.netflix.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
 
poll(long, TimeUnit) - Method in class com.netflix.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 com.netflix.curator.framework.recipes.queue.SimpleDistributedQueue
Attempts to remove the head of the queue and return it.
pollForInitialEnsemble() - Method in class com.netflix.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
Can be called prior to starting the Curator instance to set the current connection string
port(int) - Method in class com.netflix.curator.x.discovery.ServiceInstanceBuilder
 
postValue() - Method in interface com.netflix.curator.framework.recipes.atomic.AtomicValue
Returns the value of the counter after to the operation
preValue() - Method in interface com.netflix.curator.framework.recipes.atomic.AtomicValue
Returns the value of the counter prior to the operation
process(WatchedEvent) - Method in interface com.netflix.curator.framework.api.CuratorWatcher
Same as Watcher.process(WatchedEvent).
processResult(CuratorFramework, CuratorEvent) - Method in interface com.netflix.curator.framework.api.BackgroundCallback
Called when the async background operation completes
processWithLockSafety(String, DistributedQueue.ProcessType) - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
 
PromotedToLock - Class in com.netflix.curator.framework.recipes.atomic
Abstraction of arguments for mutex promotion.
PromotedToLock.Builder - Class in com.netflix.curator.framework.recipes.atomic
 
PROPERTY_DONT_LOG_CONNECTION_ISSUES - Static variable in class com.netflix.curator.utils.DebugUtils
 
PROPERTY_LOG_EVENTS - Static variable in class com.netflix.curator.utils.DebugUtils
 
ProtectACLCreateModePathAndBytesable<T> - Interface in com.netflix.curator.framework.api
 
ProviderStrategy<T> - Interface in com.netflix.curator.x.discovery
A strategy for picking one from a set of instances
providerStrategy(ProviderStrategy<T>) - Method in interface com.netflix.curator.x.discovery.ServiceProviderBuilder
optional - set the provider strategy.
put(T, long) - Method in class com.netflix.curator.framework.recipes.queue.DistributedDelayQueue
Add an item into the queue.
put(T, long, int, TimeUnit) - Method in class com.netflix.curator.framework.recipes.queue.DistributedDelayQueue
Same as DistributedDelayQueue.put(Object, long) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
put(T, String) - Method in class com.netflix.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 com.netflix.curator.framework.recipes.queue.DistributedIdQueue
Same as DistributedIdQueue.put(Object, String) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
put(T, int) - Method in class com.netflix.curator.framework.recipes.queue.DistributedPriorityQueue
Add an item into the queue.
put(T, int, int, TimeUnit) - Method in class com.netflix.curator.framework.recipes.queue.DistributedPriorityQueue
Same as DistributedPriorityQueue.put(Object, int) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
put(T) - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
Add an item into the queue.
put(T, int, TimeUnit) - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
Same as DistributedQueue.put(Object) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
putCompleted(T) - Method in interface com.netflix.curator.framework.recipes.queue.QueuePutListener
Notification that a single item put has completed
putInBackground(boolean) - Method in class com.netflix.curator.framework.recipes.queue.QueueBuilder
By default, messages are added in the background.
putMulti(MultiItem<T>, long) - Method in class com.netflix.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 com.netflix.curator.framework.recipes.queue.DistributedDelayQueue
Same as DistributedDelayQueue.putMulti(MultiItem, long) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
putMulti(MultiItem<T>, int) - Method in class com.netflix.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 com.netflix.curator.framework.recipes.queue.DistributedPriorityQueue
Same as DistributedPriorityQueue.putMulti(MultiItem, int) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
putMulti(MultiItem<T>) - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
Add a set of items into the queue.
putMulti(MultiItem<T>, int, TimeUnit) - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
Same as DistributedQueue.putMulti(MultiItem) but allows a maximum wait time if an upper bound was set via QueueBuilder.maxItems.
putMultiCompleted(MultiItem<T>) - Method in interface com.netflix.curator.framework.recipes.queue.QueuePutListener
Notification that a multi item put has completed
putService(ServiceInstance<T>, String, String) - Method in class com.netflix.curator.x.discovery.server.rest.DiscoveryResource
 

Q

queryForInstance(String, String) - Method in class com.netflix.curator.x.discovery.details.ServiceDiscoveryImpl
Return a service instance POJO
queryForInstance(String, String) - Method in interface com.netflix.curator.x.discovery.ServiceDiscovery
Return a service instance POJO
queryForInstances(String) - Method in class com.netflix.curator.x.discovery.details.ServiceDiscoveryImpl
Return all known instances for the given service
queryForInstances(String) - Method in interface com.netflix.curator.x.discovery.ServiceDiscovery
Return all known instances for the given service
queryForNames() - Method in class com.netflix.curator.x.discovery.details.ServiceDiscoveryImpl
Return the names of all known services
queryForNames() - Method in interface com.netflix.curator.x.discovery.ServiceDiscovery
Return the names of all known services
QueueAllocator<U,T extends QueueBase<U>> - Interface in com.netflix.curator.framework.recipes.queue
 
QueueBase<T> - Interface in com.netflix.curator.framework.recipes.queue
 
QueueBuilder<T> - Class in com.netflix.curator.framework.recipes.queue
QueueConsumer<T> - Interface in com.netflix.curator.framework.recipes.queue
Message Consumer
QueuePutListener<T> - Interface in com.netflix.curator.framework.recipes.queue
Queue puts are done in the background.
QueueSafety<T> - Class in com.netflix.curator.framework.recipes.queue
Parameter block for specifying queue safety with either DistributedQueue or DistributedPriorityQueue
QueueSafety(String, QueueConsumer<T>) - Constructor for class com.netflix.curator.framework.recipes.queue.QueueSafety
 
QueueSerializer<T> - Interface in com.netflix.curator.framework.recipes.queue
Helper to serialize/deserialize queue items
QueueSharder<U,T extends QueueBase<U>> - Class in com.netflix.curator.framework.recipes.queue
A utility for shard a distributed queue.
QueueSharder(CuratorFramework, QueueAllocator<U, T>, String, String, QueueSharderPolicies) - Constructor for class com.netflix.curator.framework.recipes.queue.QueueSharder
 
QueueSharderPolicies - Class in com.netflix.curator.framework.recipes.queue
Various policies/options for sharding.
QueueSharderPolicies.Builder - Class in com.netflix.curator.framework.recipes.queue
 
QuorumConfigBuilder - Class in com.netflix.curator.test
 
QuorumConfigBuilder(Collection<InstanceSpec>) - Constructor for class com.netflix.curator.test.QuorumConfigBuilder
 
QuorumConfigBuilder(InstanceSpec...) - Constructor for class com.netflix.curator.test.QuorumConfigBuilder
 

R

RandomStrategy<T> - Class in com.netflix.curator.x.discovery.strategies
This strategy always picks a random instance from the list
RandomStrategy() - Constructor for class com.netflix.curator.x.discovery.strategies.RandomStrategy
 
readData(String, Stat, boolean) - Method in class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
 
readFrom(Class<ServiceInstance<T>>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
 
readFrom(Class<ServiceInstances<T>>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
 
readFrom(Class<ServiceNames>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
 
readLock() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessReadWriteLock
Returns the lock used for reading.
Reaper - Class in com.netflix.curator.framework.recipes.locks
Utility to clean up parent lock nodes so that they don't stay around as garbage
Reaper(CuratorFramework) - Constructor for class com.netflix.curator.framework.recipes.locks.Reaper
Uses the default reaping threshold of 5 minutes and creates an internal thread pool
Reaper(CuratorFramework, int) - Constructor for class com.netflix.curator.framework.recipes.locks.Reaper
Uses the given reaping threshold and creates an internal thread pool
Reaper(CuratorFramework, ScheduledExecutorService, int) - Constructor for class com.netflix.curator.framework.recipes.locks.Reaper
 
Reaper.Mode - Enum in com.netflix.curator.framework.recipes.locks
 
rebuild() - Method in class com.netflix.curator.framework.recipes.cache.PathChildrenCache
NOTE: this is a BLOCKING method.
refreshPaddingMs(int) - Method in interface com.netflix.curator.x.discovery.ServiceCacheBuilder
To avoid herding in noisy scenarios, the cache should be padded to only update 1 per period.
refreshPaddingMs(int) - Method in interface com.netflix.curator.x.discovery.ServiceProviderBuilder
optional To avoid herding in noisy scenarios, the cache should be padded to only update 1 per period.
registerService(ServiceInstance<T>) - Method in class com.netflix.curator.x.discovery.details.ServiceDiscoveryImpl
Register/re-register/update a service instance
registerService(ServiceInstance<T>) - Method in interface com.netflix.curator.x.discovery.ServiceDiscovery
Register/re-register/update a service instance
registrationTimeUTC(long) - Method in class com.netflix.curator.x.discovery.ServiceInstanceBuilder
 
release() - Method in interface com.netflix.curator.framework.recipes.locks.InterProcessLock
Perform one release of the mutex if the calling thread is the same thread that acquired it.
release() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessMultiLock
Perform one release of the mutex if the calling thread is the same thread that acquired it.
release() - Method in class com.netflix.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 com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreMutex
 
remove(String) - Method in class com.netflix.curator.framework.recipes.queue.DistributedIdQueue
Remove any items with the given Id
remove() - Method in class com.netflix.curator.framework.recipes.queue.SimpleDistributedQueue
Attempts to remove the head of the queue and return it.
remove(UriSpec.Part) - Method in class com.netflix.curator.x.discovery.UriSpec
Remove the given part
removeBarrier() - Method in class com.netflix.curator.framework.recipes.barriers.DistributedBarrier
Utility to remove the barrier node
removeListener(T) - Method in interface com.netflix.curator.framework.listen.Listenable
Remove the given listener
removeListener(T) - Method in class com.netflix.curator.framework.listen.ListenerContainer
 
removeListener(SharedCountListener) - Method in class com.netflix.curator.framework.recipes.shared.SharedCount
 
removeListener(ServiceCacheListener) - Method in class com.netflix.curator.x.discovery.details.ServiceCacheImpl
 
removePath(String) - Method in class com.netflix.curator.framework.recipes.locks.Reaper
Stop reaping the given path
removeService(String, String) - Method in class com.netflix.curator.x.discovery.server.rest.DiscoveryResource
 
requeue() - Method in class com.netflix.curator.framework.recipes.leader.LeaderSelector
Re-queue an attempt for leadership.
restart() - Method in class com.netflix.curator.test.TestingZooKeeperServer
 
restartServer(InstanceSpec) - Method in class com.netflix.curator.test.TestingCluster
Restart the given server of the cluster
RetryLoop - Class in com.netflix.curator
Mechanism to perform an operation on Zookeeper that is safe against disconnections and "recoverable" errors.
RetryNTimes - Class in com.netflix.curator.retry
Retry policy that retries a max number of times
RetryNTimes(int, int) - Constructor for class com.netflix.curator.retry.RetryNTimes
 
RetryOneTime - Class in com.netflix.curator.retry
A retry policy that retries only once
RetryOneTime(int) - Constructor for class com.netflix.curator.retry.RetryOneTime
 
retryPolicy(RetryPolicy) - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
retryPolicy(RetryPolicy) - Method in class com.netflix.curator.framework.recipes.atomic.PromotedToLock.Builder
Set the retry policy to use when an operation does not succeed
RetryPolicy - Interface in com.netflix.curator
Abstracts the policy to use when retrying connections
RetrySleeper - Interface in com.netflix.curator
Abstraction for retry policies to sleep
RetryUntilElapsed - Class in com.netflix.curator.retry
A retry policy that retries until a given amount of time elapses
RetryUntilElapsed(int, int) - Constructor for class com.netflix.curator.retry.RetryUntilElapsed
 
returnAll(Collection<Lease>) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
Convenience method.
returnAll(Collection<Lease>) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreV2
Convenience method.
returnLease(Lease) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphore
Deprecated.
Convenience method.
returnLease(Lease) - Method in class com.netflix.curator.framework.recipes.locks.InterProcessSemaphoreV2
Convenience method.
Revocable<T> - Interface in com.netflix.curator.framework.recipes.locks
Specifies locks that can be revoked
RevocationListener<T> - Interface in com.netflix.curator.framework.recipes.locks
 
revocationRequested(T) - Method in interface com.netflix.curator.framework.recipes.locks.RevocationListener
Called when a revocation request has been received.
Revoker - Class in com.netflix.curator.framework.recipes.locks
 
RoundRobinStrategy<T> - Class in com.netflix.curator.x.discovery.strategies
This strategy rotates sequentially through the list of instances
RoundRobinStrategy() - Constructor for class com.netflix.curator.x.discovery.strategies.RoundRobinStrategy
 
runFromConfig(QuorumPeerConfig) - Method in class com.netflix.curator.test.TestingZooKeeperMain
 
runFromConfig(QuorumPeerConfig) - Method in interface com.netflix.curator.test.ZooKeeperMainFace
 

S

seconds() - Method in class com.netflix.curator.test.Timing
Return the base time in seconds
serialize(T) - Method in interface com.netflix.curator.framework.recipes.queue.QueueSerializer
Turn a queue item into bytes
serialize(ServiceInstance<T>) - Method in interface com.netflix.curator.x.discovery.details.InstanceSerializer
Serialize an instance into bytes
serialize(ServiceInstance<T>) - Method in class com.netflix.curator.x.discovery.details.JsonInstanceSerializer
 
serializer(InstanceSerializer<T>) - Method in class com.netflix.curator.x.discovery.ServiceDiscoveryBuilder
optional - change the serializer used (the default is JsonInstanceSerializer
ServiceCache<T> - Interface in com.netflix.curator.x.discovery
 
serviceCacheBuilder() - Method in class com.netflix.curator.x.discovery.details.ServiceDiscoveryImpl
Allocate a new service cache builder.
ServiceCacheBuilder<T> - Interface in com.netflix.curator.x.discovery
 
serviceCacheBuilder() - Method in interface com.netflix.curator.x.discovery.ServiceDiscovery
Allocate a new service cache builder.
ServiceCacheImpl<T> - Class in com.netflix.curator.x.discovery.details
 
ServiceCacheListener - Interface in com.netflix.curator.x.discovery.details
Listener for changes to a service cache
ServiceDiscovery<T> - Interface in com.netflix.curator.x.discovery
 
ServiceDiscoveryBuilder<T> - Class in com.netflix.curator.x.discovery
 
ServiceDiscoveryImpl<T> - Class in com.netflix.curator.x.discovery.details
A mechanism to register and query service instances using ZooKeeper
ServiceDiscoveryImpl(CuratorFramework, String, InstanceSerializer<T>, ServiceInstance<T>) - Constructor for class com.netflix.curator.x.discovery.details.ServiceDiscoveryImpl
 
ServiceInstance<T> - Class in com.netflix.curator.x.discovery
POJO that represents a service instance
ServiceInstanceBuilder<T> - Class in com.netflix.curator.x.discovery
Builder for service instances
ServiceInstances<T> - Class in com.netflix.curator.x.discovery.server.entity
Raw generic lists don't work well in JAX-RS.
ServiceInstances() - Constructor for class com.netflix.curator.x.discovery.server.entity.ServiceInstances
 
ServiceInstances(Collection<? extends ServiceInstance<T>>) - Constructor for class com.netflix.curator.x.discovery.server.entity.ServiceInstances
 
serviceName(String) - Method in interface com.netflix.curator.x.discovery.ServiceProviderBuilder
required - set the name of the service to be provided
ServiceNames - Class in com.netflix.curator.x.discovery.server.entity
Raw generic lists don't work well in JAX-RS.
ServiceNames() - Constructor for class com.netflix.curator.x.discovery.server.entity.ServiceNames
 
ServiceNames(Collection<? extends String>) - Constructor for class com.netflix.curator.x.discovery.server.entity.ServiceNames
 
ServiceProvider<T> - Interface in com.netflix.curator.x.discovery
The main API for Discovery.
serviceProviderBuilder() - Method in class com.netflix.curator.x.discovery.details.ServiceDiscoveryImpl
Allocate a new builder.
serviceProviderBuilder() - Method in interface com.netflix.curator.x.discovery.ServiceDiscovery
Allocate a new builder.
ServiceProviderBuilder<T> - Interface in com.netflix.curator.x.discovery
 
ServiceProviderImpl<T> - Class in com.netflix.curator.x.discovery.details
The main interface for Service Discovery.
ServiceProviderImpl(ServiceDiscoveryImpl<T>, String, ProviderStrategy<T>, ThreadFactory, int) - Constructor for class com.netflix.curator.x.discovery.details.ServiceProviderImpl
 
serviceType(ServiceType) - Method in class com.netflix.curator.x.discovery.ServiceInstanceBuilder
 
ServiceType - Enum in com.netflix.curator.x.discovery
 
session() - Method in class com.netflix.curator.test.Timing
Return the value to use for ZK session timeout
SessionFailRetryLoop - Class in com.netflix.curator
See RetryLoop for the main details on retry loops.
SessionFailRetryLoop.Mode - Enum in com.netflix.curator
 
SessionFailRetryLoop.SessionFailedException - Exception in com.netflix.curator
 
SessionFailRetryLoop.SessionFailedException() - Constructor for exception com.netflix.curator.SessionFailRetryLoop.SessionFailedException
 
sessionTimeoutMs(int) - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
setACL() - Method in interface com.netflix.curator.framework.CuratorFramework
Start a set ACL builder
setACL() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
SetACLBuilder - Interface in com.netflix.curator.framework.api
 
setBarrier() - Method in class com.netflix.curator.framework.recipes.barriers.DistributedBarrier
Utility to set the barrier node
setCount(int) - Method in class com.netflix.curator.framework.recipes.shared.SharedCount
Change the shared count value irrespective of its previous state
setData() - Method in interface com.netflix.curator.framework.api.transaction.CuratorTransaction
Start a setData builder in the transaction
setData() - Method in interface com.netflix.curator.framework.CuratorFramework
Start a set data builder
setData() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
setData(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
 
setDataAsync(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
 
setDataAsyncWithCallback(CuratorFramework, BackgroundCallback, String, byte[]) - Static method in class framework.CrudExamples
 
SetDataBackgroundVersionable - Interface in com.netflix.curator.framework.api
 
SetDataBuilder - Interface in com.netflix.curator.framework.api
 
setDescription(String) - Method in class discovery.InstanceDetails
 
setErrorMode(ErrorMode) - Method in class com.netflix.curator.framework.recipes.queue.DistributedDelayQueue
 
setErrorMode(ErrorMode) - Method in class com.netflix.curator.framework.recipes.queue.DistributedIdQueue
 
setErrorMode(ErrorMode) - Method in class com.netflix.curator.framework.recipes.queue.DistributedPriorityQueue
 
setErrorMode(ErrorMode) - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
Used when the queue is created with a QueueBuilder.lockPath(String).
setErrorMode(ErrorMode) - Method in interface com.netflix.curator.framework.recipes.queue.QueueBase
Used when the queue is created with a QueueBuilder.lockPath(String).
setExhibitors(Exhibitors) - Method in class com.netflix.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
Change the set of exhibitors to poll
setId(String) - Method in class com.netflix.curator.framework.recipes.leader.LeaderSelector
Sets the ID to store for this leader.
setRetryPolicy(RetryPolicy) - Method in class com.netflix.curator.CuratorZookeeperClient
Change the retry policy
setTracerDriver(TracerDriver) - Method in class com.netflix.curator.CuratorZookeeperClient
Change the tracing driver
setValue(byte[]) - Method in class com.netflix.curator.framework.recipes.shared.SharedValue
Change the shared value value irrespective of its previous state
SharedCount - Class in com.netflix.curator.framework.recipes.shared
Manages a shared integer.
SharedCount(CuratorFramework, String, int) - Constructor for class com.netflix.curator.framework.recipes.shared.SharedCount
 
SharedCountListener - Interface in com.netflix.curator.framework.recipes.shared
Listener for changes to a shared count
SharedCountReader - Interface in com.netflix.curator.framework.recipes.shared
Abstracts a shared integer and allows listening for changes to its value
SharedValue - Class in com.netflix.curator.framework.recipes.shared
Manages a shared value.
SharedValue(CuratorFramework, String, byte[]) - Constructor for class com.netflix.curator.framework.recipes.shared.SharedValue
 
SharedValueListener - Interface in com.netflix.curator.framework.recipes.shared
Listener for changes to a shared value
SharedValueReader - Interface in com.netflix.curator.framework.recipes.shared
Abstracts a shared value and allows listening for changes to the value
shouldContinue() - Method in class com.netflix.curator.RetryLoop
If true is returned, make an attempt at the operation
shouldContinue() - Method in class com.netflix.curator.SessionFailRetryLoop
If true is returned, make an attempt at the set of operations
shouldRetry(int) - Static method in class com.netflix.curator.RetryLoop
Utility - return true if the given Zookeeper result code is retry-able
SimpleDistributedQueue - Class in com.netflix.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 com.netflix.curator.framework.recipes.queue.SimpleDistributedQueue
 
size() - Method in class com.netflix.curator.framework.listen.ListenerContainer
Return the number of listeners
size() - Method in class com.netflix.curator.framework.recipes.queue.BlockingQueueConsumer
Returns the number of currently queue items
size() - Method in class com.netflix.curator.test.QuorumConfigBuilder
 
sleepABit() - Method in class com.netflix.curator.test.Timing
Sleep for a small amount of time
sleepFor(long, TimeUnit) - Method in interface com.netflix.curator.RetrySleeper
Sleep for the given time
sortChildren(List<String>) - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
 
sslPort(int) - Method in class com.netflix.curator.x.discovery.ServiceInstanceBuilder
 
standardFixForSorting(String, String) - Static method in class com.netflix.curator.framework.recipes.locks.StandardLockInternalsDriver
 
StandardLockInternalsDriver - Class in com.netflix.curator.framework.recipes.locks
 
StandardLockInternalsDriver() - Constructor for class com.netflix.curator.framework.recipes.locks.StandardLockInternalsDriver
 
start() - Method in class com.netflix.curator.CuratorZookeeperClient
Must be called after construction
start() - Method in interface com.netflix.curator.ensemble.EnsembleProvider
Curator will call this method when CuratorZookeeperClient.start() is called
start() - Method in class com.netflix.curator.ensemble.exhibitor.ExhibitorEnsembleProvider
 
start() - Method in class com.netflix.curator.ensemble.fixed.FixedEnsembleProvider
 
start() - Method in interface com.netflix.curator.framework.CuratorFramework
Start the client.
start() - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
start() - Method in class com.netflix.curator.framework.recipes.cache.PathChildrenCache
Start the cache.
start(boolean) - Method in class com.netflix.curator.framework.recipes.cache.PathChildrenCache
Same as PathChildrenCache.start() but gives the option of doing an initial build
start() - Method in class com.netflix.curator.framework.recipes.leader.LeaderLatch
Add this instance to the leadership election and attempt to acquire leadership.
start() - Method in class com.netflix.curator.framework.recipes.leader.LeaderSelector
Attempt leadership.
start() - Method in class com.netflix.curator.framework.recipes.locks.ChildReaper
The reaper must be started
start() - Method in class com.netflix.curator.framework.recipes.locks.Reaper
The reaper must be started
start() - Method in class com.netflix.curator.framework.recipes.queue.DistributedDelayQueue
Start the queue.
start() - Method in class com.netflix.curator.framework.recipes.queue.DistributedIdQueue
 
start() - Method in class com.netflix.curator.framework.recipes.queue.DistributedPriorityQueue
Start the queue.
start() - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
Start the queue.
start() - Method in interface com.netflix.curator.framework.recipes.queue.QueueBase
Start the queue.
start() - Method in class com.netflix.curator.framework.recipes.queue.QueueSharder
The sharder must be started
start() - Method in class com.netflix.curator.framework.recipes.shared.SharedCount
The shared count must be started before it can be used.
start() - Method in class com.netflix.curator.framework.recipes.shared.SharedValue
The shared value must be started before it can be used.
start() - Method in class com.netflix.curator.framework.state.ConnectionStateManager
Start the manager
start() - Method in class com.netflix.curator.SessionFailRetryLoop
SessionFailRetryLoop must be started
start() - Method in class com.netflix.curator.test.TestingCluster
Start the ensemble.
start() - Method in class com.netflix.curator.test.TestingZooKeeperServer
 
start() - Method in class com.netflix.curator.x.discovery.details.ServiceCacheImpl
 
start() - Method in class com.netflix.curator.x.discovery.details.ServiceDiscoveryImpl
The discovery must be started before use
start() - Method in class com.netflix.curator.x.discovery.details.ServiceProviderImpl
The provider must be started before use
start() - Method in class com.netflix.curator.x.discovery.server.rest.InstanceCleanup
Start the task
start() - Method in interface com.netflix.curator.x.discovery.ServiceCache
The cache must be started before use
start() - Method in interface com.netflix.curator.x.discovery.ServiceDiscovery
The discovery must be started before use
start() - Method in interface com.netflix.curator.x.discovery.ServiceProvider
The provider must be started before use
start() - Method in class discovery.ExampleServer
 
start() - Method in class leader.ExampleClient
 
startTracer(String) - Method in class com.netflix.curator.CuratorZookeeperClient
Start a new tracer
Statable<T> - Interface in com.netflix.curator.framework.api
 
stateChanged(CuratorFramework, ConnectionState) - Method in class com.netflix.curator.framework.recipes.queue.BlockingQueueConsumer
 
stateChanged(CuratorFramework, ConnectionState) - Method in interface com.netflix.curator.framework.state.ConnectionStateListener
Called when there is a state change in the connection
stateChanged(CuratorFramework, ConnectionState) - Method in class leader.ExampleClient
 
StickyStrategy<T> - Class in com.netflix.curator.x.discovery.strategies
This strategy uses a master strategy to pick the initial instance.
StickyStrategy(ProviderStrategy<T>) - Constructor for class com.netflix.curator.x.discovery.strategies.StickyStrategy
 
stop() - Method in class com.netflix.curator.test.TestingCluster
Shutdown the ensemble WITHOUT freeing resources, etc.
stop() - Method in class com.netflix.curator.test.TestingServer
Stop the server without deleting the temp directory
stop() - Method in class com.netflix.curator.test.TestingZooKeeperServer
 
storingStatIn(Stat) - Method in interface com.netflix.curator.framework.api.Statable
Have the operation fill the provided stat object
StringDiscoveryContext - Class in com.netflix.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 com.netflix.curator.x.discovery.server.contexts.StringDiscoveryContext
 
subtract(Integer) - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicInteger
Subtract delta from the current value and return the new value information.
subtract(Long) - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicLong
Subtract delta from the current value and return the new value information.
subtract(T) - Method in interface com.netflix.curator.framework.recipes.atomic.DistributedAtomicNumber
Subtract delta from the current value and return the new value information.
succeeded() - Method in interface com.netflix.curator.framework.recipes.atomic.AtomicValue
MUST be checked. Returns true if the operation succeeded.
sync(String, Object) - Method in interface com.netflix.curator.framework.CuratorFramework
Perform a sync on the given path - syncs are always in the background
sync(String, Object) - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 

T

take() - Method in class com.netflix.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 com.netflix.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 com.netflix.curator.framework.recipes.queue.SimpleDistributedQueue
Removes the head of the queue and returns it, blocks until it succeeds.
takeException(Exception) - Method in class com.netflix.curator.RetryLoop
Pass any caught exceptions here
takeException(Exception) - Method in class com.netflix.curator.SessionFailRetryLoop
Pass any caught exceptions here
takeLeadership(CuratorFramework) - Method in interface com.netflix.curator.framework.recipes.leader.LeaderSelectorListener
Called when your instance has been granted leadership.
takeLeadership(CuratorFramework) - Method in class leader.ExampleClient
 
TestingCluster - Class in com.netflix.curator.test
manages an internally running ensemble of ZooKeeper servers.
TestingCluster(int) - Constructor for class com.netflix.curator.test.TestingCluster
Creates an ensemble comprised of n servers.
TestingCluster(InstanceSpec...) - Constructor for class com.netflix.curator.test.TestingCluster
Creates an ensemble using the given server specs
TestingCluster(Collection<InstanceSpec>) - Constructor for class com.netflix.curator.test.TestingCluster
Creates an ensemble using the given server specs
TestingServer - Class in com.netflix.curator.test
manages an internally running ZooKeeper server.
TestingServer() - Constructor for class com.netflix.curator.test.TestingServer
Create the server using a random port
TestingServer(int) - Constructor for class com.netflix.curator.test.TestingServer
Create the server using the given port
TestingServer(int, File) - Constructor for class com.netflix.curator.test.TestingServer
Create the server using the given port
TestingServer(InstanceSpec) - Constructor for class com.netflix.curator.test.TestingServer
 
TestingZooKeeperMain - Class in com.netflix.curator.test
 
TestingZooKeeperMain() - Constructor for class com.netflix.curator.test.TestingZooKeeperMain
 
TestingZooKeeperServer - Class in com.netflix.curator.test
Thanks to Jeremie BORDIER (ahfeel) for this code
TestingZooKeeperServer(QuorumConfigBuilder) - Constructor for class com.netflix.curator.test.TestingZooKeeperServer
 
TestingZooKeeperServer(QuorumConfigBuilder, int) - Constructor for class com.netflix.curator.test.TestingZooKeeperServer
 
thisInstance(ServiceInstance<T>) - Method in class com.netflix.curator.x.discovery.ServiceDiscoveryBuilder
Optional - instance that represents the service that is running.
threadFactory(ThreadFactory) - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
threadFactory(ThreadFactory) - Method in class com.netflix.curator.framework.recipes.queue.QueueBuilder
Change the thread factory used.
threadFactory(ThreadFactory) - Method in class com.netflix.curator.framework.recipes.queue.QueueSharderPolicies.Builder
Change the thread factory that's used to create the sharder's thread
threadFactory(ThreadFactory) - Method in interface com.netflix.curator.x.discovery.ServiceCacheBuilder
Optional thread factory to use for the cache's internal thread
threadFactory(ThreadFactory) - Method in interface com.netflix.curator.x.discovery.ServiceProviderBuilder
optional - the thread factory to use for creating internal threads
ThreadUtils - Class in com.netflix.curator.utils
 
ThreadUtils() - Constructor for class com.netflix.curator.utils.ThreadUtils
 
thresholdCheckMs(int) - Method in class com.netflix.curator.framework.recipes.queue.QueueSharderPolicies.Builder
Change the threshold check.
timeout(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.atomic.PromotedToLock.Builder
Set the timeout to use when locking (optional)
TimeTrace - Class in com.netflix.curator
Utility to time a method or portion of code
TimeTrace(String, TracerDriver) - Constructor for class com.netflix.curator.TimeTrace
Create and start a timer
Timing - Class in com.netflix.curator.test
Utility to get various testing times
Timing() - Constructor for class com.netflix.curator.test.Timing
Use the default base time
Timing(double) - Constructor for class com.netflix.curator.test.Timing
Use a multiple of the default base time
Timing(long, TimeUnit) - Constructor for class com.netflix.curator.test.Timing
 
toString() - Method in class com.netflix.curator.framework.recipes.cache.ChildData
 
toString() - Method in class com.netflix.curator.framework.recipes.cache.PathChildrenCacheEvent
 
toString() - Method in class com.netflix.curator.framework.recipes.leader.Participant
 
toString() - Method in class com.netflix.curator.test.InstanceSpec
 
toString() - Method in class com.netflix.curator.x.discovery.ServiceInstance
 
TracerDriver - Interface in com.netflix.curator.drivers
Mechanism for timing methods and recording counters
transaction(CuratorFramework) - Static method in class framework.TransactionExamples
 
TransactionCheckBuilder - Interface in com.netflix.curator.framework.api.transaction
 
TransactionCreateBuilder - Interface in com.netflix.curator.framework.api.transaction
 
TransactionDeleteBuilder - Interface in com.netflix.curator.framework.api.transaction
 
TransactionExamples - Class in framework
 
TransactionExamples() - Constructor for class framework.TransactionExamples
 
TransactionSetDataBuilder - Interface in com.netflix.curator.framework.api.transaction
 
tryRemove(String) - Method in class com.netflix.curator.framework.recipes.queue.DistributedQueue
 
trySet(Integer) - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicInteger
 
trySet(Long) - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicLong
 
trySet(T) - Method in interface com.netflix.curator.framework.recipes.atomic.DistributedAtomicNumber
Attempt to atomically set the value to the given value.
trySet(byte[]) - Method in class com.netflix.curator.framework.recipes.atomic.DistributedAtomicValue
Attempt to atomically set the value to the given value.
trySetCount(int) - Method in class com.netflix.curator.framework.recipes.shared.SharedCount
Changes the shared count only if its value has not changed since this client last read it.
trySetValue(byte[]) - Method in class com.netflix.curator.framework.recipes.shared.SharedValue
Changes the shared value only if its value has not changed since this client last read it.

U

unhandledError(String, Throwable) - Method in interface com.netflix.curator.framework.api.UnhandledErrorListener
Called when an exception is caught in a background thread, handler, etc.
UnhandledErrorListener - Interface in com.netflix.curator.framework.api
 
unMarshallJson(JsonNode) - Method in class com.netflix.curator.x.discovery.server.contexts.IntegerDiscoveryContext
 
unMarshallJson(JsonNode) - Method in class com.netflix.curator.x.discovery.server.contexts.MapDiscoveryContext
 
unMarshallJson(JsonNode) - Method in class com.netflix.curator.x.discovery.server.contexts.StringDiscoveryContext
 
unMarshallJson(JsonNode) - Method in interface com.netflix.curator.x.discovery.server.rest.DiscoveryContext
Deserialize your payload
unregisterService(ServiceInstance<T>) - Method in class com.netflix.curator.x.discovery.details.ServiceDiscoveryImpl
Unregister/remove a service instance
unregisterService(ServiceInstance<T>) - Method in interface com.netflix.curator.x.discovery.ServiceDiscovery
Unregister/remove a service instance
uriSpec(UriSpec) - Method in class com.netflix.curator.x.discovery.ServiceInstanceBuilder
 
UriSpec - Class in com.netflix.curator.x.discovery
An abstraction for specifying a URI for an instance allowing for variable substitutions.
UriSpec() - Constructor for class com.netflix.curator.x.discovery.UriSpec
 
UriSpec(String) - Constructor for class com.netflix.curator.x.discovery.UriSpec
 
UriSpec.Part - Class in com.netflix.curator.x.discovery
Represents one token in the Uri spec
UriSpec.Part(String, boolean) - Constructor for class com.netflix.curator.x.discovery.UriSpec.Part
 
UriSpec.Part() - Constructor for class com.netflix.curator.x.discovery.UriSpec.Part
 
use() - Method in class locking.FakeLimitedResource
 
usingNamespace(String) - Method in interface com.netflix.curator.framework.CuratorFramework
Returns a facade of the current instance that uses the specified namespace or no namespace if newNamespace is null.
usingNamespace(String) - Method in class com.netflix.curator.framework.imps.CuratorFrameworkImpl
 
usingWatcher(Watcher) - Method in interface com.netflix.curator.framework.api.Watchable
Set a watcher for the operation
usingWatcher(CuratorWatcher) - Method in interface com.netflix.curator.framework.api.Watchable
Set a watcher for the operation

V

valueHasChanged(SharedValueReader, byte[]) - Method in interface com.netflix.curator.framework.recipes.shared.SharedValueListener
Called when the shared value has changed
valueOf(String) - Static method in enum com.netflix.curator.framework.api.CuratorEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.curator.framework.api.transaction.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.curator.framework.recipes.cache.PathChildrenCacheEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.curator.framework.recipes.cache.PathChildrenCacheMode
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.curator.framework.recipes.locks.Reaper.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.curator.framework.recipes.queue.DistributedQueue.ProcessType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.curator.framework.recipes.queue.ErrorMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.curator.framework.state.ConnectionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.curator.SessionFailRetryLoop.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.curator.x.discovery.ServiceType
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.netflix.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 com.netflix.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 com.netflix.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 com.netflix.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 com.netflix.curator.framework.recipes.locks.Reaper.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.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 com.netflix.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 com.netflix.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 com.netflix.curator.SessionFailRetryLoop.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.curator.x.discovery.ServiceType
Returns an array containing the constants of this enum type, in the order they are declared.
Versionable<T> - Interface in com.netflix.curator.framework.api
 

W

waitOnBarrier() - Method in class com.netflix.curator.framework.recipes.barriers.DistributedBarrier
Blocks until the barrier node comes into existence
waitOnBarrier(long, TimeUnit) - Method in class com.netflix.curator.framework.recipes.barriers.DistributedBarrier
Blocks until the barrier no longer exists or the timeout elapses
Watchable<T> - Interface in com.netflix.curator.framework.api
 
watched() - Method in interface com.netflix.curator.framework.api.Watchable
Have the operation set a watch
watchedGetChildren(CuratorFramework, String) - Static method in class framework.CrudExamples
 
watchedGetChildren(CuratorFramework, String, Watcher) - Static method in class framework.CrudExamples
 
WatchPathable<T> - Interface in com.netflix.curator.framework.api
 
withACL(List<ACL>) - Method in interface com.netflix.curator.framework.api.ACLable
Set an ACL list (default is ZooDefs.Ids#OPEN_ACL_UNSAFE)
withMode(CreateMode) - Method in interface com.netflix.curator.framework.api.CreateModable
Set a create mode - the default is CreateMode.PERSISTENT
withProtectedEphemeralSequential() - Method in interface com.netflix.curator.framework.api.CreateBackgroundModeACLable
Hat-tip to https://github.com/sbridges for pointing this out
withProtectedEphemeralSequential() - Method in interface com.netflix.curator.framework.api.CreateBuilder
Deprecated.
this has been generalized to support all create modes. Instead, use:
     client.create().withProtection().withMode(CreateMode.PERSISTENT_SEQUENTIAL)...
 
withProtection() - Method in interface com.netflix.curator.framework.api.CreateBuilder
Hat-tip to https://github.com/sbridges for pointing this out
withProtection() - Method in interface com.netflix.curator.framework.api.ProtectACLCreateModePathAndBytesable
Hat-tip to https://github.com/sbridges for pointing this out
withVersion(int) - Method in interface com.netflix.curator.framework.api.Versionable
Use the given version (the default is -1)
writeData(String, byte[], int) - Method in class com.netflix.curator.x.zkclientbridge.CuratorZKClientBridge
 
writeLock() - Method in class com.netflix.curator.framework.recipes.locks.InterProcessReadWriteLock
Returns the lock used for writing.
writeTo(ServiceInstance<T>, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
 
writeTo(ServiceInstances<T>, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
 
writeTo(ServiceNames, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class com.netflix.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
 

Z

ZKPaths - Class in com.netflix.curator.utils
 
ZKPaths.PathAndNode - Class in com.netflix.curator.utils
 
ZKPaths.PathAndNode(String, String) - Constructor for class com.netflix.curator.utils.ZKPaths.PathAndNode
 
zookeeperFactory(ZookeeperFactory) - Method in class com.netflix.curator.framework.CuratorFrameworkFactory.Builder
 
ZookeeperFactory - Interface in com.netflix.curator.utils
 
ZooKeeperMainFace - Interface in com.netflix.curator.test
 
A B C D E F G H I J K L M N O P Q R S T U V W Z