static class RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable extends RegionAdminServiceCallable<org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse>
Modifier and Type | Field and Description |
---|---|
private List<WAL.Entry> |
entries |
private byte[] |
initialEncodedRegionName |
private AtomicLong |
skippedEntries |
connection, location, replicaId, row, rpcControllerFactory, stub, tableName
Constructor and Description |
---|
RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
HRegionLocation location,
HRegionInfo regionInfo,
byte[] row,
List<WAL.Entry> entries,
AtomicLong skippedEntries) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse |
call(int timeout)
Computes a result, or throws an exception if unable to do so.
|
private org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse |
replayToServer(List<WAL.Entry> entries,
int timeout) |
getExceptionMessage, getExceptionMessageAdditionalDetail, getLocation, getRegionLocations, prepare, setStub, sleep, throwable
private final byte[] initialEncodedRegionName
private final AtomicLong skippedEntries
public RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, TableName tableName, HRegionLocation location, HRegionInfo regionInfo, byte[] row, List<WAL.Entry> entries, AtomicLong skippedEntries)
public org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse call(int timeout) throws IOException
RetryingCallable
timeout
- - the time available for this call. 0 for infinite.IOException
private org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse replayToServer(List<WAL.Entry> entries, int timeout) throws IOException
IOException
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.