You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by zh...@apache.org on 2021/12/23 09:15:02 UTC

svn commit: r51725 [2/5] - /release/hbase/3.0.0-alpha-2/

Added: release/hbase/3.0.0-alpha-2/CHANGES.md
==============================================================================
--- release/hbase/3.0.0-alpha-2/CHANGES.md (added)
+++ release/hbase/3.0.0-alpha-2/CHANGES.md Thu Dec 23 09:15:02 2021
@@ -0,0 +1,3383 @@
+
+<!---
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+-->
+# HBASE Changelog
+
+## Release 3.0.0-alpha-2 - Unreleased (as of 2021-12-19)
+
+
+
+### NEW FEATURES:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-26284](https://issues.apache.org/jira/browse/HBASE-26284) | Add HBase Thrift API to get all table names along with whether it is enabled or not |  Major | Thrift |
+| [HBASE-6908](https://issues.apache.org/jira/browse/HBASE-6908) | Pluggable Call BlockingQueue for HBaseServer |  Major | IPC/RPC |
+
+
+### IMPROVEMENTS:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-26579](https://issues.apache.org/jira/browse/HBASE-26579) | Set storage policy of recovered edits  when wal storage type is configured |  Major | Recovery |
+| [HBASE-26601](https://issues.apache.org/jira/browse/HBASE-26601) | maven-gpg-plugin failing with "Inappropriate ioctl for device" |  Major | build |
+| [HBASE-26554](https://issues.apache.org/jira/browse/HBASE-26554) | Introduce a new parameter in jmx servlet to exclude the specific mbean |  Minor | metrics |
+| [HBASE-25547](https://issues.apache.org/jira/browse/HBASE-25547) | Thread pools should release unused resources |  Minor | master, regionserver |
+| [HBASE-25799](https://issues.apache.org/jira/browse/HBASE-25799) | add clusterReadRequests and clusterWriteRequests jmx |  Major | metrics |
+| [HBASE-26526](https://issues.apache.org/jira/browse/HBASE-26526) | Introduce a timeout to shutdown of WAL |  Major | wal |
+| [HBASE-26525](https://issues.apache.org/jira/browse/HBASE-26525) | Use unique thread name for group WALs |  Major | wal |
+| [HBASE-26524](https://issues.apache.org/jira/browse/HBASE-26524) | Support remove coprocessor by class name via alter table command |  Major | Coprocessors, shell |
+| [HBASE-26517](https://issues.apache.org/jira/browse/HBASE-26517) | Add auth method information to AccessChecker audit log |  Trivial | security |
+| [HBASE-26512](https://issues.apache.org/jira/browse/HBASE-26512) | Make timestamp format configurable in HBase shell scan output |  Major | shell |
+| [HBASE-26485](https://issues.apache.org/jira/browse/HBASE-26485) | Introduce a method to clean restore directory after Snapshot Scan |  Minor | snapshots |
+| [HBASE-26479](https://issues.apache.org/jira/browse/HBASE-26479) | Print too slow/big scan's operation\_id in region server log |  Minor | regionserver, scan |
+| [HBASE-26475](https://issues.apache.org/jira/browse/HBASE-26475) | The flush and compact methods in HTU should skip processing secondary replicas |  Major | test |
+| [HBASE-26249](https://issues.apache.org/jira/browse/HBASE-26249) | Ameliorate compaction made by bulk-loading files |  Major | . |
+| [HBASE-26421](https://issues.apache.org/jira/browse/HBASE-26421) | Use HFileLink file to replace entire file¡®s reference when splitting |  Major | . |
+| [HBASE-26267](https://issues.apache.org/jira/browse/HBASE-26267) | Master initialization fails if Master Region WAL dir is missing |  Major | master |
+| [HBASE-26446](https://issues.apache.org/jira/browse/HBASE-26446) | CellCounter should report serialized cell size counts too |  Minor | . |
+| [HBASE-26432](https://issues.apache.org/jira/browse/HBASE-26432) | Add tracing support in hbase shell |  Minor | shell, tracing |
+| [HBASE-26337](https://issues.apache.org/jira/browse/HBASE-26337) | Optimization for weighted random generators |  Major | Balancer |
+| [HBASE-26439](https://issues.apache.org/jira/browse/HBASE-26439) | improve upgrading doc |  Minor | documentation |
+| [HBASE-26363](https://issues.apache.org/jira/browse/HBASE-26363) | OpenTelemetry configuration support for per-process service names |  Major | tracing |
+| [HBASE-26309](https://issues.apache.org/jira/browse/HBASE-26309) | Balancer tends to move regions to the server at the end of list |  Major | Balancer |
+| [HBASE-26348](https://issues.apache.org/jira/browse/HBASE-26348) | Implement a special procedure to migrate rs group information when upgrading |  Major | proc-v2, rsgroup |
+| [HBASE-26305](https://issues.apache.org/jira/browse/HBASE-26305) | Move NavigableSet add operation to writer thread in BucketCache |  Minor | BucketCache, Performance |
+| [HBASE-26251](https://issues.apache.org/jira/browse/HBASE-26251) | StochasticLoadBalancer metrics should update even if balancer doesn't run |  Minor | Balancer |
+| [HBASE-26270](https://issues.apache.org/jira/browse/HBASE-26270) | Provide getConfiguration method for Region and Store interface |  Minor | . |
+| [HBASE-26273](https://issues.apache.org/jira/browse/HBASE-26273) | TableSnapshotInputFormat/TableSnapshotInputFormatImpl should use ReadType.STREAM for scanning HFiles |  Major | mapreduce |
+| [HBASE-25891](https://issues.apache.org/jira/browse/HBASE-25891) | Remove dependence on storing WAL filenames for backup |  Major | backup&restore |
+| [HBASE-26276](https://issues.apache.org/jira/browse/HBASE-26276) | Allow HashTable/SyncTable to perform rawScan when comparing cells |  Major | . |
+| [HBASE-26255](https://issues.apache.org/jira/browse/HBASE-26255) | Add an option to use region location from meta table in TableSnapshotInputFormat |  Major | mapreduce |
+| [HBASE-26229](https://issues.apache.org/jira/browse/HBASE-26229) | Limit count and size of L0 files compaction in StripeCompactionPolicy |  Major | Compaction |
+| [HBASE-26243](https://issues.apache.org/jira/browse/HBASE-26243) | Fix typo for file 'hbase-server/src/main/java/org/apache/hadoop/hbase/util/HBaseFsck.java' |  Trivial | . |
+| [HBASE-26163](https://issues.apache.org/jira/browse/HBASE-26163) | Better logging in RSGroupInfoManagerImpl |  Minor | logging, rsgroup |
+| [HBASE-25773](https://issues.apache.org/jira/browse/HBASE-25773) | TestSnapshotScannerHDFSAclController.setupBeforeClass is flaky |  Major | . |
+| [HBASE-26147](https://issues.apache.org/jira/browse/HBASE-26147) | Add dry run mode to hbase balancer |  Major | Balancer, master |
+| [HBASE-25642](https://issues.apache.org/jira/browse/HBASE-25642) | Fix or stop warning about already cached block |  Major | BlockCache, Operability, regionserver |
+| [HBASE-26212](https://issues.apache.org/jira/browse/HBASE-26212) | Allow AuthUtil automatic renewal to be disabled |  Minor | Client, security |
+| [HBASE-26187](https://issues.apache.org/jira/browse/HBASE-26187) | Write straight into the store directory when Splitting and Merging |  Major | . |
+| [HBASE-26193](https://issues.apache.org/jira/browse/HBASE-26193) | Do not store meta region location as permanent state on zookeeper |  Major | meta, Zookeeper |
+| [HBASE-24842](https://issues.apache.org/jira/browse/HBASE-24842) | make export snapshot report size can be config |  Minor | mapreduce |
+| [HBASE-24652](https://issues.apache.org/jira/browse/HBASE-24652) | master-status UI make date type fields sortable |  Minor | master, Operability, UI, Usability |
+| [HBASE-26037](https://issues.apache.org/jira/browse/HBASE-26037) | Implement namespace and table level access control for thrift & thrift2 |  Major | Admin, Thrift |
+| [HBASE-25680](https://issues.apache.org/jira/browse/HBASE-25680) | Non-idempotent test in TestReplicationHFileCleaner |  Minor | test |
+| [HBASE-26179](https://issues.apache.org/jira/browse/HBASE-26179) | TestRequestTooBigException spends too much time to finish |  Major | test |
+| [HBASE-26160](https://issues.apache.org/jira/browse/HBASE-26160) | Configurable disallowlist for live editing of loglevels |  Minor | . |
+| [HBASE-25469](https://issues.apache.org/jira/browse/HBASE-25469) | Add detailed RIT info in JSON format for consumption as metrics |  Minor | master |
+| [HBASE-26153](https://issues.apache.org/jira/browse/HBASE-26153) | [create-release] Use cmd-line defined env vars |  Trivial | RC |
+| [HBASE-26154](https://issues.apache.org/jira/browse/HBASE-26154) | Provide exception metric for quota exceeded and throttling |  Minor | . |
+| [HBASE-26144](https://issues.apache.org/jira/browse/HBASE-26144) | The HStore.snapshot method is never called in main code |  Major | regionserver |
+| [HBASE-26105](https://issues.apache.org/jira/browse/HBASE-26105) | Rectify the expired TODO comment in CombinedBC |  Trivial | BlockCache |
+| [HBASE-26146](https://issues.apache.org/jira/browse/HBASE-26146) | Allow custom opts for hbck in hbase bin |  Minor | . |
+| [HBASE-26118](https://issues.apache.org/jira/browse/HBASE-26118) | The HStore.commitFile and HStore.moveFileIntoPlace almost have the same logic |  Major | Compaction, regionserver |
+| [HBASE-26119](https://issues.apache.org/jira/browse/HBASE-26119) | Polish TestAsyncNonMetaRegionLocator |  Major | meta replicas, test |
+| [HBASE-21946](https://issues.apache.org/jira/browse/HBASE-21946) | Use ByteBuffer pread instead of byte[] pread in HFileBlock when applicable |  Critical | Offheaping |
+| [HBASE-26108](https://issues.apache.org/jira/browse/HBASE-26108) | add option to disable scanMetrics in TableSnapshotInputFormat |  Major | . |
+| [HBASE-25986](https://issues.apache.org/jira/browse/HBASE-25986) | Expose the NORMALIZARION\_ENABLED table descriptor through a property in hbase-site |  Minor | Normalizer |
+| [HBASE-25700](https://issues.apache.org/jira/browse/HBASE-25700) | Enhance znode parent validation when add\_peer |  Minor | Replication |
+| [HBASE-26069](https://issues.apache.org/jira/browse/HBASE-26069) | Remove HStore.compactRecentForTestingAssumingDefaultPolicy and DefaultCompactor.compactForTesting |  Major | Compaction, test |
+| [HBASE-26065](https://issues.apache.org/jira/browse/HBASE-26065) | StripeStoreFileManager does not need to throw IOException for most methods |  Major | Compaction, HFile |
+
+
+### BUG FIXES:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-26488](https://issues.apache.org/jira/browse/HBASE-26488) | Memory leak when MemStore retry flushing |  Major | regionserver |
+| [HBASE-26340](https://issues.apache.org/jira/browse/HBASE-26340) | TableSplit returns false size under 1MB |  Major | mapreduce, regionserver |
+| [HBASE-26550](https://issues.apache.org/jira/browse/HBASE-26550) | Make sure the master is running normally before accepting a balance command |  Minor | Balancer, master |
+| [HBASE-26557](https://issues.apache.org/jira/browse/HBASE-26557) | log4j2 has a critical RCE vulnerability |  Major | logging, security |
+| [HBASE-26541](https://issues.apache.org/jira/browse/HBASE-26541) | hbase-protocol-shaded not buildable on M1 MacOSX |  Major | . |
+| [HBASE-26527](https://issues.apache.org/jira/browse/HBASE-26527) | ArrayIndexOutOfBoundsException in KeyValueUtil.copyToNewKeyValue() |  Major | wal |
+| [HBASE-26462](https://issues.apache.org/jira/browse/HBASE-26462) | Should persist restoreAcl flag in the procedure state for CloneSnapshotProcedure and RestoreSnapshotProcedure |  Critical | proc-v2, snapshots |
+| [HBASE-26535](https://issues.apache.org/jira/browse/HBASE-26535) | [site, branch-2] DependencyManagement report is broken |  Blocker | build, pom |
+| [HBASE-26533](https://issues.apache.org/jira/browse/HBASE-26533) | KeyValueScanner might not be properly closed when using InternalScan.checkOnlyMemStore() |  Minor | . |
+| [HBASE-26482](https://issues.apache.org/jira/browse/HBASE-26482) | HMaster may clean wals that is replicating in rare cases |  Critical | Replication |
+| [HBASE-26468](https://issues.apache.org/jira/browse/HBASE-26468) | Region Server doesn't exit cleanly incase it crashes. |  Major | regionserver |
+| [HBASE-25905](https://issues.apache.org/jira/browse/HBASE-25905) | Shutdown of WAL stuck at waitForSafePoint |  Blocker | regionserver, wal |
+| [HBASE-26455](https://issues.apache.org/jira/browse/HBASE-26455) | TestStochasticLoadBalancerRegionReplicaWithRacks fails consistently |  Major | Balancer |
+| [HBASE-26450](https://issues.apache.org/jira/browse/HBASE-26450) | Server configuration will overwrite HStore configuration after using shell command 'update\_config' |  Minor | Compaction, conf, regionserver |
+| [HBASE-26476](https://issues.apache.org/jira/browse/HBASE-26476) | Make DefaultMemStore extensible for HStore.memstore |  Major | regionserver |
+| [HBASE-26465](https://issues.apache.org/jira/browse/HBASE-26465) | MemStoreLAB may be released early when its SegmentScanner is scanning |  Critical | regionserver |
+| [HBASE-26458](https://issues.apache.org/jira/browse/HBASE-26458) | Value of hbase.master.snapshot.ttl is not used |  Minor | snapshots |
+| [HBASE-26467](https://issues.apache.org/jira/browse/HBASE-26467) | Wrong Cell Generated by MemStoreLABImpl.forceCopyOfBigCellInto when Cell size bigger than data chunk size |  Critical | in-memory-compaction |
+| [HBASE-26463](https://issues.apache.org/jira/browse/HBASE-26463) | Unreadable table names after HBASE-24605 |  Trivial | UI |
+| [HBASE-26438](https://issues.apache.org/jira/browse/HBASE-26438) | Fix  flaky test TestHStore.testCompactingMemStoreCellExceedInmemoryFlushSize |  Major | test |
+| [HBASE-26436](https://issues.apache.org/jira/browse/HBASE-26436) | check-aggregate-license error related to javadns after HADOOP-17317 |  Major | build, hadoop3 |
+| [HBASE-26311](https://issues.apache.org/jira/browse/HBASE-26311) | Balancer gets stuck in cohosted replica distribution |  Major | Balancer |
+| [HBASE-26384](https://issues.apache.org/jira/browse/HBASE-26384) | Segment already flushed to hfile may still be remained in CompactingMemStore |  Major | in-memory-compaction |
+| [HBASE-26414](https://issues.apache.org/jira/browse/HBASE-26414) | Tracing INSTRUMENTATION\_NAME is incorrect |  Blocker | tracing |
+| [HBASE-26410](https://issues.apache.org/jira/browse/HBASE-26410) | Fix HBase TestCanaryTool for Java17 |  Major | java |
+| [HBASE-26429](https://issues.apache.org/jira/browse/HBASE-26429) | HeapMemoryManager fails memstore flushes with NPE if enabled |  Major | Operability, regionserver |
+| [HBASE-25322](https://issues.apache.org/jira/browse/HBASE-25322) | Redundant Reference file in bottom region of split |  Minor | . |
+| [HBASE-26406](https://issues.apache.org/jira/browse/HBASE-26406) | Can not add peer replicating to non-HBase |  Major | Replication |
+| [HBASE-26398](https://issues.apache.org/jira/browse/HBASE-26398) | CellCounter fails for large tables filling up local disk |  Minor | mapreduce |
+| [HBASE-26190](https://issues.apache.org/jira/browse/HBASE-26190) | High rate logging of BucketAllocatorException: Allocation too big |  Major | BucketCache, Operability |
+| [HBASE-26392](https://issues.apache.org/jira/browse/HBASE-26392) | Update ClassSize.BYTE\_BUFFER for JDK17 |  Major | java, util |
+| [HBASE-26396](https://issues.apache.org/jira/browse/HBASE-26396) | Remove duplicate thread creation during migrating rsgroup |  Minor | master, rsgroup |
+| [HBASE-26394](https://issues.apache.org/jira/browse/HBASE-26394) | Cache in RSRpcServices.executeProcedures does not take effect |  Major | . |
+| [HBASE-26385](https://issues.apache.org/jira/browse/HBASE-26385) | Clear CellScanner when replay |  Major | regionserver, rpc |
+| [HBASE-26383](https://issues.apache.org/jira/browse/HBASE-26383) | HBCK incorrectly reports inconsistencies for recently split regions following a master failover |  Critical | master |
+| [HBASE-26371](https://issues.apache.org/jira/browse/HBASE-26371) | Prioritize meta region move over other region moves in region\_mover |  Major | . |
+| [HBASE-26361](https://issues.apache.org/jira/browse/HBASE-26361) | Enable OpenTelemetry to be used from developer sandbox |  Major | tracing |
+| [HBASE-26364](https://issues.apache.org/jira/browse/HBASE-26364) | TestThriftServer is failing 100% in our flaky test job |  Major | test, Thrift |
+| [HBASE-26350](https://issues.apache.org/jira/browse/HBASE-26350) | Missing server side debugging on failed SASL handshake |  Minor | . |
+| [HBASE-26344](https://issues.apache.org/jira/browse/HBASE-26344) | Fix Bug for MultiByteBuff.put(int, byte) |  Major | . |
+| [HBASE-26312](https://issues.apache.org/jira/browse/HBASE-26312) | Shell scan fails with timestamp |  Major | shell, test |
+| [HBASE-24601](https://issues.apache.org/jira/browse/HBASE-24601) | Change default Hfile storage policy from HOT to NONE for HDFS |  Major | HFile |
+| [HBASE-26295](https://issues.apache.org/jira/browse/HBASE-26295) | BucketCache could not free BucketEntry which restored from persistence file |  Major | BucketCache |
+| [HBASE-26289](https://issues.apache.org/jira/browse/HBASE-26289) | Hbase scan setMaxResultsPerColumnFamily not giving right results |  Major | regionserver |
+| [HBASE-26238](https://issues.apache.org/jira/browse/HBASE-26238) | OOME in VerifyReplication for the table contains rows with 10M+ cells |  Major | Client, Replication |
+| [HBASE-26297](https://issues.apache.org/jira/browse/HBASE-26297) | Balancer run is improperly triggered by accuracy error of double comparison |  Major | Balancer |
+| [HBASE-26178](https://issues.apache.org/jira/browse/HBASE-26178) | Improve data structure and algorithm for BalanceClusterState to improve computation speed for large cluster |  Major | Balancer, Performance |
+| [HBASE-26261](https://issues.apache.org/jira/browse/HBASE-26261) | Store configuration loss when use update\_config |  Minor | . |
+| [HBASE-26281](https://issues.apache.org/jira/browse/HBASE-26281) | DBB got from BucketCache would be freed unexpectedly before RPC completed |  Critical | BucketCache |
+| [HBASE-26197](https://issues.apache.org/jira/browse/HBASE-26197) | Fix some obvious bugs in MultiByteBuff.put |  Major | . |
+| [HBASE-26228](https://issues.apache.org/jira/browse/HBASE-26228) | updateRSGroupConfig operation should be authorized by AccessController |  Major | acl, rsgroup |
+| [HBASE-26106](https://issues.apache.org/jira/browse/HBASE-26106) | AbstractFSWALProvider#getArchivedLogPath doesn't look for wal file in all oldWALs directory. |  Critical | wal |
+| [HBASE-26205](https://issues.apache.org/jira/browse/HBASE-26205) | TableMRUtil#initCredentialsForCluster should use specified conf for UserProvider |  Major | mapreduce |
+| [HBASE-26210](https://issues.apache.org/jira/browse/HBASE-26210) | HBase Write should be doomed to hang when cell size exceeds InmemoryFlushSize for CompactingMemStore |  Critical | in-memory-compaction |
+| [HBASE-26244](https://issues.apache.org/jira/browse/HBASE-26244) | Avoid trim the error stack trace when running UT with maven |  Major | . |
+| [HBASE-25588](https://issues.apache.org/jira/browse/HBASE-25588) | Excessive logging of "hbase.zookeeper.useMulti is deprecated. Default to true always." |  Minor | logging, Operability, Replication |
+| [HBASE-26232](https://issues.apache.org/jira/browse/HBASE-26232) | SEEK\_NEXT\_USING\_HINT is ignored on reversed Scans |  Critical | Filters, scan |
+| [HBASE-26204](https://issues.apache.org/jira/browse/HBASE-26204) | VerifyReplication should obtain token for peerQuorumAddress too |  Major | . |
+| [HBASE-26219](https://issues.apache.org/jira/browse/HBASE-26219) | Negative time is logged while waiting on regionservers |  Trivial | . |
+| [HBASE-26184](https://issues.apache.org/jira/browse/HBASE-26184) | TestTableSnapshotScanner.testMergeRegion error message is misleading. |  Minor | . |
+| [HBASE-26087](https://issues.apache.org/jira/browse/HBASE-26087) | JVM crash when displaying RPC params by MonitoredRPCHandler |  Major | UI |
+| [HBASE-26200](https://issues.apache.org/jira/browse/HBASE-26200) | Undo 'HBASE-25165 Change 'State time' in UI so sorts (#2508)' in favor of HBASE-24652 |  Major | UI |
+| [HBASE-26196](https://issues.apache.org/jira/browse/HBASE-26196) | Support configuration override for remote cluster of HFileOutputFormat locality sensitive |  Major | mapreduce |
+| [HBASE-26026](https://issues.apache.org/jira/browse/HBASE-26026) | HBase Write may be stuck forever when using CompactingMemStore |  Critical | in-memory-compaction |
+| [HBASE-26176](https://issues.apache.org/jira/browse/HBASE-26176) | Correct regex in hbase-personality.sh |  Minor | build |
+| [HBASE-26170](https://issues.apache.org/jira/browse/HBASE-26170) | handleTooBigRequest in NettyRpcServer didn't skip enough bytes |  Major | . |
+| [HBASE-26142](https://issues.apache.org/jira/browse/HBASE-26142) | NullPointerException when set 'hbase.hregion.memstore.mslab.indexchunksize.percent' to zero |  Critical | . |
+| [HBASE-25651](https://issues.apache.org/jira/browse/HBASE-25651) | NORMALIZER\_TARGET\_REGION\_SIZE needs a unit in its name |  Major | Normalizer |
+| [HBASE-26166](https://issues.apache.org/jira/browse/HBASE-26166) | table list in master ui has a minor bug |  Minor | UI |
+| [HBASE-26107](https://issues.apache.org/jira/browse/HBASE-26107) | MOB compaction with missing files catches incorrect exception |  Major | mob |
+| [HBASE-24984](https://issues.apache.org/jira/browse/HBASE-24984) | WAL corruption due to early DBBs re-use when Durability.ASYNC\_WAL is used with multi operation |  Critical | rpc, wal |
+| [HBASE-25973](https://issues.apache.org/jira/browse/HBASE-25973) | Balancer should explain progress in a better way in log |  Major | Balancer |
+| [HBASE-26083](https://issues.apache.org/jira/browse/HBASE-26083) | L1 miss metric is incorrect when using CombinedBlockCache |  Minor | BlockCache |
+| [HBASE-26068](https://issues.apache.org/jira/browse/HBASE-26068) | The last assertion in TestHStore.testRefreshStoreFilesNotChanged is wrong |  Major | test |
+
+
+### TESTS:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-26542](https://issues.apache.org/jira/browse/HBASE-26542) | Apply a \`package\` to test protobuf files |  Minor | Protobufs, test |
+| [HBASE-26349](https://issues.apache.org/jira/browse/HBASE-26349) | Improve recent change to IntegrationTestLoadCommonCrawl |  Minor | integration tests, test |
+| [HBASE-26335](https://issues.apache.org/jira/browse/HBASE-26335) | Minor improvements to IntegrationTestLoadCommonCrawl |  Minor | integration tests, test |
+| [HBASE-26185](https://issues.apache.org/jira/browse/HBASE-26185) | Fix TestMaster#testMoveRegionWhenNotInitialized with hbase.min.version.move.system.tables |  Minor | . |
+
+
+### SUB-TASKS:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-26472](https://issues.apache.org/jira/browse/HBASE-26472) | Adhere to semantic conventions regarding table data operations |  Major | . |
+| [HBASE-26572](https://issues.apache.org/jira/browse/HBASE-26572) | Upgrade to log4j 2.16.0 |  Major | dependencies |
+| [HBASE-26558](https://issues.apache.org/jira/browse/HBASE-26558) | Set version as 3.0.0-alpha-2 in master in prep for first RC of 3.0.0-alpha-2 |  Major | build, pom |
+| [HBASE-26304](https://issues.apache.org/jira/browse/HBASE-26304) | Reflect out-of-band locality improvements in served requests |  Major | . |
+| [HBASE-26471](https://issues.apache.org/jira/browse/HBASE-26471) | Move tracing semantic attributes to their own class |  Major | . |
+| [HBASE-26403](https://issues.apache.org/jira/browse/HBASE-26403) | Remove 1.4.x from our download page |  Major | website |
+| [HBASE-26327](https://issues.apache.org/jira/browse/HBASE-26327) | Replicas cohosted on a rack shouldn't keep triggering Balancer |  Major | Balancer |
+| [HBASE-26308](https://issues.apache.org/jira/browse/HBASE-26308) | Sum of multiplier of cost functions is not populated properly when we have a shortcut for trigger |  Critical | Balancer |
+| [HBASE-26430](https://issues.apache.org/jira/browse/HBASE-26430) | Increase DefaultHeapMemoryTuner log level |  Minor | regionserver |
+| [HBASE-26402](https://issues.apache.org/jira/browse/HBASE-26402) | Remove branch-1.4 from compatibility matrix and release manager section in our ref guide |  Major | documentation |
+| [HBASE-26353](https://issues.apache.org/jira/browse/HBASE-26353) | Support loadable dictionaries in hbase-compression-zstd |  Minor | . |
+| [HBASE-26319](https://issues.apache.org/jira/browse/HBASE-26319) | Make flaky find job track more builds |  Major | flakies, jenkins |
+| [HBASE-26395](https://issues.apache.org/jira/browse/HBASE-26395) | Add 1.4.14 to download page |  Major | website |
+| [HBASE-26390](https://issues.apache.org/jira/browse/HBASE-26390) | Upload src tarball to nightlies for nightly jobs |  Major | jenkins, scripts |
+| [HBASE-26382](https://issues.apache.org/jira/browse/HBASE-26382) | Use gen\_redirect\_html for linking flaky test logs |  Major | jenkins, scripts, test |
+| [HBASE-26362](https://issues.apache.org/jira/browse/HBASE-26362) | Upload mvn site artifacts for nightly build to nightlies |  Major | jenkins, scripts |
+| [HBASE-26380](https://issues.apache.org/jira/browse/HBASE-26380) | Add 2.3.7 to downloads page |  Major | website |
+| [HBASE-26316](https://issues.apache.org/jira/browse/HBASE-26316) | Per-table or per-CF compression codec setting overrides |  Minor | HFile, Operability |
+| [HBASE-26360](https://issues.apache.org/jira/browse/HBASE-26360) | Use gen\_redirect\_html for linking test logs |  Major | jenkins, scripts |
+| [HBASE-26341](https://issues.apache.org/jira/browse/HBASE-26341) | Upload dashboard html for flaky find job to nightlies |  Major | flakies, jenkins, scripts |
+| [HBASE-26339](https://issues.apache.org/jira/browse/HBASE-26339) | SshPublisher will skip uploading artifacts if the build is failure |  Major | jenkins, scripts |
+| [HBASE-26324](https://issues.apache.org/jira/browse/HBASE-26324) | Reuse compressors and decompressors in WAL CompressionContext |  Minor | wal |
+| [HBASE-26317](https://issues.apache.org/jira/browse/HBASE-26317) | Publish the test logs for pre commit jenkins job to nightlies |  Major | jenkins, scripts |
+| [HBASE-26313](https://issues.apache.org/jira/browse/HBASE-26313) | Publish the test logs for our nightly jobs to nightlies.apache.org |  Major | jenkins, scripts |
+| [HBASE-26318](https://issues.apache.org/jira/browse/HBASE-26318) | Publish test logs for flaky jobs to nightlies |  Major | flakies, jenkins |
+| [HBASE-26259](https://issues.apache.org/jira/browse/HBASE-26259) | Fallback support to pure Java compression |  Major | Performance |
+| [HBASE-26220](https://issues.apache.org/jira/browse/HBASE-26220) | Use P2P communicate between region servers to sync the list for bootstrap node |  Major | master, regionserver |
+| [HBASE-26293](https://issues.apache.org/jira/browse/HBASE-26293) | Use reservoir sampling when selecting bootstrap nodes |  Major | master, regionserver |
+| [HBASE-25288](https://issues.apache.org/jira/browse/HBASE-25288) | Make MasterRpcServices not extends RSRpcServices and also HMaster not extends HRegionServer |  Major | master, rpc |
+| [HBASE-26277](https://issues.apache.org/jira/browse/HBASE-26277) | Revert 26240, Apply InterfaceAudience.Private to BalanceResponse$Builder |  Minor | . |
+| [HBASE-26240](https://issues.apache.org/jira/browse/HBASE-26240) | Set BalanceRequest$Builder to InterfaceAudience.Private |  Trivial | . |
+| [HBASE-26237](https://issues.apache.org/jira/browse/HBASE-26237) | Improve computation complexity for primaryRegionCountSkewCostFunctio |  Minor | Balancer |
+| [HBASE-26230](https://issues.apache.org/jira/browse/HBASE-26230) | Start an in process HRegionServer in maintenance mode |  Major | master |
+| [HBASE-26157](https://issues.apache.org/jira/browse/HBASE-26157) | Expose some IA.LimitedPrivate interface in TestingHBaseCluster |  Major | API, test |
+| [HBASE-26103](https://issues.apache.org/jira/browse/HBASE-26103) | conn.getBufferedMutator(tableName) leaks thread executors and other problems (for master branch) |  Major | Client |
+| [HBASE-26235](https://issues.apache.org/jira/browse/HBASE-26235) | We could start RegionServerTracker before becoming active master |  Major | master, Zookeeper |
+| [HBASE-26216](https://issues.apache.org/jira/browse/HBASE-26216) | Move HRegionServer.abort(String) to Abortable as a default method |  Major | API, regionserver |
+| [HBASE-26189](https://issues.apache.org/jira/browse/HBASE-26189) | Reduce log level of CompactionProgress notice to DEBUG |  Minor | Compaction |
+| [HBASE-26227](https://issues.apache.org/jira/browse/HBASE-26227) | Forward port HBASE-26223 test code to branch-2.4+ |  Major | test |
+| [HBASE-26214](https://issues.apache.org/jira/browse/HBASE-26214) | Introduce a ConnectionRegistryEndpoint interface |  Major | master, regionserver |
+| [HBASE-26180](https://issues.apache.org/jira/browse/HBASE-26180) | Introduce a initial refresh interval for RpcConnectionRegistry |  Major | Client |
+| [HBASE-26213](https://issues.apache.org/jira/browse/HBASE-26213) | Refactor AnnotationReadingPriorityFunction |  Major | master, regionserver, rpc |
+| [HBASE-26215](https://issues.apache.org/jira/browse/HBASE-26215) | The backup master status page should use ActiveMasterManager instead of MasterAddressTracker |  Major | master, UI |
+| [HBASE-26173](https://issues.apache.org/jira/browse/HBASE-26173) | Return only a sub set of region servers as bootstrap nodes |  Major | Client |
+| [HBASE-26182](https://issues.apache.org/jira/browse/HBASE-26182) | Allow disabling refresh of connection registry endpoint |  Major | Client |
+| [HBASE-26181](https://issues.apache.org/jira/browse/HBASE-26181) | Region server and master could use itself as ConnectionRegistry |  Major | master, regionserver |
+| [HBASE-26174](https://issues.apache.org/jira/browse/HBASE-26174) | Make rpc connection registry the default registry on 3.0.0 |  Major | Client |
+| [HBASE-26172](https://issues.apache.org/jira/browse/HBASE-26172) | Deprecate MasterRegistry |  Major | Client |
+| [HBASE-26150](https://issues.apache.org/jira/browse/HBASE-26150) | Let region server also carry ClientMetaService |  Major | Client, meta |
+| [HBASE-26151](https://issues.apache.org/jira/browse/HBASE-26151) | Reimplement MasterAddressTracker to also cache backup master addresses |  Major | Client, Zookeeper |
+| [HBASE-26098](https://issues.apache.org/jira/browse/HBASE-26098) | Support passing a customized Configuration object when creating TestingHBaseCluster |  Major | API, test |
+| [HBASE-26096](https://issues.apache.org/jira/browse/HBASE-26096) | Cleanup the deprecated methods in HBTU related classes and format code |  Major | test |
+| [HBASE-26049](https://issues.apache.org/jira/browse/HBASE-26049) | Remove DfsBuilderUtility |  Major | . |
+| [HBASE-26091](https://issues.apache.org/jira/browse/HBASE-26091) | Remove FirstKeyValueMatchingQualifiersFilter |  Major | Client |
+| [HBASE-26093](https://issues.apache.org/jira/browse/HBASE-26093) | Replication is stuck due to zero length wal file in oldWALs directory [master/branch-2] |  Major | . |
+| [HBASE-24734](https://issues.apache.org/jira/browse/HBASE-24734) | RegionInfo#containsRange should support check meta table |  Major | HFile, MTTR |
+| [HBASE-26100](https://issues.apache.org/jira/browse/HBASE-26100) | Set version as 3.0.0-alpha-2-SNAPSHOT in master |  Major | build, pom |
+| [HBASE-26099](https://issues.apache.org/jira/browse/HBASE-26099) | Add 3.0.0-alpha-1 to download page |  Major | website |
+| [HBASE-26081](https://issues.apache.org/jira/browse/HBASE-26081) | Copy HBTU to hbase-testing-util, rename the HBTU related classes in hbase-server and mark them as IA.LimitedPrivate |  Major | API, test |
+| [HBASE-25739](https://issues.apache.org/jira/browse/HBASE-25739) | TableSkewCostFunction need to use aggregated deviation |  Major | Balancer, master |
+| [HBASE-26090](https://issues.apache.org/jira/browse/HBASE-26090) | Remove the deprecated methods in Scan which should be removed in 3.0.0 |  Major | API, Client, scan |
+| [HBASE-26082](https://issues.apache.org/jira/browse/HBASE-26082) | Mark LocalHBaseCluster as IA.Private |  Major | API, test |
+| [HBASE-26080](https://issues.apache.org/jira/browse/HBASE-26080) | Implement a new mini cluster class for end users |  Major | API, test |
+| [HBASE-25516](https://issues.apache.org/jira/browse/HBASE-25516) | [JDK17] reflective access Field.class.getDeclaredField("modifiers") not supported |  Major | Filesystem Integration |
+
+
+### OTHER:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-26606](https://issues.apache.org/jira/browse/HBASE-26606) | Upgrade log4j2 to 2.17.0 |  Major | logging, security |
+| [HBASE-26580](https://issues.apache.org/jira/browse/HBASE-26580) | The message of StoreTooBusy is confused |  Trivial | logging, regionserver |
+| [HBASE-26549](https://issues.apache.org/jira/browse/HBASE-26549) | hbaseprotoc plugin should initialize maven |  Major | jenkins |
+| [HBASE-26529](https://issues.apache.org/jira/browse/HBASE-26529) | Document HBASE-26524 to section of Dynamic Unloading |  Minor | Coprocessors, shell |
+| [HBASE-26490](https://issues.apache.org/jira/browse/HBASE-26490) | Add builder for class ReplicationLoadSink |  Minor | Client |
+| [HBASE-26484](https://issues.apache.org/jira/browse/HBASE-26484) | Update vote.tmpl in our create-release scripts to link KEYS from downloads.a.o instead of dist.a.o |  Major | community |
+| [HBASE-26444](https://issues.apache.org/jira/browse/HBASE-26444) | BucketCacheWriter should log only the BucketAllocatorException message, not the full stack trace |  Major | logging, Operability |
+| [HBASE-26443](https://issues.apache.org/jira/browse/HBASE-26443) | Some BaseLoadBalancer log lines should be at DEBUG level |  Major | logging, Operability |
+| [HBASE-26426](https://issues.apache.org/jira/browse/HBASE-26426) | Remove 'Review Board' section from the site |  Major | website |
+| [HBASE-26431](https://issues.apache.org/jira/browse/HBASE-26431) | Add hadoop 3.3.x to our hadoop version support matrix |  Major | documentation, hadoop3 |
+| [HBASE-26428](https://issues.apache.org/jira/browse/HBASE-26428) | Add hadoop 2.10.1, 3.2.2 and 3.3.1 to our hadoop checks |  Major | jenkins, test |
+| [HBASE-26427](https://issues.apache.org/jira/browse/HBASE-26427) | Modify download page to mention that 2.4.x is the stable release line |  Major | website |
+| [HBASE-26369](https://issues.apache.org/jira/browse/HBASE-26369) | Fix checkstyle issues for HBase-common: KeyValue and ByteBufferUtils |  Trivial | . |
+| [HBASE-26368](https://issues.apache.org/jira/browse/HBASE-26368) | Fix checkstyle issues for HRegionserver |  Trivial | . |
+| [HBASE-26359](https://issues.apache.org/jira/browse/HBASE-26359) | Loosen Dockerfile pinned package versions for \`create-release/mac-sshd-gpg-agent/Dockerfile\` |  Major | build, community |
+| [HBASE-26345](https://issues.apache.org/jira/browse/HBASE-26345) | Design doc for HBase NamedQueue framework |  Major | . |
+| [HBASE-26329](https://issues.apache.org/jira/browse/HBASE-26329) | Upgrade commons-io to 2.11.0 |  Major | dependencies |
+| [HBASE-26186](https://issues.apache.org/jira/browse/HBASE-26186) | jenkins script for caching artifacts should verify cached file before relying on it |  Major | build, integration tests |
+| [HBASE-26321](https://issues.apache.org/jira/browse/HBASE-26321) | Post blog to hbase.apache.org on SCR cache sizing |  Major | . |
+| [HBASE-26288](https://issues.apache.org/jira/browse/HBASE-26288) | Revisit the usage of MetaTableLocator when HRegionServer.TEST\_SKIP\_REPORTING\_TRANSITION is true |  Major | meta, regionserver, test, Zookeeper |
+| [HBASE-26285](https://issues.apache.org/jira/browse/HBASE-26285) | Remove MetaTableLocator usages in non-migration code |  Major | meta, Zookeeper |
+| [HBASE-26282](https://issues.apache.org/jira/browse/HBASE-26282) | Update downloads.xml for release 2.4.6 |  Minor | website |
+| [HBASE-26165](https://issues.apache.org/jira/browse/HBASE-26165) | 2.3.5 listed on website downloads page but row intends to be for 2.3.6 |  Trivial | website |
+| [HBASE-25521](https://issues.apache.org/jira/browse/HBASE-25521) | Change ChoreService and ScheduledChore to IA.Private |  Major | util |
+
+
+## Release 3.0.0-alpha-1 - Unreleased (as of 2021-07-04)
+
+
+
+### IMPORTANT ISSUES:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-19848](https://issues.apache.org/jira/browse/HBASE-19848) | Zookeeper thread leaks in hbase-spark bulkLoad method |  Major | spark, Zookeeper |
+
+
+### NEW FEATURES:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-25841](https://issues.apache.org/jira/browse/HBASE-25841) | Add basic jshell support |  Minor | shell, Usability |
+| [HBASE-22120](https://issues.apache.org/jira/browse/HBASE-22120) | Replace HTrace with OpenTelemetry |  Major | tracing |
+| [HBASE-25756](https://issues.apache.org/jira/browse/HBASE-25756) | Support alternate compression for major and minor compactions |  Minor | Compaction |
+| [HBASE-25751](https://issues.apache.org/jira/browse/HBASE-25751) | Add writable TimeToPurgeDeletes to ScanOptions |  Major | . |
+| [HBASE-25665](https://issues.apache.org/jira/browse/HBASE-25665) | Disable reverse DNS lookup for SASL Kerberos client connection |  Major | . |
+| [HBASE-25587](https://issues.apache.org/jira/browse/HBASE-25587) | [hbck2] Schedule SCP for all unknown servers |  Major | hbase-operator-tools, hbck2 |
+| [HBASE-25460](https://issues.apache.org/jira/browse/HBASE-25460) | Expose drainingServers as cluster metric |  Major | metrics |
+| [HBASE-25496](https://issues.apache.org/jira/browse/HBASE-25496) | add get\_namespace\_rsgroup command |  Major | . |
+| [HBASE-24620](https://issues.apache.org/jira/browse/HBASE-24620) | Add a ClusterManager which submits command to ZooKeeper and its Agent which picks and execute those Commands. |  Major | integration tests |
+| [HBASE-25242](https://issues.apache.org/jira/browse/HBASE-25242) | Add Increment/Append support to RowMutations |  Critical | Client, regionserver |
+| [HBASE-25278](https://issues.apache.org/jira/browse/HBASE-25278) | Add option to toggle CACHE\_BLOCKS in count.rb |  Minor | shell |
+| [HBASE-18070](https://issues.apache.org/jira/browse/HBASE-18070) | Enable memstore replication for meta replica |  Critical | . |
+| [HBASE-24528](https://issues.apache.org/jira/browse/HBASE-24528) | Improve balancer decision observability |  Major | Admin, Balancer, Operability, shell, UI |
+| [HBASE-24776](https://issues.apache.org/jira/browse/HBASE-24776) | [hbtop] Support Batch mode |  Major | hbtop |
+| [HBASE-24602](https://issues.apache.org/jira/browse/HBASE-24602) | Add Increment and Append support to CheckAndMutate |  Major | . |
+| [HBASE-24760](https://issues.apache.org/jira/browse/HBASE-24760) | Add a config hbase.rsgroup.fallback.enable for RSGroup fallback feature |  Major | rsgroup |
+| [HBASE-24694](https://issues.apache.org/jira/browse/HBASE-24694) | Support flush a single column family of table |  Major | . |
+| [HBASE-24289](https://issues.apache.org/jira/browse/HBASE-24289) | Heterogeneous Storage for Date Tiered Compaction |  Major | Compaction |
+| [HBASE-24038](https://issues.apache.org/jira/browse/HBASE-24038) | Add a metric to show the locality of ssd in table.jsp |  Major | metrics |
+| [HBASE-8458](https://issues.apache.org/jira/browse/HBASE-8458) | Support for batch version of checkAndMutate() |  Major | Client, regionserver |
+| [HBASE-18659](https://issues.apache.org/jira/browse/HBASE-18659) | Use HDFS ACL to give user the ability to read snapshot directly on HDFS |  Major | . |
+| [HBASE-24260](https://issues.apache.org/jira/browse/HBASE-24260) | Add a ClusterManager that issues commands via coprocessor |  Major | integration tests |
+| [HBASE-24267](https://issues.apache.org/jira/browse/HBASE-24267) | Add limit support for scan in rest api |  Major | REST |
+| [HBASE-22749](https://issues.apache.org/jira/browse/HBASE-22749) | Distributed MOB compactions |  Major | mob |
+| [HBASE-22285](https://issues.apache.org/jira/browse/HBASE-22285) | A normalizer which merges very small size regions with adjacent regions.(MergeToNormalize) |  Minor | master, Normalizer |
+| [HBASE-22978](https://issues.apache.org/jira/browse/HBASE-22978) | Online slow response log |  Minor | Admin, Operability, regionserver, shell |
+| [HBASE-23146](https://issues.apache.org/jira/browse/HBASE-23146) | Support CheckAndMutate with multiple conditions |  Major | . |
+| [HBASE-18095](https://issues.apache.org/jira/browse/HBASE-18095) | Provide an option for clients to find the server hosting META that does not involve the ZooKeeper client |  Major | Client |
+| [HBASE-23710](https://issues.apache.org/jira/browse/HBASE-23710) | Priority configuration for system coprocessors |  Major | Coprocessors |
+| [HBASE-23653](https://issues.apache.org/jira/browse/HBASE-23653) | Expose content of meta table in web ui |  Minor | master, Operability, UI |
+| [HBASE-23073](https://issues.apache.org/jira/browse/HBASE-23073) | Add an optional costFunction to balance regions according to a capacity rule |  Minor | master |
+| [HBASE-22280](https://issues.apache.org/jira/browse/HBASE-22280) | Separate read/write handler for priority request(especially for meta). |  Major | Scheduler |
+| [HBASE-22969](https://issues.apache.org/jira/browse/HBASE-22969) | A new binary component comparator(BinaryComponentComparator) to perform comparison of arbitrary length and position |  Minor | Filters |
+| [HBASE-23223](https://issues.apache.org/jira/browse/HBASE-23223) | Support the offsetLock of bucketCache to use strong reference |  Major | BucketCache |
+| [HBASE-21874](https://issues.apache.org/jira/browse/HBASE-21874) | Bucket cache on Persistent memory |  Major | BucketCache |
+| [HBASE-11062](https://issues.apache.org/jira/browse/HBASE-11062) | hbtop |  Major | hbtop |
+| [HBASE-22623](https://issues.apache.org/jira/browse/HBASE-22623) | Add RegionObserver coprocessor hook for preWALAppend |  Major | . |
+| [HBASE-15666](https://issues.apache.org/jira/browse/HBASE-15666) | shaded dependencies for hbase-testing-util |  Critical | test |
+| [HBASE-22313](https://issues.apache.org/jira/browse/HBASE-22313) | Add a method to FsDelegationToken to accept token kind |  Minor | security |
+| [HBASE-22648](https://issues.apache.org/jira/browse/HBASE-22648) | Snapshot TTL |  Minor | snapshots |
+| [HBASE-22622](https://issues.apache.org/jira/browse/HBASE-22622) | WALKey Extended Attributes |  Major | wal |
+| [HBASE-22148](https://issues.apache.org/jira/browse/HBASE-22148) | Provide an alternative to CellUtil.setTimestamp |  Blocker | API, Coprocessors |
+| [HBASE-21815](https://issues.apache.org/jira/browse/HBASE-21815) | Make isTrackingMetrics and getMetrics of ScannerContext public |  Minor | . |
+| [HBASE-21926](https://issues.apache.org/jira/browse/HBASE-21926) | Profiler servlet |  Major | master, Operability, regionserver |
+| [HBASE-20886](https://issues.apache.org/jira/browse/HBASE-20886) | [Auth] Support keytab login in hbase client |  Critical | asyncclient, Client, security |
+| [HBASE-17942](https://issues.apache.org/jira/browse/HBASE-17942) | Disable region splits and merges per table |  Major | . |
+| [HBASE-21753](https://issues.apache.org/jira/browse/HBASE-21753) | Support getting the locations for all the replicas of a region |  Major | Client |
+| [HBASE-20727](https://issues.apache.org/jira/browse/HBASE-20727) | Persist FlushedSequenceId to speed up WAL split after cluster restart |  Major | . |
+| [HBASE-20636](https://issues.apache.org/jira/browse/HBASE-20636) | Introduce two bloom filter type : ROWPREFIX\_FIXED\_LENGTH and ROWPREFIX\_DELIMITED |  Major | HFile, regionserver, Scanners |
+| [HBASE-20649](https://issues.apache.org/jira/browse/HBASE-20649) | Validate HFiles do not have PREFIX\_TREE DataBlockEncoding |  Minor | Operability, tooling |
+| [HBASE-20833](https://issues.apache.org/jira/browse/HBASE-20833) | Modify pre-upgrade coprocessor validator to support table level coprocessors |  Major | Coprocessors |
+| [HBASE-15809](https://issues.apache.org/jira/browse/HBASE-15809) | Basic Replication WebUI |  Critical | Replication, UI |
+| [HBASE-19064](https://issues.apache.org/jira/browse/HBASE-19064) | Synchronous replication for HBase |  Major | Replication |
+| [HBASE-19735](https://issues.apache.org/jira/browse/HBASE-19735) | Create a minimal "client" tarball installation |  Major | build, Client |
+| [HBASE-20630](https://issues.apache.org/jira/browse/HBASE-20630) | B&R: Delete command enhancements |  Major | . |
+| [HBASE-20656](https://issues.apache.org/jira/browse/HBASE-20656) | Validate pre-2.0 coprocessors against HBase 2.0+ |  Major | tooling |
+| [HBASE-20592](https://issues.apache.org/jira/browse/HBASE-20592) | Create a tool to verify tables do not have prefix tree encoding |  Minor | Operability, tooling |
+| [HBASE-20046](https://issues.apache.org/jira/browse/HBASE-20046) | Reconsider the implementation for serial replication |  Major | Replication |
+| [HBASE-20159](https://issues.apache.org/jira/browse/HBASE-20159) | Support using separate ZK quorums for client |  Major | Client, Operability, Zookeeper |
+| [HBASE-19397](https://issues.apache.org/jira/browse/HBASE-19397) | Design  procedures for ReplicationManager to notify peer change event from master |  Major | proc-v2, Replication |
+| [HBASE-17933](https://issues.apache.org/jira/browse/HBASE-17933) | [hbase-spark]  Support Java api for bulkload |  Major | hbase-connectors, spark |
+| [HBASE-15572](https://issues.apache.org/jira/browse/HBASE-15572) | Adding optional timestamp semantics to HBase-Spark |  Major | hbase-connectors, spark |
+| [HBASE-14849](https://issues.apache.org/jira/browse/HBASE-14849) | Add option to set block cache to false on SparkSQL executions |  Major | hbase-connectors, spark |
+| [HBASE-14340](https://issues.apache.org/jira/browse/HBASE-14340) | Add second bulk load option to Spark Bulk Load to send puts as the value |  Minor | hbase-connectors, spark |
+| [HBASE-14181](https://issues.apache.org/jira/browse/HBASE-14181) | Add Spark DataFrame DataSource to HBase-Spark Module |  Minor | hbase-connectors, spark |
+| [HBASE-14150](https://issues.apache.org/jira/browse/HBASE-14150) | Add BulkLoad functionality to HBase-Spark Module |  Major | hbase-connectors, spark |
+| [HBASE-13992](https://issues.apache.org/jira/browse/HBASE-13992) | Integrate SparkOnHBase into HBase |  Major | hbase-connectors, spark |
+
+
+### IMPROVEMENTS:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-25914](https://issues.apache.org/jira/browse/HBASE-25914) | Provide slow/large logs on RegionServer UI |  Major | regionserver, UI |
+| [HBASE-26012](https://issues.apache.org/jira/browse/HBASE-26012) | Improve logging and dequeue logic in DelayQueue |  Minor | . |
+| [HBASE-26020](https://issues.apache.org/jira/browse/HBASE-26020) | Split TestWALEntryStream.testDifferentCounts out |  Major | Replication, test |
+| [HBASE-25937](https://issues.apache.org/jira/browse/HBASE-25937) | Clarify UnknownRegionException |  Minor | Client |
+| [HBASE-25998](https://issues.apache.org/jira/browse/HBASE-25998) | Revisit synchronization in SyncFuture |  Major | Performance, regionserver, wal |
+| [HBASE-26000](https://issues.apache.org/jira/browse/HBASE-26000) | Optimize the display of ZK dump in the master web UI |  Minor | . |
+| [HBASE-25995](https://issues.apache.org/jira/browse/HBASE-25995) | Change the method name for DoubleArrayCost.setCosts |  Major | Balancer |
+| [HBASE-26002](https://issues.apache.org/jira/browse/HBASE-26002) | MultiRowMutationEndpoint should return the result of the conditional update |  Major | Coprocessors |
+| [HBASE-25993](https://issues.apache.org/jira/browse/HBASE-25993) | Make excluded SSL cipher suites configurable for all Web UIs |  Major | . |
+| [HBASE-25987](https://issues.apache.org/jira/browse/HBASE-25987) | Make SSL keystore type configurable for HBase ThriftServer |  Major | Thrift |
+| [HBASE-25666](https://issues.apache.org/jira/browse/HBASE-25666) | Explain why balancer is skipping runs |  Major | Balancer, master, UI |
+| [HBASE-25942](https://issues.apache.org/jira/browse/HBASE-25942) | Get rid of null regioninfo in wrapped connection exceptions |  Trivial | logging |
+| [HBASE-25745](https://issues.apache.org/jira/browse/HBASE-25745) | Deprecate/Rename config \`hbase.normalizer.min.region.count\` to \`hbase.normalizer.merge.min.region.count\` |  Minor | master, Normalizer |
+| [HBASE-25908](https://issues.apache.org/jira/browse/HBASE-25908) | Exclude jakarta.activation-api |  Major | hadoop3, shading |
+| [HBASE-25933](https://issues.apache.org/jira/browse/HBASE-25933) | Log trace raw exception, instead of cause message in NettyRpcServerRequestDecoder |  Minor | . |
+| [HBASE-25534](https://issues.apache.org/jira/browse/HBASE-25534) | Honor TableDescriptor settings earlier in normalization |  Major | Normalizer |
+| [HBASE-25906](https://issues.apache.org/jira/browse/HBASE-25906) | UI of master-status to show recent history of balancer desicion |  Major | Balancer, master, UI |
+| [HBASE-25899](https://issues.apache.org/jira/browse/HBASE-25899) | Improve efficiency of SnapshotHFileCleaner |  Major | master |
+| [HBASE-25682](https://issues.apache.org/jira/browse/HBASE-25682) | Add a new command to update the configuration of all RSs in a RSGroup |  Major | Admin, shell |
+| [HBASE-25032](https://issues.apache.org/jira/browse/HBASE-25032) | Do not assign regions to region server which has not called regionServerReport yet |  Major | . |
+| [HBASE-25860](https://issues.apache.org/jira/browse/HBASE-25860) | Add metric for successful wal roll requests. |  Major | metrics, wal |
+| [HBASE-25816](https://issues.apache.org/jira/browse/HBASE-25816) | Improve the documentation of "Architecture" section of reference guide |  Minor | documentation |
+| [HBASE-25754](https://issues.apache.org/jira/browse/HBASE-25754) | StripeCompactionPolicy should support compacting cold regions |  Minor | Compaction |
+| [HBASE-25766](https://issues.apache.org/jira/browse/HBASE-25766) | Introduce RegionSplitRestriction that restricts the pattern of the split point |  Major | . |
+| [HBASE-25798](https://issues.apache.org/jira/browse/HBASE-25798) | typo in MetricsAssertHelper |  Minor | . |
+| [HBASE-25770](https://issues.apache.org/jira/browse/HBASE-25770) | Http InfoServers should honor gzip encoding when requested |  Major | UI |
+| [HBASE-25776](https://issues.apache.org/jira/browse/HBASE-25776) | Use Class.asSubclass to fix the warning in StochasticLoadBalancer.loadCustomCostFunctions |  Minor | Balancer |
+| [HBASE-25767](https://issues.apache.org/jira/browse/HBASE-25767) | CandidateGenerator.getRandomIterationOrder is too slow on large cluster |  Major | Balancer, Performance |
+| [HBASE-25762](https://issues.apache.org/jira/browse/HBASE-25762) | Improvement for some debug-logging guards |  Minor | logging, Performance |
+| [HBASE-25653](https://issues.apache.org/jira/browse/HBASE-25653) | Add units and round off region size to 2 digits after decimal |  Major | master, Normalizer |
+| [HBASE-25482](https://issues.apache.org/jira/browse/HBASE-25482) | Improve SimpleRegionNormalizer#getAverageRegionSizeMb |  Minor | Normalizer |
+| [HBASE-25759](https://issues.apache.org/jira/browse/HBASE-25759) | The master services field in LocalityBasedCostFunction is never used |  Major | Balancer |
+| [HBASE-25744](https://issues.apache.org/jira/browse/HBASE-25744) | Change default of \`hbase.normalizer.merge.min\_region\_size.mb\` to \`0\` |  Major | master, Normalizer |
+| [HBASE-25747](https://issues.apache.org/jira/browse/HBASE-25747) | Remove unused getWriteAvailable method in OperationQuota |  Minor | Quotas |
+| [HBASE-25558](https://issues.apache.org/jira/browse/HBASE-25558) | Adding audit log for execMasterService |  Major | . |
+| [HBASE-25703](https://issues.apache.org/jira/browse/HBASE-25703) | Support conditional update in MultiRowMutationEndpoint |  Major | Coprocessors |
+| [HBASE-25705](https://issues.apache.org/jira/browse/HBASE-25705) | Convert proto to RSGroupInfo is costly |  Minor | rsgroup |
+| [HBASE-25702](https://issues.apache.org/jira/browse/HBASE-25702) | Remove RowProcessor |  Major | . |
+| [HBASE-25686](https://issues.apache.org/jira/browse/HBASE-25686) | [hbtop] Add some javadoc |  Minor | hbtop |
+| [HBASE-25627](https://issues.apache.org/jira/browse/HBASE-25627) | HBase replication should have a metric to represent if the source is stuck getting initialized |  Major | Replication |
+| [HBASE-25688](https://issues.apache.org/jira/browse/HBASE-25688) | Use CustomRequestLog instead of Slf4jRequestLog for jetty |  Major | logging, UI |
+| [HBASE-25678](https://issues.apache.org/jira/browse/HBASE-25678) | Support nonce operations for Increment/Append in RowMutations and CheckAndMutate |  Major | . |
+| [HBASE-25518](https://issues.apache.org/jira/browse/HBASE-25518) | Support separate child regions to different region servers |  Major | . |
+| [HBASE-25643](https://issues.apache.org/jira/browse/HBASE-25643) | The delayed FlushRegionEntry should be removed when we need a non-delayed one |  Major | regionserver |
+| [HBASE-25608](https://issues.apache.org/jira/browse/HBASE-25608) | Support HFileOutputFormat locality sensitive even destination cluster is different from source cluster |  Major | . |
+| [HBASE-25621](https://issues.apache.org/jira/browse/HBASE-25621) | Balancer should check region plan source to avoid misplace region groups |  Major | Balancer |
+| [HBASE-25374](https://issues.apache.org/jira/browse/HBASE-25374) | Make REST Client connection and socket time out configurable |  Minor | REST |
+| [HBASE-25597](https://issues.apache.org/jira/browse/HBASE-25597) | Add row info in Exception when cell size exceeds maxCellSize |  Minor | . |
+| [HBASE-25660](https://issues.apache.org/jira/browse/HBASE-25660) | Print split policy in use on Region open (as well as split policy vitals) |  Trivial | . |
+| [HBASE-25635](https://issues.apache.org/jira/browse/HBASE-25635) | CandidateGenerator may miss some region balance actions |  Major | Balancer |
+| [HBASE-25622](https://issues.apache.org/jira/browse/HBASE-25622) | Result#compareResults should compare tags. |  Major | Client |
+| [HBASE-25570](https://issues.apache.org/jira/browse/HBASE-25570) | On largish cluster, "CleanerChore: Could not delete dir..." makes master log unreadable |  Major | . |
+| [HBASE-25566](https://issues.apache.org/jira/browse/HBASE-25566) | RoundRobinTableInputFormat |  Major | mapreduce |
+| [HBASE-25636](https://issues.apache.org/jira/browse/HBASE-25636) | Expose HBCK report as metrics |  Minor | metrics |
+| [HBASE-25548](https://issues.apache.org/jira/browse/HBASE-25548) | Optionally allow snapshots to preserve cluster's max filesize config by setting it into table descriptor |  Major | . |
+| [HBASE-25582](https://issues.apache.org/jira/browse/HBASE-25582) | Support setting scan ReadType to be STREAM at cluster level |  Major | . |
+| [HBASE-25630](https://issues.apache.org/jira/browse/HBASE-25630) | Set switch compaction after bulkload default as false |  Major | . |
+| [HBASE-23578](https://issues.apache.org/jira/browse/HBASE-23578) | [UI] Master UI shows long stack traces when table is broken |  Minor | master, UI |
+| [HBASE-25637](https://issues.apache.org/jira/browse/HBASE-25637) | Rename method completeCompaction to refreshStoreSizeCount |  Minor | . |
+| [HBASE-25603](https://issues.apache.org/jira/browse/HBASE-25603) | Add switch for compaction after bulkload |  Major | Compaction |
+| [HBASE-25539](https://issues.apache.org/jira/browse/HBASE-25539) | Add metric for age of oldest wal. |  Major | metrics, regionserver |
+| [HBASE-25574](https://issues.apache.org/jira/browse/HBASE-25574) | Revisit put/delete/increment/append related RegionObserver methods |  Major | Coprocessors |
+| [HBASE-25541](https://issues.apache.org/jira/browse/HBASE-25541) | In WALEntryStream, set the current path to null while dequeing the log |  Major | . |
+| [HBASE-23887](https://issues.apache.org/jira/browse/HBASE-23887) | New L1 cache : AdaptiveLRU |  Major | BlockCache, Performance |
+| [HBASE-25508](https://issues.apache.org/jira/browse/HBASE-25508) | Add a python example of using the thrift proxy in thrift-over-http mode |  Minor | Thrift |
+| [HBASE-25364](https://issues.apache.org/jira/browse/HBASE-25364) | Redo the getMidPoint() in HFileWriterImpl to get rid of the double comparison process |  Minor | . |
+| [HBASE-25519](https://issues.apache.org/jira/browse/HBASE-25519) | BLOCKSIZE needs to support pretty print |  Major | . |
+| [HBASE-25507](https://issues.apache.org/jira/browse/HBASE-25507) | Leak of ESTABLISHED sockets when compaction encountered "java.io.IOException: Invalid HFile block magic" |  Major | Compaction |
+| [HBASE-24772](https://issues.apache.org/jira/browse/HBASE-24772) | Use GetoptLong or OptionParser in hbase-shell |  Minor | shell |
+| [HBASE-25542](https://issues.apache.org/jira/browse/HBASE-25542) | Add client detail to scan name so when lease expires, we have clue on who was scanning |  Major | scan |
+| [HBASE-25553](https://issues.apache.org/jira/browse/HBASE-25553) | It is better for ReplicationTracker.getListOfRegionServers to return ServerName instead of String |  Major | . |
+| [HBASE-25528](https://issues.apache.org/jira/browse/HBASE-25528) | Dedicated merge dispatch threadpool on master |  Minor | master |
+| [HBASE-25536](https://issues.apache.org/jira/browse/HBASE-25536) | Remove 0 length wal file from logQueue if it belongs to old sources. |  Major | Replication |
+| [HBASE-25506](https://issues.apache.org/jira/browse/HBASE-25506) | ServerManager affects MTTR of HMaster |  Major | master, MTTR |
+| [HBASE-25368](https://issues.apache.org/jira/browse/HBASE-25368) | Filter out more invalid encoded name in isEncodedRegionName(byte[] regionName) |  Major | Client |
+| [HBASE-25329](https://issues.apache.org/jira/browse/HBASE-25329) | Dump region hashes in logs for the regions that are stuck in transition for more than a configured amount of time |  Minor | . |
+| [HBASE-25475](https://issues.apache.org/jira/browse/HBASE-25475) | Improve unit test for HBASE-25445 : SplitWALRemoteProcedure failed to archive split WAL |  Minor | wal |
+| [HBASE-25431](https://issues.apache.org/jira/browse/HBASE-25431) | MAX\_FILESIZE and MEMSTORE\_FLUSHSIZE should not be set negative number |  Major | . |
+| [HBASE-25439](https://issues.apache.org/jira/browse/HBASE-25439) | Add BYTE unit in PrettyPrinter.Unit |  Major | . |
+| [HBASE-25249](https://issues.apache.org/jira/browse/HBASE-25249) | Adding StoreContext |  Major | . |
+| [HBASE-23340](https://issues.apache.org/jira/browse/HBASE-23340) | hmaster  /hbase/replication/rs  session expired (hbase replication default value is true, we don't use ) causes logcleaner can not clean oldWALs, which resulits in oldWALs too large (more than 2TB) |  Major | master |
+| [HBASE-25449](https://issues.apache.org/jira/browse/HBASE-25449) | 'dfs.client.read.shortcircuit' should not be set in hbase-default.xml |  Major | conf |
+| [HBASE-25476](https://issues.apache.org/jira/browse/HBASE-25476) | Enable error prone check in pre commit |  Major | build |
+| [HBASE-25211](https://issues.apache.org/jira/browse/HBASE-25211) | Rack awareness in region\_mover |  Major | . |
+| [HBASE-25483](https://issues.apache.org/jira/browse/HBASE-25483) | set the loadMeta log level to debug. |  Major | MTTR, Region Assignment |
+| [HBASE-25471](https://issues.apache.org/jira/browse/HBASE-25471) | Move RegionScannerImpl out of HRegion |  Major | regionserver |
+| [HBASE-25458](https://issues.apache.org/jira/browse/HBASE-25458) | HRegion methods cleanup |  Major | regionserver |
+| [HBASE-25435](https://issues.apache.org/jira/browse/HBASE-25435) | Slow metric value can be configured |  Minor | metrics |
+| [HBASE-25438](https://issues.apache.org/jira/browse/HBASE-25438) | Update create-release mvn in Dockerfile; its 3.6.0; make it 3.6.3 |  Major | create-release |
+| [HBASE-25318](https://issues.apache.org/jira/browse/HBASE-25318) | Configure where IntegrationTestImportTsv generates HFiles |  Minor | integration tests |
+| [HBASE-25450](https://issues.apache.org/jira/browse/HBASE-25450) | The parameter "hbase.bucketcache.size" is misdescribed |  Major | conf |
+| [HBASE-25437](https://issues.apache.org/jira/browse/HBASE-25437) | Update refguide RC section; point at the dev-tools/create-releases/README.txt rather than repeat its content |  Major | documentation |
+| [HBASE-24751](https://issues.apache.org/jira/browse/HBASE-24751) | Display Task completion time and/or processing duration on Web UI |  Minor | UI |
+| [HBASE-25379](https://issues.apache.org/jira/browse/HBASE-25379) | Make retry pause time configurable for regionserver short operation RPC (reportRegionStateTransition/reportProcedureDone) |  Minor | regionserver |
+| [HBASE-24850](https://issues.apache.org/jira/browse/HBASE-24850) | CellComparator perf improvement |  Critical | Performance, scan |
+| [HBASE-25443](https://issues.apache.org/jira/browse/HBASE-25443) | Improve the experience of using the Master webpage by change the loading process of snapshot list to asynchronous |  Minor | master, UI |
+| [HBASE-24764](https://issues.apache.org/jira/browse/HBASE-24764) | Add support of adding base peer configs via hbase-site.xml for all replication peers. |  Minor | Replication |
+| [HBASE-25425](https://issues.apache.org/jira/browse/HBASE-25425) | Some notes on RawCell |  Trivial | . |
+| [HBASE-25084](https://issues.apache.org/jira/browse/HBASE-25084) | RegexStringComparator in ParseFilter should support case-insensitive regexes |  Major | Thrift |
+| [HBASE-25420](https://issues.apache.org/jira/browse/HBASE-25420) | Some minor improvements in rpc implementation |  Minor | rpc |
+| [HBASE-25246](https://issues.apache.org/jira/browse/HBASE-25246) | Backup/Restore hbase cell tags. |  Major | backup&restore |
+| [HBASE-25363](https://issues.apache.org/jira/browse/HBASE-25363) | Improve performance of HFileLinkCleaner by using ReadWriteLock instead of synchronize |  Major | master |
+| [HBASE-25328](https://issues.apache.org/jira/browse/HBASE-25328) | Add builder method to create Tags. |  Minor | . |
+| [HBASE-25339](https://issues.apache.org/jira/browse/HBASE-25339) | Method parameter and member variable are duplicated in checkSplittable() of SplitTableRegionProcedure |  Minor | . |
+| [HBASE-25237](https://issues.apache.org/jira/browse/HBASE-25237) | 'hbase master stop' shuts down the cluster, not the master only |  Major | . |
+| [HBASE-25324](https://issues.apache.org/jira/browse/HBASE-25324) | Remove unnecessary array to list conversion in SplitLogManager |  Minor | . |
+| [HBASE-25263](https://issues.apache.org/jira/browse/HBASE-25263) | Change encryption key generation algorithm used in the HBase shell |  Major | encryption, shell |
+| [HBASE-25323](https://issues.apache.org/jira/browse/HBASE-25323) | Fix potential NPE when the zookeeper path of RegionServerTracker does not exist when start |  Minor | . |
+| [HBASE-25281](https://issues.apache.org/jira/browse/HBASE-25281) | Bulkload split hfile too many times due to unreasonable split point |  Minor | tooling |
+| [HBASE-25325](https://issues.apache.org/jira/browse/HBASE-25325) | Remove unused class ClusterSchemaException |  Minor | . |
+| [HBASE-25282](https://issues.apache.org/jira/browse/HBASE-25282) | Remove processingServers in DeadServer as we can get this information by Procedure of master |  Minor | . |
+| [HBASE-25213](https://issues.apache.org/jira/browse/HBASE-25213) | Should request Compaction when bulkLoadHFiles is done |  Minor | . |
+| [HBASE-25187](https://issues.apache.org/jira/browse/HBASE-25187) | Improve SizeCachedKV variants initialization |  Minor | . |
+| [HBASE-24877](https://issues.apache.org/jira/browse/HBASE-24877) | Add option to avoid aborting RS process upon uncaught exceptions happen on replication source |  Major | Replication |
+| [HBASE-25298](https://issues.apache.org/jira/browse/HBASE-25298) | hbase.rsgroup.fallback.enable should support dynamic configuration |  Major | . |
+| [HBASE-24664](https://issues.apache.org/jira/browse/HBASE-24664) | Some changing of split region by overall region size rather than only one store size |  Major | regionserver |
+| [HBASE-24654](https://issues.apache.org/jira/browse/HBASE-24654) | Allow unset table's rsgroup |  Major | rsgroup |
+| [HBASE-25026](https://issues.apache.org/jira/browse/HBASE-25026) | Create a metric to track full region scans RPCs |  Minor | . |
+| [HBASE-25289](https://issues.apache.org/jira/browse/HBASE-25289) | [testing] Clean up resources after tests in rsgroup\_shell\_test.rb |  Major | rsgroup, test |
+| [HBASE-25261](https://issues.apache.org/jira/browse/HBASE-25261) | Upgrade Bootstrap to 3.4.1 |  Major | security, UI |
+| [HBASE-23224](https://issues.apache.org/jira/browse/HBASE-23224) | Delete the TODO ("get rid of allocations") tag in the WALProcedureStore class |  Trivial | proc-v2 |
+| [HBASE-25273](https://issues.apache.org/jira/browse/HBASE-25273) | fix typo in StripeStoreFileManager java doc |  Major | . |
+| [HBASE-25267](https://issues.apache.org/jira/browse/HBASE-25267) | Add SSL keystore type and truststore related configs for HBase RESTServer |  Major | REST |
+| [HBASE-25181](https://issues.apache.org/jira/browse/HBASE-25181) | Add options for disabling column family encryption and choosing hash algorithm for wrapped encryption keys. |  Major | encryption |
+| [HBASE-25254](https://issues.apache.org/jira/browse/HBASE-25254) | Rewrite TestMultiLogThreshold to remove the LogDelegate in RSRpcServices |  Major | logging, test |
+| [HBASE-25252](https://issues.apache.org/jira/browse/HBASE-25252) | Move HMaster inner classes out |  Minor | master |
+| [HBASE-25240](https://issues.apache.org/jira/browse/HBASE-25240) | gson format of RpcServer.logResponse is abnormal |  Minor | . |
+| [HBASE-25210](https://issues.apache.org/jira/browse/HBASE-25210) | RegionInfo.isOffline is now a duplication with RegionInfo.isSplit |  Major | meta |
+| [HBASE-25212](https://issues.apache.org/jira/browse/HBASE-25212) | Optionally abort requests in progress after deciding a region should close |  Major | regionserver |
+| [HBASE-24859](https://issues.apache.org/jira/browse/HBASE-24859) | Optimize in-memory representation of mapreduce TableSplit objects |  Major | mapreduce |
+| [HBASE-24967](https://issues.apache.org/jira/browse/HBASE-24967) | The table.jsp cost long time to load if the table include closed regions |  Major | UI |
+| [HBASE-25167](https://issues.apache.org/jira/browse/HBASE-25167) | Normalizer support for hot config reloading |  Major | master, Normalizer |
+| [HBASE-24419](https://issues.apache.org/jira/browse/HBASE-24419) | Normalizer merge plans should consider more than 2 regions when possible |  Major | master, Normalizer |
+| [HBASE-25224](https://issues.apache.org/jira/browse/HBASE-25224) | Maximize sleep for checking meta and namespace regions availability |  Major | master |
+| [HBASE-25223](https://issues.apache.org/jira/browse/HBASE-25223) | Use try-with-resources statement in snapshot package |  Minor | . |
+| [HBASE-25201](https://issues.apache.org/jira/browse/HBASE-25201) | YouAreDeadException should be moved to hbase-server module |  Major | Client |
+| [HBASE-25189](https://issues.apache.org/jira/browse/HBASE-25189) | [Metrics] Add checkAndPut and checkAndDelete latency metrics at table level |  Minor | metrics |
+| [HBASE-25193](https://issues.apache.org/jira/browse/HBASE-25193) | Add support for row prefix and type in the WAL Pretty Printer and some minor fixes |  Minor | wal |
+| [HBASE-25128](https://issues.apache.org/jira/browse/HBASE-25128) | RSGroupInfo's toString() and hashCode() does not take into account configuration map. |  Minor | rsgroup |
+| [HBASE-24840](https://issues.apache.org/jira/browse/HBASE-24840) | Avoid shows closing region task when create table |  Major | monitoring |
+| [HBASE-24628](https://issues.apache.org/jira/browse/HBASE-24628) | Region normalizer now respects a rate limit |  Major | Normalizer |
+| [HBASE-25179](https://issues.apache.org/jira/browse/HBASE-25179) | Assert format is incorrect in HFilePerformanceEvaluation class. |  Minor | Performance, test |
+| [HBASE-25065](https://issues.apache.org/jira/browse/HBASE-25065) | WAL archival to be done by a separate thread |  Major | wal |
+| [HBASE-14067](https://issues.apache.org/jira/browse/HBASE-14067) | bundle ruby files for hbase shell into a jar. |  Major | shell |
+| [HBASE-24875](https://issues.apache.org/jira/browse/HBASE-24875) | Remove the force param for unassign since it dose not take effect any more |  Major | Client |
+| [HBASE-25171](https://issues.apache.org/jira/browse/HBASE-25171) | Remove ZNodePaths.namespaceZNode |  Major | Zookeeper |
+| [HBASE-24025](https://issues.apache.org/jira/browse/HBASE-24025) | Improve performance of move\_servers\_rsgroup and move\_tables\_rsgroup by using async region move API |  Major | rsgroup |
+| [HBASE-25160](https://issues.apache.org/jira/browse/HBASE-25160) | Refactor AccessController and VisibilityController |  Major | . |
+| [HBASE-25146](https://issues.apache.org/jira/browse/HBASE-25146) | Add extra logging at info level to HFileCorruptionChecker in order to report progress |  Major | hbck, hbck2 |
+| [HBASE-24054](https://issues.apache.org/jira/browse/HBASE-24054) | The Jetty's version number leak occurred while using the thrift service |  Minor | . |
+| [HBASE-25091](https://issues.apache.org/jira/browse/HBASE-25091) | Move LogComparator from ReplicationSource to AbstractFSWALProvider#.WALsStartTimeComparator |  Minor | . |
+| [HBASE-24981](https://issues.apache.org/jira/browse/HBASE-24981) | Enable table replication fails from 1.x to 2.x if table already exist at peer. |  Major | Replication |
+| [HBASE-25062](https://issues.apache.org/jira/browse/HBASE-25062) | The link of "Re:(HBASE-451) Remove HTableDescriptor from HRegionInfo" invalid |  Minor | documentation |
+| [HBASE-25109](https://issues.apache.org/jira/browse/HBASE-25109) | Add MR Counters to WALPlayer; currently hard to tell if it is doing anything |  Major | . |
+| [HBASE-25074](https://issues.apache.org/jira/browse/HBASE-25074) | Refactor ReplicationSinkManager: reduce code and make it easy to understand |  Major | Replication |
+| [HBASE-25086](https://issues.apache.org/jira/browse/HBASE-25086) | Refactor Replication: move the default ReplicationSinkService implementation out |  Major | Replication |
+| [HBASE-25082](https://issues.apache.org/jira/browse/HBASE-25082) | Per table WAL metrics: appendCount and appendSize |  Major | metrics |
+| [HBASE-25079](https://issues.apache.org/jira/browse/HBASE-25079) | Upgrade Bootstrap to 3.3.7 |  Major | security, UI |
+| [HBASE-25076](https://issues.apache.org/jira/browse/HBASE-25076) | fix typo in MasterRegion java doc |  Major | . |
+| [HBASE-25075](https://issues.apache.org/jira/browse/HBASE-25075) | Fix typo in ReplicationProtobufUtil |  Major | Replication |
+| [HBASE-24976](https://issues.apache.org/jira/browse/HBASE-24976) | REST Server failes to start without any error message |  Major | REST |
+| [HBASE-25066](https://issues.apache.org/jira/browse/HBASE-25066) | Use FutureUtils.rethrow in AsyncTableResultScanner to better catch the stack trace |  Major | Client, Scanners |
+| [HBASE-25069](https://issues.apache.org/jira/browse/HBASE-25069) |  Display region name instead of encoded region name in HBCK report page. |  Minor | hbck |
+| [HBASE-24991](https://issues.apache.org/jira/browse/HBASE-24991) | Replace MovedRegionsCleaner with guava cache |  Minor | . |
+| [HBASE-25057](https://issues.apache.org/jira/browse/HBASE-25057) | Fix typo "memeber" |  Trivial | documentation |
+| [HBASE-25037](https://issues.apache.org/jira/browse/HBASE-25037) | Lots of thread pool are changed to non daemon after HBASE-24750 which causes trouble when shutting down |  Major | . |
+| [HBASE-24831](https://issues.apache.org/jira/browse/HBASE-24831) | Avoid invoke Counter using reflection  in SnapshotInputFormat |  Major | . |
+| [HBASE-25002](https://issues.apache.org/jira/browse/HBASE-25002) | Create simple pattern matching query for retrieving metrics matching the pattern |  Major | . |
+| [HBASE-25022](https://issues.apache.org/jira/browse/HBASE-25022) | Remove 'hbase.testing.nocluster' config |  Major | test |
+| [HBASE-25006](https://issues.apache.org/jira/browse/HBASE-25006) | Make the cost functions optional for StochastoicBalancer |  Major | . |
+| [HBASE-24974](https://issues.apache.org/jira/browse/HBASE-24974) | Provide a flexibility to print only row key and filter for multiple tables in the WALPrettyPrinter |  Minor | wal |
+| [HBASE-24994](https://issues.apache.org/jira/browse/HBASE-24994) | Add hedgedReadOpsInCurThread metric |  Minor | metrics |
+| [HBASE-25005](https://issues.apache.org/jira/browse/HBASE-25005) | Refactor CatalogJanitor |  Major | master, meta |
+| [HBASE-24992](https://issues.apache.org/jira/browse/HBASE-24992) | log after Generator success when running ITBLL |  Trivial | . |
+| [HBASE-24937](https://issues.apache.org/jira/browse/HBASE-24937) | table.rb use LocalDateTime to replace Instant |  Minor | shell |
+| [HBASE-24940](https://issues.apache.org/jira/browse/HBASE-24940) | runCatalogJanitor() API should return -1 to indicate already running status |  Major | . |
+| [HBASE-24973](https://issues.apache.org/jira/browse/HBASE-24973) | Remove read point parameter in method StoreFlush#performFlush and StoreFlush#createScanner |  Minor | . |
+| [HBASE-24569](https://issues.apache.org/jira/browse/HBASE-24569) | Get hostAndWeights in addition using localhost if it is null in local mode |  Minor | regionserver |
+| [HBASE-24913](https://issues.apache.org/jira/browse/HBASE-24913) | Refactor TestJMXConnectorServer |  Major | test |
+| [HBASE-24949](https://issues.apache.org/jira/browse/HBASE-24949) | Optimize FSTableDescriptors.get to not always go to fs when cache miss |  Major | master |
+| [HBASE-24898](https://issues.apache.org/jira/browse/HBASE-24898) | Use EnvironmentEdge.currentTime() instead of System.currentTimeMillis() in CurrentHourProvider |  Major | tooling |
+| [HBASE-24928](https://issues.apache.org/jira/browse/HBASE-24928) | balanceRSGroup should skip generating balance plan for disabled table and splitParent region |  Major | Balancer |
+| [HBASE-24942](https://issues.apache.org/jira/browse/HBASE-24942) | MergeTableRegionsProcedure should not call clean merge region |  Major | proc-v2, Region Assignment |
+| [HBASE-24811](https://issues.apache.org/jira/browse/HBASE-24811) | Use class access static field or method |  Minor | . |
+| [HBASE-24915](https://issues.apache.org/jira/browse/HBASE-24915) | Improve BlockCache read performance by specifying BlockType |  Major | BlockCache, Performance |
+| [HBASE-24686](https://issues.apache.org/jira/browse/HBASE-24686) | [LOG] Log improvement in Connection#close |  Major | Client, logging |
+| [HBASE-24912](https://issues.apache.org/jira/browse/HBASE-24912) | Enlarge MemstoreFlusherChore/CompactionChecker period for unit test |  Major | . |
+| [HBASE-24914](https://issues.apache.org/jira/browse/HBASE-24914) | Remove duplicate code appearing continuously in method ReplicationPeerManager.updatePeerConfig |  Minor | Replication |
+| [HBASE-24627](https://issues.apache.org/jira/browse/HBASE-24627) | Normalize one table at a time |  Major | Normalizer |
+| [HBASE-24872](https://issues.apache.org/jira/browse/HBASE-24872) | refactor valueOf PoolType |  Minor | Client |
+| [HBASE-24854](https://issues.apache.org/jira/browse/HBASE-24854) | Correct the help content of assign and unassign commands in hbase shell |  Minor | shell |
+| [HBASE-24750](https://issues.apache.org/jira/browse/HBASE-24750) | All executor service should start using guava ThreadFactory |  Major | . |
+| [HBASE-24709](https://issues.apache.org/jira/browse/HBASE-24709) | Support MoveCostFunction use a lower multiplier in offpeak hours |  Major | Balancer |
+| [HBASE-24824](https://issues.apache.org/jira/browse/HBASE-24824) | Add more stats in PE for read replica |  Minor | PE, read replicas |
+| [HBASE-21721](https://issues.apache.org/jira/browse/HBASE-21721) | FSHLog : reduce write#syncs() times |  Major | . |
+| [HBASE-24404](https://issues.apache.org/jira/browse/HBASE-24404) | Support flush a single column family of region |  Major | shell |
+| [HBASE-24826](https://issues.apache.org/jira/browse/HBASE-24826) | Add some comments for processlist in hbase shell |  Minor | shell |
+| [HBASE-24659](https://issues.apache.org/jira/browse/HBASE-24659) | Calculate FIXED\_OVERHEAD automatically |  Major | . |
+| [HBASE-24827](https://issues.apache.org/jira/browse/HBASE-24827) | BackPort HBASE-11554 Remove Reusable poolmap Rpc client type. |  Major | Client |
+| [HBASE-24823](https://issues.apache.org/jira/browse/HBASE-24823) | Port HBASE-22762 Print the delta between phases in the split/merge/compact/flush transaction journals to master branch |  Minor | . |
+| [HBASE-24795](https://issues.apache.org/jira/browse/HBASE-24795) | RegionMover should deal with unknown (split/merged) regions |  Major | . |
+| [HBASE-24821](https://issues.apache.org/jira/browse/HBASE-24821) | Simplify the logic of getRegionInfo in TestFlushFromClient to reduce redundancy code |  Minor | test |
+| [HBASE-24791](https://issues.apache.org/jira/browse/HBASE-24791) | Improve HFileOutputFormat2 to avoid always call getTableRelativePath method |  Critical | mapreduce |
+| [HBASE-24704](https://issues.apache.org/jira/browse/HBASE-24704) | Make the Table Schema easier to view even there are multiple families |  Major | UI |
+| [HBASE-24476](https://issues.apache.org/jira/browse/HBASE-24476) | release scripts should provide timing information |  Minor | . |
+| [HBASE-24695](https://issues.apache.org/jira/browse/HBASE-24695) | FSHLog - close the current WAL file in a background thread |  Major | . |
+| [HBASE-24803](https://issues.apache.org/jira/browse/HBASE-24803) | Unify hbase-shell ::Shell::Commands::Command#help behavior |  Minor | shell |
+| [HBASE-11686](https://issues.apache.org/jira/browse/HBASE-11686) | Shell code should create a binding / irb workspace instead of polluting the root namespace |  Minor | shell |
+| [HBASE-20226](https://issues.apache.org/jira/browse/HBASE-20226) | Performance Improvement Taking Large Snapshots In Remote Filesystems |  Minor | snapshots |
+| [HBASE-24722](https://issues.apache.org/jira/browse/HBASE-24722) | Address hbase-shell commands with unintentional return values |  Minor | shell |
+| [HBASE-24669](https://issues.apache.org/jira/browse/HBASE-24669) | Logging of ppid should be consistent across all occurrences |  Minor | Operability, proc-v2 |
+| [HBASE-24790](https://issues.apache.org/jira/browse/HBASE-24790) | Remove unused counter from SplitLogCounters |  Minor | wal |
+| [HBASE-24757](https://issues.apache.org/jira/browse/HBASE-24757) | ReplicationSink should limit the batch rowcount for batch mutations based on hbase.rpc.rows.warning.threshold |  Major | . |
+| [HBASE-24777](https://issues.apache.org/jira/browse/HBASE-24777) | InfoServer support ipv6 host and port |  Minor | UI |
+| [HBASE-24758](https://issues.apache.org/jira/browse/HBASE-24758) | Avoid flooding replication source RSes logs when no sinks are available |  Major | Replication |
+| [HBASE-24743](https://issues.apache.org/jira/browse/HBASE-24743) | Reject to add a peer which replicate to itself earlier |  Major | . |
+| [HBASE-24696](https://issues.apache.org/jira/browse/HBASE-24696) | Include JVM information on Web UI under "Software Attributes" |  Minor | UI |
+| [HBASE-24555](https://issues.apache.org/jira/browse/HBASE-24555) | Clear the description of hbase.hregion.max.filesize |  Minor | documentation |
+| [HBASE-24740](https://issues.apache.org/jira/browse/HBASE-24740) | Enable journal logging for HBase snapshot operation |  Minor | master |
+| [HBASE-24747](https://issues.apache.org/jira/browse/HBASE-24747) | Log an ERROR if HBaseSaslRpcServer initialisation fails with an uncaught exception |  Major | . |
+| [HBASE-24578](https://issues.apache.org/jira/browse/HBASE-24578) | [WAL] Add a parameter to config RingBufferEventHandler's SyncFuture count |  Major | wal |
+| [HBASE-24586](https://issues.apache.org/jira/browse/HBASE-24586) | Add table level locality in table.jsp |  Major | UI |
+| [HBASE-24663](https://issues.apache.org/jira/browse/HBASE-24663) | Add procedure process time statistics UI |  Major | . |
+| [HBASE-24653](https://issues.apache.org/jira/browse/HBASE-24653) | Show snapshot owner on Master WebUI |  Major | . |
+| [HBASE-24431](https://issues.apache.org/jira/browse/HBASE-24431) | RSGroupInfo add configuration map to store something extra |  Major | rsgroup |
+| [HBASE-24671](https://issues.apache.org/jira/browse/HBASE-24671) | Add excludefile and designatedfile options to graceful\_stop.sh |  Major | . |
+| [HBASE-24562](https://issues.apache.org/jira/browse/HBASE-24562) | Stabilize master startup with meta replicas enabled |  Major | meta, read replicas |
+| [HBASE-24560](https://issues.apache.org/jira/browse/HBASE-24560) | Add a new option of designatedfile in RegionMover |  Major | . |
+| [HBASE-20819](https://issues.apache.org/jira/browse/HBASE-20819) | Use TableDescriptor to replace HTableDescriptor in hbase-shell module |  Minor | shell |
+| [HBASE-24221](https://issues.apache.org/jira/browse/HBASE-24221) | Support bulkLoadHFile by family |  Major | HFile |
+| [HBASE-24382](https://issues.apache.org/jira/browse/HBASE-24382) | Flush partial stores of region filtered by seqId when archive wal due to too many wals |  Major | wal |
+| [HBASE-24603](https://issues.apache.org/jira/browse/HBASE-24603) | Zookeeper sync() call is async |  Critical | master, regionserver |
+| [HBASE-23339](https://issues.apache.org/jira/browse/HBASE-23339) | Release scripts should not need to write out a copy of gpg key material |  Critical | community, scripts |
+| [HBASE-24205](https://issues.apache.org/jira/browse/HBASE-24205) | Create metric to know the number of reads that happens from memstore |  Major | metrics |
+| [HBASE-24605](https://issues.apache.org/jira/browse/HBASE-24605) | Break long region names in the web UI |  Minor | UI |
+| [HBASE-15161](https://issues.apache.org/jira/browse/HBASE-15161) | Umbrella: Miscellaneous improvements from production usage |  Major | . |
+| [HBASE-24102](https://issues.apache.org/jira/browse/HBASE-24102) | RegionMover should exclude draining/decommissioning nodes from target RSs |  Major | . |
+| [HBASE-24380](https://issues.apache.org/jira/browse/HBASE-24380) | Improve WAL splitting log lines to enable sessionization |  Minor | logging, Operability, wal |
+| [HBASE-21405](https://issues.apache.org/jira/browse/HBASE-21405) | [DOC] Add Details about Output of "status 'replication'" |  Minor | documentation, Replication |
+| [HBASE-24478](https://issues.apache.org/jira/browse/HBASE-24478) | The regionInfo parameter for MasterProcedureScheduler#waitRegions and MasterProcedureScheduler#wakeRegions should be plural |  Minor | proc-v2 |
+| [HBASE-24524](https://issues.apache.org/jira/browse/HBASE-24524) | SyncTable logging improvements |  Minor | . |
+| [HBASE-24441](https://issues.apache.org/jira/browse/HBASE-24441) | CacheConfig details logged at Store open is not really useful |  Minor | logging, regionserver |
+| [HBASE-24468](https://issues.apache.org/jira/browse/HBASE-24468) | Add region info when log meessages in HStore. |  Minor | logging, regionserver |
+| [HBASE-24208](https://issues.apache.org/jira/browse/HBASE-24208) | Remove RS entry from zk draining servers node after RS been stopped |  Major | . |
+| [HBASE-24483](https://issues.apache.org/jira/browse/HBASE-24483) | Add repeated prefix logging for MultipleColumnPrefixFilter |  Minor | Filters |
+| [HBASE-24359](https://issues.apache.org/jira/browse/HBASE-24359) | Optionally ignore edits for deleted CFs for replication. |  Major | Replication |
+| [HBASE-24504](https://issues.apache.org/jira/browse/HBASE-24504) | refactor call setupCluster/tearDownCluster in TestTableSnapshotInputFormat |  Minor | mapreduce, test |
+| [HBASE-24458](https://issues.apache.org/jira/browse/HBASE-24458) | release scripts using docker should specify needed disk consistency |  Major | . |
+| [HBASE-24412](https://issues.apache.org/jira/browse/HBASE-24412) | Canary support check only one column family per RegionTask |  Major | canary |
+| [HBASE-24456](https://issues.apache.org/jira/browse/HBASE-24456) | Immutable Scan as unmodifiable subclass or wrapper of Scan |  Major | . |
+| [HBASE-21406](https://issues.apache.org/jira/browse/HBASE-21406) | "status 'replication'" should not show SINK if the cluster does not act as sink |  Minor | . |
+| [HBASE-24486](https://issues.apache.org/jira/browse/HBASE-24486) | Remove the unused method online in admin.rb |  Minor | . |
+| [HBASE-24474](https://issues.apache.org/jira/browse/HBASE-24474) | Rename LocalRegion to MasterRegion |  Blocker | master |
+| [HBASE-23841](https://issues.apache.org/jira/browse/HBASE-23841) | Remove deprecated methods from Scan |  Minor | scan |
+| [HBASE-24455](https://issues.apache.org/jira/browse/HBASE-24455) | Correct the doc of "On the number of column families" |  Minor | documentation |
+| [HBASE-24475](https://issues.apache.org/jira/browse/HBASE-24475) | Clean up the master thread name getting in SplitLogManager and AssignmentManager |  Minor | . |
+| [HBASE-24471](https://issues.apache.org/jira/browse/HBASE-24471) | The way we bootstrap meta table is confusing |  Major | master, meta, proc-v2 |
+| [HBASE-24132](https://issues.apache.org/jira/browse/HBASE-24132) | Upgrade to Apache ZooKeeper 3.5.7 |  Major | . |
+| [HBASE-24470](https://issues.apache.org/jira/browse/HBASE-24470) | Add store file info when log meessages in HStore. |  Minor | logging, regionserver |
+| [HBASE-24451](https://issues.apache.org/jira/browse/HBASE-24451) | Remove the HasThread because the related bug had been fixed since jdk7 |  Major | util |
+| [HBASE-24443](https://issues.apache.org/jira/browse/HBASE-24443) | Refactor TestCustomSaslAuthenticationProvider |  Major | test |
+| [HBASE-24416](https://issues.apache.org/jira/browse/HBASE-24416) | RegionNormalizer spliting region should not be limited by hbase.normalizer.min.region.count |  Major | Normalizer |
+| [HBASE-24428](https://issues.apache.org/jira/browse/HBASE-24428) | Priority compaction for recently split daughter regions |  Major | Compaction |
+| [HBASE-24371](https://issues.apache.org/jira/browse/HBASE-24371) | Add more details when print CompactionConfiguration info |  Minor | regionserver |
+| [HBASE-24423](https://issues.apache.org/jira/browse/HBASE-24423) | No need to get lock in canSplit because hasReferences will get lock too |  Minor | regionserver |
+| [HBASE-24369](https://issues.apache.org/jira/browse/HBASE-24369) | Provide more information about  merged child regions in Hbck Overlaps section, which cannot be fixed immediately |  Major | master |
+| [HBASE-24427](https://issues.apache.org/jira/browse/HBASE-24427) | HStore.add log format error |  Minor | . |
+| [HBASE-24387](https://issues.apache.org/jira/browse/HBASE-24387) | TableSnapshotInputFormatImpl support row limit on each InputSplit |  Major | mapreduce |
+| [HBASE-24297](https://issues.apache.org/jira/browse/HBASE-24297) | release scripts should be able to use a custom git repo |  Major | community, scripts |
+| [HBASE-24296](https://issues.apache.org/jira/browse/HBASE-24296) | install yetus as a part of building the rm docker image. |  Major | community, scripts |
+| [HBASE-24407](https://issues.apache.org/jira/browse/HBASE-24407) | Correct the comment of clusterRegionLocationMocks in TestStochasticLoadBalancer |  Minor | Balancer |
+| [HBASE-21996](https://issues.apache.org/jira/browse/HBASE-21996) | Set locale for javadoc |  Major | documentation |
+| [HBASE-24386](https://issues.apache.org/jira/browse/HBASE-24386) | TableSnapshotScanner support scan limit |  Major | Scanners, snapshots |
+| [HBASE-24164](https://issues.apache.org/jira/browse/HBASE-24164) | Retain the ReadRequests and WriteRequests of region on web UI after alter table |  Major | metrics |
+| [HBASE-23969](https://issues.apache.org/jira/browse/HBASE-23969) | Meta browser should show all \`info\` columns |  Minor | master, UI |
+| [HBASE-24313](https://issues.apache.org/jira/browse/HBASE-24313) | [DOCS] Document "ignoreTimestamps" option added to HashTable/SyncTable by HBASE-24302 to related ref-guide section |  Major | . |
+| [HBASE-24350](https://issues.apache.org/jira/browse/HBASE-24350) | HBase table level replication metrics for shippedBytes are always 0 |  Major | Replication |

[... 2733 lines stripped ...]