@InterfaceAudience.Private public class HTable extends Object implements Table
Table. Used to communicate with a single HBase table. Lightweight.
 Get as needed and just close when done. Instances of this class SHOULD NOT be constructed
 directly. Obtain an instance via Connection. See ConnectionFactory class comment
 for an example of how.
 
 This class is thread safe since 2.0.0 if not invoking any of the setter methods. All setters are
 moved into TableBuilder and reserved here only for keeping backward compatibility, and
 TODO will be removed soon.
 
 HTable is no longer a client API. Use Table instead. It is marked
 InterfaceAudience.Private indicating that this is an HBase-internal class as defined in Hadoop
 Interface Classification There are no guarantees for backwards source / binary compatibility
 and methods or class can change or go away without deprecation.
Table, 
Admin, 
Connection, 
ConnectionFactoryTable.CheckAndMutateBuilder, Table.CheckAndMutateWithFilterBuilder| Modifier | Constructor and Description | 
|---|---|
| protected  | HTable(ConnectionImplementation connection,
      org.apache.hadoop.hbase.client.TableBuilderBase builder,
      RpcRetryingCallerFactory rpcCallerFactory,
      RpcControllerFactory rpcControllerFactory,
      ExecutorService pool,
      Map<String,byte[]> requestAttributes)Creates an object to access a HBase table. | 
| Modifier and Type | Method and Description | 
|---|---|
| Result | append(Append append)Appends values to one or more columns within a single row. | 
| void | batch(List<? extends Row> actions,
     Object[] results)Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations. | 
| void | batch(List<? extends Row> actions,
     Object[] results,
     int rpcTimeout) | 
| <R> void | batchCallback(List<? extends Row> actions,
             Object[] results,
             Batch.Callback<R> callback)Same as  Table.batch(List, Object[]), but with a 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)Creates an instance of the given  Servicesubclass for each table
 region spanning the range from thestartKeyrow toendKeyrow (inclusive), all
 the invocations to the same region server will be batched into one call. | 
| <R extends com.google.protobuf.Message> | batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor,
                       com.google.protobuf.Message request,
                       byte[] startKey,
                       byte[] endKey,
                       R responsePrototype,
                       Batch.Callback<R> callback)Creates an instance of the given  Servicesubclass for each table
 region spanning the range from thestartKeyrow toendKeyrow (inclusive), all
 the invocations to the same region server will be batched into one call. | 
| boolean | checkAndDelete(byte[] row,
              byte[] family,
              byte[] qualifier,
              byte[] value,
              Delete delete)Deprecated.  | 
| boolean | checkAndDelete(byte[] row,
              byte[] family,
              byte[] qualifier,
              CompareFilter.CompareOp compareOp,
              byte[] value,
              Delete delete)Deprecated.  | 
| boolean | checkAndDelete(byte[] row,
              byte[] family,
              byte[] qualifier,
              CompareOperator op,
              byte[] value,
              Delete delete)Deprecated.  | 
| Table.CheckAndMutateBuilder | checkAndMutate(byte[] row,
              byte[] family)Deprecated.  | 
| boolean | checkAndMutate(byte[] row,
              byte[] family,
              byte[] qualifier,
              CompareFilter.CompareOp compareOp,
              byte[] value,
              RowMutations rm)Deprecated.  | 
| boolean | checkAndMutate(byte[] row,
              byte[] family,
              byte[] qualifier,
              CompareOperator op,
              byte[] value,
              RowMutations rm)Deprecated.  | 
| Table.CheckAndMutateWithFilterBuilder | checkAndMutate(byte[] row,
              Filter filter)Deprecated.  | 
| CheckAndMutateResult | checkAndMutate(CheckAndMutate checkAndMutate)checkAndMutate that atomically checks if a row matches the specified condition. | 
| List<CheckAndMutateResult> | checkAndMutate(List<CheckAndMutate> checkAndMutates)Batch version of checkAndMutate. | 
| boolean | checkAndPut(byte[] row,
           byte[] family,
           byte[] qualifier,
           byte[] value,
           Put put)Deprecated.  | 
