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 524F6200D50 for ; Sun, 29 Oct 2017 16:17:13 +0100 (CET) Received: by cust-asf.ponee.io (Postfix) id 50F7E160BFB; Sun, 29 Oct 2017 15:17:13 +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 1F4B1160BFC for ; Sun, 29 Oct 2017 16:17:10 +0100 (CET) Received: (qmail 87531 invoked by uid 500); 29 Oct 2017 15:17: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 87200 invoked by uid 99); 29 Oct 2017 15:17: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; Sun, 29 Oct 2017 15:17:07 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id ABD6EE3AA9; Sun, 29 Oct 2017 15:17:02 +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, 29 Oct 2017 15:17:29 -0000 Message-Id: In-Reply-To: <11cba8af2f38407187399e27777da895@git.apache.org> References: <11cba8af2f38407187399e27777da895@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [28/51] [partial] hbase-site git commit: Published site at . archived-at: Sun, 29 Oct 2017 15:17:13 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/1d9053bc/devapidocs/org/apache/hadoop/hbase/regionserver/HStore.StoreFlusherImpl.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/HStore.StoreFlusherImpl.html b/devapidocs/org/apache/hadoop/hbase/regionserver/HStore.StoreFlusherImpl.html index 1b08ffa..9472b3e 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/HStore.StoreFlusherImpl.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/HStore.StoreFlusherImpl.html @@ -117,7 +117,7 @@ var activeTableTab = "activeTableTab";

-
private final class HStore.StoreFlusherImpl
+
private final class HStore.StoreFlusherImpl
 extends Object
 implements StoreFlushContext
