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

B

BaseTestTreeCache - Class in org.apache.curator.framework.recipes.cache
 
BaseTestTreeCache() - Constructor for class org.apache.curator.framework.recipes.cache.BaseTestTreeCache
 
buildWithListeners(TreeCache.Builder) - Method in class org.apache.curator.framework.recipes.cache.BaseTestTreeCache
Finish constructing a TreeCache that records exceptions and automatically listens.

C

call() - Method in class org.apache.curator.framework.recipes.queue.QueueTestProducer
 
CHAOS_ZNODE - Static variable in class org.apache.curator.framework.recipes.leader.ChaosMonkeyCnxnFactory
 
CHAOS_ZNODE_PREFIX - Static variable in class org.apache.curator.framework.recipes.leader.ChaosMonkeyCnxnFactory
 
ChaosMonkeyCnxnFactory - Class in org.apache.curator.framework.recipes.leader
A connection factory that will behave like the NIOServerCnxnFactory except that it will unexpectedly close the connection right after the first znode has been created in Zookeeper.
ChaosMonkeyCnxnFactory() - Constructor for class org.apache.curator.framework.recipes.leader.ChaosMonkeyCnxnFactory
 
ChaosMonkeyCnxnFactory.ChaosMonkeyZookeeperServer - Class in org.apache.curator.framework.recipes.leader
 
ChaosMonkeyZookeeperServer(ZooKeeperServer) - Constructor for class org.apache.curator.framework.recipes.leader.ChaosMonkeyCnxnFactory.ChaosMonkeyZookeeperServer
 
createNremoveMelementTest(String, int, int) - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
createNremoveMtest(String, int, int) - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
createProtectedNodeInBackgroundTest() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelectorEdges
Create a protected node in background with a retry policy
createProtectedNodeInBackgroundTestNoRetry() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelectorEdges
Same test as above but without a retry policy
createServer() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCacheConsistency
 
createServer() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatchCluster
 
createServer() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelectorCluster
 

E

Event(TestEventOrdering.EventType, String) - Constructor for class org.apache.curator.framework.recipes.cache.TestEventOrdering.Event
 
eventType - Variable in class org.apache.curator.framework.recipes.cache.TestEventOrdering.Event
 

F

flappingTest() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelectorEdges
Create a LeaderSelector but close the connection right after the "lock" znode has been created.

G

getActualQty(CuratorCache) - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCacheEventOrdering
 
getActualQty(T) - Method in class org.apache.curator.framework.recipes.cache.TestEventOrdering
 
getActualQty(PathChildrenCache) - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCacheEventOrdering
 
getActualQty(TreeCache) - Method in class org.apache.curator.framework.recipes.cache.TestTreeCacheEventOrdering
 
getZkShutdownHandler() - Method in class org.apache.curator.framework.recipes.leader.ChaosMonkeyCnxnFactory.ChaosMonkeyZookeeperServer
 

H

hadBackgroundException - Variable in class org.apache.curator.framework.recipes.cache.BaseTestTreeCache
 

L

LOCK_BASE_PATH - Static variable in class org.apache.curator.framework.recipes.locks.TestInterProcessMutexBase
 
LOCKOUT_DURATION_MS - Static variable in class org.apache.curator.framework.recipes.leader.ChaosMonkeyCnxnFactory
 

M

makeLock(CuratorFramework) - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMultiMutex
 
makeLock(CuratorFramework) - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutex
 
makeLock(CuratorFramework) - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutexBase
 
makeLock(CuratorFramework) - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphoreMutex
 

N

newCache(CuratorFramework, String, BlockingQueue<TestEventOrdering.Event>) - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCacheEventOrdering
 
newCache(CuratorFramework, String, BlockingQueue<TestEventOrdering.Event>) - Method in class org.apache.curator.framework.recipes.cache.TestEventOrdering
 
newCache(CuratorFramework, String, BlockingQueue<TestEventOrdering.Event>) - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCacheEventOrdering
 
newCache(CuratorFramework, String, BlockingQueue<TestEventOrdering.Event>) - Method in class org.apache.curator.framework.recipes.cache.TestTreeCacheEventOrdering
 
newTreeCacheWithListeners(CuratorFramework, String) - Method in class org.apache.curator.framework.recipes.cache.BaseTestTreeCache
Construct a TreeCache that records exceptions and automatically listens.

