@InterfaceAudience.Private public class ReplicationSourceManager extends Object
When a region server dies, this class uses a watcher to get notified and it tries to grab a lock in order to transfer all the queues in a local old source.
Synchronization specification:
sources
. sources
is a ConcurrentHashMap and there
is a Lock for peer id in PeerProcedureHandlerImpl
. So there is no race for peer
operations.walsById
. There are four methods which modify it,
addPeer(String)
, removePeer(String)
,
cleanOldLogs(NavigableSet, String, boolean, String)
and preLogRoll(Path)
.
walsById
is a ConcurrentHashMap and there is a Lock for peer id in
PeerProcedureHandlerImpl
. So there is no race between addPeer(String)
and
removePeer(String)
. cleanOldLogs(NavigableSet, String, boolean, String)
is
called by ReplicationSourceInterface
. So no race with addPeer(String)
.
removePeer(String)
will terminate the ReplicationSourceInterface
firstly, then
remove the wals from walsById
. So no race with removePeer(String)
. The only
case need synchronized is cleanOldLogs(NavigableSet, String, boolean, String)
and
preLogRoll(Path)
.walsByIdRecoveredQueues
. There are three methods which
modify it, removePeer(String)
, <<<<<<< HEAD
cleanOldLogs(NavigableSet, String, boolean, String)
and
ReplicationSourceManager.NodeFailoverWorker#run()
.
cleanOldLogs(NavigableSet, String, boolean, String)
is called by =======
#cleanOldLogs(String, boolean, ReplicationSourceInterface)
and
claimQueue(ServerName, String)
.
#cleanOldLogs(String, boolean, ReplicationSourceInterface)
is called by >>>>>>>
51893b9ba3... HBASE-26029 It is not reliable to use nodeDeleted event to track region server's
death (#3430) ReplicationSourceInterface
. removePeer(String)
will terminate the
ReplicationSourceInterface
firstly, then remove the wals from
walsByIdRecoveredQueues
. And
claimQueue(ServerName, String)
will add the wals to
walsByIdRecoveredQueues
firstly, then start up a ReplicationSourceInterface
. So
there is no race here. For claimQueue(ServerName, String)
and
removePeer(String)
, there is already synchronized on oldsources
. So no need
synchronized on walsByIdRecoveredQueues
.latestPaths
to avoid the new open source miss new log.oldsources
to avoid adding recovered source for the
to-be-removed peer.Modifier and Type | Class and Description |
---|---|
private static interface |
ReplicationSourceManager.ReplicationQueueOperation |
Constructor and Description |
---|
ReplicationSourceManager(ReplicationQueueStorage queueStorage,
ReplicationPeers replicationPeers,
org.apache.hadoop.conf.Configuration conf,
Server server,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path logDir,
org.apache.hadoop.fs.Path oldLogDir,
UUID clusterId,
WALFactory walFactory,
MetricsReplicationGlobalSourceSource globalMetrics)
Creates a replication manager and sets the watch on all the other registered region servers
|
Modifier and Type | Method and Description |
---|---|
private void |
abortAndThrowIOExceptionWhenFail(ReplicationSourceManager.ReplicationQueueOperation op) |
private void |
abortWhenFail(ReplicationSourceManager.ReplicationQueueOperation op) |
(package private) int |
activeFailoverTaskCount() |
ReplicationSourceInterface |
addCatalogReplicationSource(RegionInfo regionInfo)
Add an hbase:meta Catalog replication source.
|
void |
addHFileRefs(TableName tableName,
byte[] family,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) |
void |
addPeer(String peerId)
1.
|
(package private) ReplicationSourceInterface |
addSource(String peerId)
Add a normal source for the given peer on this region server.
|
(package private) void |
claimQueue(ServerName deadRS,
String queue) |
private void |
cleanOldLogs(NavigableSet<String> wals,
String key,
boolean inclusive,
String id) |
(package private) void |
cleanOldLogs(String log,
boolean inclusive,
String queueId,
boolean queueRecovered)
Cleans a log file and all older logs from replication queue.
|
void |
cleanUpHFileRefs(String peerId,
List<String> files) |
private ReplicationSourceInterface |
createCatalogReplicationSource(RegionInfo regionInfo)
Create, initialize, and start the Catalog ReplicationSource.
|
private ReplicationSourceInterface |
createSource(String queueId,
ReplicationPeer replicationPeer) |
private void |
deleteQueue(String queueId)
Delete a complete queue of wals associated with a replication source
|
(package private) List<String> |
getAllQueues() |
org.apache.hadoop.fs.FileSystem |
getFs()
Get the handle on the local file system
|
(package private) MetricsReplicationGlobalSourceSource |
getGlobalMetrics() |
(package private) Set<org.apache.hadoop.fs.Path> |
getLastestPath() |
org.apache.hadoop.fs.Path |
getLogDir()
Get the directory where wals are stored by their RSs
|
org.apache.hadoop.fs.Path |
getOldLogDir()
Get the directory where wals are archived
|
List<ReplicationSourceInterface> |
getOldSources()
Get a list of all the recovered sources of this rs
|
(package private) ReplicationQueueStorage |
getQueueStorage() |
ReplicationPeers |
getReplicationPeers()
Get the ReplicationPeers used by this ReplicationSourceManager
|
(package private) int |
getSizeOfLatestPath() |
ReplicationSourceInterface |
getSource(String peerId)
Get the normal source for a given peer
|
List<ReplicationSourceInterface> |
getSources()
Get a list of all the normal sources of this rs
|
String |
getStats()
Get a string representation of all the sources' metrics
|
long |
getTotalBufferLimit()
Returns the maximum size in bytes of edits held in memory which are pending replication across
all sources inside this RegionServer.
|
AtomicLong |
getTotalBufferUsed() |
Map<String,Map<String,NavigableSet<String>>> |
getWALs()
Get a copy of the wals of the normal sources on this rs
|
(package private) Map<String,Map<String,NavigableSet<String>>> |
getWalsByIdRecoveredQueues()
Get a copy of the wals of the recovered sources on this rs
|
(package private) void |
init()
Adds a normal source per registered peer cluster.
|
private void |
interruptOrAbortWhenFail(ReplicationSourceManager.ReplicationQueueOperation op)
Refresh replication source will terminate the old source first, then the source thread will be
interrupted.
|
void |
join()
Terminate the replication on this region server
|
void |
logPositionAndCleanOldLogs(ReplicationSourceInterface source,
WALEntryBatch entryBatch)
This method will log the current position to storage.
|
void |
postLogRoll(org.apache.hadoop.fs.Path newLog) |
void |
preLogRoll(org.apache.hadoop.fs.Path newLog) |
void |
refreshSources(String peerId)
Close the previous replication sources of this peer id and open new sources to trigger the new
replication state changes or new replication config changes.
|
void |
removeCatalogReplicationSource(RegionInfo regionInfo)
Remove the hbase:meta Catalog replication source.
|
void |
removePeer(String peerId)
1.
|
(package private) void |
removeRecoveredSource(ReplicationSourceInterface src)
Clear the metrics and related replication queue of the specified old source
|
(package private) void |
removeSource(ReplicationSourceInterface src)
Clear the metrics and related replication queue of the specified old source
|
private void |
throwIOExceptionWhenFail(ReplicationSourceManager.ReplicationQueueOperation op) |
private static final org.slf4j.Logger LOG
private final ConcurrentMap<String,ReplicationSourceInterface> sources
private final List<ReplicationSourceInterface> oldsources
private final ReplicationQueueStorage queueStorage
private final ReplicationPeers replicationPeers
private final ConcurrentMap<String,Map<String,NavigableSet<String>>> walsById
private final ConcurrentMap<String,Map<String,NavigableSet<String>>> walsByIdRecoveredQueues
private final org.apache.hadoop.conf.Configuration conf
private final org.apache.hadoop.fs.FileSystem fs
private final Map<String,org.apache.hadoop.fs.Path> latestPaths
private final org.apache.hadoop.fs.Path logDir
private final org.apache.hadoop.fs.Path oldLogDir
private final WALFactory walFactory
private final long sleepBeforeFailover
private final ThreadPoolExecutor executor
private final boolean replicationForBulkLoadDataEnabled
private AtomicLong totalBufferUsed
private final long totalBufferLimit
private final MetricsReplicationGlobalSourceSource globalMetrics
AtomicReference<ReplicationSourceInterface> catalogReplicationSource
public ReplicationSourceManager(ReplicationQueueStorage queueStorage, ReplicationPeers replicationPeers, org.apache.hadoop.conf.Configuration conf, Server server, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path logDir, org.apache.hadoop.fs.Path oldLogDir, UUID clusterId, WALFactory walFactory, MetricsReplicationGlobalSourceSource globalMetrics) throws IOException
queueStorage
- the interface for manipulating replication queuesconf
- the configuration to useserver
- the server for this region serverfs
- the file system to uselogDir
- the directory that contains all wal directories of live RSsoldLogDir
- the directory where old logs are archivedIOException
void init() throws IOException
IOException
public void addPeer(String peerId) throws IOException
peerId
- the id of replication peerIOException
public void removePeer(String peerId)
peerId
- the id of the replication peerprivate ReplicationSourceInterface createSource(String queueId, ReplicationPeer replicationPeer) throws IOException
queueId
- the id of the replication queue to associate the ReplicationSource with.IOException
for creating a ReplicationSource for meta.
ReplicationSourceInterface addSource(String peerId) throws IOException
peerId
- the id of the replication peerIOException
public void refreshSources(String peerId) throws IOException
peerId
- the id of the replication peer nIOException
void removeRecoveredSource(ReplicationSourceInterface src)
src
- source to clearvoid removeSource(ReplicationSourceInterface src)
src
- source to clearprivate void deleteQueue(String queueId)
queueId
- the id of replication queue to deleteprivate void interruptOrAbortWhenFail(ReplicationSourceManager.ReplicationQueueOperation op)
private void abortWhenFail(ReplicationSourceManager.ReplicationQueueOperation op)
private void throwIOExceptionWhenFail(ReplicationSourceManager.ReplicationQueueOperation op) throws IOException
IOException
private void abortAndThrowIOExceptionWhenFail(ReplicationSourceManager.ReplicationQueueOperation op) throws IOException
IOException
public void logPositionAndCleanOldLogs(ReplicationSourceInterface source, WALEntryBatch entryBatch)
entryBatch
- the wal entry batch we just shippedvoid cleanOldLogs(String log, boolean inclusive, String queueId, boolean queueRecovered)
log
- Path to the loginclusive
- whether we should also remove the given log filequeueId
- id of the replication queuequeueRecovered
- Whether this is a recovered queueprivate void cleanOldLogs(NavigableSet<String> wals, String key, boolean inclusive, String id)
public void preLogRoll(org.apache.hadoop.fs.Path newLog) throws IOException
IOException
public void postLogRoll(org.apache.hadoop.fs.Path newLog) throws IOException
IOException
void claimQueue(ServerName deadRS, String queue)
public void join()
public Map<String,Map<String,NavigableSet<String>>> getWALs()
Map<String,Map<String,NavigableSet<String>>> getWalsByIdRecoveredQueues()
public List<ReplicationSourceInterface> getSources()
public List<ReplicationSourceInterface> getOldSources()
public ReplicationSourceInterface getSource(String peerId)
List<String> getAllQueues() throws IOException
IOException
int getSizeOfLatestPath()
Set<org.apache.hadoop.fs.Path> getLastestPath()
public AtomicLong getTotalBufferUsed()
public long getTotalBufferLimit()
public org.apache.hadoop.fs.Path getOldLogDir()
public org.apache.hadoop.fs.Path getLogDir()
public org.apache.hadoop.fs.FileSystem getFs()
public ReplicationPeers getReplicationPeers()
public void addHFileRefs(TableName tableName, byte[] family, List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) throws IOException
IOException
public void cleanUpHFileRefs(String peerId, List<String> files)
int activeFailoverTaskCount()
MetricsReplicationGlobalSourceSource getGlobalMetrics()
public ReplicationSourceInterface addCatalogReplicationSource(RegionInfo regionInfo) throws IOException
public void removeCatalogReplicationSource(RegionInfo regionInfo)
private ReplicationSourceInterface createCatalogReplicationSource(RegionInfo regionInfo) throws IOException
ReplicationSourceFactory
.ReplicationQueueStorage getQueueStorage()
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.