public static class Hbase.AsyncClient extends org.apache.thrift.async.TAsyncClient implements Hbase.AsyncIface
| Constructor and Description | 
|---|
AsyncClient(org.apache.thrift.protocol.TProtocolFactory protocolFactory,
           org.apache.thrift.async.TAsyncClientManager clientManager,
           org.apache.thrift.transport.TNonblockingTransport transport)  | 
| 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)  | 
public AsyncClient(org.apache.thrift.protocol.TProtocolFactory protocolFactory,
                   org.apache.thrift.async.TAsyncClientManager clientManager,
                   org.apache.thrift.transport.TNonblockingTransport transport)
public void enableTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
enableTable in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void disableTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
disableTable in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void isTableEnabled(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
isTableEnabled in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void compact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
compact in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void majorCompact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
majorCompact in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void getTableNames(org.apache.thrift.async.AsyncMethodCallback resultHandler)
                   throws org.apache.thrift.TException
getTableNames in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void getColumnDescriptors(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
getColumnDescriptors in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void getTableRegions(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
getTableRegions in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void createTable(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
createTable in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void deleteTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
deleteTable in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
get in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
getVer in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void 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
getVerTs in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void getRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
getRow in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
getRowWithColumns in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
getRowTs in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void 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
getRowWithColumnsTs in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void getRows(ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
getRows in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
getRowsWithColumns in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
getRowsTs in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void 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
getRowsWithColumnsTs in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
mutateRow in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void 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
mutateRowTs in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
mutateRows in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
mutateRowsTs in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void atomicIncrement(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
atomicIncrement in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
deleteAll in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
deleteAllTs in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
deleteAllRow in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void increment(TIncrement increment, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
increment in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void incrementRows(List<TIncrement> increments, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
incrementRows in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
deleteAllRowTs in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void scannerOpenWithScan(ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
scannerOpenWithScan in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void scannerOpen(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
scannerOpen in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void 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
scannerOpenWithStop in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void scannerOpenWithPrefix(ByteBuffer tableName, ByteBuffer startAndPrefix, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
scannerOpenWithPrefix in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void 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
scannerOpenTs in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void 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
scannerOpenWithStopTs in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void scannerGet(int id,
                       org.apache.thrift.async.AsyncMethodCallback resultHandler)
                throws org.apache.thrift.TException
scannerGet in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void scannerGetList(int id,
                           int nbRows,
                           org.apache.thrift.async.AsyncMethodCallback resultHandler)
                    throws org.apache.thrift.TException
scannerGetList in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void scannerClose(int id,
                         org.apache.thrift.async.AsyncMethodCallback resultHandler)
                  throws org.apache.thrift.TException
scannerClose in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void getRowOrBefore(ByteBuffer tableName, ByteBuffer row, ByteBuffer family, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
getRowOrBefore in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void getRegionInfo(ByteBuffer row, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
getRegionInfo in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void append(TAppend append, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
append in interface Hbase.AsyncIfaceorg.apache.thrift.TExceptionpublic void 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
checkAndPut in interface Hbase.AsyncIfaceorg.apache.thrift.TException