O

org.apache.curator.connection - package org.apache.curator.connection
 
org.apache.curator.framework.client - package org.apache.curator.framework.client
 
org.apache.curator.framework.recipes.atomic - package org.apache.curator.framework.recipes.atomic
 
org.apache.curator.framework.recipes.barriers - package org.apache.curator.framework.recipes.barriers
 
org.apache.curator.framework.recipes.cache - package org.apache.curator.framework.recipes.cache
 
org.apache.curator.framework.recipes.leader - package org.apache.curator.framework.recipes.leader
 
org.apache.curator.framework.recipes.locks - package org.apache.curator.framework.recipes.locks
 
org.apache.curator.framework.recipes.nodes - package org.apache.curator.framework.recipes.nodes
 
org.apache.curator.framework.recipes.queue - package org.apache.curator.framework.recipes.queue
 
org.apache.curator.framework.recipes.shared - package org.apache.curator.framework.recipes.shared
 
org.apache.curator.framework.recipes.watch - package org.apache.curator.framework.recipes.watch
 

P

path - Variable in class org.apache.curator.framework.recipes.cache.TestEventOrdering.Event
 

Q

QueueTestProducer - Class in org.apache.curator.framework.recipes.queue
 
QueueTestProducer(DistributedQueue<TestQueueItem>, int, int) - Constructor for class org.apache.curator.framework.recipes.queue.QueueTestProducer
 

R

resetCNXFactory() - Static method in class org.apache.curator.framework.recipes.leader.TestLeaderSelectorEdges
 

S

setCNXFactory() - Static method in class org.apache.curator.framework.recipes.leader.TestLeaderSelectorEdges
 
setDataTest(PersistentEphemeralNode.Mode) - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
setup() - Method in class org.apache.curator.framework.recipes.cache.BaseTestTreeCache
 
setup() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentTtlNode
 
setUpClass() - Static method in class org.apache.curator.framework.recipes.nodes.TestPersistentTtlNode
 
startup() - Method in class org.apache.curator.framework.recipes.leader.ChaosMonkeyCnxnFactory.ChaosMonkeyZookeeperServer
 
startup(ZooKeeperServer) - Method in class org.apache.curator.framework.recipes.leader.ChaosMonkeyCnxnFactory
 
submitRequest(Request) - Method in class org.apache.curator.framework.recipes.leader.ChaosMonkeyCnxnFactory.ChaosMonkeyZookeeperServer
 

T

teardown() - Method in class org.apache.curator.framework.recipes.cache.BaseTestTreeCache
 
teardown() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
teardown() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentTtlNode
 
test() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelectorWithExecutor
 
test2Clients() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutexBase
 
testAclErrorWithLeader() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderAcls
 
testACLsCreatingParents() - Method in class org.apache.curator.framework.recipes.locks.TestLockACLs
 
testAcquireAfterLostServer() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
testAdditions() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedPriorityQueue
 
testAfterInitialized() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCache
 
testAsyncInitialPopulation() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testAsyncInitialPopulation() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testAutoRequeue() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelector
 
TestBackgroundStates - Class in org.apache.curator.framework.client
 
TestBackgroundStates() - Constructor for class org.apache.curator.framework.client.TestBackgroundStates
 
testBadReleaseWithNoGet() - Method in class org.apache.curator.connection.TestThreadLocalRetryLoop
 
testBasic() - Method in class org.apache.curator.framework.recipes.atomic.TestCachedAtomicCounter
 
testBasic() - Method in class org.apache.curator.framework.recipes.atomic.TestDistributedAtomicLong
 
testBasic() - Method in class org.apache.curator.framework.recipes.barriers.TestDistributedBarrier
 
testBasic() - Method in class org.apache.curator.framework.recipes.barriers.TestDistributedDoubleBarrier
 
testBasic() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCacheIteratorAndSize
 
testBasic() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testBasic() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelectorParticipants
 
testBasic() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessReadWriteLock
 
testBasic() - Method in class org.apache.curator.framework.recipes.nodes.TestGroupMember
 
testBasic() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentNode
 
testBasic() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentTtlNode
 
testBasic() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedDelayQueue
 
testBasicAlt() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testBasics() - Method in class org.apache.curator.framework.recipes.cache.TestNodeCache
 
