Return-Path: X-Original-To: archive-asf-public-internal@cust-asf2.ponee.io Delivered-To: archive-asf-public-internal@cust-asf2.ponee.io Received: from cust-asf.ponee.io (cust-asf.ponee.io [163.172.22.183]) by cust-asf2.ponee.io (Postfix) with ESMTP id EF75D200C62 for ; Wed, 12 Apr 2017 03:30:44 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id EE0B4160BB7; Wed, 12 Apr 2017 01:30:44 +0000 (UTC) Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by cust-asf.ponee.io (Postfix) with SMTP id C8BD2160B9E for ; Wed, 12 Apr 2017 03:30:42 +0200 (CEST) Received: (qmail 20945 invoked by uid 500); 12 Apr 2017 01:30:40 -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 20124 invoked by uid 99); 12 Apr 2017 01:30:40 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Wed, 12 Apr 2017 01:30:40 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id D83E8E024D; Wed, 12 Apr 2017 01:30:39 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: git-site-role@apache.org To: commits@hbase.apache.org Date: Wed, 12 Apr 2017 01:30:48 -0000 Message-Id: <81273645458e431f890520a7c9af2316@git.apache.org> In-Reply-To: <9b3dbce3d46d490783bdca2deac50228@git.apache.org> References: <9b3dbce3d46d490783bdca2deac50228@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [10/51] [partial] hbase-site git commit: Published site at d7ddc79198679d8c642e7d8ad5141ba518f8d9f3. archived-at: Wed, 12 Apr 2017 01:30:45 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/3c0cf248/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/WALActionsListener.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/WALActionsListener.html b/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/WALActionsListener.html index 5d6fc7d..05d364d 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/WALActionsListener.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/WALActionsListener.html @@ -269,7 +269,7 @@ protected List<WALActionsListener> -DisabledWALProvider.DisabledWAL.listeners  +AbstractFSWALProvider.listeners  private List<WALActionsListener> @@ -277,7 +277,7 @@ protected List<WALActionsListener> -AbstractFSWALProvider.listeners  +DisabledWALProvider.DisabledWAL.listeners  @@ -334,30 +334,30 @@ void -WALProvider.init(WALFactory factory, +AbstractFSWALProvider.init(WALFactory factory, org.apache.hadoop.conf.Configuration conf, List<WALActionsListener> listeners, - String providerId) -
Set up the provider to create wals.
- + String providerId)
  void -DisabledWALProvider.init(WALFactory factory, +RegionGroupingProvider.init(WALFactory factory, org.apache.hadoop.conf.Configuration conf, List<WALActionsListener> listeners, String providerId)  void -RegionGroupingProvider.init(WALFactory factory, +WALProvider.init(WALFactory factory, org.apache.hadoop.conf.Configuration conf, List<WALActionsListener> listeners, - String providerId)  + String providerId) +
Set up the provider to create wals.
+ void -AbstractFSWALProvider.init(WALFactory factory, +DisabledWALProvider.init(WALFactory factory, org.apache.hadoop.conf.Configuration conf, List<WALActionsListener> listeners, String providerId)  http://git-wip-us.apache.org/repos/asf/hbase-site/blob/3c0cf248/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/WALEdit.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/WALEdit.html b/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/WALEdit.html index 86c5473..098eeec 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/WALEdit.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/WALEdit.html @@ -302,13 +302,13 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. -(package private) WALEdit[] -HRegion.BatchOperation.walEditsFromCoprocessors  - - private WALEdit[] MiniBatchOperationInProgress.walEditsFromCoprocessors  + +(package private) WALEdit[] +HRegion.BatchOperation.walEditsFromCoprocessors  + @@ -392,11 +392,9 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. - + boolean success)  @@ -406,9 +404,11 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. - + boolean success) +
The hook to be executed after process() and applying the Mutations to region.
+ @@ -424,10 +424,8 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. - + @@ -436,8 +434,10 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. - + @@ -447,10 +447,8 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. - + @@ -459,8 +457,10 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. - + @@ -481,6 +481,13 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. + + + + - - - - + + + + - - - - - + - +
voidRowProcessor.postProcess(HRegion region, +MultiRowMutationProcessor.postProcess(HRegion region, WALEdit walEdit, - boolean success) -
The hook to be executed after process() and applying the Mutations to region.
-
void
voidMultiRowMutationProcessor.postProcess(HRegion region, +RowProcessor.postProcess(HRegion region, WALEdit walEdit, - boolean success) 
void
voidRowProcessor.preBatchMutate(HRegion region, - WALEdit walEdit) -
The hook to be executed after the process() but before applying the Mutations to region.
-
MultiRowMutationProcessor.preBatchMutate(HRegion region, + WALEdit walEdit) 
void
voidMultiRowMutationProcessor.preBatchMutate(HRegion region, - WALEdit walEdit) RowProcessor.preBatchMutate(HRegion region, + WALEdit walEdit) +
The hook to be executed after the process() but before applying the Mutations to region.
+
boolean
voidRowProcessor.preProcess(HRegion region, - WALEdit walEdit) -
The hook to be executed before process().
-
MultiRowMutationProcessor.preProcess(HRegion region, + WALEdit walEdit) 
void
voidMultiRowMutationProcessor.preProcess(HRegion region, - WALEdit walEdit) RowProcessor.preProcess(HRegion region, + WALEdit walEdit) +
The hook to be executed before process().
+
private void
voidMultiRowMutationProcessor.process(long now, + HRegion region, + List<Mutation> mutationsToApply, + WALEdit walEdit) 
void RowProcessor.process(long now, HRegion region, List<Mutation> mutations, @@ -488,13 +495,6 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods.
HRegion handles the locks and MVCC and invokes this method properly.
voidMultiRowMutationProcessor.process(long now, - HRegion region, - List<Mutation> mutationsToApply, - WALEdit walEdit) 
void MiniBatchOperationInProgress.setWalEdit(int index, @@ -576,6 +576,13 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. boolean inMemstore) 
longAsyncFSWAL.append(HRegionInfo hri, + WALKey key, + WALEdit edits, + boolean inMemstore) 
abstract long AbstractFSWAL.append(HRegionInfo info, WALKey key, @@ -585,13 +592,6 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. transaction by calling 'begin' wherein which we assign this update a sequenceid.
longAsyncFSWAL.append(HRegionInfo hri, - WALKey key, - WALEdit edits, - boolean inMemstore) 
static WALKey WALUtil.doFullAppendTransaction(WAL wal, http://git-wip-us.apache.org/repos/asf/hbase-site/blob/3c0cf248/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationEndpoint.Context.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationEndpoint.Context.html b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationEndpoint.Context.html index bc44ad1..fe8ac0a 100644 --- a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationEndpoint.Context.html +++ b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationEndpoint.Context.html @@ -127,13 +127,13 @@
voidReplicationEndpoint.init(ReplicationEndpoint.Context context) -
Initialize the replication endpoint with the given context.
-
BaseReplicationEndpoint.init(ReplicationEndpoint.Context context) 
voidBaseReplicationEndpoint.init(ReplicationEndpoint.Context context) ReplicationEndpoint.init(ReplicationEndpoint.Context context) +
Initialize the replication endpoint with the given context.
+
@@ -151,11 +151,11 @@ void -RegionReplicaReplicationEndpoint.init(ReplicationEndpoint.Context context)  +HBaseInterClusterReplicationEndpoint.init(ReplicationEndpoint.Context context)  void -HBaseInterClusterReplicationEndpoint.init(ReplicationEndpoint.Context context)  +RegionReplicaReplicationEndpoint.init(ReplicationEndpoint.Context context)  http://git-wip-us.apache.org/repos/asf/hbase-site/blob/3c0cf248/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationEndpoint.ReplicateContext.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationEndpoint.ReplicateContext.html b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationEndpoint.ReplicateContext.html index 40b66f2..0c1a7a0 100644 --- a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationEndpoint.ReplicateContext.html +++ b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationEndpoint.ReplicateContext.html @@ -155,14 +155,14 @@ boolean -RegionReplicaReplicationEndpoint.replicate(ReplicationEndpoint.ReplicateContext replicateContext)  - - -boolean HBaseInterClusterReplicationEndpoint.replicate(ReplicationEndpoint.ReplicateContext replicateContext)
Do the shipping logic
+ +boolean +RegionReplicaReplicationEndpoint.replicate(ReplicationEndpoint.ReplicateContext replicateContext)  + http://git-wip-us.apache.org/repos/asf/hbase-site/blob/3c0cf248/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationException.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationException.html b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationException.html index 6f0ad43..9e56375 100644 --- a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationException.html +++ b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationException.html @@ -257,78 +257,78 @@ void +HMaster.addReplicationPeer(String peerId, + ReplicationPeerConfig peerConfig)  + + +void MasterServices.addReplicationPeer(String peerId, ReplicationPeerConfig peerConfig)
Add a new replication peer for replicating data to slave cluster
- + void -HMaster.addReplicationPeer(String peerId, - ReplicationPeerConfig peerConfig)  +HMaster.disableReplicationPeer(String peerId)  - + void MasterServices.disableReplicationPeer(String peerId)
Stop the replication stream to the specified peer
- + void -HMaster.disableReplicationPeer(String peerId)  +HMaster.enableReplicationPeer(String peerId)  - + void MasterServices.enableReplicationPeer(String peerId)
Restart the replication stream to the specified peer
- -void -HMaster.enableReplicationPeer(String peerId)  - ReplicationPeerConfig -MasterServices.getReplicationPeerConfig(String peerId) -
Returns the configured ReplicationPeerConfig for the specified peer
- +HMaster.getReplicationPeerConfig(String peerId)  ReplicationPeerConfig -HMaster.getReplicationPeerConfig(String peerId)  +MasterServices.getReplicationPeerConfig(String peerId) +
Returns the configured ReplicationPeerConfig for the specified peer
+ List<ReplicationPeerDescription> -MasterServices.listReplicationPeers(String regex) -
Return a list of replication peers.
- +HMaster.listReplicationPeers(String regex)  List<ReplicationPeerDescription> -HMaster.listReplicationPeers(String regex)  +MasterServices.listReplicationPeers(String regex) +
Return a list of replication peers.
+ void +HMaster.removeReplicationPeer(String peerId)  + + +void MasterServices.removeReplicationPeer(String peerId)
Removes a peer and stops the replication
- + void -HMaster.removeReplicationPeer(String peerId)  +HMaster.updateReplicationPeerConfig(String peerId, + ReplicationPeerConfig peerConfig)  - + void MasterServices.updateReplicationPeerConfig(String peerId, ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer
- -void -HMaster.updateReplicationPeerConfig(String peerId, - ReplicationPeerConfig peerConfig)  - @@ -403,10 +403,8 @@ void -ReplicationQueues.addHFileRefs(String peerId, - List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) -
Add new hfile references to the queue.
- +TableBasedReplicationQueuesImpl.addHFileRefs(String peerId, + List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs)  void @@ -415,15 +413,15 @@ void -TableBasedReplicationQueuesImpl.addHFileRefs(String peerId, - List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs)  +ReplicationQueues.addHFileRefs(String peerId, + List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) +
Add new hfile references to the queue.
+ void -ReplicationQueues.addLog(String queueId, - String filename) -
Add a new WAL file to the given queue.
- +TableBasedReplicationQueuesImpl.addLog(String queueId, + String filename)  void @@ -432,14 +430,14 @@ void -TableBasedReplicationQueuesImpl.addLog(String queueId, - String filename)  +ReplicationQueues.addLog(String queueId, + String filename) +
Add a new WAL file to the given queue.
+ void -ReplicationQueues.addPeerToHFileRefs(String peerId) -
Add a peer to hfile reference queue if peer does not exist.
- +TableBasedReplicationQueuesImpl.addPeerToHFileRefs(String peerId)  void @@ -447,7 +445,9 @@ void -TableBasedReplicationQueuesImpl.addPeerToHFileRefs(String peerId)  +ReplicationQueues.addPeerToHFileRefs(String peerId) +
Add a peer to hfile reference queue if peer does not exist.
+ private void @@ -494,10 +494,8 @@ long -ReplicationQueues.getLogPosition(String queueId, - String filename) -
Get the current position for a specific WAL in a given queue.
- +TableBasedReplicationQueuesImpl.getLogPosition(String queueId, + String filename)  long @@ -506,8 +504,10 @@ long -TableBasedReplicationQueuesImpl.getLogPosition(String queueId, - String filename)  +ReplicationQueues.getLogPosition(String queueId, + String filename) +
Get the current position for a specific WAL in a given queue.
+ Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> @@ -554,7 +554,7 @@ void -TableBasedReplicationQueuesClientImpl.init()  +ReplicationQueuesClientZKImpl.init()  void @@ -564,23 +564,21 @@ void -ReplicationQueuesClientZKImpl.init()  - - -void ReplicationPeersZKImpl.init()  - + void ReplicationQueuesClient.init()
Initialize the replication queue client interface.
+ +void +TableBasedReplicationQueuesClientImpl.init()  + void -ReplicationQueues.init(String serverName) -
Initialize the region server replication queue interface.
- +TableBasedReplicationQueuesImpl.init(String serverName)  void @@ -588,7 +586,9 @@ void -TableBasedReplicationQueuesImpl.init(String serverName)  +ReplicationQueues.init(String serverName) +
Initialize the region server replication queue interface.
+ boolean @@ -699,17 +699,11 @@ void -ReplicationSourceManager.addHFileRefs(TableName tableName, - byte[] family, - List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs)  - - -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, @@ -717,6 +711,12 @@
Add hfile names to the queue to be replicated.
+ +void +ReplicationSourceManager.addHFileRefs(TableName tableName, + byte[] family, + List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs)  + protected ReplicationSourceInterface ReplicationSourceManager.addSource(String id) http://git-wip-us.apache.org/repos/asf/hbase-site/blob/3c0cf248/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeerConfig.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeerConfig.html b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeerConfig.html index 395ceb7..e705265 100644 --- a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeerConfig.html +++ b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeerConfig.html @@ -369,13 +369,13 @@ ReplicationPeerConfig -MasterServices.getReplicationPeerConfig(String peerId) -
Returns the configured ReplicationPeerConfig for the specified peer
- +HMaster.getReplicationPeerConfig(String peerId)  ReplicationPeerConfig -HMaster.getReplicationPeerConfig(String peerId)  +MasterServices.getReplicationPeerConfig(String peerId) +
Returns the configured ReplicationPeerConfig for the specified peer
+ @@ -388,16 +388,16 @@ void +HMaster.addReplicationPeer(String peerId, + ReplicationPeerConfig peerConfig)  + + +void MasterServices.addReplicationPeer(String peerId, ReplicationPeerConfig peerConfig)
Add a new replication peer for replicating data to slave cluster
- -void -HMaster.addReplicationPeer(String peerId, - ReplicationPeerConfig peerConfig)  - void MasterCoprocessorHost.postAddReplicationPeer(String peerId, @@ -420,16 +420,16 @@ void +HMaster.updateReplicationPeerConfig(String peerId, + ReplicationPeerConfig peerConfig)  + + +void MasterServices.updateReplicationPeerConfig(String peerId, ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer
- -void -HMaster.updateReplicationPeerConfig(String peerId, - ReplicationPeerConfig peerConfig)  - @@ -510,14 +510,14 @@ ReplicationPeerConfig -ReplicationPeerDescription.getPeerConfig()  - - -ReplicationPeerConfig ReplicationPeerZKImpl.getPeerConfig()
Get the peer config object
+ +ReplicationPeerConfig +ReplicationPeerDescription.getPeerConfig()  + ReplicationPeerConfig ReplicationEndpoint.Context.getPeerConfig()  http://git-wip-us.apache.org/repos/asf/hbase-site/blob/3c0cf248/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeerDescription.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeerDescription.html b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeerDescription.html index b189da5..0e42fc0 100644 --- a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeerDescription.html +++ b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeerDescription.html @@ -219,13 +219,13 @@ List<ReplicationPeerDescription> -MasterServices.listReplicationPeers(String regex) -
Return a list of replication peers.
- +HMaster.listReplicationPeers(String regex)  List<ReplicationPeerDescription> -HMaster.listReplicationPeers(String regex)  +MasterServices.listReplicationPeers(String regex) +
Return a list of replication peers.
+