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.actionsRetriesExhaustedWithDetailsException.actionsstatic final Comparator<Row>Row.COMPARATORMethods 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.intprivate static booleanAsyncBatchRpcRetryingCaller.hasIncrementOrAppend(Row action) private voidMethod 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 voidMethod that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations.voiddefault <T> CompletableFuture<List<T>>A simple version of batch.default <R> voidTable.batchCallback(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback) Deprecated.since 3.0.0, will removed in 4.0.0.<R> voidTableOverAsyncTable.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 RowModifierConstructorDescriptionprivateCheckAndMutate(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, TimeRange timeRange, Row action, boolean queryMetricsEnabled) privateCheckAndMutate(byte[] row, Filter filter, TimeRange timeRange, Row action, boolean queryMetricsEnabled) 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.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<? extends 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)