Class ThriftTable

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

@Private public class ThriftTable extends Object implements Table
  • Field Details

  • Constructor Details

    • ThriftTable

      public ThriftTable(TableName tableName, org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client client, org.apache.thrift.transport.TTransport tTransport, org.apache.hadoop.conf.Configuration conf)
  • Method Details

    • getName

      public TableName getName()
      Description copied from interface: Table
      Gets the fully qualified table name instance of this table.
      Specified by:
      getName in interface Table
    • getConfiguration

      public org.apache.hadoop.conf.Configuration getConfiguration()
      Description copied from interface: Table
      Returns the Configuration object used by this instance.

      The reference returned is not a copy, so any change made to it will affect this instance.

      Specified by:
      getConfiguration in interface Table
    • getDescriptor

      Description copied from interface: Table
      Gets the table descriptor for this table.
      Specified by:
      getDescriptor in interface Table
      Throws:
      IOException - if a remote or network exception occurs.
    • exists

      public boolean exists(Get get) throws IOException
      Description copied from interface: Table
      Test for the existence of columns in the table, as specified by the Get.

      This will return true if the Get matches one or more keys, false if not.

      This is a server-side call so it prevents any data from being transfered to the client.

      Specified by:
      exists in interface Table
      Parameters:
      get - the Get
      Returns:
      true if the specified Get matches one or more keys, false if not
      Throws:
      IOException - e
    • exists

      public boolean[] exists(List<Get> gets) throws IOException
      Description copied from interface: Table
      Test for the existence of columns in the table, as specified by the Gets.

      This will return an array of booleans. Each value will be true if the related Get matches one or more keys, false if not.

      This is a server-side call so it prevents any data from being transferred to the client.

      Specified by:
      exists in interface Table
      Parameters:
      gets - the Gets
      Returns:
      Array of boolean. True if the specified Get matches one or more keys, false if not.
      Throws:
      IOException - e
    • batch

      public void batch(List<? extends Row> actions, Object[] results) throws IOException
      Description copied from interface: Table
      Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations. The ordering of execution of the actions is not defined. Meaning if you do a Put and a Get in the same Table.batch(java.util.List<? extends org.apache.hadoop.hbase.client.Row>, java.lang.Object[]) call, you will not necessarily be guaranteed that the Get returns what the Put had put.
      Specified by:
      batch in interface Table
      Parameters:
      actions - list of Get, Put, Delete, Increment, Append, RowMutations.
      results - Empty Object[], same size as actions. Provides access to partial results, in case an exception is thrown. A null in the result array means that the call for that action failed, even after retries. The order of the objects in the results array corresponds to the order of actions in the request list.
      Throws:
      IOException
    • batchCallback

      public <R> void batchCallback(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback) throws IOException
      Description copied from interface: Table
      Same as Table.batch(List, Object[]), but with a callback.
      Specified by:
      batchCallback in interface Table
      Throws:
      IOException
    • get

      public Result get(Get get) throws IOException
      Description copied from interface: Table
      Extracts certain cells from a given row.
      Specified by:
      get in interface Table
      Parameters:
      get - The object that specifies what data to fetch and from which row.
      Returns:
      The data coming from the specified row, if it exists. If the row specified doesn't exist, the Result instance returned won't contain any KeyValue, as indicated by Result.isEmpty().
      Throws:
      IOException - if a remote or network exception occurs.
    • get

      public Result[] get(List<Get> gets) throws IOException
      Description copied from interface: Table
      Extracts specified cells from the given rows, as a batch.
      Specified by:
      get in interface Table
      Parameters:
      gets - The objects that specify what data to fetch and from which rows.
      Returns:
      The data coming from the specified rows, if it exists. If the row specified doesn't exist, the Result instance returned won't contain any Cells, as indicated by Result.isEmpty(). If there are any failures even after retries, there will be a null in the results' array for those Gets, AND an exception will be thrown. The ordering of the Result array corresponds to the order of the list of passed in Gets.
      Throws:
      IOException - if a remote or network exception occurs.
    • getScanner

      public ResultScanner getScanner(Scan scan) throws IOException
      Description copied from interface: Table
      Returns a scanner on the current table as specified by the Scan object. Note that the passed Scan's start row and caching properties maybe changed.
      Specified by:
      getScanner in interface Table
      Parameters:
      scan - A configured Scan object.
      Returns:
      A scanner.
      Throws:
      IOException - if a remote or network exception occurs.
    • getScanner

      public ResultScanner getScanner(byte[] family) throws IOException
      Description copied from interface: Table
      Gets a scanner on the current table for the given family.
      Specified by:
      getScanner in interface Table
      Parameters:
      family - The column family to scan.
      Returns:
      A scanner.
      Throws:
      IOException - if a remote or network exception occurs.
    • getScanner

      public ResultScanner getScanner(byte[] family, byte[] qualifier) throws IOException
      Description copied from interface: Table
      Gets a scanner on the current table for the given family and qualifier.
      Specified by:
      getScanner in interface Table
      Parameters:
      family - The column family to scan.
      qualifier - The column qualifier to scan.
      Returns:
      A scanner.
      Throws:
      IOException - if a remote or network exception occurs.
    • put

      public void put(Put put) throws IOException
      Description copied from interface: Table
      Puts some data in the table.
      Specified by:
      put in interface Table
      Parameters:
      put - The data to put.
      Throws:
      IOException - if a remote or network exception occurs.
    • put

      public void put(List<Put> puts) throws IOException
      Description copied from interface: Table
      Batch puts the specified data into the table.

      This can be used for group commit, or for submitting user defined batches. Before sending a batch of mutations to the server, the client runs a few validations on the input list. If an error is found, for example, a mutation was supplied but was missing it's column an IllegalArgumentException will be thrown and no mutations will be applied. If there are any failures even after retries, a RetriesExhaustedWithDetailsException will be thrown. RetriesExhaustedWithDetailsException contains lists of failed mutations and corresponding remote exceptions. The ordering of mutations and exceptions in the encapsulating exception corresponds to the order of the input list of Put requests.

      Specified by:
      put in interface Table
      Parameters:
      puts - The list of mutations to apply.
      Throws:
      IOException - if a remote or network exception occurs.
    • delete

      public void delete(Delete delete) throws IOException
      Description copied from interface: Table
      Deletes the specified cells/row.
      Specified by:
      delete in interface Table
      Parameters:
      delete - The object that specifies what to delete.
      Throws:
      IOException - if a remote or network exception occurs.
    • delete

      public void delete(List<Delete> deletes) throws IOException
      Description copied from interface: Table
      Batch Deletes the specified cells/rows from the table.

      If a specified row does not exist, Delete will report as though sucessful delete; no exception will be thrown. If there are any failures even after retries, a RetriesExhaustedWithDetailsException will be thrown. RetriesExhaustedWithDetailsException contains lists of failed Deletes and corresponding remote exceptions.

      Specified by:
      delete in interface Table
      Parameters:
      deletes - List of things to delete. The input list gets modified by this method. All successfully applied Deletes in the list are removed (in particular it gets re-ordered, so the order in which the elements are inserted in the list gives no guarantee as to the order in which the Deletes are executed).
      Throws:
      IOException - if a remote or network exception occurs. In that case the deletes argument will contain the Delete instances that have not be successfully applied.
    • checkAndMutate

      private boolean checkAndMutate(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, RowMutations mutation) throws IOException
      Throws:
      IOException
    • checkAndMutate

      public Table.CheckAndMutateBuilder checkAndMutate(byte[] row, byte[] family)
      Description copied from interface: Table
      Atomically checks if a row/family/qualifier value matches the expected value. If it does, it adds the Put/Delete/RowMutations.

      Use the returned Table.CheckAndMutateBuilder to construct your request and then execute it. This is a fluent style API, the code is like:

       
       table.checkAndMutate(row, family).qualifier(qualifier).ifNotExists().thenPut(put);
       
       
      Specified by:
      checkAndMutate in interface Table
    • checkAndMutate

      Description copied from interface: Table
      Atomically checks if a row matches the specified filter. If it does, it adds the Put/Delete/RowMutations.

      Use the returned Table.CheckAndMutateWithFilterBuilder to construct your request and then execute it. This is a fluent style API, the code is like:

       
       table.checkAndMutate(row, filter).thenPut(put);
       
       
      Specified by:
      checkAndMutate in interface Table
    • checkAndMutate

      Description copied from interface: Table
      checkAndMutate that atomically checks if a row matches the specified condition. If it does, it performs the specified action.
      Specified by:
      checkAndMutate in interface Table
      Parameters:
      checkAndMutate - The CheckAndMutate object.
      Returns:
      A CheckAndMutateResult object that represents the result for the CheckAndMutate.
    • checkAndMutate

      Description copied from interface: Table
      Batch version of checkAndMutate. The specified CheckAndMutates are batched only in the sense that they are sent to a RS in one RPC, but each CheckAndMutate operation is still executed atomically (and thus, each may fail independently of others).
      Specified by:
      checkAndMutate in interface Table
      Parameters:
      checkAndMutates - The list of CheckAndMutate.
      Returns:
      A list of CheckAndMutateResult objects that represents the result for each CheckAndMutate.
    • mutateRow

      Description copied from interface: Table
      Performs multiple mutations atomically on a single row. Currently Put and Delete are supported.
      Specified by:
      mutateRow in interface Table
      Parameters:
      rm - object that specifies the set of mutations to perform atomically
      Returns:
      results of Increment/Append operations
      Throws:
      IOException - if a remote or network exception occurs.
    • append

      public Result append(Append append) throws IOException
      Description copied from interface: Table
      Appends values to one or more columns within a single row.

      This operation guaranteed atomicity to readers. Appends are done under a single row lock, so write operations to a row are synchronized, and readers are guaranteed to see this operation fully completed.

      Specified by:
      append in interface Table
      Parameters:
      append - object that specifies the columns and values to be appended
      Returns:
      values of columns after the append operation (maybe null)
      Throws:
      IOException - e
    • increment

      public Result increment(Increment increment) throws IOException
      Description copied from interface: Table
      Increments one or more columns within a single row.

      This operation ensures atomicity to readers. Increments are done under a single row lock, so write operations to a row are synchronized, and readers are guaranteed to see this operation fully completed.

      Specified by:
      increment in interface Table
      Parameters:
      increment - object that specifies the columns and amounts to be used for the increment operations
      Returns:
      values of columns after the increment
      Throws:
      IOException - e
    • close

      public void close() throws IOException
      Description copied from interface: Table
      Releases any resources held or pending changes in internal buffers.
      Specified by:
      close in interface AutoCloseable
      Specified by:
      close in interface Closeable
      Specified by:
      close in interface Table
      Throws:
      IOException - if a remote or network exception occurs.
    • getRpcTimeout

      public long getRpcTimeout(TimeUnit unit)
      Description copied from interface: Table
      Get timeout of each rpc request in this Table instance. It will be overridden by a more specific rpc timeout config such as readRpcTimeout or writeRpcTimeout.
      Specified by:
      getRpcTimeout in interface Table
      Parameters:
      unit - the unit of time the timeout to be represented in
      Returns:
      rpc timeout in the specified time unit
      See Also:
    • getReadRpcTimeout

      public long getReadRpcTimeout(TimeUnit unit)
      Description copied from interface: Table
      Get timeout of each rpc read request in this Table instance.
      Specified by:
      getReadRpcTimeout in interface Table
      Parameters:
      unit - the unit of time the timeout to be represented in
      Returns:
      read rpc timeout in the specified time unit
    • getWriteRpcTimeout

      public long getWriteRpcTimeout(TimeUnit unit)
      Description copied from interface: Table
      Get timeout of each rpc write request in this Table instance.
      Specified by:
      getWriteRpcTimeout in interface Table
      Parameters:
      unit - the unit of time the timeout to be represented in
      Returns:
      write rpc timeout in the specified time unit
    • getOperationTimeout

      public long getOperationTimeout(TimeUnit unit)
      Description copied from interface: Table
      Get timeout of each operation in Table instance.
      Specified by:
      getOperationTimeout in interface Table
      Parameters:
      unit - the unit of time the timeout to be represented in
      Returns:
      operation rpc timeout in the specified time unit
    • coprocessorService

      Description copied from interface: Table
      Creates and returns a RpcChannel instance connected to the table region containing the specified row. The row given does not actually have to exist. Whichever region would contain the row based on start and end keys will be used. Note that the row parameter is also not passed to the coprocessor handler registered for this protocol, unless the row is separately passed as an argument in the service request. The parameter here is only used to locate the region used to handle the call.

      The obtained RpcChannel instance can be used to access a published coprocessor Service using standard protobuf service invocations:

       CoprocessorRpcChannel channel = myTable.coprocessorService(rowkey);
       MyService.BlockingInterface service = MyService.newBlockingStub(channel);
       MyCallRequest request = MyCallRequest.newBuilder()
           ...
           .build();
       MyCallResponse response = service.myCall(null, request);
       
      Specified by:
      coprocessorService in interface Table
      Parameters:
      row - The row key used to identify the remote region location
      Returns:
      A CoprocessorRpcChannel instance
      See Also:
    • getRegionLocator

      Description copied from interface: Table
      Gets the RegionLocator for this table.
      Specified by:
      getRegionLocator in interface Table
      Throws:
      IOException