| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.thrift | Provides an HBase Thrift
service. | 
| org.apache.hadoop.hbase.thrift.generated | 
| Modifier and Type | Method and Description | 
|---|---|
| List<TCell> | ThriftServerRunner.HBaseHandler. append(TAppend tappend) | 
| protected long | ThriftServerRunner.HBaseHandler. atomicIncrement(ByteBuffer tableName,
               ByteBuffer row,
               byte[] family,
               byte[] qualifier,
               long amount) | 
| long | ThriftServerRunner.HBaseHandler. atomicIncrement(ByteBuffer tableName,
               ByteBuffer row,
               ByteBuffer column,
               long amount)Deprecated.  | 
| boolean | ThriftServerRunner.HBaseHandler. checkAndPut(ByteBuffer tableName,
           ByteBuffer row,
           ByteBuffer column,
           ByteBuffer value,
           Mutation mput,
           Map<ByteBuffer,ByteBuffer> attributes) | 
| void | ThriftServerRunner.HBaseHandler. compact(ByteBuffer tableNameOrRegionName) | 
| void | ThriftServerRunner.HBaseHandler. createTable(ByteBuffer in_tableName,
           List<ColumnDescriptor> columnFamilies) | 
| void | ThriftServerRunner.HBaseHandler. deleteAll(ByteBuffer tableName,
         ByteBuffer row,
         ByteBuffer column,
         Map<ByteBuffer,ByteBuffer> attributes) | 
| void | ThriftServerRunner.HBaseHandler. deleteAllRow(ByteBuffer tableName,
            ByteBuffer row,
            Map<ByteBuffer,ByteBuffer> attributes) | 
| void | ThriftServerRunner.HBaseHandler. deleteAllRowTs(ByteBuffer tableName,
              ByteBuffer row,
              long timestamp,
              Map<ByteBuffer,ByteBuffer> attributes) | 
| void | ThriftServerRunner.HBaseHandler. deleteAllTs(ByteBuffer tableName,
           ByteBuffer row,
           ByteBuffer column,
           long timestamp,
           Map<ByteBuffer,ByteBuffer> attributes) | 
| void | ThriftServerRunner.HBaseHandler. deleteTable(ByteBuffer in_tableName) | 
| void | ThriftServerRunner.HBaseHandler. disableTable(ByteBuffer tableName) | 
| void | ThriftServerRunner.HBaseHandler. enableTable(ByteBuffer tableName) | 
| protected List<TCell> | ThriftServerRunner.HBaseHandler. get(ByteBuffer tableName,
   ByteBuffer row,
   byte[] family,
   byte[] qualifier,
   Map<ByteBuffer,ByteBuffer> attributes)Note: this internal interface is slightly different from public APIs in regard to handling
 of the qualifier. | 
| List<TCell> | ThriftServerRunner.HBaseHandler. get(ByteBuffer tableName,
   ByteBuffer row,
   ByteBuffer column,
   Map<ByteBuffer,ByteBuffer> attributes)Deprecated.  | 
