Interface | Description |
---|---|
MetricsReplicationSinkSource | |
MetricsReplicationSource |
Provides access to gauges and counters.
|
MetricsReplicationSourceFactory | |
MetricsReplicationSourceSource | |
ReplicationSourceInterface |
Interface that defines a replication source
|
SourceFSConfigurationProvider |
Interface that defines how a region server in peer cluster will get source cluster file system
configurations.
|
Class | Description |
---|---|
DefaultSourceFSConfigurationProvider |
This will load all the xml configuration files for the source cluster replication ID from
user configured replication configuration directory.
|
DumpReplicationQueues |
Provides information about the existing states of replication, replication peers and queues.
|
HBaseInterClusterReplicationEndpoint |
A
ReplicationEndpoint
implementation for replicating to another HBase cluster. |
HFileReplicator |
It is used for replicating HFile entries.
|
MetricsReplicationGlobalSourceSource | |
MetricsReplicationSinkSourceImpl | |
MetricsReplicationSourceFactoryImpl | |
MetricsReplicationSourceImpl |
Hadoop2 implementation of MetricsReplicationSource.
|
MetricsReplicationSourceSourceImpl | |
MetricsSink |
This class is for maintaining the various replication statistics for a sink and publishing them
through the metrics interfaces.
|
MetricsSource |
This class is for maintaining the various replication statistics for a source and publishing them
through the metrics interfaces.
|
RegionReplicaReplicationEndpoint |
A
ReplicationEndpoint endpoint which receives the WAL edits from the
WAL, and sends the edits to replicas of regions. |
Replication |
Gateway to Replication.
|
ReplicationLoad |
This class is used for exporting some of the info from replication metrics
|
ReplicationObserver |
An Observer to facilitate replication operations
|
ReplicationSink |
This class is responsible for replicating the edits coming
from another cluster.
|
ReplicationSinkManager |
Maintains a collection of peers to replicate to, and randomly selects a
single peer to replicate to per set of data to replicate.
|
ReplicationSinkManager.SinkPeer |
Wraps a replication region server sink to provide the ability to identify
it.
|
ReplicationSource |
Class that handles the source of a replication stream.
|
ReplicationSource.LogsComparator |
Comparator used to compare logs together based on their start time
|
ReplicationSourceManager |
This class is responsible to manage all the replication
sources.
|
ReplicationSourceWALReaderThread |
Reads and filters WAL entries, groups the filtered entries into batches, and puts the batches onto a queue
|
ReplicationSyncUp |
In a scenario of Replication based Disaster/Recovery, when hbase
Master-Cluster crashes, this tool is used to sync-up the delta from Master to
Slave using the info from Zookeeper.
|
ReplicationThrottler |
Per-peer per-node throttling controller for replication: enabled if
bandwidth > 0, a cycle = 100ms, by throttling we guarantee data pushed
to peer within each cycle won't exceed 'bandwidth' bytes
|
WALEntryStream |
Streaming access to WAL entries.
|
Enum | Description |
---|---|
ReplicationSource.WorkerState |
Exception | Description |
---|---|
WALEntryStream.WALEntryStreamRuntimeException |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.