Interface | Description |
---|---|
MetricsReplicationGlobalSourceSource | |
MetricsReplicationSinkSource | |
MetricsReplicationSource |
Provides access to gauges and counters.
|
MetricsReplicationSourceFactory | |
MetricsReplicationSourceSource | |
MetricsReplicationTableSource | |
PeerProcedureHandler |
A handler for modifying replication peer in peer procedures.
|
ReplicationSourceInterface |
Interface that defines a replication source
|
ReplicationSourceManager.ReplicationQueueOperation | |
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.
|
WALFileLengthProvider |
Used by replication to prevent replicating unacked log entries.
|
Class | Description |
---|---|
CatalogReplicationSource |
ReplicationSource that reads catalog WAL files -- e.g.
|
CatalogReplicationSourcePeer |
The 'peer' used internally by Catalog Region Replicas Replication Source.
|
ClaimReplicationQueueCallable | |
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.
|
DumpReplicationQueues.DumpOptions | |
DumpReplicationQueues.WarnOnlyAbortable | |
HBaseInterClusterReplicationEndpoint |
A
ReplicationEndpoint implementation for replicating
to another HBase cluster. |
HFileReplicator |
It is used for replicating HFile entries.
|
MetricsReplicationGlobalSourceSourceImpl | |
MetricsReplicationSinkSourceImpl | |
MetricsReplicationSourceFactoryImpl | |
MetricsReplicationSourceImpl |
Hadoop2 implementation of MetricsReplicationSource.
|
MetricsReplicationSourceSourceImpl | |
MetricsReplicationTableSourceImpl |
This is the metric source for table level replication metrics.
|
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.
|
NoopReplicationQueueStorage |
Noop queue storage -- does nothing.
|
PeerProcedureHandlerImpl | |
RecoveredReplicationSource |
Class that handles the recovered source of a replication stream, which is transfered from another
dead region server.
|
RecoveredReplicationSourceShipper |
Used by a
RecoveredReplicationSource . |
RefreshPeerCallable |
The callable executed at RS side to refresh the peer config/state.
|
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> | |
Replication |
Gateway to Replication.
|
Replication.ReplicationStatisticsTask |
Statistics task.
|
ReplicationLoad |
This class is used for exporting some of the info from replication metrics
|
ReplicationObserver |
An Observer to add HFile References to replication queue.
|
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.
|
ReplicationSourceFactory |
Constructs a
ReplicationSourceInterface Note, not used to create specialized
ReplicationSources |
ReplicationSourceLogQueue | |
ReplicationSourceManager |
This class is responsible to manage all the replication sources.
|
ReplicationSourceShipper |
This thread reads entries from a queue and ships them.
|
ReplicationSourceWALActionListener |
Used to receive new wals.
|
ReplicationSourceWALReader |
Reads and filters WAL entries, groups the filtered entries into batches, and puts the batches
onto a queue
|
ReplicationStatus | |
ReplicationStatus.ReplicationStatusBuilder | |
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
|
SerialReplicationChecker |
Helper class to determine whether we can push a given WAL entry without breaking the replication
order.
|
SerialReplicationSourceWALReader |
WAL reader for a serial replication peer.
|
SwitchRpcThrottleRemoteCallable |
The callable executed at RS side to switch rpc throttle state.
|
WALEntryBatch |
Holds a batch of WAL entries to replicate, along with some statistics
|
WALEntryStream |
Streaming access to WAL entries.
|
Enum | Description |
---|---|
MetricsReplicationSourceFactoryImpl.SourceHolder | |
ReplicationSourceShipper.WorkerState |
Exception | Description |
---|---|
ReplicationRuntimeException |
This exception is thrown when a replication source is terminated and source threads got
interrupted.
|
WALEntryFilterRetryableException |
This exception should be thrown from any wal filter when the filter is expected to recover from
the failures and it wants the replication to backup till it fails.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.