testBasics() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testBasics() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testBasics() - Method in class org.apache.curator.framework.recipes.cache.TestWrappedNodeCache
 
testBasicsOnTwoCaches() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testBasicsOnTwoCachesWithSameExecutor() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testBasicsWithNoZkWatches() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
TestBoundedDistributedQueue - Class in org.apache.curator.framework.recipes.queue
 
TestBoundedDistributedQueue() - Constructor for class org.apache.curator.framework.recipes.queue.TestBoundedDistributedQueue
 
TestCachedAtomicCounter - Class in org.apache.curator.framework.recipes.atomic
 
TestCachedAtomicCounter() - Constructor for class org.apache.curator.framework.recipes.atomic.TestCachedAtomicCounter
 
testCallbackDontNotify() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testCallbackNotifyLeader() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testCallbackSanity() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testChildrenInitialized() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testChildrenInitialized() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testChildrenInitializedNormal() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testClearOnClose() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCache
 
testClientClose() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
testClosing() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelector
 
testClosingMultipleTimes() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testCluster() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphoreCluster
 
testCompareAndSet() - Method in class org.apache.curator.framework.recipes.atomic.TestDistributedAtomicLong
 
testCompareAndSetWithFreshInstance() - Method in class org.apache.curator.framework.recipes.atomic.TestDistributedAtomicLong
 
testConnectionLost() - Method in class org.apache.curator.framework.recipes.watch.TestPersistentWatcher
 
testConnectionLostRecursive() - Method in class org.apache.curator.framework.recipes.watch.TestPersistentWatcher
 
testConnectionStateListener() - Method in class org.apache.curator.framework.client.TestBackgroundStates
 
testConnectionStateListener() - Method in class org.apache.curator.framework.client.TestResetConnectionWithBackgroundFailure
 
testConsistencyAfterSimulation() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCacheConsistency
 
testContainerCleanup() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutexBase
 
testContendingDowngrading() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessReadWriteLock
 
testCorrectWatching() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testCorruptedValue() - Method in class org.apache.curator.framework.recipes.atomic.TestDistributedAtomicLong
 
testCreateDeleteRace() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testCreateParents() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testCreationWithParentCreationOff() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentNode
 
TestCuratorCache - Class in org.apache.curator.framework.recipes.cache
 
TestCuratorCache() - Constructor for class org.apache.curator.framework.recipes.cache.TestCuratorCache
 
TestCuratorCacheBridge - Class in org.apache.curator.framework.recipes.cache
 
TestCuratorCacheBridge() - Constructor for class org.apache.curator.framework.recipes.cache.TestCuratorCacheBridge
 
TestCuratorCacheConsistency - Class in org.apache.curator.framework.recipes.cache
Randomly create nodes in a tree while a set of CuratorCaches listens.
TestCuratorCacheConsistency() - Constructor for class org.apache.curator.framework.recipes.cache.TestCuratorCacheConsistency
 
TestCuratorCacheEdges - Class in org.apache.curator.framework.recipes.cache
 
TestCuratorCacheEdges() - Constructor for class org.apache.curator.framework.recipes.cache.TestCuratorCacheEdges
 
TestCuratorCacheEventOrdering - Class in org.apache.curator.framework.recipes.cache
 
TestCuratorCacheEventOrdering() - Constructor for class org.apache.curator.framework.recipes.cache.TestCuratorCacheEventOrdering
 
TestCuratorCacheWrappers - Class in org.apache.curator.framework.recipes.cache
 
TestCuratorCacheWrappers() - Constructor for class org.apache.curator.framework.recipes.cache.TestCuratorCacheWrappers
 
testCustomExecutor() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedQueue
 
testData() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testDeleteNodeAfterCloseDoesntCallExecutor() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testDeleteNodeAfterCloseDoesntCallExecutor() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testDeletesNodeWhenClosed() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testDeletesNodeWhenSessionDisconnects() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testDeleteThenCreate() - Method in class org.apache.curator.framework.recipes.cache.TestNodeCache
 
testDeleteThenCreate() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testDeleteThenCreate() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testDeleteThenCreate() - Method in class org.apache.curator.framework.recipes.cache.TestWrappedNodeCache
 
testDeleteThenCreateRoot() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testDeletingWithLock() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedIdQueue
 
