@InterfaceAudience.Private public class RecoveredReplicationSource extends ReplicationSource
ReplicationSource.LogsComparator
conf, DEFAULT_WAIT_ON_ENDPOINT_SECONDS, fs, manager, queueId, queueSizePerGroup, queueStorage, replicationPeer, replicationQueueInfo, server, WAIT_ON_ENDPOINT_SECONDS, walEntryFilter, workerThreads
Constructor and Description |
---|
RecoveredReplicationSource() |
Modifier and Type | Method and Description |
---|---|
protected RecoveredReplicationSourceShipper |
createNewShipper(String walGroupId,
PriorityBlockingQueue<org.apache.hadoop.fs.Path> queue) |
String |
getPeerId()
Get the id that the source is replicating to.
|
ServerName |
getServerWALsBelongTo()
The queue of WALs only belong to one region server.
|
void |
init(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueueStorage queueStorage,
ReplicationPeer replicationPeer,
Server server,
String peerClusterZnode,
UUID clusterId,
WALFileLengthProvider walFileLengthProvider,
MetricsSource metrics)
Instantiation method used by region servers
|
boolean |
isRecovered() |
void |
locateRecoveredPaths(PriorityBlockingQueue<org.apache.hadoop.fs.Path> queue) |
addHFileRefs, enqueueLog, getCurrentPath, getQueueId, getReplicationEndpoint, getSourceManager, getSourceMetrics, getStats, getWALFileLengthProvider, getWalGroupStatus, isPeerEnabled, isSourceActive, postShipEdits, sleepForRetries, startup, terminate, terminate, terminate, tryThrottle, uncaughtException
public void init(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, ReplicationSourceManager manager, ReplicationQueueStorage queueStorage, ReplicationPeer replicationPeer, Server server, String peerClusterZnode, UUID clusterId, WALFileLengthProvider walFileLengthProvider, MetricsSource metrics) throws IOException
ReplicationSource
init
in interface ReplicationSourceInterface
init
in class ReplicationSource
conf
- configuration to usefs
- file system to usemanager
- replication manager to ping toserver
- the server for this region serverpeerClusterZnode
- the id of our replication queueclusterId
- unique UUID for the clustermetrics
- metrics for replication sourceIOException
protected RecoveredReplicationSourceShipper createNewShipper(String walGroupId, PriorityBlockingQueue<org.apache.hadoop.fs.Path> queue)
createNewShipper
in class ReplicationSource
public void locateRecoveredPaths(PriorityBlockingQueue<org.apache.hadoop.fs.Path> queue) throws IOException
IOException
public String getPeerId()
ReplicationSourceInterface
getPeerId
in interface ReplicationSourceInterface
getPeerId
in class ReplicationSource
public ServerName getServerWALsBelongTo()
ReplicationSourceInterface
getServerWALsBelongTo
in interface ReplicationSourceInterface
getServerWALsBelongTo
in class ReplicationSource
public boolean isRecovered()
Copyright © 2007–2019 Cloudera. All rights reserved.