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 |
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.TException
void disableTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void isTableEnabled(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void compact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void majorCompact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void getTableNames(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void getColumnDescriptors(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void getTableRegions(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void createTable(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void deleteTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void 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.TException
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
org.apache.thrift.TException
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
org.apache.thrift.TException
void getRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void 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.TException
void 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.TException
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
org.apache.thrift.TException
void getRows(ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
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
org.apache.thrift.TException
void 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.TException
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
org.apache.thrift.TException
void 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.TException
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
org.apache.thrift.TException
void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void 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.TException
void atomicIncrement(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void 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.TException
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
org.apache.thrift.TException
void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void increment(TIncrement increment, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void incrementRows(List<TIncrement> increments, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void 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.TException
void scannerOpenWithScan(ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void 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.TException
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
org.apache.thrift.TException
void 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.TException
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
org.apache.thrift.TException
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
org.apache.thrift.TException
void scannerGet(int id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void scannerGetList(int id, int nbRows, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void scannerClose(int id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void getRegionInfo(ByteBuffer row, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
void append(TAppend append, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException
org.apache.thrift.TException
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
org.apache.thrift.TException
Copyright © 2007–2019 Cloudera. All rights reserved.