You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by mb...@apache.org on 2012/09/18 20:39:55 UTC

svn commit: r1387310 [2/3] - in /hbase/branches/0.89-fb/src: main/java/org/apache/hadoop/hbase/regionserver/ main/java/org/apache/hadoop/hbase/thrift/ main/java/org/apache/hadoop/hbase/thrift/generated/ main/java/org/apache/hadoop/hbase/util/ main/reso...

Modified: hbase/branches/0.89-fb/src/main/java/org/apache/hadoop/hbase/thrift/generated/Hbase.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/main/java/org/apache/hadoop/hbase/thrift/generated/Hbase.java?rev=1387310&r1=1387309&r2=1387310&view=diff
==============================================================================
--- hbase/branches/0.89-fb/src/main/java/org/apache/hadoop/hbase/thrift/generated/Hbase.java (original)
+++ hbase/branches/0.89-fb/src/main/java/org/apache/hadoop/hbase/thrift/generated/Hbase.java Tue Sep 18 18:39:54 2012
@@ -32,7 +32,8 @@ public class Hbase {
   public interface Iface {
 
     /**
-     * Atomically increment the column value specified.  Returns the next value post increment.
+     * Atomically increment the column value specified. Returns the next value
+     * post increment.
      *
      * @param tableName name of table
      * 
@@ -111,8 +112,10 @@ public class Hbase {
      * @param row Row to update
      * 
      * @param column name of column whose value is to be deleted
+     * 
+     * @param regionName
      */
-    public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column) throws IOError, org.apache.thrift.TException;
+    public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Completely delete the row's cells.
@@ -122,8 +125,10 @@ public class Hbase {
      * @param row key of the row to be completely deleted.
      * 
      * @param attributes Delete attributes
+     * 
+     * @param regionName
      */
-    public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException;
+    public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Completely delete the row's cells marked with a timestamp
@@ -134,8 +139,10 @@ public class Hbase {
      * @param row key of the row to be completely deleted.
      * 
      * @param timestamp timestamp
+     * 
+     * @param regionName
      */
-    public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp) throws IOError, org.apache.thrift.TException;
+    public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Delete all cells that match the passed row and column and whose
@@ -148,8 +155,10 @@ public class Hbase {
      * @param column name of column whose value is to be deleted
      *
      * @param timestamp timestamp
+     * 
+     * @param regionName
      */
-    public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp) throws IOError, org.apache.thrift.TException;
+    public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Deletes a table
@@ -187,8 +196,10 @@ public class Hbase {
      * @param row row key
      *
      * @param column column name
+     * 
+     * @param regionName
      */
-    public List<TCell> get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column) throws IOError, org.apache.thrift.TException;
+    public List<TCell> get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * List all the column families associated with a table.
@@ -218,8 +229,10 @@ public class Hbase {
      * @param tableName name of table
      *
      * @param row row key
+     * 
+     * @param regionName
      */
-    public List<TRowResult> getRow(ByteBuffer tableName, ByteBuffer row) throws IOError, org.apache.thrift.TException;
+    public List<TRowResult> getRow(ByteBuffer tableName, ByteBuffer row, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Get all the data for the specified table and row at the specified
@@ -232,8 +245,10 @@ public class Hbase {
      * @param row row key
      *
      * @param timestamp timestamp
+     * 
+     * @param regionName
      */
-    public List<TRowResult> getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp) throws IOError, org.apache.thrift.TException;
+    public List<TRowResult> getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Get the columns with the specified prefix for the specified table and
@@ -250,8 +265,10 @@ public class Hbase {
      * family name can be specified as <family>:<qualifier prefix>
      * If only <qualifier prefix> provided then all families are
      * searched
+     * 
+     * @param regionName
      */
-    public List<TRowResult> getRowWithColumnPrefix(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix) throws IOError, org.apache.thrift.TException;
+    public List<TRowResult> getRowWithColumnPrefix(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Get the columns with the specified prefix for the specified table and
@@ -270,8 +287,9 @@ public class Hbase {
      * searched
      *
      * @param timestamp
+     * @param regionName
      */
-    public List<TRowResult> getRowWithColumnPrefixTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, long timestamp) throws IOError, org.apache.thrift.TException;
+    public List<TRowResult> getRowWithColumnPrefixTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Get the specified columns for the specified table and row at the latest
@@ -284,8 +302,10 @@ public class Hbase {
      * @param row row key
      *
      * @param columns List of columns to return, null for all columns
+     * 
+     * @param regionName
      */
-    public List<TRowResult> getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns) throws IOError, org.apache.thrift.TException;
+    public List<TRowResult> getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Get the specified columns for the specified table and row at the specified
@@ -300,8 +320,9 @@ public class Hbase {
      * @param columns List of columns to return, null for all columns
      *
      * @param timestamp
+     * @param regionName
      */
-    public List<TRowResult> getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp) throws IOError, org.apache.thrift.TException;
+    public List<TRowResult> getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Get multiple rows with the same columns or timestamps for all.
@@ -311,8 +332,9 @@ public class Hbase {
      *
      * @param tableName
      * @param rows
+     * @param regionName
      */
-    public List<TRowResult> getRows(ByteBuffer tableName, List<ByteBuffer> rows) throws IOError, org.apache.thrift.TException;
+    public List<TRowResult> getRows(ByteBuffer tableName, List<ByteBuffer> rows, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Get multiple rows only up to a certain timestamp
@@ -322,8 +344,9 @@ public class Hbase {
      * @param tableName
      * @param rows
      * @param timestamp
+     * @param regionName
      */
-    public List<TRowResult> getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp) throws IOError, org.apache.thrift.TException;
+    public List<TRowResult> getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Get multiple rows only with particular cf:qualifier pairs on all rows
@@ -333,8 +356,9 @@ public class Hbase {
      * @param tableName
      * @param rows
      * @param families
+     * @param regionName
      */
-    public List<TRowResult> getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families) throws IOError, org.apache.thrift.TException;
+    public List<TRowResult> getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Get multiple rows only with particular cf:qualifier pairs on all rows
@@ -346,8 +370,9 @@ public class Hbase {
      * @param rows
      * @param families
      * @param timestamp
+     * @param regionName
      */
-    public List<TRowResult> getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, long timestamp) throws IOError, org.apache.thrift.TException;
+    public List<TRowResult> getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * List all the userspace tables.
@@ -378,8 +403,10 @@ public class Hbase {
      * @param column column name
      *
      * @param numVersions number of versions to retrieve
+     * 
+     * @param regionName
      */
-    public List<TCell> getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions) throws IOError, org.apache.thrift.TException;
+    public List<TCell> getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * Get the specified number of versions for the specified table,
@@ -397,8 +424,10 @@ public class Hbase {
      * @param timestamp timestamp
      *
      * @param numVersions number of versions to retrieve
+     * 
+     * @param regionName
      */
-    public List<TCell> getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions) throws IOError, org.apache.thrift.TException;
+    public List<TCell> getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, ByteBuffer regionName) throws IOError, org.apache.thrift.TException;
 
     /**
      * @return true if table is on-line
@@ -410,6 +439,19 @@ public class Hbase {
     public void majorCompact(ByteBuffer tableNameOrRegionName) throws IOError, org.apache.thrift.TException;
 
     /**
+     * Apply a batch of puts for the target region.
+     * It assumes all the BatchMuations are Put operations
+     * and ignores the isDelete field in Mutation.
+     * 
+     * @param tableName name of tableName
+     * 
+     * @param rowBatches list of Put
+     * 
+     * @param regionName name of the region
+     */
+    public void multiPut(ByteBuffer tableName, List<BatchMutation> rowBatches, ByteBuffer regionName) throws IOError, IllegalArgument, org.apache.thrift.TException;
+
+    /**
      * Apply a series of mutations (updates/deletes) to a row in a
      * single transaction.  If an exception is thrown, then the
      * transaction is aborted.  Default current timestamp is used, and
@@ -422,8 +464,10 @@ public class Hbase {
      * @param mutations list of mutation commands
      *
      * @param attributes Put attributes
+     * 
+     * @param regionName
      */
-    public void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException;
+    public void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws IOError, IllegalArgument, org.apache.thrift.TException;
 
     /**
      * Apply a series of mutations (updates/deletes) to a row in a
@@ -440,8 +484,10 @@ public class Hbase {
      * @param timestamp timestamp
      *
      * @param attributes Put attributes
+     * 
+     * @param regionName
      */
-    public void mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException;
+    public void mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws IOError, IllegalArgument, org.apache.thrift.TException;
 
     /**
      * Apply a series of batches (each a series of mutations on a single row)
@@ -454,8 +500,10 @@ public class Hbase {
      * @param rowBatches list of row batches
      *
      * @param attributes Put attributes
+     * 
+     * @param regionName
      */
-    public void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException;
+    public void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws IOError, IllegalArgument, org.apache.thrift.TException;
 
     /**
      * Asynchronous multi-row mutation call
@@ -480,8 +528,10 @@ public class Hbase {
      * @param timestamp timestamp
      * 
      * @param attributes Put attributes
+     * 
+     * @param regionName
      */
-    public void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException;
+    public void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws IOError, IllegalArgument, org.apache.thrift.TException;
 
     /**
      * Asynchronous multi-row mutation call with ts
@@ -752,13 +802,13 @@ public class Hbase {
 
     public void createTable(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.createTable_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.deleteAll_call> resultHandler) throws org.apache.thrift.TException;
+    public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.deleteAll_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.deleteAllRow_call> resultHandler) throws org.apache.thrift.TException;
+    public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.deleteAllRow_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.deleteAllRowTs_call> resultHandler) throws org.apache.thrift.TException;
+    public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.deleteAllRowTs_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.deleteAllTs_call> resultHandler) throws org.apache.thrift.TException;
+    public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.deleteAllTs_call> resultHandler) throws org.apache.thrift.TException;
 
     public void deleteTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.deleteTable_call> resultHandler) throws org.apache.thrift.TException;
 
@@ -766,53 +816,55 @@ public class Hbase {
 
     public void enableTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.enableTable_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_call> resultHandler) throws org.apache.thrift.TException;
+    public void get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_call> resultHandler) throws org.apache.thrift.TException;
 
     public void getColumnDescriptors(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getColumnDescriptors_call> resultHandler) throws org.apache.thrift.TException;
 
     public void getRegionInfo(ByteBuffer row, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRegionInfo_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void getRow(ByteBuffer tableName, ByteBuffer row, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRow_call> resultHandler) throws org.apache.thrift.TException;
+    public void getRow(ByteBuffer tableName, ByteBuffer row, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRow_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowTs_call> resultHandler) throws org.apache.thrift.TException;
+    public void getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowTs_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void getRowWithColumnPrefix(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowWithColumnPrefix_call> resultHandler) throws org.apache.thrift.TException;
+    public void getRowWithColumnPrefix(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowWithColumnPrefix_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void getRowWithColumnPrefixTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, long timestamp, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowWithColumnPrefixTs_call> resultHandler) throws org.apache.thrift.TException;
+    public void getRowWithColumnPrefixTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowWithColumnPrefixTs_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowWithColumns_call> resultHandler) throws org.apache.thrift.TException;
+    public void getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowWithColumns_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowWithColumnsTs_call> resultHandler) throws org.apache.thrift.TException;
+    public void getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowWithColumnsTs_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void getRows(ByteBuffer tableName, List<ByteBuffer> rows, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRows_call> resultHandler) throws org.apache.thrift.TException;
+    public void getRows(ByteBuffer tableName, List<ByteBuffer> rows, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRows_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowsTs_call> resultHandler) throws org.apache.thrift.TException;
+    public void getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowsTs_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowsWithColumns_call> resultHandler) throws org.apache.thrift.TException;
+    public void getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowsWithColumns_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, long timestamp, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowsWithColumnsTs_call> resultHandler) throws org.apache.thrift.TException;
+    public void getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getRowsWithColumnsTs_call> resultHandler) throws org.apache.thrift.TException;
 
     public void getTableNames(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getTableNames_call> resultHandler) throws org.apache.thrift.TException;
 
     public void getTableRegions(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getTableRegions_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getVer_call> resultHandler) throws org.apache.thrift.TException;
+    public void getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getVer_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getVerTs_call> resultHandler) throws org.apache.thrift.TException;
+    public void getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getVerTs_call> resultHandler) throws org.apache.thrift.TException;
 
     public void isTableEnabled(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.isTableEnabled_call> resultHandler) throws org.apache.thrift.TException;
 
     public void majorCompact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.majorCompact_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.mutateRow_call> resultHandler) throws org.apache.thrift.TException;
+    public void multiPut(ByteBuffer tableName, List<BatchMutation> rowBatches, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.multiPut_call> resultHandler) throws org.apache.thrift.TException;
+
+    public void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.mutateRow_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.mutateRowTs_call> resultHandler) throws org.apache.thrift.TException;
+    public void mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.mutateRowTs_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.mutateRows_call> resultHandler) throws org.apache.thrift.TException;
+    public void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.mutateRows_call> resultHandler) throws org.apache.thrift.TException;
 
     public void mutateRowsAsync(ByteBuffer tableName, List<BatchMutation> rowBatches, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.mutateRowsAsync_call> resultHandler) throws org.apache.thrift.TException;
 
-    public void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.mutateRowsTs_call> resultHandler) throws org.apache.thrift.TException;
+    public void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.mutateRowsTs_call> resultHandler) throws org.apache.thrift.TException;
 
     public void mutateRowsTsAsync(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.mutateRowsTsAsync_call> resultHandler) throws org.apache.thrift.TException;
 
@@ -1018,18 +1070,19 @@ public class Hbase {
       return;
     }
 
-    public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column) throws IOError, org.apache.thrift.TException
+    public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_deleteAll(tableName, row, column);
+      send_deleteAll(tableName, row, column, regionName);
       recv_deleteAll();
     }
 
-    public void send_deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column) throws org.apache.thrift.TException
+    public void send_deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       deleteAll_args args = new deleteAll_args();
       args.setTableName(tableName);
       args.setRow(row);
       args.setColumn(column);
+      args.setRegionName(regionName);
       sendBase("deleteAll", args);
     }
 
@@ -1043,18 +1096,19 @@ public class Hbase {
       return;
     }
 
-    public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
+    public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_deleteAllRow(tableName, row, attributes);
+      send_deleteAllRow(tableName, row, attributes, regionName);
       recv_deleteAllRow();
     }
 
-    public void send_deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
+    public void send_deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       deleteAllRow_args args = new deleteAllRow_args();
       args.setTableName(tableName);
       args.setRow(row);
       args.setAttributes(attributes);
+      args.setRegionName(regionName);
       sendBase("deleteAllRow", args);
     }
 
@@ -1068,18 +1122,19 @@ public class Hbase {
       return;
     }
 
-    public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp) throws IOError, org.apache.thrift.TException
+    public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_deleteAllRowTs(tableName, row, timestamp);
+      send_deleteAllRowTs(tableName, row, timestamp, regionName);
       recv_deleteAllRowTs();
     }
 
-    public void send_deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp) throws org.apache.thrift.TException
+    public void send_deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       deleteAllRowTs_args args = new deleteAllRowTs_args();
       args.setTableName(tableName);
       args.setRow(row);
       args.setTimestamp(timestamp);
+      args.setRegionName(regionName);
       sendBase("deleteAllRowTs", args);
     }
 
@@ -1093,19 +1148,20 @@ public class Hbase {
       return;
     }
 
-    public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp) throws IOError, org.apache.thrift.TException
+    public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_deleteAllTs(tableName, row, column, timestamp);
+      send_deleteAllTs(tableName, row, column, timestamp, regionName);
       recv_deleteAllTs();
     }
 
-    public void send_deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp) throws org.apache.thrift.TException
+    public void send_deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       deleteAllTs_args args = new deleteAllTs_args();
       args.setTableName(tableName);
       args.setRow(row);
       args.setColumn(column);
       args.setTimestamp(timestamp);
+      args.setRegionName(regionName);
       sendBase("deleteAllTs", args);
     }
 
@@ -1188,18 +1244,19 @@ public class Hbase {
       return;
     }
 
-    public List<TCell> get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column) throws IOError, org.apache.thrift.TException
+    public List<TCell> get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_get(tableName, row, column);
+      send_get(tableName, row, column, regionName);
       return recv_get();
     }
 
-    public void send_get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column) throws org.apache.thrift.TException
+    public void send_get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       get_args args = new get_args();
       args.setTableName(tableName);
       args.setRow(row);
       args.setColumn(column);
+      args.setRegionName(regionName);
       sendBase("get", args);
     }
 
@@ -1268,17 +1325,18 @@ public class Hbase {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRegionInfo failed: unknown result");
     }
 
-    public List<TRowResult> getRow(ByteBuffer tableName, ByteBuffer row) throws IOError, org.apache.thrift.TException
+    public List<TRowResult> getRow(ByteBuffer tableName, ByteBuffer row, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_getRow(tableName, row);
+      send_getRow(tableName, row, regionName);
       return recv_getRow();
     }
 
-    public void send_getRow(ByteBuffer tableName, ByteBuffer row) throws org.apache.thrift.TException
+    public void send_getRow(ByteBuffer tableName, ByteBuffer row, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       getRow_args args = new getRow_args();
       args.setTableName(tableName);
       args.setRow(row);
+      args.setRegionName(regionName);
       sendBase("getRow", args);
     }
 
@@ -1295,18 +1353,19 @@ public class Hbase {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRow failed: unknown result");
     }
 
-    public List<TRowResult> getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp) throws IOError, org.apache.thrift.TException
+    public List<TRowResult> getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_getRowTs(tableName, row, timestamp);
+      send_getRowTs(tableName, row, timestamp, regionName);
       return recv_getRowTs();
     }
 
-    public void send_getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp) throws org.apache.thrift.TException
+    public void send_getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       getRowTs_args args = new getRowTs_args();
       args.setTableName(tableName);
       args.setRow(row);
       args.setTimestamp(timestamp);
+      args.setRegionName(regionName);
       sendBase("getRowTs", args);
     }
 
@@ -1323,18 +1382,19 @@ public class Hbase {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowTs failed: unknown result");
     }
 
-    public List<TRowResult> getRowWithColumnPrefix(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix) throws IOError, org.apache.thrift.TException
+    public List<TRowResult> getRowWithColumnPrefix(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_getRowWithColumnPrefix(tableName, row, prefix);
+      send_getRowWithColumnPrefix(tableName, row, prefix, regionName);
       return recv_getRowWithColumnPrefix();
     }
 
-    public void send_getRowWithColumnPrefix(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix) throws org.apache.thrift.TException
+    public void send_getRowWithColumnPrefix(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       getRowWithColumnPrefix_args args = new getRowWithColumnPrefix_args();
       args.setTableName(tableName);
       args.setRow(row);
       args.setPrefix(prefix);
+      args.setRegionName(regionName);
       sendBase("getRowWithColumnPrefix", args);
     }
 
@@ -1351,19 +1411,20 @@ public class Hbase {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowWithColumnPrefix failed: unknown result");
     }
 
-    public List<TRowResult> getRowWithColumnPrefixTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, long timestamp) throws IOError, org.apache.thrift.TException
+    public List<TRowResult> getRowWithColumnPrefixTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_getRowWithColumnPrefixTs(tableName, row, prefix, timestamp);
+      send_getRowWithColumnPrefixTs(tableName, row, prefix, timestamp, regionName);
       return recv_getRowWithColumnPrefixTs();
     }
 
-    public void send_getRowWithColumnPrefixTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, long timestamp) throws org.apache.thrift.TException
+    public void send_getRowWithColumnPrefixTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, long timestamp, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       getRowWithColumnPrefixTs_args args = new getRowWithColumnPrefixTs_args();
       args.setTableName(tableName);
       args.setRow(row);
       args.setPrefix(prefix);
       args.setTimestamp(timestamp);
+      args.setRegionName(regionName);
       sendBase("getRowWithColumnPrefixTs", args);
     }
 
@@ -1380,18 +1441,19 @@ public class Hbase {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowWithColumnPrefixTs failed: unknown result");
     }
 
-    public List<TRowResult> getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns) throws IOError, org.apache.thrift.TException
+    public List<TRowResult> getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_getRowWithColumns(tableName, row, columns);
+      send_getRowWithColumns(tableName, row, columns, regionName);
       return recv_getRowWithColumns();
     }
 
-    public void send_getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns) throws org.apache.thrift.TException
+    public void send_getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       getRowWithColumns_args args = new getRowWithColumns_args();
       args.setTableName(tableName);
       args.setRow(row);
       args.setColumns(columns);
+      args.setRegionName(regionName);
       sendBase("getRowWithColumns", args);
     }
 
@@ -1408,19 +1470,20 @@ public class Hbase {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowWithColumns failed: unknown result");
     }
 
-    public List<TRowResult> getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp) throws IOError, org.apache.thrift.TException
+    public List<TRowResult> getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_getRowWithColumnsTs(tableName, row, columns, timestamp);
+      send_getRowWithColumnsTs(tableName, row, columns, timestamp, regionName);
       return recv_getRowWithColumnsTs();
     }
 
-    public void send_getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp) throws org.apache.thrift.TException
+    public void send_getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       getRowWithColumnsTs_args args = new getRowWithColumnsTs_args();
       args.setTableName(tableName);
       args.setRow(row);
       args.setColumns(columns);
       args.setTimestamp(timestamp);
+      args.setRegionName(regionName);
       sendBase("getRowWithColumnsTs", args);
     }
 
@@ -1437,17 +1500,18 @@ public class Hbase {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowWithColumnsTs failed: unknown result");
     }
 
-    public List<TRowResult> getRows(ByteBuffer tableName, List<ByteBuffer> rows) throws IOError, org.apache.thrift.TException
+    public List<TRowResult> getRows(ByteBuffer tableName, List<ByteBuffer> rows, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_getRows(tableName, rows);
+      send_getRows(tableName, rows, regionName);
       return recv_getRows();
     }
 
-    public void send_getRows(ByteBuffer tableName, List<ByteBuffer> rows) throws org.apache.thrift.TException
+    public void send_getRows(ByteBuffer tableName, List<ByteBuffer> rows, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       getRows_args args = new getRows_args();
       args.setTableName(tableName);
       args.setRows(rows);
+      args.setRegionName(regionName);
       sendBase("getRows", args);
     }
 
@@ -1464,18 +1528,19 @@ public class Hbase {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRows failed: unknown result");
     }
 
-    public List<TRowResult> getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp) throws IOError, org.apache.thrift.TException
+    public List<TRowResult> getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_getRowsTs(tableName, rows, timestamp);
+      send_getRowsTs(tableName, rows, timestamp, regionName);
       return recv_getRowsTs();
     }
 
-    public void send_getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp) throws org.apache.thrift.TException
+    public void send_getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       getRowsTs_args args = new getRowsTs_args();
       args.setTableName(tableName);
       args.setRows(rows);
       args.setTimestamp(timestamp);
+      args.setRegionName(regionName);
       sendBase("getRowsTs", args);
     }
 
@@ -1492,18 +1557,19 @@ public class Hbase {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowsTs failed: unknown result");
     }
 
-    public List<TRowResult> getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families) throws IOError, org.apache.thrift.TException
+    public List<TRowResult> getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_getRowsWithColumns(tableName, rows, families);
+      send_getRowsWithColumns(tableName, rows, families, regionName);
       return recv_getRowsWithColumns();
     }
 
-    public void send_getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families) throws org.apache.thrift.TException
+    public void send_getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       getRowsWithColumns_args args = new getRowsWithColumns_args();
       args.setTableName(tableName);
       args.setRows(rows);
       args.setFamilies(families);
+      args.setRegionName(regionName);
       sendBase("getRowsWithColumns", args);
     }
 
@@ -1520,19 +1586,20 @@ public class Hbase {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowsWithColumns failed: unknown result");
     }
 
-    public List<TRowResult> getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, long timestamp) throws IOError, org.apache.thrift.TException
+    public List<TRowResult> getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, long timestamp, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_getRowsWithColumnsTs(tableName, rows, families, timestamp);
+      send_getRowsWithColumnsTs(tableName, rows, families, timestamp, regionName);
       return recv_getRowsWithColumnsTs();
     }
 
-    public void send_getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, long timestamp) throws org.apache.thrift.TException
+    public void send_getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, long timestamp, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       getRowsWithColumnsTs_args args = new getRowsWithColumnsTs_args();
       args.setTableName(tableName);
       args.setRows(rows);
       args.setFamilies(families);
       args.setTimestamp(timestamp);
+      args.setRegionName(regionName);
       sendBase("getRowsWithColumnsTs", args);
     }
 
@@ -1600,19 +1667,20 @@ public class Hbase {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getTableRegions failed: unknown result");
     }
 
-    public List<TCell> getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions) throws IOError, org.apache.thrift.TException
+    public List<TCell> getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_getVer(tableName, row, column, numVersions);
+      send_getVer(tableName, row, column, numVersions, regionName);
       return recv_getVer();
     }
 
-    public void send_getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions) throws org.apache.thrift.TException
+    public void send_getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       getVer_args args = new getVer_args();
       args.setTableName(tableName);
       args.setRow(row);
       args.setColumn(column);
       args.setNumVersions(numVersions);
+      args.setRegionName(regionName);
       sendBase("getVer", args);
     }
 
@@ -1629,13 +1697,13 @@ public class Hbase {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getVer failed: unknown result");
     }
 
-    public List<TCell> getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions) throws IOError, org.apache.thrift.TException
+    public List<TCell> getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, ByteBuffer regionName) throws IOError, org.apache.thrift.TException
     {
-      send_getVerTs(tableName, row, column, timestamp, numVersions);
+      send_getVerTs(tableName, row, column, timestamp, numVersions, regionName);
       return recv_getVerTs();
     }
 
-    public void send_getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions) throws org.apache.thrift.TException
+    public void send_getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       getVerTs_args args = new getVerTs_args();
       args.setTableName(tableName);
@@ -1643,6 +1711,7 @@ public class Hbase {
       args.setColumn(column);
       args.setTimestamp(timestamp);
       args.setNumVersions(numVersions);
+      args.setRegionName(regionName);
       sendBase("getVerTs", args);
     }
 
@@ -1708,19 +1777,48 @@ public class Hbase {
       return;
     }
 
-    public void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException
+    public void multiPut(ByteBuffer tableName, List<BatchMutation> rowBatches, ByteBuffer regionName) throws IOError, IllegalArgument, org.apache.thrift.TException
+    {
+      send_multiPut(tableName, rowBatches, regionName);
+      recv_multiPut();
+    }
+
+    public void send_multiPut(ByteBuffer tableName, List<BatchMutation> rowBatches, ByteBuffer regionName) throws org.apache.thrift.TException
+    {
+      multiPut_args args = new multiPut_args();
+      args.setTableName(tableName);
+      args.setRowBatches(rowBatches);
+      args.setRegionName(regionName);
+      sendBase("multiPut", args);
+    }
+
+    public void recv_multiPut() throws IOError, IllegalArgument, org.apache.thrift.TException
+    {
+      multiPut_result result = new multiPut_result();
+      receiveBase(result, "multiPut");
+      if (result.io != null) {
+        throw result.io;
+      }
+      if (result.ia != null) {
+        throw result.ia;
+      }
+      return;
+    }
+
+    public void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws IOError, IllegalArgument, org.apache.thrift.TException
     {
-      send_mutateRow(tableName, row, mutations, attributes);
+      send_mutateRow(tableName, row, mutations, attributes, regionName);
       recv_mutateRow();
     }
 
-    public void send_mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
+    public void send_mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       mutateRow_args args = new mutateRow_args();
       args.setTableName(tableName);
       args.setRow(row);
       args.setMutations(mutations);
       args.setAttributes(attributes);
+      args.setRegionName(regionName);
       sendBase("mutateRow", args);
     }
 
@@ -1737,13 +1835,13 @@ public class Hbase {
       return;
     }
 
-    public void mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException
+    public void mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws IOError, IllegalArgument, org.apache.thrift.TException
     {
-      send_mutateRowTs(tableName, row, mutations, timestamp, attributes);
+      send_mutateRowTs(tableName, row, mutations, timestamp, attributes, regionName);
       recv_mutateRowTs();
     }
 
-    public void send_mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
+    public void send_mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       mutateRowTs_args args = new mutateRowTs_args();
       args.setTableName(tableName);
@@ -1751,6 +1849,7 @@ public class Hbase {
       args.setMutations(mutations);
       args.setTimestamp(timestamp);
       args.setAttributes(attributes);
+      args.setRegionName(regionName);
       sendBase("mutateRowTs", args);
     }
 
@@ -1767,18 +1866,19 @@ public class Hbase {
       return;
     }
 
-    public void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException
+    public void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws IOError, IllegalArgument, org.apache.thrift.TException
     {
-      send_mutateRows(tableName, rowBatches, attributes);
+      send_mutateRows(tableName, rowBatches, attributes, regionName);
       recv_mutateRows();
     }
 
-    public void send_mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
+    public void send_mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       mutateRows_args args = new mutateRows_args();
       args.setTableName(tableName);
       args.setRowBatches(rowBatches);
       args.setAttributes(attributes);
+      args.setRegionName(regionName);
       sendBase("mutateRows", args);
     }
 
@@ -1808,19 +1908,20 @@ public class Hbase {
       sendBase("mutateRowsAsync", args);
     }
 
-    public void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException
+    public void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws IOError, IllegalArgument, org.apache.thrift.TException
     {
-      send_mutateRowsTs(tableName, rowBatches, timestamp, attributes);
+      send_mutateRowsTs(tableName, rowBatches, timestamp, attributes, regionName);
       recv_mutateRowsTs();
     }
 
-    public void send_mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
+    public void send_mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName) throws org.apache.thrift.TException
     {
       mutateRowsTs_args args = new mutateRowsTs_args();
       args.setTableName(tableName);
       args.setRowBatches(rowBatches);
       args.setTimestamp(timestamp);
       args.setAttributes(attributes);
+      args.setRegionName(regionName);
       sendBase("mutateRowsTs", args);
     }
 
@@ -2444,9 +2545,9 @@ public class Hbase {
       }
     }
 
-    public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, org.apache.thrift.async.AsyncMethodCallback<deleteAll_call> resultHandler) throws org.apache.thrift.TException {
+    public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<deleteAll_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      deleteAll_call method_call = new deleteAll_call(tableName, row, column, resultHandler, this, ___protocolFactory, ___transport);
+      deleteAll_call method_call = new deleteAll_call(tableName, row, column, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -2455,11 +2556,13 @@ public class Hbase {
       private ByteBuffer tableName;
       private ByteBuffer row;
       private ByteBuffer column;
-      public deleteAll_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, org.apache.thrift.async.AsyncMethodCallback<deleteAll_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public deleteAll_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<deleteAll_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.row = row;
         this.column = column;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -2468,6 +2571,7 @@ public class Hbase {
         args.setTableName(tableName);
         args.setRow(row);
         args.setColumn(column);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -2482,9 +2586,9 @@ public class Hbase {
       }
     }
 
-    public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<deleteAllRow_call> resultHandler) throws org.apache.thrift.TException {
+    public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<deleteAllRow_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      deleteAllRow_call method_call = new deleteAllRow_call(tableName, row, attributes, resultHandler, this, ___protocolFactory, ___transport);
+      deleteAllRow_call method_call = new deleteAllRow_call(tableName, row, attributes, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -2493,11 +2597,13 @@ public class Hbase {
       private ByteBuffer tableName;
       private ByteBuffer row;
       private Map<ByteBuffer,ByteBuffer> attributes;
-      public deleteAllRow_call(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<deleteAllRow_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public deleteAllRow_call(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<deleteAllRow_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.row = row;
         this.attributes = attributes;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -2506,6 +2612,7 @@ public class Hbase {
         args.setTableName(tableName);
         args.setRow(row);
         args.setAttributes(attributes);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -2520,9 +2627,9 @@ public class Hbase {
       }
     }
 
-    public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, org.apache.thrift.async.AsyncMethodCallback<deleteAllRowTs_call> resultHandler) throws org.apache.thrift.TException {
+    public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<deleteAllRowTs_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      deleteAllRowTs_call method_call = new deleteAllRowTs_call(tableName, row, timestamp, resultHandler, this, ___protocolFactory, ___transport);
+      deleteAllRowTs_call method_call = new deleteAllRowTs_call(tableName, row, timestamp, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -2531,11 +2638,13 @@ public class Hbase {
       private ByteBuffer tableName;
       private ByteBuffer row;
       private long timestamp;
-      public deleteAllRowTs_call(ByteBuffer tableName, ByteBuffer row, long timestamp, org.apache.thrift.async.AsyncMethodCallback<deleteAllRowTs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public deleteAllRowTs_call(ByteBuffer tableName, ByteBuffer row, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<deleteAllRowTs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.row = row;
         this.timestamp = timestamp;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -2544,6 +2653,7 @@ public class Hbase {
         args.setTableName(tableName);
         args.setRow(row);
         args.setTimestamp(timestamp);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -2558,9 +2668,9 @@ public class Hbase {
       }
     }
 
-    public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, org.apache.thrift.async.AsyncMethodCallback<deleteAllTs_call> resultHandler) throws org.apache.thrift.TException {
+    public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<deleteAllTs_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      deleteAllTs_call method_call = new deleteAllTs_call(tableName, row, column, timestamp, resultHandler, this, ___protocolFactory, ___transport);
+      deleteAllTs_call method_call = new deleteAllTs_call(tableName, row, column, timestamp, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -2570,12 +2680,14 @@ public class Hbase {
       private ByteBuffer row;
       private ByteBuffer column;
       private long timestamp;
-      public deleteAllTs_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, org.apache.thrift.async.AsyncMethodCallback<deleteAllTs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public deleteAllTs_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<deleteAllTs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.row = row;
         this.column = column;
         this.timestamp = timestamp;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -2585,6 +2697,7 @@ public class Hbase {
         args.setRow(row);
         args.setColumn(column);
         args.setTimestamp(timestamp);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -2695,9 +2808,9 @@ public class Hbase {
       }
     }
 
-    public void get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, org.apache.thrift.async.AsyncMethodCallback<get_call> resultHandler) throws org.apache.thrift.TException {
+    public void get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<get_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      get_call method_call = new get_call(tableName, row, column, resultHandler, this, ___protocolFactory, ___transport);
+      get_call method_call = new get_call(tableName, row, column, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -2706,11 +2819,13 @@ public class Hbase {
       private ByteBuffer tableName;
       private ByteBuffer row;
       private ByteBuffer column;
-      public get_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, org.apache.thrift.async.AsyncMethodCallback<get_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public get_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<get_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.row = row;
         this.column = column;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -2719,6 +2834,7 @@ public class Hbase {
         args.setTableName(tableName);
         args.setRow(row);
         args.setColumn(column);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -2797,9 +2913,9 @@ public class Hbase {
       }
     }
 
-    public void getRow(ByteBuffer tableName, ByteBuffer row, org.apache.thrift.async.AsyncMethodCallback<getRow_call> resultHandler) throws org.apache.thrift.TException {
+    public void getRow(ByteBuffer tableName, ByteBuffer row, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRow_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getRow_call method_call = new getRow_call(tableName, row, resultHandler, this, ___protocolFactory, ___transport);
+      getRow_call method_call = new getRow_call(tableName, row, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -2807,10 +2923,12 @@ public class Hbase {
     public static class getRow_call extends org.apache.thrift.async.TAsyncMethodCall {
       private ByteBuffer tableName;
       private ByteBuffer row;
-      public getRow_call(ByteBuffer tableName, ByteBuffer row, org.apache.thrift.async.AsyncMethodCallback<getRow_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public getRow_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRow_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.row = row;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -2818,6 +2936,7 @@ public class Hbase {
         getRow_args args = new getRow_args();
         args.setTableName(tableName);
         args.setRow(row);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -2832,9 +2951,9 @@ public class Hbase {
       }
     }
 
-    public void getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, org.apache.thrift.async.AsyncMethodCallback<getRowTs_call> resultHandler) throws org.apache.thrift.TException {
+    public void getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowTs_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getRowTs_call method_call = new getRowTs_call(tableName, row, timestamp, resultHandler, this, ___protocolFactory, ___transport);
+      getRowTs_call method_call = new getRowTs_call(tableName, row, timestamp, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -2843,11 +2962,13 @@ public class Hbase {
       private ByteBuffer tableName;
       private ByteBuffer row;
       private long timestamp;
-      public getRowTs_call(ByteBuffer tableName, ByteBuffer row, long timestamp, org.apache.thrift.async.AsyncMethodCallback<getRowTs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public getRowTs_call(ByteBuffer tableName, ByteBuffer row, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowTs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.row = row;
         this.timestamp = timestamp;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -2856,6 +2977,7 @@ public class Hbase {
         args.setTableName(tableName);
         args.setRow(row);
         args.setTimestamp(timestamp);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -2870,9 +2992,9 @@ public class Hbase {
       }
     }
 
-    public void getRowWithColumnPrefix(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumnPrefix_call> resultHandler) throws org.apache.thrift.TException {
+    public void getRowWithColumnPrefix(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumnPrefix_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getRowWithColumnPrefix_call method_call = new getRowWithColumnPrefix_call(tableName, row, prefix, resultHandler, this, ___protocolFactory, ___transport);
+      getRowWithColumnPrefix_call method_call = new getRowWithColumnPrefix_call(tableName, row, prefix, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -2881,11 +3003,13 @@ public class Hbase {
       private ByteBuffer tableName;
       private ByteBuffer row;
       private ByteBuffer prefix;
-      public getRowWithColumnPrefix_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumnPrefix_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public getRowWithColumnPrefix_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumnPrefix_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.row = row;
         this.prefix = prefix;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -2894,6 +3018,7 @@ public class Hbase {
         args.setTableName(tableName);
         args.setRow(row);
         args.setPrefix(prefix);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -2908,9 +3033,9 @@ public class Hbase {
       }
     }
 
-    public void getRowWithColumnPrefixTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, long timestamp, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumnPrefixTs_call> resultHandler) throws org.apache.thrift.TException {
+    public void getRowWithColumnPrefixTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumnPrefixTs_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getRowWithColumnPrefixTs_call method_call = new getRowWithColumnPrefixTs_call(tableName, row, prefix, timestamp, resultHandler, this, ___protocolFactory, ___transport);
+      getRowWithColumnPrefixTs_call method_call = new getRowWithColumnPrefixTs_call(tableName, row, prefix, timestamp, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -2920,12 +3045,14 @@ public class Hbase {
       private ByteBuffer row;
       private ByteBuffer prefix;
       private long timestamp;
-      public getRowWithColumnPrefixTs_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, long timestamp, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumnPrefixTs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public getRowWithColumnPrefixTs_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer prefix, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumnPrefixTs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.row = row;
         this.prefix = prefix;
         this.timestamp = timestamp;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -2935,6 +3062,7 @@ public class Hbase {
         args.setRow(row);
         args.setPrefix(prefix);
         args.setTimestamp(timestamp);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -2949,9 +3077,9 @@ public class Hbase {
       }
     }
 
-    public void getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumns_call> resultHandler) throws org.apache.thrift.TException {
+    public void getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumns_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getRowWithColumns_call method_call = new getRowWithColumns_call(tableName, row, columns, resultHandler, this, ___protocolFactory, ___transport);
+      getRowWithColumns_call method_call = new getRowWithColumns_call(tableName, row, columns, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -2960,11 +3088,13 @@ public class Hbase {
       private ByteBuffer tableName;
       private ByteBuffer row;
       private List<ByteBuffer> columns;
-      public getRowWithColumns_call(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumns_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public getRowWithColumns_call(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumns_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.row = row;
         this.columns = columns;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -2973,6 +3103,7 @@ public class Hbase {
         args.setTableName(tableName);
         args.setRow(row);
         args.setColumns(columns);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -2987,9 +3118,9 @@ public class Hbase {
       }
     }
 
-    public void getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumnsTs_call> resultHandler) throws org.apache.thrift.TException {
+    public void getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumnsTs_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getRowWithColumnsTs_call method_call = new getRowWithColumnsTs_call(tableName, row, columns, timestamp, resultHandler, this, ___protocolFactory, ___transport);
+      getRowWithColumnsTs_call method_call = new getRowWithColumnsTs_call(tableName, row, columns, timestamp, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -2999,12 +3130,14 @@ public class Hbase {
       private ByteBuffer row;
       private List<ByteBuffer> columns;
       private long timestamp;
-      public getRowWithColumnsTs_call(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumnsTs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public getRowWithColumnsTs_call(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowWithColumnsTs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.row = row;
         this.columns = columns;
         this.timestamp = timestamp;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -3014,6 +3147,7 @@ public class Hbase {
         args.setRow(row);
         args.setColumns(columns);
         args.setTimestamp(timestamp);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -3028,9 +3162,9 @@ public class Hbase {
       }
     }
 
-    public void getRows(ByteBuffer tableName, List<ByteBuffer> rows, org.apache.thrift.async.AsyncMethodCallback<getRows_call> resultHandler) throws org.apache.thrift.TException {
+    public void getRows(ByteBuffer tableName, List<ByteBuffer> rows, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRows_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getRows_call method_call = new getRows_call(tableName, rows, resultHandler, this, ___protocolFactory, ___transport);
+      getRows_call method_call = new getRows_call(tableName, rows, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -3038,10 +3172,12 @@ public class Hbase {
     public static class getRows_call extends org.apache.thrift.async.TAsyncMethodCall {
       private ByteBuffer tableName;
       private List<ByteBuffer> rows;
-      public getRows_call(ByteBuffer tableName, List<ByteBuffer> rows, org.apache.thrift.async.AsyncMethodCallback<getRows_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public getRows_call(ByteBuffer tableName, List<ByteBuffer> rows, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRows_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.rows = rows;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -3049,6 +3185,7 @@ public class Hbase {
         getRows_args args = new getRows_args();
         args.setTableName(tableName);
         args.setRows(rows);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -3063,9 +3200,9 @@ public class Hbase {
       }
     }
 
-    public void getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, org.apache.thrift.async.AsyncMethodCallback<getRowsTs_call> resultHandler) throws org.apache.thrift.TException {
+    public void getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowsTs_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getRowsTs_call method_call = new getRowsTs_call(tableName, rows, timestamp, resultHandler, this, ___protocolFactory, ___transport);
+      getRowsTs_call method_call = new getRowsTs_call(tableName, rows, timestamp, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -3074,11 +3211,13 @@ public class Hbase {
       private ByteBuffer tableName;
       private List<ByteBuffer> rows;
       private long timestamp;
-      public getRowsTs_call(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, org.apache.thrift.async.AsyncMethodCallback<getRowsTs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public getRowsTs_call(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowsTs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.rows = rows;
         this.timestamp = timestamp;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -3087,6 +3226,7 @@ public class Hbase {
         args.setTableName(tableName);
         args.setRows(rows);
         args.setTimestamp(timestamp);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -3101,9 +3241,9 @@ public class Hbase {
       }
     }
 
-    public void getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, org.apache.thrift.async.AsyncMethodCallback<getRowsWithColumns_call> resultHandler) throws org.apache.thrift.TException {
+    public void getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowsWithColumns_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getRowsWithColumns_call method_call = new getRowsWithColumns_call(tableName, rows, families, resultHandler, this, ___protocolFactory, ___transport);
+      getRowsWithColumns_call method_call = new getRowsWithColumns_call(tableName, rows, families, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -3112,11 +3252,13 @@ public class Hbase {
       private ByteBuffer tableName;
       private List<ByteBuffer> rows;
       private List<ByteBuffer> families;
-      public getRowsWithColumns_call(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, org.apache.thrift.async.AsyncMethodCallback<getRowsWithColumns_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      private ByteBuffer regionName;
+      public getRowsWithColumns_call(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowsWithColumns_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tableName = tableName;
         this.rows = rows;
         this.families = families;
+        this.regionName = regionName;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -3125,6 +3267,7 @@ public class Hbase {
         args.setTableName(tableName);
         args.setRows(rows);
         args.setFamilies(families);
+        args.setRegionName(regionName);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -3139,9 +3282,9 @@ public class Hbase {
       }
     }
 
-    public void getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, long timestamp, org.apache.thrift.async.AsyncMethodCallback<getRowsWithColumnsTs_call> resultHandler) throws org.apache.thrift.TException {
+    public void getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> families, long timestamp, ByteBuffer regionName, org.apache.thrift.async.AsyncMethodCallback<getRowsWithColumnsTs_call> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getRowsWithColumnsTs_call method_call = new getRowsWithColumnsTs_call(tableName, rows, families, timestamp, resultHandler, this, ___protocolFactory, ___transport);
+      getRowsWithColumnsTs_call method_call = new getRowsWithColumnsTs_call(tableName, rows, families, timestamp, regionName, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -3151,12 +3294,14 @@ public class Hbase {
       private List<ByteBuffer> rows;
       private List<ByteBuffer> families;
       private long timestamp;

[... 8725 lines stripped ...]