Interface | Description |
---|---|
MetricsReplicationSinkSource | |
MetricsReplicationSource |
Provides access to gauges and counters.
|
MetricsReplicationSourceFactory | |
MetricsReplicationSourceSource | |
ReplicationSourceInterface |
Interface that defines a replication source
|
Class | Description |
---|---|
HBaseInterClusterReplicationEndpoint |
A
ReplicationEndpoint
implementation for replicating to another HBase cluster. |
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. |
RegionReplicaReplicationEndpoint.RegionReplicaOutputSink | |
RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable |
Calls replay on the passed edits for the given set of entries belonging to the region.
|
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter | |
RegionReplicaReplicationEndpoint.RetryingRpcCallable<V> | |
RegionReplicaReplicationEndpoint.SkipReplayedEditsFilter |
Skips the entries which has original seqId.
|
Replication |
Gateway to Replication.
|
Replication.ReplicationStatisticsThread | |
ReplicationLoad |
This class is used for exporting some of the info from replication metrics
|
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.
|
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.
|
ReplicationSyncUp.DummyServer | |
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
|
ReplicationWALReaderManager |
Wrapper class around WAL to help manage the implementation details
such as compression.
|
Enum | Description |
---|---|
MetricsReplicationSourceFactoryImpl.SourceHolder | |
ReplicationSource.WorkerState |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.