| boolean | checkAndPut(byte[] row,
           byte[] family,
           byte[] qualifier,
           CompareFilter.CompareOp compareOp,
           byte[] value,
           Put put)Deprecated.  | 
| boolean | checkAndPut(byte[] row,
           byte[] family,
           byte[] qualifier,
           CompareOperator op,
           byte[] value,
           Put put)Deprecated.  | 
| void | clearRegionCache()Explicitly clears the region cache to fetch the latest value from META. | 
| void | close()Releases any resources held or pending changes in internal buffers. | 
| CoprocessorRpcChannel | coprocessorService(byte[] row)Creates and returns a  RpcChannelinstance connected to the table
 region containing the specified row. | 
| <T extends com.google.protobuf.Service,R> | coprocessorService(Class<T> service,
                  byte[] startKey,
                  byte[] endKey,
                  Batch.Call<T,R> callable)Creates an instance of the given  Servicesubclass for each table
 region spanning the range from thestartKeyrow toendKeyrow (inclusive), and
 invokes the passedBatch.Call.call(T)method
 with eachServiceinstance. | 
| <T extends com.google.protobuf.Service,R> | coprocessorService(Class<T> service,
                  byte[] startKey,
                  byte[] endKey,
                  Batch.Call<T,R> callable,
                  Batch.Callback<R> callback)Creates an instance of the given  Servicesubclass for each table
 region spanning the range from thestartKeyrow toendKeyrow (inclusive), and
 invokes the passedBatch.Call.call(T)method
 with eachServiceinstance. | 
| void | delete(Delete delete)Deletes the specified cells/row. | 
| void | delete(List<Delete> deletes)Batch Deletes the specified cells/rows from the table. | 
| static <R> void | doBatchWithCallback(List<? extends Row> actions,
                   Object[] results,
                   Batch.Callback<R> callback,
                   ClusterConnection connection,
                   ExecutorService pool,
                   TableName tableName,
                   Map<String,byte[]> requestAttributes) | 
| boolean | exists(Get get)Test for the existence of columns in the table, as specified by the Get. | 
| boolean[] | exists(List<Get> gets)Test for the existence of columns in the table, as specified by the Gets. | 
| Result | get(Get get)Extracts certain cells from a given row. | 
| Result[] | get(List<Get> gets)Extracts specified cells from the given rows, as a batch. | 
| org.apache.hadoop.conf.Configuration | getConfiguration()Returns the  Configurationobject used by this instance. | 
| protected Connection | getConnection()INTERNAL Used by unit tests and tools to do low-level manipulations. | 
| static ThreadPoolExecutor | getDefaultExecutor(org.apache.hadoop.conf.Configuration conf) | 
| TableDescriptor | getDescriptor()Gets the  table descriptorfor this
 table. | 
| static int | getMaxKeyValueSize(org.apache.hadoop.conf.Configuration conf)Returns maxKeyValueSize from configuration. | 
| TableName | getName()Gets the fully qualified table name instance of this table. | 
| int | getOperationTimeout()Deprecated.  | 
| long | getOperationTimeout(TimeUnit unit)Get timeout of each operation in Table instance. | 
| int | getReadRpcTimeout()Deprecated.  | 
| long | getReadRpcTimeout(TimeUnit unit)Get timeout of each rpc read request in this Table instance. | 
| RegionLocator | getRegionLocator()Gets the  RegionLocatorfor this table. | 
| Map<String,byte[]> | getRequestAttributes()Get the attributes to be submitted with requests | 
| int | getRpcTimeout()Deprecated.  | 
| long | getRpcTimeout(TimeUnit unit)Get timeout of each rpc request in this Table instance. | 
| ResultScanner | getScanner(byte[] family)The underlying  HTablemust not be closed. | 
| ResultScanner | getScanner(byte[] family,
          byte[] qualifier)The underlying  HTablemust not be closed. | 
