You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by ns...@apache.org on 2011/10/11 19:44:10 UTC

svn commit: r1181955 [2/3] - in /hbase/branches/0.89/src/main: java/org/apache/hadoop/hbase/regionserver/ java/org/apache/hadoop/hbase/thrift/ java/org/apache/hadoop/hbase/thrift/generated/ resources/org/apache/hadoop/hbase/thrift/

Modified: hbase/branches/0.89/src/main/java/org/apache/hadoop/hbase/thrift/generated/Hbase.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89/src/main/java/org/apache/hadoop/hbase/thrift/generated/Hbase.java?rev=1181955&r1=1181954&r2=1181955&view=diff
==============================================================================
--- hbase/branches/0.89/src/main/java/org/apache/hadoop/hbase/thrift/generated/Hbase.java (original)
+++ hbase/branches/0.89/src/main/java/org/apache/hadoop/hbase/thrift/generated/Hbase.java Tue Oct 11 17:44:09 2011
@@ -211,6 +211,44 @@ public class Hbase {
     public List<TRowResult> getRowWithColumnsTs(byte[] tableName, byte[] row, List<byte[]> columns, long timestamp) throws IOError, TException;
 
     /**
+     * Get the columns with the specified prefix for the specified table and
+     * row at the latest timestamp. Returns an empty list if the row does not
+     * exist.
+     *
+     * @return TRowResult containing the row and map of columns to TCells
+     *
+     * @param tableName name of table
+     *
+     * @param row row key
+     *
+     * @param prefix column prefix, null for all columns
+     * family name can be specified as <family>:<qualifier prefix>
+     * If only <qualifier prefix> provided then all families are
+     * searched
+     */
+    public List<TRowResult> getRowWithColumnPrefix(byte[] tableName, byte[] row, byte[] prefix) throws IOError, TException;
+
+    /**
+     * Get the columns with the specified prefix for the specified table and
+     * row at the specified timestamp. Returns an empty list if the row does not
+     * exist.
+     *
+     * @return TRowResult containing the row and map of columns to TCells
+     *
+     * @param tableName name of table
+     *
+     * @param row row key
+     *
+     * @param prefix column prefix, null for all columns
+     * family name can be specified as <family>:<qualifier prefix>
+     * If only <qualifier prefix> provided then all families are
+     * searched
+     *
+     * @param timestamp
+     */
+    public List<TRowResult> getRowWithColumnPrefixTs(byte[] tableName, byte[] row, byte[] prefix, long timestamp) throws IOError, TException;
+
+    /**
      * Get multiple rows with the same columns or timestamps for all.
      * This returns latest entries, all columns and cfs.
      *
@@ -641,6 +679,16 @@ public class Hbase {
      */
     public void scannerClose(int id) throws IOError, IllegalArgument, TException;
 
+    /**
+     * Get the regininfo for the specified row. It scans
+     * the metatable to find region's start and end keys.
+     *
+     * @return value for specified row/column
+     *
+     * @param row row key
+     */
+    public TRegionInfo getRegionInfo(byte[] row) throws IOError, TException;
+
   }
 
   public static class Client implements Iface {
@@ -1287,6 +1335,83 @@ public class Hbase {
       throw new TApplicationException(TApplicationException.MISSING_RESULT, "getRowWithColumnsTs failed: unknown result");
     }
 
+    public List<TRowResult> getRowWithColumnPrefix(byte[] tableName, byte[] row, byte[] prefix) throws IOError, TException
+    {
+      send_getRowWithColumnPrefix(tableName, row, prefix);
+      return recv_getRowWithColumnPrefix();
+    }
+
+    public void send_getRowWithColumnPrefix(byte[] tableName, byte[] row, byte[] prefix) throws TException
+    {
+      oprot_.writeMessageBegin(new TMessage("getRowWithColumnPrefix", TMessageType.CALL, seqid_));
+      getRowWithColumnPrefix_args args = new getRowWithColumnPrefix_args();
+      args.tableName = tableName;
+      args.row = row;
+      args.prefix = prefix;
+      args.write(oprot_);
+      oprot_.writeMessageEnd();
+      oprot_.getTransport().flush();
+    }
+
+    public List<TRowResult> recv_getRowWithColumnPrefix() throws IOError, TException
+    {
+      TMessage msg = iprot_.readMessageBegin();
+      if (msg.type == TMessageType.EXCEPTION) {
+        TApplicationException x = TApplicationException.read(iprot_);
+        iprot_.readMessageEnd();
+        throw x;
+      }
+      getRowWithColumnPrefix_result result = new getRowWithColumnPrefix_result();
+      result.read(iprot_);
+      iprot_.readMessageEnd();
+      if (result.isSetSuccess()) {
+        return result.success;
+      }
+      if (result.io != null) {
+        throw result.io;
+      }
+      throw new TApplicationException(TApplicationException.MISSING_RESULT, "getRowWithColumnPrefix failed: unknown result");
+    }
+
+    public List<TRowResult> getRowWithColumnPrefixTs(byte[] tableName, byte[] row, byte[] prefix, long timestamp) throws IOError, TException
+    {
+      send_getRowWithColumnPrefixTs(tableName, row, prefix, timestamp);
+      return recv_getRowWithColumnPrefixTs();
+    }
+
+    public void send_getRowWithColumnPrefixTs(byte[] tableName, byte[] row, byte[] prefix, long timestamp) throws TException
+    {
+      oprot_.writeMessageBegin(new TMessage("getRowWithColumnPrefixTs", TMessageType.CALL, seqid_));
+      getRowWithColumnPrefixTs_args args = new getRowWithColumnPrefixTs_args();
+      args.tableName = tableName;
+      args.row = row;
+      args.prefix = prefix;
+      args.timestamp = timestamp;
+      args.write(oprot_);
+      oprot_.writeMessageEnd();
+      oprot_.getTransport().flush();
+    }
+
+    public List<TRowResult> recv_getRowWithColumnPrefixTs() throws IOError, TException
+    {
+      TMessage msg = iprot_.readMessageBegin();
+      if (msg.type == TMessageType.EXCEPTION) {
+        TApplicationException x = TApplicationException.read(iprot_);
+        iprot_.readMessageEnd();
+        throw x;
+      }
+      getRowWithColumnPrefixTs_result result = new getRowWithColumnPrefixTs_result();
+      result.read(iprot_);
+      iprot_.readMessageEnd();
+      if (result.isSetSuccess()) {
+        return result.success;
+      }
+      if (result.io != null) {
+        throw result.io;
+      }
+      throw new TApplicationException(TApplicationException.MISSING_RESULT, "getRowWithColumnPrefixTs failed: unknown result");
+    }
+
     public List<TRowResult> getRows(byte[] tableName, List<byte[]> rows) throws IOError, TException
     {
       send_getRows(tableName, rows);
@@ -2360,6 +2485,42 @@ public class Hbase {
       return;
     }
 
+    public TRegionInfo getRegionInfo(byte[] row) throws IOError, TException
+    {
+      send_getRegionInfo(row);
+      return recv_getRegionInfo();
+    }
+
+    public void send_getRegionInfo(byte[] row) throws TException
+    {
+      oprot_.writeMessageBegin(new TMessage("getRegionInfo", TMessageType.CALL, seqid_));
+      getRegionInfo_args args = new getRegionInfo_args();
+      args.row = row;
+      args.write(oprot_);
+      oprot_.writeMessageEnd();
+      oprot_.getTransport().flush();
+    }
+
+    public TRegionInfo recv_getRegionInfo() throws IOError, TException
+    {
+      TMessage msg = iprot_.readMessageBegin();
+      if (msg.type == TMessageType.EXCEPTION) {
+        TApplicationException x = TApplicationException.read(iprot_);
+        iprot_.readMessageEnd();
+        throw x;
+      }
+      getRegionInfo_result result = new getRegionInfo_result();
+      result.read(iprot_);
+      iprot_.readMessageEnd();
+      if (result.isSetSuccess()) {
+        return result.success;
+      }
+      if (result.io != null) {
+        throw result.io;
+      }
+      throw new TApplicationException(TApplicationException.MISSING_RESULT, "getRegionInfo failed: unknown result");
+    }
+
   }
   public static class Processor implements TProcessor {
     private static final Logger LOGGER = LoggerFactory.getLogger(Processor.class.getName());
@@ -2383,6 +2544,8 @@ public class Hbase {
       processMap_.put("getRowWithColumns", new getRowWithColumns());
       processMap_.put("getRowTs", new getRowTs());
       processMap_.put("getRowWithColumnsTs", new getRowWithColumnsTs());
+      processMap_.put("getRowWithColumnPrefix", new getRowWithColumnPrefix());
+      processMap_.put("getRowWithColumnPrefixTs", new getRowWithColumnPrefixTs());
       processMap_.put("getRows", new getRows());
       processMap_.put("getRowsTs", new getRowsTs());
       processMap_.put("getRowsWithColumns", new getRowsWithColumns());
@@ -2411,6 +2574,7 @@ public class Hbase {
       processMap_.put("scannerGet", new scannerGet());
       processMap_.put("scannerGetList", new scannerGetList());
       processMap_.put("scannerClose", new scannerClose());
+      processMap_.put("getRegionInfo", new getRegionInfo());
     }
 
     protected static interface ProcessFunction {
@@ -2919,6 +3083,62 @@ public class Hbase {
 
     }
 
+    private class getRowWithColumnPrefix implements ProcessFunction {
+      public void process(int seqid, TProtocol iprot, TProtocol oprot) throws TException
+      {
+        getRowWithColumnPrefix_args args = new getRowWithColumnPrefix_args();
+        args.read(iprot);
+        iprot.readMessageEnd();
+        getRowWithColumnPrefix_result result = new getRowWithColumnPrefix_result();
+        try {
+          result.success = iface_.getRowWithColumnPrefix(args.tableName, args.row, args.prefix);
+        } catch (IOError io) {
+          result.io = io;
+        } catch (Throwable th) {
+          LOGGER.error("Internal error processing getRowWithColumnPrefix", th);
+          TApplicationException x = new TApplicationException(TApplicationException.INTERNAL_ERROR, "Internal error processing getRowWithColumnPrefix");
+          oprot.writeMessageBegin(new TMessage("getRowWithColumnPrefix", TMessageType.EXCEPTION, seqid));
+          x.write(oprot);
+          oprot.writeMessageEnd();
+          oprot.getTransport().flush();
+          return;
+        }
+        oprot.writeMessageBegin(new TMessage("getRowWithColumnPrefix", TMessageType.REPLY, seqid));
+        result.write(oprot);
+        oprot.writeMessageEnd();
+        oprot.getTransport().flush();
+      }
+
+    }
+
+    private class getRowWithColumnPrefixTs implements ProcessFunction {
+      public void process(int seqid, TProtocol iprot, TProtocol oprot) throws TException
+      {
+        getRowWithColumnPrefixTs_args args = new getRowWithColumnPrefixTs_args();
+        args.read(iprot);
+        iprot.readMessageEnd();
+        getRowWithColumnPrefixTs_result result = new getRowWithColumnPrefixTs_result();
+        try {
+          result.success = iface_.getRowWithColumnPrefixTs(args.tableName, args.row, args.prefix, args.timestamp);
+        } catch (IOError io) {
+          result.io = io;
+        } catch (Throwable th) {
+          LOGGER.error("Internal error processing getRowWithColumnPrefixTs", th);
+          TApplicationException x = new TApplicationException(TApplicationException.INTERNAL_ERROR, "Internal error processing getRowWithColumnPrefixTs");
+          oprot.writeMessageBegin(new TMessage("getRowWithColumnPrefixTs", TMessageType.EXCEPTION, seqid));
+          x.write(oprot);
+          oprot.writeMessageEnd();
+          oprot.getTransport().flush();
+          return;
+        }
+        oprot.writeMessageBegin(new TMessage("getRowWithColumnPrefixTs", TMessageType.REPLY, seqid));
+        result.write(oprot);
+        oprot.writeMessageEnd();
+        oprot.getTransport().flush();
+      }
+
+    }
+
     private class getRows implements ProcessFunction {
       public void process(int seqid, TProtocol iprot, TProtocol oprot) throws TException
       {
@@ -3736,6 +3956,34 @@ public class Hbase {
 
     }
 
+    private class getRegionInfo implements ProcessFunction {
+      public void process(int seqid, TProtocol iprot, TProtocol oprot) throws TException
+      {
+        getRegionInfo_args args = new getRegionInfo_args();
+        args.read(iprot);
+        iprot.readMessageEnd();
+        getRegionInfo_result result = new getRegionInfo_result();
+        try {
+          result.success = iface_.getRegionInfo(args.row);
+        } catch (IOError io) {
+          result.io = io;
+        } catch (Throwable th) {
+          LOGGER.error("Internal error processing getRegionInfo", th);
+          TApplicationException x = new TApplicationException(TApplicationException.INTERNAL_ERROR, "Internal error processing getRegionInfo");
+          oprot.writeMessageBegin(new TMessage("getRegionInfo", TMessageType.EXCEPTION, seqid));
+          x.write(oprot);
+          oprot.writeMessageEnd();
+          oprot.getTransport().flush();
+          return;
+        }
+        oprot.writeMessageBegin(new TMessage("getRegionInfo", TMessageType.REPLY, seqid));
+        result.write(oprot);
+        oprot.writeMessageEnd();
+        oprot.getTransport().flush();
+      }
+
+    }
+
   }
 
   public static class enableTable_args implements TBase<enableTable_args._Fields>, java.io.Serializable, Cloneable, Comparable<enableTable_args>   {
@@ -16968,19 +17216,46 @@ public class Hbase {
 
   }
 
-  public static class getRows_args implements TBase<getRows_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRows_args>   {
-    private static final TStruct STRUCT_DESC = new TStruct("getRows_args");
+  public static class getRowWithColumnPrefix_args implements TBase<getRowWithColumnPrefix_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowWithColumnPrefix_args>   {
+    private static final TStruct STRUCT_DESC = new TStruct("getRowWithColumnPrefix_args");
 
     private static final TField TABLE_NAME_FIELD_DESC = new TField("tableName", TType.STRING, (short)1);
-    private static final TField ROWS_FIELD_DESC = new TField("rows", TType.LIST, (short)2);
+    private static final TField ROW_FIELD_DESC = new TField("row", TType.STRING, (short)2);
+    private static final TField PREFIX_FIELD_DESC = new TField("prefix", TType.STRING, (short)3);
 
+    /**
+     * name of table
+     */
     public byte[] tableName;
-    public List<byte[]> rows;
+    /**
+     * row key
+     */
+    public byte[] row;
+    /**
+     * column prefix, null for all columns
+     * family name can be specified as <family>:<qualifier prefix>
+     * If only <qualifier prefix> provided then all families are
+     * searched
+     */
+    public byte[] prefix;
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
     public enum _Fields implements TFieldIdEnum {
+      /**
+       * name of table
+       */
       TABLE_NAME((short)1, "tableName"),
-      ROWS((short)2, "rows");
+      /**
+       * row key
+       */
+      ROW((short)2, "row"),
+      /**
+       * column prefix, null for all columns
+       * family name can be specified as <family>:<qualifier prefix>
+       * If only <qualifier prefix> provided then all families are
+       * searched
+       */
+      PREFIX((short)3, "prefix");
 
       private static final Map<Integer, _Fields> byId = new HashMap<Integer, _Fields>();
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -17038,57 +17313,65 @@ public class Hbase {
     public static final Map<_Fields, FieldMetaData> metaDataMap = Collections.unmodifiableMap(new EnumMap<_Fields, FieldMetaData>(_Fields.class) {{
       put(_Fields.TABLE_NAME, new FieldMetaData("tableName", TFieldRequirementType.DEFAULT,
           new FieldValueMetaData(TType.STRING)));
-      put(_Fields.ROWS, new FieldMetaData("rows", TFieldRequirementType.DEFAULT,
-          new ListMetaData(TType.LIST,
-              new FieldValueMetaData(TType.STRING))));
+      put(_Fields.ROW, new FieldMetaData("row", TFieldRequirementType.DEFAULT,
+          new FieldValueMetaData(TType.STRING)));
+      put(_Fields.PREFIX, new FieldMetaData("prefix", TFieldRequirementType.DEFAULT,
+          new FieldValueMetaData(TType.STRING)));
     }});
 
     static {
-      FieldMetaData.addStructMetaDataMap(getRows_args.class, metaDataMap);
+      FieldMetaData.addStructMetaDataMap(getRowWithColumnPrefix_args.class, metaDataMap);
     }
 
-    public getRows_args() {
+    public getRowWithColumnPrefix_args() {
     }
 
-    public getRows_args(
+    public getRowWithColumnPrefix_args(
       byte[] tableName,
-      List<byte[]> rows)
+      byte[] row,
+      byte[] prefix)
     {
       this();
       this.tableName = tableName;
-      this.rows = rows;
+      this.row = row;
+      this.prefix = prefix;
     }
 
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public getRows_args(getRows_args other) {
+    public getRowWithColumnPrefix_args(getRowWithColumnPrefix_args other) {
       if (other.isSetTableName()) {
         this.tableName = other.tableName;
       }
-      if (other.isSetRows()) {
-        List<byte[]> __this__rows = new ArrayList<byte[]>();
-        for (byte[] other_element : other.rows) {
-          __this__rows.add(other_element);
-        }
-        this.rows = __this__rows;
+      if (other.isSetRow()) {
+        this.row = other.row;
+      }
+      if (other.isSetPrefix()) {
+        this.prefix = other.prefix;
       }
     }
 
-    public getRows_args deepCopy() {
-      return new getRows_args(this);
+    public getRowWithColumnPrefix_args deepCopy() {
+      return new getRowWithColumnPrefix_args(this);
     }
 
     @Deprecated
-    public getRows_args clone() {
-      return new getRows_args(this);
+    public getRowWithColumnPrefix_args clone() {
+      return new getRowWithColumnPrefix_args(this);
     }
 
+    /**
+     * name of table
+     */
     public byte[] getTableName() {
       return this.tableName;
     }
 
-    public getRows_args setTableName(byte[] tableName) {
+    /**
+     * name of table
+     */
+    public getRowWithColumnPrefix_args setTableName(byte[] tableName) {
       this.tableName = tableName;
       return this;
     }
@@ -17108,42 +17391,69 @@ public class Hbase {
       }
     }
 
-    public int getRowsSize() {
-      return (this.rows == null) ? 0 : this.rows.size();
+    /**
+     * row key
+     */
+    public byte[] getRow() {
+      return this.row;
     }
 
-    public java.util.Iterator<byte[]> getRowsIterator() {
-      return (this.rows == null) ? null : this.rows.iterator();
+    /**
+     * row key
+     */
+    public getRowWithColumnPrefix_args setRow(byte[] row) {
+      this.row = row;
+      return this;
     }
 
-    public void addToRows(byte[] elem) {
-      if (this.rows == null) {
-        this.rows = new ArrayList<byte[]>();
+    public void unsetRow() {
+      this.row = null;
+    }
+
+    /** Returns true if field row is set (has been asigned a value) and false otherwise */
+    public boolean isSetRow() {
+      return this.row != null;
+    }
+
+    public void setRowIsSet(boolean value) {
+      if (!value) {
+        this.row = null;
       }
-      this.rows.add(elem);
     }
 
-    public List<byte[]> getRows() {
-      return this.rows;
+    /**
+     * column prefix, null for all columns
+     * family name can be specified as <family>:<qualifier prefix>
+     * If only <qualifier prefix> provided then all families are
+     * searched
+     */
+    public byte[] getPrefix() {
+      return this.prefix;
     }
 
-    public getRows_args setRows(List<byte[]> rows) {
-      this.rows = rows;
+    /**
+     * column prefix, null for all columns
+     * family name can be specified as <family>:<qualifier prefix>
+     * If only <qualifier prefix> provided then all families are
+     * searched
+     */
+    public getRowWithColumnPrefix_args setPrefix(byte[] prefix) {
+      this.prefix = prefix;
       return this;
     }
 
-    public void unsetRows() {
-      this.rows = null;
+    public void unsetPrefix() {
+      this.prefix = null;
     }
 
-    /** Returns true if field rows is set (has been asigned a value) and false otherwise */
-    public boolean isSetRows() {
-      return this.rows != null;
+    /** Returns true if field prefix is set (has been asigned a value) and false otherwise */
+    public boolean isSetPrefix() {
+      return this.prefix != null;
     }
 
-    public void setRowsIsSet(boolean value) {
+    public void setPrefixIsSet(boolean value) {
       if (!value) {
-        this.rows = null;
+        this.prefix = null;
       }
     }
 
@@ -17157,11 +17467,19 @@ public class Hbase {
         }
         break;
 
-      case ROWS:
+      case ROW:
         if (value == null) {
-          unsetRows();
+          unsetRow();
         } else {
-          setRows((List<byte[]>)value);
+          setRow((byte[])value);
+        }
+        break;
+
+      case PREFIX:
+        if (value == null) {
+          unsetPrefix();
+        } else {
+          setPrefix((byte[])value);
         }
         break;
 
@@ -17177,8 +17495,11 @@ public class Hbase {
       case TABLE_NAME:
         return getTableName();
 
-      case ROWS:
-        return getRows();
+      case ROW:
+        return getRow();
+
+      case PREFIX:
+        return getPrefix();
 
       }
       throw new IllegalStateException();
@@ -17193,8 +17514,10 @@ public class Hbase {
       switch (field) {
       case TABLE_NAME:
         return isSetTableName();
-      case ROWS:
-        return isSetRows();
+      case ROW:
+        return isSetRow();
+      case PREFIX:
+        return isSetPrefix();
       }
       throw new IllegalStateException();
     }
@@ -17207,12 +17530,12 @@ public class Hbase {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof getRows_args)
-        return this.equals((getRows_args)that);
+      if (that instanceof getRowWithColumnPrefix_args)
+        return this.equals((getRowWithColumnPrefix_args)that);
       return false;
     }
 
-    public boolean equals(getRows_args that) {
+    public boolean equals(getRowWithColumnPrefix_args that) {
       if (that == null)
         return false;
 
@@ -17225,12 +17548,21 @@ public class Hbase {
           return false;
       }
 
-      boolean this_present_rows = true && this.isSetRows();
-      boolean that_present_rows = true && that.isSetRows();
-      if (this_present_rows || that_present_rows) {
-        if (!(this_present_rows && that_present_rows))
+      boolean this_present_row = true && this.isSetRow();
+      boolean that_present_row = true && that.isSetRow();
+      if (this_present_row || that_present_row) {
+        if (!(this_present_row && that_present_row))
           return false;
-        if (!this.rows.equals(that.rows))
+        if (!java.util.Arrays.equals(this.row, that.row))
+          return false;
+      }
+
+      boolean this_present_prefix = true && this.isSetPrefix();
+      boolean that_present_prefix = true && that.isSetPrefix();
+      if (this_present_prefix || that_present_prefix) {
+        if (!(this_present_prefix && that_present_prefix))
+          return false;
+        if (!java.util.Arrays.equals(this.prefix, that.prefix))
           return false;
       }
 
@@ -17246,21 +17578,26 @@ public class Hbase {
       if (present_tableName)
         builder.append(tableName);
 
-      boolean present_rows = true && (isSetRows());
-      builder.append(present_rows);
-      if (present_rows)
-        builder.append(rows);
+      boolean present_row = true && (isSetRow());
+      builder.append(present_row);
+      if (present_row)
+        builder.append(row);
+
+      boolean present_prefix = true && (isSetPrefix());
+      builder.append(present_prefix);
+      if (present_prefix)
+        builder.append(prefix);
 
       return builder.toHashCode();
     }
 
-    public int compareTo(getRows_args other) {
+    public int compareTo(getRowWithColumnPrefix_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      getRows_args typedOther = (getRows_args)other;
+      getRowWithColumnPrefix_args typedOther = (getRowWithColumnPrefix_args)other;
 
       lastComparison = Boolean.valueOf(isSetTableName()).compareTo(isSetTableName());
       if (lastComparison != 0) {
@@ -17270,11 +17607,19 @@ public class Hbase {
       if (lastComparison != 0) {
         return lastComparison;
       }
-      lastComparison = Boolean.valueOf(isSetRows()).compareTo(isSetRows());
+      lastComparison = Boolean.valueOf(isSetRow()).compareTo(isSetRow());
       if (lastComparison != 0) {
         return lastComparison;
       }
-      lastComparison = TBaseHelper.compareTo(rows, typedOther.rows);
+      lastComparison = TBaseHelper.compareTo(row, typedOther.row);
+      if (lastComparison != 0) {
+        return lastComparison;
+      }
+      lastComparison = Boolean.valueOf(isSetPrefix()).compareTo(isSetPrefix());
+      if (lastComparison != 0) {
+        return lastComparison;
+      }
+      lastComparison = TBaseHelper.compareTo(prefix, typedOther.prefix);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -17302,19 +17647,16 @@ public class Hbase {
                 TProtocolUtil.skip(iprot, field.type);
               }
               break;
-            case ROWS:
-              if (field.type == TType.LIST) {
-                {
-                  TList _list66 = iprot.readListBegin();
-                  this.rows = new ArrayList<byte[]>(_list66.size);
-                  for (int _i67 = 0; _i67 < _list66.size; ++_i67)
-                  {
-                    byte[] _elem68;
-                    _elem68 = iprot.readBinary();
-                    this.rows.add(_elem68);
-                  }
-                  iprot.readListEnd();
-                }
+            case ROW:
+              if (field.type == TType.STRING) {
+                this.row = iprot.readBinary();
+              } else {
+                TProtocolUtil.skip(iprot, field.type);
+              }
+              break;
+            case PREFIX:
+              if (field.type == TType.STRING) {
+                this.prefix = iprot.readBinary();
               } else {
                 TProtocolUtil.skip(iprot, field.type);
               }
@@ -17338,16 +17680,14 @@ public class Hbase {
         oprot.writeBinary(this.tableName);
         oprot.writeFieldEnd();
       }
-      if (this.rows != null) {
-        oprot.writeFieldBegin(ROWS_FIELD_DESC);
-        {
-          oprot.writeListBegin(new TList(TType.STRING, this.rows.size()));
-          for (byte[] _iter69 : this.rows)
-          {
-            oprot.writeBinary(_iter69);
-          }
-          oprot.writeListEnd();
-        }
+      if (this.row != null) {
+        oprot.writeFieldBegin(ROW_FIELD_DESC);
+        oprot.writeBinary(this.row);
+        oprot.writeFieldEnd();
+      }
+      if (this.prefix != null) {
+        oprot.writeFieldBegin(PREFIX_FIELD_DESC);
+        oprot.writeBinary(this.prefix);
         oprot.writeFieldEnd();
       }
       oprot.writeFieldStop();
@@ -17356,7 +17696,7 @@ public class Hbase {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("getRows_args(");
+      StringBuilder sb = new StringBuilder("getRowWithColumnPrefix_args(");
       boolean first = true;
 
       sb.append("tableName:");
@@ -17367,11 +17707,19 @@ public class Hbase {
       }
       first = false;
       if (!first) sb.append(", ");
-      sb.append("rows:");
-      if (this.rows == null) {
+      sb.append("row:");
+      if (this.row == null) {
         sb.append("null");
       } else {
-        sb.append(this.rows);
+        sb.append(this.row);
+      }
+      first = false;
+      if (!first) sb.append(", ");
+      sb.append("prefix:");
+      if (this.prefix == null) {
+        sb.append("null");
+      } else {
+        sb.append(this.prefix);
       }
       first = false;
       sb.append(")");
@@ -17384,8 +17732,8 @@ public class Hbase {
 
   }
 
-  public static class getRows_result implements TBase<getRows_result._Fields>, java.io.Serializable, Cloneable   {
-    private static final TStruct STRUCT_DESC = new TStruct("getRows_result");
+  public static class getRowWithColumnPrefix_result implements TBase<getRowWithColumnPrefix_result._Fields>, java.io.Serializable, Cloneable   {
+    private static final TStruct STRUCT_DESC = new TStruct("getRowWithColumnPrefix_result");
 
     private static final TField SUCCESS_FIELD_DESC = new TField("success", TType.LIST, (short)0);
     private static final TField IO_FIELD_DESC = new TField("io", TType.STRUCT, (short)1);
@@ -17460,13 +17808,13 @@ public class Hbase {
     }});
 
     static {
-      FieldMetaData.addStructMetaDataMap(getRows_result.class, metaDataMap);
+      FieldMetaData.addStructMetaDataMap(getRowWithColumnPrefix_result.class, metaDataMap);
     }
 
-    public getRows_result() {
+    public getRowWithColumnPrefix_result() {
     }
 
-    public getRows_result(
+    public getRowWithColumnPrefix_result(
       List<TRowResult> success,
       IOError io)
     {
@@ -17478,7 +17826,7 @@ public class Hbase {
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public getRows_result(getRows_result other) {
+    public getRowWithColumnPrefix_result(getRowWithColumnPrefix_result other) {
       if (other.isSetSuccess()) {
         List<TRowResult> __this__success = new ArrayList<TRowResult>();
         for (TRowResult other_element : other.success) {
@@ -17491,13 +17839,13 @@ public class Hbase {
       }
     }
 
-    public getRows_result deepCopy() {
-      return new getRows_result(this);
+    public getRowWithColumnPrefix_result deepCopy() {
+      return new getRowWithColumnPrefix_result(this);
     }
 
     @Deprecated
-    public getRows_result clone() {
-      return new getRows_result(this);
+    public getRowWithColumnPrefix_result clone() {
+      return new getRowWithColumnPrefix_result(this);
     }
 
     public int getSuccessSize() {
@@ -17519,7 +17867,7 @@ public class Hbase {
       return this.success;
     }
 
-    public getRows_result setSuccess(List<TRowResult> success) {
+    public getRowWithColumnPrefix_result setSuccess(List<TRowResult> success) {
       this.success = success;
       return this;
     }
@@ -17543,7 +17891,7 @@ public class Hbase {
       return this.io;
     }
 
-    public getRows_result setIo(IOError io) {
+    public getRowWithColumnPrefix_result setIo(IOError io) {
       this.io = io;
       return this;
     }
@@ -17623,12 +17971,12 @@ public class Hbase {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof getRows_result)
-        return this.equals((getRows_result)that);
+      if (that instanceof getRowWithColumnPrefix_result)
+        return this.equals((getRowWithColumnPrefix_result)that);
       return false;
     }
 
-    public boolean equals(getRows_result that) {
+    public boolean equals(getRowWithColumnPrefix_result that) {
       if (that == null)
         return false;
 
@@ -17687,14 +18035,14 @@ public class Hbase {
             case SUCCESS:
               if (field.type == TType.LIST) {
                 {
-                  TList _list70 = iprot.readListBegin();
-                  this.success = new ArrayList<TRowResult>(_list70.size);
-                  for (int _i71 = 0; _i71 < _list70.size; ++_i71)
+                  TList _list66 = iprot.readListBegin();
+                  this.success = new ArrayList<TRowResult>(_list66.size);
+                  for (int _i67 = 0; _i67 < _list66.size; ++_i67)
                   {
-                    TRowResult _elem72;
-                    _elem72 = new TRowResult();
-                    _elem72.read(iprot);
-                    this.success.add(_elem72);
+                    TRowResult _elem68;
+                    _elem68 = new TRowResult();
+                    _elem68.read(iprot);
+                    this.success.add(_elem68);
                   }
                   iprot.readListEnd();
                 }
@@ -17727,9 +18075,9 @@ public class Hbase {
         oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
         {
           oprot.writeListBegin(new TList(TType.STRUCT, this.success.size()));
-          for (TRowResult _iter73 : this.success)
+          for (TRowResult _iter69 : this.success)
           {
-            _iter73.write(oprot);
+            _iter69.write(oprot);
           }
           oprot.writeListEnd();
         }
@@ -17745,7 +18093,7 @@ public class Hbase {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("getRows_result(");
+      StringBuilder sb = new StringBuilder("getRowWithColumnPrefix_result(");
       boolean first = true;
 
       sb.append("success:");
@@ -17773,22 +18121,49 @@ public class Hbase {
 
   }
 
-  public static class getRowsTs_args implements TBase<getRowsTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowsTs_args>   {
-    private static final TStruct STRUCT_DESC = new TStruct("getRowsTs_args");
+  public static class getRowWithColumnPrefixTs_args implements TBase<getRowWithColumnPrefixTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowWithColumnPrefixTs_args>   {
+    private static final TStruct STRUCT_DESC = new TStruct("getRowWithColumnPrefixTs_args");
 
     private static final TField TABLE_NAME_FIELD_DESC = new TField("tableName", TType.STRING, (short)1);
-    private static final TField ROWS_FIELD_DESC = new TField("rows", TType.LIST, (short)2);
-    private static final TField TIMESTAMP_FIELD_DESC = new TField("timestamp", TType.I64, (short)3);
+    private static final TField ROW_FIELD_DESC = new TField("row", TType.STRING, (short)2);
+    private static final TField PREFIX_FIELD_DESC = new TField("prefix", TType.STRING, (short)3);
+    private static final TField TIMESTAMP_FIELD_DESC = new TField("timestamp", TType.I64, (short)4);
 
+    /**
+     * name of table
+     */
     public byte[] tableName;
-    public List<byte[]> rows;
+    /**
+     * row key
+     */
+    public byte[] row;
+    /**
+     * column prefix, null for all columns
+     * family name can be specified as <family>:<qualifier prefix>
+     * If only <qualifier prefix> provided then all families are
+     * searched
+     */
+    public byte[] prefix;
     public long timestamp;
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
     public enum _Fields implements TFieldIdEnum {
+      /**
+       * name of table
+       */
       TABLE_NAME((short)1, "tableName"),
-      ROWS((short)2, "rows"),
-      TIMESTAMP((short)3, "timestamp");
+      /**
+       * row key
+       */
+      ROW((short)2, "row"),
+      /**
+       * column prefix, null for all columns
+       * family name can be specified as <family>:<qualifier prefix>
+       * If only <qualifier prefix> provided then all families are
+       * searched
+       */
+      PREFIX((short)3, "prefix"),
+      TIMESTAMP((short)4, "timestamp");
 
       private static final Map<Integer, _Fields> byId = new HashMap<Integer, _Fields>();
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -17848,28 +18223,31 @@ public class Hbase {
     public static final Map<_Fields, FieldMetaData> metaDataMap = Collections.unmodifiableMap(new EnumMap<_Fields, FieldMetaData>(_Fields.class) {{
       put(_Fields.TABLE_NAME, new FieldMetaData("tableName", TFieldRequirementType.DEFAULT,
           new FieldValueMetaData(TType.STRING)));
-      put(_Fields.ROWS, new FieldMetaData("rows", TFieldRequirementType.DEFAULT,
-          new ListMetaData(TType.LIST,
-              new FieldValueMetaData(TType.STRING))));
+      put(_Fields.ROW, new FieldMetaData("row", TFieldRequirementType.DEFAULT,
+          new FieldValueMetaData(TType.STRING)));
+      put(_Fields.PREFIX, new FieldMetaData("prefix", TFieldRequirementType.DEFAULT,
+          new FieldValueMetaData(TType.STRING)));
       put(_Fields.TIMESTAMP, new FieldMetaData("timestamp", TFieldRequirementType.DEFAULT,
           new FieldValueMetaData(TType.I64)));
     }});
 
     static {
-      FieldMetaData.addStructMetaDataMap(getRowsTs_args.class, metaDataMap);
+      FieldMetaData.addStructMetaDataMap(getRowWithColumnPrefixTs_args.class, metaDataMap);
     }
 
-    public getRowsTs_args() {
+    public getRowWithColumnPrefixTs_args() {
     }
 
-    public getRowsTs_args(
+    public getRowWithColumnPrefixTs_args(
       byte[] tableName,
-      List<byte[]> rows,
+      byte[] row,
+      byte[] prefix,
       long timestamp)
     {
       this();
       this.tableName = tableName;
-      this.rows = rows;
+      this.row = row;
+      this.prefix = prefix;
       this.timestamp = timestamp;
       setTimestampIsSet(true);
     }
@@ -17877,36 +18255,41 @@ public class Hbase {
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public getRowsTs_args(getRowsTs_args other) {
+    public getRowWithColumnPrefixTs_args(getRowWithColumnPrefixTs_args other) {
       __isset_bit_vector.clear();
       __isset_bit_vector.or(other.__isset_bit_vector);
       if (other.isSetTableName()) {
         this.tableName = other.tableName;
       }
-      if (other.isSetRows()) {
-        List<byte[]> __this__rows = new ArrayList<byte[]>();
-        for (byte[] other_element : other.rows) {
-          __this__rows.add(other_element);
-        }
-        this.rows = __this__rows;
+      if (other.isSetRow()) {
+        this.row = other.row;
+      }
+      if (other.isSetPrefix()) {
+        this.prefix = other.prefix;
       }
       this.timestamp = other.timestamp;
     }
 
-    public getRowsTs_args deepCopy() {
-      return new getRowsTs_args(this);
+    public getRowWithColumnPrefixTs_args deepCopy() {
+      return new getRowWithColumnPrefixTs_args(this);
     }
 
     @Deprecated
-    public getRowsTs_args clone() {
-      return new getRowsTs_args(this);
+    public getRowWithColumnPrefixTs_args clone() {
+      return new getRowWithColumnPrefixTs_args(this);
     }
 
+    /**
+     * name of table
+     */
     public byte[] getTableName() {
       return this.tableName;
     }
 
-    public getRowsTs_args setTableName(byte[] tableName) {
+    /**
+     * name of table
+     */
+    public getRowWithColumnPrefixTs_args setTableName(byte[] tableName) {
       this.tableName = tableName;
       return this;
     }
@@ -17926,42 +18309,69 @@ public class Hbase {
       }
     }
 
-    public int getRowsSize() {
-      return (this.rows == null) ? 0 : this.rows.size();
+    /**
+     * row key
+     */
+    public byte[] getRow() {
+      return this.row;
     }
 
-    public java.util.Iterator<byte[]> getRowsIterator() {
-      return (this.rows == null) ? null : this.rows.iterator();
+    /**
+     * row key
+     */
+    public getRowWithColumnPrefixTs_args setRow(byte[] row) {
+      this.row = row;
+      return this;
     }
 
-    public void addToRows(byte[] elem) {
-      if (this.rows == null) {
-        this.rows = new ArrayList<byte[]>();
+    public void unsetRow() {
+      this.row = null;
+    }
+
+    /** Returns true if field row is set (has been asigned a value) and false otherwise */
+    public boolean isSetRow() {
+      return this.row != null;
+    }
+
+    public void setRowIsSet(boolean value) {
+      if (!value) {
+        this.row = null;
       }
-      this.rows.add(elem);
     }
 
-    public List<byte[]> getRows() {
-      return this.rows;
+    /**
+     * column prefix, null for all columns
+     * family name can be specified as <family>:<qualifier prefix>
+     * If only <qualifier prefix> provided then all families are
+     * searched
+     */
+    public byte[] getPrefix() {
+      return this.prefix;
     }
 
-    public getRowsTs_args setRows(List<byte[]> rows) {
-      this.rows = rows;
+    /**
+     * column prefix, null for all columns
+     * family name can be specified as <family>:<qualifier prefix>
+     * If only <qualifier prefix> provided then all families are
+     * searched
+     */
+    public getRowWithColumnPrefixTs_args setPrefix(byte[] prefix) {
+      this.prefix = prefix;
       return this;
     }
 
-    public void unsetRows() {
-      this.rows = null;
+    public void unsetPrefix() {
+      this.prefix = null;
     }
 
-    /** Returns true if field rows is set (has been asigned a value) and false otherwise */
-    public boolean isSetRows() {
-      return this.rows != null;
+    /** Returns true if field prefix is set (has been asigned a value) and false otherwise */
+    public boolean isSetPrefix() {
+      return this.prefix != null;
     }
 
-    public void setRowsIsSet(boolean value) {
+    public void setPrefixIsSet(boolean value) {
       if (!value) {
-        this.rows = null;
+        this.prefix = null;
       }
     }
 
@@ -17969,7 +18379,7 @@ public class Hbase {
       return this.timestamp;
     }
 
-    public getRowsTs_args setTimestamp(long timestamp) {
+    public getRowWithColumnPrefixTs_args setTimestamp(long timestamp) {
       this.timestamp = timestamp;
       setTimestampIsSet(true);
       return this;
@@ -17998,11 +18408,19 @@ public class Hbase {
         }
         break;
 
-      case ROWS:
+      case ROW:
         if (value == null) {
-          unsetRows();
+          unsetRow();
         } else {
-          setRows((List<byte[]>)value);
+          setRow((byte[])value);
+        }
+        break;
+
+      case PREFIX:
+        if (value == null) {
+          unsetPrefix();
+        } else {
+          setPrefix((byte[])value);
         }
         break;
 
@@ -18026,8 +18444,11 @@ public class Hbase {
       case TABLE_NAME:
         return getTableName();
 
-      case ROWS:
-        return getRows();
+      case ROW:
+        return getRow();
+
+      case PREFIX:
+        return getPrefix();
 
       case TIMESTAMP:
         return new Long(getTimestamp());
@@ -18045,8 +18466,10 @@ public class Hbase {
       switch (field) {
       case TABLE_NAME:
         return isSetTableName();
-      case ROWS:
-        return isSetRows();
+      case ROW:
+        return isSetRow();
+      case PREFIX:
+        return isSetPrefix();
       case TIMESTAMP:
         return isSetTimestamp();
       }
@@ -18061,12 +18484,12 @@ public class Hbase {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof getRowsTs_args)
-        return this.equals((getRowsTs_args)that);
+      if (that instanceof getRowWithColumnPrefixTs_args)
+        return this.equals((getRowWithColumnPrefixTs_args)that);
       return false;
     }
 
-    public boolean equals(getRowsTs_args that) {
+    public boolean equals(getRowWithColumnPrefixTs_args that) {
       if (that == null)
         return false;
 
@@ -18079,12 +18502,21 @@ public class Hbase {
           return false;
       }
 
-      boolean this_present_rows = true && this.isSetRows();
-      boolean that_present_rows = true && that.isSetRows();
-      if (this_present_rows || that_present_rows) {
-        if (!(this_present_rows && that_present_rows))
+      boolean this_present_row = true && this.isSetRow();
+      boolean that_present_row = true && that.isSetRow();
+      if (this_present_row || that_present_row) {
+        if (!(this_present_row && that_present_row))
           return false;
-        if (!this.rows.equals(that.rows))
+        if (!java.util.Arrays.equals(this.row, that.row))
+          return false;
+      }
+
+      boolean this_present_prefix = true && this.isSetPrefix();
+      boolean that_present_prefix = true && that.isSetPrefix();
+      if (this_present_prefix || that_present_prefix) {
+        if (!(this_present_prefix && that_present_prefix))
+          return false;
+        if (!java.util.Arrays.equals(this.prefix, that.prefix))
           return false;
       }
 
@@ -18109,10 +18541,15 @@ public class Hbase {
       if (present_tableName)
         builder.append(tableName);
 
-      boolean present_rows = true && (isSetRows());
-      builder.append(present_rows);
-      if (present_rows)
-        builder.append(rows);
+      boolean present_row = true && (isSetRow());
+      builder.append(present_row);
+      if (present_row)
+        builder.append(row);
+
+      boolean present_prefix = true && (isSetPrefix());
+      builder.append(present_prefix);
+      if (present_prefix)
+        builder.append(prefix);
 
       boolean present_timestamp = true;
       builder.append(present_timestamp);
@@ -18122,13 +18559,13 @@ public class Hbase {
       return builder.toHashCode();
     }
 
-    public int compareTo(getRowsTs_args other) {
+    public int compareTo(getRowWithColumnPrefixTs_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      getRowsTs_args typedOther = (getRowsTs_args)other;
+      getRowWithColumnPrefixTs_args typedOther = (getRowWithColumnPrefixTs_args)other;
 
       lastComparison = Boolean.valueOf(isSetTableName()).compareTo(isSetTableName());
       if (lastComparison != 0) {
@@ -18138,11 +18575,19 @@ public class Hbase {
       if (lastComparison != 0) {
         return lastComparison;
       }
-      lastComparison = Boolean.valueOf(isSetRows()).compareTo(isSetRows());
+      lastComparison = Boolean.valueOf(isSetRow()).compareTo(isSetRow());
       if (lastComparison != 0) {
         return lastComparison;
       }
-      lastComparison = TBaseHelper.compareTo(rows, typedOther.rows);
+      lastComparison = TBaseHelper.compareTo(row, typedOther.row);
+      if (lastComparison != 0) {
+        return lastComparison;
+      }
+      lastComparison = Boolean.valueOf(isSetPrefix()).compareTo(isSetPrefix());
+      if (lastComparison != 0) {
+        return lastComparison;
+      }
+      lastComparison = TBaseHelper.compareTo(prefix, typedOther.prefix);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -18178,19 +18623,16 @@ public class Hbase {
                 TProtocolUtil.skip(iprot, field.type);
               }
               break;
-            case ROWS:
-              if (field.type == TType.LIST) {
-                {
-                  TList _list74 = iprot.readListBegin();
-                  this.rows = new ArrayList<byte[]>(_list74.size);
-                  for (int _i75 = 0; _i75 < _list74.size; ++_i75)
-                  {
-                    byte[] _elem76;
-                    _elem76 = iprot.readBinary();
-                    this.rows.add(_elem76);
-                  }
-                  iprot.readListEnd();
-                }
+            case ROW:
+              if (field.type == TType.STRING) {
+                this.row = iprot.readBinary();
+              } else {
+                TProtocolUtil.skip(iprot, field.type);
+              }
+              break;
+            case PREFIX:
+              if (field.type == TType.STRING) {
+                this.prefix = iprot.readBinary();
               } else {
                 TProtocolUtil.skip(iprot, field.type);
               }
@@ -18222,16 +18664,14 @@ public class Hbase {
         oprot.writeBinary(this.tableName);
         oprot.writeFieldEnd();
       }
-      if (this.rows != null) {
-        oprot.writeFieldBegin(ROWS_FIELD_DESC);
-        {
-          oprot.writeListBegin(new TList(TType.STRING, this.rows.size()));
-          for (byte[] _iter77 : this.rows)
-          {
-            oprot.writeBinary(_iter77);
-          }
-          oprot.writeListEnd();
-        }
+      if (this.row != null) {
+        oprot.writeFieldBegin(ROW_FIELD_DESC);
+        oprot.writeBinary(this.row);
+        oprot.writeFieldEnd();
+      }
+      if (this.prefix != null) {
+        oprot.writeFieldBegin(PREFIX_FIELD_DESC);
+        oprot.writeBinary(this.prefix);
         oprot.writeFieldEnd();
       }
       oprot.writeFieldBegin(TIMESTAMP_FIELD_DESC);
@@ -18243,7 +18683,7 @@ public class Hbase {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("getRowsTs_args(");
+      StringBuilder sb = new StringBuilder("getRowWithColumnPrefixTs_args(");
       boolean first = true;
 
       sb.append("tableName:");
@@ -18254,11 +18694,19 @@ public class Hbase {
       }
       first = false;
       if (!first) sb.append(", ");
-      sb.append("rows:");
-      if (this.rows == null) {
+      sb.append("row:");
+      if (this.row == null) {
         sb.append("null");
       } else {
-        sb.append(this.rows);
+        sb.append(this.row);
+      }
+      first = false;
+      if (!first) sb.append(", ");
+      sb.append("prefix:");
+      if (this.prefix == null) {
+        sb.append("null");
+      } else {
+        sb.append(this.prefix);
       }
       first = false;
       if (!first) sb.append(", ");
@@ -18275,8 +18723,8 @@ public class Hbase {
 
   }
 
-  public static class getRowsTs_result implements TBase<getRowsTs_result._Fields>, java.io.Serializable, Cloneable   {
-    private static final TStruct STRUCT_DESC = new TStruct("getRowsTs_result");
+  public static class getRowWithColumnPrefixTs_result implements TBase<getRowWithColumnPrefixTs_result._Fields>, java.io.Serializable, Cloneable   {
+    private static final TStruct STRUCT_DESC = new TStruct("getRowWithColumnPrefixTs_result");
 
     private static final TField SUCCESS_FIELD_DESC = new TField("success", TType.LIST, (short)0);
     private static final TField IO_FIELD_DESC = new TField("io", TType.STRUCT, (short)1);
@@ -18351,13 +18799,13 @@ public class Hbase {
     }});
 
     static {
-      FieldMetaData.addStructMetaDataMap(getRowsTs_result.class, metaDataMap);
+      FieldMetaData.addStructMetaDataMap(getRowWithColumnPrefixTs_result.class, metaDataMap);
     }
 
-    public getRowsTs_result() {
+    public getRowWithColumnPrefixTs_result() {
     }
 
-    public getRowsTs_result(
+    public getRowWithColumnPrefixTs_result(
       List<TRowResult> success,
       IOError io)
     {
@@ -18369,7 +18817,7 @@ public class Hbase {
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public getRowsTs_result(getRowsTs_result other) {
+    public getRowWithColumnPrefixTs_result(getRowWithColumnPrefixTs_result other) {
       if (other.isSetSuccess()) {
         List<TRowResult> __this__success = new ArrayList<TRowResult>();
         for (TRowResult other_element : other.success) {
@@ -18382,13 +18830,13 @@ public class Hbase {
       }
     }
 
-    public getRowsTs_result deepCopy() {
-      return new getRowsTs_result(this);
+    public getRowWithColumnPrefixTs_result deepCopy() {
+      return new getRowWithColumnPrefixTs_result(this);
     }
 
     @Deprecated
-    public getRowsTs_result clone() {
-      return new getRowsTs_result(this);
+    public getRowWithColumnPrefixTs_result clone() {
+      return new getRowWithColumnPrefixTs_result(this);
     }
 
     public int getSuccessSize() {
@@ -18410,7 +18858,7 @@ public class Hbase {
       return this.success;
     }
 
-    public getRowsTs_result setSuccess(List<TRowResult> success) {
+    public getRowWithColumnPrefixTs_result setSuccess(List<TRowResult> success) {
       this.success = success;
       return this;
     }
@@ -18434,7 +18882,7 @@ public class Hbase {
       return this.io;
     }
 
-    public getRowsTs_result setIo(IOError io) {
+    public getRowWithColumnPrefixTs_result setIo(IOError io) {
       this.io = io;
       return this;
     }
@@ -18514,12 +18962,12 @@ public class Hbase {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof getRowsTs_result)
-        return this.equals((getRowsTs_result)that);
+      if (that instanceof getRowWithColumnPrefixTs_result)
+        return this.equals((getRowWithColumnPrefixTs_result)that);
       return false;
     }
 
-    public boolean equals(getRowsTs_result that) {
+    public boolean equals(getRowWithColumnPrefixTs_result that) {
       if (that == null)
         return false;
 
@@ -18578,14 +19026,14 @@ public class Hbase {
             case SUCCESS:
               if (field.type == TType.LIST) {
                 {
-                  TList _list78 = iprot.readListBegin();
-                  this.success = new ArrayList<TRowResult>(_list78.size);
-                  for (int _i79 = 0; _i79 < _list78.size; ++_i79)
+                  TList _list70 = iprot.readListBegin();
+                  this.success = new ArrayList<TRowResult>(_list70.size);
+                  for (int _i71 = 0; _i71 < _list70.size; ++_i71)
                   {
-                    TRowResult _elem80;
-                    _elem80 = new TRowResult();
-                    _elem80.read(iprot);
-                    this.success.add(_elem80);
+                    TRowResult _elem72;
+                    _elem72 = new TRowResult();
+                    _elem72.read(iprot);
+                    this.success.add(_elem72);
                   }
                   iprot.readListEnd();
                 }
@@ -18618,9 +19066,9 @@ public class Hbase {
         oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
         {
           oprot.writeListBegin(new TList(TType.STRUCT, this.success.size()));
-          for (TRowResult _iter81 : this.success)
+          for (TRowResult _iter73 : this.success)
           {
-            _iter81.write(oprot);
+            _iter73.write(oprot);
           }
           oprot.writeListEnd();
         }
@@ -18636,7 +19084,7 @@ public class Hbase {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("getRowsTs_result(");
+      StringBuilder sb = new StringBuilder("getRowWithColumnPrefixTs_result(");
       boolean first = true;
 
       sb.append("success:");
@@ -18664,22 +19112,19 @@ public class Hbase {
 
   }
 
-  public static class getRowsWithColumns_args implements TBase<getRowsWithColumns_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowsWithColumns_args>   {
-    private static final TStruct STRUCT_DESC = new TStruct("getRowsWithColumns_args");
+  public static class getRows_args implements TBase<getRows_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRows_args>   {
+    private static final TStruct STRUCT_DESC = new TStruct("getRows_args");
 
     private static final TField TABLE_NAME_FIELD_DESC = new TField("tableName", TType.STRING, (short)1);
     private static final TField ROWS_FIELD_DESC = new TField("rows", TType.LIST, (short)2);
-    private static final TField FAMILIES_FIELD_DESC = new TField("families", TType.LIST, (short)3);
 
     public byte[] tableName;
     public List<byte[]> rows;
-    public List<byte[]> families;
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
     public enum _Fields implements TFieldIdEnum {
       TABLE_NAME((short)1, "tableName"),
-      ROWS((short)2, "rows"),
-      FAMILIES((short)3, "families");
+      ROWS((short)2, "rows");
 
       private static final Map<Integer, _Fields> byId = new HashMap<Integer, _Fields>();
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -18740,33 +19185,28 @@ public class Hbase {
       put(_Fields.ROWS, new FieldMetaData("rows", TFieldRequirementType.DEFAULT,
           new ListMetaData(TType.LIST,
               new FieldValueMetaData(TType.STRING))));
-      put(_Fields.FAMILIES, new FieldMetaData("families", TFieldRequirementType.DEFAULT,
-          new ListMetaData(TType.LIST,
-              new FieldValueMetaData(TType.STRING))));
     }});
 
     static {
-      FieldMetaData.addStructMetaDataMap(getRowsWithColumns_args.class, metaDataMap);
+      FieldMetaData.addStructMetaDataMap(getRows_args.class, metaDataMap);
     }
 
-    public getRowsWithColumns_args() {
+    public getRows_args() {
     }
 
-    public getRowsWithColumns_args(
+    public getRows_args(
       byte[] tableName,
-      List<byte[]> rows,
-      List<byte[]> families)
+      List<byte[]> rows)
     {
       this();
       this.tableName = tableName;
       this.rows = rows;
-      this.families = families;
     }
 
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public getRowsWithColumns_args(getRowsWithColumns_args other) {
+    public getRows_args(getRows_args other) {
       if (other.isSetTableName()) {
         this.tableName = other.tableName;
       }
@@ -18777,29 +19217,22 @@ public class Hbase {
         }
         this.rows = __this__rows;
       }
-      if (other.isSetFamilies()) {
-        List<byte[]> __this__families = new ArrayList<byte[]>();
-        for (byte[] other_element : other.families) {
-          __this__families.add(other_element);
-        }
-        this.families = __this__families;
-      }
     }
 
-    public getRowsWithColumns_args deepCopy() {
-      return new getRowsWithColumns_args(this);
+    public getRows_args deepCopy() {
+      return new getRows_args(this);
     }
 
     @Deprecated
-    public getRowsWithColumns_args clone() {
-      return new getRowsWithColumns_args(this);
+    public getRows_args clone() {
+      return new getRows_args(this);
     }
 
     public byte[] getTableName() {
       return this.tableName;
     }
 
-    public getRowsWithColumns_args setTableName(byte[] tableName) {
+    public getRows_args setTableName(byte[] tableName) {
       this.tableName = tableName;
       return this;
     }
@@ -18838,7 +19271,7 @@ public class Hbase {
       return this.rows;
     }
 
-    public getRowsWithColumns_args setRows(List<byte[]> rows) {
+    public getRows_args setRows(List<byte[]> rows) {
       this.rows = rows;
       return this;
     }
@@ -18858,45 +19291,6 @@ public class Hbase {
       }
     }
 
-    public int getFamiliesSize() {
-      return (this.families == null) ? 0 : this.families.size();
-    }
-
-    public java.util.Iterator<byte[]> getFamiliesIterator() {
-      return (this.families == null) ? null : this.families.iterator();
-    }
-
-    public void addToFamilies(byte[] elem) {
-      if (this.families == null) {
-        this.families = new ArrayList<byte[]>();
-      }
-      this.families.add(elem);
-    }
-
-    public List<byte[]> getFamilies() {
-      return this.families;
-    }
-
-    public getRowsWithColumns_args setFamilies(List<byte[]> families) {
-      this.families = families;
-      return this;
-    }
-
-    public void unsetFamilies() {
-      this.families = null;
-    }
-
-    /** Returns true if field families is set (has been asigned a value) and false otherwise */
-    public boolean isSetFamilies() {
-      return this.families != null;
-    }
-
-    public void setFamiliesIsSet(boolean value) {
-      if (!value) {
-        this.families = null;
-      }
-    }
-
     public void setFieldValue(_Fields field, Object value) {
       switch (field) {
       case TABLE_NAME:
@@ -18915,14 +19309,6 @@ public class Hbase {
         }
         break;
 
-      case FAMILIES:
-        if (value == null) {
-          unsetFamilies();
-        } else {
-          setFamilies((List<byte[]>)value);
-        }
-        break;
-
       }
     }
 
@@ -18938,9 +19324,6 @@ public class Hbase {
       case ROWS:
         return getRows();
 
-      case FAMILIES:
-        return getFamilies();
-
       }
       throw new IllegalStateException();
     }
@@ -18956,8 +19339,6 @@ public class Hbase {
         return isSetTableName();
       case ROWS:
         return isSetRows();
-      case FAMILIES:
-        return isSetFamilies();
       }
       throw new IllegalStateException();
     }
@@ -18970,12 +19351,12 @@ public class Hbase {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof getRowsWithColumns_args)
-        return this.equals((getRowsWithColumns_args)that);
+      if (that instanceof getRows_args)
+        return this.equals((getRows_args)that);
       return false;
     }
 
-    public boolean equals(getRowsWithColumns_args that) {
+    public boolean equals(getRows_args that) {
       if (that == null)
         return false;
 
@@ -18997,15 +19378,6 @@ public class Hbase {
           return false;
       }
 
-      boolean this_present_families = true && this.isSetFamilies();
-      boolean that_present_families = true && that.isSetFamilies();
-      if (this_present_families || that_present_families) {
-        if (!(this_present_families && that_present_families))
-          return false;
-        if (!this.families.equals(that.families))
-          return false;
-      }
-
       return true;
     }
 
@@ -19023,21 +19395,16 @@ public class Hbase {
       if (present_rows)
         builder.append(rows);
 
-      boolean present_families = true && (isSetFamilies());
-      builder.append(present_families);
-      if (present_families)
-        builder.append(families);
-
       return builder.toHashCode();
     }
 
-    public int compareTo(getRowsWithColumns_args other) {
+    public int compareTo(getRows_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      getRowsWithColumns_args typedOther = (getRowsWithColumns_args)other;
+      getRows_args typedOther = (getRows_args)other;
 
       lastComparison = Boolean.valueOf(isSetTableName()).compareTo(isSetTableName());
       if (lastComparison != 0) {
@@ -19055,14 +19422,6 @@ public class Hbase {
       if (lastComparison != 0) {
         return lastComparison;
       }
-      lastComparison = Boolean.valueOf(isSetFamilies()).compareTo(isSetFamilies());
-      if (lastComparison != 0) {
-        return lastComparison;
-      }
-      lastComparison = TBaseHelper.compareTo(families, typedOther.families);
-      if (lastComparison != 0) {
-        return lastComparison;
-      }
       return 0;
     }
 
@@ -19090,30 +19449,13 @@ public class Hbase {
             case ROWS:
               if (field.type == TType.LIST) {
                 {
-                  TList _list82 = iprot.readListBegin();
-                  this.rows = new ArrayList<byte[]>(_list82.size);
-                  for (int _i83 = 0; _i83 < _list82.size; ++_i83)
-                  {
-                    byte[] _elem84;
-                    _elem84 = iprot.readBinary();
-                    this.rows.add(_elem84);
-                  }
-                  iprot.readListEnd();
-                }
-              } else {
-                TProtocolUtil.skip(iprot, field.type);
-              }
-              break;
-            case FAMILIES:
-              if (field.type == TType.LIST) {
-                {
-                  TList _list85 = iprot.readListBegin();
-                  this.families = new ArrayList<byte[]>(_list85.size);
-                  for (int _i86 = 0; _i86 < _list85.size; ++_i86)
+                  TList _list74 = iprot.readListBegin();
+                  this.rows = new ArrayList<byte[]>(_list74.size);
+                  for (int _i75 = 0; _i75 < _list74.size; ++_i75)
                   {
-                    byte[] _elem87;
-                    _elem87 = iprot.readBinary();
-                    this.families.add(_elem87);
+                    byte[] _elem76;
+                    _elem76 = iprot.readBinary();
+                    this.rows.add(_elem76);
                   }
                   iprot.readListEnd();
                 }
@@ -19144,21 +19486,9 @@ public class Hbase {
         oprot.writeFieldBegin(ROWS_FIELD_DESC);
         {
           oprot.writeListBegin(new TList(TType.STRING, this.rows.size()));
-          for (byte[] _iter88 : this.rows)
-          {
-            oprot.writeBinary(_iter88);
-          }
-          oprot.writeListEnd();
-        }
-        oprot.writeFieldEnd();
-      }
-      if (this.families != null) {
-        oprot.writeFieldBegin(FAMILIES_FIELD_DESC);
-        {
-          oprot.writeListBegin(new TList(TType.STRING, this.families.size()));
-          for (byte[] _iter89 : this.families)
+          for (byte[] _iter77 : this.rows)
           {
-            oprot.writeBinary(_iter89);
+            oprot.writeBinary(_iter77);
           }
           oprot.writeListEnd();
         }
@@ -19170,7 +19500,7 @@ public class Hbase {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("getRowsWithColumns_args(");
+      StringBuilder sb = new StringBuilder("getRows_args(");
       boolean first = true;
 
       sb.append("tableName:");
@@ -19188,14 +19518,6 @@ public class Hbase {
         sb.append(this.rows);
       }
       first = false;
-      if (!first) sb.append(", ");
-      sb.append("families:");
-      if (this.families == null) {
-        sb.append("null");
-      } else {
-        sb.append(this.families);
-      }
-      first = false;
       sb.append(")");
       return sb.toString();
     }
@@ -19206,8 +19528,8 @@ public class Hbase {
 
   }
 
-  public static class getRowsWithColumns_result implements TBase<getRowsWithColumns_result._Fields>, java.io.Serializable, Cloneable   {
-    private static final TStruct STRUCT_DESC = new TStruct("getRowsWithColumns_result");
+  public static class getRows_result implements TBase<getRows_result._Fields>, java.io.Serializable, Cloneable   {
+    private static final TStruct STRUCT_DESC = new TStruct("getRows_result");
 
     private static final TField SUCCESS_FIELD_DESC = new TField("success", TType.LIST, (short)0);
     private static final TField IO_FIELD_DESC = new TField("io", TType.STRUCT, (short)1);
@@ -19282,13 +19604,13 @@ public class Hbase {
     }});
 
     static {
-      FieldMetaData.addStructMetaDataMap(getRowsWithColumns_result.class, metaDataMap);
+      FieldMetaData.addStructMetaDataMap(getRows_result.class, metaDataMap);
     }
 
-    public getRowsWithColumns_result() {
+    public getRows_result() {
     }
 
-    public getRowsWithColumns_result(
+    public getRows_result(
       List<TRowResult> success,
       IOError io)
     {
@@ -19300,7 +19622,7 @@ public class Hbase {
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public getRowsWithColumns_result(getRowsWithColumns_result other) {
+    public getRows_result(getRows_result other) {
       if (other.isSetSuccess()) {
         List<TRowResult> __this__success = new ArrayList<TRowResult>();
         for (TRowResult other_element : other.success) {
@@ -19313,13 +19635,13 @@ public class Hbase {
       }
     }
 
-    public getRowsWithColumns_result deepCopy() {
-      return new getRowsWithColumns_result(this);
+    public getRows_result deepCopy() {
+      return new getRows_result(this);
     }
 
     @Deprecated
-    public getRowsWithColumns_result clone() {
-      return new getRowsWithColumns_result(this);
+    public getRows_result clone() {
+      return new getRows_result(this);
     }
 
     public int getSuccessSize() {
@@ -19341,7 +19663,7 @@ public class Hbase {
       return this.success;
     }
 
-    public getRowsWithColumns_result setSuccess(List<TRowResult> success) {
+    public getRows_result setSuccess(List<TRowResult> success) {
       this.success = success;
       return this;
     }
@@ -19365,7 +19687,7 @@ public class Hbase {
       return this.io;
     }
 
-    public getRowsWithColumns_result setIo(IOError io) {
+    public getRows_result setIo(IOError io) {
       this.io = io;
       return this;
     }
@@ -19445,12 +19767,12 @@ public class Hbase {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof getRowsWithColumns_result)
-        return this.equals((getRowsWithColumns_result)that);
+      if (that instanceof getRows_result)
+        return this.equals((getRows_result)that);
       return false;
     }
 
-    public boolean equals(getRowsWithColumns_result that) {
+    public boolean equals(getRows_result that) {
       if (that == null)
         return false;
 
@@ -19509,14 +19831,14 @@ public class Hbase {
             case SUCCESS:
               if (field.type == TType.LIST) {
                 {
-                  TList _list90 = iprot.readListBegin();
-                  this.success = new ArrayList<TRowResult>(_list90.size);
-                  for (int _i91 = 0; _i91 < _list90.size; ++_i91)
+                  TList _list78 = iprot.readListBegin();
+                  this.success = new ArrayList<TRowResult>(_list78.size);
+                  for (int _i79 = 0; _i79 < _list78.size; ++_i79)
                   {
-                    TRowResult _elem92;
-                    _elem92 = new TRowResult();
-                    _elem92.read(iprot);
-                    this.success.add(_elem92);
+                    TRowResult _elem80;
+                    _elem80 = new TRowResult();
+                    _elem80.read(iprot);
+                    this.success.add(_elem80);
                   }
                   iprot.readListEnd();
                 }
@@ -19549,9 +19871,9 @@ public class Hbase {
         oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
         {
           oprot.writeListBegin(new TList(TType.STRUCT, this.success.size()));
-          for (TRowResult _iter93 : this.success)
+          for (TRowResult _iter81 : this.success)
           {
-            _iter93.write(oprot);
+            _iter81.write(oprot);
           }
           oprot.writeListEnd();
         }
@@ -19567,7 +19889,7 @@ public class Hbase {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("getRowsWithColumns_result(");
+      StringBuilder sb = new StringBuilder("getRows_result(");
       boolean first = true;
 
       sb.append("success:");
@@ -19595,25 +19917,22 @@ public class Hbase {
 
   }
 
-  public static class getRowsWithColumnsTs_args implements TBase<getRowsWithColumnsTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowsWithColumnsTs_args>   {
-    private static final TStruct STRUCT_DESC = new TStruct("getRowsWithColumnsTs_args");
+  public static class getRowsTs_args implements TBase<getRowsTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowsTs_args>   {
+    private static final TStruct STRUCT_DESC = new TStruct("getRowsTs_args");
 
     private static final TField TABLE_NAME_FIELD_DESC = new TField("tableName", TType.STRING, (short)1);
     private static final TField ROWS_FIELD_DESC = new TField("rows", TType.LIST, (short)2);
-    private static final TField FAMILIES_FIELD_DESC = new TField("families", TType.LIST, (short)3);
-    private static final TField TIMESTAMP_FIELD_DESC = new TField("timestamp", TType.I64, (short)4);
+    private static final TField TIMESTAMP_FIELD_DESC = new TField("timestamp", TType.I64, (short)3);
 
     public byte[] tableName;
     public List<byte[]> rows;
-    public List<byte[]> families;
     public long timestamp;
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
     public enum _Fields implements TFieldIdEnum {
       TABLE_NAME((short)1, "tableName"),
       ROWS((short)2, "rows"),
-      FAMILIES((short)3, "families"),
-      TIMESTAMP((short)4, "timestamp");
+      TIMESTAMP((short)3, "timestamp");
 
       private static final Map<Integer, _Fields> byId = new HashMap<Integer, _Fields>();
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -19676,30 +19995,25 @@ public class Hbase {
       put(_Fields.ROWS, new FieldMetaData("rows", TFieldRequirementType.DEFAULT,
           new ListMetaData(TType.LIST,
               new FieldValueMetaData(TType.STRING))));
-      put(_Fields.FAMILIES, new FieldMetaData("families", TFieldRequirementType.DEFAULT,
-          new ListMetaData(TType.LIST,
-              new FieldValueMetaData(TType.STRING))));
       put(_Fields.TIMESTAMP, new FieldMetaData("timestamp", TFieldRequirementType.DEFAULT,
           new FieldValueMetaData(TType.I64)));
     }});
 
     static {
-      FieldMetaData.addStructMetaDataMap(getRowsWithColumnsTs_args.class, metaDataMap);
+      FieldMetaData.addStructMetaDataMap(getRowsTs_args.class, metaDataMap);
     }
 
-    public getRowsWithColumnsTs_args() {
+    public getRowsTs_args() {
     }
 
-    public getRowsWithColumnsTs_args(
+    public getRowsTs_args(
       byte[] tableName,
       List<byte[]> rows,
-      List<byte[]> families,
       long timestamp)
     {
       this();
       this.tableName = tableName;
       this.rows = rows;
-      this.families = families;
       this.timestamp = timestamp;
       setTimestampIsSet(true);
     }
@@ -19707,7 +20021,7 @@ public class Hbase {
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public getRowsWithColumnsTs_args(getRowsWithColumnsTs_args other) {
+    public getRowsTs_args(getRowsTs_args other) {
       __isset_bit_vector.clear();
       __isset_bit_vector.or(other.__isset_bit_vector);
       if (other.isSetTableName()) {
@@ -19720,30 +20034,23 @@ public class Hbase {
         }
         this.rows = __this__rows;
       }
-      if (other.isSetFamilies()) {
-        List<byte[]> __this__families = new ArrayList<byte[]>();
-        for (byte[] other_element : other.families) {
-          __this__families.add(other_element);
-        }
-        this.families = __this__families;
-      }
       this.timestamp = other.timestamp;
     }
 
-    public getRowsWithColumnsTs_args deepCopy() {
-      return new getRowsWithColumnsTs_args(this);
+    public getRowsTs_args deepCopy() {
+      return new getRowsTs_args(this);
     }
 
     @Deprecated
-    public getRowsWithColumnsTs_args clone() {
-      return new getRowsWithColumnsTs_args(this);
+    public getRowsTs_args clone() {
+      return new getRowsTs_args(this);
     }
 
     public byte[] getTableName() {
       return this.tableName;
     }
 
-    public getRowsWithColumnsTs_args setTableName(byte[] tableName) {
+    public getRowsTs_args setTableName(byte[] tableName) {
       this.tableName = tableName;
       return this;
     }
@@ -19782,7 +20089,7 @@ public class Hbase {
       return this.rows;
     }
 
-    public getRowsWithColumnsTs_args setRows(List<byte[]> rows) {
+    public getRowsTs_args setRows(List<byte[]> rows) {
       this.rows = rows;
       return this;
     }
@@ -19802,50 +20109,11 @@ public class Hbase {
       }
     }
 
-    public int getFamiliesSize() {
-      return (this.families == null) ? 0 : this.families.size();
-    }
-
-    public java.util.Iterator<byte[]> getFamiliesIterator() {
-      return (this.families == null) ? null : this.families.iterator();
-    }
-
-    public void addToFamilies(byte[] elem) {
-      if (this.families == null) {
-        this.families = new ArrayList<byte[]>();
-      }
-      this.families.add(elem);
-    }
-
-    public List<byte[]> getFamilies() {
-      return this.families;
-    }
-
-    public getRowsWithColumnsTs_args setFamilies(List<byte[]> families) {
-      this.families = families;
-      return this;
-    }
-
-    public void unsetFamilies() {
-      this.families = null;
-    }
-
-    /** Returns true if field families is set (has been asigned a value) and false otherwise */
-    public boolean isSetFamilies() {
-      return this.families != null;
-    }
-
-    public void setFamiliesIsSet(boolean value) {
-      if (!value) {
-        this.families = null;
-      }
-    }
-
     public long getTimestamp() {
       return this.timestamp;
     }
 
-    public getRowsWithColumnsTs_args setTimestamp(long timestamp) {
+    public getRowsTs_args setTimestamp(long timestamp) {
       this.timestamp = timestamp;
       setTimestampIsSet(true);
       return this;
@@ -19882,14 +20150,6 @@ public class Hbase {
         }
         break;
 
-      case FAMILIES:
-        if (value == null) {
-          unsetFamilies();
-        } else {
-          setFamilies((List<byte[]>)value);
-        }
-        break;
-
       case TIMESTAMP:
         if (value == null) {
           unsetTimestamp();
@@ -19913,9 +20173,6 @@ public class Hbase {
       case ROWS:
         return getRows();
 
-      case FAMILIES:
-        return getFamilies();
-
       case TIMESTAMP:
         return new Long(getTimestamp());
 
@@ -19934,8 +20191,6 @@ public class Hbase {
         return isSetTableName();
       case ROWS:
         return isSetRows();
-      case FAMILIES:
-        return isSetFamilies();
       case TIMESTAMP:
         return isSetTimestamp();
       }
@@ -19950,12 +20205,12 @@ public class Hbase {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof getRowsWithColumnsTs_args)
-        return this.equals((getRowsWithColumnsTs_args)that);
+      if (that instanceof getRowsTs_args)
+        return this.equals((getRowsTs_args)that);
       return false;
     }
 
-    public boolean equals(getRowsWithColumnsTs_args that) {
+    public boolean equals(getRowsTs_args that) {
       if (that == null)
         return false;
 
@@ -19977,15 +20232,6 @@ public class Hbase {
           return false;
       }
 
-      boolean this_present_families = true && this.isSetFamilies();
-      boolean that_present_families = true && that.isSetFamilies();
-      if (this_present_families || that_present_families) {
-        if (!(this_present_families && that_present_families))
-          return false;
-        if (!this.families.equals(that.families))
-          return false;
-      }
-
       boolean this_present_timestamp = true;
       boolean that_present_timestamp = true;
       if (this_present_timestamp || that_present_timestamp) {
@@ -20012,11 +20258,6 @@ public class Hbase {
       if (present_rows)
         builder.append(rows);
 
-      boolean present_families = true && (isSetFamilies());
-      builder.append(present_families);
-      if (present_families)
-        builder.append(families);
-
       boolean present_timestamp = true;
       builder.append(present_timestamp);
       if (present_timestamp)
@@ -20025,13 +20266,13 @@ public class Hbase {
       return builder.toHashCode();
     }
 
-    public int compareTo(getRowsWithColumnsTs_args other) {
+    public int compareTo(getRowsTs_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      getRowsWithColumnsTs_args typedOther = (getRowsWithColumnsTs_args)other;
+      getRowsTs_args typedOther = (getRowsTs_args)other;
 
       lastComparison = Boolean.valueOf(isSetTableName()).compareTo(isSetTableName());
       if (lastComparison != 0) {
@@ -20049,14 +20290,6 @@ public class Hbase {
       if (lastComparison != 0) {
         return lastComparison;
       }
-      lastComparison = Boolean.valueOf(isSetFamilies()).compareTo(isSetFamilies());
-      if (lastComparison != 0) {
-        return lastComparison;
-      }
-      lastComparison = TBaseHelper.compareTo(families, typedOther.families);
-      if (lastComparison != 0) {
-        return lastComparison;
-      }
       lastComparison = Boolean.valueOf(isSetTimestamp()).compareTo(isSetTimestamp());
       if (lastComparison != 0) {
         return lastComparison;
@@ -20092,30 +20325,13 @@ public class Hbase {
             case ROWS:
               if (field.type == TType.LIST) {
                 {
-                  TList _list94 = iprot.readListBegin();
-                  this.rows = new ArrayList<byte[]>(_list94.size);
-                  for (int _i95 = 0; _i95 < _list94.size; ++_i95)
-                  {
-                    byte[] _elem96;
-                    _elem96 = iprot.readBinary();
-                    this.rows.add(_elem96);
-                  }
-                  iprot.readListEnd();
-                }
-              } else {
-                TProtocolUtil.skip(iprot, field.type);
-              }
-              break;
-            case FAMILIES:
-              if (field.type == TType.LIST) {
-                {
-                  TList _list97 = iprot.readListBegin();
-                  this.families = new ArrayList<byte[]>(_list97.size);
-                  for (int _i98 = 0; _i98 < _list97.size; ++_i98)
+                  TList _list82 = iprot.readListBegin();
+                  this.rows = new ArrayList<byte[]>(_list82.size);
+                  for (int _i83 = 0; _i83 < _list82.size; ++_i83)
                   {
-                    byte[] _elem99;
-                    _elem99 = iprot.readBinary();
-                    this.families.add(_elem99);
+                    byte[] _elem84;
+                    _elem84 = iprot.readBinary();
+                    this.rows.add(_elem84);
                   }
                   iprot.readListEnd();
                 }
@@ -20154,21 +20370,9 @@ public class Hbase {
         oprot.writeFieldBegin(ROWS_FIELD_DESC);
         {
           oprot.writeListBegin(new TList(TType.STRING, this.rows.size()));
-          for (byte[] _iter100 : this.rows)
-          {
-            oprot.writeBinary(_iter100);
-          }
-          oprot.writeListEnd();
-        }
-        oprot.writeFieldEnd();
-      }
-      if (this.families != null) {
-        oprot.writeFieldBegin(FAMILIES_FIELD_DESC);
-        {
-          oprot.writeListBegin(new TList(TType.STRING, this.families.size()));
-          for (byte[] _iter101 : this.families)
+          for (byte[] _iter85 : this.rows)
           {
-            oprot.writeBinary(_iter101);
+            oprot.writeBinary(_iter85);
           }
           oprot.writeListEnd();
         }
@@ -20183,7 +20387,7 @@ public class Hbase {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("getRowsWithColumnsTs_args(");
+      StringBuilder sb = new StringBuilder("getRowsTs_args(");
       boolean first = true;
 
       sb.append("tableName:");
@@ -20202,14 +20406,6 @@ public class Hbase {
       }
       first = false;
       if (!first) sb.append(", ");
-      sb.append("families:");
-      if (this.families == null) {
-        sb.append("null");
-      } else {
-        sb.append(this.families);
-      }
-      first = false;
-      if (!first) sb.append(", ");
       sb.append("timestamp:");
       sb.append(this.timestamp);
       first = false;
@@ -20223,8 +20419,8 @@ public class Hbase {
 
   }
 
-  public static class getRowsWithColumnsTs_result implements TBase<getRowsWithColumnsTs_result._Fields>, java.io.Serializable, Cloneable   {
-    private static final TStruct STRUCT_DESC = new TStruct("getRowsWithColumnsTs_result");
+  public static class getRowsTs_result implements TBase<getRowsTs_result._Fields>, java.io.Serializable, Cloneable   {
+    private static final TStruct STRUCT_DESC = new TStruct("getRowsTs_result");
 
     private static final TField SUCCESS_FIELD_DESC = new TField("success", TType.LIST, (short)0);
     private static final TField IO_FIELD_DESC = new TField("io", TType.STRUCT, (short)1);
@@ -20299,13 +20495,13 @@ public class Hbase {
     }});
 
     static {
-      FieldMetaData.addStructMetaDataMap(getRowsWithColumnsTs_result.class, metaDataMap);
+      FieldMetaData.addStructMetaDataMap(getRowsTs_result.class, metaDataMap);
     }
 
-    public getRowsWithColumnsTs_result() {
+    public getRowsTs_result() {
     }
 
-    public getRowsWithColumnsTs_result(
+    public getRowsTs_result(
       List<TRowResult> success,
       IOError io)
     {
@@ -20317,7 +20513,7 @@ public class Hbase {
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public getRowsWithColumnsTs_result(getRowsWithColumnsTs_result other) {
+    public getRowsTs_result(getRowsTs_result other) {
       if (other.isSetSuccess()) {
         List<TRowResult> __this__success = new ArrayList<TRowResult>();
         for (TRowResult other_element : other.success) {
@@ -20330,13 +20526,13 @@ public class Hbase {
       }
     }
 
-    public getRowsWithColumnsTs_result deepCopy() {
-      return new getRowsWithColumnsTs_result(this);
+    public getRowsTs_result deepCopy() {
+      return new getRowsTs_result(this);
     }
 
     @Deprecated
-    public getRowsWithColumnsTs_result clone() {
-      return new getRowsWithColumnsTs_result(this);
+    public getRowsTs_result clone() {
+      return new getRowsTs_result(this);
     }
 
     public int getSuccessSize() {
@@ -20358,7 +20554,7 @@ public class Hbase {
       return this.success;
     }
 
-    public getRowsWithColumnsTs_result setSuccess(List<TRowResult> success) {
+    public getRowsTs_result setSuccess(List<TRowResult> success) {
       this.success = success;
       return this;
     }
@@ -20382,7 +20578,7 @@ public class Hbase {
       return this.io;
     }
 
-    public getRowsWithColumnsTs_result setIo(IOError io) {
+    public getRowsTs_result setIo(IOError io) {
       this.io = io;
       return this;
     }
@@ -20462,12 +20658,12 @@ public class Hbase {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof getRowsWithColumnsTs_result)
-        return this.equals((getRowsWithColumnsTs_result)that);
+      if (that instanceof getRowsTs_result)
+        return this.equals((getRowsTs_result)that);
       return false;
     }
 
-    public boolean equals(getRowsWithColumnsTs_result that) {
+    public boolean equals(getRowsTs_result that) {
       if (that == null)
         return false;
 
@@ -20526,14 +20722,14 @@ public class Hbase {
             case SUCCESS:
               if (field.type == TType.LIST) {
                 {
-                  TList _list102 = iprot.readListBegin();
-                  this.success = new ArrayList<TRowResult>(_list102.size);
-                  for (int _i103 = 0; _i103 < _list102.size; ++_i103)
+                  TList _list86 = iprot.readListBegin();
+                  this.success = new ArrayList<TRowResult>(_list86.size);
+                  for (int _i87 = 0; _i87 < _list86.size; ++_i87)
                   {
-                    TRowResult _elem104;
-                    _elem104 = new TRowResult();
-                    _elem104.read(iprot);
-                    this.success.add(_elem104);
+                    TRowResult _elem88;
+                    _elem88 = new TRowResult();
+                    _elem88.read(iprot);
+                    this.success.add(_elem88);
                   }
                   iprot.readListEnd();
                 }
@@ -20566,9 +20762,9 @@ public class Hbase {
         oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
         {
           oprot.writeListBegin(new TList(TType.STRUCT, this.success.size()));
-          for (TRowResult _iter105 : this.success)
+          for (TRowResult _iter89 : this.success)
           {
-            _iter105.write(oprot);
+            _iter89.write(oprot);
           }
           oprot.writeListEnd();
         }
@@ -20584,7 +20780,7 @@ public class Hbase {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("getRowsWithColumnsTs_result(");
+      StringBuilder sb = new StringBuilder("getRowsTs_result(");
       boolean first = true;
 
       sb.append("success:");
@@ -20612,40 +20808,22 @@ public class Hbase {
 
   }
 
-  public static class mutateRow_args implements TBase<mutateRow_args._Fields>, java.io.Serializable, Cloneable, Comparable<mutateRow_args>   {
-    private static final TStruct STRUCT_DESC = new TStruct("mutateRow_args");
+  public static class getRowsWithColumns_args implements TBase<getRowsWithColumns_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowsWithColumns_args>   {
+    private static final TStruct STRUCT_DESC = new TStruct("getRowsWithColumns_args");
 
     private static final TField TABLE_NAME_FIELD_DESC = new TField("tableName", TType.STRING, (short)1);
-    private static final TField ROW_FIELD_DESC = new TField("row", TType.STRING, (short)2);
-    private static final TField MUTATIONS_FIELD_DESC = new TField("mutations", TType.LIST, (short)3);
+    private static final TField ROWS_FIELD_DESC = new TField("rows", TType.LIST, (short)2);
+    private static final TField FAMILIES_FIELD_DESC = new TField("families", TType.LIST, (short)3);
 
-    /**
-     * name of table
-     */
     public byte[] tableName;
-    /**
-     * row key
-     */
-    public byte[] row;
-    /**
-     * list of mutation commands
-     */
-    public List<Mutation> mutations;
+    public List<byte[]> rows;
+    public List<byte[]> families;
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
     public enum _Fields implements TFieldIdEnum {
-      /**
-       * name of table
-       */
       TABLE_NAME((short)1, "tableName"),
-      /**
-       * row key
-       */
-      ROW((short)2, "row"),
-      /**
-       * list of mutation commands
-       */
-      MUTATIONS((short)3, "mutations");
+      ROWS((short)2, "rows"),
+      FAMILIES((short)3, "families");
 
       private static final Map<Integer, _Fields> byId = new HashMap<Integer, _Fields>();
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -20703,70 +20881,69 @@ public class Hbase {
     public static final Map<_Fields, FieldMetaData> metaDataMap = Collections.unmodifiableMap(new EnumMap<_Fields, FieldMetaData>(_Fields.class) {{
       put(_Fields.TABLE_NAME, new FieldMetaData("tableName", TFieldRequirementType.DEFAULT,
           new FieldValueMetaData(TType.STRING)));
-      put(_Fields.ROW, new FieldMetaData("row", TFieldRequirementType.DEFAULT,
-          new FieldValueMetaData(TType.STRING)));
-      put(_Fields.MUTATIONS, new FieldMetaData("mutations", TFieldRequirementType.DEFAULT,
+      put(_Fields.ROWS, new FieldMetaData("rows", TFieldRequirementType.DEFAULT,
           new ListMetaData(TType.LIST,
-              new StructMetaData(TType.STRUCT, Mutation.class))));
+              new FieldValueMetaData(TType.STRING))));

[... 19634 lines stripped ...]