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
BatchErrors.actions
RetriesExhaustedWithDetailsException.actions
static final Comparator<Row>
Row.COMPARATOR
AsyncProcessTask.Builder.rows
AsyncProcessTask.rows
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 TypeMethodDescriptionAsyncRequestFuture.getFailedOperations()
AsyncRequestFutureImpl.getFailedOperations()
AsyncProcessTask.getRowAccess()
BufferedMutatorImpl.QueueRowAccess.iterator()
Modifier and TypeMethodDescriptionvoid
BatchErrors.add
(Throwable ex, Row row, ServerName serverName) RequestController.Checker.canTakeRow
(HRegionLocation loc, Row row) Checks the data whether it is valid to submit.int
int
int
Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.int
int
Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.int
Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.private static boolean
AsyncBatchRpcRetryingCaller.hasIncrementOrAppend
(Row action) private static boolean
AsyncProcess.hasIncrementOrAppend
(Row action) private boolean
AsyncRequestFutureImpl.isActionComplete
(int index, Row row) Checks if the action is complete; used on error to prevent needless retries.(package private) static boolean
AsyncProcess.isReplicaGet
(Row row) (package private) AsyncRequestFutureImpl.Retry
AsyncRequestFutureImpl.manageError
(int originalIndex, Row row, AsyncRequestFutureImpl.Retry canRetry, Throwable throwable, ServerName server) Check that we can retry acts accordingly: logs, set the error status.private void
private void
AsyncRequestFutureImpl.setError
(int index, Row row, Throwable throwable, ServerName server) Sets the error from a particular action.private void
AsyncProcess.setNonce
(NonceGenerator ng, Row r, Action action) AsyncRequestFutureImpl.trySetResultSimple
(int index, Row row, boolean isError, Object result, ServerName server, boolean isFromReplica) Tries to set the result or error for a particular action as if there were no replica calls.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>>
void
void
<T> List<CompletableFuture<T>>
private <T> List<CompletableFuture<T>>
default void
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations.default <T> CompletableFuture<List<T>>
A simple version of batch.<R> void
HTable.batchCallback
(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback) default <R> void
Table.batchCallback
(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback) Same asTable.batch(List, Object[])
, but with a callback.static <R> void
HTable.doBatchWithCallback
(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback, ClusterConnection connection, ExecutorService pool, TableName tableName, Map<String, byte[]> requestAttributes) <R> void
HTable.processBatchCallback
(List<? extends Row> list, Object[] results, Batch.Callback<R> callback) Process a mixed batch of Get, Put and Delete actions.AsyncProcessTask.Builder.setRowAccess
(List<? extends Row> rows) AsyncProcessTask.Builder.setRowAccess
(RowAccess<? extends Row> rows) 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) (package private)
AsyncProcessTask
(ExecutorService pool, TableName tableName, RowAccess<? extends Row> rows, AsyncProcessTask.SubmittedRows size, Batch.Callback<T> callback, CancellableRegionServerCallable callable, boolean needResults, int rpcTimeout, int operationTimeout, Object[] results, 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<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) -
Uses of Row in org.apache.hadoop.hbase.util
Modifier and TypeMethodDescription<R> void
MultiHConnection.processBatchCallback
(List<? extends Row> actions, TableName tableName, Object[] results, Batch.Callback<R> callback) Randomly pick a connection and process the batch of actions for a given table