testDepth0() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testDepth1() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testDepth1Deeper() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testDisconnectEventOnWatcherDoesNotRetry() - Method in class org.apache.curator.framework.recipes.shared.TestSharedCount
 
testDisconnectReconnectEventDoesNotFireValueWatcher() - Method in class org.apache.curator.framework.recipes.shared.TestSharedCount
 
testDisconnectReconnectWithMultipleClients() - Method in class org.apache.curator.framework.recipes.shared.TestSharedCount
 
TestDistributedAtomicLong - Class in org.apache.curator.framework.recipes.atomic
 
TestDistributedAtomicLong() - Constructor for class org.apache.curator.framework.recipes.atomic.TestDistributedAtomicLong
 
TestDistributedBarrier - Class in org.apache.curator.framework.recipes.barriers
 
TestDistributedBarrier() - Constructor for class org.apache.curator.framework.recipes.barriers.TestDistributedBarrier
 
TestDistributedDelayQueue - Class in org.apache.curator.framework.recipes.queue
 
TestDistributedDelayQueue() - Constructor for class org.apache.curator.framework.recipes.queue.TestDistributedDelayQueue
 
TestDistributedDoubleBarrier - Class in org.apache.curator.framework.recipes.barriers
 
TestDistributedDoubleBarrier() - Constructor for class org.apache.curator.framework.recipes.barriers.TestDistributedDoubleBarrier
 
TestDistributedIdQueue - Class in org.apache.curator.framework.recipes.queue
 
TestDistributedIdQueue() - Constructor for class org.apache.curator.framework.recipes.queue.TestDistributedIdQueue
 
TestDistributedPriorityQueue - Class in org.apache.curator.framework.recipes.queue
 
TestDistributedPriorityQueue() - Constructor for class org.apache.curator.framework.recipes.queue.TestDistributedPriorityQueue
 
TestDistributedQueue - Class in org.apache.curator.framework.recipes.queue
 
TestDistributedQueue() - Constructor for class org.apache.curator.framework.recipes.queue.TestDistributedQueue
 
testDistribution() - Method in class org.apache.curator.framework.recipes.queue.TestQueueSharder
 
testDowngrading() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessReadWriteLock
 
testElement1() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testElement2() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testElement3() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testElement4() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testEmptyTree() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCacheIteratorAndSize
 
testEnsurePath() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testEphemeralSequentialWithProtectionReconnection() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentNode
 
testErrorListener() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testErrorMode() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedQueue
 
testErrorPolicies() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testErrorPolicies() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelector
 
TestEventOrdering<T extends Closeable> - Class in org.apache.curator.framework.recipes.cache
 
TestEventOrdering() - Constructor for class org.apache.curator.framework.recipes.cache.TestEventOrdering
 
testEventOrdering() - Method in class org.apache.curator.framework.recipes.cache.TestEventOrdering
 
TestEventOrdering.Event - Class in org.apache.curator.framework.recipes.cache
 
TestEventOrdering.EventType - Enum in org.apache.curator.framework.recipes.cache
 
testEventsOnParent() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentTtlNode
 
testFlush() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedQueue
 
testForcedDeleteOfTouchNode() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentTtlNode
 
testForceSet() - Method in class org.apache.curator.framework.recipes.atomic.TestDistributedAtomicLong
 
testForceTreeCache() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCacheBridge
 
testFromRoot() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testFromRootWithDepth() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testGetParticipantNodes() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessReadWriteLock
 
testGetParticipantNodes() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
testGiantRandomDeepTree() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCacheRandomTree
 
testGiantRandomDeepTreeWithDepth() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCacheRandomTree
 
TestGroupMember - Class in org.apache.curator.framework.recipes.nodes
 
TestGroupMember() - Constructor for class org.apache.curator.framework.recipes.nodes.TestGroupMember
 
testHangFromContainerLoss() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testId() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelectorParticipants
 
testImplementationSelection() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCacheBridge
 
testInCluster() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatchCluster
 
testInitializedEvenIfChildDeleted() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
TestInterProcessMultiMutex - Class in org.apache.curator.framework.recipes.locks
 
TestInterProcessMultiMutex() - Constructor for class org.apache.curator.framework.recipes.locks.TestInterProcessMultiMutex
 
