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 2022/06/15 16:03:18 UTC

svn commit: r55137 [2/3] - in /dev/hbase/3.0.0-alpha-3RC0: CHANGES.md RELEASENOTES.md

Added: dev/hbase/3.0.0-alpha-3RC0/CHANGES.md
==============================================================================
--- dev/hbase/3.0.0-alpha-3RC0/CHANGES.md (added)
+++ dev/hbase/3.0.0-alpha-3RC0/CHANGES.md Wed Jun 15 16:03:17 2022
@@ -0,0 +1,3730 @@
+
+<!---
+# 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-3 - Unreleased (as of 2022-06-15)
+
+
+
+### NEW FEATURES:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-26956](https://issues.apache.org/jira/browse/HBASE-26956) | ExportSnapshot tool supports removing TTL |  Major | snapshots |
+| [HBASE-26342](https://issues.apache.org/jira/browse/HBASE-26342) | Support custom paths of independent configuration and pool for hfile cleaner |  Major | master |
+| [HBASE-27018](https://issues.apache.org/jira/browse/HBASE-27018) | Add a tool command list\_liveservers |  Major | . |
+| [HBASE-26617](https://issues.apache.org/jira/browse/HBASE-26617) | Use spotless to reduce the pain on fixing checkstyle issues |  Major | build, community |
+| [HBASE-26959](https://issues.apache.org/jira/browse/HBASE-26959) | Brotli compression support |  Minor | . |
+| [HBASE-25865](https://issues.apache.org/jira/browse/HBASE-25865) | Visualize current state of region assignment |  Blocker | master, Operability, Usability |
+| [HBASE-26323](https://issues.apache.org/jira/browse/HBASE-26323) | Introduce a SnapshotProcedure |  Major | proc-v2, snapshots |
+| [HBASE-26703](https://issues.apache.org/jira/browse/HBASE-26703) | Allow configuration of IPC queue balancer |  Minor | . |
+| [HBASE-26576](https://issues.apache.org/jira/browse/HBASE-26576) | Allow Pluggable Queue to belong to FastPath or normal Balanced Executor |  Minor | regionserver, rpc |
+| [HBASE-26347](https://issues.apache.org/jira/browse/HBASE-26347) | Support detect and exclude slow DNs in fan-out of WAL |  Major | wal |
+
+
+### IMPROVEMENTS:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-26923](https://issues.apache.org/jira/browse/HBASE-26923) | PerformanceEvaluation support encryption option |  Minor | PE |
+| [HBASE-26983](https://issues.apache.org/jira/browse/HBASE-26983) | Upgrade JRuby to 9.3.4.0 |  Major | shell |
+| [HBASE-27095](https://issues.apache.org/jira/browse/HBASE-27095) | HbckChore should produce a report |  Major | hbck2, master |
+| [HBASE-27046](https://issues.apache.org/jira/browse/HBASE-27046) | The filenum in AbstractFSWAL should be monotone increasing |  Major | . |
+| [HBASE-27093](https://issues.apache.org/jira/browse/HBASE-27093) | AsyncNonMetaRegionLocator¿put Complete CompletableFuture outside lock block |  Major | asyncclient, Client |
+| [HBASE-26993](https://issues.apache.org/jira/browse/HBASE-26993) | Make the new framework for region replication could work for SKIP\_WAL |  Major | read replicas |
+| [HBASE-26649](https://issues.apache.org/jira/browse/HBASE-26649) | Support meta replica LoadBalance mode for RegionLocator#getAllRegionLocations() |  Major | meta replicas |
+| [HBASE-26320](https://issues.apache.org/jira/browse/HBASE-26320) | Separate Log Cleaner DirScanPool to prevent the OLDWALs from filling up the disk when archive is large |  Major | Operability |
+| [HBASE-27043](https://issues.apache.org/jira/browse/HBASE-27043) | Let lock wait timeout to improve performance of SnapshotHFileCleaner |  Major | snapshots |
+| [HBASE-25465](https://issues.apache.org/jira/browse/HBASE-25465) | Use javac --release option for supporting cross version compilation |  Minor | create-release |
+| [HBASE-27040](https://issues.apache.org/jira/browse/HBASE-27040) | Optimize the log display of the ZKProcedureUtil.java |  Minor | proc-v2 |
+| [HBASE-27013](https://issues.apache.org/jira/browse/HBASE-27013) | Introduce read all bytes when using pread for prefetch |  Major | HFile, Performance |
+| [HBASE-27003](https://issues.apache.org/jira/browse/HBASE-27003) | Optimize log format for PerformanceEvaluation |  Minor | . |
+| [HBASE-26943](https://issues.apache.org/jira/browse/HBASE-26943) | HMaster page style display confusion |  Minor | master |
+| [HBASE-26990](https://issues.apache.org/jira/browse/HBASE-26990) | Add default implementation for BufferedMutator interface setters |  Minor | . |
+| [HBASE-26419](https://issues.apache.org/jira/browse/HBASE-26419) | Tracing Spans of RPCs should follow otel semantic conventions |  Blocker | tracing |
+| [HBASE-26886](https://issues.apache.org/jira/browse/HBASE-26886) | Add unit test for custom RpcControllerFactory's ability to overwrite priorities |  Minor | . |
+| [HBASE-26975](https://issues.apache.org/jira/browse/HBASE-26975) | Add on heap and off heap memstore info in rs web UI |  Minor | UI |
+| [HBASE-26980](https://issues.apache.org/jira/browse/HBASE-26980) | Update javadoc of BucketCache.java |  Trivial | documentation |
+| [HBASE-26581](https://issues.apache.org/jira/browse/HBASE-26581) | Add metrics around failed replication edits |  Minor | metrics, Replication |
+| [HBASE-26971](https://issues.apache.org/jira/browse/HBASE-26971) | SnapshotInfo --snapshot param is marked as required even when trying to list all snapshots |  Minor | . |
+| [HBASE-26807](https://issues.apache.org/jira/browse/HBASE-26807) | Unify CallQueueTooBigException special pause with CallDroppedException |  Major | . |
+| [HBASE-26942](https://issues.apache.org/jira/browse/HBASE-26942) | cache region locations when getAllRegionLocations() |  Minor | Client |
+| [HBASE-26891](https://issues.apache.org/jira/browse/HBASE-26891) | Make MetricsConnection scope configurable |  Minor | . |
+| [HBASE-26947](https://issues.apache.org/jira/browse/HBASE-26947) | Implement a special TestAppender to limit the size of test output |  Major | logging, test |
+| [HBASE-26618](https://issues.apache.org/jira/browse/HBASE-26618) | Involving primary meta region in meta scan with CatalogReplicaLoadBalanceSimpleSelector |  Minor | meta replicas |
+| [HBASE-26637](https://issues.apache.org/jira/browse/HBASE-26637) | Add more information to release manager table in our ref guide |  Major | community, documentation |
+| [HBASE-26885](https://issues.apache.org/jira/browse/HBASE-26885) | The TRSP should not go on when it get a bogus server name from AM |  Major | proc-v2 |
+| [HBASE-26872](https://issues.apache.org/jira/browse/HBASE-26872) | Load rate calculator for cost functions should be more precise |  Major | Balancer |
+| [HBASE-26832](https://issues.apache.org/jira/browse/HBASE-26832) | Avoid repeated releasing of flushed wal entries in AsyncFSWAL#syncCompleted |  Major | wal |
+| [HBASE-26878](https://issues.apache.org/jira/browse/HBASE-26878) | TableInputFormatBase should cache RegionSizeCalculator |  Minor | . |
+| [HBASE-26175](https://issues.apache.org/jira/browse/HBASE-26175) | MetricsHBaseServer should record all kinds of Exceptions |  Minor | metrics |
+| [HBASE-26858](https://issues.apache.org/jira/browse/HBASE-26858) | Refactor TestMasterRegionOnTwoFileSystems to avoid dead loop |  Major | test |
+| [HBASE-26859](https://issues.apache.org/jira/browse/HBASE-26859) | Split TestSnapshotProcedure to several smaller tests |  Minor | proc-v2, snapshots |
+| [HBASE-26851](https://issues.apache.org/jira/browse/HBASE-26851) | [Documentation]  Point out compatibility issues with WAL Compression and Replication in doc |  Minor | documentation, Replication, wal |
+| [HBASE-26833](https://issues.apache.org/jira/browse/HBASE-26833) | Avoid waiting to clear buffer usage of ReplicationSourceShipper when aborting the RS |  Major | regionserver, Replication |
+| [HBASE-26848](https://issues.apache.org/jira/browse/HBASE-26848) | Set java.io.tmpdir on mvn command when running jenkins job |  Major | jenkins, test |
+| [HBASE-26828](https://issues.apache.org/jira/browse/HBASE-26828) | Increase the concurrency when running UTs in pre commit job |  Major | jenkins, test |
+| [HBASE-26680](https://issues.apache.org/jira/browse/HBASE-26680) | Close and do not write trailer for the broken WAL writer |  Major | wal |
+| [HBASE-26720](https://issues.apache.org/jira/browse/HBASE-26720) | ExportSnapshot should validate the source snapshot before copying files |  Major | snapshots |
+| [HBASE-26275](https://issues.apache.org/jira/browse/HBASE-26275) | update error message when executing deleteall with ROWPREFIXFILTER in meta table |  Minor | shell |
+| [HBASE-26835](https://issues.apache.org/jira/browse/HBASE-26835) | Rewrite TestLruAdaptiveBlockCache to make it more stable |  Major | test |
+| [HBASE-26830](https://issues.apache.org/jira/browse/HBASE-26830) | Rewrite TestLruBlockCache to make it more stable |  Major | test |
+| [HBASE-26814](https://issues.apache.org/jira/browse/HBASE-26814) | Default StoreHotnessProtector to off, with logs to guide when to turn it on |  Major | . |
+| [HBASE-26784](https://issues.apache.org/jira/browse/HBASE-26784) | Use HIGH\_QOS for ResultScanner.close requests |  Major | . |
+| [HBASE-26552](https://issues.apache.org/jira/browse/HBASE-26552) | Introduce retry to logroller to avoid abort |  Major | wal |
+| [HBASE-26792](https://issues.apache.org/jira/browse/HBASE-26792) | Implement ScanInfo#toString |  Minor | regionserver |
+| [HBASE-26731](https://issues.apache.org/jira/browse/HBASE-26731) | Metrics for tracking of active scanners |  Minor | . |
+| [HBASE-26789](https://issues.apache.org/jira/browse/HBASE-26789) | Automatically add default security headers to http/rest if SSL enabled |  Major | REST, UI |
+| [HBASE-26723](https://issues.apache.org/jira/browse/HBASE-26723) | Switch to use log4j2.properties file to configure log4j2 |  Major | logging |
+| [HBASE-26765](https://issues.apache.org/jira/browse/HBASE-26765) | Minor refactor of async scanning code |  Major | . |
+| [HBASE-26659](https://issues.apache.org/jira/browse/HBASE-26659) | The ByteBuffer of metadata in RAMQueueEntry in BucketCache could be reused. |  Major | BucketCache, Performance |
+| [HBASE-26730](https://issues.apache.org/jira/browse/HBASE-26730) | Extend hbase shell 'status' command to support an option 'tasks' |  Minor | Operability, shell |
+| [HBASE-26709](https://issues.apache.org/jira/browse/HBASE-26709) | Ban the usage of junit 3 TestCase |  Major | test |
+| [HBASE-26702](https://issues.apache.org/jira/browse/HBASE-26702) | Make ageOfLastShip, ageOfLastApplied  extend TimeHistogram instead of plain histogram. |  Minor | metrics, Replication |
+| [HBASE-26726](https://issues.apache.org/jira/browse/HBASE-26726) | Allow disable of region warmup before graceful move |  Minor | master, Region Assignment |
+| [HBASE-26657](https://issues.apache.org/jira/browse/HBASE-26657) | ProfileServlet should move the output location to hbase specific directory |  Minor | . |
+| [HBASE-26567](https://issues.apache.org/jira/browse/HBASE-26567) | Remove IndexType from ChunkCreator |  Major | in-memory-compaction |
+| [HBASE-26641](https://issues.apache.org/jira/browse/HBASE-26641) | Split TestMasterFailoverWithProcedures |  Major | proc-v2, test |
+| [HBASE-26629](https://issues.apache.org/jira/browse/HBASE-26629) | Add expiration for long time vacant scanners in Thrift2 |  Major | Performance, Thrift |
+| [HBASE-26635](https://issues.apache.org/jira/browse/HBASE-26635) | Optimize decodeNumeric in OrderedBytes |  Major | Performance |
+| [HBASE-26623](https://issues.apache.org/jira/browse/HBASE-26623) | Report CallDroppedException in exception metrics |  Minor | IPC/RPC, metrics, rpc |
+| [HBASE-26609](https://issues.apache.org/jira/browse/HBASE-26609) | Round the size to MB or KB at the end of calculation in HRegionServer.createRegionLoad |  Major | regionserver |
+| [HBASE-26598](https://issues.apache.org/jira/browse/HBASE-26598) | Fix excessive connections in MajorCompactor |  Major | Compaction, tooling |
+| [HBASE-23303](https://issues.apache.org/jira/browse/HBASE-23303) | Add security headers to REST server/info page |  Major | REST |
+
+
+### BUG FIXES:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-26856](https://issues.apache.org/jira/browse/HBASE-26856) | BufferedDataBlockEncoder.OnheapDecodedCell value can get corrupted |  Major | . |
+| [HBASE-27106](https://issues.apache.org/jira/browse/HBASE-27106) | HBase site generation should use its own JRuby |  Major | website |
+| [HBASE-27097](https://issues.apache.org/jira/browse/HBASE-27097) | SimpleRpcServer is broken |  Blocker | rpc |
+| [HBASE-27103](https://issues.apache.org/jira/browse/HBASE-27103) | All MR UTs are broken because of ClassNotFound |  Critical | hadoop3, test |
+| [HBASE-27066](https://issues.apache.org/jira/browse/HBASE-27066) | The Region Visualizer display failed |  Major | . |
+| [HBASE-27092](https://issues.apache.org/jira/browse/HBASE-27092) | Regionserver table on Master UI is broken |  Major | master |
+| [HBASE-27038](https://issues.apache.org/jira/browse/HBASE-27038) | CellComparator should extend Serializable |  Minor | . |
+| [HBASE-27017](https://issues.apache.org/jira/browse/HBASE-27017) | MOB snapshot is broken when FileBased SFT is used |  Major | mob |
+| [HBASE-26985](https://issues.apache.org/jira/browse/HBASE-26985) | SecureBulkLoadManager will set wrong permission if umask too strict |  Major | regionserver |
+| [HBASE-27079](https://issues.apache.org/jira/browse/HBASE-27079) | Lower some DEBUG level logs in ReplicationSourceWALReader to TRACE |  Minor | . |
+| [HBASE-27067](https://issues.apache.org/jira/browse/HBASE-27067) | Upgrade pyjwt to version 2.4.0 or later for dev-support/git-jira-release-audit |  Trivial | . |
+| [HBASE-27068](https://issues.apache.org/jira/browse/HBASE-27068) | NPE occurs when the active master has not yet been elected |  Major | . |
+| [HBASE-27064](https://issues.apache.org/jira/browse/HBASE-27064) | CME in TestRegionNormalizerWorkQueue |  Minor | test |
+| [HBASE-27069](https://issues.apache.org/jira/browse/HBASE-27069) | Hbase SecureBulkload permission regression |  Major | . |
+| [HBASE-27065](https://issues.apache.org/jira/browse/HBASE-27065) | Build against Hadoop 3.3.3 |  Major | build |
+| [HBASE-26854](https://issues.apache.org/jira/browse/HBASE-26854) | Shell startup logs a bunch of noise |  Major | . |
+| [HBASE-27061](https://issues.apache.org/jira/browse/HBASE-27061) | two phase bulkload is broken when SFT is in use. |  Major | . |
+| [HBASE-27055](https://issues.apache.org/jira/browse/HBASE-27055) | Add additional comments when using HBASE\_TRACE\_OPTS with standalone mode |  Minor | tracing |
+| [HBASE-27030](https://issues.apache.org/jira/browse/HBASE-27030) | Fix undefined local variable error in draining\_servers.rb |  Major | jruby, shell |
+| [HBASE-27047](https://issues.apache.org/jira/browse/HBASE-27047) | Fix typo for metric drainingRegionServers |  Minor | metrics |
+| [HBASE-27027](https://issues.apache.org/jira/browse/HBASE-27027) | Deprecated jetty SslContextFactory cause HMaster startup failure due to multiple certificates in KeyStores |  Major | security |
+| [HBASE-27032](https://issues.apache.org/jira/browse/HBASE-27032) | The draining region servers metric description is incorrect |  Minor | . |
+| [HBASE-27019](https://issues.apache.org/jira/browse/HBASE-27019) | Minor compression performance improvements |  Trivial | . |
+| [HBASE-26905](https://issues.apache.org/jira/browse/HBASE-26905) | ReplicationPeerManager#checkPeerExists should throw ReplicationPeerNotFoundException if peer doesn't exists |  Major | Replication |
+| [HBASE-27021](https://issues.apache.org/jira/browse/HBASE-27021) | StoreFileInfo should set its initialPath in a consistent way |  Major | . |
+| [HBASE-27020](https://issues.apache.org/jira/browse/HBASE-27020) | Fix spotless warn for master branch |  Minor | . |
+| [HBASE-27015](https://issues.apache.org/jira/browse/HBASE-27015) | Fix log format for ServerManager |  Minor | . |
+| [HBASE-26994](https://issues.apache.org/jira/browse/HBASE-26994) | MasterFileSystem create directory without permission check |  Major | master |
+| [HBASE-26963](https://issues.apache.org/jira/browse/HBASE-26963) | ReplicationSource#removePeer hangs if we try to remove bad peer. |  Major | regionserver, Replication |
+| [HBASE-27000](https://issues.apache.org/jira/browse/HBASE-27000) | Block cache stats (Misses Caching) display error in RS web UI |  Major | . |
+| [HBASE-26984](https://issues.apache.org/jira/browse/HBASE-26984) | Chaos Monkey thread dies in ITBLL Chaos GracefulRollingRestartRsAction |  Major | integration tests |
+| [HBASE-26992](https://issues.apache.org/jira/browse/HBASE-26992) | Brotli compressor has unexpected behavior during reinitialization |  Minor | . |
+| [HBASE-26960](https://issues.apache.org/jira/browse/HBASE-26960) | Another case for unnecessary replication suspending in RegionReplicationSink |  Major | read replicas |
+| [HBASE-26988](https://issues.apache.org/jira/browse/HBASE-26988) | Balancer should reset to default setting for hbase.master.loadbalance.bytable if dynamically reloading configuration |  Minor | Balancer |
+| [HBASE-26917](https://issues.apache.org/jira/browse/HBASE-26917) | Do not add --threads when running 'mvn site' |  Major | build, scripts |
+| [HBASE-22349](https://issues.apache.org/jira/browse/HBASE-22349) | Stochastic Load Balancer skips balancing when node is replaced in cluster |  Major | Balancer |
+| [HBASE-26978](https://issues.apache.org/jira/browse/HBASE-26978) | Update inmemory\_compaction.adoc |  Minor | documentation |
+| [HBASE-26979](https://issues.apache.org/jira/browse/HBASE-26979) | StoreFileListFile logs frequent stacktraces at INFO level |  Minor | . |
+| [HBASE-26951](https://issues.apache.org/jira/browse/HBASE-26951) | HMaster should exit gracefully, when stopped via hbase-daemon.sh |  Critical | master |
+| [HBASE-26964](https://issues.apache.org/jira/browse/HBASE-26964) | Fix java import in admin.rb |  Minor | shell |
+| [HBASE-26941](https://issues.apache.org/jira/browse/HBASE-26941) | LocalHBaseCluster.waitOnRegionServer should not call join while interrupted |  Critical | test |
+| [HBASE-26938](https://issues.apache.org/jira/browse/HBASE-26938) | Compaction failures after StoreFileTracker integration |  Blocker | Compaction |
+| [HBASE-26944](https://issues.apache.org/jira/browse/HBASE-26944) | Possible resource leak while creating new region scanner |  Major | . |
+| [HBASE-26895](https://issues.apache.org/jira/browse/HBASE-26895) | on hbase shell, 'delete/deleteall' for a columnfamily is not working |  Major | shell |
+| [HBASE-26901](https://issues.apache.org/jira/browse/HBASE-26901) | delete with null columnQualifier occurs NullPointerException when NewVersionBehavior is on |  Major | Deletes, Scanners |
+| [HBASE-26880](https://issues.apache.org/jira/browse/HBASE-26880) | Misspelling commands in hbase shell will crash the shell |  Minor | shell |
+| [HBASE-26924](https://issues.apache.org/jira/browse/HBASE-26924) | [Documentation] Fix log parameter error and spelling error |  Trivial | logging |
+| [HBASE-26811](https://issues.apache.org/jira/browse/HBASE-26811) | Secondary replica may be disabled for read incorrectly forever |  Major | read replicas |
+| [HBASE-26838](https://issues.apache.org/jira/browse/HBASE-26838) | Junit jar is not included in the hbase tar ball, causing issues for some  hbase tools that do rely on it |  Major | integration tests, tooling |
+| [HBASE-26896](https://issues.apache.org/jira/browse/HBASE-26896) | list\_quota\_snapshots fails with ¿ERROR NameError: uninitialized constant Shell::Commands::ListQuotaSnapshots::TABLE¿ |  Major | shell |
+| [HBASE-26718](https://issues.apache.org/jira/browse/HBASE-26718) | HFileArchiver can remove referenced StoreFiles from the archive |  Major | Compaction, HFile, snapshots |
+| [HBASE-26864](https://issues.apache.org/jira/browse/HBASE-26864) | SplitTableRegionProcedure calls openParentRegions() at a wrong state during rollback. |  Major | Region Assignment |
+| [HBASE-26810](https://issues.apache.org/jira/browse/HBASE-26810) | Add dynamic configuration support for system coprocessors |  Major | conf, Coprocessors |
+| [HBASE-26869](https://issues.apache.org/jira/browse/HBASE-26869) | RSRpcServices.scan should deep clone cells when RpcCallContext is null |  Major | regionserver |
+| [HBASE-26866](https://issues.apache.org/jira/browse/HBASE-26866) | Shutdown WAL may abort region server |  Major | wal |
+| [HBASE-26870](https://issues.apache.org/jira/browse/HBASE-26870) | Log4j2 integration is incorrect in nighly's client integration test |  Critical | jenkins, logging |
+| [HBASE-26840](https://issues.apache.org/jira/browse/HBASE-26840) | Fix NPE in the retry of logroller |  Minor | wal |
+| [HBASE-26831](https://issues.apache.org/jira/browse/HBASE-26831) | TestAdminShell2 is failing because of we referenced a deleted method |  Major | shell |
+| [HBASE-26670](https://issues.apache.org/jira/browse/HBASE-26670) | HFileLinkCleaner should be added even if snapshot is disabled |  Critical | snapshots |
+| [HBASE-26761](https://issues.apache.org/jira/browse/HBASE-26761) | TestMobStoreScanner (testGetMassive) can OOME |  Minor | mob, test |
+| [HBASE-26816](https://issues.apache.org/jira/browse/HBASE-26816) | Fix CME in ReplicationSourceManager |  Minor | Replication |
+| [HBASE-26821](https://issues.apache.org/jira/browse/HBASE-26821) | Bump dependencies in /dev-support/git-jira-release-audit |  Minor | dependabot |
+| [HBASE-26715](https://issues.apache.org/jira/browse/HBASE-26715) | Blocked on SyncFuture in AsyncProtobufLogWriter#write |  Major | . |
+| [HBASE-26815](https://issues.apache.org/jira/browse/HBASE-26815) | TestFanOutOneBlockAsyncDFSOutput is flakey |  Major | test |
+| [HBASE-26768](https://issues.apache.org/jira/browse/HBASE-26768) | Avoid unnecessary replication suspending in RegionReplicationSink |  Major | read replicas |
+| [HBASE-26805](https://issues.apache.org/jira/browse/HBASE-26805) | TestRegionHDFSBlockLocationFinder is flaky |  Major | Balancer, test |
+| [HBASE-26799](https://issues.apache.org/jira/browse/HBASE-26799) | TestCanaryTool.testWriteTableTimeout is flaky |  Major | . |
+| [HBASE-26777](https://issues.apache.org/jira/browse/HBASE-26777) | BufferedDataBlockEncoder$OffheapDecodedExtendedCell.deepClone throws UnsupportedOperationException |  Major | regionserver |
+| [HBASE-26787](https://issues.apache.org/jira/browse/HBASE-26787) | TestRegionReplicaReplicationError should inject error in replicateToReplica method |  Major | test |
+| [HBASE-26745](https://issues.apache.org/jira/browse/HBASE-26745) | MetricsStochasticBalancerSource metrics don't render in /jmx endpoint |  Minor | . |
+| [HBASE-26776](https://issues.apache.org/jira/browse/HBASE-26776) | RpcServer failure to SASL handshake always logs user "unknown" to audit log |  Major | security |
+| [HBASE-26772](https://issues.apache.org/jira/browse/HBASE-26772) | Shell suspended in background |  Minor | shell |
+| [HBASE-26767](https://issues.apache.org/jira/browse/HBASE-26767) | Rest server should not use a large Header Cache. |  Major | REST |
+| [HBASE-26546](https://issues.apache.org/jira/browse/HBASE-26546) | hbase-shaded-client missing required thirdparty classes under hadoop 3.3.1 |  Major | Client, hadoop3, shading |
+| [HBASE-26727](https://issues.apache.org/jira/browse/HBASE-26727) | Fix CallDroppedException reporting |  Minor | . |
+| [HBASE-26712](https://issues.apache.org/jira/browse/HBASE-26712) | Balancer encounters NPE in rare case |  Major | . |
+| [HBASE-26742](https://issues.apache.org/jira/browse/HBASE-26742) | Comparator of NOT\_EQUAL NULL is invalid for checkAndMutate |  Major | . |
+| [HBASE-26688](https://issues.apache.org/jira/browse/HBASE-26688) | Threads shared EMPTY\_RESULT may lead to unexpected client job down. |  Major | Client |
+| [HBASE-26755](https://issues.apache.org/jira/browse/HBASE-26755) | HBase website generation should show error details on failure |  Major | website |
+| [HBASE-26753](https://issues.apache.org/jira/browse/HBASE-26753) | RegionReplicationSink.send set timeout for replicating meta edits error |  Major | . |
+| [HBASE-26741](https://issues.apache.org/jira/browse/HBASE-26741) | Incorrect exception handling in shell |  Critical | shell |
+| [HBASE-26713](https://issues.apache.org/jira/browse/HBASE-26713) | Increments submitted by 1.x clients will be stored with timestamp 0 on 2.x+ clusters |  Major | . |
+| [HBASE-26679](https://issues.apache.org/jira/browse/HBASE-26679) | Wait on the future returned by FanOutOneBlockAsyncDFSOutput.flush would stuck |  Critical | wal |
+| [HBASE-26675](https://issues.apache.org/jira/browse/HBASE-26675) | Data race on Compactor.writer |  Major | Compaction |
+| [HBASE-26674](https://issues.apache.org/jira/browse/HBASE-26674) | Should modify filesCompacting under storeWriteLock |  Major | Compaction |
+| [HBASE-26662](https://issues.apache.org/jira/browse/HBASE-26662) | User.createUserForTesting should not reset UserProvider.groups every time if hbase.group.service.for.test.only is true |  Major | . |
+| [HBASE-26654](https://issues.apache.org/jira/browse/HBASE-26654) | ModifyTableDescriptorProcedure shoud load TableDescriptor while executing |  Major | master, proc-v2 |
+| [HBASE-26671](https://issues.apache.org/jira/browse/HBASE-26671) | Misspellings of hbck usage |  Minor | hbck |
+| [HBASE-26469](https://issues.apache.org/jira/browse/HBASE-26469) | correct HBase shell exit behavior to match code passed to exit |  Critical | shell |
+| [HBASE-26543](https://issues.apache.org/jira/browse/HBASE-26543) | correct parsing of hbase shell args with GetoptLong |  Blocker | shell |
+| [HBASE-26643](https://issues.apache.org/jira/browse/HBASE-26643) | LoadBalancer should not return empty map |  Critical | proc-v2, Region Assignment, test |
+| [HBASE-26646](https://issues.apache.org/jira/browse/HBASE-26646) | WALPlayer should obtain token from filesystem |  Minor | . |
+| [HBASE-26578](https://issues.apache.org/jira/browse/HBASE-26578) | CompactedHFilesDischarger should be shutdown when aborting regionserver |  Major | master, regionserver |
+| [HBASE-26494](https://issues.apache.org/jira/browse/HBASE-26494) | Using RefCnt to fix the flawed MemStoreLABImpl |  Major | regionserver |
+| [HBASE-26625](https://issues.apache.org/jira/browse/HBASE-26625) | ExportSnapshot tool failed to copy data files for tables with merge region |  Minor | . |
+| [HBASE-26615](https://issues.apache.org/jira/browse/HBASE-26615) | Snapshot referenced data files are deleted when delete a table with merge regions |  Major | . |
+| [HBASE-26613](https://issues.apache.org/jira/browse/HBASE-26613) | The logic of the method incrementIV in Encryption class has problem |  Major | Performance, security |
+
+
+### TESTS:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-27039](https://issues.apache.org/jira/browse/HBASE-27039) | Some methods of MasterRegion should be annotated for testing only |  Minor | master |
+| [HBASE-27054](https://issues.apache.org/jira/browse/HBASE-27054) | TestStochasticLoadBalancerRegionReplicaLargeCluster.testRegionReplicasOnLargeCluster is flaky |  Major | test |
+| [HBASE-27052](https://issues.apache.org/jira/browse/HBASE-27052) | TestAsyncTableScanner.testScanWrongColumnFamily is flaky |  Major | test |
+| [HBASE-27051](https://issues.apache.org/jira/browse/HBASE-27051) | TestReplicationSource.testReplicationSourceInitializingMetric is flaky |  Minor | test |
+| [HBASE-27050](https://issues.apache.org/jira/browse/HBASE-27050) | Support unit test pattern matching again |  Minor | test |
+| [HBASE-26989](https://issues.apache.org/jira/browse/HBASE-26989) | TestStochasticLoadBalancer has some slow methods, and inconsistent set, reset, unset of configuration |  Minor | Balancer, test |
+
+
+### SUB-TASKS:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-27121](https://issues.apache.org/jira/browse/HBASE-27121) | Set version as 3.0.0-alpha-3 in master in prep for first RC of 3.0.0-alpha-3 |  Major | build, pom |
+| [HBASE-26167](https://issues.apache.org/jira/browse/HBASE-26167) | Allow users to not start zookeeper and dfs cluster when using TestingHBaseCluster |  Major | test |
+| [HBASE-26366](https://issues.apache.org/jira/browse/HBASE-26366) | Provide meaningful parent spans to ZK interactions |  Major | tracing |
+| [HBASE-15519](https://issues.apache.org/jira/browse/HBASE-15519) | Add per-user metrics |  Major | metrics |
+| [HBASE-27006](https://issues.apache.org/jira/browse/HBASE-27006) | cordon off large ci worker nodes |  Major | . |
+| [HBASE-26855](https://issues.apache.org/jira/browse/HBASE-26855) | Delete unnecessary dependency on jaxb-runtime jar |  Major | . |
+| [HBASE-27024](https://issues.apache.org/jira/browse/HBASE-27024) | The User API and Developer API links are broken on hbase.apache.org |  Major | website |
+| [HBASE-27045](https://issues.apache.org/jira/browse/HBASE-27045) | Disable TestClusterScopeQuotaThrottle |  Major | test |
+| [HBASE-26986](https://issues.apache.org/jira/browse/HBASE-26986) | Trace a one-shot execution of a Master procedure |  Major | . |
+| [HBASE-26999](https://issues.apache.org/jira/browse/HBASE-26999) | HStore should try write WAL compaction marker before replacing compacted files in StoreEngine |  Major | . |
+| [HBASE-26330](https://issues.apache.org/jira/browse/HBASE-26330) | Document new provided compression codecs |  Blocker | . |
+| [HBASE-26995](https://issues.apache.org/jira/browse/HBASE-26995) | Remove ref guide check in pre commit and nightly for branches other than master |  Major | build, scripts |
+| [HBASE-26931](https://issues.apache.org/jira/browse/HBASE-26931) | Add the information of EOL releases to our ref guide on master branch |  Major | documentation |
+| [HBASE-26648](https://issues.apache.org/jira/browse/HBASE-26648) | Improve fidelity of RegionLocator spans |  Major | tracing |
+| [HBASE-26899](https://issues.apache.org/jira/browse/HBASE-26899) | Run spotless:apply |  Major | . |
+| [HBASE-26932](https://issues.apache.org/jira/browse/HBASE-26932) | Skip generating ref guide when running 'mvn site' on branch other than master |  Major | build, pom |
+| [HBASE-25058](https://issues.apache.org/jira/browse/HBASE-25058) | Export necessary modules when running under JDK11 |  Major | Performance, rpc |
+| [HBASE-26928](https://issues.apache.org/jira/browse/HBASE-26928) | Fix several indentation problems |  Major | . |
+| [HBASE-26922](https://issues.apache.org/jira/browse/HBASE-26922) | Fix LineLength warnings as much as possible if it can not be fixed by spotless |  Major | . |
+| [HBASE-26929](https://issues.apache.org/jira/browse/HBASE-26929) | Upgrade surefire plugin to 3.0.0-M6 |  Major | pom, test |
+| [HBASE-26927](https://issues.apache.org/jira/browse/HBASE-26927) | Add snapshot scanner UT with SFT and some cleanups to TestTableSnapshotScanner |  Major | . |
+| [HBASE-26916](https://issues.apache.org/jira/browse/HBASE-26916) | Fix missing braces warnings in DefaultVisibilityExpressionResolver |  Major | . |
+| [HBASE-26919](https://issues.apache.org/jira/browse/HBASE-26919) | Rewrite the counting rows part in TestFromClientSide4 |  Major | test |
+| [HBASE-26920](https://issues.apache.org/jira/browse/HBASE-26920) | Fix missing braces warnings in TestProcedureMember |  Major | test |
+| [HBASE-26921](https://issues.apache.org/jira/browse/HBASE-26921) | Rewrite the counting cells part in TestMultiVersions |  Major | test |
+| [HBASE-26545](https://issues.apache.org/jira/browse/HBASE-26545) | Implement tracing of scan |  Major | tracing |
+| [HBASE-26531](https://issues.apache.org/jira/browse/HBASE-26531) | Trace coprocessor exec endpoints |  Major | . |
+| [HBASE-26791](https://issues.apache.org/jira/browse/HBASE-26791) | Memstore flush fencing issue for SFT |  Major | HFile |
+| [HBASE-26837](https://issues.apache.org/jira/browse/HBASE-26837) | Set SFT config when creating TableDescriptor in TestCloneSnapshotProcedure |  Major | test |
+| [HBASE-25896](https://issues.apache.org/jira/browse/HBASE-25896) | Implement a Region Visualization on Master WebUI |  Major | . |
+| [HBASE-26611](https://issues.apache.org/jira/browse/HBASE-26611) | Changing SFT implementation on disabled table is dangerous |  Critical | HFile, proc-v2 |
+| [HBASE-25895](https://issues.apache.org/jira/browse/HBASE-25895) | Implement a Cluster Metrics JSON endpoint |  Major | . |
+| [HBASE-26824](https://issues.apache.org/jira/browse/HBASE-26824) | TestHBaseTestingUtil.testResolvePortConflict failing after HBASE-26582 |  Major | . |
+| [HBASE-26582](https://issues.apache.org/jira/browse/HBASE-26582) | Prune use of Random and SecureRandom objects |  Minor | . |
+| [HBASE-26764](https://issues.apache.org/jira/browse/HBASE-26764) | Implement generic exception support for TraceUtil methods over Callables and Runnables |  Major | . |
+| [HBASE-26759](https://issues.apache.org/jira/browse/HBASE-26759) | Fix trace continuity through CallRunner |  Major | . |
+| [HBASE-26707](https://issues.apache.org/jira/browse/HBASE-26707) | Reduce number of renames during bulkload |  Major | . |
+| [HBASE-26640](https://issues.apache.org/jira/browse/HBASE-26640) | Reimplement master local region initialization to better work with SFT |  Major | master, RegionProcedureStore |
+| [HBASE-26673](https://issues.apache.org/jira/browse/HBASE-26673) | Implement a shell command for change SFT implementation |  Major | shell |
+| [HBASE-26434](https://issues.apache.org/jira/browse/HBASE-26434) | Compact L0 files for cold regions using StripeCompactionPolicy |  Major | . |
+| [HBASE-26749](https://issues.apache.org/jira/browse/HBASE-26749) | Migrate HBase main pre commit job to ci-hbase |  Major | . |
+| [HBASE-26697](https://issues.apache.org/jira/browse/HBASE-26697) | Migrate HBase Nightly HBase-Flaky-Tests and HBase-Find-Flaky-Tests to ci-hbase |  Major | jenkins |
+| [HBASE-26521](https://issues.apache.org/jira/browse/HBASE-26521) | Name RPC spans as \`$package.$service/$method\` |  Major | . |
+| [HBASE-26747](https://issues.apache.org/jira/browse/HBASE-26747) | Use python2 instead of python in our python scripts |  Major | jenkins |
+| [HBASE-26473](https://issues.apache.org/jira/browse/HBASE-26473) | Introduce \`db.hbase.container\_operations\` span attribute |  Major | . |
+| [HBASE-26587](https://issues.apache.org/jira/browse/HBASE-26587) | Introduce a new Admin API to change SFT implementation |  Major | Admin, API |
+| [HBASE-26690](https://issues.apache.org/jira/browse/HBASE-26690) | Modify FSTableDescriptors to not rely on renaming when writing TableDescriptor |  Major | master |
+| [HBASE-26711](https://issues.apache.org/jira/browse/HBASE-26711) | Remove 2.3 from Downloads page |  Major | . |
+| [HBASE-26700](https://issues.apache.org/jira/browse/HBASE-26700) | The way we bypass broken track file is not enough in StoreFileListFile |  Critical | HFile |
+| [HBASE-26474](https://issues.apache.org/jira/browse/HBASE-26474) | Implement connection-level attributes |  Major | . |
+| [HBASE-26520](https://issues.apache.org/jira/browse/HBASE-26520) | Remove use of \`db.hbase.namespace\` tracing attribute |  Major | . |
+| [HBASE-26661](https://issues.apache.org/jira/browse/HBASE-26661) | Remove deprecated methods in MasterObserver |  Major | Coprocessors, master |
+| [HBASE-26397](https://issues.apache.org/jira/browse/HBASE-26397) | Display the excluded datanodes on regionserver UI |  Major | . |
+| [HBASE-26586](https://issues.apache.org/jira/browse/HBASE-26586) | Should not rely on the global config when setting SFT implementation for a table while upgrading |  Critical | HFile |
+| [HBASE-26639](https://issues.apache.org/jira/browse/HBASE-26639) | The implementation of TestMergesSplitsAddToTracker is problematic |  Major | test |
+| [HBASE-26585](https://issues.apache.org/jira/browse/HBASE-26585) | Add SFT configuration to META table descriptor when creating META |  Major | . |
+| [HBASE-26621](https://issues.apache.org/jira/browse/HBASE-26621) | Set version as 3.0.0-alpha-3-SNAPSHOT in master |  Major | website |
+| [HBASE-26079](https://issues.apache.org/jira/browse/HBASE-26079) | Use StoreFileTracker when splitting and merging |  Major | proc-v2 |
+| [HBASE-26620](https://issues.apache.org/jira/browse/HBASE-26620) | Add 3.0.0-alpha-2 to download page |  Major | website |
+| [HBASE-26487](https://issues.apache.org/jira/browse/HBASE-26487) | Run some tests to verify the new region replication framework |  Major | integration tests, test |
+| [HBASE-26540](https://issues.apache.org/jira/browse/HBASE-26540) | Implement a tool to verify the lag of region replication |  Major | read replicas |
+| [HBASE-26265](https://issues.apache.org/jira/browse/HBASE-26265) | Update ref guide to mention the new store file tracker implementations |  Major | documentation |
+| [HBASE-26286](https://issues.apache.org/jira/browse/HBASE-26286) | Add support for specifying store file tracker when restoring or cloning snapshot |  Major | HFile, snapshots |
+| [HBASE-26539](https://issues.apache.org/jira/browse/HBASE-26539) | The default rpc timeout 200ms is too small for replicating meta edits |  Major | read replicas |
+| [HBASE-26538](https://issues.apache.org/jira/browse/HBASE-26538) | Should find a way to clear the replication queue for a legacy region\_replica\_replication peer |  Major | read replicas, Replication |
+| [HBASE-26486](https://issues.apache.org/jira/browse/HBASE-26486) | Attach the new region replication framework design doc to git repo |  Major | documentation |
+| [HBASE-26478](https://issues.apache.org/jira/browse/HBASE-26478) | Update ref guide about the new region replication framework |  Major | documentation |
+| [HBASE-26481](https://issues.apache.org/jira/browse/HBASE-26481) | Consider rolling upgrading from old region replication framework |  Major | read replicas |
+| [HBASE-26417](https://issues.apache.org/jira/browse/HBASE-26417) | Remove NoopReplicationQueueStorage |  Major | meta replicas, read replicas, Replication |
+| [HBASE-26456](https://issues.apache.org/jira/browse/HBASE-26456) | Limit the size for one replicating |  Major | read replicas |
+| [HBASE-26416](https://issues.apache.org/jira/browse/HBASE-26416) | Implement a new method for region replication instead of using replay |  Major | read replicas |
+| [HBASE-26454](https://issues.apache.org/jira/browse/HBASE-26454) | CreateTableProcedure still relies on temp dir and renames when creating table FS layout |  Major | . |
+| [HBASE-26457](https://issues.apache.org/jira/browse/HBASE-26457) | Should not always clear all the failed replicas when getting a flush all request |  Major | read replicas |
+| [HBASE-26448](https://issues.apache.org/jira/browse/HBASE-26448) | Make sure we do not flush a region too frequently |  Major | . |
+| [HBASE-26449](https://issues.apache.org/jira/browse/HBASE-26449) | The way we add or clear failedReplicas may have race |  Major | read replicas |
+| [HBASE-26413](https://issues.apache.org/jira/browse/HBASE-26413) | Limit the total size of buffered region replication entries |  Major | read replicas |
+| [HBASE-26271](https://issues.apache.org/jira/browse/HBASE-26271) | Cleanup the broken store files under data directory |  Major | HFile |
+| [HBASE-26412](https://issues.apache.org/jira/browse/HBASE-26412) | Handle sink failure in RegionReplicationSink |  Major | read replicas |
+| [HBASE-26263](https://issues.apache.org/jira/browse/HBASE-26263) | [Rolling Upgrading] Persist the StoreFileTracker configurations to TableDescriptor for existing tables |  Major | HFile, master |
+| [HBASE-26407](https://issues.apache.org/jira/browse/HBASE-26407) | Introduce a region replication sink for sinking WAL edits to secondary replicas directly |  Major | read replicas |
+| [HBASE-26328](https://issues.apache.org/jira/browse/HBASE-26328) | Clone snapshot doesn't load reference files into FILE SFT impl |  Major | HFile, snapshots |
+| [HBASE-26386](https://issues.apache.org/jira/browse/HBASE-26386) | Refactor StoreFileTracker implementations to expose the set method |  Major | HFile |
+| [HBASE-26326](https://issues.apache.org/jira/browse/HBASE-26326) | CreateTableProcedure fails when FileBasedStoreFileTracker is set in global config |  Major | . |
+| [HBASE-26280](https://issues.apache.org/jira/browse/HBASE-26280) | Use store file tracker when snapshoting |  Major | HFile, snapshots |
+| [HBASE-26264](https://issues.apache.org/jira/browse/HBASE-26264) | Add more checks to prevent misconfiguration on store file tracker |  Major | conf, HFile |
+| [HBASE-26248](https://issues.apache.org/jira/browse/HBASE-26248) | Should find a suitable way to let users specify the store file tracker implementation |  Major | HFile |
+| [HBASE-26246](https://issues.apache.org/jira/browse/HBASE-26246) | Persist the StoreFileTracker configurations to TableDescriptor when creating table |  Major | HFile, master |
+| [HBASE-26224](https://issues.apache.org/jira/browse/HBASE-26224) | Introduce a MigrationStoreFileTracker to support migrating from different store file tracker implementations |  Major | HFile |
+| [HBASE-25988](https://issues.apache.org/jira/browse/HBASE-25988) | Store the store file list by a file |  Major | HFile |
+| [HBASE-26064](https://issues.apache.org/jira/browse/HBASE-26064) | Introduce a StoreFileTracker to abstract the store file tracking logic |  Major | HFile |
+
+
+### OTHER:
+
+| JIRA | Summary | Priority | Component |
+|:---- |:---- | :--- |:---- |
+| [HBASE-27037](https://issues.apache.org/jira/browse/HBASE-27037) | Display the region server state on the Web UI |  Major | . |
+| [HBASE-26067](https://issues.apache.org/jira/browse/HBASE-26067) | Change the way on how we track store file list |  Major | HFile |
+| [HBASE-26245](https://issues.apache.org/jira/browse/HBASE-26245) | Store region server list in master local region |  Major | master, Zookeeper |
+| [HBASE-26233](https://issues.apache.org/jira/browse/HBASE-26233) | The region replication framework should not be built upon the general replication framework |  Major | read replicas |
+| [HBASE-22953](https://issues.apache.org/jira/browse/HBASE-22953) | Supporting Hadoop 3.3.0 |  Major | hadoop3 |
+| [HBASE-26949](https://issues.apache.org/jira/browse/HBASE-26949) | Purge references to ports 60010 and 60030 from the book |  Minor | documentation |
+| [HBASE-27108](https://issues.apache.org/jira/browse/HBASE-27108) | Revert HBASE-25709 |  Blocker | . |
+| [HBASE-27102](https://issues.apache.org/jira/browse/HBASE-27102) | Vacate the .idea folder in order to simplify spotless configuration |  Major | build |
+| [HBASE-27023](https://issues.apache.org/jira/browse/HBASE-27023) | Add protobuf to NOTICE file |  Major | . |
+| [HBASE-27082](https://issues.apache.org/jira/browse/HBASE-27082) | Change the return value of RSGroupInfo.getServers from SortedSet to Set to keep compatibility |  Blocker | rsgroup |
+| [HBASE-26912](https://issues.apache.org/jira/browse/HBASE-26912) | Bump checkstyle from 8.28 to 8.29 |  Minor | test |
+| [HBASE-26523](https://issues.apache.org/jira/browse/HBASE-26523) | Upgrade hbase-thirdparty dependency to 4.0.1 |  Blocker | thirdparty |
+| [HBASE-26892](https://issues.apache.org/jira/browse/HBASE-26892) | Add spotless:check in our pre commit general check |  Major | jenkins |
+| [HBASE-26954](https://issues.apache.org/jira/browse/HBASE-26954) | Compilation of master vs hadoop-3.3.2 fails |  Major | build, hadoop3 |
+| [HBASE-26908](https://issues.apache.org/jira/browse/HBASE-26908) | Remove warnings from meta replicas feature references in the HBase book |  Major | documentation |
+| [HBASE-26903](https://issues.apache.org/jira/browse/HBASE-26903) | Bump httpclient from 4.5.3 to 4.5.13 |  Minor | . |
+| [HBASE-26902](https://issues.apache.org/jira/browse/HBASE-26902) | Bump bcprov-jdk15on from 1.60 to 1.67 |  Minor | . |
+| [HBASE-26834](https://issues.apache.org/jira/browse/HBASE-26834) | Adapt ConnectionRule for both sync and async connections |  Major | test |
+| [HBASE-26861](https://issues.apache.org/jira/browse/HBASE-26861) | Fix flaky TestSnapshotFromMaster.testSnapshotHFileArchiving |  Major | snapshots, test |
+| [HBASE-26822](https://issues.apache.org/jira/browse/HBASE-26822) | Revert the changes on hbase-daemon.sh after switching to log4j2 properties file |  Major | logging, scripts |
+| [HBASE-26819](https://issues.apache.org/jira/browse/HBASE-26819) | Minor code cleanup in and around RpcScheduler |  Minor | IPC/RPC |
+| [HBASE-26817](https://issues.apache.org/jira/browse/HBASE-26817) | Mark RpcExecutor as IA.LimitedPrivate COPROC and PHOENIX |  Major | compatibility |
+| [HBASE-26782](https://issues.apache.org/jira/browse/HBASE-26782) | Minor code cleanup in and around RpcExecutor |  Minor | IPC/RPC |
+| [HBASE-26760](https://issues.apache.org/jira/browse/HBASE-26760) | LICENSE handling should not allow non-aggregated "apache-2.0" |  Minor | community |
+| [HBASE-26803](https://issues.apache.org/jira/browse/HBASE-26803) | Ban reload4j and logback dependencies |  Major | dependencies, logging, pom |
+| [HBASE-26788](https://issues.apache.org/jira/browse/HBASE-26788) | Disable Checks API callback from test results in PRs |  Major | build |
+| [HBASE-26622](https://issues.apache.org/jira/browse/HBASE-26622) | Update to error-prone 2.10 |  Major | . |
+| [HBASE-26663](https://issues.apache.org/jira/browse/HBASE-26663) | Upgrade Maven Enforcer Plugin |  Major | build |
+| [HBASE-26714](https://issues.apache.org/jira/browse/HBASE-26714) | Introduce path configuration for system coprocessors |  Major | Coprocessors |
+| [HBASE-26614](https://issues.apache.org/jira/browse/HBASE-26614) | Refactor code related to "dump"ing ZK nodes |  Major | Zookeeper |
+| [HBASE-26551](https://issues.apache.org/jira/browse/HBASE-26551) | Add FastPath feature to HBase RWQueueRpcExecutor |  Major | rpc, Scheduler |
+| [HBASE-26616](https://issues.apache.org/jira/browse/HBASE-26616) | Refactor code related to ZooKeeper authentication |  Major | Zookeeper |
+| [HBASE-26006](https://issues.apache.org/jira/browse/HBASE-26006) | Update ref guide about the 2.4.x release line |  Major | documentation |
+| [HBASE-26632](https://issues.apache.org/jira/browse/HBASE-26632) | Should use downloads.apache.org for checksum, signature, changes.md and releasenote.md |  Major | website |
+| [HBASE-26631](https://issues.apache.org/jira/browse/HBASE-26631) | Upgrade junit to 4.13.2 |  Major | security, test |
+| [HBASE-26634](https://issues.apache.org/jira/browse/HBASE-26634) | Upgrade log4j to 2.17.1 |  Major | logging, security |
+| [HBASE-26636](https://issues.apache.org/jira/browse/HBASE-26636) | Update the ref guide upgrading section to mention that the master issue when upgrading to 2.3 |  Major | documentation |
+| [HBASE-26564](https://issues.apache.org/jira/browse/HBASE-26564) | Retire the method visitLogEntryBeforeWrite without RegionInfo in WALActionListner |  Minor | wal |
+| [HBASE-26566](https://issues.apache.org/jira/browse/HBASE-26566) | Optimize encodeNumeric in OrderedBytes |  Major | Performance |
+
+
+## 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 |

[... 3044 lines stripped ...]