Uses of Interface
org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Uses of ReplicationSourceInterface in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeClassDescriptionclass
Class that handles the recovered source of a replication stream, which is transfered from another dead region server.class
Class that handles the source of a replication stream.Modifier and TypeFieldDescriptionprivate final List<ReplicationSourceInterface>
ReplicationSourceManager.oldsources
private final ConcurrentMap<String,
ReplicationSourceInterface> ReplicationSourceManager.sources
Modifier and TypeMethodDescription(package private) static ReplicationSourceInterface
ReplicationSourceFactory.create
(org.apache.hadoop.conf.Configuration conf, ReplicationQueueId queueId) private ReplicationSourceInterface
ReplicationSourceManager.createRefreshedSource
(ReplicationQueueId queueId, ReplicationPeer peer) private ReplicationSourceInterface
ReplicationSourceManager.createSource
(ReplicationQueueData queueData, ReplicationPeer replicationPeer) Get the normal source for a given peerReplicationSource.startup()
ReplicationSourceInterface.startup()
Start the replicationModifier and TypeMethodDescriptionReplicationSourceManager.getOldSources()
Get a list of all the recovered sources of this rsReplicationSourceManager.getSources()
Get a list of all the normal sources of this rsModifier and TypeMethodDescriptionprivate void
ReplicationSourceManager.addRecoveredSource
(ReplicationSourceInterface src, ReplicationPeerImpl oldPeer, ReplicationQueueId claimedQueueId, PriorityQueue<org.apache.hadoop.fs.Path> walFiles) (package private) void
ReplicationSourceManager.cleanOldLogs
(String log, boolean inclusive, ReplicationSourceInterface source) Cleans a log file and all older logs from replication queue.private void
ReplicationSourceManager.cleanOldLogs
(NavigableSet<String> wals, ReplicationSourceInterface source) (package private) void
ReplicationSourceManager.finishRecoveredSource
(ReplicationSourceInterface src) void
ReplicationSourceManager.logPositionAndCleanOldLogs
(ReplicationSourceInterface source, WALEntryBatch entryBatch) This method will log the current position to storage.private boolean
ReplicationSourceManager.removeRecoveredSource
(ReplicationSourceInterface src) Clear the metrics and related replication queue of the specified old source(package private) void
ReplicationSourceManager.removeSource
(ReplicationSourceInterface src) Clear the metrics and related replication queue of the specified old sourceModifier and TypeMethodDescriptionvoid
ReplicationLoad.buildReplicationLoad
(List<ReplicationSourceInterface> sources, MetricsSink sinkMetrics) buildReplicationLoad