public static class Hbase.Client extends org.apache.thrift.TServiceClient implements Hbase.Iface
| Modifier and Type | Class and Description | 
|---|---|
static class  | 
Hbase.Client.Factory  | 
| Constructor and Description | 
|---|
Client(org.apache.thrift.protocol.TProtocol prot)  | 
Client(org.apache.thrift.protocol.TProtocol iprot,
      org.apache.thrift.protocol.TProtocol oprot)  | 
| Modifier and Type | Method and Description | 
|---|---|
List<TCell> | 
append(TAppend append)
Appends values to one or more columns within a single row. 
 | 
long | 
atomicIncrement(ByteBuffer tableName,
               ByteBuffer row,
               ByteBuffer column,
               long value)
Atomically increment the column value specified. 
 | 
boolean | 
checkAndPut(ByteBuffer tableName,
           ByteBuffer row,
           ByteBuffer column,
           ByteBuffer value,
           Mutation mput,
           Map<ByteBuffer,ByteBuffer> attributes)
Atomically checks if a row/family/qualifier value matches the expected
 value. 
 | 
void | 
compact(ByteBuffer tableNameOrRegionName)  | 
void | 
createTable(ByteBuffer tableName,
           List<ColumnDescriptor> columnFamilies)
Create a table with the specified column families. 
 | 
void | 
deleteAll(ByteBuffer tableName,
         ByteBuffer row,
         ByteBuffer column,
         Map<ByteBuffer,ByteBuffer> attributes)
Delete all cells that match the passed row and column. 
 | 
void | 
deleteAllRow(ByteBuffer tableName,
            ByteBuffer row,
            Map<ByteBuffer,ByteBuffer> attributes)
Completely delete the row's cells. 
 | 
void | 
deleteAllRowTs(ByteBuffer tableName,
              ByteBuffer row,
              long timestamp,
              Map<ByteBuffer,ByteBuffer> attributes)
Completely delete the row's cells marked with a timestamp
 equal-to or older than the passed timestamp. 
 | 
void | 
deleteAllTs(ByteBuffer tableName,
           ByteBuffer row,
           ByteBuffer column,
           long timestamp,
           Map<ByteBuffer,ByteBuffer> attributes)
Delete all cells that match the passed row and column and whose
 timestamp is equal-to or older than the passed timestamp. 
 | 
void | 
deleteTable(ByteBuffer tableName)
Deletes a table 
 | 
void | 
disableTable(ByteBuffer tableName)
Disables a table (takes it off-line) If it is being served, the master
 will tell the servers to stop serving it. 
 | 
void | 
enableTable(ByteBuffer tableName)
Brings a table on-line (enables it) 
 | 
List<TCell> | 
get(ByteBuffer tableName,
   ByteBuffer row,
   ByteBuffer column,
   Map<ByteBuffer,ByteBuffer> attributes)
Get a single TCell for the specified table, row, and column at the
 latest timestamp. 
 | 
Map<ByteBuffer,ColumnDescriptor> | 
getColumnDescriptors(ByteBuffer tableName)
List all the column families assoicated with a table. 
 | 
TRegionInfo | 
getRegionInfo(ByteBuffer row)
Get the regininfo for the specified row. 
 | 
List<TRowResult> | 
getRow(ByteBuffer tableName,
      ByteBuffer row,
      Map<ByteBuffer,ByteBuffer> attributes)
Get all the data for the specified table and row at the latest
 timestamp. 
 | 
List<TCell> | 
getRowOrBefore(ByteBuffer tableName,
              ByteBuffer row,
              ByteBuffer family)
Get the row just before the specified one. 
 | 
List<TRowResult> | 
getRows(ByteBuffer tableName,
       List<ByteBuffer> rows,
       Map<ByteBuffer,ByteBuffer> attributes)
Get all the data for the specified table and rows at the latest
 timestamp. 
 | 
List<TRowResult> | 
getRowsTs(ByteBuffer tableName,
         List<ByteBuffer> rows,
         long timestamp,
         Map<ByteBuffer,ByteBuffer> attributes)
