Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.client.replication | |
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.master.replication | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.replication.master | |
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.util | |
org.apache.hadoop.hbase.util.hbck |
Modifier and Type | Method and Description |
---|---|
void |
HBaseAdmin.appendReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs) |
void |
Admin.appendReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs)
Append the replicable table column family config from the specified peer.
|
void |
HBaseAdmin.removeReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs) |
void |
Admin.removeReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs)
Remove some table-cfs from config of the specified peer.
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationAdmin.addPeer(String id,
ReplicationPeerConfig peerConfig)
Deprecated.
|
void |
ReplicationAdmin.addPeer(String id,
ReplicationPeerConfig peerConfig,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0,
use
ReplicationAdmin.addPeer(String, ReplicationPeerConfig) instead. |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig(Map<TableName,List<String>> excludeTableCfs,
ReplicationPeerConfig peerConfig) |
void |
ReplicationAdmin.appendPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
void |
ReplicationAdmin.appendPeerTableCFs(String id,
String tableCfs)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0,
use
ReplicationAdmin.appendPeerTableCFs(String, Map) instead. |
boolean |
ReplicationAdmin.getPeerState(String id)
Deprecated.
|
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig(Map<TableName,List<String>> excludeTableCfs,
ReplicationPeerConfig peerConfig,
String id) |
void |
ReplicationAdmin.removePeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
void |
ReplicationAdmin.removePeerTableCFs(String id,
String tableCf)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0,
use
ReplicationAdmin.removePeerTableCFs(String, Map) instead. |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig(Map<TableName,List<String>> tableCfs,
ReplicationPeerConfig peerConfig,
String id) |
Modifier and Type | Method and Description |
---|---|
long |
MasterServices.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new replication peer for replicating data to slave cluster
|
long |
HMaster.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
long |
MasterServices.disableReplicationPeer(String peerId)
Stop the replication stream to the specified peer
|
long |
HMaster.disableReplicationPeer(String peerId) |
long |
MasterServices.enableReplicationPeer(String peerId)
Restart the replication stream to the specified peer
|
long |
HMaster.enableReplicationPeer(String peerId) |
ReplicationPeerConfig |
MasterServices.getReplicationPeerConfig(String peerId)
Returns the configured ReplicationPeerConfig for the specified peer
|
ReplicationPeerConfig |
HMaster.getReplicationPeerConfig(String peerId) |
protected void |
HMaster.initializeZKBasedSystemTrackers()
Initialize all ZK based system trackers.
|
List<ReplicationPeerDescription> |
MasterServices.listReplicationPeers(String regex)
Return a list of replication peers.
|
List<ReplicationPeerDescription> |
HMaster.listReplicationPeers(String regex) |
long |
MasterServices.removeReplicationPeer(String peerId)
Removes a peer and stops the replication
|
long |
HMaster.removeReplicationPeer(String peerId) |
long |
MasterServices.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer
|
long |
HMaster.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationPeerManager.addPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
static ReplicationPeerManager |
ReplicationPeerManager.create(ZKWatcher zk,
org.apache.hadoop.conf.Configuration conf) |
void |
ReplicationPeerManager.disablePeer(String peerId) |
protected void |
ModifyPeerProcedure.enablePeer(MasterProcedureEnv env) |
void |
ReplicationPeerManager.enablePeer(String peerId) |
protected void |
UpdatePeerConfigProcedure.postPeerModification(MasterProcedureEnv env) |
protected void |
RemovePeerProcedure.postPeerModification(MasterProcedureEnv env) |
protected void |
AddPeerProcedure.postPeerModification(MasterProcedureEnv env) |
protected abstract void |
ModifyPeerProcedure.postPeerModification(MasterProcedureEnv env)
Called before we finish the procedure.
|
protected void |
AddPeerProcedure.prePeerModification(MasterProcedureEnv env) |
protected abstract void |
ModifyPeerProcedure.prePeerModification(MasterProcedureEnv env)
Called before we start the actual processing.
|
void |
ReplicationPeerManager.removePeer(String peerId) |
protected void |
ModifyPeerProcedure.setLastPushedSequenceId(MasterProcedureEnv env,
ReplicationPeerConfig peerConfig) |
protected void |
ModifyPeerProcedure.setLastPushedSequenceIdForTable(MasterProcedureEnv env,
TableName tableName,
Map<String,Long> lastSeqIds) |
protected void |
UpdatePeerConfigProcedure.updateLastPushedSequenceIdForSerialPeer(MasterProcedureEnv env) |
protected void |
AddPeerProcedure.updateLastPushedSequenceIdForSerialPeer(MasterProcedureEnv env) |
protected void |
ModifyPeerProcedure.updateLastPushedSequenceIdForSerialPeer(MasterProcedureEnv env) |
void |
ReplicationPeerManager.updatePeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
protected void |
DisablePeerProcedure.updatePeerStorage(MasterProcedureEnv env) |
protected void |
UpdatePeerConfigProcedure.updatePeerStorage(MasterProcedureEnv env) |
protected void |
RemovePeerProcedure.updatePeerStorage(MasterProcedureEnv env) |
protected void |
EnablePeerProcedure.updatePeerStorage(MasterProcedureEnv env) |
protected void |
AddPeerProcedure.updatePeerStorage(MasterProcedureEnv env) |
protected abstract void |
ModifyPeerProcedure.updatePeerStorage(MasterProcedureEnv env) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationQueueStorage.addHFileRefs(String peerId,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs)
Add new hfile references to the queue.
|
boolean |
ReplicationPeers.addPeer(String peerId)
Method called after a peer has been connected.
|
void |
ZKReplicationPeerStorage.addPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
void |
ReplicationPeerStorage.addPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a replication peer.
|
void |
ReplicationQueueStorage.addPeerToHFileRefs(String peerId)
Add a peer to hfile reference queue if peer does not exist.
|
void |
ReplicationQueueStorage.addWAL(ServerName serverName,
String queueId,
String fileName)
Add a new WAL file to the given queue for a given regionserver.
|
Pair<String,SortedSet<String>> |
ReplicationQueueStorage.claimQueue(ServerName sourceServerName,
String queueId,
ServerName destServerName)
Change ownership for the queue identified by queueId and belongs to a dead region server.
|
Set<String> |
ReplicationQueueStorage.getAllHFileRefs()
Load all hfile references in all replication queues.
|
List<String> |
ReplicationQueueStorage.getAllPeersFromHFileRefsQueue()
Get list of all peers from hfile reference queue.
|
List<String> |
ReplicationQueueStorage.getAllQueues(ServerName serverName)
Get a list of all queues for the specified region server.
|
Set<String> |
ReplicationQueueStorage.getAllWALs()
Load all wals in all replication queues.
|
long |
ReplicationQueueStorage.getLastSequenceId(String encodedRegionName,
String peerId)
Read the max sequence id of the specific region for a given peer.
|
List<ServerName> |
ReplicationQueueStorage.getListOfReplicators()
Get a list of all region servers that have outstanding replication queues.
|
static org.apache.hadoop.conf.Configuration |
ReplicationUtils.getPeerClusterConfiguration(ReplicationPeerConfig peerConfig,
org.apache.hadoop.conf.Configuration baseConf) |
ReplicationPeerConfig |
ZKReplicationPeerStorage.getPeerConfig(String peerId) |
ReplicationPeerConfig |
ReplicationPeerStorage.getPeerConfig(String peerId)
Get the peer config of a replication peer.
|
List<String> |
ReplicationQueueStorage.getReplicableHFiles(String peerId)
Get a list of all hfile references in the given peer.
|
long |
ReplicationQueueStorage.getWALPosition(ServerName serverName,
String queueId,
String fileName)
Get the current position for a specific WAL in a given queue for a given regionserver.
|
List<String> |
ReplicationQueueStorage.getWALsInQueue(ServerName serverName,
String queueId)
Get a list of all WALs in the given queue on the given region server.
|
void |
ReplicationPeers.init() |
boolean |
ZKReplicationPeerStorage.isPeerEnabled(String peerId) |
boolean |
ReplicationPeerStorage.isPeerEnabled(String peerId)
Test whether a replication peer is enabled.
|
List<String> |
ZKReplicationPeerStorage.listPeerIds() |
List<String> |
ReplicationPeerStorage.listPeerIds()
Return the peer ids of all replication peers.
|
ReplicationPeerConfig |
ReplicationPeers.refreshPeerConfig(String peerId) |
ReplicationPeer.PeerState |
ReplicationPeers.refreshPeerState(String peerId) |
static void |
ReplicationUtils.removeAllQueues(ReplicationQueueStorage queueStorage,
String peerId) |
void |
ReplicationQueueStorage.removeHFileRefs(String peerId,
List<String> files)
Remove hfile references from the queue.
|
void |
ReplicationQueueStorage.removeLastSequenceIds(String peerId)
Remove all the max sequence id record for the given peer.
|
void |
ReplicationQueueStorage.removeLastSequenceIds(String peerId,
List<String> encodedRegionNames)
Remove the max sequence id record for the given peer and regions.
|
void |
ZKReplicationPeerStorage.removePeer(String peerId) |
void |
ReplicationPeerStorage.removePeer(String peerId)
Remove a replication peer.
|
void |
ReplicationQueueStorage.removePeerFromHFileRefs(String peerId)
Remove a peer from hfile reference queue.
|
void |
ReplicationQueueStorage.removeQueue(ServerName serverName,
String queueId)
Remove a replication queue for a given regionserver.
|
void |
ReplicationQueueStorage.removeReplicatorIfQueueIsEmpty(ServerName serverName)
Remove the record of region server if the queue is empty.
|
void |
ReplicationQueueStorage.removeWAL(ServerName serverName,
String queueId,
String fileName)
Remove an WAL file from the given queue for a given regionserver.
|
void |
ReplicationQueueStorage.setLastSequenceIds(String peerId,
Map<String,Long> lastSeqIds)
Set the max sequence id of a bunch of regions for a given peer.
|
void |
ZKReplicationPeerStorage.setPeerState(String peerId,
boolean enabled) |
void |
ReplicationPeerStorage.setPeerState(String peerId,
boolean enabled)
Set the state of peer,
true to ENABLED , otherwise to DISABLED . |
void |
ReplicationQueueStorage.setWALPosition(ServerName serverName,
String queueId,
String fileName,
long position,
Map<String,Long> lastSeqIds)
Set the current position for a specific WAL in a given queue for a given regionserver.
|
void |
ZKReplicationPeerStorage.updatePeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
void |
ReplicationPeerStorage.updatePeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the config a replication peer.
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationPeerConfigUpgrader.copyTableCFs() |
boolean |
ReplicationPeerConfigUpgrader.copyTableCFs(String peerId) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationSource.addHFileRefs(TableName tableName,
byte[] family,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) |
void |
ReplicationSourceInterface.addHFileRefs(TableName tableName,
byte[] family,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs)
Add hfile names to the queue to be replicated.
|
void |
PeerProcedureHandler.addPeer(String peerId) |
void |
PeerProcedureHandlerImpl.disablePeer(String peerId) |
void |
PeerProcedureHandler.disablePeer(String peerId) |
void |
PeerProcedureHandlerImpl.enablePeer(String peerId) |
void |
PeerProcedureHandler.enablePeer(String peerId) |
void |
PeerProcedureHandler.removePeer(String peerId) |
void |
PeerProcedureHandlerImpl.updatePeerConfig(String peerId) |
void |
PeerProcedureHandler.updatePeerConfig(String peerId) |
Modifier and Type | Method and Description |
---|---|
HBaseFsck |
HBaseFsck.exec(ExecutorService exec,
String[] args) |
int |
HBaseFsck.onlineHbck()
Contacts the master and prints out cluster-wide information
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationChecker.checkUnDeletedQueues() |
void |
ReplicationChecker.fixUnDeletedQueues() |
Copyright © 2007–2019 Cloudera. All rights reserved.