Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.rest.client | |
org.apache.hadoop.hbase.thrift2.client | |
org.apache.hadoop.hbase.util |
Modifier and Type | Class and Description |
---|---|
class |
Append
Performs Append operations on a single row.
|
class |
Delete
Used to perform Delete operations on a single row.
|
class |
Get
Used to perform Get operations on a single row.
|
class |
Increment
Used to perform Increment operations on a single row.
|
class |
Mutation |
class |
Put
Used to perform Put operations for a single row.
|
class |
RegionCoprocessorServiceExec
Represents a coprocessor service method execution against a single region.
|
class |
RowMutations
Performs multiple mutations atomically on a single row.
|
Modifier and Type | Field and Description |
---|---|
private Row |
Action.action |
Modifier and Type | Field and Description |
---|---|
(package private) List<Row> |
RetriesExhaustedWithDetailsException.actions |
(package private) List<Row> |
BatchErrors.actions |
private List<? extends Row> |
AsyncRpcRetryingCallerFactory.BatchCallerBuilder.actions |
static Comparator<Row> |
Row.COMPARATOR |
private RowAccess<? extends Row> |
AsyncProcessTask.rows |
private RowAccess<? extends Row> |
AsyncProcessTask.Builder.rows |
Modifier and Type | Method and Description |
---|---|
private <T,R extends OperationWithAttributes & Row> |
RawAsyncTableImpl.newCaller(R row,
long rpcTimeoutNs) |
Modifier and Type | Method and Description |
---|---|
Row |
Action.getAction() |
Row |
RetriesExhaustedWithDetailsException.getRow(int i) |
Modifier and Type | Method and Description |
---|---|
List<? extends Row> |
AsyncRequestFuture.getFailedOperations() |
List<? extends Row> |
AsyncRequestFutureImpl.getFailedOperations() |
RowAccess<? extends Row> |
AsyncProcessTask.getRowAccess() |
Iterator<Row> |
BufferedMutatorImpl.QueueRowAccess.iterator() |
Modifier and Type | Method and Description |
---|---|
void |
BatchErrors.add(Throwable ex,
Row row,
ServerName serverName) |
RequestController.ReturnCode |
RequestController.Checker.canTakeRow(HRegionLocation loc,
Row row)
Checks the data whether it is valid to submit.
|
int |
Mutation.compareTo(Row d)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
COMPARATOR instead |
int |
RowMutations.compareTo(Row i)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
COMPARATOR instead |
int |
Row.compareTo(Row var1)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
COMPARATOR instead |
int |
RegionCoprocessorServiceExec.compareTo(Row o) |
int |
Get.compareTo(Row other) |
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 |
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) |
private AsyncRequestFutureImpl.ReplicaResultState |
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 Type | Method and Description |
---|---|
AsyncRpcRetryingCallerFactory.BatchCallerBuilder |
AsyncRpcRetryingCallerFactory.BatchCallerBuilder.actions(List<? extends Row> actions) |
<T> List<CompletableFuture<T>> |
AsyncTable.batch(List<? extends Row> actions)
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends and RowMutations.
|
<T> List<CompletableFuture<T>> |
RawAsyncTableImpl.batch(List<? extends Row> actions) |
<T> List<CompletableFuture<T>> |
AsyncTableImpl.batch(List<? extends Row> actions) |
private <T> List<CompletableFuture<T>> |
RawAsyncTableImpl.batch(List<? extends Row> actions,
long rpcTimeoutNs) |
void |
HTable.batch(List<? extends Row> actions,
Object[] results) |
default void |
Table.batch(List<? extends Row> actions,
Object[] results)
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations.
|
void |
HTable.batch(List<? extends Row> actions,
Object[] results,
int rpcTimeout) |
default <T> CompletableFuture<List<T>> |
AsyncTable.batchAll(List<? extends Row> actions)
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 as
Table.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) |
static String |
RetriesExhaustedWithDetailsException.getDesc(List<Throwable> exceptions,
List<? extends Row> actions,
List<String> hostnamePort) |
<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<T> |
AsyncProcessTask.Builder.setRowAccess(List<? extends Row> rows) |
AsyncProcessTask.Builder<T> |
AsyncProcessTask.Builder.setRowAccess(RowAccess<? extends Row> rows) |
private List<CompletableFuture<Void>> |
RawAsyncTableImpl.voidMutate(List<? extends Row> actions) |
Constructor and Description |
---|
Action(Row action,
int originalIndex) |
Action(Row action,
int originalIndex,
int priority) |
Constructor and Description |
---|
AsyncBatchRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
AsyncConnectionImpl conn,
TableName tableName,
List<? extends Row> actions,
long pauseNs,
long pauseForCQTBENs,
int maxAttempts,
long operationTimeoutNs,
long rpcTimeoutNs,
int startLogErrorsCnt) |
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) |
RetriesExhaustedWithDetailsException(List<Throwable> exceptions,
List<Row> actions,
List<String> hostnameAndPort) |
Modifier and Type | Method and Description |
---|---|
private 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) |
Modifier and Type | Method and Description |
---|---|
protected void |
ReplicationSink.batch(TableName tableName,
Collection<List<Row>> allRows)
Do the changes and handle the pool
|
Modifier and Type | Method and Description |
---|---|
void |
RemoteHTable.batch(List<? extends Row> actions,
Object[] results) |
<R> void |
RemoteHTable.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback) |
Modifier and Type | Method and Description |
---|---|
void |
ThriftTable.batch(List<? extends Row> actions,
Object[] results) |
<R> void |
ThriftTable.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback) |
Modifier and Type | Method and Description |
---|---|
<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
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.