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 C3A1E200D4B for ; Sun, 12 Nov 2017 16:17:04 +0100 (CET) Received: by cust-asf.ponee.io (Postfix) id C274A160C09; Sun, 12 Nov 2017 15:17:04 +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 51783160C0C for ; Sun, 12 Nov 2017 16:17:02 +0100 (CET) Received: (qmail 28586 invoked by uid 500); 12 Nov 2017 15:16:55 -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 27148 invoked by uid 99); 12 Nov 2017 15:16:55 -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; Sun, 12 Nov 2017 15:16:55 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 4ED55F5E28; Sun, 12 Nov 2017 15:16:53 +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: Sun, 12 Nov 2017 15:17:27 -0000 Message-Id: <32c325db244e413d81c88f4ffe74dff6@git.apache.org> In-Reply-To: <6b29f3aa91c045f78e858f6d91ba1f26@git.apache.org> References: <6b29f3aa91c045f78e858f6d91ba1f26@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [35/51] [partial] hbase-site git commit: Published site at . archived-at: Sun, 12 Nov 2017 15:17:04 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/abb69192/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RegionScannerImpl.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RegionScannerImpl.html b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RegionScannerImpl.html index e04d11d..0c95fe3 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RegionScannerImpl.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RegionScannerImpl.html @@ -121,7 +121,7 @@ var activeTableTab = "activeTableTab";

-
class HRegion.RegionScannerImpl
+
class HRegion.RegionScannerImpl
 extends Object
 implements RegionScanner, Shipper, RpcCallback
