Package | Description |
---|---|
org.apache.hadoop.hive.metastore | |
org.apache.hadoop.hive.metastore.api | |
org.apache.hadoop.hive.metastore.txn |
Modifier and Type | Method and Description |
---|---|
LockResponse |
HiveMetaStore.HMSHandler.check_lock(CheckLockRequest rqst) |
Modifier and Type | Method and Description |
---|---|
CheckLockRequest |
CheckLockRequest.deepCopy() |
CheckLockRequest |
ThriftHiveMetastore.check_lock_args.getRqst() |
Modifier and Type | Method and Description |
---|---|
LockResponse |
ThriftHiveMetastore.Iface.check_lock(CheckLockRequest rqst) |
LockResponse |
ThriftHiveMetastore.Client.check_lock(CheckLockRequest rqst) |
void |
ThriftHiveMetastore.AsyncIface.check_lock(CheckLockRequest rqst,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.check_lock_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.check_lock(CheckLockRequest rqst,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.check_lock_call> resultHandler) |
int |
CheckLockRequest.compareTo(CheckLockRequest other) |
boolean |
CheckLockRequest.equals(CheckLockRequest that) |
void |
ThriftHiveMetastore.Client.send_check_lock(CheckLockRequest rqst) |
void |
ThriftHiveMetastore.check_lock_args.setRqst(CheckLockRequest rqst) |
Constructor and Description |
---|
CheckLockRequest(CheckLockRequest other)
Performs a deep copy on other.
|
ThriftHiveMetastore.AsyncClient.check_lock_call(CheckLockRequest rqst,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.check_lock_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.check_lock_args(CheckLockRequest rqst) |
Modifier and Type | Method and Description |
---|---|
LockResponse |
TxnHandler.checkLock(CheckLockRequest rqst) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.