| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AppendPerforms Append operations on a single row. | 
| class  | DeleteUsed to perform Delete operations on a single row. | 
| class  | GetUsed to perform Get operations on a single row. | 
| class  | IncrementUsed to perform Increment operations on a single row. | 
| class  | Mutation | 
| class  | PutUsed to perform Put operations for a single row. | 
| class  | RowMutationsPerforms multiple mutations atomically on a single row. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected List<Row> | HTable. writeAsyncBuffer | 
| Modifier and Type | Method and Description | 
|---|---|
| Row | Action. getAction() | 
| Row | RetriesExhaustedWithDetailsException. getRow(int i) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Row> | HTable. getWriteBuffer()Deprecated. 
 since 0.96. This is an internal buffer that should not be read nor write. | 
| Modifier and Type | Method and Description | 
|---|---|
| int | Get. compareTo(Row other) | 
| int | RowMutations. compareTo(Row i) | 
| int | Mutation. compareTo(Row d) | 
| int | Increment. compareTo(Row i) | 
| Modifier and Type | Method and Description | 
|---|---|
| Object[] | HTableInterface. batch(List<? extends Row> actions)Same as  HTableInterface.batch(List, Object[]), but returns an array of
 results instead of using a results parameter reference. | 
| Object[] | HTable. batch(List<? extends Row> actions) | 
| void | HTableInterface. batch(List<? extends Row> actions,
     Object[] results)Method that does a batch call on Deletes, Gets, Puts, Increments, Appends and RowMutations. | 
| void | HTable. batch(List<? extends Row> actions,
     Object[] results) | 
| <R> Object[] | HTableInterface. batchCallback(List<? extends Row> actions,
             Batch.Callback<R> callback)Same as  HTableInterface.batch(List), but with a callback. | 
| <R> Object[] | HTable. batchCallback(List<? extends Row> actions,
             Batch.Callback<R> callback) | 
| <R> void | HTableInterface. batchCallback(List<? extends Row> actions,
             Object[] results,
             Batch.Callback<R> callback)Same as  HTableInterface.batch(List, Object[]), but with a callback. | 
| <R> void | HTable. batchCallback(List<? extends Row> actions,
             Object[] results,
             Batch.Callback<R> callback) | 
| static void | HTableUtil. bucketRsBatch(HTable htable,
             List<Row> rows)Processes a List of Rows (Put, Delete) and writes them to an HTable instance in RegionServer buckets via the htable.batch method. | 
| static String | RetriesExhaustedWithDetailsException. getDesc(List<Throwable> exceptions,
       List<? extends Row> actions,
       List<String> hostnamePort) | 
| void | HConnection. processBatch(List<? extends Row> actions,
            byte[] tableName,
            ExecutorService pool,
            Object[] results)Deprecated.  | 
| void | HTable. processBatch(List<? extends Row> list,
            Object[] results)Parameterized batch processing, allowing varying return types for different
  Rowimplementations. | 
| void | HConnection. processBatch(List<? extends Row> actions,
            TableName tableName,
            ExecutorService pool,
            Object[] results)Deprecated. 
 | 
| <R> void | HConnection. processBatchCallback(List<? extends Row> list,
                    byte[] tableName,
                    ExecutorService pool,
                    Object[] results,
                    Batch.Callback<R> callback)Deprecated.  | 
| <R> void | HTable. processBatchCallback(List<? extends Row> list,
                    Object[] results,
                    Batch.Callback<R> callback)Process a mixed batch of Get, Put and Delete actions. | 
| <R> void | HConnection. processBatchCallback(List<? extends Row> list,
                    TableName tableName,
                    ExecutorService pool,
                    Object[] results,
                    Batch.Callback<R> callback) | 
| Constructor and Description | 
|---|
| Action(Row action,
      int originalIndex) | 
| Constructor and Description | 
|---|
| RetriesExhaustedWithDetailsException(List<Throwable> exceptions,
                                    List<? extends Row> actions,
                                    List<String> hostnameAndPort) | 
Copyright © 2013 The Apache Software Foundation. All Rights Reserved.