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 TypeClassDescriptionclassPerforms Append operations on a single row.final classUsed to perform CheckAndMutate operations.classUsed to perform Delete operations on a single row.classUsed to perform Get operations on a single row.classUsed to perform Increment operations on a single row.classclassUsed to perform Put operations for a single row.classRepresents a coprocessor service method execution against a single region.classPerforms multiple mutations atomically on a single row.Fields in org.apache.hadoop.hbase.client declared as RowModifier and TypeFieldDescriptionprivate final RowAction.actionprivate final RowCheckAndMutate.actionFields in org.apache.hadoop.hbase.client with type parameters of type RowModifier and TypeFieldDescriptionAsyncRpcRetryingCallerFactory.BatchCallerBuilder.actionsBatchErrors.actionsRetriesExhaustedWithDetailsException.actionsstatic final Comparator<Row>Row.COMPARATORAsyncProcessTask.Builder.rowsAsyncProcessTask.rowsMethods 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 that return types with arguments of type RowModifier and TypeMethodDescriptionAsyncRequestFuture.getFailedOperations()AsyncRequestFutureImpl.getFailedOperations()AsyncProcessTask.getRowAccess()BufferedMutatorImpl.QueueRowAccess.iterator()Methods in org.apache.hadoop.hbase.client with parameters of type RowModifier and TypeMethodDescriptionvoidBatchErrors.add(Throwable ex, Row row, ServerName serverName) RequestController.Checker.canTakeRow(HRegionLocation loc, Row row) Checks the data whether it is valid to submit.intintintDeprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.intintDeprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.intDeprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.private static booleanAsyncBatchRpcRetryingCaller.hasIncrementOrAppend(Row action) private static booleanAsyncProcess.hasIncrementOrAppend(Row action) private booleanAsyncRequestFutureImpl.isActionComplete(int index, Row row) Checks if the action is complete; used on error to prevent needless retries.(package private) static booleanAsyncProcess.isReplicaGet(Row row) (package private) AsyncRequestFutureImpl.RetryAsyncRequestFutureImpl.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 voidprivate voidAsyncRequestFutureImpl.setError(int index, Row row, Throwable throwable, ServerName server) Sets the error from a particular action.private voidAsyncProcess.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.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>>voidvoid<T> List<CompletableFuture<T>>private <T> List<CompletableFuture<T>>default voidMethod that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations.default <T> CompletableFuture<List<T>>A simple version of batch.<R> voidHTable.batchCallback(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback) default <R> voidTable.batchCallback(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback) Same asTable.batch(List, Object[]), but with a callback.static <R> voidHTable.doBatchWithCallback(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback, ClusterConnection connection, ExecutorService pool, TableName tableName, Map<String, byte[]> requestAttributes) <R> voidHTable.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) Constructors in org.apache.hadoop.hbase.client with parameters of type RowModifierConstructorDescriptionprivateCheckAndMutate(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, TimeRange timeRange, Row action) privateCheckAndMutate(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) (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
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.OperationMethod 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.opsNameMapMethods in org.apache.hadoop.hbase.coprocessor with parameters of type RowModifier and TypeMethodDescriptionprivate StringMetaTableMetrics.ExampleRegionObserverMeta.getRegionIdFromOp(Row op) Get regionId from Ops such as: get, put, delete.private StringMetaTableMetrics.ExampleRegionObserverMeta.getTableNameFromOp(Row op) Get table name from Ops such as: get, put, delete.private voidMetaTableMetrics.ExampleRegionObserverMeta.opMetricRegisterAndMark(Row op) private voidMetaTableMetrics.ExampleRegionObserverMeta.regionMetricRegisterAndMark(Row op) private voidMetaTableMetrics.ExampleRegionObserverMeta.registerAndMarkMetrics(ObserverContext<RegionCoprocessorEnvironment> e, Row row) private voidMetaTableMetrics.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 voidReplicationSink.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> voidThriftTable.batchCallback(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback) -
Uses of Row in org.apache.hadoop.hbase.util
Method parameters in org.apache.hadoop.hbase.util with type arguments of type RowModifier and TypeMethodDescription<R> voidMultiHConnection.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