RegionScannerImpl is used to combine scanners from multiple Stores (aka column families).
@@ -425,7 +425,7 @@ implements
  • storeHeap

    -
    KeyValueHeap storeHeap
    +
    KeyValueHeap storeHeap
  • @@ -434,7 +434,7 @@ implements
  • joinedHeap

    -
    KeyValueHeap joinedHeap
    +
    KeyValueHeap joinedHeap
    Heap of key-values that are not essential for the provided filters and are thus read on demand, if on-demand column family loading is enabled.
  • @@ -445,7 +445,7 @@ implements
  • joinedContinuationRow

    -
    protected Cell joinedContinuationRow
    +
    protected Cell joinedContinuationRow
    If the joined heap data gathering is interrupted due to scan limits, this will contain the row for which we are populating the values.
  • @@ -456,7 +456,7 @@ implements
  • filterClosed

    -
    private boolean filterClosed
    +
    private boolean filterClosed
  • @@ -465,7 +465,7 @@ implements
  • stopRow

    -
    protected final byte[] stopRow
    +
    protected final byte[] stopRow
  • @@ -474,7 +474,7 @@ implements
  • includeStopRow

    -
    protected final boolean includeStopRow
    +
    protected final boolean includeStopRow
  • @@ -483,7 +483,7 @@ implements
  • region

    -
    protected final HRegion region
    +
    protected final HRegion region
  • @@ -492,7 +492,7 @@ implements
  • comparator

    -
    protected final CellComparator comparator
    +
    protected final CellComparator comparator
  • @@ -501,7 +501,7 @@ implements
  • readPt

    -
    private final long readPt
    +
    private final long readPt
  • @@ -510,7 +510,7 @@ implements
  • maxResultSize

    -
    private final long maxResultSize
    +
    private final long maxResultSize
  • @@ -519,7 +519,7 @@ implements
  • defaultScannerContext

    -
    private final ScannerContext defaultScannerContext
    +
    private final ScannerContext defaultScannerContext
  • @@ -528,7 +528,7 @@ implements
  • filter

    -
    private final FilterWrapper filter
    +
    private final FilterWrapper filter
  • @@ -545,7 +545,7 @@ implements
  • RegionScannerImpl

    -
    RegionScannerImpl(Scan scan,
    +
    RegionScannerImpl(Scan scan,
                       List<KeyValueScanner> additionalScanners,
                       HRegion region)
                throws IOException
    @@ -561,7 +561,7 @@ implements
  • RegionScannerImpl

    -
    RegionScannerImpl(Scan scan,
    +
    RegionScannerImpl(Scan scan,
                       List<KeyValueScanner> additionalScanners,
                       HRegion region,
                       long nonceGroup,
    @@ -587,7 +587,7 @@ implements 
     
  • getRegionInfo

    -
    public RegionInfo getRegionInfo()
    +
    public RegionInfo getRegionInfo()
    Specified by:
    getRegionInfo in interface RegionScanner
    @@ -602,7 +602,7 @@ implements
  • initializeScanners

    -
    protected void initializeScanners(Scan scan,
    +
    protected void initializeScanners(Scan scan,
                                       List<KeyValueScanner> additionalScanners)
                                throws IOException
    @@ -617,7 +617,7 @@ implements
  • initializeKVHeap

    -
    protected void initializeKVHeap(List<KeyValueScanner> scanners,
    +
    protected void initializeKVHeap(List<KeyValueScanner> scanners,
                                     List<KeyValueScanner> joinedScanners,
                                     HRegion region)
                              throws IOException
    @@ -633,7 +633,7 @@ implements
  • handleException

    -
    private IOException handleException(List<KeyValueScanner> instantiatedScanners,
    +
    private IOException handleException(List<KeyValueScanner> instantiatedScanners,
                                         Throwable t)
  • @@ -643,7 +643,7 @@ implements
  • getMaxResultSize

    -
    public long getMaxResultSize()
    +
    public long getMaxResultSize()
    Specified by:
    getMaxResultSize in interface RegionScanner
    @@ -659,7 +659,7 @@ implements
  • getMvccReadPoint

    -
    public long getMvccReadPoint()
    +
    public long getMvccReadPoint()
    Specified by:
    getMvccReadPoint in interface RegionScanner
    @@ -674,7 +674,7 @@ implements
  • getBatch

    -
    public int getBatch()
    +
    public int getBatch()
    Specified by:
    getBatch in interface RegionScanner
    @@ -690,7 +690,7 @@ implements
  • resetFilters

    -
    protected void resetFilters()
    +
    protected void resetFilters()
                          throws IOException
    Reset both the filter and the old filter.
    @@ -705,7 +705,7 @@ implements
  • next

    -
    public boolean next(List<Cell> outResults)
    +
    public boolean next(List<Cell> outResults)
                  throws IOException
    Description copied from interface: InternalScanner
    Grab the next row's worth of values.
    @@ -727,7 +727,7 @@ implements
  • next

    -
    public boolean next(List<Cell> outResults,
    +
    public boolean next(List<Cell> outResults,
                         ScannerContext scannerContext)
                  throws IOException
    Description copied from interface: InternalScanner
    @@ -750,7 +750,7 @@ implements
  • nextRaw

    -
    public boolean nextRaw(List<Cell> outResults)
    +
    public boolean nextRaw(List<Cell> outResults)
                     throws IOException
    Description copied from interface: RegionScanner
    Grab the next row's worth of values. This is a special internal method to be called from @@ -775,7 +775,7 @@ implements
  • nextRaw

    -
    public boolean nextRaw(List<Cell> outResults,
    +
    public boolean nextRaw(List<Cell> outResults,
                            ScannerContext scannerContext)
                     throws IOException
    Description copied from interface: RegionScanner
    @@ -821,7 +821,7 @@ implements
  • populateFromJoinedHeap

    -
    private boolean populateFromJoinedHeap(List<Cell> results,
    +
    private boolean populateFromJoinedHeap(List<Cell> results,
                                            ScannerContext scannerContext)
                                     throws IOException
    @@ -838,7 +838,7 @@ implements
  • populateResult

    -
    private boolean populateResult(List<Cell> results,
    +
    private boolean populateResult(List<Cell> results,
                                    KeyValueHeap heap,
                                    ScannerContext scannerContext,
                                    Cell currentRowCell)
    @@ -863,7 +863,7 @@ implements 
     
  • moreCellsInRow

    -
    private boolean moreCellsInRow(Cell nextKv,
    +
    private boolean moreCellsInRow(Cell nextKv,
                                    Cell currentRowCell)
    Based on the nextKv in the heap, and the current row, decide whether or not there are more cells to be read in the heap. If the row of the nextKv in the heap matches the current row @@ -883,7 +883,7 @@ implements
  • isFilterDone

    -
    public boolean isFilterDone()
    +
    public boolean isFilterDone()
                          throws IOException
    Specified by:
    @@ -901,7 +901,7 @@ implements
  • isFilterDoneInternal

    -
    private boolean isFilterDoneInternal()
    +
    private boolean isFilterDoneInternal()
                                   throws IOException
    Throws:
    @@ -915,7 +915,7 @@ implements
  • nextInternal

    -
    private boolean nextInternal(List<Cell> results,
    +
    private boolean nextInternal(List<Cell> results,
                                  ScannerContext scannerContext)
                           throws IOException
    @@ -930,7 +930,7 @@ implements
  • incrementCountOfRowsFilteredMetric

    -
    protected void incrementCountOfRowsFilteredMetric(ScannerContext scannerContext)
    +
    protected void incrementCountOfRowsFilteredMetric(ScannerContext scannerContext)
  • @@ -939,7 +939,7 @@ implements
  • incrementCountOfRowsScannedMetric

    -
    protected void incrementCountOfRowsScannedMetric(ScannerContext scannerContext)
    +
    protected void incrementCountOfRowsScannedMetric(ScannerContext scannerContext)
  • @@ -948,7 +948,7 @@ implements
  • joinedHeapMayHaveData

    -
    private boolean joinedHeapMayHaveData(Cell currentRowCell)
    +
    private boolean joinedHeapMayHaveData(Cell currentRowCell)
                                    throws IOException
    Parameters:
    @@ -966,7 +966,7 @@ implements
  • filterRow

    -
    private boolean filterRow()
    +
    private boolean filterRow()
                        throws IOException
    This function is to maintain backward compatibility for 0.94 filters. HBASE-6429 combines both filterRow & filterRow(List<KeyValue> kvs) functions. While 0.94 code or older, @@ -985,7 +985,7 @@ implements
  • filterRowKey

    -
    private boolean filterRowKey(Cell current)
    +
    private boolean filterRowKey(Cell current)
                           throws IOException
    Throws:
    @@ -999,7 +999,7 @@ implements
  • nextRow

    -
    protected boolean nextRow(ScannerContext scannerContext,
    +
    protected boolean nextRow(ScannerContext scannerContext,
                               Cell curRowCell)
                        throws IOException
    @@ -1014,7 +1014,7 @@ implements
  • shouldStop

    -
    protected boolean shouldStop(Cell currentRowCell)
    +
    protected boolean shouldStop(Cell currentRowCell)
  • @@ -1023,7 +1023,7 @@ implements
  • close

    -
    public void close()
    +
    public void close()
    Description copied from interface: InternalScanner
    Closes the scanner and releases any resources it has allocated
    @@ -1042,7 +1042,7 @@ implements
  • getStoreHeapForTesting

    -
    KeyValueHeap getStoreHeapForTesting()
    +
    KeyValueHeap getStoreHeapForTesting()
  • @@ -1051,7 +1051,7 @@ implements
  • reseek

    -
    public boolean reseek(byte[] row)
    +
    public boolean reseek(byte[] row)
                    throws IOException
    Description copied from interface: RegionScanner
    Do a reseek to the required row. Should not be used to seek to a key which @@ -1071,7 +1071,7 @@ implements
  • shipped

    -
    public void shipped()
    +
    public void shipped()
                  throws IOException
    Description copied from interface: Shipper
    Called after a batch of rows scanned and set to be returned to client. Any in between cleanup @@ -1090,7 +1090,7 @@ implements
  • run

    -
    public void run()
    +
    public void run()
              throws IOException
    Description copied from interface: RpcCallback
    Called at the end of an Rpc Call RpcCallContext
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/abb69192/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.ReplayBatchOperation.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.ReplayBatchOperation.html b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.ReplayBatchOperation.html index e5dc1ac..626d9d8 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.ReplayBatchOperation.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.ReplayBatchOperation.html @@ -118,7 +118,7 @@ var activeTableTab = "activeTableTab";


  • -
    static class HRegion.ReplayBatchOperation
    +
    static class HRegion.ReplayBatchOperation
     extends HRegion.BatchOperation<WALSplitter.MutationReplay>
    Batch of mutations for replay. Base class is shared with HRegion.MutationBatchOperation as most of the logic is same.
    @@ -306,7 +306,7 @@ extends
  • origLogSeqNum

    -
    private long origLogSeqNum
    +
    private long origLogSeqNum
  • @@ -323,7 +323,7 @@ extends
  • ReplayBatchOperation

    -
    public ReplayBatchOperation(HRegion region,
    +
    public ReplayBatchOperation(HRegion region,
                                 WALSplitter.MutationReplay[] operations,
                                 long origLogSeqNum)
  • @@ -342,7 +342,7 @@ extends
  • getMutation

    -
    public Mutation getMutation(int index)
    +
    public Mutation getMutation(int index)
    Specified by:
    getMutation in class HRegion.BatchOperation<WALSplitter.MutationReplay>
    @@ -355,7 +355,7 @@ extends
  • getNonceGroup

    -
    public long getNonceGroup(int index)
    +
    public long getNonceGroup(int index)
    Specified by:
    getNonceGroup in class HRegion.BatchOperation<WALSplitter.MutationReplay>
    @@ -368,7 +368,7 @@ extends
  • getNonce

    -
    public long getNonce(int index)
    +
    public long getNonce(int index)
    Specified by:
    getNonce in class HRegion.BatchOperation<WALSplitter.MutationReplay>
    @@ -381,7 +381,7 @@ extends
  • getMutationsForCoprocs

    -
    public Mutation[] getMutationsForCoprocs()
    +
    public Mutation[] getMutationsForCoprocs()
    Description copied from class: HRegion.BatchOperation
    This method is potentially expensive and useful mostly for non-replay CP path.
    @@ -396,7 +396,7 @@ extends
  • isInReplay

    -
    public boolean isInReplay()
    +
    public boolean isInReplay()
    Specified by:
    isInReplay in class HRegion.BatchOperation<WALSplitter.MutationReplay>
    @@ -409,7 +409,7 @@ extends
  • getOrigLogSeqNum

    -
    public long getOrigLogSeqNum()
    +
    public long getOrigLogSeqNum()
    Specified by:
    getOrigLogSeqNum in class HRegion.BatchOperation<WALSplitter.MutationReplay>
    @@ -422,7 +422,7 @@ extends
  • startRegionOperation

    -
    public void startRegionOperation()
    +
    public void startRegionOperation()
                               throws IOException
    Specified by:
    @@ -438,7 +438,7 @@ extends
  • closeRegionOperation

    -
    public void closeRegionOperation()
    +
    public void closeRegionOperation()
                               throws IOException
    Specified by:
    @@ -454,7 +454,7 @@ extends
  • checkAndPreparePut

    -
    protected void checkAndPreparePut(Put p)
    +
    protected void checkAndPreparePut(Put p)
                                throws IOException
    During replay, there could exist column families which are removed between region server failure and replay
    @@ -472,7 +472,7 @@ extends
  • checkAndPrepare

    -
    public void checkAndPrepare()
    +
    public void checkAndPrepare()
                          throws IOException
    Description copied from class: HRegion.BatchOperation
    Validates each mutation and prepares a batch for write. If necessary (non-replay case), runs @@ -494,7 +494,7 @@ extends
  • prepareMiniBatchOperations

    -
    public void prepareMiniBatchOperations(MiniBatchOperationInProgress<Mutation> miniBatchOp,
    +
    public void prepareMiniBatchOperations(MiniBatchOperationInProgress<Mutation> miniBatchOp,
                                            long timestamp,
                                            List<Region.RowLock> acquiredRowLocks)
                                     throws IOException
    @@ -515,7 +515,7 @@ extends
  • writeMiniBatchOperationsToMemStore

    -
    public MultiVersionConcurrencyControl.WriteEntry writeMiniBatchOperationsToMemStore(MiniBatchOperationInProgress<Mutation> miniBatchOp,
    +
    public MultiVersionConcurrencyControl.WriteEntry writeMiniBatchOperationsToMemStore(MiniBatchOperationInProgress<Mutation> miniBatchOp,
                                                                                         MultiVersionConcurrencyControl.WriteEntry writeEntry)
                                                                                  throws IOException
    Description copied from class: HRegion.BatchOperation
    @@ -534,7 +534,7 @@ extends
  • completeMiniBatchOperations

    -
    public void completeMiniBatchOperations(MiniBatchOperationInProgress<Mutation> miniBatchOp,
    +
    public void completeMiniBatchOperations(MiniBatchOperationInProgress<Mutation> miniBatchOp,
                                             MultiVersionConcurrencyControl.WriteEntry writeEntry)
                                      throws IOException
    Description copied from class: HRegion.BatchOperation
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/abb69192/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RowLockContext.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RowLockContext.html b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RowLockContext.html index d557085..9c5bd19 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RowLockContext.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RowLockContext.html @@ -113,7 +113,7 @@ var activeTableTab = "activeTableTab";


  • -
    class HRegion.RowLockContext
    +
    class HRegion.RowLockContext
     extends Object
  • @@ -241,7 +241,7 @@ extends
  • row

    -
    private final HashedBytes row
    +
    private final HashedBytes row
  • @@ -250,7 +250,7 @@ extends
  • readWriteLock

    -
    final ReadWriteLock readWriteLock
    +
    final ReadWriteLock readWriteLock
  • @@ -259,7 +259,7 @@ extends
  • usable

    -
    final AtomicBoolean usable
    +
    final AtomicBoolean usable
  • @@ -268,7 +268,7 @@ extends
  • count

    -
    final AtomicInteger count
    +
    final AtomicInteger count
  • @@ -277,7 +277,7 @@ extends
  • lock

    -
    final Object lock
    +
    final Object lock
  • @@ -286,7 +286,7 @@ extends
  • threadName

    -
    private String threadName
    +
    private String threadName
  • @@ -303,7 +303,7 @@ extends
  • RowLockContext

    -
    RowLockContext(HashedBytes row)
    +
    RowLockContext(HashedBytes row)
  • @@ -320,7 +320,7 @@ extends
  • newWriteLock

    -
    HRegion.RowLockImpl newWriteLock()
    +
    HRegion.RowLockImpl newWriteLock()
  • @@ -329,7 +329,7 @@ extends
  • newReadLock

    -
    HRegion.RowLockImpl newReadLock()
    +
    HRegion.RowLockImpl newReadLock()
  • @@ -338,7 +338,7 @@ extends
  • getRowLock

    -
    private HRegion.RowLockImpl getRowLock(Lock l)
    +
    private HRegion.RowLockImpl getRowLock(Lock l)
  • @@ -347,7 +347,7 @@ extends
  • cleanUp

    -
    void cleanUp()
    +
    void cleanUp()
  • @@ -356,7 +356,7 @@ extends
  • setThreadName

    -
    public void setThreadName(String threadName)
    +
    public void setThreadName(String threadName)
  • @@ -365,7 +365,7 @@ extends
  • toString

    -
    public String toString()
    +
    public String toString()
    Overrides:
    toString in class Object
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/abb69192/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RowLockImpl.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RowLockImpl.html b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RowLockImpl.html index 5833858..dc3ce12 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RowLockImpl.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.RowLockImpl.html @@ -117,7 +117,7 @@ var activeTableTab = "activeTableTab";


    -
    public static class HRegion.RowLockImpl
    +
    public static class HRegion.RowLockImpl
     extends Object
     implements Region.RowLock
    Class used to represent a lock on a row.
    @@ -226,7 +226,7 @@ implements
  • context

    -
    private final HRegion.RowLockContext context
    +
    private final HRegion.RowLockContext context
  • @@ -235,7 +235,7 @@ implements
  • lock

    -
    private final Lock lock
    +
    private final Lock lock
  • @@ -252,7 +252,7 @@ implements
  • RowLockImpl

    -
    public RowLockImpl(HRegion.RowLockContext context,
    +
    public RowLockImpl(HRegion.RowLockContext context,
                        Lock lock)
  • @@ -270,7 +270,7 @@ implements
  • getLock

    -
    public Lock getLock()
    +
    public Lock getLock()
  • @@ -279,7 +279,7 @@ implements
  • getContext

    -
    public HRegion.RowLockContext getContext()
    +
    public HRegion.RowLockContext getContext()
  • @@ -288,7 +288,7 @@ implements
  • release

    -
    public void release()
    +
    public void release()
    Description copied from interface: Region.RowLock
    Release the given lock. If there are no remaining locks held by the current thread then unlock the row and allow other threads to acquire the lock.
    @@ -304,7 +304,7 @@ implements
  • toString

    -
    public String toString()
    +
    public String toString()
    Overrides:
    toString in class Object