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 25A4C1880B for ; Tue, 9 Feb 2016 17:28:06 +0000 (UTC) Received: (qmail 9258 invoked by uid 500); 9 Feb 2016 17:27:49 -0000 Delivered-To: apmail-hbase-commits-archive@hbase.apache.org Received: (qmail 9133 invoked by uid 500); 9 Feb 2016 17:27: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 7700 invoked by uid 99); 9 Feb 2016 17:27:48 -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, 09 Feb 2016 17:27:48 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 7646DE0577; Tue, 9 Feb 2016 17:27:48 +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, 09 Feb 2016 17:28:28 -0000 Message-Id: <83e8e0ab6344406bb563c333fe65d6f5@git.apache.org> In-Reply-To: <93201ed227144eab9c2a5ace07d2cd4b@git.apache.org> References: <93201ed227144eab9c2a5ace07d2cd4b@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [42/51] [partial] hbase-site git commit: Published site at 7bb68b9031591cf378954a0eb8f71a8b9be01f9c. http://git-wip-us.apache.org/repos/asf/hbase-site/blob/358717f6/devapidocs/org/apache/hadoop/hbase/class-use/Cell.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/class-use/Cell.html b/devapidocs/org/apache/hadoop/hbase/class-use/Cell.html index 698a6a4..1c4a695 100644 --- a/devapidocs/org/apache/hadoop/hbase/class-use/Cell.html +++ b/devapidocs/org/apache/hadoop/hbase/class-use/Cell.html @@ -4281,6 +4281,24 @@ service. +private Cell +HRegion.reckonAppend(Cell delta, + Cell currentValue, + long now, + Append mutation)  + + +private Cell +HRegion.reckonIncrement(Cell delta, + long deltaAmount, + Cell currentValue, + byte[] columnFamily, + long now, + Mutation mutation) +
Calculate new Increment Cell.
+ + + Cell HMobStore.resolve(Cell reference, boolean cacheBlocks) @@ -4318,26 +4336,27 @@ service. CellSkipListSet.descendingSet()  -private List<Cell> -HRegion.doGet(Store store, - byte[] row, - Map.Entry<byte[],List<Cell>> family, - TimeRange tr) -
Run a Get against passed in store on passed row, etc.
- - - List<Cell> HRegion.get(Get get, boolean withCoprocessor)  - + List<Cell> Region.get(Get get, boolean withCoprocessor)
Do a get based on the get parameter.
+ +private List<Cell> +HRegion.get(Mutation mutation, + Store store, + List<Cell> coordinates, + IsolationLevel isolation, + TimeRange tr) +
Do a specific Get on passed columnFamily and column qualifiers.
+ + SortedSet<Cell> CellSkipListSet.headSet(Cell toElement)  @@ -4352,6 +4371,24 @@ service. CellSkipListSet.iterator()  +private List<Cell> +HRegion.reckonDeltasByStore(Store store, + Region.Operation op, + Mutation mutation, + Durability effectiveDurability, + long now, + List<Cell> deltas, + List<Cell> results) +
Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed + column family/Store.
+ + + +private static List<Cell> +HRegion.sort(List<Cell> cells, + Comparator<Cell> comparator)  + + NavigableSet<Cell> CellSkipListSet.subSet(Cell fromElement, boolean fromInclusive, @@ -4446,16 +4483,22 @@ service. StoreFile.Writer.appendGeneralBloomfilter(Cell cell)  +private long +HRegion.applyToMemstore(Store store, + Cell cell, + long sequenceId)  + + boolean ReversedKeyValueHeap.backwardSeek(Cell seekKey)  - + boolean DefaultMemStore.MemStoreScanner.backwardSeek(Cell key)
Seek scanner to the given key first.
- + boolean KeyValueScanner.backwardSeek(Cell key)
Seek the scanner at or before the row of specified Cell, it firstly @@ -4465,23 +4508,18 @@ service.
previous row of specified KeyValue - + boolean StoreFileScanner.backwardSeek(Cell key)  - + boolean NonReversedNonLazyKeyValueScanner.backwardSeek(Cell key)  - + boolean ReversedStoreScanner.backwardSeek(Cell key)  - -private static List<Tag> -HRegion.carryForwardTags(Cell cell, - List<Tag> tags)  - Cell CellSkipListSet.ceiling(Cell e)  @@ -4647,67 +4685,71 @@ service. ScanQueryMatcher.getKeyForNextRow(Cell c)  +private static long +HRegion.getLongValue(Cell cell)  + + private Cell DefaultMemStore.getLowest(Cell a, Cell b)  - + private Cell DefaultMemStore.MemStoreScanner.getLowest(Cell first, Cell second)  - + Cell ScanQueryMatcher.getNextKeyHint(Cell kv)  - + (package private) Cell DefaultMemStore.getNextRow(Cell cell)  - + private Cell DefaultMemStore.getNextRow(Cell key, NavigableSet<Cell> set)  - + ScanQueryMatcher.MatchCode ScanWildcardColumnTracker.getNextRowOrNextColumn(Cell cell)  - + ScanQueryMatcher.MatchCode ExplicitColumnTracker.getNextRowOrNextColumn(Cell cell)  - + ScanQueryMatcher.MatchCode ColumnTracker.getNextRowOrNextColumn(Cell cell)
Retrieve the MatchCode for the next row or column
- + private Store HRegion.getStore(Cell cell)
Return HStore instance.
- + SortedSet<Cell> CellSkipListSet.headSet(Cell toElement)  - + NavigableSet<Cell> CellSkipListSet.headSet(Cell toElement, boolean inclusive)  - + (package private) static long DefaultMemStore.heapSizeChange(Cell cell, boolean notpresent)  - + Cell CellSkipListSet.higher(Cell e)  - + void TimeRangeTracker.includeTimestamp(Cell cell)
Update the current TimestampRange to include the timestamp from Cell @@ -4715,58 +4757,58 @@ service.
entire time range from 0 to timestamp of the key. - + private long DefaultMemStore.internalAdd(Cell toAdd)
Internal version of add() that doesn't clone Cells with the allocator, and doesn't take the lock.
- + private boolean StripeMultiFileWriter.BoundaryMultiWriter.isCellAfterCurrentWriter(Cell cell)  - + (package private) static boolean HStore.isCellTTLExpired(Cell cell, long oldestTimestamp, long now)  - + DeleteTracker.DeleteResult DeleteTracker.isDeleted(Cell cell)
Check if the specified cell buffer has been deleted by a previously seen delete.
- + DeleteTracker.DeleteResult ScanDeleteTracker.isDeleted(Cell cell)
Check if the specified KeyValue buffer has been deleted by a previously seen delete.
- + private static boolean StripeStoreFileManager.isOpen(Cell key)  - + protected boolean HRegion.RegionScannerImpl.isStopRow(Cell currentRowCell)  - + protected boolean ReversedRegionScannerImpl.isStopRow(Cell currentRowCell)  - + private boolean HRegion.RegionScannerImpl.joinedHeapMayHaveData(Cell currentRowCell)  - + Cell CellSkipListSet.lower(Cell e)  - + ScanQueryMatcher.MatchCode ScanQueryMatcher.match(Cell cell)
Determines if the caller should do one of several things: @@ -4777,11 +4819,11 @@ service.
- got to the next row (MatchCode.DONE) - + private Cell DefaultMemStore.maybeCloneWithAllocator(Cell cell)  - + private boolean HRegion.RegionScannerImpl.moreCellsInRow(Cell nextKv, Cell currentRowCell) @@ -4789,44 +4831,44 @@ service. cells to be read in the heap. - + boolean ScanQueryMatcher.moreRowsMayExistAfter(Cell kv)  - + protected boolean HRegion.RegionScannerImpl.nextRow(ScannerContext scannerContext, Cell curRowCell)  - + protected boolean ReversedRegionScannerImpl.nextRow(ScannerContext scannerContext, Cell curRowCell)  - + private int StripeStoreFileManager.nonOpenRowCompare(Cell k1, byte[] k2)  - + private ScanQueryMatcher.MatchCode StoreScanner.optimize(ScanQueryMatcher.MatchCode qcode, Cell cell)  - + private void StoreScanner.parallelSeek(List<? extends KeyValueScanner> scanners, Cell kv)
Seek storefiles in parallel to optimize IO latency as much as possible
- + boolean StoreFile.Reader.passesGeneralRowColBloomFilter(Cell cell)
A method for checking Bloom filters.
- + private boolean HRegion.RegionScannerImpl.populateResult(List<Cell> results, KeyValueHeap heap, @@ -4836,14 +4878,14 @@ service. reached, or remainingResultSize (if not -1) is reaced - + Cell RegionCoprocessorHost.postMutationBeforeWAL(RegionObserver.MutationType opType, Mutation mutation, Cell oldCell, Cell newCell)  - + boolean RegionCoprocessorHost.postScannerFilterRow(InternalScanner s, Cell curRowCell) @@ -4851,18 +4893,18 @@ service. filter. - + private void StripeMultiFileWriter.BoundaryMultiWriter.prepareWriterFor(Cell cell)  - + boolean RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(Mutation mutation, Cell kv, byte[] byteNow, Get get)  - + private Cell HMobStore.readCell(List<org.apache.hadoop.fs.Path> locations, String fileName, @@ -4873,23 +4915,41 @@ service.
Reads the cell from a mob file.
+ +private Cell +HRegion.reckonAppend(Cell delta, + Cell currentValue, + long now, + Append mutation)  + +private Cell +HRegion.reckonIncrement(Cell delta, + long deltaAmount, + Cell currentValue, + byte[] columnFamily, + long now, + Mutation mutation) +
Calculate new Increment Cell.
+ + + private boolean DefaultMemStore.removeFromCellSet(Cell e)  - + boolean ReversedKeyValueHeap.requestSeek(Cell key, boolean forward, boolean useBloom)  - + boolean NonLazyKeyValueScanner.requestSeek(Cell kv, boolean forward, boolean useBloom)  - + boolean KeyValueScanner.requestSeek(Cell kv, boolean forward, @@ -4899,7 +4959,7 @@ service. row/column combination specified by the kv parameter. - + boolean StoreFileScanner.requestSeek(Cell kv, boolean forward, @@ -4907,7 +4967,7 @@ service.
Pretend we have done a seek but don't do it yet, if possible.
- + boolean KeyValueHeap.requestSeek(Cell key, boolean forward, @@ -4917,62 +4977,62 @@ service. row/column combination specified by the kv parameter. - + boolean ReversedKeyValueHeap.reseek(Cell seekKey)  - + boolean DefaultMemStore.MemStoreScanner.reseek(Cell key)
Move forward on the sub-lists set previously by seek.
- + boolean KeyValueScanner.reseek(Cell key)
Reseek the scanner at or after the specified KeyValue.
- + boolean StoreFileScanner.reseek(Cell key)  - + boolean KeyValueHeap.reseek(Cell seekKey)
This function is identical to the KeyValueHeap.seek(Cell) function except that scanner.seek(seekKey) is changed to scanner.reseek(seekKey).
- + boolean ReversedStoreScanner.reseek(Cell kv)  - + boolean StoreScanner.reseek(Cell kv)  - + (package private) static boolean StoreFileScanner.reseekAtOrAfter(HFileScanner s, Cell k)  - + private void ScanWildcardColumnTracker.resetCell(Cell columnCell)  - + protected void StoreScanner.resetScannerStack(Cell lastTopKey)  - + Cell HMobStore.resolve(Cell reference, boolean cacheBlocks)
Reads the cell from the mob file, and the read point does not count.
- + Cell HMobStore.resolve(Cell reference, boolean cacheBlocks, @@ -4981,114 +5041,114 @@ service.
Reads the cell from the mob file.
- + protected boolean HRegion.restoreEdit(Store s, Cell cell)
Used by tests
- + void DefaultMemStore.rollback(Cell cell)
Remove n key from the memstore.
- + void MemStore.rollback(Cell cell)
Remove n key from the memstore.
- + void HStore.rollback(Cell cell)  - + void Store.rollback(Cell cell)
Removes a Cell from the memstore.
- + protected void StripeMultiFileWriter.sanityCheckLeft(byte[] left, Cell cell)
Subclasses can call this method to make sure the first KV is within multi-writer range.
- + protected void StripeMultiFileWriter.sanityCheckRight(byte[] right, Cell cell)
Subclasses can call this method to make sure the last KV is within multi-writer range.
- + boolean ReversedKeyValueHeap.seek(Cell seekKey)  - + boolean DefaultMemStore.MemStoreScanner.seek(Cell key)
Set the scanner at the seek key.
- + boolean KeyValueScanner.seek(Cell key)
Seek the scanner at or after the specified KeyValue.
- + boolean StoreFileScanner.seek(Cell key)  - + boolean KeyValueHeap.seek(Cell seekKey)
Seeks all scanners at or below the specified seek key.
- + boolean ReversedStoreScanner.seek(Cell key)  - + boolean StoreScanner.seek(Cell key)  - + protected boolean ReversedStoreScanner.seekAsDirection(Cell kv)
Do a backwardSeek in a reversed StoreScanner(scan backward)
- + protected boolean StoreScanner.seekAsDirection(Cell kv)
Do a reseek in a normal StoreScanner(scan forward)
- + static boolean StoreFileScanner.seekAtOrAfter(HFileScanner s, Cell k)  - + private boolean DefaultMemStore.MemStoreScanner.seekInSubLists(Cell key)
(Re)initialize the iterators after a seek or a reseek.
- + protected void ReversedStoreScanner.seekScanners(List<? extends KeyValueScanner> scanners, Cell seekKey, boolean isLazy, boolean isParallelSeek)  - + protected void StoreScanner.seekScanners(List<? extends KeyValueScanner> scanners, Cell seekKey, @@ -5097,19 +5157,19 @@ service.
Seek the specified scanners with the given key
- + protected boolean ReversedStoreScanner.seekToNextRow(Cell kv)  - + protected boolean StoreScanner.seekToNextRow(Cell c)  - + boolean ReversedKeyValueHeap.seekToPreviousRow(Cell seekKey)  - + boolean DefaultMemStore.MemStoreScanner.seekToPreviousRow(Cell originalKey)
Separately get the KeyValue before the specified key from kvset and @@ -5117,63 +5177,63 @@ service.
specified key, then seek to the first KeyValue of previous row - + boolean KeyValueScanner.seekToPreviousRow(Cell key)
Seek the scanner at the first Cell of the row which is the previous row of specified key
- + boolean StoreFileScanner.seekToPreviousRow(Cell originalKey)  - + boolean NonReversedNonLazyKeyValueScanner.seekToPreviousRow(Cell key)  - + boolean ReversedStoreScanner.seekToPreviousRow(Cell key)  - + protected void StoreFileScanner.setCurrentCell(Cell newVal)  - + void ScanQueryMatcher.setToNewRow(Cell curCell)
Set the row when there is change in row
- + NavigableSet<Cell> CellSkipListSet.subSet(Cell fromElement, boolean fromInclusive, Cell toElement, boolean toInclusive)  - + SortedSet<Cell> CellSkipListSet.subSet(Cell fromElement, Cell toElement)  - + SortedSet<Cell> CellSkipListSet.tailSet(Cell fromElement)  - + NavigableSet<Cell> CellSkipListSet.tailSet(Cell fromElement, boolean inclusive)  - + void StoreFile.Writer.trackTimestamps(Cell cell)
Record the earlest Put timestamp.
- + Iterator<StoreFile> StripeStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles, KeyValue targetKey, @@ -5183,13 +5243,13 @@ service. for details on this methods. - + Iterator<StoreFile> DefaultStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles, KeyValue targetKey, Cell candidate)  - + Iterator<StoreFile> StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles, KeyValue targetKey, @@ -5197,14 +5257,14 @@ service.
Updates the candidate list for finding row key before.
- + (package private) void HRegion.updateDeleteLatestVersionTimeStamp(Cell cell, Get get, int count, byte[] byteNow)  - + private long DefaultMemStore.upsert(Cell cell, long readpoint) @@ -5234,146 +5294,155 @@ service. private long -HRegion.applyFamilyMapToMemstore(Map<byte[],List<Cell>> familyMap, - long mvccNum, - boolean isInReplay) +HRegion.applyFamilyMapToMemstore(