Get all the data for the specified table and rows at the specified
 timestamp. 
 | 
List<TRowResult> | 
getRowsWithColumns(ByteBuffer tableName,
                  List<ByteBuffer> rows,
                  List<ByteBuffer> columns,
                  Map<ByteBuffer,ByteBuffer> attributes)
Get the specified columns for the specified table and rows at the latest
 timestamp. 
 | 
List<TRowResult> | 
getRowsWithColumnsTs(ByteBuffer tableName,
                    List<ByteBuffer> rows,
                    List<ByteBuffer> columns,
                    long timestamp,
                    Map<ByteBuffer,ByteBuffer> attributes)
Get the specified columns for the specified table and rows at the specified
 timestamp. 
 | 
List<TRowResult> | 
getRowTs(ByteBuffer tableName,
        ByteBuffer row,
        long timestamp,
        Map<ByteBuffer,ByteBuffer> attributes)
Get all the data for the specified table and row at the specified
 timestamp. 
 | 
List<TRowResult> | 
getRowWithColumns(ByteBuffer tableName,
                 ByteBuffer row,
                 List<ByteBuffer> columns,
                 Map<ByteBuffer,ByteBuffer> attributes)
Get the specified columns for the specified table and row at the latest
 timestamp. 
 | 
List<TRowResult> | 
getRowWithColumnsTs(ByteBuffer tableName,
                   ByteBuffer row,
                   List<ByteBuffer> columns,
                   long timestamp,
                   Map<ByteBuffer,ByteBuffer> attributes)
Get the specified columns for the specified table and row at the specified
 timestamp. 
 | 
List<ByteBuffer> | 
getTableNames()
List all the userspace tables. 
 | 
List<TRegionInfo> | 
getTableRegions(ByteBuffer tableName)
List the regions associated with a table. 
 | 
List<TCell> | 
getVer(ByteBuffer tableName,
      ByteBuffer row,
      ByteBuffer column,
      int numVersions,
      Map<ByteBuffer,ByteBuffer> attributes)
Get the specified number of versions for the specified table,
 row, and column. 
 | 
List<TCell> | 
getVerTs(ByteBuffer tableName,
        ByteBuffer row,
        ByteBuffer column,
        long timestamp,
        int numVersions,
        Map<ByteBuffer,ByteBuffer> attributes)
Get the specified number of versions for the specified table,
 row, and column. 
 | 
void | 
increment(TIncrement increment)
Increment a cell by the ammount. 
 | 
void | 
incrementRows(List<TIncrement> increments)  | 
boolean | 
isTableEnabled(ByteBuffer tableName)  | 
void | 
majorCompact(ByteBuffer tableNameOrRegionName)  | 
void | 
mutateRow(ByteBuffer tableName,
         ByteBuffer row,
         List<Mutation> mutations,
         Map<ByteBuffer,ByteBuffer> attributes)
Apply a series of mutations (updates/deletes) to a row in a
 single transaction. 
 | 
void | 
mutateRows(ByteBuffer tableName,
          List<BatchMutation> rowBatches,
          Map<ByteBuffer,ByteBuffer> attributes)
Apply a series of batches (each a series of mutations on a single row)
 in a single transaction. 
 | 
void | 
mutateRowsTs(ByteBuffer tableName,
            List<BatchMutation> rowBatches,
            long timestamp,
            Map<ByteBuffer,ByteBuffer> attributes)
Apply a series of batches (each a series of mutations on a single row)
 in a single transaction. 
 | 
void | 
mutateRowTs(ByteBuffer tableName,
           ByteBuffer row,
           List<Mutation> mutations,
           long timestamp,
           Map<ByteBuffer,ByteBuffer> attributes)
Apply a series of mutations (updates/deletes) to a row in a
 single transaction. 
 | 
