Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.rest.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 |
---|---|
private List<Row> |
AsyncProcess.BatchErrors.actions |
(package private) List<Row> |
RetriesExhaustedWithDetailsException.actions |
private Set<MultiServerCallable<Row>> |
AsyncProcess.AsyncRequestFutureImpl.callsInProgress |
private Set<MultiServerCallable<Row>> |
AsyncProcess.AsyncRequestFutureImpl.SingleServerRequestRunnable.callsInProgress |
private List<Action<Row>> |
AsyncProcess.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.initialActions |
private MultiAction<Row> |
AsyncProcess.AsyncRequestFutureImpl.SingleServerRequestRunnable.multiAction |
Modifier and Type | Method and Description |
---|---|
Row |
Action.getAction() |
Row |
RetriesExhaustedWithDetailsException.getRow(int i) |
Modifier and Type | Method and Description |
---|---|
protected MultiServerCallable<Row> |
AsyncProcess.createCallable(ServerName server,
TableName tableName,
MultiAction<Row> multi)
Create a callable.
|
private static Map<String,List<Row>> |
HTableUtil.createRsRowMap(RegionLocator htable,
List<Row> rows)
Deprecated.
|
Set<MultiServerCallable<Row>> |
AsyncProcess.AsyncRequestFutureImpl.getCallsInProgress() |
List<? extends Row> |
AsyncProcess.AsyncRequestFuture.getFailedOperations() |
List<? extends Row> |
AsyncProcess.AsyncRequestFutureImpl.getFailedOperations() |
List<Row> |
HTable.getWriteBuffer()
Deprecated.
since 0.96. This is an internal buffer that should not be read nor write.
|
List<Row> |
BufferedMutatorImpl.getWriteBuffer()
Deprecated.
Going away when we drop public support for
HTableInterface .
Ó |
Modifier and Type | Method and Description |
---|---|
void |
AsyncProcess.BatchErrors.add(Throwable ex,
Row row,
ServerName serverName) |
int |
RowMutations.compareTo(Row i) |
int |
Increment.compareTo(Row i) |
int |
Get.compareTo(Row other) |
int |
Mutation.compareTo(Row d) |
int |
RegionCoprocessorServiceExec.compareTo(Row o) |
private boolean |
AsyncProcess.AsyncRequestFutureImpl.isActionComplete(int index,
Row row)
Checks if the action is complete; used on error to prevent needless retries.
|
private static boolean |
AsyncProcess.isReplicaGet(Row row) |
AsyncProcess.Retry |
AsyncProcess.AsyncRequestFutureImpl.manageError(int originalIndex,
Row row,
AsyncProcess.Retry canRetry,
Throwable throwable,
ServerName server)
Check that we can retry acts accordingly: logs, set the error status.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.setError(int index,
Row row,
Throwable throwable,
ServerName server)
Sets the error from a particular action.
|
private static void |
AsyncProcess.setNonce(NonceGenerator ng,
Row r,
Action<Row> action) |
private AsyncProcess.ReplicaResultState |
AsyncProcess.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 |
---|---|
private static void |
AsyncProcess.addAction(ServerName server,
byte[] regionName,
Action<Row> action,
Map<ServerName,MultiAction<Row>> actionsByServer,
long nonceGroup)
Helper that is used when grouping the actions per region server.
|
private static void |
AsyncProcess.addAction(ServerName server,
byte[] regionName,
Action<Row> action,
Map<ServerName,MultiAction<Row>> actionsByServer,
long nonceGroup)
Helper that is used when grouping the actions per region server.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActions(int index,
Map<ServerName,MultiAction<Row>> actionsByServer,
List<Action<Row>> unknownReplicaActions)
Add replica actions to action map by server.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActions(int index,
Map<ServerName,MultiAction<Row>> actionsByServer,
List<Action<Row>> unknownReplicaActions)
Add replica actions to action map by server.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActionsAgain(Action<Row> action,
Map<ServerName,MultiAction<Row>> actionsByServer) |
private void |
AsyncProcess.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActionsAgain(Action<Row> action,
Map<ServerName,MultiAction<Row>> actionsByServer) |
Object[] |
HTable.batch(List<? extends Row> actions)
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use
HTable.batch(List, Object[]) instead. |
Object[] |
Table.batch(List<? extends Row> actions)
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use
Table.batch(List, Object[]) instead. |
Object[] |
HTablePool.PooledHTable.batch(List<? extends Row> actions)
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use
HTablePool.PooledHTable.batch(List, Object[]) instead. |
Object[] |
HTableWrapper.batch(List<? extends Row> actions)
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use
HTableWrapper.batch(List, Object[]) instead. |
void |
HTable.batch(List<? extends Row> actions,
Object[] results)
Method that does a batch call on Deletes, Gets, Puts, Increments and Appends.
|
void |
Table.batch(List<? extends Row> actions,
Object[] results)
Method that does a batch call on Deletes, Gets, Puts, Increments and Appends.
|
void |
HTablePool.PooledHTable.batch(List<? extends Row> actions,
Object[] results) |
void |
HTableWrapper.batch(List<? extends Row> actions,
Object[] results) |
<R> Object[] |
HTable.batchCallback(List<? extends Row> actions,
Batch.Callback<R> callback)
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use
HTable.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback)
instead. |
<R> Object[] |
Table.batchCallback(List<? extends Row> actions,
Batch.Callback<R> callback)
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the
partially executed results. Use
Table.batchCallback(List, Object[],
org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead. |
<R> Object[] |
HTablePool.PooledHTable.batchCallback(List<? extends Row> actions,
Batch.Callback<R> callback)
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use
HTablePool.PooledHTable.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback)
instead. |
<R> Object[] |
HTableWrapper.batchCallback(List<? extends Row> actions,
Batch.Callback<R> callback)
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use
HTableWrapper.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback)
instead. |
<R> void |
HTable.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback)
Same as
Table.batch(List, Object[]) , but with a callback. |
<R> void |
Table.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback)
Same as
Table.batch(List, Object[]) , but with a callback. |
<R> void |
HTablePool.PooledHTable.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback) |
<R> void |
HTableWrapper.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback) |
static void |
HTableUtil.bucketRsBatch(HTable htable,
List<Row> rows)
Deprecated.
Processes a List of Rows (Put, Delete) and writes them to an HTable instance in RegionServer buckets via the htable.batch method.
|
protected <CResult> AsyncProcess.AsyncRequestFutureImpl<CResult> |
AsyncProcess.createAsyncRequestFuture(TableName tableName,
List<Action<Row>> actions,
long nonceGroup,
ExecutorService pool,
Batch.Callback<CResult> callback,
Object[] results,
boolean needResults) |
protected MultiServerCallable<Row> |
AsyncProcess.createCallable(ServerName server,
TableName tableName,
MultiAction<Row> multi)
Create a callable.
|
protected RpcRetryingCaller<MultiResponse> |
AsyncProcess.createCaller(MultiServerCallable<Row> callable)
Create a caller.
|
private static Map<String,List<Row>> |
HTableUtil.createRsRowMap(RegionLocator htable,
List<Row> rows)
Deprecated.
|
private RegionLocations |
AsyncProcess.AsyncRequestFutureImpl.findAllLocationsOrFail(Action<Row> action,
boolean useCache) |
static String |
RetriesExhaustedWithDetailsException.getDesc(List<Throwable> exceptions,
List<? extends Row> actions,
List<String> hostnamePort) |
private Collection<? extends Runnable> |
AsyncProcess.AsyncRequestFutureImpl.getNewMultiActionRunnable(ServerName server,
MultiAction<Row> multiAction,
int numAttempt) |
private HRegionLocation |
AsyncProcess.AsyncRequestFutureImpl.getReplicaLocationOrFail(Action<Row> action) |
private void |
AsyncProcess.AsyncRequestFutureImpl.groupAndSendMultiAction(List<Action<Row>> currentActions,
int numAttempt)
Group a list of actions per region servers, and send them.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.manageLocationError(Action<Row> action,
Exception ex) |
void |
ConnectionManager.HConnectionImplementation.processBatch(List<? extends Row> list,
byte[] tableName,
ExecutorService pool,
Object[] results)
Deprecated.
|
void |
ConnectionAdapter.processBatch(List<? extends Row> actions,
byte[] tableName,
ExecutorService pool,
Object[] results)
Deprecated.
|
void |
HConnection.processBatch(List<? extends Row> actions,
byte[] tableName,
ExecutorService pool,
Object[] results)
Deprecated.
|
void |
HTable.processBatch(List<? extends Row> list,
Object[] results)
Parameterized batch processing, allowing varying return types for different
Row implementations. |
void |
ConnectionManager.HConnectionImplementation.processBatch(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results)
Deprecated.
|
void |
ConnectionAdapter.processBatch(List<? extends Row> actions,
TableName tableName,
ExecutorService pool,
Object[] results)
Deprecated.
|
void |
HConnection.processBatch(List<? extends Row> actions,
TableName tableName,
ExecutorService pool,
Object[] results)
Deprecated.
since 0.96 - Use
Table.batch(java.util.List<? extends org.apache.hadoop.hbase.client.Row>, java.lang.Object[]) instead |
<R> void |
ConnectionManager.HConnectionImplementation.processBatchCallback(List<? extends Row> list,
byte[] tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
Deprecated.
|
<R> void |
ConnectionAdapter.processBatchCallback(List<? extends Row> list,
byte[] tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
Deprecated.
|
<R> void |
HConnection.processBatchCallback(List<? extends Row> list,
byte[] tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
Deprecated.
|
<R> void |
HTable.processBatchCallback(List<? extends Row> list,
Object[] results,
Batch.Callback<R> callback)
Process a mixed batch of Get, Put and Delete actions.
|
<R> void |
ConnectionManager.HConnectionImplementation.processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
|
<R> void |
ConnectionAdapter.processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
Deprecated.
|
<R> void |
HConnection.processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
|
private void |
AsyncProcess.AsyncRequestFutureImpl.receiveGlobalFailure(MultiAction<Row> rsActions,
ServerName server,
int numAttempt,
Throwable t)
Resubmit all the actions from this multiaction after a failure.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.receiveMultiAction(MultiAction<Row> multiAction,
ServerName server,
MultiResponse responses,
int numAttempt)
Called when we receive the result of a server query.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.resubmit(ServerName oldServer,
List<Action<Row>> toReplay,
int numAttempt,
int failureCount,
Throwable throwable)
Log as much info as possible, and, if there is something to replay,
submit it again after a back off sleep.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.sendMultiAction(Map<ServerName,MultiAction<Row>> actionsByServer,
int numAttempt,
List<Action<Row>> actionsForReplicaThread,
boolean reuseThread)
Send a multi action structure to the servers, after a delay depending on the attempt
number.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.sendMultiAction(Map<ServerName,MultiAction<Row>> actionsByServer,
int numAttempt,
List<Action<Row>> actionsForReplicaThread,
boolean reuseThread)
Send a multi action structure to the servers, after a delay depending on the attempt
number.
|
private static void |
AsyncProcess.setNonce(NonceGenerator ng,
Row r,
Action<Row> action) |
private void |
AsyncProcess.AsyncRequestFutureImpl.setResult(Action<Row> action,
Object result)
Sets the non-error result from a particular action.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.startWaitingForReplicaCalls(List<Action<Row>> actionsForReplicaThread)
Starts waiting to issue replica calls on a different thread; or issues them immediately.
|
<CResult> AsyncProcess.AsyncRequestFuture |
AsyncProcess.submit(ExecutorService pool,
TableName tableName,
List<? extends Row> rows,
boolean atLeastOne,
Batch.Callback<CResult> callback,
boolean needResults)
Extract from the rows list what we can submit.
|
<CResult> AsyncProcess.AsyncRequestFuture |
AsyncProcess.submit(TableName tableName,
List<? extends Row> rows,
boolean atLeastOne,
Batch.Callback<CResult> callback,
boolean needResults)
|
<CResult> AsyncProcess.AsyncRequestFuture |
AsyncProcess.submitAll(ExecutorService pool,
TableName tableName,
List<? extends Row> rows,
Batch.Callback<CResult> callback,
Object[] results)
Submit immediately the list of rows, whatever the server status.
|
<CResult> AsyncProcess.AsyncRequestFuture |
AsyncProcess.submitAll(TableName tableName,
List<? extends Row> rows,
Batch.Callback<CResult> callback,
Object[] results)
|
(package private) <CResult> AsyncProcess.AsyncRequestFuture |
AsyncProcess.submitMultiActions(TableName tableName,
List<Action<Row>> retainedActions,
long nonceGroup,
Batch.Callback<CResult> callback,
Object[] results,
boolean needResults,
List<Exception> locationErrors,
List<Integer> locationErrorRows,
Map<ServerName,MultiAction<Row>> actionsByServer,
ExecutorService pool) |
(package private) <CResult> AsyncProcess.AsyncRequestFuture |
AsyncProcess.submitMultiActions(TableName tableName,
List<Action<Row>> retainedActions,
long nonceGroup,
Batch.Callback<CResult> callback,
Object[] results,
boolean needResults,
List<Exception> locationErrors,
List<Integer> locationErrorRows,
Map<ServerName,MultiAction<Row>> actionsByServer,
ExecutorService pool) |
RetriesExhaustedWithDetailsException |
AsyncProcess.waitForAllPreviousOpsAndReset(List<Row> failedRows,
String tableName)
Only used w/useGlobalErrors ctor argument, for HTable backward compat.
|
Constructor and Description |
---|
Action(Row action,
int originalIndex) |
Constructor and Description |
---|
AsyncProcess.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable(List<Action<Row>> initialActions,
long startTime) |
AsyncProcess.AsyncRequestFutureImpl.SingleServerRequestRunnable(MultiAction<Row> multiAction,
int numAttempt,
ServerName server,
Set<MultiServerCallable<Row>> callsInProgress) |
AsyncProcess.AsyncRequestFutureImpl.SingleServerRequestRunnable(MultiAction<Row> multiAction,
int numAttempt,
ServerName server,
Set<MultiServerCallable<Row>> callsInProgress) |
AsyncProcess.AsyncRequestFutureImpl(TableName tableName,
List<Action<Row>> actions,
long nonceGroup,
ExecutorService pool,
boolean needResults,
Object[] results,
Batch.Callback<CResult> callback) |
RetriesExhaustedWithDetailsException(List<Throwable> exceptions,
List<Row> actions,
List<String> hostnameAndPort) |
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 |
---|---|
Object[] |
RemoteHTable.batch(List<? extends Row> actions) |
void |
RemoteHTable.batch(List<? extends Row> actions,
Object[] results) |
<R> Object[] |
RemoteHTable.batchCallback(List<? extends Row> actions,
Batch.Callback<R> callback) |
<R> void |
RemoteHTable.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–2019 The Apache Software Foundation. All rights reserved.