| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.master | |
| org.apache.hadoop.hbase.zookeeper.lock | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
InterProcessLock.visitLocks(InterProcessLock.MetadataHandler handler)
Visits the locks (both held and attempted) of this type with the given
  
InterProcessLock.MetadataHandler. | 
| Modifier and Type | Method and Description | 
|---|---|
abstract void | 
TableLockManager.visitAllLocks(InterProcessLock.MetadataHandler handler)
Visits all table locks(read and write), and lock attempts with the given callback
 MetadataHandler. 
 | 
void | 
TableLockManager.NullTableLockManager.visitAllLocks(InterProcessLock.MetadataHandler handler)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected InterProcessLock.MetadataHandler | 
ZKInterProcessLockBase.handler  | 
| Modifier and Type | Method and Description | 
|---|---|
protected boolean | 
ZKInterProcessLockBase.handleLockMetadata(String lockZNode,
                  InterProcessLock.MetadataHandler handler)
Process metadata stored in a ZNode using a callback object passed to
 this instance. 
 | 
void | 
ZKInterProcessLockBase.visitLocks(InterProcessLock.MetadataHandler handler)
Visits the locks (both held and attempted) with the given MetadataHandler. 
 | 
| Constructor and Description | 
|---|
ZKInterProcessLockBase(ZooKeeperWatcher zkWatcher,
                      String parentLockNode,
                      byte[] metadata,
                      InterProcessLock.MetadataHandler handler,
                      String childNode)
Called by implementing classes. 
 | 
ZKInterProcessReadLock(ZooKeeperWatcher zooKeeperWatcher,
                      String znode,
                      byte[] metadata,
                      InterProcessLock.MetadataHandler handler)  | 
ZKInterProcessReadWriteLock(ZooKeeperWatcher zkWatcher,
                           String znode,
                           InterProcessLock.MetadataHandler handler)
Creates a DistributedReadWriteLock instance. 
 | 
ZKInterProcessWriteLock(ZooKeeperWatcher zooKeeperWatcher,
                       String znode,
                       byte[] metadata,
                       InterProcessLock.MetadataHandler handler)  | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.