Uses of Interface
org.apache.hadoop.hbase.client.Row
Package
Description
Provides HBase Client
Table of Contents
-
Uses of Row in org.apache.hadoop.hbase.client
Modifier 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.Modifier and TypeFieldDescriptionprivate final Row
Action.action
private final Row
CheckAndMutate.action
Modifier and TypeFieldDescriptionAsyncRpcRetryingCallerFactory.BatchCallerBuilder.actions
RetriesExhaustedWithDetailsException.actions
static final Comparator<Row>
Row.COMPARATOR
Modifier and TypeMethodDescriptionprivate <T,
R extends OperationWithAttributes & Row>
AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder<T>RawAsyncTableImpl.newCaller
(R row, long rpcTimeoutNs) Modifier and TypeMethodDescriptionAction.getAction()
CheckAndMutate.getAction()
Returns the action done if check succeedsRetriesExhaustedWithDetailsException.getRow
(int i) Modifier 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
Modifier 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) ModifierConstructorDescriptionprivate
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) ModifierConstructorDescriptionAsyncBatchRpcRetryingCaller
(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
Modifier and TypeMethodDescriptionTableOperationSpanBuilder.setContainerOperations
(Row row) TableOperationSpanBuilder.setOperation
(Row row) private static Set<HBaseSemanticAttributes.Operation>
TableOperationSpanBuilder.unpackRowOperations
(Row row) private static HBaseSemanticAttributes.Operation
Modifier and TypeMethodDescriptionTableOperationSpanBuilder.setContainerOperations
(Collection<? extends Row> operations) TableOperationSpanBuilder.setOperation
(Collection<? extends Row> operations) -
Uses of Row in org.apache.hadoop.hbase.coprocessor
Modifier and TypeFieldDescriptionprivate org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap<Class<? extends Row>,
MetaTableMetrics.MetaTableOps> MetaTableMetrics.opsNameMap
Modifier 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
-
Uses of Row in org.apache.hadoop.hbase.replication.regionserver
Modifier 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
Modifier and TypeMethodDescriptionvoid
<R> void
ThriftTable.batchCallback
(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback)