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 089E719726 for ; Thu, 14 Apr 2016 18:47:50 +0000 (UTC) Received: (qmail 20464 invoked by uid 500); 14 Apr 2016 18:47:49 -0000 Delivered-To: apmail-hbase-commits-archive@hbase.apache.org Received: (qmail 20336 invoked by uid 500); 14 Apr 2016 18:47:49 -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 19926 invoked by uid 99); 14 Apr 2016 18:47:49 -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; Thu, 14 Apr 2016 18:47:49 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 53E6CE050B; Thu, 14 Apr 2016 18:47:49 +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: Thu, 14 Apr 2016 18:47:52 -0000 Message-Id: In-Reply-To: References: X-Mailer: ASF-Git Admin Mailer Subject: [04/51] [partial] hbase-site git commit: Published site at 7efb9edecbdf8b35046230575d504e4caeb80f34. http://git-wip-us.apache.org/repos/asf/hbase-site/blob/3c6f3528/devapidocs/org/apache/hadoop/hbase/io/hfile/CompoundBloomFilterWriter.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/hfile/CompoundBloomFilterWriter.html b/devapidocs/org/apache/hadoop/hbase/io/hfile/CompoundBloomFilterWriter.html index b742702..1eb6cab 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/hfile/CompoundBloomFilterWriter.html +++ b/devapidocs/org/apache/hadoop/hbase/io/hfile/CompoundBloomFilterWriter.html @@ -105,7 +105,7 @@

@InterfaceAudience.Private
-public class CompoundBloomFilterWriter
+public class CompoundBloomFilterWriter
 extends CompoundBloomFilterBase
 implements BloomFilterWriter, InlineBlockWriter
