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 |
---|---|
void |
HiveMetaStore.HMSHandler.add_dynamic_partitions(AddDynamicPartitions rqst) |
LockResponse |
HiveMetaStore.HMSHandler.check_lock(CheckLockRequest rqst) |
LockResponse |
IMetaStoreClient.checkLock(long lockid)
Check the status of a set of locks requested via a
IMetaStoreClient.lock(org.apache.hadoop.hive.metastore.api.LockRequest) call. |
LockResponse |
HiveMetaStoreClient.checkLock(long lockid) |
void |
HiveMetaStore.HMSHandler.commit_txn(CommitTxnRequest rqst) |
void |
IMetaStoreClient.commitTxn(long txnid)
Commit a transaction.
|
void |
HiveMetaStoreClient.commitTxn(long txnid) |
void |
HiveMetaStore.HMSHandler.heartbeat(HeartbeatRequest ids) |
void |
IMetaStoreClient.heartbeat(long txnid,
long lockid)
Send a heartbeat to indicate that the client holding these locks (if
any) and that opened this transaction (if one exists) is still alive.
|
void |
HiveMetaStoreClient.heartbeat(long txnid,
long lockid) |
HeartbeatTxnRangeResponse |
HiveMetaStoreClient.heartbeatTxnRange(long min,
long max) |
LockResponse |
IMetaStoreClient.lock(LockRequest request)
Request a set of locks.
|
LockResponse |
HiveMetaStoreClient.lock(LockRequest request) |
LockResponse |
HiveMetaStore.HMSHandler.lock(LockRequest rqst) |
Modifier and Type | Method and Description |
---|---|
TxnAbortedException |
TxnAbortedException.deepCopy() |
TxnAbortedException |
ThriftHiveMetastore.commit_txn_result.getO2() |
TxnAbortedException |
ThriftHiveMetastore.lock_result.getO2() |
TxnAbortedException |
ThriftHiveMetastore.check_lock_result.getO2() |
TxnAbortedException |
ThriftHiveMetastore.add_dynamic_partitions_result.getO2() |
TxnAbortedException |
ThriftHiveMetastore.heartbeat_result.getO3() |
Modifier and Type | Method and Description |
---|---|
int |
TxnAbortedException.compareTo(TxnAbortedException other) |
boolean |
TxnAbortedException.equals(TxnAbortedException that) |
void |
ThriftHiveMetastore.commit_txn_result.setO2(TxnAbortedException o2) |
void |
ThriftHiveMetastore.lock_result.setO2(TxnAbortedException o2) |
void |
ThriftHiveMetastore.check_lock_result.setO2(TxnAbortedException o2) |
void |
ThriftHiveMetastore.add_dynamic_partitions_result.setO2(TxnAbortedException o2) |
void |
ThriftHiveMetastore.heartbeat_result.setO3(TxnAbortedException o3) |
Modifier and Type | Method and Description |
---|---|
void |
ThriftHiveMetastore.Iface.add_dynamic_partitions(AddDynamicPartitions rqst) |
void |
ThriftHiveMetastore.Client.add_dynamic_partitions(AddDynamicPartitions rqst) |
LockResponse |
ThriftHiveMetastore.Iface.check_lock(CheckLockRequest rqst) |
LockResponse |
ThriftHiveMetastore.Client.check_lock(CheckLockRequest rqst) |
void |
ThriftHiveMetastore.Iface.commit_txn(CommitTxnRequest rqst) |
void |
ThriftHiveMetastore.Client.commit_txn(CommitTxnRequest rqst) |
void |
ThriftHiveMetastore.AsyncClient.commit_txn_call.getResult() |
LockResponse |
ThriftHiveMetastore.AsyncClient.lock_call.getResult() |
LockResponse |
ThriftHiveMetastore.AsyncClient.check_lock_call.getResult() |
void |
ThriftHiveMetastore.AsyncClient.heartbeat_call.getResult() |
void |
ThriftHiveMetastore.AsyncClient.add_dynamic_partitions_call.getResult() |
void |
ThriftHiveMetastore.Iface.heartbeat(HeartbeatRequest ids) |
void |
ThriftHiveMetastore.Client.heartbeat(HeartbeatRequest ids) |
LockResponse |
ThriftHiveMetastore.Iface.lock(LockRequest rqst) |
LockResponse |
ThriftHiveMetastore.Client.lock(LockRequest rqst) |
void |
ThriftHiveMetastore.Client.recv_add_dynamic_partitions() |
LockResponse |
ThriftHiveMetastore.Client.recv_check_lock() |
void |
ThriftHiveMetastore.Client.recv_commit_txn() |
void |
ThriftHiveMetastore.Client.recv_heartbeat() |
LockResponse |
ThriftHiveMetastore.Client.recv_lock() |
Constructor and Description |
---|
ThriftHiveMetastore.add_dynamic_partitions_result(NoSuchTxnException o1,
TxnAbortedException o2) |
ThriftHiveMetastore.check_lock_result(LockResponse success,
NoSuchTxnException o1,
TxnAbortedException o2,
NoSuchLockException o3) |
ThriftHiveMetastore.commit_txn_result(NoSuchTxnException o1,
TxnAbortedException o2) |
ThriftHiveMetastore.heartbeat_result(NoSuchLockException o1,
NoSuchTxnException o2,
TxnAbortedException o3) |
ThriftHiveMetastore.lock_result(LockResponse success,
NoSuchTxnException o1,
TxnAbortedException o2) |
TxnAbortedException(TxnAbortedException other)
Performs a deep copy on other.
|
Modifier and Type | Method and Description |
---|---|
void |
TxnHandler.addDynamicPartitions(AddDynamicPartitions rqst) |
LockResponse |
TxnHandler.checkLock(CheckLockRequest rqst) |
void |
TxnHandler.commitTxn(CommitTxnRequest rqst) |
void |
TxnHandler.heartbeat(HeartbeatRequest ids) |
LockResponse |
TxnHandler.lock(LockRequest rqst) |
LockResponse |
TxnHandler.lockNoWait(LockRequest rqst) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.