Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- accept(ModeledCacheListener.Type, ZPath, Stat, T) - Method in interface org.apache.curator.x.async.modeled.cached.ModeledCacheListener
-
The given path was added, updated or removed
- acceptChild(String) - Method in class org.apache.curator.framework.recipes.cache.DefaultTreeCacheSelector
- acceptChild(String) - Method in interface org.apache.curator.framework.recipes.cache.TreeCacheSelector
-
Return true if this node should be returned from the cache
- ACLable<T> - Interface in org.apache.curator.framework.api
- ACLableExistBuilderMain - Interface in org.apache.curator.framework.api
- ACLBackgroundPathAndBytesable<T> - Interface in org.apache.curator.framework.api
- ACLCreateModeBackgroundPathAndBytesable<T> - Interface in org.apache.curator.framework.api
- ACLCreateModePathAndBytesable<T> - Interface in org.apache.curator.framework.api
- ACLCreateModeStatBackgroundPathAndBytesable<T> - Interface in org.apache.curator.framework.api
- aclList() - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- aclList() - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return the model's ACL list
- ACLPathAndBytesable<T> - Interface in org.apache.curator.framework.api
- aclProvider(ACLProvider) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- ACLProvider - Interface in org.apache.curator.framework.api
- acquire() - Method in interface org.apache.curator.framework.recipes.locks.InterProcessLock
-
Acquire the mutex - blocking until it's available.
- acquire() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMultiLock
-
Acquire the mutex - blocking until it's available.
- acquire() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
-
Acquire the mutex - blocking until it's available.
- acquire() - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
-
Deprecated.Acquire a lease.
- acquire() - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreMutex
- acquire() - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
-
Acquire a lease.
- acquire(int) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
-
Deprecated.Acquire
qty
leases. - acquire(int) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
-
Acquire
qty
leases. - acquire(int, long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
-
Deprecated.Acquire
qty
leases. - acquire(int, long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
-
Acquire
qty
leases. - acquire(long, TimeUnit) - Method in interface org.apache.curator.framework.recipes.locks.InterProcessLock
-
Acquire the mutex - blocks until it's available or the given time expires.
- acquire(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessMultiLock
-
Acquire the mutex - blocks until it's available or the given time expires.
- acquire(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
-
Acquire the mutex - blocks until it's available or the given time expires.
- acquire(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
-
Deprecated.Acquire a lease.
- acquire(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreMutex
- acquire(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
-
Acquire a lease.
- acquireLock(InterProcessLock) - Method in class org.apache.curator.framework.recipes.locks.Locker
- acquireLock(InterProcessLock, long, TimeUnit) - Method in class org.apache.curator.framework.recipes.locks.Locker
- acquireSemaphore(Semaphore) - Method in class org.apache.curator.test.compatibility.Timing2
-
Wait on the given semaphore
- acquireSemaphore(Semaphore) - Method in class org.apache.curator.test.Timing
-
Wait on the given semaphore
- acquireSemaphore(Semaphore, int) - Method in class org.apache.curator.test.compatibility.Timing2
-
Wait on the given semaphore
- acquireSemaphore(Semaphore, int) - Method in class org.apache.curator.test.Timing
-
Wait on the given semaphore
- add() - Method in interface org.apache.curator.framework.api.WatchesBuilder
-
Start an add watch operation
- add() - Method in class org.apache.curator.framework.imps.WatchesBuilderImpl
- add(Integer) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
-
Add delta to the current value and return the new value information.
- add(Long) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
-
Add delta to the current value and return the new value information.
- add(Throwable) - Method in class org.apache.curator.utils.ExceptionAccumulator
-
Add an exception into the accumulated exceptions.
- add(UriSpec.Part) - Method in class org.apache.curator.x.discovery.UriSpec
-
Add a part to the end of the list
- add(T) - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
-
Add delta to the current value and return the new value information.
- ADD_WATCH - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.watchers()
- Addable<T> - Interface in org.apache.curator.framework.api
- addCount(String, int) - Method in class org.apache.curator.drivers.AdvancedTracerDriver
-
Deprecated.
- addCount(String, int) - Method in interface org.apache.curator.drivers.TracerDriver
-
Add to a named counter
- addCount(String, int) - Method in class org.apache.curator.utils.DefaultTracerDriver
- addEvent(EventTrace) - Method in class org.apache.curator.drivers.AdvancedTracerDriver
-
Add to a named counter
- adding(String...) - Method in interface org.apache.curator.framework.api.Addable
-
Sets one or more members that are meant to be part of the ensemble.
- adding(List<String>) - Method in interface org.apache.curator.framework.api.Addable
-
Sets one or more members that are meant to be part of the ensemble.
- additionalFilter(InstanceFilter<T>) - Method in interface org.apache.curator.x.discovery.ServiceProviderBuilder
-
Add an instance filter.
- addListener(K) - Method in class org.apache.curator.framework.listen.MappingListenerManager
- addListener(K, Executor) - Method in class org.apache.curator.framework.listen.MappingListenerManager
- addListener(LeaderLatchListener) - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Attaches a listener to this LeaderLatch
- addListener(LeaderLatchListener, Executor) - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Attaches a listener to this LeaderLatch
- addListener(SharedCountListener) - Method in class org.apache.curator.framework.recipes.shared.SharedCount
- addListener(SharedCountListener, Executor) - Method in class org.apache.curator.framework.recipes.shared.SharedCount
- addListener(ServiceCacheListener) - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
- addListener(ServiceCacheListener, Executor) - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
- addListener(T) - Method in interface org.apache.curator.framework.listen.Listenable
-
Add the given listener.
- addListener(T) - Method in class org.apache.curator.framework.listen.StandardListenerManager
- addListener(T, Executor) - Method in interface org.apache.curator.framework.listen.Listenable
-
Add the given listener.
- addListener(T, Executor) - Method in class org.apache.curator.framework.listen.StandardListenerManager
- address(String) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
- AddStatConfigEnsembleable - Interface in org.apache.curator.framework.api
-
An non-incremental reconfiguration builder.
- addStateChange(ConnectionState) - Method in class org.apache.curator.framework.state.ConnectionStateManager
-
Post a state change.
- addToDigest(MessageDigest) - Method in class org.apache.curator.framework.imps.ExtractingCuratorOp
- addTrace(String, long, TimeUnit) - Method in class org.apache.curator.drivers.AdvancedTracerDriver
-
Deprecated.
- addTrace(String, long, TimeUnit) - Method in interface org.apache.curator.drivers.TracerDriver
-
Record the given trace event
- addTrace(String, long, TimeUnit) - Method in class org.apache.curator.utils.DefaultTracerDriver
- addTrace(OperationTrace) - Method in class org.apache.curator.drivers.AdvancedTracerDriver
-
Record the given trace event
- addWatch() - Method in interface org.apache.curator.x.async.api.AsyncCuratorFrameworkDsl
-
Start an add watch builder.
- addWatch() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- AddWatchBuilder - Interface in org.apache.curator.framework.api
- AddWatchBuilder2 - Interface in org.apache.curator.framework.api
- AddWatchBuilderImpl - Class in org.apache.curator.framework.imps
- AddWatchBuilderImpl(CuratorFrameworkImpl, Watching, Backgrounding, AddWatchMode) - Constructor for class org.apache.curator.framework.imps.AddWatchBuilderImpl
- AdvancedTracerDriver - Class in org.apache.curator.drivers
-
Expose more metrics for the operations and events
- AdvancedTracerDriver() - Constructor for class org.apache.curator.drivers.AdvancedTracerDriver
- AfterConnectionEstablished - Class in org.apache.curator.framework.recipes
-
Utility class to allow execution of logic once a ZooKeeper connection becomes available.
- afterInitialized() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
-
Make the built listener so that it only becomes active once
CuratorCacheListener.initialized()
has been called. - allocateQueue(CuratorFramework, String) - Method in interface org.apache.curator.framework.recipes.queue.QueueAllocator
- allowRetry(int, long, RetrySleeper) - Method in class org.apache.curator.retry.RetryForever
- allowRetry(int, long, RetrySleeper) - Method in class org.apache.curator.retry.RetryUntilElapsed
- allowRetry(int, long, RetrySleeper) - Method in class org.apache.curator.retry.BoundedExponentialBackoffRetry
- allowRetry(int, long, RetrySleeper) - Method in class org.apache.curator.retry.ExponentialBackoffRetry
- allowRetry(int, long, RetrySleeper) - Method in class org.apache.curator.retry.RetryNTimes
- allowRetry(int, long, RetrySleeper) - Method in class org.apache.curator.retry.RetryOneTime
- allowRetry(int, long, RetrySleeper) - Method in interface org.apache.curator.RetryPolicy
-
Called when an operation has failed for some reason.
- allowRetry(int, long, RetrySleeper) - Method in class org.apache.curator.SessionFailedRetryPolicy
- allowRetry(Throwable) - Method in interface org.apache.curator.RetryPolicy
-
Called when an operation has failed with a specific exception.
- allowRetry(Throwable) - Method in class org.apache.curator.SessionFailedRetryPolicy
- and() - Method in interface org.apache.curator.framework.api.transaction.CuratorTransactionBridge
-
Syntactic sugar to make the fluent interface more readable
- asContainers() - Method in class org.apache.curator.utils.EnsurePath
-
Deprecated.
- async - package async
- AsyncCreateBuilder - Interface in org.apache.curator.x.async.api
-
Builder for ZNode creates
- AsyncCuratorFramework - Interface in org.apache.curator.x.async
-
Zookeeper framework-style client that returns composable async operations that implement
CompletionStage
- AsyncCuratorFrameworkDsl - Interface in org.apache.curator.x.async.api
-
Zookeeper framework-style client
- AsyncCuratorFrameworkImpl - Class in org.apache.curator.x.async.details
- AsyncCuratorFrameworkImpl(CuratorFramework) - Constructor for class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- AsyncCuratorFrameworkImpl(CuratorFrameworkImpl, Filters, WatchMode, boolean) - Constructor for class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- AsyncDeleteBuilder - Interface in org.apache.curator.x.async.api
-
Builder for ZNode deletions
- AsyncEnsemblable<T> - Interface in org.apache.curator.x.async.api
-
Terminal operation for config/reconfig builders
- asyncEnsureContainers(AsyncCuratorFramework, String) - Static method in class org.apache.curator.x.async.AsyncWrappers
-
Asynchronously ensure that the parents of the given path are created as containers
- asyncEnsureParents(AsyncCuratorFramework, String) - Static method in class org.apache.curator.x.async.AsyncWrappers
-
Asynchronously ensure that the parents of the given path are created
- AsyncEventException - Exception Class in org.apache.curator.x.async
-
The exception type set for async watchers
- AsyncEventException() - Constructor for exception class org.apache.curator.x.async.AsyncEventException
- AsyncExamples - Class in async
-
Examples using the asynchronous DSL
- AsyncExamples() - Constructor for class async.AsyncExamples
- AsyncExistsBuilder - Interface in org.apache.curator.x.async.api
-
Builder for ZNode exists
- AsyncGetACLBuilder - Interface in org.apache.curator.x.async.api
-
Builder for getAcls
- AsyncGetChildrenBuilder - Interface in org.apache.curator.x.async.api
-
Builder for getChildren()
- AsyncGetConfigBuilder - Interface in org.apache.curator.x.async.api
-
Builder for getConfig()
- AsyncGetDataBuilder - Interface in org.apache.curator.x.async.api
-
Builder to get ZNode data
- AsyncMultiTransaction - Interface in org.apache.curator.x.async.api
-
Terminal operation to support multi/transactions
- AsyncPathable<T> - Interface in org.apache.curator.x.async.api
-
Terminal operation for various builders
- AsyncPathAndBytesable<T> - Interface in org.apache.curator.x.async.api
-
Terminal operation for various builders
- AsyncReconfigBuilder - Interface in org.apache.curator.x.async.api
-
Builder for reconfigs
- AsyncReconfigurable - Interface in org.apache.curator.framework.api
- AsyncRemoveWatchesBuilder - Interface in org.apache.curator.x.async.api
-
Builder for watcher removal
- AsyncResult<T> - Interface in org.apache.curator.x.async
-
Utility that combines the value, the ZooKeeper result code and the exception in one object allowing you to not worry about exceptional completions.
- AsyncResultImpl<T> - Class in org.apache.curator.x.async.details
- AsyncResultImpl() - Constructor for class org.apache.curator.x.async.details.AsyncResultImpl
- AsyncResultImpl(Throwable) - Constructor for class org.apache.curator.x.async.details.AsyncResultImpl
- AsyncResultImpl(KeeperException.Code) - Constructor for class org.apache.curator.x.async.details.AsyncResultImpl
- AsyncResultImpl(T) - Constructor for class org.apache.curator.x.async.details.AsyncResultImpl
- AsyncSetACLBuilder - Interface in org.apache.curator.x.async.api
-
Builder for setting ACLs
- AsyncSetDataBuilder - Interface in org.apache.curator.x.async.api
-
Builder for setting ZNode data
- AsyncStage<T> - Interface in org.apache.curator.x.async
-
A
CompletionStage
that is the result of most operations. - AsyncSyncBuilder - Interface in org.apache.curator.x.async.api
-
Builder for syncs
- AsyncTransactionCheckBuilder - Interface in org.apache.curator.x.async.api
- AsyncTransactionCreateBuilder - Interface in org.apache.curator.x.async.api
- AsyncTransactionDeleteBuilder - Interface in org.apache.curator.x.async.api
- AsyncTransactionOp - Interface in org.apache.curator.x.async.api
-
Builds operations that can be committed as a transaction via
AsyncCuratorFrameworkDsl.transaction()
- AsyncTransactionSetDataBuilder - Interface in org.apache.curator.x.async.api
- AsyncWatchBuilder - Interface in org.apache.curator.x.async.api
- AsyncWatchBuilder2 - Interface in org.apache.curator.x.async.api
- AsyncWrappers - Class in org.apache.curator.x.async
-
Utility for adding asynchronous behavior
- AsyncWrappers.TimeoutException - Exception Class in org.apache.curator.x.async
-
Set as the completion stage's exception when trying to acquire a lock times out
- AtomicStats - Class in org.apache.curator.framework.recipes.atomic
-
Debugging stats about operations
- AtomicStats() - Constructor for class org.apache.curator.framework.recipes.atomic.AtomicStats
- AtomicValue<T> - Interface in org.apache.curator.framework.recipes.atomic
-
Abstracts a value returned from one of the Atomics
- attemptRevoke(CuratorFramework, String) - Static method in class org.apache.curator.framework.recipes.locks.Revoker
-
Utility to mark a lock for revocation.
- AuthInfo - Class in org.apache.curator.framework
- AuthInfo(String, byte[]) - Constructor for class org.apache.curator.framework.AuthInfo
- authorization(String, byte[]) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Add connection authorization Subsequent calls to this method overwrite the prior calls.
- authorization(List<AuthInfo>) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Add connection authorization.
- autoRequeue() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
By default, when
LeaderSelectorListener.takeLeadership(CuratorFramework)
returns, this instance is not requeued. - await() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Causes the current thread to wait until this instance acquires leadership unless the thread is interrupted or closed.
- await(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Causes the current thread to wait until this instance acquires leadership unless the thread is interrupted, the specified waiting time elapses or the instance is closed.
- awaitLatch(CountDownLatch) - Method in class org.apache.curator.test.compatibility.Timing2
-
Wait on the given latch
- awaitLatch(CountDownLatch) - Method in class org.apache.curator.test.Timing
-
Wait on the given latch
- awaitTermination(long, TimeUnit) - Method in class org.apache.curator.test.DelegatingExecutorService
B
- Backgroundable<T> - Interface in org.apache.curator.framework.api
- BackgroundCallback - Interface in org.apache.curator.framework.api
-
Functor for an async background operation
- BackgroundEnsembleable<T> - Interface in org.apache.curator.framework.api
- Backgrounding - Class in org.apache.curator.framework.imps
- Backgrounding(BackgroundCallback, UnhandledErrorListener) - Constructor for class org.apache.curator.framework.imps.Backgrounding
- BackgroundPathable<T> - Interface in org.apache.curator.framework.api
- BackgroundPathableQuietlyable<T> - Interface in org.apache.curator.framework.api
- BackgroundPathAndBytesable<T> - Interface in org.apache.curator.framework.api
- BackgroundVersionable - Interface in org.apache.curator.framework.api
- BaseClassForTests - Class in org.apache.curator.test
- BaseClassForTests() - Constructor for class org.apache.curator.test.BaseClassForTests
- basePath(String) - Method in class org.apache.curator.x.discovery.ServiceDiscoveryBuilder
-
Required - set the base path to store in ZK, see
ServiceDiscoveryBuilder.pathConstructor(DiscoveryPathConstructor)
for alternative - bindInstance(int, int) - Method in class org.apache.curator.test.QuorumConfigBuilder
- BlockingQueueConsumer<T> - Class in org.apache.curator.framework.recipes.queue
-
Utility - a queue consumer that provides behavior similar to a
BlockingQueue
- BlockingQueueConsumer(ConnectionStateListener) - Constructor for class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
-
Creates with capacity of
Integer.MAX_VALUE
- BlockingQueueConsumer(ConnectionStateListener, int) - Constructor for class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
- BlockingQueueConsumer(ConnectionStateListener, BlockingQueue<T>) - Constructor for class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
-
Wrap the given blocking queue
- blockUntilConnected() - Method in interface org.apache.curator.framework.CuratorFramework
-
Block until a connection to ZooKeeper is available.
- blockUntilConnected() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- blockUntilConnected(int, TimeUnit) - Method in interface org.apache.curator.framework.CuratorFramework
-
Block until a connection to ZooKeeper is available or the maxWaitTime has been exceeded
- blockUntilConnected(int, TimeUnit) - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- blockUntilConnected(int, TimeUnit) - Method in class org.apache.curator.framework.state.ConnectionStateManager
- blockUntilConnectedOrTimedOut() - Method in class org.apache.curator.CuratorZookeeperClient
-
This method blocks until the connection to ZK succeeds.
- BoundedExponentialBackoffRetry - Class in org.apache.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 org.apache.curator.retry.BoundedExponentialBackoffRetry
- bridgeBuilder(CuratorFramework, String) - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCache
-
Start a Curator Cache Bridge builder.
- build() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Apply the current values and build a new CuratorFramework
- build() - Method in class org.apache.curator.framework.recipes.atomic.PromotedToLock.Builder
-
Build the argument block
- build() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBridgeBuilder
-
Return a new Curator Cache Bridge based on the builder methods that have been called
- build() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBuilder
-
Return a new Curator Cache based on the builder methods that have been called
- build() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
-
Build and return a new listener based on the methods that have been previously called
- build() - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
Deprecated.Builds the
TreeCache
based on configured values. - build() - Method in class org.apache.curator.framework.recipes.queue.QueueSharderPolicies.Builder
- build() - Method in class org.apache.curator.framework.schema.SchemaBuilder
-
Build a new schema from the currently set values
- build() - Method in class org.apache.curator.utils.ZookeeperCompatibility.Builder
- build() - Method in class org.apache.curator.x.async.modeled.ModeledFrameworkBuilder
-
Build a new ModeledFramework instance
- build() - Method in class org.apache.curator.x.async.modeled.ModelSpecBuilder
-
Build a new ModelSpec instance
- build() - Method in interface org.apache.curator.x.discovery.ServiceCacheBuilder
-
Return a new service cache with the current settings
- build() - Method in class org.apache.curator.x.discovery.ServiceDiscoveryBuilder
-
Build a new service discovery with the currently set values.
- build() - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
Return a new instance with the currently set values
- build() - Method in interface org.apache.curator.x.discovery.ServiceProviderBuilder
-
Allocate a new service provider based on the current builder settings
- build() - Method in class org.apache.curator.x.discovery.UriSpec
-
Build into a UriSpec string
- build(TypeReference) - Static method in class org.apache.curator.x.async.modeled.JacksonModelSerializer
- build(JavaType) - Static method in class org.apache.curator.x.async.modeled.JacksonModelSerializer
- build(Class<T>) - Static method in class org.apache.curator.x.async.modeled.JacksonModelSerializer
- build(String, List<Migration>) - Static method in interface org.apache.curator.x.async.migrations.MigrationSet
- build(Map<String, Object>) - Method in class org.apache.curator.x.discovery.UriSpec
-
Build into a UriSpec string
- build(CuratorFramework, String, CuratorCache.Options...) - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCache
-
Return a Curator Cache for the given path with the given options using a standard storage instance
- build(AsyncCuratorFramework, ModelSpec<T>, WatchMode, UnaryOperator<WatchedEvent>, UnhandledErrorListener, UnaryOperator<CuratorEvent>, Set<ModeledOptions>) - Static method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- build(ServiceInstance<?>) - Method in class org.apache.curator.x.discovery.UriSpec
-
Build into a UriSpec string
- build(ServiceInstance<?>, Map<String, Object>) - Method in class org.apache.curator.x.discovery.UriSpec
-
Build into a UriSpec string
- BUILD_INITIAL_CACHE - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCache.StartMode
-
Deprecated.The cache will be primed (in the foreground) with initial values.
- buildConfig() - Method in class org.apache.curator.test.QuorumConfigBuilder
- buildConfig() - Method in class org.apache.curator.test.QuorumPeerConfigBuilder
- buildConfig(int) - Method in class org.apache.curator.test.QuorumConfigBuilder
- buildConfig(int, int) - Method in class org.apache.curator.test.QuorumConfigBuilder
- buildConfigProperties(int) - Method in class org.apache.curator.test.QuorumConfigBuilder
- buildConfigProperties(int, int) - Method in class org.apache.curator.test.QuorumConfigBuilder
- buildDelayQueue() - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
-
Build a
DistributedDelayQueue
from the current builder values. - builder() - Static method in class org.apache.curator.framework.CuratorFrameworkFactory
-
Return a new builder that builds a CuratorFramework
- builder() - Static method in class org.apache.curator.framework.recipes.atomic.PromotedToLock
-
Allocate a new builder
- builder() - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListener
-
Returns a builder allowing type specific, and special purpose listeners.
- builder() - Static method in class org.apache.curator.framework.recipes.queue.QueueSharderPolicies
-
Allocate a new builder
- builder() - Static method in class org.apache.curator.utils.ZookeeperCompatibility
- builder() - Static method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Start a new ModeledFrameworkBuilder.
- builder() - Static method in class org.apache.curator.x.discovery.ServiceInstance
-
Return a new builder.
- builder(Class<T>) - Static method in class org.apache.curator.x.discovery.ServiceDiscoveryBuilder
-
Return a new builder.
- builder(String) - Static method in class org.apache.curator.framework.schema.Schema
-
Start a builder for the given full path.
- builder(Pattern) - Static method in class org.apache.curator.framework.schema.Schema
-
Start a builder for the given path pattern.
- builder(CuratorFramework, String) - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCache
-
Start a Curator Cache builder
- builder(CuratorFramework, QueueConsumer<T>, QueueSerializer<T>, String) - Static method in class org.apache.curator.framework.recipes.queue.QueueBuilder
-
Allocate a new builder
- builder(AsyncCuratorFramework, ModelSpec<T>) - Static method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Start a new ModeledFrameworkBuilder for the given model
- builder(ModelSerializer<T>) - Static method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Start a new ModelSpecBuilder for the given serializer.
- builder(ZPath, ModelSerializer<T>) - Static method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Start a new ModelSpecBuilder for the given path and serializer.
- Builder() - Constructor for class org.apache.curator.utils.ZookeeperCompatibility.Builder
- builderForRecipe(String) - Static method in class org.apache.curator.framework.schema.Schema
-
Start a schema builder for a typical Curator recipe's children
- builderForRecipeParent(String) - Static method in class org.apache.curator.framework.schema.Schema
-
Start a schema builder for a typical Curator recipe's parent node
- buildIdQueue() - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
-
Build a
DistributedIdQueue
from the current builder values - buildPriorityQueue(int) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
-
Build a
DistributedPriorityQueue
from the current builder values. - buildProperties() - Method in class org.apache.curator.test.QuorumPeerConfigBuilder
- buildQueue() - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
-
Build a
DistributedQueue
from the current builder values - buildTemp() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Apply the current values and build a new temporary CuratorFramework.
- buildTemp(long, TimeUnit) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Apply the current values and build a new temporary CuratorFramework.
- buildUriSpec() - Method in class org.apache.curator.x.discovery.ServiceInstance
- buildUriSpec(Map<String, Object>) - Method in class org.apache.curator.x.discovery.ServiceInstance
C
- cache - package cache
- cache - Enum constant in enum pubsub.models.InstanceType
- cache() - Method in interface org.apache.curator.x.async.modeled.cached.CachedModeledFramework
-
Return the cache instance
- CACHE_DATA - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheMode
-
Deprecated.The cache will hold all the children and the data for each child node.
- CACHE_DATA_AND_STAT - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheMode
-
Deprecated.The cache will hold all the children, the data for each child node and the stat for each child node
- CACHE_PATHS_ONLY - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheMode
-
Deprecated.The cache will hold only the children path names.
- cacheChanged() - Method in interface org.apache.curator.x.discovery.details.ServiceCacheListener
-
Called when the cache has changed (instances added/deleted, etc.)
- cached() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- cached() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Use an internally created cache as a front for this modeled instance.
- cached(ExecutorService) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- cached(ExecutorService) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Same as
ModeledFramework.cached()
but allows for providing an executor service - CachedAtomicInteger - Class in org.apache.curator.framework.recipes.atomic
-
Uses an
DistributedAtomicNumber
and allocates values in chunks for better performance - CachedAtomicInteger(DistributedAtomicInteger, int) - Constructor for class org.apache.curator.framework.recipes.atomic.CachedAtomicInteger
- CachedAtomicLong - Class in org.apache.curator.framework.recipes.atomic
-
Uses an
DistributedAtomicNumber
and allocates values in chunks for better performance - CachedAtomicLong(DistributedAtomicLong, int) - Constructor for class org.apache.curator.framework.recipes.atomic.CachedAtomicLong
- CachedModeledFramework<T> - Interface in org.apache.curator.x.async.modeled.cached
- callWithRetry(CuratorZookeeperClient, Callable<T>) - Static method in class org.apache.curator.RetryLoop
-
Convenience utility: creates a retry loop calling the given proc and retrying if needed
- callWithRetry(CuratorZookeeperClient, SessionFailRetryLoop.Mode, Callable<T>) - Static method in class org.apache.curator.SessionFailRetryLoop
-
Convenience utility: creates a "session fail" retry loop calling the given proc
- CAN - Enum constant in enum org.apache.curator.framework.schema.Schema.Allowance
- canBeDeleted() - Method in class org.apache.curator.framework.schema.Schema
- canBeDeleted(boolean) - Method in class org.apache.curator.framework.schema.SchemaBuilder
- canBeReadOnly() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- canBeReadOnly(boolean) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- cancel(boolean) - Method in class org.apache.curator.utils.CloseableExecutorService.InternalScheduledFutureTask
- CancelLeadershipException - Exception Class in org.apache.curator.framework.recipes.leader
-
When thrown from
ConnectionStateListener.stateChanged(CuratorFramework, ConnectionState)
, will causeLeaderSelector.interruptLeadership()
to get called. - CancelLeadershipException() - Constructor for exception class org.apache.curator.framework.recipes.leader.CancelLeadershipException
- CancelLeadershipException(String) - Constructor for exception class org.apache.curator.framework.recipes.leader.CancelLeadershipException
- CancelLeadershipException(String, Throwable) - Constructor for exception class org.apache.curator.framework.recipes.leader.CancelLeadershipException
- CancelLeadershipException(Throwable) - Constructor for exception class org.apache.curator.framework.recipes.leader.CancelLeadershipException
- cancelStartTask() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
- CANNOT - Enum constant in enum org.apache.curator.framework.schema.Schema.Allowance
- check() - Method in interface org.apache.curator.framework.api.transaction.CuratorTransaction
-
Deprecated.Start a check builder in the transaction
- check() - Method in interface org.apache.curator.framework.api.transaction.TransactionOp
-
Start a check builder in the transaction
- check() - Method in class org.apache.curator.framework.imps.TransactionOpImpl
- check() - Method in interface org.apache.curator.x.async.api.AsyncTransactionOp
-
Start a check builder in the transaction
- CHECK - Enum constant in enum org.apache.curator.framework.api.transaction.OperationType
- checkError() - Method in interface org.apache.curator.x.async.AsyncResult
-
If there was a general exception or a
KeeperException
aRuntimeException
is thrown that wraps the exception. - checkError() - Method in class org.apache.curator.x.async.details.AsyncResultImpl
- checkException() - Method in interface org.apache.curator.x.async.AsyncResult
-
If there was a general exception (but not a
KeeperException
) aRuntimeException
is thrown that wraps the exception. - checkException() - Method in class org.apache.curator.x.async.details.AsyncResultImpl
- checkExists() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start an exists builder
- checkExists() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- checkExists() - Method in interface org.apache.curator.x.async.api.WatchableAsyncCuratorFramework
-
Start an exists builder.
- checkExists() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- checkExists() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- checkExists() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Check to see if the ZNode at this instance's path exists
- checkExistsOp() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- checkExistsOp() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Check exists operation instance that can be passed among other operations to
ModeledFramework.inTransaction(java.util.List)
to be executed as a single transaction. - checkExistsOp(int) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- checkExistsOp(int) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Check exists operation instance that can be passed among other operations to
ModeledFramework.inTransaction(java.util.List)
to be executed as a single transaction. - checkInterrupted(Throwable) - Static method in class org.apache.curator.utils.ThreadUtils
- child(Object) - Method in interface org.apache.curator.x.async.modeled.cached.CachedModeledFramework
-
Return a new Modeled Curator instance with all the same options but applying to the given child node of this Modeled Curator's path.
- child(Object) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- child(Object) - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- child(Object) - Method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- child(Object) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Return a new Modeled Curator instance with all the same options but applying to the given child node of this Modeled Curator's path.
- child(Object) - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return a new CuratorModel instance with all the same options but applying to the given child node of this CuratorModel's path.
- child(Object) - Method in interface org.apache.curator.x.async.modeled.ZPath
-
Return a ZPath that represents a child ZNode of this ZPath.
- CHILD_ADDED - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent.Type
-
A child was added to the path
- CHILD_REMOVED - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent.Type
-
A child was removed from the path
- CHILD_UPDATED - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent.Type
-
A child's data was changed
- ChildData - Class in org.apache.curator.framework.recipes.cache
- ChildData(String, Stat, byte[]) - Constructor for class org.apache.curator.framework.recipes.cache.ChildData
- childEvent(CuratorFramework, PathChildrenCacheEvent) - Method in interface org.apache.curator.framework.recipes.cache.PathChildrenCacheListener
-
Called when a change has occurred
- childEvent(CuratorFramework, PathChildrenCacheEvent) - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
- childEvent(CuratorFramework, TreeCacheEvent) - Method in interface org.apache.curator.framework.recipes.cache.TreeCacheListener
-
Called when a change has occurred
- children() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- children() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Return the child paths of this instance's path (in no particular order)
- CHILDREN - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.getChildren()
- childrenAsZNodes() - Method in interface org.apache.curator.x.async.modeled.cached.CachedModeledFramework
-
Same as
ModeledFramework.childrenAsZNodes()
but always reads from cache - i.e. - childrenAsZNodes() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- childrenAsZNodes() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Return the child paths of this instance's path (in no particular order) and deserialize into a models.
- ChildrenDeletable - Interface in org.apache.curator.framework.api
- childrenWithData(AsyncCuratorFramework, String) - Static method in class org.apache.curator.x.async.AsyncWrappers
-
Return the children of the given path (keyed by the full path) and the data for each node.
- childrenWithData(AsyncCuratorFramework, String, boolean) - Static method in class org.apache.curator.x.async.AsyncWrappers
-
Return the children of the given path (keyed by the full path) and the data for each node.
- circuitBreaking(RetryPolicy) - Static method in interface org.apache.curator.framework.state.ConnectionStateListenerManagerFactory
-
Listeners set in this manager receive circuit breaking behavior using
CircuitBreakingConnectionStateListener
as a master listener that proxies to any listener registered by client code (unless the listener returns true forConnectionStateListener.doNotProxy()
). - circuitBreaking(RetryPolicy, ScheduledExecutorService) - Static method in interface org.apache.curator.framework.state.ConnectionStateListenerManagerFactory
-
Listeners set in this manager receive circuit breaking behavior using
CircuitBreakingConnectionStateListener
as a master listener that proxies to any listener registered by client code (unless the listener returns true forConnectionStateListener.doNotProxy()
). - CircuitBreakingConnectionStateListener - Class in org.apache.curator.framework.state
-
A proxy for connection state listeners that adds circuit breaking behavior.
- CircuitBreakingConnectionStateListener(CuratorFramework, ConnectionStateListener, RetryPolicy) - Constructor for class org.apache.curator.framework.state.CircuitBreakingConnectionStateListener
- CircuitBreakingConnectionStateListener(CuratorFramework, ConnectionStateListener, RetryPolicy, ScheduledExecutorService) - Constructor for class org.apache.curator.framework.state.CircuitBreakingConnectionStateListener
- clean() - Method in class org.apache.curator.framework.recipes.locks.LockInternals
-
Attempt to delete the lock node so that sequence numbers get reset
- clear() - Method in interface org.apache.curator.framework.listen.ListenerManager
-
Remove all listeners
- clear() - Method in class org.apache.curator.framework.listen.MappingListenerManager
- clear() - Method in class org.apache.curator.framework.listen.StandardListenerManager
- clear() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
-
Reset the storage to zero entries
- clear() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.Clears the current data without beginning a new query and without generating any events for listeners.
- clearAndRefresh() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.Clear out current data and begin a new query on the path
- clearDataBytes(String) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.As a memory optimization, you can clear the cached data bytes for a node.
- clearDataBytes(String, int) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.As a memory optimization, you can clear the cached data bytes for a node.
- clearWatcherReferences(Watcher) - Method in interface org.apache.curator.framework.CuratorFramework
-
Deprecated.
- clearWatcherReferences(Watcher) - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- client(CuratorFramework) - Method in class org.apache.curator.x.discovery.ServiceDiscoveryBuilder
-
Required - set the client to use
- Clients - Class in pubsub
- close() - Method in class discovery.ExampleServer
- close() - Method in class leader.ExampleClient
- close() - Method in class org.apache.curator.CuratorZookeeperClient
-
Close the client.
- close() - Method in interface org.apache.curator.ensemble.EnsembleProvider
-
Curator will call this method when
CuratorZookeeperClient.close()
is called - close() - Method in class org.apache.curator.ensemble.fixed.FixedEnsembleProvider
- close() - Method in interface org.apache.curator.framework.CuratorFramework
-
Stop the client
- close() - Method in interface org.apache.curator.framework.CuratorTempFramework
-
Stop the client
- close() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- close() - Method in class org.apache.curator.framework.imps.CuratorTempFrameworkImpl
- close() - Method in class org.apache.curator.framework.imps.EnsembleTracker
- close() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCache
-
Close the cache, stop responding to events, etc.
- close() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
Deprecated.
- close() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.Close/end the cache
- close() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
Deprecated.Close/end the cache.
- close() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Remove this instance from the leadership election.
- close() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
Shutdown this selector and remove yourself from the leadership group
- close() - Method in interface org.apache.curator.framework.recipes.locks.Lease
-
Releases the lease so that other clients/processes can acquire it
- close() - Method in class org.apache.curator.framework.recipes.locks.Locker
- close() - Method in class org.apache.curator.framework.recipes.nodes.GroupMember
-
Have thisId leave the group and stop caching membership
- close() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
- close() - Method in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
-
Call when you are done with the PersistentTtlNode.
- close() - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
- close() - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
- close() - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
- close() - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
- close() - Method in class org.apache.curator.framework.recipes.queue.QueueSharder
- close() - Method in class org.apache.curator.framework.recipes.shared.SharedCount
- close() - Method in class org.apache.curator.framework.recipes.shared.SharedValue
- close() - Method in class org.apache.curator.framework.recipes.watch.PersistentWatcher
-
Remove the watcher
- close() - Method in class org.apache.curator.framework.state.ConnectionStateManager
- close() - Method in class org.apache.curator.SessionFailRetryLoop
-
Must be called in a finally handler when done with the loop
- close() - Method in class org.apache.curator.test.QuorumConfigBuilder
- close() - Method in class org.apache.curator.test.TestingCluster
-
Shutdown the ensemble, free resources, etc.
- close() - Method in class org.apache.curator.test.TestingServer
-
Close the server and any open clients and delete the temp directory
- close() - Method in class org.apache.curator.test.TestingZooKeeperMain
- close() - Method in class org.apache.curator.test.TestingZooKeeperServer
- close() - Method in class org.apache.curator.test.ZooKeeperServerEmbeddedAdapter
- close() - Method in class org.apache.curator.utils.CloseableExecutorService
-
Closes any tasks currently in progress
- close() - Method in interface org.apache.curator.x.async.modeled.cached.CachedModeledFramework
-
Close/stop the internally created cache
- close() - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
- close() - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
- close() - Method in class org.apache.curator.x.discovery.details.ServiceProviderImpl
-
Close the provider.
- close() - Method in class org.apache.curator.x.discovery.server.rest.InstanceCleanup
- close() - Method in interface org.apache.curator.x.discovery.ServiceProvider
-
Close the provider.
- close() - Method in class pubsub.SubPubTest
- close(int) - Method in class org.apache.curator.CuratorZookeeperClient
-
Close this client object as the
CuratorZookeeperClient.close()
method. - close(LeaderLatch.CloseMode) - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Remove this instance from the leadership election.
- CloseableExecutorService - Class in org.apache.curator.utils
-
Decoration on an ExecutorService that tracks created futures and provides a method to close futures created via this class
- CloseableExecutorService(ExecutorService) - Constructor for class org.apache.curator.utils.CloseableExecutorService
- CloseableExecutorService(ExecutorService, boolean) - Constructor for class org.apache.curator.utils.CloseableExecutorService
- CloseableExecutorService.InternalFutureTask<T> - Class in org.apache.curator.utils
- CloseableExecutorService.InternalScheduledFutureTask - Class in org.apache.curator.utils
- CloseableScheduledExecutorService - Class in org.apache.curator.utils
-
Decoration on an ScheduledExecutorService that tracks created futures and provides a method to close futures created via this class
- CloseableScheduledExecutorService(ScheduledExecutorService) - Constructor for class org.apache.curator.utils.CloseableScheduledExecutorService
- CloseableScheduledExecutorService(ScheduledExecutorService, boolean) - Constructor for class org.apache.curator.utils.CloseableScheduledExecutorService
- CloseableUtils - Class in org.apache.curator.utils
-
This class adds back functionality that was removed in Guava v16.0.
- CloseableUtils() - Constructor for class org.apache.curator.utils.CloseableUtils
- CLOSED - Enum constant in enum org.apache.curator.framework.recipes.leader.LeaderLatch.State
- closeQuietly(Closeable) - Static method in class org.apache.curator.utils.CloseableUtils
-
This method has been added because Guava has removed the
closeQuietly()
method fromCloseables
in v16.0. - closeServer() - Method in class org.apache.curator.test.BaseClassForTests
- CLOSING - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Event sent when client is being closed
- commit() - Method in class org.apache.curator.drivers.EventTrace
- commit() - Method in class org.apache.curator.drivers.OperationTrace
- commit() - Method in interface org.apache.curator.framework.api.transaction.CuratorTransactionFinal
-
Commit all added operations as an atomic unit and return results for the operations.
- commit() - Method in class org.apache.curator.TimeTrace
-
Record the elapsed time
- compareAndSet(byte[], byte[]) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
-
Atomically sets the value to the given updated value if the current value
==
the expected value. - compareAndSet(Integer, Integer) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
- compareAndSet(Long, Long) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
- compareAndSet(T, T) - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
-
Atomically sets the value to the given updated value if the current value
==
the expected value. - compareTo(ChildData) - Method in class org.apache.curator.framework.recipes.cache.ChildData
-
Note: this class has a natural ordering that is inconsistent with equals.
- Compatibility - Class in org.apache.curator.test
- Compatibility - Class in org.apache.curator.utils
-
Utils to help with ZK version compatibility
- Compatibility() - Constructor for class org.apache.curator.test.Compatibility
- Compatibility() - Constructor for class org.apache.curator.utils.Compatibility
- compress - Enum constant in enum org.apache.curator.x.async.api.CreateOption
-
Cause the data to be compressed using the configured compression provider
- compress(String, byte[]) - Method in interface org.apache.curator.framework.api.CompressionProvider
- compress(String, byte[]) - Method in class org.apache.curator.framework.imps.GzipCompressionProvider
- compressed() - Method in interface org.apache.curator.framework.api.Compressible
-
Cause the data to be compressed using the configured compression provider
- compressed() - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- compressed() - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- compressed() - Method in interface org.apache.curator.x.async.api.AsyncSetDataBuilder
-
Cause the data to be compressed using the configured compression provider
- compressed() - Method in interface org.apache.curator.x.async.api.AsyncTransactionCreateBuilder
-
Cause the data to be compressed using the configured compression provider
- compressed() - Method in interface org.apache.curator.x.async.api.AsyncTransactionSetDataBuilder
-
Cause the data to be compressed using the configured compression provider
- COMPRESSED_DATA - Enum constant in enum org.apache.curator.framework.recipes.cache.CuratorCache.Options
-
Decompress data via
Decompressible.decompressed()
- compressedWithVersion(int) - Method in interface org.apache.curator.x.async.api.AsyncSetDataBuilder
-
Cause the data to be compressed using the configured compression provider.
- Compressible<T> - Interface in org.apache.curator.framework.api
- compressionProvider(CompressionProvider) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- CompressionProvider - Interface in org.apache.curator.framework.api
- configToConnectionString(QuorumVerifier) - Static method in class org.apache.curator.framework.imps.EnsembleTracker
- ConfigurableZookeeperFactory - Class in org.apache.curator.utils
-
Configurable ZookeeperFactory, by using org.apache.zookeeper.client.ZKClientConfig.
- ConfigurableZookeeperFactory() - Constructor for class org.apache.curator.utils.ConfigurableZookeeperFactory
- ConfigureEnsembleable - Interface in org.apache.curator.framework.api
- CONNECTED - Enum constant in enum org.apache.curator.framework.state.ConnectionState
-
Sent for the first successful connection to the server.
- connection() - Method in class org.apache.curator.test.compatibility.Timing2
-
Return the value to use for ZK connection timeout
- connection() - Method in class org.apache.curator.test.Timing
-
Return the value to use for ZK connection timeout
- CONNECTION_LOST - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent.Type
-
Called when the connection has changed to
ConnectionState.LOST
This is exposed so that users of the class can be notified of issues that *might* affect normal operation. - CONNECTION_LOST - Enum constant in enum org.apache.curator.framework.recipes.cache.TreeCacheEvent.Type
-
Called when the connection has changed to
ConnectionState.LOST
- CONNECTION_RECONNECTED - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent.Type
-
Called when the connection has changed to
ConnectionState.RECONNECTED
This is exposed so that users of the class can be notified of issues that *might* affect normal operation. - CONNECTION_RECONNECTED - Enum constant in enum org.apache.curator.framework.recipes.cache.TreeCacheEvent.Type
-
Called when the connection has changed to
ConnectionState.RECONNECTED
- CONNECTION_SUSPENDED - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent.Type
-
Called when the connection has changed to
ConnectionState.SUSPENDED
This is exposed so that users of the class can be notified of issues that *might* affect normal operation. - CONNECTION_SUSPENDED - Enum constant in enum org.apache.curator.framework.recipes.cache.TreeCacheEvent.Type
-
Called when the connection has changed to
ConnectionState.SUSPENDED
- ConnectionState - Enum in org.apache.curator.framework.state
-
Represents state changes in the connection to ZK
- connectionStateErrorPolicy(ConnectionStateErrorPolicy) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Set the error policy to use.
- ConnectionStateErrorPolicy - Interface in org.apache.curator.framework.state
-
Recipes should use the configured error policy to decide how to handle errors such as
ConnectionState
changes. - ConnectionStateListener - Interface in org.apache.curator.framework.state
- connectionStateListenerManagerFactory(ConnectionStateListenerManagerFactory) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Sets the connection state listener manager factory.
- ConnectionStateListenerManagerFactory - Interface in org.apache.curator.framework.state
- ConnectionStateManager - Class in org.apache.curator.framework.state
-
Used internally to manage connection state
- ConnectionStateManager(CuratorFramework, ThreadFactory, int, int) - Constructor for class org.apache.curator.framework.state.ConnectionStateManager
- ConnectionStateManager(CuratorFramework, ThreadFactory, int, int, ConnectionStateListenerManagerFactory) - Constructor for class org.apache.curator.framework.state.ConnectionStateManager
- connectionTimeoutMs(int) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- connectString(String) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Set the list of servers to connect to.
- consumeMessage(T) - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
- consumeMessage(T) - Method in interface org.apache.curator.framework.recipes.queue.QueueConsumer
-
Process a message from the queue
- ContainerType - Class in modeled
- ContainerType() - Constructor for class modeled.ContainerType
- ContainerType(int) - Constructor for class modeled.ContainerType
- countHasChanged(SharedCountReader, int) - Method in interface org.apache.curator.framework.recipes.shared.SharedCountListener
-
Called when the shared value has changed
- create() - Method in interface org.apache.curator.framework.api.transaction.CuratorTransaction
-
Deprecated.Start a create builder in the transaction
- create() - Method in interface org.apache.curator.framework.api.transaction.TransactionOp
-
Start a create builder in the transaction
- create() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a create builder
- create() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- create() - Method in class org.apache.curator.framework.imps.TransactionOpImpl
- create() - Method in interface org.apache.curator.x.async.api.AsyncCuratorFrameworkDsl
-
Start a create builder
- create() - Method in interface org.apache.curator.x.async.api.AsyncTransactionOp
-
Start a create builder in the transaction
- create() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- create(CuratorFramework, String, byte[]) - Static method in class async.AsyncExamples
- create(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
- CREATE - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.create()
- CREATE - Enum constant in enum org.apache.curator.framework.api.transaction.OperationType
- createAndStartCluster(int) - Method in class org.apache.curator.test.BaseClassForTests
- CreateBackgroundModeACLable - Interface in org.apache.curator.framework.api
- CreateBackgroundModeStatACLable - Interface in org.apache.curator.framework.api
- CreateBuilder - Interface in org.apache.curator.framework.api
- CreateBuilder2 - Interface in org.apache.curator.framework.api
- CreateBuilderImpl - Class in org.apache.curator.framework.imps
- CreateBuilderImpl(CuratorFrameworkImpl, CreateMode, Backgrounding, boolean, boolean, boolean, boolean, boolean, List<ACL>, Stat, long) - Constructor for class org.apache.curator.framework.imps.CreateBuilderImpl
- CreateBuilderMain - Interface in org.apache.curator.framework.api
- CreateClientExamples - Class in framework
- CreateClientExamples() - Constructor for class framework.CreateClientExamples
- createContainers(String) - Method in interface org.apache.curator.framework.CuratorFramework
-
Create all nodes in the specified path as containers if they don't already exist
- createContainers(String) - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- createEphemeral(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
- createEphemeralSequential(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
- createIdempotent(CuratorFramework, String, byte[]) - Static method in class framework.CrudExamples
- CreateModable<T> - Interface in org.apache.curator.framework.api
- createMode() - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- createMode() - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return the model's create mode
- createOp(T) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- createOp(T) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Create operation instance that can be passed among other operations to
ModeledFramework.inTransaction(java.util.List)
to be executed as a single transaction. - CreateOption - Enum in org.apache.curator.x.async.api
-
Options when creating ZNodes
- createOptions() - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- createOptions() - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return the model's create options
- createOrUpdate(PersonModelSpec, PersonModel) - Static method in class modeled.ModeledCuratorExamplesAlt
- createOrUpdate(ModeledFramework<PersonModel>, PersonModel) - Static method in class modeled.ModeledCuratorExamples
- createParentsAsContainers - Enum constant in enum org.apache.curator.x.async.api.CreateOption
-
Causes any parent nodes to get created using
CreateMode.CONTAINER
if they haven't already been. - createParentsAsContainers - Enum constant in enum org.apache.curator.x.async.api.ExistsOption
- createParentsIfNeeded - Enum constant in enum org.apache.curator.x.async.api.CreateOption
-
Causes any parent nodes to get created if they haven't already been
- createParentsIfNeeded - Enum constant in enum org.apache.curator.x.async.api.ExistsOption
- CreateProtectACLCreateModePathAndBytesable<T> - Interface in org.apache.curator.framework.api
- createServer() - Method in class org.apache.curator.test.BaseClassForTests
- createSimple(String) - Static method in class framework.CreateClientExamples
- createsTheLock(CuratorFramework, String, byte[]) - Method in interface org.apache.curator.framework.recipes.locks.LockInternalsDriver
- createsTheLock(CuratorFramework, String, byte[]) - Method in class org.apache.curator.framework.recipes.locks.StandardLockInternalsDriver
- createTempDirectory() - Static method in class org.apache.curator.test.DirectoryUtils
- createThenWatch(CuratorFramework, String) - Static method in class async.AsyncExamples
- createThenWatchSimple(CuratorFramework, String) - Static method in class async.AsyncExamples
- createWithOptions(String, RetryPolicy, int, int) - Static method in class framework.CreateClientExamples
- creatingParentContainersIfNeeded() - Method in interface org.apache.curator.framework.api.CreateBackgroundModeACLable
-
Causes any parent nodes to get created using
CreateMode.CONTAINER
if they haven't already been. - creatingParentContainersIfNeeded() - Method in interface org.apache.curator.framework.api.CreateBackgroundModeStatACLable
-
Causes any parent nodes to get created using
CreateMode.CONTAINER
if they haven't already been. - creatingParentContainersIfNeeded() - Method in interface org.apache.curator.framework.api.CreateBuilderMain
-
Causes any parent nodes to get created using
CreateMode.CONTAINER
if they haven't already been. - creatingParentContainersIfNeeded() - Method in interface org.apache.curator.framework.api.CreateProtectACLCreateModePathAndBytesable
-
Causes any parent nodes to get created using
CreateMode.CONTAINER
if they haven't already been. - creatingParentContainersIfNeeded() - Method in interface org.apache.curator.framework.api.ExistsBuilder
-
Causes any parent nodes to get created using
CreateMode.CONTAINER
if they haven't already been. - creatingParentContainersIfNeeded() - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- creatingParentContainersIfNeeded() - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- creatingParentsIfNeeded() - Method in interface org.apache.curator.framework.api.CreateBackgroundModeACLable
-
Causes any parent nodes to get created if they haven't already been
- creatingParentsIfNeeded() - Method in interface org.apache.curator.framework.api.CreateBackgroundModeStatACLable
-
Causes any parent nodes to get created if they haven't already been
- creatingParentsIfNeeded() - Method in interface org.apache.curator.framework.api.CreateBuilderMain
-
Causes any parent nodes to get created if they haven't already been
- creatingParentsIfNeeded() - Method in interface org.apache.curator.framework.api.CreateProtectACLCreateModePathAndBytesable
-
Causes any parent nodes to get created if they haven't already been
- creatingParentsIfNeeded() - Method in interface org.apache.curator.framework.api.ExistsBuilder
-
Causes any parent nodes to get created if they haven't already been
- creatingParentsIfNeeded() - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- creatingParentsIfNeeded() - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- CrudExamples - Class in framework
- CrudExamples() - Constructor for class framework.CrudExamples
- CuratorCache - Interface in org.apache.curator.framework.recipes.cache
-
A utility that attempts to keep the data from a node locally cached.
- CuratorCache.Options - Enum in org.apache.curator.framework.recipes.cache
-
cache build options
- CuratorCacheAccessor - Interface in org.apache.curator.framework.recipes.cache
-
Methods to access the underlying storage
- CuratorCacheBridge - Interface in org.apache.curator.framework.recipes.cache
-
A facade that uses
CuratorCache
if persistent watches are available or aTreeCache
otherwise - CuratorCacheBridgeBuilder - Interface in org.apache.curator.framework.recipes.cache
- CuratorCacheBuilder - Interface in org.apache.curator.framework.recipes.cache
- CuratorCacheExample - Class in cache
-
Very simple example of creating a CuratorCache that listens to events and logs the changes to standard out.
- CuratorCacheExample() - Constructor for class cache.CuratorCacheExample
- CuratorCacheListener - Interface in org.apache.curator.framework.recipes.cache
-
Listener for
CuratorCache
events. - CuratorCacheListener.Type - Enum in org.apache.curator.framework.recipes.cache
-
An enumerated type that describes a change
- CuratorCacheListenerBuilder - Interface in org.apache.curator.framework.recipes.cache
- CuratorCacheListenerBuilder.ChangeListener - Interface in org.apache.curator.framework.recipes.cache
- CuratorCacheStorage - Interface in org.apache.curator.framework.recipes.cache
-
Interface for maintaining data in a
CuratorCache
- CuratorConnectionLossException - Exception Class in org.apache.curator
- CuratorConnectionLossException() - Constructor for exception class org.apache.curator.CuratorConnectionLossException
- CuratorEvent - Interface in org.apache.curator.framework.api
-
A super set of all the various Zookeeper events/background methods.
- CuratorEventType - Enum in org.apache.curator.framework.api
- CuratorFramework - Interface in org.apache.curator.framework
-
Zookeeper framework-style client
- CuratorFrameworkFactory - Class in org.apache.curator.framework
-
Factory methods for creating framework-style clients
- CuratorFrameworkFactory.Builder - Class in org.apache.curator.framework
- CuratorFrameworkImpl - Class in org.apache.curator.framework.imps
- CuratorFrameworkImpl(CuratorFrameworkFactory.Builder) - Constructor for class org.apache.curator.framework.imps.CuratorFrameworkImpl
- CuratorFrameworkImpl(CuratorFrameworkImpl) - Constructor for class org.apache.curator.framework.imps.CuratorFrameworkImpl
- CuratorFrameworkState - Enum in org.apache.curator.framework.imps
- CuratorListener - Interface in org.apache.curator.framework.api
-
Receives notifications about errors and background events
- CuratorMultiTransaction - Interface in org.apache.curator.framework.api.transaction
- CuratorMultiTransactionImpl - Class in org.apache.curator.framework.imps
- CuratorMultiTransactionImpl(CuratorFrameworkImpl) - Constructor for class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- CuratorMultiTransactionImpl(CuratorFrameworkImpl, Backgrounding) - Constructor for class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- CuratorMultiTransactionMain - Interface in org.apache.curator.framework.api.transaction
- CuratorOp - Interface in org.apache.curator.framework.api.transaction
-
Internal representation of a transaction operation
- CuratorTempFramework - Interface in org.apache.curator.framework
-
Temporary CuratorFramework instances are meant for single requests to ZooKeeper ensembles over a failure prone network such as a WAN.
- CuratorTempFrameworkImpl - Class in org.apache.curator.framework.imps
- CuratorTempFrameworkImpl(CuratorFrameworkFactory.Builder, long) - Constructor for class org.apache.curator.framework.imps.CuratorTempFrameworkImpl
- CuratorTestBase - Class in org.apache.curator.test.compatibility
- CuratorTestBase() - Constructor for class org.apache.curator.test.compatibility.CuratorTestBase
- CuratorTransaction - Interface in org.apache.curator.framework.api.transaction
-
Deprecated.
- CuratorTransactionBridge - Interface in org.apache.curator.framework.api.transaction
- CuratorTransactionFinal - Interface in org.apache.curator.framework.api.transaction
-
Adds commit to the transaction interface
- CuratorTransactionResult - Class in org.apache.curator.framework.api.transaction
-
Holds the result of one transactional operation
- CuratorTransactionResult(OperationType, String, String, Stat) - Constructor for class org.apache.curator.framework.api.transaction.CuratorTransactionResult
- CuratorTransactionResult(OperationType, String, String, Stat, int) - Constructor for class org.apache.curator.framework.api.transaction.CuratorTransactionResult
- CuratorWatcher - Interface in org.apache.curator.framework.api
-
A version of
Watcher
that can throw an exception - CuratorZookeeperClient - Class in org.apache.curator
-
A wrapper around Zookeeper that takes care of some low-level housekeeping
- CuratorZookeeperClient(String, int, int, Watcher, RetryPolicy) - Constructor for class org.apache.curator.CuratorZookeeperClient
- CuratorZookeeperClient(EnsembleProvider, int, int, Watcher, RetryPolicy) - Constructor for class org.apache.curator.CuratorZookeeperClient
- CuratorZookeeperClient(ZookeeperFactory, EnsembleProvider, int, int, int, Watcher, RetryPolicy, boolean) - Constructor for class org.apache.curator.CuratorZookeeperClient
- CuratorZookeeperClient(ZookeeperFactory, EnsembleProvider, int, int, Watcher, RetryPolicy, boolean) - Constructor for class org.apache.curator.CuratorZookeeperClient
- currentChildren(ZPath) - Method in interface org.apache.curator.x.async.modeled.cached.ModeledCache
-
Return the modeled current set of children at the given path, mapped by child name.
- currentData(ZPath) - Method in interface org.apache.curator.x.async.modeled.cached.ModeledCache
-
Return the modeled current data for the given path.
D
- database - Enum constant in enum pubsub.models.InstanceType
- DataCallbackable<T> - Interface in org.apache.curator.framework.api
- dataNotCached() - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
-
Return a new storage instance that does not retain the data bytes.
- dataValidator(SchemaValidator) - Method in class org.apache.curator.framework.schema.SchemaBuilder
- debugUnhandledErrorListener - Variable in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- DebugUtils - Class in org.apache.curator.utils
- decompress(String, byte[]) - Method in interface org.apache.curator.framework.api.CompressionProvider
- decompress(String, byte[]) - Method in class org.apache.curator.framework.imps.GzipCompressionProvider
- decompressed() - Method in interface org.apache.curator.framework.api.Decompressible
-
Cause the data to be de-compressed using the configured compression provider
- decompressed() - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- decompressed() - Method in interface org.apache.curator.x.async.api.AsyncGetDataBuilder
-
Cause the data to be de-compressed using the configured compression provider
- decompressedStoringStatIn(Stat) - Method in interface org.apache.curator.x.async.api.AsyncGetDataBuilder
-
Have the operation fill the provided stat object and have the data be de-compressed
- Decompressible<T> - Interface in org.apache.curator.framework.api
- decrement() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
-
Subtract 1 from the current value and return the new value information.
- decrement() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
-
Subtract 1 from the current value and return the new value information.
- decrement() - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
-
Subtract 1 from the current value and return the new value information.
- DEFAULT_CHILD_NODE_NAME - Static variable in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
- DEFAULT_TOUCH_SCHEDULE_FACTOR - Static variable in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
- DEFAULT_USE_PARENT_CREATION - Static variable in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
- DefaultACLProvider - Class in org.apache.curator.framework.imps
- DefaultACLProvider() - Constructor for class org.apache.curator.framework.imps.DefaultACLProvider
- defaultCreateOptions - Static variable in interface org.apache.curator.x.async.modeled.ModelSpec
- defaultData(byte[]) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Sets the data to use when
PathAndBytesable.forPath(String)
is used. - defaultDeleteOptions - Static variable in interface org.apache.curator.x.async.modeled.ModelSpec
- DefaultSchemaValidator - Class in org.apache.curator.framework.schema
-
The default data validator - always returns true
- DefaultSchemaValidator() - Constructor for class org.apache.curator.framework.schema.DefaultSchemaValidator
- defaultThreadFactorySupplier - Static variable in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.
- DefaultTracerDriver - Class in org.apache.curator.utils
-
Default tracer driver
- DefaultTracerDriver() - Constructor for class org.apache.curator.utils.DefaultTracerDriver
- DefaultTreeCacheSelector - Class in org.apache.curator.framework.recipes.cache
-
Default TreeCache selector - returns true for all methods
- DefaultTreeCacheSelector() - Constructor for class org.apache.curator.framework.recipes.cache.DefaultTreeCacheSelector
- DefaultZookeeperFactory - Class in org.apache.curator.utils
- DefaultZookeeperFactory() - Constructor for class org.apache.curator.utils.DefaultZookeeperFactory
- DelegatingExecutorService - Class in org.apache.curator.test
- DelegatingExecutorService(ExecutorService) - Constructor for class org.apache.curator.test.DelegatingExecutorService
- delete() - Method in interface org.apache.curator.framework.api.transaction.CuratorTransaction
-
Deprecated.Start a delete builder in the transaction
- delete() - Method in interface org.apache.curator.framework.api.transaction.TransactionOp
-
Start a delete builder in the transaction
- delete() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a delete builder
- delete() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- delete() - Method in class org.apache.curator.framework.imps.TransactionOpImpl
- delete() - Method in interface org.apache.curator.x.async.api.AsyncCuratorFrameworkDsl
-
Start a delete builder
- delete() - Method in interface org.apache.curator.x.async.api.AsyncTransactionOp
-
Start a delete builder in the transaction
- delete() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- delete() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- delete() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Delete the ZNode at this instance's path passing -1 for the delete version
- delete(int) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- delete(int) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Delete the ZNode at this instance's path passing the given delete version
- delete(CuratorFramework, String) - Static method in class framework.CrudExamples
- DELETE - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.delete()
- DELETE - Enum constant in enum org.apache.curator.framework.api.transaction.OperationType
- DELETE - Enum constant in enum org.apache.curator.framework.recipes.queue.ErrorMode
-
If the consumer throws an exception, delete the message
- DeleteBuilder - Interface in org.apache.curator.framework.api
- DeleteBuilderImpl - Class in org.apache.curator.framework.imps
- DeleteBuilderImpl(CuratorFrameworkImpl, int, Backgrounding, boolean, boolean, boolean) - Constructor for class org.apache.curator.framework.imps.DeleteBuilderImpl
- DeleteBuilderMain - Interface in org.apache.curator.framework.api
- deleteChildren(ZooKeeper, String, boolean) - Static method in class org.apache.curator.utils.ZKPaths
-
Recursively deletes children of a node.
- deleteDataDirectoryOnClose() - Method in class org.apache.curator.test.InstanceSpec
- deleteDirectoryContents(File) - Static method in class org.apache.curator.test.DirectoryUtils
- deleteIdempotent(CuratorFramework, String, int) - Static method in class framework.CrudExamples
- deleteNode() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
- deleteOp() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- deleteOp() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Delete operation instance that can be passed among other operations to
ModeledFramework.inTransaction(java.util.List)
to be executed as a single transaction. - deleteOp(int) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- deleteOp(int) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Delete operation instance that can be passed among other operations to
ModeledFramework.inTransaction(java.util.List)
to be executed as a single transaction. - DeleteOption - Enum in org.apache.curator.x.async.api
-
Options to use when deleting ZNodes
- deleteOptions() - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- deleteOptions() - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return the model's delete options
- deleteRecursively(File) - Static method in class org.apache.curator.test.DirectoryUtils
- deletingChildrenIfNeeded - Enum constant in enum org.apache.curator.x.async.api.DeleteOption
-
Will also delete children if they exist
- deletingChildrenIfNeeded() - Method in interface org.apache.curator.framework.api.ChildrenDeletable
-
Will also delete children if they exist.
- deletingChildrenIfNeeded() - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- deserialize(byte[]) - Method in interface org.apache.curator.framework.recipes.queue.QueueSerializer
-
Deserialize bytes into a queue item
- deserialize(byte[]) - Method in class org.apache.curator.x.async.modeled.JacksonModelSerializer
- deserialize(byte[]) - Method in interface org.apache.curator.x.async.modeled.ModelSerializer
-
Given bytes serialized via
ModelSerializer.serialize(Object)
return the model - deserialize(byte[]) - Method in interface org.apache.curator.x.discovery.details.InstanceSerializer
-
Deserialize a byte array into an instance
- deserialize(byte[]) - Method in class org.apache.curator.x.discovery.details.JsonInstanceSerializer
- DirectoryUtils - Class in org.apache.curator.test
- DirectoryUtils() - Constructor for class org.apache.curator.test.DirectoryUtils
- disableZkWatches(boolean) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
Deprecated.By default, TreeCache creates
ZooKeeper
watches for every created path. - discovery - package discovery
- DiscoveryContext<T> - Interface in org.apache.curator.x.discovery.server.rest
-
Bridge between the specifics of your needs and the generic implementation
- DiscoveryExample - Class in discovery
- DiscoveryExample() - Constructor for class discovery.DiscoveryExample
- DiscoveryPathConstructor - Interface in org.apache.curator.x.discovery
-
Constructs ZooKeeper paths to services for service discovering.
- DiscoveryPathConstructorImpl - Class in org.apache.curator.x.discovery.details
-
A standard constructor, it uses standard path constructing strategy by applying name to the base path.
- DiscoveryPathConstructorImpl(String) - Constructor for class org.apache.curator.x.discovery.details.DiscoveryPathConstructorImpl
- DiscoveryResource<T> - Class in org.apache.curator.x.discovery.server.rest
-
The JAX-RS web service.
- DiscoveryResource(DiscoveryContext<T>) - Constructor for class org.apache.curator.x.discovery.server.rest.DiscoveryResource
- DistributedAtomicInteger - Class in org.apache.curator.framework.recipes.atomic
-
A counter that attempts atomic increments.
- DistributedAtomicInteger(CuratorFramework, String, RetryPolicy) - Constructor for class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
-
Creates in optimistic mode only - i.e.
- DistributedAtomicInteger(CuratorFramework, String, RetryPolicy, PromotedToLock) - Constructor for class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
-
Creates in mutex promotion mode.
- DistributedAtomicLong - Class in org.apache.curator.framework.recipes.atomic
-
A counter that attempts atomic increments.
- DistributedAtomicLong(CuratorFramework, String, RetryPolicy) - Constructor for class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
-
Creates in optimistic mode only - i.e.
- DistributedAtomicLong(CuratorFramework, String, RetryPolicy, PromotedToLock) - Constructor for class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
-
Creates in mutex promotion mode.
- DistributedAtomicNumber<T> - Interface in org.apache.curator.framework.recipes.atomic
- DistributedAtomicValue - Class in org.apache.curator.framework.recipes.atomic
-
A distributed value that attempts atomic sets.
- DistributedAtomicValue(CuratorFramework, String, RetryPolicy) - Constructor for class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
-
Creates in optimistic mode only - i.e.
- DistributedAtomicValue(CuratorFramework, String, RetryPolicy, PromotedToLock) - Constructor for class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
-
Creates in mutex promotion mode.
- DistributedBarrier - Class in org.apache.curator.framework.recipes.barriers
-
A barrier as described in the ZK recipes.
- DistributedBarrier(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.barriers.DistributedBarrier
- DistributedDelayQueue<T> - Class in org.apache.curator.framework.recipes.queue
-
A variation of the DistributedPriorityQueue that uses time as the priority.
- DistributedDoubleBarrier - Class in org.apache.curator.framework.recipes.barriers
-
A double barrier as described in the ZK recipes.
- DistributedDoubleBarrier(CuratorFramework, String, int) - Constructor for class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
-
Creates the barrier abstraction.
- DistributedIdQueue<T> - Class in org.apache.curator.framework.recipes.queue
-
A version of
DistributedQueue
that allows IDs to be associated with queue items. - DistributedPriorityQueue<T> - Class in org.apache.curator.framework.recipes.queue
-
An implementation of the Distributed Priority Queue ZK recipe.
- DistributedQueue<T> - Class in org.apache.curator.framework.recipes.queue
-
An implementation of the Distributed Queue ZK recipe.
- DistributedQueue.ProcessType - Enum in org.apache.curator.framework.recipes.queue
- DO_NOT_CLEAR_ON_CLOSE - Enum constant in enum org.apache.curator.framework.recipes.cache.CuratorCache.Options
-
Normally, when the cache is closed via
CuratorCache.close()
, the storage is cleared viaCuratorCacheStorage.clear()
. - documentation(String) - Method in class org.apache.curator.framework.schema.SchemaBuilder
- done() - Method in class org.apache.curator.utils.CloseableExecutorService.InternalFutureTask
- doNotProxy() - Method in interface org.apache.curator.framework.state.ConnectionStateListener
-
ConnectionStateListener managers set via
CuratorFrameworkFactory.Builder.connectionStateListenerManagerFactory(ConnectionStateListenerManagerFactory)
are allowed to proxy (etc.) ConnectionStateListeners as needed. - dontUseContainerParents() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
By default, Curator uses
CreateBuilderMain.creatingParentContainersIfNeeded()
if the ZK JAR supportsCreateMode.CONTAINER
. - doProtected - Enum constant in enum org.apache.curator.x.async.api.CreateOption
-
Hat-tip to https://github.com/sbridges for pointing this out
- downInstancePolicy(DownInstancePolicy) - Method in interface org.apache.curator.x.discovery.ServiceProviderBuilder
-
Set the down instance policy
- DownInstancePolicy - Class in org.apache.curator.x.discovery
-
Abstraction for values that determine when an instance is down
- DownInstancePolicy() - Constructor for class org.apache.curator.x.discovery.DownInstancePolicy
-
Policy with default values
- DownInstancePolicy(long, TimeUnit, int) - Constructor for class org.apache.curator.x.discovery.DownInstancePolicy
- doWork(long, TimeUnit) - Method in class locking.ExampleClientThatLocks
- drainTo(Collection<? super T>) - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
-
Removes all available elements from this queue and adds them to the given collection.
- DYNAMIC - Enum constant in enum org.apache.curator.x.discovery.ServiceType
- DYNAMIC_SEQUENTIAL - Enum constant in enum org.apache.curator.x.discovery.ServiceType
E
- element() - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
-
Return the head of the queue without modifying the queue.
- enabled(boolean) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
- Ensembleable<T> - Interface in org.apache.curator.framework.api
- ensembleProvider(EnsembleProvider) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Set the list ensemble provider.
- EnsembleProvider - Interface in org.apache.curator.ensemble
-
Abstraction that provides the ZooKeeper connection string
- ensembleTracker(boolean) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Allows to configure if the ensemble configuration changes will be watched.
- EnsembleTracker - Class in org.apache.curator.framework.imps
- ensure() - Method in class org.apache.curator.framework.EnsureContainers
-
The first time this method is called, all nodes in the path will be created as containers if needed
- ensure(CuratorZookeeperClient) - Method in class org.apache.curator.utils.EnsurePath
-
Deprecated.First time, synchronizes and makes sure all nodes in the path are created.
- EnsureContainers - Class in org.apache.curator.framework
-
Similar to
EnsurePath
but creates containers. - EnsureContainers(CuratorFramework, String) - Constructor for class org.apache.curator.framework.EnsureContainers
- ensurePath() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.
- ensurePath() - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
- EnsurePath - Class in org.apache.curator.utils
-
Deprecated.Since 2.9.0 - Prefer CuratorFramework.create().creatingParentContainersIfNeeded() or CuratorFramework.exists().creatingParentContainersIfNeeded()
- EnsurePath(String) - Constructor for class org.apache.curator.utils.EnsurePath
-
Deprecated.
- EnsurePath(String, AtomicReference<EnsurePath.Helper>, boolean, InternalACLProvider) - Constructor for class org.apache.curator.utils.EnsurePath
-
Deprecated.
- EnsurePath(String, InternalACLProvider) - Constructor for class org.apache.curator.utils.EnsurePath
-
Deprecated.
- enter() - Method in class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
-
Enter the barrier and block until all members have entered
- enter(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
-
Enter the barrier and block until all members have entered or the timeout has elapsed
- ephemeral(Schema.Allowance) - Method in class org.apache.curator.framework.schema.SchemaBuilder
- EPHEMERAL - Enum constant in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
-
Deprecated.Same as
CreateMode.EPHEMERAL
- EPHEMERAL_SEQUENTIAL - Enum constant in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
-
Deprecated.Same as
CreateMode.EPHEMERAL_SEQUENTIAL
- equals(Object) - Method in class modeled.ContainerType
- equals(Object) - Method in class modeled.PersonId
- equals(Object) - Method in class modeled.PersonModel
- equals(Object) - Method in class org.apache.curator.framework.recipes.cache.ChildData
- equals(Object) - Method in class org.apache.curator.framework.recipes.leader.Participant
- equals(Object) - Method in class org.apache.curator.framework.schema.Schema
- equals(Object) - Method in class org.apache.curator.test.InstanceSpec
- equals(Object) - Method in class org.apache.curator.utils.ZKPaths.PathAndNode
- equals(Object) - Method in class org.apache.curator.x.async.details.AsyncResultImpl
- equals(Object) - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- equals(Object) - Method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- equals(Object) - Method in class org.apache.curator.x.discovery.ServiceInstance
- equals(Object) - Method in class org.apache.curator.x.discovery.UriSpec
- equals(Object) - Method in class org.apache.curator.x.discovery.UriSpec.Part
- ErrorListenerEnsembleable<T> - Interface in org.apache.curator.framework.api
- ErrorListenerMultiTransactionMain - Interface in org.apache.curator.framework.api
- ErrorListenerPathable<T> - Interface in org.apache.curator.framework.api
- ErrorListenerPathAndBytesable<T> - Interface in org.apache.curator.framework.api
- ErrorListenerReconfigBuilderMain - Interface in org.apache.curator.framework.api
- ErrorMode - Enum in org.apache.curator.framework.recipes.queue
-
Used when the queue is created with a
QueueBuilder.lockPath(String)
. - event() - Method in interface org.apache.curator.x.async.AsyncStage
-
If the
WatchableAsyncCuratorFramework
facade is used (viaAsyncCuratorFrameworkDsl.watched()
), this returns the completion stage used when the watcher is triggered - event(ChildData, ChildData) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder.ChangeListener
- event(CuratorCacheListener.Type, ChildData, ChildData) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListener
-
Called when a data is created, changed or deleted.
- eventReceived(CuratorFramework, CuratorEvent) - Method in interface org.apache.curator.framework.api.CuratorListener
-
Called when a background task has completed or a watch has triggered
- EventTrace - Class in org.apache.curator.drivers
- EventTrace(String, TracerDriver) - Constructor for class org.apache.curator.drivers.EventTrace
- EventTrace(String, TracerDriver, long) - Constructor for class org.apache.curator.drivers.EventTrace
- 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
- ExceptionAccumulator - Class in org.apache.curator.utils
-
Utility to accumulate multiple potential exceptions into one that is thrown at the end
- ExceptionAccumulator() - Constructor for class org.apache.curator.utils.ExceptionAccumulator
- excludingLast() - Method in class org.apache.curator.utils.EnsurePath
-
Deprecated.Returns a view of this EnsurePath instance that does not make the last node.
- execute(Runnable) - Method in class org.apache.curator.test.DelegatingExecutorService
- execute(Runnable) - Method in class org.apache.curator.test.ExecuteCalledWatchingExecutorService
- execute(CuratorFramework, Runnable) - Static method in class org.apache.curator.framework.recipes.AfterConnectionEstablished
-
Spawns a new new background thread that will block until a connection is available and then execute the 'runAfterConnection' logic
- ExecuteCalledWatchingExecutorService - Class in org.apache.curator.test
- ExecuteCalledWatchingExecutorService(ExecutorService) - Constructor for class org.apache.curator.test.ExecuteCalledWatchingExecutorService
- executor - Variable in class org.apache.curator.framework.listen.ListenerEntry
- executor(Executor) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
-
Change the executor used.
- executorService(ExecutorService) - Method in interface org.apache.curator.x.discovery.ServiceCacheBuilder
-
Optional ExecutorService to use for the cache's background thread.
- executorService(ExecutorService) - Method in interface org.apache.curator.x.discovery.ServiceProviderBuilder
-
Optional ExecutorService to use for the cache's background thread.
- EXISTS - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.checkExists()
- ExistsBuilder - Interface in org.apache.curator.framework.api
- ExistsBuilderImpl - Class in org.apache.curator.framework.imps
- ExistsBuilderImpl(CuratorFrameworkImpl, Backgrounding, Watcher, boolean, boolean) - Constructor for class org.apache.curator.framework.imps.ExistsBuilderImpl
- ExistsBuilderMain - Interface in org.apache.curator.framework.api
- ExistsOption - Enum in org.apache.curator.x.async.api
-
Options to use when checking for ZNode existence
- ExponentialBackoffRetry - Class in org.apache.curator.retry
-
Retry policy that retries a set number of times with increasing sleep time between retries
- ExponentialBackoffRetry(int, int) - Constructor for class org.apache.curator.retry.ExponentialBackoffRetry
- ExponentialBackoffRetry(int, int, int) - Constructor for class org.apache.curator.retry.ExponentialBackoffRetry
- ExtractingCuratorOp - Class in org.apache.curator.framework.imps
- ExtractingCuratorOp() - Constructor for class org.apache.curator.framework.imps.ExtractingCuratorOp
- extractProtectedId(String) - Static method in class org.apache.curator.framework.imps.ProtectedUtils
-
Extracts protectedId in case the provided name is protected
- extractSequentialSuffix(String) - Static method in class org.apache.curator.utils.ZKPaths
-
Extracts the ten-digit suffix from a sequential znode path.
F
- FAIL - Enum constant in enum org.apache.curator.SessionFailRetryLoop.Mode
-
If the session fails, throw
KeeperException.SessionExpiredException
whenSessionFailRetryLoop.shouldContinue()
is called - FailedServerStartException - Exception Class in org.apache.curator.test
- FailedServerStartException(String) - Constructor for exception class org.apache.curator.test.FailedServerStartException
- FailedServerStartException(Throwable) - Constructor for exception class org.apache.curator.test.FailedServerStartException
- 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 org.apache.curator.x.discovery.UriSpec
-
If a
ServiceInstance
is passed when building, the replacement isServiceInstance.getAddress()
- FIELD_CLOSE_BRACE - Static variable in class org.apache.curator.x.discovery.UriSpec
-
Always replaced with '}' - i.e.
- FIELD_ID - Static variable in class org.apache.curator.x.discovery.UriSpec
-
If a
ServiceInstance
is passed when building, the replacement isServiceInstance.getId()
- FIELD_NAME - Static variable in class org.apache.curator.x.discovery.UriSpec
-
If a
ServiceInstance
is passed when building, the replacement isServiceInstance.getName()
- FIELD_OPEN_BRACE - Static variable in class org.apache.curator.x.discovery.UriSpec
-
Always replaced with '{' - i.e.
- FIELD_PORT - Static variable in class org.apache.curator.x.discovery.UriSpec
-
If a
ServiceInstance
is passed when building, the replacement isServiceInstance.getPort()
- FIELD_REGISTRATION_TIME_UTC - Static variable in class org.apache.curator.x.discovery.UriSpec
-
If a
ServiceInstance
is passed when building, the replacement isServiceInstance.getRegistrationTimeUTC()
- FIELD_SCHEME - Static variable in class org.apache.curator.x.discovery.UriSpec
-
This defaults to "http".
- FIELD_SERVICE_TYPE - Static variable in class org.apache.curator.x.discovery.UriSpec
-
If a
ServiceInstance
is passed when building, the replacement isServiceInstance.getServiceType()
- FIELD_SSL_PORT - Static variable in class org.apache.curator.x.discovery.UriSpec
-
If a
ServiceInstance
is passed when building, the replacement isServiceInstance.getSslPort()
- filter(MigrationSet, List<byte[]>) - Method in class org.apache.curator.x.async.migrations.MigrationManager
-
Can be overridden to change how the comparison to previous migrations is done.
- Filters - Class in org.apache.curator.x.async.details
- Filters(UnhandledErrorListener, UnaryOperator<CuratorEvent>, UnaryOperator<WatchedEvent>) - Constructor for class org.apache.curator.x.async.details.Filters
- finalFlushTime(int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
-
Sets an amount of time to call
DistributedQueue.flushPuts(long, TimeUnit)
when the queue is closed. - findConnectionInstance(ZooKeeper) - Method in class org.apache.curator.test.TestingCluster
-
Given a ZooKeeper instance, returns which server it is connected to
- FixedEnsembleProvider - Class in org.apache.curator.ensemble.fixed
-
Standard ensemble provider that wraps a fixed connection string
- FixedEnsembleProvider(String) - Constructor for class org.apache.curator.ensemble.fixed.FixedEnsembleProvider
-
The connection string to use
- FixedEnsembleProvider(String, boolean) - Constructor for class org.apache.curator.ensemble.fixed.FixedEnsembleProvider
-
The connection string to use
- fixForNamespace(String, String) - Static method in class org.apache.curator.utils.ZKPaths
-
Apply the namespace to the given path
- fixForNamespace(String, String, boolean) - Static method in class org.apache.curator.utils.ZKPaths
-
Apply the namespace to the given path
- fixForSorting(String, String) - Method in interface org.apache.curator.framework.recipes.locks.LockInternalsSorter
- fixForSorting(String, String) - Method in class org.apache.curator.framework.recipes.locks.StandardLockInternalsDriver
- flushPuts(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
- flushPuts(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
- flushPuts(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
- flushPuts(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
-
Wait until any pending puts are committed
- flushPuts(long, TimeUnit) - Method in interface org.apache.curator.framework.recipes.queue.QueueBase
-
Wait until any pending puts are committed
- forAll(CuratorCacheListener) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
-
Add a standard listener
- forceSet(byte[]) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
-
Forcibly sets the value any guarantees of atomicity.
- forceSet(Integer) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
- forceSet(Long) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
- forceSet(T) - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
-
Forcibly sets the value of the counter without any guarantees of atomicity.
- forChanges(CuratorCacheListenerBuilder.ChangeListener) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
-
Add a listener only for
CuratorCacheListener.Type.NODE_CHANGED
- forCreates(Consumer<ChildData>) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
-
Add a listener only for
CuratorCacheListener.Type.NODE_CREATED
- forCreatesAndChanges(CuratorCacheListenerBuilder.ChangeListener) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
-
Add a listener only both
CuratorCacheListener.Type.NODE_CREATED
andCuratorCacheListener.Type.NODE_CHANGED
- forDeletes(Consumer<ChildData>) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
-
Add a listener only for
CuratorCacheListener.Type.NODE_DELETED
- forEach(Consumer<T>) - Method in class org.apache.curator.framework.listen.StandardListenerManager
- forEach(Consumer<V>) - Method in interface org.apache.curator.framework.listen.ListenerManager
-
Utility - apply the given function to each listener.
- forEach(Consumer<V>) - Method in class org.apache.curator.framework.listen.MappingListenerManager
- forEnsemble() - Method in interface org.apache.curator.framework.api.Ensembleable
- forEnsemble() - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- forEnsemble() - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- forEnsemble() - Method in interface org.apache.curator.x.async.api.AsyncEnsemblable
-
Commit the currently building operation and invoke ZooKeeper
- forInitialized(Runnable) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
-
Add a listener only for
CuratorCacheListener.initialized()
- forNodeCache(NodeCacheListener) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
-
Bridge listener.
- forOperations(List<CuratorOp>) - Method in interface org.apache.curator.framework.api.transaction.CuratorMultiTransactionMain
-
Commit the given operations as a single transaction.
- forOperations(List<CuratorOp>) - Method in class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- forOperations(List<CuratorOp>) - Method in interface org.apache.curator.x.async.api.AsyncMultiTransaction
-
Invoke ZooKeeper to commit the given operations as a single transaction.
- forOperations(CuratorOp...) - Method in interface org.apache.curator.framework.api.transaction.CuratorMultiTransactionMain
-
Commit the given operations as a single transaction.
- forOperations(CuratorOp...) - Method in class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- forPath(String) - Method in interface org.apache.curator.framework.api.Pathable
-
Commit the currently building operation using the given path
- forPath(String) - Method in interface org.apache.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[])
). - forPath(String) - Method in class org.apache.curator.framework.imps.AddWatchBuilderImpl
- forPath(String) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- forPath(String) - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- forPath(String) - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- forPath(String) - Method in class org.apache.curator.framework.imps.GetACLBuilderImpl
- forPath(String) - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- forPath(String) - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- forPath(String) - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- forPath(String) - Method in class org.apache.curator.framework.imps.SetACLBuilderImpl
- forPath(String) - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- forPath(String) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
- forPath(String) - Method in interface org.apache.curator.x.async.api.AsyncPathable
-
Commit the currently building operation using the given path and invoke ZooKeeper
- forPath(String, byte[]) - Method in interface org.apache.curator.framework.api.PathAndBytesable
-
Commit the currently building operation using the given path and data
- forPath(String, byte[]) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- forPath(String, byte[]) - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- forPath(String, byte[]) - Method in interface org.apache.curator.x.async.api.AsyncPathAndBytesable
-
Commit the currently building operation using the given path and data and invoke ZooKeeper
- forPathChildrenCache(String, CuratorFramework, PathChildrenCacheListener) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
-
Bridge listener.
- forSessionSleep() - Method in class org.apache.curator.test.compatibility.Timing2
-
Return a new timing with a multiple that ensures a ZK session timeout
- forSleepingABit() - Method in class org.apache.curator.test.compatibility.Timing2
-
Return a new timing with a multiple for sleeping a smaller amount of time
- forTreeCache(CuratorFramework, TreeCacheListener) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListenerBuilder
-
Bridge listener.
- forWaiting() - Method in class org.apache.curator.test.compatibility.Timing2
-
Return a new timing with the standard multiple for waiting on latches, etc.
- forWaiting() - Method in class org.apache.curator.test.Timing
-
Return a new timing with the standard multiple for waiting on latches, etc.
- framework - package framework
- from(String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath
-
Return a TypedZPath using
ZPath.parseWithIds(java.lang.String)
- from(String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath0
-
Return a TypedZPath using
ZPath.parseWithIds(java.lang.String)
- from(String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath10
-
Return a TypedZPath using
ZPath.parseWithIds(java.lang.String)
- from(String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath2
-
Return a TypedZPath using
ZPath.parseWithIds(java.lang.String)
- from(String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath3
-
Return a TypedZPath using
ZPath.parseWithIds(java.lang.String)
- from(String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath4
-
Return a TypedZPath using
ZPath.parseWithIds(java.lang.String)
- from(String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath5
-
Return a TypedZPath using
ZPath.parseWithIds(java.lang.String)
- from(String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath6
-
Return a TypedZPath using
ZPath.parseWithIds(java.lang.String)
- from(String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath7
-
Return a TypedZPath using
ZPath.parseWithIds(java.lang.String)
- from(String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath8
-
Return a TypedZPath using
ZPath.parseWithIds(java.lang.String)
- from(String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath9
-
Return a TypedZPath using
ZPath.parseWithIds(java.lang.String)
- from(String[]) - Static method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- from(String...) - Static method in interface org.apache.curator.x.async.modeled.ZPath
-
Convert individual path names into a ZPath.
- from(List<String>) - Static method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- from(List<String>) - Static method in interface org.apache.curator.x.async.modeled.ZPath
-
Convert individual path names into a ZPath.
- from(ModeledFrameworkBuilder<M>, ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework
-
Return a new TypedModeledFramework using the given modeled framework builder, model spec builder and a path with ids.
- from(ModeledFrameworkBuilder<M>, ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework0
-
Return a new TypedModeledFramework using the given modeled framework builder, model spec builder and a path with ids.
- from(ModeledFrameworkBuilder<M>, ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework10
-
Return a new TypedModeledFramework using the given modeled framework builder, model spec builder and a path with ids.
- from(ModeledFrameworkBuilder<M>, ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework2
-
Return a new TypedModeledFramework using the given modeled framework builder, model spec builder and a path with ids.
- from(ModeledFrameworkBuilder<M>, ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework3
-
Return a new TypedModeledFramework using the given modeled framework builder, model spec builder and a path with ids.
- from(ModeledFrameworkBuilder<M>, ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework4
-
Return a new TypedModeledFramework using the given modeled framework builder, model spec builder and a path with ids.
- from(ModeledFrameworkBuilder<M>, ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework5
-
Return a new TypedModeledFramework using the given modeled framework builder, model spec builder and a path with ids.
- from(ModeledFrameworkBuilder<M>, ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework6
-
Return a new TypedModeledFramework using the given modeled framework builder, model spec builder and a path with ids.
- from(ModeledFrameworkBuilder<M>, ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework7
-
Return a new TypedModeledFramework using the given modeled framework builder, model spec builder and a path with ids.
- from(ModeledFrameworkBuilder<M>, ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework8
-
Return a new TypedModeledFramework using the given modeled framework builder, model spec builder and a path with ids.
- from(ModeledFrameworkBuilder<M>, ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework9
-
Return a new TypedModeledFramework using the given modeled framework builder, model spec builder and a path with ids.
- from(ModeledFrameworkBuilder<M>, TypedModelSpec<M, P1>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework
-
Return a new TypedModeledFramework using the given modeled framework builder and typed model spec.
- from(ModeledFrameworkBuilder<M>, TypedModelSpec0<M>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework0
-
Return a new TypedModeledFramework using the given modeled framework builder and typed model spec.
- from(ModeledFrameworkBuilder<M>, TypedModelSpec10<M, P1, P2, P3, P4, P5, P6, P7, P8, P9, P10>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework10
-
Return a new TypedModeledFramework using the given modeled framework builder and typed model spec.
- from(ModeledFrameworkBuilder<M>, TypedModelSpec2<M, P1, P2>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework2
-
Return a new TypedModeledFramework using the given modeled framework builder and typed model spec.
- from(ModeledFrameworkBuilder<M>, TypedModelSpec3<M, P1, P2, P3>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework3
-
Return a new TypedModeledFramework using the given modeled framework builder and typed model spec.
- from(ModeledFrameworkBuilder<M>, TypedModelSpec4<M, P1, P2, P3, P4>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework4
-
Return a new TypedModeledFramework using the given modeled framework builder and typed model spec.
- from(ModeledFrameworkBuilder<M>, TypedModelSpec5<M, P1, P2, P3, P4, P5>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework5
-
Return a new TypedModeledFramework using the given modeled framework builder and typed model spec.
- from(ModeledFrameworkBuilder<M>, TypedModelSpec6<M, P1, P2, P3, P4, P5, P6>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework6
-
Return a new TypedModeledFramework using the given modeled framework builder and typed model spec.
- from(ModeledFrameworkBuilder<M>, TypedModelSpec7<M, P1, P2, P3, P4, P5, P6, P7>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework7
-
Return a new TypedModeledFramework using the given modeled framework builder and typed model spec.
- from(ModeledFrameworkBuilder<M>, TypedModelSpec8<M, P1, P2, P3, P4, P5, P6, P7, P8>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework8
-
Return a new TypedModeledFramework using the given modeled framework builder and typed model spec.
- from(ModeledFrameworkBuilder<M>, TypedModelSpec9<M, P1, P2, P3, P4, P5, P6, P7, P8, P9>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework9
-
Return a new TypedModeledFramework using the given modeled framework builder and typed model spec.
- from(ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec
-
Return a new TypedModelSpec using the given model spec builder and path.
- from(ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec0
-
Return a new TypedModelSpec using the given model spec builder and path.
- from(ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec10
-
Return a new TypedModelSpec using the given model spec builder and path.
- from(ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec2
-
Return a new TypedModelSpec using the given model spec builder and path.
- from(ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec3
-
Return a new TypedModelSpec using the given model spec builder and path.
- from(ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec4
-
Return a new TypedModelSpec using the given model spec builder and path.
- from(ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec5
-
Return a new TypedModelSpec using the given model spec builder and path.
- from(ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec6
-
Return a new TypedModelSpec using the given model spec builder and path.
- from(ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec7
-
Return a new TypedModelSpec using the given model spec builder and path.
- from(ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec8
-
Return a new TypedModelSpec using the given model spec builder and path.
- from(ModelSpecBuilder<M>, String) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec9
-
Return a new TypedModelSpec using the given model spec builder and path.
- from(ModelSpecBuilder<M>, TypedZPath<P1>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec
-
Return a new TypedModelSpec using the given model spec builder and typed path.
- from(ModelSpecBuilder<M>, TypedZPath0) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec0
-
Return a new TypedModelSpec using the given model spec builder and typed path.
- from(ModelSpecBuilder<M>, TypedZPath10<P1, P2, P3, P4, P5, P6, P7, P8, P9, P10>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec10
-
Return a new TypedModelSpec using the given model spec builder and typed path.
- from(ModelSpecBuilder<M>, TypedZPath2<P1, P2>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec2
-
Return a new TypedModelSpec using the given model spec builder and typed path.
- from(ModelSpecBuilder<M>, TypedZPath3<P1, P2, P3>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec3
-
Return a new TypedModelSpec using the given model spec builder and typed path.
- from(ModelSpecBuilder<M>, TypedZPath4<P1, P2, P3, P4>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec4
-
Return a new TypedModelSpec using the given model spec builder and typed path.
- from(ModelSpecBuilder<M>, TypedZPath5<P1, P2, P3, P4, P5>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec5
-
Return a new TypedModelSpec using the given model spec builder and typed path.
- from(ModelSpecBuilder<M>, TypedZPath6<P1, P2, P3, P4, P5, P6>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec6
-
Return a new TypedModelSpec using the given model spec builder and typed path.
- from(ModelSpecBuilder<M>, TypedZPath7<P1, P2, P3, P4, P5, P6, P7>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec7
-
Return a new TypedModelSpec using the given model spec builder and typed path.
- from(ModelSpecBuilder<M>, TypedZPath8<P1, P2, P3, P4, P5, P6, P7, P8>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec8
-
Return a new TypedModelSpec using the given model spec builder and typed path.
- from(ModelSpecBuilder<M>, TypedZPath9<P1, P2, P3, P4, P5, P6, P7, P8, P9>) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec9
-
Return a new TypedModelSpec using the given model spec builder and typed path.
- from(ZPath) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath
-
Return a TypedZPath
- from(ZPath) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath0
-
Return a TypedZPath
- from(ZPath) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath10
-
Return a TypedZPath
- from(ZPath) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath2
-
Return a TypedZPath
- from(ZPath) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath3
-
Return a TypedZPath
- from(ZPath) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath4
-
Return a TypedZPath
- from(ZPath) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath5
-
Return a TypedZPath
- from(ZPath) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath6
-
Return a TypedZPath
- from(ZPath) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath7
-
Return a TypedZPath
- from(ZPath) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath8
-
Return a TypedZPath
- from(ZPath) - Static method in interface org.apache.curator.x.async.modeled.typed.TypedZPath9
-
Return a TypedZPath
- from(ZPath, String[]) - Static method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- from(ZPath, String...) - Static method in interface org.apache.curator.x.async.modeled.ZPath
-
Convert individual path names into a ZPath starting at the given base.
- from(ZPath, List<String>) - Static method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- from(ZPath, List<String>) - Static method in interface org.apache.curator.x.async.modeled.ZPath
-
Convert individual path names into a ZPath starting at the given base.
- from(T, int) - Static method in interface org.apache.curator.x.async.modeled.versioned.Versioned
-
Return a new Versioned wrapper for the given model and version
- fromConfig(long) - Method in interface org.apache.curator.framework.api.AsyncReconfigurable
-
Sets the configuration version to use.
- fromConfig(long) - Method in interface org.apache.curator.framework.api.ConfigureEnsembleable
-
Sets the configuration version to use.
- fullPath() - Method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- fullPath() - Method in interface org.apache.curator.x.async.modeled.ZPath
-
The string full path that this ZPath represents
G
- GenericDiscoveryContext<T> - Class in org.apache.curator.x.discovery.server.contexts
-
For convenience, a version of
DiscoveryContext
that uses any generic type as the payload - GenericDiscoveryContext(ServiceDiscovery<T>, ProviderStrategy<T>, int, TypeToken<T>) - Constructor for class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
- GenericDiscoveryContext(ServiceDiscovery<T>, ProviderStrategy<T>, int, Class<T>) - Constructor for class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
- get() - Method in interface org.apache.curator.framework.api.transaction.CuratorOp
- get() - Method in class org.apache.curator.framework.imps.ExtractingCuratorOp
- get() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
- get() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
- get() - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
-
Returns the current value of the counter.
- get() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
-
Returns the current value of the counter.
- get() - Method in class org.apache.curator.utils.CloseableExecutorService.InternalScheduledFutureTask
- get(long, TimeUnit) - Method in class org.apache.curator.utils.CloseableExecutorService.InternalScheduledFutureTask
- get(String) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCache
-
Return an entry from storage
- get(String) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheAccessor
-
Return an entry from storage
- get(String) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
-
Return an entry from storage
- get(String, String) - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
- GET_ACL - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.getACL()
- GET_CONFIG - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.getConfig()
- GET_DATA - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.getData()
- getAcl() - Method in class org.apache.curator.framework.schema.SchemaViolation.ViolatorData
-
The ACLs used in the API or
null
- getACL() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a get ACL builder
- getACL() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getACL() - Method in interface org.apache.curator.x.async.api.AsyncCuratorFrameworkDsl
-
Start a get ACL builder
- getACL() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- GetACLBuilder - Interface in org.apache.curator.framework.api
- GetACLBuilderImpl - Class in org.apache.curator.framework.imps
- GetACLBuilderImpl(CuratorFrameworkImpl, Backgrounding, Stat) - Constructor for class org.apache.curator.framework.imps.GetACLBuilderImpl
- getAclForPath(String) - Method in interface org.apache.curator.framework.api.ACLProvider
-
Return the ACL list to use for the given path
- getAclForPath(String) - Method in class org.apache.curator.framework.imps.DefaultACLProvider
- getAclForPath(String) - Method in interface org.apache.curator.utils.InternalACLProvider
-
Return the ACL list to use for the given path
- getACLList() - Method in interface org.apache.curator.framework.api.CuratorEvent
- getAclProvider() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getActualPath() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
-
Returns the currently set path or null if the node does not exist
- getAddress() - Method in class org.apache.curator.x.discovery.ServiceInstance
- getAge() - Method in class modeled.PersonModel
- getAll(String) - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
- getAllInstances() - Method in class org.apache.curator.x.discovery.details.ServiceProviderImpl
-
Return the current available set of instances IMPORTANT: users should not hold on to the instance returned.
- getAllInstances() - Method in interface org.apache.curator.x.discovery.ServiceProvider
-
Return the current available set of instances IMPORTANT: users should not hold on to the instance returned.
- getAllLocalIPs() - Static method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
based on http://pastebin.com/5X073pUc
- getAllNames() - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
- getAny(String) - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
- getAuth() - Method in class org.apache.curator.framework.AuthInfo
- getAuthInfos() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getAuthScheme() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Deprecated.
- getAuthValue() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Deprecated.
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.AddWatchBuilderImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.GetACLBuilderImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.SetACLBuilderImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- getBackgroundEventType() - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
- getBasePath() - Method in class org.apache.curator.x.discovery.details.DiscoveryPathConstructorImpl
- getBasePath() - Method in interface org.apache.curator.x.discovery.DiscoveryPathConstructor
-
Return the parent path where all service names registered.
- getBaseSleepTimeMs() - Method in class org.apache.curator.retry.ExponentialBackoffRetry
- getChildren() - Method in interface org.apache.curator.framework.api.CuratorEvent
- getChildren() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a get children builder
- getChildren() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getChildren() - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
- getChildren() - Method in interface org.apache.curator.x.async.api.WatchableAsyncCuratorFramework
-
Start a get children builder
- getChildren() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- GetChildrenBuilder - Interface in org.apache.curator.framework.api
- GetChildrenBuilderImpl - Class in org.apache.curator.framework.imps
- GetChildrenBuilderImpl(CuratorFrameworkImpl, Watcher, Backgrounding, Stat) - Constructor for class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- getChildrenForEntering() - Method in class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
- getChildWatches(ZooKeeper) - Static method in class org.apache.curator.test.WatchersDebug
- getClient() - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- getClient() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
Deprecated.
- getClientPort() - Method in class org.apache.curator.test.TestingZooKeeperMain
- getClientPort() - Method in class org.apache.curator.test.ZooKeeperServerEmbeddedAdapter
- getCode() - Method in interface org.apache.curator.x.async.AsyncResult
-
Return the ZooKeeper result code.
- getCode() - Method in class org.apache.curator.x.async.details.AsyncResultImpl
- getCompressionProvider() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getConfig() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a getConfig builder
- getConfig() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getConfig() - Method in interface org.apache.curator.x.async.api.WatchableAsyncCuratorFramework
-
Start a getConfig builder
- getConfig() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- GetConfigBuilder - Interface in org.apache.curator.framework.api
- GetConfigBuilderImpl - Class in org.apache.curator.framework.imps
- GetConfigBuilderImpl(CuratorFrameworkImpl) - Constructor for class org.apache.curator.framework.imps.GetConfigBuilderImpl
- GetConfigBuilderImpl(CuratorFrameworkImpl, Backgrounding, Watcher, Stat) - Constructor for class org.apache.curator.framework.imps.GetConfigBuilderImpl
- getConnectionStateErrorPolicy() - Method in interface org.apache.curator.framework.CuratorFramework
-
Return the configured error policy
- getConnectionStateErrorPolicy() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getConnectionStateErrorPolicy() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getConnectionStateListenable() - Method in interface org.apache.curator.framework.CuratorFramework
-
Returns the listenable interface for the Connect State
- getConnectionStateListenable() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getConnectionStateListenerManagerFactory() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getConnectionString() - Method in interface org.apache.curator.ensemble.EnsembleProvider
-
Return the current connection string to use.
- getConnectionString() - Method in class org.apache.curator.ensemble.fixed.FixedEnsembleProvider
- getConnectionTimeoutMs() - Method in class org.apache.curator.CuratorZookeeperClient
-
Return the configured connection timeout
- getConnectionTimeoutMs() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getConnectString() - Method in class org.apache.curator.test.InstanceSpec
-
Deprecated.
- getConnectString() - Method in class org.apache.curator.test.TestingCluster
-
Returns the connection string to pass to the ZooKeeper constructor
- getConnectString() - Method in class org.apache.curator.test.TestingServer
-
Returns the connection string to use
- getContainerCreateMode() - Static method in class org.apache.curator.utils.ZKPaths
- getContainerType() - Method in class modeled.PersonModel
- getContext() - Method in interface org.apache.curator.framework.api.CuratorEvent
- getContext(Class<?>) - Method in class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
- getContext(Class<?>) - Method in class org.apache.curator.x.discovery.server.contexts.IntegerDiscoveryContext
- getContext(Class<?>) - Method in class org.apache.curator.x.discovery.server.contexts.StringDiscoveryContext
- getCount() - Method in class org.apache.curator.framework.recipes.shared.SharedCount
- getCount() - Method in interface org.apache.curator.framework.recipes.shared.SharedCountReader
-
Return the current value of the count
- getCreateMode(boolean) - Method in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
-
Deprecated.
- getCuratorListenable() - Method in interface org.apache.curator.framework.CuratorFramework
-
Returns the listenable interface for events
- getCuratorListenable() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getCurrentChildren(String) - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
Deprecated.Return the current set of children at the given path, mapped by child name.
- getCurrentConfig() - Method in interface org.apache.curator.framework.CuratorFramework
-
Current maintains a cached view of the Zookeeper quorum config.
- getCurrentConfig() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getCurrentConfig() - Method in class org.apache.curator.framework.imps.EnsembleTracker
-
Return the current quorum config
- getCurrentConnectionString() - Method in class org.apache.curator.CuratorZookeeperClient
-
Returns the current known connection string - not guaranteed to be correct value at any point in the future.
- getCurrentData() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
Deprecated.Return the current data.
- getCurrentData() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.Return the current data.
- getCurrentData(String) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.Return the current data for the given path.
- getCurrentData(String) - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
Deprecated.Return the current data for the given path.
- getCurrentMembers() - Method in class org.apache.curator.framework.recipes.nodes.GroupMember
-
Return the current view of membership.
- getCustomProperties() - Method in class org.apache.curator.test.InstanceSpec
- getData() - Method in interface org.apache.curator.framework.api.CuratorEvent
- getData() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a get data builder
- getData() - Method in interface org.apache.curator.framework.CuratorTempFramework
-
Start a get data builder
- getData() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getData() - Method in class org.apache.curator.framework.imps.CuratorTempFrameworkImpl
- getData() - Method in class org.apache.curator.framework.recipes.cache.ChildData
-
Returns the node data for this child when the cache mode is set to cache data.
- getData() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent
- getData() - Method in class org.apache.curator.framework.recipes.cache.TreeCacheEvent
- getData() - Method in interface org.apache.curator.framework.recipes.locks.Lease
-
Return the data stored in the node for this lease
- getData() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
-
Return the current value of our data
- getData() - Method in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
-
Return the current value of our data
- getData() - Method in class org.apache.curator.framework.schema.SchemaViolation.ViolatorData
-
The data used in the API or
null
- getData() - Method in interface org.apache.curator.x.async.api.WatchableAsyncCuratorFramework
-
Start a get data builder
- getData() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- GetDataBuilder - Interface in org.apache.curator.framework.api
- GetDataBuilderImpl - Class in org.apache.curator.framework.imps
- GetDataBuilderImpl(CuratorFrameworkImpl, Stat, Watcher, Backgrounding, boolean) - Constructor for class org.apache.curator.framework.imps.GetDataBuilderImpl
- getDataDirectory() - Method in class org.apache.curator.test.InstanceSpec
- GetDataWatchBackgroundStatable - Interface in org.apache.curator.framework.api
- getDataWatches(ZooKeeper) - Static method in class org.apache.curator.test.WatchersDebug
- getDefaultAcl() - Method in interface org.apache.curator.framework.api.ACLProvider
-
Return the ACL list to use by default (usually
ZooDefs.Ids.OPEN_ACL_UNSAFE
). - getDefaultAcl() - Method in class org.apache.curator.framework.imps.DefaultACLProvider
- getDefaultAcl() - Method in interface org.apache.curator.utils.InternalACLProvider
-
Return the ACL list to use by default (usually
ZooDefs.Ids.OPEN_ACL_UNSAFE
). - getDefaultData() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getDefaultRetrySleeper() - Static method in class org.apache.curator.RetryLoop
-
Returns the default retry sleeper
- getDefaultSchemaSet() - Static method in class org.apache.curator.framework.schema.SchemaSet
-
Return the default (empty) schema set
- getDelay(String) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
- getDeprecated(String, String) - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
-
Deprecated.
- getDescription() - Method in class discovery.InstanceDetails
- getDocumentation() - Method in class org.apache.curator.framework.schema.Schema
- getElectionPort() - Method in class org.apache.curator.test.InstanceSpec
- getEnsembleProvider() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getEphemeral() - Method in class org.apache.curator.framework.schema.Schema
- getError() - Method in class org.apache.curator.framework.api.transaction.CuratorTransactionResult
-
Returns the operation generated error or
0
i.e. - getErrorThreshold() - Method in class org.apache.curator.x.discovery.DownInstancePolicy
- getException() - Method in interface org.apache.curator.x.async.AsyncResult
-
An optional wrapper around any general exception
- getException() - Method in class org.apache.curator.x.async.details.AsyncResultImpl
- getExistWatches(ZooKeeper) - Static method in class org.apache.curator.test.WatchersDebug
- getFirstName() - Method in class modeled.PersonModel
- getFirstProcessor() - Method in class org.apache.curator.test.TestingZooKeeperMain.TestZooKeeperServer
- getForPath() - Method in class org.apache.curator.framework.api.transaction.CuratorTransactionResult
-
Returns the path that was passed to the operation when added
- getForPath() - Method in class org.apache.curator.framework.api.transaction.TypeAndPath
- getFuture(CompletableFuture<T>) - Method in class org.apache.curator.test.compatibility.Timing2
- getGroupName() - Method in class pubsub.models.Group
- getHostname() - Method in class org.apache.curator.test.InstanceSpec
- getHostname() - Method in class pubsub.models.Instance
- getHostString(QuorumPeer.QuorumServer) - Static method in class org.apache.curator.utils.Compatibility
- getId() - Method in class modeled.PersonId
- getId() - Method in class modeled.PersonModel
- getId() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Return this instance's participant Id
- getId() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
Return the ID that was set via
LeaderSelector.setId(String)
- getId() - Method in class org.apache.curator.framework.recipes.leader.Participant
-
Returns the ID set via
LeaderSelector.setId(String)
- getId() - Method in class org.apache.curator.x.discovery.ServiceInstance
- getId() - Method in class pubsub.models.Instance
- getId() - Method in class pubsub.models.Message
- getInitialData() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent
-
Special purpose method.
- getInstance() - Method in class org.apache.curator.x.discovery.details.ServiceProviderImpl
-
Return an instance for a single use.
- getInstance() - Method in interface org.apache.curator.x.discovery.ServiceProvider
-
Return an instance for a single use.
- getInstance(InstanceProvider<T>) - Method in interface org.apache.curator.x.discovery.ProviderStrategy
-
Given a source of instances, return one of them for a single use.
- getInstance(InstanceProvider<T>) - Method in class org.apache.curator.x.discovery.strategies.RandomStrategy
- getInstance(InstanceProvider<T>) - Method in class org.apache.curator.x.discovery.strategies.RoundRobinStrategy
- getInstance(InstanceProvider<T>) - Method in class org.apache.curator.x.discovery.strategies.StickyStrategy
- getInstanceIndex() - Method in class org.apache.curator.CuratorZookeeperClient
-
Every time a new
ZooKeeper
instance is allocated, the "instance index" is incremented. - getInstanceNumber() - Method in class org.apache.curator.x.discovery.strategies.StickyStrategy
-
Each time a new instance is picked, an internal counter is incremented.
- getInstanceRefreshMs() - Method in class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
- getInstanceRefreshMs() - Method in class org.apache.curator.x.discovery.server.contexts.IntegerDiscoveryContext
- getInstanceRefreshMs() - Method in class org.apache.curator.x.discovery.server.contexts.StringDiscoveryContext
- getInstanceRefreshMs() - Method in interface org.apache.curator.x.discovery.server.rest.DiscoveryContext
-
Return the threshold in milliseconds to consider a registration stale
- getInstances() - Method in class org.apache.curator.test.TestingCluster
-
Returns the set of servers in the ensemble
- getInstances() - Method in interface org.apache.curator.x.discovery.details.InstanceProvider
-
Return the current available set of instances
- getInstances() - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
- getInstances() - Method in interface org.apache.curator.x.discovery.ServiceCache
-
Return the current list of instances.
- getInstanceSpec() - Method in class org.apache.curator.test.QuorumPeerConfigBuilder
- getInstanceSpec() - Method in class org.apache.curator.test.TestingZooKeeperServer
- getInstanceSpec(int) - Method in class org.apache.curator.test.QuorumConfigBuilder
- getInstanceSpecs() - Method in class org.apache.curator.test.QuorumConfigBuilder
- getInstanceSpecs() - Method in class org.apache.curator.test.TestingZooKeeperServer
- getItems() - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
-
Return any currently queued items without removing them from the queue
- getKeeperState() - Method in exception class org.apache.curator.x.async.AsyncEventException
-
Returns the error condition that temporarily triggered the watcher.
- getLastMessageCount() - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
-
Return the most recent message count from the queue.
- getLastMessageCount() - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
- getLastMessageCount() - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
-
Return the most recent message count from the queue.
- getLastMessageCount() - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
-
Return the most recent message count from the queue.
- getLastMessageCount() - Method in interface org.apache.curator.framework.recipes.queue.QueueBase
-
Return the most recent message count from the queue.
- getLastName() - Method in class modeled.PersonModel
- getLastNegotiatedSessionTimeoutMs() - Method in class org.apache.curator.CuratorZookeeperClient
-
Return the most recent value of
ZooKeeper.getSessionTimeout()
or 0 - getLastPathIsLeader() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Return last of this instance's lock node path that was leader ever.
- getLatencyMs() - Method in class org.apache.curator.drivers.OperationTrace
- getLeader() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Return the id for the current leader.
- getLeader() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
Return the id for the current leader.
- getListenable() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
Deprecated.Return the cache listenable
- getListenable() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.Return the cache listenable
- getListenable() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
Deprecated.Return the cache listenable
- getListenable() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
-
Returns the listenable
- getListenable() - Method in class org.apache.curator.framework.recipes.shared.SharedValue
-
Returns the listenable
- getListenable() - Method in interface org.apache.curator.framework.recipes.shared.SharedValueReader
-
Returns the listenable
- getListenable() - Method in class org.apache.curator.framework.recipes.watch.PersistentWatcher
-
Container for setting listeners
- getListenable() - Method in class org.apache.curator.framework.state.ConnectionStateManager
-
Return the listenable
- getListener() - Method in class org.apache.curator.x.async.details.Filters
- getLocalAddress() - Static method in class org.apache.curator.framework.CuratorFrameworkFactory
-
Return the local address as bytes that can be used as a node payload
- getLocalIpFilter() - Static method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
Return the current local ip filter used by
ServiceInstanceBuilder.getAllLocalIPs()
- getLocalPort() - Method in class org.apache.curator.test.TestingZooKeeperServer
- getLockNodeBytes() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
- getLockNodeBytes() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock.ReadLock
- getLockNodeBytes() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock.WriteLock
- getLockPath() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
- getLockPath() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock.ReadLock
- getLockPath() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock.WriteLock
- getMaxClientCnxns() - Method in class org.apache.curator.test.InstanceSpec
- getMaxCloseWaitMs() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getMaxSleepTimeMs() - Method in class org.apache.curator.retry.BoundedExponentialBackoffRetry
- getMessage() - Method in exception class org.apache.curator.framework.recipes.shared.IllegalTrySetVersionException
- getMetadata() - Method in class org.apache.curator.framework.schema.Schema
- getMigrationId() - Method in exception class org.apache.curator.x.async.migrations.MigrationException
- getN() - Method in class org.apache.curator.retry.BoundedExponentialBackoffRetry
- getN() - Method in class org.apache.curator.retry.ExponentialBackoffRetry
- getN() - Method in class org.apache.curator.retry.RetryNTimes
- getN() - Method in class org.apache.curator.retry.RetryOneTime
- getN() - Method in class org.apache.curator.retry.RetryUntilElapsed
- getName() - Method in class org.apache.curator.drivers.EventTrace
- getName() - Method in class org.apache.curator.drivers.OperationTrace
- getName() - Method in interface org.apache.curator.framework.api.CuratorEvent
- getName() - Method in class org.apache.curator.framework.schema.Schema
- getName() - Method in class org.apache.curator.x.discovery.ServiceInstance
- getName() - Method in class pubsub.messages.UserCreated
- getNamedPath(CuratorFramework, String) - Static method in class org.apache.curator.framework.schema.SchemaSet
-
Utility to return a ZNode path for the given name
- getNamedSchema(String) - Method in class org.apache.curator.framework.schema.SchemaSet
-
Return the schema with the given key/name
- getNames() - Method in class org.apache.curator.x.discovery.server.entity.ServiceNames
- getNamespace() - Method in interface org.apache.curator.framework.CuratorFramework
-
Return the current namespace or "" if none
- getNamespace() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getNamespace() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getNode() - Method in class org.apache.curator.utils.ZKPaths.PathAndNode
- getNodeFromPath(String) - Static method in class org.apache.curator.utils.ZKPaths
-
Given a full path, return the node name.
- getNodeName() - Method in interface org.apache.curator.framework.recipes.locks.Lease
-
Return the the node for this lease
- getOldData() - Method in class org.apache.curator.framework.recipes.cache.TreeCacheEvent
- getOpResults() - Method in interface org.apache.curator.framework.api.CuratorEvent
- getOptimisticTimeMs() - Method in class org.apache.curator.framework.recipes.atomic.AtomicStats
-
Returns the time spent trying the operation with optimistic locks
- getOptimisticTries() - Method in class org.apache.curator.framework.recipes.atomic.AtomicStats
-
Returns the number of optimistic locks used to perform the operation
- getOurPath() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Return this instance's lock node path.
- getParticipantNodes() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
-
Return a sorted list of all current nodes participating in the lock
- getParticipantNodes() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock.ReadLock
- getParticipantNodes() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock.WriteLock
- getParticipantNodes() - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
-
Return a list of all current nodes participating in the semaphore
- getParticipantNodes(CuratorFramework, String, String, LockInternalsSorter) - Static method in class org.apache.curator.framework.recipes.locks.LockInternals
- getParticipants() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Returns the set of current participants in the leader selection
- getParticipants() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
Returns the set of current participants in the leader selection
- getParts() - Method in class org.apache.curator.x.discovery.UriSpec
- getPath() - Method in class org.apache.curator.drivers.OperationTrace
- getPath() - Method in interface org.apache.curator.framework.api.CuratorEvent
- getPath() - Method in class org.apache.curator.framework.recipes.cache.ChildData
-
Returns the full path of the this child
- getPath() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
Deprecated.Return the path this cache is watching
- getPath() - Method in class org.apache.curator.framework.schema.Schema
- getPath() - Method in class org.apache.curator.framework.schema.SchemaViolation.ViolatorData
-
The path used in the API or
null
- getPath() - Method in class org.apache.curator.utils.EnsurePath
-
Deprecated.Returns the path being Ensured
- getPath() - Method in class org.apache.curator.utils.ZKPaths.PathAndNode
- getPathAndNode(String) - Static method in class org.apache.curator.utils.ZKPaths
-
Given a full path, return the node name and its path.
- getPathForInstances(String) - Method in class org.apache.curator.x.discovery.details.DiscoveryPathConstructorImpl
- getPathForInstances(String) - Method in interface org.apache.curator.x.discovery.DiscoveryPathConstructor
-
Return the parent path where all instances of the service registered.
- getPathRegex() - Method in class org.apache.curator.framework.schema.Schema
- getPathToWatch() - Method in class org.apache.curator.framework.recipes.locks.PredicateResults
- getPayload() - Method in class org.apache.curator.x.discovery.ServiceInstance
- getPort() - Method in class org.apache.curator.test.InstanceSpec
- getPort() - Method in class org.apache.curator.test.TestingServer
-
Return the port being used or will be used.
- getPort() - Method in class org.apache.curator.x.discovery.ServiceInstance
- getPort() - Method in class pubsub.models.Instance
- getPosition() - Method in class pubsub.messages.UserCreated
- getPriority() - Method in class pubsub.models.Message
- getProcessName(Class<?>) - Static method in class org.apache.curator.utils.ThreadUtils
- getPromotedLockTries() - Method in class org.apache.curator.framework.recipes.atomic.AtomicStats
-
Returns the number of mutex locks used to perform the operation
- getPromotedTimeMs() - Method in class org.apache.curator.framework.recipes.atomic.AtomicStats
-
Returns the time spent trying the operation with mutex locks
- getProtectedPrefix(String) - Static method in class org.apache.curator.framework.imps.ProtectedUtils
-
Provides a prefix to be prepended to a ZNode name when protected.
- getProviderStrategy() - Method in class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
- getProviderStrategy() - Method in class org.apache.curator.x.discovery.server.contexts.IntegerDiscoveryContext
- getProviderStrategy() - Method in class org.apache.curator.x.discovery.server.contexts.StringDiscoveryContext
- getProviderStrategy() - Method in interface org.apache.curator.x.discovery.server.rest.DiscoveryContext
-
Return the provider strategy to use for
DiscoveryResource.getAny(String)
- getPutListenerContainer() - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
-
Return the manager for put listeners
- getPutListenerContainer() - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
- getPutListenerContainer() - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
-
Return the manager for put listeners
- getPutListenerContainer() - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
-
Return the manager for put listeners
- getPutListenerContainer() - Method in interface org.apache.curator.framework.recipes.queue.QueueBase
-
Return the manager for put listeners
- getQueue() - Method in class org.apache.curator.framework.recipes.queue.QueueSharder
-
Return one of the managed queues - the selection method cannot be relied on.
- getQueuePaths() - Method in class org.apache.curator.framework.recipes.queue.QueueSharder
-
Return the current set of shard paths
- getQuorumPort() - Method in class org.apache.curator.test.InstanceSpec
- getRandomPort() - Static method in class org.apache.curator.test.InstanceSpec
- getRawException() - Method in interface org.apache.curator.x.async.AsyncResult
-
Return any general exception or
null
- getRawException() - Method in class org.apache.curator.x.async.details.AsyncResultImpl
- getRawPath() - Method in class org.apache.curator.framework.schema.Schema
-
Return the raw path for this schema.
- getRawValue() - Method in interface org.apache.curator.x.async.AsyncResult
-
Returns the raw result of the ZooKeeper method or
null
- getRawValue() - Method in class org.apache.curator.x.async.details.AsyncResultImpl
- getRegistrationTimeUTC() - Method in class org.apache.curator.x.discovery.ServiceInstance
- getRequestBytesLength() - Method in class org.apache.curator.drivers.OperationTrace
- getResetListenable() - Method in class org.apache.curator.framework.recipes.watch.PersistentWatcher
-
Listeners are called when the persistent watcher has been successfully registered or re-registered after a connection disruption
- getResponseBytesLength() - Method in class org.apache.curator.drivers.OperationTrace
- getResultCode() - Method in interface org.apache.curator.framework.api.CuratorEvent
- getResultFilter() - Method in class org.apache.curator.x.async.details.Filters
- getResultPath() - Method in class org.apache.curator.framework.api.transaction.CuratorTransactionResult
-
Returns the operation generated path or
null
. - getResultStat() - Method in class org.apache.curator.framework.api.transaction.CuratorTransactionResult
-
Returns the operation generated stat or
null
. - getRetryLoop(Supplier<RetryLoop>) - Method in class org.apache.curator.connection.ThreadLocalRetryLoop
-
Call to get the current retry loop.
- getRetryPolicy() - Method in class org.apache.curator.CuratorZookeeperClient
-
Return the current retry policy
- getRetryPolicy() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getReturnCode() - Method in class org.apache.curator.drivers.OperationTrace
- getRunSafeService() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getSchema() - Method in exception class org.apache.curator.framework.schema.SchemaViolation
- getSchema(String) - Method in class org.apache.curator.framework.schema.SchemaSet
-
Find the first matching schema for the path and return it
- getSchemas() - Method in class org.apache.curator.framework.schema.SchemaSet
-
Return the schemas
- getSchemas() - Method in class org.apache.curator.framework.schema.SchemaSetLoader
- getSchemaSet() - Method in interface org.apache.curator.framework.CuratorFramework
-
Return this instance's schema set
- getSchemaSet() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getSchemaSet() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getSchemaValidator() - Method in class org.apache.curator.framework.schema.Schema
- getSchemaValidator(String) - Method in interface org.apache.curator.framework.schema.SchemaSetLoader.SchemaValidatorMapper
- getScheme() - Method in class org.apache.curator.framework.AuthInfo
- getSequential() - Method in class org.apache.curator.framework.schema.Schema
- getServerCnxnFactory() - Method in class org.apache.curator.test.ZooKeeperServerEmbeddedAdapter
- getServerId() - Method in class org.apache.curator.test.InstanceSpec
- getServers() - Method in class org.apache.curator.test.TestingCluster
- getServiceDiscovery() - Method in class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
- getServiceDiscovery() - Method in class org.apache.curator.x.discovery.server.contexts.IntegerDiscoveryContext
- getServiceDiscovery() - Method in class org.apache.curator.x.discovery.server.contexts.StringDiscoveryContext
- getServiceDiscovery() - Method in interface org.apache.curator.x.discovery.server.rest.DiscoveryContext
-
Return the service singleton
- getServices() - Method in class org.apache.curator.x.discovery.server.entity.ServiceInstances
- getServiceType() - Method in class org.apache.curator.x.discovery.ServiceInstance
- getSessionId() - Method in class org.apache.curator.drivers.EventTrace
- getSessionId() - Method in class org.apache.curator.drivers.OperationTrace
- getSessionTimeoutMs() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getShardQty() - Method in class org.apache.curator.framework.recipes.queue.QueueSharder
-
Return the current number of mananged queues
- getSimulatedSessionExpirationPercent() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getSize(ServiceInstances<T>, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
- getSize(ServiceNames, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
- getSize(ServiceInstance<T>, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
- getSleepTimeMs(int, long) - Method in class org.apache.curator.retry.BoundedExponentialBackoffRetry
- getSleepTimeMs(int, long) - Method in class org.apache.curator.retry.ExponentialBackoffRetry
- getSleepTimeMs(int, long) - Method in class org.apache.curator.retry.RetryNTimes
- getSleepTimeMs(int, long) - Method in class org.apache.curator.retry.RetryUntilElapsed
- getSortedChildren(String, LockInternalsSorter, List<String>) - Static method in class org.apache.curator.framework.recipes.locks.LockInternals
- getSortedChildren(CuratorFramework, String, String, LockInternalsSorter) - Static method in class org.apache.curator.framework.recipes.locks.LockInternals
- getSortedChildren(ZooKeeper, String) - Static method in class org.apache.curator.utils.ZKPaths
-
Return the children of the given path sorted by sequence number
- getSortingSequence() - Method in class org.apache.curator.framework.recipes.locks.StandardLockInternalsDriver
- getSslPort() - Method in class org.apache.curator.x.discovery.ServiceInstance
- getStat() - Method in class org.apache.curator.drivers.OperationTrace
- getStat() - Method in interface org.apache.curator.framework.api.CuratorEvent
- getStat() - Method in class org.apache.curator.framework.recipes.cache.ChildData
-
Returns the stat data for this child
- getState() - Method in interface org.apache.curator.framework.CuratorFramework
-
Returns the state of this instance
- getState() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getState() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Returns this instances current state, this is the only way to verify that the object has been closed before closing again.
- getStats() - Method in interface org.apache.curator.framework.recipes.atomic.AtomicValue
-
Returns debugging stats about the operation
- getsTheLock() - Method in class org.apache.curator.framework.recipes.locks.PredicateResults
- getsTheLock(CuratorFramework, List<String>, String, int) - Method in interface org.apache.curator.framework.recipes.locks.LockInternalsDriver
- getsTheLock(CuratorFramework, List<String>, String, int) - Method in class org.apache.curator.framework.recipes.locks.StandardLockInternalsDriver
- getTempDirectory() - Method in class org.apache.curator.test.TestingServer
-
Returns the temp directory being used
- getThisInstance() - Method in class discovery.ExampleServer
- getThreadFactory() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getTickTime() - Method in class org.apache.curator.test.InstanceSpec
- getTimeoutMs() - Method in class org.apache.curator.x.discovery.DownInstancePolicy
- getTracerDriver() - Method in class org.apache.curator.CuratorZookeeperClient
-
Return the current tracing driver
- getType() - Method in interface org.apache.curator.framework.api.CuratorEvent
-
check here first - this value determines the type of event and which methods will have valid values
- getType() - Method in class org.apache.curator.framework.api.transaction.CuratorTransactionResult
-
Returns the operation type
- getType() - Method in class org.apache.curator.framework.api.transaction.TypeAndPath
- getType() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent
- getType() - Method in class org.apache.curator.framework.recipes.cache.TreeCacheEvent
- getType() - Method in class pubsub.models.Instance
- getTypeAndPath() - Method in interface org.apache.curator.framework.api.transaction.CuratorOp
- getTypeAndPath() - Method in class org.apache.curator.framework.imps.ExtractingCuratorOp
- getTypeId() - Method in class modeled.ContainerType
- getUnhandledErrorListenable() - Method in interface org.apache.curator.framework.CuratorFramework
-
Returns the listenable interface for unhandled errors
- getUnhandledErrorListenable() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getUnhandledErrorListenable() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
Deprecated.Allows catching unhandled errors in asynchronous operations.
- getUriSpec() - Method in class org.apache.curator.x.discovery.ServiceInstance
- getValue() - Method in class org.apache.curator.framework.recipes.shared.SharedValue
- getValue() - Method in interface org.apache.curator.framework.recipes.shared.SharedValueReader
-
Return the current value of the count
- getValue() - Method in class org.apache.curator.framework.recipes.shared.VersionedValue
- getValue() - Method in interface org.apache.curator.x.async.AsyncResult
-
An optional wrapper around the ZooKeeper method result
- getValue() - Method in class org.apache.curator.x.async.details.AsyncResultImpl
- getValue() - Method in class org.apache.curator.x.discovery.UriSpec.Part
- getVersion() - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- getVersion() - Method in class org.apache.curator.framework.recipes.shared.VersionedValue
-
It is
Stat.getVersion()
of the corresponding node. - getVersionedValue() - Method in class org.apache.curator.framework.recipes.shared.SharedCount
- getVersionedValue() - Method in interface org.apache.curator.framework.recipes.shared.SharedCountReader
-
Return the current count and version
- getVersionedValue() - Method in class org.apache.curator.framework.recipes.shared.SharedValue
- getVersionedValue() - Method in interface org.apache.curator.framework.recipes.shared.SharedValueReader
-
Return the current version and value
- getViolation() - Method in exception class org.apache.curator.framework.schema.SchemaViolation
- getViolatorData() - Method in exception class org.apache.curator.framework.schema.SchemaViolation
- getWaitForShutdownTimeoutMs() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getWatched() - Method in class org.apache.curator.framework.schema.Schema
- getWatchedEvent() - Method in interface org.apache.curator.framework.api.CuratorEvent
-
If
CuratorEvent.getType()
returnsCuratorEventType.WATCHED
this will return the WatchedEvent - getWatcherFilter() - Method in class org.apache.curator.x.async.details.Filters
- getZkClientConfig() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getZooKeeper() - Method in class org.apache.curator.CuratorZookeeperClient
-
Return the managed ZK instance.
- getZookeeperClient() - Method in interface org.apache.curator.framework.CuratorFramework
-
Return the managed zookeeper client
- getZookeeperClient() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getZookeeperCompatibility() - Method in interface org.apache.curator.framework.CuratorFramework
-
Return zookeeper server compatibility
- getZookeeperCompatibility() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getZookeeperCompatibility() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- getZookeeperFactory() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- getZxid() - Method in class org.apache.curator.framework.recipes.shared.VersionedValue
-
It is
Stat.getMzxid()
of the corresponding node. - Group - Class in pubsub.models
- Group() - Constructor for class pubsub.models.Group
- Group(String) - Constructor for class pubsub.models.Group
- GroupMember - Class in org.apache.curator.framework.recipes.nodes
-
Group membership management.
- GroupMember(CuratorFramework, String, String) - Constructor for class org.apache.curator.framework.recipes.nodes.GroupMember
- GroupMember(CuratorFramework, String, String, byte[]) - Constructor for class org.apache.curator.framework.recipes.nodes.GroupMember
- Guaranteeable<T> - Interface in org.apache.curator.framework.api
- GuaranteeableDeletable - Interface in org.apache.curator.framework.api
-
Solves this edge case: deleting a node can fail due to connection issues.
- guaranteed - Enum constant in enum org.apache.curator.x.async.api.DeleteOption
-
Solves edge cases where an operation may succeed on the server but connection failure occurs before a response can be successfully returned to the client.
- guaranteed - Enum constant in enum org.apache.curator.x.async.api.RemoveWatcherOption
-
Solves edge cases where an operation may succeed on the server but connection failure occurs before a response can be successfully returned to the client.
- guaranteed() - Method in interface org.apache.curator.framework.api.Guaranteeable
-
Solves edge cases where an operation may succeed on the server but connection failure occurs before a response can be successfully returned to the client.
- guaranteed() - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- guaranteed() - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- guaranteedDelete(CuratorFramework, String) - Static method in class framework.CrudExamples
- GzipCompressionProvider - Class in org.apache.curator.framework.imps
- GzipCompressionProvider() - Constructor for class org.apache.curator.framework.imps.GzipCompressionProvider
H
- handleException(Exception) - Method in interface org.apache.curator.x.async.modeled.cached.ModeledCacheListener
-
Called when there is an exception processing a message from the internal cache.
- handleException(Throwable) - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
Deprecated.Default behavior is just to log the exception
- handleException(Throwable) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.Default behavior is just to log the exception
- handleStateChange(ConnectionState) - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
- hasAddrField() - Static method in class org.apache.curator.utils.Compatibility
- hasContainerSupport() - Static method in class org.apache.curator.utils.ZKPaths
-
Returns true if the version of ZooKeeper client in use supports containers
- hasGetReachableOrOneMethod() - Static method in class org.apache.curator.utils.Compatibility
- hashCode() - Method in class modeled.ContainerType
- hashCode() - Method in class modeled.PersonId
- hashCode() - Method in class modeled.PersonModel
- hashCode() - Method in class org.apache.curator.framework.recipes.cache.ChildData
- hashCode() - Method in class org.apache.curator.framework.recipes.leader.Participant
- hashCode() - Method in class org.apache.curator.framework.schema.Schema
- hashCode() - Method in class org.apache.curator.test.InstanceSpec
- hashCode() - Method in class org.apache.curator.utils.ZKPaths.PathAndNode
- hashCode() - Method in class org.apache.curator.x.async.details.AsyncResultImpl
- hashCode() - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- hashCode() - Method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- hashCode() - Method in class org.apache.curator.x.discovery.ServiceInstance
- hashCode() - Method in class org.apache.curator.x.discovery.UriSpec
- hashCode() - Method in class org.apache.curator.x.discovery.UriSpec.Part
- hasLeadership() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Return true if leadership is currently held by this instance
- hasLeadership() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
Return true if leadership is currently held by this instance
- hasOutstanding() - Method in class org.apache.curator.framework.imps.EnsembleTracker
- hasPersistentWatchers() - Static method in class org.apache.curator.utils.Compatibility
- hasPersistentWatchers() - Method in class org.apache.curator.utils.ZookeeperCompatibility.Builder
- hasPersistentWatchers() - Method in class org.apache.curator.utils.ZookeeperCompatibility
-
Check if both client and server support persistent watchers
- hasPersistentWatchers(boolean) - Method in class org.apache.curator.utils.ZookeeperCompatibility.Builder
- high - Enum constant in enum pubsub.models.Priority
I
- id() - Method in interface org.apache.curator.x.async.migrations.MigrationSet
- id(String) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
- idempotent() - Method in interface org.apache.curator.framework.api.Idempotentable
-
If the first try of this operation gets a transient error, curator will retry the operation, and treat it as successful so long as the end state of the znode is the same as if the operation had completed without error on the first try.
- idempotent() - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- idempotent() - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- idempotent() - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- Idempotentable<T> - Interface in org.apache.curator.framework.api
- idFromPath(String) - Method in class org.apache.curator.framework.recipes.nodes.GroupMember
-
Given a full ZNode path, return the member ID
- ignoreMissingNodesForChildren - Enum constant in enum org.apache.curator.x.async.modeled.ModeledOptions
-
Causes
ModeledFramework.children()
andModeledFramework.childrenAsZNodes()
to ignoreKeeperException.NoNodeException
and merely return an empty list - IllegalTrySetVersionException - Exception Class in org.apache.curator.framework.recipes.shared
-
Exception to alert overflowed
Stat.getVersion()
-1
which is not suitable inSharedValue.trySetValue(VersionedValue, byte[])
andSharedCount.trySetCount(VersionedValue, int)
. - IllegalTrySetVersionException() - Constructor for exception class org.apache.curator.framework.recipes.shared.IllegalTrySetVersionException
- inBackground() - Method in interface org.apache.curator.framework.api.Backgroundable
-
Perform the action in the background
- inBackground() - Method in class org.apache.curator.framework.imps.AddWatchBuilderImpl
- inBackground() - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- inBackground() - Method in class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- inBackground() - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- inBackground() - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- inBackground() - Method in class org.apache.curator.framework.imps.GetACLBuilderImpl
- inBackground() - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- inBackground() - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- inBackground() - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- inBackground() - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- inBackground() - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- inBackground() - Method in class org.apache.curator.framework.imps.SetACLBuilderImpl
- inBackground() - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- inBackground() - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
- inBackground(Object) - Method in interface org.apache.curator.framework.api.Backgroundable
-
Perform the action in the background
- inBackground(Object) - Method in class org.apache.curator.framework.imps.AddWatchBuilderImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.GetACLBuilderImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.SetACLBuilderImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- inBackground(Object) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
- inBackground(BackgroundCallback) - Method in interface org.apache.curator.framework.api.Backgroundable
-
Perform the action in the background
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.AddWatchBuilderImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.GetACLBuilderImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.SetACLBuilderImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- inBackground(BackgroundCallback) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in interface org.apache.curator.framework.api.Backgroundable
-
Perform the action in the background
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.AddWatchBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.GetACLBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.SetACLBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- inBackground(BackgroundCallback, Object) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in interface org.apache.curator.framework.api.Backgroundable
-
Perform the action in the background
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.AddWatchBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.GetACLBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.SetACLBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- inBackground(BackgroundCallback, Object, Executor) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in interface org.apache.curator.framework.api.Backgroundable
-
Perform the action in the background
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.AddWatchBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.GetACLBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.SetACLBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- inBackground(BackgroundCallback, Executor) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
- increment() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
-
Add 1 to the current value and return the new value information.
- increment() - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
-
Add 1 to the current value and return the new value information.
- increment() - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
-
Add 1 to the current value and return the new value information.
- initialize(byte[]) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
-
Atomic values are initially set to the equivalent of
NULL
in a database. - initialize(Integer) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
- initialize(Long) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
- initialize(T) - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
-
Atomic values are initially set to the equivalent of
NULL
in a database. - initialized() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheListener
-
When the cache is started, the initial nodes are tracked and when they are finished loading into the cache this method is called.
- initialized() - Method in interface org.apache.curator.x.async.modeled.cached.ModeledCacheListener
-
The cache has finished initializing
- INITIALIZED - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent.Type
-
Posted when
PathChildrenCache.start(PathChildrenCache.StartMode)
is called withPathChildrenCache.StartMode.POST_INITIALIZED_EVENT
. - INITIALIZED - Enum constant in enum org.apache.curator.framework.recipes.cache.TreeCacheEvent.Type
-
Posted after the initial cache has been fully populated.
- Instance - Class in pubsub.models
- Instance() - Constructor for class pubsub.models.Instance
- Instance(String, InstanceType, String, int) - Constructor for class pubsub.models.Instance
- InstanceCleanup - Class in org.apache.curator.x.discovery.server.rest
-
A background task that purges stale registrations.
- InstanceCleanup(ServiceDiscovery<?>, int) - Constructor for class org.apache.curator.x.discovery.server.rest.InstanceCleanup
- instanceClient - Static variable in class pubsub.Clients
-
A client template for Instance instances
- InstanceDetails - Class in discovery
-
In a real application, the Service payload will most likely be more detailed than this.
- InstanceDetails() - Constructor for class discovery.InstanceDetails
- InstanceDetails(String) - Constructor for class discovery.InstanceDetails
- InstanceFilter<T> - Interface in org.apache.curator.x.discovery
-
Typedef for an Instance predicate
- InstanceProvider<T> - Interface in org.apache.curator.x.discovery.details
-
Provides a set of available instances for a service so that a strategy can pick one of them
- InstanceSerializer<T> - Interface in org.apache.curator.x.discovery.details
-
Injectable serializer for service instances
- InstanceSpec - Class in org.apache.curator.test
-
Abstracts one of the servers in the ensemble
- InstanceSpec(File, int, int, int, boolean, int) - Constructor for class org.apache.curator.test.InstanceSpec
- InstanceSpec(File, int, int, int, boolean, int, int, int) - Constructor for class org.apache.curator.test.InstanceSpec
- InstanceSpec(File, int, int, int, boolean, int, int, int, Map<String, Object>) - Constructor for class org.apache.curator.test.InstanceSpec
- InstanceSpec(File, int, int, int, boolean, int, int, int, Map<String, Object>, String) - Constructor for class org.apache.curator.test.InstanceSpec
- InstanceType - Enum in pubsub.models
- IntegerDiscoveryContext - Class in org.apache.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 org.apache.curator.x.discovery.server.contexts.IntegerDiscoveryContext
- InternalACLProvider - Interface in org.apache.curator.utils
- internalBlockUntilConnectedOrTimedOut() - Method in class org.apache.curator.CuratorZookeeperClient
-
For internal use only
- internalRegisterService(ServiceInstance<T>) - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
- InternalScheduledFutureTask(ScheduledFuture<?>) - Constructor for class org.apache.curator.utils.CloseableExecutorService.InternalScheduledFutureTask
- internalSync(CuratorFrameworkImpl, String, Object) - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- InterProcessLock - Interface in org.apache.curator.framework.recipes.locks
-
NOTE: depending on its implementation,
InterProcessLock.release()
may throw an exception if the current thread does not own the lock - InterProcessMultiLock - Class in org.apache.curator.framework.recipes.locks
-
A container that manages multiple locks as a single entity.
- InterProcessMultiLock(List<InterProcessLock>) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessMultiLock
-
Creates a multi lock of any type of inter process lock
- InterProcessMultiLock(CuratorFramework, List<String>) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessMultiLock
-
Creates a multi lock of
InterProcessMutex
s - InterProcessMutex - Class in org.apache.curator.framework.recipes.locks
-
A re-entrant mutex that works across JVMs.
- InterProcessMutex(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessMutex
- InterProcessMutex(CuratorFramework, String, LockInternalsDriver) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessMutex
- InterProcessReadWriteLock - Class in org.apache.curator.framework.recipes.locks
-
A re-entrant read/write mutex that works across JVMs.
- InterProcessReadWriteLock(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock
- InterProcessReadWriteLock(CuratorFramework, String, byte[]) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock
- InterProcessReadWriteLock(InterProcessReadWriteLock.WriteLock, InterProcessReadWriteLock.ReadLock) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock
- InterProcessReadWriteLock.ReadLock - Class in org.apache.curator.framework.recipes.locks
- InterProcessReadWriteLock.WriteLock - Class in org.apache.curator.framework.recipes.locks
- InterProcessSemaphore - Class in org.apache.curator.framework.recipes.locks
-
Deprecated.Use
InterProcessSemaphoreV2
instead of this class. It uses a better algorithm. - InterProcessSemaphore(CuratorFramework, String, int) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
-
Deprecated.
- InterProcessSemaphore(CuratorFramework, String, SharedCountReader) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
-
Deprecated.
- InterProcessSemaphoreMutex - Class in org.apache.curator.framework.recipes.locks
-
A NON re-entrant mutex that works across JVMs.
- InterProcessSemaphoreMutex(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreMutex
- InterProcessSemaphoreV2 - Class in org.apache.curator.framework.recipes.locks
-
A counting semaphore that works across JVMs.
- InterProcessSemaphoreV2(CuratorFramework, String, int) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
- InterProcessSemaphoreV2(CuratorFramework, String, SharedCountReader) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
- interruptLeadership() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
Attempt to cancel and interrupt the current leadership if this instance has leadership
- inTransaction() - Method in interface org.apache.curator.framework.CuratorFramework
-
Deprecated.use
CuratorFramework.transaction()
instead - inTransaction() - Method in interface org.apache.curator.framework.CuratorTempFramework
-
Start a transaction builder
- inTransaction() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- inTransaction() - Method in class org.apache.curator.framework.imps.CuratorTempFrameworkImpl
- inTransaction(List<CuratorOp>) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- inTransaction(List<CuratorOp>) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Invoke ZooKeeper to commit the given operations as a single transaction.
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.curator.test.DelegatingExecutorService
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.curator.test.DelegatingExecutorService
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.curator.test.DelegatingExecutorService
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.curator.test.DelegatingExecutorService
- isAcquiredInThisProcess() - Method in interface org.apache.curator.framework.recipes.locks.InterProcessLock
-
Returns true if the mutex is acquired by a thread in this JVM
- isAcquiredInThisProcess() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMultiLock
- isAcquiredInThisProcess() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
-
Returns true if the mutex is acquired by a thread in this JVM
- isAcquiredInThisProcess() - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreMutex
- isCancelled() - Method in class org.apache.curator.utils.CloseableExecutorService.InternalScheduledFutureTask
- isCompressed(Set<CreateOption>) - Static method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- isConnected() - Method in class org.apache.curator.CuratorZookeeperClient
-
Returns true if the client is current connected
- isConnected() - Method in enum org.apache.curator.framework.state.ConnectionState
-
Check if this state indicates that Curator has a connection to ZooKeeper
- isConnected() - Method in class org.apache.curator.framework.state.ConnectionStateManager
- isCuratorCache() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBridge
-
Returns true if the underlying cache is
CuratorCache
(i.e. - isDone() - Method in class org.apache.curator.utils.CloseableExecutorService.InternalScheduledFutureTask
- isDynamic() - Method in enum org.apache.curator.x.discovery.ServiceType
- isEmpty() - Method in interface org.apache.curator.framework.listen.ListenerManager
- isEnabled() - Method in class org.apache.curator.x.discovery.ServiceInstance
-
IMPORTANT: Due to CURATOR-275 the
enabled
field is NOT supported by default. - isErrorState(ConnectionState) - Method in interface org.apache.curator.framework.state.ConnectionStateErrorPolicy
-
Returns true if the given state should cause the recipe to act as though the connection has been lost.
- isErrorState(ConnectionState) - Method in class org.apache.curator.framework.state.SessionConnectionStateErrorPolicy
- isErrorState(ConnectionState) - Method in class org.apache.curator.framework.state.StandardConnectionStateErrorPolicy
- isExecuteCalled() - Method in class org.apache.curator.test.ExecuteCalledWatchingExecutorService
- isFromRandom() - Method in class org.apache.curator.test.QuorumConfigBuilder
- isFromRandom() - Method in class org.apache.curator.test.QuorumPeerConfigBuilder
- isId(String) - Static method in interface org.apache.curator.x.async.modeled.ZPath
-
Return true if the given string conforms to the "{XXXX}" ID pattern
- isLeader() - Method in interface org.apache.curator.framework.recipes.leader.LeaderLatchListener
-
This is called when the LeaderLatch's state goes from hasLeadership = false to hasLeadership = true.
- isLeader() - Method in class org.apache.curator.framework.recipes.leader.Participant
-
Returns true if this participant is the current leader
- isOpen - Variable in class org.apache.curator.utils.CloseableExecutorService
- isOpen() - Method in class org.apache.curator.framework.state.CircuitBreakingConnectionStateListener
-
Returns true if the circuit is open
- isOwnedByCurrentThread() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
-
Returns true if the mutex is acquired by the calling thread
- isProtected() - Method in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
-
Deprecated.
- isProtectedZNode(String) - Static method in class org.apache.curator.framework.imps.ProtectedUtils
-
Utility method to determine if a given ZNode name starts with Curator's generated protected prefix.
- isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
- isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
- isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
- isResolved() - Method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- isResolved() - Method in interface org.apache.curator.x.async.modeled.ZPath
-
Return true if this path is fully resolved (i.e.
- isRoot() - Method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- isRoot() - Method in interface org.apache.curator.x.async.modeled.ZPath
-
Return true/false if this is the root ZPath
- isRunning() - Method in class org.apache.curator.test.TestingZooKeeperMain.TestZooKeeperServer
- isShutdown() - Method in class org.apache.curator.test.DelegatingExecutorService
- isShutdown() - Method in class org.apache.curator.utils.CloseableExecutorService
-
Returns true if this executor has been shut down.
- isStarted() - Method in interface org.apache.curator.framework.CuratorFramework
-
Deprecated.use
CuratorFramework.getState()
instead - isStarted() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
Deprecated.
- isTerminated() - Method in class org.apache.curator.test.DelegatingExecutorService
- isValid(Schema, String, byte[], List<ACL>) - Method in class org.apache.curator.framework.schema.DefaultSchemaValidator
- isValid(Schema, String, byte[], List<ACL>) - Method in interface org.apache.curator.framework.schema.SchemaValidator
- isValid(Schema, String, byte[], List<ACL>) - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- isVariable() - Method in class org.apache.curator.x.discovery.UriSpec.Part
- isWithWatcher() - Method in class org.apache.curator.drivers.OperationTrace
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
- iterator() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
Deprecated.Return an iterator over all nodes in the cache.
- iterator() - Method in class org.apache.curator.x.discovery.UriSpec
J
- JacksonModelSerializer<T> - Class in org.apache.curator.x.async.modeled
-
Model serializer that uses Jackson for JSON serialization.
- JacksonModelSerializer(TypeReference) - Constructor for class org.apache.curator.x.async.modeled.JacksonModelSerializer
- JacksonModelSerializer(JavaType) - Constructor for class org.apache.curator.x.async.modeled.JacksonModelSerializer
- JacksonModelSerializer(ObjectMapper, TypeReference) - Constructor for class org.apache.curator.x.async.modeled.JacksonModelSerializer
- JacksonModelSerializer(ObjectMapper, JavaType) - Constructor for class org.apache.curator.x.async.modeled.JacksonModelSerializer
- JacksonModelSerializer(ObjectReader, ObjectWriter) - Constructor for class org.apache.curator.x.async.modeled.JacksonModelSerializer
- JacksonModelSerializer(Class<T>) - Constructor for class org.apache.curator.x.async.modeled.JacksonModelSerializer
- Joinable<T> - Interface in org.apache.curator.framework.api
- joining(String...) - Method in interface org.apache.curator.framework.api.Joinable
-
Adds one or more servers to joining the ensemble.
- joining(String...) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- joining(List<String>) - Method in interface org.apache.curator.framework.api.Joinable
-
Adds one or more servers to joining the ensemble.
- joining(List<String>) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- JoinStatConfigEnsembleable - Interface in org.apache.curator.framework.api
-
An incremental reconfiguration builder.
- JsonInstanceSerializer<T> - Class in org.apache.curator.x.discovery.details
-
A serializer that uses Jackson to serialize/deserialize as JSON.
- JsonInstanceSerializer(Class<T>) - Constructor for class org.apache.curator.x.discovery.details.JsonInstanceSerializer
-
CURATOR-275 introduced a new field into
ServiceInstance
. - JsonInstanceSerializer(Class<T>, boolean) - Constructor for class org.apache.curator.x.discovery.details.JsonInstanceSerializer
-
CURATOR-275 introduced a new field into
ServiceInstance
. - JsonServiceInstanceMarshaller<T> - Class in org.apache.curator.x.discovery.server.entity
-
Message body reader/writer.
- JsonServiceInstanceMarshaller(DiscoveryContext<T>) - Constructor for class org.apache.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
- JsonServiceInstancesMarshaller<T> - Class in org.apache.curator.x.discovery.server.entity
-
Message body reader/writer.
- JsonServiceInstancesMarshaller(DiscoveryContext<T>) - Constructor for class org.apache.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
- JsonServiceNamesMarshaller - Class in org.apache.curator.x.discovery.server.entity
-
Message body reader/writer.
- JsonServiceNamesMarshaller() - Constructor for class org.apache.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
K
- kill() - Method in class org.apache.curator.test.TestingZooKeeperMain
- kill() - Method in class org.apache.curator.test.TestingZooKeeperServer
- kill() - Method in class org.apache.curator.test.ZooKeeperServerEmbeddedAdapter
- kill(ZooKeeper) - Static method in class org.apache.curator.test.KillSession
-
Kill the given ZK session
- kill(ZooKeeper, String) - Static method in class org.apache.curator.test.KillSession
-
Deprecated.use
KillSession.kill(ZooKeeper)
instead - kill(ZooKeeper, String, int) - Static method in class org.apache.curator.test.KillSession
-
Deprecated.use
KillSession.kill(ZooKeeper)
instead - killServer(InstanceSpec) - Method in class org.apache.curator.test.TestingCluster
-
Kills the given server.
- KillSession - Class in org.apache.curator.test
-
Utility to simulate a ZK session dying.
- KillSession() - Constructor for class org.apache.curator.test.KillSession
L
- LATENT - Enum constant in enum org.apache.curator.framework.imps.CuratorFrameworkState
-
CuratorFramework.start()
has not yet been called - LATENT - Enum constant in enum org.apache.curator.framework.recipes.leader.LeaderLatch.State
- LATEST - Static variable in class org.apache.curator.utils.ZookeeperCompatibility
-
Represent latest version with all features enabled
- leader - package leader
- LeaderLatch - Class in org.apache.curator.framework.recipes.leader
-
Abstraction to select a "leader" amongst multiple contenders in a group of JVMs connected to a Zookeeper cluster.
- LeaderLatch(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderLatch
- LeaderLatch(CuratorFramework, String, String) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderLatch
- LeaderLatch(CuratorFramework, String, String, LeaderLatch.CloseMode) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderLatch
- LeaderLatch.CloseMode - Enum in org.apache.curator.framework.recipes.leader
-
How to handle listeners when the latch is closed
- LeaderLatch.State - Enum in org.apache.curator.framework.recipes.leader
- LeaderLatchListener - Interface in org.apache.curator.framework.recipes.leader
-
A LeaderLatchListener can be used to be notified asynchronously about when the state of the LeaderLatch has changed.
- LeaderSelector - Class in org.apache.curator.framework.recipes.leader
-
Abstraction to select a "leader" amongst multiple contenders in a group of JMVs connected to a Zookeeper cluster.
- LeaderSelector(CuratorFramework, String, ExecutorService, LeaderSelectorListener) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderSelector
- LeaderSelector(CuratorFramework, String, ThreadFactory, Executor, LeaderSelectorListener) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderSelector
-
Deprecated.This constructor was poorly thought out. Custom executor is useless. Use this version instead:
LeaderSelector(CuratorFramework, String, ExecutorService, LeaderSelectorListener)
- LeaderSelector(CuratorFramework, String, LeaderSelectorListener) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderSelector
- LeaderSelector(CuratorFramework, String, CloseableExecutorService, LeaderSelectorListener) - Constructor for class org.apache.curator.framework.recipes.leader.LeaderSelector
- LeaderSelectorExample - Class in leader
- LeaderSelectorExample() - Constructor for class leader.LeaderSelectorExample
- LeaderSelectorListener - Interface in org.apache.curator.framework.recipes.leader
-
Notification for leadership
- LeaderSelectorListenerAdapter - Class in org.apache.curator.framework.recipes.leader
-
An implementation of
LeaderSelectorListener
that adds the recommended handling for connection state problems - LeaderSelectorListenerAdapter() - Constructor for class org.apache.curator.framework.recipes.leader.LeaderSelectorListenerAdapter
- Lease - Interface in org.apache.curator.framework.recipes.locks
-
Represents an acquired lease from an
InterProcessSemaphore
. - leave() - Method in class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
-
Leave the barrier and block until all members have left
- leave(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.barriers.DistributedDoubleBarrier
-
Leave the barrier and block until all members have left or the timeout has elapsed
- Leaveable<T> - Interface in org.apache.curator.framework.api
- LeaveStatConfigEnsembleable - Interface in org.apache.curator.framework.api
-
An incremental reconfiguration builder.
- leaving(String...) - Method in interface org.apache.curator.framework.api.Leaveable
-
Sets one or more servers to leaving the ensemble.
- leaving(String...) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- leaving(List<String>) - Method in interface org.apache.curator.framework.api.Leaveable
-
Sets one or more servers to leaving the ensemble.
- leaving(List<String>) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- list() - Method in interface org.apache.curator.x.async.modeled.cached.CachedModeledFramework
-
Return the instances of the base path of this cached framework
- listenable() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCache
-
Return the listener container so that listeners can be registered to be notified of changes to the cache
- listenable() - Method in interface org.apache.curator.x.async.modeled.cached.CachedModeledFramework
-
Return the listener container so that you can add/remove listeners
- Listenable<T> - Interface in org.apache.curator.framework.listen
-
Abstracts a listenable object
- listener - Variable in class org.apache.curator.framework.listen.ListenerEntry
- ListenerEntry<T> - Class in org.apache.curator.framework.listen
-
Generic holder POJO for a listener and its executor
- ListenerEntry(T, Executor) - Constructor for class org.apache.curator.framework.listen.ListenerEntry
- ListenerManager<K,
V> - Interface in org.apache.curator.framework.listen - local - Enum constant in enum org.apache.curator.x.async.api.RemoveWatcherOption
-
Specify if the client should just remove client side watches if a connection to ZK is not available.
- LocalIpFilter - Interface in org.apache.curator.x.discovery
- locally() - Method in interface org.apache.curator.framework.api.RemoveWatchesLocal
-
Specify if the client should just remove client side watches if a connection to ZK is not available.
- locally() - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- LocationAvailable - Class in pubsub.messages
- LocationAvailable() - Constructor for class pubsub.messages.LocationAvailable
- LocationAvailable(String, Priority, String, Duration) - Constructor for class pubsub.messages.LocationAvailable
- LocationAvailable(Priority, String, Duration) - Constructor for class pubsub.messages.LocationAvailable
- locationAvailableClient - Static variable in class pubsub.Clients
-
A client template for LocationAvailable instances
- LOCK_SCHEMA - Static variable in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
- lockAsync(InterProcessLock) - Static method in class org.apache.curator.x.async.AsyncWrappers
-
Attempt to acquire the given lock asynchronously without timeout using the
ForkJoinPool.commonPool()
. - lockAsync(InterProcessLock, long, TimeUnit) - Static method in class org.apache.curator.x.async.AsyncWrappers
-
Attempt to acquire the given lock asynchronously using the given timeout using the
ForkJoinPool.commonPool()
. - lockAsync(InterProcessLock, long, TimeUnit, Executor) - Static method in class org.apache.curator.x.async.AsyncWrappers
-
Attempt to acquire the given lock asynchronously using the given timeout and executor.
- lockAsync(InterProcessLock, Executor) - Static method in class org.apache.curator.x.async.AsyncWrappers
-
Attempt to acquire the given lock asynchronously using the given executor and without a timeout.
- lockAsyncIf(InterProcessLock, long, TimeUnit) - Static method in class org.apache.curator.x.async.AsyncWrappers
-
Attempt to acquire the given lock asynchronously using the given timeout using the
ForkJoinPool.commonPool()
. - lockAsyncIf(InterProcessLock, long, TimeUnit, Executor) - Static method in class org.apache.curator.x.async.AsyncWrappers
-
Attempt to acquire the given lock asynchronously using the given timeout and executor.
- Locker - Class in org.apache.curator.framework.recipes.locks
-
Utility for safely acquiring a lock and releasing it using Java 7's try-with-resource feature.
- Locker(InterProcessLock) - Constructor for class org.apache.curator.framework.recipes.locks.Locker
- Locker(InterProcessLock, long, TimeUnit) - Constructor for class org.apache.curator.framework.recipes.locks.Locker
- locking - package locking
- LockingExample - Class in locking
- LockingExample() - Constructor for class locking.LockingExample
- LockInternals - Class in org.apache.curator.framework.recipes.locks
- LockInternalsDriver - Interface in org.apache.curator.framework.recipes.locks
- LockInternalsSorter - Interface in org.apache.curator.framework.recipes.locks
- lockPath(String) - Method in class org.apache.curator.framework.recipes.atomic.PromotedToLock.Builder
-
Set the path for the mutex lock (required)
- lockPath(String) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
-
Without a lock set, queue items are removed before being sent to the queue consumer.
- log - Variable in class org.apache.curator.test.BaseClassForTests
- LOST - Enum constant in enum org.apache.curator.framework.state.ConnectionState
-
Curator will set the LOST state when it believes that the ZooKeeper session has expired.
- low - Enum constant in enum pubsub.models.Priority
M
- main(String[]) - Static method in class cache.CuratorCacheExample
- main(String[]) - Static method in class cache.PathCacheExample
- main(String[]) - Static method in class cache.TreeCacheExample
- main(String[]) - Static method in class discovery.DiscoveryExample
- main(String[]) - Static method in class leader.LeaderSelectorExample
- main(String[]) - Static method in class locking.LockingExample
- main(String[]) - Static method in class pubsub.SubPubTest
- makePath(String, String) - Static method in class org.apache.curator.utils.ZKPaths
-
Given a parent path and a child node, create a combined full path
- makePath(String, String, String...) - Static method in class org.apache.curator.utils.ZKPaths
-
Given a parent path and a list of children nodes, create a combined full path
- makeRequeueItemPath(String) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
- makeRevocable(RevocationListener<InterProcessMutex>) - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
- makeRevocable(RevocationListener<InterProcessMutex>, Executor) - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
- makeRevocable(RevocationListener<T>) - Method in interface org.apache.curator.framework.recipes.locks.Revocable
-
Make the lock revocable.
- makeRevocable(RevocationListener<T>, Executor) - Method in interface org.apache.curator.framework.recipes.locks.Revocable
-
Make the lock revocable.
- makeSpecs(int) - Static method in class org.apache.curator.test.TestingCluster
- makeSpecs(int, boolean) - Static method in class org.apache.curator.test.TestingCluster
- MapDiscoveryContext - Class in org.apache.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 org.apache.curator.x.discovery.server.contexts.MapDiscoveryContext
- mapping(Function<K, V>) - Static method in class org.apache.curator.framework.listen.MappingListenerManager
-
Returns a new container that wraps listeners using the given mapper
- MappingListenerManager<K,
V> - Class in org.apache.curator.framework.listen -
Version of ListenerManager that supports mapping/wrapping of listeners
- mappingStandard(UnaryOperator<T>) - Static method in class org.apache.curator.framework.listen.StandardListenerManager
-
Returns a new mapping container that maps to the same type
- markComplete() - Method in class org.apache.curator.RetryLoop
-
Call this when your operation has successfully completed
- marshallJson(ObjectNode, String, Integer) - Method in class org.apache.curator.x.discovery.server.contexts.IntegerDiscoveryContext
- marshallJson(ObjectNode, String, String) - Method in class org.apache.curator.x.discovery.server.contexts.StringDiscoveryContext
- marshallJson(ObjectNode, String, T) - Method in class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
- marshallJson(ObjectNode, String, T) - Method in interface org.apache.curator.x.discovery.server.rest.DiscoveryContext
-
Serialize your payload
- maxCloseWaitMs(int) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- maxItems(int) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
-
By default, the various queues are unbounded.
- maxQueues(int) - Method in class org.apache.curator.framework.recipes.queue.QueueSharderPolicies.Builder
-
Change the maximum number of queues to create.
- medium - Enum constant in enum pubsub.models.Priority
- Membersable<T> - Interface in org.apache.curator.framework.api
- Message - Class in pubsub.models
- Message() - Constructor for class pubsub.models.Message
- Message(String, Priority) - Constructor for class pubsub.models.Message
- Message(Priority) - Constructor for class pubsub.models.Message
- metadata(Map<String, String>) - Method in class org.apache.curator.framework.schema.SchemaBuilder
- migrate(MigrationSet) - Method in class org.apache.curator.x.async.migrations.MigrationManager
-
Process the given migration set
- Migration - Interface in org.apache.curator.x.async.migrations
-
Models a single migration/transition
- MigrationException - Exception Class in org.apache.curator.x.async.migrations
- MigrationException(String, String) - Constructor for exception class org.apache.curator.x.async.migrations.MigrationException
- MigrationManager - Class in org.apache.curator.x.async.migrations
-
Manages migrations
- MigrationManager(AsyncCuratorFramework, String, String, Executor, Duration) - Constructor for class org.apache.curator.x.async.migrations.MigrationManager
- migrations() - Method in interface org.apache.curator.x.async.migrations.MigrationSet
- MigrationSet - Interface in org.apache.curator.x.async.migrations
-
Models a set of migrations.
- milliseconds() - Method in class org.apache.curator.test.compatibility.Timing2
-
Return the base time in milliseconds
- milliseconds() - Method in class org.apache.curator.test.Timing
-
Return the base time in milliseconds
- mkdirs(ZooKeeper, String) - Static method in class org.apache.curator.utils.ZKPaths
-
Make sure all the nodes in the path are created.
- mkdirs(ZooKeeper, String, boolean) - Static method in class org.apache.curator.utils.ZKPaths
-
Make sure all the nodes in the path are created.
- mkdirs(ZooKeeper, String, boolean, InternalACLProvider) - Static method in class org.apache.curator.utils.ZKPaths
-
Make sure all the nodes in the path are created.
- mkdirs(ZooKeeper, String, boolean, InternalACLProvider, boolean) - Static method in class org.apache.curator.utils.ZKPaths
-
Make sure all the nodes in the path are created.
- model() - Method in class org.apache.curator.x.async.modeled.details.ZNodeImpl
- model() - Method in interface org.apache.curator.x.async.modeled.versioned.Versioned
-
Returns the contained model
- model() - Method in interface org.apache.curator.x.async.modeled.ZNode
-
The node's current model
- model(AsyncStage<ZNode<T>>) - Static method in interface org.apache.curator.x.async.modeled.ZNode
-
Utility that modifies an async stage of a znode into an async stage of a model
- modeled - package modeled
- ModeledCache<T> - Interface in org.apache.curator.x.async.modeled.cached
- ModeledCacheListener<T> - Interface in org.apache.curator.x.async.modeled.cached
- ModeledCacheListener.Type - Enum in org.apache.curator.x.async.modeled.cached
- ModeledCuratorExamples - Class in modeled
- ModeledCuratorExamples() - Constructor for class modeled.ModeledCuratorExamples
- ModeledCuratorExamplesAlt - Class in modeled
- ModeledCuratorExamplesAlt() - Constructor for class modeled.ModeledCuratorExamplesAlt
- ModeledFramework<T> - Interface in org.apache.curator.x.async.modeled
- ModeledFrameworkBuilder<T> - Class in org.apache.curator.x.async.modeled
- ModeledFrameworkImpl<T> - Class in org.apache.curator.x.async.modeled.details
- ModeledOptions - Enum in org.apache.curator.x.async.modeled
- models(AsyncStage<List<ZNode<T>>>) - Static method in interface org.apache.curator.x.async.modeled.ZNode
-
Utility that modifies an async stage of znodes into an async stage of models
- ModelSerializer<T> - Interface in org.apache.curator.x.async.modeled
-
Serializing interface for models
- modelSpec() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- modelSpec() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Return the model being used
- ModelSpec<T> - Interface in org.apache.curator.x.async.modeled
-
A full specification for dealing with a portion of the ZooKeeper tree.
- ModelSpecBuilder<T> - Class in org.apache.curator.x.async.modeled
- ModelSpecImpl<T> - Class in org.apache.curator.x.async.modeled.details
- ModelSpecImpl(ZPath, ModelSerializer<T>, CreateMode, List<ACL>, Set<CreateOption>, Set<DeleteOption>, long) - Constructor for class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- MultiItem<T> - Interface in org.apache.curator.framework.recipes.queue
-
Abstraction for multiple items.
- multiple(double) - Method in class org.apache.curator.test.compatibility.Timing2
-
Return a new timing that is a multiple of the this timing
- multiple(double) - Method in class org.apache.curator.test.Timing
-
Return a new timing that is a multiple of the this timing
- multiple(double, int) - Method in class org.apache.curator.test.compatibility.Timing2
-
Return a new timing that is a multiple of the this timing
- MUST - Enum constant in enum org.apache.curator.framework.schema.Schema.Allowance
N
- name(String) - Method in class org.apache.curator.framework.schema.SchemaBuilder
- name(String) - Method in interface org.apache.curator.x.discovery.ServiceCacheBuilder
-
The name of the service to cache (required)
- name(String) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
- nameFrom(Object) - Static method in interface org.apache.curator.x.async.modeled.NodeName
- namespace(String) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
As ZooKeeper is a shared space, users of a given cluster should stay within a pre-defined namespace.
- newBuilder(CuratorFramework, String) - Static method in class org.apache.curator.framework.recipes.cache.TreeCache
-
Deprecated.Create a TreeCache builder for the given client and path to configure advanced options.
- newClient(String, int, int, RetryPolicy) - Static method in class org.apache.curator.framework.CuratorFrameworkFactory
-
Create a new client
- newClient(String, int, int, RetryPolicy, ZKClientConfig) - Static method in class org.apache.curator.framework.CuratorFrameworkFactory
-
Create a new client
- newClient(String, RetryPolicy) - Static method in class org.apache.curator.framework.CuratorFrameworkFactory
-
Create a new client with default session timeout and default connection timeout
- newFixedThreadPool(int, String) - Static method in class org.apache.curator.utils.ThreadUtils
- newFixedThreadScheduledPool(int, String) - Static method in class org.apache.curator.utils.ThreadUtils
- newGenericThreadFactory(String) - Static method in class org.apache.curator.utils.ThreadUtils
- newInstanceSpec() - Static method in class org.apache.curator.test.InstanceSpec
- newManager(CuratorFramework) - Method in interface org.apache.curator.framework.state.ConnectionStateListenerManagerFactory
-
Create a new listener manager
- newNamespaceAwareEnsurePath(String) - Method in interface org.apache.curator.framework.CuratorFramework
-
Deprecated.
- newNamespaceAwareEnsurePath(String) - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- newQueueThreshold(int) - Method in class org.apache.curator.framework.recipes.queue.QueueSharderPolicies.Builder
-
Change the queue threshold.
- newRetryLoop() - Method in class org.apache.curator.CuratorZookeeperClient
-
Return a new retry loop.
- newSessionFailRetryLoop(SessionFailRetryLoop.Mode) - Method in class org.apache.curator.CuratorZookeeperClient
-
Return a new "session fail" retry loop.
- newSingleThreadExecutor(String) - Static method in class org.apache.curator.utils.ThreadUtils
- newSingleThreadScheduledExecutor(String) - Static method in class org.apache.curator.utils.ThreadUtils
- newThreadFactory(String) - Static method in class org.apache.curator.utils.ThreadUtils
- newWatcherRemoveCuratorFramework() - Method in interface org.apache.curator.framework.CuratorFramework
-
Returns a facade of the current instance that tracks watchers created and allows a one-shot removal of all watchers via
WatcherRemoveCuratorFramework.removeWatchers()
- newWatcherRemoveCuratorFramework() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- newZooKeeper(String, int, Watcher, boolean) - Method in class org.apache.curator.utils.DefaultZookeeperFactory
- newZooKeeper(String, int, Watcher, boolean) - Method in class org.apache.curator.utils.NonAdminZookeeperFactory
- newZooKeeper(String, int, Watcher, boolean) - Method in interface org.apache.curator.utils.ZookeeperFactory
-
Allocate a new ZooKeeper instance
- newZooKeeper(String, int, Watcher, boolean, ZKClientConfig) - Method in class org.apache.curator.utils.ConfigurableZookeeperFactory
- newZooKeeper(String, int, Watcher, boolean, ZKClientConfig) - Method in interface org.apache.curator.utils.ZookeeperFactory
-
Allocate a new ZooKeeper instance
- next() - Method in class org.apache.curator.framework.recipes.atomic.CachedAtomicInteger
-
Returns the next value (incrementing by 1).
- next() - Method in class org.apache.curator.framework.recipes.atomic.CachedAtomicLong
-
Returns the next value (incrementing by 1).
- nextItem() - Method in interface org.apache.curator.framework.recipes.queue.MultiItem
-
Called repeatedly to get the items to add to the queue.
- NODE_ADDED - Enum constant in enum org.apache.curator.framework.recipes.cache.TreeCacheEvent.Type
-
A node was added.
- NODE_ADDED - Enum constant in enum org.apache.curator.x.async.modeled.cached.ModeledCacheListener.Type
-
A child was added to the path
- NODE_CHANGED - Enum constant in enum org.apache.curator.framework.recipes.cache.CuratorCacheListener.Type
-
A node already in the cache has changed
- NODE_CREATED - Enum constant in enum org.apache.curator.framework.recipes.cache.CuratorCacheListener.Type
-
A new node was added to the cache
- NODE_DELETED - Enum constant in enum org.apache.curator.framework.recipes.cache.CuratorCacheListener.Type
-
A node already in the cache was deleted
- NODE_REMOVED - Enum constant in enum org.apache.curator.framework.recipes.cache.TreeCacheEvent.Type
-
A node was removed from the tree
- NODE_REMOVED - Enum constant in enum org.apache.curator.x.async.modeled.cached.ModeledCacheListener.Type
-
A child was removed from the path
- NODE_UPDATED - Enum constant in enum org.apache.curator.framework.recipes.cache.TreeCacheEvent.Type
-
A node's data was changed
- NODE_UPDATED - Enum constant in enum org.apache.curator.x.async.modeled.cached.ModeledCacheListener.Type
-
A child's data was changed
- NodeCache - Class in org.apache.curator.framework.recipes.cache
-
Deprecated.replace by
CuratorCache
- NodeCache(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.cache.NodeCache
-
Deprecated.
- NodeCache(CuratorFramework, String, boolean) - Constructor for class org.apache.curator.framework.recipes.cache.NodeCache
-
Deprecated.
- NodeCacheListener - Interface in org.apache.curator.framework.recipes.cache
- nodeChanged() - Method in interface org.apache.curator.framework.recipes.cache.NodeCacheListener
-
Called when a change has occurred
- nodeCreated(String) - Method in interface org.apache.curator.framework.recipes.nodes.PersistentNodeListener
-
Called on a persistentNode event when node is created
- nodeName() - Method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- nodeName() - Method in interface org.apache.curator.x.async.modeled.NodeName
- nodeName() - Method in interface org.apache.curator.x.async.modeled.ZPath
-
The node name at this ZPath
- nodeName() - Method in class pubsub.models.Group
- nodeName() - Method in class pubsub.models.Instance
- nodeName() - Method in class pubsub.models.Message
- NodeName - Interface in org.apache.curator.x.async.modeled
-
Used by the various "resolved" methods and "at" methods.
- NonAdminZookeeperFactory - Class in org.apache.curator.utils
- NonAdminZookeeperFactory() - Constructor for class org.apache.curator.utils.NonAdminZookeeperFactory
- nonNamespaceView() - Method in interface org.apache.curator.framework.CuratorFramework
-
Deprecated.Since 2.9.0 - use
CuratorFramework.usingNamespace(java.lang.String)
passingnull
- nonNamespaceView() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
-
Deprecated.
- NORMAL - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCache.StartMode
-
Deprecated.The cache will be primed (in the background) with initial values.
- NORMAL - Enum constant in enum org.apache.curator.framework.recipes.queue.DistributedQueue.ProcessType
- normalize(String) - Static method in class org.apache.curator.framework.imps.ProtectedUtils
-
Utility method to remove Curator's generated protected prefix if present
- normalizePath(String) - Static method in class org.apache.curator.framework.imps.ProtectedUtils
-
Utility method to provide a path removing Curator's generated protected prefix if present in the ZNode name
- noteError(ServiceInstance<T>) - Method in class org.apache.curator.x.discovery.details.ServiceProviderImpl
- noteError(ServiceInstance<T>) - Method in interface org.apache.curator.x.discovery.ServiceProvider
-
Take note of an error connecting to the given instance.
- noteStartup() - Method in class org.apache.curator.test.TestingZooKeeperMain.TestZooKeeperServer
- NOTIFY_LEADER - Enum constant in enum org.apache.curator.framework.recipes.leader.LeaderLatch.CloseMode
-
When the latch is closed, listeners *will* be notified
- notLeader() - Method in interface org.apache.curator.framework.recipes.leader.LeaderLatchListener
-
This is called when the LeaderLatch's state goes from hasLeadership = true to hasLeadership = false.
O
- of(AsyncStage<T>) - Static method in interface org.apache.curator.x.async.AsyncResult
-
Return a new stage that wraps an async stage into a result-style completion stage.
- offer(byte[]) - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
-
Inserts data into queue.
- ofType(Watcher.WatcherType) - Method in interface org.apache.curator.framework.api.RemoveWatchesType
-
Specify the type of watcher to be removed.
- ofType(Watcher.WatcherType) - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- ofTypeAndPath(OperationType, String) - Static method in class org.apache.curator.framework.api.transaction.CuratorTransactionResult
-
Utility that can be passed to Google Guava to find a particular result.
- operations() - Method in interface org.apache.curator.x.async.migrations.Migration
-
Return the operations to execute in a transaction.
- OperationTrace - Class in org.apache.curator.drivers
-
Used to trace the metrics of a certain Zookeeper operation.
- OperationTrace(String, TracerDriver) - Constructor for class org.apache.curator.drivers.OperationTrace
- OperationTrace(String, TracerDriver, long) - Constructor for class org.apache.curator.drivers.OperationTrace
- OperationType - Enum in org.apache.curator.framework.api.transaction
-
Transaction operation types
- org.apache.curator - package org.apache.curator
- org.apache.curator.connection - package org.apache.curator.connection
- org.apache.curator.drivers - package org.apache.curator.drivers
- org.apache.curator.ensemble - package org.apache.curator.ensemble
- org.apache.curator.ensemble.fixed - package org.apache.curator.ensemble.fixed
- org.apache.curator.framework - package org.apache.curator.framework
- org.apache.curator.framework.api - package org.apache.curator.framework.api
- org.apache.curator.framework.api.transaction - package org.apache.curator.framework.api.transaction
- org.apache.curator.framework.imps - package org.apache.curator.framework.imps
- org.apache.curator.framework.listen - package org.apache.curator.framework.listen
- org.apache.curator.framework.recipes - package org.apache.curator.framework.recipes
- org.apache.curator.framework.recipes.atomic - package org.apache.curator.framework.recipes.atomic
- org.apache.curator.framework.recipes.barriers - package org.apache.curator.framework.recipes.barriers
- org.apache.curator.framework.recipes.cache - package org.apache.curator.framework.recipes.cache
- org.apache.curator.framework.recipes.leader - package org.apache.curator.framework.recipes.leader
- org.apache.curator.framework.recipes.locks - package org.apache.curator.framework.recipes.locks
- org.apache.curator.framework.recipes.nodes - package org.apache.curator.framework.recipes.nodes
- org.apache.curator.framework.recipes.queue - package org.apache.curator.framework.recipes.queue
- org.apache.curator.framework.recipes.shared - package org.apache.curator.framework.recipes.shared
- org.apache.curator.framework.recipes.watch - package org.apache.curator.framework.recipes.watch
- org.apache.curator.framework.schema - package org.apache.curator.framework.schema
- org.apache.curator.framework.state - package org.apache.curator.framework.state
- org.apache.curator.retry - package org.apache.curator.retry
- org.apache.curator.test - package org.apache.curator.test
- org.apache.curator.test.compatibility - package org.apache.curator.test.compatibility
- org.apache.curator.utils - package org.apache.curator.utils
- org.apache.curator.x.async - package org.apache.curator.x.async
- org.apache.curator.x.async.api - package org.apache.curator.x.async.api
- org.apache.curator.x.async.details - package org.apache.curator.x.async.details
- org.apache.curator.x.async.migrations - package org.apache.curator.x.async.migrations
- org.apache.curator.x.async.modeled - package org.apache.curator.x.async.modeled
- org.apache.curator.x.async.modeled.cached - package org.apache.curator.x.async.modeled.cached
- org.apache.curator.x.async.modeled.details - package org.apache.curator.x.async.modeled.details
- org.apache.curator.x.async.modeled.typed - package org.apache.curator.x.async.modeled.typed
- org.apache.curator.x.async.modeled.versioned - package org.apache.curator.x.async.modeled.versioned
- org.apache.curator.x.discovery - package org.apache.curator.x.discovery
- org.apache.curator.x.discovery.details - package org.apache.curator.x.discovery.details
- org.apache.curator.x.discovery.server.contexts - package org.apache.curator.x.discovery.server.contexts
- org.apache.curator.x.discovery.server.entity - package org.apache.curator.x.discovery.server.entity
- org.apache.curator.x.discovery.server.rest - package org.apache.curator.x.discovery.server.rest
- org.apache.curator.x.discovery.strategies - package org.apache.curator.x.discovery.strategies
- orSetData() - Method in interface org.apache.curator.framework.api.CreateBuilder
-
If the ZNode already exists, Curator will instead call setData()
- orSetData() - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- orSetData(int) - Method in interface org.apache.curator.framework.api.CreateBuilder
-
If the ZNode already exists, Curator will instead call setData()
- orSetData(int) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
P
- parameter() - Static method in interface org.apache.curator.x.async.modeled.ZPath
-
Returns the special node name that can be used for replacements at runtime via
ZPath.resolved(Object...)
when passed via the variousfrom()
methods - parameter(String) - Static method in interface org.apache.curator.x.async.modeled.ZPath
-
Same as
ZPath.parameter()
but allows you to specify an alternate code/name. - parent() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- parent() - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- parent() - Method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- parent() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Return a new Modeled Curator instance with all the same options but applying to the parent node of this Modeled Curator's path.
- parent() - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return a new CuratorModel instance with all the same options but applying to the parent node of this CuratorModel's path.
- parent() - Method in interface org.apache.curator.x.async.modeled.ZPath
-
Return this ZPath's parent
- ParentACLable<T> - Interface in org.apache.curator.framework.api
- parentPathFilter(String) - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCacheAccessor
-
Filter for a ChildData stream.
- parse(String) - Static method in interface org.apache.curator.x.async.modeled.ZPath
-
Take a string path and return a ZPath.
- parse(String, UnaryOperator<String>) - Static method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- parse(String, UnaryOperator<String>) - Static method in interface org.apache.curator.x.async.modeled.ZPath
-
Take a ZNode string path and return a ZPath
- parseWithIds(String) - Static method in interface org.apache.curator.x.async.modeled.ZPath
-
Take a string path and return a ZPath.
- Part() - Constructor for class org.apache.curator.x.discovery.UriSpec.Part
- Part(String, boolean) - Constructor for class org.apache.curator.x.discovery.UriSpec.Part
- Participant - Class in org.apache.curator.framework.recipes.leader
-
Describes a participant in a leadership selection
- Participant(String, boolean) - Constructor for class org.apache.curator.framework.recipes.leader.Participant
- path() - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- path() - Method in class org.apache.curator.x.async.modeled.details.ZNodeImpl
- path() - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return the model's path
- path() - Method in interface org.apache.curator.x.async.modeled.ZNode
-
The path of the node
- PATH_SEPARATOR - Static variable in class org.apache.curator.utils.ZKPaths
-
Zookeeper's path separator character.
- Pathable<T> - Interface in org.apache.curator.framework.api
- PathAndBytesable<T> - Interface in org.apache.curator.framework.api
- PathAndNode(String, String) - Constructor for class org.apache.curator.utils.ZKPaths.PathAndNode
- PathCacheExample - Class in cache
-
An example of the PathChildrenCache.
- PathCacheExample() - Constructor for class cache.PathCacheExample
- PathChildrenCache - Class in org.apache.curator.framework.recipes.cache
-
Deprecated.replace by
CuratorCache
- PathChildrenCache(CuratorFramework, String, boolean) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.
- PathChildrenCache(CuratorFramework, String, boolean, boolean, ExecutorService) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.
- PathChildrenCache(CuratorFramework, String, boolean, boolean, ThreadFactory) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.
- PathChildrenCache(CuratorFramework, String, boolean, boolean, CloseableExecutorService) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.
- PathChildrenCache(CuratorFramework, String, boolean, ThreadFactory) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.
- PathChildrenCache(CuratorFramework, String, PathChildrenCacheMode) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.
- PathChildrenCache(CuratorFramework, String, PathChildrenCacheMode, ThreadFactory) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.
- PathChildrenCache.StartMode - Enum in org.apache.curator.framework.recipes.cache
-
Deprecated.Method of priming cache on
PathChildrenCache.start(StartMode)
- PathChildrenCacheEvent - Class in org.apache.curator.framework.recipes.cache
-
POJO that abstracts a change to a path
- PathChildrenCacheEvent(PathChildrenCacheEvent.Type, ChildData) - Constructor for class org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent
- PathChildrenCacheEvent.Type - Enum in org.apache.curator.framework.recipes.cache
-
Type of change
- PathChildrenCacheListener - Interface in org.apache.curator.framework.recipes.cache
-
Listener for PathChildrenCache changes
- PathChildrenCacheMode - Enum in org.apache.curator.framework.recipes.cache
-
Deprecated.no longer used. Instead use either
PathChildrenCache(CuratorFramework, String, boolean)
orPathChildrenCache(CuratorFramework, String, boolean, ThreadFactory)
- pathConstructor(DiscoveryPathConstructor) - Method in class org.apache.curator.x.discovery.ServiceDiscoveryBuilder
-
Required - shape the service tree in ZK, see
ServiceDiscoveryBuilder.basePath(String)
for alternative - PathUtils - Class in org.apache.curator.utils
-
This class is copied from Apache ZooKeeper.
- PathUtils() - Constructor for class org.apache.curator.utils.PathUtils
- payload(T) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
- peek() - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
-
Returns the data at the first element of the queue, or null if the queue is empty.
- performBackgroundOperation(OperationAndData<String>) - Method in class org.apache.curator.framework.imps.AddWatchBuilderImpl
- performBackgroundOperation(OperationAndData<String>) - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- performBackgroundOperation(OperationAndData<String>) - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- performBackgroundOperation(OperationAndData<String>) - Method in class org.apache.curator.framework.imps.GetACLBuilderImpl
- performBackgroundOperation(OperationAndData<String>) - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- performBackgroundOperation(OperationAndData<String>) - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- performBackgroundOperation(OperationAndData<String>) - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- performBackgroundOperation(OperationAndData<String>) - Method in class org.apache.curator.framework.imps.SetACLBuilderImpl
- performBackgroundOperation(OperationAndData<String>) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
- performBackgroundOperation(OperationAndData<Void>) - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- performBackgroundOperation(OperationAndData<Void>) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- performBackgroundOperation(OperationAndData<CuratorMultiTransactionRecord>) - Method in class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- performBackgroundOperation(OperationAndData<PathAndBytes>) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- performBackgroundOperation(OperationAndData<PathAndBytes>) - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- PERMANENT - Enum constant in enum org.apache.curator.x.discovery.ServiceType
- PersistentEphemeralNode - Class in org.apache.curator.framework.recipes.nodes
-
Deprecated.This has been replaced with the more general
PersistentNode
- PersistentEphemeralNode(CuratorFramework, PersistentEphemeralNode.Mode, String, byte[]) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode
-
Deprecated.
- PersistentEphemeralNode.Mode - Enum in org.apache.curator.framework.recipes.nodes
-
Deprecated.This has been replaced with the more general
PersistentNode
- PersistentNode - Class in org.apache.curator.framework.recipes.nodes
-
A persistent node is a node that attempts to stay present in ZooKeeper, even through connection and session interruptions.
- PersistentNode(CuratorFramework, CreateMode, boolean, String, byte[]) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentNode
- PersistentNode(CuratorFramework, CreateMode, boolean, String, byte[], boolean) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentNode
- PersistentNode(CuratorFramework, CreateMode, boolean, String, byte[], long, boolean) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentNode
- PersistentNodeListener - Interface in org.apache.curator.framework.recipes.nodes
-
Listener for changes to a PersistentNode
- PersistentTtlNode - Class in org.apache.curator.framework.recipes.nodes
-
Manages a
PersistentNode
that usesCreateMode.CONTAINER
. - PersistentTtlNode(CuratorFramework, String, long, byte[]) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
- PersistentTtlNode(CuratorFramework, String, long, byte[], boolean) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
- PersistentTtlNode(CuratorFramework, ScheduledExecutorService, String, long, byte[], String, int) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
- PersistentTtlNode(CuratorFramework, ScheduledExecutorService, String, long, byte[], String, int, boolean) - Constructor for class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
- PersistentWatcher - Class in org.apache.curator.framework.recipes.watch
-
A managed persistent watcher.
- PersistentWatcher(CuratorFramework, String, boolean) - Constructor for class org.apache.curator.framework.recipes.watch.PersistentWatcher
- PersonId - Class in modeled
- PersonId() - Constructor for class modeled.PersonId
- PersonId(String) - Constructor for class modeled.PersonId
- PersonModel - Class in modeled
- PersonModel() - Constructor for class modeled.PersonModel
- PersonModel(PersonId, ContainerType, String, String, int) - Constructor for class modeled.PersonModel
- PersonModelSpec - Class in modeled
- PersonModelSpec(AsyncCuratorFramework) - Constructor for class modeled.PersonModelSpec
- poll() - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
-
Attempts to remove the head of the queue and return it.
- poll(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
-
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
- port(int) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
- POST_INITIALIZED_EVENT - Enum constant in enum org.apache.curator.framework.recipes.cache.PathChildrenCache.StartMode
-
Deprecated.After cache is primed with initial values (in the background) a
PathChildrenCacheEvent.Type.INITIALIZED
will be posted. - postInitializedOnly() - Method in interface org.apache.curator.x.async.modeled.cached.ModeledCacheListener
-
Returns a version of this listener that only begins calling
ModeledCacheListener.accept(org.apache.curator.x.async.modeled.cached.ModeledCacheListener.Type, org.apache.curator.x.async.modeled.ZPath, org.apache.zookeeper.data.Stat, Object)
onceModeledCacheListener.initialized()
has been called. - postSafeNotify(Object) - Method in interface org.apache.curator.framework.CuratorFramework
-
Calls
invalid reference
#notifyAll()
- postValue() - Method in interface org.apache.curator.framework.recipes.atomic.AtomicValue
-
Returns the value of the counter after to the operation
- PredicateResults - Class in org.apache.curator.framework.recipes.locks
- PredicateResults(String, boolean) - Constructor for class org.apache.curator.framework.recipes.locks.PredicateResults
- preValue() - Method in interface org.apache.curator.framework.recipes.atomic.AtomicValue
-
Returns the value of the counter prior to the operation
- Priority - Enum in pubsub.models
- process(WatchedEvent) - Method in interface org.apache.curator.framework.api.CuratorWatcher
-
Same as
Watcher.process(WatchedEvent)
. - process(WatchedEvent) - Method in class org.apache.curator.framework.imps.EnsembleTracker
- processResult(CuratorFramework, CuratorEvent) - Method in interface org.apache.curator.framework.api.BackgroundCallback
-
Called when the async background operation completes
- processWithLockSafety(String, DistributedQueue.ProcessType) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
- PromotedToLock - Class in org.apache.curator.framework.recipes.atomic
-
Abstraction of arguments for mutex promotion.
- PromotedToLock.Builder - Class in org.apache.curator.framework.recipes.atomic
- propagate() - Method in class org.apache.curator.utils.ExceptionAccumulator
-
If there is an accumulated exception, throw it
- PROPERTY_DONT_LOG_CONNECTION_ISSUES - Static variable in class org.apache.curator.utils.DebugUtils
- PROPERTY_LOG_EVENTS - Static variable in class org.apache.curator.utils.DebugUtils
- PROPERTY_LOG_ONLY_FIRST_CONNECTION_ISSUE_AS_ERROR_LEVEL - Static variable in class org.apache.curator.utils.DebugUtils
- PROPERTY_REMOVE_WATCHERS_IN_FOREGROUND - Static variable in class org.apache.curator.utils.DebugUtils
- PROPERTY_VALIDATE_NAMESPACE_WATCHER_MAP_EMPTY - Static variable in class org.apache.curator.utils.DebugUtils
- PROPERTY_VALIDATE_NO_REMAINING_WATCHERS - Static variable in class org.apache.curator.utils.DebugUtils
- ProtectACLCreateModePathAndBytesable<T> - Interface in org.apache.curator.framework.api
- ProtectACLCreateModeStatPathAndBytesable<T> - Interface in org.apache.curator.framework.api
- PROTECTED_EPHEMERAL - Enum constant in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
-
Deprecated.Same as
CreateMode.EPHEMERAL
with protection - PROTECTED_EPHEMERAL_SEQUENTIAL - Enum constant in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
-
Deprecated.Same as
CreateMode.EPHEMERAL_SEQUENTIAL
with protection - ProtectedUtils - Class in org.apache.curator.framework.imps
-
Utility class to handle ZNode names when using
CreateBuilderMain.withProtection()
- providerStrategy(ProviderStrategy<T>) - Method in interface org.apache.curator.x.discovery.ServiceProviderBuilder
-
optional - set the provider strategy.
- ProviderStrategy<T> - Interface in org.apache.curator.x.discovery
-
A strategy for picking one from a set of instances
- proxy - Enum constant in enum pubsub.models.InstanceType
- Publisher - Class in pubsub
- Publisher(AsyncCuratorFramework) - Constructor for class pubsub.Publisher
- publishInstance(Instance) - Method in class pubsub.Publisher
-
Publish the given instance using the Instance client template
- publishInstances(List<Instance>) - Method in class pubsub.Publisher
-
Publish the given instances using the Instance client template in a transaction
- publishLocationAvailable(Group, LocationAvailable) - Method in class pubsub.Publisher
-
Publish the given LocationAvailable using the LocationAvailable client template
- publishLocationsAvailable(Group, List<LocationAvailable>) - Method in class pubsub.Publisher
-
Publish the given LocationAvailables using the LocationAvailable client template in a transaction
- publishUserCreated(Group, UserCreated) - Method in class pubsub.Publisher
-
Publish the given UserCreated using the UserCreated client template
- publishUsersCreated(Group, List<UserCreated>) - Method in class pubsub.Publisher
-
Publish the given UserCreateds using the UserCreated client template in a transaction
- pubsub - package pubsub
- pubsub.messages - package pubsub.messages
- pubsub.models - package pubsub.models
- put(ChildData) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
-
Add an entry to storage and return any previous entry at that path
- put(T) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
-
Add an item into the queue.
- put(T, int) - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
-
Add an item into the queue.
- put(T, int, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
-
Same as
DistributedPriorityQueue.put(Object, int)
but allows a maximum wait time if an upper bound was set viaQueueBuilder.maxItems
. - put(T, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
-
Same as
DistributedQueue.put(Object)
but allows a maximum wait time if an upper bound was set viaQueueBuilder.maxItems
. - put(T, long) - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
-
Add an item into the queue.
- put(T, long, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
-
Same as
DistributedDelayQueue.put(Object, long)
but allows a maximum wait time if an upper bound was set viaQueueBuilder.maxItems
. - put(T, String) - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
-
Put an item into the queue with the given Id
NOTE: if an upper bound was set viaQueueBuilder.maxItems
, this method will block until there is available space in the queue. - put(T, String, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
-
Same as
DistributedIdQueue.put(Object, String)
but allows a maximum wait time if an upper bound was set viaQueueBuilder.maxItems
. - putCompleted(T) - Method in interface org.apache.curator.framework.recipes.queue.QueuePutListener
-
Notification that a single item put has completed
- putInBackground(boolean) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
-
By default, messages are added in the background.
- putMulti(MultiItem<T>) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
-
Add a set of items into the queue.
- putMulti(MultiItem<T>, int) - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
-
Add a set of items with the same priority into the queue.
- putMulti(MultiItem<T>, int, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
-
Same as
DistributedPriorityQueue.putMulti(MultiItem, int)
but allows a maximum wait time if an upper bound was set viaQueueBuilder.maxItems
. - putMulti(MultiItem<T>, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
-
Same as
DistributedQueue.putMulti(MultiItem)
but allows a maximum wait time if an upper bound was set viaQueueBuilder.maxItems
. - putMulti(MultiItem<T>, long) - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
-
Add a set of items with the same priority into the queue.
- putMulti(MultiItem<T>, long, int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
-
Same as
DistributedDelayQueue.putMulti(MultiItem, long)
but allows a maximum wait time if an upper bound was set viaQueueBuilder.maxItems
. - putMultiCompleted(MultiItem<T>) - Method in interface org.apache.curator.framework.recipes.queue.QueuePutListener
-
Notification that a multi item put has completed
- putService(ServiceInstance<T>, String, String) - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
Q
- queryForInstance(String, String) - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
Return a service instance POJO
- queryForInstance(String, String) - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
Return a service instance POJO
- queryForInstances(String) - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
Return all known instances for the given service
- queryForInstances(String) - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
Return all known instances for the given service
- queryForNames() - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
Return the names of all known services
- queryForNames() - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
Return the names of all known services
- QueueAllocator<U,
T> - Interface in org.apache.curator.framework.recipes.queue - QueueBase<T> - Interface in org.apache.curator.framework.recipes.queue
- QueueBuilder<T> - Class in org.apache.curator.framework.recipes.queue
-
The builder for both
DistributedQueue
andDistributedPriorityQueue
- QueueConsumer<T> - Interface in org.apache.curator.framework.recipes.queue
-
Message Consumer
- QueuePutListener<T> - Interface in org.apache.curator.framework.recipes.queue
-
Queue puts are done in the background.
- QueueSafety<T> - Class in org.apache.curator.framework.recipes.queue
-
Parameter block for specifying queue safety with either
DistributedQueue
orDistributedPriorityQueue
- QueueSafety(String, QueueConsumer<T>) - Constructor for class org.apache.curator.framework.recipes.queue.QueueSafety
- QueueSerializer<T> - Interface in org.apache.curator.framework.recipes.queue
-
Helper to serialize/deserialize queue items
- QueueSharder<U,
T> - Class in org.apache.curator.framework.recipes.queue -
A utility for shard a distributed queue.
- QueueSharder(CuratorFramework, QueueAllocator<U, T>, String, String, QueueSharderPolicies) - Constructor for class org.apache.curator.framework.recipes.queue.QueueSharder
- QueueSharderPolicies - Class in org.apache.curator.framework.recipes.queue
-
Various policies/options for sharding.
- QueueSharderPolicies.Builder - Class in org.apache.curator.framework.recipes.queue
- quietly - Enum constant in enum org.apache.curator.x.async.api.DeleteOption
-
Prevents the reporting of
KeeperException.NoNodeException
s. - quietly - Enum constant in enum org.apache.curator.x.async.api.RemoveWatcherOption
-
Prevents the reporting of
KeeperException.NoNodeException
s. - quietly() - Method in interface org.apache.curator.framework.api.Quietly
- quietly() - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- quietly() - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- Quietly<T> - Interface in org.apache.curator.framework.api
- QuorumConfigBuilder - Class in org.apache.curator.test
- QuorumConfigBuilder(Collection<InstanceSpec>) - Constructor for class org.apache.curator.test.QuorumConfigBuilder
- QuorumConfigBuilder(InstanceSpec...) - Constructor for class org.apache.curator.test.QuorumConfigBuilder
- QuorumPeerConfigBuilder - Class in org.apache.curator.test
R
- RandomStrategy<T> - Class in org.apache.curator.x.discovery.strategies
-
This strategy always picks a random instance from the list
- RandomStrategy() - Constructor for class org.apache.curator.x.discovery.strategies.RandomStrategy
- raw - Static variable in interface org.apache.curator.x.async.modeled.ModelSerializer
-
A pass through serializer
- read() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- read() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Read the ZNode at this instance's path and deserialize into a model
- read() - Method in interface org.apache.curator.x.async.modeled.versioned.VersionedModeledFramework
- read(Stat) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- read(Stat) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Read the ZNode at this instance's path and deserialize into a model
- read(Stat) - Method in interface org.apache.curator.x.async.modeled.versioned.VersionedModeledFramework
- READ_ONLY - Enum constant in enum org.apache.curator.framework.state.ConnectionState
-
The connection has gone into read-only mode.
- readAsZNode() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- readAsZNode() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Read the ZNode at this instance's path and deserialize into a model
- readFrom(Class<ServiceInstances<T>>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
- readFrom(Class<ServiceNames>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
- readFrom(Class<ServiceInstance<T>>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
- readLock() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock
-
Returns the lock used for reading.
- ReadLock(CuratorFramework, String, byte[], InterProcessReadWriteLock.WriteLock) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock.ReadLock
- readPerson(PersonModelSpec, ContainerType, PersonId, Consumer<PersonModel>) - Static method in class modeled.ModeledCuratorExamplesAlt
- readPerson(ModeledFramework<PersonModel>, String, Consumer<PersonModel>) - Static method in class modeled.ModeledCuratorExamples
- readThrough() - Method in interface org.apache.curator.x.async.modeled.cached.CachedModeledFramework
-
Same as
ModeledFramework.read()
except that if the cache does not have a value for this path a direct query is made. - readThrough(Stat) - Method in interface org.apache.curator.x.async.modeled.cached.CachedModeledFramework
-
Same as
ModeledFramework.read(org.apache.zookeeper.data.Stat)
except that if the cache does not have a value for this path a direct query is made. - readThroughAsZNode() - Method in interface org.apache.curator.x.async.modeled.cached.CachedModeledFramework
-
Same as
ModeledFramework.readAsZNode()
except that if the cache does not have a value for this path a direct query is made. - rebuild() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
Deprecated.NOTE: this is a BLOCKING method.
- rebuild() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.NOTE: this is a BLOCKING method.
- rebuildNode(String) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.NOTE: this is a BLOCKING method.
- reconfig() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a reconfig builder
- reconfig() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- reconfig() - Method in interface org.apache.curator.x.async.api.AsyncCuratorFrameworkDsl
-
Start a reconfig builder
- reconfig() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- RECONFIG - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.reconfig()
- ReconfigBuilder - Interface in org.apache.curator.framework.api
- ReconfigBuilderImpl - Class in org.apache.curator.framework.imps
- ReconfigBuilderImpl(CuratorFrameworkImpl) - Constructor for class org.apache.curator.framework.imps.ReconfigBuilderImpl
- ReconfigBuilderImpl(CuratorFrameworkImpl, Backgrounding, Stat, long, List<String>, List<String>, List<String>) - Constructor for class org.apache.curator.framework.imps.ReconfigBuilderImpl
- ReconfigBuilderMain - Interface in org.apache.curator.framework.api
- RECONNECTED - Enum constant in enum org.apache.curator.framework.state.ConnectionState
-
A suspended, lost, or read-only connection has been re-established
- registerJMX() - Method in class org.apache.curator.test.TestingZooKeeperMain.TestZooKeeperServer
- registerService(ServiceInstance<T>) - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
Register/re-register/update a service instance
- registerService(ServiceInstance<T>) - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
Register/re-register a service
- registrationTimeUTC(long) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
- release() - Method in class org.apache.curator.connection.ThreadLocalRetryLoop
-
Must be called to release the retry loop.
- release() - Method in interface org.apache.curator.framework.recipes.locks.InterProcessLock
-
Perform one release of the mutex.
- release() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMultiLock
-
Perform one release of the mutex.
- release() - Method in class org.apache.curator.framework.recipes.locks.InterProcessMutex
-
Perform one release of the mutex if the calling thread is the same thread that acquired it.
- release() - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreMutex
-
Perform one release of the mutex.
- release(InterProcessLock) - Static method in class org.apache.curator.x.async.AsyncWrappers
-
Release the lock and wrap any exception in
RuntimeException
- release(InterProcessLock, boolean) - Static method in class org.apache.curator.x.async.AsyncWrappers
-
Release the lock and wrap any exception in
RuntimeException
- releaseLock() - Method in class org.apache.curator.framework.recipes.locks.Locker
- remove() - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
-
Attempts to remove the head of the queue and return it.
- remove(String) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
-
Remove the entry from storage and return any previous entry at that path
- remove(String) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.
- remove(String) - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
-
Remove any items with the given Id
- remove(CuratorWatcher) - Method in interface org.apache.curator.framework.api.RemoveWatchesBuilder
-
Specify the watcher to be removed
- remove(CuratorWatcher) - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- remove(UriSpec.Part) - Method in class org.apache.curator.x.discovery.UriSpec
-
Remove the given part
- remove(Watcher) - Method in interface org.apache.curator.framework.api.RemoveWatchesBuilder
-
Specify the watcher to be removed
- remove(Watcher) - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- REMOVE - Enum constant in enum org.apache.curator.framework.recipes.queue.DistributedQueue.ProcessType
- REMOVE_WATCHES - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.watchers()
()} - removeAll() - Method in interface org.apache.curator.framework.api.RemoveWatchesBuilder
-
Specify that all watches should be removed
- removeAll() - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- removeBarrier() - Method in class org.apache.curator.framework.recipes.barriers.DistributedBarrier
-
Utility to remove the barrier node
- removeListener(K) - Method in class org.apache.curator.framework.listen.MappingListenerManager
- removeListener(LeaderLatchListener) - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Removes a given listener from this LeaderLatch
- removeListener(SharedCountListener) - Method in class org.apache.curator.framework.recipes.shared.SharedCount
- removeListener(ServiceCacheListener) - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
- removeListener(T) - Method in interface org.apache.curator.framework.listen.Listenable
-
Remove the given listener
- removeListener(T) - Method in class org.apache.curator.framework.listen.StandardListenerManager
- removeService(String, String) - Method in class org.apache.curator.x.discovery.server.rest.DiscoveryResource
- RemoveWatcherOption - Enum in org.apache.curator.x.async.api
-
Options to use when removing watchers
- removeWatchers() - Method in interface org.apache.curator.framework.WatcherRemoveCuratorFramework
-
Remove all outstanding watchers that have been set
- removeWatches() - Method in interface org.apache.curator.x.async.api.AsyncCuratorFrameworkDsl
-
Start a remove watches builder
- removeWatches() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- RemoveWatchesBuilder - Interface in org.apache.curator.framework.api
-
Builder to allow watches to be removed
- RemoveWatchesBuilderImpl - Class in org.apache.curator.framework.imps
- RemoveWatchesBuilderImpl(CuratorFrameworkImpl) - Constructor for class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- RemoveWatchesBuilderImpl(CuratorFrameworkImpl, Watcher, CuratorWatcher, Watcher.WatcherType, boolean, boolean, boolean, Backgrounding) - Constructor for class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- RemoveWatchesLocal - Interface in org.apache.curator.framework.api
-
Builder to allow the specification of whether it is acceptable to remove client side watch information in the case where ZK cannot be contacted.
- RemoveWatchesType - Interface in org.apache.curator.framework.api
-
Builder to allow the specification of whether it is acceptable to remove client side watch information in the case where ZK cannot be contacted.
- removing(CuratorWatcher) - Method in interface org.apache.curator.x.async.api.AsyncRemoveWatchesBuilder
- removing(CuratorWatcher, Set<RemoveWatcherOption>) - Method in interface org.apache.curator.x.async.api.AsyncRemoveWatchesBuilder
- removing(CuratorWatcher, Watcher.WatcherType) - Method in interface org.apache.curator.x.async.api.AsyncRemoveWatchesBuilder
-
Remove a watcher of a given type
- removing(CuratorWatcher, Watcher.WatcherType, Set<RemoveWatcherOption>) - Method in interface org.apache.curator.x.async.api.AsyncRemoveWatchesBuilder
-
Remove a watcher of a given type
- removing(Watcher) - Method in interface org.apache.curator.x.async.api.AsyncRemoveWatchesBuilder
- removing(Watcher, Set<RemoveWatcherOption>) - Method in interface org.apache.curator.x.async.api.AsyncRemoveWatchesBuilder
- removing(Watcher, Watcher.WatcherType) - Method in interface org.apache.curator.x.async.api.AsyncRemoveWatchesBuilder
-
Remove a watcher of a given type
- removing(Watcher, Watcher.WatcherType, Set<RemoveWatcherOption>) - Method in interface org.apache.curator.x.async.api.AsyncRemoveWatchesBuilder
-
Remove a watcher of a given type
- removingAll() - Method in interface org.apache.curator.x.async.api.AsyncRemoveWatchesBuilder
-
Remove all watchers
- removingAll(Set<RemoveWatcherOption>) - Method in interface org.apache.curator.x.async.api.AsyncRemoveWatchesBuilder
-
Remove all watchers
- removingAll(Watcher.WatcherType) - Method in interface org.apache.curator.x.async.api.AsyncRemoveWatchesBuilder
-
Remove all watchers of a given type
- removingAll(Watcher.WatcherType, Set<RemoveWatcherOption>) - Method in interface org.apache.curator.x.async.api.AsyncRemoveWatchesBuilder
-
Remove all watchers of a given type
- requeue() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
Re-queue an attempt for leadership.
- REQUEUE - Enum constant in enum org.apache.curator.framework.recipes.queue.ErrorMode
-
If the consumer throws an exception, requeue the message.
- reset() - Method in class org.apache.curator.CuratorZookeeperClient
-
For internal use only - reset the internally managed ZK handle
- reset() - Method in class org.apache.curator.framework.EnsureContainers
-
Reset so that the next call to
EnsureContainers.ensure()
will attempt to create containers - reset() - Static method in class org.apache.curator.test.InstanceSpec
- reset() - Method in exception class org.apache.curator.x.async.AsyncEventException
-
ZooKeeper temporarily triggers watchers when there is a connection event.
- Resolvable - Interface in org.apache.curator.x.async.modeled
- resolved() - Method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec0
- resolved() - Method in interface org.apache.curator.x.async.modeled.typed.TypedZPath0
- resolved(Object...) - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- resolved(Object...) - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return a new CuratorModel instance with all the same options but using a resolved path by calling
ZPath.resolved(Object...)
using the given parameters - resolved(Object...) - Method in interface org.apache.curator.x.async.modeled.Resolvable
-
When creating paths, any node in the path can be set to
ZPath.parameter()
. - resolved(Object...) - Method in interface org.apache.curator.x.async.modeled.ZPath
-
When creating paths, any node in the path can be set to
ZPath.parameter()
. - resolved(List<Object>) - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- resolved(List<Object>) - Method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- resolved(List<Object>) - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return a new CuratorModel instance with all the same options but using a resolved path by calling
ZPath.resolved(java.util.List)
using the given parameters - resolved(List<Object>) - Method in interface org.apache.curator.x.async.modeled.Resolvable
-
When creating paths, any node in the path can be set to
ZPath.parameter()
. - resolved(List<Object>) - Method in interface org.apache.curator.x.async.modeled.ZPath
-
When creating paths, any node in the path can be set to
ZPath.parameter()
. - resolved(ContainerType, PersonId) - Method in class modeled.PersonModelSpec
- resolved(AsyncCuratorFramework) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework0
- resolved(AsyncCuratorFramework, P1) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework
-
Resolve into a ModeledFramework using the given parameter
- resolved(AsyncCuratorFramework, P1, P2) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework2
- resolved(AsyncCuratorFramework, P1, P2, P3) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework3
- resolved(AsyncCuratorFramework, P1, P2, P3, P4) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework4
- resolved(AsyncCuratorFramework, P1, P2, P3, P4, P5) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework5
- resolved(AsyncCuratorFramework, P1, P2, P3, P4, P5, P6) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework6
- resolved(AsyncCuratorFramework, P1, P2, P3, P4, P5, P6, P7) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework7
- resolved(AsyncCuratorFramework, P1, P2, P3, P4, P5, P6, P7, P8) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework8
- resolved(AsyncCuratorFramework, P1, P2, P3, P4, P5, P6, P7, P8, P9) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework9
- resolved(AsyncCuratorFramework, P1, P2, P3, P4, P5, P6, P7, P8, P9, P10) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModeledFramework10
- resolved(P1) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec
-
Resolve into a ZPath using the given parameter
- resolved(P1, P2) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec2
- resolved(P1, P2, P3) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec3
- resolved(P1, P2, P3, P4) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec4
- resolved(P1, P2, P3, P4, P5) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec5
- resolved(P1, P2, P3, P4, P5, P6) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec6
- resolved(P1, P2, P3, P4, P5, P6, P7) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec7
- resolved(P1, P2, P3, P4, P5, P6, P7, P8) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec8
- resolved(P1, P2, P3, P4, P5, P6, P7, P8, P9) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec9
- resolved(P1, P2, P3, P4, P5, P6, P7, P8, P9, P10) - Method in interface org.apache.curator.x.async.modeled.typed.TypedModelSpec10
- resolved(T) - Method in interface org.apache.curator.x.async.modeled.typed.TypedZPath
-
Resolve into a ZPath using the given parameter
- resolved(T1, T2) - Method in interface org.apache.curator.x.async.modeled.typed.TypedZPath2
- resolved(T1, T2, T3) - Method in interface org.apache.curator.x.async.modeled.typed.TypedZPath3
- resolved(T1, T2, T3, T4) - Method in interface org.apache.curator.x.async.modeled.typed.TypedZPath4
- resolved(T1, T2, T3, T4, T5) - Method in interface org.apache.curator.x.async.modeled.typed.TypedZPath5
- resolved(T1, T2, T3, T4, T5, T6) - Method in interface org.apache.curator.x.async.modeled.typed.TypedZPath6
- resolved(T1, T2, T3, T4, T5, T6, T7) - Method in interface org.apache.curator.x.async.modeled.typed.TypedZPath7
- resolved(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface org.apache.curator.x.async.modeled.typed.TypedZPath8
- resolved(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface org.apache.curator.x.async.modeled.typed.TypedZPath9
- resolved(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in interface org.apache.curator.x.async.modeled.typed.TypedZPath10
- restart() - Method in class org.apache.curator.test.TestingServer
-
Restart the server.
- restart() - Method in class org.apache.curator.test.TestingZooKeeperServer
-
Restart the server.
- restartServer() - Method in class org.apache.curator.test.BaseClassForTests
- restartServer(InstanceSpec) - Method in class org.apache.curator.test.TestingCluster
-
Restart the given server of the cluster
- RETRY - Enum constant in enum org.apache.curator.SessionFailRetryLoop.Mode
-
If the session fails, retry the entire set of operations when
SessionFailRetryLoop.shouldContinue()
is called - RetryForever - Class in org.apache.curator.retry
-
RetryPolicy
implementation that always allowsRetry. - RetryForever(int) - Constructor for class org.apache.curator.retry.RetryForever
- RetryLoop - Class in org.apache.curator
-
Mechanism to perform an operation on Zookeeper that is safe against disconnections and "recoverable" errors.
- RetryLoop() - Constructor for class org.apache.curator.RetryLoop
- RetryNTimes - Class in org.apache.curator.retry
-
Retry policy that retries a max number of times
- RetryNTimes(int, int) - Constructor for class org.apache.curator.retry.RetryNTimes
- RetryOneTime - Class in org.apache.curator.retry
-
A retry policy that retries only once
- RetryOneTime(int) - Constructor for class org.apache.curator.retry.RetryOneTime
- retryPolicy(RetryPolicy) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- retryPolicy(RetryPolicy) - Method in class org.apache.curator.framework.recipes.atomic.PromotedToLock.Builder
-
Set the retry policy to use when an operation does not succeed
- RetryPolicy - Interface in org.apache.curator
-
Abstracts the policy to use when retrying connections
- RetrySleeper - Interface in org.apache.curator
-
Abstraction for retry policies to sleep
- RetryUntilElapsed - Class in org.apache.curator.retry
-
A retry policy that retries until a given amount of time elapses
- RetryUntilElapsed(int, int) - Constructor for class org.apache.curator.retry.RetryUntilElapsed
- returnAll(Collection<Lease>) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
-
Deprecated.Convenience method.
- returnAll(Collection<Lease>) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
-
Convenience method.
- returnLease(Lease) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphore
-
Deprecated.Convenience method.
- returnLease(Lease) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
-
Convenience method.
- Revocable<T> - Interface in org.apache.curator.framework.recipes.locks
-
Specifies locks that can be revoked
- RevocationListener<T> - Interface in org.apache.curator.framework.recipes.locks
- revocationRequested(T) - Method in interface org.apache.curator.framework.recipes.locks.RevocationListener
-
Called when a revocation request has been received.
- Revoker - Class in org.apache.curator.framework.recipes.locks
- root - Static variable in class org.apache.curator.x.async.modeled.details.ZPathImpl
- root - Static variable in interface org.apache.curator.x.async.modeled.ZPath
-
The root path: "/"
- RoundRobinStrategy<T> - Class in org.apache.curator.x.discovery.strategies
-
This strategy rotates sequentially through the list of instances
- RoundRobinStrategy() - Constructor for class org.apache.curator.x.discovery.strategies.RoundRobinStrategy
- runSafe(Runnable) - Method in interface org.apache.curator.framework.CuratorFramework
-
Curator (and user) recipes can use this to run notifyAll and other blocking calls that might normally block ZooKeeper's event thread.
- runSafe(Runnable) - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- runSafeService(Executor) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Curator (and user) recipes will use this executor to call notifyAll and other blocking calls that might normally block ZooKeeper's event thread.
S
- schedule(Runnable, long, TimeUnit) - Method in class org.apache.curator.utils.CloseableScheduledExecutorService
-
Creates and executes a one-shot action that becomes enabled after the given delay.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.curator.utils.CloseableScheduledExecutorService
-
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given delay between the termination of one execution and the commencement of the next.
- schema() - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- schema() - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return a Curator schema that validates ZNodes at this model's path using this model's values
- Schema - Class in org.apache.curator.framework.schema
-
Represents and documents operations allowed for a given path pattern
- Schema.Allowance - Enum in org.apache.curator.framework.schema
- SchemaBuilder - Class in org.apache.curator.framework.schema
- schemaSet(SchemaSet) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Add an enforced schema set
- SchemaSet - Class in org.apache.curator.framework.schema
-
Collection of all schemas for a Curator instance
- SchemaSet(List<Schema>, boolean) - Constructor for class org.apache.curator.framework.schema.SchemaSet
-
Define a schema set.
- SchemaSetLoader - Class in org.apache.curator.framework.schema
-
Utility to load schems set from a JSON stream/file.
- SchemaSetLoader(JsonNode, SchemaSetLoader.SchemaValidatorMapper) - Constructor for class org.apache.curator.framework.schema.SchemaSetLoader
- SchemaSetLoader(Reader, SchemaSetLoader.SchemaValidatorMapper) - Constructor for class org.apache.curator.framework.schema.SchemaSetLoader
- SchemaSetLoader(String, SchemaSetLoader.SchemaValidatorMapper) - Constructor for class org.apache.curator.framework.schema.SchemaSetLoader
- SchemaSetLoader.SchemaValidatorMapper - Interface in org.apache.curator.framework.schema
-
Called to map a schema validator name in the JSON stream to an actual data validator
- SchemaValidator - Interface in org.apache.curator.framework.schema
- SchemaViolation - Exception Class in org.apache.curator.framework.schema
-
Thrown by the various
validation
methods in a Schema - SchemaViolation(String) - Constructor for exception class org.apache.curator.framework.schema.SchemaViolation
-
Deprecated.use
SchemaViolation(Schema, ViolatorData, String)
instance - SchemaViolation(Schema, String) - Constructor for exception class org.apache.curator.framework.schema.SchemaViolation
-
Deprecated.use
SchemaViolation(Schema, ViolatorData, String)
instance - SchemaViolation(Schema, SchemaViolation.ViolatorData, String) - Constructor for exception class org.apache.curator.framework.schema.SchemaViolation
- SchemaViolation.ViolatorData - Class in org.apache.curator.framework.schema
-
Data about the calling API that violated the schema
- seconds() - Method in class org.apache.curator.test.compatibility.Timing2
-
Return the base time in seconds
- seconds() - Method in class org.apache.curator.test.Timing
-
Return the base time in seconds
- sequential(Schema.Allowance) - Method in class org.apache.curator.framework.schema.SchemaBuilder
- serialize(ServiceInstance<T>) - Method in interface org.apache.curator.x.discovery.details.InstanceSerializer
-
Serialize an instance into bytes
- serialize(ServiceInstance<T>) - Method in class org.apache.curator.x.discovery.details.JsonInstanceSerializer
- serialize(T) - Method in interface org.apache.curator.framework.recipes.queue.QueueSerializer
-
Turn a queue item into bytes
- serialize(T) - Method in class org.apache.curator.x.async.modeled.JacksonModelSerializer
- serialize(T) - Method in interface org.apache.curator.x.async.modeled.ModelSerializer
-
Given a model return the serialized bytes
- serializer() - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- serializer() - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return the model's serializer
- serializer(InstanceSerializer<T>) - Method in class org.apache.curator.x.discovery.ServiceDiscoveryBuilder
-
optional - change the serializer used (the default is
JsonInstanceSerializer
- server - Variable in class org.apache.curator.test.BaseClassForTests
- serverCnxnClose(ServerCnxn) - Static method in class org.apache.curator.test.Compatibility
- serverCnxnFactoryCloseAll(ServerCnxnFactory) - Static method in class org.apache.curator.test.Compatibility
- ServiceCache<T> - Interface in org.apache.curator.x.discovery
- serviceCacheBuilder() - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
Allocate a new service cache builder.
- serviceCacheBuilder() - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
Allocate a new service cache builder.
- ServiceCacheBuilder<T> - Interface in org.apache.curator.x.discovery
- ServiceCacheImpl<T> - Class in org.apache.curator.x.discovery.details
- ServiceCacheListener - Interface in org.apache.curator.x.discovery.details
-
Listener for changes to a service cache
- ServiceDiscovery<T> - Interface in org.apache.curator.x.discovery
- ServiceDiscoveryBuilder<T> - Class in org.apache.curator.x.discovery
- ServiceDiscoveryImpl<T> - Class in org.apache.curator.x.discovery.details
-
A mechanism to register and query service instances using ZooKeeper
- ServiceDiscoveryImpl(CuratorFramework, String, InstanceSerializer<T>, ServiceInstance<T>, boolean) - Constructor for class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
- ServiceDiscoveryImpl(CuratorFramework, DiscoveryPathConstructor, InstanceSerializer<T>, ServiceInstance<T>, boolean) - Constructor for class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
- ServiceInstance<T> - Class in org.apache.curator.x.discovery
-
POJO that represents a service instance
- ServiceInstance(String, String, String, Integer, Integer, T, long, ServiceType, UriSpec) - Constructor for class org.apache.curator.x.discovery.ServiceInstance
- ServiceInstance(String, String, String, Integer, Integer, T, long, ServiceType, UriSpec, boolean) - Constructor for class org.apache.curator.x.discovery.ServiceInstance
-
IMPORTANT: Due to CURATOR-275 the
enabled
field is NOT supported by default. - ServiceInstanceBuilder<T> - Class in org.apache.curator.x.discovery
-
Builder for service instances
- ServiceInstances<T> - Class in org.apache.curator.x.discovery.server.entity
-
Raw generic lists don't work well in JAX-RS.
- ServiceInstances() - Constructor for class org.apache.curator.x.discovery.server.entity.ServiceInstances
- ServiceInstances(Collection<? extends ServiceInstance<T>>) - Constructor for class org.apache.curator.x.discovery.server.entity.ServiceInstances
- serviceName(String) - Method in interface org.apache.curator.x.discovery.ServiceProviderBuilder
-
required - set the name of the service to be provided
- ServiceNames - Class in org.apache.curator.x.discovery.server.entity
-
Raw generic lists don't work well in JAX-RS.
- ServiceNames() - Constructor for class org.apache.curator.x.discovery.server.entity.ServiceNames
- ServiceNames(Collection<? extends String>) - Constructor for class org.apache.curator.x.discovery.server.entity.ServiceNames
- ServiceProvider<T> - Interface in org.apache.curator.x.discovery
-
The main API for Discovery.
- serviceProviderBuilder() - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
Allocate a new builder.
- serviceProviderBuilder() - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
Allocate a new builder.
- ServiceProviderBuilder<T> - Interface in org.apache.curator.x.discovery
- ServiceProviderImpl<T> - Class in org.apache.curator.x.discovery.details
-
The main interface for Service Discovery.
- ServiceProviderImpl(ServiceDiscoveryImpl<T>, String, ProviderStrategy<T>, ThreadFactory, ExecutorService, List<InstanceFilter<T>>, DownInstancePolicy) - Constructor for class org.apache.curator.x.discovery.details.ServiceProviderImpl
- ServiceProviderImpl(ServiceDiscoveryImpl<T>, String, ProviderStrategy<T>, ThreadFactory, List<InstanceFilter<T>>, DownInstancePolicy) - Constructor for class org.apache.curator.x.discovery.details.ServiceProviderImpl
- serviceType(ServiceType) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
- ServiceType - Enum in org.apache.curator.x.discovery
- session() - Method in class org.apache.curator.test.compatibility.Timing2
-
Return the value to use for ZK session timeout
- session() - Method in class org.apache.curator.test.Timing
-
Return the value to use for ZK session timeout
- SessionConnectionStateErrorPolicy - Class in org.apache.curator.framework.state
-
This policy treats only
ConnectionState.LOST
as an error - SessionConnectionStateErrorPolicy() - Constructor for class org.apache.curator.framework.state.SessionConnectionStateErrorPolicy
- SessionFailedException() - Constructor for exception class org.apache.curator.SessionFailRetryLoop.SessionFailedException
- SessionFailedRetryPolicy - Class in org.apache.curator
-
RetryPolicy
implementation that failed on session expired. - SessionFailedRetryPolicy(RetryPolicy) - Constructor for class org.apache.curator.SessionFailedRetryPolicy
- SessionFailRetryLoop - Class in org.apache.curator
-
See
RetryLoop
for the main details on retry loops. - SessionFailRetryLoop.Mode - Enum in org.apache.curator
- SessionFailRetryLoop.SessionFailedException - Exception Class in org.apache.curator
- sessionTimeoutMs(int) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- set(Versioned<T>) - Method in interface org.apache.curator.x.async.modeled.versioned.VersionedModeledFramework
- set(Versioned<T>, Stat) - Method in interface org.apache.curator.x.async.modeled.versioned.VersionedModeledFramework
- set(T) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- set(T) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Create (or update depending on build options) a ZNode at this instance's path with a serialized version of the given model
- set(T, int) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- set(T, int) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Create (or update depending on build options) a ZNode at this instance's path with a serialized version of the given model
- set(T, Stat) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- set(T, Stat) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Create (or update depending on build options) a ZNode at this instance's path with a serialized form of the given model
- set(T, Stat, int) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- set(T, Stat, int) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Create (or update depending on build options) a ZNode at this instance's path with a serialized form of the given model
- SET_ACL - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.setACL()
- SET_DATA - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.setData()
- SET_DATA - Enum constant in enum org.apache.curator.framework.api.transaction.OperationType
- setACL() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a set ACL builder
- setACL() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- setACL() - Method in interface org.apache.curator.x.async.api.AsyncCuratorFrameworkDsl
-
Start a set ACL builder
- setACL() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- SetACLBuilder - Interface in org.apache.curator.framework.api
- SetACLBuilderImpl - Class in org.apache.curator.framework.imps
- SetACLBuilderImpl(CuratorFrameworkImpl, Backgrounding, List<ACL>, int) - Constructor for class org.apache.curator.framework.imps.SetACLBuilderImpl
- setBarrier() - Method in class org.apache.curator.framework.recipes.barriers.DistributedBarrier
-
Utility to set the barrier node
- setCacheData(boolean) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
Deprecated.Sets whether or not to cache byte data per node; default
true
. - setConnectionString(String) - Method in interface org.apache.curator.ensemble.EnsembleProvider
-
A new connection string event was received
- setConnectionString(String) - Method in class org.apache.curator.ensemble.fixed.FixedEnsembleProvider
- setCount(int) - Method in class org.apache.curator.framework.recipes.shared.SharedCount
-
Change the shared count value irrespective of its previous state
- setCreateParentNodes(boolean) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
Deprecated.By default, TreeCache does not auto-create parent nodes for the cached path.
- setData() - Method in interface org.apache.curator.framework.api.transaction.CuratorTransaction
-
Deprecated.Start a setData builder in the transaction
- setData() - Method in interface org.apache.curator.framework.api.transaction.TransactionOp
-
Start a setData builder in the transaction
- setData() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a set data builder
- setData() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- setData() - Method in class org.apache.curator.framework.imps.TransactionOpImpl
- setData() - Method in interface org.apache.curator.x.async.api.AsyncCuratorFrameworkDsl
-
Start a set data builder
- setData() - Method in interface org.apache.curator.x.async.api.AsyncTransactionOp
-
Start a setData builder in the transaction
- setData() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- setData(byte[]) - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
-
Set data that node should set in ZK also writes the data to the node.
- setData(byte[]) - Method in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
-
Set data that node should set in ZK also writes the data to the node.
- 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 org.apache.curator.framework.api
- SetDataBuilder - Interface in org.apache.curator.framework.api
- SetDataBuilderImpl - Class in org.apache.curator.framework.imps
- SetDataBuilderImpl(CuratorFrameworkImpl, Backgrounding, int, boolean) - Constructor for class org.apache.curator.framework.imps.SetDataBuilderImpl
- setDataIdempotent(CuratorFramework, String, byte[], int) - Static method in class framework.CrudExamples
- setDataIfExists - Enum constant in enum org.apache.curator.x.async.api.CreateOption
-
If the ZNode already exists, Curator will instead call setData()
- setDataIsCompressed(boolean) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
Deprecated.Sets whether or to decompress node data; default
false
. - setDescription(String) - Method in class discovery.InstanceDetails
- setErrorMode(ErrorMode) - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
- setErrorMode(ErrorMode) - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
- setErrorMode(ErrorMode) - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
- setErrorMode(ErrorMode) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
-
Used when the queue is created with a
QueueBuilder.lockPath(String)
. - setErrorMode(ErrorMode) - Method in interface org.apache.curator.framework.recipes.queue.QueueBase
-
Used when the queue is created with a
QueueBuilder.lockPath(String)
. - setExecuteCalled(boolean) - Method in class org.apache.curator.test.ExecuteCalledWatchingExecutorService
- setExecutor(ExecutorService) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
Deprecated.Sets the executor to publish events; a default executor will be created if not specified.
- setExecutor(ThreadFactory) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
Deprecated.Sets the executor to publish events; a default executor will be created if not specified.
- setId(String) - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
Sets the ID to store for this leader.
- setLocalIpFilter(LocalIpFilter) - Static method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
-
Replace the default local ip filter used by
ServiceInstanceBuilder.getAllLocalIPs()
- setMaxDepth(int) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
Deprecated.Sets the maximum depth to explore/watch.
- setNodeData(byte[]) - Method in class org.apache.curator.framework.recipes.locks.InterProcessSemaphoreV2
-
Set the data to put for the node created by this semaphore.
- setPath(String) - Method in class org.apache.curator.drivers.OperationTrace
- setRequestBytesLength(byte[]) - Method in class org.apache.curator.drivers.OperationTrace
- setRequestBytesLength(long) - Method in class org.apache.curator.drivers.OperationTrace
- setRequestBytesLength(String) - Method in class org.apache.curator.drivers.OperationTrace
- setResponseBytesLength(byte[]) - Method in class org.apache.curator.drivers.OperationTrace
- setResponseBytesLength(long) - Method in class org.apache.curator.drivers.OperationTrace
- setRetryPolicy(RetryPolicy) - Method in class org.apache.curator.CuratorZookeeperClient
-
Change the retry policy
- setReturnCode(int) - Method in class org.apache.curator.drivers.OperationTrace
- setSelector(TreeCacheSelector) - Method in class org.apache.curator.framework.recipes.cache.TreeCache.Builder
-
Deprecated.By default,
DefaultTreeCacheSelector
is used. - setSetDataIfExistsVersion(int) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- setStat(Stat) - Method in class org.apache.curator.drivers.OperationTrace
- setState(ZooKeeperServer.State) - Method in class org.apache.curator.test.TestingZooKeeperMain.TestZooKeeperServer
- setThisData(byte[]) - Method in class org.apache.curator.framework.recipes.nodes.GroupMember
-
Change the data stored in this instance's node
- setToSuspended() - Method in class org.apache.curator.framework.state.ConnectionStateManager
-
Change to
ConnectionState.SUSPENDED
only if not already suspended and not lost - setTracerDriver(TracerDriver) - Method in class org.apache.curator.CuratorZookeeperClient
-
Change the tracing driver
- setup() - Method in class org.apache.curator.test.BaseClassForTests
- setValue(byte[]) - Method in class org.apache.curator.framework.recipes.shared.SharedValue
-
Change the shared value irrespective of its previous state
- setWithWatcher(boolean) - Method in class org.apache.curator.drivers.OperationTrace
- SharedCount - Class in org.apache.curator.framework.recipes.shared
-
Manages a shared integer.
- SharedCount(CuratorFramework, String, int) - Constructor for class org.apache.curator.framework.recipes.shared.SharedCount
- SharedCount(CuratorFramework, String, SharedValue) - Constructor for class org.apache.curator.framework.recipes.shared.SharedCount
- SharedCountListener - Interface in org.apache.curator.framework.recipes.shared
-
Listener for changes to a shared count
- SharedCountReader - Interface in org.apache.curator.framework.recipes.shared
-
Abstracts a shared integer and allows listening for changes to its value
- SharedValue - Class in org.apache.curator.framework.recipes.shared
-
Manages a shared value.
- SharedValue(CuratorFramework, String, byte[]) - Constructor for class org.apache.curator.framework.recipes.shared.SharedValue
- SharedValue(WatcherRemoveCuratorFramework, String, byte[], CuratorWatcher) - Constructor for class org.apache.curator.framework.recipes.shared.SharedValue
- SharedValueListener - Interface in org.apache.curator.framework.recipes.shared
-
Listener for changes to a shared value
- SharedValueReader - Interface in org.apache.curator.framework.recipes.shared
-
Abstracts a shared value and allows listening for changes to the value
- shouldContinue() - Method in class org.apache.curator.RetryLoop
-
If true is returned, make an attempt at the operation
- shouldContinue() - Method in class org.apache.curator.SessionFailRetryLoop
-
If true is returned, make an attempt at the set of operations
- shutdown() - Method in class org.apache.curator.test.DelegatingExecutorService
- shutdown(boolean) - Method in class org.apache.curator.test.TestingZooKeeperMain.TestZooKeeperServer
- shutdownNow() - Method in class org.apache.curator.test.DelegatingExecutorService
- SILENT - Enum constant in enum org.apache.curator.framework.recipes.leader.LeaderLatch.CloseMode
-
When the latch is closed, listeners will *not* be notified (default behavior)
- SimpleDistributedQueue - Class in org.apache.curator.framework.recipes.queue
-
Drop in replacement for: org.apache.zookeeper.recipes.queue.DistributedQueue that is part of the ZooKeeper distribution
- SimpleDistributedQueue(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
- simulatedSessionExpirationPercent(int) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Prior to 3.0.0, Curator did not try to manage session expiration other than the functionality provided by ZooKeeper itself.
- SINGLE_NODE_CACHE - Enum constant in enum org.apache.curator.framework.recipes.cache.CuratorCache.Options
-
Normally the entire tree of nodes starting at the given node are cached.
- size() - Method in interface org.apache.curator.framework.listen.ListenerManager
-
Return the number of listeners
- size() - Method in class org.apache.curator.framework.listen.MappingListenerManager
- size() - Method in class org.apache.curator.framework.listen.StandardListenerManager
- size() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCache
-
Return the current number of entries in storage
- size() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheAccessor
-
Return the current number of entries in storage
- size() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
-
Return the current number of entries in storage
- size() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
Deprecated.Return the number of nodes in the cache.
- size() - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
-
Returns the number of currently queue items
- size() - Method in class org.apache.curator.test.QuorumConfigBuilder
- sleep() - Method in class org.apache.curator.test.compatibility.Timing2
-
Sleep for a the full amount of time
- sleepABit() - Method in class org.apache.curator.test.compatibility.Timing2
-
Sleep for a small amount of time
- sleepABit() - Method in class org.apache.curator.test.Timing
-
Sleep for a small amount of time
- sleepFor(long, TimeUnit) - Method in interface org.apache.curator.RetrySleeper
-
Sleep for the given time
- sortChildren(List<String>) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
- split(String) - Static method in class org.apache.curator.utils.ZKPaths
-
Given a full path, return the the individual parts, without slashes.
- sslPort(int) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
- standard - Static variable in interface org.apache.curator.framework.state.ConnectionStateListenerManagerFactory
-
Pass through
- standard() - Static method in class org.apache.curator.framework.listen.StandardListenerManager
-
Returns a new standard listener container
- standard() - Static method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
-
Return a new standard storage instance
- StandardConnectionStateErrorPolicy - Class in org.apache.curator.framework.state
-
This policy treats
ConnectionState.SUSPENDED
andConnectionState.LOST
as errors - StandardConnectionStateErrorPolicy() - Constructor for class org.apache.curator.framework.state.StandardConnectionStateErrorPolicy
- standardFixForSorting(String, String) - Static method in class org.apache.curator.framework.recipes.locks.StandardLockInternalsDriver
- StandardListenerManager<T> - Class in org.apache.curator.framework.listen
-
Non mapping version of a listener container
- StandardLockInternalsDriver - Class in org.apache.curator.framework.recipes.locks
- StandardLockInternalsDriver() - Constructor for class org.apache.curator.framework.recipes.locks.StandardLockInternalsDriver
- start() - Method in class discovery.ExampleServer
- start() - Method in class leader.ExampleClient
- start() - Method in class org.apache.curator.CuratorZookeeperClient
-
Must be called after construction
- start() - Method in interface org.apache.curator.ensemble.EnsembleProvider
-
Curator will call this method when
CuratorZookeeperClient.start()
is called - start() - Method in class org.apache.curator.ensemble.fixed.FixedEnsembleProvider
- start() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start the client.
- start() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- start() - Method in class org.apache.curator.framework.imps.EnsembleTracker
- start() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCache
-
Start the cache.
- start() - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
Deprecated.Start the cache.
- start() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.Start the cache.
- start() - Method in class org.apache.curator.framework.recipes.cache.TreeCache
-
Deprecated.Start the cache.
- start() - Method in class org.apache.curator.framework.recipes.leader.LeaderLatch
-
Add this instance to the leadership election and attempt to acquire leadership.
- start() - Method in class org.apache.curator.framework.recipes.leader.LeaderSelector
-
Attempt leadership.
- start() - Method in class org.apache.curator.framework.recipes.nodes.GroupMember
-
Start the group membership.
- start() - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
-
You must call start() to initiate the persistent node.
- start() - Method in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
-
You must call start() to initiate the persistent ttl node
- start() - Method in class org.apache.curator.framework.recipes.queue.DistributedDelayQueue
-
Start the queue.
- start() - Method in class org.apache.curator.framework.recipes.queue.DistributedIdQueue
- start() - Method in class org.apache.curator.framework.recipes.queue.DistributedPriorityQueue
-
Start the queue.
- start() - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
-
Start the queue.
- start() - Method in interface org.apache.curator.framework.recipes.queue.QueueBase
-
Start the queue.
- start() - Method in class org.apache.curator.framework.recipes.queue.QueueSharder
-
The sharder must be started
- start() - Method in class org.apache.curator.framework.recipes.shared.SharedCount
-
The shared count must be started before it can be used.
- start() - Method in class org.apache.curator.framework.recipes.shared.SharedValue
-
The shared value must be started before it can be used.
- start() - Method in class org.apache.curator.framework.recipes.watch.PersistentWatcher
-
Start watching
- start() - Method in class org.apache.curator.framework.state.ConnectionStateManager
-
Start the manager
- start() - Method in class org.apache.curator.SessionFailRetryLoop
-
SessionFailRetryLoop must be started
- start() - Method in class org.apache.curator.test.TestingCluster
-
Start the ensemble.
- start() - Method in class org.apache.curator.test.TestingServer
-
Start the server
- start() - Method in class org.apache.curator.test.TestingZooKeeperServer
- start() - Method in interface org.apache.curator.x.async.modeled.cached.CachedModeledFramework
-
Start the internally created cache
- start() - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
- start() - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
The discovery must be started before use
- start() - Method in class org.apache.curator.x.discovery.details.ServiceProviderImpl
-
The provider must be started before use
- start() - Method in class org.apache.curator.x.discovery.server.rest.InstanceCleanup
-
Start the task
- start() - Method in interface org.apache.curator.x.discovery.ServiceCache
-
The cache must be started before use
- start() - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
The discovery must be started before use
- start() - Method in interface org.apache.curator.x.discovery.ServiceProvider
-
The provider must be started before use
- start() - Method in class pubsub.SubPubTest
- start(boolean) - Method in class org.apache.curator.framework.recipes.cache.NodeCache
-
Deprecated.Same as
NodeCache.start()
but gives the option of doing an initial build - start(boolean) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.
- start(PathChildrenCache.StartMode) - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCache
-
Deprecated.Start the cache.
- start(QuorumPeerConfigBuilder) - Method in class org.apache.curator.test.TestingZooKeeperMain
- start(QuorumPeerConfigBuilder) - Method in class org.apache.curator.test.ZooKeeperServerEmbeddedAdapter
- startAdvancedTracer(String) - Method in class org.apache.curator.CuratorZookeeperClient
-
Start a new advanced tracer with more metrics being recorded
- STARTED - Enum constant in enum org.apache.curator.framework.imps.CuratorFrameworkState
-
CuratorFramework.start()
has been called - STARTED - Enum constant in enum org.apache.curator.framework.recipes.leader.LeaderLatch.State
- startImmediate() - Method in class org.apache.curator.x.discovery.details.ServiceCacheImpl
- startImmediate() - Method in interface org.apache.curator.x.discovery.ServiceCache
- startInstanceSubscriber(InstanceType) - Method in class pubsub.Subscriber
-
Start a subscriber (a CachedModeledFramework instance) using the Instance client template
- startLocationAvailableSubscriber(Group, Priority) - Method in class pubsub.Subscriber
-
Start a subscriber (a CachedModeledFramework instance) using the LocationAvailable client template
- startsWith(ZPath) - Method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- startsWith(ZPath) - Method in interface org.apache.curator.x.async.modeled.ZPath
-
Return true if this path starts with the given path.
- startTracer(String) - Method in class org.apache.curator.CuratorZookeeperClient
-
Start a new tracer
- startUserCreatedSubscriber(Group, Priority) - Method in class pubsub.Subscriber
-
Start a subscriber (a CachedModeledFramework instance) using the UserCreated client template
- stat() - Method in class org.apache.curator.x.async.modeled.details.ZNodeImpl
- stat() - Method in interface org.apache.curator.x.async.modeled.ZNode
-
The node's last known stat if available
- Statable<T> - Interface in org.apache.curator.framework.api
- StatConfigureEnsembleable - Interface in org.apache.curator.framework.api
- stateChangeAndSuccess - Enum constant in enum org.apache.curator.x.async.WatchMode
-
The
CompletionStage
<org.apache.zookeeper.WatchedEvent> will complete for both successful trigger and connection exceptions. - stateChanged(CuratorFramework, ConnectionState) - Method in class org.apache.curator.framework.recipes.leader.LeaderSelectorListenerAdapter
- stateChanged(CuratorFramework, ConnectionState) - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
- stateChanged(CuratorFramework, ConnectionState) - Method in class org.apache.curator.framework.state.CircuitBreakingConnectionStateListener
- stateChanged(CuratorFramework, ConnectionState) - Method in interface org.apache.curator.framework.state.ConnectionStateListener
-
Called when there is a state change in the connection
- stateChangeOnly - Enum constant in enum org.apache.curator.x.async.WatchMode
-
The
CompletionStage
<org.apache.zookeeper.WatchedEvent> will only completeExceptionally. - STATIC - Enum constant in enum org.apache.curator.x.discovery.ServiceType
- StatPathable<T> - Interface in org.apache.curator.framework.api
- StickyStrategy<T> - Class in org.apache.curator.x.discovery.strategies
-
This strategy uses a master strategy to pick the initial instance.
- StickyStrategy(ProviderStrategy<T>) - Constructor for class org.apache.curator.x.discovery.strategies.StickyStrategy
- stop() - Method in class org.apache.curator.test.TestingCluster
-
Shutdown the ensemble WITHOUT freeing resources, etc.
- stop() - Method in class org.apache.curator.test.TestingServer
-
Stop the server without deleting the temp directory
- stop() - Method in class org.apache.curator.test.TestingZooKeeperServer
- STOPPED - Enum constant in enum org.apache.curator.framework.imps.CuratorFrameworkState
-
CuratorFramework.close()
has been called - storingStatIn(Stat) - Method in interface org.apache.curator.framework.api.Statable
-
Have the operation fill the provided stat object
- storingStatIn(Stat) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- storingStatIn(Stat) - Method in class org.apache.curator.framework.imps.GetACLBuilderImpl
- storingStatIn(Stat) - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- storingStatIn(Stat) - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- storingStatIn(Stat) - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- storingStatIn(Stat) - Method in interface org.apache.curator.x.async.api.AsyncCreateBuilder
-
Have the operation fill the provided stat object
- storingStatIn(Stat) - Method in interface org.apache.curator.x.async.api.AsyncGetACLBuilder
-
Have the operation fill the provided stat object
- storingStatIn(Stat) - Method in interface org.apache.curator.x.async.api.AsyncGetChildrenBuilder
-
Have the operation fill the provided stat object
- storingStatIn(Stat) - Method in interface org.apache.curator.x.async.api.AsyncGetConfigBuilder
-
Have the operation fill the provided stat object
- storingStatIn(Stat) - Method in interface org.apache.curator.x.async.api.AsyncGetDataBuilder
-
Have the operation fill the provided stat object
- stream() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCache
-
Return a stream over the storage entries.
- stream() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheAccessor
-
Return a stream over the storage entries.
- stream() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheStorage
-
Return a stream over the storage entries.
- StringDiscoveryContext - Class in org.apache.curator.x.discovery.server.contexts
-
For convenience, a version of
DiscoveryContext
that uses a string as the payload - StringDiscoveryContext(ServiceDiscovery<String>, ProviderStrategy<String>, int) - Constructor for class org.apache.curator.x.discovery.server.contexts.StringDiscoveryContext
- submit(Runnable) - Method in class org.apache.curator.test.DelegatingExecutorService
- submit(Runnable) - Method in class org.apache.curator.utils.CloseableExecutorService
-
Submits a Runnable task for execution and returns a Future representing that task.
- submit(Runnable, T) - Method in class org.apache.curator.test.DelegatingExecutorService
- submit(Callable<T>) - Method in class org.apache.curator.test.DelegatingExecutorService
- submit(Callable<V>) - Method in class org.apache.curator.utils.CloseableExecutorService
-
Submits a value-returning task for execution and returns a Future representing the pending results of the task.
- SubPubTest - Class in pubsub
- SubPubTest() - Constructor for class pubsub.SubPubTest
- Subscriber - Class in pubsub
- Subscriber(AsyncCuratorFramework) - Constructor for class pubsub.Subscriber
- subtract(Integer) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
-
Subtract delta from the current value and return the new value information.
- subtract(Long) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
-
Subtract delta from the current value and return the new value information.
- subtract(T) - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
-
Subtract delta from the current value and return the new value information.
- succeeded() - Method in interface org.apache.curator.framework.recipes.atomic.AtomicValue
-
MUST be checked. Returns true if the operation succeeded.
- successOnly - Enum constant in enum org.apache.curator.x.async.WatchMode
-
The
CompletionStage
<org.apache.zookeeper.WatchedEvent> will only complete on successful trigger. - SUSPENDED - Enum constant in enum org.apache.curator.framework.state.ConnectionState
-
There has been a loss of connection.
- sync() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a sync builder.
- sync() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- sync() - Method in interface org.apache.curator.x.async.api.AsyncCuratorFrameworkDsl
-
Start a sync builder
- sync() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- sync(String, Object) - Method in interface org.apache.curator.framework.CuratorFramework
-
Deprecated.use
CuratorFramework.sync()
instead - sync(String, Object) - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- SYNC - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.sync()
- SyncBuilder - Interface in org.apache.curator.framework.api
- SyncBuilderImpl - Class in org.apache.curator.framework.imps
- SyncBuilderImpl(CuratorFrameworkImpl) - Constructor for class org.apache.curator.framework.imps.SyncBuilderImpl
- SyncBuilderImpl(CuratorFrameworkImpl, Backgrounding) - Constructor for class org.apache.curator.framework.imps.SyncBuilderImpl
T
- take() - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
-
Take the next item from the queue, blocking until there is an item available
- take() - Method in class org.apache.curator.framework.recipes.queue.SimpleDistributedQueue
-
Removes the head of the queue and returns it, blocks until it succeeds.
- take(int, TimeUnit) - Method in class org.apache.curator.framework.recipes.queue.BlockingQueueConsumer
-
Take the next item from the queue, waiting up to the specified time for an available item.
- takeException(Exception) - Method in class org.apache.curator.RetryLoop
-
Pass any caught exceptions here
- takeException(Exception) - Method in class org.apache.curator.SessionFailRetryLoop
-
Pass any caught exceptions here
- takeFromQueue(BlockingQueue<T>) - Method in class org.apache.curator.test.compatibility.Timing2
-
Try to take an item from the given queue
- takeLeadership(CuratorFramework) - Method in class leader.ExampleClient
- takeLeadership(CuratorFramework) - Method in interface org.apache.curator.framework.recipes.leader.LeaderSelectorListener
-
Called when your instance has been granted leadership.
- teardown() - Method in class org.apache.curator.test.BaseClassForTests
- TempGetDataBuilder - Interface in org.apache.curator.framework.api
- TestingCluster - Class in org.apache.curator.test
-
manages an internally running ensemble of ZooKeeper servers.
- TestingCluster(int) - Constructor for class org.apache.curator.test.TestingCluster
-
Creates an ensemble comprised of
n
servers. - TestingCluster(Collection<InstanceSpec>) - Constructor for class org.apache.curator.test.TestingCluster
-
Creates an ensemble using the given server specs
- TestingCluster(Map<InstanceSpec, Collection<InstanceSpec>>) - Constructor for class org.apache.curator.test.TestingCluster
-
Creates an ensemble using the given server specs
- TestingCluster(InstanceSpec...) - Constructor for class org.apache.curator.test.TestingCluster
-
Creates an ensemble using the given server specs
- TestingServer - Class in org.apache.curator.test
-
manages an internally running ZooKeeper server.
- TestingServer() - Constructor for class org.apache.curator.test.TestingServer
-
Create the server using a random port
- TestingServer(boolean) - Constructor for class org.apache.curator.test.TestingServer
-
Create the server using a random port
- TestingServer(int) - Constructor for class org.apache.curator.test.TestingServer
-
Create and start the server using the given port
- TestingServer(int, boolean) - Constructor for class org.apache.curator.test.TestingServer
-
Create the server using the given port
- TestingServer(int, File) - Constructor for class org.apache.curator.test.TestingServer
-
Create and start the server using the given port
- TestingServer(int, File, boolean) - Constructor for class org.apache.curator.test.TestingServer
-
Create the server using the given port
- TestingServer(InstanceSpec, boolean) - Constructor for class org.apache.curator.test.TestingServer
-
Create the server using the given port
- TestingZooKeeperMain - Class in org.apache.curator.test
- TestingZooKeeperMain() - Constructor for class org.apache.curator.test.TestingZooKeeperMain
- TestingZooKeeperMain.TestZooKeeperServer - Class in org.apache.curator.test
- TestingZooKeeperServer - Class in org.apache.curator.test
-
Thanks to Jeremie BORDIER (ahfeel) for this code
- TestingZooKeeperServer(QuorumConfigBuilder) - Constructor for class org.apache.curator.test.TestingZooKeeperServer
- TestingZooKeeperServer(QuorumConfigBuilder, int) - Constructor for class org.apache.curator.test.TestingZooKeeperServer
- TestZooKeeperServer(FileTxnSnapLog, ServerConfig) - Constructor for class org.apache.curator.test.TestingZooKeeperMain.TestZooKeeperServer
- thisInstance(ServiceInstance<T>) - Method in class org.apache.curator.x.discovery.ServiceDiscoveryBuilder
-
Optional - instance that represents the service that is running.
- threadFactory(ThreadFactory) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- threadFactory(ThreadFactory) - Method in class org.apache.curator.framework.recipes.queue.QueueBuilder
-
Change the thread factory used.
- threadFactory(ThreadFactory) - Method in class org.apache.curator.framework.recipes.queue.QueueSharderPolicies.Builder
-
Change the thread factory that's used to create the sharder's thread
- threadFactory(ThreadFactory) - Method in interface org.apache.curator.x.discovery.ServiceCacheBuilder
-
Deprecated.
- threadFactory(ThreadFactory) - Method in interface org.apache.curator.x.discovery.ServiceProviderBuilder
-
Deprecated.
- ThreadLocalRetryLoop - Class in org.apache.curator.connection
-
Retry loops can easily end up getting nested which can cause exponential calls of the retry policy (see https://issues.apache.org/jira/browse/CURATOR-559).
- ThreadLocalRetryLoop() - Constructor for class org.apache.curator.connection.ThreadLocalRetryLoop
- ThreadUtils - Class in org.apache.curator.utils
- ThreadUtils() - Constructor for class org.apache.curator.utils.ThreadUtils
- thresholdCheckMs(int) - Method in class org.apache.curator.framework.recipes.queue.QueueSharderPolicies.Builder
-
Change the threshold check.
- tickTime() - Method in class org.apache.curator.test.compatibility.Timing2
-
Value to use for server "tickTime"
- timeout(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.atomic.PromotedToLock.Builder
-
Set the timeout to use when locking (optional)
- TimeoutException() - Constructor for exception class org.apache.curator.x.async.AsyncWrappers.TimeoutException
- TimeTrace - Class in org.apache.curator
-
Utility to time a method or portion of code
- TimeTrace(String, TracerDriver) - Constructor for class org.apache.curator.TimeTrace
-
Create and start a timer
- timing - Variable in class org.apache.curator.test.compatibility.CuratorTestBase
- Timing - Class in org.apache.curator.test
-
Utility to get various testing times
- Timing() - Constructor for class org.apache.curator.test.Timing
-
Use the default base time
- Timing(double) - Constructor for class org.apache.curator.test.Timing
-
Use a multiple of the default base time
- Timing(double, int) - Constructor for class org.apache.curator.test.Timing
-
Use a multiple of the default base time
- Timing(long, TimeUnit) - Constructor for class org.apache.curator.test.Timing
- Timing(long, TimeUnit, int) - Constructor for class org.apache.curator.test.Timing
- Timing2 - Class in org.apache.curator.test.compatibility
-
Utility to get various testing times.
- Timing2() - Constructor for class org.apache.curator.test.compatibility.Timing2
-
Use the default base time
- Timing2(double) - Constructor for class org.apache.curator.test.compatibility.Timing2
-
Use a multiple of the default base time
- Timing2(double, int) - Constructor for class org.apache.curator.test.compatibility.Timing2
-
Use a multiple of the default base time
- Timing2(long, TimeUnit) - Constructor for class org.apache.curator.test.compatibility.Timing2
- Timing2(long, TimeUnit, int) - Constructor for class org.apache.curator.test.compatibility.Timing2
- toDocumentation() - Method in class org.apache.curator.framework.schema.Schema
- toDocumentation() - Method in class org.apache.curator.framework.schema.SchemaSet
-
Build a user displayable documentation string for the schemas in this set
- toProtectedZNode(String, String) - Static method in class org.apache.curator.framework.imps.ProtectedUtils
-
Converts a given ZNode name to protected format
- toProtectedZNodePath(String, String) - Static method in class org.apache.curator.framework.imps.ProtectedUtils
-
Converts a given path to protected format
- toSchemaPathPattern() - Method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- toSchemaPathPattern() - Method in interface org.apache.curator.x.async.modeled.ZPath
-
Return a regex Pattern useful for using in
Schema
- toSchemaSet(boolean) - Method in class org.apache.curator.framework.schema.SchemaSetLoader
- toString() - Method in class modeled.ContainerType
- toString() - Method in class modeled.PersonId
- toString() - Method in class modeled.PersonModel
- toString() - Method in class org.apache.curator.framework.AuthInfo
- toString() - Method in class org.apache.curator.framework.recipes.cache.ChildData
- toString() - Method in class org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent
- toString() - Method in class org.apache.curator.framework.recipes.cache.TreeCacheEvent
- toString() - Method in class org.apache.curator.framework.recipes.leader.Participant
- toString() - Method in class org.apache.curator.framework.schema.Schema
- toString() - Method in exception class org.apache.curator.framework.schema.SchemaViolation
- toString() - Method in class org.apache.curator.framework.schema.SchemaViolation.ViolatorData
- toString() - Method in class org.apache.curator.test.InstanceSpec
- toString() - Method in class org.apache.curator.utils.ZKPaths.PathAndNode
- toString() - Method in class org.apache.curator.x.async.details.AsyncResultImpl
- toString() - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- toString() - Method in class org.apache.curator.x.async.modeled.details.ZPathImpl
- toString() - Method in class org.apache.curator.x.discovery.ServiceInstance
- toString() - Method in class pubsub.messages.LocationAvailable
- toString() - Method in class pubsub.messages.UserCreated
- toString() - Method in class pubsub.models.Instance
- toString() - Method in class pubsub.models.Message
- TracerDriver - Interface in org.apache.curator.drivers
-
Mechanism for timing methods and recording counters
- transaction() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a transaction builder
- transaction() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- transaction() - Method in interface org.apache.curator.x.async.api.AsyncCuratorFrameworkDsl
-
Start a transaction builder
- transaction() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- transaction(CuratorFramework) - Static method in class framework.TransactionExamples
- TRANSACTION - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
CuratorFramework.transaction()
- TransactionCheckBuilder<T> - Interface in org.apache.curator.framework.api.transaction
- TransactionCreateBuilder<T> - Interface in org.apache.curator.framework.api.transaction
- TransactionCreateBuilder2<T> - Interface in org.apache.curator.framework.api.transaction
- TransactionDeleteBuilder<T> - Interface in org.apache.curator.framework.api.transaction
- TransactionExamples - Class in framework
- TransactionExamples() - Constructor for class framework.TransactionExamples
- transactionOp() - Method in interface org.apache.curator.framework.CuratorFramework
-
Allocate an operation that can be used with
CuratorFramework.transaction()
. - transactionOp() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- transactionOp() - Method in interface org.apache.curator.x.async.api.AsyncCuratorFrameworkDsl
-
Allocate an operation that can be used with
AsyncCuratorFrameworkDsl.transaction()
. - transactionOp() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- TransactionOp - Interface in org.apache.curator.framework.api.transaction
-
Builds operations that can be committed as a transaction via
CuratorFramework.transaction()
- TransactionOpImpl - Class in org.apache.curator.framework.imps
- TransactionOpImpl(CuratorFrameworkImpl) - Constructor for class org.apache.curator.framework.imps.TransactionOpImpl
- TransactionSetDataBuilder<T> - Interface in org.apache.curator.framework.api.transaction
- traverseChildren(String) - Method in class org.apache.curator.framework.recipes.cache.DefaultTreeCacheSelector
- traverseChildren(String) - Method in interface org.apache.curator.framework.recipes.cache.TreeCacheSelector
-
Return true if children of this path should be cached.
- TreeCache - Class in org.apache.curator.framework.recipes.cache
-
Deprecated.replace by
CuratorCache
- TreeCache(CuratorFramework, String) - Constructor for class org.apache.curator.framework.recipes.cache.TreeCache
-
Deprecated.Create a TreeCache for the given client and path with default options.
- TreeCache.Builder - Class in org.apache.curator.framework.recipes.cache
-
Deprecated.
- TreeCacheEvent - Class in org.apache.curator.framework.recipes.cache
-
POJO that abstracts a change to a path
- TreeCacheEvent(TreeCacheEvent.Type, ChildData) - Constructor for class org.apache.curator.framework.recipes.cache.TreeCacheEvent
- TreeCacheEvent(TreeCacheEvent.Type, ChildData, ChildData) - Constructor for class org.apache.curator.framework.recipes.cache.TreeCacheEvent
- TreeCacheEvent.Type - Enum in org.apache.curator.framework.recipes.cache
-
Type of change
- TreeCacheExample - Class in cache
- TreeCacheExample() - Constructor for class cache.TreeCacheExample
- TreeCacheListener - Interface in org.apache.curator.framework.recipes.cache
-
Listener for
TreeCache
changes - TreeCacheSelector - Interface in org.apache.curator.framework.recipes.cache
-
Controls which nodes a TreeCache processes.
- tryRemove(String) - Method in class org.apache.curator.framework.recipes.queue.DistributedQueue
- trySet(byte[]) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicValue
-
Attempt to atomically set the value to the given value.
- trySet(Integer) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger
- trySet(Long) - Method in class org.apache.curator.framework.recipes.atomic.DistributedAtomicLong
- trySet(T) - Method in interface org.apache.curator.framework.recipes.atomic.DistributedAtomicNumber
-
Attempt to atomically set the value to the given value.
- trySetCount(int) - Method in class org.apache.curator.framework.recipes.shared.SharedCount
-
Deprecated.use
SharedCount.trySetCount(VersionedValue, int)
for stronger atomicity guarantees. Even if this object's internal state is up-to-date, the caller has no way to ensure that they've read the most recently seen count. - trySetCount(VersionedValue<Integer>, int) - Method in class org.apache.curator.framework.recipes.shared.SharedCount
-
Changes the shared count only if its value has not changed since the version specified by newCount.
- trySetValue(byte[]) - Method in class org.apache.curator.framework.recipes.shared.SharedValue
-
Deprecated.use
SharedValue.trySetValue(VersionedValue, byte[])
for stronger atomicity guarantees. Even if this object's internal state is up-to-date, the caller has no way to ensure that they've read the most recently seen value. - trySetValue(VersionedValue<byte[]>, byte[]) - Method in class org.apache.curator.framework.recipes.shared.SharedValue
-
Changes the shared value only if its value has not changed since the version specified by newValue.
- ttl() - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- ttl() - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return the TTL to use or -1
- TypeAndPath - Class in org.apache.curator.framework.api.transaction
- TypeAndPath(OperationType, String) - Constructor for class org.apache.curator.framework.api.transaction.TypeAndPath
- TypedModeledFramework<M,
P1> - Interface in org.apache.curator.x.async.modeled.typed -
Abstraction that allows the construction of ModeledFrameworks using strongly typed parameter replacements.
- TypedModeledFramework0<M> - Interface in org.apache.curator.x.async.modeled.typed
-
Same as
TypedModeledFramework
, but with 0 parameters - TypedModeledFramework10<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4, P5, P6, P7, P8, P9, P10> -
Same as
TypedModeledFramework
, but with 10 parameters - TypedModeledFramework2<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2> -
Same as
TypedModeledFramework
, but with 2 parameters - TypedModeledFramework3<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3> -
Same as
TypedModeledFramework
, but with 3 parameters - TypedModeledFramework4<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4> -
Same as
TypedModeledFramework
, but with 4 parameters - TypedModeledFramework5<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4, P5> -
Same as
TypedModeledFramework
, but with 5 parameters - TypedModeledFramework6<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4, P5, P6> -
Same as
TypedModeledFramework
, but with 6 parameters - TypedModeledFramework7<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4, P5, P6, P7> -
Same as
TypedModeledFramework
, but with 7 parameters - TypedModeledFramework8<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4, P5, P6, P7, P8> -
Same as
TypedModeledFramework
, but with 8 parameters - TypedModeledFramework9<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4, P5, P6, P7, P8, P9> -
Same as
TypedModeledFramework
, but with 9 parameters - TypedModelSpec<M,
P1> - Interface in org.apache.curator.x.async.modeled.typed -
Abstraction that allows the construction of ModelSpecs using strongly typed parameter replacements.
- TypedModelSpec0<M> - Interface in org.apache.curator.x.async.modeled.typed
-
Same as
TypedModelSpec
, but with 0 parameters - TypedModelSpec10<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4, P5, P6, P7, P8, P9, P10> -
Same as
TypedModelSpec
, but with 10 parameters - TypedModelSpec2<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2> -
Same as
TypedModelSpec
, but with 2 parameters - TypedModelSpec3<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3> -
Same as
TypedModelSpec
, but with 3 parameters - TypedModelSpec4<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4> -
Same as
TypedModelSpec
, but with 4 parameters - TypedModelSpec5<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4, P5> -
Same as
TypedModelSpec
, but with 5 parameters - TypedModelSpec6<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4, P5, P6> -
Same as
TypedModelSpec
, but with 6 parameters - TypedModelSpec7<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4, P5, P6, P7> -
Same as
TypedModelSpec
, but with 7 parameters - TypedModelSpec8<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4, P5, P6, P7, P8> -
Same as
TypedModelSpec
, but with 8 parameters - TypedModelSpec9<M,
P1, - Interface in org.apache.curator.x.async.modeled.typedP2, P3, P4, P5, P6, P7, P8, P9> -
Same as
TypedModelSpec
, but with 9 parameters - TypedZPath<T> - Interface in org.apache.curator.x.async.modeled.typed
-
Abstraction that allows the construction of ZPaths using strongly typed parameter replacements.
- TypedZPath0 - Interface in org.apache.curator.x.async.modeled.typed
-
Same as
TypedZPath
, but with 0 parameters. - TypedZPath10<T1,
T2, - Interface in org.apache.curator.x.async.modeled.typedT3, T4, T5, T6, T7, T8, T9, T10> -
Same as
TypedZPath
, but with 10 parameters - TypedZPath2<T1,
T2> - Interface in org.apache.curator.x.async.modeled.typed -
Same as
TypedZPath
, but with 2 parameters - TypedZPath3<T1,
T2, - Interface in org.apache.curator.x.async.modeled.typedT3> -
Same as
TypedZPath
, but with 3 parameters - TypedZPath4<T1,
T2, - Interface in org.apache.curator.x.async.modeled.typedT3, T4> -
Same as
TypedZPath
, but with 4 parameters - TypedZPath5<T1,
T2, - Interface in org.apache.curator.x.async.modeled.typedT3, T4, T5> -
Same as
TypedZPath
, but with 5 parameters - TypedZPath6<T1,
T2, - Interface in org.apache.curator.x.async.modeled.typedT3, T4, T5, T6> -
Same as
TypedZPath
, but with 6 parameters - TypedZPath7<T1,
T2, - Interface in org.apache.curator.x.async.modeled.typedT3, T4, T5, T6, T7> -
Same as
TypedZPath
, but with 7 parameters - TypedZPath8<T1,
T2, - Interface in org.apache.curator.x.async.modeled.typedT3, T4, T5, T6, T7, T8> -
Same as
TypedZPath
, but with 8 parameters - TypedZPath9<T1,
T2, - Interface in org.apache.curator.x.async.modeled.typedT3, T4, T5, T6, T7, T8, T9> -
Same as
TypedZPath
, but with 9 parameters
U
- UnaryListenerManager<T> - Interface in org.apache.curator.framework.listen
-
A
ListenerManager
that doesn't do any mapping - unhandledError(String, Throwable) - Method in interface org.apache.curator.framework.api.UnhandledErrorListener
-
Called when an exception is caught in a background thread, handler, etc.
- UnhandledErrorListener - Interface in org.apache.curator.framework.api
- unMarshallJson(JsonNode) - Method in class org.apache.curator.x.discovery.server.contexts.GenericDiscoveryContext
- unMarshallJson(JsonNode) - Method in class org.apache.curator.x.discovery.server.contexts.IntegerDiscoveryContext
- unMarshallJson(JsonNode) - Method in class org.apache.curator.x.discovery.server.contexts.StringDiscoveryContext
- unMarshallJson(JsonNode) - Method in interface org.apache.curator.x.discovery.server.rest.DiscoveryContext
-
Deserialize your payload
- unregisterJMX() - Method in class org.apache.curator.test.TestingZooKeeperMain.TestZooKeeperServer
- unregisterService(ServiceInstance<T>) - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
-
Unregister/remove a service instance
- unregisterService(ServiceInstance<T>) - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
Unregister/remove a service instance
- unwrap() - Method in interface org.apache.curator.x.async.AsyncCuratorFramework
-
Returns the client that was originally passed to
AsyncCuratorFramework.wrap(org.apache.curator.framework.CuratorFramework)
- unwrap() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- unwrap() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- unwrap() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Returns the client that was originally passed to
ModeledFramework.wrap(org.apache.curator.x.async.AsyncCuratorFramework, ModelSpec)
or the builder. - update(Versioned<T>) - Method in interface org.apache.curator.x.async.modeled.versioned.VersionedModeledFramework
- update(T) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- update(T) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Update the ZNode at this instance's path with a serialized form of the given model passing "-1" for the update version
- update(T, int) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- update(T, int) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Update the ZNode at this instance's path with a serialized form of the given model passing the given update version
- updateOp(Versioned<T>) - Method in interface org.apache.curator.x.async.modeled.versioned.VersionedModeledFramework
- updateOp(T) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- updateOp(T) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Update operation instance that can be passed among other operations to
ModeledFramework.inTransaction(java.util.List)
to be executed as a single transaction. - updateOp(T, int) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- updateOp(T, int) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Create operation instance that can be passed among other operations to
ModeledFramework.inTransaction(java.util.List)
to be executed as a single transaction. - updateServerListEnabled() - Method in interface org.apache.curator.ensemble.EnsembleProvider
-
Return true if this ensemble provider supports
ZooKeeper.updateServerList(String)
- updateServerListEnabled() - Method in class org.apache.curator.ensemble.fixed.FixedEnsembleProvider
- updateService(ServiceInstance<T>) - Method in class org.apache.curator.x.discovery.details.ServiceDiscoveryImpl
- updateService(ServiceInstance<T>) - Method in interface org.apache.curator.x.discovery.ServiceDiscovery
-
Update a service
- uriSpec(UriSpec) - Method in class org.apache.curator.x.discovery.ServiceInstanceBuilder
- UriSpec - Class in org.apache.curator.x.discovery
-
An abstraction for specifying a URI for an instance allowing for variable substitutions.
- UriSpec() - Constructor for class org.apache.curator.x.discovery.UriSpec
- UriSpec(String) - Constructor for class org.apache.curator.x.discovery.UriSpec
- UriSpec.Part - Class in org.apache.curator.x.discovery
-
Represents one token in the Uri spec
- use() - Method in class locking.FakeLimitedResource
- use(NetworkInterface, InetAddress) - Method in interface org.apache.curator.x.discovery.LocalIpFilter
- useContainerParentsIfAvailable() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- UserCreated - Class in pubsub.messages
- UserCreated() - Constructor for class pubsub.messages.UserCreated
- UserCreated(String, Priority, String, String) - Constructor for class pubsub.messages.UserCreated
- UserCreated(Priority, String, String) - Constructor for class pubsub.messages.UserCreated
- userCreatedClient - Static variable in class pubsub.Clients
-
A client template for UserCreated instances
- usingDataCallback(AsyncCallback.DataCallback, Object) - Method in interface org.apache.curator.framework.api.DataCallbackable
-
Passes a callback and a context object to the config/reconfig command.
- usingNamespace(String) - Method in interface org.apache.curator.framework.CuratorFramework
-
Returns a facade of the current instance that uses the specified namespace or no namespace if
newNamespace
isnull
. - usingNamespace(String) - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- usingWatcher(CuratorWatcher) - Method in interface org.apache.curator.framework.api.WatchableBase
-
Set a watcher for the operation
- usingWatcher(CuratorWatcher) - Method in class org.apache.curator.framework.imps.AddWatchBuilderImpl
- usingWatcher(CuratorWatcher) - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- usingWatcher(CuratorWatcher) - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- usingWatcher(CuratorWatcher) - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- usingWatcher(CuratorWatcher) - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- usingWatcher(Watcher) - Method in interface org.apache.curator.framework.api.WatchableBase
-
Set a watcher for the operation
- usingWatcher(Watcher) - Method in class org.apache.curator.framework.imps.AddWatchBuilderImpl
- usingWatcher(Watcher) - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- usingWatcher(Watcher) - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- usingWatcher(Watcher) - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- usingWatcher(Watcher) - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
V
- validateCreate(CreateMode, String, byte[], List<ACL>) - Method in class org.apache.curator.framework.schema.Schema
-
Validate that this schema's create mode setting matches and that the data is valid
- validateDelete(String) - Method in class org.apache.curator.framework.schema.Schema
-
Validate that this schema allows znode deletion
- validateGeneral(String, byte[], List<ACL>) - Method in class org.apache.curator.framework.schema.Schema
-
Validate that this schema validates the data
- validatePath(String) - Static method in class org.apache.curator.utils.PathUtils
-
Validate the provided znode path string
- validatePath(String, boolean) - Static method in class org.apache.curator.utils.PathUtils
-
validate the provided znode path string
- validateWatch(String, boolean) - Method in class org.apache.curator.framework.schema.Schema
-
Validate that this schema's watching setting matches
- valueHasChanged(SharedValueReader, byte[]) - Method in interface org.apache.curator.framework.recipes.shared.SharedValueListener
-
Called when the shared value has changed
- valueOf(String) - Static method in enum org.apache.curator.framework.api.CuratorEventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.api.transaction.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.imps.CuratorFrameworkState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.CuratorCache.Options
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.CuratorCacheListener.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.PathChildrenCache.StartMode
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheMode
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.TreeCacheEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.recipes.leader.LeaderLatch.CloseMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.recipes.leader.LeaderLatch.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.recipes.queue.DistributedQueue.ProcessType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.recipes.queue.ErrorMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.schema.Schema.Allowance
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.framework.state.ConnectionState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.SessionFailRetryLoop.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.x.async.api.CreateOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.x.async.api.DeleteOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.x.async.api.ExistsOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.x.async.api.RemoveWatcherOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.x.async.modeled.cached.ModeledCacheListener.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.x.async.modeled.ModeledOptions
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.x.async.WatchMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.curator.x.discovery.ServiceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum pubsub.models.InstanceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum pubsub.models.Priority
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.curator.framework.api.CuratorEventType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.api.transaction.OperationType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.imps.CuratorFrameworkState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.recipes.cache.CuratorCache.Options
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.recipes.cache.CuratorCacheListener.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.recipes.cache.PathChildrenCache.StartMode
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.recipes.cache.PathChildrenCacheMode
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.recipes.cache.TreeCacheEvent.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.recipes.leader.LeaderLatch.CloseMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.recipes.leader.LeaderLatch.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.Mode
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.recipes.queue.DistributedQueue.ProcessType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.recipes.queue.ErrorMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.schema.Schema.Allowance
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.framework.state.ConnectionState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.SessionFailRetryLoop.Mode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.x.async.api.CreateOption
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.x.async.api.DeleteOption
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.x.async.api.ExistsOption
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.x.async.api.RemoveWatcherOption
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.x.async.modeled.cached.ModeledCacheListener.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.x.async.modeled.ModeledOptions
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.x.async.WatchMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.curator.x.discovery.ServiceType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum pubsub.models.InstanceType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum pubsub.models.Priority
-
Returns an array containing the constants of this enum type, in the order they are declared.
- version() - Method in interface org.apache.curator.x.async.modeled.versioned.Versioned
-
Returns the version of the model when it was read
- Versionable<T> - Interface in org.apache.curator.framework.api
- versioned() - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- versioned() - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Return mutator APIs that work with
Versioned
containers - Versioned<T> - Interface in org.apache.curator.x.async.modeled.versioned
-
A container for a model instance and a version.
- VersionedModeledFramework<T> - Interface in org.apache.curator.x.async.modeled.versioned
- VersionedValue<T> - Class in org.apache.curator.framework.recipes.shared
-
POJO for versioned value.
- VersionPathAndBytesable<T> - Interface in org.apache.curator.framework.api
- ViolatorData(String, byte[], List<ACL>) - Constructor for class org.apache.curator.framework.schema.SchemaViolation.ViolatorData
W
- waitForInitialCreate(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.nodes.PersistentNode
-
Block until the either initial node creation initiated by
PersistentNode.start()
succeeds or the timeout elapses. - waitForInitialCreate(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.nodes.PersistentTtlNode
-
Block until the either initial node creation initiated by
PersistentTtlNode.start()
succeeds or the timeout elapses. - waitForShutdownTimeoutMs(int) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
-
Set a timeout for
CuratorZookeeperClient.close(int)
}. - waitOnBarrier() - Method in class org.apache.curator.framework.recipes.barriers.DistributedBarrier
-
Blocks until the barrier node comes into existence
- waitOnBarrier(long, TimeUnit) - Method in class org.apache.curator.framework.recipes.barriers.DistributedBarrier
-
Blocks until the barrier no longer exists or the timeout elapses
- Watchable<T> - Interface in org.apache.curator.framework.api
- WatchableAsyncCuratorFramework - Interface in org.apache.curator.x.async.api
-
operations that support watching
- WatchableBase<T> - Interface in org.apache.curator.framework.api
- WatchBackgroundEnsembleable<T> - Interface in org.apache.curator.framework.api
- watched() - Method in interface org.apache.curator.framework.api.Watchable
-
Have the operation set a watch
- watched() - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- watched() - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- watched() - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- watched() - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- watched() - Method in interface org.apache.curator.x.async.api.AsyncCuratorFrameworkDsl
-
Returns a facade that adds watching to any of the subsequently created builders.
- watched() - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- watched() - Method in class org.apache.curator.x.async.modeled.ModeledFrameworkBuilder
-
Add watchers as appropriate to the Modeled Curator's ZNode using
WatchMode.stateChangeAndSuccess
- watched(Schema.Allowance) - Method in class org.apache.curator.framework.schema.SchemaBuilder
- watched(WatchMode) - Method in class org.apache.curator.x.async.modeled.ModeledFrameworkBuilder
-
Add watchers as appropriate using the given watchMode to the Modeled Curator's ZNode
- watched(WatchMode, UnaryOperator<WatchedEvent>) - Method in class org.apache.curator.x.async.modeled.ModeledFrameworkBuilder
-
Add watchers as appropriate using the given watchMode and filter to the Modeled Curator's ZNode
- WATCHED - Enum constant in enum org.apache.curator.framework.api.CuratorEventType
-
Corresponds to
WatchableBase.usingWatcher(Watcher)
orWatchable.watched()
- watchedGetChildren(CuratorFramework, String) - Static method in class framework.CrudExamples
- watchedGetChildren(CuratorFramework, String, Watcher) - Static method in class framework.CrudExamples
- WatcherRemovalManager - Class in org.apache.curator.framework.imps
- WatcherRemoveCuratorFramework - Interface in org.apache.curator.framework
-
A CuratorFramework facade that tracks watchers created and allows a one-shot removal of all watchers
- watchers() - Method in interface org.apache.curator.framework.CuratorFramework
-
Start a watch builder.
- watchers() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- WatchersDebug - Class in org.apache.curator.test
- watches() - Method in interface org.apache.curator.framework.CuratorFramework
-
Deprecated.use
CuratorFramework.watchers()
in ZooKeeper 3.6+ - watches() - Method in class org.apache.curator.framework.imps.CuratorFrameworkImpl
- WatchesBuilder - Interface in org.apache.curator.framework.api
-
Builder to allow watches to be removed
- WatchesBuilderImpl - Class in org.apache.curator.framework.imps
- WatchesBuilderImpl(CuratorFrameworkImpl) - Constructor for class org.apache.curator.framework.imps.WatchesBuilderImpl
- WatchesBuilderImpl(CuratorFrameworkImpl, Watcher, CuratorWatcher, Watcher.WatcherType, boolean, boolean, boolean, Backgrounding) - Constructor for class org.apache.curator.framework.imps.WatchesBuilderImpl
- Watching - Class in org.apache.curator.framework.imps
- Watching(CuratorFrameworkImpl) - Constructor for class org.apache.curator.framework.imps.Watching
- Watching(CuratorFrameworkImpl, boolean) - Constructor for class org.apache.curator.framework.imps.Watching
- Watching(CuratorFrameworkImpl, CuratorWatcher) - Constructor for class org.apache.curator.framework.imps.Watching
- Watching(CuratorFrameworkImpl, Watcher) - Constructor for class org.apache.curator.framework.imps.Watching
- watchInstances(boolean) - Method in class org.apache.curator.x.discovery.ServiceDiscoveryBuilder
-
Optional - if true, watches for changes to locally registered instances (via
ServiceDiscoveryBuilder.thisInstance(ServiceInstance)
orServiceDiscovery.registerService(ServiceInstance)
). - WatchMode - Enum in org.apache.curator.x.async
- WatchPathable<T> - Interface in org.apache.curator.framework.api
- web - Enum constant in enum pubsub.models.InstanceType
- with(UnaryOperator<CuratorEvent>, UnaryOperator<WatchedEvent>) - Method in interface org.apache.curator.x.async.AsyncCuratorFramework
-
Returns a facade that adds the the given filters to all background operations and watchers.
- with(UnaryOperator<CuratorEvent>, UnaryOperator<WatchedEvent>) - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- with(UnhandledErrorListener) - Method in interface org.apache.curator.x.async.AsyncCuratorFramework
-
Returns a facade that adds the given UnhandledErrorListener to all background operations
- with(UnhandledErrorListener) - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- with(UnhandledErrorListener, UnaryOperator<CuratorEvent>, UnaryOperator<WatchedEvent>) - Method in interface org.apache.curator.x.async.AsyncCuratorFramework
-
Set any combination of listener or filters
- with(UnhandledErrorListener, UnaryOperator<CuratorEvent>, UnaryOperator<WatchedEvent>) - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- with(WatchMode) - Method in interface org.apache.curator.x.async.AsyncCuratorFramework
-
Returns a facade that changes how watchers are set when
AsyncCuratorFrameworkDsl.watched()
is called - with(WatchMode) - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- with(WatchMode, UnhandledErrorListener, UnaryOperator<CuratorEvent>, UnaryOperator<WatchedEvent>) - Method in interface org.apache.curator.x.async.AsyncCuratorFramework
-
Set any combination of listener, filters or watch mode
- with(WatchMode, UnhandledErrorListener, UnaryOperator<CuratorEvent>, UnaryOperator<WatchedEvent>) - Method in class org.apache.curator.x.async.details.AsyncCuratorFrameworkImpl
- withACL(List<ACL>) - Method in interface org.apache.curator.framework.api.ACLable
-
Set an ACL list (default is
ZooDefs.Ids.OPEN_ACL_UNSAFE
) - withACL(List<ACL>) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- withACL(List<ACL>) - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- withACL(List<ACL>) - Method in class org.apache.curator.framework.imps.SetACLBuilderImpl
- withACL(List<ACL>) - Method in interface org.apache.curator.x.async.api.AsyncCreateBuilder
-
Set an ACL list (default is
ZooDefs.Ids.OPEN_ACL_UNSAFE
) - withACL(List<ACL>) - Method in interface org.apache.curator.x.async.api.AsyncSetACLBuilder
-
Set the given ACLs
- withACL(List<ACL>) - Method in interface org.apache.curator.x.async.api.AsyncTransactionCreateBuilder
-
Set an ACL list (default is
ZooDefs.Ids.OPEN_ACL_UNSAFE
) - withACL(List<ACL>, boolean) - Method in interface org.apache.curator.framework.api.ParentACLable
-
Set an ACL list (default is
ZooDefs.Ids.OPEN_ACL_UNSAFE
). - withACL(List<ACL>, boolean) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- withACL(List<ACL>, int) - Method in interface org.apache.curator.x.async.api.AsyncSetACLBuilder
-
Set the given ACLs only if the "a" version matches.
- withAclList(List<ACL>) - Method in class org.apache.curator.x.async.modeled.ModelSpecBuilder
-
Use the given aclList for create operations on the Modeled Curator's ZNode
- withClient(AsyncCuratorFramework) - Method in class org.apache.curator.x.async.modeled.ModeledFrameworkBuilder
-
Change the client to use
- withCreateMode(CreateMode) - Method in class org.apache.curator.x.async.modeled.ModelSpecBuilder
-
Use the given createMode for create operations on the Modeled Curator's ZNode
- withCreateOptions(Set<CreateOption>) - Method in class org.apache.curator.x.async.modeled.ModelSpecBuilder
-
Use the given create options on the Modeled Curator's ZNode
- withDataNotCached() - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBridgeBuilder
-
The bridge cache will not retain the data bytes.
- withDeleteOptions(Set<DeleteOption>) - Method in class org.apache.curator.x.async.modeled.ModelSpecBuilder
-
Use the given delete options on the Modeled Curator's ZNode
- withEnsembleTracker() - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- withExceptionHandler(Consumer<Exception>) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBuilder
-
By default any unexpected exception is handled by logging the exception.
- withExecutorService(ExecutorService) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBridgeBuilder
-
If the old
TreeCache
is used by the bridge (i.e. - withJoiningAndLeaving(List<String>, List<String>) - Method in interface org.apache.curator.x.async.api.AsyncReconfigBuilder
-
Adds servers to join the ensemble and/or servers to leave the ensemble.
- withJoiningAndLeaving(List<String>, List<String>, long) - Method in interface org.apache.curator.x.async.api.AsyncReconfigBuilder
-
Specify joiners, leaves and config version.
- withJoiningAndLeaving(List<String>, List<String>, Stat) - Method in interface org.apache.curator.x.async.api.AsyncReconfigBuilder
-
Same as
AsyncReconfigBuilder.withJoiningAndLeaving(java.util.List, java.util.List)
but allows a stat to hold the stat info from "/zookeeper/config" - withJoiningAndLeaving(List<String>, List<String>, Stat, long) - Method in interface org.apache.curator.x.async.api.AsyncReconfigBuilder
-
Same as
AsyncReconfigBuilder.withJoiningAndLeaving(java.util.List, java.util.List)
with stat and config version - withMode(AddWatchMode) - Method in interface org.apache.curator.framework.api.AddWatchBuilder
-
The mode to use.
- withMode(AddWatchMode) - Method in class org.apache.curator.framework.imps.AddWatchBuilderImpl
- withMode(AddWatchMode) - Method in interface org.apache.curator.x.async.api.AsyncWatchBuilder
-
The mode to use.
- withMode(CreateMode) - Method in interface org.apache.curator.framework.api.CreateModable
-
Set a create mode - the default is
CreateMode.PERSISTENT
- withMode(CreateMode) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- withMode(CreateMode) - Method in interface org.apache.curator.x.async.api.AsyncCreateBuilder
-
Use the given create mode.
- withMode(CreateMode) - Method in interface org.apache.curator.x.async.api.AsyncTransactionCreateBuilder
-
Specify a mode for the create.
- withModelSpec(ModelSpec<T>) - Method in class org.apache.curator.x.async.modeled.ModeledFrameworkBuilder
-
Change the model spec to use
- withNewMembers(String...) - Method in interface org.apache.curator.framework.api.Membersable
-
Sets one or more members that are meant to be the ensemble.
- withNewMembers(String...) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- withNewMembers(List<String>) - Method in interface org.apache.curator.framework.api.Membersable
-
Sets one or more members that are meant to be the ensemble.
- withNewMembers(List<String>) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- withNewMembers(List<String>) - Method in interface org.apache.curator.x.async.api.AsyncReconfigBuilder
-
Sets one or more members that are meant to be the ensemble.
- withNewMembers(List<String>, long) - Method in interface org.apache.curator.x.async.api.AsyncReconfigBuilder
-
Same as
AsyncReconfigBuilder.withNewMembers(java.util.List)
but allows specified the configuration version to use. - withNewMembers(List<String>, Stat) - Method in interface org.apache.curator.x.async.api.AsyncReconfigBuilder
-
Same as
AsyncReconfigBuilder.withNewMembers(java.util.List)
but allows a stat to hold the stat info from "/zookeeper/config" - withNewMembers(List<String>, Stat, long) - Method in interface org.apache.curator.x.async.api.AsyncReconfigBuilder
-
Same as
AsyncReconfigBuilder.withNewMembers(java.util.List)
with stat and config version - withOptions(Set<CreateOption>) - Method in interface org.apache.curator.x.async.api.AsyncCreateBuilder
-
Options to change how the ZNode is created
- withOptions(Set<CreateOption>, List<ACL>) - Method in interface org.apache.curator.x.async.api.AsyncCreateBuilder
-
set options and ACLs
- withOptions(Set<CreateOption>, CreateMode) - Method in interface org.apache.curator.x.async.api.AsyncCreateBuilder
-
set options and mode
- withOptions(Set<CreateOption>, CreateMode, List<ACL>) - Method in interface org.apache.curator.x.async.api.AsyncCreateBuilder
-
set options, mode and ACLs
- withOptions(Set<CreateOption>, CreateMode, List<ACL>, Stat) - Method in interface org.apache.curator.x.async.api.AsyncCreateBuilder
-
set options, mode, ACLs, and stat
- withOptions(Set<CreateOption>, CreateMode, List<ACL>, Stat, long) - Method in interface org.apache.curator.x.async.api.AsyncCreateBuilder
-
set options, mode, ACLs, and stat
- withOptions(Set<CreateOption>, CreateMode, List<ACL>, Stat, long, int) - Method in interface org.apache.curator.x.async.api.AsyncCreateBuilder
-
set options, mode, ACLs, and stat
- withOptions(Set<DeleteOption>) - Method in interface org.apache.curator.x.async.api.AsyncDeleteBuilder
-
Changes the deletion options.
- withOptions(Set<ExistsOption>) - Method in interface org.apache.curator.x.async.api.AsyncExistsBuilder
-
Use the given options.
- withOptions(Set<ModeledOptions>) - Method in class org.apache.curator.x.async.modeled.ModeledFrameworkBuilder
-
Change the modeled options
- withOptions(CuratorCache.Options...) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBridgeBuilder
- withOptions(CuratorCache.Options...) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBuilder
- withOptions(CreateMode, List<ACL>, boolean) - Method in interface org.apache.curator.x.async.api.AsyncTransactionCreateBuilder
-
Specify mode, acl list and compression
- withOptions(CreateMode, List<ACL>, boolean, long) - Method in interface org.apache.curator.x.async.api.AsyncTransactionCreateBuilder
-
Specify mode, acl list, compression and ttl
- withOptionsAndVersion(Set<DeleteOption>, int) - Method in interface org.apache.curator.x.async.api.AsyncDeleteBuilder
-
Set options and version.
- withPath(ZPath) - Method in interface org.apache.curator.x.async.modeled.cached.CachedModeledFramework
-
Return a Modeled Curator instance with all the same options but using the given path.
- withPath(ZPath) - Method in class org.apache.curator.x.async.modeled.details.ModeledFrameworkImpl
- withPath(ZPath) - Method in class org.apache.curator.x.async.modeled.details.ModelSpecImpl
- withPath(ZPath) - Method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Return a Modeled Curator instance with all the same options but using the given path.
- withPath(ZPath) - Method in interface org.apache.curator.x.async.modeled.ModelSpec
-
Return a new CuratorModel instance with all the same options but using the given path.
- withPath(ZPath) - Method in class org.apache.curator.x.async.modeled.ModelSpecBuilder
-
Change the model spec's path
- withProtectedEphemeralSequential() - Method in interface org.apache.curator.framework.api.CreateBackgroundModeACLable
-
Hat-tip to https://github.com/sbridges for pointing this out
- withProtectedEphemeralSequential() - Method in interface org.apache.curator.framework.api.CreateBackgroundModeStatACLable
-
Hat-tip to https://github.com/sbridges for pointing this out
- withProtectedEphemeralSequential() - Method in interface org.apache.curator.framework.api.CreateBuilderMain
-
Deprecated.this has been generalized to support all create modes. Instead, use:
client.create().withProtection().withMode(CreateMode.EPHEMERAL_SEQUENTIAL)...
- withProtectedEphemeralSequential() - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- withProtection() - Method in interface org.apache.curator.framework.api.CreateBuilderMain
-
Hat-tip to https://github.com/sbridges for pointing this out
- withProtection() - Method in interface org.apache.curator.framework.api.CreateProtectACLCreateModePathAndBytesable
-
Hat-tip to https://github.com/sbridges for pointing this out
- withProtection() - Method in interface org.apache.curator.framework.api.ProtectACLCreateModePathAndBytesable
-
Hat-tip to https://github.com/sbridges for pointing this out
- withProtection() - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- withResultFilter(UnaryOperator<CuratorEvent>) - Method in class org.apache.curator.x.async.modeled.ModeledFrameworkBuilder
-
Use the given result filter for operations on the Modeled Curator's ZNode
- withSetDataVersion(int) - Method in interface org.apache.curator.x.async.api.AsyncCreateBuilder
-
Specify the setData expected matching version when using option
CreateOption.setDataIfExists
. - withStorage(CuratorCacheStorage) - Method in interface org.apache.curator.framework.recipes.cache.CuratorCacheBuilder
-
Alternate storage to use.
- withTtl(long) - Method in interface org.apache.curator.framework.api.CreateBuilder
-
Specify a TTL when mode is
CreateMode.PERSISTENT_WITH_TTL
orCreateMode.PERSISTENT_SEQUENTIAL_WITH_TTL
. - withTtl(long) - Method in interface org.apache.curator.framework.api.CreateBuilder2
-
Specify a TTL when mode is
CreateMode.PERSISTENT_WITH_TTL
orCreateMode.PERSISTENT_SEQUENTIAL_WITH_TTL
. - withTtl(long) - Method in interface org.apache.curator.framework.api.transaction.TransactionCreateBuilder
-
Specify a TTL when mode is
CreateMode.PERSISTENT_WITH_TTL
orCreateMode.PERSISTENT_SEQUENTIAL_WITH_TTL
. - withTtl(long) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- withTtl(long) - Method in interface org.apache.curator.x.async.api.AsyncCreateBuilder
-
Specify a TTL when mode is
CreateMode.PERSISTENT_WITH_TTL
orCreateMode.PERSISTENT_SEQUENTIAL_WITH_TTL
. - withTtl(long) - Method in interface org.apache.curator.x.async.api.AsyncTransactionCreateBuilder
-
Specify a TTL when mode is
CreateMode.PERSISTENT_WITH_TTL
orCreateMode.PERSISTENT_SEQUENTIAL_WITH_TTL
. - withTtl(long) - Method in class org.apache.curator.x.async.modeled.ModelSpecBuilder
-
Specify a TTL when mode is
CreateMode.PERSISTENT_WITH_TTL
orCreateMode.PERSISTENT_SEQUENTIAL_WITH_TTL
. - withUnhandledErrorListener(UnhandledErrorListener) - Method in interface org.apache.curator.framework.api.ErrorListenerEnsembleable
-
Set an error listener for this background operation.
- withUnhandledErrorListener(UnhandledErrorListener) - Method in interface org.apache.curator.framework.api.ErrorListenerMultiTransactionMain
-
Set an error listener for this background operation.
- withUnhandledErrorListener(UnhandledErrorListener) - Method in interface org.apache.curator.framework.api.ErrorListenerPathable
-
Set an error listener for this background operation.
- withUnhandledErrorListener(UnhandledErrorListener) - Method in interface org.apache.curator.framework.api.ErrorListenerPathAndBytesable
-
Set an error listener for this background operation.
- withUnhandledErrorListener(UnhandledErrorListener) - Method in interface org.apache.curator.framework.api.ErrorListenerReconfigBuilderMain
-
Set an error listener for this background operation.
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.CreateBuilderImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.CuratorMultiTransactionImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.ExistsBuilderImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.GetACLBuilderImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.GetChildrenBuilderImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.GetConfigBuilderImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.GetDataBuilderImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.ReconfigBuilderImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.RemoveWatchesBuilderImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.SetACLBuilderImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.framework.imps.SyncBuilderImpl
- withUnhandledErrorListener(UnhandledErrorListener) - Method in class org.apache.curator.x.async.modeled.ModeledFrameworkBuilder
-
Use the given unhandledErrorListener for operations on the Modeled Curator's ZNode
- withVersion(int) - Method in interface org.apache.curator.framework.api.Versionable
-
Use the given version (the default is -1)
- withVersion(int) - Method in class org.apache.curator.framework.imps.DeleteBuilderImpl
- withVersion(int) - Method in class org.apache.curator.framework.imps.SetACLBuilderImpl
- withVersion(int) - Method in class org.apache.curator.framework.imps.SetDataBuilderImpl
- withVersion(int) - Method in interface org.apache.curator.x.async.api.AsyncDeleteBuilder
-
Changes the version number passed to the delete() method.
- withVersion(int) - Method in interface org.apache.curator.x.async.api.AsyncSetDataBuilder
-
Only sets if the version matches.
- withVersion(int) - Method in interface org.apache.curator.x.async.api.AsyncTransactionCheckBuilder
-
Use the given version (the default is -1)
- withVersion(int) - Method in interface org.apache.curator.x.async.api.AsyncTransactionDeleteBuilder
-
Changes the version number used.
- withVersion(int) - Method in interface org.apache.curator.x.async.api.AsyncTransactionSetDataBuilder
-
Changes the version number used.
- withVersionCompressed(int) - Method in interface org.apache.curator.x.async.api.AsyncTransactionSetDataBuilder
-
Cause the data to be compressed using the configured compression provider.
- wrap(CuratorFramework) - Static method in class async.AsyncExamples
- wrap(CuratorFramework) - Static method in interface org.apache.curator.x.async.AsyncCuratorFramework
-
Takes an old-style Curator instance and returns a new async instance that wraps it.
- wrap(AsyncCuratorFramework) - Static method in class modeled.ModeledCuratorExamples
- wrap(AsyncCuratorFramework, ModelSpec<T>) - Static method in interface org.apache.curator.x.async.modeled.ModeledFramework
-
Return a new ModeledFramework for the given model
- writeLock() - Method in class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock
-
Returns the lock used for writing.
- WriteLock(CuratorFramework, String, byte[]) - Constructor for class org.apache.curator.framework.recipes.locks.InterProcessReadWriteLock.WriteLock
- writeTo(ServiceInstances<T>, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstancesMarshaller
- writeTo(ServiceNames, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceNamesMarshaller
- writeTo(ServiceInstance<T>, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class org.apache.curator.x.discovery.server.entity.JsonServiceInstanceMarshaller
Z
- zk35TestCompatibilityGroup - Static variable in class org.apache.curator.test.compatibility.CuratorTestBase
- zk36Group - Static variable in class org.apache.curator.test.compatibility.CuratorTestBase
- zkClientConfig(ZKClientConfig) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- ZKPaths - Class in org.apache.curator.utils
- ZKPaths.PathAndNode - Class in org.apache.curator.utils
- ZNode<T> - Interface in org.apache.curator.x.async.modeled
-
Abstracts a ZooKeeper node
- ZNodeImpl<T> - Class in org.apache.curator.x.async.modeled.details
- ZNodeImpl(ZPath, Stat, T) - Constructor for class org.apache.curator.x.async.modeled.details.ZNodeImpl
- zookeeperCompatibility(ZookeeperCompatibility) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- ZookeeperCompatibility - Class in org.apache.curator.utils
-
Describe feature supports based on server compatibility (as opposed to
Compatibility
which represents client compatibility. - ZookeeperCompatibility.Builder - Class in org.apache.curator.utils
- zookeeperFactory(ZookeeperFactory) - Method in class org.apache.curator.framework.CuratorFrameworkFactory.Builder
- ZookeeperFactory - Interface in org.apache.curator.utils
- ZooKeeperServerEmbeddedAdapter - Class in org.apache.curator.test
- ZooKeeperServerEmbeddedAdapter() - Constructor for class org.apache.curator.test.ZooKeeperServerEmbeddedAdapter
- ZPath - Interface in org.apache.curator.x.async.modeled
-
Abstracts a ZooKeeper ZNode path
- ZPathImpl - Class in org.apache.curator.x.async.modeled.details
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
CuratorFramework.newWatcherRemoveCuratorFramework()
callingWatcherRemoveCuratorFramework.removeWatchers()
when closing your instance.