You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by to...@apache.org on 2018/03/05 22:33:37 UTC

hbase git commit: Update POMs and CHANGES.txt for 1.3.2 release

Repository: hbase
Updated Branches:
  refs/heads/branch-1.3 6a9ddaca1 -> 4fc36c6e4


Update POMs and CHANGES.txt for 1.3.2 release


Project: http://git-wip-us.apache.org/repos/asf/hbase/repo
Commit: http://git-wip-us.apache.org/repos/asf/hbase/commit/4fc36c6e
Tree: http://git-wip-us.apache.org/repos/asf/hbase/tree/4fc36c6e
Diff: http://git-wip-us.apache.org/repos/asf/hbase/diff/4fc36c6e

Branch: refs/heads/branch-1.3
Commit: 4fc36c6e4ee84091d02a7e26fc45bae3fcb0e30f
Parents: 6a9ddac
Author: Francis Liu <to...@apache.org>
Authored: Mon Mar 5 14:31:55 2018 -0800
Committer: Francis Liu <to...@apache.org>
Committed: Mon Mar 5 14:31:55 2018 -0800

----------------------------------------------------------------------
 CHANGES.txt                                     | 258 +++++++++++++++++++
 hbase-annotations/pom.xml                       |   2 +-
 .../hbase-archetype-builder/pom.xml             |   2 +-
 hbase-archetypes/hbase-client-project/pom.xml   |   2 +-
 .../hbase-shaded-client-project/pom.xml         |   2 +-
 hbase-archetypes/pom.xml                        |   2 +-
 hbase-assembly/pom.xml                          |   2 +-
 hbase-checkstyle/pom.xml                        |   4 +-
 hbase-client/pom.xml                            |   2 +-
 hbase-common/pom.xml                            |   2 +-
 hbase-examples/pom.xml                          |   2 +-
 hbase-external-blockcache/pom.xml               |   2 +-
 hbase-hadoop-compat/pom.xml                     |   2 +-
 hbase-hadoop2-compat/pom.xml                    |   2 +-
 hbase-it/pom.xml                                |   2 +-
 hbase-prefix-tree/pom.xml                       |   2 +-
 hbase-procedure/pom.xml                         |   2 +-
 hbase-protocol/pom.xml                          |   2 +-
 hbase-resource-bundle/pom.xml                   |   2 +-
 hbase-rest/pom.xml                              |   2 +-
 hbase-server/pom.xml                            |   2 +-
 .../hbase-shaded-check-invariants/pom.xml       |   2 +-
 hbase-shaded/hbase-shaded-client/pom.xml        |   2 +-
 hbase-shaded/hbase-shaded-server/pom.xml        |   2 +-
 hbase-shaded/pom.xml                            |   2 +-
 hbase-shell/pom.xml                             |   2 +-
 hbase-testing-util/pom.xml                      |   2 +-
 hbase-thrift/pom.xml                            |   2 +-
 pom.xml                                         |   2 +-
 29 files changed, 287 insertions(+), 29 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/CHANGES.txt
----------------------------------------------------------------------
diff --git a/CHANGES.txt b/CHANGES.txt
index d9a9e2e..cd60bc9 100644
--- a/CHANGES.txt
+++ b/CHANGES.txt
@@ -1,5 +1,263 @@
 HBase Change Log
 
+Release Notes - HBase - Version 1.3.2 03/05/18
+
+** Sub-task
+    * [HBASE-15691] - Port HBASE-10205 (ConcurrentModificationException in BucketAllocator) to branch-1
+    * [HBASE-17887] - Row-level consistency is broken for read
+    * [HBASE-17925] - mvn assembly:single fails against hadoop3-alpha2
+    * [HBASE-18268] - Eliminate the findbugs warnings for hbase-client
+    * [HBASE-18293] - Only add the spotbugs dependency when jdk8 is active
+    * [HBASE-18295] -  The result contains the cells across different rows
+    * [HBASE-18308] - Eliminate the findbugs warnings for hbase-server
+    * [HBASE-18315] - Eliminate the findbugs warnings for hbase-rest
+    * [HBASE-18365] - Eliminate the findbugs warnings for hbase-common
+    * [HBASE-18398] - Snapshot operation fails with FileNotFoundException
+    * [HBASE-18656] - Address issues found by error-prone in hbase-common
+    * [HBASE-18731] - [compat 1-2] Mark protected methods of QuotaSettings that touch Protobuf internals as IA.Private
+    * [HBASE-18867] - maven enforcer plugin needs update to work with jdk9
+    * [HBASE-18936] - Backport HBASE-16870 to branch-1.3
+    * [HBASE-18937] - Backport HBASE-16815 to branch-1.3
+    * [HBASE-18938] - Backport HBASE-16985 to branch-1.3
+    * [HBASE-18939] - Backport HBASE-16538 to branch-1.3
+    * [HBASE-18957] - add test that confirms 2 FamilyFilters in a FilterList using MUST_PASS_ONE operator will return results that match either of the FamilyFilters and revert as needed to make it pass.
+    * [HBASE-18967] - Backport HBASE-17181 to branch-1.3
+    * [HBASE-18980] - Address issues found by error-prone in hbase-hadoop2-compat
+    * [HBASE-19070] - temporarily make the mvnsite nightly test non-voting.
+    * [HBASE-19182] - Add deprecation in branch-1 for hbase-prefix-tree so some heads up it removed in hbase2
+    * [HBASE-19205] - Backport HBASE-18441 ZookeeperWatcher#interruptedException should throw exception
+    * [HBASE-19243] - Start mini cluster once before class for TestFIFOCompactionPolicy
+    * [HBASE-19354] - [branch-1] Build using a jdk that is beyond ubuntu trusty's openjdk-151
+    * [HBASE-19368] - [nightly] Make xml test non-voting in branch-1.2
+    * [HBASE-19373] - Fix Checkstyle error in hbase-annotations
+    * [HBASE-19468] - FNFE during scans and flushes
+    * [HBASE-19877] - hbase-common and hbase-zookeeper don't add the log4j.properties to the resource path for testing
+
+** Bug
+    * [HBASE-8758] - Error in RegionCoprocessorHost class preScanner method documentation.
+    * [HBASE-9393] - Hbase does not closing a closed socket resulting in many CLOSE_WAIT 
+    * [HBASE-13860] - Remove units from ServerMetricsTmpl.jamon since values are formatted human readable
+    * [HBASE-14499] - Master coprocessors shutdown will not happen on master abort
+    * [HBASE-14897] - TestTableLockManager.testReapAllTableLocks is flakey
+    * [HBASE-15497] - Incorrect javadoc for atomicity guarantee of Increment and Append
+    * [HBASE-15548] - SyncTable: sourceHashDir is supposed to be optional but won't work without 
+    * [HBASE-15947] - Classes used only for tests included in main code base
+    * [HBASE-16011] - TableSnapshotScanner and TableSnapshotInputFormat can produce duplicate rows
+    * [HBASE-16090] - ResultScanner is not closed in SyncTable#finishRemainingHashRanges()
+    * [HBASE-16615] - Fix flaky TestScannerHeartbeatMessages
+    * [HBASE-16731] - Inconsistent results from the Get/Scan if we use the empty FilterList
+    * [HBASE-16939] - ExportSnapshot: set owner and permission on right directory
+    * [HBASE-17079] - HBase build fails on windows, hbase-archetype-builder is reason for failure
+    * [HBASE-17131] - Avoid livelock caused by HRegion#processRowsWithLocks
+    * [HBASE-17352] - Fix hbase-assembly build with bash 4
+    * [HBASE-17441] - precommit test "hadoopcheck" not properly testing Hadoop 3 profile
+    * [HBASE-17513] - Thrift Server 1 uses different QOP settings than RPC and Thrift Server 2 and can easily be misconfigured so there is no encryption when the operator expects it.
+    * [HBASE-17534] - SecureBulkLoadClient squashes DoNotRetryIOExceptions from the server
+    * [HBASE-17617] - Backport HBASE-16731 (Inconsistent results from the Get/Scan if we use the empty FilterList) to branch-1
+    * [HBASE-17648] - HBase Table-level synchronization fails between two secured(kerberized) clusters
+    * [HBASE-17658] - Fix bookkeeping error with max regions for a table
+    * [HBASE-17803] - PE always re-creates table when we specify the split policy
+    * [HBASE-17862] - Condition that always returns true
+    * [HBASE-17902] - Backport HBASE-16367 "Race between master and region server initialization may lead to premature server abort" to 1.3
+    * [HBASE-17934] - Backport HBASE-17779 "disable_table_replication returns misleading message and does not turn off replication" to branch-1.3
+    * [HBASE-17937] - Memstore size becomes negative in case of expensive postPut/Delete Coprocessor call
+    * [HBASE-17985] - Inline package manage updates with package installation in Yetus Dockerfile
+    * [HBASE-18000] - Make sure we always return the scanner id with ScanResponse
+    * [HBASE-18014] - A case of Region remain unassigned when table enabled
+    * [HBASE-18024] - HRegion#initializeRegionInternals should not re-create .hregioninfo file when the region directory no longer exists
+    * [HBASE-18025] - CatalogJanitor should collect outdated RegionStates from the AM
+    * [HBASE-18026] - ProtobufUtil seems to do extra array copying
+    * [HBASE-18027] - Replication should respect RPC size limits when batching edits
+    * [HBASE-18030] - Per Cell TTL tags may get duplicated with increments/Append causing tags length overflow
+    * [HBASE-18036] - HBase 1.x : Data locality is not maintained after cluster restart or SSH
+    * [HBASE-18042] - Client Compatibility breaks between versions 1.2 and 1.3
+    * [HBASE-18066] - Get with closest_row_before on "hbase:meta" can return empty Cell during region merge/split
+    * [HBASE-18077] - Update JUnit license to EPL from CPL
+    * [HBASE-18081] - The way we process connection preamble in SimpleRpcServer is broken
+    * [HBASE-18092] - Removing a peer does not properly clean up the ReplicationSourceManager state and metrics
+    * [HBASE-18093] - Overloading the meaning of 'enabled' in Quota Manager to indicate either quota disabled or quota manager not ready is not good
+    * [HBASE-18122] - Scanner id should include ServerName of region server
+    * [HBASE-18125] - HBase shell disregards spaces at the end of a split key in a split file
+    * [HBASE-18132] - Low replication should be checked in period in case of datanode rolling upgrade
+    * [HBASE-18137] - Replication gets stuck for empty WALs
+    * [HBASE-18141] - Regionserver fails to shutdown when abort triggered in RegionScannerImpl during RPC call
+    * [HBASE-18142] - Deletion of a cell deletes the previous versions too
+    * [HBASE-18145] - The flush may cause the corrupt data for reading
+    * [HBASE-18159] - Use OpenJDK7 instead of Oracle JDK7 in pre commit docker file
+    * [HBASE-18167] - OfflineMetaRepair tool may cause HMaster abort always
+    * [HBASE-18180] - Possible connection leak while closing BufferedMutator in TableOutputFormat
+    * [HBASE-18185] - IntegrationTestTimeBoundedRequestsWithRegionReplicas unbalanced tests fails with AssertionError
+    * [HBASE-18192] - Replication drops recovered queues on region server shutdown
+    * [HBASE-18197] - Avoided to call job.waitForCompletion(true) two times
+    * [HBASE-18212] - In Standalone mode with local filesystem HBase logs Warning message:Failed to invoke 'unbuffer' method in class class org.apache.hadoop.fs.FSDataInputStream
+    * [HBASE-18230] - Generated LICENSE file includes unsubstituted Velocity variables
+    * [HBASE-18233] - We shouldn't wait for readlock in doMiniBatchMutation in case of deadlock
+    * [HBASE-18247] - Hbck to fix the case that replica region shows as key in the meta table
+    * [HBASE-18255] - Time-Delayed HBase Performance Degradation with Java 7
+    * [HBASE-18282] - ReplicationLogCleaner can delete WALs not yet replicated in case of a KeeperException
+    * [HBASE-18330] - NPE in ReplicationZKLockCleanerChore
+    * [HBASE-18358] - Backport HBASE-18099 'FlushSnapshotSubprocedure should wait for concurrent Region#flush() to finish' to branch-1.3
+    * [HBASE-18362] - hbck should not report split replica parent region from meta as errors 
+    * [HBASE-18390] - Sleep too long when finding region location failed
+    * [HBASE-18437] - Revoke access permissions of a user from a table does not work as expected
+    * [HBASE-18438] - Precommit doesn't warn about unused imports
+    * [HBASE-18461] - Build broken If the username contains a backslash
+    * [HBASE-18470] - Remove the redundant comma from RetriesExhaustedWithDetailsException#getDesc
+    * [HBASE-18471] - The DeleteFamily cell is skipped when StoreScanner seeks to next column
+    * [HBASE-18473] - VC.listLabels() erroneously closes any connection
+    * [HBASE-18479] - should apply HBASE-18255 to HBASE_MASTER_OPTS too
+    * [HBASE-18480] - The cost of BaseLoadBalancer.cluster is changed even if the rollback is done
+    * [HBASE-18481] - The autoFlush flag was not used in PE tool
+    * [HBASE-18487] - Minor fixes in row lock implementation
+    * [HBASE-18505] - Our build/yetus personality will run tests on individual modules and then on all (i.e. 'root'). Should do one or other
+    * [HBASE-18572] - Delete can't remove the cells which have no visibility label
+    * [HBASE-18577] - shaded client includes several non-relocated third party dependencies
+    * [HBASE-18587] - Fix Flaky TestFileIOEngine
+    * [HBASE-18607] - fix submit-patch.py to support utf8
+    * [HBASE-18625] - Splitting of region with replica, doesn't update region list in serverHolding. A server crash leads to overlap.
+    * [HBASE-18644] - Duplicate "compactionQueueLength" metric in Region Server metrics
+    * [HBASE-18665] - ReversedScannerCallable invokes getRegionLocations incorrectly
+    * [HBASE-18679] - YARN may null Counters object and cause an NPE in ITBLL
+    * [HBASE-18743] - HFiles in use by a table which has the same name and namespace with a default table cloned from snapshot may be deleted when that snapshot and default table are deleted
+    * [HBASE-18757] - Fix Improper bitwise & in BucketCache offset calculation
+    * [HBASE-18771] - Incorrect StoreFileRefresh leading to split and compaction failures
+    * [HBASE-18796] - Admin#isTableAvailable returns incorrect result before daughter regions are opened
+    * [HBASE-18818] - TestConnectionImplemenation fails
+    * [HBASE-18885] - HFileOutputFormat2 hardcodes default FileOutputCommitter
+    * [HBASE-18890] - Backport HBASE-14499 (Master coprocessors shutdown will not happen on master abort) to branch-1
+    * [HBASE-18891] - Upgrade netty-all jar
+    * [HBASE-18921] - Result.current() throws ArrayIndexOutOfBoundsException after calling advance()
+    * [HBASE-18923] - TestTableResource flaky on branch-1
+    * [HBASE-18924] - Backport HBASE-18568 (Correct metric of numRegions) to branch-1.2 and branch-1.3
+    * [HBASE-18934] - precommit on branch-1 isn't supposed to run against hadoop 3
+    * [HBASE-18940] - branch-2 (and probably others) fail check of generated source artifact
+    * [HBASE-18959] - Backport HBASE-18874 (HMaster abort message will be skipped if Throwable is passed null) to branch-1
+    * [HBASE-18985] - Fix the building warning of missing version in hbase-shaded-check-invariants module
+    * [HBASE-18998] - processor.getRowsToLock() always assumes there is some row being locked
+    * [HBASE-19014] - surefire fails; When writing xml report stdout/stderr ... No such file or directory
+    * [HBASE-19020] - TestXmlParsing exception checking relies on a particular xml implementation without declaring it.
+    * [HBASE-19030] - nightly runs should attempt to log test results after archiving
+    * [HBASE-19032] - Set Content-Type header for patches uploaded by submit-patch.py
+    * [HBASE-19038] - precommit mvn install should run from root on patch
+    * [HBASE-19039] - refactor shadedjars test to only run on java changes.
+    * [HBASE-19042] - Oracle Java 8u144 downloader broken in precommit check
+    * [HBASE-19055] - Backport HBASE-19042 to other active branches
+    * [HBASE-19058] - The wget isn't installed in building docker image
+    * [HBASE-19060] - "Hadoop check" test is running all the time instead of just when changes to java
+    * [HBASE-19061] - enforcer NPE on hbase-shaded-invariants
+    * [HBASE-19065] - HRegion#bulkLoadHFiles() should wait for concurrent Region#flush() to finish
+    * [HBASE-19066] - Correct the directory of openjdk-8 for jenkins
+    * [HBASE-19072] - Missing break in catch block of InterruptedException in HRegion#waitForFlushes() 
+    * [HBASE-19098] - Python based compatiblity checker fails if git repo does not have a remote named 'origin'
+    * [HBASE-19102] - TestZooKeeperMainServer fails with KeeperException$ConnectionLossException
+    * [HBASE-19124] - Move HBase-Nightly source artifact creation test from JenkinsFile to a script in dev-support
+    * [HBASE-19137] - Nightly test should make junit reports optional rather than attempt archive after reporting.
+    * [HBASE-19156] - Duplicative regions_per_server options on LoadTestTool
+    * [HBASE-19184] - clean up nightly source artifact test to match expectations from switch to git-archive
+    * [HBASE-19188] - Build fails on branch-1 using maven-3.5.2
+    * [HBASE-19198] - TestIPv6NIOServerSocketChannel fails; unable to bind
+    * [HBASE-19215] - Incorrect exception handling on the client causes incorrect call timeouts and byte buffer allocations on the server
+    * [HBASE-19223] - Remove references to Date Tiered compaction from branch-1.2 and branch-1.1 ref guide
+    * [HBASE-19229] - Nightly script to check source artifact should not do a destructive git operation without opt-in
+    * [HBASE-19245] - MultiTableInputFormatBase#getSplits creates a Connection per Table
+    * [HBASE-19249] - test for "hbase antipatterns" should check _count_ of occurance rather than text of
+    * [HBASE-19260] - Add lock back to avoid parallel accessing meta to locate region
+    * [HBASE-19332] - DumpReplicationQueues misreports total WAL size
+    * [HBASE-19340] - Backport missing options in shell
+    * [HBASE-19350] - TestMetaWithReplicas is flaky
+    * [HBASE-19383] - [1.2] java.lang.AssertionError: expected:<2> but was:<1>     at org.apache.hadoop.hbase.TestChoreService.testTriggerNowFailsWhenNotScheduled(TestChoreService.java:707)
+    * [HBASE-19385] - [1.3] TestReplicator failed 1.3 nightly
+    * [HBASE-19388] - Incorrect value is being set for Compaction Pressure in RegionLoadStats object inside HRegion class
+    * [HBASE-19393] - HTTP 413 FULL head while accessing HBase UI using SSL. 
+    * [HBASE-19396] - Fix flaky test TestHTableMultiplexerFlushCache
+    * [HBASE-19422] - using hadoop-profile property leads to confusing failures
+    * [HBASE-19424] - Metrics servlet throws NPE
+    * [HBASE-19442] - Backport HBASE-19065 to branch-1 (HRegion#bulkLoadHFiles() should wait for concurrent Region#flush() to finish)
+    * [HBASE-19490] - Rare failure in TestRateLimiter
+    * [HBASE-19546] - TestMasterReplication.testCyclicReplication2 uses wrong assertion
+    * [HBASE-19685] - Fix TestFSErrorsExposed#testFullSystemBubblesFSErrors
+    * [HBASE-19708] - Avoid NPE when the RPC listener's accept channel is closed
+    * [HBASE-19728] - Add lock to filesCompacting in all place.
+    * [HBASE-19756] - Master NPE during completed failed proc eviction
+    * [HBASE-19790] - Fix compatibility break in 1.3.2-SNAPSHOT
+    * [HBASE-19796] - ReplicationSynUp tool is not replicating the data if the WAL is moved to splitting directory
+    * [HBASE-19871] - delete.rb should require user to provide the column
+    * [HBASE-19876] - The exception happening in converting pb mutation to hbase.mutation messes up the CellScanner
+    * [HBASE-19900] - Region-level exception destroy the result of batch
+    * [HBASE-19901] - Up yetus proclimit on nightlies
+    * [HBASE-19979] - ReplicationSyncUp tool may leak Zookeeper connection
+    * [HBASE-19981] - Boolean#getBoolean is used to parse value
+    * [HBASE-19989] - READY_TO_MERGE and READY_TO_SPLIT do not update region state correctly
+    * [HBASE-19996] - Some nonce procs might not be cleaned up (follow up HBASE-19756)
+    * [HBASE-20001] - cleanIfNoMetaEntry() uses encoded instead of region name to lookup region
+    * [HBASE-20016] - TestCatalogJanitorInMemoryStates#testInMemoryForReplicaParentCleanup is flaky
+    * [HBASE-20051] - Correct usage statement of endtime for VerifyReplication
+    * [HBASE-20061] - HStore synchronized member variable filesCompacting should be private
+    * [HBASE-20062] - findbugs is not running on precommit checks
+    * [HBASE-20106] - API Compliance checker should fall back to specifying origin as remote repo
+
+** New Feature
+    * [HBASE-19189] - Ad-hoc test job for running a subset of tests lots of times
+
+** Improvement
+    * [HBASE-14220] - nightly tests should verify src tgz generates and builds correctly
+    * [HBASE-16116] - Remove redundant pattern *.iml
+    * [HBASE-16351] - do dependency license check via enforcer plugin
+    * [HBASE-17514] - Warn when Thrift Server 1 is configured for proxy users but not the HTTP transport
+    * [HBASE-17817] - Make Regionservers log which tables it removed coprocessors from when aborting
+    * [HBASE-17877] - Improve HBase's byte[] comparator
+    * [HBASE-17916] - Error message not clear when the permission of staging dir is not as expected
+    * [HBASE-17944] - Removed unused JDK version parsing from ClassSize.
+    * [HBASE-18020] - Update API Compliance Checker to Incorporate Improvements Done in Hadoop
+    * [HBASE-18023] - Log multi-* requests for more than threshold number of rows
+    * [HBASE-18041] - Add pylintrc file to HBase
+    * [HBASE-18090] - Improve TableSnapshotInputFormat to allow more multiple mappers per region
+    * [HBASE-18387] - [Thrift] Make principal configurable in DemoClient.java
+    * [HBASE-18426] - nightly job should use independent stages to check supported jdks
+    * [HBASE-18631] - Allow configuration of ChaosMonkey properties via hbase-site
+    * [HBASE-18675] - Making {max,min}SessionTimeout configurable for MiniZooKeeperCluster
+    * [HBASE-18746] - Throw exception with job.getStatus().getFailureInfo() when ExportSnapshot fails
+    * [HBASE-19052] - FixedFileTrailer should recognize CellComparatorImpl class in branch-1.x
+    * [HBASE-19091] - Code annotation wrote "BinaryComparator" instead of "LongComparator"
+    * [HBASE-19140] - hbase-cleanup.sh uses deprecated call to remove files in hdfs
+    * [HBASE-19228] - nightly job should gather machine stats.
+    * [HBASE-19262] - Revisit checkstyle rules
+    * [HBASE-19489] - Check against only the latest maintenance release in pre-commit hadoopcheck.
+    * [HBASE-19491] - Exclude flaky tests from nightly master run
+    * [HBASE-19570] - Add hadoop3 tests to Nightly master/branch-2 runs
+    * [HBASE-19571] - Minor refactor of Nightly run scripts
+    * [HBASE-19684] - BlockCacheKey toString Performance
+    * [HBASE-19789] - Not exclude flaky tests from nightly builds
+
+** Test
+    * [HBASE-17703] - TestThriftServerCmdLine is flaky in master branch
+    * [HBASE-18147] - nightly job to check health of active branches
+    * [HBASE-18979] - TestInterfaceAudienceAnnotations fails on branch-1.3
+    * [HBASE-19414] - enable TestMasterOperationsForRegionReplicas#testIncompleteMetaTableReplicaInformation in branch-1.3 and branch-1.2
+    * [HBASE-19514] - Use random port for TestJMXListener
+
+** Task
+    * [HBASE-16459] - Remove unused hbase shell --format option
+    * [HBASE-17954] - Switch findbugs implementation to spotbugs
+    * [HBASE-17968] - Update copyright year in NOTICE file
+    * [HBASE-18096] - Limit HFileUtil visibility and add missing annotations
+    * [HBASE-18527] - update nightly builds to compensate for jenkins plugin upgrades
+    * [HBASE-18582] - Correct the docs for Mutation#setCellVisibility
+    * [HBASE-18670] - Add .DS_Store to .gitignore
+    * [HBASE-18676] - Update branch 1.3 pom version
+    * [HBASE-18690] - Replace o.a.h.c.InterfaceAudience by o.a.h.h.c.InterfaceAudience
+    * [HBASE-18833] - Ensure precommit personality is up to date on all active branches
+    * [HBASE-18996] - Backport HBASE-17703 (TestThriftServerCmdLine is flaky in master branch) to branch-1
+    * [HBASE-19097] - update testing to use Apache Yetus Test Patch version 0.6.0
+    * [HBASE-19637] - Add .checkstyle to gitignore
+    * [HBASE-20088] - Update copyright notices to year 2018
+    * [HBASE-20089] - make_rc.sh should name SHA-512 checksum files with the extension .sha512
+
+** Umbrella
+    * [HBASE-18266] - Eliminate the warnings from the spotbugs
+    * [HBASE-18935] - Backport bug fixes which were fixed in 1.2.x and 1.4.x versions but not in 1.3.x version
+
+
 Release Notes - HBase - Version 1.3.1 04/30/2017
 
 ** Sub-task

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-annotations/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-annotations/pom.xml b/hbase-annotations/pom.xml
index dedc203..a1ec2c5 100644
--- a/hbase-annotations/pom.xml
+++ b/hbase-annotations/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-archetypes/hbase-archetype-builder/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-archetypes/hbase-archetype-builder/pom.xml b/hbase-archetypes/hbase-archetype-builder/pom.xml
index 2ae1acc..352b555 100644
--- a/hbase-archetypes/hbase-archetype-builder/pom.xml
+++ b/hbase-archetypes/hbase-archetype-builder/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <artifactId>hbase-archetypes</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-archetypes/hbase-client-project/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-archetypes/hbase-client-project/pom.xml b/hbase-archetypes/hbase-client-project/pom.xml
index ea00c45..bb8a4ce 100644
--- a/hbase-archetypes/hbase-client-project/pom.xml
+++ b/hbase-archetypes/hbase-client-project/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <artifactId>hbase-archetypes</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
   <artifactId>hbase-client-project</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-archetypes/hbase-shaded-client-project/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-archetypes/hbase-shaded-client-project/pom.xml b/hbase-archetypes/hbase-shaded-client-project/pom.xml
index e79d5fe..44173af6 100644
--- a/hbase-archetypes/hbase-shaded-client-project/pom.xml
+++ b/hbase-archetypes/hbase-shaded-client-project/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <artifactId>hbase-archetypes</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
   <artifactId>hbase-shaded-client-project</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-archetypes/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-archetypes/pom.xml b/hbase-archetypes/pom.xml
index 1742d54..2740e3c 100644
--- a/hbase-archetypes/pom.xml
+++ b/hbase-archetypes/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-assembly/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-assembly/pom.xml b/hbase-assembly/pom.xml
index ee1478b..8cf8e55 100644
--- a/hbase-assembly/pom.xml
+++ b/hbase-assembly/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
   <artifactId>hbase-assembly</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-checkstyle/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-checkstyle/pom.xml b/hbase-checkstyle/pom.xml
index ae3543b..d138572 100644
--- a/hbase-checkstyle/pom.xml
+++ b/hbase-checkstyle/pom.xml
@@ -24,14 +24,14 @@
 <modelVersion>4.0.0</modelVersion>
 <groupId>org.apache.hbase</groupId>
 <artifactId>hbase-checkstyle</artifactId>
-<version>1.3.2-SNAPSHOT</version>
+<version>1.3.2</version>
 <name>Apache HBase - Checkstyle</name>
 <description>Module to hold Checkstyle properties for HBase.</description>
 
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-client/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-client/pom.xml b/hbase-client/pom.xml
index 5201d78..982b264 100644
--- a/hbase-client/pom.xml
+++ b/hbase-client/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-common/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-common/pom.xml b/hbase-common/pom.xml
index 38d94c5..b09c308 100644
--- a/hbase-common/pom.xml
+++ b/hbase-common/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-examples/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-examples/pom.xml b/hbase-examples/pom.xml
index efeaf31..3f88471 100644
--- a/hbase-examples/pom.xml
+++ b/hbase-examples/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
   <artifactId>hbase-examples</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-external-blockcache/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-external-blockcache/pom.xml b/hbase-external-blockcache/pom.xml
index 1a88eba..82685ee 100644
--- a/hbase-external-blockcache/pom.xml
+++ b/hbase-external-blockcache/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
   <artifactId>hbase-external-blockcache</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-hadoop-compat/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-hadoop-compat/pom.xml b/hbase-hadoop-compat/pom.xml
index 6dea2be..8be9758 100644
--- a/hbase-hadoop-compat/pom.xml
+++ b/hbase-hadoop-compat/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <artifactId>hbase</artifactId>
         <groupId>org.apache.hbase</groupId>
-        <version>1.3.2-SNAPSHOT</version>
+        <version>1.3.2</version>
         <relativePath>..</relativePath>
     </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-hadoop2-compat/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-hadoop2-compat/pom.xml b/hbase-hadoop2-compat/pom.xml
index bafb4d8..10d7102 100644
--- a/hbase-hadoop2-compat/pom.xml
+++ b/hbase-hadoop2-compat/pom.xml
@@ -21,7 +21,7 @@ limitations under the License.
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-it/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-it/pom.xml b/hbase-it/pom.xml
index 6220147..57a5c1e 100644
--- a/hbase-it/pom.xml
+++ b/hbase-it/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-prefix-tree/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-prefix-tree/pom.xml b/hbase-prefix-tree/pom.xml
index 8a6eaf0..f0d3091 100644
--- a/hbase-prefix-tree/pom.xml
+++ b/hbase-prefix-tree/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-procedure/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-procedure/pom.xml b/hbase-procedure/pom.xml
index 72ab6eb..0605351 100644
--- a/hbase-procedure/pom.xml
+++ b/hbase-procedure/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-protocol/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-protocol/pom.xml b/hbase-protocol/pom.xml
index ad96e5d..ff92635 100644
--- a/hbase-protocol/pom.xml
+++ b/hbase-protocol/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <artifactId>hbase</artifactId>
         <groupId>org.apache.hbase</groupId>
-        <version>1.3.2-SNAPSHOT</version>
+        <version>1.3.2</version>
         <relativePath>..</relativePath>
     </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-resource-bundle/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-resource-bundle/pom.xml b/hbase-resource-bundle/pom.xml
index 2da54fa..3d8bafc 100644
--- a/hbase-resource-bundle/pom.xml
+++ b/hbase-resource-bundle/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-rest/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-rest/pom.xml b/hbase-rest/pom.xml
index be6bc62..2b058e4 100644
--- a/hbase-rest/pom.xml
+++ b/hbase-rest/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
   <artifactId>hbase-rest</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-server/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-server/pom.xml b/hbase-server/pom.xml
index dddbb42..7b71382 100644
--- a/hbase-server/pom.xml
+++ b/hbase-server/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
   <artifactId>hbase-server</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-shaded/hbase-shaded-check-invariants/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-shaded/hbase-shaded-check-invariants/pom.xml b/hbase-shaded/hbase-shaded-check-invariants/pom.xml
index 8bf6936..fceae26 100644
--- a/hbase-shaded/hbase-shaded-check-invariants/pom.xml
+++ b/hbase-shaded/hbase-shaded-check-invariants/pom.xml
@@ -16,7 +16,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>../..</relativePath>
   </parent>
   <artifactId>hbase-shaded-check-invariants</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-shaded/hbase-shaded-client/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-shaded/hbase-shaded-client/pom.xml b/hbase-shaded/hbase-shaded-client/pom.xml
index 40d874d..0f0a395 100644
--- a/hbase-shaded/hbase-shaded-client/pom.xml
+++ b/hbase-shaded/hbase-shaded-client/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <artifactId>hbase-shaded</artifactId>
         <groupId>org.apache.hbase</groupId>
-        <version>1.3.2-SNAPSHOT</version>
+        <version>1.3.2</version>
         <relativePath>..</relativePath>
     </parent>
     <artifactId>hbase-shaded-client</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-shaded/hbase-shaded-server/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-shaded/hbase-shaded-server/pom.xml b/hbase-shaded/hbase-shaded-server/pom.xml
index 95b7001..75523ae 100644
--- a/hbase-shaded/hbase-shaded-server/pom.xml
+++ b/hbase-shaded/hbase-shaded-server/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <artifactId>hbase-shaded</artifactId>
         <groupId>org.apache.hbase</groupId>
-        <version>1.3.2-SNAPSHOT</version>
+        <version>1.3.2</version>
         <relativePath>..</relativePath>
     </parent>
     <artifactId>hbase-shaded-server</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-shaded/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-shaded/pom.xml b/hbase-shaded/pom.xml
index 41c1407..d85318f 100644
--- a/hbase-shaded/pom.xml
+++ b/hbase-shaded/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <artifactId>hbase</artifactId>
         <groupId>org.apache.hbase</groupId>
-        <version>1.3.2-SNAPSHOT</version>
+        <version>1.3.2</version>
         <relativePath>..</relativePath>
     </parent>
     <artifactId>hbase-shaded</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-shell/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-shell/pom.xml b/hbase-shell/pom.xml
index 571a8d1..688505f 100644
--- a/hbase-shell/pom.xml
+++ b/hbase-shell/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
   <artifactId>hbase-shell</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-testing-util/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-testing-util/pom.xml b/hbase-testing-util/pom.xml
index 5471a16..3201c82 100644
--- a/hbase-testing-util/pom.xml
+++ b/hbase-testing-util/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <artifactId>hbase</artifactId>
         <groupId>org.apache.hbase</groupId>
-        <version>1.3.2-SNAPSHOT</version>
+        <version>1.3.2</version>
         <relativePath>..</relativePath>
     </parent>
     <artifactId>hbase-testing-util</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/hbase-thrift/pom.xml
----------------------------------------------------------------------
diff --git a/hbase-thrift/pom.xml b/hbase-thrift/pom.xml
index c6c232e..3aab22a 100644
--- a/hbase-thrift/pom.xml
+++ b/hbase-thrift/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <artifactId>hbase</artifactId>
     <groupId>org.apache.hbase</groupId>
-    <version>1.3.2-SNAPSHOT</version>
+    <version>1.3.2</version>
     <relativePath>..</relativePath>
   </parent>
   <artifactId>hbase-thrift</artifactId>

http://git-wip-us.apache.org/repos/asf/hbase/blob/4fc36c6e/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 6ab3335..eb99179 100644
--- a/pom.xml
+++ b/pom.xml
@@ -39,7 +39,7 @@
   <groupId>org.apache.hbase</groupId>
   <artifactId>hbase</artifactId>
   <packaging>pom</packaging>
-  <version>1.3.2-SNAPSHOT</version>
+  <version>1.3.2</version>
   <name>Apache HBase</name>
   <description>
     Apache HBase™ is the Hadoop database. Use it when you need