| ResultScanner | getScanner(Scan scan)The underlying  HTablemust not be closed. | 
| HTableDescriptor | getTableDescriptor()Deprecated.  | 
| int | getWriteRpcTimeout()Deprecated.  | 
| long | getWriteRpcTimeout(TimeUnit unit)Get timeout of each rpc write request in this Table instance. | 
| Result | increment(Increment increment)Increments one or more columns within a single row. | 
| long | incrementColumnValue(byte[] row,
                    byte[] family,
                    byte[] qualifier,
                    long amount) | 
| long | incrementColumnValue(byte[] row,
                    byte[] family,
                    byte[] qualifier,
                    long amount,
                    Durability durability)Atomically increments a column value. | 
| Result | mutateRow(RowMutations rm)Performs multiple mutations atomically on a single row. | 
| <R> void | processBatchCallback(List<? extends Row> list,
                    Object[] results,
                    Batch.Callback<R> callback)Process a mixed batch of Get, Put and Delete actions. | 
| void | put(List<Put> puts)Batch puts the specified data into the table. | 
| void | put(Put put)Puts some data in the table. | 
| void | setOperationTimeout(int operationTimeout)Deprecated.  | 
| void | setReadRpcTimeout(int readRpcTimeout)Deprecated.  | 
| void | setRpcTimeout(int rpcTimeout)Deprecated.  | 
| void | setWriteRpcTimeout(int writeRpcTimeout)Deprecated.  | 
| String | toString() | 
@InterfaceAudience.Private protected HTable(ConnectionImplementation connection, org.apache.hadoop.hbase.client.TableBuilderBase builder, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, ExecutorService pool, Map<String,byte[]> requestAttributes)
ConnectionFactory class comment for how to get a Table instance (use
 Table instead of HTable).connection - Connection to be used.builder - The table builderrpcCallerFactory - The RPC caller factoryrpcControllerFactory - The RPC controller factorypool - ExecutorService to be used.@InterfaceAudience.Private public static ThreadPoolExecutor getDefaultExecutor(org.apache.hadoop.conf.Configuration conf)
public static int getMaxKeyValueSize(org.apache.hadoop.conf.Configuration conf)
public org.apache.hadoop.conf.Configuration getConfiguration()
TableConfiguration object used by this instance.
 The reference returned is not a copy, so any change made to it will affect this instance.
getConfiguration in interface Tablepublic TableName getName()
Tableprotected Connection getConnection()
@Deprecated public HTableDescriptor getTableDescriptor() throws IOException
Tabletable descriptor for this table.getTableDescriptor in interface TableIOException - if a remote or network exception occurs.public TableDescriptor getDescriptor() throws IOException
Tabletable descriptor for this
 table.getDescriptor in interface TableIOException - if a remote or network exception occurs.public ResultScanner getScanner(Scan scan) throws IOException
HTable must not be closed. Table.getScanner(Scan) has other
 usage details.getScanner in interface Tablescan - A configured Scan object.IOException - if a remote or network exception occurs.public ResultScanner getScanner(byte[] family) throws IOException
HTable must not be closed. Table.getScanner(byte[]) has other
 usage details.getScanner in interface Tablefamily - The column family to scan.IOException - if a remote or network exception occurs.public ResultScanner getScanner(byte[] family, byte[] qualifier) throws IOException
HTable must not be closed. Table.getScanner(byte[], byte[]) has
 other usage details.getScanner in interface Tablefamily - The column family to scan.qualifier - The column qualifier to scan.IOException - if a remote or network exception occurs.public Result get(Get get) throws IOException
Tableget in interface Tableget - The object that specifies what data to fetch and from which row.Result instance returned won't contain any
         KeyValue, as indicated by Result.isEmpty().IOException - if a remote or network exception occurs.public Result[] get(List<Get> gets) throws IOException
