Package | Description |
---|---|
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.wal | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.wal |
Class and Description |
---|
ReplicationLoad
This class is used for exporting some of the info from replication metrics
|
Class and Description |
---|
WALFileLengthProvider
Used by replication to prevent replicating unacked log entries.
|
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 |
---|
DumpReplicationQueues.DumpOptions |
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.
|
RecoveredReplicationSource
Class that handles the recovered source of a replication stream, which is transfered from
another dead region server.
|
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.
|
ReplicationSourceInterface
Interface that defines a replication source
|
ReplicationSourceManager
This class is responsible to manage all the replication
sources.
|
ReplicationSourceShipper
This thread reads entries from a queue and ships them.
|
ReplicationSourceShipper.WorkerState |
ReplicationSourceWALReader
Reads and filters WAL entries, groups the filtered entries into batches, and puts the batches onto a queue
|
ReplicationSourceWALReader.WALEntryBatch
Holds a batch of WAL entries to replicate, along with some statistics
|
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
|
SourceFSConfigurationProvider
Interface that defines how a region server in peer cluster will get source cluster file system
configurations.
|
WALEntrySinkFilter
Implementations are installed on a Replication Sink called from inside
ReplicationSink#replicateEntries to filter replicated WALEntries based off WALEntry attributes.
|
WALEntryStream
Streaming access to WAL entries.
|
WALFileLengthProvider
Used by replication to prevent replicating unacked log entries.
|
Class and Description |
---|
WALFileLengthProvider
Used by replication to prevent replicating unacked log entries.
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.