TestInterProcessMutex - Class in org.apache.curator.framework.recipes.locks
 
TestInterProcessMutex() - Constructor for class org.apache.curator.framework.recipes.locks.TestInterProcessMutex
 
TestInterProcessMutexBase - Class in org.apache.curator.framework.recipes.locks
 
TestInterProcessMutexBase() - Constructor for class org.apache.curator.framework.recipes.locks.TestInterProcessMutexBase
 
TestInterProcessReadWriteLock - Class in org.apache.curator.framework.recipes.locks
 
TestInterProcessReadWriteLock() - Constructor for class org.apache.curator.framework.recipes.locks.TestInterProcessReadWriteLock
 
TestInterProcessSemaphore - Class in org.apache.curator.framework.recipes.locks
 
TestInterProcessSemaphore() - Constructor for class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
TestInterProcessSemaphoreCluster - Class in org.apache.curator.framework.recipes.locks
 
TestInterProcessSemaphoreCluster() - Constructor for class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphoreCluster
 
TestInterProcessSemaphoreMutex - Class in org.apache.curator.framework.recipes.locks
 
TestInterProcessSemaphoreMutex() - Constructor for class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphoreMutex
 
testInterruptAcquire() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
testInterruptedOperationOnShutdown() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
Tests the case where there's an outstanding operation being executed when the cache is shut down.
testInterruption() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelector
 
testInterruptLeadership() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelector
 
testInterruptLeadershipWithRequeue() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelector
 
testIssue27() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testIssue27Alt() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testIteratorWithRandomGraph() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCacheIteratorAndSize
 
testKilledServerWithEnsembleProvider() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphoreCluster
 
testKilledSession() - Method in class org.apache.curator.framework.recipes.cache.TestNodeCache
 
testKilledSession() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testKilledSession() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testKilledSession() - Method in class org.apache.curator.framework.recipes.cache.TestWrappedNodeCache
 
testKilledSession() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutexBase
 
testKillServerThenCloseShouldElectNewLeader() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelector
This is similar to TestLeaderSelector.testKillSessionThenCloseShouldElectNewLeader The differences are: it restarts the TestingServer instead of killing the session it uses autoRequeue instead of explicitly calling requeue
testKillSessionThenCloseShouldElectNewLeader() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelector
 
testLateAddition() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedDelayQueue
 
TestLeaderAcls - Class in org.apache.curator.framework.recipes.leader
 
TestLeaderAcls() - Constructor for class org.apache.curator.framework.recipes.leader.TestLeaderAcls
 
TestLeaderLatch - Class in org.apache.curator.framework.recipes.leader
 
TestLeaderLatch() - Constructor for class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
TestLeaderLatchCluster - Class in org.apache.curator.framework.recipes.leader
 
TestLeaderLatchCluster() - Constructor for class org.apache.curator.framework.recipes.leader.TestLeaderLatchCluster
 
testLeaderNodeDeleteOnInterrupt() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelector
 
TestLeaderSelector - Class in org.apache.curator.framework.recipes.leader
 
TestLeaderSelector() - Constructor for class org.apache.curator.framework.recipes.leader.TestLeaderSelector
 
TestLeaderSelectorCluster - Class in org.apache.curator.framework.recipes.leader
 
TestLeaderSelectorCluster() - Constructor for class org.apache.curator.framework.recipes.leader.TestLeaderSelectorCluster
 
TestLeaderSelectorEdges - Class in org.apache.curator.framework.recipes.leader
Test cases designed after CURATOR-45
TestLeaderSelectorEdges() - Constructor for class org.apache.curator.framework.recipes.leader.TestLeaderSelectorEdges
 
TestLeaderSelectorParticipants - Class in org.apache.curator.framework.recipes.leader
 
TestLeaderSelectorParticipants() - Constructor for class org.apache.curator.framework.recipes.leader.TestLeaderSelectorParticipants
 
TestLeaderSelectorWithExecutor - Class in org.apache.curator.framework.recipes.leader
 
TestLeaderSelectorWithExecutor() - Constructor for class org.apache.curator.framework.recipes.leader.TestLeaderSelectorWithExecutor
 
testLeadershipElectionWhenNodeDisappearsAfterChildrenAreRetrieved() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testListenerBuilder() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCache
 