Tableget in interface Tablegets - The objects that specify what data to fetch and from which rows.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.IOException - if a remote or network exception occurs.public void batch(List<? extends Row> actions, Object[] results) throws InterruptedException, IOException
TableTable.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.batch in interface Tableactions - 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.InterruptedExceptionIOExceptionpublic void batch(List<? extends Row> actions, Object[] results, int rpcTimeout) throws InterruptedException, IOException
InterruptedExceptionIOExceptionpublic <R> void batchCallback(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback) throws IOException, InterruptedException
TableTable.batch(List, Object[]), but with a callback.batchCallback in interface TableIOExceptionInterruptedExceptionpublic static <R> void doBatchWithCallback(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback, ClusterConnection connection, ExecutorService pool, TableName tableName, Map<String,byte[]> requestAttributes) throws InterruptedIOException, RetriesExhaustedWithDetailsException
public void delete(Delete delete) throws IOException
Tabledelete in interface Tabledelete - The object that specifies what to delete.IOException - if a remote or network exception occurs.public void delete(List<Delete> deletes) throws IOException
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.
delete in interface Tabledeletes - 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).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.public void put(Put put) throws IOException
Tableput in interface Tableput - The data to put.IOException - if a remote or network exception occurs.public void put(List<Put> puts) throws IOException
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.
put in interface Tableputs - The list of mutations to apply.IOException - if a remote or network exception occurs.public Result mutateRow(RowMutations rm) throws IOException
TablemutateRow in interface Tablerm - object that specifies the set of mutations to perform atomicallyIOException - if a remote or network exception occurs.public Result append(Append append) throws IOException
TableThis 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.
append in interface Tableappend - object that specifies the columns and values to be appendedIOException - epublic Result increment(Increment increment) throws IOException
TableThis 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.
increment in interface Tableincrement - object that specifies the columns and amounts to be used for the increment
                  operationsIOException - epublic long incrementColumnValue(byte[] row,
                                 byte[] family,
                                 byte[] qualifier,
                                 long amount)
                          throws IOException
TableTable.incrementColumnValue(byte[], byte[], byte[], long, Durability)
 
 The Durability is defaulted to Durability.SYNC_WAL.
incrementColumnValue in interface Tablerow - The row that contains the cell to increment.family - The column family of the cell to increment.qualifier - The column qualifier of the cell to increment.amount - The amount to increment the cell with (or decrement, if the amount is
                  negative).IOException - if a remote or network exception occurs.public long incrementColumnValue(byte[] row,
                                 byte[] family,
                                 byte[] qualifier,
                                 long amount,
                                 Durability durability)
                          throws IOException
Tableamount and written to the specified column.
 
 Setting durability to Durability.SKIP_WAL means that in a fail scenario you will lose
 any increments that have not been flushed.
incrementColumnValue in interface Tablerow - The row that contains the cell to increment.family - The column family of the cell to increment.qualifier - The column qualifier of the cell to increment.amount - The amount to increment the cell with (or decrement, if the amount is
                   negative).durability - The persistence guarantee for this increment.IOException - if a remote or network exception occurs.@Deprecated public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, byte[] value, Put put) throws IOException
TablecheckAndPut in interface Tablerow - to checkfamily - column family to checkqualifier - column qualifier to checkvalue - the expected valueput - data to put if check succeedsIOException - e@Deprecated public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, CompareFilter.CompareOp compareOp, byte[] value, Put put) throws IOException
TablecheckAndPut in interface Tablerow - to checkfamily - column family to checkqualifier - column qualifier to checkcompareOp - comparison operator to usevalue - the expected valueput - data to put if check succeedsIOException - e@Deprecated public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, Put put) throws IOException
TablecheckAndPut in interface Tablerow - to checkfamily - column family to checkqualifier - column qualifier to checkop - comparison operator to usevalue - the expected valueput - data to put if check succeedsIOException - e@Deprecated public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, byte[] value, Delete delete) throws IOException
TablecheckAndDelete in interface Tablerow - to checkfamily - column family to checkqualifier - column qualifier to checkvalue - the expected valuedelete - data to delete if check succeedsIOException - e@Deprecated public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, CompareFilter.CompareOp compareOp, byte[] value, Delete delete) throws IOException
TablecheckAndDelete in interface Tablerow - to checkfamily - column family to checkqualifier - column qualifier to checkcompareOp - comparison operator to usevalue - the expected valuedelete - data to delete if check succeedsIOException - e@Deprecated public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, Delete delete) throws IOException
TablecheckAndDelete in interface Tablerow - to checkfamily - column family to checkqualifier - column qualifier to checkop - comparison operator to usevalue - the expected valuedelete - data to delete if check succeedsIOException - e@Deprecated public Table.CheckAndMutateBuilder checkAndMutate(byte[] row, byte[] family)
Table
 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);
 
 checkAndMutate in interface Table@Deprecated public Table.CheckAndMutateWithFilterBuilder checkAndMutate(byte[] row, Filter filter)
