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 9C0A2200C75 for ; Fri, 7 Apr 2017 02:31:11 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id 9AEB2160BA9; Fri, 7 Apr 2017 00:31:11 +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 998E7160BAE for ; Fri, 7 Apr 2017 02:31:09 +0200 (CEST) Received: (qmail 81232 invoked by uid 500); 7 Apr 2017 00:31:07 -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 80411 invoked by uid 99); 7 Apr 2017 00:31:07 -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; Fri, 07 Apr 2017 00:31:07 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 1B54DF21A2; Fri, 7 Apr 2017 00:31:07 +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: Fri, 07 Apr 2017 00:31:23 -0000 Message-Id: In-Reply-To: <6f4af2b6e24d4b5c9aeb36c7da19ab0c@git.apache.org> References: <6f4af2b6e24d4b5c9aeb36c7da19ab0c@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [18/19] hbase-site git commit: Published site at 48b2502a5fcd4d3cd954c3abf6703422da7cdc2f. archived-at: Fri, 07 Apr 2017 00:31:11 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/794df1af/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.html b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.html index 71778e4..0ca858e 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.html @@ -3173,7 +3173,7 @@ implements
  • FIXED_OVERHEAD

    -
    public static final long FIXED_OVERHEAD
    +
    public static final long FIXED_OVERHEAD
  • @@ -3182,7 +3182,7 @@ implements
  • DEEP_OVERHEAD

    -
    public static final long DEEP_OVERHEAD
    +
    public static final long DEEP_OVERHEAD
  • @@ -3191,7 +3191,7 @@ implements
  • MOCKED_LIST

    -
    private static final List<Cell> MOCKED_LIST
    +
    private static final List<Cell> MOCKED_LIST
    A mocked list implementation - discards all updates.
  • @@ -6895,7 +6895,7 @@ public static org.apache.hadoop.fs.Path 
  • getLoadStatistics

    -
    public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionLoadStats getLoadStatistics()
    +
    public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionLoadStats getLoadStatistics()
    Returns:
    statistics about the current load of the region
    @@ -6908,7 +6908,7 @@ public static org.apache.hadoop.fs.Path 
  • processRowsWithLocks

    -
    public void processRowsWithLocks(RowProcessor<?,?> processor)
    +
    public void processRowsWithLocks(RowProcessor<?,?> processor)
                               throws IOException
    Description copied from interface: Region
    Performs atomic multiple reads and writes on a given row.
    @@ -6928,7 +6928,7 @@ public static org.apache.hadoop.fs.Path 
  • processRowsWithLocks

    -
    public void processRowsWithLocks(RowProcessor<?,?> processor,
    +
    public void processRowsWithLocks(RowProcessor<?,?> processor,
                                      long nonceGroup,
                                      long nonce)
                               throws IOException
    @@ -6952,7 +6952,7 @@ public static org.apache.hadoop.fs.Path 
  • processRowsWithLocks

    -
    public void processRowsWithLocks(RowProcessor<?,?> processor,
    +
    public void processRowsWithLocks(RowProcessor<?,?> processor,
                                      long timeout,
                                      long nonceGroup,
                                      long nonce)
    @@ -6979,7 +6979,7 @@ public static org.apache.hadoop.fs.Path 
     
  • preProcess

    -
    private void preProcess(RowProcessor<?,?> processor,
    +
    private void preProcess(RowProcessor<?,?> processor,
                             WALEdit walEdit)
                      throws IOException
    @@ -6994,7 +6994,7 @@ public static org.apache.hadoop.fs.Path 
  • doProcessRowWithTimeout

    -
    private void doProcessRowWithTimeout(RowProcessor<?,?> processor,
    +
    private void doProcessRowWithTimeout(RowProcessor<?,?> processor,
                                          long now,
                                          HRegion region,
                                          List<Mutation> mutations,
    @@ -7013,7 +7013,7 @@ public static org.apache.hadoop.fs.Path 
     
  • append

    -
    public Result append(Append append)
    +
    public Result append(Append append)
                   throws IOException
    Throws:
    @@ -7027,7 +7027,7 @@ public static org.apache.hadoop.fs.Path 
  • append

    -
    public Result append(Append mutation,
    +
    public Result append(Append mutation,
                          long nonceGroup,
                          long nonce)
                   throws IOException
    @@ -7049,7 +7049,7 @@ public static org.apache.hadoop.fs.Path 
  • increment

    -
    public Result increment(Increment increment)
    +
    public Result increment(Increment increment)
                      throws IOException
    Throws:
    @@ -7063,7 +7063,7 @@ public static org.apache.hadoop.fs.Path 
  • increment

    -
    public Result increment(Increment mutation,
    +
    public Result increment(Increment mutation,
                             long nonceGroup,
                             long nonce)
                      throws IOException
    @@ -7085,7 +7085,7 @@ public static org.apache.hadoop.fs.Path 
  • doDelta

    -
    private Result doDelta(Region.Operation op,
    +
    private Result doDelta(Region.Operation op,
                            Mutation mutation,
                            long nonceGroup,
                            long nonce,
    @@ -7111,7 +7111,7 @@ public static org.apache.hadoop.fs.Path 
     
  • doWALAppend

    -
    private MultiVersionConcurrencyControl.WriteEntry doWALAppend(WALEdit walEdit,
    +
    private MultiVersionConcurrencyControl.WriteEntry doWALAppend(WALEdit walEdit,
                                                                   Durability durability,
                                                                   long nonceGroup,
                                                                   long nonce)
    @@ -7128,7 +7128,7 @@ public static org.apache.hadoop.fs.Path 
     
  • doWALAppend

    -
    private MultiVersionConcurrencyControl.WriteEntry doWALAppend(WALEdit walEdit,
    +
    private MultiVersionConcurrencyControl.WriteEntry doWALAppend(WALEdit walEdit,
                                                                   Durability durability,
                                                                   List<UUID> clusterIds,
                                                                   long now,
    @@ -7149,7 +7149,7 @@ public static org.apache.hadoop.fs.Path 
     
  • doCoprocessorPreCall

    -
    private Result doCoprocessorPreCall(Region.Operation op,
    +
    private Result doCoprocessorPreCall(Region.Operation op,
                                         Mutation mutation)
                                  throws IOException
    Do coprocessor pre-increment or pre-append call.
    @@ -7168,7 +7168,7 @@ public static org.apache.hadoop.fs.Path 
  • reckonDeltas

    -
    private WALEdit reckonDeltas(Region.Operation op,
    +
    private WALEdit reckonDeltas(Region.Operation op,
                                  Mutation mutation,
                                  Durability effectiveDurability,
                                  Map<Store,List<Cell>> forMemStore,
    @@ -7195,7 +7195,7 @@ public static org.apache.hadoop.fs.Path 
     
  • reckonDeltasByStore

    -
    private List<CellreckonDeltasByStore(Store store,
    +
    private List<CellreckonDeltasByStore(Store store,
                                            Region.Operation op,
                                            Mutation mutation,
                                            Durability effectiveDurability,
    @@ -7229,7 +7229,7 @@ public static org.apache.hadoop.fs.Path 
     
  • reckonIncrement

    -
    private Cell reckonIncrement(Cell delta,
    +
    private Cell reckonIncrement(Cell delta,
                                  long deltaAmount,
                                  Cell currentValue,
                                  byte[] columnFamily,
    @@ -7252,7 +7252,7 @@ public static org.apache.hadoop.fs.Path 
     
  • reckonAppend

    -
    private Cell reckonAppend(Cell delta,
    +
    private Cell reckonAppend(Cell delta,
                               Cell currentValue,
                               long now,
                               Append mutation)
    @@ -7269,7 +7269,7 @@ public static org.apache.hadoop.fs.Path 
     
  • getLongValue

    -
    private static long getLongValue(Cell cell)
    +
    private static long getLongValue(Cell cell)
                               throws DoNotRetryIOException
    Returns:
    @@ -7285,7 +7285,7 @@ public static org.apache.hadoop.fs.Path 
  • get

    -
    private List<Cellget(Mutation mutation,
    +
    private List<Cellget(Mutation mutation,
                            Store store,
                            List<Cell> coordinates,
                            IsolationLevel isolation,
    @@ -7310,7 +7310,7 @@ public static org.apache.hadoop.fs.Path 
     
  • sort

    -
    private static List<Cellsort(List<Cell> cells,
    +
    private static List<Cellsort(List<Cell> cells,
                                    Comparator<Cell> comparator)
    Returns:
    @@ -7324,7 +7324,7 @@ public static org.apache.hadoop.fs.Path 
  • checkFamily

    -
    void checkFamily(byte[] family)
    +
    void checkFamily(byte[] family)
               throws NoSuchColumnFamilyException
    Throws:
    @@ -7338,7 +7338,7 @@ public static org.apache.hadoop.fs.Path 
  • heapSize

    -
    public long heapSize()
    +
    public long heapSize()
    Specified by:
    heapSize in interface HeapSize
    @@ -7354,7 +7354,7 @@ public static org.apache.hadoop.fs.Path 
  • registerService

    -
    public boolean registerService(com.google.protobuf.Service instance)
    +
    public boolean registerService(com.google.protobuf.Service instance)
    Description copied from interface: Region
    Registers a new protocol buffer Service subclass as a coprocessor endpoint to be available for handling Region#execService(com.google.protobuf.RpcController, @@ -7383,7 +7383,7 @@ public static org.apache.hadoop.fs.Path 
  • execService

    -
    public com.google.protobuf.Message execService(com.google.protobuf.RpcController controller,
    +
    public com.google.protobuf.Message execService(com.google.protobuf.RpcController controller,
                                                    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceCall call)
                                             throws IOException
    Description copied from interface: Region
    @@ -7414,7 +7414,7 @@ public static org.apache.hadoop.fs.Path 
  • shouldForceSplit

    -
    boolean shouldForceSplit()
    +
    boolean shouldForceSplit()
  • @@ -7423,7 +7423,7 @@ public static org.apache.hadoop.fs.Path 
  • getExplicitSplitPoint

    -
    byte[] getExplicitSplitPoint()
    +
    byte[] getExplicitSplitPoint()
  • @@ -7432,7 +7432,7 @@ public static org.apache.hadoop.fs.Path 
  • forceSplit

    -
    void forceSplit(byte[] sp)
    +
    void forceSplit(byte[] sp)
  • @@ -7441,7 +7441,7 @@ public static org.apache.hadoop.fs.Path 
  • clearSplit

    -
    void clearSplit()
    +
    void clearSplit()
  • @@ -7450,7 +7450,7 @@ public static org.apache.hadoop.fs.Path 
  • prepareToSplit

    -
    protected void prepareToSplit()
    +
    protected void prepareToSplit()
    Give the region a chance to prepare before it is split.
  • @@ -7460,7 +7460,7 @@ public static org.apache.hadoop.fs.Path 
  • checkSplit

    -
    public byte[] checkSplit()
    +
    public byte[] checkSplit()
    Return the splitpoint. null indicates the region isn't splittable If the splitpoint isn't explicitly specified, it will go over the stores to find the best splitpoint. Currently the criteria of best splitpoint @@ -7473,7 +7473,7 @@ public static org.apache.hadoop.fs.Path 
  • getCompactPriority

    -
    public int getCompactPriority()
    +
    public int getCompactPriority()
    Returns:
    The priority that this region should have in the compaction queue
    @@ -7486,7 +7486,7 @@ public static org.apache.hadoop.fs.Path 
  • getCoprocessorHost

    -
    public RegionCoprocessorHost getCoprocessorHost()
    +
    public RegionCoprocessorHost getCoprocessorHost()
    Specified by:
    getCoprocessorHost in interface Region
    @@ -7501,7 +7501,7 @@ public static org.apache.hadoop.fs.Path 
  • setCoprocessorHost

    -
    public void setCoprocessorHost(RegionCoprocessorHost coprocessorHost)
    +
    public void setCoprocessorHost(RegionCoprocessorHost coprocessorHost)
    Parameters:
    coprocessorHost - the new coprocessor host
    @@ -7514,7 +7514,7 @@ public static org.apache.hadoop.fs.Path 
  • startRegionOperation

    -
    public void startRegionOperation()
    +
    public void startRegionOperation()
                               throws IOException
    Description copied from interface: Region
    This method needs to be called before any public call that reads or @@ -7536,7 +7536,7 @@ public static org.apache.hadoop.fs.Path 
  • startRegionOperation

    -
    public void startRegionOperation(Region.Operation op)
    +
    public void startRegionOperation(Region.Operation op)
                               throws IOException
    Description copied from interface: Region
    This method needs to be called before any public call that reads or @@ -7560,7 +7560,7 @@ public static org.apache.hadoop.fs.Path 
  • closeRegionOperation

    -
    public void closeRegionOperation()
    +
    public void closeRegionOperation()
                               throws IOException
    Description copied from interface: Region
    Closes the region operation lock.
    @@ -7578,7 +7578,7 @@ public static org.apache.hadoop.fs.Path 
  • closeRegionOperation

    -
    public void closeRegionOperation(Region.Operation operation)
    +
    public void closeRegionOperation(Region.Operation operation)
                               throws IOException
    Closes the lock. This needs to be called in the finally block corresponding to the try block of Region.startRegionOperation(Operation)
    @@ -7594,7 +7594,7 @@ public static org.apache.hadoop.fs.Path 
  • startBulkRegionOperation

    -
    private void startBulkRegionOperation(boolean writeLockNeeded)
    +
    private void startBulkRegionOperation(boolean writeLockNeeded)
                                    throws NotServingRegionException,
                                           RegionTooBusyException,
                                           InterruptedIOException
    @@ -7616,7 +7616,7 @@ public static org.apache.hadoop.fs.Path 
  • closeBulkRegionOperation

    -
    private void closeBulkRegionOperation()
    +
    private void closeBulkRegionOperation()
    Closes the lock. This needs to be called in the finally block corresponding to the try block of #startRegionOperation
  • @@ -7627,7 +7627,7 @@ public static org.apache.hadoop.fs.Path 
  • recordMutationWithoutWal

    -
    private void recordMutationWithoutWal(Map<byte[],List<Cell>> familyMap)
    +
    private void recordMutationWithoutWal(Map<byte[],List<Cell>> familyMap)
    Update LongAdders for number of puts without wal and the size of possible data loss. These information are exposed by the region server metrics.
  • @@ -7638,7 +7638,7 @@ public static org.apache.hadoop.fs.Path 
  • lock

    -
    private void lock(Lock lock)
    +
    private void lock(Lock lock)
                throws RegionTooBusyException,
                       InterruptedIOException
    @@ -7654,7 +7654,7 @@ public static org.apache.hadoop.fs.Path 
  • lock

    -
    private void lock(Lock lock,
    +
    private void lock(Lock lock,
                       int multiplier)
                throws RegionTooBusyException,
                       InterruptedIOException
    @@ -7674,7 +7674,7 @@ public static org.apache.hadoop.fs.Path 
  • sync

    -
    private void sync(long txid,
    +
    private void sync(long txid,
                       Durability durability)
                throws IOException
    Calls sync with the given transaction ID
    @@ -7692,7 +7692,7 @@ public static org.apache.hadoop.fs.Path 
  • shouldSyncWAL

    -
    private boolean shouldSyncWAL()
    +
    private boolean shouldSyncWAL()
    Check whether we should sync the wal from the table's durability settings
  • @@ -7702,7 +7702,7 @@ public static org.apache.hadoop.fs.Path 
  • getOpenSeqNum

    -
    public long getOpenSeqNum()
    +
    public long getOpenSeqNum()
    Specified by:
    getOpenSeqNum in interface Region
    @@ -7717,7 +7717,7 @@ public static org.apache.hadoop.fs.Path 
  • getMaxStoreSeqId

    -
    public Map<byte[],LonggetMaxStoreSeqId()
    +
    public Map<byte[],LonggetMaxStoreSeqId()
    Specified by:
    getMaxStoreSeqId in interface Region
    @@ -7733,7 +7733,7 @@ public static org.apache.hadoop.fs.Path 
  • getOldestSeqIdOfStore

    -
    public long getOldestSeqIdOfStore(byte[] familyName)
    +
    public long getOldestSeqIdOfStore(byte[] familyName)
    Specified by:
    getOldestSeqIdOfStore in interface Region
    @@ -7750,7 +7750,7 @@ public static org.apache.hadoop.fs.Path 
  • getCompactionState

    -
    public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState getCompactionState()
    +
    public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState getCompactionState()
    Specified by:
    getCompactionState in interface Region
    @@ -7765,7 +7765,7 @@ public static org.apache.hadoop.fs.Path 
  • reportCompactionRequestStart

    -
    public void reportCompactionRequestStart(boolean isMajor)
    +
    public void reportCompactionRequestStart(boolean isMajor)
  • @@ -7774,7 +7774,7 @@ public static org.apache.hadoop.fs.Path 
  • reportCompactionRequestEnd

    -
    public void reportCompactionRequestEnd(boolean isMajor,
    +
    public void reportCompactionRequestEnd(boolean isMajor,
                                            int numFiles,
                                            long filesSizeCompacted)
  • @@ -7785,7 +7785,7 @@ public static org.apache.hadoop.fs.Path 
  • reportCompactionRequestFailure

    -
    public void reportCompactionRequestFailure()
    +
    public void reportCompactionRequestFailure()
  • @@ -7794,7 +7794,7 @@ public static org.apache.hadoop.fs.Path 
  • getReadPoint

    -
    public long getReadPoint()
    +
    public long getReadPoint()
  • @@ -7803,7 +7803,7 @@ public static org.apache.hadoop.fs.Path 
  • onConfigurationChange

    -
    public void onConfigurationChange(org.apache.hadoop.conf.Configuration conf)
    +
    public void onConfigurationChange(org.apache.hadoop.conf.Configuration conf)
    This method would be called by the ConfigurationManager object when the Configuration object is reloaded from disk.
    @@ -7818,7 +7818,7 @@ public static org.apache.hadoop.fs.Path 
  • registerChildren

    -
    public void registerChildren(ConfigurationManager manager)
    +
    public void registerChildren(ConfigurationManager manager)
    Needs to be called to register the children to the manager.
    Specified by:
    @@ -7834,7 +7834,7 @@ public static org.apache.hadoop.fs.Path 
  • deregisterChildren

    -
    public void deregisterChildren(ConfigurationManager manager)
    +
    public void deregisterChildren(ConfigurationManager manager)
    Needs to be called to deregister the children from the manager.
    Specified by:
    @@ -7850,7 +7850,7 @@ public static org.apache.hadoop.fs.Path 
  • getCellComparator

    -
    public CellComparator getCellComparator()
    +
    public CellComparator getCellComparator()
    Description copied from interface: Region
    The comparator to be used with the region
    @@ -7865,7 +7865,7 @@ public static org.apache.hadoop.fs.Path 
  • getMemstoreFlushSize

    -
    public long getMemstoreFlushSize()
    +
    public long getMemstoreFlushSize()
  • @@ -7874,7 +7874,7 @@ public static org.apache.hadoop.fs.Path 
  • throwException

    -
    void throwException(String title,
    +
    void throwException(String title,
                         String regionName)