Package | Description |
---|---|
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.replication.regionserver |
Class and Description |
---|
ReplicationLoad
This class is used for exporting some of the info from replication metrics
|
Class and Description |
---|
MetricsSource
This class is for maintaining the various replication statistics for a source and publishing them
through the metrics interfaces.
|
Class and Description |
---|
HBaseInterClusterReplicationEndpoint.Replicator |
MetricsReplicationSinkSource |
MetricsReplicationSource
Provides access to gauges and counters.
|
MetricsReplicationSourceFactory |
MetricsReplicationSourceFactoryImpl.SourceHolder |
MetricsReplicationSourceImpl
Hadoop2 implementation of MetricsReplicationSource.
|
MetricsReplicationSourceSource |
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.RegionReplicaOutputSink |
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter |
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.ReplicationSourceWorkerThread |
ReplicationSource.WorkerState |
ReplicationSourceInterface
Interface that defines a replication source
|
ReplicationSourceManager
This class is responsible to manage all the replication
sources.
|
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.
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.