Table
 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);
 
 checkAndMutate in interface Table@Deprecated public boolean checkAndMutate(byte[] row, byte[] family, byte[] qualifier, CompareFilter.CompareOp compareOp, byte[] value, RowMutations rm) throws IOException
TablecheckAndMutate in interface Tablerow - to checkfamily - column family to checkqualifier - column qualifier to checkcompareOp - the comparison operatorvalue - the expected valuerm - mutations to perform if check succeedsIOException - e@Deprecated public boolean checkAndMutate(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, RowMutations rm) throws IOException
TablecheckAndMutate in interface Tablerow - to checkfamily - column family to checkqualifier - column qualifier to checkop - the comparison operatorvalue - the expected valuerm - mutations to perform if check succeedsIOException - epublic CheckAndMutateResult checkAndMutate(CheckAndMutate checkAndMutate) throws IOException
TablecheckAndMutate in interface TablecheckAndMutate - The CheckAndMutate object.IOException - if a remote or network exception occurs.public List<CheckAndMutateResult> checkAndMutate(List<CheckAndMutate> checkAndMutates) throws IOException
TablecheckAndMutate in interface TablecheckAndMutates - The list of CheckAndMutate.IOException - if a remote or network exception occurs.public boolean exists(Get get) throws IOException
TableThis 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.
exists in interface Tableget - the GetIOException - epublic boolean[] exists(List<Get> gets) throws IOException
TableThis 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.
exists in interface Tablegets - the GetsIOException - epublic <R> void processBatchCallback(List<? extends Row> list, Object[] results, Batch.Callback<R> callback) throws IOException, InterruptedException
list - The collection of actions.results - An empty array, same size as list. If an exception is thrown, you can test here
                for partial results, and to determine which actions processed successfully.IOException - if there are problems talking to META. Per-item exceptions are stored in
                     the results array.InterruptedExceptionpublic void close()
           throws IOException
Tableclose in interface Closeableclose in interface AutoCloseableclose in interface TableIOException - if a remote or network exception occurs.public void clearRegionCache()
public CoprocessorRpcChannel coprocessorService(byte[] row)
TableRpcChannel 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);
 
 coprocessorService in interface Tablerow - The row key used to identify the remote region locationpublic <T extends com.google.protobuf.Service,R> Map<byte[],R> coprocessorService(Class<T> service, byte[] startKey, byte[] endKey, Batch.Call<T,R> callable) throws com.google.protobuf.ServiceException, Throwable
TableService subclass for each table
 region spanning the range from the startKey row to endKey row (inclusive), and
 invokes the passed Batch.Call.call(T) method
 with each Service instance.coprocessorService in interface TableT - the Service subclass to connect toR - Return type for the callable parameter's
                 Batch.Call.call(T) methodservice - the protocol buffer Service implementation to callstartKey - start region selection with region containing this row. If null, the
                 selection will start with the first table region.endKey - select regions up to and including the region containing this row. If
                 null, selection will continue through the last table region.callable - this instance's
                 Batch.Call.call(T) method will
                 be invoked once per table region, using the Service
                 instance connected to that region.com.google.protobuf.ServiceExceptionThrowablepublic <T extends com.google.protobuf.Service,R> void coprocessorService(Class<T> service, byte[] startKey, byte[] endKey, Batch.Call<T,R> callable, Batch.Callback<R> callback) throws com.google.protobuf.ServiceException, Throwable
TableService subclass for each table
 region spanning the range from the startKey row to endKey row (inclusive), and
 invokes the passed Batch.Call.call(T) method
 with each Service instance.
 
 The given
 Batch.Callback.update(byte[],byte[],Object)
 method will be called with the return value from each region's
 Batch.Call.call(T) invocation.
 