testListenersReconnectedIsFast() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testListenersReconnectedIsOK() - Method in class org.apache.curator.framework.client.TestBackgroundStates
 
testListenersReconnectedIsOK() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNodeListener
 
TestLockACLs - Class in org.apache.curator.framework.recipes.locks
 
TestLockACLs() - Constructor for class org.apache.curator.framework.recipes.locks.TestLockACLs
 
testLockACLs() - Method in class org.apache.curator.framework.recipes.locks.TestLockACLs
 
TestLockCleanlinessWithFaults - Class in org.apache.curator.framework.recipes.locks
 
TestLockCleanlinessWithFaults() - Constructor for class org.apache.curator.framework.recipes.locks.TestLockCleanlinessWithFaults
 
testLocker() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutexBase
 
testLockPath() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessReadWriteLock
 
TestLongNetworkPartition - Class in org.apache.curator.framework.recipes.queue
 
TestLongNetworkPartition() - Constructor for class org.apache.curator.framework.recipes.queue.TestLongNetworkPartition
 
testLongNetworkPartition() - Method in class org.apache.curator.framework.recipes.queue.TestLongNetworkPartition
 
testLostConnection() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testLostRestart() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelectorCluster
 
testMaxPerSession() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
testMinItemsBeforeRefresh() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedPriorityQueue
 
testMissedDelete() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCacheInCluster
 
testModes() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testMulti() - Method in class org.apache.curator.framework.recipes.queue.TestBoundedDistributedQueue
 
testMultiClient() - Method in class org.apache.curator.framework.recipes.barriers.TestDistributedBarrier
 
testMultiClient() - Method in class org.apache.curator.framework.recipes.barriers.TestDistributedDoubleBarrier
 
testMultiClientDifferentSeed() - Method in class org.apache.curator.framework.recipes.shared.TestSharedCount
 
testMultiClients() - Method in class org.apache.curator.framework.recipes.shared.TestSharedCount
 
testMultiClientVersioned() - Method in class org.apache.curator.framework.recipes.shared.TestSharedCount
 
testMultiPutterSingleGetter() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedQueue
 
testNoBarrier() - Method in class org.apache.curator.framework.recipes.barriers.TestDistributedBarrier
 
testNoCreatePermission() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testNodeCache() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCacheWrappers
 
TestNodeCache - Class in org.apache.curator.framework.recipes.cache
 
TestNodeCache() - Constructor for class org.apache.curator.framework.recipes.cache.TestNodeCache
 
testNodeDeleted() - Method in class org.apache.curator.framework.recipes.locks.TestLockCleanlinessWithFaults
 
testNodesCreateUniquePaths() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testNoDuplicateProcessing() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedQueue
 
testNoOrphanedNodes() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
testNoServerAtStart() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testNoServerAtStart() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testNoWritePermission() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testNullCurator() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testNullData() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testNullMode() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testNullPath() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testOffer1() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testOffer2() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testOrdering() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedIdQueue
 
testOverSubscribed() - Method in class org.apache.curator.framework.recipes.barriers.TestDistributedDoubleBarrier
 
testParentContainerMissing() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testPathChildrenCache() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCacheWrappers
 
TestPathChildrenCache - Class in org.apache.curator.framework.recipes.cache
 
TestPathChildrenCache() - Constructor for class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
TestPathChildrenCacheEventOrdering - Class in org.apache.curator.framework.recipes.cache
 
TestPathChildrenCacheEventOrdering() - Constructor for class org.apache.curator.framework.recipes.cache.TestPathChildrenCacheEventOrdering
 
TestPathChildrenCacheInCluster - Class in org.apache.curator.framework.recipes.cache
 
TestPathChildrenCacheInCluster() - Constructor for class org.apache.curator.framework.recipes.cache.TestPathChildrenCacheInCluster
 
TestPersistentEphemeralNode - Class in org.apache.curator.framework.recipes.nodes
 
TestPersistentEphemeralNode() - Constructor for class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
TestPersistentEphemeralNodeListener - Class in org.apache.curator.framework.recipes.nodes
 
TestPersistentEphemeralNodeListener() - Constructor for class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNodeListener
 
testPersistentLock() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutex
 
TestPersistentNode - Class in org.apache.curator.framework.recipes.nodes
 
TestPersistentNode() - Constructor for class org.apache.curator.framework.recipes.nodes.TestPersistentNode
 
