Return-Path: X-Original-To: apmail-hbase-commits-archive@www.apache.org Delivered-To: apmail-hbase-commits-archive@www.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id C9CFE101BD for ; Fri, 19 Dec 2014 21:54:37 +0000 (UTC) Received: (qmail 72272 invoked by uid 500); 19 Dec 2014 21:54:37 -0000 Delivered-To: apmail-hbase-commits-archive@hbase.apache.org Received: (qmail 72114 invoked by uid 500); 19 Dec 2014 21:54:37 -0000 Mailing-List: contact commits-help@hbase.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@hbase.apache.org Delivered-To: mailing list commits@hbase.apache.org Received: (qmail 71993 invoked by uid 99); 19 Dec 2014 21:54:37 -0000 Received: from tyr.zones.apache.org (HELO tyr.zones.apache.org) (140.211.11.114) by apache.org (qpsmtpd/0.29) with ESMTP; Fri, 19 Dec 2014 21:54:37 +0000 Received: by tyr.zones.apache.org (Postfix, from userid 65534) id 4C881A30400; Fri, 19 Dec 2014 21:54:37 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 8bit From: enis@apache.org To: commits@hbase.apache.org Date: Fri, 19 Dec 2014 21:54:38 -0000 Message-Id: In-Reply-To: References: X-Mailer: ASF-Git Admin Mailer Subject: [2/2] hbase git commit: Updated documentation Updated documentation Project: http://git-wip-us.apache.org/repos/asf/hbase/repo Commit: http://git-wip-us.apache.org/repos/asf/hbase/commit/6707c350 Tree: http://git-wip-us.apache.org/repos/asf/hbase/tree/6707c350 Diff: http://git-wip-us.apache.org/repos/asf/hbase/diff/6707c350 Branch: refs/heads/branch-1.0 Commit: 6707c350662bb80dee1d01260d3ab10051682cb1 Parents: 2e33cde Author: Enis Soztutar Authored: Fri Dec 19 13:51:43 2014 -0800 Committer: Enis Soztutar Committed: Fri Dec 19 13:51:43 2014 -0800 ---------------------------------------------------------------------- src/main/docbkx/book.xml | 2 +- src/main/docbkx/developer.xml | 15 +- src/main/docbkx/ops_mgt.xml | 782 +++++++++++++++++++-------------- src/main/docbkx/schema_design.xml | 15 + src/main/docbkx/security.xml | 32 +- 5 files changed, 503 insertions(+), 343 deletions(-) ---------------------------------------------------------------------- http://git-wip-us.apache.org/repos/asf/hbase/blob/6707c350/src/main/docbkx/book.xml ---------------------------------------------------------------------- diff --git a/src/main/docbkx/book.xml b/src/main/docbkx/book.xml index f835dc7..ee2d7fb 100644 --- a/src/main/docbkx/book.xml +++ b/src/main/docbkx/book.xml @@ -966,7 +966,7 @@ table.put(put);
HBase, MapReduce, and the CLASSPATH - Ny default, MapReduce jobs deployed to a MapReduce cluster do not have access to either + By default, MapReduce jobs deployed to a MapReduce cluster do not have access to either the HBase configuration under $HBASE_CONF_DIR or the HBase classes. To give the MapReduce jobs the access they need, you could add hbase-site.xml to the http://git-wip-us.apache.org/repos/asf/hbase/blob/6707c350/src/main/docbkx/developer.xml ---------------------------------------------------------------------- diff --git a/src/main/docbkx/developer.xml b/src/main/docbkx/developer.xml index a6b5dc2..47c78b4 100644 --- a/src/main/docbkx/developer.xml +++ b/src/main/docbkx/developer.xml @@ -743,8 +743,10 @@ $ mvn deploy -DskipTests -Papache-release You can always delete it if the build goes haywire. - Sign and upload your version directory to <link - xlink:href="http://people.apache.org">people.apache.org</link>. + Sign, upload, and 'stage' your version directory to <link + xlink:href="http://people.apache.org">people.apache.org</link> (TODO: + There is a new location to stage releases using svnpubsub. See + (<link xlink:href="https://issues.apache.org/jira/browse/HBASE-10554">HBASE-10554 Please delete old releases from mirroring system</link>). If all checks out, next put the version directory up on people.apache.org. You will need to sign and fingerprint them before you push them up. In the @@ -874,12 +876,13 @@ $ rsync -av 0.96.0RC0 people.apache.org:public_html Alternatively, you may limit the shell tests that run using the system variable - shell.test. This value may specify a particular test case by name. For - example, the tests that cover the shell commands for altering tables are contained in the test - case AdminAlterTableTest and you can run them with: + shell.test. This value should specify the ruby literal equivalent of a + particular test case by name. For example, the tests that cover the shell commands for + altering tables are contained in the test case AdminAlterTableTest + and you can run them with: - mvn clean test -Dtest=TestShell -Dshell.test=AdminAlterTableTest + mvn clean test -Dtest=TestShell -Dshell.test=/AdminAlterTableTest/ You may also use a This information was previously available at Cluster Replication. - HBase provides a replication mechanism to copy data between HBase - clusters. Replication can be used as a disaster recovery solution and as a mechanism for high - availability. You can also use replication to separate web-facing operations from back-end - jobs such as MapReduce. - - In terms of architecture, HBase replication is master-push. This takes advantage of the - fact that each region server has its own write-ahead log (WAL). One master cluster can - replicate to any number of slave clusters, and each region server replicates its own stream of - edits. For more information on the different properties of master/slave replication and other - types of replication, see the article How - Google Serves Data From Multiple Datacenters. - - Replication is asynchronous, allowing clusters to be geographically distant or to have - some gaps in availability. This also means that data between master and slave clusters will - not be instantly consistent. Rows inserted on the master are not immediately available or - consistent with rows on the slave clusters. rows inserted on the master cluster won’t be - available at the same time on the slave clusters. The goal is eventual consistency. - - The replication format used in this design is conceptually the same as the statement-based - replication design used by MySQL. Instead of SQL statements, entire - WALEdits (consisting of multiple cell inserts coming from Put and Delete operations on the - clients) are replicated in order to maintain atomicity. - + HBase provides a cluster replication mechanism which allows you to keep one cluster's + state synchronized with that of another cluster, using the write-ahead log (WAL) of the source + cluster to propagate the changes. Some use cases for cluster replication include: + + Backup and disaster recovery + Data aggregation + Geographic data distribution + Online data ingestion combined with offline data analytics + + Replication is enabled at the granularity of the column family. Before enabling + replication for a column family, create the table and all column families to be replicated, on + the destination cluster. + Cluster replication uses a source-push methodology. An HBase cluster can be a source (also + called master or active, meaning that it is the originator of new data), a destination (also + called slave or passive, meaning that it receives data via replication), or can fulfill both + roles at once. Replication is asynchronous, and the goal of replication is eventual + consistency. When the source receives an edit to a column family with replication enabled, + that edit is propagated to all destination clusters using the WAL for that for that column + family on the RegionServer managing the relevant region. + When data is replicated from one cluster to another, the original source of the data is + tracked via a cluster ID which is part of the metadata. In HBase 0.96 and newer (HBASE-7709), all + clusters which have already consumed the data are also tracked. This prevents replication + loops. The WALs for each region server must be kept in HDFS as long as they are needed to replicate data to any slave cluster. Each region server reads from the oldest log it needs to - replicate and keeps track of the current position inside ZooKeeper to simplify failure - recovery. That position, as well as the queue of WALs to process, may be different for every - slave cluster. - - The clusters participating in replication can be of different sizes. The master - cluster relies on randomization to attempt to balance the stream of replication on the slave clusters - - HBase supports master/master and cyclic replication as well as replication to multiple - slaves. - + replicate and keeps track of its progress processing WALs inside ZooKeeper to simplify failure + recovery. The position marker which indicates a slave cluster's progress, as well as the queue + of WALs to process, may be different for every slave cluster. + The clusters participating in replication can be of different sizes. The master cluster + relies on randomization to attempt to balance the stream of replication on the slave clusters. + It is expected that the slave cluster has storage capacity to hold the replicated data, as + well as any data it is responsible for ingesting. If a slave cluster does run out of room, or + is inaccessible for other reasons, it throws an error and the master retains the WAL and + retries the replication at intervals. + + Terminology Changes + Previously, terms such as master-master, + master-slave, and cyclical were used to + describe replication relationships in HBase. These terms added confusion, and have been + abandoned in favor of discussions about cluster topologies appropriate for different + scenarios. + + + Cluster Topologies + + A central source cluster might propagate changes out to multiple destination clusters, + for failover or due to geographic distribution. + + + A source cluster might push changes to a destination cluster, which might also push + its own changes back to the original cluster. + + Many different low-latency clusters might push changes to one centralized cluster for + backup or resource-intensive data analytics jobs. The processed data might then be + replicated back to the low-latency clusters. + + + Multiple levels of replication may be chained together to suit your organization's needs. + The following diagram shows a hypothetical scenario. Use the arrows to follow the data + paths.
- Replication Architecture Overview + Example of a Complex Cluster Replication Configuration - - - - - Illustration of the replication architecture in HBase, as described in the prior - text. - + + + At the top of the diagram, the San Jose and Tokyo clusters, shown in red, + replicate changes to each other, and each also replicates changes to a User Data and a + Payment Data cluster. + Each cluster in the second row, shown in blue, replicates its changes to the All Data + Backup 1 cluster, shown in grey. The All Data Backup 1 cluster replicates changes to the + All Data Backup 2 cluster (also shown in grey), as well as the Data Analysis cluster + (shown in green). All Data Backup 2 also propagates any of its own changes back to All + Data Backup 1. + The Data Analysis cluster runs MapReduce jobs on its data, and then pushes the + processed data back to the San Jose and Tokyo clusters. +
- - Enabling and Configuring Replication - See the - API documentation for replication for information on enabling and configuring - replication. - + HBase replication borrows many concepts from the statement-based replication design used by MySQL. Instead of SQL + statements, entire WALEdits (consisting of multiple cell inserts coming from Put and Delete + operations on the clients) are replicated in order to maintain atomicity.
- Life of a WAL Edit - A single WAL edit goes through several steps in order to be replicated to a slave - cluster. - - - When the slave responds correctly: - - A HBase client uses a Put or Delete operation to manipulate data in HBase. - - - The region server writes the request to the WAL in a way that would allow it to be - replayed if it were not written successfully. - - - If the changed cell corresponds to a column family that is scoped for replication, - the edit is added to the queue for replication. - - - In a separate thread, the edit is read from the log, as part of a batch process. - Only the KeyValues that are eligible for replication are kept. Replicable KeyValues are - part of a column family whose schema is scoped GLOBAL, are not part of a catalog such as - hbase:meta, and did not originate from the target slave cluster, in the - case of cyclic replication. - - - The edit is tagged with the master's UUID and added to a buffer. When the buffer is - filled, or the reader reaches the end of the file, the buffer is sent to a random region - server on the slave cluster. - - - The region server reads the edits sequentially and separates them into buffers, one - buffer per table. After all edits are read, each buffer is flushed using HTable, HBase's normal client. The master's UUID is preserved in the edits - they are applied, in order to allow for cyclic replication. - - - In the master, the offset for the WAL that is currently being replicated is - registered in ZooKeeper. - - - - When the slave does not respond: - - The first three steps, where the edit is inserted, are identical. - + Configuring Cluster Replication + The following is a simplified procedure for configuring cluster replication. It may not + cover every edge case. For more information, see the API documentation for replication. + - Again in a separate thread, the region server reads, filters, and edits the log - edits in the same way as above. The slave region server does not answer the RPC - call. + Configure and start the source and destination clusters. Create tables with the same + names and column families on both the source and destination clusters, so that the + destination cluster knows where to store data it will receive. All hosts in the source + and destination clusters should be reachable to each other. - The master sleeps and tries again a configurable number of times. + On the source cluster, enable replication by setting hbase.replication + to true in hbase-site.xml. - If the slave region server is still not available, the master selects a new subset - of region server to replicate to, and tries again to send the buffer of edits. + On the source cluster, in HBase Shell, add the destination cluster as a peer, using + the add_peer command. The syntax is as follows: + hbase< add_peer 'ID' 'CLUSTER_KEY' + The ID is a string (prior to HBASE-11367, it + was a short integer), which must not contain a hyphen (see HBASE-11394). To + compose the CLUSTER_KEY, use the following template: + hbase.zookeeper.quorum:hbase.zookeeper.property.clientPort:zookeeper.znode.parent + If both clusters use the same ZooKeeper cluster, you must use a different + zookeeper.znode.parent, because they cannot write in the same folder. - Meanwhile, the WALs are rolled and stored in a queue in ZooKeeper. Logs that are - archived by their region server, by moving them from the region - server's log directory to a central log directory, will update their paths in the - in-memory queue of the replicating thread. + On the source cluster, configure each column family to be replicated by setting its + REPLICATION_SCOPE to 1, using commands such as the following in HBase Shell. + hbase> disable 'example_table' +hbase> alter 'example_table', {NAME => 'example_family', REPLICATION_SCOPE => '1'} +hbase> enable 'example_table' + You can verify that replication is taking place by examining the logs on the + source cluster for messages such as the following. + Considering 1 rs, with ratio 0.1 +Getting 1 rs from peer cluster # 0 +Choosing peer 10.10.1.49:62020 + - When the slave cluster is finally available, the buffer is applied in the same way - as during normal processing. The master region server will then replicate the backlog of - logs that accumulated during the outage. + To verify the validity of replicated data, you can use the included + VerifyReplication MapReduce job on the source cluster, providing it with + the ID of the replication peer and table name to verify. Other options are possible, + such as a time range or specific families to verify. + The command has the following form: + hbase org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication [--starttime=timestamp1] [--stoptime=timestamp [--families=comma separated list of families] <peerId><tablename> + The VerifyReplication command prints out GOODROWS + and BADROWS counters to indicate rows that did and did not replicate + correctly. - - - - Spreading Queue Failover Load - When replication is active, a subset of RegionServers in the source cluster are - responsible for shipping edits to the sink. This function must be failed over like all - other RegionServer functions should a process or node crash. The following configuration - settings are recommended for maintaining an even distribution of replication activity - over the remaining live servers in the source cluster: Set - replication.source.maxretriesmultiplier to - 300 (5 minutes), and - replication.sleep.before.failover to - 30000 (30 seconds) in the source cluster site configuration. - - - - - Preserving Tags During Replication - By default, the codec used for replication between clusters strips tags, such as - cell-level ACLs, from cells. To prevent the tags from being stripped, you can use a - different codec which does not strip them. Configure - hbase.replication.rpc.codec to use - org.apache.hadoop.hbase.codec.KeyValueCodecWithTags, on both the - source and sink RegionServers involved in the replication. This option was introduced in - HBASE-10322. - +
- Replication Internals - - - Replication State in ZooKeeper + Detailed Information About Cluster Replication + +
+ Replication Architecture Overview + + + + + + Illustration of the replication architecture in HBase, as described in the prior + text. + + +
+ + +
+ Life of a WAL Edit + A single WAL edit goes through several steps in order to be replicated to a slave + cluster. + + + When the slave responds correctly: - HBase replication maintains its state in ZooKeeper. By default, the state is - contained in the base node /hbase/replication. This node contains - two child nodes, the Peers znode and the RS znode. - - Replication may be disrupted and data loss may occur if you delete the - replication tree (/hbase/replication/) from ZooKeeper. This is - despite the information about invariants at . Follow progress on this issue at HBASE-10295. - + An HBase client uses a Put or Delete operation to manipulate data in HBase. + + + The region server writes the request to the WAL in a way allows it to be replayed + if it is not written successfully. + + + If the changed cell corresponds to a column family that is scoped for replication, + the edit is added to the queue for replication. + + + In a separate thread, the edit is read from the log, as part of a batch process. + Only the KeyValues that are eligible for replication are kept. Replicable KeyValues + are part of a column family whose schema is scoped GLOBAL, are not part of a catalog + such as hbase:meta, did not originate from the target slave cluster, and + have not already been consumed by the target slave cluster. + + + The edit is tagged with the master's UUID and added to a buffer. When the buffer + is filled, or the reader reaches the end of the file, the buffer is sent to a random + region server on the slave cluster. + + + The region server reads the edits sequentially and separates them into buffers, + one buffer per table. After all edits are read, each buffer is flushed using HTable, HBase's normal client. The master's UUID and the UUIDs of slaves + which have already consumed the data are preserved in the edits they are applied, in + order to prevent replication loops. + + + In the master, the offset for the WAL that is currently being replicated is + registered in ZooKeeper. + + + + When the slave does not respond: + + The first three steps, where the edit is inserted, are identical. + + + Again in a separate thread, the region server reads, filters, and edits the log + edits in the same way as above. The slave region server does not answer the RPC + call. + + + The master sleeps and tries again a configurable number of times. + + + If the slave region server is still not available, the master selects a new subset + of region server to replicate to, and tries again to send the buffer of edits. + + + Meanwhile, the WALs are rolled and stored in a queue in ZooKeeper. Logs that are + archived by their region server, by moving them from the + region server's log directory to a central log directory, will update their paths in + the in-memory queue of the replicating thread. + + + When the slave cluster is finally available, the buffer is applied in the same way + as during normal processing. The master region server will then replicate the backlog + of logs that accumulated during the outage. + + + + + Spreading Queue Failover Load + When replication is active, a subset of region servers in the source cluster is + responsible for shipping edits to the sink. This responsibility must be failed over like + all other region server functions should a process or node crash. The following + configuration settings are recommended for maintaining an even distribution of + replication activity over the remaining live servers in the source cluster: + + + + Set replication.source.maxretriesmultiplier to + 300. + + + Set replication.source.sleepforretries to 1 (1 + second). This value, combined with the value of + replication.source.maxretriesmultiplier, causes the retry cycle to last + about 5 minutes. - - - The Peers Znode - The peers znode is stored in - /hbase/replication/peers by default. It consists of a list of - all peer replication clusters, along with the status of each of them. The value of - each peer is its cluster key, which is provided in the HBase Shell. The cluster key - contains a list of ZooKeeper nodes in the cluster's quorum, the client port for the - ZooKeeper quorum, and the base znode for HBase in HDFS on that cluster. - + Set replication.sleep.before.failover to 30000 (30 + seconds) in the source cluster site configuration. + + + + + Preserving Tags During Replication + By default, the codec used for replication between clusters strips tags, such as + cell-level ACLs, from cells. To prevent the tags from being stripped, you can use a + different codec which does not strip them. Configure + hbase.replication.rpc.codec to use + org.apache.hadoop.hbase.codec.KeyValueCodecWithTags, on both the + source and sink RegionServers involved in the replication. This option was introduced in + HBASE-10322. + +
+ +
+ Replication Internals + + + Replication State in ZooKeeper + + HBase replication maintains its state in ZooKeeper. By default, the state is + contained in the base node /hbase/replication. This node + contains two child nodes, the Peers znode and the RS + znode. + + Replication may be disrupted and data loss may occur if you delete the + replication tree (/hbase/replication/) from ZooKeeper. This + is despite the information about invariants at . Follow progress on this issue at HBASE-10295. + + + + + The Peers Znode + + The peers znode is stored in + /hbase/replication/peers by default. It consists of a list of + all peer replication clusters, along with the status of each of them. The value of + each peer is its cluster key, which is provided in the HBase Shell. The cluster key + contains a list of ZooKeeper nodes in the cluster's quorum, the client port for the + ZooKeeper quorum, and the base znode for HBase in HDFS on that cluster. + /hbase/replication/peers /1 [Value: zk1.host.com,zk2.host.com,zk3.host.com:2181:/hbase] /2 [Value: zk5.host.com,zk6.host.com,zk7.host.com:2181:/hbase] - - Each peer has a child znode which indicates whether or not replication is enabled - on that cluster. These peer-state znodes do not contain any child znodes, but only - contain a Boolean value. This value is read and maintained by the - ReplicationPeer.PeerStateTracker class. - + + Each peer has a child znode which indicates whether or not replication is + enabled on that cluster. These peer-state znodes do not contain any child znodes, + but only contain a Boolean value. This value is read and maintained by the + ReplicationPeer.PeerStateTracker class. + /hbase/replication/peers /1/peer-state [Value: ENABLED] /2/peer-state [Value: DISABLED] - - - - - The RS Znode - - The rs znode contains a list of WAL logs which need to be replicated. - This list is divided into a set of queues organized by region server and the peer - cluster the region server is shipping the logs to. The rs znode has one child znode - for each region server in the cluster. The child znode name is the region server's - hostname, client port, and start code. This list includes both live and dead region - servers. - + + + + + The RS Znode + + The rs znode contains a list of WAL logs which need to be + replicated. This list is divided into a set of queues organized by region server and + the peer cluster the region server is shipping the logs to. The rs znode has one + child znode for each region server in the cluster. The child znode name is the + region server's hostname, client port, and start code. This list includes both live + and dead region servers. + /hbase/replication/rs /hostname.example.org,6020,1234 /hostname2.example.org,6020,2856 - - Each rs znode contains a list of WAL replication queues, one queue - for each peer cluster it replicates to. These queues are represented by child znodes - named by the cluster ID of the peer cluster they represent. - + + Each rs znode contains a list of WAL replication queues, one queue + for each peer cluster it replicates to. These queues are represented by child znodes + named by the cluster ID of the peer cluster they represent. + /hbase/replication/rs /hostname.example.org,6020,1234 /1 /2 - - Each queue has one child znode for each WAL log that still needs to be replicated. - the value of these child znodes is the last position that was replicated. This - position is updated each time a WAL log is replicated. - + + Each queue has one child znode for each WAL log that still needs to be + replicated. the value of these child znodes is the last position that was + replicated. This position is updated each time a WAL log is replicated. + /hbase/replication/rs /hostname.example.org,6020,1234 /1 23522342.23422 [VALUE: 254] 12340993.22342 [VALUE: 0] - - - - -
-
- Replication Configuration Options - - - - - Option - Description - Default - - - - - zookeeper.znode.parent - The name of the base ZooKeeper znode used for HBase - /hbase - - - zookeeper.znode.replication - The name of the base znode used for replication - replication - - - zookeeper.znode.replication.peers - The name of the peer znode - peers - - - zookeeper.znode.replication.peers.state - The name of peer-state znode - peer-state - - - zookeeper.znode.replication.rs - The name of the rs znode - rs - - - hbase.replication - Whether replication is enabled or disabled on a given cluster - false - - - eplication.sleep.before.failover - How many milliseconds a worker should sleep before attempting to replicate - a dead region server's WAL queues. - - - - replication.executor.workers - The number of region servers a given region server should attempt to - failover simultaneously. - 1 - - - - -
- -
- Replication Implementation Details - + + + + +
+
Choosing Region Servers to Replicate To When a master cluster region server initiates a replication source to a slave cluster, it first connects to the slave's ZooKeeper ensemble using the provided cluster key . It @@ -1802,17 +1856,16 @@ $ for i in `cat conf/regionservers|sort`; do ./bin/graceful_stop.sh --restart -- high, and this method works for clusters of any size. For example, a master cluster of 10 machines replicating to a slave cluster of 5 machines with a ratio of 10% causes the master cluster region servers to choose one machine each at random. - - A ZooKeeper watcher is placed on the - ${zookeeper.znode.parent}/rs node of the - slave cluster by each of the master cluster's region servers. This watch is used to monitor - changes in the composition of the slave cluster. When nodes are removed from the slave - cluster, or if nodes go down or come back up, the master cluster's region servers will - respond by selecting a new pool of slave region servers to replicate to. + A ZooKeeper watcher is placed on the + ${zookeeper.znode.parent}/rs node of + the slave cluster by each of the master cluster's region servers. This watch is used to + monitor changes in the composition of the slave cluster. When nodes are removed from the + slave cluster, or if nodes go down or come back up, the master cluster's region servers + will respond by selecting a new pool of slave region servers to replicate to. +
- +
Keeping Track of Logs - Each master cluster region server has its own znode in the replication znodes hierarchy. It contains one znode per peer cluster (if 5 slave clusters, 5 znodes are created), and each of these contain a queue of WALs to process. Each of these queues will @@ -1820,26 +1873,26 @@ $ for i in `cat conf/regionservers|sort`; do ./bin/graceful_stop.sh --restart -- one slave cluster becomes unavailable for some time, the WALs should not be deleted, so they need to stay in the queue while the others are processed. See for an example. - - When a source is instantiated, it contains the current WAL that the region server is - writing to. During log rolling, the new file is added to the queue of each slave cluster's - znode just before it is made available. This ensures that all the sources are aware that a - new log exists before the region server is able to append edits into it, but this operations - is now more expensive. The queue items are discarded when the replication thread cannot read - more entries from a file (because it reached the end of the last block) and there are other - files in the queue. This means that if a source is up to date and replicates from the log - that the region server writes to, reading up to the "end" of the current file will not - delete the item in the queue. - A log can be archived if it is no longer used or if the number of logs exceeds - hbase.regionserver.maxlogs because the insertion rate is faster than regions - are flushed. When a log is archived, the source threads are notified that the path for that - log changed. If a particular source has already finished with an archived log, it will just - ignore the message. If the log is in the queue, the path will be updated in memory. If the - log is currently being replicated, the change will be done atomically so that the reader - doesn't attempt to open the file when has already been moved. Because moving a file is a - NameNode operation , if the reader is currently reading the log, it won't generate any - exception. - + When a source is instantiated, it contains the current WAL that the region server is + writing to. During log rolling, the new file is added to the queue of each slave cluster's + znode just before it is made available. This ensures that all the sources are aware that a + new log exists before the region server is able to append edits into it, but this + operations is now more expensive. The queue items are discarded when the replication + thread cannot read more entries from a file (because it reached the end of the last block) + and there are other files in the queue. This means that if a source is up to date and + replicates from the log that the region server writes to, reading up to the "end" of the + current file will not delete the item in the queue. + A log can be archived if it is no longer used or if the number of logs exceeds + hbase.regionserver.maxlogs because the insertion rate is faster than + regions are flushed. When a log is archived, the source threads are notified that the path + for that log changed. If a particular source has already finished with an archived log, it + will just ignore the message. If the log is in the queue, the path will be updated in + memory. If the log is currently being replicated, the change will be done atomically so + that the reader doesn't attempt to open the file when has already been moved. Because + moving a file is a NameNode operation , if the reader is currently reading the log, it + won't generate any exception. +
+
Reading, Filtering and Sending Edits By default, a source attempts to read from a WAL and ship log entries to a sink as quickly as possible. Speed is limited by the filtering of log entries Only KeyValues that @@ -1848,16 +1901,17 @@ $ for i in `cat conf/regionservers|sort`; do ./bin/graceful_stop.sh --restart -- MB by default. With this configuration, a master cluster region server with three slaves would use at most 192 MB to store data to replicate. This does not account for the data which was filtered but not garbage collected. - - Once the maximum size of edits has been buffered or the reader reaces the end of the - WAL, the source thread stops reading and chooses at random a sink to replicate to (from the - list that was generated by keeping only a subset of slave region servers). It directly - issues a RPC to the chosen region server and waits for the method to return. If the RPC was - successful, the source determines whether the current file has been emptied or it contains - more data which needs to be read. If the file has been emptied, the source deletes the znode - in the queue. Otherwise, it registers the new offset in the log's znode. If the RPC threw an - exception, the source will retry 10 times before trying to find a different sink. - + Once the maximum size of edits has been buffered or the reader reaces the end of the + WAL, the source thread stops reading and chooses at random a sink to replicate to (from + the list that was generated by keeping only a subset of slave region servers). It directly + issues a RPC to the chosen region server and waits for the method to return. If the RPC + was successful, the source determines whether the current file has been emptied or it + contains more data which needs to be read. If the file has been emptied, the source + deletes the znode in the queue. Otherwise, it registers the new offset in the log's znode. + If the RPC threw an exception, the source will retry 10 times before trying to find a + different sink. +
+
Cleaning Logs If replication is not enabled, the master's log-cleaning thread deletes old logs using a configured TTL. This TTL-based method does not work well with replication, because @@ -1866,33 +1920,32 @@ $ for i in `cat conf/regionservers|sort`; do ./bin/graceful_stop.sh --restart -- until it finds the log, while caching queues it has found. If the log is not found in any queues, the log will be deleted. The next time the cleaning process needs to look for a log, it starts by using its cached list. - - +
+
Region Server Failover When no region servers are failing, keeping track of the logs in ZooKeeper adds no value. Unfortunately, region servers do fail, and since ZooKeeper is highly available, it is useful for managing the transfer of the queues in the event of a failure. - - Each of the master cluster region servers keeps a watcher on every other region server, - in order to be notified when one dies (just as the master does). When a failure happens, - they all race to create a znode called lock inside the dead region - server's znode that contains its queues. The region server that creates it successfully then - transfers all the queues to its own znode, one at a time since ZooKeeper does not support - renaming queues. After queues are all transferred, they are deleted from the old location. - The znodes that were recovered are renamed with the ID of the slave cluster appended with - the name of the dead server. - Next, the master cluster region server creates one new source thread per copied queue, - and each of the source threads follows the read/filter/ship pattern. The main difference is - that those queues will never receive new data, since they do not belong to their new region - server. When the reader hits the end of the last log, the queue's znode is deleted and the - master cluster region server closes that replication source. - Given a master cluster with 3 region servers replicating to a single slave with id - 2, the following hierarchy represents what the znodes layout could be - at some point in time. The region servers' znodes all contain a peers - znode which contains a single queue. The znode names in the queues represent the actual file - names on HDFS in the form - address,port.timestamp. - + Each of the master cluster region servers keeps a watcher on every other region + server, in order to be notified when one dies (just as the master does). When a failure + happens, they all race to create a znode called lock inside the dead + region server's znode that contains its queues. The region server that creates it + successfully then transfers all the queues to its own znode, one at a time since ZooKeeper + does not support renaming queues. After queues are all transferred, they are deleted from + the old location. The znodes that were recovered are renamed with the ID of the slave + cluster appended with the name of the dead server. + Next, the master cluster region server creates one new source thread per copied queue, + and each of the source threads follows the read/filter/ship pattern. The main difference + is that those queues will never receive new data, since they do not belong to their new + region server. When the reader hits the end of the last log, the queue's znode is deleted + and the master cluster region server closes that replication source. + Given a master cluster with 3 region servers replicating to a single slave with id + 2, the following hierarchy represents what the znodes layout could be + at some point in time. The region servers' znodes all contain a peers + znode which contains a single queue. The znode names in the queues represent the actual + file names on HDFS in the form + address,port.timestamp. + /hbase/replication/rs/ 1.1.1.1,60020,123456780/ 2/ @@ -1907,11 +1960,11 @@ $ for i in `cat conf/regionservers|sort`; do ./bin/graceful_stop.sh --restart -- 2/ 1.1.1.3,60020.1280 (Contains a position) - Assume that 1.1.1.2 loses its ZooKeeper session. The survivors will race to create a - lock, and, arbitrarily, 1.1.1.3 wins. It will then start transferring all the queues to its - local peers znode by appending the name of the dead server. Right before 1.1.1.3 is able to - clean up the old znodes, the layout will look like the following: - + Assume that 1.1.1.2 loses its ZooKeeper session. The survivors will race to create a + lock, and, arbitrarily, 1.1.1.3 wins. It will then start transferring all the queues to + its local peers znode by appending the name of the dead server. Right before 1.1.1.3 is + able to clean up the old znodes, the layout will look like the following: + /hbase/replication/rs/ 1.1.1.1,60020,123456780/ 2/ @@ -1932,11 +1985,11 @@ $ for i in `cat conf/regionservers|sort`; do ./bin/graceful_stop.sh --restart -- 1.1.1.2,60020.1248 1.1.1.2,60020.1312 - Some time later, but before 1.1.1.3 is able to finish replicating the last WAL from - 1.1.1.2, it dies too. Some new logs were also created in the normal queues. The last region - server will then try to lock 1.1.1.3's znode and will begin transferring all the queues. The - new layout will be: - + Some time later, but before 1.1.1.3 is able to finish replicating the last WAL from + 1.1.1.2, it dies too. Some new logs were also created in the normal queues. The last + region server will then try to lock 1.1.1.3's znode and will begin transferring all the + queues. The new layout will be: + /hbase/replication/rs/ 1.1.1.1,60020,123456780/ 2/ @@ -1957,11 +2010,12 @@ $ for i in `cat conf/regionservers|sort`; do ./bin/graceful_stop.sh --restart -- 2-1.1.1.2,60020,123456790/ 1.1.1.2,60020.1312 (Contains a position) - - Replication Metrics - The following metrics are exposed at the global region server level and (since HBase - 0.95) at the peer level: - +
+
+
+ Replication Metrics + The following metrics are exposed at the global region server level and (since HBase + 0.95) at the peer level: source.sizeOfLogQueue @@ -1989,7 +2043,65 @@ $ for i in `cat conf/regionservers|sort`; do ./bin/graceful_stop.sh --restart -- - +
+
+ Replication Configuration Options + + + + + Option + Description + Default + + + + + zookeeper.znode.parent + The name of the base ZooKeeper znode used for HBase + /hbase + + + zookeeper.znode.replication + The name of the base znode used for replication + replication + + + zookeeper.znode.replication.peers + The name of the peer znode + peers + + + zookeeper.znode.replication.peers.state + The name of peer-state znode + peer-state + + + zookeeper.znode.replication.rs + The name of the rs znode + rs + + + hbase.replication + Whether replication is enabled or disabled on a given + cluster + false + + + eplication.sleep.before.failover + How many milliseconds a worker should sleep before attempting to replicate + a dead region server's WAL queues. + + + + replication.executor.workers + The number of region servers a given region server should attempt to + failover simultaneously. + 1 + + + +
See HColumnDescriptor for more information. + Recent versions of HBase also support setting time to live on a per cell basis. See HBASE-10560 for more + information. Cell TTLs are submitted as an attribute on mutation requests (Appends, + Increments, Puts, etc.) using Mutation#setTTL. If the TTL attribute is set, it will be applied + to all cells updated on the server by the operation. There are two notable differences + between cell TTL handling and ColumnFamily TTLs: + + + Cell TTLs are expressed in units of milliseconds instead of seconds. + + + A cell TTLs cannot extend the effective lifetime of a cell beyond a ColumnFamily level + TTL setting. + +
http://git-wip-us.apache.org/repos/asf/hbase/blob/6707c350/src/main/docbkx/security.xml ---------------------------------------------------------------------- diff --git a/src/main/docbkx/security.xml b/src/main/docbkx/security.xml index d649f95..61493cd 100644 --- a/src/main/docbkx/security.xml +++ b/src/main/docbkx/security.xml @@ -28,7 +28,37 @@ * limitations under the License. */ --> - Secure Apache HBase + Securing Apache HBase + HBase provides mechanisms to secure various components and aspects of HBase and how it + relates to the rest of the Hadoop infrastructure, as well as clients and resources outside + Hadoop. +
+ Using Secure HTTP (HTTPS) for the Web UI + A default HBase install uses insecure HTTP connections for web UIs for the master and + region servers. To enable secure HTTP (HTTPS) connections instead, set + hadoop.ssl.enabled to true in + hbase-site.xml. This does not change the port used by the Web UI. To + change the port for the web UI for a given HBase component, configure that port's setting in + hbase-site.xml. These settings are: + + hbase.master.info.port + hbase.regionserver.info.port + + + If you enable HTTPS, clients should avoid using the non-secure HTTP connection. + If you enable secure HTTP, clients should connect to HBase using the + https:// URL. Clients using the http:// URL will receive an HTTP + response of 200, but will not receive any data. The following exception is logged: + javax.net.ssl.SSLException: Unrecognized SSL message, plaintext connection? + This is because the same port is used for HTTP and HTTPS. + HBase uses Jetty for the Web UI. Without modifying Jetty itself, it does not seem + possible to configure Jetty to redirect one port to another on the same host. See Nick + Dimiduk's contribution on this Stack Overflow thread for more information. If you know how to fix this without + opening a second port for HTTPS, patches are appreciated. + +
Secure Client Access to Apache HBase