Adds methods required for writing a compound Bloom filter to the data @@ -351,7 +351,7 @@ implements
  • LOG

    -
    private static final org.apache.commons.logging.Log LOG
    +
    private static final org.apache.commons.logging.Log LOG
  • @@ -360,7 +360,7 @@ implements
  • chunk

    -
    private BloomFilterChunk chunk
    +
    private BloomFilterChunk chunk
    The current chunk being written to
  • @@ -370,7 +370,7 @@ implements
  • prevChunk

    -
    private BloomFilterChunk prevChunk
    +
    private BloomFilterChunk prevChunk
    Previous chunk, so that we can create another similar chunk
  • @@ -380,7 +380,7 @@ implements
  • maxFold

    -
    private int maxFold
    +
    private int maxFold
    Maximum fold factor
  • @@ -390,7 +390,7 @@ implements
  • chunkByteSize

    -
    private int chunkByteSize
    +
    private int chunkByteSize
    The size of individual Bloom filter chunks to create
  • @@ -400,7 +400,7 @@ implements
  • readyChunks

    -
    private Queue<CompoundBloomFilterWriter.ReadyChunk> readyChunks
    +
    private Queue<CompoundBloomFilterWriter.ReadyChunk> readyChunks
  • @@ -409,7 +409,7 @@ implements
  • firstKeyInChunk

    -
    private byte[] firstKeyInChunk
    +
    private byte[] firstKeyInChunk
    The first key in the current Bloom filter chunk.
  • @@ -419,7 +419,7 @@ implements
  • bloomBlockIndexWriter

    -
    private HFileBlockIndex.BlockIndexWriter bloomBlockIndexWriter
    +
    private HFileBlockIndex.BlockIndexWriter bloomBlockIndexWriter
  • @@ -428,7 +428,7 @@ implements
  • cacheOnWrite

    -
    private boolean cacheOnWrite
    +
    private boolean cacheOnWrite
    Whether to cache-on-write compound Bloom filter chunks
  • @@ -446,7 +446,7 @@ implements
  • CompoundBloomFilterWriter

    -
    public CompoundBloomFilterWriter(int chunkByteSizeHint,
    +
    public CompoundBloomFilterWriter(int chunkByteSizeHint,
                              float errorRate,
                              int hashType,
                              int maxFold,
    @@ -470,7 +470,7 @@ implements 
     
  • shouldWriteBlock

    -
    public boolean shouldWriteBlock(boolean closing)
    +
    public boolean shouldWriteBlock(boolean closing)
    Description copied from interface: InlineBlockWriter
    Determines whether there is a new block to be written out.
    @@ -486,7 +486,7 @@ implements
  • enqueueReadyChunk

    -
    private void enqueueReadyChunk(boolean closing)
    +
    private void enqueueReadyChunk(boolean closing)
    Enqueue the current chunk if it is ready to be written out.
    Parameters:
    closing - true if we are closing the file, so we do not expect new keys to show up
    @@ -498,13 +498,13 @@ implements
  • add

    -
    public void add(byte[] bloomKey,
    +
    public void add(byte[] bloomKey,
            int keyOffset,
            int keyLength)
    Adds a Bloom filter key. This key must be greater than the previous key, as defined by the comparator this compound Bloom filter is configured with. For efficiency, key monotonicity is not checked here. See - StoreFile.Writer.append( + StoreFileWriter.append( org.apache.hadoop.hbase.Cell) for the details of deduplication.
    Specified by:
    @@ -518,7 +518,7 @@ implements
  • writeInlineBlock

    -
    public void writeInlineBlock(DataOutput out)
    +
    public void writeInlineBlock(DataOutput out)
                           throws IOException
    Description copied from interface: InlineBlockWriter
    Writes the block to the provided stream. Must not write any magic records. @@ -537,7 +537,7 @@ implements
  • blockWritten

    -
    public void blockWritten(long offset,
    +
    public void blockWritten(long offset,
                     int onDiskSize,
                     int uncompressedSize)
    Description copied from interface: InlineBlockWriter
    @@ -557,7 +557,7 @@ implements
  • getInlineBlockType

    -
    public BlockType getInlineBlockType()
    +
    public BlockType getInlineBlockType()
    Description copied from interface: InlineBlockWriter
    The type of blocks this block writer produces.
    @@ -572,7 +572,7 @@ implements
  • compactBloom

    -
    public void compactBloom()
    +
    public void compactBloom()
    Description copied from interface: BloomFilterWriter
    Compact the Bloom filter before writing metadata & data to disk.
    @@ -587,7 +587,7 @@ implements
  • getMetaWriter

    -
    public org.apache.hadoop.io.Writable getMetaWriter()
    +
    public org.apache.hadoop.io.Writable getMetaWriter()
    Description copied from interface: BloomFilterWriter
    Get a writable interface into bloom filter meta data.
    @@ -602,7 +602,7 @@ implements
  • getDataWriter

    -
    public org.apache.hadoop.io.Writable getDataWriter()
    +
    public org.apache.hadoop.io.Writable getDataWriter()
    Description copied from interface: BloomFilterWriter
    Get a writable interface into bloom filter data (the actual Bloom bits). Not used for compound Bloom filters.
    @@ -618,7 +618,7 @@ implements
  • getCacheOnWrite

    -
    public boolean getCacheOnWrite()
    +
    public boolean getCacheOnWrite()
    Specified by:
    getCacheOnWrite in interface InlineBlockWriter
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/3c6f3528/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockCache.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockCache.html b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockCache.html index e3a17a7..54091a4 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockCache.html +++ b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockCache.html @@ -219,11 +219,11 @@ BlockCache[] -CombinedBlockCache.getBlockCaches()  +BlockCache.getBlockCaches()  BlockCache[] -BlockCache.getBlockCaches()  +CombinedBlockCache.getBlockCaches()  BlockCache[] http://git-wip-us.apache.org/repos/asf/hbase-site/blob/3c6f3528/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockCacheKey.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockCacheKey.html b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockCacheKey.html index 090b827..c7550c3 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockCacheKey.html +++ b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockCacheKey.html @@ -160,16 +160,16 @@ void -CombinedBlockCache.cacheBlock(BlockCacheKey cacheKey, - Cacheable buf)  - - -void BlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf)
    Add block to cache (defaults to not in-memory).
    + +void +CombinedBlockCache.cacheBlock(BlockCacheKey cacheKey, + Cacheable buf)  + void LruBlockCache.cacheBlock(BlockCacheKey cacheKey, @@ -184,19 +184,19 @@ void -CombinedBlockCache.cacheBlock(BlockCacheKey cacheKey, +BlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf, boolean inMemory, - boolean cacheDataInL1)  + boolean cacheDataInL1) +
    Add block to cache.
    + void -BlockCache.cacheBlock(BlockCacheKey cacheKey, +CombinedBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf, boolean inMemory, - boolean cacheDataInL1) -
    Add block to cache.
    - + boolean cacheDataInL1)
      void @@ -229,14 +229,14 @@ boolean -CombinedBlockCache.evictBlock(BlockCacheKey cacheKey)  - - -boolean BlockCache.evictBlock(BlockCacheKey cacheKey)
    Evict block from cache.
    + +boolean +CombinedBlockCache.evictBlock(BlockCacheKey cacheKey)  + boolean LruBlockCache.evictBlock(BlockCacheKey cacheKey)  @@ -247,19 +247,19 @@ Cacheable -CombinedBlockCache.getBlock(BlockCacheKey cacheKey, +BlockCache.getBlock(BlockCacheKey cacheKey, boolean caching, boolean repeat, - boolean updateCacheMetrics)  + boolean updateCacheMetrics) +
    Fetch block from cache.
    + Cacheable -BlockCache.getBlock(BlockCacheKey cacheKey, +CombinedBlockCache.getBlock(BlockCacheKey cacheKey, boolean caching, boolean repeat, - boolean updateCacheMetrics) -
    Fetch block from cache.
    - + boolean updateCacheMetrics)
      Cacheable @@ -302,17 +302,17 @@ void -CombinedBlockCache.returnBlock(BlockCacheKey cacheKey, - Cacheable block)  - - -void BlockCache.returnBlock(BlockCacheKey cacheKey, Cacheable block)
    Called when the scanner using the block decides to return the block once its usage is over.
    + +void +CombinedBlockCache.returnBlock(BlockCacheKey cacheKey, + Cacheable block)  + void LruBlockCache.returnBlock(BlockCacheKey cacheKey, http://git-wip-us.apache.org/repos/asf/hbase-site/blob/3c6f3528/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockType.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockType.html b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockType.html index a83a9f9..100213f 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockType.html +++ b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/BlockType.html @@ -161,20 +161,20 @@ private BlockType -BlockCacheKey.blockType  - - -private BlockType HFileBlock.blockType
    Type of block.
    - + private BlockType HFileBlock.Writer.blockType
    Current block type.
    + +private BlockType +BlockCacheKey.blockType  + @@ -186,11 +186,13 @@ - + - + @@ -198,27 +200,25 @@ - + - + - + - + - + @@ -276,19 +276,19 @@ the order they are declared. - + BlockType blockType)  - + BlockType blockType) +
    Ends encoding for a block of KeyValues.
    + @@ -347,27 +347,27 @@ the order they are declared. - + DataBlockEncoding expectedDataBlockEncoding) +
    Read in a file block.
    + - + DataBlockEncoding expectedDataBlockEncoding)  @@ -444,12 +444,12 @@ the order they are declared. - - + + - +
    BlockTypeBlockCacheKey.getBlockType() HFileBlock.getBlockType() 
    BlockTypeCacheable.getBlockType() HFileBlock.BlockWritable.getBlockType() +
    The type of block this data should use.
    +
    BlockType
    BlockTypeHFileBlock.getBlockType() BlockCacheKey.getBlockType() 
    BlockTypeHFileBlock.BlockWritable.getBlockType() -
    The type of block this data should use.
    -
    Cacheable.getBlockType() 
    BlockTypeCompoundBloomFilterWriter.getInlineBlockType() HFileBlockIndex.BlockIndexWriter.getInlineBlockType() 
    BlockTypeInlineBlockWriter.getInlineBlockType() -
    The type of blocks this block writer produces.
    -
    CompoundBloomFilterWriter.getInlineBlockType() 
    BlockTypeHFileBlockIndex.BlockIndexWriter.getInlineBlockType() InlineBlockWriter.getInlineBlockType() +
    The type of blocks this block writer produces.
    +
    static BlockType
    voidHFileDataBlockEncoder.endBlockEncoding(HFileBlockEncodingContext encodingCtx, +NoOpDataBlockEncoder.endBlockEncoding(HFileBlockEncodingContext encodingCtx, DataOutputStream out, byte[] uncompressedBytesWithHeader, - BlockType blockType) -
    Ends encoding for a block of KeyValues.
    -
    voidNoOpDataBlockEncoder.endBlockEncoding(HFileBlockEncodingContext encodingCtx, +HFileDataBlockEncoder.endBlockEncoding(HFileBlockEncodingContext encodingCtx, DataOutputStream out, byte[] uncompressedBytesWithHeader, - BlockType blockType) 
    void
    HFileBlockHFileReaderImpl.readBlock(long dataBlockOffset, +HFile.CachingBlockReader.readBlock(long offset, long onDiskBlockSize, boolean cacheBlock, boolean pread, boolean isCompaction, boolean updateCacheMetrics, BlockType expectedBlockType, - DataBlockEncoding expectedDataBlockEncoding) 
    HFileBlockHFile.CachingBlockReader.readBlock(long offset, +HFileReaderImpl.readBlock(long dataBlockOffset, long onDiskBlockSize, boolean cacheBlock, boolean pread, boolean isCompaction, boolean updateCacheMetrics, BlockType expectedBlockType, - DataBlockEncoding expectedDataBlockEncoding) -
    Read in a file block.
    -
    private void
    private voidStoreFile.Reader.loadBloomfilter(BlockType blockType) voidStoreFileReader.loadBloomfilter(BlockType blockType) 
    private voidStoreFile.Reader.setBloomFilterFaulty(BlockType blockType) StoreFileReader.setBloomFilterFaulty(BlockType blockType)