TestPersistentTtlNode - Class in org.apache.curator.framework.recipes.nodes
 
TestPersistentTtlNode() - Constructor for class org.apache.curator.framework.recipes.nodes.TestPersistentTtlNode
 
TestPersistentWatcher - Class in org.apache.curator.framework.recipes.watch
 
TestPersistentWatcher() - Constructor for class org.apache.curator.framework.recipes.watch.TestPersistentWatcher
 
testPollWithTimeout() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testPostInitializedForEmpty() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testProperCloseWithoutConnectionEstablished() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testProtected() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
See CURATOR-190 For protected nodes on reconnect the current protected name was passed to the create builder meaning that it got appended to the new protected node name.
testPutListener() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedQueue
 
testPutMulti() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedQueue
 
TestQueueSharder - Class in org.apache.curator.framework.recipes.queue
 
TestQueueSharder() - Constructor for class org.apache.curator.framework.recipes.queue.TestQueueSharder
 
testQuickClose() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentNode
 
testQuickCloseNodeExists() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentNode
 
testQuickSetData() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentNode
 
testRaceAtStateChanged() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelector
 
testRebuildAgainstOtherProcesses() - Method in class org.apache.curator.framework.recipes.cache.TestNodeCache
 
testRebuildAgainstOtherProcesses() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testRebuildNode() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testReconnectConsistency() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCacheEdges
 
testRecreatesNodeWhenEphemeralOwnerSessionExpires() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testRecreatesNodeWhenItGetsDeleted() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testRecreatesNodeWhenSessionReconnects() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testRecreatesNodeWhenSessionReconnectsMultipleTimes() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testRecreationOfParentNodeWithParentCreationOff() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentTtlNode
 
testRecreationWithParentCreationOff() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentNode
 
testRecursingRetry() - Method in class org.apache.curator.connection.TestThreadLocalRetryLoop
 
testReentrant() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutexBase
 
testReentrant() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphoreMutex
 
testReentrant2Threads() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutexBase
 
testReentrant2Threads() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphoreMutex
 
testReentrantSingleLock() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutexBase
 
testReentrantSingleLock() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphoreMutex
 
testRelativePath() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testRelease1AtATime() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
testReleaseInChunks() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
testRemova1() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testRemove2() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testRemove3() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testRequeuingWithLock() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedIdQueue
 
TestResetConnectionWithBackgroundFailure - Class in org.apache.curator.framework.client
 
TestResetConnectionWithBackgroundFailure() - Constructor for class org.apache.curator.framework.client.TestResetConnectionWithBackgroundFailure
 
testResetRace() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testResettingOfLeadershipAfterConcurrentLeadershipChange() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testRestart() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelectorCluster
 
testRetryAfterFailure_Curator56() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedQueue
 
testRevoking() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutex
 
testRotatingLeadership() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelector
 
testSafetyBasic() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedQueue
 
testSafetyWithCrash() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedQueue
 
testSelector() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testServerCrash() - Method in class org.apache.curator.framework.recipes.barriers.TestDistributedBarrier
 
testServerDying() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderSelector
 
testServerLoss() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCacheEdges
 
testServerLoss() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCacheInCluster
 
testServerNotStartedYet() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
Make sure TreeCache gets to a sane state when we can't initially connect to server.
testSessionErrorPolicy() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testSetDataWhenDisconnected() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testSetDataWhenNodeExists() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
Test that if a persistent ephemeral node is created and the node already exists that if data is present in the PersistentEphermalNode that it is still set.
testSetNodeData() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessReadWriteLock
 
testSettingData() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testSettingDataSequential() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testSetUpdatedDataWhenReconnected() - Method in class org.apache.curator.framework.recipes.nodes.TestPersistentEphemeralNode
 
testSharderWatchSync() - Method in class org.apache.curator.framework.recipes.queue.TestQueueSharder
 
TestSharedCount - Class in org.apache.curator.framework.recipes.shared
 
TestSharedCount() - Constructor for class org.apache.curator.framework.recipes.shared.TestSharedCount
 
testSimple() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
testSimple() - Method in class org.apache.curator.framework.recipes.queue.TestBoundedDistributedQueue
 
testSimple() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedDelayQueue
 
testSimple() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedPriorityQueue
 
