Class RemoteHTable

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

@Private public class RemoteHTable extends Object implements org.apache.hadoop.hbase.client.Table
HTable interface to remote tables accessed via REST gateway
  • Nested Class Summary

    Nested Classes
    Modifier and Type
    Class
    Description
    private class 
     
    (package private) 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
    (package private) final org.apache.hadoop.hbase.rest.client.Client
     
    (package private) final org.apache.hadoop.conf.Configuration
     
    private static final org.slf4j.Logger
     
    (package private) final int
     
    (package private) final byte[]
     
    private String
     
    (package private) final long
     
  • Constructor Summary

    Constructors
    Constructor
    Description
    RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client, String name)
    Constructor
    RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client, org.apache.hadoop.conf.Configuration conf, byte[] name)
    Constructor
    RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client, org.apache.hadoop.conf.Configuration conf, byte[] name, String pathPrefix)
     
    RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client, org.apache.hadoop.conf.Configuration conf, String name)
    Constructor
  • 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 org.apache.hbase.thirdparty.com.google.protobuf.Message>
    Map<byte[],R>
    batchCoprocessorService(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor method, 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>
    void
    batchCoprocessorService(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor method, 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)
     
    protected org.apache.hadoop.hbase.rest.model.CellSetModel
    buildModelFromPut(org.apache.hadoop.hbase.client.Put put)
     
    protected String
    buildMultiRowSpec(byte[][] rows, int maxVersions)
     
    protected org.apache.hadoop.hbase.client.Result[]
    buildResultFromModel(org.apache.hadoop.hbase.rest.model.CellSetModel model)
     
    protected String
    buildRowSpec(byte[] row, Map familyMap, long startTime, long endTime, int maxVersions)
     
    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)
     
    List<org.apache.hadoop.hbase.client.CheckAndMutateResult>
    checkAndMutate(List<org.apache.hadoop.hbase.client.CheckAndMutate> checkAndMutates)
     
    org.apache.hadoop.hbase.client.CheckAndMutateResult
    checkAndMutate(org.apache.hadoop.hbase.client.CheckAndMutate checkAndMutate)
     
    void
     
    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>
    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)
     
    private boolean
    doCheckAndDelete(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Delete delete)
     
    private boolean
    doCheckAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Put put)
     
    boolean[]
    exists(List<org.apache.hadoop.hbase.client.Get> gets)
     
    boolean
    exists(org.apache.hadoop.hbase.client.Get get)
     
    void
     
    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
     
    long
     
    long
     
    org.apache.hadoop.hbase.client.RegionLocator
     
    private org.apache.hadoop.hbase.client.Result[]
     
    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)
     
    byte[]
     
    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)
     
    boolean
     
    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)
     
    private static String
    toURLEncodedBytes(byte[] row)
     

    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

    getRequestAttributes
  • Field Details

    • LOG

      private static final org.slf4j.Logger LOG
    • client

      final org.apache.hadoop.hbase.rest.client.Client client
    • conf

      final org.apache.hadoop.conf.Configuration conf
    • name

      final byte[] name
    • maxRetries

      final int maxRetries
    • sleepTime

      final long sleepTime
    • pathPrefix

      private String pathPrefix
  • Constructor Details

    • RemoteHTable

      public RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client, String name)
      Constructor
    • RemoteHTable

      public RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client, org.apache.hadoop.conf.Configuration conf, String name)
      Constructor
    • RemoteHTable

      public RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client, org.apache.hadoop.conf.Configuration conf, byte[] name)
      Constructor
    • RemoteHTable

      public RemoteHTable(org.apache.hadoop.hbase.rest.client.Client client, org.apache.hadoop.conf.Configuration conf, byte[] name, String pathPrefix)
  • Method Details

    • buildRowSpec

      protected String buildRowSpec(byte[] row, Map familyMap, long startTime, long endTime, int maxVersions)
    • buildMultiRowSpec

      protected String buildMultiRowSpec(byte[][] rows, int maxVersions)
    • buildResultFromModel

      protected org.apache.hadoop.hbase.client.Result[] buildResultFromModel(org.apache.hadoop.hbase.rest.model.CellSetModel model)
    • buildModelFromPut

      protected org.apache.hadoop.hbase.rest.model.CellSetModel buildModelFromPut(org.apache.hadoop.hbase.client.Put put)
    • getTableName

      public byte[] getTableName()
    • 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
    • close

      public void close() throws IOException
      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
    • 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
    • getResults

      private org.apache.hadoop.hbase.client.Result[] getResults(String spec) throws IOException
      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
    • 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
    • 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
    • flushCommits

      public void flushCommits() throws IOException
      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
    • 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
    • isAutoFlush

      public boolean isAutoFlush()
    • doCheckAndPut

      private boolean doCheckAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Put put) throws IOException
      Throws:
      IOException
    • doCheckAndDelete

      private boolean doCheckAndDelete(byte[] row, byte[] family, byte[] qualifier, byte[] value, org.apache.hadoop.hbase.client.Delete delete) throws IOException
      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
    • checkAndMutate

      public org.apache.hadoop.hbase.client.CheckAndMutateResult checkAndMutate(org.apache.hadoop.hbase.client.CheckAndMutate checkAndMutate)
      Specified by:
      checkAndMutate in interface org.apache.hadoop.hbase.client.Table
    • checkAndMutate

      public List<org.apache.hadoop.hbase.client.CheckAndMutateResult> checkAndMutate(List<org.apache.hadoop.hbase.client.CheckAndMutate> checkAndMutates)
      Specified by:
      checkAndMutate in interface org.apache.hadoop.hbase.client.Table
    • 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
    • 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
    • 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
    • batch

      public void batch(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results) throws IOException
      Specified by:
      batch in interface org.apache.hadoop.hbase.client.Table
      Throws:
      IOException
    • 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
    • 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 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 interface org.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 interface org.apache.hadoop.hbase.client.Table
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Throwable
    • 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
    • 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 method, 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 interface org.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 method, 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 interface org.apache.hadoop.hbase.client.Table
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Throwable
    • getReadRpcTimeout

      public long getReadRpcTimeout(TimeUnit unit)
      Specified by:
      getReadRpcTimeout 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

      public long getWriteRpcTimeout(TimeUnit unit)
      Specified by:
      getWriteRpcTimeout 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
    • toURLEncodedBytes

      private static String toURLEncodedBytes(byte[] row)
    • getRegionLocator

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