Uses of Interface
org.apache.curator.framework.CuratorFramework
Packages that use CuratorFramework
Package
Description
-
Uses of CuratorFramework in async
Methods in async with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionstatic void
AsyncExamples.create
(CuratorFramework client, String path, byte[] payload) static void
AsyncExamples.createThenWatch
(CuratorFramework client, String path) static void
AsyncExamples.createThenWatchSimple
(CuratorFramework client, String path) static AsyncCuratorFramework
AsyncExamples.wrap
(CuratorFramework client) -
Uses of CuratorFramework in discovery
Constructors in discovery with parameters of type CuratorFrameworkModifierConstructorDescriptionExampleServer
(CuratorFramework client, String path, String serviceName, String description) -
Uses of CuratorFramework in framework
Methods in framework that return CuratorFrameworkModifier and TypeMethodDescriptionstatic CuratorFramework
CreateClientExamples.createSimple
(String connectionString) static CuratorFramework
CreateClientExamples.createWithOptions
(String connectionString, RetryPolicy retryPolicy, int connectionTimeoutMs, int sessionTimeoutMs) Methods in framework with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionstatic void
CrudExamples.create
(CuratorFramework client, String path, byte[] payload) static void
CrudExamples.createEphemeral
(CuratorFramework client, String path, byte[] payload) static String
CrudExamples.createEphemeralSequential
(CuratorFramework client, String path, byte[] payload) static void
CrudExamples.createIdempotent
(CuratorFramework client, String path, byte[] payload) static void
CrudExamples.delete
(CuratorFramework client, String path) static void
CrudExamples.deleteIdempotent
(CuratorFramework client, String path, int currentVersion) static void
CrudExamples.guaranteedDelete
(CuratorFramework client, String path) static void
CrudExamples.setData
(CuratorFramework client, String path, byte[] payload) static void
CrudExamples.setDataAsync
(CuratorFramework client, String path, byte[] payload) static void
CrudExamples.setDataAsyncWithCallback
(CuratorFramework client, BackgroundCallback callback, String path, byte[] payload) static void
CrudExamples.setDataIdempotent
(CuratorFramework client, String path, byte[] payload, int currentVersion) static Collection
<CuratorTransactionResult> TransactionExamples.transaction
(CuratorFramework client) CrudExamples.watchedGetChildren
(CuratorFramework client, String path) CrudExamples.watchedGetChildren
(CuratorFramework client, String path, org.apache.zookeeper.Watcher watcher) -
Uses of CuratorFramework in leader
Methods in leader with parameters of type CuratorFrameworkConstructors in leader with parameters of type CuratorFramework -
Uses of CuratorFramework in locking
Constructors in locking with parameters of type CuratorFrameworkModifierConstructorDescriptionExampleClientThatLocks
(CuratorFramework client, String lockPath, FakeLimitedResource resource, String clientName) -
Uses of CuratorFramework in org.apache.curator.framework
Subinterfaces of CuratorFramework in org.apache.curator.frameworkModifier and TypeInterfaceDescriptioninterface
A CuratorFramework facade that tracks watchers created and allows a one-shot removal of all watchersMethods in org.apache.curator.framework that return CuratorFrameworkModifier and TypeMethodDescriptionCuratorFrameworkFactory.Builder.build()
Apply the current values and build a new CuratorFrameworkstatic CuratorFramework
CuratorFrameworkFactory.newClient
(String connectString, int sessionTimeoutMs, int connectionTimeoutMs, RetryPolicy retryPolicy) Create a new clientstatic CuratorFramework
CuratorFrameworkFactory.newClient
(String connectString, int sessionTimeoutMs, int connectionTimeoutMs, RetryPolicy retryPolicy, org.apache.zookeeper.client.ZKClientConfig zkClientConfig) Create a new clientstatic CuratorFramework
CuratorFrameworkFactory.newClient
(String connectString, RetryPolicy retryPolicy) Create a new client with default session timeout and default connection timeoutCuratorFramework.nonNamespaceView()
Deprecated.CuratorFramework.usingNamespace
(String newNamespace) Returns a facade of the current instance that uses the specified namespace or no namespace ifnewNamespace
isnull
.Constructors in org.apache.curator.framework with parameters of type CuratorFramework -
Uses of CuratorFramework in org.apache.curator.framework.api
Methods in org.apache.curator.framework.api with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionvoid
CuratorListener.eventReceived
(CuratorFramework client, CuratorEvent event) Called when a background task has completed or a watch has triggeredvoid
BackgroundCallback.processResult
(CuratorFramework client, CuratorEvent event) Called when the async background operation completes -
Uses of CuratorFramework in org.apache.curator.framework.imps
Classes in org.apache.curator.framework.imps that implement CuratorFrameworkModifier and TypeClassDescriptionclass
This is the base class of allCuratorFramework
s, it is public for private usages (a.k.a.final class
Methods in org.apache.curator.framework.imps that return CuratorFrameworkModifier and TypeMethodDescriptionfinal CuratorFramework
CuratorFrameworkBase.nonNamespaceView()
CuratorFrameworkImpl.usingNamespace
(String newNamespace) -
Uses of CuratorFramework in org.apache.curator.framework.recipes
Methods in org.apache.curator.framework.recipes with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionstatic Future
<?> AfterConnectionEstablished.execute
(CuratorFramework client, Runnable runAfterConnection) Spawns a new new background thread that will block until a connection is available and then execute the 'runAfterConnection' logic -
Uses of CuratorFramework in org.apache.curator.framework.recipes.atomic
Constructors in org.apache.curator.framework.recipes.atomic with parameters of type CuratorFrameworkModifierConstructorDescriptionDistributedAtomicInteger
(CuratorFramework client, String counterPath, RetryPolicy retryPolicy) Creates in optimistic mode only - i.e.DistributedAtomicInteger
(CuratorFramework client, String counterPath, RetryPolicy retryPolicy, PromotedToLock promotedToLock) Creates in mutex promotion mode.DistributedAtomicLong
(CuratorFramework client, String counterPath, RetryPolicy retryPolicy) Creates in optimistic mode only - i.e.DistributedAtomicLong
(CuratorFramework client, String counterPath, RetryPolicy retryPolicy, PromotedToLock promotedToLock) Creates in mutex promotion mode.DistributedAtomicValue
(CuratorFramework client, String path, RetryPolicy retryPolicy) Creates in optimistic mode only - i.e.DistributedAtomicValue
(CuratorFramework client, String path, RetryPolicy retryPolicy, PromotedToLock promotedToLock) Creates in mutex promotion mode. -
Uses of CuratorFramework in org.apache.curator.framework.recipes.barriers
Constructors in org.apache.curator.framework.recipes.barriers with parameters of type CuratorFrameworkModifierConstructorDescriptionDistributedBarrier
(CuratorFramework client, String barrierPath) DistributedDoubleBarrier
(CuratorFramework client, String barrierPath, int memberQty) Creates the barrier abstraction. -
Uses of CuratorFramework in org.apache.curator.framework.recipes.cache
Methods in org.apache.curator.framework.recipes.cache that return CuratorFrameworkMethods in org.apache.curator.framework.recipes.cache with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionstatic CuratorCacheBridgeBuilder
CuratorCache.bridgeBuilder
(CuratorFramework client, String path) Start a Curator Cache Bridge builder.static CuratorCache
CuratorCache.build
(CuratorFramework client, String path, CuratorCache.Options... options) Return a Curator Cache for the given path with the given options using a standard storage instancestatic CuratorCacheBuilder
CuratorCache.builder
(CuratorFramework client, String path) Start a Curator Cache buildervoid
PathChildrenCacheListener.childEvent
(CuratorFramework client, PathChildrenCacheEvent event) Called when a change has occurredvoid
TreeCacheListener.childEvent
(CuratorFramework client, TreeCacheEvent event) Called when a change has occurredCuratorCacheListenerBuilder.forPathChildrenCache
(String rootPath, CuratorFramework client, PathChildrenCacheListener listener) Bridge listener.CuratorCacheListenerBuilder.forTreeCache
(CuratorFramework client, TreeCacheListener listener) Bridge listener.static TreeCache.Builder
TreeCache.newBuilder
(CuratorFramework client, String path) Deprecated.Create a TreeCache builder for the given client and path to configure advanced options.Constructors in org.apache.curator.framework.recipes.cache with parameters of type CuratorFrameworkModifierConstructorDescriptionNodeCache
(CuratorFramework client, String path) Deprecated.NodeCache
(CuratorFramework client, String path, boolean dataIsCompressed) Deprecated.PathChildrenCache
(CuratorFramework client, String path, boolean cacheData) Deprecated.PathChildrenCache
(CuratorFramework client, String path, boolean cacheData, boolean dataIsCompressed, ExecutorService executorService) Deprecated.PathChildrenCache
(CuratorFramework client, String path, boolean cacheData, boolean dataIsCompressed, ThreadFactory threadFactory) Deprecated.PathChildrenCache
(CuratorFramework client, String path, boolean cacheData, boolean dataIsCompressed, CloseableExecutorService executorService) Deprecated.PathChildrenCache
(CuratorFramework client, String path, boolean cacheData, ThreadFactory threadFactory) Deprecated.PathChildrenCache
(CuratorFramework client, String path, PathChildrenCacheMode mode) Deprecated.PathChildrenCache
(CuratorFramework client, String path, PathChildrenCacheMode mode, ThreadFactory threadFactory) Deprecated.TreeCache
(CuratorFramework client, String path) Deprecated.Create a TreeCache for the given client and path with default options. -
Uses of CuratorFramework in org.apache.curator.framework.recipes.leader
Methods in org.apache.curator.framework.recipes.leader with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionvoid
LeaderSelectorListenerAdapter.stateChanged
(CuratorFramework client, ConnectionState newState) void
LeaderSelectorListener.takeLeadership
(CuratorFramework client) Called when your instance has been granted leadership.Constructors in org.apache.curator.framework.recipes.leader with parameters of type CuratorFrameworkModifierConstructorDescriptionLeaderLatch
(CuratorFramework client, String latchPath) LeaderLatch
(CuratorFramework client, String latchPath, String id) LeaderLatch
(CuratorFramework client, String latchPath, String id, LeaderLatch.CloseMode closeMode) LeaderSelector
(CuratorFramework client, String leaderPath, ExecutorService executorService, LeaderSelectorListener listener) LeaderSelector
(CuratorFramework client, String leaderPath, ThreadFactory threadFactory, Executor executor, LeaderSelectorListener listener) Deprecated.This constructor was poorly thought out.LeaderSelector
(CuratorFramework client, String leaderPath, LeaderSelectorListener listener) LeaderSelector
(CuratorFramework client, String leaderPath, CloseableExecutorService executorService, LeaderSelectorListener listener) -
Uses of CuratorFramework in org.apache.curator.framework.recipes.locks
Methods in org.apache.curator.framework.recipes.locks with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionstatic void
Revoker.attemptRevoke
(CuratorFramework client, String path) Utility to mark a lock for revocation.LockInternalsDriver.createsTheLock
(CuratorFramework client, String path, byte[] lockNodeBytes) StandardLockInternalsDriver.createsTheLock
(CuratorFramework client, String path, byte[] lockNodeBytes) static Collection
<String> LockInternals.getParticipantNodes
(CuratorFramework client, String basePath, String lockName, LockInternalsSorter sorter) LockInternals.getSortedChildren
(CuratorFramework client, String basePath, String lockName, LockInternalsSorter sorter) LockInternalsDriver.getsTheLock
(CuratorFramework client, List<String> children, String sequenceNodeName, int maxLeases) StandardLockInternalsDriver.getsTheLock
(CuratorFramework client, List<String> children, String sequenceNodeName, int maxLeases) Constructors in org.apache.curator.framework.recipes.locks with parameters of type CuratorFrameworkModifierConstructorDescriptionInterProcessMultiLock
(CuratorFramework client, List<String> paths) Creates a multi lock ofInterProcessMutex
sInterProcessMutex
(CuratorFramework client, String path) InterProcessMutex
(CuratorFramework client, String path, LockInternalsDriver driver) InterProcessReadWriteLock
(CuratorFramework client, String basePath) InterProcessReadWriteLock
(CuratorFramework client, String basePath, byte[] lockData) InterProcessSemaphore
(CuratorFramework client, String path, int maxLeases) Deprecated.InterProcessSemaphore
(CuratorFramework client, String path, SharedCountReader count) Deprecated.InterProcessSemaphoreMutex
(CuratorFramework client, String path) InterProcessSemaphoreV2
(CuratorFramework client, String path, int maxLeases) InterProcessSemaphoreV2
(CuratorFramework client, String path, SharedCountReader count) ReadLock
(CuratorFramework client, String basePath, byte[] lockData, InterProcessReadWriteLock.WriteLock writeLock) WriteLock
(CuratorFramework client, String basePath, byte[] lockData) -
Uses of CuratorFramework in org.apache.curator.framework.recipes.nodes
Constructors in org.apache.curator.framework.recipes.nodes with parameters of type CuratorFrameworkModifierConstructorDescriptionGroupMember
(CuratorFramework client, String membershipPath, String thisId) GroupMember
(CuratorFramework client, String membershipPath, String thisId, byte[] payload) PersistentEphemeralNode
(CuratorFramework client, PersistentEphemeralNode.Mode mode, String basePath, byte[] initData) Deprecated.PersistentNode
(CuratorFramework givenClient, org.apache.zookeeper.CreateMode mode, boolean useProtection, String basePath, byte[] initData) PersistentNode
(CuratorFramework givenClient, org.apache.zookeeper.CreateMode mode, boolean useProtection, String basePath, byte[] initData, boolean useParentCreation) PersistentNode
(CuratorFramework givenClient, org.apache.zookeeper.CreateMode mode, boolean useProtection, String basePath, byte[] initData, long ttl, boolean useParentCreation) PersistentTtlNode
(CuratorFramework client, String path, long ttlMs, byte[] initData) PersistentTtlNode
(CuratorFramework client, String path, long ttlMs, byte[] initData, boolean useParentCreation) PersistentTtlNode
(CuratorFramework client, ScheduledExecutorService executorService, String path, long ttlMs, byte[] initData, String childNodeName, int touchScheduleFactor) PersistentTtlNode
(CuratorFramework client, ScheduledExecutorService executorService, String path, long ttlMs, byte[] initData, String childNodeName, int touchScheduleFactor, boolean useParentCreation) -
Uses of CuratorFramework in org.apache.curator.framework.recipes.queue
Methods in org.apache.curator.framework.recipes.queue with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionQueueAllocator.allocateQueue
(CuratorFramework client, String queuePath) static <T> QueueBuilder
<T> QueueBuilder.builder
(CuratorFramework client, QueueConsumer<T> consumer, QueueSerializer<T> serializer, String queuePath) Allocate a new buildervoid
BlockingQueueConsumer.stateChanged
(CuratorFramework client, ConnectionState newState) Constructors in org.apache.curator.framework.recipes.queue with parameters of type CuratorFrameworkModifierConstructorDescriptionQueueSharder
(CuratorFramework client, QueueAllocator<U, T> queueAllocator, String queuePath, String leaderPath, QueueSharderPolicies policies) SimpleDistributedQueue
(CuratorFramework client, String path) -
Uses of CuratorFramework in org.apache.curator.framework.recipes.watch
Constructors in org.apache.curator.framework.recipes.watch with parameters of type CuratorFrameworkModifierConstructorDescriptionPersistentWatcher
(CuratorFramework client, String basePath, boolean recursive) -
Uses of CuratorFramework in org.apache.curator.framework.schema
Methods in org.apache.curator.framework.schema with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionstatic String
SchemaSet.getNamedPath
(CuratorFramework client, String name) Utility to return a ZNode path for the given name -
Uses of CuratorFramework in org.apache.curator.framework.state
Methods in org.apache.curator.framework.state with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionConnectionStateListenerManagerFactory.newManager
(CuratorFramework client) Create a new listener managervoid
CircuitBreakingConnectionStateListener.stateChanged
(CuratorFramework client, ConnectionState newState) void
ConnectionStateListener.stateChanged
(CuratorFramework client, ConnectionState newState) Called when there is a state change in the connectionConstructors in org.apache.curator.framework.state with parameters of type CuratorFrameworkModifierConstructorDescriptionCircuitBreakingConnectionStateListener
(CuratorFramework client, ConnectionStateListener listener, RetryPolicy retryPolicy) CircuitBreakingConnectionStateListener
(CuratorFramework client, ConnectionStateListener listener, RetryPolicy retryPolicy, ScheduledExecutorService service) ConnectionStateManager
(CuratorFramework client, ThreadFactory threadFactory, int sessionTimeoutMs, int sessionExpirationPercent) ConnectionStateManager
(CuratorFramework client, ThreadFactory threadFactory, int sessionTimeoutMs, int sessionExpirationPercent, ConnectionStateListenerManagerFactory managerFactory) -
Uses of CuratorFramework in org.apache.curator.x.async
Methods in org.apache.curator.x.async that return CuratorFrameworkModifier and TypeMethodDescriptionAsyncCuratorFramework.unwrap()
Returns the client that was originally passed toAsyncCuratorFramework.wrap(org.apache.curator.framework.CuratorFramework)
Methods in org.apache.curator.x.async with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionstatic AsyncCuratorFramework
AsyncCuratorFramework.wrap
(CuratorFramework client) Takes an old-style Curator instance and returns a new async instance that wraps it. -
Uses of CuratorFramework in org.apache.curator.x.async.details
Methods in org.apache.curator.x.async.details that return CuratorFrameworkConstructors in org.apache.curator.x.async.details with parameters of type CuratorFramework -
Uses of CuratorFramework in org.apache.curator.x.discovery
Methods in org.apache.curator.x.discovery with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionServiceDiscoveryBuilder.client
(CuratorFramework client) Required - set the client to use -
Uses of CuratorFramework in org.apache.curator.x.discovery.details
Methods in org.apache.curator.x.discovery.details with parameters of type CuratorFrameworkModifier and TypeMethodDescriptionvoid
ServiceCacheImpl.childEvent
(CuratorFramework client, PathChildrenCacheEvent event) Constructors in org.apache.curator.x.discovery.details with parameters of type CuratorFrameworkModifierConstructorDescriptionServiceDiscoveryImpl
(CuratorFramework client, String basePath, InstanceSerializer<T> serializer, ServiceInstance<T> thisInstance, boolean watchInstances) ServiceDiscoveryImpl
(CuratorFramework client, DiscoveryPathConstructor pathConstructor, InstanceSerializer<T> serializer, ServiceInstance<T> thisInstance, boolean watchInstances)
usingNamespace(java.lang.String)
passingnull