Uses of Interface
org.apache.hadoop.hbase.client.Row

Packages that use org.apache.hadoop.hbase.client.Row
  • Uses of org.apache.hadoop.hbase.client.Row in org.apache.hadoop.hbase.client

    Classes in org.apache.hadoop.hbase.client that implement org.apache.hadoop.hbase.client.Row in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.client.Append
    Performs Append operations on a single row.
    final class 
    Used to perform CheckAndMutate operations.
    class 
    org.apache.hadoop.hbase.client.Delete
    Used to perform Delete operations on a single row.
    class 
    org.apache.hadoop.hbase.client.Get
    Used to perform Get operations on a single row.
    class 
    org.apache.hadoop.hbase.client.Increment
    Used to perform Increment operations on a single row.
    class 
    org.apache.hadoop.hbase.client.Mutation
     
    class 
    org.apache.hadoop.hbase.client.Put
    Used to perform Put operations for a single row.
    class 
    org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
    Represents a coprocessor service method execution against a single region.
    class 
    org.apache.hadoop.hbase.client.RowMutations
    Performs multiple mutations atomically on a single row.
    Fields in org.apache.hadoop.hbase.client with type parameters of type org.apache.hadoop.hbase.client.Row in in
    Modifier and Type
    Field
    Description
    static final Comparator<org.apache.hadoop.hbase.client.Row>
    Row.COMPARATOR
     
    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.client.Row in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.Row
    Action.getAction()
     
    org.apache.hadoop.hbase.client.Row
    CheckAndMutate.getAction()
    Returns the action done if check succeeds
    org.apache.hadoop.hbase.client.Row
    RetriesExhaustedWithDetailsException.getRow(int i)
     
    Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.client.Row in in
    Modifier and Type
    Method
    Description
    List<? extends org.apache.hadoop.hbase.client.Row>
    AsyncRequestFuture.getFailedOperations()
     
    org.apache.hadoop.hbase.client.RowAccess<? extends org.apache.hadoop.hbase.client.Row>
    AsyncProcessTask.getRowAccess()
     
    Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.Row in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.RequestController.ReturnCode
    RequestController.Checker.canTakeRow(org.apache.hadoop.hbase.HRegionLocation loc, org.apache.hadoop.hbase.client.Row row)
    Checks the data whether it is valid to submit.
    int
    CheckAndMutate.compareTo(org.apache.hadoop.hbase.client.Row row)
     
    int
    Get.compareTo(org.apache.hadoop.hbase.client.Row other)
     
    int
    Mutation.compareTo(org.apache.hadoop.hbase.client.Row d)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    int
    RegionCoprocessorServiceExec.compareTo(org.apache.hadoop.hbase.client.Row o)
     
    int
    Row.compareTo(org.apache.hadoop.hbase.client.Row var1)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    int
    RowMutations.compareTo(org.apache.hadoop.hbase.client.Row i)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    Method parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.client.Row in in
    Modifier and Type
    Method
    Description
    AsyncTable.batch(List<? extends org.apache.hadoop.hbase.client.Row> actions)
    Method that does a batch call on Deletes, Gets, Puts, Increments, Appends and RowMutations.
    void
    HTable.batch(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results)
     
    void
    HTable.batch(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results, int rpcTimeout)
     
    default void
    Table.batch(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results)
    Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations.
    default <T> CompletableFuture<List<T>>
    AsyncTable.batchAll(List<? extends org.apache.hadoop.hbase.client.Row> actions)
    A simple version of batch.
    <R> void
    HTable.batchCallback(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback)
     
    default <R> void
    Table.batchCallback(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback)
    Same as Table.batch(List, Object[]), but with a callback.
    static <R> void
    HTable.doBatchWithCallback(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback, org.apache.hadoop.hbase.client.ClusterConnection connection, ExecutorService pool, org.apache.hadoop.hbase.TableName tableName, Map<String,byte[]> requestAttributes)
     
    <R> void
    HTable.processBatchCallback(List<? extends org.apache.hadoop.hbase.client.Row> list, Object[] results, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback)
    Process a mixed batch of Get, Put and Delete actions.
    org.apache.hadoop.hbase.client.AsyncProcessTask.Builder<T>
    AsyncProcessTask.Builder.setRowAccess(List<? extends org.apache.hadoop.hbase.client.Row> rows)
     
    org.apache.hadoop.hbase.client.AsyncProcessTask.Builder<T>
    AsyncProcessTask.Builder.setRowAccess(org.apache.hadoop.hbase.client.RowAccess<? extends org.apache.hadoop.hbase.client.Row> rows)
     
    Constructors in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.Row in in
    Modifier
    Constructor
    Description
     
    Action(org.apache.hadoop.hbase.client.Row action, int originalIndex)
     
     
    Action(org.apache.hadoop.hbase.client.Row action, int originalIndex, int priority)
     
  • Uses of org.apache.hadoop.hbase.client.Row in org.apache.hadoop.hbase.client.trace

    Methods in org.apache.hadoop.hbase.client.trace with parameters of type org.apache.hadoop.hbase.client.Row in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
    TableOperationSpanBuilder.setContainerOperations(org.apache.hadoop.hbase.client.Row row)
     
    org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
    TableOperationSpanBuilder.setOperation(org.apache.hadoop.hbase.client.Row row)
     
    Method parameters in org.apache.hadoop.hbase.client.trace with type arguments of type org.apache.hadoop.hbase.client.Row in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
    TableOperationSpanBuilder.setContainerOperations(Collection<? extends org.apache.hadoop.hbase.client.Row> operations)
     
    org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
    TableOperationSpanBuilder.setOperation(Collection<? extends org.apache.hadoop.hbase.client.Row> operations)
     
  • Uses of org.apache.hadoop.hbase.client.Row in org.apache.hadoop.hbase.util

    Method parameters in org.apache.hadoop.hbase.util with type arguments of type org.apache.hadoop.hbase.client.Row in in
    Modifier and Type
    Method
    Description
    <R> void
    MultiHConnection.processBatchCallback(List<? extends org.apache.hadoop.hbase.client.Row> actions, org.apache.hadoop.hbase.TableName tableName, Object[] results, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback)
    Randomly pick a connection and process the batch of actions for a given table