testSimple() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedQueue
 
testSimple() - Method in class org.apache.curator.framework.recipes.shared.TestSharedCount
 
testSimple2() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
testSimpleDistributedQueue() - Method in class org.apache.curator.framework.recipes.queue.TestQueueSharder
 
TestSimpleDistributedQueue - Class in org.apache.curator.framework.recipes.queue
 
TestSimpleDistributedQueue() - Constructor for class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testSimpleVersioned() - Method in class org.apache.curator.framework.recipes.shared.TestSharedCount
 
testSimulation() - Method in class org.apache.curator.framework.recipes.atomic.TestDistributedAtomicLong
 
testSomeLocksFailToLock() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMultiMutex
 
testSomeReleasesFail() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMultiMutex
 
testSorting() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedDelayQueue
 
testSortingWhileTaking() - Method in class org.apache.curator.framework.recipes.queue.TestDistributedPriorityQueue
 
testStartEmpty() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testStartEmptyDeeper() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testStartup() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testSyncInitialPopulation() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testTake1() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testTakeWait1() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testTakeWait2() - Method in class org.apache.curator.framework.recipes.queue.TestSimpleDistributedQueue
 
testThatDowngradingRespectsThreads() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessReadWriteLock
 
testThatUpgradingIsDisallowed() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessReadWriteLock
 
testThreadedLeaseIncrease() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
testThreadedRecursingRetry() - Method in class org.apache.curator.connection.TestThreadLocalRetryLoop
 
TestThreadLocalRetryLoop - Class in org.apache.curator.connection
 
TestThreadLocalRetryLoop() - Constructor for class org.apache.curator.connection.TestThreadLocalRetryLoop
 
testThreads() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessSemaphore
 
testTreeCache() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCacheWrappers
 
TestTreeCache - Class in org.apache.curator.framework.recipes.cache
 
TestTreeCache() - Constructor for class org.apache.curator.framework.recipes.cache.TestTreeCache
 
TestTreeCacheEventOrdering - Class in org.apache.curator.framework.recipes.cache
 
TestTreeCacheEventOrdering() - Constructor for class org.apache.curator.framework.recipes.cache.TestTreeCacheEventOrdering
 
TestTreeCacheIteratorAndSize - Class in org.apache.curator.framework.recipes.cache
 
TestTreeCacheIteratorAndSize() - Constructor for class org.apache.curator.framework.recipes.cache.TestTreeCacheIteratorAndSize
 
TestTreeCacheRandomTree - Class in org.apache.curator.framework.recipes.cache
 
TestTreeCacheRandomTree() - Constructor for class org.apache.curator.framework.recipes.cache.TestTreeCacheRandomTree
 
testUncreatedPathGetLeader() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testUpdateWhenNotCachingData() - Method in class org.apache.curator.framework.recipes.cache.TestCuratorCache
 
testUpdateWhenNotCachingData() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testUpdateWhenNotCachingData() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testWaiting() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testWaitingProcessKilledServer() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutexBase
 
testWatchedNodeDeletedOnReconnect() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testWithBadConnect() - Method in class org.apache.curator.framework.recipes.cache.TestPathChildrenCache
 
testWithCircuitBreaker() - Method in class org.apache.curator.framework.recipes.leader.TestLeaderLatch
 
testWithDeletedNodes() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCacheIteratorAndSize
 
testWithError() - Method in class org.apache.curator.framework.recipes.atomic.TestCachedAtomicCounter
 
testWithNamespace() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testWithNamespace() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutexBase
 
testWithNamespaceAtRoot() - Method in class org.apache.curator.framework.recipes.cache.TestTreeCache
 
testWithSchema() - Method in class org.apache.curator.framework.recipes.locks.TestInterProcessMutex
 
TestWrappedNodeCache - Class in org.apache.curator.framework.recipes.cache
 
TestWrappedNodeCache() - Constructor for class org.apache.curator.framework.recipes.cache.TestWrappedNodeCache
 
time - Variable in class org.apache.curator.framework.recipes.cache.TestEventOrdering.Event
 

V

valueOf(String) - Static method in enum org.apache.curator.framework.recipes.cache.TestEventOrdering.EventType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.curator.framework.recipes.cache.TestEventOrdering.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
B C E F G H L M N O P Q R S T V 
Skip navigation links

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