List<TCell> | 
recv_append()  | 
long | 
recv_atomicIncrement()  | 
boolean | 
recv_checkAndPut()  | 
void | 
recv_compact()  | 
void | 
recv_createTable()  | 
void | 
recv_deleteAll()  | 
void | 
recv_deleteAllRow()  | 
void | 
recv_deleteAllRowTs()  | 
void | 
recv_deleteAllTs()  | 
void | 
recv_deleteTable()  | 
void | 
recv_disableTable()  | 
void | 
recv_enableTable()  | 
List<TCell> | 
recv_get()  | 
Map<ByteBuffer,ColumnDescriptor> | 
recv_getColumnDescriptors()  | 
TRegionInfo | 
recv_getRegionInfo()  | 
List<TRowResult> | 
recv_getRow()  | 
List<TCell> | 
recv_getRowOrBefore()  | 
List<TRowResult> | 
recv_getRows()  | 
List<TRowResult> | 
recv_getRowsTs()  | 
List<TRowResult> | 
recv_getRowsWithColumns()  | 
List<TRowResult> | 
recv_getRowsWithColumnsTs()  | 
List<TRowResult> | 
recv_getRowTs()  | 
List<TRowResult> | 
recv_getRowWithColumns()  | 
List<TRowResult> | 
recv_getRowWithColumnsTs()  | 
List<ByteBuffer> | 
recv_getTableNames()  | 
List<TRegionInfo> | 
recv_getTableRegions()  | 
List<TCell> | 
recv_getVer()  | 
List<TCell> | 
recv_getVerTs()  | 
void | 
recv_increment()  | 
void | 
recv_incrementRows()  | 
boolean | 
recv_isTableEnabled()  | 
void | 
recv_majorCompact()  | 
void | 
recv_mutateRow()  | 
void | 
recv_mutateRows()  | 
void | 
recv_mutateRowsTs()  | 
void | 
recv_mutateRowTs()  | 
void | 
recv_scannerClose()  | 
List<TRowResult> | 
recv_scannerGet()  | 
List<TRowResult> | 
recv_scannerGetList()  | 
int | 
recv_scannerOpen()  | 
int | 
recv_scannerOpenTs()  | 
int | 
recv_scannerOpenWithPrefix()  | 
int | 
recv_scannerOpenWithScan()  | 
int | 
recv_scannerOpenWithStop()  | 
int | 
recv_scannerOpenWithStopTs()  | 
void | 
scannerClose(int id)
Closes the server-state associated with an open scanner. 
 | 
List<TRowResult> | 
scannerGet(int id)
Returns the scanner's current row value and advances to the next
 row in the table. 
 | 
List<TRowResult> | 
scannerGetList(int id,
              int nbRows)
Returns, starting at the scanner's current row value nbRows worth of
 rows and advances to the next row in the table. 
 | 
int | 
scannerOpen(ByteBuffer tableName,
           ByteBuffer startRow,
           List<ByteBuffer> columns,
           Map<ByteBuffer,ByteBuffer> attributes)
Get a scanner on the current table starting at the specified row and
 ending at the last row in the table. 
 | 
int | 
scannerOpenTs(ByteBuffer tableName,
             ByteBuffer startRow,
             List<ByteBuffer> columns,
             long timestamp,
             Map<ByteBuffer,ByteBuffer> attributes)
Get a scanner on the current table starting at the specified row and
 ending at the last row in the table. 
 | 
int | 
scannerOpenWithPrefix(ByteBuffer tableName,
                     ByteBuffer startAndPrefix,
                     List<ByteBuffer> columns,
                     Map<ByteBuffer,ByteBuffer> attributes)
Open a scanner for a given prefix. 
 | 
int | 
scannerOpenWithScan(ByteBuffer tableName,
                   TScan scan,
                   Map<ByteBuffer,ByteBuffer> attributes)
Get a scanner on the current table, using the Scan instance
 for the scan parameters. 
 | 
int | 
scannerOpenWithStop(ByteBuffer tableName,
                   ByteBuffer startRow,
                   ByteBuffer stopRow,
                   List<ByteBuffer> columns,
                   Map<ByteBuffer,ByteBuffer> attributes)
Get a scanner on the current table starting and stopping at the
 specified rows. 
 | 
int | 
scannerOpenWithStopTs(ByteBuffer tableName,
                     ByteBuffer startRow,
                     ByteBuffer stopRow,
                     List<ByteBuffer> columns,
                     long timestamp,
                     Map<ByteBuffer,ByteBuffer> attributes)
