static class RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable extends RegionAdminServiceCallable<org.apache.hadoop.hbase.shaded.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 |
---|
RegionReplicaReplayCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
HRegionLocation location,
RegionInfo regionInfo,
byte[] row,
List<WAL.Entry> entries,
AtomicLong skippedEntries) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse |
call(HBaseRpcController controller)
Run RPC call.
|
call, getExceptionMessage, getExceptionMessageAdditionalDetail, getLocation, getRegionLocations, prepare, setStub, sleep, throwable
private final byte[] initialEncodedRegionName
private final AtomicLong skippedEntries
public RegionReplicaReplayCallable(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, TableName tableName, HRegionLocation location, RegionInfo regionInfo, byte[] row, List<WAL.Entry> entries, AtomicLong skippedEntries)
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse call(HBaseRpcController controller) throws Exception
RegionAdminServiceCallable
call
in class RegionAdminServiceCallable<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse>
controller
- PayloadCarryingRpcController is a mouthful but it at a minimum is a facade
on protobuf so we don't have to put protobuf everywhere; we can keep it
behind this class. nException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.