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 3B048195A6 for ; Tue, 12 Apr 2016 17:31:53 +0000 (UTC) Received: (qmail 30850 invoked by uid 500); 12 Apr 2016 17:31:51 -0000 Delivered-To: apmail-hbase-commits-archive@hbase.apache.org Received: (qmail 30738 invoked by uid 500); 12 Apr 2016 17:31:51 -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 29930 invoked by uid 99); 12 Apr 2016 17:31:50 -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; Tue, 12 Apr 2016 17:31:50 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id B210ADFF10; Tue, 12 Apr 2016 17:31:50 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: misty@apache.org To: commits@hbase.apache.org Date: Tue, 12 Apr 2016 17:31:59 -0000 Message-Id: <960f0c1833904ae58fc7ab80ea7b1a9e@git.apache.org> In-Reply-To: <9158f18ce31c4326a568e441e4899fc9@git.apache.org> References: <9158f18ce31c4326a568e441e4899fc9@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [10/51] [partial] hbase-site git commit: Published site at ff9c92e16831fe350904ac99f92619fb97ba2bef. http://git-wip-us.apache.org/repos/asf/hbase-site/blob/5c0cc30a/devapidocs/org/apache/hadoop/hbase/regionserver/throttle/class-use/ThroughputController.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/throttle/class-use/ThroughputController.html b/devapidocs/org/apache/hadoop/hbase/regionserver/throttle/class-use/ThroughputController.html index dd4bb45..d216194 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/throttle/class-use/ThroughputController.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/throttle/class-use/ThroughputController.html @@ -200,42 +200,42 @@ List<StoreFile> -Store.compact(CompactionContext compaction, +HMobStore.compact(CompactionContext compaction, ThroughputController throughputController) -
Deprecated.  -
see compact(CompactionContext, ThroughputController, User)
-
+
The compaction in the store of mob.
List<StoreFile> -HMobStore.compact(CompactionContext compaction, +HStore.compact(CompactionContext compaction, ThroughputController throughputController) -
The compaction in the store of mob.
+
Compact the StoreFiles.
List<StoreFile> -HStore.compact(CompactionContext compaction, +Store.compact(CompactionContext compaction, ThroughputController throughputController) -
Compact the StoreFiles.
+
Deprecated.  +
see compact(CompactionContext, ThroughputController, User)
+
List<StoreFile> -Store.compact(CompactionContext compaction, +HStore.compact(CompactionContext compaction, ThroughputController throughputController, User user)  List<StoreFile> -HStore.compact(CompactionContext compaction, +Store.compact(CompactionContext compaction, ThroughputController throughputController, User user)  List<org.apache.hadoop.fs.Path> -StripeStoreEngine.StripeCompaction.compact(ThroughputController throughputController, +DateTieredStoreEngine.DateTieredCompactionContext.compact(ThroughputController throughputController, User user)  @@ -245,7 +245,7 @@ List<org.apache.hadoop.fs.Path> -DateTieredStoreEngine.DateTieredCompactionContext.compact(ThroughputController throughputController, +StripeStoreEngine.StripeCompaction.compact(ThroughputController throughputController, User user)  @@ -266,6 +266,13 @@ +List<org.apache.hadoop.fs.Path> +DefaultStoreFlusher.flushSnapshot(MemStoreSnapshot snapshot, + long cacheFlushId, + MonitoredTask status, + ThroughputController throughputController)  + + abstract List<org.apache.hadoop.fs.Path> StoreFlusher.flushSnapshot(MemStoreSnapshot snapshot, long cacheFlushSeqNum, @@ -274,20 +281,13 @@
Turns a snapshot of memstore into a set of store files.
- + List<org.apache.hadoop.fs.Path> StripeStoreFlusher.flushSnapshot(MemStoreSnapshot snapshot, long cacheFlushSeqNum, MonitoredTask status, ThroughputController throughputController)  - -List<org.apache.hadoop.fs.Path> -DefaultStoreFlusher.flushSnapshot(MemStoreSnapshot snapshot, - long cacheFlushId, - MonitoredTask status, - ThroughputController throughputController)  - protected void StoreFlusher.performFlush(InternalScanner scanner, @@ -476,12 +476,12 @@ static ThroughputController -CompactionThroughputControllerFactory.create(RegionServerServices server, +FlushThroughputControllerFactory.create(RegionServerServices server, org.apache.hadoop.conf.Configuration conf)  static ThroughputController -FlushThroughputControllerFactory.create(RegionServerServices server, +CompactionThroughputControllerFactory.create(RegionServerServices server, org.apache.hadoop.conf.Configuration conf)  @@ -495,11 +495,11 @@ static Class<? extends ThroughputController> -CompactionThroughputControllerFactory.getThroughputControllerClass(org.apache.hadoop.conf.Configuration conf)  +FlushThroughputControllerFactory.getThroughputControllerClass(org.apache.hadoop.conf.Configuration conf)  static Class<? extends ThroughputController> -FlushThroughputControllerFactory.getThroughputControllerClass(org.apache.hadoop.conf.Configuration conf)  +CompactionThroughputControllerFactory.getThroughputControllerClass(org.apache.hadoop.conf.Configuration conf)  http://git-wip-us.apache.org/repos/asf/hbase-site/blob/5c0cc30a/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/CompressionContext.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/CompressionContext.html b/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/CompressionContext.html index 0228a86..ca653ad 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/CompressionContext.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/CompressionContext.html @@ -112,14 +112,14 @@ protected CompressionContext -AbstractProtobufLogWriter.compressionContext  - - -protected CompressionContext ReaderBase.compressionContext
Compression context to use reading.
+ +protected CompressionContext +AbstractProtobufLogWriter.compressionContext  + private CompressionContext WALEdit.compressionContext  http://git-wip-us.apache.org/repos/asf/hbase-site/blob/5c0cc30a/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/SyncFuture.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/SyncFuture.html b/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/SyncFuture.html index 1c79980..b5253b7 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/SyncFuture.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/wal/class-use/SyncFuture.html @@ -122,13 +122,13 @@ AsyncFSWAL.SEQ_COMPARATOR  -private BlockingQueue<SyncFuture> -FSHLog.SyncRunner.syncFutures  - - private PriorityQueue<SyncFuture> AsyncFSWAL.syncFutures  + +private BlockingQueue<SyncFuture> +FSHLog.SyncRunner.syncFutures  + private ConcurrentMap<Thread,SyncFuture> AbstractFSWAL.syncFuturesByHandler http://git-wip-us.apache.org/repos/asf/hbase-site/blob/5c0cc30a/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 997f442..0bf0d5f 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 @@ -260,16 +260,16 @@ -protected List<WALActionsListener> -DisabledWALProvider.DisabledWAL.listeners  +private List<WALActionsListener> +RegionGroupingProvider.listeners  protected List<WALActionsListener> AbstractFSWALProvider.listeners  -private List<WALActionsListener> -RegionGroupingProvider.listeners  +protected List<WALActionsListener> +DisabledWALProvider.DisabledWAL.listeners  @@ -326,33 +326,33 @@ void -DisabledWALProvider.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, +RegionGroupingProvider.init(WALFactory factory, org.apache.hadoop.conf.Configuration conf, List<WALActionsListener> listeners, String providerId)  void -RegionGroupingProvider.init(WALFactory factory, +AbstractFSWALProvider.init(WALFactory factory, org.apache.hadoop.conf.Configuration conf, List<WALActionsListener> listeners, String providerId)  void -WALProvider.init(WALFactory factory, +DisabledWALProvider.init(WALFactory factory, org.apache.hadoop.conf.Configuration conf, List<WALActionsListener> listeners, - String providerId) -
Set up the provider to create wals.
- + String providerId)
  http://git-wip-us.apache.org/repos/asf/hbase-site/blob/5c0cc30a/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 061b927..66e55e2 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 @@ -390,17 +390,17 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. +org.apache.hadoop.mapreduce.RecordReader<WALKey,WALEdit> +WALInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split, + org.apache.hadoop.mapreduce.TaskAttemptContext context)  + + org.apache.hadoop.mapreduce.RecordReader<HLogKey,WALEdit> HLogInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context)
Deprecated. 
  - -org.apache.hadoop.mapreduce.RecordReader<WALKey,WALEdit> -WALInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split, - org.apache.hadoop.mapreduce.TaskAttemptContext context)  - @@ -527,21 +527,21 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. - + boolean success)  - + boolean success) +
The hook to be executed after process() and applying the Mutations to region.
+ - @@ -569,19 +569,19 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. + + + + - - - - - @@ -592,19 +592,19 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. + + + + - - - - - @@ -738,19 +738,12 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. - - - - - + + + + + + + + + - + - - - - - - - - + + + +
voidRowProcessor.postProcess(HRegion region, +BaseRowProcessor.postProcess(HRegion region, WALEdit walEdit, - boolean success) -
The hook to be executed after process() and applying the Mutations to region.
-
voidMultiRowMutationProcessor.postProcess(HRegion region, +RowProcessor.postProcess(HRegion region, WALEdit walEdit, - boolean success) 
voidBaseRowProcessor.postProcess(HRegion region, +MultiRowMutationProcessor.postProcess(HRegion region, WALEdit walEdit, boolean success) 
voidBaseRowProcessor.preBatchMutate(HRegion region, + WALEdit walEdit) 
void RowProcessor.preBatchMutate(HRegion region, WALEdit walEdit)
The hook to be executed after the process() but before applying the Mutations to region.
voidMultiRowMutationProcessor.preBatchMutate(HRegion region, - WALEdit walEdit) 
voidBaseRowProcessor.preBatchMutate(HRegion region, +MultiRowMutationProcessor.preBatchMutate(HRegion region, WALEdit walEdit) 
voidBaseRowProcessor.preProcess(HRegion region, + WALEdit walEdit) 
void RowProcessor.preProcess(HRegion region, WALEdit walEdit)
The hook to be executed before process().
voidMultiRowMutationProcessor.preProcess(HRegion region, - WALEdit walEdit) 
voidBaseRowProcessor.preProcess(HRegion region, +MultiRowMutationProcessor.preProcess(HRegion region, WALEdit walEdit) 
longFSHLog.append(HRegionInfo hri, - WALKey key, - WALEdit edits, - boolean inMemstore) 
long AsyncFSWAL.append(HRegionInfo hri, WALKey key, WALEdit edits, boolean inMemstore) 
abstract long AbstractFSWAL.append(HRegionInfo info, WALKey key, @@ -760,6 +753,13 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods. transaction by calling 'begin' wherein which we assign this update a sequenceid.
longFSHLog.append(HRegionInfo hri, + WALKey key, + WALEdit edits, + boolean inMemstore) 
static WALKey WALUtil.doFullAppendTransaction(WAL wal, @@ -774,6 +774,13 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods.
voidMetricsWAL.postAppend(long size, + long time, + WALKey logkey, + WALEdit logEdit) 
void WALActionsListener.postAppend(long entryLen, long elapsedTimeMillis, WALKey logKey, @@ -781,20 +788,13 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods.
For notification post append to the writer.
void WALActionsListener.Base.postAppend(long entryLen, long elapsedTimeMillis, WALKey logKey, WALEdit logEdit) 
voidMetricsWAL.postAppend(long size, - long time, - WALKey logkey, - WALEdit logEdit) 
void WALCoprocessorHost.postWALWrite(HRegionInfo info, http://git-wip-us.apache.org/repos/asf/hbase-site/blob/5c0cc30a/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 1a415e6..62faeee 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 @@ -119,14 +119,14 @@
voidBaseReplicationEndpoint.init(ReplicationEndpoint.Context context) 
void ReplicationEndpoint.init(ReplicationEndpoint.Context context)
Initialize the replication endpoint with the given context.
voidBaseReplicationEndpoint.init(ReplicationEndpoint.Context context) 
@@ -143,11 +143,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/5c0cc30a/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 9c6c6e2..a2a1025 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 @@ -147,14 +147,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/5c0cc30a/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 9860ac6..8222110 100644 --- a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationException.html +++ b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationException.html @@ -379,14 +379,14 @@ void -ReplicationPeers.init() -
Initialize the ReplicationPeers interface.
+ReplicationQueuesClient.init() +
Initialize the replication queue client interface.
void -ReplicationQueuesClient.init() -
Initialize the replication queue client interface.
+ReplicationPeers.init() +
Initialize the ReplicationPeers interface.
@@ -477,23 +477,23 @@ void -ReplicationSource.addHFileRefs(TableName tableName, +ReplicationSourceManager.addHFileRefs(TableName tableName, byte[] family, List<String> files)  void -ReplicationSourceInterface.addHFileRefs(TableName tableName, +ReplicationSource.addHFileRefs(TableName tableName, byte[] family, - List<String> files) -
Add hfile names to the queue to be replicated.
- + List<String> files)
  void -ReplicationSourceManager.addHFileRefs(TableName tableName, +ReplicationSourceInterface.addHFileRefs(TableName tableName, byte[] family, - List<String> files)  + List<String> files) +
Add hfile names to the queue to be replicated.
+ protected ReplicationSourceInterface http://git-wip-us.apache.org/repos/asf/hbase-site/blob/5c0cc30a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeers.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeers.html b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeers.html index 2ebb71f..69f487b 100644 --- a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeers.html +++ b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationPeers.html @@ -215,7 +215,7 @@ private ReplicationPeers -ReplicationSource.replicationPeers  +Replication.replicationPeers  private ReplicationPeers @@ -223,7 +223,7 @@ private ReplicationPeers -Replication.replicationPeers  +ReplicationSource.replicationPeers  private ReplicationPeers http://git-wip-us.apache.org/repos/asf/hbase-site/blob/5c0cc30a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationQueues.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationQueues.html b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationQueues.html index c6d16fc..a60d278 100644 --- a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationQueues.html +++ b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationQueues.html @@ -137,7 +137,7 @@ private ReplicationQueues -ReplicationSource.replicationQueues  +Replication.replicationQueues  private ReplicationQueues @@ -145,7 +145,7 @@ private ReplicationQueues -Replication.replicationQueues  +ReplicationSource.replicationQueues  private ReplicationQueues http://git-wip-us.apache.org/repos/asf/hbase-site/blob/5c0cc30a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationTracker.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationTracker.html b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationTracker.html index 32db09b..0c68cd1 100644 --- a/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationTracker.html +++ b/devapidocs/org/apache/hadoop/hbase/replication/class-use/ReplicationTracker.html @@ -139,11 +139,11 @@ private ReplicationTracker -ReplicationSourceManager.replicationTracker  +Replication.replicationTracker  private ReplicationTracker -Replication.replicationTracker  +ReplicationSourceManager.replicationTracker  http://git-wip-us.apache.org/repos/asf/hbase-site/blob/5c0cc30a/devapidocs/org/apache/hadoop/hbase/replication/class-use/WALEntryFilter.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/replication/class-use/WALEntryFilter.html b/devapidocs/org/apache/hadoop/hbase/replication/class-use/WALEntryFilter.html index a450ea2..78d54c1 100644 --- a/devapidocs/org/apache/hadoop/hbase/replication/class-use/WALEntryFilter.html +++ b/devapidocs/org/apache/hadoop/hbase/replication/class-use/WALEntryFilter.html @@ -169,14 +169,14 @@ WALEntryFilter -BaseReplicationEndpoint.getWALEntryfilter() -
Returns a default set of filters
+ReplicationEndpoint.getWALEntryfilter() +
Returns a WALEntryFilter to use for filtering out WALEntries from the log.
WALEntryFilter -ReplicationEndpoint.getWALEntryfilter() -
Returns a WALEntryFilter to use for filtering out WALEntries from the log.
+BaseReplicationEndpoint.getWALEntryfilter() +
Returns a default set of filters