Get a scanner on the current table starting and stopping at the
 specified rows. 
 | 
void | 
send_append(TAppend append)  | 
void | 
send_atomicIncrement(ByteBuffer tableName,
                    ByteBuffer row,
                    ByteBuffer column,
                    long value)  | 
void | 
send_checkAndPut(ByteBuffer tableName,
                ByteBuffer row,
                ByteBuffer column,
                ByteBuffer value,
                Mutation mput,
                Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_compact(ByteBuffer tableNameOrRegionName)  | 
void | 
send_createTable(ByteBuffer tableName,
                List<ColumnDescriptor> columnFamilies)  | 
void | 
send_deleteAll(ByteBuffer tableName,
              ByteBuffer row,
              ByteBuffer column,
              Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_deleteAllRow(ByteBuffer tableName,
                 ByteBuffer row,
                 Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_deleteAllRowTs(ByteBuffer tableName,
                   ByteBuffer row,
                   long timestamp,
                   Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_deleteAllTs(ByteBuffer tableName,
                ByteBuffer row,
                ByteBuffer column,
                long timestamp,
                Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_deleteTable(ByteBuffer tableName)  | 
void | 
send_disableTable(ByteBuffer tableName)  | 
void | 
send_enableTable(ByteBuffer tableName)  | 
void | 
send_get(ByteBuffer tableName,
        ByteBuffer row,
        ByteBuffer column,
        Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_getColumnDescriptors(ByteBuffer tableName)  | 
void | 
send_getRegionInfo(ByteBuffer row)  | 
void | 
send_getRow(ByteBuffer tableName,
           ByteBuffer row,
           Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_getRowOrBefore(ByteBuffer tableName,
                   ByteBuffer row,
                   ByteBuffer family)  | 
void | 
send_getRows(ByteBuffer tableName,
            List<ByteBuffer> rows,
            Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_getRowsTs(ByteBuffer tableName,
              List<ByteBuffer> rows,
              long timestamp,
              Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_getRowsWithColumns(ByteBuffer tableName,
                       List<ByteBuffer> rows,
                       List<ByteBuffer> columns,
                       Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_getRowsWithColumnsTs(ByteBuffer tableName,
                         List<ByteBuffer> rows,
                         List<ByteBuffer> columns,
                         long timestamp,
                         Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_getRowTs(ByteBuffer tableName,
             ByteBuffer row,
             long timestamp,
             Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_getRowWithColumns(ByteBuffer tableName,
                      ByteBuffer row,
                      List<ByteBuffer> columns,
                      Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_getRowWithColumnsTs(ByteBuffer tableName,
                        ByteBuffer row,
                        List<ByteBuffer> columns,
                        long timestamp,
                        Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_getTableNames()  | 
void | 
send_getTableRegions(ByteBuffer tableName)  | 
void | 
send_getVer(ByteBuffer tableName,
           ByteBuffer row,
           ByteBuffer column,
           int numVersions,
           Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_getVerTs(ByteBuffer tableName,
             ByteBuffer row,
             ByteBuffer column,
             long timestamp,
             int numVersions,
             Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_increment(TIncrement increment)  | 
void | 
send_incrementRows(List<TIncrement> increments)  | 
void | 
send_isTableEnabled(ByteBuffer tableName)  | 
void | 
send_majorCompact(ByteBuffer tableNameOrRegionName)  | 
void | 
send_mutateRow(ByteBuffer tableName,
              ByteBuffer row,
              List<Mutation> mutations,
              Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_mutateRows(ByteBuffer tableName,
               List<BatchMutation> rowBatches,
               Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_mutateRowsTs(ByteBuffer tableName,
                 List<BatchMutation> rowBatches,
                 long timestamp,
                 Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_mutateRowTs(ByteBuffer tableName,
                ByteBuffer row,
                List<Mutation> mutations,
                long timestamp,
                Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_scannerClose(int id)  | 
void | 
send_scannerGet(int id)  | 
void | 
send_scannerGetList(int id,
                   int nbRows)  | 
void | 
send_scannerOpen(ByteBuffer tableName,
                ByteBuffer startRow,
                List<ByteBuffer> columns,
                Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_scannerOpenTs(ByteBuffer tableName,
                  ByteBuffer startRow,
                  List<ByteBuffer> columns,
                  long timestamp,
                  Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_scannerOpenWithPrefix(ByteBuffer tableName,
                          ByteBuffer startAndPrefix,
                          List<ByteBuffer> columns,
                          Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_scannerOpenWithScan(ByteBuffer tableName,
                        TScan scan,
                        Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_scannerOpenWithStop(ByteBuffer tableName,
                        ByteBuffer startRow,
                        ByteBuffer stopRow,
                        List<ByteBuffer> columns,
                        Map<ByteBuffer,ByteBuffer> attributes)  | 
void | 
send_scannerOpenWithStopTs(ByteBuffer tableName,
                          ByteBuffer startRow,
                          ByteBuffer stopRow,
                          List<ByteBuffer> columns,
                          long timestamp,
                          Map<ByteBuffer,ByteBuffer> attributes)  | 
public Client(org.apache.thrift.protocol.TProtocol prot)
public Client(org.apache.thrift.protocol.TProtocol iprot,
              org.apache.thrift.protocol.TProtocol oprot)
public void enableTable(ByteBuffer tableName) throws IOError, org.apache.thrift.TException
Hbase.IfaceenableTable in interface Hbase.IfacetableName - name of the tableIOErrororg.apache.thrift.TExceptionpublic void send_enableTable(ByteBuffer tableName) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_enableTable()
                      throws IOError,
                             org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void disableTable(ByteBuffer tableName) throws IOError, org.apache.thrift.TException
Hbase.IfacedisableTable in interface Hbase.IfacetableName - name of the tableIOErrororg.apache.thrift.TExceptionpublic void send_disableTable(ByteBuffer tableName) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_disableTable()
                       throws IOError,
                              org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic boolean isTableEnabled(ByteBuffer tableName) throws IOError, org.apache.thrift.TException
isTableEnabled in interface Hbase.IfacetableName - name of the table to checkIOErrororg.apache.thrift.TExceptionpublic void send_isTableEnabled(ByteBuffer tableName) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic boolean recv_isTableEnabled()
                            throws IOError,
                                   org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void compact(ByteBuffer tableNameOrRegionName) throws IOError, org.apache.thrift.TException
compact in interface Hbase.IfaceIOErrororg.apache.thrift.TExceptionpublic void send_compact(ByteBuffer tableNameOrRegionName) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_compact()
                  throws IOError,
                         org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void majorCompact(ByteBuffer tableNameOrRegionName) throws IOError, org.apache.thrift.TException
majorCompact in interface Hbase.IfaceIOErrororg.apache.thrift.TExceptionpublic void send_majorCompact(ByteBuffer tableNameOrRegionName) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_majorCompact()
                       throws IOError,
                              org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<ByteBuffer> getTableNames() throws IOError, org.apache.thrift.TException
Hbase.IfacegetTableNames in interface Hbase.IfaceIOErrororg.apache.thrift.TExceptionpublic void send_getTableNames()
                        throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<ByteBuffer> recv_getTableNames() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic Map<ByteBuffer,ColumnDescriptor> getColumnDescriptors(ByteBuffer tableName) throws IOError, org.apache.thrift.TException
Hbase.IfacegetColumnDescriptors in interface Hbase.IfacetableName - table nameIOErrororg.apache.thrift.TExceptionpublic void send_getColumnDescriptors(ByteBuffer tableName) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic Map<ByteBuffer,ColumnDescriptor> recv_getColumnDescriptors() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TRegionInfo> getTableRegions(ByteBuffer tableName) throws IOError, org.apache.thrift.TException
Hbase.IfacegetTableRegions in interface Hbase.IfacetableName - table nameIOErrororg.apache.thrift.TExceptionpublic void send_getTableRegions(ByteBuffer tableName) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TRegionInfo> recv_getTableRegions() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void createTable(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies) throws IOError, IllegalArgument, AlreadyExists, org.apache.thrift.TException
Hbase.IfacecreateTable in interface Hbase.IfacetableName - name of table to createcolumnFamilies - list of column family descriptorsIllegalArgument - if an input parameter is invalidAlreadyExists - if the table name already existsIOErrororg.apache.thrift.TExceptionpublic void send_createTable(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_createTable()
                      throws IOError,
                             IllegalArgument,
                             AlreadyExists,
                             org.apache.thrift.TException
IOErrorIllegalArgumentAlreadyExistsorg.apache.thrift.TExceptionpublic void deleteTable(ByteBuffer tableName) throws IOError, org.apache.thrift.TException
Hbase.IfacedeleteTable in interface Hbase.IfacetableName - name of table to deleteIOError - if table doesn't exist on server or there was some other
 problemorg.apache.thrift.TExceptionpublic void send_deleteTable(ByteBuffer tableName) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_deleteTable()
                      throws IOError,
                             org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TCell> get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.Ifaceget in interface Hbase.IfacetableName - name of tablerow - row keycolumn - column nameattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TCell> recv_get() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TCell> getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetVer in interface Hbase.IfacetableName - name of tablerow - row keycolumn - column namenumVersions - number of versions to retrieveattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TCell> recv_getVer() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TCell> getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetVerTs in interface Hbase.IfacetableName - name of tablerow - row keycolumn - column nametimestamp - timestampnumVersions - number of versions to retrieveattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TCell> recv_getVerTs() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TRowResult> getRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRow in interface Hbase.IfacetableName - name of tablerow - row keyattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TRowResult> recv_getRow() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TRowResult> getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowWithColumns in interface Hbase.IfacetableName - name of tablerow - row keycolumns - List of columns to return, null for all columnsattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TRowResult> recv_getRowWithColumns() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TRowResult> getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowTs in interface Hbase.IfacetableName - name of the tablerow - row keytimestamp - timestampattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TRowResult> recv_getRowTs() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TRowResult> getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowWithColumnsTs in interface Hbase.IfacetableName - name of tablerow - row keycolumns - List of columns to return, null for all columnsattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TRowResult> recv_getRowWithColumnsTs() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TRowResult> getRows(ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRows in interface Hbase.IfacetableName - name of tablerows - row keysattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRows(ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TRowResult> recv_getRows() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TRowResult> getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowsWithColumns in interface Hbase.IfacetableName - name of tablerows - row keyscolumns - List of columns to return, null for all columnsattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TRowResult> recv_getRowsWithColumns() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TRowResult> getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowsTs in interface Hbase.IfacetableName - name of the tablerows - row keystimestamp - timestampattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TRowResult> recv_getRowsTs() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TRowResult> getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowsWithColumnsTs in interface Hbase.IfacetableName - name of tablerows - row keyscolumns - List of columns to return, null for all columnsattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TRowResult> recv_getRowsWithColumnsTs() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException
Hbase.IfacemutateRow in interface Hbase.IfacetableName - name of tablerow - row keymutations - list of mutation commandsattributes - Mutation attributesIOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void send_mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_mutateRow()
                    throws IOError,
                           IllegalArgument,
                           org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException
Hbase.IfacemutateRowTs in interface Hbase.IfacetableName - name of tablerow - row keymutations - list of mutation commandstimestamp - timestampattributes - Mutation attributesIOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void send_mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_mutateRowTs()
                      throws IOError,
                             IllegalArgument,
                             org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException
Hbase.IfacemutateRows in interface Hbase.IfacetableName - name of tablerowBatches - list of row batchesattributes - Mutation attributesIOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void send_mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_mutateRows()
                     throws IOError,
                            IllegalArgument,
                            org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException
Hbase.IfacemutateRowsTs in interface Hbase.IfacetableName - name of tablerowBatches - list of row batchestimestamp - timestampattributes - Mutation attributesIOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void send_mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_mutateRowsTs()
                       throws IOError,
                              IllegalArgument,
                              org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic long atomicIncrement(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value) throws IOError, IllegalArgument, org.apache.thrift.TException
Hbase.IfaceatomicIncrement in interface Hbase.IfacetableName - name of tablerow - row to incrementcolumn - name of columnvalue - amount to increment byIOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void send_atomicIncrement(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic long recv_atomicIncrement()
                          throws IOError,
                                 IllegalArgument,
                                 org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacedeleteAll in interface Hbase.IfacetableName - name of tablerow - Row to updatecolumn - name of column whose value is to be deletedattributes - Delete attributesIOErrororg.apache.thrift.TExceptionpublic void send_deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_deleteAll()
                    throws IOError,
                           org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacedeleteAllTs in interface Hbase.IfacetableName - name of tablerow - Row to updatecolumn - name of column whose value is to be deletedtimestamp - timestampattributes - Delete attributesIOErrororg.apache.thrift.TExceptionpublic void send_deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_deleteAllTs()
                      throws IOError,
                             org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacedeleteAllRow in interface Hbase.IfacetableName - name of tablerow - key of the row to be completely deleted.attributes - Delete attributesIOErrororg.apache.thrift.TExceptionpublic void send_deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_deleteAllRow()
                       throws IOError,
                              org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void increment(TIncrement increment) throws IOError, org.apache.thrift.TException
Hbase.Ifaceincrement in interface Hbase.Ifaceincrement - The single increment to applyIOErrororg.apache.thrift.TExceptionpublic void send_increment(TIncrement increment) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_increment()
                    throws IOError,
                           org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void incrementRows(List<TIncrement> increments) throws IOError, org.apache.thrift.TException
incrementRows in interface Hbase.IfaceIOErrororg.apache.thrift.TExceptionpublic void send_incrementRows(List<TIncrement> increments) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_incrementRows()
                        throws IOError,
                               org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacedeleteAllRowTs in interface Hbase.IfacetableName - name of tablerow - key of the row to be completely deleted.timestamp - timestampattributes - Delete attributesIOErrororg.apache.thrift.TExceptionpublic void send_deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_deleteAllRowTs()
                         throws IOError,
                                org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic int scannerOpenWithScan(ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacescannerOpenWithScan in interface Hbase.IfacetableName - name of tablescan - Scan instanceattributes - Scan attributesIOErrororg.apache.thrift.TExceptionpublic void send_scannerOpenWithScan(ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic int recv_scannerOpenWithScan()
                             throws IOError,
                                    org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic int scannerOpen(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacescannerOpen in interface Hbase.IfacetableName - name of tablestartRow - Starting row in table to scan.
 Send "" (empty string) to start at the first row.columns - columns to scan. If column name is a column family, all
 columns of the specified column family are returned. It's also possible
 to pass a regex in the column qualifier.attributes - Scan attributesIOErrororg.apache.thrift.TExceptionpublic void send_scannerOpen(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic int recv_scannerOpen()
                     throws IOError,
                            org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic int scannerOpenWithStop(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacescannerOpenWithStop in interface Hbase.IfacetableName - name of tablestartRow - Starting row in table to scan.
 Send "" (empty string) to start at the first row.stopRow - row to stop scanning on. This row is *not* included in the
 scanner's resultscolumns - columns to scan. If column name is a column family, all
 columns of the specified column family are returned. It's also possible
 to pass a regex in the column qualifier.attributes - Scan attributesIOErrororg.apache.thrift.TExceptionpublic void send_scannerOpenWithStop(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic int recv_scannerOpenWithStop()
                             throws IOError,
                                    org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic int scannerOpenWithPrefix(ByteBuffer tableName, ByteBuffer startAndPrefix, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacescannerOpenWithPrefix in interface Hbase.IfacetableName - name of tablestartAndPrefix - the prefix (and thus start row) of the keys you wantcolumns - the columns you want returnedattributes - Scan attributesIOErrororg.apache.thrift.TExceptionpublic void send_scannerOpenWithPrefix(ByteBuffer tableName, ByteBuffer startAndPrefix, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic int recv_scannerOpenWithPrefix()
                               throws IOError,
                                      org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic int scannerOpenTs(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacescannerOpenTs in interface Hbase.IfacetableName - name of tablestartRow - Starting row in table to scan.
 Send "" (empty string) to start at the first row.columns - columns to scan. If column name is a column family, all
 columns of the specified column family are returned. It's also possible
 to pass a regex in the column qualifier.timestamp - timestampattributes - Scan attributesIOErrororg.apache.thrift.TExceptionpublic void send_scannerOpenTs(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic int recv_scannerOpenTs()
                       throws IOError,
                              org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic int scannerOpenWithStopTs(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacescannerOpenWithStopTs in interface Hbase.IfacetableName - name of tablestartRow - Starting row in table to scan.
 Send "" (empty string) to start at the first row.stopRow - row to stop scanning on. This row is *not* included in the
 scanner's resultscolumns - columns to scan. If column name is a column family, all
 columns of the specified column family are returned. It's also possible
 to pass a regex in the column qualifier.timestamp - timestampattributes - Scan attributesIOErrororg.apache.thrift.TExceptionpublic void send_scannerOpenWithStopTs(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic int recv_scannerOpenWithStopTs()
                               throws IOError,
                                      org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TRowResult> scannerGet(int id) throws IOError, IllegalArgument, org.apache.thrift.TException
Hbase.IfacescannerGet in interface Hbase.Ifaceid - id of a scanner returned by scannerOpenIllegalArgument - if ScannerID is invalidIOErrororg.apache.thrift.TExceptionpublic void send_scannerGet(int id)
                     throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TRowResult> recv_scannerGet() throws IOError, IllegalArgument, org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic List<TRowResult> scannerGetList(int id, int nbRows) throws IOError, IllegalArgument, org.apache.thrift.TException
Hbase.IfacescannerGetList in interface Hbase.Ifaceid - id of a scanner returned by scannerOpennbRows - number of results to returnIllegalArgument - if ScannerID is invalidIOErrororg.apache.thrift.TExceptionpublic void send_scannerGetList(int id,
                                int nbRows)
                         throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TRowResult> recv_scannerGetList() throws IOError, IllegalArgument, org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void scannerClose(int id)
                  throws IOError,
                         IllegalArgument,
                         org.apache.thrift.TException
Hbase.IfacescannerClose in interface Hbase.Ifaceid - id of a scanner returned by scannerOpenIllegalArgument - if ScannerID is invalidIOErrororg.apache.thrift.TExceptionpublic void send_scannerClose(int id)
                       throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_scannerClose()
                       throws IOError,
                              IllegalArgument,
                              org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic List<TCell> getRowOrBefore(ByteBuffer tableName, ByteBuffer row, ByteBuffer family) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowOrBefore in interface Hbase.IfacetableName - name of tablerow - row keyfamily - column nameIOErrororg.apache.thrift.TExceptionpublic void send_getRowOrBefore(ByteBuffer tableName, ByteBuffer row, ByteBuffer family) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TCell> recv_getRowOrBefore() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic TRegionInfo getRegionInfo(ByteBuffer row) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRegionInfo in interface Hbase.Ifacerow - row keyIOErrororg.apache.thrift.TExceptionpublic void send_getRegionInfo(ByteBuffer row) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic TRegionInfo recv_getRegionInfo() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic List<TCell> append(TAppend append) throws IOError, org.apache.thrift.TException
Hbase.Ifaceappend in interface Hbase.Ifaceappend - The single append operation to applyIOErrororg.apache.thrift.TExceptionpublic void send_append(TAppend append) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic List<TCell> recv_append() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic boolean checkAndPut(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer value, Mutation mput, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException
Hbase.IfacecheckAndPut in interface Hbase.IfacetableName - name of tablerow - row keycolumn - column namevalue - the expected value for the column parameter, if not
 provided the check is for the non-existence of the
 column in questionmput - mutation for the putattributes - Mutation attributesIOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void send_checkAndPut(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer value, Mutation mput, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic boolean recv_checkAndPut()
                         throws IOError,
                                IllegalArgument,
                                org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TException