@InterfaceAudience.Private public class ReplicationSource extends Thread implements ReplicationSourceInterface
Modifier and Type | Class and Description |
---|---|
static class |
ReplicationSource.LogsComparator
Comparator used to compare logs together based on their start time
|
Thread.State, Thread.UncaughtExceptionHandler
Modifier and Type | Field and Description |
---|---|
static org.apache.commons.logging.Log |
LOG |
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Constructor and Description |
---|
ReplicationSource() |
Modifier and Type | Method and Description |
---|---|
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
|
protected boolean |
getNextPath()
Poll for the next path
|
String |
getPeerClusterId()
Get the id that the source is replicating to.
|
String |
getPeerClusterZnode()
Get the id that the source is replicating to
|
MetricsSource |
getSourceMetrics()
Get Replication Source Metrics
|
String |
getStats()
Get a string representation of the current statistics
for this source
|
void |
init(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
Stoppable stopper,
String peerClusterZnode,
UUID clusterId,
ReplicationEndpoint replicationEndpoint,
MetricsSource metrics)
Instantiation method used by region servers
|
protected boolean |
isPeerEnabled()
check whether the peer is enabled or not
|
protected boolean |
openReader(int sleepMultiplier)
Open a reader on the current path
|
protected boolean |
processEndOfFile()
If the queue isn't empty, switch to the next one
Else if this is a recovered queue, it means we're done!
Else we'll just continue to try reading the log file
|
protected boolean |
readAllEntriesToReplicateOrNextFile(boolean currentWALisBeingWrittenTo,
List<WAL.Entry> entries)
Read all the entries from the current log files and retain those
that need to be replicated.
|
void |
run() |
protected void |
shipEdits(boolean currentWALisBeingWrittenTo,
List<WAL.Entry> entries)
Do the shipping logic
|
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) |
activeCount, checkAccess, clone, countStackFrames, currentThread, destroy, dumpStack, enumerate, getAllStackTraces, getContextClassLoader, getDefaultUncaughtExceptionHandler, getId, getName, getPriority, getStackTrace, getState, getThreadGroup, getUncaughtExceptionHandler, holdsLock, interrupt, interrupted, isAlive, isDaemon, isInterrupted, join, join, join, resume, setContextClassLoader, setDaemon, setDefaultUncaughtExceptionHandler, setName, setPriority, setUncaughtExceptionHandler, sleep, sleep, start, stop, stop, suspend, toString, yield
public void init(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, ReplicationSourceManager manager, ReplicationQueues replicationQueues, ReplicationPeers replicationPeers, Stoppable stopper, String peerClusterZnode, UUID clusterId, ReplicationEndpoint replicationEndpoint, MetricsSource metrics) throws IOException
init
in interface ReplicationSourceInterface
conf
- configuration to usefs
- file system to usemanager
- replication manager to ping tostopper
- the atomic boolean to use to stop the regionserverpeerClusterZnode
- the name of our znodeclusterId
- unique UUID for the clusterreplicationEndpoint
- the replication endpoint implementationmetrics
- metrics for replication sourceIOException
public void enqueueLog(org.apache.hadoop.fs.Path log)
ReplicationSourceInterface
enqueueLog
in interface ReplicationSourceInterface
log
- path to the log to replicateprotected boolean readAllEntriesToReplicateOrNextFile(boolean currentWALisBeingWrittenTo, List<WAL.Entry> entries) throws IOException
currentWALisBeingWrittenTo
- is the current WAL being written toentries
- resulting entries to be replicatedIOException
protected boolean getNextPath()
protected boolean openReader(int sleepMultiplier)
sleepMultiplier
- by how many times the default sleeping time is augmentedprotected boolean sleepForRetries(String msg, int sleepMultiplier)
msg
- Why we sleepsleepMultiplier
- by how many times the default sleeping time is augmentedsleepMultiplier
is < maxRetriesMultiplier
protected void shipEdits(boolean currentWALisBeingWrittenTo, List<WAL.Entry> entries)
currentWALisBeingWrittenTo
- was the current WAL being (seemingly)
written to when this method was calledprotected boolean isPeerEnabled()
protected boolean processEndOfFile()
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 getPeerClusterZnode()
ReplicationSourceInterface
getPeerClusterZnode
in interface ReplicationSourceInterface
public String getPeerClusterId()
ReplicationSourceInterface
getPeerClusterId
in interface ReplicationSourceInterface
public org.apache.hadoop.fs.Path getCurrentPath()
ReplicationSourceInterface
getCurrentPath
in interface ReplicationSourceInterface
public String getStats()
ReplicationSourceInterface
getStats
in interface ReplicationSourceInterface
public MetricsSource getSourceMetrics()
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.