public static interface Hbase.AsyncIface
| Modifier and Type | Method and Description | 
|---|---|
void | 
append(TAppend append,
      org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
atomicIncrement(ByteBuffer tableName,
               ByteBuffer row,
               ByteBuffer column,
               long value,
               org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
checkAndPut(ByteBuffer tableName,
           ByteBuffer row,
           ByteBuffer column,
           ByteBuffer value,
           Mutation mput,
           Map<ByteBuffer,ByteBuffer> attributes,
           org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
compact(ByteBuffer tableNameOrRegionName,
       org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
createTable(ByteBuffer tableName,
           List<ColumnDescriptor> columnFamilies,
           org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
deleteAll(ByteBuffer tableName,
         ByteBuffer row,
         ByteBuffer column,
         Map<ByteBuffer,ByteBuffer> attributes,
         org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
deleteAllRow(ByteBuffer tableName,
            ByteBuffer row,
            Map<ByteBuffer,ByteBuffer> attributes,
            org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
deleteAllRowTs(ByteBuffer tableName,
              ByteBuffer row,
              long timestamp,
              Map<ByteBuffer,ByteBuffer> attributes,
              org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
deleteAllTs(ByteBuffer tableName,
           ByteBuffer row,
           ByteBuffer column,
           long timestamp,
           Map<ByteBuffer,ByteBuffer> attributes,
           org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
deleteTable(ByteBuffer tableName,
           org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
disableTable(ByteBuffer tableName,
            org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
enableTable(ByteBuffer tableName,
           org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
get(ByteBuffer tableName,
   ByteBuffer row,
   ByteBuffer column,
   Map<ByteBuffer,ByteBuffer> attributes,
   org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getColumnDescriptors(ByteBuffer tableName,
                    org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getRegionInfo(ByteBuffer row,
             org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getRow(ByteBuffer tableName,
      ByteBuffer row,
      Map<ByteBuffer,ByteBuffer> attributes,
      org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getRowOrBefore(ByteBuffer tableName,
              ByteBuffer row,
              ByteBuffer family,
              org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getRows(ByteBuffer tableName,
       List<ByteBuffer> rows,
       Map<ByteBuffer,ByteBuffer> attributes,
       org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getRowsTs(ByteBuffer tableName,
         List<ByteBuffer> rows,
         long timestamp,
         Map<ByteBuffer,ByteBuffer> attributes,
         org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getRowsWithColumns(ByteBuffer tableName,
                  List<ByteBuffer> rows,
                  List<ByteBuffer> columns,
                  Map<ByteBuffer,ByteBuffer> attributes,
                  org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getRowsWithColumnsTs(ByteBuffer tableName,
                    List<ByteBuffer> rows,
                    List<ByteBuffer> columns,
                    long timestamp,
                    Map<ByteBuffer,ByteBuffer> attributes,
                    org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getRowTs(ByteBuffer tableName,
        ByteBuffer row,
        long timestamp,
        Map<ByteBuffer,ByteBuffer> attributes,
        org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getRowWithColumns(ByteBuffer tableName,
                 ByteBuffer row,
                 List<ByteBuffer> columns,
                 Map<ByteBuffer,ByteBuffer> attributes,
                 org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getRowWithColumnsTs(ByteBuffer tableName,
                   ByteBuffer row,
                   List<ByteBuffer> columns,
                   long timestamp,
                   Map<ByteBuffer,ByteBuffer> attributes,
                   org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getTableNames(org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getTableRegions(ByteBuffer tableName,
               org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getVer(ByteBuffer tableName,
      ByteBuffer row,
      ByteBuffer column,
      int numVersions,
      Map<ByteBuffer,ByteBuffer> attributes,
      org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
getVerTs(ByteBuffer tableName,
        ByteBuffer row,
        ByteBuffer column,
        long timestamp,
        int numVersions,
        Map<ByteBuffer,ByteBuffer> attributes,
        org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
increment(TIncrement increment,
         org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
incrementRows(List<TIncrement> increments,
             org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
isTableEnabled(ByteBuffer tableName,
              org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
majorCompact(ByteBuffer tableNameOrRegionName,
            org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
mutateRow(ByteBuffer tableName,
         ByteBuffer row,
         List<Mutation> mutations,
         Map<ByteBuffer,ByteBuffer> attributes,
         org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
mutateRows(ByteBuffer tableName,
          List<BatchMutation> rowBatches,
          Map<ByteBuffer,ByteBuffer> attributes,
          org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
mutateRowsTs(ByteBuffer tableName,
            List<BatchMutation> rowBatches,
            long timestamp,
            Map<ByteBuffer,ByteBuffer> attributes,
            org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
mutateRowTs(ByteBuffer tableName,
           ByteBuffer row,
           List<Mutation> mutations,
           long timestamp,
           Map<ByteBuffer,ByteBuffer> attributes,
           org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
scannerClose(int id,
            org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
scannerGet(int id,
          org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
scannerGetList(int id,
              int nbRows,
              org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
scannerOpen(ByteBuffer tableName,
           ByteBuffer startRow,
           List<ByteBuffer> columns,
           Map<ByteBuffer,ByteBuffer> attributes,
           org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
scannerOpenTs(ByteBuffer tableName,
             ByteBuffer startRow,
             List<ByteBuffer> columns,
             long timestamp,
             Map<ByteBuffer,ByteBuffer> attributes,
             org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
scannerOpenWithPrefix(ByteBuffer tableName,
                     ByteBuffer startAndPrefix,
                     List<ByteBuffer> columns,
                     Map<ByteBuffer,ByteBuffer> attributes,
                     org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
scannerOpenWithScan(ByteBuffer tableName,
                   TScan scan,
                   Map<ByteBuffer,ByteBuffer> attributes,
                   org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
scannerOpenWithStop(ByteBuffer tableName,
                   ByteBuffer startRow,
                   ByteBuffer stopRow,
                   List<ByteBuffer> columns,
                   Map<ByteBuffer,ByteBuffer> attributes,
                   org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void | 
scannerOpenWithStopTs(ByteBuffer tableName,
                     ByteBuffer startRow,
                     ByteBuffer stopRow,
                     List<ByteBuffer> columns,
                     long timestamp,
                     Map<ByteBuffer,ByteBuffer> attributes,
                     org.apache.thrift.async.AsyncMethodCallback resultHandler)  | 
void enableTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid disableTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid isTableEnabled(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid compact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid majorCompact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getTableNames(org.apache.thrift.async.AsyncMethodCallback resultHandler)
            throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getColumnDescriptors(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getTableRegions(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid createTable(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid deleteTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getRows(ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid atomicIncrement(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid increment(TIncrement increment, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid incrementRows(List<TIncrement> increments, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid scannerOpenWithScan(ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid scannerOpen(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid scannerOpenWithStop(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid scannerOpenWithPrefix(ByteBuffer tableName, ByteBuffer startAndPrefix, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid scannerOpenTs(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid scannerOpenWithStopTs(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid scannerGet(int id,
                org.apache.thrift.async.AsyncMethodCallback resultHandler)
         throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid scannerGetList(int id,
                    int nbRows,
                    org.apache.thrift.async.AsyncMethodCallback resultHandler)
             throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid scannerClose(int id,
                  org.apache.thrift.async.AsyncMethodCallback resultHandler)
           throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getRowOrBefore(ByteBuffer tableName, ByteBuffer row, ByteBuffer family, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid getRegionInfo(ByteBuffer row, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid append(TAppend append, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid checkAndPut(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer value, Mutation mput, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException