public static class Hbase.AsyncClient extends org.apache.thrift.async.TAsyncClient implements Hbase.AsyncIface
Constructor and Description |
---|
Hbase.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<Hbase.AsyncClient.append_call> resultHandler) |
void |
atomicIncrement(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
long value,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.atomicIncrement_call> resultHandler) |
void |
checkAndPut(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
ByteBuffer value,
Mutation mput,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.checkAndPut_call> resultHandler) |
void |
compact(ByteBuffer tableNameOrRegionName,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.compact_call> resultHandler) |
void |
createTable(ByteBuffer tableName,
List<ColumnDescriptor> columnFamilies,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.createTable_call> resultHandler) |
void |
deleteAll(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.deleteAll_call> resultHandler) |
void |
deleteAllRow(ByteBuffer tableName,
ByteBuffer row,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.deleteAllRow_call> resultHandler) |
void |
deleteAllRowTs(ByteBuffer tableName,
ByteBuffer row,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.deleteAllRowTs_call> resultHandler) |
void |
deleteAllTs(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.deleteAllTs_call> resultHandler) |
void |
deleteTable(ByteBuffer tableName,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.deleteTable_call> resultHandler) |
void |
disableTable(ByteBuffer tableName,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.disableTable_call> resultHandler) |
void |
enableTable(ByteBuffer tableName,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.enableTable_call> resultHandler) |
void |
get(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.get_call> resultHandler) |
void |
getColumnDescriptors(ByteBuffer tableName,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getColumnDescriptors_call> resultHandler) |
void |
getRegionInfo(ByteBuffer row,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRegionInfo_call> resultHandler) |
void |
getRow(ByteBuffer tableName,
ByteBuffer row,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRow_call> resultHandler) |
void |
getRowOrBefore(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer family,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowOrBefore_call> resultHandler) |
void |
getRows(ByteBuffer tableName,
List<ByteBuffer> rows,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRows_call> resultHandler) |
void |
getRowsTs(ByteBuffer tableName,
List<ByteBuffer> rows,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowsTs_call> resultHandler) |
void |
getRowsWithColumns(ByteBuffer tableName,
List<ByteBuffer> rows,
List<ByteBuffer> columns,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumns_call> resultHandler) |
void |
getRowsWithColumnsTs(ByteBuffer tableName,
List<ByteBuffer> rows,
List<ByteBuffer> columns,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumnsTs_call> resultHandler) |
void |
getRowTs(ByteBuffer tableName,
ByteBuffer row,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowTs_call> resultHandler) |
void |
getRowWithColumns(ByteBuffer tableName,
ByteBuffer row,
List<ByteBuffer> columns,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumns_call> resultHandler) |
void |
getRowWithColumnsTs(ByteBuffer tableName,
ByteBuffer row,
List<ByteBuffer> columns,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumnsTs_call> resultHandler) |
void |
getTableNames(org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getTableNames_call> resultHandler) |
void |
getTableRegions(ByteBuffer tableName,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getTableRegions_call> resultHandler) |
void |
getVer(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
int numVersions,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getVer_call> resultHandler) |
void |
getVerTs(ByteBuffer tableName,
ByteBuffer row,
ByteBuffer column,
long timestamp,
int numVersions,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getVerTs_call> resultHandler) |
void |
increment(TIncrement increment,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.increment_call> resultHandler) |
void |
incrementRows(List<TIncrement> increments,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.incrementRows_call> resultHandler) |
void |
isTableEnabled(ByteBuffer tableName,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.isTableEnabled_call> resultHandler) |
void |
majorCompact(ByteBuffer tableNameOrRegionName,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.majorCompact_call> resultHandler) |
void |
mutateRow(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRow_call> resultHandler) |
void |
mutateRows(ByteBuffer tableName,
List<BatchMutation> rowBatches,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRows_call> resultHandler) |
void |
mutateRowsTs(ByteBuffer tableName,
List<BatchMutation> rowBatches,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRowsTs_call> resultHandler) |
void |
mutateRowTs(ByteBuffer tableName,
ByteBuffer row,
List<Mutation> mutations,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRowTs_call> resultHandler) |
void |
scannerClose(int id,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerClose_call> resultHandler) |
void |
scannerGet(int id,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerGet_call> resultHandler) |
void |
scannerGetList(int id,
int nbRows,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerGetList_call> resultHandler) |
void |
scannerOpen(ByteBuffer tableName,
ByteBuffer startRow,
List<ByteBuffer> columns,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerOpen_call> resultHandler) |
void |
scannerOpenTs(ByteBuffer tableName,
ByteBuffer startRow,
List<ByteBuffer> columns,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerOpenTs_call> resultHandler) |
void |
scannerOpenWithPrefix(ByteBuffer tableName,
ByteBuffer startAndPrefix,
List<ByteBuffer> columns,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithPrefix_call> resultHandler) |
void |
scannerOpenWithScan(ByteBuffer tableName,
TScan scan,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithScan_call> resultHandler) |
void |
scannerOpenWithStop(ByteBuffer tableName,
ByteBuffer startRow,
ByteBuffer stopRow,
List<ByteBuffer> columns,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStop_call> resultHandler) |
void |
scannerOpenWithStopTs(ByteBuffer tableName,
ByteBuffer startRow,
ByteBuffer stopRow,
List<ByteBuffer> columns,
long timestamp,
Map<ByteBuffer,ByteBuffer> attributes,
org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStopTs_call> resultHandler) |
public Hbase.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<Hbase.AsyncClient.enableTable_call> resultHandler) throws org.apache.thrift.TException
enableTable
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void disableTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.disableTable_call> resultHandler) throws org.apache.thrift.TException
disableTable
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void isTableEnabled(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.isTableEnabled_call> resultHandler) throws org.apache.thrift.TException
isTableEnabled
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void compact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.compact_call> resultHandler) throws org.apache.thrift.TException
compact
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void majorCompact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.majorCompact_call> resultHandler) throws org.apache.thrift.TException
majorCompact
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getTableNames(org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getTableNames_call> resultHandler) throws org.apache.thrift.TException
getTableNames
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getColumnDescriptors(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getColumnDescriptors_call> resultHandler) throws org.apache.thrift.TException
getColumnDescriptors
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getTableRegions(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getTableRegions_call> resultHandler) throws org.apache.thrift.TException
getTableRegions
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void createTable(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.createTable_call> resultHandler) throws org.apache.thrift.TException
createTable
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void deleteTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.deleteTable_call> resultHandler) throws org.apache.thrift.TException
deleteTable
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.get_call> resultHandler) throws org.apache.thrift.TException
get
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getVer_call> resultHandler) throws org.apache.thrift.TException
getVer
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getVerTs_call> resultHandler) throws org.apache.thrift.TException
getVerTs
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRow_call> resultHandler) throws org.apache.thrift.TException
getRow
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumns_call> resultHandler) throws org.apache.thrift.TException
getRowWithColumns
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowTs_call> resultHandler) throws org.apache.thrift.TException
getRowTs
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumnsTs_call> resultHandler) throws org.apache.thrift.TException
getRowWithColumnsTs
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getRows(ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRows_call> resultHandler) throws org.apache.thrift.TException
getRows
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumns_call> resultHandler) throws org.apache.thrift.TException
getRowsWithColumns
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowsTs_call> resultHandler) throws org.apache.thrift.TException
getRowsTs
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumnsTs_call> resultHandler) throws org.apache.thrift.TException
getRowsWithColumnsTs
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRow_call> resultHandler) throws org.apache.thrift.TException
mutateRow
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRowTs_call> resultHandler) throws org.apache.thrift.TException
mutateRowTs
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRows_call> resultHandler) throws org.apache.thrift.TException
mutateRows
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.mutateRowsTs_call> resultHandler) throws org.apache.thrift.TException
mutateRowsTs
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void atomicIncrement(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.atomicIncrement_call> resultHandler) throws org.apache.thrift.TException
atomicIncrement
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.deleteAll_call> resultHandler) throws org.apache.thrift.TException
deleteAll
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.deleteAllTs_call> resultHandler) throws org.apache.thrift.TException
deleteAllTs
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.deleteAllRow_call> resultHandler) throws org.apache.thrift.TException
deleteAllRow
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void increment(TIncrement increment, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.increment_call> resultHandler) throws org.apache.thrift.TException
increment
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void incrementRows(List<TIncrement> increments, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.incrementRows_call> resultHandler) throws org.apache.thrift.TException
incrementRows
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.deleteAllRowTs_call> resultHandler) throws org.apache.thrift.TException
deleteAllRowTs
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void scannerOpenWithScan(ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithScan_call> resultHandler) throws org.apache.thrift.TException
scannerOpenWithScan
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void scannerOpen(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerOpen_call> resultHandler) throws org.apache.thrift.TException
scannerOpen
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void scannerOpenWithStop(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStop_call> resultHandler) throws org.apache.thrift.TException
scannerOpenWithStop
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void scannerOpenWithPrefix(ByteBuffer tableName, ByteBuffer startAndPrefix, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithPrefix_call> resultHandler) throws org.apache.thrift.TException
scannerOpenWithPrefix
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void scannerOpenTs(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerOpenTs_call> resultHandler) throws org.apache.thrift.TException
scannerOpenTs
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void scannerOpenWithStopTs(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStopTs_call> resultHandler) throws org.apache.thrift.TException
scannerOpenWithStopTs
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void scannerGet(int id, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerGet_call> resultHandler) throws org.apache.thrift.TException
scannerGet
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void scannerGetList(int id, int nbRows, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerGetList_call> resultHandler) throws org.apache.thrift.TException
scannerGetList
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void scannerClose(int id, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.scannerClose_call> resultHandler) throws org.apache.thrift.TException
scannerClose
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getRowOrBefore(ByteBuffer tableName, ByteBuffer row, ByteBuffer family, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRowOrBefore_call> resultHandler) throws org.apache.thrift.TException
getRowOrBefore
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getRegionInfo(ByteBuffer row, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.getRegionInfo_call> resultHandler) throws org.apache.thrift.TException
getRegionInfo
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void append(TAppend append, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.append_call> resultHandler) throws org.apache.thrift.TException
append
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void checkAndPut(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer value, Mutation mput, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback<Hbase.AsyncClient.checkAndPut_call> resultHandler) throws org.apache.thrift.TException
checkAndPut
in interface Hbase.AsyncIface
org.apache.thrift.TException
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.