Class RegionAsTable
java.lang.Object
org.apache.hadoop.hbase.regionserver.RegionAsTable
- All Implemented Interfaces:
Closeable
,AutoCloseable
,org.apache.hadoop.hbase.client.Table
An implementation of
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.
-
Nested Class Summary
Modifier and TypeClassDescription(package private) static class
Nested classes/interfaces inherited from interface org.apache.hadoop.hbase.client.Table
org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder, org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder
-
Field Summary
Modifier and TypeFieldDescriptionprivate final org.apache.hadoop.hbase.regionserver.Region
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Result
append
(org.apache.hadoop.hbase.client.Append append) void
<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 org.apache.hbase.thirdparty.com.google.protobuf.Message>
Map<byte[],R> batchCoprocessorService
(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor, org.apache.hbase.thirdparty.com.google.protobuf.Message request, byte[] startKey, byte[] endKey, R responsePrototype) <R extends org.apache.hbase.thirdparty.com.google.protobuf.Message>
voidbatchCoprocessorService
(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor, org.apache.hbase.thirdparty.com.google.protobuf.Message request, byte[] startKey, byte[] endKey, R responsePrototype, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
checkAndMutate
(byte[] row, byte[] family) org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder
checkAndMutate
(byte[] row, org.apache.hadoop.hbase.filter.Filter filter) void
close()
This call will NOT close the underlying region.org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
coprocessorService
(byte[] row) <T extends org.apache.hbase.thirdparty.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) <T extends org.apache.hbase.thirdparty.com.google.protobuf.Service,
R>
voidcoprocessorService
(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
void
delete
(org.apache.hadoop.hbase.client.Delete delete) boolean[]
boolean
exists
(org.apache.hadoop.hbase.client.Get get) org.apache.hadoop.hbase.client.Result[]
org.apache.hadoop.hbase.client.Result
get
(org.apache.hadoop.hbase.client.Get get) org.apache.hadoop.conf.Configuration
org.apache.hadoop.hbase.client.TableDescriptor
org.apache.hadoop.hbase.TableName
getName()
long
getOperationTimeout
(TimeUnit unit) long
getReadRpcTimeout
(TimeUnit unit) org.apache.hadoop.hbase.client.RegionLocator
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) 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) org.apache.hadoop.hbase.client.Result
mutateRow
(org.apache.hadoop.hbase.client.RowMutations rm) void
void
put
(org.apache.hadoop.hbase.client.Put put) Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
Methods inherited from interface org.apache.hadoop.hbase.client.Table
checkAndMutate, checkAndMutate, getRequestAttributes
-
Field Details
-
region
-
-
Constructor Details
-
RegionAsTable
- Parameters:
region
- Region to decorate with Table API.
-
-
Method Details
-
getName
- Specified by:
getName
in interfaceorg.apache.hadoop.hbase.client.Table
-
getConfiguration
- Specified by:
getConfiguration
in interfaceorg.apache.hadoop.hbase.client.Table
-
getDescriptor
- Specified by:
getDescriptor
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
exists
- Specified by:
exists
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
exists
- Specified by:
exists
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
batch
public void batch(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results) throws IOException, InterruptedException - Specified by:
batch
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
InterruptedException
-
batchCallback
public <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 - Specified by:
batchCallback
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
InterruptedException
-
get
public org.apache.hadoop.hbase.client.Result get(org.apache.hadoop.hbase.client.Get get) throws IOException - Specified by:
get
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
get
public org.apache.hadoop.hbase.client.Result[] get(List<org.apache.hadoop.hbase.client.Get> gets) throws IOException - Specified by:
get
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
getScanner
public org.apache.hadoop.hbase.client.ResultScanner getScanner(org.apache.hadoop.hbase.client.Scan scan) throws IOException - Specified by:
getScanner
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
getScanner
- Specified by:
getScanner
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
getScanner
public org.apache.hadoop.hbase.client.ResultScanner getScanner(byte[] family, byte[] qualifier) throws IOException - Specified by:
getScanner
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
put
- Specified by:
put
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
put
- Specified by:
put
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
delete
- Specified by:
delete
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
delete
- Specified by:
delete
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
checkAndMutate
public org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder checkAndMutate(byte[] row, byte[] family) - Specified by:
checkAndMutate
in interfaceorg.apache.hadoop.hbase.client.Table
-
checkAndMutate
public org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder checkAndMutate(byte[] row, org.apache.hadoop.hbase.filter.Filter filter) - Specified by:
checkAndMutate
in interfaceorg.apache.hadoop.hbase.client.Table
-
mutateRow
public org.apache.hadoop.hbase.client.Result mutateRow(org.apache.hadoop.hbase.client.RowMutations rm) throws IOException - Specified by:
mutateRow
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
append
public org.apache.hadoop.hbase.client.Result append(org.apache.hadoop.hbase.client.Append append) throws IOException - Specified by:
append
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
increment
public org.apache.hadoop.hbase.client.Result increment(org.apache.hadoop.hbase.client.Increment increment) throws IOException - Specified by:
increment
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
incrementColumnValue
public long incrementColumnValue(byte[] row, byte[] family, byte[] qualifier, long amount) throws IOException - Specified by:
incrementColumnValue
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
incrementColumnValue
public long incrementColumnValue(byte[] row, byte[] family, byte[] qualifier, long amount, org.apache.hadoop.hbase.client.Durability durability) throws IOException - Specified by:
incrementColumnValue
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
close
This call will NOT close the underlying region.- Specified by:
close
in interfaceAutoCloseable
- Specified by:
close
in interfaceCloseable
- Specified by:
close
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-
coprocessorService
- Specified by:
coprocessorService
in interfaceorg.apache.hadoop.hbase.client.Table
-
coprocessorService
public <T extends org.apache.hbase.thirdparty.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 org.apache.hbase.thirdparty.com.google.protobuf.ServiceException, Throwable- Specified by:
coprocessorService
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
Throwable
-
coprocessorService
public <T extends org.apache.hbase.thirdparty.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 org.apache.hbase.thirdparty.com.google.protobuf.ServiceException, Throwable- Specified by:
coprocessorService
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
Throwable
-
batchCoprocessorService
public <R extends org.apache.hbase.thirdparty.com.google.protobuf.Message> Map<byte[],R> batchCoprocessorService(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor, org.apache.hbase.thirdparty.com.google.protobuf.Message request, byte[] startKey, byte[] endKey, R responsePrototype) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException, Throwable - Specified by:
batchCoprocessorService
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
Throwable
-
batchCoprocessorService
public <R extends org.apache.hbase.thirdparty.com.google.protobuf.Message> void batchCoprocessorService(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor, org.apache.hbase.thirdparty.com.google.protobuf.Message request, byte[] startKey, byte[] endKey, R responsePrototype, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException, Throwable - Specified by:
batchCoprocessorService
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
Throwable
-
getReadRpcTimeout
- Specified by:
getReadRpcTimeout
in interfaceorg.apache.hadoop.hbase.client.Table
-
getOperationTimeout
- Specified by:
getOperationTimeout
in interfaceorg.apache.hadoop.hbase.client.Table
-
getWriteRpcTimeout
- Specified by:
getWriteRpcTimeout
in interfaceorg.apache.hadoop.hbase.client.Table
-
getRpcTimeout
- Specified by:
getRpcTimeout
in interfaceorg.apache.hadoop.hbase.client.Table
-
getRegionLocator
- Specified by:
getRegionLocator
in interfaceorg.apache.hadoop.hbase.client.Table
- Throws:
IOException
-