@@ -279,7 +279,7 @@ implements
  • tracker

    -
    private final FlushLifeCycleTracker tracker
    +
    private final FlushLifeCycleTracker tracker
  • @@ -288,7 +288,7 @@ implements
  • cacheFlushSeqNum

    -
    private final long cacheFlushSeqNum
    +
    private final long cacheFlushSeqNum
  • @@ -297,7 +297,7 @@ implements
  • snapshot

    -
    private MemStoreSnapshot snapshot
    +
    private MemStoreSnapshot snapshot
  • @@ -306,7 +306,7 @@ implements
  • tempFiles

    -
    private List<org.apache.hadoop.fs.Path> tempFiles
    +
    private List<org.apache.hadoop.fs.Path> tempFiles
  • @@ -315,7 +315,7 @@ implements
  • committedFiles

    -
    private List<org.apache.hadoop.fs.Path> committedFiles
    +
    private List<org.apache.hadoop.fs.Path> committedFiles
  • @@ -324,7 +324,7 @@ implements
  • cacheFlushCount

    -
    private long cacheFlushCount
    +
    private long cacheFlushCount
  • @@ -333,7 +333,7 @@ implements
  • cacheFlushSize

    -
    private long cacheFlushSize
    +
    private long cacheFlushSize
  • @@ -342,7 +342,7 @@ implements
  • outputFileSize

    -
    private long outputFileSize
    +
    private long outputFileSize
  • @@ -359,7 +359,7 @@ implements
  • StoreFlusherImpl

    -
    private StoreFlusherImpl(long cacheFlushSeqNum,
    +
    private StoreFlusherImpl(long cacheFlushSeqNum,
                              FlushLifeCycleTracker tracker)
  • @@ -377,7 +377,7 @@ implements
  • prepare

    -
    public void prepare()
    +
    public void prepare()
    This is not thread safe. The caller should have a lock on the region or the store. If necessary, the lock can be added with the patch provided in HBASE-10087
    @@ -392,7 +392,7 @@ implements
  • flushCache

    -
    public void flushCache(MonitoredTask status)
    +
    public void flushCache(MonitoredTask status)
                     throws IOException
    Description copied from interface: StoreFlushContext
    Flush the cache (create the new store file) @@ -413,7 +413,7 @@ implements
  • commit

    -
    public boolean commit(MonitoredTask status)
    +
    public boolean commit(MonitoredTask status)
                    throws IOException
    Description copied from interface: StoreFlushContext
    Commit the flush - add the store file to the store and clear the @@ -437,7 +437,7 @@ implements
  • getOutputFileSize

    -
    public long getOutputFileSize()
    +
    public long getOutputFileSize()
    Specified by:
    getOutputFileSize in interface StoreFlushContext
    @@ -452,7 +452,7 @@ implements
  • getCommittedFiles

    -
    public List<org.apache.hadoop.fs.Path> getCommittedFiles()
    +
    public List<org.apache.hadoop.fs.Path> getCommittedFiles()
    Description copied from interface: StoreFlushContext
    Returns the newly committed files from the flush. Called only if commit returns true
    @@ -469,7 +469,7 @@ implements
  • replayFlush

    -
    public void replayFlush(List<String> fileNames,
    +
    public void replayFlush(List<String> fileNames,
                             boolean dropMemstoreSnapshot)
                      throws IOException
    Similar to commit, but called in secondary region replicas for replaying the @@ -492,7 +492,7 @@ implements
  • abort

    -
    public void abort()
    +
    public void abort()
                throws IOException
    Abort the snapshot preparation. Drops the snapshot if any.
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/1d9053bc/devapidocs/org/apache/hadoop/hbase/regionserver/HStore.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/HStore.html b/devapidocs/org/apache/hadoop/hbase/regionserver/HStore.html index 8153066..c3357a2 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/HStore.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/HStore.html @@ -534,7 +534,8 @@ implements protected KeyValueScanner -createScanner(Scan scan, +createScanner(Scan scan, + ScanInfo scanInfo, NavigableSet<byte[]> targetCols, long readPt)  @@ -1680,7 +1681,7 @@ implements
  • FIXED_OVERHEAD

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

    -
    public static final long DEEP_OVERHEAD
    +
    public static final long DEEP_OVERHEAD
  • @@ -3119,7 +3120,7 @@ public static org.apache.hadoop.fs.Path 
  • getScanner

    -
    public KeyValueScanner getScanner(Scan scan,
    +
    public KeyValueScanner getScanner(Scan scan,
                                       NavigableSet<byte[]> targetCols,
                                       long readPt)
                                throws IOException
    @@ -3136,13 +3137,14 @@ public static org.apache.hadoop.fs.Path  + @@ -3249,7 +3251,7 @@ public static org.apache.hadoop.fs.Path 
  • getMaxStoreFileAge

    -
    public OptionalLong getMaxStoreFileAge()
    +
    public OptionalLong getMaxStoreFileAge()
    Specified by:
    getMaxStoreFileAge in interface Store
    @@ -3264,7 +3266,7 @@ public static org.apache.hadoop.fs.Path 
  • getMinStoreFileAge

    -
    public OptionalLong getMinStoreFileAge()
    +
    public OptionalLong getMinStoreFileAge()
    Specified by:
    getMinStoreFileAge in interface Store
    @@ -3279,7 +3281,7 @@ public static org.apache.hadoop.fs.Path 
  • getAvgStoreFileAge

    -
    public OptionalDouble getAvgStoreFileAge()
    +
    public OptionalDouble getAvgStoreFileAge()
    Specified by:
    getAvgStoreFileAge in interface Store
    @@ -3294,7 +3296,7 @@ public static org.apache.hadoop.fs.Path 
  • getNumReferenceFiles

    -
    public long getNumReferenceFiles()
    +
    public long getNumReferenceFiles()
    Specified by:
    getNumReferenceFiles in interface Store
    @@ -3309,7 +3311,7 @@ public static org.apache.hadoop.fs.Path 
  • getNumHFiles

    -
    public long getNumHFiles()
    +
    public long getNumHFiles()
    Specified by:
    getNumHFiles in interface Store
    @@ -3324,7 +3326,7 @@ public static org.apache.hadoop.fs.Path 
  • getStoreSizeUncompressed

    -
    public long getStoreSizeUncompressed()
    +
    public long getStoreSizeUncompressed()
    Specified by:
    getStoreSizeUncompressed in interface Store
    @@ -3339,7 +3341,7 @@ public static org.apache.hadoop.fs.Path 
  • getStorefilesSize

    -
    public long getStorefilesSize()
    +
    public long getStorefilesSize()
    Specified by:
    getStorefilesSize in interface Store
    @@ -3354,7 +3356,7 @@ public static org.apache.hadoop.fs.Path 
  • getHFilesSize

    -
    public long getHFilesSize()
    +
    public long getHFilesSize()
    Specified by:
    getHFilesSize in interface Store
    @@ -3369,7 +3371,7 @@ public static org.apache.hadoop.fs.Path 
  • getStorefilesSize

    -
    private long getStorefilesSize(Predicate<HStoreFile> predicate)
    +
    private long getStorefilesSize(Predicate<HStoreFile> predicate)
  • @@ -3378,7 +3380,7 @@ public static org.apache.hadoop.fs.Path 
  • getStoreFileFieldSize

    -
    private long getStoreFileFieldSize(ToLongFunction<StoreFileReader> f)
    +
    private long getStoreFileFieldSize(ToLongFunction<StoreFileReader> f)
  • @@ -3387,7 +3389,7 @@ public static org.apache.hadoop.fs.Path 
  • getStorefilesIndexSize

    -
    public long getStorefilesIndexSize()
    +
    public long getStorefilesIndexSize()
    Specified by:
    getStorefilesIndexSize in interface Store
    @@ -3402,7 +3404,7 @@ public static org.apache.hadoop.fs.Path 
  • getTotalStaticIndexSize

    -
    public long getTotalStaticIndexSize()
    +
    public long getTotalStaticIndexSize()
    Description copied from interface: Store
    Returns the total size of all index blocks in the data block indexes, including the root level, intermediate levels, and the leaf level for multi-level indexes, or just the root level for @@ -3421,7 +3423,7 @@ public static org.apache.hadoop.fs.Path 
  • getTotalStaticBloomSize

    -
    public long getTotalStaticBloomSize()
    +
    public long getTotalStaticBloomSize()
    Description copied from interface: Store
    Returns the total byte size of all Bloom filter bit arrays. For compound Bloom filters even the Bloom blocks currently not loaded into the block cache are counted.
    @@ -3439,7 +3441,7 @@ public static org.apache.hadoop.fs.Path 
  • getMemStoreSize

    -
    public MemStoreSize getMemStoreSize()
    +
    public MemStoreSize getMemStoreSize()
    Specified by:
    getMemStoreSize in interface Store
    @@ -3454,7 +3456,7 @@ public static org.apache.hadoop.fs.Path 
  • getCompactPriority

    -
    public int getCompactPriority()
    +
    public int getCompactPriority()
    Specified by:
    getCompactPriority in interface Store
    @@ -3467,7 +3469,7 @@ public static org.apache.hadoop.fs.Path 
  • throttleCompaction

    -
    public boolean throttleCompaction(long compactionSize)
    +
    public boolean throttleCompaction(long compactionSize)
  • @@ -3476,7 +3478,7 @@ public static org.apache.hadoop.fs.Path 
  • getHRegion

    -
    public HRegion getHRegion()
    +
    public HRegion getHRegion()
  • @@ -3485,7 +3487,7 @@ public static org.apache.hadoop.fs.Path 
  • getCoprocessorHost

    -
    public RegionCoprocessorHost getCoprocessorHost()
    +
    public RegionCoprocessorHost getCoprocessorHost()
  • @@ -3494,7 +3496,7 @@ public static org.apache.hadoop.fs.Path 
  • getRegionInfo

    -
    public RegionInfo getRegionInfo()
    +
    public RegionInfo getRegionInfo()
    Specified by:
    getRegionInfo in interface Store
    @@ -3509,7 +3511,7 @@ public static org.apache.hadoop.fs.Path 
  • areWritesEnabled

    -
    public boolean areWritesEnabled()
    +
    public boolean areWritesEnabled()
    Specified by:
    areWritesEnabled in interface Store
    @@ -3522,7 +3524,7 @@ public static org.apache.hadoop.fs.Path 
  • getSmallestReadPoint

    -
    public long getSmallestReadPoint()
    +
    public long getSmallestReadPoint()
    Specified by:
    getSmallestReadPoint in interface Store
    @@ -3539,7 +3541,7 @@ public static org.apache.hadoop.fs.Path 
  • upsert

    -
    public void upsert(Iterable<Cell> cells,
    +
    public void upsert(Iterable<Cell> cells,
                        long readpoint,
                        MemStoreSizing memstoreSizing)
                 throws IOException
    @@ -3564,7 +3566,7 @@ public static org.apache.hadoop.fs.Path 
  • createFlushContext

    -
    public StoreFlushContext createFlushContext(long cacheFlushId,
    +
    public StoreFlushContext createFlushContext(long cacheFlushId,
                                                 FlushLifeCycleTracker tracker)
  • @@ -3574,7 +3576,7 @@ public static org.apache.hadoop.fs.Path 
  • needsCompaction

    -
    public boolean needsCompaction()
    +
    public boolean needsCompaction()
    Description copied from interface: Store
    See if there's too much store files in this store
    @@ -3592,7 +3594,7 @@ public static org.apache.hadoop.fs.Path 
  • getCacheConfig

    -
    public CacheConfig getCacheConfig()
    +
    public CacheConfig getCacheConfig()
    Used for tests.
    Returns:
    @@ -3606,7 +3608,7 @@ public static org.apache.hadoop.fs.Path 
  • heapSize

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

    -
    public CellComparator getComparator()
    +
    public CellComparator getComparator()
    Specified by:
    getComparator in interface Store
    @@ -3635,7 +3637,7 @@ public static org.apache.hadoop.fs.Path 
  • getScanInfo

    -
    public ScanInfo getScanInfo()
    +
    public ScanInfo getScanInfo()
  • @@ -3644,7 +3646,7 @@ public static org.apache.hadoop.fs.Path 
  • setScanInfo

    -
    void setScanInfo(ScanInfo scanInfo)
    +
    void setScanInfo(ScanInfo scanInfo)
    Set scan info, used by test
    Parameters:
    @@ -3658,7 +3660,7 @@ public static org.apache.hadoop.fs.Path 
  • hasTooManyStoreFiles

    -
    public boolean hasTooManyStoreFiles()
    +
    public boolean hasTooManyStoreFiles()
    Specified by:
    hasTooManyStoreFiles in interface Store
    @@ -3673,7 +3675,7 @@ public static org.apache.hadoop.fs.Path 
  • getFlushedCellsCount

    -
    public long getFlushedCellsCount()
    +
    public long getFlushedCellsCount()
    Specified by:
    getFlushedCellsCount in interface Store
    @@ -3688,7 +3690,7 @@ public static org.apache.hadoop.fs.Path 
  • getFlushedCellsSize

    -
    public long getFlushedCellsSize()
    +
    public long getFlushedCellsSize()
    Specified by:
    getFlushedCellsSize in interface Store
    @@ -3703,7 +3705,7 @@ public static org.apache.hadoop.fs.Path 
  • getFlushedOutputFileSize

    -
    public long getFlushedOutputFileSize()
    +
    public long getFlushedOutputFileSize()
    Specified by:
    getFlushedOutputFileSize in interface Store
    @@ -3718,7 +3720,7 @@ public static org.apache.hadoop.fs.Path 
  • getCompactedCellsCount

    -
    public long getCompactedCellsCount()
    +
    public long getCompactedCellsCount()
    Specified by:
    getCompactedCellsCount in interface Store
    @@ -3733,7 +3735,7 @@ public static org.apache.hadoop.fs.Path 
  • getCompactedCellsSize

    -
    public long getCompactedCellsSize()
    +
    public long getCompactedCellsSize()
    Specified by:
    getCompactedCellsSize in interface Store
    @@ -3748,7 +3750,7 @@ public static org.apache.hadoop.fs.Path 
  • getMajorCompactedCellsCount

    -
    public long getMajorCompactedCellsCount()
    +
    public long getMajorCompactedCellsCount()
    Specified by:
    getMajorCompactedCellsCount in interface Store
    @@ -3763,7 +3765,7 @@ public static org.apache.hadoop.fs.Path 
  • getMajorCompactedCellsSize

    -
    public long getMajorCompactedCellsSize()
    +
    public long getMajorCompactedCellsSize()
    Specified by:
    getMajorCompactedCellsSize in interface Store
    @@ -3778,7 +3780,7 @@ public static org.apache.hadoop.fs.Path 
  • getStoreEngine

    -
    public StoreEngine<?,?,?,?> getStoreEngine()
    +
    public StoreEngine<?,?,?,?> getStoreEngine()
    Returns the StoreEngine that is backing this concrete implementation of Store.
    Returns:
    @@ -3792,7 +3794,7 @@ public static org.apache.hadoop.fs.Path 
  • getOffPeakHours

    -
    protected OffPeakHours getOffPeakHours()
    +
    protected OffPeakHours getOffPeakHours()
  • @@ -3801,7 +3803,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.
    @@ -3816,7 +3818,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:
    @@ -3832,7 +3834,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:
    @@ -3848,7 +3850,7 @@ public static org.apache.hadoop.fs.Path 
  • getCompactionPressure

    -
    public double getCompactionPressure()
    +
    public double getCompactionPressure()
    Description copied from interface: Store
    This value can represent the degree of emergency of compaction for this store. It should be greater than or equal to 0.0, any value greater than 1.0 means we have too many store files. @@ -3875,7 +3877,7 @@ public static org.apache.hadoop.fs.Path 
  • isPrimaryReplicaStore

    -
    public boolean isPrimaryReplicaStore()
    +
    public boolean isPrimaryReplicaStore()
    Specified by:
    isPrimaryReplicaStore in interface Store
    @@ -3888,7 +3890,7 @@ public static org.apache.hadoop.fs.Path 
  • preSnapshotOperation

    -
    public void preSnapshotOperation()
    +
    public void preSnapshotOperation()
    Sets the store up for a region level snapshot operation.
    See Also:
    @@ -3902,7 +3904,7 @@ public static org.apache.hadoop.fs.Path 
  • postSnapshotOperation

    -
    public void postSnapshotOperation()
    +
    public void postSnapshotOperation()
    Perform tasks needed after the completion of snapshot operation.
    See Also:
    @@ -3916,7 +3918,7 @@ public static org.apache.hadoop.fs.Path 
  • closeAndArchiveCompactedFiles

    -
    public void closeAndArchiveCompactedFiles()
    +
    public void closeAndArchiveCompactedFiles()
                                        throws IOException
    Closes and archives the compacted files under this store
    @@ -3931,7 +3933,7 @@ public static org.apache.hadoop.fs.Path 
  • removeCompactedfiles

    -
    private void removeCompactedfiles(Collection<HStoreFile> compactedfiles)
    +
    private void removeCompactedfiles(Collection<HStoreFile> compactedfiles)
                                throws IOException
    Archives and removes the compacted files
    @@ -3948,7 +3950,7 @@ public static org.apache.hadoop.fs.Path 
  • preFlushSeqIDEstimation

    -
    public Long preFlushSeqIDEstimation()
    +
    public Long preFlushSeqIDEstimation()
  • @@ -3957,7 +3959,7 @@ public static org.apache.hadoop.fs.Path 
  • isSloppyMemStore

    -
    public boolean isSloppyMemStore()
    +
    public boolean isSloppyMemStore()
    Specified by:
    isSloppyMemStore in interface Store
    @@ -3972,7 +3974,7 @@ public static org.apache.hadoop.fs.Path 
  • clearCompactedfiles

    -
    private void clearCompactedfiles(List<HStoreFile> filesToRemove)
    +
    private void clearCompactedfiles(List<HStoreFile> filesToRemove)
                               throws IOException
    Throws:
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/1d9053bc/devapidocs/org/apache/hadoop/hbase/regionserver/MemStoreCompactorSegmentsIterator.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/MemStoreCompactorSegmentsIterator.html b/devapidocs/org/apache/hadoop/hbase/regionserver/MemStoreCompactorSegmentsIterator.html index abce8fc..059c5f6 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/MemStoreCompactorSegmentsIterator.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/MemStoreCompactorSegmentsIterator.html @@ -119,7 +119,7 @@ var activeTableTab = "activeTableTab";

    @InterfaceAudience.Private
    -public class MemStoreCompactorSegmentsIterator
    +public class MemStoreCompactorSegmentsIterator
     extends MemStoreSegmentsIterator
    The MemStoreCompactorSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for compaction operation meaning it is based on SQM
    @@ -261,7 +261,7 @@ extends
  • kvs

    -
    private List<Cell> kvs
    +
    private List<Cell> kvs
  • @@ -270,7 +270,7 @@ extends
  • hasMore

    -
    private boolean hasMore
    +
    private boolean hasMore
  • @@ -279,7 +279,7 @@ extends
  • kvsIterator

    -
    private Iterator<Cell> kvsIterator
    +
    private Iterator<Cell> kvsIterator
  • @@ -288,7 +288,7 @@ extends
  • compactingScanner

    -
    private StoreScanner compactingScanner
    +
    private StoreScanner compactingScanner
  • @@ -305,7 +305,7 @@ extends
  • MemStoreCompactorSegmentsIterator

    -
    public MemStoreCompactorSegmentsIterator(List<ImmutableSegment> segments,
    +
    public MemStoreCompactorSegmentsIterator(List<ImmutableSegment> segments,
                                              CellComparator comparator,
                                              int compactionKVMax,
                                              HStore store)
    @@ -330,7 +330,7 @@ extends 
     
  • hasNext

    -
    public boolean hasNext()
    +
    public boolean hasNext()
  • @@ -339,7 +339,7 @@ extends
  • next

    -
    public Cell next()
    +
    public Cell next()
  • @@ -348,7 +348,7 @@ extends
  • close

    -
    public void close()
    +
    public void close()
    Specified by:
    close in class MemStoreSegmentsIterator
    @@ -361,7 +361,7 @@ extends
  • remove

    -
    public void remove()
    +
    public void remove()
  • @@ -370,7 +370,7 @@ extends
  • createScanner

    -
    private StoreScanner createScanner(HStore store,
    +
    private StoreScanner createScanner(HStore store,
                                        List<KeyValueScanner> scanners)
                                 throws IOException
    Creates the scanner for compacting the pipeline.
    @@ -388,7 +388,7 @@ extends
  • refillKVS

    -
    private boolean refillKVS()
    +
    private boolean refillKVS()