Class RegionAsTable

java.lang.Object
org.apache.hadoop.hbase.regionserver.RegionAsTable
All Implemented Interfaces:
Closeable, AutoCloseable, org.apache.hadoop.hbase.client.Table

public class RegionAsTable extends Object implements 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

    Nested Classes
    Modifier and Type
    Class
    Description
    (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

    Fields
    Modifier and Type
    Field
    Description
    private final org.apache.hadoop.hbase.regionserver.Region
     
  • Constructor Summary

    Constructors
    Constructor
    Description
    RegionAsTable(org.apache.hadoop.hbase.regionserver.Region region)
     
  • Method Summary

    Modifier and Type
    Method
    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>
    Map<byte[],R>
    batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor, com.google.protobuf.Message request, byte[] startKey, byte[] endKey, R responsePrototype)
     
    <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)
     
    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.CompareOperator compareOp, byte[] value, org.apache.hadoop.hbase.client.Delete delete)
    Deprecated.
    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.
    org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
    checkAndMutate(byte[] row, byte[] family)
     
    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
    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.
    org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder
    checkAndMutate(byte[] row, org.apache.hadoop.hbase.filter.Filter filter)
     
    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.CompareOperator compareOp, 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.
    void
    This call will NOT close the underlying region.
    org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
    coprocessorService(byte[] row)
     
    <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)
     
    <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)
     
    void
    delete(List<org.apache.hadoop.hbase.client.Delete> deletes)
     
    void
    delete(org.apache.hadoop.hbase.client.Delete delete)
     
    boolean[]
    exists(List<org.apache.hadoop.hbase.client.Get> gets)
     
    boolean
    exists(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.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
     
    int
    Deprecated.
    long
     
    int
    Deprecated.
    long
     
    org.apache.hadoop.hbase.client.RegionLocator
     
    int
    Deprecated.
    long
     
    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
    Deprecated.
    int
    Deprecated.
    long
     
    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
    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.

    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, existsAll, getRequestAttributes
  • Field Details

    • region

      private final org.apache.hadoop.hbase.regionserver.Region region
  • Constructor Details

    • RegionAsTable

      public RegionAsTable(org.apache.hadoop.hbase.regionserver.Region region)
      Parameters:
      region - Region to decorate with Table API.
  • Method Details

    • getName

      public org.apache.hadoop.hbase.TableName getName()
      Specified by:
      getName in interface org.apache.hadoop.hbase.client.Table
    • getConfiguration

      public org.apache.hadoop.conf.Configuration getConfiguration()
      Specified by:
      getConfiguration in interface org.apache.hadoop.hbase.client.Table
    • getTableDescriptor

      @Deprecated public org.apache.hadoop.hbase.HTableDescriptor getTableDescriptor() throws IOException
      Deprecated.
      Specified by:
      getTableDescriptor in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • getDescriptor

      public org.apache.hadoop.hbase.client.TableDescriptor getDescriptor() throws IOException
      Specified by:
      getDescriptor in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • exists

      public boolean exists(org.apache.hadoop.hbase.client.Get get) throws IOException
      Specified by:
      exists in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • exists

      public boolean[] exists(List<org.apache.hadoop.hbase.client.Get> gets) throws IOException
      Specified by:
      exists in interface org.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 interface org.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 interface org.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 interface org.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 interface org.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 interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • getScanner

      public org.apache.hadoop.hbase.client.ResultScanner getScanner(byte[] family) throws IOException
      Specified by:
      getScanner in interface org.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 interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • put

      public void put(org.apache.hadoop.hbase.client.Put put) throws IOException
      Specified by:
      put in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • put

      public void put(List<org.apache.hadoop.hbase.client.Put> puts) throws IOException
      Specified by:
      put in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • checkAndPut

      @Deprecated public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Put put) throws IOException
      Deprecated.
      Specified by:
      checkAndPut in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • checkAndPut

      @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
      Deprecated.
      Specified by:
      checkAndPut in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • checkAndPut

      @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
      Deprecated.
      Specified by:
      checkAndPut in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • delete

      public void delete(org.apache.hadoop.hbase.client.Delete delete) throws IOException
      Specified by:
      delete in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • delete

      public void delete(List<org.apache.hadoop.hbase.client.Delete> deletes) throws IOException
      Specified by:
      delete in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • checkAndDelete

      public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Delete delete) throws IOException
      Specified by:
      checkAndDelete in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • checkAndDelete

      @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
      Deprecated.
      Specified by:
      checkAndDelete in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • checkAndDelete

      @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
      Deprecated.
      Specified by:
      checkAndDelete in interface org.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 interface org.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 interface org.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 interface org.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 interface org.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 interface org.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 interface org.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 interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • close

      public void close() throws IOException
      This call will NOT close the underlying region.
      Specified by:
      close in interface AutoCloseable
      Specified by:
      close in interface Closeable
      Specified by:
      close in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • coprocessorService

      public org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel coprocessorService(byte[] row)
      Specified by:
      coprocessorService in interface org.apache.hadoop.hbase.client.Table
    • coprocessorService

      public <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
      Specified by:
      coprocessorService in interface org.apache.hadoop.hbase.client.Table
      Throws:
      com.google.protobuf.ServiceException
      Throwable
    • coprocessorService

      public <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
      Specified by:
      coprocessorService in interface org.apache.hadoop.hbase.client.Table
      Throws:
      com.google.protobuf.ServiceException
      Throwable
    • batchCoprocessorService

      public <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
      Specified by:
      batchCoprocessorService in interface org.apache.hadoop.hbase.client.Table
      Throws:
      com.google.protobuf.ServiceException
      Throwable
    • batchCoprocessorService

      public <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
      Specified by:
      batchCoprocessorService in interface org.apache.hadoop.hbase.client.Table
      Throws:
      com.google.protobuf.ServiceException
      Throwable
    • checkAndMutate

      @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
      Deprecated.
      Specified by:
      checkAndMutate in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • checkAndMutate

      @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
      Deprecated.
      Specified by:
      checkAndMutate in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • setOperationTimeout

      @Deprecated public void setOperationTimeout(int operationTimeout)
      Deprecated.
      Specified by:
      setOperationTimeout in interface org.apache.hadoop.hbase.client.Table
    • getOperationTimeout

      Deprecated.
      Specified by:
      getOperationTimeout in interface org.apache.hadoop.hbase.client.Table
    • setRpcTimeout

      @Deprecated public void setRpcTimeout(int rpcTimeout)
      Deprecated.
      Specified by:
      setRpcTimeout in interface org.apache.hadoop.hbase.client.Table
    • getReadRpcTimeout

      public long getReadRpcTimeout(TimeUnit unit)
      Specified by:
      getReadRpcTimeout in interface org.apache.hadoop.hbase.client.Table
    • setWriteRpcTimeout

      @Deprecated public void setWriteRpcTimeout(int writeRpcTimeout)
      Deprecated.
      Specified by:
      setWriteRpcTimeout in interface org.apache.hadoop.hbase.client.Table
    • getOperationTimeout

      public long getOperationTimeout(TimeUnit unit)
      Specified by:
      getOperationTimeout in interface org.apache.hadoop.hbase.client.Table
    • setReadRpcTimeout

      @Deprecated public void setReadRpcTimeout(int readRpcTimeout)
      Deprecated.
      Specified by:
      setReadRpcTimeout in interface org.apache.hadoop.hbase.client.Table
    • getWriteRpcTimeout

      public long getWriteRpcTimeout(TimeUnit unit)
      Specified by:
      getWriteRpcTimeout in interface org.apache.hadoop.hbase.client.Table
    • getRpcTimeout

      @Deprecated public int getRpcTimeout()
      Deprecated.
      Specified by:
      getRpcTimeout in interface org.apache.hadoop.hbase.client.Table
    • getRpcTimeout

      public long getRpcTimeout(TimeUnit unit)
      Specified by:
      getRpcTimeout in interface org.apache.hadoop.hbase.client.Table
    • getWriteRpcTimeout

      Deprecated.
      Specified by:
      getWriteRpcTimeout in interface org.apache.hadoop.hbase.client.Table
    • getReadRpcTimeout

      Deprecated.
      Specified by:
      getReadRpcTimeout in interface org.apache.hadoop.hbase.client.Table
    • getRegionLocator

      public org.apache.hadoop.hbase.client.RegionLocator getRegionLocator() throws IOException
      Specified by:
      getRegionLocator in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException