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 E370E200D21 for ; Mon, 16 Oct 2017 17:16:31 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id E2199160BF0; Mon, 16 Oct 2017 15:16:31 +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 B2D0E160BE9 for ; Mon, 16 Oct 2017 17:16:29 +0200 (CEST) Received: (qmail 48025 invoked by uid 500); 16 Oct 2017 15:16:23 -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 47090 invoked by uid 99); 16 Oct 2017 15:16:22 -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; Mon, 16 Oct 2017 15:16:22 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 161D5DFE15; Mon, 16 Oct 2017 15:16:21 +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: Mon, 16 Oct 2017 15:16:51 -0000 Message-Id: In-Reply-To: <645193abe9df4d0a95d3df532bee202f@git.apache.org> References: <645193abe9df4d0a95d3df532bee202f@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [32/51] [partial] hbase-site git commit: Published site at . archived-at: Mon, 16 Oct 2017 15:16:32 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/47abd8e6/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 58bc57a..7bda4ab 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/HRegion.html @@ -3206,7 +3206,7 @@ implements
  • FIXED_OVERHEAD

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

    -
    public static final long DEEP_OVERHEAD
    +
    public static final long DEEP_OVERHEAD
  • @@ -3224,7 +3224,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.
  • @@ -4904,7 +4904,7 @@ public long 
  • updateDeleteLatestVersionTimeStamp

    -
    void updateDeleteLatestVersionTimeStamp(Cell cell,
    +
    void updateDeleteLatestVersionTimeStamp(Cell cell,
                                             Get get,
                                             int count,
                                             byte[] byteNow)
    @@ -4921,7 +4921,7 @@ public long 
     
  • put

    -
    public void put(Put put)
    +
    public void put(Put put)
              throws IOException
    Description copied from interface: Region
    Puts some data in the table.
    @@ -4939,7 +4939,7 @@ public long 
  • batchMutate

    -
    public OperationStatus[] batchMutate(Mutation[] mutations,
    +
    public OperationStatus[] batchMutate(Mutation[] mutations,
                                          long nonceGroup,
                                          long nonce)
                                   throws IOException
    @@ -4955,7 +4955,7 @@ public long 
  • batchMutate

    -
    public OperationStatus[] batchMutate(Mutation[] mutations)
    +
    public OperationStatus[] batchMutate(Mutation[] mutations)
                                   throws IOException
    Description copied from interface: Region
    Perform a batch of mutations. @@ -4980,7 +4980,7 @@ public long 
  • batchReplay

    -
    public OperationStatus[] batchReplay(WALSplitter.MutationReplay[] mutations,
    +
    public OperationStatus[] batchReplay(WALSplitter.MutationReplay[] mutations,
                                          long replaySeqId)
                                   throws IOException
    @@ -4995,7 +4995,7 @@ public long 
  • batchMutate

    -
    OperationStatus[] batchMutate(HRegion.BatchOperation<?> batchOp)
    +
    OperationStatus[] batchMutate(HRegion.BatchOperation<?> batchOp)
                            throws IOException
    Perform a batch of mutations. It supports only Put and Delete mutations and will ignore other types passed.
    @@ -5016,7 +5016,7 @@ public long 
  • doPreBatchMutateHook

    -
    private void doPreBatchMutateHook(HRegion.BatchOperation<?> batchOp)
    +
    private void doPreBatchMutateHook(HRegion.BatchOperation<?> batchOp)
                                throws IOException
    Throws:
    @@ -5030,7 +5030,7 @@ public long 
  • doMiniBatchMutate

    -
    private void doMiniBatchMutate(HRegion.BatchOperation<?> batchOp)
    +
    private void doMiniBatchMutate(HRegion.BatchOperation<?> batchOp)
                             throws IOException
    Called to do a piece of the batch that came in to batchMutate(Mutation[], long, long) In here we also handle replay of edits on region recover.
    @@ -5046,7 +5046,7 @@ public long 
  • mergeFamilyMaps

    -
    private void mergeFamilyMaps(Map<byte[],List<Cell>> familyMap,
    +
    private void mergeFamilyMaps(Map<byte[],List<Cell>> familyMap,
                                  Map<byte[],List<Cell>> toBeMerged)
  • @@ -5056,7 +5056,7 @@ public long 
  • appendCurrentNonces

    -
    private void appendCurrentNonces(Mutation mutation,
    +
    private void appendCurrentNonces(Mutation mutation,
                                      boolean replay,
                                      WALEdit walEdit,
                                      long now,
    @@ -5075,7 +5075,7 @@ public long 
     
  • checkBatchOp

    -
    private boolean checkBatchOp(HRegion.BatchOperation<?> batchOp,
    +
    private boolean checkBatchOp(HRegion.BatchOperation<?> batchOp,
                                  int lastIndexExclusive,
                                  Map<byte[],List<Cell>>[] familyMaps,
                                  long now,
    @@ -5093,7 +5093,7 @@ public long 
     
  • checkAndPrepareMutation

    -
    private void checkAndPrepareMutation(Mutation mutation,
    +
    private void checkAndPrepareMutation(Mutation mutation,
                                          boolean replay,
                                          Map<byte[],List<Cell>> familyMap,
                                          long now)
    @@ -5110,7 +5110,7 @@ public long 
     
  • removeNonExistentColumnFamilyForReplay

    -
    private void removeNonExistentColumnFamilyForReplay(Map<byte[],List<Cell>> familyMap)
    +
    private void removeNonExistentColumnFamilyForReplay(Map<byte[],List<Cell>> familyMap)
    During replay, there could exist column families which are removed between region server failure and replay
  • @@ -5121,7 +5121,7 @@ public long 
  • getEffectiveDurability

    -
    protected Durability getEffectiveDurability(Durability d)
    +
    protected Durability getEffectiveDurability(Durability d)
    Returns effective durability from the passed durability and the table descriptor.
  • @@ -5132,7 +5132,7 @@ public long 
  • checkAndMutate

    -
    public boolean checkAndMutate(byte[] row,
    +
    public boolean checkAndMutate(byte[] row,
                                   byte[] family,
                                   byte[] qualifier,
                                   CompareOperator op,
    @@ -5166,7 +5166,7 @@ public long 
     
  • checkAndRowMutate

    -
    public boolean checkAndRowMutate(byte[] row,
    +
    public boolean checkAndRowMutate(byte[] row,
                                      byte[] family,
                                      byte[] qualifier,
                                      CompareOperator op,
    @@ -5200,7 +5200,7 @@ public long 
     
  • doCheckAndRowMutate

    -
    private boolean doCheckAndRowMutate(byte[] row,
    +
    private boolean doCheckAndRowMutate(byte[] row,
                                         byte[] family,
                                         byte[] qualifier,
                                         CompareOperator op,
    @@ -5223,7 +5223,7 @@ public long 
     
  • checkMutationType

    -
    private void checkMutationType(Mutation mutation,
    +
    private void checkMutationType(Mutation mutation,
                                    byte[] row)
                             throws DoNotRetryIOException
    @@ -5238,7 +5238,7 @@ public long 
  • matches

    -
    private boolean matches(CompareOperator op,
    +
    private boolean matches(CompareOperator op,
                             int compareResult)
  • @@ -5248,7 +5248,7 @@ public long 
  • doBatchMutate

    -
    private void doBatchMutate(Mutation mutation)
    +
    private void doBatchMutate(Mutation mutation)
                         throws IOException
    Throws:
    @@ -5262,7 +5262,7 @@ public long 
  • addRegionToSnapshot

    -
    public void addRegionToSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription desc,
    +
    public void addRegionToSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription desc,
                                     ForeignExceptionSnare exnSnare)
                              throws IOException
    Complete taking the snapshot on the region. Writes the region info and adds references to the @@ -5287,7 +5287,7 @@ public long 
  • updateSequenceId

    -
    private void updateSequenceId(Iterable<List<Cell>> cellItr,
    +
    private void updateSequenceId(Iterable<List<Cell>> cellItr,
                                   long sequenceId)
                            throws IOException
    @@ -5302,7 +5302,7 @@ public long 
  • updateCellTimestamps

    -
    public void updateCellTimestamps(Iterable<List<Cell>> cellItr,
    +
    public void updateCellTimestamps(Iterable<List<Cell>> cellItr,
                                      byte[] now)
                               throws IOException
    Replace any cell timestamps set to HConstants.LATEST_TIMESTAMP @@ -5322,7 +5322,7 @@ public long 
  • rewriteCellTags

    -
    void rewriteCellTags(Map<byte[],List<Cell>> familyMap,
    +
    void rewriteCellTags(Map<byte[],List<Cell>> familyMap,
                          Mutation m)
    Possibly rewrite incoming cell tags.
  • @@ -5333,7 +5333,7 @@ public long 
  • checkResources

    -
    void checkResources()
    +
    void checkResources()
                  throws RegionTooBusyException
    Throws:
    @@ -5347,7 +5347,7 @@ public long 
  • checkReadOnly

    -
    protected void checkReadOnly()
    +
    protected void checkReadOnly()
                           throws IOException
    Throws:
    @@ -5361,7 +5361,7 @@ public long 
  • checkReadsEnabled

    -
    protected void checkReadsEnabled()
    +
    protected void checkReadsEnabled()
                               throws IOException
    Throws:
    @@ -5375,7 +5375,7 @@ public long 
  • setReadsEnabled

    -
    public void setReadsEnabled(boolean readsEnabled)
    +
    public void setReadsEnabled(boolean readsEnabled)
  • @@ -5384,7 +5384,7 @@ public long 
  • put

    -
    void put(byte[] row,
    +
    void put(byte[] row,
              byte[] family,
              List<Cell> edits)
       throws IOException
    @@ -5404,7 +5404,7 @@ public long 
  • applyFamilyMapToMemStore

    -
    private void applyFamilyMapToMemStore(Map<byte[],List<Cell>> familyMap,
    +
    private void applyFamilyMapToMemStore(Map<byte[],List<Cell>> familyMap,
                                           MemStoreSize memstoreSize)
                                    throws IOException
    @@ -5419,7 +5419,7 @@ public long 
  • applyToMemStore

    -
    private void applyToMemStore(HStore store,
    +
    private void applyToMemStore(HStore store,
                                  List<Cell> cells,
                                  boolean delta,
                                  MemStoreSize memstoreSize)
    @@ -5442,7 +5442,7 @@ public long 
     
  • applyToMemStore

    -
    private void applyToMemStore(HStore store,
    +
    private void applyToMemStore(HStore store,
                                  Cell cell,
                                  MemStoreSize memstoreSize)
                           throws IOException
    @@ -5460,7 +5460,7 @@ public long 
  • checkFamilies

    -
    public void checkFamilies(Collection<byte[]> families)
    +
    public void checkFamilies(Collection<byte[]> families)
                        throws NoSuchColumnFamilyException
    Check the collection of families for validity.
    @@ -5477,7 +5477,7 @@ public long 
  • checkTimestamps

    -
    public void checkTimestamps(Map<byte[],List<Cell>> familyMap,
    +
    public void checkTimestamps(Map<byte[],List<Cell>> familyMap,
                                 long now)
                          throws FailedSanityCheckException
    Check the collection of families for valid timestamps
    @@ -5496,7 +5496,7 @@ public long 
  • addFamilyMapToWALEdit

    -
    private void addFamilyMapToWALEdit(Map<byte[],List<Cell>> familyMap,
    +
    private void addFamilyMapToWALEdit(Map<byte[],List<Cell>> familyMap,
                                        WALEdit walEdit)
    Append the given map of family->edits to a WALEdit data structure. This does not write to the WAL itself.
    @@ -5513,7 +5513,7 @@ public long 
  • requestFlushIfNeeded

    -
    private void requestFlushIfNeeded(long memstoreTotalSize)
    +
    private void requestFlushIfNeeded(long memstoreTotalSize)
                                throws RegionTooBusyException
    Throws:
    @@ -5527,7 +5527,7 @@ public long 
  • requestFlush

    -
    private void requestFlush()
    +
    private void requestFlush()
  • @@ -5536,7 +5536,7 @@ public long 
  • isFlushSize

    -
    private boolean isFlushSize(long size)
    +
    private boolean isFlushSize(long size)
  • @@ -5545,7 +5545,7 @@ public long 
  • replayRecoveredEditsIfAny

    -
    protected long replayRecoveredEditsIfAny(org.apache.hadoop.fs.Path regiondir,
    +
    protected long replayRecoveredEditsIfAny(org.apache.hadoop.fs.Path regiondir,
                                              Map<byte[],Long> maxSeqIdInStores,
                                              CancelableProgressable reporter,
                                              MonitoredTask status)
    @@ -5593,7 +5593,7 @@ public long 
     
  • replayRecoveredEdits

    -
    private long replayRecoveredEdits(org.apache.hadoop.fs.Path edits,
    +
    private long replayRecoveredEdits(org.apache.hadoop.fs.Path edits,
                                       Map<byte[],Long> maxSeqIdInStores,
                                       CancelableProgressable reporter)
                                throws IOException
    @@ -5609,7 +5609,7 @@ public long 
  • replayWALCompactionMarker

    -
    void replayWALCompactionMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor compaction,
    +
    void replayWALCompactionMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor compaction,
                                    boolean pickCompactionFiles,
                                    boolean removeFiles,
                                    long replaySeqId)
    @@ -5629,7 +5629,7 @@ public long 
     
  • replayWALFlushMarker

    -
    void replayWALFlushMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flush,
    +
    void replayWALFlushMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flush,
                               long replaySeqId)
                        throws IOException
    @@ -5644,7 +5644,7 @@ public long 
  • replayWALFlushStartMarker

    -
    HRegion.PrepareFlushResult replayWALFlushStartMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flush)
    +
    HRegion.PrepareFlushResult replayWALFlushStartMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flush)
                                                   throws IOException
    Replay the flush marker from primary region by creating a corresponding snapshot of the store memstores, only if the memstores do not have a higher seqId from an earlier wal @@ -5661,7 +5661,7 @@ public long 
  • replayWALFlushCommitMarker

    -
    void replayWALFlushCommitMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flush)
    +
    void replayWALFlushCommitMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flush)
                              throws IOException
    Throws:
    @@ -5675,7 +5675,7 @@ public long 
  • replayFlushInStores

    -
    private void replayFlushInStores(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flush,
    +
    private void replayFlushInStores(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flush,
                                      HRegion.PrepareFlushResult prepareFlushResult,
                                      boolean dropMemstoreSnapshot)
                               throws IOException
    @@ -5697,7 +5697,7 @@ public long 
  • dropMemStoreContentsForSeqId

    -
    private MemStoreSize dropMemStoreContentsForSeqId(long seqId,
    +
    private MemStoreSize dropMemStoreContentsForSeqId(long seqId,
                                                       HStore store)
                                                throws IOException
    Drops the memstore contents after replaying a flush descriptor or region open event replay @@ -5714,7 +5714,7 @@ public long 
  • doDropStoreMemStoreContentsForSeqId

    -
    private MemStoreSize doDropStoreMemStoreContentsForSeqId(HStore s,
    +
    private MemStoreSize doDropStoreMemStoreContentsForSeqId(HStore s,
                                                              long currentSeqId)
                                                       throws IOException
    @@ -5729,7 +5729,7 @@ public long 
  • replayWALFlushAbortMarker

    -
    private void replayWALFlushAbortMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flush)
    +
    private void replayWALFlushAbortMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flush)
  • @@ -5738,7 +5738,7 @@ public long 
  • replayWALFlushCannotFlushMarker

    -
    private void replayWALFlushCannotFlushMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flush,
    +
    private void replayWALFlushCannotFlushMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flush,
                                                  long replaySeqId)
  • @@ -5748,7 +5748,7 @@ public long 
  • getPrepareFlushResult

    -
    HRegion.PrepareFlushResult getPrepareFlushResult()
    +
    HRegion.PrepareFlushResult getPrepareFlushResult()
  • @@ -5757,7 +5757,7 @@ public long 
  • replayWALRegionEventMarker

    -
    void replayWALRegionEventMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor regionEvent)
    +
    void replayWALRegionEventMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor regionEvent)
                              throws IOException
    Throws:
    @@ -5771,7 +5771,7 @@ public long 
  • replayWALBulkLoadEventMarker

    -
    void replayWALBulkLoadEventMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor bulkLoadEvent)
    +
    void replayWALBulkLoadEventMarker(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor bulkLoadEvent)
                                throws IOException
    Throws:
    @@ -5785,7 +5785,7 @@ public long 
  • dropPrepareFlushIfPossible

    -
    private void dropPrepareFlushIfPossible()
    +
    private void dropPrepareFlushIfPossible()
    If all stores ended up dropping their snapshots, we can safely drop the prepareFlushResult
  • @@ -5795,7 +5795,7 @@ public long 
  • refreshStoreFiles

    -
    public boolean refreshStoreFiles()
    +
    public boolean refreshStoreFiles()
                               throws IOException
    Description copied from interface: Region
    Check the region's underlying store files, open the files that have not @@ -5815,7 +5815,7 @@ public long 
  • refreshStoreFiles

    -
    protected boolean refreshStoreFiles(boolean force)
    +
    protected boolean refreshStoreFiles(boolean force)
                                  throws IOException
    Throws:
    @@ -5829,7 +5829,7 @@ public long 
  • logRegionFiles

    -
    private void logRegionFiles()
    +
    private void logRegionFiles()
  • @@ -5838,7 +5838,7 @@ public long 
  • checkTargetRegion

    -
    private void checkTargetRegion(byte[] encodedRegionName,
    +
    private void checkTargetRegion(byte[] encodedRegionName,
                                    String exceptionMsg,
                                    Object payload)
                             throws WrongRegionException
    @@ -5856,7 +5856,7 @@ public long 
  • restoreEdit

    -
    protected void restoreEdit(HStore s,
    +
    protected void restoreEdit(HStore s,
                                Cell cell,
                                MemStoreSize memstoreSize)
    Used by tests
    @@ -5874,7 +5874,7 @@ public long 
  • isZeroLengthThenDelete

    -
    private static boolean isZeroLengthThenDelete(org.apache.hadoop.fs.FileSystem fs,
    +
    private static boolean isZeroLengthThenDelete(org.apache.hadoop.fs.FileSystem fs,
                                                   org.apache.hadoop.fs.Path p)
                                            throws IOException
    @@ -5894,7 +5894,7 @@ public long 
  • instantiateHStore

    -
    protected HStore instantiateHStore(ColumnFamilyDescriptor family)
    +
    protected HStore instantiateHStore(ColumnFamilyDescriptor family)
                                 throws IOException
    Throws:
    @@ -5908,7 +5908,7 @@ public long 
  • getStore

    -
    public HStore getStore(byte[] column)
    +
    public HStore getStore(byte[] column)
    Description copied from interface: Region
    Return the Store for the given family

    Use with caution. Exposed for use of fixup utilities.

    @@ -5926,7 +5926,7 @@ public long 
  • getStore

    -
    private HStore getStore(Cell cell)
    +
    private HStore getStore(Cell cell)
    Return HStore instance. Does not do any copy: as the number of store is limited, we iterate on the list.
  • @@ -5937,7 +5937,7 @@ public long 
  • getStores

    -
    public List<HStoregetStores()
    +
    public List<HStoregetStores()
    Description copied from interface: Region
    Return the list of Stores managed by this region

    Use with caution. Exposed for use of fixup utilities.

    @@ -5955,7 +5955,7 @@ public long 
  • getStoreFileList

    -
    public List<StringgetStoreFileList(byte[][] columns)
    +
    public List<StringgetStoreFileList(byte[][] columns)
                                   throws IllegalArgumentException
    Specified by:
    @@ -5973,7 +5973,7 @@ public long 
  • checkRow

    -
    void checkRow(byte[] row,
    +
    void checkRow(byte[] row,
                   String op)
            throws IOException
    Make sure this is a valid row for the HRegion
    @@ -5989,7 +5989,7 @@ public long 
  • getRowLock

    -
    public Region.RowLock getRowLock(byte[] row)
    +
    public Region.RowLock getRowLock(byte[] row)
                               throws IOException
    Get an exclusive ( write lock ) lock on a given row.
    @@ -6008,7 +6008,7 @@ public long 
  • getRowLock

    -
    public Region.RowLock getRowLock(byte[] row,
    +
    public Region.RowLock getRowLock(byte[] row,
                                      boolean readLock)
                               throws IOException
    Description copied from interface: Region
    @@ -6043,7 +6043,7 @@ public long 
  • getRowLockInternal

    -
    protected Region.RowLock getRowLockInternal(byte[] row,
    +
    protected Region.RowLock getRowLockInternal(byte[] row,
                                                 boolean readLock)
                                          throws IOException
    @@ -6058,7 +6058,7 @@ public long 
  • releaseRowLocks

    -
    private void releaseRowLocks(List<Region.RowLock> rowLocks)
    +
    private void releaseRowLocks(List<Region.RowLock> rowLocks)
  • @@ -6067,7 +6067,7 @@ public long 
  • getReadLockCount

    -
    public int getReadLockCount()
    +
    public int getReadLockCount()
  • @@ -6076,7 +6076,7 @@ public long 
  • getLockedRows

    -
    public ConcurrentHashMap<HashedBytes,HRegion.RowLockContextgetLockedRows()
    +
    public ConcurrentHashMap<HashedBytes,HRegion.RowLockContextgetLockedRows()
  • @@ -6085,7 +6085,7 @@ public long 
  • hasMultipleColumnFamilies

    -
    private static boolean hasMultipleColumnFamilies(Collection<Pair<byte[],String>> familyPaths)
    +
    private static boolean hasMultipleColumnFamilies(Collection<Pair<byte[],String>> familyPaths)
    Determines whether multiple column families are present Precondition: familyPaths is not null
    @@ -6100,7 +6100,7 @@ public long 
  • bulkLoadHFiles

    -
    public Map<byte[],List<org.apache.hadoop.fs.Path>> bulkLoadHFiles(Collection<Pair<byte[],String>> familyPaths,
    +
    public Map<byte[],List<org.apache.hadoop.fs.Path>> bulkLoadHFiles(Collection<Pair<byte[],String>> familyPaths,
                                                                       boolean assignSeqId,
                                                                       HRegion.BulkLoadListener bulkLoadListener)
                                                                throws IOException
    @@ -6125,7 +6125,7 @@ public long 
  • bulkLoadHFiles

    -
    public Map<byte[],List<org.apache.hadoop.fs.Path>> bulkLoadHFiles(Collection<Pair<byte[],String>> familyPaths,
    +
    public Map<byte[],List<org.apache.hadoop.fs.Path>> bulkLoadHFiles(Collection<Pair<byte[],String>> familyPaths,
                                                                       boolean assignSeqId,
                                                                       HRegion.BulkLoadListener bulkLoadListener,
                                                                       boolean copyFile)
    @@ -6152,7 +6152,7 @@ public long 
     
  • equals

    -
    public boolean equals(Object o)
    +
    public boolean equals(Object o)
    Overrides:
    equals in class Object
    @@ -6165,7 +6165,7 @@ public long 
  • hashCode

    -
    public int