@InterfaceAudience.Private public class ReplicationSource extends Object implements ReplicationSourceInterface
A stream is considered down when we cannot contact a region server on the peer cluster for more than 55 seconds by default.
Modifier and Type | Class and Description |
---|---|
static class |
ReplicationSource.LogsComparator
Comparator used to compare logs together based on their start time
|
Modifier and Type | Field and Description |
---|---|
protected org.apache.hadoop.conf.Configuration |
conf |
static int |
DEFAULT_WAIT_ON_ENDPOINT_SECONDS |
protected org.apache.hadoop.fs.FileSystem |
fs |
protected ReplicationSourceManager |
manager |
protected String |
queueId |
protected int |
queueSizePerGroup |
protected ReplicationQueueStorage |
queueStorage |
protected ReplicationPeer |
replicationPeer |
protected ReplicationQueueInfo |
replicationQueueInfo |
protected Server |
server |
static String |
WAIT_ON_ENDPOINT_SECONDS |
protected WALEntryFilter |
walEntryFilter |
protected ConcurrentHashMap<String,ReplicationSourceShipper> |
workerThreads |
Constructor and Description |
---|
ReplicationSource() |
Modifier and Type | Method and Description |
---|---|
void |
addHFileRefs(TableName tableName,
byte[] family,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs)
Add hfile names to the queue to be replicated.
|
protected ReplicationSourceShipper |
createNewShipper(String walGroupId,
PriorityBlockingQueue<org.apache.hadoop.fs.Path> queue) |
void |
enqueueLog(org.apache.hadoop.fs.Path log)
Add a log to the list of logs to replicate
|
org.apache.hadoop.fs.Path |
getCurrentPath()
Get the current log that's replicated
|
String |
getPeerId()
Get the id that the source is replicating to.
|
String |
getQueueId()
Get the queue id that the source is replicating to
|
ReplicationEndpoint |
getReplicationEndpoint() |
ServerName |
getServerWALsBelongTo()
The queue of WALs only belong to one region server.
|
ReplicationSourceManager |
getSourceManager() |
MetricsSource |
getSourceMetrics() |
String |
getStats()
Get a string representation of the current statistics
for this source
|
WALFileLengthProvider |
getWALFileLengthProvider() |
Map<String,ReplicationStatus> |
getWalGroupStatus()
get the stat of replication for each wal group.
|
void |
init(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueueStorage queueStorage,
ReplicationPeer replicationPeer,
Server server,
String queueId,
UUID clusterId,
WALFileLengthProvider walFileLengthProvider,
MetricsSource metrics)
Instantiation method used by region servers
|
boolean |
isPeerEnabled()
check whether the peer is enabled or not
|
boolean |
isSourceActive() |
void |
postShipEdits(List<WAL.Entry> entries,
int batchSize)
Call this after the shipper thread ship some entries to peer cluster.
|
protected boolean |
sleepForRetries(String msg,
int sleepMultiplier)
Do the sleeping logic
|
void |
startup()
Start the replication
|
void |
terminate(String reason)
End the replication
|
void |
terminate(String reason,
Exception cause)
End the replication
|
void |
terminate(String reason,
Exception cause,
boolean join) |
void |
tryThrottle(int batchSize)
Try to throttle when the peer config with a bandwidth
|
protected void |
uncaughtException(Thread t,
Throwable e) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
isRecovered
protected int queueSizePerGroup
protected ReplicationQueueStorage queueStorage
protected ReplicationPeer replicationPeer
protected org.apache.hadoop.conf.Configuration conf
protected ReplicationQueueInfo replicationQueueInfo
protected ReplicationSourceManager manager
protected Server server
protected org.apache.hadoop.fs.FileSystem fs
protected String queueId
protected volatile WALEntryFilter walEntryFilter
protected final ConcurrentHashMap<String,ReplicationSourceShipper> workerThreads
public static final String WAIT_ON_ENDPOINT_SECONDS
public static final int DEFAULT_WAIT_ON_ENDPOINT_SECONDS
public void init(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, ReplicationSourceManager manager, ReplicationQueueStorage queueStorage, ReplicationPeer replicationPeer, Server server, String queueId, UUID clusterId, WALFileLengthProvider walFileLengthProvider, MetricsSource metrics) throws IOException
init
in interface ReplicationSourceInterface
conf
- configuration to usefs
- file system to usemanager
- replication manager to ping toserver
- the server for this region serverqueueId
- the id of our replication queueclusterId
- unique UUID for the clustermetrics
- metrics for replication sourceIOException
public void enqueueLog(org.apache.hadoop.fs.Path log)
ReplicationSourceInterface
enqueueLog
in interface ReplicationSourceInterface
log
- path to the log to replicatepublic void addHFileRefs(TableName tableName, byte[] family, List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) throws ReplicationException
ReplicationSourceInterface
addHFileRefs
in interface ReplicationSourceInterface
tableName
- Name of the table these files belongs tofamily
- Name of the family these files belong topairs
- list of pairs of { HFile location in staging dir, HFile path in region dir which
will be added in the queue for replication}ReplicationException
- If failed to add hfile referencespublic Map<String,ReplicationStatus> getWalGroupStatus()
ReplicationSourceInterface
getWalGroupStatus
in interface ReplicationSourceInterface
protected ReplicationSourceShipper createNewShipper(String walGroupId, PriorityBlockingQueue<org.apache.hadoop.fs.Path> queue)
public ReplicationEndpoint getReplicationEndpoint()
getReplicationEndpoint
in interface ReplicationSourceInterface
public ReplicationSourceManager getSourceManager()
getSourceManager
in interface ReplicationSourceInterface
public void tryThrottle(int batchSize) throws InterruptedException
ReplicationSourceInterface
tryThrottle
in interface ReplicationSourceInterface
batchSize
- entries size will be pushedInterruptedException
protected boolean sleepForRetries(String msg, int sleepMultiplier)
msg
- Why we sleepsleepMultiplier
- by how many times the default sleeping time is augmentedsleepMultiplier
is < maxRetriesMultiplier
public boolean isPeerEnabled()
isPeerEnabled
in interface ReplicationSourceInterface
public void startup()
ReplicationSourceInterface
startup
in interface ReplicationSourceInterface
public void terminate(String reason)
ReplicationSourceInterface
terminate
in interface ReplicationSourceInterface
reason
- why it's terminatingpublic void terminate(String reason, Exception cause)
ReplicationSourceInterface
terminate
in interface ReplicationSourceInterface
reason
- why it's terminatingcause
- the error that's causing itpublic String getQueueId()
ReplicationSourceInterface
getQueueId
in interface ReplicationSourceInterface
public String getPeerId()
ReplicationSourceInterface
getPeerId
in interface ReplicationSourceInterface
public org.apache.hadoop.fs.Path getCurrentPath()
ReplicationSourceInterface
getCurrentPath
in interface ReplicationSourceInterface
public boolean isSourceActive()
isSourceActive
in interface ReplicationSourceInterface
public String getStats()
ReplicationSourceInterface
getStats
in interface ReplicationSourceInterface
public MetricsSource getSourceMetrics()
getSourceMetrics
in interface ReplicationSourceInterface
public void postShipEdits(List<WAL.Entry> entries, int batchSize)
ReplicationSourceInterface
postShipEdits
in interface ReplicationSourceInterface
entries
- pushedbatchSize
- entries size pushedpublic WALFileLengthProvider getWALFileLengthProvider()
getWALFileLengthProvider
in interface ReplicationSourceInterface
public ServerName getServerWALsBelongTo()
ReplicationSourceInterface
getServerWALsBelongTo
in interface ReplicationSourceInterface
Copyright © 2007–2019 Cloudera. All rights reserved.