Uses of Interface
org.apache.hadoop.hbase.client.Row
Packages that use Row
Package
Description
Provides HBase Client
Table of Contents
-
Uses of Row in org.apache.hadoop.hbase.client
Classes in org.apache.hadoop.hbase.client that implement RowModifier and TypeClassDescriptionclass
Performs Append operations on a single row.final class
Used to perform CheckAndMutate operations.class
Used to perform Delete operations on a single row.class
Used to perform Get operations on a single row.class
Used to perform Increment operations on a single row.class
class
Used to perform Put operations for a single row.class
Represents a coprocessor service method execution against a single region.class
Performs multiple mutations atomically on a single row.Fields in org.apache.hadoop.hbase.client declared as RowModifier and TypeFieldDescriptionprivate final Row
Action.action
private final Row
CheckAndMutate.action
Fields in org.apache.hadoop.hbase.client with type parameters of type RowModifier and TypeFieldDescriptionAsyncRpcRetryingCallerFactory.BatchCallerBuilder.actions
RetriesExhaustedWithDetailsException.actions
static final Comparator<Row>
Row.COMPARATOR
Methods in org.apache.hadoop.hbase.client with type parameters of type RowModifier and TypeMethodDescriptionprivate <T,
R extends OperationWithAttributes & Row>
AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder<T>RawAsyncTableImpl.newCaller
(R row, long rpcTimeoutNs) Methods in org.apache.hadoop.hbase.client that return RowModifier and TypeMethodDescriptionAction.getAction()
CheckAndMutate.getAction()
Returns the action done if check succeedsRetriesExhaustedWithDetailsException.getRow
(int i) Methods in org.apache.hadoop.hbase.client with parameters of type RowModifier and TypeMethodDescriptionRequestController.Checker.canTakeRow
(HRegionLocation loc, Row row) Checks the data whether it is valid to submit.int
private static boolean
AsyncBatchRpcRetryingCaller.hasIncrementOrAppend
(Row action) private void
Method parameters in org.apache.hadoop.hbase.client with type arguments of type RowModifier and TypeMethodDescription<T> List<CompletableFuture<T>>
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends and RowMutations.<T> List<CompletableFuture<T>>
<T> List<CompletableFuture<T>>
private <T> List<CompletableFuture<T>>
default void
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations.void
default <T> CompletableFuture<List<T>>
A simple version of batch.default <R> void
Table.batchCallback
(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback) Deprecated.since 3.0.0, will removed in 4.0.0.<R> void
TableOverAsyncTable.batchCallback
(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback) private List<CompletableFuture<Void>>
RawAsyncTableImpl.voidMutate
(List<? extends Row> actions) Constructors in org.apache.hadoop.hbase.client with parameters of type RowModifierConstructorDescriptionprivate
CheckAndMutate
(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, TimeRange timeRange, Row action) private
CheckAndMutate
(byte[] row, Filter filter, TimeRange timeRange, Row action) Constructor parameters in org.apache.hadoop.hbase.client with type arguments of type RowModifierConstructorDescriptionAsyncBatchRpcRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncConnectionImpl conn, TableName tableName, List<? extends Row> actions, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long operationTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes) -
Uses of Row in org.apache.hadoop.hbase.client.trace
Methods in org.apache.hadoop.hbase.client.trace with parameters of type RowModifier and TypeMethodDescriptionTableOperationSpanBuilder.setContainerOperations
(Row row) TableOperationSpanBuilder.setOperation
(Row row) private static Set<HBaseSemanticAttributes.Operation>
TableOperationSpanBuilder.unpackRowOperations
(Row row) private static HBaseSemanticAttributes.Operation
Method parameters in org.apache.hadoop.hbase.client.trace with type arguments of type RowModifier and TypeMethodDescriptionTableOperationSpanBuilder.setContainerOperations
(Collection<? extends Row> operations) TableOperationSpanBuilder.setOperation
(Collection<? extends Row> operations) -
Uses of Row in org.apache.hadoop.hbase.coprocessor
Fields in org.apache.hadoop.hbase.coprocessor with type parameters of type RowModifier and TypeFieldDescriptionprivate org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap<Class<? extends Row>,
MetaTableMetrics.MetaTableOps> MetaTableMetrics.opsNameMap
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type RowModifier and TypeMethodDescriptionprivate String
MetaTableMetrics.ExampleRegionObserverMeta.getRegionIdFromOp
(Row op) Get regionId from Ops such as: get, put, delete.private String
MetaTableMetrics.ExampleRegionObserverMeta.getTableNameFromOp
(Row op) Get table name from Ops such as: get, put, delete.private void
MetaTableMetrics.ExampleRegionObserverMeta.opMetricRegisterAndMark
(Row op) private void
MetaTableMetrics.ExampleRegionObserverMeta.regionMetricRegisterAndMark
(Row op) private void
MetaTableMetrics.ExampleRegionObserverMeta.registerAndMarkMetrics
(ObserverContext<? extends RegionCoprocessorEnvironment> e, Row row) private void
MetaTableMetrics.ExampleRegionObserverMeta.tableMetricRegisterAndMark
(Row op) -
Uses of Row in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver with parameters of type Row -
Uses of Row in org.apache.hadoop.hbase.replication.regionserver
Method parameters in org.apache.hadoop.hbase.replication.regionserver with type arguments of type RowModifier and TypeMethodDescriptionprivate void
ReplicationSink.batch
(TableName tableName, Collection<List<Row>> allRows, int batchRowSizeThreshold) Do the changes and handle the pool -
Uses of Row in org.apache.hadoop.hbase.thrift2.client
Method parameters in org.apache.hadoop.hbase.thrift2.client with type arguments of type RowModifier and TypeMethodDescriptionvoid
<R> void
ThriftTable.batchCallback
(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback)