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 |
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.AsyncIface
org.apache.thrift.TException
public void disableTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback 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 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 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 resultHandler) throws org.apache.thrift.TException
majorCompact
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getTableNames(org.apache.thrift.async.AsyncMethodCallback 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 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 resultHandler) throws org.apache.thrift.TException
scannerClose
in interface Hbase.AsyncIface
org.apache.thrift.TException
public void getRegionInfo(ByteBuffer row, org.apache.thrift.async.AsyncMethodCallback 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 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 resultHandler) throws org.apache.thrift.TException
checkAndPut
in interface Hbase.AsyncIface
org.apache.thrift.TException
Copyright © 2007–2019 Cloudera. All rights reserved.