public static class Hbase.Client extends org.apache.thrift.TServiceClient implements Hbase.Iface
| Modifier and Type | Class and Description |
|---|---|
static class |
Hbase.Client.Factory |
| Constructor and Description |
|---|
Client(org.apache.thrift.protocol.TProtocol prot) |
Client(org.apache.thrift.protocol.TProtocol iprot,
org.apache.thrift.protocol.TProtocol oprot) |
| Modifier and Type | Method and Description |
|---|---|
java.util.List<TCell> |
append(TAppend append)
Appends values to one or more columns within a single row.
|
long |
atomicIncrement(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
long value)
Atomically increment the column value specified.
|
boolean |
checkAndPut(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
java.nio.ByteBuffer value,
Mutation mput,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Atomically checks if a row/family/qualifier value matches the expected
value.
|
void |
compact(java.nio.ByteBuffer tableNameOrRegionName) |
void |
createTable(java.nio.ByteBuffer tableName,
java.util.List<ColumnDescriptor> columnFamilies)
Create a table with the specified column families.
|
void |
deleteAll(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Delete all cells that match the passed row and column.
|
void |
deleteAllRow(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Completely delete the row's cells.
|
void |
deleteAllRowTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Completely delete the row's cells marked with a timestamp
equal-to or older than the passed timestamp.
|
void |
deleteAllTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Delete all cells that match the passed row and column and whose
timestamp is equal-to or older than the passed timestamp.
|
void |
deleteTable(java.nio.ByteBuffer tableName)
Deletes a table
|
void |
disableTable(java.nio.ByteBuffer tableName)
Disables a table (takes it off-line) If it is being served, the master
will tell the servers to stop serving it.
|
void |
enableTable(java.nio.ByteBuffer tableName)
Brings a table on-line (enables it)
|
java.util.List<TCell> |
get(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get a single TCell for the specified table, row, and column at the
latest timestamp.
|
java.util.Map<java.nio.ByteBuffer,ColumnDescriptor> |
getColumnDescriptors(java.nio.ByteBuffer tableName)
List all the column families assoicated with a table.
|
TRegionInfo |
getRegionInfo(java.nio.ByteBuffer row)
Get the regininfo for the specified row.
|
java.util.List<TRowResult> |
getRow(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get all the data for the specified table and row at the latest
timestamp.
|
java.util.List<TCell> |
getRowOrBefore(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer family)
Get the row just before the specified one.
|
java.util.List<TRowResult> |
getRows(java.nio.ByteBuffer tableName,
java.util.List<java.nio.ByteBuffer> rows,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get all the data for the specified table and rows at the latest
timestamp.
|
java.util.List<TRowResult> |
getRowsTs(java.nio.ByteBuffer tableName,
java.util.List<java.nio.ByteBuffer> rows,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get all the data for the specified table and rows at the specified
timestamp.
|
java.util.List<TRowResult> |
getRowsWithColumns(java.nio.ByteBuffer tableName,
java.util.List<java.nio.ByteBuffer> rows,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get the specified columns for the specified table and rows at the latest
timestamp.
|
java.util.List<TRowResult> |
getRowsWithColumnsTs(java.nio.ByteBuffer tableName,
java.util.List<java.nio.ByteBuffer> rows,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get the specified columns for the specified table and rows at the specified
timestamp.
|
java.util.List<TRowResult> |
getRowTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get all the data for the specified table and row at the specified
timestamp.
|
java.util.List<TRowResult> |
getRowWithColumns(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get the specified columns for the specified table and row at the latest
timestamp.
|
java.util.List<TRowResult> |
getRowWithColumnsTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get the specified columns for the specified table and row at the specified
timestamp.
|
java.util.List<java.nio.ByteBuffer> |
getTableNames()
List all the userspace tables.
|
java.util.List<TRegionInfo> |
getTableRegions(java.nio.ByteBuffer tableName)
List the regions associated with a table.
|
java.util.List<TCell> |
getVer(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
int numVersions,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get the specified number of versions for the specified table,
row, and column.
|
java.util.List<TCell> |
getVerTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
long timestamp,
int numVersions,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get the specified number of versions for the specified table,
row, and column.
|
void |
increment(TIncrement increment)
Increment a cell by the ammount.
|
void |
incrementRows(java.util.List<TIncrement> increments) |
boolean |
isTableEnabled(java.nio.ByteBuffer tableName) |
void |
majorCompact(java.nio.ByteBuffer tableNameOrRegionName) |
void |
mutateRow(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<Mutation> mutations,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Apply a series of mutations (updates/deletes) to a row in a
single transaction.
|
void |
mutateRows(java.nio.ByteBuffer tableName,
java.util.List<BatchMutation> rowBatches,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Apply a series of batches (each a series of mutations on a single row)
in a single transaction.
|
void |
mutateRowsTs(java.nio.ByteBuffer tableName,
java.util.List<BatchMutation> rowBatches,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Apply a series of batches (each a series of mutations on a single row)
in a single transaction.
|
void |
mutateRowTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<Mutation> mutations,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Apply a series of mutations (updates/deletes) to a row in a
single transaction.
|
java.util.List<TCell> |
recv_append() |
long |
recv_atomicIncrement() |
boolean |
recv_checkAndPut() |
void |
recv_compact() |
void |
recv_createTable() |
void |
recv_deleteAll() |
void |
recv_deleteAllRow() |
void |
recv_deleteAllRowTs() |
void |
recv_deleteAllTs() |
void |
recv_deleteTable() |
void |
recv_disableTable() |
void |
recv_enableTable() |
java.util.List<TCell> |
recv_get() |
java.util.Map<java.nio.ByteBuffer,ColumnDescriptor> |
recv_getColumnDescriptors() |
TRegionInfo |
recv_getRegionInfo() |
java.util.List<TRowResult> |
recv_getRow() |
java.util.List<TCell> |
recv_getRowOrBefore() |
java.util.List<TRowResult> |
recv_getRows() |
java.util.List<TRowResult> |
recv_getRowsTs() |
java.util.List<TRowResult> |
recv_getRowsWithColumns() |
java.util.List<TRowResult> |
recv_getRowsWithColumnsTs() |
java.util.List<TRowResult> |
recv_getRowTs() |
java.util.List<TRowResult> |
recv_getRowWithColumns() |
java.util.List<TRowResult> |
recv_getRowWithColumnsTs() |
java.util.List<java.nio.ByteBuffer> |
recv_getTableNames() |
java.util.List<TRegionInfo> |
recv_getTableRegions() |
java.util.List<TCell> |
recv_getVer() |
java.util.List<TCell> |
recv_getVerTs() |
void |
recv_increment() |
void |
recv_incrementRows() |
boolean |
recv_isTableEnabled() |
void |
recv_majorCompact() |
void |
recv_mutateRow() |
void |
recv_mutateRows() |
void |
recv_mutateRowsTs() |
void |
recv_mutateRowTs() |
void |
recv_scannerClose() |
java.util.List<TRowResult> |
recv_scannerGet() |
java.util.List<TRowResult> |
recv_scannerGetList() |
int |
recv_scannerOpen() |
int |
recv_scannerOpenTs() |
int |
recv_scannerOpenWithPrefix() |
int |
recv_scannerOpenWithScan() |
int |
recv_scannerOpenWithStop() |
int |
recv_scannerOpenWithStopTs() |
void |
scannerClose(int id)
Closes the server-state associated with an open scanner.
|
java.util.List<TRowResult> |
scannerGet(int id)
Returns the scanner's current row value and advances to the next
row in the table.
|
java.util.List<TRowResult> |
scannerGetList(int id,
int nbRows)
Returns, starting at the scanner's current row value nbRows worth of
rows and advances to the next row in the table.
|
int |
scannerOpen(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get a scanner on the current table starting at the specified row and
ending at the last row in the table.
|
int |
scannerOpenTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get a scanner on the current table starting at the specified row and
ending at the last row in the table.
|
int |
scannerOpenWithPrefix(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startAndPrefix,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Open a scanner for a given prefix.
|
int |
scannerOpenWithScan(java.nio.ByteBuffer tableName,
TScan scan,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get a scanner on the current table, using the Scan instance
for the scan parameters.
|
int |
scannerOpenWithStop(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.nio.ByteBuffer stopRow,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get a scanner on the current table starting and stopping at the
specified rows.
|
int |
scannerOpenWithStopTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.nio.ByteBuffer stopRow,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
Get a scanner on the current table starting and stopping at the
specified rows.
|
void |
send_append(TAppend append) |
void |
send_atomicIncrement(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
long value) |
void |
send_checkAndPut(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
java.nio.ByteBuffer value,
Mutation mput,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_compact(java.nio.ByteBuffer tableNameOrRegionName) |
void |
send_createTable(java.nio.ByteBuffer tableName,
java.util.List<ColumnDescriptor> columnFamilies) |
void |
send_deleteAll(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_deleteAllRow(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_deleteAllRowTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_deleteAllTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_deleteTable(java.nio.ByteBuffer tableName) |
void |
send_disableTable(java.nio.ByteBuffer tableName) |
void |
send_enableTable(java.nio.ByteBuffer tableName) |
void |
send_get(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_getColumnDescriptors(java.nio.ByteBuffer tableName) |
void |
send_getRegionInfo(java.nio.ByteBuffer row) |
void |
send_getRow(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_getRowOrBefore(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer family) |
void |
send_getRows(java.nio.ByteBuffer tableName,
java.util.List<java.nio.ByteBuffer> rows,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_getRowsTs(java.nio.ByteBuffer tableName,
java.util.List<java.nio.ByteBuffer> rows,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_getRowsWithColumns(java.nio.ByteBuffer tableName,
java.util.List<java.nio.ByteBuffer> rows,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_getRowsWithColumnsTs(java.nio.ByteBuffer tableName,
java.util.List<java.nio.ByteBuffer> rows,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_getRowTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_getRowWithColumns(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_getRowWithColumnsTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_getTableNames() |
void |
send_getTableRegions(java.nio.ByteBuffer tableName) |
void |
send_getVer(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
int numVersions,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_getVerTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
long timestamp,
int numVersions,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_increment(TIncrement increment) |
void |
send_incrementRows(java.util.List<TIncrement> increments) |
void |
send_isTableEnabled(java.nio.ByteBuffer tableName) |
void |
send_majorCompact(java.nio.ByteBuffer tableNameOrRegionName) |
void |
send_mutateRow(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<Mutation> mutations,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_mutateRows(java.nio.ByteBuffer tableName,
java.util.List<BatchMutation> rowBatches,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_mutateRowsTs(java.nio.ByteBuffer tableName,
java.util.List<BatchMutation> rowBatches,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_mutateRowTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<Mutation> mutations,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_scannerClose(int id) |
void |
send_scannerGet(int id) |
void |
send_scannerGetList(int id,
int nbRows) |
void |
send_scannerOpen(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_scannerOpenTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_scannerOpenWithPrefix(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startAndPrefix,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_scannerOpenWithScan(java.nio.ByteBuffer tableName,
TScan scan,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_scannerOpenWithStop(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.nio.ByteBuffer stopRow,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
void |
send_scannerOpenWithStopTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.nio.ByteBuffer stopRow,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) |
public Client(org.apache.thrift.protocol.TProtocol prot)
public Client(org.apache.thrift.protocol.TProtocol iprot,
org.apache.thrift.protocol.TProtocol oprot)
public void enableTable(java.nio.ByteBuffer tableName)
throws IOError,
org.apache.thrift.TException
Hbase.IfaceenableTable in interface Hbase.IfacetableName - name of the tableIOErrororg.apache.thrift.TExceptionpublic void send_enableTable(java.nio.ByteBuffer tableName)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_enableTable()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void disableTable(java.nio.ByteBuffer tableName)
throws IOError,
org.apache.thrift.TException
Hbase.IfacedisableTable in interface Hbase.IfacetableName - name of the tableIOErrororg.apache.thrift.TExceptionpublic void send_disableTable(java.nio.ByteBuffer tableName)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_disableTable()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic boolean isTableEnabled(java.nio.ByteBuffer tableName)
throws IOError,
org.apache.thrift.TException
isTableEnabled in interface Hbase.IfacetableName - name of the table to checkIOErrororg.apache.thrift.TExceptionpublic void send_isTableEnabled(java.nio.ByteBuffer tableName)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic boolean recv_isTableEnabled()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void compact(java.nio.ByteBuffer tableNameOrRegionName)
throws IOError,
org.apache.thrift.TException
compact in interface Hbase.IfaceIOErrororg.apache.thrift.TExceptionpublic void send_compact(java.nio.ByteBuffer tableNameOrRegionName)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_compact()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void majorCompact(java.nio.ByteBuffer tableNameOrRegionName)
throws IOError,
org.apache.thrift.TException
majorCompact in interface Hbase.IfaceIOErrororg.apache.thrift.TExceptionpublic void send_majorCompact(java.nio.ByteBuffer tableNameOrRegionName)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_majorCompact()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<java.nio.ByteBuffer> getTableNames()
throws IOError,
org.apache.thrift.TException
Hbase.IfacegetTableNames in interface Hbase.IfaceIOErrororg.apache.thrift.TExceptionpublic void send_getTableNames()
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<java.nio.ByteBuffer> recv_getTableNames()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.Map<java.nio.ByteBuffer,ColumnDescriptor> getColumnDescriptors(java.nio.ByteBuffer tableName) throws IOError, org.apache.thrift.TException
Hbase.IfacegetColumnDescriptors in interface Hbase.IfacetableName - table nameIOErrororg.apache.thrift.TExceptionpublic void send_getColumnDescriptors(java.nio.ByteBuffer tableName)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.Map<java.nio.ByteBuffer,ColumnDescriptor> recv_getColumnDescriptors() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TRegionInfo> getTableRegions(java.nio.ByteBuffer tableName) throws IOError, org.apache.thrift.TException
Hbase.IfacegetTableRegions in interface Hbase.IfacetableName - table nameIOErrororg.apache.thrift.TExceptionpublic void send_getTableRegions(java.nio.ByteBuffer tableName)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TRegionInfo> recv_getTableRegions() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void createTable(java.nio.ByteBuffer tableName,
java.util.List<ColumnDescriptor> columnFamilies)
throws IOError,
IllegalArgument,
AlreadyExists,
org.apache.thrift.TException
Hbase.IfacecreateTable in interface Hbase.IfacetableName - name of table to createcolumnFamilies - list of column family descriptorsIllegalArgument - if an input parameter is invalidAlreadyExists - if the table name already existsIOErrororg.apache.thrift.TExceptionpublic void send_createTable(java.nio.ByteBuffer tableName,
java.util.List<ColumnDescriptor> columnFamilies)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_createTable()
throws IOError,
IllegalArgument,
AlreadyExists,
org.apache.thrift.TException
IOErrorIllegalArgumentAlreadyExistsorg.apache.thrift.TExceptionpublic void deleteTable(java.nio.ByteBuffer tableName)
throws IOError,
org.apache.thrift.TException
Hbase.IfacedeleteTable in interface Hbase.IfacetableName - name of table to deleteIOError - if table doesn't exist on server or there was some other
problemorg.apache.thrift.TExceptionpublic void send_deleteTable(java.nio.ByteBuffer tableName)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_deleteTable()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TCell> get(java.nio.ByteBuffer tableName, java.nio.ByteBuffer row, java.nio.ByteBuffer column, java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.Ifaceget in interface Hbase.IfacetableName - name of tablerow - row keycolumn - column nameattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_get(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TCell> recv_get() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TCell> getVer(java.nio.ByteBuffer tableName, java.nio.ByteBuffer row, java.nio.ByteBuffer column, int numVersions, java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetVer in interface Hbase.IfacetableName - name of tablerow - row keycolumn - column namenumVersions - number of versions to retrieveattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getVer(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
int numVersions,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TCell> recv_getVer() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TCell> getVerTs(java.nio.ByteBuffer tableName, java.nio.ByteBuffer row, java.nio.ByteBuffer column, long timestamp, int numVersions, java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetVerTs in interface Hbase.IfacetableName - name of tablerow - row keycolumn - column nametimestamp - timestampnumVersions - number of versions to retrieveattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getVerTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
long timestamp,
int numVersions,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TCell> recv_getVerTs() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TRowResult> getRow(java.nio.ByteBuffer tableName, java.nio.ByteBuffer row, java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRow in interface Hbase.IfacetableName - name of tablerow - row keyattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRow(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TRowResult> recv_getRow() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TRowResult> getRowWithColumns(java.nio.ByteBuffer tableName, java.nio.ByteBuffer row, java.util.List<java.nio.ByteBuffer> columns, java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowWithColumns in interface Hbase.IfacetableName - name of tablerow - row keycolumns - List of columns to return, null for all columnsattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRowWithColumns(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TRowResult> recv_getRowWithColumns() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TRowResult> getRowTs(java.nio.ByteBuffer tableName, java.nio.ByteBuffer row, long timestamp, java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowTs in interface Hbase.IfacetableName - name of the tablerow - row keytimestamp - timestampattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRowTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TRowResult> recv_getRowTs() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TRowResult> getRowWithColumnsTs(java.nio.ByteBuffer tableName, java.nio.ByteBuffer row, java.util.List<java.nio.ByteBuffer> columns, long timestamp, java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowWithColumnsTs in interface Hbase.IfacetableName - name of tablerow - row keycolumns - List of columns to return, null for all columnsattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRowWithColumnsTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TRowResult> recv_getRowWithColumnsTs() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TRowResult> getRows(java.nio.ByteBuffer tableName, java.util.List<java.nio.ByteBuffer> rows, java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRows in interface Hbase.IfacetableName - name of tablerows - row keysattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRows(java.nio.ByteBuffer tableName,
java.util.List<java.nio.ByteBuffer> rows,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TRowResult> recv_getRows() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TRowResult> getRowsWithColumns(java.nio.ByteBuffer tableName, java.util.List<java.nio.ByteBuffer> rows, java.util.List<java.nio.ByteBuffer> columns, java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowsWithColumns in interface Hbase.IfacetableName - name of tablerows - row keyscolumns - List of columns to return, null for all columnsattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRowsWithColumns(java.nio.ByteBuffer tableName,
java.util.List<java.nio.ByteBuffer> rows,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TRowResult> recv_getRowsWithColumns() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TRowResult> getRowsTs(java.nio.ByteBuffer tableName, java.util.List<java.nio.ByteBuffer> rows, long timestamp, java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowsTs in interface Hbase.IfacetableName - name of the tablerows - row keystimestamp - timestampattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRowsTs(java.nio.ByteBuffer tableName,
java.util.List<java.nio.ByteBuffer> rows,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TRowResult> recv_getRowsTs() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TRowResult> getRowsWithColumnsTs(java.nio.ByteBuffer tableName, java.util.List<java.nio.ByteBuffer> rows, java.util.List<java.nio.ByteBuffer> columns, long timestamp, java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowsWithColumnsTs in interface Hbase.IfacetableName - name of tablerows - row keyscolumns - List of columns to return, null for all columnsattributes - Get attributesIOErrororg.apache.thrift.TExceptionpublic void send_getRowsWithColumnsTs(java.nio.ByteBuffer tableName,
java.util.List<java.nio.ByteBuffer> rows,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TRowResult> recv_getRowsWithColumnsTs() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void mutateRow(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<Mutation> mutations,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
IllegalArgument,
org.apache.thrift.TException
Hbase.IfacemutateRow in interface Hbase.IfacetableName - name of tablerow - row keymutations - list of mutation commandsattributes - Mutation attributesIOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void send_mutateRow(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<Mutation> mutations,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_mutateRow()
throws IOError,
IllegalArgument,
org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void mutateRowTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<Mutation> mutations,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
IllegalArgument,
org.apache.thrift.TException
Hbase.IfacemutateRowTs in interface Hbase.IfacetableName - name of tablerow - row keymutations - list of mutation commandstimestamp - timestampattributes - Mutation attributesIOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void send_mutateRowTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.List<Mutation> mutations,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_mutateRowTs()
throws IOError,
IllegalArgument,
org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void mutateRows(java.nio.ByteBuffer tableName,
java.util.List<BatchMutation> rowBatches,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
IllegalArgument,
org.apache.thrift.TException
Hbase.IfacemutateRows in interface Hbase.IfacetableName - name of tablerowBatches - list of row batchesattributes - Mutation attributesIOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void send_mutateRows(java.nio.ByteBuffer tableName,
java.util.List<BatchMutation> rowBatches,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_mutateRows()
throws IOError,
IllegalArgument,
org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void mutateRowsTs(java.nio.ByteBuffer tableName,
java.util.List<BatchMutation> rowBatches,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
IllegalArgument,
org.apache.thrift.TException
Hbase.IfacemutateRowsTs in interface Hbase.IfacetableName - name of tablerowBatches - list of row batchestimestamp - timestampattributes - Mutation attributesIOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void send_mutateRowsTs(java.nio.ByteBuffer tableName,
java.util.List<BatchMutation> rowBatches,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_mutateRowsTs()
throws IOError,
IllegalArgument,
org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic long atomicIncrement(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
long value)
throws IOError,
IllegalArgument,
org.apache.thrift.TException
Hbase.IfaceatomicIncrement in interface Hbase.IfacetableName - name of tablerow - row to incrementcolumn - name of columnvalue - amount to increment byIOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void send_atomicIncrement(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
long value)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic long recv_atomicIncrement()
throws IOError,
IllegalArgument,
org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void deleteAll(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
org.apache.thrift.TException
Hbase.IfacedeleteAll in interface Hbase.IfacetableName - name of tablerow - Row to updatecolumn - name of column whose value is to be deletedattributes - Delete attributesIOErrororg.apache.thrift.TExceptionpublic void send_deleteAll(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_deleteAll()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void deleteAllTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
org.apache.thrift.TException
Hbase.IfacedeleteAllTs in interface Hbase.IfacetableName - name of tablerow - Row to updatecolumn - name of column whose value is to be deletedtimestamp - timestampattributes - Delete attributesIOErrororg.apache.thrift.TExceptionpublic void send_deleteAllTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_deleteAllTs()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void deleteAllRow(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
org.apache.thrift.TException
Hbase.IfacedeleteAllRow in interface Hbase.IfacetableName - name of tablerow - key of the row to be completely deleted.attributes - Delete attributesIOErrororg.apache.thrift.TExceptionpublic void send_deleteAllRow(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_deleteAllRow()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void increment(TIncrement increment) throws IOError, org.apache.thrift.TException
Hbase.Ifaceincrement in interface Hbase.Ifaceincrement - The single increment to applyIOErrororg.apache.thrift.TExceptionpublic void send_increment(TIncrement increment) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_increment()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void incrementRows(java.util.List<TIncrement> increments) throws IOError, org.apache.thrift.TException
incrementRows in interface Hbase.IfaceIOErrororg.apache.thrift.TExceptionpublic void send_incrementRows(java.util.List<TIncrement> increments) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_incrementRows()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic void deleteAllRowTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
org.apache.thrift.TException
Hbase.IfacedeleteAllRowTs in interface Hbase.IfacetableName - name of tablerow - key of the row to be completely deleted.timestamp - timestampattributes - Delete attributesIOErrororg.apache.thrift.TExceptionpublic void send_deleteAllRowTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_deleteAllRowTs()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic int scannerOpenWithScan(java.nio.ByteBuffer tableName,
TScan scan,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
org.apache.thrift.TException
Hbase.IfacescannerOpenWithScan in interface Hbase.IfacetableName - name of tablescan - Scan instanceattributes - Scan attributesIOErrororg.apache.thrift.TExceptionpublic void send_scannerOpenWithScan(java.nio.ByteBuffer tableName,
TScan scan,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic int recv_scannerOpenWithScan()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic int scannerOpen(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
org.apache.thrift.TException
Hbase.IfacescannerOpen in interface Hbase.IfacetableName - name of tablestartRow - Starting row in table to scan.
Send "" (empty string) to start at the first row.columns - columns to scan. If column name is a column family, all
columns of the specified column family are returned. It's also possible
to pass a regex in the column qualifier.attributes - Scan attributesIOErrororg.apache.thrift.TExceptionpublic void send_scannerOpen(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic int recv_scannerOpen()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic int scannerOpenWithStop(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.nio.ByteBuffer stopRow,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
org.apache.thrift.TException
Hbase.IfacescannerOpenWithStop in interface Hbase.IfacetableName - name of tablestartRow - Starting row in table to scan.
Send "" (empty string) to start at the first row.stopRow - row to stop scanning on. This row is *not* included in the
scanner's resultscolumns - columns to scan. If column name is a column family, all
columns of the specified column family are returned. It's also possible
to pass a regex in the column qualifier.attributes - Scan attributesIOErrororg.apache.thrift.TExceptionpublic void send_scannerOpenWithStop(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.nio.ByteBuffer stopRow,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic int recv_scannerOpenWithStop()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic int scannerOpenWithPrefix(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startAndPrefix,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
org.apache.thrift.TException
Hbase.IfacescannerOpenWithPrefix in interface Hbase.IfacetableName - name of tablestartAndPrefix - the prefix (and thus start row) of the keys you wantcolumns - the columns you want returnedattributes - Scan attributesIOErrororg.apache.thrift.TExceptionpublic void send_scannerOpenWithPrefix(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startAndPrefix,
java.util.List<java.nio.ByteBuffer> columns,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic int recv_scannerOpenWithPrefix()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic int scannerOpenTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
org.apache.thrift.TException
Hbase.IfacescannerOpenTs in interface Hbase.IfacetableName - name of tablestartRow - Starting row in table to scan.
Send "" (empty string) to start at the first row.columns - columns to scan. If column name is a column family, all
columns of the specified column family are returned. It's also possible
to pass a regex in the column qualifier.timestamp - timestampattributes - Scan attributesIOErrororg.apache.thrift.TExceptionpublic void send_scannerOpenTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic int recv_scannerOpenTs()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic int scannerOpenWithStopTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.nio.ByteBuffer stopRow,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
org.apache.thrift.TException
Hbase.IfacescannerOpenWithStopTs in interface Hbase.IfacetableName - name of tablestartRow - Starting row in table to scan.
Send "" (empty string) to start at the first row.stopRow - row to stop scanning on. This row is *not* included in the
scanner's resultscolumns - columns to scan. If column name is a column family, all
columns of the specified column family are returned. It's also possible
to pass a regex in the column qualifier.timestamp - timestampattributes - Scan attributesIOErrororg.apache.thrift.TExceptionpublic void send_scannerOpenWithStopTs(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer startRow,
java.nio.ByteBuffer stopRow,
java.util.List<java.nio.ByteBuffer> columns,
long timestamp,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic int recv_scannerOpenWithStopTs()
throws IOError,
org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TRowResult> scannerGet(int id) throws IOError, IllegalArgument, org.apache.thrift.TException
Hbase.IfacescannerGet in interface Hbase.Ifaceid - id of a scanner returned by scannerOpenIllegalArgument - if ScannerID is invalidIOErrororg.apache.thrift.TExceptionpublic void send_scannerGet(int id)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TRowResult> recv_scannerGet() throws IOError, IllegalArgument, org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic java.util.List<TRowResult> scannerGetList(int id, int nbRows) throws IOError, IllegalArgument, org.apache.thrift.TException
Hbase.IfacescannerGetList in interface Hbase.Ifaceid - id of a scanner returned by scannerOpennbRows - number of results to returnIllegalArgument - if ScannerID is invalidIOErrororg.apache.thrift.TExceptionpublic void send_scannerGetList(int id,
int nbRows)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TRowResult> recv_scannerGetList() throws IOError, IllegalArgument, org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void scannerClose(int id)
throws IOError,
IllegalArgument,
org.apache.thrift.TException
Hbase.IfacescannerClose in interface Hbase.Ifaceid - id of a scanner returned by scannerOpenIllegalArgument - if ScannerID is invalidIOErrororg.apache.thrift.TExceptionpublic void send_scannerClose(int id)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic void recv_scannerClose()
throws IOError,
IllegalArgument,
org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic java.util.List<TCell> getRowOrBefore(java.nio.ByteBuffer tableName, java.nio.ByteBuffer row, java.nio.ByteBuffer family) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRowOrBefore in interface Hbase.IfacetableName - name of tablerow - row keyfamily - column nameIOErrororg.apache.thrift.TExceptionpublic void send_getRowOrBefore(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer family)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TCell> recv_getRowOrBefore() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic TRegionInfo getRegionInfo(java.nio.ByteBuffer row) throws IOError, org.apache.thrift.TException
Hbase.IfacegetRegionInfo in interface Hbase.Ifacerow - row keyIOErrororg.apache.thrift.TExceptionpublic void send_getRegionInfo(java.nio.ByteBuffer row)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic TRegionInfo recv_getRegionInfo() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic java.util.List<TCell> append(TAppend append) throws IOError, org.apache.thrift.TException
Hbase.Ifaceappend in interface Hbase.Ifaceappend - The single append operation to applyIOErrororg.apache.thrift.TExceptionpublic void send_append(TAppend append) throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic java.util.List<TCell> recv_append() throws IOError, org.apache.thrift.TException
IOErrororg.apache.thrift.TExceptionpublic boolean checkAndPut(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
java.nio.ByteBuffer value,
Mutation mput,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws IOError,
IllegalArgument,
org.apache.thrift.TException
Hbase.IfacecheckAndPut in interface Hbase.IfacetableName - name of tablerow - row keycolumn - column namevalue - the expected value for the column parameter, if not
provided the check is for the non-existence of the
column in questionmput - mutation for the putattributes - Mutation attributesIOErrorIllegalArgumentorg.apache.thrift.TExceptionpublic void send_checkAndPut(java.nio.ByteBuffer tableName,
java.nio.ByteBuffer row,
java.nio.ByteBuffer column,
java.nio.ByteBuffer value,
Mutation mput,
java.util.Map<java.nio.ByteBuffer,java.nio.ByteBuffer> attributes)
throws org.apache.thrift.TException
org.apache.thrift.TExceptionpublic boolean recv_checkAndPut()
throws IOError,
IllegalArgument,
org.apache.thrift.TException
IOErrorIllegalArgumentorg.apache.thrift.TException