| Map<ByteBuffer,ColumnDescriptor> | ThriftServerRunner.HBaseHandler. getColumnDescriptors(ByteBuffer tableName) | 
| TRegionInfo | ThriftServerRunner.HBaseHandler. getRegionInfo(ByteBuffer searchRow) | 
| List<TRowResult> | ThriftServerRunner.HBaseHandler. getRow(ByteBuffer tableName,
      ByteBuffer row,
      Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TCell> | ThriftServerRunner.HBaseHandler. getRowOrBefore(ByteBuffer tableName,
              ByteBuffer row,
              ByteBuffer family)Deprecated.  | 
| List<TRowResult> | ThriftServerRunner.HBaseHandler. getRows(ByteBuffer tableName,
       List<ByteBuffer> rows,
       Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TRowResult> | ThriftServerRunner.HBaseHandler. getRowsTs(ByteBuffer tableName,
         List<ByteBuffer> rows,
         long timestamp,
         Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TRowResult> | ThriftServerRunner.HBaseHandler. getRowsWithColumns(ByteBuffer tableName,
                  List<ByteBuffer> rows,
                  List<ByteBuffer> columns,
                  Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TRowResult> | ThriftServerRunner.HBaseHandler. getRowsWithColumnsTs(ByteBuffer tableName,
                    List<ByteBuffer> rows,
                    List<ByteBuffer> columns,
                    long timestamp,
                    Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TRowResult> | ThriftServerRunner.HBaseHandler. getRowTs(ByteBuffer tableName,
        ByteBuffer row,
        long timestamp,
        Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TRowResult> | ThriftServerRunner.HBaseHandler. getRowWithColumns(ByteBuffer tableName,
                 ByteBuffer row,
                 List<ByteBuffer> columns,
                 Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TRowResult> | ThriftServerRunner.HBaseHandler. getRowWithColumnsTs(ByteBuffer tableName,
                   ByteBuffer row,
                   List<ByteBuffer> columns,
                   long timestamp,
                   Map<ByteBuffer,ByteBuffer> attributes) | 
| List<ByteBuffer> | ThriftServerRunner.HBaseHandler. getTableNames() | 
| List<TRegionInfo> | ThriftServerRunner.HBaseHandler. getTableRegions(ByteBuffer tableName) | 
| List<TCell> | ThriftServerRunner.HBaseHandler. getVer(ByteBuffer tableName,
      ByteBuffer row,
      byte[] family,
      byte[] qualifier,
      int numVersions,
      Map<ByteBuffer,ByteBuffer> attributes)Note: this public interface is slightly different from public Java APIs in regard to
 handling of the qualifier. | 
| List<TCell> | ThriftServerRunner.HBaseHandler. getVer(ByteBuffer tableName,
      ByteBuffer row,
      ByteBuffer column,
      int numVersions,
      Map<ByteBuffer,ByteBuffer> attributes)Deprecated.  | 
| protected List<TCell> | ThriftServerRunner.HBaseHandler. getVerTs(ByteBuffer tableName,
        ByteBuffer row,
        byte[] family,
        byte[] qualifier,
        long timestamp,
        int numVersions,
        Map<ByteBuffer,ByteBuffer> attributes)Note: this internal interface is slightly different from public APIs in regard to handling
 of the qualifier. | 
| List<TCell> | ThriftServerRunner.HBaseHandler. getVerTs(ByteBuffer tableName,
        ByteBuffer row,
        ByteBuffer column,
        long timestamp,
        int numVersions,
        Map<ByteBuffer,ByteBuffer> attributes)Deprecated.  | 
| void | ThriftServerRunner.HBaseHandler. increment(TIncrement tincrement) | 
| void | ThriftServerRunner.HBaseHandler. incrementRows(List<TIncrement> tincrements) | 
| boolean | ThriftServerRunner.HBaseHandler. isTableEnabled(ByteBuffer tableName) | 
| void | ThriftServerRunner.HBaseHandler. majorCompact(ByteBuffer tableNameOrRegionName) | 
| void | ThriftServerRunner.HBaseHandler. mutateRow(ByteBuffer tableName,
         ByteBuffer row,
         List<Mutation> mutations,
         Map<ByteBuffer,ByteBuffer> attributes) | 
| void | ThriftServerRunner.HBaseHandler. mutateRows(ByteBuffer tableName,
          List<BatchMutation> rowBatches,
          Map<ByteBuffer,ByteBuffer> attributes) | 
| void | ThriftServerRunner.HBaseHandler. mutateRowsTs(ByteBuffer tableName,
            List<BatchMutation> rowBatches,
            long timestamp,
            Map<ByteBuffer,ByteBuffer> attributes) | 
| void | ThriftServerRunner.HBaseHandler. mutateRowTs(ByteBuffer tableName,
           ByteBuffer row,
           List<Mutation> mutations,
           long timestamp,
           Map<ByteBuffer,ByteBuffer> attributes) | 
| void | ThriftServerRunner.HBaseHandler. scannerClose(int id) | 
| List<TRowResult> | ThriftServerRunner.HBaseHandler. scannerGet(int id) | 
| List<TRowResult> | ThriftServerRunner.HBaseHandler. scannerGetList(int id,
              int nbRows) | 
| int | ThriftServerRunner.HBaseHandler. scannerOpen(ByteBuffer tableName,
           ByteBuffer startRow,
           List<ByteBuffer> columns,
           Map<ByteBuffer,ByteBuffer> attributes) | 
| int | ThriftServerRunner.HBaseHandler. scannerOpenTs(ByteBuffer tableName,
             ByteBuffer startRow,
             List<ByteBuffer> columns,
             long timestamp,
             Map<ByteBuffer,ByteBuffer> attributes) | 
| int | ThriftServerRunner.HBaseHandler. scannerOpenWithPrefix(ByteBuffer tableName,
                     ByteBuffer startAndPrefix,
                     List<ByteBuffer> columns,
                     Map<ByteBuffer,ByteBuffer> attributes) | 
| int | ThriftServerRunner.HBaseHandler. scannerOpenWithScan(ByteBuffer tableName,
                   TScan tScan,
                   Map<ByteBuffer,ByteBuffer> attributes) | 
| int | ThriftServerRunner.HBaseHandler. scannerOpenWithStop(ByteBuffer tableName,
                   ByteBuffer startRow,
                   ByteBuffer stopRow,
                   List<ByteBuffer> columns,
                   Map<ByteBuffer,ByteBuffer> attributes) | 
| int | ThriftServerRunner.HBaseHandler. scannerOpenWithStopTs(ByteBuffer tableName,
                     ByteBuffer startRow,
                     ByteBuffer stopRow,
                     List<ByteBuffer> columns,
                     long timestamp,
                     Map<ByteBuffer,ByteBuffer> attributes) | 
| Modifier and Type | Field and Description | 
|---|---|
| IOError | Hbase.enableTable_result. io | 
| IOError | Hbase.disableTable_result. io | 
| IOError | Hbase.isTableEnabled_result. io | 
| IOError | Hbase.compact_result. io | 
| IOError | Hbase.majorCompact_result. io | 
| IOError | Hbase.getTableNames_result. io | 
| IOError | Hbase.getColumnDescriptors_result. io | 
| IOError | Hbase.getTableRegions_result. io | 
| IOError | Hbase.createTable_result. io | 
| IOError | Hbase.deleteTable_result. io | 
| IOError | Hbase.get_result. io | 
| IOError | Hbase.getVer_result. io | 
| IOError | Hbase.getVerTs_result. io | 
| IOError | Hbase.getRow_result. io | 
| IOError | Hbase.getRowWithColumns_result. io | 
| IOError | Hbase.getRowTs_result. io | 
| IOError | Hbase.getRowWithColumnsTs_result. io | 
| IOError | Hbase.getRows_result. io | 
| IOError | Hbase.getRowsWithColumns_result. io | 
| IOError | Hbase.getRowsTs_result. io | 
| IOError | Hbase.getRowsWithColumnsTs_result. io | 
| IOError | Hbase.mutateRow_result. io | 
| IOError | Hbase.mutateRowTs_result. io | 
| IOError | Hbase.mutateRows_result. io | 
| IOError | Hbase.mutateRowsTs_result. io | 
| IOError | Hbase.atomicIncrement_result. io | 
| IOError | Hbase.deleteAll_result. io | 
| IOError | Hbase.deleteAllTs_result. io | 
| IOError | Hbase.deleteAllRow_result. io | 
| IOError | Hbase.increment_result. io | 
| IOError | Hbase.incrementRows_result. io | 
| IOError | Hbase.deleteAllRowTs_result. io | 
| IOError | Hbase.scannerOpenWithScan_result. io | 
| IOError | Hbase.scannerOpen_result. io | 
| IOError | Hbase.scannerOpenWithStop_result. io | 
| IOError | Hbase.scannerOpenWithPrefix_result. io | 
| IOError | Hbase.scannerOpenTs_result. io | 
| IOError | Hbase.scannerOpenWithStopTs_result. io | 
| IOError | Hbase.scannerGet_result. io | 
| IOError | Hbase.scannerGetList_result. io | 
| IOError | Hbase.scannerClose_result. io | 
| IOError | Hbase.getRowOrBefore_result. io | 
| IOError | Hbase.getRegionInfo_result. io | 
| IOError | Hbase.append_result. io | 
| IOError | Hbase.checkAndPut_result. io | 
| Modifier and Type | Method and Description | 
|---|---|
| IOError | IOError. deepCopy() | 
| IOError | Hbase.enableTable_result. getIo() | 
| IOError | Hbase.disableTable_result. getIo() | 
| IOError | Hbase.isTableEnabled_result. getIo() | 
| IOError | Hbase.compact_result. getIo() | 
| IOError | Hbase.majorCompact_result. getIo() | 
| IOError | Hbase.getTableNames_result. getIo() | 
| IOError | Hbase.getColumnDescriptors_result. getIo() | 
| IOError | Hbase.getTableRegions_result. getIo() | 
| IOError | Hbase.createTable_result. getIo() | 
| IOError | Hbase.deleteTable_result. getIo() | 
| IOError | Hbase.get_result. getIo() | 
| IOError | Hbase.getVer_result. getIo() | 
| IOError | Hbase.getVerTs_result. getIo() | 
| IOError | Hbase.getRow_result. getIo() | 
| IOError | Hbase.getRowWithColumns_result. getIo() | 
| IOError | Hbase.getRowTs_result. getIo() | 
| IOError | Hbase.getRowWithColumnsTs_result. getIo() | 
| IOError | Hbase.getRows_result. getIo() | 
| IOError | Hbase.getRowsWithColumns_result. getIo() | 
| IOError | Hbase.getRowsTs_result. getIo() | 
| IOError | Hbase.getRowsWithColumnsTs_result. getIo() | 
| IOError | Hbase.mutateRow_result. getIo() | 
| IOError | Hbase.mutateRowTs_result. getIo() | 
| IOError | Hbase.mutateRows_result. getIo() | 
| IOError | Hbase.mutateRowsTs_result. getIo() | 
| IOError | Hbase.atomicIncrement_result. getIo() | 
| IOError | Hbase.deleteAll_result. getIo() | 
| IOError | Hbase.deleteAllTs_result. getIo() | 
| IOError | Hbase.deleteAllRow_result. getIo() | 
| IOError | Hbase.increment_result. getIo() | 
| IOError | Hbase.incrementRows_result. getIo() | 
| IOError | Hbase.deleteAllRowTs_result. getIo() | 
| IOError | Hbase.scannerOpenWithScan_result. getIo() | 
| IOError | Hbase.scannerOpen_result. getIo() | 
| IOError | Hbase.scannerOpenWithStop_result. getIo() | 
| IOError | Hbase.scannerOpenWithPrefix_result. getIo() | 
| IOError | Hbase.scannerOpenTs_result. getIo() | 
| IOError | Hbase.scannerOpenWithStopTs_result. getIo() | 
| IOError | Hbase.scannerGet_result. getIo() | 
| IOError | Hbase.scannerGetList_result. getIo() | 
| IOError | Hbase.scannerClose_result. getIo() | 
| IOError | Hbase.getRowOrBefore_result. getIo() | 
| IOError | Hbase.getRegionInfo_result. getIo() | 
| IOError | Hbase.append_result. getIo() | 
| IOError | Hbase.checkAndPut_result. getIo() | 
| IOError | IOError. setMessage(String message) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<TCell> | Hbase.Iface. append(TAppend append)Appends values to one or more columns within a single row. | 
| List<TCell> | Hbase.Client. append(TAppend append) | 
| long | Hbase.Iface. atomicIncrement(ByteBuffer tableName,
               ByteBuffer row,
               ByteBuffer column,
               long value)Atomically increment the column value specified. | 
| long | Hbase.Client. atomicIncrement(ByteBuffer tableName,
               ByteBuffer row,
               ByteBuffer column,
               long value) | 
| boolean | Hbase.Iface. 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. | 
| boolean | Hbase.Client. checkAndPut(ByteBuffer tableName,
           ByteBuffer row,
           ByteBuffer column,
           ByteBuffer value,
           Mutation mput,
           Map<ByteBuffer,ByteBuffer> attributes) | 
| void | Hbase.Iface. compact(ByteBuffer tableNameOrRegionName) | 
| void | Hbase.Client. compact(ByteBuffer tableNameOrRegionName) | 
| void | Hbase.Iface. createTable(ByteBuffer tableName,
           List<ColumnDescriptor> columnFamilies)Create a table with the specified column families. | 
| void | Hbase.Client. createTable(ByteBuffer tableName,
           List<ColumnDescriptor> columnFamilies) | 
| void | Hbase.Iface. deleteAll(ByteBuffer tableName,
         ByteBuffer row,
         ByteBuffer column,
         Map<ByteBuffer,ByteBuffer> attributes)Delete all cells that match the passed row and column. | 
| void | Hbase.Client. deleteAll(ByteBuffer tableName,
         ByteBuffer row,
         ByteBuffer column,
         Map<ByteBuffer,ByteBuffer> attributes) | 
| void | Hbase.Iface. deleteAllRow(ByteBuffer tableName,
            ByteBuffer row,
            Map<ByteBuffer,ByteBuffer> attributes)Completely delete the row's cells. | 
| void | Hbase.Client. deleteAllRow(ByteBuffer tableName,
            ByteBuffer row,
            Map<ByteBuffer,ByteBuffer> attributes) | 
| void | Hbase.Iface. 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 | Hbase.Client. deleteAllRowTs(ByteBuffer tableName,
              ByteBuffer row,
              long timestamp,
              Map<ByteBuffer,ByteBuffer> attributes) | 
| void | Hbase.Iface. 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 | Hbase.Client. deleteAllTs(ByteBuffer tableName,
           ByteBuffer row,
           ByteBuffer column,
           long timestamp,
           Map<ByteBuffer,ByteBuffer> attributes) | 
| void | Hbase.Iface. deleteTable(ByteBuffer tableName)Deletes a table | 
| void | Hbase.Client. deleteTable(ByteBuffer tableName) | 
| void | Hbase.Iface. 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 | Hbase.Client. disableTable(ByteBuffer tableName) | 
| void | Hbase.Iface. enableTable(ByteBuffer tableName)Brings a table on-line (enables it) | 
| void | Hbase.Client. enableTable(ByteBuffer tableName) | 
| List<TCell> | Hbase.Iface. 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. | 
| List<TCell> | Hbase.Client. get(ByteBuffer tableName,
   ByteBuffer row,
   ByteBuffer column,
   Map<ByteBuffer,ByteBuffer> attributes) | 
| Map<ByteBuffer,ColumnDescriptor> | Hbase.Iface. getColumnDescriptors(ByteBuffer tableName)List all the column families assoicated with a table. | 
| Map<ByteBuffer,ColumnDescriptor> | Hbase.Client. getColumnDescriptors(ByteBuffer tableName) | 
| TRegionInfo | Hbase.Iface. getRegionInfo(ByteBuffer row)Get the regininfo for the specified row. | 
| TRegionInfo | Hbase.Client. getRegionInfo(ByteBuffer row) | 
| void | Hbase.AsyncClient.enableTable_call. getResult() | 
| void | Hbase.AsyncClient.disableTable_call. getResult() | 
| boolean | Hbase.AsyncClient.isTableEnabled_call. getResult() | 
| void | Hbase.AsyncClient.compact_call. getResult() | 
| void | Hbase.AsyncClient.majorCompact_call. getResult() | 
| List<ByteBuffer> | Hbase.AsyncClient.getTableNames_call. getResult() | 
| Map<ByteBuffer,ColumnDescriptor> | Hbase.AsyncClient.getColumnDescriptors_call. getResult() | 
| List<TRegionInfo> | Hbase.AsyncClient.getTableRegions_call. getResult() | 
| void | Hbase.AsyncClient.createTable_call. getResult() | 
| void | Hbase.AsyncClient.deleteTable_call. getResult() | 
| List<TCell> | Hbase.AsyncClient.get_call. getResult() | 
| List<TCell> | Hbase.AsyncClient.getVer_call. getResult() | 
| List<TCell> | Hbase.AsyncClient.getVerTs_call. getResult() | 
| List<TRowResult> | Hbase.AsyncClient.getRow_call. getResult() | 
| List<TRowResult> | Hbase.AsyncClient.getRowWithColumns_call. getResult() | 
| List<TRowResult> | Hbase.AsyncClient.getRowTs_call. getResult() | 
| List<TRowResult> | Hbase.AsyncClient.getRowWithColumnsTs_call. getResult() | 
| List<TRowResult> | Hbase.AsyncClient.getRows_call. getResult() | 
| List<TRowResult> | Hbase.AsyncClient.getRowsWithColumns_call. getResult() | 
| List<TRowResult> | Hbase.AsyncClient.getRowsTs_call. getResult() | 
| List<TRowResult> | Hbase.AsyncClient.getRowsWithColumnsTs_call. getResult() | 
| void | Hbase.AsyncClient.mutateRow_call. getResult() | 
| void | Hbase.AsyncClient.mutateRowTs_call. getResult() | 
| void | Hbase.AsyncClient.mutateRows_call. getResult() | 
| void | Hbase.AsyncClient.mutateRowsTs_call. getResult() | 
| long | Hbase.AsyncClient.atomicIncrement_call. getResult() | 
| void | Hbase.AsyncClient.deleteAll_call. getResult() | 
| void | Hbase.AsyncClient.deleteAllTs_call. getResult() | 
| void | Hbase.AsyncClient.deleteAllRow_call. getResult() | 
| void | Hbase.AsyncClient.increment_call. getResult() | 
| void | Hbase.AsyncClient.incrementRows_call. getResult() | 
| void | Hbase.AsyncClient.deleteAllRowTs_call. getResult() | 
| int | Hbase.AsyncClient.scannerOpenWithScan_call. getResult() | 
| int | Hbase.AsyncClient.scannerOpen_call. getResult() | 
| int | Hbase.AsyncClient.scannerOpenWithStop_call. getResult() | 
| int | Hbase.AsyncClient.scannerOpenWithPrefix_call. getResult() | 
| int | Hbase.AsyncClient.scannerOpenTs_call. getResult() | 
| int | Hbase.AsyncClient.scannerOpenWithStopTs_call. getResult() | 
| List<TRowResult> | Hbase.AsyncClient.scannerGet_call. getResult() | 
| List<TRowResult> | Hbase.AsyncClient.scannerGetList_call. getResult() | 
| void | Hbase.AsyncClient.scannerClose_call. getResult() | 
| List<TCell> | Hbase.AsyncClient.getRowOrBefore_call. getResult() | 
| TRegionInfo | Hbase.AsyncClient.getRegionInfo_call. getResult() | 
| List<TCell> | Hbase.AsyncClient.append_call. getResult() | 
| boolean | Hbase.AsyncClient.checkAndPut_call. getResult() | 
| List<TRowResult> | Hbase.Iface. getRow(ByteBuffer tableName,
      ByteBuffer row,
      Map<ByteBuffer,ByteBuffer> attributes)Get all the data for the specified table and row at the latest
 timestamp. | 
| List<TRowResult> | Hbase.Client. getRow(ByteBuffer tableName,
      ByteBuffer row,
      Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TCell> | Hbase.Iface. getRowOrBefore(ByteBuffer tableName,
              ByteBuffer row,
              ByteBuffer family)Get the row just before the specified one. | 
| List<TCell> | Hbase.Client. getRowOrBefore(ByteBuffer tableName,
              ByteBuffer row,
              ByteBuffer family) | 
| List<TRowResult> | Hbase.Iface. 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> | Hbase.Client. getRows(ByteBuffer tableName,
       List<ByteBuffer> rows,
       Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TRowResult> | Hbase.Iface. 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> | Hbase.Client. getRowsTs(ByteBuffer tableName,
         List<ByteBuffer> rows,
         long timestamp,
         Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TRowResult> | Hbase.Iface. 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> | Hbase.Client. getRowsWithColumns(ByteBuffer tableName,
                  List<ByteBuffer> rows,
                  List<ByteBuffer> columns,
                  Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TRowResult> | Hbase.Iface. 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> | Hbase.Client. getRowsWithColumnsTs(ByteBuffer tableName,
                    List<ByteBuffer> rows,
                    List<ByteBuffer> columns,
                    long timestamp,
                    Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TRowResult> | Hbase.Iface. 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> | Hbase.Client. getRowTs(ByteBuffer tableName,
        ByteBuffer row,
        long timestamp,
        Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TRowResult> | Hbase.Iface. 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> | Hbase.Client. getRowWithColumns(ByteBuffer tableName,
                 ByteBuffer row,
                 List<ByteBuffer> columns,
                 Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TRowResult> | Hbase.Iface. 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<TRowResult> | Hbase.Client. getRowWithColumnsTs(ByteBuffer tableName,
                   ByteBuffer row,
                   List<ByteBuffer> columns,
                   long timestamp,
                   Map<ByteBuffer,ByteBuffer> attributes) | 
| List<ByteBuffer> | Hbase.Iface. getTableNames()List all the userspace tables. | 
| List<ByteBuffer> | Hbase.Client. getTableNames() | 
| List<TRegionInfo> | Hbase.Iface. getTableRegions(ByteBuffer tableName)List the regions associated with a table. | 
| List<TRegionInfo> | Hbase.Client. getTableRegions(ByteBuffer tableName) | 
| List<TCell> | Hbase.Iface. 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> | Hbase.Client. getVer(ByteBuffer tableName,
      ByteBuffer row,
      ByteBuffer column,
      int numVersions,
      Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TCell> | Hbase.Iface. 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. | 
| List<TCell> | Hbase.Client. getVerTs(ByteBuffer tableName,
        ByteBuffer row,
        ByteBuffer column,
        long timestamp,
        int numVersions,
        Map<ByteBuffer,ByteBuffer> attributes) | 
| void | Hbase.Iface. increment(TIncrement increment)Increment a cell by the ammount. | 
| void | Hbase.Client. increment(TIncrement increment) | 
| void | Hbase.Iface. incrementRows(List<TIncrement> increments) | 
| void | Hbase.Client. incrementRows(List<TIncrement> increments) | 
| boolean | Hbase.Iface. isTableEnabled(ByteBuffer tableName) | 
| boolean | Hbase.Client. isTableEnabled(ByteBuffer tableName) | 
| void | Hbase.Iface. majorCompact(ByteBuffer tableNameOrRegionName) | 
| void | Hbase.Client. majorCompact(ByteBuffer tableNameOrRegionName) | 
| void | Hbase.Iface. 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 | Hbase.Client. mutateRow(ByteBuffer tableName,
         ByteBuffer row,
         List<Mutation> mutations,
         Map<ByteBuffer,ByteBuffer> attributes) | 
| void | Hbase.Iface. 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 | Hbase.Client. mutateRows(ByteBuffer tableName,
          List<BatchMutation> rowBatches,
          Map<ByteBuffer,ByteBuffer> attributes) | 
| void | Hbase.Iface. 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 | Hbase.Client. mutateRowsTs(ByteBuffer tableName,
            List<BatchMutation> rowBatches,
            long timestamp,
            Map<ByteBuffer,ByteBuffer> attributes) | 
| void | Hbase.Iface. 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. | 
| void | Hbase.Client. mutateRowTs(ByteBuffer tableName,
           ByteBuffer row,
           List<Mutation> mutations,
           long timestamp,
           Map<ByteBuffer,ByteBuffer> attributes) | 
| List<TCell> | Hbase.Client. recv_append() | 
| long | Hbase.Client. recv_atomicIncrement() | 
| boolean | Hbase.Client. recv_checkAndPut() | 
| void | Hbase.Client. recv_compact() | 
| void | Hbase.Client. recv_createTable() | 
| void | Hbase.Client. recv_deleteAll() | 
| void | Hbase.Client. recv_deleteAllRow() | 
| void | Hbase.Client. recv_deleteAllRowTs() | 
| void | Hbase.Client. recv_deleteAllTs() | 
| void | Hbase.Client. recv_deleteTable() | 
| void | Hbase.Client. recv_disableTable() | 
| void | Hbase.Client. recv_enableTable() | 
| List<TCell> | Hbase.Client. recv_get() | 
| Map<ByteBuffer,ColumnDescriptor> | Hbase.Client. recv_getColumnDescriptors() | 
| TRegionInfo | Hbase.Client. recv_getRegionInfo() | 
| List<TRowResult> | Hbase.Client. recv_getRow() | 
| List<TCell> | Hbase.Client. recv_getRowOrBefore() | 
| List<TRowResult> | Hbase.Client. recv_getRows() | 
| List<TRowResult> | Hbase.Client. recv_getRowsTs() | 
| List<TRowResult> | Hbase.Client. recv_getRowsWithColumns() | 
| List<TRowResult> | Hbase.Client. recv_getRowsWithColumnsTs() | 
| List<TRowResult> | Hbase.Client. recv_getRowTs() | 
| List<TRowResult> | Hbase.Client. recv_getRowWithColumns() | 
| List<TRowResult> | Hbase.Client. recv_getRowWithColumnsTs() | 
| List<ByteBuffer> | Hbase.Client. recv_getTableNames() | 
| List<TRegionInfo> | Hbase.Client. recv_getTableRegions() | 
| List<TCell> | Hbase.Client. recv_getVer() | 
| List<TCell> | Hbase.Client. recv_getVerTs() | 
| void | Hbase.Client. recv_increment() | 
| void | Hbase.Client. recv_incrementRows() | 
| boolean | Hbase.Client. recv_isTableEnabled() | 
| void | Hbase.Client. recv_majorCompact() | 
| void | Hbase.Client. recv_mutateRow() | 
| void | Hbase.Client. recv_mutateRows() | 
| void | Hbase.Client. recv_mutateRowsTs() | 
| void | Hbase.Client. recv_mutateRowTs() | 
| void | Hbase.Client. recv_scannerClose() | 
| List<TRowResult> | Hbase.Client. recv_scannerGet() | 
| List<TRowResult> | Hbase.Client. recv_scannerGetList() | 
| int | Hbase.Client. recv_scannerOpen() | 
| int | Hbase.Client. recv_scannerOpenTs() | 
| int | Hbase.Client. recv_scannerOpenWithPrefix() | 
| int | Hbase.Client. recv_scannerOpenWithScan() | 
| int | Hbase.Client. recv_scannerOpenWithStop() | 
| int | Hbase.Client. recv_scannerOpenWithStopTs() | 
| void | Hbase.Iface. scannerClose(int id)Closes the server-state associated with an open scanner. | 
| void | Hbase.Client. scannerClose(int id) | 
| List<TRowResult> | Hbase.Iface. scannerGet(int id)Returns the scanner's current row value and advances to the next
 row in the table. | 
| List<TRowResult> | Hbase.Client. scannerGet(int id) | 
| List<TRowResult> | Hbase.Iface. 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. | 
| List<TRowResult> | Hbase.Client. scannerGetList(int id,
              int nbRows) | 
| int | Hbase.Iface. 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 | Hbase.Client. scannerOpen(ByteBuffer tableName,
           ByteBuffer startRow,
           List<ByteBuffer> columns,
           Map<ByteBuffer,ByteBuffer> attributes) | 
| int | Hbase.Iface. 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 | Hbase.Client. scannerOpenTs(ByteBuffer tableName,
             ByteBuffer startRow,
             List<ByteBuffer> columns,
             long timestamp,
             Map<ByteBuffer,ByteBuffer> attributes) | 
| int | Hbase.Iface. scannerOpenWithPrefix(ByteBuffer tableName,
                     ByteBuffer startAndPrefix,
                     List<ByteBuffer> columns,
                     Map<ByteBuffer,ByteBuffer> attributes)Open a scanner for a given prefix. | 
| int | Hbase.Client. scannerOpenWithPrefix(ByteBuffer tableName,
                     ByteBuffer startAndPrefix,
                     List<ByteBuffer> columns,
                     Map<ByteBuffer,ByteBuffer> attributes) | 
| int | Hbase.Iface. 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 | Hbase.Client. scannerOpenWithScan(ByteBuffer tableName,
                   TScan scan,
                   Map<ByteBuffer,ByteBuffer> attributes) | 
| int | Hbase.Iface. 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 | Hbase.Client. scannerOpenWithStop(ByteBuffer tableName,
                   ByteBuffer startRow,
                   ByteBuffer stopRow,
                   List<ByteBuffer> columns,
                   Map<ByteBuffer,ByteBuffer> attributes) | 
| int | Hbase.Iface. 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. | 
| int | Hbase.Client. scannerOpenWithStopTs(ByteBuffer tableName,
                     ByteBuffer startRow,
                     ByteBuffer stopRow,
                     List<ByteBuffer> columns,
                     long timestamp,
                     Map<ByteBuffer,ByteBuffer> attributes) | 
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.