coprocessorService in interface TableT - the Service subclass to connect toR - Return type for the callable parameter's
                 Batch.Call.call(T) methodservice - the protocol buffer Service implementation to callstartKey - start region selection with region containing this row. If null, the
                 selection will start with the first table region.endKey - select regions up to and including the region containing this row. If
                 null, selection will continue through the last table region.callable - this instance's
                 Batch.Call.call(T) method will
                 be invoked once per table region, using the Service instance connected
                 to that region.com.google.protobuf.ServiceExceptionThrowablepublic long getRpcTimeout(TimeUnit unit)
TablegetRpcTimeout in interface Tableunit - the unit of time the timeout to be represented inTable.getReadRpcTimeout(TimeUnit), 
Table.getWriteRpcTimeout(TimeUnit)@Deprecated public int getRpcTimeout()
TablegetRpcTimeout in interface Table@Deprecated public void setRpcTimeout(int rpcTimeout)
TableNOTE: This will set both the read and write timeout settings to the provided value.
setRpcTimeout in interface TablerpcTimeout - the timeout of each rpc request in millisecond.public long getReadRpcTimeout(TimeUnit unit)
TablegetReadRpcTimeout in interface Tableunit - the unit of time the timeout to be represented in@Deprecated public int getReadRpcTimeout()
TablegetReadRpcTimeout in interface Table@Deprecated public void setReadRpcTimeout(int readRpcTimeout)
TablesetReadRpcTimeout in interface TablereadRpcTimeout - the timeout for read rpc request in millisecondspublic long getWriteRpcTimeout(TimeUnit unit)
TablegetWriteRpcTimeout in interface Tableunit - the unit of time the timeout to be represented in@Deprecated public int getWriteRpcTimeout()
TablegetWriteRpcTimeout in interface Table@Deprecated public void setWriteRpcTimeout(int writeRpcTimeout)
TablesetWriteRpcTimeout in interface TablewriteRpcTimeout - the timeout for write rpc request in millisecondspublic long getOperationTimeout(TimeUnit unit)
TablegetOperationTimeout in interface Tableunit - the unit of time the timeout to be represented in@Deprecated public int getOperationTimeout()
TablegetOperationTimeout in interface Table@Deprecated public void setOperationTimeout(int operationTimeout)
TablesetOperationTimeout in interface TableoperationTimeout - the total timeout of each operation in millisecond.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
TableService subclass for each table
 region spanning the range from the startKey row to endKey row (inclusive), all
 the invocations to the same region server will be batched into one call. The coprocessor
 service is invoked according to the service instance, method name and parameters. the
 descriptor for the protobuf service method to call. the method call parameters start region
 selection with region containing this row. If null, the selection will start with the
 first table region. select regions up to and including the region containing this row. If
 null, selection will continue through the last table region. the proto type of the
 response of the method in Service.batchCoprocessorService in interface TableR - the response type for the coprocessor Service methodcom.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,
                                                                            Batch.Callback<R> callback)
                                                                     throws com.google.protobuf.ServiceException,
                                                                            Throwable
TableService subclass for each table
 region spanning the range from the startKey row to endKey row (inclusive), all
 the invocations to the same region server will be batched into one call. The coprocessor
 service is invoked according to the service instance, method name and parameters.
 
 The given
 Batch.Callback.update(byte[],byte[],Object)
 method will be called with the return value from each region's invocation.
 
batchCoprocessorService in interface TableR - the response type for the coprocessor Service methodmethodDescriptor - the descriptor for the protobuf service method to call.request - the method call parametersstartKey - start region selection with region containing this row. If
                          null, the selection will start with the first table region.endKey - select regions up to and including the region containing this row. If
                          null, selection will continue through the last table region.responsePrototype - the proto type of the response of the method in Service.callback - callback to invoke with the response for each regioncom.google.protobuf.ServiceExceptionThrowablepublic RegionLocator getRegionLocator()
TableRegionLocator for this table.getRegionLocator in interface Tablepublic Map<String,byte[]> getRequestAttributes()
TablegetRequestAttributes in interface TableCopyright © 2007–2020 The Apache Software Foundation. All rights reserved.