You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by ha...@apache.org on 2016/08/04 23:07:20 UTC

hive git commit: Missed file for HIVE-14204

Repository: hive
Updated Branches:
  refs/heads/master d297b5108 -> 44bcedbad


Missed file for HIVE-14204


Project: http://git-wip-us.apache.org/repos/asf/hive/repo
Commit: http://git-wip-us.apache.org/repos/asf/hive/commit/44bcedba
Tree: http://git-wip-us.apache.org/repos/asf/hive/tree/44bcedba
Diff: http://git-wip-us.apache.org/repos/asf/hive/diff/44bcedba

Branch: refs/heads/master
Commit: 44bcedbadefe3673baf3c3dd11615b6facbb78dd
Parents: d297b51
Author: Ashutosh Chauhan <ha...@apache.org>
Authored: Thu Aug 4 16:06:51 2016 -0700
Committer: Ashutosh Chauhan <ha...@apache.org>
Committed: Thu Aug 4 16:06:51 2016 -0700

----------------------------------------------------------------------
 .../metastore/SynchronizedMetaStoreClient.java  | 90 ++++++++++++++++++++
 1 file changed, 90 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hive/blob/44bcedba/ql/src/java/org/apache/hadoop/hive/metastore/SynchronizedMetaStoreClient.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/metastore/SynchronizedMetaStoreClient.java b/ql/src/java/org/apache/hadoop/hive/metastore/SynchronizedMetaStoreClient.java
new file mode 100644
index 0000000..f5d2c76
--- /dev/null
+++ b/ql/src/java/org/apache/hadoop/hive/metastore/SynchronizedMetaStoreClient.java
@@ -0,0 +1,90 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * <p>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p>
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.hadoop.hive.metastore;
+
+import org.apache.hadoop.hive.common.ValidTxnList;
+import org.apache.hadoop.hive.metastore.api.EnvironmentContext;
+import org.apache.hadoop.hive.metastore.api.LockRequest;
+import org.apache.hadoop.hive.metastore.api.LockResponse;
+import org.apache.hadoop.hive.metastore.api.Partition;
+import org.apache.hadoop.hive.metastore.api.ShowLocksRequest;
+import org.apache.hadoop.hive.metastore.api.ShowLocksResponse;
+import org.apache.thrift.TException;
+
+
+/**
+ * Synchronized MetaStoreClient wrapper
+ */
+public final class SynchronizedMetaStoreClient {
+
+  private final IMetaStoreClient client;
+
+  public SynchronizedMetaStoreClient(IMetaStoreClient client) {
+    this.client = client;
+  }
+
+  public synchronized long openTxn(String user) throws TException {
+    return client.openTxn(user);
+  }
+
+  public synchronized void commitTxn(long txnid) throws TException {
+    client.commitTxn(txnid);
+  }
+
+  public synchronized void rollbackTxn(long txnid) throws TException {
+    client.rollbackTxn(txnid);
+  }
+
+  public synchronized void heartbeat(long txnid, long lockid) throws TException {
+    client.heartbeat(txnid, lockid);
+  }
+
+  public synchronized ValidTxnList getValidTxns(long currentTxn) throws TException {
+    return client.getValidTxns(currentTxn);
+  }
+
+  public synchronized LockResponse lock(LockRequest request) throws TException {
+    return client.lock(request);
+  }
+
+  public synchronized Partition add_partition(Partition partition) throws TException {
+    return client.add_partition(partition);
+  }
+
+  public synchronized void alter_partition(String dbName, String tblName,
+      Partition newPart, EnvironmentContext environmentContext) throws TException {
+    client.alter_partition(dbName, tblName, newPart, environmentContext);
+  }
+
+  public synchronized LockResponse checkLock(long lockid) throws TException {
+    return client.checkLock(lockid);
+  }
+
+  public synchronized void unlock(long lockid) throws TException {
+    client.unlock(lockid);
+  }
+
+  public synchronized ShowLocksResponse showLocks(ShowLocksRequest showLocksRequest) throws TException {
+    return client.showLocks(showLocksRequest);
+  }
+
+  public synchronized void close() {
+    client.close();
+  }
+}