public class RegionAsTable extends Object implements org.apache.hadoop.hbase.client.Table
Table that sits directly on a Region; it decorates the passed in
Region instance with the Table API. Some API is not implemented yet (throws
UnsupportedOperationException) mostly because no need as yet or it necessitates copying
a load of code local from RegionServer.
Use as an instance of a Table in-the-small -- no networking or servers
necessary -- or to write a test that can run directly against the datastore and then
over the network.
| Modifier and Type | Class and Description |
|---|---|
(package private) static class |
RegionAsTable.RegionScannerToResultScannerAdaptor |
| Modifier and Type | Field and Description |
|---|---|
private org.apache.hadoop.hbase.regionserver.Region |
region |
| Constructor and Description |
|---|
RegionAsTable(org.apache.hadoop.hbase.regionserver.Region region) |
| Modifier and Type | Method and Description |
|---|---|
org.apache.hadoop.hbase.client.Result |
append(org.apache.hadoop.hbase.client.Append append) |
void |
batch(List<? extends org.apache.hadoop.hbase.client.Row> actions,
Object[] results) |
<R> void |
batchCallback(List<? extends org.apache.hadoop.hbase.client.Row> actions,
Object[] results,
org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) |
<R extends com.google.protobuf.Message> |
batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor,
com.google.protobuf.Message request,
byte[] startKey,
byte[] endKey,
R responsePrototype) |
<R extends com.google.protobuf.Message> |
batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor,
com.google.protobuf.Message request,
byte[] startKey,
byte[] endKey,
R responsePrototype,
org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) |
boolean |
checkAndDelete(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
org.apache.hadoop.hbase.client.Delete delete) |
boolean |
checkAndDelete(byte[] row,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp,
byte[] value,
org.apache.hadoop.hbase.client.Delete delete)
Deprecated.
|
boolean |
checkAndDelete(byte[] row,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.CompareOperator compareOp,
byte[] value,
org.apache.hadoop.hbase.client.Delete delete)
Deprecated.
|
org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder |
checkAndMutate(byte[] row,
byte[] family) |
boolean |
checkAndMutate(byte[] row,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp,
byte[] value,
org.apache.hadoop.hbase.client.RowMutations mutation)
Deprecated.
|
boolean |
checkAndMutate(byte[] row,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.CompareOperator compareOp,
byte[] value,
org.apache.hadoop.hbase.client.RowMutations mutation)
Deprecated.
|
boolean |
checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
org.apache.hadoop.hbase.client.Put put)
Deprecated.
|
boolean |
checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp,
byte[] value,
org.apache.hadoop.hbase.client.Put put)
Deprecated.
|
boolean |
checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.CompareOperator compareOp,
byte[] value,
org.apache.hadoop.hbase.client.Put put)
Deprecated.
|
void |
close()
This call will NOT close the underlying region.
|
org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel |
coprocessorService(byte[] row) |
<T extends com.google.protobuf.Service,R> |
coprocessorService(Class<T> service,
byte[] startKey,
byte[] endKey,
org.apache.hadoop.hbase.client.coprocessor.Batch.Call<T,R> callable) |
<T extends com.google.protobuf.Service,R> |
coprocessorService(Class<T> service,
byte[] startKey,
byte[] endKey,
org.apache.hadoop.hbase.client.coprocessor.Batch.Call<T,R> callable,
org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) |
void |
delete(org.apache.hadoop.hbase.client.Delete delete) |
void |
delete(List<org.apache.hadoop.hbase.client.Delete> deletes) |
boolean |
exists(org.apache.hadoop.hbase.client.Get get) |
boolean[] |
exists(List<org.apache.hadoop.hbase.client.Get> gets) |
org.apache.hadoop.hbase.client.Result |
get(org.apache.hadoop.hbase.client.Get get) |
org.apache.hadoop.hbase.client.Result[] |
get(List<org.apache.hadoop.hbase.client.Get> gets) |
org.apache.hadoop.conf.Configuration |
getConfiguration() |
org.apache.hadoop.hbase.client.TableDescriptor |
getDescriptor() |
org.apache.hadoop.hbase.TableName |
getName() |
int |
getOperationTimeout()
Deprecated.
|
long |
getOperationTimeout(TimeUnit unit) |
int |
getReadRpcTimeout()
Deprecated.
|
long |
getReadRpcTimeout(TimeUnit unit) |
int |
getRpcTimeout()
Deprecated.
|
long |
getRpcTimeout(TimeUnit unit) |
org.apache.hadoop.hbase.client.ResultScanner |
getScanner(byte[] family) |
org.apache.hadoop.hbase.client.ResultScanner |
getScanner(byte[] family,
byte[] qualifier) |
org.apache.hadoop.hbase.client.ResultScanner |
getScanner(org.apache.hadoop.hbase.client.Scan scan) |
org.apache.hadoop.hbase.HTableDescriptor |
getTableDescriptor()
Deprecated.
|
int |
getWriteRpcTimeout()
Deprecated.
|
long |
getWriteRpcTimeout(TimeUnit unit) |
org.apache.hadoop.hbase.client.Result |
increment(org.apache.hadoop.hbase.client.Increment increment) |
long |
incrementColumnValue(byte[] row,
byte[] family,
byte[] qualifier,
long amount) |
long |
incrementColumnValue(byte[] row,
byte[] family,
byte[] qualifier,
long amount,
org.apache.hadoop.hbase.client.Durability durability) |
void |
mutateRow(org.apache.hadoop.hbase.client.RowMutations rm) |
void |
put(List<org.apache.hadoop.hbase.client.Put> puts) |
void |
put(org.apache.hadoop.hbase.client.Put put) |
void |
setOperationTimeout(int operationTimeout)
Deprecated.
|
void |
setReadRpcTimeout(int readRpcTimeout)
Deprecated.
|
void |
setRpcTimeout(int rpcTimeout)
Deprecated.
|
void |
setWriteRpcTimeout(int writeRpcTimeout)
Deprecated.
|
private final org.apache.hadoop.hbase.regionserver.Region region
public RegionAsTable(org.apache.hadoop.hbase.regionserver.Region region)
region - Region to decorate with Table API.public org.apache.hadoop.hbase.TableName getName()
getName in interface org.apache.hadoop.hbase.client.Tablepublic org.apache.hadoop.conf.Configuration getConfiguration()
getConfiguration in interface org.apache.hadoop.hbase.client.Table@Deprecated public org.apache.hadoop.hbase.HTableDescriptor getTableDescriptor() throws IOException
getTableDescriptor in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic org.apache.hadoop.hbase.client.TableDescriptor getDescriptor() throws IOException
getDescriptor in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic boolean exists(org.apache.hadoop.hbase.client.Get get) throws IOException
exists in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic boolean[] exists(List<org.apache.hadoop.hbase.client.Get> gets) throws IOException
exists in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic void batch(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results) throws IOException, InterruptedException
batch in interface org.apache.hadoop.hbase.client.TableIOExceptionInterruptedExceptionpublic <R> void batchCallback(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) throws IOException, InterruptedException
batchCallback in interface org.apache.hadoop.hbase.client.TableIOExceptionInterruptedExceptionpublic org.apache.hadoop.hbase.client.Result get(org.apache.hadoop.hbase.client.Get get) throws IOException
get in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic org.apache.hadoop.hbase.client.Result[] get(List<org.apache.hadoop.hbase.client.Get> gets) throws IOException
get in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic org.apache.hadoop.hbase.client.ResultScanner getScanner(org.apache.hadoop.hbase.client.Scan scan) throws IOException
getScanner in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic org.apache.hadoop.hbase.client.ResultScanner getScanner(byte[] family) throws IOException
getScanner in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic org.apache.hadoop.hbase.client.ResultScanner getScanner(byte[] family, byte[] qualifier) throws IOException
getScanner in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic void put(org.apache.hadoop.hbase.client.Put put) throws IOException
put in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic void put(List<org.apache.hadoop.hbase.client.Put> puts) throws IOException
put in interface org.apache.hadoop.hbase.client.TableIOException@Deprecated public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Put put) throws IOException
checkAndPut in interface org.apache.hadoop.hbase.client.TableIOException@Deprecated public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, byte[] value, org.apache.hadoop.hbase.client.Put put) throws IOException
checkAndPut in interface org.apache.hadoop.hbase.client.TableIOException@Deprecated public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator compareOp, byte[] value, org.apache.hadoop.hbase.client.Put put) throws IOException
checkAndPut in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic void delete(org.apache.hadoop.hbase.client.Delete delete) throws IOException
delete in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic void delete(List<org.apache.hadoop.hbase.client.Delete> deletes) throws IOException
delete in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Delete delete) throws IOException
checkAndDelete in interface org.apache.hadoop.hbase.client.TableIOException@Deprecated public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, byte[] value, org.apache.hadoop.hbase.client.Delete delete) throws IOException
checkAndDelete in interface org.apache.hadoop.hbase.client.TableIOException@Deprecated public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator compareOp, byte[] value, org.apache.hadoop.hbase.client.Delete delete) throws IOException
checkAndDelete in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder checkAndMutate(byte[] row, byte[] family)
checkAndMutate in interface org.apache.hadoop.hbase.client.Tablepublic void mutateRow(org.apache.hadoop.hbase.client.RowMutations rm) throws IOException
mutateRow in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic org.apache.hadoop.hbase.client.Result append(org.apache.hadoop.hbase.client.Append append) throws IOException
append in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic org.apache.hadoop.hbase.client.Result increment(org.apache.hadoop.hbase.client.Increment increment) throws IOException
increment in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic long incrementColumnValue(byte[] row, byte[] family, byte[] qualifier, long amount) throws IOException
incrementColumnValue in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic long incrementColumnValue(byte[] row, byte[] family, byte[] qualifier, long amount, org.apache.hadoop.hbase.client.Durability durability) throws IOException
incrementColumnValue in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic void close() throws IOException
close in interface Closeableclose in interface AutoCloseableclose in interface org.apache.hadoop.hbase.client.TableIOExceptionpublic org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel coprocessorService(byte[] row)
coprocessorService in interface org.apache.hadoop.hbase.client.Tablepublic <T extends com.google.protobuf.Service,R> Map<byte[],R> coprocessorService(Class<T> service, byte[] startKey, byte[] endKey, org.apache.hadoop.hbase.client.coprocessor.Batch.Call<T,R> callable) throws com.google.protobuf.ServiceException, Throwable
coprocessorService in interface org.apache.hadoop.hbase.client.Tablecom.google.protobuf.ServiceExceptionThrowablepublic <T extends com.google.protobuf.Service,R> void coprocessorService(Class<T> service, byte[] startKey, byte[] endKey, org.apache.hadoop.hbase.client.coprocessor.Batch.Call<T,R> callable, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) throws com.google.protobuf.ServiceException, Throwable
coprocessorService in interface org.apache.hadoop.hbase.client.Tablecom.google.protobuf.ServiceExceptionThrowablepublic <R extends com.google.protobuf.Message> Map<byte[],R> batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor, com.google.protobuf.Message request, byte[] startKey, byte[] endKey, R responsePrototype) throws com.google.protobuf.ServiceException, Throwable
batchCoprocessorService in interface org.apache.hadoop.hbase.client.Tablecom.google.protobuf.ServiceExceptionThrowablepublic <R extends com.google.protobuf.Message> void batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor, com.google.protobuf.Message request, byte[] startKey, byte[] endKey, R responsePrototype, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) throws com.google.protobuf.ServiceException, Throwable
batchCoprocessorService in interface org.apache.hadoop.hbase.client.Tablecom.google.protobuf.ServiceExceptionThrowable@Deprecated public boolean checkAndMutate(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, byte[] value, org.apache.hadoop.hbase.client.RowMutations mutation) throws IOException
checkAndMutate in interface org.apache.hadoop.hbase.client.TableIOException@Deprecated public boolean checkAndMutate(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator compareOp, byte[] value, org.apache.hadoop.hbase.client.RowMutations mutation) throws IOException
checkAndMutate in interface org.apache.hadoop.hbase.client.TableIOException@Deprecated public void setOperationTimeout(int operationTimeout)
setOperationTimeout in interface org.apache.hadoop.hbase.client.Table@Deprecated public int getOperationTimeout()
getOperationTimeout in interface org.apache.hadoop.hbase.client.Table@Deprecated public void setRpcTimeout(int rpcTimeout)
setRpcTimeout in interface org.apache.hadoop.hbase.client.Tablepublic long getReadRpcTimeout(TimeUnit unit)
getReadRpcTimeout in interface org.apache.hadoop.hbase.client.Table@Deprecated public void setWriteRpcTimeout(int writeRpcTimeout)
setWriteRpcTimeout in interface org.apache.hadoop.hbase.client.Tablepublic long getOperationTimeout(TimeUnit unit)
getOperationTimeout in interface org.apache.hadoop.hbase.client.Table@Deprecated public void setReadRpcTimeout(int readRpcTimeout)
setReadRpcTimeout in interface org.apache.hadoop.hbase.client.Tablepublic long getWriteRpcTimeout(TimeUnit unit)
getWriteRpcTimeout in interface org.apache.hadoop.hbase.client.Table@Deprecated public int getRpcTimeout()
getRpcTimeout in interface org.apache.hadoop.hbase.client.Tablepublic long getRpcTimeout(TimeUnit unit)
getRpcTimeout in interface org.apache.hadoop.hbase.client.Table@Deprecated public int getWriteRpcTimeout()
getWriteRpcTimeout in interface org.apache.hadoop.hbase.client.Table@Deprecated public int getReadRpcTimeout()
getReadRpcTimeout in interface org.apache.hadoop.hbase.client.TableCopyright © 2007–2020 The Apache Software Foundation. All rights reserved.