HBASE Changelog

Release 2.3.4 - Unreleased (as of 2021-01-11)

NEW FEATURES:

JIRASummaryPriorityComponent
HBASE-24620Add a ClusterManager which submits command to ZooKeeper and its Agent which picks and execute those Commands.Majorintegration tests

IMPROVEMENTS:

JIRASummaryPriorityComponent
HBASE-25449‘dfs.client.read.shortcircuit’ should not be set in hbase-default.xmlMajorconf
HBASE-25483set the loadMeta log level to debug.MajorMTTR, Region Assignment
HBASE-25435Slow metric value can be configuredMinormetrics
HBASE-25318Configure where IntegrationTestImportTsv generates HFilesMinorintegration tests
HBASE-24850CellComparator perf improvementCriticalPerformance, scan
HBASE-25420Some minor improvements in rpc implementationMinorrpc
HBASE-25246Backup/Restore hbase cell tags.Majorbackup&restore
HBASE-25328Add builder method to create Tags.Minor.
HBASE-25339Method parameter and member variable are duplicated in checkSplittable() of SplitTableRegionProcedureMinor.
HBASE-25237‘hbase master stop’ shuts down the cluster, not the master onlyMajor.
HBASE-25323Fix potential NPE when the zookeeper path of RegionServerTracker does not exist when startMinor.
HBASE-25187Improve SizeCachedKV variants initializationMinor.
HBASE-25289[testing] Clean up resources after tests in rsgroup_shell_test.rbMajorrsgroup, test
HBASE-25261Upgrade Bootstrap to 3.4.1Majorsecurity, UI
HBASE-25267Add SSL keystore type and truststore related configs for HBase RESTServerMajorREST
HBASE-25003Backport HBASE-24350 and HBASE-24779 to branch-2.2 & branch-2.3MajorReplication
HBASE-25240gson format of RpcServer.logResponse is abnormalMinor.
HBASE-24859Optimize in-memory representation of mapreduce TableSplit objectsMajormapreduce
HBASE-25224Maximize sleep for checking meta and namespace regions availabilityMajormaster
HBASE-24872refactor valueOf PoolTypeMinorClient
HBASE-24827BackPort HBASE-11554 Remove Reusable poolmap Rpc client type.MajorClient

BUG FIXES:

JIRASummaryPriorityComponent
HBASE-25459WAL can't be cleaned in some scenesMajor.
HBASE-25434SlowDelete & SlowPut metric value should use updateDelete & updatePutMajorregionserver
HBASE-25441add security check for some APIs in RSRpcServicesCritical.
HBASE-25432we should add security checks for setTableStateInMeta and fixMetaBlocker.
HBASE-25445Old WALs archive fails in procedure based WAL splitCriticalwal
HBASE-25287Forgetting to unbuffer streams results in many CLOSE_WAIT sockets when loading filesMajor.
HBASE-25447remoteProc is suspended due to OOM ERRORMajorproc-v2
HBASE-24755[LOG][RSGroup]Error message is confusing while adding a offline RS to rsgroupMajorrsgroup
HBASE-25463Fix comment errorMinorshell
HBASE-25456setRegionStateInMeta need security checkCritical.
HBASE-25371When openRegion fails during initial verification(before initializing and setting seq num), exception is observed during region close.MajorRegion Assignment
HBASE-25404Procedures table Id under master web UI gets word break to single characterMinorUI
HBASE-25277postScannerFilterRow impacts Scan performance a lot in HBase 2.xCriticalCoprocessors, scan
HBASE-25332one NPEMajorZookeeper
HBASE-25361[Flakey Tests] branch-2 TestMetaRegionLocationCache.testStandByMetaLocationsMajorflakies
HBASE-25230Embedded zookeeper server not clean up the old dataMinorZookeeper
HBASE-25345[Flakey Tests] branch-2 TestReadReplicas#testVerifySecondaryAbilityToReadWithOnFilesMajortest
HBASE-25307ThreadLocal pooling leads to NullPointerExceptionMajorClient
HBASE-25330RSGroupInfoManagerImpl#moveServers return is not set of servers movedMajorrsgroup
HBASE-25321The sort icons not shown after Upgrade JQuery to 3.5.1MajorUI
HBASE-25311ui throws NPEMajor.
HBASE-25306The log in SimpleLoadBalancer#onConfigurationChange is wrongMajor.
HBASE-25300‘Unknown table hbase:quota’ happens when desc table in shell if quota disabledMajorshell
HBASE-25255Master fails to initialize when creating rs group tableCriticalmaster, rsgroup
HBASE-25276Need to throw the original exception in HRegion#openHRegionMajor.
HBASE-25238Upgrading HBase from 2.2.0 to 2.3.x fails because of “Message missing required fields: state”Critical.
HBASE-25234[Upgrade]Incompatibility in reading RS report from 2.1 RS when Master is upgraded to a version containing HBASE-21406Major.
HBASE-25090CompactionConfiguration logs unrealistic store file sizesMinorCompaction

TESTS:

JIRASummaryPriorityComponent
HBASE-25370Fix flaky test TestClassFinder#testClassFinderDefaultsToOwnPackageMajortest

SUB-TASKS:

JIRASummaryPriorityComponent
HBASE-25488Clean up mess made by broken create-release in CHANGES.mdMajorcreate-release
HBASE-25353[Flakey Tests] branch-2 TestShutdownBackupMasterMajorflakies

OTHER:

JIRASummaryPriorityComponent
HBASE-25342Upgrade error prone to 2.4.0Majorbuild
HBASE-25452Use MatcherAssert.assertThat instead of org.junit.Assert.assertThatMajortest
HBASE-25400[Flakey Tests] branch-2 TestRegionMoveAndAbandonMajor.
HBASE-25228Delete dev-support/jenkins_precommit_jira_yetus.shMinorbuild
HBASE-24200Upgrade to Yetus 0.12.0Minorbuild

Release 2.3.3 - Unreleased (as of 2020-10-28)

IMPROVEMENTS:

JIRASummaryPriorityComponent
HBASE-25189[Metrics] Add checkAndPut and checkAndDelete latency metrics at table levelMinormetrics
HBASE-25193Add support for row prefix and type in the WAL Pretty Printer and some minor fixesMinorwal
HBASE-25179Assert format is incorrect in HFilePerformanceEvaluation class.MinorPerformance, test
HBASE-25146Add extra logging at info level to HFileCorruptionChecker in order to report progressMajorhbck, hbck2
HBASE-24981Enable table replication fails from 1.x to 2.x if table already exist at peer.MajorReplication
HBASE-25109Add MR Counters to WALPlayer; currently hard to tell if it is doing anythingMajor.
HBASE-25082Per table WAL metrics: appendCount and appendSizeMajormetrics
HBASE-25079Upgrade Bootstrap to 3.3.7Majorsecurity, UI
HBASE-24976REST Server failes to start without any error messageMajorREST

BUG FIXES:

JIRASummaryPriorityComponent
HBASE-25206Data loss can happen if a cloned table loses original split region(delete table)Majorproc-v2, Region Assignment, snapshots
HBASE-25207Revisit the implementation and usage of RegionStates.includeMajorRegion Assignment
HBASE-25204Nightly job failed as the name of jdk and maven changedMajor.
HBASE-25093the RSGroupBasedLoadBalancer#retainAssignment throws NPEMajorrsgroup
HBASE-25117ReplicationSourceShipper thread can not be finishedMajor.
HBASE-25168Unify WAL name timestamp parsersMajor.
HBASE-25048[HBCK2] Bypassed parent procedures are not updated in storeMajorhbck2, proc-v2
HBASE-25147Should store the regionNames field in state data for ReopenTableRegionsProcedureMajorproc-v2
HBASE-25115HFilePrettyPrinter can't seek to the row which is the first row of a hfileMajorHFile, tooling
HBASE-25135Convert the internal seperator while emitting the memstore read metrics to #Minor.
HBASE-25096WAL size in RegionServer UI is wrongMajor.
HBASE-25077hbck.jsp page loading fails, logs NPE in master log.Majorhbck
HBASE-25088CatalogFamilyFormat/MetaTableAccessor.parseRegionInfoFromRegionName incorrectly setEndKey to regionIdCriticalmeta
HBASE-25097Wrong RIT page number in Master UIMinorUI

TESTS:

JIRASummaryPriorityComponent
HBASE-24015Coverage for Assign and Unassign of Regions on RegionServer on failureMajoramv2
HBASE-25156TestMasterFailover.testSimpleMasterFailover is flakyMajortest

SUB-TASKS:

JIRASummaryPriorityComponent
HBASE-25203Change the reference url to flaky list in our jenkins jobsMajorflakies, jenkins
HBASE-25194Do not publish workspace in flaky find jobMajorjenkins
HBASE-25162Make flaky tests run more aggressivelyMajorjenkins, scripts, test
HBASE-25163Increase the timeout value for nightly jobsMajorjenkins, scripts, test
HBASE-22976[HBCK2] Add RecoveredEditsPlayerMajorhbck2, walplayer
HBASE-25154Set java.io.tmpdir to project build directory to avoid writing std*deferred files to /tmpMajorbuild, test
HBASE-24503Backport HBASE-24492 to all 2.x branchMinor.
HBASE-25133Migrate HBase Nightly jenkins job from Hadoop to hbaseMajorjenkins, scripts
HBASE-25132Migrate flaky test jenkins job from Hadoop to hbaseMajorjenkins, scripts
HBASE-25107Migrate flaky reporting jenkins job from Hadoop to hbaseMajorjenkins, scripts

OTHER:

JIRASummaryPriorityComponent
HBASE-25120Remove the deprecated annotation for MetaTableAccessor.getScanForTableNameMajormeta
HBASE-25073Should not use XXXService.Interface.class.getSimpleName as stub key prefix in AsyncConnectionImplMajorClient

Release 2.3.2 - Unreleased (as of 2020-09-20)

NEW FEATURES:

JIRASummaryPriorityComponent
HBASE-24776[hbtop] Support Batch modeMajorhbtop

IMPROVEMENTS:

JIRASummaryPriorityComponent
HBASE-25066Use FutureUtils.rethrow in AsyncTableResultScanner to better catch the stack traceMajorClient, Scanners
HBASE-25069Display region name instead of encoded region name in HBCK report page.Minorhbck
HBASE-24991Replace MovedRegionsCleaner with guava cacheMinor.
HBASE-25057Fix typo “memeber”Trivialdocumentation
HBASE-24831Avoid invoke Counter using reflection in SnapshotInputFormatMajor.
HBASE-25006Make the cost functions optional for StochastoicBalancerMajor.
HBASE-24974Provide a flexibility to print only row key and filter for multiple tables in the WALPrettyPrinterMinorwal
HBASE-24937table.rb use LocalDateTime to replace InstantMinorshell
HBASE-24940runCatalogJanitor() API should return -1 to indicate already running statusMajor.
HBASE-24569Get hostAndWeights in addition using localhost if it is null in local modeMinorregionserver
HBASE-24913Refactor TestJMXConnectorServerMajortest
HBASE-24898Use EnvironmentEdge.currentTime() instead of System.currentTimeMillis() in CurrentHourProviderMajortooling
HBASE-24928balanceRSGroup should skip generating balance plan for disabled table and splitParent regionMajorBalancer
HBASE-24942MergeTableRegionsProcedure should not call clean merge regionMajorproc-v2, Region Assignment
HBASE-24811Use class access static field or methodMinor.
HBASE-24686[LOG] Log improvement in Connection#closeMajorClient, logging
HBASE-24912Enlarge MemstoreFlusherChore/CompactionChecker period for unit testMajor.
HBASE-24854Correct the help content of assign and unassign commands in hbase shellMinorshell

BUG FIXES:

JIRASummaryPriorityComponent
HBASE-24896‘Stuck’ in static initialization creating RegionInfo instanceMajor.
HBASE-24956ConnectionManager#locateRegionInMeta waits for user region lock indefinitely.MajorClient
HBASE-24481HBase Rest: Request for region detail of a table which doesn't exits is success(200 success code) instead of 404Minor.
HBASE-25047WAL split edits number is negative in RegionServerUIMinorUI, wal
HBASE-25021Nightly job should skip hadoop-2 integration test for masterMajorbuild, scripts
HBASE-25012HBASE-24359 causes replication missed log of some RemoteExceptionMajorReplication
HBASE-25009Hbck chore logs wrong message when loading regions from RS reportMinor.
HBASE-25014ScheduledChore is never triggered when initalDelay > 1.5*periodMajor.
HBASE-25016Should close ResultScanner in MetaTableAccessor.scanByRegionEncodedNameCriticalmaster, meta
HBASE-24958CompactingMemStore.timeOfOldestEdit error updateCriticalregionserver
HBASE-24995MetaFixer fails to fix overlaps when multiple tables have overlapsMajorhbck2
HBASE-24719Renaming invalid rsgroup throws NPE instead of proper error messageMajor.
HBASE-19352Port HADOOP-10379: Protect authentication cookies with the HttpOnly and Secure flagsMajor.
HBASE-24971Upgrade JQuery to 3.5.1Majorsecurity, UI
HBASE-24968One of static initializers of CellComparatorImpl referring to subclass MetaCellComparatorMajor.
HBASE-24916Region hole contains wrong regions pair when hole is created by first region deletionMajorhbck2
HBASE-24892config ‘hbase.hregion.memstore.mslab.indexchunksize’ not be usedMajor.
HBASE-24871Replication may loss data when refresh recovered replication sourcesMajorReplication
HBASE-24885STUCK RIT by hbck2 assignsMajorhbck2, Region Assignment
HBASE-24926Should call setFailure in MergeTableRegionsProcedure when isMergeable returns falseMajormaster, proc-v2
HBASE-24884BulkLoadHFilesTool/LoadIncrementalHFiles should accept -D options from command line parametersMinor.

TESTS:

JIRASummaryPriorityComponent
HBASE-24979Include batch mutatations in client operation timeout testsMajor.
HBASE-24894[Flakey Test] TestStochasticLoadBalancer.testMoveCostMultiplierMajorBalancer, master, test

SUB-TASKS:

JIRASummaryPriorityComponent
HBASE-24857Fix several problems when starting webUIMinorcanary, UI
HBASE-24918Make RegionInfo#UNDEFINED IA.PrivateMajor.
HBASE-24876Fix the flaky job url in hbase-personality.shMajor.

OTHER:

JIRASummaryPriorityComponent
HBASE-25004Log RegionTooBusyException detailsMajor.
HBASE-14847Add FIFO compaction section to HBase bookMajordocumentation

Release 2.3.1 - Unreleased (as of 2020-08-12)

IMPROVEMENTS:

JIRASummaryPriorityComponent
HBASE-24709Support MoveCostFunction use a lower multiplier in offpeak hoursMajorBalancer
HBASE-24824Add more stats in PE for read replicaMinorPE, read replicas
HBASE-21721FSHLog : reduce write#syncs() timesMajor.
HBASE-24823Port HBASE-22762 Print the delta between phases in the split/merge/compact/flush transaction journals to master branchMinor.
HBASE-24795RegionMover should deal with unknown (split/merged) regionsMajor.
HBASE-24821Simplify the logic of getRegionInfo in TestFlushFromClient to reduce redundancy codeMinortest
HBASE-24704Make the Table Schema easier to view even there are multiple familiesMajorUI
HBASE-20226Performance Improvement Taking Large Snapshots In Remote FilesystemsMinorsnapshots
HBASE-24722Address hbase-shell commands with unintentional return valuesMinorshell
HBASE-24669Logging of ppid should be consistent across all occurrencesMinorOperability, proc-v2
HBASE-24757ReplicationSink should limit the batch rowcount for batch mutations based on hbase.rpc.rows.warning.thresholdMajor.
HBASE-24777InfoServer support ipv6 host and portMinorUI
HBASE-24758Avoid flooding replication source RSes logs when no sinks are availableMajorReplication
HBASE-24696Include JVM information on Web UI under “Software Attributes”MinorUI
HBASE-24740Enable journal logging for HBase snapshot operationMinormaster
HBASE-24747Log an ERROR if HBaseSaslRpcServer initialisation fails with an uncaught exceptionMajor.
HBASE-24578[WAL] Add a parameter to config RingBufferEventHandler's SyncFuture countMajorwal

BUG FIXES:

JIRASummaryPriorityComponent
HBASE-24583Normalizer can't actually merge empty regions when neighbor is larger than average sizeMajormaster, Normalizer
HBASE-24844Exception on standalone (master) shutdownMinorZookeeper
HBASE-24665MultiWAL : Avoid rolling of ALL WALs when one of the WAL needs a rollMajorwal
HBASE-24838The pre commit job fails to archive surefire reportsCriticalbuild, scripts
HBASE-23157WAL unflushed seqId tracking may wrong when Durability.ASYNC_WAL is usedMajorregionserver, wal
HBASE-24625AsyncFSWAL.getLogFileSizeIfBeingWritten does not return the expected synced file length.CriticalReplication, wal
HBASE-24788Fix the connection leaks on getting hbase admin from unclosed connectionMajormapreduce
HBASE-24808skip empty log cleaner delegate class names (WAS => cleaner.CleanerChore: Can NOT create CleanerDelegate= ClassNotFoundException)Trivial.
HBASE-24767Change default to false for HBASE-15519 per-user metricsMajormetrics
HBASE-24713RS startup with FSHLog throws NPE after HBASE-21751Minorwal
HBASE-24794hbase.rowlock.wait.duration should not be <= 0Minorregionserver
HBASE-24797Move log code out of loopMinorNormalizer
HBASE-24752NPE/500 accessing webui on master startupMinormaster
HBASE-24775[hbtop] StoreFile size should be rounded offMinorhbtop
HBASE-24675On Master restart all servers are assigned to default rsgroup.Majorrsgroup
HBASE-22146SpaceQuotaViolationPolicy Disable is not working in Namespace levelMajor.
HBASE-24742Improve performance of SKIP vs SEEK logicMajorPerformance, regionserver
HBASE-24710Incorrect checksum calculation in saveVersion.shMajorscripts
HBASE-24714Error message is displayed in the UI of table's compaction state if any region of that table is not open.MajorCompaction, UI
HBASE-24748Add hbase.master.balancer.stochastic.moveCost.offpeak to doc as support dynamically changeMinordocumentation
HBASE-24746The sort icons overlap the col name in master UIMajorUI
HBASE-24721rename_rsgroup overwriting the existing rsgroup.Major.
HBASE-24615MutableRangeHistogram#updateSnapshotRangeMetrics doesn't calculate the distribution for last bucket.Majormetrics
HBASE-24705MetaFixer#fixHoles() does not include the case for read replicas (i.e, replica regions are not created)Majorread replicas
HBASE-24720Meta replicas not cleaned when disabledMinorread replicas
HBASE-24693regioninfo#isLast() has a logic errorMinor.

SUB-TASKS:

JIRASummaryPriorityComponent
HBASE-24715Cleanup RELEASENOTES.md in the wake of HBASE-24711Majorcommunity
HBASE-24841Change the jenkins job urls in our jenkinsfileMajorbuild, scripts
HBASE-24846Address compaction races in TestFIFOCompactionPolicyMajorCompaction, master
HBASE-24698Turn OFF Canary WebUI as defaultMajorcanary

OTHER:

JIRASummaryPriorityComponent
HBASE-24835Normalizer should log a successful run at INFO levelMinorNormalizer
HBASE-24662Update DumpClusterStatusAction to notice changes in region server countMajorintegration tests
HBASE-24658Update PolicyBasedChaosMonkey to handle uncaught exceptionsMinorintegration tests

Release 2.3.0 - Unreleased (as of 2020-07-06)

NEW FEATURES:

JIRASummaryPriorityComponent
HBASE-18659Use HDFS ACL to give user the ability to read snapshot directly on HDFSMajor.
HBASE-24260Add a ClusterManager that issues commands via coprocessorMajorintegration tests
HBASE-22285A normalizer which merges very small size regions with adjacent regions.(MergeToNormalize)Minormaster
HBASE-22978Online slow response logMinorAdmin, Operability, regionserver, shell
HBASE-23146Support CheckAndMutate with multiple conditionsMajor.
HBASE-18095Provide an option for clients to find the server hosting META that does not involve the ZooKeeper clientMajorClient
HBASE-23710Priority configuration for system coprocessorsMajorCoprocessors
HBASE-23653Expose content of meta table in web uiMinormaster, Operability, UI
HBASE-23073Add an optional costFunction to balance regions according to a capacity ruleMinormaster
HBASE-22280Separate read/write handler for priority request(especially for meta).MajorScheduler
HBASE-22969A new binary component comparator(BinaryComponentComparator) to perform comparison of arbitrary length and positionMinorFilters
HBASE-21874Bucket cache on Persistent memoryMajorBucketCache
HBASE-11062hbtopMajorhbtop
HBASE-22623Add RegionObserver coprocessor hook for preWALAppendMajor.
HBASE-15666shaded dependencies for hbase-testing-utilCriticaltest
HBASE-22313Add a method to FsDelegationToken to accept token kindMinorsecurity
HBASE-22648Snapshot TTLMinorsnapshots
HBASE-22622WALKey Extended AttributesMajorwal
HBASE-22148Provide an alternative to CellUtil.setTimestampBlockerAPI, Coprocessors
HBASE-21815Make isTrackingMetrics and getMetrics of ScannerContext publicMinor.
HBASE-21926Profiler servletMajormaster, Operability, regionserver
HBASE-17942Disable region splits and merges per tableMajor.

IMPROVEMENTS:

JIRASummaryPriorityComponent
HBASE-24562Stabilize master startup with meta replicas enabledMajormeta, read replicas
HBASE-24221Support bulkLoadHFile by familyMajorHFile
HBASE-24603Zookeeper sync() call is asyncCriticalmaster, regionserver
HBASE-24205Create metric to know the number of reads that happens from memstoreMajormetrics
HBASE-24605Break long region names in the web UIMinorUI
HBASE-15161Umbrella: Miscellaneous improvements from production usageMajor.
HBASE-24102RegionMover should exclude draining/decommissioning nodes from target RSsMajor.
HBASE-24380Improve WAL splitting log lines to enable sessionizationMinorlogging, Operability, wal
HBASE-21405[DOC] Add Details about Output of “status ‘replication’”Minordocumentation, Replication
HBASE-24478The regionInfo parameter for MasterProcedureScheduler#waitRegions and MasterProcedureScheduler#wakeRegions should be pluralMinorproc-v2
HBASE-24524SyncTable logging improvementsMinor.
HBASE-24441CacheConfig details logged at Store open is not really usefulMinorlogging, regionserver
HBASE-24468Add region info when log meessages in HStore.Minorlogging, regionserver
HBASE-24483Add repeated prefix logging for MultipleColumnPrefixFilterMinorFilters
HBASE-24359Optionally ignore edits for deleted CFs for replication.MajorReplication
HBASE-24504refactor call setupCluster/tearDownCluster in TestTableSnapshotInputFormatMinormapreduce, test
HBASE-24412Canary support check only one column family per RegionTaskMajorcanary
HBASE-21406“status ‘replication’” should not show SINK if the cluster does not act as sinkMinor.
HBASE-24474Rename LocalRegion to MasterRegionBlockermaster
HBASE-24455Correct the doc of “On the number of column families”Minordocumentation
HBASE-24475Clean up the master thread name getting in SplitLogManager and AssignmentManagerMinor.
HBASE-24132Upgrade to Apache ZooKeeper 3.5.7Major.
HBASE-24470Add store file info when log meessages in HStore.Minorlogging, regionserver
HBASE-24451Remove the HasThread because the related bug had been fixed since jdk7Majorutil
HBASE-24416RegionNormalizer spliting region should not be limited by hbase.normalizer.min.region.countMajor.
HBASE-24428Priority compaction for recently split daughter regionsMajorCompaction
HBASE-24371Add more details when print CompactionConfiguration infoMinorregionserver
HBASE-24423No need to get lock in canSplit because hasReferences will get lock tooMinorregionserver
HBASE-24369Provide more information about merged child regions in Hbck Overlaps section, which cannot be fixed immediatelyMajormaster
HBASE-24427HStore.add log format errorMinor.
HBASE-24387TableSnapshotInputFormatImpl support row limit on each InputSplitMajormapreduce
HBASE-21996Set locale for javadocMajordocumentation
HBASE-24386TableSnapshotScanner support scan limitMajorScanners, snapshots
HBASE-24164Retain the ReadRequests and WriteRequests of region on web UI after alter tableMajormetrics
HBASE-23969Meta browser should show all `info` columnsMinormaster, UI
HBASE-24256When fixOverlap hits the max region limit, it is possible to include the same region in multiple merge requestMajorhbck2
HBASE-24355Fix typos in the HStore#compact annotationMinor.
HBASE-24321Add writable MinVersions and read-only Scan to coproc ScanOptionsMajor.
HBASE-24345[ACL] renameRSGroup should require Admin level permissionMajoracl, rsgroup
HBASE-24328skip duplicate GCMultipleMergedRegionsProcedure while previous finishedMajor.
HBASE-24335Support deleteall with ts but without column in shell modeMajorshell
HBASE-24304Separate a hbase-asyncfs moduleMajorbuild, pom
HBASE-24302Add an “ignoreTimestamps” option (defaulted to false) to HashTable/SyncTable toolMajor.
HBASE-24199Procedure related metrics is not consumed in the JMX metricMinormetrics
HBASE-24252Implement proxyuser/doAs mechanism for hbase-httpMajorsecurity, UI
HBASE-23264Resolve a TODO of BucketAllocator: “Why we add the extra 1024 bytes? Slop?”MinorBucketCache
HBASE-24024Optionally reject multi() requests with very high no of rowsMajor.
HBASE-24222remove FSUtils.checkAccess and replace with FileSystem.access in HBCKMajorFilesystem Integration
HBASE-24139Balancer should avoid leaving idle region serversCriticalBalancer, Operability
HBASE-24196[Shell] Add rename rsgroup command in hbase shellMajorrsgroup, shell
HBASE-24166Duplicate implementation for acquireLock between CreateTableProcedure and its parent classMinorproc-v2
HBASE-24182log when the region is set to closing statusMinor.
HBASE-24148Upgrade Thrift to 0.13.0: 0.12.0 has outstanding CVEs.MajorThrift
HBASE-24195Admin.getRegionServers() should return live servers excluding decom RS optionallyMajor.
HBASE-24112[RSGroup] Support renaming rsgroupMajorrsgroup
HBASE-23994Add WebUI to CanaryTrivialcanary, UI, Usability
HBASE-24181Add region info when log meessages in HRegion.Minorregionserver
HBASE-24099Use a fair ReentrantReadWriteLock for the region close lockMajor.
HBASE-24055Make AsyncFSWAL can run on EC clusterMajorwal
HBASE-24077When encounter RowTooBigException, log the row info.Minor.
HBASE-24111Enable CompactionTool executions on non-HDFS filesystemsMajorCompaction, mapreduce, tooling
HBASE-24021Fail fast when bulkLoadHFiles method catch some IOExceptionMajorHFile, regionserver
HBASE-23678Literate builder API for version management in schemaMajor.
HBASE-8868add metric to report client shortcircuit readsMinormetrics, regionserver
HBASE-24032[RSGroup] Assign created tables to respective rsgroup automatically instead of manual operationsMajormaster, rsgroup
HBASE-23967Improve the accuracy of the method sizeToStringMinor.
HBASE-23930Shell should attempt to format `timestamp` attributes as ISO-8601Minorshell, Usability
HBASE-23929Shell formatter for for meta table should pretty-print values of info:merge columnsMinorshell, Usability
HBASE-23932Minor improvements to Region NormalizerMinorhbck2, master
HBASE-23939Remove unused variables from HBaseSaslRpcServerTrivial.
HBASE-22827Expose multi-region merge in shell and Admin APIMajorAdmin, shell
HBASE-23864No need to submit SplitTableRegionProcedure/MergeTableRegionsProcedure when split/merge is disabledMajor.
HBASE-23859Modify “Block locality” of RegionServer Web UI to human readable percentageTrivial.
HBASE-23855Change bytes size to human readable size for Server Metrics of RegionServer Web UITrivial.
HBASE-23802Remove unnecessary Configuration instantiation in LossyAccountingMinormetrics
HBASE-23822Fix typo in procedures.jspTrivialwebsite
HBASE-23621Reduce number of Checkstyle violations in tests of hbase-commonMinor.
HBASE-23069periodic dependency bump for Sep 2019Criticaldependencies
HBASE-23686Revert binary incompatible change and remove reflectionMajor.
HBASE-23683Make HBaseInterClusterReplicationEndpoint more extensibleMajorReplication
HBASE-23627Resolve remaining Checkstyle violations in hbase-thriftMinorThrift
HBASE-23623Reduce number of Checkstyle violations in hbase-restMinorREST
HBASE-23645Fix remaining Checkstyle violations in tests of hbase-commonMinor.
HBASE-23347Pluggable RPC authenticationMajorrpc, security
HBASE-23646Fix remaining Checkstyle violations in tests of hbase-restMinor.
HBASE-23622Reduce number of Checkstyle violations in hbase-commonMinor.
HBASE-23626Reduce number of Checkstyle violations in tests of hbase-commonMinor.
HBASE-23675Move to Apache parent POM version 22Minordependencies
HBASE-23674Too many rit page Numbers show confusionTrivialmaster
HBASE-23383[hbck2] `fixHoles` should queue assignment procedures for any regions its fixingMinorhbck2, master, Region Assignment
HBASE-23286Improve MTTR: Split WAL to HFileMajorMTTR
HBASE-23635Reduce number of Checkstyle violations in hbase-mapreduceMinormapreduce
HBASE-23619Use built-in formatting for logging in hbase-zookeeperTrivialZookeeper
HBASE-23165[hbtop] Some modifications from HBASE-22988Minor.
HBASE-23668Master log start filling with “Flush journal status” messagesMajorproc-v2, RegionProcedureStore
HBASE-23654Please add Apache Trafodion and EsgynDB to “Powered by Apache HBase” pageMajordocumentation
HBASE-23651Region balance throttling can be disabledMajor.
HBASE-23333Include simple Call.toShortString() in sendCall exceptionsMinorClient, Operability
HBASE-23629Addition to Supporting projects pageMinor.
HBASE-23632DeadServer cleanupMinor.
HBASE-23624Add a tool to dump the procedure info in HFileMajorproc-v2
HBASE-23615Use a dedicated thread for executing WorkerMonitor in ProcedureExecutor.Majoramv2
HBASE-23618Add a tool to dump procedure info in the WAL fileMajorproc-v2
HBASE-23617Add a stress test tool for region based procedure storeMajorproc-v2
HBASE-23238Additional test and checks for null references on ScannerCallableWithReplicasMinor.
HBASE-23613ProcedureExecutor check StuckWorkers blocked by DeadServerMetricRegionChoreMajor.
HBASE-23326Implement a ProcedureStore which stores procedures in a HRegionCriticalproc-v2
HBASE-23065[hbtop] Top-N heavy hitter user and client drill downsMajorhbtop, Operability
HBASE-23066Create a config that forces to cache blocks on compactionMinorCompaction, regionserver
HBASE-23239Reporting on status of backing MOB files from client-facing cellsMajormapreduce, mob, Operability
HBASE-23549Document steps to disable MOB for a column familyMinordocumentation, mob
HBASE-23380General Cleanup of FSUtilMinorFilesystem Integration
HBASE-23379Clean Up FSUtil getRegionLocalityMappingFromFSMinor.
HBASE-23377Balancer should skip disabled tables's regionsMajorBalancer
HBASE-23373Log `RetriesExhaustedException` context with full time precisionMinorasyncclient, Client
HBASE-23303Add security headers to REST server/info pageMajorREST
HBASE-23361[UI] Limit two decimals even for total average loadMinorUI
HBASE-23365Minor change MemStoreFlusher's logTrivial.
HBASE-23362WalPrettyPrinter should include the table nameMinortooling
HBASE-23352Allow chaos monkeys to access cmd line params, and improve FillDiskCommandActionMinorintegration tests
HBASE-20395Displaying thrift server type on the thrift pageMajorThrift
HBASE-23293[REPLICATION] make ship edits timeout configurableMinorReplication
HBASE-23334The table-lock node of zk is not needed since HBASE-16786Minor.
HBASE-23325[UI]rsgoup average load keep two decimalsMinor.
HBASE-23321[hbck2] fixHoles of fixMeta doesn't update in-memory stateMinorhbck2
HBASE-23308Review of NullPointerExceptionsMinor.
HBASE-23315Miscellaneous HBCK Report page cleanupMinor.
HBASE-23278Add a table-level compaction progress display on the UIMinorUI
HBASE-19450Add log about average execution time for ScheduledChoreMinorOperability
HBASE-23283Provide clear and consistent logging about the period of enabled choresMinorOperability
HBASE-23245All MutableHistogram implementations should remove maxExpectedMajormetrics
HBASE-23251Add Column Family and Table Names to HFileContext and use in HFileWriterImpl loggingMajor.
HBASE-23228Allow for jdk8 specific modules on branch-1 in precommit/nightly testingCriticalbuild, test
HBASE-23212Provide config reload for Auto Region Reopen based on storeFile ref countMajor.
HBASE-23082Backport low-latency snapshot tracking for space quotas to 2.xMajorQuotas
HBASE-23221Polish the WAL interface after HBASE-23181Majorregionserver, wal
HBASE-23191Log spams on ReplicationTrivialReplication
HBASE-23208Unit formatting in Master & RS UITrivialUI
HBASE-23207Log a region open journalMinor.
HBASE-23172HBase Canary region success count metrics reflect column family successes, not region successesMinorcanary
HBASE-23170Admin#getRegionServers use ClusterMetrics.Option.SERVERS_NAMEMajor.
HBASE-23107Avoid temp byte array creation when doing cacheDataOnWriteMajorBlockCache, HFile
HBASE-20626Change the value of “Requests Per Second” on WEBUIMajormetrics, UI
HBASE-23093Avoid Optional Anti-Pattern where possibleMinor.
HBASE-23083Collect Executor status info periodically and report to metrics systemMajor.
HBASE-23017[Forward-port] Verify the file integrity in persistent IOEngineMajorBucketCache
HBASE-23114Use archiveArtifacts in JenkinsfilesTrivial.
HBASE-23140Remove unknown table errorMinor.
HBASE-23095Reuse FileStatus in StoreFileInfoMajormob, snapshots
HBASE-23116LoadBalancer should log table name when balancing per tableMinor.
HBASE-22874Define a public interface for Canary and move existing implementation to LimitedPrivateCriticalcanary
HBASE-22930Set unique name to longCompactions/shortCompactions threadsMinor.
HBASE-23035Retain region to the last RegionServer make the failover slowerMajor.
HBASE-23038Provide consistent and clear logging about disabling choresMinormaster, regionserver
HBASE-23075Upgrade jackson to version 2.9.10 due to CVE-2019-16335 and CVE-2019-14540Majordependencies, hbase-connectors, REST, security
HBASE-23058Should be “Column Family Name” in table.jspMinor.
HBASE-22027Move non-MR parts of TokenUtil into hbase-clientMajor.
HBASE-23049TableDescriptors#getAll should return the tables ordering by the name which contain namespaceMinor.
HBASE-23041Should not show split parent regions in HBCK report's unknown server partMajor.
HBASE-23044CatalogJanitor#cleanMergeQualifier may clean wrong parent regionsCritical.
HBASE-23037Make the split WAL related log more readableMinor.
HBASE-22846Internal Error 500 when Using HBASE REST API to Create Namespace.Majorhbase-connectors
HBASE-22804Provide an API to get list of successful regions and total expected regions in CanaryMinorcanary
HBASE-22899logging improvements for snapshot operations w/large manifestsMinorsnapshots
HBASE-22760Stop/Resume Snapshot Auto-Cleanup activity with shell commandMajorAdmin, shell, snapshots
HBASE-22802Avoid temp ByteBuffer allocation in FileIOEngine#readMajorBucketCache
HBASE-22701Better handle invalid local directory for DynamicClassLoaderMajorregionserver
HBASE-21879Read HFile's block to ByteBuffer directly instead of to byte for reducing young gc purposeMajor.
HBASE-22724Add a emoji on the vote table for pre commit result on githubMajorbuild, test
HBASE-22954Whitelist net.java.dev.jna which got pulled in through Hadoop 3.3.0Minorcommunity, hadoop3
HBASE-22905Avoid temp ByteBuffer allocation in BlockingRpcConnection#writeRequestMajor.
HBASE-22962Fix typo in javadoc descriptionMinordocumentation
HBASE-22933Do not need to kick reassign for rs group change any moreMajorrsgroup
HBASE-22618added the possibility to load custom cost functionsMajor.
HBASE-20509Put List in HashSet directly without using addAll function to improve performanceTrivialPerformance
HBASE-22464Improvements to hbase-vote scriptTrivialscripts
HBASE-22810Initialize an separate ThreadPoolExecutor for taking/restoring snapshotMajor.
HBASE-22844Fix Checkstyle issues in client snapshot exceptionsMinorClient
HBASE-22871Move the DirScanPool out and do not use static fieldMajormaster
HBASE-22841TimeRange's factory functions do not support ranges, only `allTime` and `at`MajorClient
HBASE-22543Revisit HBASE-21207 to make all values fully sortableMinormaster, monitoring, Operability, UI, Usability
HBASE-22812InterfaceAudience annotation in CatalogJanitor uses fully-qualified nameMinor.
HBASE-22800Add mapreduce dependencies to hbase-shaded-testing-utilMajor.
HBASE-22759Add user info to AUDITLOG events when doing grant/revokeMajorlogging, security
HBASE-22785Reduce number of Checkstyle issues in client exceptionsMinorClient
HBASE-22786Fix Checkstyle issues in tests of hbase-clientMinorClient
HBASE-22790Add deprecation version for hbase.ipc.server.reservoir.initial.buffer.size & hbase.ipc.server.reservoir.initial.maxTrivial.
HBASE-22677Add unit tests for org.apache.hadoop.hbase.util.ByteRangeUtils and org.apache.hadoop.hbase.util.ClassesMajorjava, test
HBASE-22787Clean up of tests in hbase-zookeeperMinorZookeeper
HBASE-22707[HBCK2] MasterRpcServices assigns method should try to reload regions from meta if the passed regions isn't found under AssignmentManager RegionsStateStoreMajorhbck2, master
HBASE-22363Remove hardcoded number of read cache block bucketsTrivialBlockCache, BucketCache
HBASE-22764Fix remaining Checkstyle issues in hbase-rsgroupTrivialrsgroup
HBASE-22763Fix remaining Checkstyle issue in hbase-procedureTrivial.
HBASE-22743ClientUtils for hbase-examplesMinor.
HBASE-22750Correct @throws in commentTrivialClient, rpc
HBASE-22721Refactor HBaseFsck: move the inner class outMajor.
HBASE-22692Rubocop definition is not used in the /bin directoryMinor.
HBASE-22610[BucketCache] Rename “hbase.offheapcache.minblocksize”Trivial.
HBASE-22690Deprecate / Remove OfflineMetaRepair in hbase-2+Majorhbck2
HBASE-22704Avoid NPE when access table.jsp and snapshot.jsp but master not finish initializationMinor.
HBASE-22643Delete region without archiving only if regiondir is presentMajorHFile
HBASE-22689Line break for fix version in documentationTrivialdocumentation
HBASE-22638Zookeeper Utility enhancementsMinorZookeeper
HBASE-7129Need documentation for REST atomic operations (HBASE-4720)Minordocumentation, REST
HBASE-22669Add unit tests for org.apache.hadoop.hbase.util.StringsMajorjava
HBASE-22403Balance in RSGroup should consider throttling and a failure affects the wholeMajorrsgroup
HBASE-22604fix the link in the docs to “Understanding HBase and BigTable” by Jim R. WilsonTrivialdocumentation
HBASE-22624Should sanity check table configuration when clone snapshot to a new tableMajor.
HBASE-22633Remove redundant call to substring for ZKReplicationQueueStorageMinor.
HBASE-22595Use full qualified name in Checkstyle suppressionsTrivial.
HBASE-22454refactor WALSplitterMajorwal
HBASE-22616responseTooXXX logging for Multi should characterize the component opsMinor.
HBASE-22596[Chore] Separate the execution period between CompactionChecker and PeriodicMemStoreFlusherMinorCompaction
HBASE-22561modify HFilePrettyPrinter to accept non-hbase.rootdir directoriesMinor.
HBASE-22344Document deprecated public APIsMajorAPI, community, documentation
HBASE-22593Add local Jenv file to gitignoreTrivial.
HBASE-22116HttpDoAsClient to support keytab and principal in command line argument.Major.
HBASE-22160Add sorting functionality in regionserver web UI for user regionsMinormonitoring, regionserver, UI, Usability
HBASE-22284optimization StringBuilder.append of AbstractMemStore.toStringTrivial.
HBASE-22523Refactor RegionStates#getAssignmentsByTable to make it easy to understandMajor.
HBASE-22511More missing /rs-status linksMinorUI
HBASE-22459Expose store reader reference countMinorHFile, metrics, regionserver
HBASE-22488Cleanup the explicit timeout value for test methodsMajor.
HBASE-22411Refactor codes of moving reigons in RSGroupMajorrsgroup
HBASE-22467WebUI changes to enable Apache Knox UI proxyingMajorUI
HBASE-22469replace md5 checksum in saveVersion script with sha512 for hbase version informationMinor.
HBASE-20305Add option to SyncTable that skip deletes on target clusterMinormapreduce
HBASE-21784Dump replication queue should show list of wal files ordered chronologicallyMajorReplication, tooling
HBASE-22384Formatting issues in administration section of bookMinorcommunity, documentation
HBASE-22377Provide API to check the existence of a namespace which does not require ADMIN permissionsMajor.
HBASE-21658Should get the meta replica number from zk instead of config at client sideCriticalClient
HBASE-22365Region may be opened on two RegionServersBlockeramv2
HBASE-22392Remove extra/useless +Trivial.
HBASE-20494Upgrade com.yammer.metrics dependencyMajordependencies
HBASE-22358Change rubocop configuration for method lengthMinorcommunity, shell
HBASE-22379Fix Markdown for “Voting on Release Candidates” in bookMinorcommunity, documentation
HBASE-22109Update hbase shaded content checker after guava update in hadoop branch-3.0 to 27.0-jreMinor.
HBASE-22087Update LICENSE/shading for the dependencies from the latest Hadoop trunkMinorhadoop3
HBASE-22301Consider rolling the WAL if the HDFS write pipeline is slowMinorwal
HBASE-21883Enhancements to Major Compaction toolMinorClient, Compaction, tooling
HBASE-22341Add explicit guidelines for removing deprecations in bookMajorAPI, community, documentation
HBASE-22225Profiler tab on Master/RS UI not working w/o comprehensive messageMinorUI
HBASE-22291Fix recovery of recovered.edits files under root dirMajor.
HBASE-22296Remove TestFromClientSide.testGetStartEndKeysWithRegionReplicasMajortest
HBASE-22250The same constants used in many places should be placed in constant classesMinorClient, conf, regionserver
HBASE-22279Add a getRegionLocator method in Table/AsyncTable interfaceMajorasyncclient, Client
HBASE-15560TinyLFU-based BlockCacheMajorBlockCache
HBASE-20586SyncTable tool: Add support for cross-realm remote clustersMajormapreduce, Operability, Replication
HBASE-21257misspelled words.[occured -> occurred]Trivial.
HBASE-22193Add backoff when region failed open too many timesMajor.
HBASE-22188Make TestSplitMerge more stableMajortest
HBASE-22097Modify the description of split command in shellTrivialshell
HBASE-21964unset Quota by Throttle TypeMajormaster
HBASE-22093Combine TestRestoreSnapshotFromClientWithRegionReplicas to CloneSnapshotFromClientAfterSplittingRegionTestBase#testCloneSnapshotAfterSplittingRegionMajor.
HBASE-22032KeyValue validation should check for null byte arrayMajor.
HBASE-21667Move to latest ASF Parent POMMinorbuild
HBASE-21810bulkload support set hfile compression on clientMajormapreduce
HBASE-21871Support to specify a peer table name in VerifyReplication toolMajor.
HBASE-21481[acl] Superuser's permissions should not be granted or revoked by any non-su global adminMajor.
HBASE-21967Split TestServerCrashProcedure and TestServerCrashProcedureWithReplicasMajor.
HBASE-21867Support multi-threads in HFileArchiverMajor.
HBASE-21932Use Runtime.getRuntime().halt to terminate regionserver when abort timeoutMajor.
HBASE-21875Change the retry logic in RSProcedureDispatcher to ‘retry by default, only if xxx’Majorproc-v2
HBASE-21780Avoid a wide line on the RegionServer webUI for many ZooKeeper serversMinorUI, Usability
HBASE-21636Enhance the shell scan command to support missing scanner specifications like ReadType, IsolationLevel etc.Majorshell
HBASE-21857Do not need to check clusterKey if replicationEndpoint is provided when adding a peerMajor.
HBASE-21201Support to run VerifyReplication MR tool without peeridMajorhbase-operator-tools
HBASE-21816Print source cluster replication config directoryTrivialReplication
HBASE-19616Review of LogCleaner ClassMinor.
HBASE-21830Backport HBASE-20577 (Make Log Level page design consistent with the design of other pages in UI) to branch-2MajorUI, Usability
HBASE-21833Use NettyAsyncFSWALConfigHelper.setEventLoopConfig to prevent creating too many netty event loop when executing TestHRegionMinortest
HBASE-21808Ensure we can build with JDK11 targetting JDK8Majorbuild, community, java
HBASE-21684Throw DNRIOE when connection or rpc client is closedMajorasyncclient, Client
HBASE-21634Print error message when user uses unacceptable values for LIMIT while setting quotas.Minor.
HBASE-20894Move BucketCache from java serialization to protobufMajorBucketCache

BUG FIXES:

JIRASummaryPriorityComponent
HBASE-24546CloneSnapshotProcedure unlimited retryMajorsnapshots
HBASE-24657JsonBean representation of metrics at /jmx endpoint now quotes all numbersMinormetrics
HBASE-24656[Flakey Tests] branch-2 TestMasterNoCluster.testStopDuringStartMajor.
HBASE-24552Replica region needs to check if primary region directory exists at file system in TransitRegionStateProcedureMajorread replicas
HBASE-24117Shutdown AssignmentManager before ProcedureExecutor may cause SCP to accidentally skip assigning a regionCriticalproc-v2
HBASE-24588Normalizer plan execution is not consistent between plan typesMajormaster, Normalizer
HBASE-24616Remove BoundedRecoveredHFilesOutputSink dependency on a TableDescriptorMajorHFile, MTTR
HBASE-24600Empty RegionAction added to MultiRequest in case of RowMutations/CheckAndMutate batchMajor.
HBASE-24446Use EnvironmentEdgeManager to compute clock skew in MasterMinor.
HBASE-21773rowcounter utility should respond to pleas for helpCriticaltooling
HBASE-24579Failed SASL authentication does not result in an exception on client sideMajorrpc
HBASE-24550Passing ‘-h’ or ‘--help’ to bin/hbase doesn't do as expectedTrivialOperability, shell
HBASE-24516Parameter copyFiles should be passed in SecureBulkLoadClientMinorReplication
HBASE-24517AssignmentManager.start should add meta region to ServerStateNodeCriticalamv2
HBASE-24189WALSplit recreates region dirs for deleted table with recovered edits dataMajorregionserver, wal
HBASE-23195FSDataInputStreamWrapper unbuffer can NOT invoke the classes that NOT implements CanUnbuffer but its parents class implements CanUnbufferCriticalio
HBASE-24545Add backoff to SCP check on WAL split completionMajor.
HBASE-24529hbase.rs.evictblocksonclose is not honored when removing compacted files and closing the storefilesMajor.
HBASE-24532Execute region plans with throttle should return succeeded plansMajor.
HBASE-24511Ability to configure timeout between RPC retry to RS from masterMajor.
HBASE-23202ExportSnapshot (import) will fail if copying files to root directory takes longer than cleaner TTLMajorsnapshots
HBASE-24444Should shutdown mini cluster after class in TestMetaAssignmentWithStopMasterMinortest
HBASE-24515batch Increment/Append fails when retrying the RPCMajor.
HBASE-24506async client deadlockBlockerasyncclient
HBASE-24513The default readRpcTimeout and writeRpcTimeout is incorrectly calculated in AsyncConnectionConfigurationCriticalasyncclient, Client
HBASE-24496The tab of Base Stats not actived by default in table.jspMajorUI
HBASE-24499Use a client property for SaslConnection MAX_ATTEMPTS (currently hardcoded to 5)MinorClient, security
HBASE-24280Hadoop2 and Hadoop3 profiles being activated simultaneously causing test failuresMajor.
HBASE-24479Deflake TestCompaction#testStopStartCompactionMajortest
HBASE-24454BucketCache disabled instantly before error duration toleration is reached due to timing issueMajorBucketCache
HBASE-23715MasterFileSystem should not create MasterProcWALs dir on fresh installsMinor.
HBASE-22287inifinite retries on failed server in RSProcedureDispatcherMajor.
HBASE-24379CatalogJanitor misreports region holes when there are actually over laps.Majormaster
HBASE-24434fix building cpp-example DemoClientMajorClient
HBASE-24437Flaky test, TestLocalRegionOnTwoFileSystems#testFlushAndCompactMajormeta, test
HBASE-24425Run hbck_chore_run and catalogjanitor_run on draw of ‘HBCK Report’ pageMajor.
HBASE-24370Avoid aggressive MergeRegion and GCMultipleMergedRegionsProcedureMajormaster
HBASE-24376MergeNormalizer is merging non-adjacent regions and causing region overlaps/holes.Criticalmaster
HBASE-24426Missing regionName while logging warning in HBCKServerCrashProcedureMinor.
HBASE-24401Cell size limit check on append should consider 0 or less value to disable the checkMajor.
HBASE-24364[Chaos Monkey] Invalid data block encoding in ChangeEncodingActionMajor.
HBASE-24399[Flakey Tests] Some UTs about RSGroup should wait RSGroupInfoManager to be onlineMinorrsgroup
HBASE-20289Comparator for NormalizationPlan breaks comparator's conventionMinormaster
HBASE-24365MetricsTableWrapperAggregateImpl runnable fails due to exception and never runsMinormetrics
HBASE-24377MemStoreFlusher throw NullPointerExceptionMajor.
HBASE-24381The Size metrics in Master Webui is wrong if the size is 0MajorUI
HBASE-24135TableStateNotFoundException happends when table creation if rsgroup is enableMinor.
HBASE-23702`hbase.hstore.flusher.count` setting to 0 breaks HMasterMajorregionserver
HBASE-24368Let HBCKSCP clear ‘Unknown Servers’, even if RegionStateNode has RegionLocation == nullMajorhbck2
HBASE-23832Old config hbase.hstore.compactionThreshold is ignoredCritical.
HBASE-24190Make kerberos value of hbase.security.authentication property case insensitiveMajor.
HBASE-24338[Flakey Tests] NPE in TestRaceBetweenSCPAndDTPMajorflakies, test
HBASE-24273HBCK's “Orphan Regions on FileSystem” reports regions with referenced HFilesCriticalhbck2
HBASE-24211Create table is slow in large cluster when AccessController is enabled.Major.
HBASE-24284[h3/jdk11] REST server won't startMajorREST
HBASE-24250CatalogJanitor resubmits GCMultipleMergedRegionsProcedure for the same regionMajormaster
HBASE-24342[Flakey Tests] Disable TestClusterPortAssignment.testClusterPortAssignment as it can't pass 100% of the timeMajorflakies, test
HBASE-24316GCMulitpleMergedRegionsProcedure is not idempotentMajorproc-v2
HBASE-24336[Metrics] FSDataInputStream's localBytesRead is wrongMinormetrics
HBASE-24307[Flakey Tests] krb server for secure thrift tests throws BindExceptionMajor.
HBASE-24322UnsafeAvailChecker should also check that required methods are availableMinor.
HBASE-24314Some classes still use log4j logger directlyBlockerlogging
HBASE-24246Miscellaneous hbck2 fixMeta bulk merge fixes: better logging around merges/overlap-fixing, ‘HBCK Report’ overlap listing, and configurationMajor.
HBASE-24288Allow admin user to create table and do bulkLoadMajoracl
HBASE-24294[Flakey Tests] TestThriftHttpServer BindExceptionMajor.
HBASE-22710Wrong result in one case of scan that use raw and versions and filter togetherMajorScanners
HBASE-24282‘scandetail’ log message is missing when responseTooSlow happens on the first scan rpc callMajorOperability
HBASE-24247Failed multi-merge because two regions not adjacent (legitimately).Majorhbck2
HBASE-24274`RESTApiClusterManager` attempts to deserialize response using serialization APIMajorintegration tests
HBASE-24215[Flakey Tests] [ERROR] TestSecureRESTServer java.lang.NoClassDefFoundError: com/sun/jersey/core/spi/factory/AbstractRuntimeDelegateMajor.
HBASE-24281Remove some stale hadoop.version properties in the pom for sub modulesMajorhadoop3, pom
HBASE-24251PreCommit build is failing because of can not build docker imageMajorscripts
HBASE-24253HBASE-Find-Flaky-Tests job is failing because of can not build docker imageMajorscripts
HBASE-24223The -Phadoop-3.0 option does not work on branch-2 and branch-2.3 with JDK11Majorhadoop3, pom
HBASE-24213Backport the pre commit changes for HBASE-24169 to all branchesMajorscripts
HBASE-24220Allow that zk NOTEMPTY multi exception is retryable by running in-seriesMajorflakies
HBASE-24174Fix findbugs warning on ServiceAuthorizationManagerMajor.
HBASE-24203Bump git version in DockerfileBlockerbuild
HBASE-24177MetricsTable#updateFlushTime is wrongMinormetrics
HBASE-23833The relocated hadoop-thirdparty protobuf breaks HBase asyncwalMajorwal
HBASE-24158[Flakey Tests] TestAsyncTableGetMultiThreadedMajor.
HBASE-24186RegionMover ignores replicationIdMinorread replicas
HBASE-24151[rsgroup] The master server aborted for IllegalThreadStateExceptionMinorrsgroup
HBASE-24197TestHttpServer.testBindAddress failure with latest jettyMajor.
HBASE-24176user_permission ‘.*’ command failed to show all table permissionsMinorshell
HBASE-24167[Flakey Tests] TestHRegionWithInMemoryFlush#testWritesWhileScanning gets stuck MVCCMajor.
HBASE-22879user_permission command failed to show global permissionMajor.
HBASE-24168Align the internal.protobuf.version in hbase-protocol-shaded with hbase-thirdpartyMajorpom, Protobufs
HBASE-23998Update license for jetty-clientMajorbuild, dependencies
HBASE-24162Move CHANGES.txt to CHANGES.md. Add RELEASENOTES.md too on branch-2, branch-2.3, and masterMajorbuild
HBASE-24074ConcurrentModificationException occurred in ReplicationSourceManager while refreshing the peerMajorReplication
HBASE-24121[Authorization] ServiceAuthorizationManager isn't dynamically updatable. And it should be.Majorrpc, security
HBASE-24131[Flakey Tests] TestExportSnapshot takes too long; up against 13min maxMajor.
HBASE-23153PrimaryRegionCountSkewCostFunction SLB function should implement CostFunction#isNeededMajor.
HBASE-24128[Flakey Tests] Add retry on thrift cmdline if client fails plus misc debugMajor.
HBASE-24122Change machine ulimit-l to ulimit-a so dumps full ulimit rather than just ‘max locked memory’Majorbuild
HBASE-24001The “HBase Nightly” job may exhaust all executors - and create a deadlockMajor.
HBASE-24041[regression] Increase RESTServer buffer size back to 64kMajorREST
HBASE-24057Add modules to mapreduce job classpathsMajormapreduce
HBASE-24040WALFactory.Providers.multiwal causes StackOverflowErrorMinorwal
HBASE-23949refactor loadBalancer implements for rsgroup balance by table to achieve overallbalancedMajorrsgroup
HBASE-24043[Flakey Tests] TestAsyncRegionAdminApi, TestRegionMergeTransactionOnCluster fixes and debugMajorflakies
HBASE-23741Data loss when WAL split to HFile enabledBlockerMTTR
HBASE-23633Find a way to handle the corrupt recovered hfilesCriticalMTTR, wal
HBASE-24019Correct exception messages for table null and namespace unavailable.Minor.
HBASE-24016Change nightly poll from cron @daily to pollSCM @daily; i.e. run nightly if a change ONLYMajor.
HBASE-22103HDFS-13209 in Hadoop 3.3.0 breaks asyncwalMajorhadoop3, wal
HBASE-23987NettyRpcClientConfigHelper will not share event loop by default which is incorrectMajorClient, rpc
HBASE-23953SimpleBalancer bug when second pass to fill up to minMajorBalancer
HBASE-23954SplitParent region should not be balancedMajorBalancer
HBASE-23944The method setClusterLoad of SimpleLoadBalancer is incorrect when balance by tableMajorBalancer
HBASE-23895STUCK Region-In-Transition when failed to insert procedure to procedure storeMajorproc-v2, RegionProcedureStore
HBASE-23909list_regions fails if table is under splitMinorshell
HBASE-23553Snapshot referenced data files are deleted in some caseMajorsnapshots
HBASE-23904Procedure updating meta and Master shutdown are incompatible: CODE-BUGMajoramv2
HBASE-23892SecureTestCluster should allow its subclasses to pass their Class reference on HBaseKerberosUtils.setSSLConfigurationMajor.
HBASE-23804Fix default master addr hostname in master registryMajorClient
HBASE-23554Encoded regionname to regionname utilityMajorshell
HBASE-23682Fix NPE when disable DeadServerMetricRegionChoreMajormaster
HBASE-23813Get surefire version from parent pom rather than define it in hbase-archetypesTrivial.
HBASE-23809The RSGroup shell test is missingMajorrsgroup, test
HBASE-23782We still reference the hard coded meta descriptor in some places when listing table descriptorsBlockermeta
HBASE-17115HMaster/HRegion Info Server does not honour admin.aclMajor.
HBASE-23737[Flakey Tests] TestFavoredNodeTableImport fails 30% of the timeMajor.
HBASE-23733[Flakey Tests] TestSplitTransactionOnClusterMajorflakies
HBASE-23709Unwrap the real user to properly dispatch proxy-user auth'nMajor.
HBASE-23601OutputSink.WriterThread exception gets stuck and repeated indefinietlyMajorread replicas
HBASE-23156start-hbase.sh failed with ClassNotFoundException when build with hadoop3Major.
HBASE-23701Make sure HBaseClassTestRule doesn't suffer same issue as HBaseClassTestRuleCheckerMinor.
HBASE-23695Fail more gracefully when test class is missing CategoryMinor.
HBASE-23694After RegionProcedureStore completes migration of WALProcedureStore, still running WALProcedureStore.syncThread keeps trying to delete now inexistent log files.Majorproc-v2, RegionProcedureStore
HBASE-23677region.jsp returns 500/NPE when provided encoded region name is not onlineMinorregionserver, UI
HBASE-23679FileSystem instance leaks due to bulk loads with Kerberos enabledCritical.
HBASE-23658Fix flaky TestSnapshotFromMasterMajor.
HBASE-23659BaseLoadBalancer#wouldLowerAvailability should consider region replicasMajor.
HBASE-23655Fix flaky TestRSGroupsKillRS: should wait the SCP to finishMajor.
HBASE-23648Re-use underlying connection registry in RawAsyncHBaseAdminMinorClient
HBASE-23663Allow dot and hyphen in Profiler's URLMinorprofiler
HBASE-23666Backport “HBASE-23660 hbase:meta's table.jsp ref to wrong rs address” to branch-2Majormaster
HBASE-23636Disable table may hang when regionserver stop or abort.Majoramv2
HBASE-23369Auto-close ‘unknown’ Regions reported as OPEN on RegionServersMajor.
HBASE-23175Yarn unable to acquire delegation token for HBase Spark jobsMajorsecurity, spark
HBASE-23587The FSYNC_WAL flag does not work on branch-2.xMajorwal
HBASE-23098[bulkload] If one of the peers in a cluster is configured with NAMESPACE level, its hfile-refs(zk) will be backloggedMajor.
HBASE-23596HBCKServerCrashProcedure can double assignMajorproc-v2
HBASE-23590Update maxStoreFileRefCount to maxCompactedStoreFileRefCountMajor.
HBASE-23589FlushDescriptor contains non-matching family/output combinationsCriticalread replicas
HBASE-23581Creating table gets stuck when specifying an invalid split policy as METADATAMajor.
HBASE-23572In ‘HBCK Report’, distinguish between live, dead, and unknown serversTrivial.
HBASE-23564RegionStates may has some expired serverinfo and make regions do not balance.Major.
HBASE-23594Procedure stuck due to region happen to recorded on two servers.Criticalamv2, Region Assignment
HBASE-23376NPE happens while replica region is movingMinorread replicas
HBASE-23582Unbalanced braces in string representation of table descriptorMinor.
HBASE-23566Fix package/packet terminology problem in chaos monkeysMinorintegration tests
HBASE-23360[CLI] Fix help command “set_quota” to explain removing quotaMinorshell
HBASE-22096/storeFile.jsp shows CorruptHFileException when the storeFile is a reference fileMajorUI
HBASE-23364HRegionServer sometimes does not shut down.Majormetrics, regionserver
HBASE-22529Sanity check for in-memory compaction policyMinor.
HBASE-23337Several modules missing in nexus for Apache HBase 2.2.2Blockerbuild, community, scripts
HBASE-23345Table need to replication unless all of cfs are excludedMinorReplication
HBASE-23356When construct StoreScanner throw exceptions it is possible to left some KeyValueScanner not closed.Major.
HBASE-23313[hbck2] setRegionState should update Master in-memory state tooMajorhbck2
HBASE-23117Bad enum in hbase:meta info:state column can fail loadMeta and stop startupMinor.
HBASE-23312HBase Thrift SPNEGO configs (HBASE-19852) should be backwards compatibleMajorThrift
HBASE-23197“IllegalArgumentException: Wrong FS” on edits replay when WALs on different file system and hbase.region.archive.recovered.edits is enabled.Major.
HBASE-23336[CLI] Incorrect row(s) count “clear_deadservers”Minorshell
HBASE-23237Negative ‘Requests per Second’ counts in UIMajorUI
HBASE-23328info:regioninfo goes wrong when region replicas enabledMajorread replicas
HBASE-22607TestExportSnapshotNoCluster::testSnapshotWithRefsExportFileSystemState() fails intermittentlyMajortest
HBASE-23318LoadTestTool doesn't startMinor.
HBASE-23282HBCKServerCrashProcedure for ‘Unknown Servers’Majorhbck2, proc-v2
HBASE-23294ReplicationBarrierCleaner should delete all the barriers for a removed region which does not belong to any serial replication peerMajormaster, Replication
HBASE-23290shell processlist command is brokenMajorshell
HBASE-18439Subclasses of o.a.h.h.chaos.actions.Action all use the same loggerMinorintegration tests
HBASE-23262Cannot load Master UIMajormaster, UI
HBASE-23263NPE in Quotas.jspMajorUI
HBASE-22980HRegionPartioner getPartition() method incorrectly partitions the regions of the table.Majormapreduce
HBASE-21458Error: Could not find or load main class org.apache.hadoop.hbase.util.GetJavaPropertyMinorbuild, Client
HBASE-23243[pv2] Filter out SUCCESS procedures; on decent-sized cluster, plethora overwhelms problemsMajorproc-v2, UI
HBASE-23247[hbck2] Schedule SCPs for ‘Unknown Servers’Majorhbck2
HBASE-23241TestExecutorService sometimes failMajortest
HBASE-23244NPEs running CanaryMajorcanary
HBASE-23184The HeapAllocation in WebUI is not accurateMinorUI
HBASE-23231ReplicationSource do not update metrics after refreshMajorwal
HBASE-22739ArrayIndexOutOfBoundsException when balanceMajorBalancer
HBASE-23192CatalogJanitor consistencyCheck does not log problematic row on exceptionMinorhbck2
HBASE-20827Add pause when retrying after CallQueueTooBigException for reportRegionStateTransitionMajorRegion Assignment
HBASE-23187Update parent region state to SPLIT in metaMajormaster
HBASE-23199Error populating Table-Attribute fieldsMajormaster, UI
HBASE-23222Better logging and mitigation for MOB compaction failuresCriticalmob
HBASE-23181Blocked WAL archive: “LogRoller: Failed to schedule flush of XXXX, because it is not online on us”Majorregionserver, wal
HBASE-23193ConnectionImplementation.isTableAvailable can not deal with meta table on branch-2.xMajorrsgroup, test
HBASE-23177If fail to open reference because FNFE, make it plain it is a ReferenceMajorOperability
HBASE-23042Parameters are incorrect in procedures jspMajor.
HBASE-22881Fix non-daemon threads in hbase server implementationMajormaster
HBASE-22370ByteBuf LEAK ERRORMajorrpc, wal
HBASE-23078BaseLoadBalancer should consider region replicas when randomAssignment and roundRobinAssignmentMajor.
HBASE-23155May NPE when concurrent AsyncNonMetaRegionLocator#updateCachedLocationOnErrorMajorasyncclient
HBASE-21540when set property “hbase.systemtables.compacting.memstore.type” to “basic” or “eager” will cause an exceptionMajorconf
HBASE-23159HStore#getStorefilesSize may throw NPEMajorregionserver
HBASE-23154list_deadservers return incorrect no of rowsMinorshell
HBASE-23152Compaction_switch does not work by RegionServer nameMajorClient, Compaction
HBASE-23056Block count is 0 when BucketCache using persistent IOEngine and retrieve from fileMinorBucketCache
HBASE-23115Unit change for StoreFileSize and MemStoreSizeMinormetrics, UI
HBASE-23138Drop_all table by regex fail from Shell - Similar to HBASE-23134Majorshell
HBASE-23139MapReduce jobs lauched from convenience distribution are nonfunctionalBlockermapreduce
HBASE-22887HFileOutputFormat2 split a lot of HFile by roll once per rowkeyMajormapreduce
HBASE-22767System table RIT STUCK if their RSGroup has no highest version RSesMajorrsgroup
HBASE-23134Enable_all and Disable_all table by Regex fail from ShellMajorshell
HBASE-22903alter_status command is brokenMajormetrics, shell
HBASE-23094Wrong log message in simpleRegionNormaliser while checking if merge is enabled.Minor.
HBASE-23125TestRSGroupsAdmin2 is flakyMajortest
HBASE-22735list_regions may throw an error if a region is RITMinorshell
HBASE-23119ArrayIndexOutOfBoundsException in PrivateCellUtil#qualifierStartsWithMajor.
HBASE-23054Remove synchronization block from MetaTableMetrics and fix LossyCounting algorithmMajormetrics
HBASE-22380break circle replication when doing bulkloadCriticalReplication
HBASE-23079RegionRemoteProcedureBase should override setTimeoutFailureBlockeramv2
HBASE-22965RS Crash due to DBE reference to an reused ByteBuffMajor.
HBASE-22012SpaceQuota DisableTableViolationPolicy will cause cycles of enable/disable tableMajor.
HBASE-22944TableNotFoundException: hbase:quota is thrown when region server is restarted.MinorQuotas
HBASE-22142Space quota: If table inside namespace having space quota is dropped, data size usage is still considered for the drop table.Minor.
HBASE-22649Encode StoreFile path URLs in the UI to handle scenarios where CF contains special characters (like # etc.)MajorUI
HBASE-22941MetaTableAccessor.getMergeRegions() returns parent regions in random orderMajor.
HBASE-23051Remove unneeded Mockito.mock invocationsMajortest
HBASE-23005Table UI showed exception message when table is disabledMinor.
HBASE-23040region mover gives NullPointerException instead of saying a host isn't in the clusterMinor.
HBASE-23043TestWALEntryStream times outMajorwal
HBASE-22955Branches-1 precommit and nightly yetus jobs are using jdk8 for jdk7 jobsMajor.
HBASE-22929MemStoreLAB ChunkCreator may memory leakMajor.
HBASE-23009TestSnapshotScannerHDFSAclController is broken on branch-2Majorsnapshots
HBASE-23006RSGroupBasedLoadBalancer should also try to place replicas for the same region to different region serversMajorRegion Assignment, rsgroup
HBASE-23007UnsatisfiedLinkError when using hbase-shaded packages under linuxCriticalshading
HBASE-22013SpaceQuotas - getNumRegions() returning wrong number of regions due to region replicasMajor.
HBASE-22979Call ChunkCreator.initialize in TestHRegionWithInMemoryFlushCritical.
HBASE-22964Fix flaky TestClusterRestartFailover and TestClusterRestartFailoverSplitWithoutZkMajor.
HBASE-22963Netty ByteBuf leak in rpc client implementationMajorrpc
HBASE-22981Remove unused flags for YetusCriticalbuild
HBASE-22970split parents show as overlaps in the HBCK ReportMajor.
HBASE-22961Deprecate hbck1 in coreMajorhbck
HBASE-22896TestHRegion.testFlushMarkersWALFail is flakyMinor.
HBASE-22943Various procedures should not cache log trace levelMinorproc-v2
HBASE-22893Change the comment in HBaseClassTestRule to reflect change in default test timeoutsTrivial.
HBASE-22928ScanMetrics counter update may not happen in case of exception in TableRecordReaderImplMinormapreduce
HBASE-22935TaskMonitor warns MonitoredRPCHandler task may be stuck when it recently startedMinorlogging
HBASE-22857Fix the failed ut TestHRegion and TestHRegionWithInMemoryFlushMajor.
HBASE-22922Only the two first regions are locked in MergeTableRegionsProcedureMajor.
HBASE-22852hbase nightlies leaking gpg-agentsMinorbuild
HBASE-22867The ForkJoinPool in CleanerChore will spawn thousands of threads in our cluster with thousands tableCriticalmaster
HBASE-22904NPE occurs when RS send space quota usage report during HMaster initMinor.
HBASE-22806Deleted CF are not cleared if memstore contain entriesMajorAPI
HBASE-22601Misconfigured addition of peers leads to cluster shutdown.Major.
HBASE-22863Avoid Jackson versions and dependencies with known CVEsMajordependencies
HBASE-22882TestFlushSnapshotFromClient#testConcurrentSnapshottingAttempts is flakey (was written flakey)Majortest
HBASE-22870reflection fails to access a private nested classMajormaster
HBASE-22856HBASE-Find-Flaky-Tests fails with pip errorMajorbuild, test
HBASE-22632SplitTableRegionProcedure and MergeTableRegionsProcedure should skip store files for unknown column familiesMajorproc-v2
HBASE-22838assembly:single failure: user id or group id ‘xxxxx’ is too bigMajorbuild
HBASE-22115HBase RPC aspires to grow an infinite tree of trace scopes; some other places are also unsafeCriticalrpc, tracing
HBASE-22539WAL corruption due to early DBBs re-use when Durability.ASYNC_WAL is usedBlockerrpc, wal
HBASE-22801Maven build issue on Github PRsMajorbuild
HBASE-22793RPC server connection is logging user as NULL principalMinorrpc
HBASE-22778Upgrade jasckson databind to 2.9.9.2Blockerdependencies
HBASE-22773when set blockSize option in Performance Evaluation tool, error occurs:ERROR: Unrecognized option/command: --blockSize=131072Minormapreduce
HBASE-22145windows hbase-env causes hbase cli/etc to ignore HBASE_OPTSMajor.
HBASE-22408add a metric for regions OPEN on non-live serversMajor.
HBASE-22758Remove the unneccesary info cf deletion in DeleteTableProcedure#deleteFromMetaMajor.
HBASE-22714BuffferedMutatorParams opertationTimeOut() is misspeltTrivialClient
HBASE-22751table.jsp fails if ugly regions in tableMajorUI
HBASE-22733TestSplitTransactionOnCluster.testMasterRestartAtRegionSplitPendingCatalogJanitor is flakeyMajor.
HBASE-22715All scan requests should be handled by scan handler threads in RWQueueRpcExecutorMinor.
HBASE-22722Upgrade jackson databind dependencies to 2.9.9.1Blockerdependencies
HBASE-22603Javadoc Warnings related to @link tagTrivialdocumentation
HBASE-22720Incorrect link for hbase.unittestsTrivialdocumentation
HBASE-21426TestEncryptionKeyRotation.testCFKeyRotation is flakyMajor.
HBASE-20368Fix RIT stuck when a rsgroup has no online servers but AM's pendingAssginQueue is clearedMajorrsgroup
HBASE-22700Incorrect timeout in recommended ZooKeeper configurationMinordocumentation
HBASE-22661list_regions command in hbase shell is brokenMajorshell
HBASE-22684The log rolling request maybe canceled immediately in LogRoller due to a raceMajorwal
HBASE-22414Interruption of moving regions in RSGroup will cause regions on wrong rsMajorrsgroup
HBASE-22586Javadoc Warnings related to @param tagTrivialdocumentation
HBASE-22571Javadoc Warnings related to @return tagTrivialdocumentation
HBASE-22681The ‘assert highestUnsyncedTxid < entry.getTxid();’ in AbstractFWAL.append may fail when using AsyncFSWALCriticalwal
HBASE-22686ZkSplitLogWorkerCoordination doesn't allow a regionserver to pick up all of the split work it is capable ofMajor.
HBASE-22656[Metrics] Tabe metrics ‘BatchPut’ and ‘BatchDelete’ are never updatedMinormetrics
HBASE-22582The Compaction writer may access the lastCell whose memory has been released when appending fileInfo in the finalMajorCompaction
HBASE-22652Flakey TestLockManager; test timed out after 780 secondsMajorproc-v2
HBASE-22637fix flaky TestMetaTableMetrics testMajormetrics, test
HBASE-13798TestFromClientSide* don't close the TableTrivialtest
HBASE-21751WAL creation fails during region open may cause region assign forever failMajor.
HBASE-22477Throwing exception when meta region is not in OPEN state in client registry may crash a masterMajorClient, master, meta
HBASE-22617Recovered WAL directories not getting cleaned upBlockerwal
HBASE-22605Ref guide includes dev guidance only applicable to EOM versionsTrivialdocumentation
HBASE-22495Update SyncTable section, explaining from which specific minor versions “doDeletes/doPuts” is availableMajordocumentation
HBASE-22565Javadoc Warnings: @see cannot be used in inline documentationTrivialdocumentation
HBASE-22562PressureAwareThroughputController#skipControl never invokedTrivialOperability
HBASE-22559[RPC] set guard against CALL_QUEUE_HANDLER_FACTOR_CONF_KEYMinorrpc
HBASE-22530The metrics of store files count of region are returned to clients incorrectlyMinormetrics, regionserver
HBASE-22563Reduce retained jobs for Jenkins pipelinesMajor.
HBASE-22552Rewrite TestEndToEndSplitTransaction.testCanSplitJustAfterASplitMajortest
HBASE-22551TestMasterOperationsForRegionReplicas is flakeyMajorread replicas, test
HBASE-22481Javadoc Warnings: reference not foundTrivialdocumentation
HBASE-22520Avoid possible NPE in HalfStoreFileReader seekBefore()Major.
HBASE-22546TestRegionServerHostname#testRegionServerHostname fails reliably for meMajor.
HBASE-22518yetus personality is treating branch-1.4 like earlier branches for hadoopcheckMajortest
HBASE-22513Admin#getQuota does not work correctly if exceedThrottleQuota is setMajorQuotas
HBASE-22522The integration test in master branch's nightly job has error “ERROR: Only found 1050 rows.”Major.
HBASE-22490Nightly client integration test fails with hadoop-3Majorbuild
HBASE-22502Purge the logs when we reach the EOF for the last wal file when replicationMajor.
HBASE-22503Failed to upgrade to 2.2+ as the global permission which storaged in zk is not rightBlocker.
HBASE-22487getMostLoadedRegions is unusedTrivialregionserver
HBASE-22485Fix failed ut TestClusterRestartFailoverMajor.
HBASE-22486Fix flaky test TestLockManagerMajor.
HBASE-22471Our nightly jobs for master and branch-2 are still using hadoop-2.7.1 in integration testMajorbuild
HBASE-22003Fix flaky test TestVerifyReplication.testHBase14905Major.
HBASE-22441BucketCache NullPointerException in cacheBlockMajorBucketCache
HBASE-22473Split TestSCPMajorRecovery, test
HBASE-22456Polish TestSplitTransitionOnClusterMajortest
HBASE-21991Fix MetaMetrics issues - [Race condition, Faulty remove logic], few improvementsMajorCoprocessors, metrics
HBASE-21800RegionServer aborted due to NPE from MetaTableMetrics coprocessorCriticalCoprocessors, meta, metrics, Operability
HBASE-22462Should run a ‘mvn install’ at the end of hadoop check in pre commit jobMajorbuild
HBASE-22440HRegionServer#getWalGroupsReplicationStatus() throws NPEMajorregionserver, Replication
HBASE-22226Incorrect level for headings in asciidocTrivialdocumentation
HBASE-22442Nightly build is failing with hadoop 3.xMajorbuild, hadoop3
HBASE-20970Update hadoop check versions for hadoop3 in hbase-personalityMajorbuild
HBASE-22424Interactions in RSGroup test classes will cause TestRSGroupsAdmin2.testMoveServersAndTables and TestRSGroupsBalance.testGroupBalance flakyMajorrsgroup
HBASE-22404Open/Close region request may be executed twice when master restartMajor.
HBASE-21048Get LogLevel is not working from console in secure environmentMajor.
HBASE-22378HBase Canary fails with TableNotFoundException when table deleted during Canary runMinorcanary
HBASE-22274Cell size limit check on append should consider cell's previous size.Minor.
HBASE-22072High read/write intensive regions may cause long crash recoveryMajorPerformance, Recovery
HBASE-22324loss a mass of data when the sequenceId of cells greater than Integer.Max, because MemStoreMergerSegmentsIterator can not merge segmentsBlockerin-memory-compaction
HBASE-21777“Tune compaction throughput” debug messages even when nothing has changedTrivialCompaction
HBASE-22360Abort timer doesn't set when abort is called during graceful shutdown processMajorregionserver
HBASE-20851Change rubocop config for max line length of 100Minorcommunity, shell
HBASE-21070SnapshotFileCache won't update for snapshots stored in S3Criticalsnapshots
HBASE-21467Fix flaky test TestCoprocessorClassLoader.testCleanupOldJarsMinor.
HBASE-22312Hadoop 3 profile for hbase-shaded-mapreduce should like mapreduce as a provided dependencyMajormapreduce, shading
HBASE-22314shaded byo-hadoop client should list needed hadoop modules as provided scope to avoid inclusion of unnecessary transitive depednenciesMajorhadoop2, hadoop3, shading
HBASE-22047LeaseException in Scan should be retiredMajorClient, Scanners
HBASE-22343Make procedure retry interval configurable in testMajoramv2, test
HBASE-22190SnapshotFileCache may fail to load the correct snapshot file list when there is an on-going snapshot operationBlockersnapshots
HBASE-22054Space Quota: Compaction is not working for super user in case of NO_WRITES_COMPACTIONSMinor.
HBASE-22236AsyncNonMetaRegionLocator should not cache HRegionLocation with null locationMajorasyncclient
HBASE-22086space quota issue: deleting snapshot doesn't update the usage of tableMinor.
HBASE-22298branch-2.2 nightly fails “[ForOverride] Method annotated @ForOverride must have protected or package-private visibility”Major.
HBASE-22292PreemptiveFastFailInterceptor clean repeatedFailuresMap issueBlocker.
HBASE-22230REST Server drops connection on long scansMajor.
HBASE-22286License handling incorrectly lists CDDL/GPLv2+CE as safe to not aggregateCriticalbuild, community
HBASE-22268Update shading for javax.activationMinorhadoop3, java, shading
HBASE-22282Should deal with error in the callback of RawAsyncHBaseAdmin.splitRegion methodsMajorAdmin, asyncclient
HBASE-22278RawAsyncHBaseAdmin should not use cached region locationMajorAdmin, asyncclient
HBASE-22222Site build fails after hbase-thirdparty upgradeBlockerwebsite
HBASE-21959CompactionTool should close the store it uses for compacting files, in order to properly archive compacted files.Majortooling
HBASE-22150rssStub in HRegionServer is not thread safe and should not directly be usedMajorregionserver
HBASE-22235OperationStatus.{SUCCESS|FAILURE|NOT_RUN} are not visible to 3rd party coprocessorsMajorCoprocessors
HBASE-22207Fix flakey TestAssignmentManager.testAssignSocketTimeoutMajortest
HBASE-22202Fix new findbugs issues after we upgrade hbase-thirdparty dependenciesMajorfindbugs
HBASE-22144MultiRowRangeFilter does not work with reversed scansCriticalFilters, Scanners
HBASE-22194Snapshot unittests fail on Windows due to invalid file path uriMajorregionserver, test
HBASE-22198Fix flakey TestAsyncTableGetMultiThreadedMajortest
HBASE-22163Should not archive the compacted store files when region warmupBlocker.
HBASE-22178Introduce a createTableAsync with TableDescriptor method in AdminMajorAdmin
HBASE-22180Make TestBlockEvictionFromClient.testBlockRefCountAfterSplits more stableMajortest
HBASE-22179Fix RawAsyncHBaseAdmin.getCompactionStateMajorAdmin, asyncclient
HBASE-22177Do not recreate IOException in RawAsyncHBaseAdmin.adminCallMajorAdmin, asyncclient
HBASE-22070Checking restoreDir in RestoreSnapshotHelperMinorsnapshots
HBASE-20912Add import order config in dev support for eclipseMajor.
HBASE-22133Forward port HBASE-22073 “/rits.jsp throws an exception if no procedure” to branch-2.2+MajorUI
HBASE-20911correct Swtich/case indentation in formatter template for eclipseMajor.
HBASE-22121AsyncAdmin can not deal with non default meta replicaMajorAdmin, asyncclient, Client
HBASE-22123REST gateway reports Insufficient permissions exceptions as 404 Not FoundMinorREST
HBASE-21135Build fails on windows as it fails to parse windows path during license checkMajorbuild
HBASE-21781list_deadservers elapsed time is incorrectMajorshell
HBASE-22100False positive for error prone warnings in pre commit jobMinorbuild
HBASE-22098Backport HBASE-18667 “Disable error-prone for hbase-protocol-shaded” to branch-2Majorbuild
HBASE-22057Impose upper-bound on size of ZK ops sent in a single multi()Major.
HBASE-22067Fix log line in StochasticLoadBalancer when balancer is an ill-fit for cluster sizeMajorBalancer
HBASE-22074Should use procedure store to persist the state in reportRegionStateTransitionBlockeramv2, proc-v2
HBASE-21619Fix warning message caused by incorrect ternary operator evaluationTrivial.
HBASE-22095Taking a snapshot fails in local modeMajor.
HBASE-22045Mutable range histogram reports incorrect outliersMajor.
HBASE-21736Remove the server from online servers before scheduling SCP for it in hbckMajorhbck2, test
HBASE-21915FileLink$FileLinkInputStream doesn't implement CanUnbufferMajorFilesystem Integration
HBASE-21740NPE happens while shutdown the RSMajor.
HBASE-21866Do not move the table to null rsgroup when creating an existing tableMajorproc-v2, rsgroup
HBASE-21983Should track the scan metrics in AsyncScanSingleRegionRpcRetryingCaller if scan metrics is enabledMajorasyncclient, Client
HBASE-21980Fix typo in AbstractTestAsyncTableRegionReplicasReadMajortest
HBASE-21487Concurrent modify table ops can lead to unexpected resultsMajor.
HBASE-20724Sometimes some compacted storefiles are still opened after region failoverCritical.
HBASE-21961Infinite loop in AsyncNonMetaRegionLocator if there is only one region and we tried to locate before a non empty rowCriticalasyncclient, Client
HBASE-21943The usage of RegionLocations.mergeRegionLocations is wrong for async clientCriticalasyncclient, Client
HBASE-21947TestShell is broken after we remove the jackson dependenciesMajordependencies, shell
HBASE-21942[UI] requests per second is incorrect in rsgroup page(rsgroup.jsp)Minor.
HBASE-21505Several inconsistencies on information reported for Replication Sources by hbase shell status ‘replication’ command.MajorReplication
HBASE-21922BloomContext#sanityCheck may failed when use ROWPREFIX_DELIMITED bloom filterMajor.
HBASE-21929The checks at the end of TestRpcClientLeaks are not executedMajortest
HBASE-20587Replace Jackson with shaded thirdparty gsonMajordependencies
HBASE-21938Add a new ClusterMetrics.Option SERVERS_NAME to only return the live region servers's name without metricsMajor.
HBASE-21928Deprecated HConstants.META_QOSMajorClient, rpc
HBASE-21899Fix missing variables in slf4j LoggerTriviallogging
HBASE-21910The nonce implementation is wrong for AsyncTableCriticalasyncclient, Client
HBASE-21900Infinite loop in AsyncMetaRegionLocator if we can not get the location for metaMajorasyncclient, Client
HBASE-21890Use execute instead of submit to submit a task in RemoteProcedureDispatcherCriticalproc-v2
HBASE-21889Use thrift 0.12.0 when build thrift by compile-thrift profileMajor.
HBASE-21854Race condition in TestProcedureSkipPersistenceMinorproc-v2
HBASE-21862IPCUtil.wrapException should keep the original exception types for all the connection exceptionsBlocker.
HBASE-18484VerifyRep by snapshot does not work when Yarn / SourceHBase / PeerHBase located in different HDFS clustersMajorReplication
HBASE-21843RegionGroupingProvider breaks the meta wal file name pattern which may cause data loss for meta regionBlockerwal
HBASE-21795Client application may get stuck (time bound) if a table modify op is called immediately after split opCriticalamv2
HBASE-21840TestHRegionWithInMemoryFlush fails with NPEBlockertest
HBASE-21811region can be opened on two servers due to race condition with procedures and server reportsBlockeramv2
HBASE-21644Modify table procedure runs infinitely for a table having region replication > 1CriticalAdmin
HBASE-21733SnapshotQuotaObserverChore should only fetch space quotasMajor.
HBASE-21699Create table failed when using SPLITS_FILE => ‘splits.txt’BlockerClient, shell
HBASE-21535Zombie Master detector is not workingCriticalmaster
HBASE-19893restore_snapshot is broken in master branch when region splitsCriticalsnapshots

TESTS:

JIRASummaryPriorityComponent
HBASE-24594testReplicationStatusSink last applied op ts comparison failureMajor.
HBASE-24493[flakey test] TestExportSnapshot family of tests failing due to timeout in AbstractDelegationTokenSecretManager$ExpiredTokenRemoverMajortest
HBASE-24115Relocate test-only REST “client” from src/ to test/ and mark PrivateMajorREST, security
HBASE-23957[flakey test] client.TestMultiParallel fails to read hbase-site.xmlMinortest
HBASE-24361Make `RESTApiClusterManager` more resilientMajorintegration tests
HBASE-24360RollingBatchRestartRsAction loses track of dead serversMajorintegration tests
HBASE-24080[flakey test] TestRegionReplicaFailover.testSecondaryRegionKill fails.Majorread replicas
HBASE-23943Rubocop configuration needs updatedMinorbuild
HBASE-23976[flakey test] TestVerifyBucketCacheFileMajorregionserver, test
HBASE-24118[Flakey Tests] TestCloseRegionWhileRSCrashMajor.
HBASE-23956Use less resources running testsMajortest
HBASE-24185Junit tests do not behave well with System.exit or Runtime.halt or JVM exits in general.Majortest
HBASE-24183[flakey test] replication.TestAddToSerialReplicationPeerMajorClient
HBASE-23853[Flakey Test] TestBlockEvictionFromClient#testBlockRefCountAfterSplitsMajorflakies
HBASE-24159[flakey test] regionserver.TestRegionMergeTransactionOnClusterMajorregionserver
HBASE-24161[flakey test] locking.TestEntityLocks.testEntityLockTimeoutMinorClient
HBASE-24114[Flakey Tests] TestSnapshotScannerHDFSAclControllerMajoracl
HBASE-24120Flakey Test: TestReplicationAdminWithClusters timeoutMajorReplication
HBASE-24105[Flakey Test] regionserver.TestRegionReplicasMajorread replicas
HBASE-24107[Flakey Test] TestThriftServerCmdLine.testRunThriftServer NPEs if InfoServer port clashMajorflakies
HBASE-24103[Flakey Tests] TestSnapshotScannerHDFSAclControllerMajor.
HBASE-24073[flakey test] client.TestAsyncRegionAdminApi messed up compaction state.MajorCompaction
HBASE-24100[Flakey Tests] Add test to check we work properly when port clash setting up thriftserverMajorflakies, Thrift
HBASE-24075[Flakey Tests] teardown fails because JmxCacheBuster wants to read ClusterId from closed fsMajorflakies
HBASE-24097[Flakey Tests] TestSnapshotScannerHDFSAclController#testRestoreSnapshotMajorflakies
HBASE-24079[Flakey Tests] Misc fixes and debug; fix BindException in Thrift tests; add waits on quota table to come online; etc.Majorflakies
HBASE-22555Re-enable TestMasterOperationsForRegionReplicas$testIncompleteMetaTableReplicaInformationMajorReplication, test
HBASE-24047[Flakey Tests] Disable TestCustomSaslAuthenticationProvider#testNegativeAuthentication on branch-2.3Majorflakies
HBASE-24034[Flakey Tests] A couple of fixes and cleanupsMajorflakies
HBASE-24035[Flakey Tests] Disable TestClusterScopeQuotaThrottle#testUserNamespaceClusterScopeQuotaMajor.
HBASE-23984[Flakey Tests] TestMasterAbortAndRSGotKilled fails in teardownMajor.
HBASE-23977[Flakey Tests] TestSlowLogRecorder.testOnlieSlowLogConsumption:178->confirmPayloadParams:97 expected:<client_1[0]> but was:<client_1[4]>Majortest
HBASE-23999[flakey test] TestTableOutputFormatConnectionExhaustMajortest
HBASE-23974[Flakey Tests] Allow that server may not yet be cleared from DeadServers in TestHBCKSCPMajor.
HBASE-23963Split TestFromClientSide; it takes too long to complete timing outMajortest
HBASE-23914TestThriftHBaseServiceHandler.testMetricsWithException failingMajor.
HBASE-23899[Flakey Test] Stabilizations and DebugMajorflakies
HBASE-23863[Flakey Test] TestReplicationEndpointWithMultipleWAL#testInterClusterReplication improvementsMajorflakies
HBASE-23867[Flakey Test] TestStochasticLoadBalancerRegionReplicaSameHosts#testRegionReplicationOnMidClusterSameHostsMajor.
HBASE-23808[Flakey Test] TestMasterShutdown#testMasterShutdownBeforeStartingAnyRegionServerMajortest
HBASE-23838Adding debug logging to a few ExportSnapshot testsTrivial.
HBASE-23812[Flakey Test] TestReplicator#testReplicatorWithErrors: AssertionError: We did not replicate enough rows expected:<10> but was:<7>Majorflakies
HBASE-23824TestSnapshotScannerHDFSAclController is flakeyMajor.
HBASE-23815[Flakey Test] AbstractTestAsyncTableRegionReplicasRead family of tests fails with no breadcrumbs on whyMajorflakies
HBASE-23814Add null checks and logging to misc set of testsTrivial.
HBASE-23805[Flakey Test] TestRaceBetweenSCPAndDTPMajor.
HBASE-23793Increase maven heap allocation to 4G in Yetus personalityMajorbuild, test
HBASE-23789[Flakey Tests] ERROR [Time-limited test] balancer.HeterogeneousRegionCountCostFunction(199): cannot read rules file located at ' /tmp/hbase-balancer.rules 'Majorflakies
HBASE-23792[Flakey Test] TestExportSnapshotNoCluster.testSnapshotWithRefsExportFileSystemStateMajortest
HBASE-23783Address tests writing and reading SSL/Security files in a common location.Minor.
HBASE-23786[Flakey Test] TestMasterNotCarryTable.testMasterMemStoreLABMajorflakies
HBASE-23780Edit of test classificationsMajortest
HBASE-23752Fix a couple more test failures from nightly runMajortest
HBASE-23764Flaky tests due to ZK client name resolution delaysMajortest
HBASE-23770[Flakey Tests] TestRegionReplicasWithRestartScenarios#testWhenRestartMajorflakies
HBASE-23749TestHFileWriterV3 should have tests for all data block encodingsMajor.
HBASE-23746[Flakey Tests] Caused by: org.apache.hadoop.hbase.util.CommonFSUtils$StreamLacksCapabilityException: hflush and hsyncMajor.
HBASE-23731TestFromClientSide flakey after junit upgradeMajortest
HBASE-23735[Flakey Tests] TestClusterRestartFailover & TestClusterRestartFailoverSplitWithoutZkMajor.
HBASE-23729[Flakeys] TestRSGroupsBasics#testClearNotProcessedDeadServer fails most of the timeMajor.
HBASE-23711Add test for MinVersions and KeepDeletedCells TTLMinor.
HBASE-23665Split unit tests from TestTableName into a separate test only classMinortest
HBASE-23569Validate that the log cleaner actually cleans oldWALs as expectedMajorintegration tests, master, test
HBASE-23555TestQuotaThrottle is brokenMinor.
HBASE-23552Format Javadocs on ITBLLTrivialintegration tests
HBASE-23259Ability to run mini cluster using pre-determined available random portsMajortest
HBASE-22886Code Coverage Improvement: Create Unit Tests for ConnectionIdTrivialtest
HBASE-22766Code Coverage Improvement: Create Unit Tests for ResultStatsUtilTrivialtest
HBASE-22894Move testOpenRegionFailedMemoryLeak to dedicated classMajortest
HBASE-22725Remove all remaining javadoc warningsTrivialtest
HBASE-22791Wrong order of asserts in TestZKMultiTrivialZookeeper
HBASE-22615Make TestChoreService more robust to timingMinortest
HBASE-22545TestLogLevel brokenMajortest
HBASE-22548Split TestAdmin1MajorAdmin, test
HBASE-22524Refactor TestReplicationSyncUpToolMajortest
HBASE-22472The newly split TestReplicationStatus* tests are flakyMajorReplication, test
HBASE-20782Fix duplication of TestServletFilter.accessMinor.
HBASE-22455Split TestReplicationStatusMajorReplication, test
HBASE-22051Expect values are hard-coded in the verifications of TestRSGroupsBasicsMinorrsgroup, test
HBASE-21963Add a script for building and verifying release candidateMinorcommunity, scripts
HBASE-20918Re-enable TestRpcHandlerExceptionMinortest
HBASE-21416Intermittent TestRegionInfoDisplay failure due to shift in relTime of RegionState#toDescriptiveStringMinor.
HBASE-21952Test Failure: TestClientOperationInterrupt.testInterrupt50PercentMinor.

SUB-TASKS:

JIRASummaryPriorityComponent
HBASE-24144Update docs from masterMajordocumentation
HBASE-22504Optimize the MultiByteBuff#get(ByteBuffer, offset, len)MajorBucketCache
HBASE-24630Purge dev javadoc from client bin tarballMajorbuild
HBASE-24574Procedure V2 - Distributed WAL Splitting => LOGGINGMajorwal
HBASE-24577Doc WALSplitter classesTrivialwal
HBASE-24505Reimplement Hbck.setRegionStateInMetaBlockerhbck2
HBASE-24309Avoid introducing log4j and slf4j-log4j dependencies for modules other than hbase-assemblyMajorlogging, pom
HBASE-24347Hadoop2&Hadoop3 profiles are both active when pre-commit PR builds runMajorbuild
HBASE-23941get_slowlog_responses filters with AND/OR operator supportMajor.
HBASE-24343Document how to configure the http request logMajordocumentation
HBASE-24405Document hbase:slowlog in detailMajor.
HBASE-23771[Flakey Tests] Test TestSplitTransactionOnCluster AgainMajor.
HBASE-23938Replicate slow/large RPC calls to HDFSMajor.
HBASE-24333Backport HBASE-24304 “Separate a hbase-asyncfs module” to branch-2.xMajorbuild, pom
HBASE-24354Make it so can make an hbase1 schema and hbase2 schema equateMajor.
HBASE-24331[Flakey Test] TestJMXListener rmi port clashMajorflakies, test
HBASE-24310Use Slf4jRequestLog for hbase-httpMajorlogging
HBASE-24265Remove hedged rpc call support, implement the logic in MaterRegistry directlyMajorIPC/RPC
HBASE-24303Undo core of parent TestSecureRESTServer change; use fix over in HBASE-24280 insteadMajor.
HBASE-24143[JDK11] Switch default garbage collector from CMSMajorscripts
HBASE-24218Add hadoop 3.2.x in hadoop checkMajorscripts
HBASE-23829Get `-PrunSmallTests` passing on JDK11Majortest
HBASE-24175[Flakey Tests] TestSecureExportSnapshot FileNotFoundExceptionMajorflakies
HBASE-23697Document new RegionProcedureStore operation and migrationMajordocumentation
HBASE-24134Down forked JVM heap size from 2800m to 2200m for jdk8 and jdk11Major.
HBASE-24126Up the container nproc uplimit from 10000 to 12500Majorbuild
HBASE-24150Allow module tests run in parallelMajorbuild
HBASE-24113Upgrade the maven we use from 3.5.4 to 3.6.3 in nightliesMajorbuild
HBASE-24109Change fork count from 0.5C to 0.25CMajor.
HBASE-24071[JDK11] Remove `unit` filter from nightly and precommit jobsMajorbuild, test
HBASE-23937Retrieve online large RPC logsMajor.
HBASE-22022nightly fails rat check down in the dev-support/hbase_nightly_source-artifact.sh checkMajor.
HBASE-23992Fix TestAdminShell and TestQuotasShell mistakenly broken by parent commitTrivialtest
HBASE-24052Add debug+fix to TestMasterShutdownTrivial.
HBASE-24007Get `-PrunLargeTests` passing on JDK11Majortest
HBASE-24050Deprecated PBType on all 2.x branchesMajorProtobufs
HBASE-24045Support setting `-Dhadoop.profile` in adhoc_run_tests.shMinortooling
HBASE-24037Add ut for root dir and wal root dir are differentMajor.
HBASE-23936Thrift support for get and clear slow_log APIsMajor.
HBASE-24033Add ut for loading the corrupt recovered hfilesMajor.
HBASE-24009Backport the personality changes in HBASE-23989 to all active branchesMajorbuild
HBASE-23993Use loopback for zk standalone server in minizkclusterMajorZookeeper
HBASE-23891Add an option to Actions to filter out meta RSMinorintegration tests
HBASE-23991[Flakey Tests] Disable TestSecureExport.testVisibilityLabelsMajorflakies
HBASE-23979Disable TestSlowLogRecorder until parent addressedMajortest
HBASE-23851Log networks and bind addresses when multicast publisher/listener enabledTrivial.
HBASE-23946[JDK11] Yetus should vote -0 for known JDK11 issuesMinorbuild
HBASE-23739BoundedRecoveredHFilesOutputSink should read the table descriptor directlyMajor.
HBASE-23912Resolve the TODO of FSTableDescriptor's construct methodMajor.
HBASE-23788ROW_INDEX_V1 encoder should consider the secondary index size with the encoded data size trackingMajor.
HBASE-23876Add JDK11 compilation and unit test support to nightly jobMajorbuild
HBASE-23767Add JDK11 compilation and unit test support to Github precommitMajorbuild
HBASE-23926[Flakey Tests] Down the flakies re-run ferocity; it makes for too many fails.Majorflakies
HBASE-23740Invalid StoreFile WARN log message printed for recovered.hfiles directoryMinorMTTR
HBASE-23755[OpenTracing] Declare HTrace is unusable in the user docMajor.
HBASE-23877[Flakey Test] TestStochasticLoadBalancerRegionReplicaHighReplication “Two or more region replicas are hosted on the same host after balance”Major.
HBASE-23331Document HBASE-18095Majordocumentation
HBASE-23304Implement RPCs needed for master based registryMajormaster
HBASE-23816[Flakey Test] TestExportSnapshotNoCluster.testSnapshotV2WithRefsExportFileSystemState(TestExportSnapshotNoCluster.java:91) Wrong FS!Major.
HBASE-23350Make compaction files cacheonWrite configurable based on thresholdMajorCompaction
HBASE-23705Add CellComparator to HFileContextMajorio
HBASE-23753Update of errorprone generated failuresMajor.
HBASE-23647Make MasterRegistry the default registry implMajorClient
HBASE-23707Add IntelliJ check style plugin configurationMinorbuild
HBASE-23330Expose cluster ID for clients using it for delegation token based authMajorClient, master
HBASE-23728Include HBASE-21018 in 2.2 & 2.3Major.
HBASE-23727Port HBASE-20981 in 2.2 & 2.3Major.
HBASE-23726Forward-port HBASE-21345 to branch-2.2, 2.3 & master as well.Major.
HBASE-23722TestCustomSaslAuthenticationProvider failing in nightliesMajor.
HBASE-23680RegionProcedureStore missing cleaning of hfile archiveMajorproc-v2, RegionProcedureStore
HBASE-18326Fix and reenable TestMasterProcedureWalLeaseBlockertest
HBASE-23305Master based registry implementationMajormaster
HBASE-23681Add UT for procedure store region flusherMajorproc-v2, RegionProcedureStore
HBASE-23588Cache index blocks and bloom blocks on write if CacheCompactedBlocksOnWrite is enabledMajor.
HBASE-23320Upgrade surefire plugin to 3.0.0-M4Majordependencies, test
HBASE-20461Implement fsync for AsyncFSWALMajorwal
HBASE-23085Network and Data related ActionsMinorintegration tests
HBASE-23281Track meta region changes on mastersMajormaster
HBASE-23307Add running of ReplicationBarrierCleaner to hbck2 fixMeta invocationMajorhbck2
HBASE-23322[hbck2] Simplification on HBCKSCP schedulingMinorhbck2
HBASE-23275Track active master server name in ActiveMasterManagerMajormaster
HBASE-23257Track ClusterID in stand by mastersMajormaster
HBASE-22480Get block from BlockCache once and return this block to BlockCache twice make ref count error.Major.
HBASE-23136PartionedMobFileCompactor bulkloaded files shouldn't get replicated (addressing buklload replication related issue raised in HBASE-22380)Critical.
HBASE-15519Add per-user metricsMajormetrics
HBASE-22460Reopen a region if store reader references may have leakedMinor.
HBASE-23163Refactor HStore.getStorefilesSize related methodsMajorregionserver
HBASE-22982Send SIGSTOP to hang or SIGCONT to resume rs and add graceful rolling restartMinorintegration tests
HBASE-22927Upgrade mockito version for Java 11 compatibilityMajor.
HBASE-22796[HBCK2] Add fix of overlaps to fixMeta hbck ServiceMajor.
HBASE-22993HBCK report UI showed -1 if hbck chore not runningMinor.
HBASE-23014Should not show split parent regions in hbck report UIMajor.
HBASE-22859[HBCK2] Fix the orphan regions on filesystemMajordocumentation, hbck2
HBASE-22878Show table throttle quotas in table jspMajor.
HBASE-22946Fix TableNotFound when grant/revoke if AccessController is not loadedMajor.
HBASE-22945Show quota infos in master UIMajormaster, UI
HBASE-22858Add HBCK Report to master's header.jspMinormaster
HBASE-22891Use HBaseQA in HBase-PreCommit-GitHub-PR jobMajorbuild, scripts
HBASE-22842Tmp directory should not be deleted when master restart used for user scan snapshot featureMajor.
HBASE-22771[HBCK2] fixMeta method and server-side supportMajorhbck2
HBASE-22845Revert MetaTableAccessor#makePutFromTableState access to publicBlocker.
HBASE-22777Add a multi-region merge (for fixing overlaps, etc.)Majorhbck2, proc-v2
HBASE-22803Modify config value range to enable turning off of the hbck choreMajor.
HBASE-22824Show filesystem path for the orphans regions on filesystemMajor.
HBASE-22808HBCK Report showed the offline regions which belong to disabled tableMajor.
HBASE-22776Rename config names in user scan snapshot featureMajor.
HBASE-22807HBCK Report showed wrong orphans regions on FileSystemMajor.
HBASE-22737Add a new admin method and shell cmd to trigger the hbck chore to runMajor.
HBASE-22741Show catalogjanitor consistency complaints in new ‘HBCK Report’ pageMajorhbck2, UI
HBASE-22723Have CatalogJanitor report holes and overlaps; i.e. problems it sees when doing its regular scan of hbase:metaMajor.
HBASE-22580Add a table attribute to make user scan snapshot feature configurable for tableMajor.
HBASE-22709Add a chore thread in master to do hbck checking and display results in ‘HBCK Report’ pageMajor.
HBASE-22742[HBCK2] Add more log for hbck operations at master sideMinor.
HBASE-22578HFileCleaner should not delete empty ns/table directories used for user san snapshot featureMajor.
HBASE-22527[hbck2] Add a master web ui to show the problematic regionsMajorhbase-operator-tools, hbck2
HBASE-22719Add debug support for github PR pre commit jobMajorbuild
HBASE-22663The HeapAllocationRatio in WebUI is not accurate because all of the heap allocation will happen in another separated allocator named HEAPMajor.
HBASE-22673Avoid to expose protobuf stuff in Hbck interfaceMajorhbck2
HBASE-7191HBCK - Add offline create/fix hbase.version and hbase.idMajorhbck
HBASE-22621Backport offheap block reading (HBASE-21879) to branch-2MajorOffheaping
HBASE-20060Add details of off heap memstore into book.Criticaldocumentation
HBASE-21995Add a coprocessor to set HDFS ACL for hbase granted userMajorCoprocessors, security
HBASE-22547Align the config keys and add document for offheap read in HBase Book.Major.
HBASE-21284Forward port HBASE-21000 to branch-2Major.
HBASE-22600Document that LoadIncrementalHFiles will be removed in 3.0.0Major.
HBASE-22588Upgrade jaxws-ri dependency to 2.3.2Majordependencies, java
HBASE-22585Ensure javax.annotation doesn't get include in shaded artifacts when built with Java 11Majorbuild, java
HBASE-22598Deprecated the hbase.ipc.server.reservoir.initial.buffer.size & hbase.ipc.server.reservoir.initial.max for HBase2.x compatibilityMajor.
HBASE-22264Separate out jars related to JDK 11 into a folder in /libMinorjava
HBASE-22531The HFileReaderImpl#shouldUseHeap return the incorrect true when disabled BlockCacheMajor.
HBASE-22458TestClassFinder fails when run on JDK11Minorjava, test
HBASE-22491Separate the heap HFileBlock and offheap HFileBlock because the heap block won't need refCnt and save into prevBlocks list before shippingMajor.
HBASE-22569Should treat null consistency as Consistency.STRONG in ConnectionUtils.timelineConsistentReadMajor.
HBASE-22357Fix remaining Checkstyle issues in hbase-replicationTrivialReplication
HBASE-22554Upgrade to surefire 2.22.2Majortest
HBASE-22534TestCellUtil fails when run on JDK11Minorjava, test
HBASE-22536TestForeignExceptionSerialization fails when run on JDK11Minorjava
HBASE-22535TestShellRSGroups fails when run on JDK11Minorjava, shell
HBASE-22500Modify pom and jenkins jobs for hadoop versionsBlockerbuild, hadoop2, hadoop3
HBASE-22483It's better to use 65KB as the default buffer size in ByteBuffAllocatorMajorBucketCache
HBASE-22463Some paths in HFileScannerImpl did not consider block#release which will exhaust the ByteBuffAllocatorMajor.
HBASE-22316Record the stack trace for current thread in FutureUtils.getMajorasyncclient, Client
HBASE-22422Retain an ByteBuff with refCnt=0 when getBlock from LRUCacheMajorBlockCache
HBASE-22326Fix Checkstyle errors in hbase-examplesMinor.
HBASE-22327Fix remaining Checkstyle issues in hbase-hadoop-compatTrivial.
HBASE-22478Add jackson dependency for hbase-http moduleMajorbuild, dependencies
HBASE-22445Add file info when throw exceptions in HFileReaderImplMajor.
HBASE-22447Check refCount before free block in BucketCacheMajorBucketCache
HBASE-22435Add a UT to address the HFileBlock#heapSize() in TestHeapSizeMajor.
HBASE-22412Improve the metrics in ByteBuffAllocatorMajor.
HBASE-22400Remove the adapter code in async fs implementation for hadoop-2.7.xMajorwal
HBASE-22430hbase-vote should tee build and test output to consoleTrivial.
HBASE-22429hbase-vote download step requires URL to end with ‘/’Trivial.
HBASE-22399Change default hadoop-two.version to 2.8.x and remove the 2.7.x hadoop checksMajorbuild, hadoop2
HBASE-22405Update Ref Guide for EOL of Hadoop 2.7Majorcommunity, documentation
HBASE-22090The HFileBlock#CacheableDeserializer should pass ByteBuffAllocator to the newly created HFileBlockMajor.
HBASE-21921Notify users if the ByteBufAllocator is always allocating ByteBuffers from heap which means the increacing GC pressureMinor.
HBASE-22345REST Server must have specific version of javax.annotations available at runtimeMajorREST
HBASE-22325AsyncRpcRetryingCaller will not schedule retry if we hit a NotServingRegionException but there is no TableName providedMajorasyncclient, Client
HBASE-22322Use special pause for CallQueueTooBigExceptionMajorasyncclient, Client
HBASE-22317Support reading from meta replicasMajorasyncclient, read replicas
HBASE-22122Change to release mob hfile's block after rpc server shipped response to clientMajor.
HBASE-22218Shell throws “Unsupported Java version” when tried with Java 11 (run-time)Major.
HBASE-21937Make the Compression#decompress can accept ByteBuff as inputMajor.
HBASE-22211Remove the returnBlock method because we can just call HFileBlock#release directlyMajor.
HBASE-19222update jruby to 9.1.17.0Majorshell
HBASE-21957Unify refCount of BucketEntry and refCount of hbase.nio.ByteBuff into oneMajor.
HBASE-22208Create access checker and expose it in RSMajor.
HBASE-22261Make use of ClusterStatusListener for async clientMajorasyncclient
HBASE-22267Implement client push back for async clientMajorasyncclient
HBASE-19763Fix Checkstyle errors in hbase-procedureMinor.
HBASE-22244Make use of MetricsConnection in async clientMajorasyncclient, metrics
HBASE-22249Rest Server throws NoClassDefFoundError with Java 11 (run-time)Major.
HBASE-22159ByteBufferIOEngine should support write off-heap ByteBuff to the bufferArrayMajor.
HBASE-22084Rename AccessControlLists to PermissionStorageMajor.
HBASE-22196Split TestRestartClusterMajortest
HBASE-21965Fix failed split and merge transactions that have failed to roll backMajorhbck2
HBASE-22117Move hasPermission/checkPermissions from region server to masterMajor.
HBASE-22153Fix the flaky TestRestartClusterMajortest
HBASE-22127Ensure that the block cached in the LRUBlockCache offheap is allocated from heapMajor.
HBASE-22152Create a jenkins file for yetus to processing GitHub PRMajorbuild
HBASE-22158RawAsyncHBaseAdmin.getTableSplits should filter out none default replicasMajorAdmin
HBASE-22157Include the cause when constructing RestoreSnapshotException in restoreSnapshotMajorAdmin
HBASE-22141Fix TestAsyncDecommissionAdminApiMajortest
HBASE-22005Use ByteBuff's refcnt to track the life cycle of data blockMajor.
HBASE-22135AsyncAdmin will not refresh master addressMajorAdmin, asyncclient, Client
HBASE-22101AsyncAdmin.isTableAvailable should not throw TableNotFoundExceptionMajorAdmin, asyncclient, Client
HBASE-22094Throw TableNotFoundException if table not exists in AsyncAdmin.compactMajorAdmin
HBASE-21911Move getUserPermissions from regionserver to masterMajor.
HBASE-22015UserPermission should be annotated as InterfaceAudience.PublicBlocker.
HBASE-22040Add mergeRegionsAsync with a List of region names method in AsyncAdminMajorAdmin, asyncclient, Client
HBASE-22039Should add the synchronous parameter for the XXXSwitch method in AsyncAdminMajorAdmin, asyncclient, Client
HBASE-22025RAT check fails in nightlies; fails on (old) test data files.Major.
HBASE-21977Skip replay WAL and update seqid when open regions restored from snapshotMajorRegion Assignment, snapshots
HBASE-22016Rewrite the block reading methods by using hbase.nio.ByteBuffMajor.
HBASE-22000Deprecated isTableAvailable with splitKeysMajorasyncclient, Client
HBASE-21917Make the HFileBlock#validateChecksum can accept ByteBuff as an input.Major.
HBASE-21949Fix flaky test TestHBaseTestingUtility.testMiniZooKeeperWithMultipleClientPortsMajor.
HBASE-15728Add remaining per-table region / store / flush / compaction related metricsMajormetrics
HBASE-21934RemoteProcedureDispatcher should track the ongoing dispatched callsBlockerproc-v2
HBASE-21978Should close AsyncRegistry if we fail to get cluster id when creating AsyncConnectionMajorasyncclient, Client
HBASE-21974Change Admin#grant/revoke parameter from UserPermission to user and PermissionMajor.
HBASE-21976Deal with RetryImmediatelyException for batching requestMajorasyncclient, Client
HBASE-21082Reimplement assign/unassign related procedure metricsCriticalamv2, metrics
HBASE-21916Abstract an ByteBuffAllocator to allocate/free ByteBuffer in ByteBufferPoolMajor.
HBASE-21820Implement CLUSTER quota scopeMajor.
HBASE-21927Always fail the locate request when error occurMajorasyncclient, Client
HBASE-21944Validate put for batch operationMajorasyncclient, Client
HBASE-21945Maintain the original order when sending batch requestMajorasyncclient, Client
HBASE-21783Support exceed user/table/ns throttle quota if region server has available quotaMajor.
HBASE-21930Deal with ScannerResetException when opening region scannerMajorasyncclient, Client
HBASE-21907Should set priority for rpc requestMajorasyncclient, Client
HBASE-21909Validate the put instance before executing in AsyncTable.put methodMajorasyncclient, Client
HBASE-21814Remove the TODO in AccessControlLists#addUserPermissionMajor.
HBASE-19889Revert Workaround: Purge User API building from branch-2 so can make a beta-1Majorwebsite
HBASE-21838Create a special ReplicationEndpoint just for verifying the WAL entries are fineMajorReplication, wal
HBASE-21829Use FutureUtils.addListener instead of calling whenComplete directlyMajorasyncclient, Client
HBASE-21828Make sure we do not return CompletionException when locating regionMajorasyncclient, Client
HBASE-21764Size of in-memory compaction thread pool should be configurableMajorCompaction, in-memory-compaction
HBASE-21739Move grant/revoke from regionserver to masterMajor.
HBASE-21799Update branch-2 version to 2.3.0-SNAPSHOTMajorbuild

OTHER:

JIRASummaryPriorityComponent
HBASE-24217Add hadoop 3.2.x supportMajor.
HBASE-21745Make HBCK2 be able to fix issues other than region assignmentCriticalhbase-operator-tools, hbck2
HBASE-22833MultiRowRangeFilter should provide a method for creating a filter which is functionally equivalent to multiple prefix filtersMinorClient
HBASE-24635Split TestMetaWithReplicasMajortest
HBASE-24646Set the log level for ScheduledChore to INFO in HBTUMajortest
HBASE-24631Loosen Dockerfile pinned package versions of the “debian-revision”Majorbuild
HBASE-23055Alter hbase:metaMajormeta
HBASE-24611Bring back old constructor of SnapshotDescriptionMajor.
HBASE-24547Thrift support for HBASE-23941Major.
HBASE-24535Tweak the master registry docs for branch-2MajorClient, master
HBASE-24367ScheduledChore log elapsed timespan in a human-friendly formatMinormaster, regionserver
HBASE-24500The behavior of RegionInfoBuilder.newBuilder(RegionInfo) is strangeBlockerClient, read replicas
HBASE-24418Consolidate Normalizer implementationsMajormaster, Normalizer
HBASE-24477Move ConfigurationObserver and related classes to hbase-commonMinorconf
HBASE-24417update copyright notices year to 2020Majordocumentation
HBASE-24408Introduce a general ‘local region’ to store data on masterBlockermaster
HBASE-24271Set values in `conf/hbase-site.xml` that enable running on `LocalFileSystem` out of the boxMajor.
HBASE-24295[Chaos Monkey] abstract logging through the class hierarchyMinorintegration tests
HBASE-24258[Hadoop3.3] Update license for org.ow2.asm:*Minordependencies
HBASE-24301Update Apache POM to version 23Minor.
HBASE-24285Move to hbase-thirdparty-3.3.0Major.
HBASE-24249Move code in FSHDFSUtils to FSUtils and mark related classes as finalMajorFilesystem Integration
HBASE-24264Disable TestNettyIPC.testHedgedAsyncEchoMajorIPC/RPC
HBASE-23896Snapshot owner cannot delete snapshot when ACL is enabled and Kerberos is not enabledMajor.
HBASE-24072Nightlies reporting OutOfMemoryError: unable to create new native threadMajortest
HBASE-24194Refactor BufferedEncodedSeeker anonymous classes to named inner classMinor.
HBASE-23779Up the default fork count to make builds complete faster; make count relative to CPU countMajortest
HBASE-24140Move CandidateGenerator out of StochasticLoadBalancerMajor.
HBASE-24156Make ZK registry the default for branch-2 and branch-2.3MajorClient
HBASE-24138Ensure StochasticLoadBalancer can log details of decision to not run balancerMajorBalancer, Operability
HBASE-24049“Packaging and Integration” check failsMajorbuild
HBASE-24084Fix missing jdk8 dependencies in hbase-assembly/hadoop-two-compatMajorbuild, master
HBASE-24092Fix links to build reports generated by nightly jobMinorbuild
HBASE-24078SpotBugs check automatically skip inapplicable modulesMinorbuild, test
HBASE-20467Precommit personality should only run checkstyle once if we're going to run it at the root.Minorcommunity, test
HBASE-24000Simplify CommonFSUtils after upgrading to hadoop 2.10.0Majorhadoop2, wal
HBASE-24002shadedjars check does not propagate --hadoop-profileMajorbuild
HBASE-23980Use enforcer plugin to print JVM info in maven outputMinorbuild
HBASE-24030Add necessary validations to HRegion.checkAndMutate() and HRegion.checkAndRowMutate()Major.
HBASE-23861Reconcile Hadoop versionMajordependencies
HBASE-23971protoc warns: “no protobuf syntax specified”MinorProtobufs
HBASE-24004Include hadoop version in Nightly report nameTrivialbuild
HBASE-23986Bump hadoop-two.version to 2.10.0 on master and branch-2Majorbuild, dependencies, hadoop2
HBASE-23978Dockerfiles reusing stale apt sources infoMajorbuild
HBASE-23077move entirely to spotbugsMajorbuild, test
HBASE-23945Dockerfiles showing hadolint check failuresMinorbuild
HBASE-18418Remove apache_hbase_topology from dev-supportMinor.
HBASE-23874Move Jira-attached file precommit definition from script in Jenkins config to dev-supportMinorbuild
HBASE-23854Documentation update of external_apis.adoc#example-scala-codeTrivialdocumentation
HBASE-23872[Flakey Test] TestGenerateDelegationToken; Master not initialized after 200000msMajorflakies
HBASE-23866More test classificationsTrivialtest
HBASE-23865Up flakey history from 5 to 10Major.
HBASE-23774Announce user-zh listTrivialwebsite
HBASE-23751Move core to hbase-thirdparty 3.2.0Major.
HBASE-23661Reduce number of Checkstyle violations in hbase-restMinor.
HBASE-23625Reduce number of Checkstyle violations in hbase-commonMinor.
HBASE-23335Improve cost functions array copy in StochasticLoadBalancerMinor.
HBASE-23700Upgrade checkstyle and plugin versionsMinorbuild
HBASE-23652Move the unsupported procedure type check before migrating to RegionProcedureStoreBlockermaster
HBASE-23687DEBUG logging cleanupTrivial.
HBASE-23664Upgrade JUnit to 4.13Minorintegration tests, test
HBASE-23628Replace Apache Commons Digest Base64 with JDK8 Base64Minordependencies
HBASE-23642Reintroduce ReplicationUtils.contains as deprecatedMajorReplication
HBASE-23604Clarify AsyncRegistry usage in the codeMinorClient
HBASE-23374ExclusiveMemHFileBlock’s allocator should not be hardcoded as ByteBuffAllocator.HEAPMinor.
HBASE-23575Remove dead code from AsyncRegistry interfaceMinorClient
HBASE-23556Minor ChoreService CleanupMinor.
HBASE-23298Refactor LogRecoveredEditsOutputSink and BoundedLogWriterCreationOutputSinkMajor.
HBASE-23234Provide .editorconfig based on checkstyle configurationMajorbuild, tooling
HBASE-23230Enforce member visibility in HRegionServerMajorregionserver
HBASE-22888Share some stuffs with the initial reader when new stream reader createdMajorHFile, regionserver
HBASE-23236Upgrade to yetus 0.11.1Majorbuild
HBASE-23250Log message about CleanerChore delegate initialization should be at INFOMinormaster, Operability
HBASE-23227Upgrade jackson-databind to 2.9.10.1 to avoid recent CVEsBlockerdependencies, REST, security
HBASE-23129Move core to use hbase-thirdparty-3.1.1Major.
HBASE-23053Disable concurrent nightly buildsMinorbuild
HBASE-23023upgrade shellcheck used to test in nightly and precommitMajorbuild
HBASE-23032Upgrade to Curator 4.2.0Major.
HBASE-23047ChecksumUtil.validateChecksum logs an INFO message inside a “if(LOG.isTraceEnabled())” block.Minor.
HBASE-23046Remove compatibility case from truncate commandMinorshell
HBASE-21056Findbugs false positive: BucketCache.persistToFile may fail to clean up java.io.OutputStreamMinorBucketCache
HBASE-23024Replace Exception.initCause() with Constructor argsMinor.
HBASE-22642Make move operations of RSGroup idempotentMajorrsgroup
HBASE-22895Fix the flakey TestSpaceQuotasMajorQuotas, test
HBASE-22910Enable TestMultiVersionConcurrencyControlMajortest
HBASE-22913Use Hadoop label for nightly buildsMajorbuild
HBASE-22911fewer concurrent github PR buildsCriticalbuild
HBASE-21400correct spelling error of ‘initilize’ in commentTrivialdocumentation
HBASE-22382Refactor tests in TestFromClientSideMajortest
HBASE-22594Clean up for backup examplesMinor.
HBASE-21606Document use of the meta table load metrics added in HBASE-19722Criticaldocumentation, meta, metrics, Operability
HBASE-19230Write up fixVersion policy from dev discussion in refguideMajordocumentation
HBASE-22651ErrorProne issue in TestByteBufferArrayMajortest
HBASE-22572Javadoc Warnings: @link reference not foundTrivialdocumentation
HBASE-22597Upgrading commons-lang to 3.9Majordependencies
HBASE-22556[DOCS] Backport HBASE-15557 to branch-1 and branch-2Major.
HBASE-22566Call out default compaction throttling for 2.x in BookMajordocumentation
HBASE-22560Upgrade to Jetty 9.3.latest and Jackson 2.9.latestMajordependencies
HBASE-22373maven-eclipse-plugin does not define version in every moduleMinor.
HBASE-21536Fix completebulkload usage instructionsTrivialdocumentation, mapreduce
HBASE-22449https everywhere in Maven metadataMinor.
HBASE-22406skip generating rdoc when building gems in our docker image for running yetusCriticalbuild, test
HBASE-22375Promote AccessChecker to LimitedPrivate(Coprocessor)MinorCoprocessors, security
HBASE-21714Deprecated isTableAvailableWithSplit method in thrift moduleMajorThrift
HBASE-22359Backport of HBASE-21371 misses activation-api license informationMinorbuild, community
HBASE-22174Remove error prone from our precommit javac checkMajorbuild
HBASE-22321Add 1.5 release line to the Hadoop supported versions tableMinordocumentation
HBASE-22083move eclipse specific configs into a profileMinorbuild
HBASE-22231Remove unused and * importsMinor.
HBASE-22307Deprecated Preemptive Fail FastMajorClient
HBASE-22304Fix remaining Checkstyle issues in hbase-endpointTrivial.
HBASE-22020upgrade to yetus 0.9.0Majorbuild, community
HBASE-22240[backport] HBASE-19762 Fix Checkstyle errors in hbase-httpMajor.
HBASE-22187Remove usage of deprecated ClusterConnection.clearRegionCacheTrivialClient
HBASE-22203Reformat DemoClient.javaTrivial.
HBASE-22189Remove usage of StoreFile.getModificationTimeStampTrivial.
HBASE-22108Avoid passing null in Admin methodsMajorAdmin
HBASE-22007Add restoreSnapshot and cloneSnapshot with acl methods in AsyncAdminMajorAdmin, asyncclient, Client
HBASE-22131Delete the patches in hbase-protocol-shaded moduleMajorbuild, Protobufs
HBASE-22099Backport HBASE-21895 “Error prone upgrade” to branch-2Majorbuild
HBASE-22052pom cleaning; filter out jersey-core in hadoop2 to match hadoop3 and remove redunant version specificationsMajor.
HBASE-22065Add listTableDescriptors(List<TableName>) method in AsyncAdminMajorAdmin
HBASE-22063Deprecated Admin.deleteSnapshot(byte[])MajorAdmin
HBASE-22042Missing @Override annotation for RawAsyncTableImpl.scanMajorasyncclient, Client
HBASE-22044ByteBufferUtils should not be IA.Public APIMajorcompatibility, util
HBASE-22001Polish the Admin interfaceMajorAdmin, Client
HBASE-21969Improve the update of destination rsgroup of RSGroupInfoManagerImpl#moveTables()Minorrsgroup
HBASE-21057upgrade to latest spotbugsMinorcommunity, test
HBASE-21888Add a isClosed method to AsyncConnectionMajorasyncclient, Client
HBASE-21884Fix box/unbox findbugs warning in secure bulk loadMinor.
HBASE-21859Add clearRegionLocationCache method for AsyncConnectionMajorasyncclient, Client
HBASE-21853update copyright notices to 2019Majordocumentation
HBASE-21812Address ruby static analysis for bin module [2nd pass]Minorscripts
HBASE-21791Upgrade thrift dependency to 0.12.0BlockerThrift

Release 2.2.0 - Unreleased (as of 2019-06-11)

INCOMPATIBLE CHANGES:

JIRASummaryPriorityComponent
HBASE-21991Fix MetaMetrics issues - [Race condition, Faulty remove logic], few improvementsMajorCoprocessors, metrics
HBASE-22399Change default hadoop-two.version to 2.8.x and remove the 2.7.x hadoop checksMajorbuild, hadoop2
HBASE-21082Reimplement assign/unassign related procedure metricsCriticalamv2, metrics
HBASE-20587Replace Jackson with shaded thirdparty gsonMajordependencies
HBASE-21727Simplify documentation around client timeoutMinor.
HBASE-21684Throw DNRIOE when connection or rpc client is closedMajorasyncclient, Client
HBASE-21792Mark HTableMultiplexer as deprecated and remove it in 3.0.0MajorClient
HBASE-21657PrivateCellUtil#estimatedSerializedSizeOf has been the bottleneck in 100% scan case.MajorPerformance
HBASE-21560Return a new TableDescriptor for MasterObserver#preModifyTable to allow coprocessor modify the TableDescriptorMajorCoprocessors
HBASE-21492CellCodec Written To WAL Before It's VerifiedCriticalwal
HBASE-21452Illegal character in hbase counters group nameMajorspark
HBASE-21158Empty qualifier cell should not be returned if it does not match QualifierFilterCriticalFilters
HBASE-21223[amv2] Remove abort_procedure from shellCriticalamv2, hbck2, shell
HBASE-20881Introduce a region transition procedure to handle all the state transition for a regionMajoramv2, proc-v2
HBASE-20884Replace usage of our Base64 implementation with java.util.Base64Major.

NEW FEATURES:

JIRASummaryPriorityComponent
HBASE-22148Provide an alternative to CellUtil.setTimestampBlockerAPI, Coprocessors
HBASE-21815Make isTrackingMetrics and getMetrics of ScannerContext publicMinor.
HBASE-21926Profiler servletMajormaster, Operability, regionserver
HBASE-20886[Auth] Support keytab login in hbase clientCriticalasyncclient, Client, security
HBASE-17942Disable region splits and merges per tableMajor.
HBASE-21753Support getting the locations for all the replicas of a regionMajorClient
HBASE-20636Introduce two bloom filter type : ROWPREFIX_FIXED_LENGTH and ROWPREFIX_DELIMITEDMajorHFile, regionserver, Scanners
HBASE-20649Validate HFiles do not have PREFIX_TREE DataBlockEncodingMinorOperability, tooling

IMPROVEMENTS:

JIRASummaryPriorityComponent
HBASE-22284optimization StringBuilder.append of AbstractMemStore.toStringTrivial.
HBASE-22523Refactor RegionStates#getAssignmentsByTable to make it easy to understandMajor.
HBASE-22511More missing /rs-status linksMinorUI
HBASE-22496UnsafeAccess.unsafeCopy should not copy more than UNSAFE_COPY_THRESHOLD on each iterationMajor.
HBASE-22488Cleanup the explicit timeout value for test methodsMajor.
HBASE-22411Refactor codes of moving reigons in RSGroupMajorrsgroup
HBASE-22467WebUI changes to enable Apache Knox UI proxyingMajorUI
HBASE-22474Add --mvn-custom-repo parameter to yetus callsMinor.
HBASE-20305Add option to SyncTable that skip deletes on target clusterMinormapreduce
HBASE-21784Dump replication queue should show list of wal files ordered chronologicallyMajorReplication, tooling
HBASE-22384Formatting issues in administration section of bookMinorcommunity, documentation
HBASE-21658Should get the meta replica number from zk instead of config at client sideCriticalClient
HBASE-22365Region may be opened on two RegionServersBlockeramv2
HBASE-22392Remove extra/useless +Trivial.
HBASE-20494Upgrade com.yammer.metrics dependencyMajordependencies
HBASE-22358Change rubocop configuration for method lengthMinorcommunity, shell
HBASE-22379Fix Markdown for “Voting on Release Candidates” in bookMinorcommunity, documentation
HBASE-22109Update hbase shaded content checker after guava update in hadoop branch-3.0 to 27.0-jreMinor.
HBASE-22087Update LICENSE/shading for the dependencies from the latest Hadoop trunkMinorhadoop3
HBASE-22341Add explicit guidelines for removing deprecations in bookMajorAPI, community, documentation
HBASE-22225Profiler tab on Master/RS UI not working w/o comprehensive messageMinorUI
HBASE-22291Fix recovery of recovered.edits files under root dirMajor.
HBASE-22283Print row and table information when failed to get region locationMajorClient, logging
HBASE-22296Remove TestFromClientSide.testGetStartEndKeysWithRegionReplicasMajortest
HBASE-22250The same constants used in many places should be placed in constant classesMinorClient, conf, regionserver
HBASE-20586SyncTable tool: Add support for cross-realm remote clustersMajormapreduce, Operability, Replication
HBASE-21257misspelled words.[occured -> occurred]Trivial.
HBASE-22193Add backoff when region failed open too many timesMajor.
HBASE-22188Make TestSplitMerge more stableMajortest
HBASE-22097Modify the description of split command in shellTrivialshell
HBASE-21964unset Quota by Throttle TypeMajormaster
HBASE-22093Combine TestRestoreSnapshotFromClientWithRegionReplicas to CloneSnapshotFromClientAfterSplittingRegionTestBase#testCloneSnapshotAfterSplittingRegionMajor.
HBASE-22009Improve RSGroupInfoManagerImpl#getDefaultServers()Minorrsgroup
HBASE-22032KeyValue validation should check for null byte arrayMajor.
HBASE-21667Move to latest ASF Parent POMMinorbuild
HBASE-21810bulkload support set hfile compression on clientMajormapreduce
HBASE-21987Simplify RSGroupInfoManagerImpl#flushConfig() for offline modeMinorrsgroup
HBASE-21871Support to specify a peer table name in VerifyReplication toolMajor.
HBASE-21255[acl] Refactor TablePermission into three classes (Global, Namespace, Table)Major.
HBASE-21410A helper page that help find all problematic regions and proceduresMajor.
HBASE-20734Colocate recovered edits directory with hbase.wal.dirMajorMTTR, Recovery, wal
HBASE-20401Make `MAX_WAIT` and `waitIfNotFinished` in CleanerContext configurableMinormaster
HBASE-21481[acl] Superuser's permissions should not be granted or revoked by any non-su global adminMajor.
HBASE-21967Split TestServerCrashProcedure and TestServerCrashProcedureWithReplicasMajor.
HBASE-21867Support multi-threads in HFileArchiverMajor.
HBASE-21932Use Runtime.getRuntime().halt to terminate regionserver when abort timeoutMajor.
HBASE-21875Change the retry logic in RSProcedureDispatcher to ‘retry by default, only if xxx’Majorproc-v2
HBASE-21780Avoid a wide line on the RegionServer webUI for many ZooKeeper serversMinorUI, Usability
HBASE-21636Enhance the shell scan command to support missing scanner specifications like ReadType, IsolationLevel etc.Majorshell
HBASE-21857Do not need to check clusterKey if replicationEndpoint is provided when adding a peerMajor.
HBASE-21201Support to run VerifyReplication MR tool without peeridMajorhbase-operator-tools
HBASE-21816Print source cluster replication config directoryTrivialReplication
HBASE-19616Review of LogCleaner ClassMinor.
HBASE-21830Backport HBASE-20577 (Make Log Level page design consistent with the design of other pages in UI) to branch-2MajorUI, Usability
HBASE-21833Use NettyAsyncFSWALConfigHelper.setEventLoopConfig to prevent creating too many netty event loop when executing TestHRegionMinortest
HBASE-21634Print error message when user uses unacceptable values for LIMIT while setting quotas.Minor.
HBASE-21789Rewrite MetaTableAccessor.multiMutate with Table.coprocessorServiceMajorClient, Coprocessors
HBASE-21689Make table/namespace specific current quota info available in shell(describe_namespace & describe)Minor.
HBASE-20215Rename CollectionUtils to ConcurrentMapUtilsTrivial.
HBASE-21720metric to measure how actions are distributed to servers within a MultiActionMinorClient, metrics, monitoring
HBASE-21595Print thread's information and stack traces when RS is aborting forciblyMinorregionserver
HBASE-20209Do Not Use Both Map containsKey and get Methods in Replication SinkTrivialReplication
HBASE-21712Make submit-patch.py python3 compatibleMinortooling
HBASE-21590Optimize trySkipToNextColumn in StoreScanner a bitCriticalPerformance, Scanners
HBASE-21297ModifyTableProcedure can throw TNDE instead of IOE in case of REGION_REPLICATION changeMinor.
HBASE-21700Simplify the implementation of RSGroupInfoManagerImplMajorrsgroup
HBASE-21694Add append_peer_exclude_tableCFs and remove_peer_exclude_tableCFs shell commandsMajor.
HBASE-21645Perform sanity check and disallow table creation/modification with region replication < 1Minor.
HBASE-21360Disable printing of stack-trace in shell for quotasMinorshell
HBASE-21662Add append_peer_exclude_namespaces and remove_peer_exclude_namespaces shell commandsMajor.
HBASE-21659Avoid to load duplicate coprocessors in system config and table descriptorMinor.
HBASE-21642CopyTable by reading snapshot and bulkloading will save a lot of time.Major.
HBASE-21643Introduce two new region coprocessor method and deprecated postMutationBeforeWALMajor.
HBASE-21640Remove the TODO when increment zeroMajor.
HBASE-21631list_quotas should print human readable values for LIMITMinorshell
HBASE-21635Use maven enforcer to ban imports from illegal packagesMajorbuild
HBASE-21514Refactor CacheConfigMajor.
HBASE-21520TestMultiColumnScanner cost long time when using ROWCOL bloom typeMajortest
HBASE-21554Show replication endpoint classname for replication peer on master web UIMinorUI
HBASE-21549Add shell command for serial replication peerMajor.
HBASE-21283Add new shell command ‘rit’ for listing regions in transitionMinorOperability, shell
HBASE-21567Allow overriding configs starting up the shellMajorshell
HBASE-21413Empty meta log doesn't get split when restart whole clusterMajor.
HBASE-21524Unnecessary DEBUG log in ConnectionImplementation#isTableEnabledMajorClient
HBASE-21511Remove in progress snapshot check in SnapshotFileCache#getUnreferencedFilesMinorsnapshots
HBASE-21480Taking snapshot when RS crashes prevent we bring the regions onlineMajorsnapshots
HBASE-21485Add more debug logs for remote procedure executionMajorproc-v2
HBASE-21328add HBASE_DISABLE_HADOOP_CLASSPATH_LOOKUP switch to hbase-env.shMinordocumentation, Operability
HBASE-19682Use Collections.emptyList() For Empty List ValuesMinor.
HBASE-21388No need to instantiate MemStoreLAB for master which not carry tableMajor.
HBASE-21325Force to terminate regionserver when abort hang in somewhereMajor.
HBASE-21385HTable.delete request use rpc call directly instead of AsyncProcessMajor.
HBASE-21318Make RefreshHFilesClient runnableMinorHFile
HBASE-21263Mention compression algorithm along with other storefile detailsMinor.
HBASE-21290No need to instantiate BlockCache for master which not carry tableMajor.
HBASE-21256Improve IntegrationTestBigLinkedList for testing huge dataMajorintegration tests
HBASE-21251Refactor RegionMoverMajorOperability
HBASE-21303[shell] clear_deadservers with no args failsMajor.
HBASE-21098Improve Snapshot Performance with Temporary Snapshot Directory when rootDir on S3Major.
HBASE-21299List counts of actual region states in master UI tables sectionMajorUI
HBASE-21289Remove the log “‘hbase.regionserver.maxlogs’ was deprecated.” in AbstractFSWALMinor.
HBASE-21185WALPrettyPrinter: Additional useful info to be printed by wal printer tool, for debugability purposesMinorOperability
HBASE-21103nightly test cache of yetus install needs to be more thorough in verificationMajortest
HBASE-21207Add client side sorting functionality in master web UI for table and region server details.Minormaster, monitoring, UI, Usability
HBASE-20857JMX - add Balancer status = enabled / disabledMajorAPI, master, metrics, REST, tooling, Usability
HBASE-21164reportForDuty to spew less log if master is initializingMinorregionserver
HBASE-21204NPE when scan raw DELETE_FAMILY_VERSION and codec is not setMajor.
HBASE-20307LoadTestTool prints too much zookeeper loggingMinortooling
HBASE-21155Save on a few log strings and some churn in wal splitter by skipping out early if no logs in dirTrivial.
HBASE-21129Clean up duplicate codes in #equals and #hashCode methods of FilterMinorFilters
HBASE-21157Split TableInputFormatScan to individual testsMinortest
HBASE-21107add a metrics for netty direct memoryMinorIPC/RPC
HBASE-21153Shaded client jars should always build in relevant phase to avoid confusionMajorbuild
HBASE-21126Add ability for HBase Canary to ignore a configurable number of ZooKeeper down nodesMinorcanary, Zookeeper
HBASE-20749Upgrade our use of checkstyle to 8.6+Minorbuild, community
HBASE-21071HBaseTestingUtility::startMiniCluster() to use builder patternMajortest
HBASE-20387flaky infrastructure should work for all branchesCriticaltest
HBASE-20469Directory used for sidelining old recovered edits files should be made configurableMinor.
HBASE-20979Flaky test reporting should specify what JSON it needs and handle HTTP errorsMinortest
HBASE-20985add two attributes when we do normalizationMajor.
HBASE-20965Separate region server report requests to new handlersMajorPerformance
HBASE-20845Support set the consistency for Gets and Scans in thrift2MajorThrift
HBASE-20986Separate the config of block size when we do log splitting and write HlogMajor.
HBASE-19036Add action in Chaos Monkey to restart Active NamenodeMinor.
HBASE-20856PITA having to set WAL provider in two placesMinorOperability, wal
HBASE-20935HStore.removeCompactedFiles should log in case it is unable to delete a fileMinor.
HBASE-20873Update doc for Endpoint-based ExportMinordocumentation
HBASE-20672New metrics ReadRequestRate and WriteRequestRateMinormetrics
HBASE-20617Upgrade/remove jetty-jspMinor.
HBASE-20396Remove redundant MBean from thrift JMXMajorThrift
HBASE-20357AccessControlClient API EnhancementMajorsecurity

BUG FIXES:

JIRASummaryPriorityComponent
HBASE-22563Reduce retained jobs for Jenkins pipelinesMajor.
HBASE-22552Rewrite TestEndToEndSplitTransaction.testCanSplitJustAfterASplitMajortest
HBASE-22551TestMasterOperationsForRegionReplicas is flakeyMajorread replicas, test
HBASE-22481Javadoc Warnings: reference not foundTrivialdocumentation
HBASE-22546TestRegionServerHostname#testRegionServerHostname fails reliably for meMajor.
HBASE-22534TestCellUtil fails when run on JDK11Minorjava, test
HBASE-22536TestForeignExceptionSerialization fails when run on JDK11Minorjava
HBASE-22535TestShellRSGroups fails when run on JDK11Minorjava, shell
HBASE-22518yetus personality is treating branch-1.4 like earlier branches for hadoopcheckMajortest
HBASE-22513Admin#getQuota does not work correctly if exceedThrottleQuota is setMajorQuotas
HBASE-22522The integration test in master branch's nightly job has error “ERROR: Only found 1050 rows.”Major.
HBASE-22490Nightly client integration test fails with hadoop-3Majorbuild
HBASE-22502Purge the logs when we reach the EOF for the last wal file when replicationMajor.
HBASE-22503Failed to upgrade to 2.2+ as the global permission which storaged in zk is not rightBlocker.
HBASE-22487getMostLoadedRegions is unusedTrivialregionserver
HBASE-22485Fix failed ut TestClusterRestartFailoverMajor.
HBASE-22486Fix flaky test TestLockManagerMajor.
HBASE-22471Our nightly jobs for master and branch-2 are still using hadoop-2.7.1 in integration testMajorbuild
HBASE-22003Fix flaky test TestVerifyReplication.testHBase14905Major.
HBASE-22441BucketCache NullPointerException in cacheBlockMajorBucketCache
HBASE-22473Split TestSCPMajorRecovery, test
HBASE-22456Polish TestSplitTransitionOnClusterMajortest
HBASE-21800RegionServer aborted due to NPE from MetaTableMetrics coprocessorCriticalCoprocessors, meta, metrics, Operability
HBASE-22462Should run a ‘mvn install’ at the end of hadoop check in pre commit jobMajorbuild
HBASE-22440HRegionServer#getWalGroupsReplicationStatus() throws NPEMajorregionserver, Replication
HBASE-22226Incorrect level for headings in asciidocTrivialdocumentation
HBASE-22442Nightly build is failing with hadoop 3.xMajorbuild, hadoop3
HBASE-20970Update hadoop check versions for hadoop3 in hbase-personalityMajorbuild
HBASE-22424Interactions in RSGroup test classes will cause TestRSGroupsAdmin2.testMoveServersAndTables and TestRSGroupsBalance.testGroupBalance flakyMajorrsgroup
HBASE-22404Open/Close region request may be executed twice when master restartMajor.
HBASE-22274Cell size limit check on append should consider cell's previous size.Minor.
HBASE-22072High read/write intensive regions may cause long crash recoveryMajorPerformance, Recovery
HBASE-22324loss a mass of data when the sequenceId of cells greater than Integer.Max, because MemStoreMergerSegmentsIterator can not merge segmentsBlockerin-memory-compaction
HBASE-21777“Tune compaction throughput” debug messages even when nothing has changedTrivialCompaction
HBASE-22360Abort timer doesn't set when abort is called during graceful shutdown processMajorregionserver
HBASE-20851Change rubocop config for max line length of 100Minorcommunity, shell
HBASE-21467Fix flaky test TestCoprocessorClassLoader.testCleanupOldJarsMinor.
HBASE-22312Hadoop 3 profile for hbase-shaded-mapreduce should like mapreduce as a provided dependencyMajormapreduce, shading
HBASE-22314shaded byo-hadoop client should list needed hadoop modules as provided scope to avoid inclusion of unnecessary transitive depednenciesMajorhadoop2, hadoop3, shading
HBASE-22047LeaseException in Scan should be retiredMajorClient, Scanners
HBASE-22343Make procedure retry interval configurable in testMajoramv2, test
HBASE-22190SnapshotFileCache may fail to load the correct snapshot file list when there is an on-going snapshot operationBlockersnapshots
HBASE-22354master never sets abortRequested, and thus abort timeout doesn't work for itMajor.
HBASE-22350Rewrite TestClientOperationTimeout so we do not timeout when creating tableMajortest
HBASE-22340Corrupt KeyValue is silently ignoredCriticalwal
HBASE-22054Space Quota: Compaction is not working for super user in case of NO_WRITES_COMPACTIONSMinor.
HBASE-22236AsyncNonMetaRegionLocator should not cache HRegionLocation with null locationMajorasyncclient
HBASE-22086space quota issue: deleting snapshot doesn't update the usage of tableMinor.
HBASE-22298branch-2.2 nightly fails “[ForOverride] Method annotated @ForOverride must have protected or package-private visibility”Major.
HBASE-22292PreemptiveFastFailInterceptor clean repeatedFailuresMap issueBlocker.
HBASE-22230REST Server drops connection on long scansMajor.
HBASE-22200WALSplitter.hasRecoveredEdits should use same FS instance from WAL region dirMajorwal
HBASE-22286License handling incorrectly lists CDDL/GPLv2+CE as safe to not aggregateCriticalbuild, community
HBASE-22282Should deal with error in the callback of RawAsyncHBaseAdmin.splitRegion methodsMajorAdmin, asyncclient
HBASE-22278RawAsyncHBaseAdmin should not use cached region locationMajorAdmin, asyncclient
HBASE-22222Site build fails after hbase-thirdparty upgradeBlockerwebsite
HBASE-22249Rest Server throws NoClassDefFoundError with Java 11 (run-time)Major.
HBASE-22235OperationStatus.{SUCCESS|FAILURE|NOT_RUN} are not visible to 3rd party coprocessorsMajorCoprocessors
HBASE-22207Fix flakey TestAssignmentManager.testAssignSocketTimeoutMajortest
HBASE-22202Fix new findbugs issues after we upgrade hbase-thirdparty dependenciesMajorfindbugs
HBASE-22144MultiRowRangeFilter does not work with reversed scansCriticalFilters, Scanners
HBASE-22198Fix flakey TestAsyncTableGetMultiThreadedMajortest
HBASE-22185RAMQueueEntry#writeToCache should freeBlock if any exception encountered instead of the IOException catch blockMajor.
HBASE-22163Should not archive the compacted store files when region warmupBlocker.
HBASE-22178Introduce a createTableAsync with TableDescriptor method in AdminMajorAdmin
HBASE-22180Make TestBlockEvictionFromClient.testBlockRefCountAfterSplits more stableMajortest
HBASE-22179Fix RawAsyncHBaseAdmin.getCompactionStateMajorAdmin, asyncclient
HBASE-22177Do not recreate IOException in RawAsyncHBaseAdmin.adminCallMajorAdmin, asyncclient
HBASE-22070Checking restoreDir in RestoreSnapshotHelperMinorsnapshots
HBASE-20912Add import order config in dev support for eclipseMajor.
HBASE-22133Forward port HBASE-22073 “/rits.jsp throws an exception if no procedure” to branch-2.2+MajorUI
HBASE-20911correct Swtich/case indentation in formatter template for eclipseMajor.
HBASE-21688Address WAL filesystem issuesMajorFilesystem Integration, wal
HBASE-22121AsyncAdmin can not deal with non default meta replicaMajorAdmin, asyncclient, Client
HBASE-22115HBase RPC aspires to grow an infinite tree of trace scopes; some other places are also unsafeCritical.
HBASE-22123REST gateway reports Insufficient permissions exceptions as 404 Not FoundMinorREST
HBASE-21135Build fails on windows as it fails to parse windows path during license checkMajorbuild
HBASE-21781list_deadservers elapsed time is incorrectMajorshell
HBASE-22100False positive for error prone warnings in pre commit jobMinorbuild
HBASE-22098Backport HBASE-18667 “Disable error-prone for hbase-protocol-shaded” to branch-2Majorbuild
HBASE-20662Increasing space quota on a violated table does not remove SpaceViolationPolicy.DISABLE enforcementMajor.
HBASE-22057Impose upper-bound on size of ZK ops sent in a single multi()Major.
HBASE-22074Should use procedure store to persist the state in reportRegionStateTransitionBlockeramv2, proc-v2
HBASE-21619Fix warning message caused by incorrect ternary operator evaluationTrivial.
HBASE-22095Taking a snapshot fails in local modeMajor.
HBASE-22061SplitTableRegionProcedure should hold the lock of its daughter regionsMajor.
HBASE-22045Mutable range histogram reports incorrect outliersMajor.
HBASE-21736Remove the server from online servers before scheduling SCP for it in hbckMajorhbck2, test
HBASE-22011ThriftUtilities.getFromThrift should set filter when not set columnsMajor.
HBASE-21990puppycrawl checkstyle dtds 404... moved to sourceforgeMajorbuild
HBASE-22010docs on upgrade from 2.0,2.1 -> 2.2 renders incorrectlyMinordocumentation
HBASE-22006Fix branch-2.1 findbugs warning; causes nightly show as failed.Major.
HBASE-21960RESTServletContainer not configured for REST Jetty serverBlockerREST
HBASE-21915FileLink$FileLinkInputStream doesn't implement CanUnbufferMajorFilesystem Integration
HBASE-21565Delete dead server from dead server list too early leads to concurrent Server Crash Procedures(SCP) for a same serverCritical.
HBASE-21740NPE happens while shutdown the RSMajor.
HBASE-21866Do not move the table to null rsgroup when creating an existing tableMajorproc-v2, rsgroup
HBASE-21983Should track the scan metrics in AsyncScanSingleRegionRpcRetryingCaller if scan metrics is enabledMajorasyncclient, Client
HBASE-21980Fix typo in AbstractTestAsyncTableRegionReplicasReadMajortest
HBASE-21487Concurrent modify table ops can lead to unexpected resultsMajor.
HBASE-20724Sometimes some compacted storefiles are still opened after region failoverCritical.
HBASE-21961Infinite loop in AsyncNonMetaRegionLocator if there is only one region and we tried to locate before a non empty rowCriticalasyncclient, Client
HBASE-21943The usage of RegionLocations.mergeRegionLocations is wrong for async clientCriticalasyncclient, Client
HBASE-21947TestShell is broken after we remove the jackson dependenciesMajordependencies, shell
HBASE-21942[UI] requests per second is incorrect in rsgroup page(rsgroup.jsp)Minor.
HBASE-21922BloomContext#sanityCheck may failed when use ROWPREFIX_DELIMITED bloom filterMajor.
HBASE-21929The checks at the end of TestRpcClientLeaks are not executedMajortest
HBASE-21938Add a new ClusterMetrics.Option SERVERS_NAME to only return the live region servers's name without metricsMajor.
HBASE-21928Deprecated HConstants.META_QOSMajorClient, rpc
HBASE-21899Fix missing variables in slf4j LoggerTriviallogging
HBASE-21910The nonce implementation is wrong for AsyncTableCriticalasyncclient, Client
HBASE-21900Infinite loop in AsyncMetaRegionLocator if we can not get the location for metaMajorasyncclient, Client
HBASE-21890Use execute instead of submit to submit a task in RemoteProcedureDispatcherCriticalproc-v2
HBASE-21889Use thrift 0.12.0 when build thrift by compile-thrift profileMajor.
HBASE-21785master reports open regions as RITs and also messes up rit age metricMajor.
HBASE-21854Race condition in TestProcedureSkipPersistenceMinorproc-v2
HBASE-21862IPCUtil.wrapException should keep the original exception types for all the connection exceptionsBlocker.
HBASE-18484VerifyRep by snapshot does not work when Yarn / SourceHBase / PeerHBase located in different HDFS clustersMajorReplication
HBASE-21775The BufferedMutator doesn't ever refresh region location cacheMajorClient
HBASE-21843RegionGroupingProvider breaks the meta wal file name pattern which may cause data loss for meta regionBlockerwal
HBASE-21795Client application may get stuck (time bound) if a table modify op is called immediately after split opCriticalamv2
HBASE-21840TestHRegionWithInMemoryFlush fails with NPEBlockertest
HBASE-21811region can be opened on two servers due to race condition with procedures and server reportsBlockeramv2
HBASE-21644Modify table procedure runs infinitely for a table having region replication > 1CriticalAdmin
HBASE-21733SnapshotQuotaObserverChore should only fetch space quotasMajor.
HBASE-21699Create table failed when using SPLITS_FILE => ‘splits.txt’BlockerClient, shell
HBASE-21535Zombie Master detector is not workingCriticalmaster
HBASE-21770Should deal with meta table in HRegionLocator.getAllRegionLocationsMajorClient
HBASE-21754ReportRegionStateTransitionRequest should be executed in priority executorMajor.
HBASE-21475Put mutation (having TTL set) added via co-processor is retrieved even after TTL expiresMajorCoprocessors
HBASE-21749RS UI may throw NPE and make rs-status page inaccessible with multiwal and replicationMajorReplication, UI
HBASE-21746Fix two concern cases in RegionMoverMajor.
HBASE-21732Should call toUpperCase before using Enum.valueOf in some methods for ColumnFamilyDescriptorCriticalClient
HBASE-21704The implementation of DistributedHBaseCluster.getServerHoldingRegion is incorrectMajor.
HBASE-20917MetaTableMetrics#stop references uninitialized requestsMap for non-meta regionMajormeta, metrics
HBASE-21639maxHeapUsage value not read properly from config during EntryBuffers initializationMinor.
HBASE-21225Having RPC & Space quota on a table/Namespace doesn't allow space quota to be removed using ‘NONE’Major.
HBASE-21707Fix warnings in hbase-rsgroup module and also make the UTs more stableMajorRegion Assignment, rsgroup
HBASE-20220[RSGroup] Check if table exists in the cluster before moving it to the specified regionserver groupMajorrsgroup
HBASE-21691Fix flaky test TestRecoveredEditsMajor.
HBASE-21695Fix flaky test TestRegionServerAbortTimeoutMajor.
HBASE-21614RIT recovery with ServerCrashProcedure doesn't account for all regionsCriticalamv2
HBASE-21618Scan with the same startRow(inclusive=true) and stopRow(inclusive=false) returns one resultCriticalClient
HBASE-21683Reset readsEnabled flag after successfully flushing the primary regionCriticalread replicas
HBASE-21630[shell] Define ENDKEY == STOPROW (we have ENDROW)Trivialshell
HBASE-21547Precommit uses master flaky list for other branchesMajortest
HBASE-21660Apply the cell to right memstore for increment/append operationMajor.
HBASE-21646Flakey TestTableSnapshotInputFormat; DisableTable not completing...Majortest
HBASE-21545NEW_VERSION_BEHAVIOR breaks Get/Scan with specified columnsMajorAPI
HBASE-21629draining_servers.rb is brokenMajorscripts
HBASE-21621Reversed scan does not return expected number of rowsCriticalScanners
HBASE-21620Problem in scan query when using more than one column prefix filter in some cases.MajorScanners
HBASE-21610numOpenConnections metric is set to -1 when zero server channel existMinormetrics
HBASE-21498Master OOM when SplitTableRegionProcedure new CacheConfig and instantiate a new BlockCacheMajor.
HBASE-21592quota.addGetResult(r) throw NPEMajor.
HBASE-21589TestCleanupMetaWAL failsBlockertest, wal
HBASE-21575memstore above high watermark message is logged too muchMinorlogging, regionserver
HBASE-21582If call HBaseAdmin#snapshotAsync but forget call isSnapshotFinished, then SnapshotHFileCleaner will skip to run every timeMajor.
HBASE-21568Disable use of BlockCache for LoadIncrementalHFilesMajorClient
HBASE-21453Convert ReadOnlyZKClient to DEBUG instead of INFOMajorlogging, Zookeeper
HBASE-21559The RestoreSnapshotFromClientTestBase related UT are flakyMajor.
HBASE-21551Memory leak when use scan with STREAM at server sideBlockerregionserver
HBASE-21550Add a new method preCreateTableRegionInfos for MasterObserver which allows CPs to modify the TableDescriptorMajorCoprocessors
HBASE-21479Individual tests in TestHRegionReplayEvents class are failingMajor.
HBASE-21518TestMasterFailoverWithProcedures is flakyMajor.
HBASE-21504If enable FIFOCompactionPolicy, a compaction may write a “empty” hfile whose maxTimeStamp is long max. This kind of hfile will never be archived.CriticalCompaction
HBASE-21300Fix the wrong reference file path when restoring snapshots for tables with MOB columnsMajor.
HBASE-21507Compaction failed when execute AbstractMultiFileWriter.beforeShipped() methodMajorCompaction, regionserver
HBASE-21387Race condition surrounding in progress snapshot handling in snapshot cache leads to loss of snapshot filesMajorsnapshots
HBASE-21503Replication normal source can get stuck due potential race conditions between source wal reader and wal provider initialization threads.BlockerReplication
HBASE-21466WALProcedureStore uses wrong FileSystem if wal.dir is not under rootdirMajor.
HBASE-21445CopyTable by bulkload will write hfile into yarn's HDFSMajormapreduce
HBASE-21437Bypassed procedure throw IllegalArgumentException when its state is WAITING_TIMEOUTMajor.
HBASE-21439StochasticLoadBalancer RegionLoads aren’t being used in RegionLoad cost functionsMajorBalancer
HBASE-20604ProtobufLogReader#readNext can incorrectly loop to the same position in the stream until the the WAL is rolledCriticalReplication, wal
HBASE-21247Custom Meta WAL Provider doesn't default to custom WAL Provider whose configuration value is outside the enums in ProvidersMajorwal
HBASE-21430[hbase-connectors] Move hbase-spark* modules to hbase-connectors repoMajorhbase-connectors, spark
HBASE-21438TestAdmin2#testGetProcedures fails due to FailedProcedure inaccessibleMajor.
HBASE-214252.1.1 fails to start over 1.x data; namespace not assignedCriticalamv2
HBASE-21407Resolve NPE in backup Master UIMinorUI
HBASE-21422NPE in TestMergeTableRegionsProcedure.testMergeWithoutPONRMajorproc-v2, test
HBASE-21424Change flakies and nightlies so scheduled less oftenMajorbuild
HBASE-21417Pre commit build is broken due to surefire plugin crashesCriticalbuild
HBASE-21371Hbase unable to compile against Hadoop trunk (3.3.0-SNAPSHOT) due to license errorMajor.
HBASE-21391RefreshPeerProcedure should also wait master initialized before executingMajorReplication
HBASE-21342FileSystem in use may get closed by other bulk load call in secure bulkLoadMajor.
HBASE-21349Cluster is going down but CatalogJanitor and Normalizer try to run and fail noiselyMinor.
HBASE-21356bulkLoadHFile API should ensure that rs has the source hfile's write permissionMajor.
HBASE-21355HStore's storeSize is calculated repeatedly which causing the confusing region splitBlockerregionserver
HBASE-21334TestMergeTableRegionsProcedure is flakeyMajoramv2, proc-v2, test
HBASE-21178[BC break] : Get and Scan operation with a custom converter_class not workingCriticalshell
HBASE-21200Memstore flush doesn't finish because of seekToPreviousRow() in memstore scanner.CriticalScanners
HBASE-21292IdLock.getLockEntry() may hang if interruptedMajor.
HBASE-21335Change the default wait time of HBCK2 toolCritical.
HBASE-21291Add a test for bypassing stuck state-machine proceduresMajor.
HBASE-21055NullPointerException when balanceOverall() but server balance info is nullMajorBalancer
HBASE-21327Fix minor logging issue where we don't report servername if no associated SCPTrivialamv2
HBASE-21320[canary] Cleanup of usage and add commentaryMajorcanary
HBASE-21266Not running balancer because processing dead regionservers, but empty dead rs listMajor.
HBASE-21260The whole balancer plans might be aborted if there are more than one plans to move a same regionMajorBalancer, master
HBASE-21280Add anchors for each heading in UITrivialUI, Usability
HBASE-20764build broken when latest commit is gpg signedCriticalbuild
HBASE-18549Unclaimed replication queues can go undetectedCriticalReplication
HBASE-21248Implement exponential backoff when retrying for ModifyPeerProcedureMajorproc-v2, Replication
HBASE-21196HTableMultiplexer clears the meta cache after every put operationCriticalPerformance
HBASE-19418RANGE_OF_DELAY in PeriodicMemstoreFlusher should be configurable.Minor.
HBASE-18451PeriodicMemstoreFlusher should inspect the queue before adding a delayed flush requestMajorregionserver
HBASE-21228Memory leak since AbstractFSWAL caches Thread object and never clean laterCriticalwal
HBASE-20766Verify Replication Tool Has Typo “remove cluster”Trivial.
HBASE-21232Show table state in Tables view on Master home pageMajorOperability, UI
HBASE-21212Wrong flush time when update flush metricMinor.
HBASE-21208Bytes#toShort doesn't work without unsafeCritical.
HBASE-20704Sometimes some compacted storefiles are not archived on region closeCriticalCompaction
HBASE-21203TestZKMainServer#testCommandLineWorks won't pass with default 4lw whitelistMinortest, Zookeeper
HBASE-21102ServerCrashProcedure should select target server where no other replicas exist for the current regionMajorRegion Assignment
HBASE-21206Scan with batch size may return incomplete cellsCriticalScanners
HBASE-21182Failed to execute start-hbase.shMajor.
HBASE-21179Fix the number of actions in responseTooSlow logMajorlogging, rpc
HBASE-21174[REST] Failed to parse empty qualifier in TableResource#getScanResourceMajorREST
HBASE-21181Use the same filesystem for wal archive directory and wal directoryMajor.
HBASE-21021Result returned by Append operation should be orderedMajor.
HBASE-21173Remove the duplicate HRegion#close in TestHRegionMinortest
HBASE-21144AssignmentManager.waitForAssignment is not stableMajoramv2, test
HBASE-21143Update findbugs-maven-plugin to 3.0.4Majorpom
HBASE-21171[amv2] Tool to parse a directory of MasterProcWALs standaloneMajoramv2, test
HBASE-21052After restoring a snapshot, table.jsp page for the table gets stuckMajorsnapshots
HBASE-21001ReplicationObserver fails to load in HBase 2.0.0Major.
HBASE-20741Split of a region with replicas creates all daughter regions and its replica in same serverMajorread replicas
HBASE-21127TableRecordReader need to handle cursor result tooMajor.
HBASE-20892[UI] Start / End keys are empty on table.jspMajor.
HBASE-21136NPE in MetricsTableSourceImpl.updateFlushTimeMajormetrics
HBASE-21132return wrong result in rest multigetMajor.
HBASE-21128TestAsyncRegionAdminApi.testAssignRegionAndUnassignRegion is brokenMajortest
HBASE-20940HStore.cansplit should not allow split to happen if it has referencesMajor.
HBASE-21084When cloning a snapshot including a split parent region, the split parent region of the cloned table will be onlineMajorsnapshots
HBASE-20968list_procedures_test fails due to no matching regexMajorshell, test
HBASE-21030Correct javadoc for append operationMinordocumentation
HBASE-21088HStoreFile should be closed in HStore#hasReferencesMajor.
HBASE-20890PE filterScan seems to be stuck foreverMinor.
HBASE-20772Controlled shutdown fills Master log with the disturbing message "No matching procedure found for rit=OPEN, location=ZZZZ, table=YYYYY, region=XXXX transition to CLOSEDMajorlogging
HBASE-20978[amv2] Worker terminating UNNATURALLY during MoveRegionProcedureCriticalamv2
HBASE-21078[amv2] CODE-BUG NPE in RTP doing UnassignMajoramv2
HBASE-21113Apply the branch-2 version of HBASE-21095, The timeout retry logic for several procedures are broken after master restartsMajoramv2
HBASE-21101Remove the waitUntilAllRegionsAssigned call after split in TestTruncateTableProcedureMajortest
HBASE-19008Add missing equals or hashCode method(s) to stock Filter implementationsMajor.
HBASE-20614REST scan API with incorrect filter text file throws HTTP 503 Service Unavailable errorMinorREST
HBASE-21041Memstore's heap size will be decreased to minus zero after flushMajor.
HBASE-21031Memory leak if replay edits failed during region openingMajor.
HBASE-20666Unsuccessful table creation leaves entry in hbase:rsgroup tableMinor.
HBASE-21032ScanResponses contain only one cell eachMajorPerformance, Scanners
HBASE-20705Having RPC Quota on a table prevents Space quota to be recreated/removedMajor.
HBASE-21058Nightly tests for branches 1 fail to build ref guideMajordocumentation
HBASE-21074JDK7 branches need to pass “-Dhttps.protocols=TLSv1.2” to maven when buildingMajorbuild, community, test
HBASE-21062WALFactory has misleading notion of “default”Majorwal
HBASE-21047Object creation of StoreFileScanner thru constructor and close may leave refCount to -1Major.
HBASE-21005Maven site configuration causes downstream projects to get a directory named ${project.basedir}Minorbuild
HBASE-21007Memory leak in HBase rest serverCriticalREST
HBASE-20794CreateTable operation does not log its landing at the master nor the initiator at INFO levelMajorlogging
HBASE-20538Upgrade our hadoop versions to 2.7.7 and 3.0.3Criticaljava, security
HBASE-20927RSGroupAdminEndpoint doesn't handle clearing dead servers if they are not processed yet.Major.
HBASE-20932Effective MemStoreSize::hashCode()Major.
HBASE-20928Rewrite calculation of midpoint in binarySearch functions to prevent overflowMinorio
HBASE-20565ColumnRangeFilter combined with ColumnPaginationFilter can produce incorrect result since 1.4MajorFilters
HBASE-20908Infinite loop on regionserver if region replica are reducedMajorread replicas
HBASE-19893restore_snapshot is broken in master branch when region splitsCriticalsnapshots
HBASE-20870Wrong HBase root dir in ITBLL's Search ToolMinorintegration tests
HBASE-20901Reducing region replica has no effectMajor.
HBASE-6028Implement a cancel for in-progress compactionsMinorregionserver
HBASE-20869Endpoint-based Export use incorrect user to write to destinationMajorCoprocessors
HBASE-20879Compacting memstore config should handle lower caseMajor.
HBASE-20865CreateTableProcedure is stuck in retry loop in CREATE_TABLE_WRITE_FS_LAYOUT stateMajoramv2
HBASE-19572RegionMover should use the configured default port number and not the one from HConstantsMajor.
HBASE-20697Can't cache All region locations of the specify table by calling table.getRegionLocator().getAllRegionLocations()Majormeta
HBASE-20791RSGroupBasedLoadBalancer#setClusterMetrics should pass ClusterMetrics to its internalBalancerMajorBalancer, rsgroup
HBASE-20770WAL cleaner logs way too much; gets clogged when lots of work to doCriticallogging

TESTS:

JIRASummaryPriorityComponent
HBASE-21963Add a script for building and verifying release candidateMinorcommunity, scripts
HBASE-21756Backport HBASE-21279 (Split TestAdminShell into several tests) to branch-2Major.
HBASE-20136TestKeyValue misses ClassRule and Category annotationsMinor.
HBASE-21261Add log4j.properties for hbase-rsgroup testsTrivial.
HBASE-21258Add resetting of flags for RS Group pre/post hooks in TestRSGroupsMajor.
HBASE-21097Flush pressure assertion may fail in testFlushThroughputTuningMajorregionserver
HBASE-21138Close HRegion instance at the end of every test in TestHRegionMajor.
HBASE-21161Enable the test added in HBASE-20741 that was removed accidentallyMinor.
HBASE-21076TestTableResource fails with NPEMajorREST, test
HBASE-20907Fix Intermittent failure on TestProcedurePriorityMajor.
HBASE-20838Include hbase-server in precommit test if CommonFSUtils is changedMajor.

SUB-TASKS:

JIRASummaryPriorityComponent
HBASE-21970Document that how to upgrade from 2.0 or 2.1 to 2.2+Major.
HBASE-22357Fix remaining Checkstyle issues in hbase-replicationTrivialReplication
HBASE-22554Upgrade to surefire 2.22.2Majortest
HBASE-22500Modify pom and jenkins jobs for hadoop versionsBlockerbuild, hadoop2, hadoop3
HBASE-22316Record the stack trace for current thread in FutureUtils.getMajorasyncclient, Client
HBASE-22326Fix Checkstyle errors in hbase-examplesMinor.
HBASE-22327Fix remaining Checkstyle issues in hbase-hadoop-compatTrivial.
HBASE-22478Add jackson dependency for hbase-http moduleMajorbuild, dependencies
HBASE-22445Add file info when throw exceptions in HFileReaderImplMajor.
HBASE-22447Check refCount before free block in BucketCacheMajorBucketCache
HBASE-22400Remove the adapter code in async fs implementation for hadoop-2.7.xMajorwal
HBASE-22430hbase-vote should tee build and test output to consoleTrivial.
HBASE-22429hbase-vote download step requires URL to end with ‘/’Trivial.
HBASE-22405Update Ref Guide for EOL of Hadoop 2.7Majorcommunity, documentation
HBASE-22325AsyncRpcRetryingCaller will not schedule retry if we hit a NotServingRegionException but there is no TableName providedMajorasyncclient, Client
HBASE-22322Use special pause for CallQueueTooBigExceptionMajorasyncclient, Client
HBASE-22317Support reading from meta replicasMajorasyncclient, read replicas
HBASE-22261Make use of ClusterStatusListener for async clientMajorasyncclient
HBASE-22267Implement client push back for async clientMajorasyncclient
HBASE-19763Fix Checkstyle errors in hbase-procedureMinor.
HBASE-22244Make use of MetricsConnection in async clientMajorasyncclient, metrics
HBASE-22196Split TestRestartClusterMajortest
HBASE-22117Move hasPermission/checkPermissions from region server to masterMajor.
HBASE-21886Run ITBLL for branch-2.2Major.
HBASE-22155Move 2.2.0 on to hbase-thirdparty-2.2.0Majorthirdparty
HBASE-22153Fix the flaky TestRestartClusterMajortest
HBASE-22152Create a jenkins file for yetus to processing GitHub PRMajorbuild
HBASE-22158RawAsyncHBaseAdmin.getTableSplits should filter out none default replicasMajorAdmin
HBASE-22157Include the cause when constructing RestoreSnapshotException in restoreSnapshotMajorAdmin
HBASE-22141Fix TestAsyncDecommissionAdminApiMajortest
HBASE-22135AsyncAdmin will not refresh master addressMajorAdmin, asyncclient, Client
HBASE-22101AsyncAdmin.isTableAvailable should not throw TableNotFoundExceptionMajorAdmin, asyncclient, Client
HBASE-22094Throw TableNotFoundException if table not exists in AsyncAdmin.compactMajorAdmin
HBASE-21911Move getUserPermissions from regionserver to masterMajor.
HBASE-22015UserPermission should be annotated as InterfaceAudience.PublicBlocker.
HBASE-22066Add markers to CHANGES.md and RELEASENOTES.mdMajor.
HBASE-22040Add mergeRegionsAsync with a List of region names method in AsyncAdminMajorAdmin, asyncclient, Client
HBASE-22039Should add the synchronous parameter for the XXXSwitch method in AsyncAdminMajorAdmin, asyncclient, Client
HBASE-22022nightly fails rat check down in the dev-support/hbase_nightly_source-artifact.sh checkMajor.
HBASE-22025RAT check fails in nightlies; fails on (old) test data files.Major.
HBASE-21977Skip replay WAL and update seqid when open regions restored from snapshotMajorRegion Assignment, snapshots
HBASE-21999[DEBUG] Exit if git returns empty revision!Majorbuild
HBASE-22000Deprecated isTableAvailable with splitKeysMajorasyncclient, Client
HBASE-21949Fix flaky test TestHBaseTestingUtility.testMiniZooKeeperWithMultipleClientPortsMajor.
HBASE-21993Set version as 2.2.0 in branch-2.2 in prep for first RCMajor.
HBASE-21997Fix hbase-rest findbugs ST_WRITE_TO_STATIC_FROM_INSTANCE_METHOD complaintMajorREST
HBASE-21986Generate CHANGES.md and RELEASENOTES.md for 2.2.0Major.
HBASE-21972Copy master doc into branch-2.2 and edit to make it suit 2.2.0Major.
HBASE-15728Add remaining per-table region / store / flush / compaction related metricsMajormetrics
HBASE-21934RemoteProcedureDispatcher should track the ongoing dispatched callsBlockerproc-v2
HBASE-21588Procedure v2 wal splitting implementationMajor.
HBASE-21729Extract ProcedureCoordinatorRpcs and ProcedureMemberRpcs from CoordinatedStateManagerMajor.
HBASE-21094Remove the explicit timeout config for TestTruncateTableProcedureMajortest
HBASE-21093Move TestCreateTableProcedure.testMRegions to a separated fileMajortest
HBASE-18201add UT and docs for DataBlockEncodingToolMinortooling
HBASE-21978Should close AsyncRegistry if we fail to get cluster id when creating AsyncConnectionMajorasyncclient, Client
HBASE-21974Change Admin#grant/revoke parameter from UserPermission to user and PermissionMajor.
HBASE-21976Deal with RetryImmediatelyException for batching requestMajorasyncclient, Client
HBASE-21820Implement CLUSTER quota scopeMajor.
HBASE-21962Filters do not work in ThriftTableMajorThrift
HBASE-21927Always fail the locate request when error occurMajorasyncclient, Client
HBASE-21944Validate put for batch operationMajorasyncclient, Client
HBASE-21945Maintain the original order when sending batch requestMajorasyncclient, Client
HBASE-21783Support exceed user/table/ns throttle quota if region server has available quotaMajor.
HBASE-21930Deal with ScannerResetException when opening region scannerMajorasyncclient, Client
HBASE-21907Should set priority for rpc requestMajorasyncclient, Client
HBASE-21909Validate the put instance before executing in AsyncTable.put methodMajorasyncclient, Client
HBASE-21814Remove the TODO in AccessControlLists#addUserPermissionMajor.
HBASE-19889Revert Workaround: Purge User API building from branch-2 so can make a beta-1Majorwebsite
HBASE-21838Create a special ReplicationEndpoint just for verifying the WAL entries are fineMajorReplication, wal
HBASE-21829Use FutureUtils.addListener instead of calling whenComplete directlyMajorasyncclient, Client
HBASE-21828Make sure we do not return CompletionException when locating regionMajorasyncclient, Client
HBASE-21764Size of in-memory compaction thread pool should be configurableMajorCompaction, in-memory-compaction
HBASE-21809Add retry thrift client for ThriftTable/AdminMajor.
HBASE-21739Move grant/revoke from regionserver to masterMajor.
HBASE-21798Cut branch-2.2Major.
HBASE-20542Better heap utilization for IMC with MSLABsMajorin-memory-compaction
HBASE-21713Support set region server throttle quotaMajor.
HBASE-21761Align the methods in RegionLocator and AsyncTableRegionLocatorMajorasyncclient, Client
HBASE-17370Fix or provide shell scripts to drain and decommission region serverMajor.
HBASE-21750Most of KeyValueUtil#length can be replaced by cell#getSerializedSize for better performance because the latter one has been optimizedMajor.
HBASE-21734Some optimization in FilterListWithORMajor.
HBASE-21738Remove all the CSLM#size operation in our memstore because it's an quite time consuming.CriticalPerformance
HBASE-21034Add new throttle type: read/write capacity unitMajor.
HBASE-21726Add getAllRegionLocations method to AsyncTableRegionLocatorMajorasyncclient, Client
HBASE-19695Handle disabled table for async clientMajorasyncclient, Client
HBASE-21711Remove references to git.apache.org/hbase.gitCritical.
HBASE-21647Add status track for splitting WAL tasksMajorOperability
HBASE-21705Should treat meta table specially for some methods in AsyncAdminMajorAdmin, asyncclient, Client
HBASE-21663Add replica scan supportMajorasyncclient, Client, read replicas
HBASE-21580Support getting Hbck instance from AsyncConnectionMajorasyncclient, Client, hbck2
HBASE-21652Refactor ThriftServer making thrift2 server inherited from thrift1 serverMajor.
HBASE-21661Provide Thrift2 implementation of Table/AdminMajor.
HBASE-21682Support getting from specific replicaMajorread replicas
HBASE-21159Add shell command to switch throttle on or offMajor.
HBASE-21362Disable printing of stack-trace in shell when quotas are violatedMinorshell
HBASE-21361Disable printing of stack-trace in shell when quotas are not enabledMinorshell
HBASE-17356Add replica get supportMajorClient
HBASE-21650Add DDL operation and some other miscellaneous to thrift2MajorThrift
HBASE-21401Sanity check when constructing the KeyValueCriticalregionserver
HBASE-21578Fix wrong throttling exception for capacity unitMajor.
HBASE-21570Add write buffer periodic flush support for AsyncBufferedMutatorMajorasyncclient, Client
HBASE-21465Retry on reportRegionStateTransition can lead to unexpected errorsMajoramv2
HBASE-21508Ignore the reportRegionStateTransition call from a dead serverMajoramv2
HBASE-21490WALProcedure may remove proc wal files still with active proceduresMajorproc-v2
HBASE-21377Add debug log for procedure stack id related operationsMajorproc-v2
HBASE-21472Should not persist the dispatched field for RegionRemoteProcedureBaseMajoramv2
HBASE-21473RowIndexSeekerV1 may return cell with extra two \x00\x00 bytes which has no tagsMajor.
HBASE-21463The checkOnlineRegionsReport can accidentally complete a TRSPCriticalamv2
HBASE-21376Add some verbose log to MasterProcedureSchedulerMajorlogging, proc-v2
HBASE-21443[hbase-connectors] Purge hbase-* modules from core now they've been moved to hbase-connectorsMajorhbase-connectors, spark
HBASE-21421Do not kill RS if reportOnlineRegions failsMajor.
HBASE-21314The implementation of BitSetNode is not efficientMajorproc-v2
HBASE-21351The force update thread may have race with PE worker when the procedure is rolling backCriticalproc-v2
HBASE-21191Add a holding-pattern if no assign for meta or namespace (Can happen if masterprocwals have been cleared).Majoramv2
HBASE-21322Add a scheduleServerCrashProcedure() API to HbckServiceCriticalhbck2
HBASE-21375Revisit the lock and queue implementation in MasterProcedureSchedulerMajorproc-v2
HBASE-20973ArrayIndexOutOfBoundsException when rolling back procedureCriticalamv2
HBASE-21384Procedure with holdlock=false should not be restored lock when restartsBlocker.
HBASE-21364Procedure holds the lock should put to front of the queue after restartBlocker.
HBASE-21215Figure how to invoke hbck2; make it easy to findMajoramv2, hbck2
HBASE-21372Set hbase.assignment.maximum.attempts to Long.MAXMajoramv2
HBASE-21363Rewrite the buildingHoldCleanupTracker method in WALProcedureStoreMajorproc-v2
HBASE-21338[balancer] If balancer is an ill-fit for cluster size, it gives little indicationMajorBalancer, Operability
HBASE-21192Add HOW-TO repair damaged AMv2.Majoramv2
HBASE-21073“Maintenance mode” masterMajoramv2, hbck2, master
HBASE-21354Procedure may be deleted improperly during master restarts resulting in ‘Corrupt’Major.
HBASE-21336Simplify the implementation of WALProcedureMapMajorproc-v2
HBASE-21323Should not skip force updating for a sub procedure even if it has been finishedMajorproc-v2
HBASE-21269Forward-port to branch-2 " HBASE-21213 [hbck2] bypass leaves behind state in RegionStates when assign/unassign"Majoramv2
HBASE-20716Unsafe access cleanupCriticalPerformance
HBASE-21330ReopenTableRegionsProcedure will enter an infinite loop if we schedule a TRSP at the same timeMajoramv2
HBASE-21310Split TestCloneSnapshotFromClientMajortest
HBASE-21311Split TestRestoreSnapshotFromClientMajortest
HBASE-21315The getActiveMinProcId and getActiveMaxProcId of BitSetNode are incorrect if there are no active procedureMajor.
HBASE-21278Do not rollback successful sub procedures when rolling back a procedureCriticalproc-v2
HBASE-21309Increase the waiting timeout for TestProcedurePriorityMajortest
HBASE-21254Need to find a way to limit the number of proc wal filesCriticalproc-v2
HBASE-21250Refactor WALProcedureStore and add more comments for better understanding the implementationMajorproc-v2
HBASE-19275TestSnapshotFileCache never worked properlyMajor.
HBASE-21249Add jitter for ProcedureUtil.getBackoffTimeMsMajorproc-v2
HBASE-21244Skip persistence when retrying for assignment related proceduresMajoramv2, Performance, proc-v2
HBASE-21233Allow the procedure implementation to skip persistence of the state after a executionMajorPerformance, proc-v2
HBASE-21227Implement exponential retrying backoff for Assign/UnassignRegionHandler introduced in HBASE-21217Majoramv2, regionserver
HBASE-21217Revisit the executeProcedure method for open/close regionCriticalamv2, proc-v2
HBASE-21214[hbck2] setTableState just sets hbase:meta state, not in-memory stateMajoramv2, hbck2
HBASE-21023Add bypassProcedureToCompletion() API to HbckServiceMajorhbck2
HBASE-21156[hbck2] Queue an assign of hbase:meta and bulk assign/unassignCriticalhbck2
HBASE-21169Initiate hbck2 tool in hbase-operator-tools repoMajorhbck2
HBASE-21172Reimplement the retry backoff logic for ReopenTableRegionsProcedureMajoramv2, proc-v2
HBASE-21189flaky job should gather machine statsMinortest
HBASE-21190Log files and count of entries in each as we load from the MasterProcWAL storeMajoramv2
HBASE-21083Introduce a mechanism to bypass the execution of a stuck procedureMajoramv2
HBASE-21017Revisit the expected states for open/closeMajoramv2
HBASE-20941Create and implement HbckService in masterMajor.
HBASE-21072Block out HBCK1 in hbase2Majorhbck
HBASE-21095The timeout retry logic for several procedures are broken after master restartsCriticalamv2, proc-v2
HBASE-20975Lock may not be taken or released while rolling back procedureMajoramv2
HBASE-21025Add cache for TableStateManagerMajor.
HBASE-21012Revert the change of serializing TimeRangeTrackerCritical.
HBASE-20813Remove RPC quotas when the associated table/Namespace is dropped offMinor.
HBASE-20885Remove entry for RPC quota from hbase:quota when RPC quota is removed.Minor.
HBASE-20893Data loss if splitting region while ServerCrashProcedure executingMajor.
HBASE-20950Helper method to configure secure DFS cluster for testsMajortest
HBASE-19369HBase Should use Builder Pattern to Create Log Files while using WAL on Erasure CodingMajor.
HBASE-20939There will be race when we call suspendIfNotReady and then throw ProcedureSuspendedExceptionCriticalamv2
HBASE-20921Possible NPE in ReopenTableRegionsProcedureMajoramv2
HBASE-20867RS may get killed while master restartsMajor.
HBASE-20878Data loss if merging regions while ServerCrashProcedure executingCriticalamv2
HBASE-20846Restore procedure locks when master restartsMajor.
HBASE-20914Trim Master memory usageMajorBalancer, master
HBASE-20853Polish “Add defaults to Table Interface so Implementors don't have to”MajorAPI
HBASE-20875MemStoreLABImp::copyIntoCell uses 7% CPU when writingMajorPerformance
HBASE-20860Merged region's RIT state may not be cleaned after master restartMajor.
HBASE-20847The parent procedure of RegionTransitionProcedure may not have the table lockMajorproc-v2, Region Assignment
HBASE-20776Update branch-2 version to 2.2.0-SNAPSHOTMajorbuild

OTHER:

JIRASummaryPriorityComponent
HBASE-21612Add developer debug options in HBase Config for REST serverMinorOperability, REST, scripts
HBASE-18735Provide a fast mechanism for shutting down mini clusterMajor.
HBASE-21489TestShell is brokenMajorshell
HBASE-20152[AMv2] DisableTableProcedure versus ServerCrashProcedureMajoramv2
HBASE-20540[umbrella] Hadoop 3 compatibilityMajor.
HBASE-21536Fix completebulkload usage instructionsTrivialdocumentation, mapreduce
HBASE-22449https everywhere in Maven metadataMinor.
HBASE-22406skip generating rdoc when building gems in our docker image for running yetusCriticalbuild, test
HBASE-22375Promote AccessChecker to LimitedPrivate(Coprocessor)MinorCoprocessors, security
HBASE-21714Deprecated isTableAvailableWithSplit method in thrift moduleMajorThrift
HBASE-22359Backport of HBASE-21371 misses activation-api license informationMinorbuild, community
HBASE-22174Remove error prone from our precommit javac checkMajorbuild
HBASE-22231Remove unused and * importsMinor.
HBASE-22304Fix remaining Checkstyle issues in hbase-endpointTrivial.
HBASE-22020upgrade to yetus 0.9.0Majorbuild, community
HBASE-22187Remove usage of deprecated ClusterConnection.clearRegionCacheTrivialClient
HBASE-22203Reformat DemoClient.javaTrivial.
HBASE-22189Remove usage of StoreFile.getModificationTimeStampTrivial.
HBASE-22108Avoid passing null in Admin methodsMajorAdmin
HBASE-22007Add restoreSnapshot and cloneSnapshot with acl methods in AsyncAdminMajorAdmin, asyncclient, Client
HBASE-22131Delete the patches in hbase-protocol-shaded moduleMajorbuild, Protobufs
HBASE-22099Backport HBASE-21895 “Error prone upgrade” to branch-2Majorbuild
HBASE-22052pom cleaning; filter out jersey-core in hadoop2 to match hadoop3 and remove redunant version specificationsMajor.
HBASE-22065Add listTableDescriptors(List<TableName>) method in AsyncAdminMajorAdmin
HBASE-22042Missing @Override annotation for RawAsyncTableImpl.scanMajorasyncclient, Client
HBASE-21057upgrade to latest spotbugsMinorcommunity, test
HBASE-21888Add a isClosed method to AsyncConnectionMajorasyncclient, Client
HBASE-21884Fix box/unbox findbugs warning in secure bulk loadMinor.
HBASE-21859Add clearRegionLocationCache method for AsyncConnectionMajorasyncclient, Client
HBASE-21853update copyright notices to 2019Majordocumentation
HBASE-21791Upgrade thrift dependency to 0.12.0BlockerThrift
HBASE-21710Add quota related methods to the Admin interfaceMajor.
HBASE-21782LoadIncrementalHFiles should not be IA.PublicMajormapreduce
HBASE-21762Move some methods in ClusterConnection to ConnectionMajorClient
HBASE-21715Do not throw UnsupportedOperationException in ProcedureFuture.getMajorClient
HBASE-21716Add toStringCustomizedValues to TableDescriptorMajor.
HBASE-21731Do not need to use ClusterConnection in IntegrationTestBigLinkedListWithVisibilityMajor.
HBASE-21685Change repository urls to GitboxCritical.
HBASE-21534TestAssignmentManager is flakeyMajortest
HBASE-21541Move MetaTableLocator.verifyRegionLocation to hbase-rsgroup moduleMajor.
HBASE-21265Split up TestRSGroupsMinorrsgroup, test
HBASE-21517Move the getTableRegionForRow method from HMaster to TestMasterMajortest
HBASE-21281Update bouncycastle dependency.Majordependencies, test
HBASE-21198Exclude dependency on net.minidev:json-smartMajor.
HBASE-21282Upgrade to latest jetty 9.2 and 9.3 versionsMajordependencies
HBASE-21287JVMClusterUtil Master initialization wait time not configurableMajortest
HBASE-21168BloomFilterUtil uses hardcoded randomnessTrivial.
HBASE-20482Print a link to the ref guide chapter for the shell during startupMinordocumentation, shell
HBASE-20942Improve RpcServer TRACE loggingMajorOperability
HBASE-20989Minor, miscellaneous logging fixesTriviallogging

Release 2.1.0 - Unreleased (as of 2018-07-10)

INCOMPATIBLE CHANGES:

JIRASummaryPriorityComponent
HBASE-20691Storage policy should allow deferring to HDFSBlockerFilesystem Integration, wal
HBASE-20270Turn off command help that follows all errors in shellMajorshell
HBASE-20501Change the Hadoop minimum version to 2.7.1Blockercommunity, documentation
HBASE-20406HBase Thrift HTTP - Shouldn't handle TRACE/OPTIONS methodsMajorsecurity, Thrift
HBASE-20159Support using separate ZK quorums for clientMajorClient, Operability, Zookeeper
HBASE-20148Make serial replication as a option for a peer instead of a tableMajorReplication

NEW FEATURES:

JIRASummaryPriorityComponent
HBASE-20833Modify pre-upgrade coprocessor validator to support table level coprocessorsMajorCoprocessors
HBASE-15809Basic Replication WebUICriticalReplication, UI
HBASE-19735Create a minimal “client” tarball installationMajorbuild, Client
HBASE-20656Validate pre-2.0 coprocessors against HBase 2.0+Majortooling
HBASE-20592Create a tool to verify tables do not have prefix tree encodingMinorOperability, tooling
HBASE-20046Reconsider the implementation for serial replicationMajorReplication
HBASE-19397Design procedures for ReplicationManager to notify peer change event from masterMajorproc-v2, Replication

IMPROVEMENTS:

JIRASummaryPriorityComponent
HBASE-20806Split style journal for flushes and compactionsMinor.
HBASE-20474Show non-RPC tasks on master/regionserver Web UI by defaultMajorUI
HBASE-20826Truncate responseInfo attributes on RpcServer WARN messagesMajorrpc
HBASE-20450Provide metrics for number of total active, priority and replication rpc handlersMajormetrics
HBASE-20810Include the procedure id in the exception message in HBaseAdmin for better debuggingMajorAdmin, proc-v2
HBASE-20040Master UI should include “Cluster Key” needed to use the cluster as a replication sinkMinorReplication, Usability
HBASE-20095Redesign single instance pool in CleanerChoreCritical.
HBASE-19164Avoid UUID.randomUUID in testsMajortest
HBASE-20739Add priority for SCPMajorRecovery
HBASE-20737put collection into ArrayList instead of addAll functionTrivial.
HBASE-20695Implement table level RegionServer replication metricsMinormetrics
HBASE-20733QABot should run checkstyle tests if the checkstyle configs changeMinorbuild, community
HBASE-20625refactor some WALCellCodec related codeMinorwal
HBASE-19852HBase Thrift 1 server SPNEGO ImprovementsMajorThrift
HBASE-20579Improve snapshot manifest copy in ExportSnapshotMinormapreduce
HBASE-20444Improve version comparison logic for HBase specific version string and add unit testsMajorutil
HBASE-20594provide utility to compare old and new descriptorsMajor.
HBASE-20640TestQuotaGlobalsSettingsBypass missing test category and ClassRuleCriticaltest
HBASE-20478move import checks from hbaseanti to checkstyleMinortest
HBASE-20548Master fails to startup on large clusters, refreshing block distributionMajor.
HBASE-20488PE tool prints full name in help messageMinorshell
HBASE-20567Pass both old and new descriptors to pre/post hooks of modify operations for table and namespaceMajor.
HBASE-20545Improve performance of BaseLoadBalancer.retainAssignmentMajorBalancer
HBASE-16191Add stop_regionserver and stop_master to shellMajor.
HBASE-20536Make TestRegionServerAccounting stable and it should not use absolute numberMinor.
HBASE-20523PE tool should support configuring client side buffering sizesMinor.
HBASE-20527Remove unused code in MetaTableAccessorTrivial.
HBASE-20507Do not need to call recoverLease on the broken file when we fail to create a wal writerMajorwal
HBASE-20484Remove the unnecessary autoboxing in FilterListBaseTrivial.
HBASE-20327When qualifier is not specified, append and incr operation do not work (shell)Minorshell
HBASE-20389Move website building flags into a profileMinorbuild, website
HBASE-20379shadedjars yetus plugin should add a footer linkMajortest
HBASE-20243[Shell] Add shell command to create a new table by cloning the existent tableMinorshell
HBASE-20286Improving shell command compaction_stateMinorshell
HBASE-19488Move to using Apache commons CollectionUtilsTrivial.
HBASE-20197Review of ByteBufferWriterOutputStream.javaMinor.
HBASE-20047AuthenticationTokenIdentifier should provide a toStringMinorUsability
HBASE-19024Configurable default durability for synchronous WALCriticalwal
HBASE-19389Limit concurrency of put with dense (hundreds) columns to prevent write handler exhaustedCriticalPerformance
HBASE-20186Improve RSGroupBasedLoadBalancer#balanceCluster() to be more efficient when calculating cluster state for each rsgroupMinorrsgroup
HBASE-19449Minor logging change in HFileArchiverTrivial.
HBASE-20120Remove some unused classes/ java files from hbase-serverMinor.

BUG FIXES:

JIRASummaryPriorityComponent
HBASE-20854Wrong retries number in RpcRetryingCaller's log messageMinorClient, logging
HBASE-20784Will lose the SNAPSHOT suffix if we get the version of RS from ServerManagerMinormaster, UI
HBASE-20822TestAsyncNonMetaRegionLocator is flakeyMajorasyncclient
HBASE-20808Wrong shutdown order between Chores and ChoreServiceMinor.
HBASE-20789TestBucketCache#testCacheBlockNextBlockMetadataMissing is flakyMajor.
HBASE-20829Remove the addFront assertion in MasterProcedureScheduler.doAddMajorReplication
HBASE-20825Fix pre and post hooks of CloneSnapshot and RestoreSnapshot for Access checksMajorsecurity
HBASE-20812Add defaults to Table Interface so implementors don't have toMajor.
HBASE-20817Infinite loop when executing ReopenTableRegionsProcedureBlockerRegion Assignment
HBASE-20792info:servername and info:sn inconsistent for OPEN regionBlockerRegion Assignment
HBASE-20769getSplits() has a out of bounds problem in TableSnapshotInputFormatImplMajor.
HBASE-20732Shutdown scan pool when master is stopped.Minor.
HBASE-20785NPE getting metrics in PE testing scansMajorPerformance
HBASE-20795Allow option in BBKVComparator.compare to do comparison without sequence idMajor.
HBASE-20777RpcConnection could still remain opened after we shutdown the NettyRpcServerMajorrpc
HBASE-20403Prefetch sometimes doesn't work with encrypted file systemMajor.
HBASE-20635Support to convert the shaded user permission proto to client user permission objectMajor.
HBASE-20778Make it so WALPE runs on DFSMajortest
HBASE-20775TestMultiParallel is flakeyMajorRegion Assignment
HBASE-20752Make sure the regions are truly reopened after ReopenTableRegionsProcedureMajorproc-v2
HBASE-18622Mitigate API compatibility concerns between branch-1 and branch-2BlockerAPI
HBASE-20767Always close hbaseAdmin along with connection in HBTUMajortest
HBASE-20642IntegrationTestDDLMasterFailover throws 'InvalidFamilyOperationExceptionMajor.
HBASE-20742Always create WAL directory for region serverMajorwal
HBASE-20708Remove the usage of RecoverMetaProcedure in master startupBlockerproc-v2, Region Assignment
HBASE-20723Custom hbase.wal.dir results in data loss because we write recovered edits into a different place than where the recovering region server looks for themCriticalRecovery, wal
HBASE-20681IntegrationTestDriver fails after HADOOP-15406 due to missing hamcrest-coreMajorintegration tests
HBASE-20561The way we stop a ReplicationSource may cause the RS downMajorReplication
HBASE-19377Compatibility checker complaining about hash collisionsMajorcommunity
HBASE-20689Docker fails to install rubocop for precommitBlockerbuild
HBASE-20707Move MissingSwitchDefault check from checkstyle to error-proneMajorbuild
HBASE-20699QuotaCache should cancel the QuotaRefresherChore service inside its stop()Major.
HBASE-20590REST Java client is not able to negotiate with the server in the secure modeCriticalREST, security
HBASE-20683Incorrect return value for PreUpgradeValidatorCritical.
HBASE-20684org.apache.hadoop.hbase.client.Scan#setStopRow javadoc uses incorrect methodTrivialClient, documentation
HBASE-20678NPE in ReplicationSourceManager#NodeFailoverWorkerMinor.
HBASE-20670NPE in HMaster#isInMaintenanceModeMinor.
HBASE-20634Reopen region while server crash can cause the procedure to be stuckCritical.
HBASE-12882Log level for org.apache.hadoop.hbase package should be configurableMajor.
HBASE-20668Avoid permission change if ExportSnapshot's copy failsMajor.
HBASE-18116Replication source in-memory accounting should not include bulk transfer hfilesMajorReplication
HBASE-20602hbase.master.quota.observer.ignore property seems to be not taking effectMinordocumentation
HBASE-20664Variable shared across multiple threadsMajor.
HBASE-20659Implement a reopen table regions procedureMajor.
HBASE-20582Bump up JRuby version because of some reported vulnerabilitiesMajordependencies, shell
HBASE-20533Fix the flaky TestAssignmentManagerMetricsMajor.
HBASE-20597Use a lock to serialize access to a shared reference to ZooKeeperWatcher in HBaseReplicationEndpointMinorReplication
HBASE-20633Dropping a table containing a disable violation policy fails to remove the quota upon table deleteMajor.
HBASE-20645Fix security_available method in security.rbMajor.
HBASE-20612TestReplicationKillSlaveRSWithSeparateOldWALs sometimes fail because it uses an expired cluster connMajor.
HBASE-20648HBASE-19364 “Truncate_preserve fails with table when replica region > 1” for master branchMajor.
HBASE-20588Space quota change after quota violation doesn't seem to take in effectMajorregionserver
HBASE-20616TruncateTableProcedure is stuck in retry loop in TRUNCATE_TABLE_CREATE_FS_LAYOUT stateMajoramv2
HBASE-20638nightly source artifact testing should fail the stage if it's going to report an error on jiraMajortest
HBASE-20624Race in ReplicationSource which causes walEntryFilter being null when creating new shipperMajorReplication
HBASE-20601Add multiPut support and other miscellaneous to PEMinortooling
HBASE-20627Relocate RS Group pre/post hooks from RSGroupAdminServer to RSGroupAdminEndpointMajor.
HBASE-20591nightly job doesn't respect maven optionsCriticaltest
HBASE-20560Revisit the TestReplicationDroppedTables utMajor.
HBASE-20571JMXJsonServlet generates invalid JSON if it has NaN in metricsMajorUI
HBASE-20585Need to clear peer map when clearing MasterProcedureSchedulerMajorproc-v2
HBASE-20457Return immediately for a scan rpc call when we want to switch from pread to streamMajorscan
HBASE-20447Only fail cacheBlock if block collisions aren't related to next block metadataMajorBlockCache, BucketCache
HBASE-20544downstream HBaseTestingUtility fails with invalid portBlockertest
HBASE-20004Client is not able to execute REST queries in a secure clusterMinorREST, security
HBASE-20475Fix the flaky TestReplicationDroppedTables unit test.Major.
HBASE-20554“WALs outstanding” message from CleanerChore is noisyTrivial.
HBASE-20204Add locking to RefreshFileConnections in BucketCacheMajorBucketCache
HBASE-20485Copy constructor of Scan doesn't copy the readType and replicaIdMinor.
HBASE-20543Fix the flaky TestThriftHttpServerMajor.
HBASE-20521TableOutputFormat.checkOutputSpecs conf checking sequence cause pig script run failMajormapreduce
HBASE-20500[rsgroup] should keep at least one server in default groupMajorrsgroup
HBASE-20517Fix PerformanceEvaluation ‘column’ parameterMajortest
HBASE-20524Need to clear metrics when ReplicationSourceManager refresh replication sourcesMinor.
HBASE-20476Open sequence number could go backwards in AssignProcedureMajorRegion Assignment
HBASE-20506Add doc and test for unused RetryCounter, useful-looking utilityMinor.
HBASE-20492UnassignProcedure is stuck in retry loop on region stuck in OPENING stateCriticalamv2
HBASE-20497The getRecoveredQueueStartPos always return 0 in RecoveredReplicationSourceShipperMajorReplication
HBASE-18842The hbase shell clone_snaphost command returns bad error messageMinorshell
HBASE-20466Consistently use override mechanism for exempt classes in CoprocessClassloaderMajorCoprocessors
HBASE-20006TestRestoreSnapshotFromClientWithRegionReplicas is flakeyCriticalread replicas
HBASE-18059The scanner order for memstore scanners are wrongCriticalregionserver, scan, Scanners
HBASE-20404Ugly cleanerchore complaint that dir is not emptyMajormaster
HBASE-20419Fix potential NPE in ZKUtil#listChildrenAndWatchForNewChildren callersMajor.
HBASE-20364nightly job gives old results or no results for stages that timeout on SCMCriticaltest
HBASE-20335nightly jobs no longer contain machine informationCriticaltest
HBASE-20338WALProcedureStore#recoverLease() should have fixed sleeps for retrying rollWriter()Major.
HBASE-20356make skipping protoc possibleCriticaldependencies, thirdparty
HBASE-15291FileSystem not closed in secure bulkLoadMajor.
HBASE-20068Hadoopcheck project health check uses default maven repo instead of yetus managed onesMajorcommunity, test
HBASE-20361Non-successive TableInputSplits may wrongly be merged by auto balancing featureMajormapreduce
HBASE-20260Purge old content from the book for branch-2/masterCriticaldocumentation
HBASE-20058improper quoting in presplitting command docsMinordocumentation
HBASE-19923Reset peer state and config when refresh replication source failedMajorReplication
HBASE-19748TestRegionReplicaFailover and TestRegionReplicaReplicationEndpoint UT hangsMajor.

TESTS:

JIRASummaryPriorityComponent
HBASE-20667Rename TestGlobalThrottler to TestReplicationGlobalThrottlerTrivial.
HBASE-20646TestWALProcedureStoreOnHDFS failing on branch-1Trivial.
HBASE-20505PE should support multi column family read and write casesMinor.
HBASE-20513Collect and emit ScanMetrics in PerformanceEvaluationMinortest
HBASE-20414TestLockProcedure#testMultipleLocks may fail on slow machineMajor.

SUB-TASKS:

JIRASummaryPriorityComponent
HBASE-20831Copy master doc into branch-2.1 and edit to make it suit 2.1.0Blockerdocumentation
HBASE-20839Fallback to FSHLog if we can not instantiated AsyncFSWAL when user does not specify AsyncFSWAL explicitlyBlockerwal
HBASE-20244NoSuchMethodException when retrieving private method decryptEncryptedDataEncryptionKey from DFSClientBlockerwal
HBASE-20193Basic Replication Web UI - RegionserverCriticalReplication, Usability
HBASE-20489Update Reference Guide that CLUSTER_KEY value is present on the Master UI info page.Minordocumentation
HBASE-19722Meta query statistics metrics sourceMajor.
HBASE-20781Save recalculating families in a WALEdit batch of CellsMajorPerformance
HBASE-20194Basic Replication WebUI - MasterCriticalReplication, Usability
HBASE-20780ServerRpcConnection logging cleanupMajorlogging, Performance
HBASE-19764Fix Checkstyle errors in hbase-endpointMinor.
HBASE-20710extra cloneFamily() in Mutation.add(Cell)Minorregionserver
HBASE-18569Add prefetch support for async region locatorMajorasyncclient, Client
HBASE-20706[hack] Don't add known not-OPEN regions in reopen phase of MTPCriticalamv2
HBASE-20334add a test that expressly uses both our shaded client and the one from hadoop 3Majorhadoop3, shading
HBASE-20615emphasize use of shaded client jars when they're present in an installMajorbuild, Client, Usability
HBASE-20333break up shaded client into one with no Hadoop and one that's standaloneCriticalshading
HBASE-20332shaded mapreduce module shouldn't include hadoopCriticalmapreduce, shading
HBASE-20722Make RegionServerTracker only depend on children changed eventMajor.
HBASE-20700Move meta region when server crash can cause the procedure to be stuckCriticalmaster, proc-v2, Region Assignment
HBASE-20628SegmentScanner does over-comparing when one flushingCriticalPerformance
HBASE-19761Fix Checkstyle errors in hbase-zookeeperMinor.
HBASE-19724Fix Checkstyle errors in hbase-hadoop2-compatMinor.
HBASE-20518Need to serialize the enabled field for UpdatePeerConfigProcedureMajorReplication
HBASE-20481Replicate entries from same region serially in ReplicationEndpoint for serial replicationMajor.
HBASE-20378Provide a hbck option to cleanup replication barrier for a tableMajor.
HBASE-20128Add new UTs which extends the old replication UTs but set replication scope to SERIALMajor.
HBASE-20417Do not read wal entries when peer is disabledMajorReplication
HBASE-20294Also cleanup last pushed sequence id in ReplicationBarrierCleanerMajorReplication
HBASE-20377Deal with table in enabling and disabling state when modifying serial replication peerMajorReplication
HBASE-20367Write a replication barrier for regions when disabling a tableMajorReplication
HBASE-20296Remove last pushed sequence ids when removing tables from a peerMajorReplication
HBASE-20285Delete all last pushed sequence ids when removing a peer or removing the serial flag for a peerMajorReplication
HBASE-20138Find a way to deal with the conflicts when updating replication positionMajorReplication
HBASE-20127Add UT for serial replication after failoverMajorReplication, test
HBASE-20271ReplicationSourceWALReader.switched should use the file name instead of the path object directlyMajorReplication
HBASE-20227Add UT for ReplicationUtils.contains methodMajorReplication, test
HBASE-20147Serial replication will be stuck if we create a table with serial replication but add it to a peer after there are region movesMajor.
HBASE-20116Optimize the region last pushed sequence id layout on zkMajorReplication
HBASE-20242The open sequence number will grow if we fail to open a region after writing the max sequence id fileMajor.
HBASE-20155update branch-2 version to 2.1.0-SNAPSHOTMajorbuild, community
HBASE-20206WALEntryStream should not switch WAL file silentlyMajorReplication
HBASE-20117Cleanup the unused replication barriers in meta tableMajormaster, Replication
HBASE-20165Shell command to make a normal peer to be a serial replication peerMajor.
HBASE-20167Optimize the implementation of ReplicationSourceWALReaderMajorReplication
HBASE-20125Add UT for serial replication after region split and mergeMajorReplication
HBASE-20129Add UT for serial replication checkerMajorReplication
HBASE-20115Reimplement serial replication based on the new replication storage layerMajorReplication
HBASE-20050Reimplement updateReplicationPositions logic in serial replication based on the newly introduced replication storage layerMajor.
HBASE-20082Fix findbugs errors only on master which are introduced by HBASE-19397Majorfindbugs
HBASE-19936Introduce a new base class for replication peer procedureMajor.
HBASE-19719Fix checkstyle issuesMajorproc-v2, Replication
HBASE-19711TestReplicationAdmin.testConcurrentPeerOperations hangsMajorproc-v2
HBASE-19707Race in start and terminate of a replication source after we async start replicatione endpointMajorproc-v2, Replication
HBASE-19636All rs should already start work with the new peer change when replication peer procedure is finishedMajorproc-v2, Replication
HBASE-19634Add permission check for executeProcedures in AccessControllerMajorproc-v2, Replication
HBASE-19697Remove TestReplicationAdminUsingProcedureMajorproc-v2, Replication
HBASE-19661Replace ReplicationStateZKBase with ZKReplicationStorageBaseMajorproc-v2, Replication
HBASE-19687Move the logic in ReplicationZKNodeCleaner to ReplicationChecker and remove ReplicationZKNodeCleanerChoreMajorproc-v2, Replication
HBASE-19544Add UTs for testing concurrent modifications on replication peerMajorproc-v2, Replication, test
HBASE-19686Use KeyLocker instead of ReentrantLock in PeerProcedureHandlerImplMajorproc-v2, Replication
HBASE-19623Create replication endpoint asynchronously when adding a replication sourceMajorproc-v2, Replication
HBASE-19633Clean up the replication queues in the postPeerModification stage when removing a peerMajorproc-v2, Replication
HBASE-19622Reimplement ReplicationPeers with the new replication storage interfaceMajorproc-v2, Replication
HBASE-19635Introduce a thread at RS side to call reportProcedureDoneMajorproc-v2
HBASE-19617Remove ReplicationQueues, use ReplicationQueueStorage directlyMajorReplication
HBASE-19642Fix locking for peer modification procedureCriticalproc-v2, Replication
HBASE-19592Add UTs to test retry on update zk failureMajorproc-v2, Replication
HBASE-19630Add peer cluster key check when add new replication peerMajorproc-v2, Replication
HBASE-19573Rewrite ReplicationPeer with the new replication storage interfaceMajorproc-v2, Replication
HBASE-19579Add peer lock test for shell command list_locksMajorproc-v2, Replication
HBASE-19599Remove ReplicationQueuesClient, use ReplicationQueueStorage directlyMajorReplication
HBASE-19543Abstract a replication storage interface to extract the zk specific codeMajorproc-v2, Replication
HBASE-19525RS side changes for moving peer modification from zk watcher to procedureMajorproc-v2, Replication
HBASE-19580Use slf4j instead of commons-logging in new, just-added Peer Procedure classesMajorproc-v2, Replication
HBASE-19520Add UTs for the new lock type PEERMajorproc-v2
HBASE-19564Procedure id is missing in the response of peer related operationsMajorproc-v2, Replication
HBASE-19536Client side changes for moving peer modification from zk watcher to procedureMajorReplication
HBASE-19524Master side changes for moving peer modification from zk watcher to procedureMajorproc-v2, Replication
HBASE-19216Implement a general framework to execute remote procedure on RSMajorproc-v2, Replication

OTHER:

JIRASummaryPriorityComponent
HBASE-19997[rolling upgrade] 1.x => 2.xBlocker.
HBASE-20360Further optimization for serial replicationMajorReplication
HBASE-20862Address 2.1.0 Compatibility Report IssuesBlockercompatibility
HBASE-20665“Already cached block XXX” message should be DEBUGMinorBlockCache
HBASE-20677Backport test of HBASE-20566 ‘Creating a system table after enabling rsgroup feature puts region into RIT’ to branch-2Major.
HBASE-19475Extend backporting strategy in documentationTrivialdocumentation
HBASE-20595Remove the concept of ‘special tables’ from rsgroupsMajorRegion Assignment, rsgroup
HBASE-20415branches-2 don't need maven-scala-pluginMajorbuild
HBASE-20112Include test results from nightly hadoop3 tests in jenkins test resultsCriticaltest
HBASE-17918document serial replicationCriticaldocumentation, Replication
HBASE-19737Manage a HBASE-19397-branch-2 branch and merge it to branch-2Majorproc-v2, Replication

Release 2.0.0 - Unreleased (as of 2018-04-22)

INCOMPATIBLE CHANGES:

JIRASummaryPriorityComponent
HBASE-20276[shell] Revert shell REPL change and documentBlockerdocumentation, shell
HBASE-16459Remove unused hbase shell --format optionTrivialshell
HBASE-19128Purge Distributed Log Replay from codebase, configurations, text; mark the feature as unsupported, broken.Majordocumentation
HBASE-19504Add TimeRange support into checkAndMutateMajor.
HBASE-20119Introduce a pojo class to carry coprocessor information in order to make TableDescriptorBuilder accept multiple cp at onceMinor.
HBASE-19437Batch operation can't handle the null result for Append/IncrementCriticalUsability
HBASE-19873Add a CategoryBasedTimeout ClassRule for all UTsMajor.
HBASE-19783Change replication peer cluster key/endpoint from a not-null value to null is not allowedMinorReplication
HBASE-19483Add proper privilege check for rsgroup commandsMajorrsgroup, security
HBASE-19492Add EXCLUDE_NAMESPACE and EXCLUDE_TABLECFS support to replication peer configMajor.
HBASE-19357Bucket cache no longer L2 for LRU cacheMajor.
HBASE-19359Revisit the default config of hbase client retries numberMajor.
HBASE-19092Make Tag IA.LimitedPrivate and expose for CPsCriticalCoprocessors
HBASE-19187Remove option to create on heap bucket cacheMinorregionserver
HBASE-19033Allow CP users to change versions and TTL before opening StoreScannerBlockerCoprocessors
HBASE-19047CP exposed Scanner types should not extend ShipperCriticalCoprocessors
HBASE-18905Allow CPs to request flush on Region and know the completion of the requested flushMajorCoprocessors
HBASE-18410FilterList Improvement.MajorFilters
HBASE-18893Remove Add/Modify/DeleteColumnFamilyProcedure in favor of using ModifyTableProcedureMajorCoprocessors, master
HBASE-19067Do not expose getHDFSBlockDistribution in StoreFileMajorCoprocessors
HBASE-18989Polish the compaction related CP hooksMajorCompaction, Coprocessors
HBASE-19046RegionObserver#postCompactSelection Avoid passing shaded ImmutableList paramMajorCoprocessors
HBASE-19001Remove the hooks in RegionObserver which are designed to construct a StoreScanner which is marked as IA.PrivateMajorCoprocessors
HBASE-14247Separate the old WALs into different regionserver directoriesCriticalwal
HBASE-18183Region interface cleanup for CP exposeMajorCoprocessors
HBASE-18878Use Optional<T> return types when T can be nullMajorCoprocessors
HBASE-18649Deprecate KV Usage in MR to move to Cells in 3.0MajorAPI, mapreduce
HBASE-18897Substitute MemStore for MemstoreMajor.
HBASE-18883Upgrade to Curator 4.0MajorClient, dependencies
HBASE-18839Apply RegionInfo to code baseMajorCoprocessors
HBASE-18826Use HStore instead of Store in our own code base and remove unnecessary methods in Store interfaceMajorCoprocessors
HBASE-17732Coprocessor Design ImprovementsCriticalCoprocessors
HBASE-18298RegionServerServices Interface cleanup for CP exposeCriticalCoprocessors
HBASE-16769Deprecate/remove PB references from MasterObserver and RegionServerObserverBlocker.
HBASE-18859Purge PB from BulkLoadObserverMajorCoprocessors
HBASE-18731[compat 1-2] Mark protected methods of QuotaSettings that touch Protobuf internals as IA.PrivateMajorAPI
HBASE-18825Use HStoreFile instead of StoreFile in our own code base and remove unnecessary methods in StoreFile interfaceMajorCoprocessors
HBASE-18142Deletion of a cell deletes the previous versions tooMajorAPI, shell
HBASE-18446Mark StoreFileScanner/StoreFileReader as IA.LimitedPrivate(Phoenix)CriticalCoprocessors
HBASE-18798Remove the unused methods in RegionServerObserverMajorCoprocessors
HBASE-18453CompactionRequest should not be exposed to user directlyMajorCoprocessors
HBASE-18794Remove deprecated methods in MasterObserverMajorCoprocessors
HBASE-17823Migrate to Apache Yetus Audience AnnotationsMajorAPI
HBASE-18793Remove deprecated methods in RegionObserverMajorCoprocessors
HBASE-18733[compat 1-2] Hide WALKeyMajorAPI
HBASE-16479Move WALEdit from hbase.regionserver.wal package to hbase.wal packageMajorwal
HBASE-18783Declare the builder of ClusterStatus as IA.Private, and remove the Writables from ClusterStatusMinor.
HBASE-18106Redo ProcedureInfo and LockInfoCriticalproc-v2
HBASE-18780Remove HLogPrettyPrinter and hlog commandMinordocumentation, wal
HBASE-18704Upgrade hbase to commons-collections 4Majordependencies
HBASE-15607Remove PB references from Admin for 2.0Blocker.
HBASE-18736Cleanup the HTD/HCD for AdminMajor.
HBASE-18577shaded client includes several non-relocated third party dependenciesCriticalClient
HBASE-3935HServerLoad.storefileIndexSizeMB should be changed to storefileIndexSizeKBMajor.
HBASE-15982Interface ReplicationEndpoint extends Guava's ServiceBlocker.
HBASE-18546Always overwrite the TS for Append/Increment unless no existing cells are foundCriticalAPI, Client
HBASE-17442Move most of the replication related classes from hbase-client to hbase-replication packageCriticalbuild, Replication
HBASE-18511Default no regions on masterBlockermaster
HBASE-18528DON'T allow user to modify the passed table/column descriptorCriticalCoprocessors, master
HBASE-18469Correct RegionServer metric of totalRequestCountCriticalmetrics, regionserver
HBASE-18500Performance issue: Don‘t use BufferedMutator for HTable’s put methodMajor.
HBASE-17125Inconsistent result when use filter to read dataCritical.
HBASE-18517limit max log message width in log4jMajor.
HBASE-18502Change MasterObserver to use TableDescriptor and ColumnFamilyDescriptorCriticalCoprocessors, master
HBASE-18374RegionServer Metrics improvementsMajor.
HBASE-17908Upgrade guavaCriticaldependencies
HBASE-18161Incremental Load support for Multiple-Table HFileOutputFormatMinor.
HBASE-18267The result from the postAppend is ignoredMajorCoprocessors
HBASE-18241Change client.Table, client.Admin, Region, Store, and HBaseTestingUtility to not use HTableDescriptor or HColumnDescriptorCriticalClient
HBASE-18038Rename StoreFile to HStoreFile and add a StoreFile interface for CPCriticalCoprocessors, regionserver
HBASE-16196Update jruby to a newer version.Criticaldependencies, shell
HBASE-14614Procedure v2: Core Assignment ManagerMajorproc-v2
HBASE-3462Fix table.jsp in regards to splitting a region/table with an optional splitkeyMajormaster
HBASE-11013Clone Snapshots on Secure Cluster Should provide option to apply Retained User PermissionsMajorsnapshots
HBASE-15296Break out writer and reader from StoreFileMajorregionserver
HBASE-15199Move jruby jar so only on hbase-shell module classpath; currently globally availableCriticaldependencies, jruby, shell
HBASE-18009Move RpcServer.Call to a separated fileMajorIPC/RPC
HBASE-17956Raw scan should ignore TTLMajorscan
HBASE-17914Create a new reader instead of cloning a new StoreFile when compactionMajorCompaction, regionserver
HBASE-17595Add partial result support for small/limited scanCriticalasyncclient, Client, scan
HBASE-17584Expose ScanMetrics with ResultScanner rather than ScanMajorClient, mapreduce, scan
HBASE-17716Formalize Scan Metric namesMinormetrics
HBASE-17312[JDK8] Use default method for Observer CoprocessorsMajorCoprocessors
HBASE-17647OffheapKeyValue#heapSize() implementation is wrongMajorregionserver
HBASE-17472Correct the semantic of permission grantMajorAdmin
HBASE-17599Use mayHaveMoreCellsInRow instead of isPartialMajorClient, scan
HBASE-17508Unify the implementation of small scan and regular scan for sync clientMajorClient, scan
HBASE-12894Upgrade Jetty to 9.2.6CriticalREST, UI
HBASE-16786Procedure V2 - Move ZK-lock's uses to Procedure framework locks (LockProcedure)Major.
HBASE-17470Remove merge region code from region serverMajorregionserver
HBASE-5401PerformanceEvaluation generates 10x the number of expected mappersMajortest
HBASE-17221Abstract out an interface for RpcServer.CallMajor.
HBASE-16119Procedure v2 - Reimplement mergeMajorproc-v2, Region Assignment
HBASE-17132Cleanup deprecated code for WALMajorwal
HBASE-17017Remove the current per-region latency histogram metricsMajormetrics
HBASE-15513hbase.hregion.memstore.chunkpool.maxsize is 0.0 by defaultMajor.
HBASE-16972Log more details for Scan#next request when responseTooSlowMajorOperability
HBASE-16765New SteppingRegionSplitPolicy, avoid too aggressive spread of regions for small tables.Critical.
HBASE-16747Track memstore data size and heap overhead separatelyMajorregionserver
HBASE-14551Procedure v2 - Reimplement splitMinorproc-v2
HBASE-16729Define the behavior of (default) empty FilterListTrivial.
HBASE-16799CP exposed Store should not expose unwanted APIsMajor.
HBASE-16117Fix Connection leak in mapred.TableOutputFormatMajormapreduce
HBASE-15638Shade protobufCriticalProtobufs
HBASE-16257Move staging dir to be under hbase root dirBlocker.
HBASE-16650Wrong usage of BlockCache eviction stat for heap memory tuningMajor.
HBASE-16598Enable zookeeper useMulti always and clean up in HBase codeMajor.
HBASE-15297error message is wrong when a wrong namspace is specified in grant in hbase shellMinorshell
HBASE-16340ensure no Xerces jars includedCriticaldependencies
HBASE-16321Ensure findbugs jsr305 jar isn't presentBlockerdependencies
HBASE-16355hbase-client dependency on hbase-common test-jar should be test scopeMajorClient, dependencies
HBASE-16186Fix AssignmentManager MBean nameMajormaster
HBASE-13823Procedure V2: unnecessaery operations on AssignmentManager#recoverTableInDisablingState() and recoverTableInEnablingState()Majormaster, proc-v2
HBASE-15950Fix memstore size estimates to be more tighterMajor.
HBASE-15971Regression: Random Read/WorkloadC slower in 1.x than 0.98Criticalrpc
HBASE-15875Remove HTable references and HTableInterfaceMajor.
HBASE-15610Remove deprecated HConnection for 2.0 thus removing all PB references for 2.0Blocker.
HBASE-15876Remove doBulkLoad(Path hfofDir, final HTable table) though it has not been through a full deprecation cycleBlocker.
HBASE-15575Rename table DDL *Handler methods in MasterObserver to more meaningful namesMinorCoprocessors
HBASE-15481Add pre/post roll to WALObserverTrivial.
HBASE-15568Procedure V2 - Remove CreateTableHandler in HBase Apache 2.0 releaseMajormaster, proc-v2
HBASE-15521Procedure V2 - RestoreSnapshot and CloneSnapshotMajorClient, master, proc-v2
HBASE-11393Replication TableCfs should be a PB object rather than a stringMajorReplication
HBASE-15265Implement an asynchronous FSHLogMajorwal
HBASE-15323Hbase Rest CheckAndDeleteAPi should be able to delete more cellsMajorhbase
HBASE-15377Per-RS Get metric is time based, per-region metric is size-basedMajor.
HBASE-13963avoid leaking jdk.toolsCriticalbuild, documentation
HBASE-15376ScanNext metric is size-based while every other per-operation metric is time basedMajor.
HBASE-15290Hbase Rest CheckAndAPI should save other cells along with compared cellMajorhbase
HBASE-15100Master WALProcs still never clean upBlockermaster, proc-v2
HBASE-15111“hbase version” should write to stdoutTrivialutil
HBASE-14888ClusterSchema: Add Namespace OperationsMajorAPI
HBASE-15018Inconsistent way of handling TimeoutException in the rpc client implementationsMajorClient, IPC/RPC
HBASE-14205RegionCoprocessorHost System.nanoTime() performance bottleneckCriticalCoprocessors, Performance, regionserver
HBASE-12751Allow RowLock to be reader writerMajorregionserver
HBASE-13706CoprocessorClassLoader should not exempt Hive classesMinorCoprocessors
HBASE-13954Remove HTableInterface#getRowOrBefore related server side codeMajorAPI
HBASE-12296Filters should work with ByteBufferedCellMajorregionserver, Scanners
HBASE-14027Clean up netty dependenciesMajorbuild
HBASE-7782HBaseTestingUtility.truncateTable() not acting like CLIMinortest
HBASE-14047Cleanup deprecated APIs from Cell classMajorClient
HBASE-13849Remove restore and clone snapshot from the WebUIMajorsnapshots
HBASE-13646HRegion#execService should not try to build incomplete messagesMajorCoprocessors, regionserver
HBASE-13983Doc how the oddball HTable methods getStartKey, getEndKey, etc. will be removed in 2.0.0Minordocumentation
HBASE-13214Remove deprecated and unused methods from HTable classMajorAPI
HBASE-13843Fix internal constant text in ReplicationManager.javaTrivialmaster
HBASE-13375Provide HBase superuser higher priority over other users in the RPC handlingMajorIPC/RPC
HBASE-13636Remove deprecation for HBASE-4072 (Reading of zoo.cfg)Major.
HBASE-10800Use CellComparator instead of KVComparatorMajor.
HBASE-13118[PE] Add being able to write many columnsMajortest
HBASE-12990MetaScanner should be replaced by MetaTableAccessorMajorClient
HBASE-13373Squash HFileReaderV3 together with HFileReaderV2 and AbstractHFileReader; ditto for Scanners and BlockReader, etc.Major.
HBASE-10728get_counter value is never used.Major.
HBASE-13298Clarify if Table.{set|get}WriteBufferSize() is deprecated or notCriticalAPI
HBASE-13248Make HConnectionImplementation top-level class.MajorAPI
HBASE-13198Remove HConnectionManagerMajorAPI
HBASE-12586Task 6 & 7 from HBASE-9117, delete all public HTable constructors and delete ConnectionManager#{delete,get}ConnectionMajor.
HBASE-13171Change AccessControlClient methods to accept connection object to reduce setup time.Minor.
HBASE-6778Deprecate Chore; its a thread per task when we should have one thread to do all tasksMajor.
HBASE-12684Add new AsyncRpcClientMajorClient
HBASE-10378Divide HLog interface into User and Implementor specific interfacesMajorwal
HBASE-12111Remove deprecated APIs from Mutation(s)MajorClient
HBASE-12084Remove deprecated APIs from ResultMajorClient
HBASE-12048Remove deprecated APIs from FilterMajorregionserver
HBASE-11556Move HTablePool to hbase-thrift module.MajorThrift
HBASE-4072Deprecate/disable and remove support for reading ZooKeeper zoo.cfg files from the classpathMajor.

IMPORTANT ISSUES:

JIRASummaryPriorityComponent
HBASE-15780Expose AuthUtil as IA.PublicCriticalAPI, security
HBASE-15322Operations using Unsafe path broken for platforms not having sun.misc.UnsafeCriticalhbase
HBASE-15125HBaseFsck's adoptHdfsOrphan function creates region with wrong end key boundaryMajorhbck

NEW FEATURES:

JIRASummaryPriorityComponent
HBASE-19950Introduce a ColumnValueFilterMinorFilters
HBASE-19844Shell should support flush by regionserverMinorshell
HBASE-19886Display maintenance mode in shell, web UIMajor.
HBASE-19528Major Compaction ToolMajor.
HBASE-19897RowMutations should follow the fluent patternMinor.
HBASE-4224Need a flush by regionserver rather than by table optionMajor.
HBASE-15321Ability to open a HRegion from hdfs snapshot.Major.
HBASE-19799Add web UI to rsgroupMajorrsgroup, UI
HBASE-19326Remove decommissioned servers from rsgroupMajorrsgroup
HBASE-19189Ad-hoc test job for running a subset of tests lots of timesMajorbuild
HBASE-19103Add BigDecimalComparator for filterMinorClient
HBASE-18171Scanning cursor for async clientMajor.
HBASE-18875Thrift server supports read-only modeMajorThrift
HBASE-14417Incremental backup and bulk loadingBlocker.
HBASE-18131Add an hbase shell command to clear deadserver list in ServerManagerMajorOperability
HBASE-15806An endpoint-based export toolCriticalCoprocessors, tooling
HBASE-14135HBase Backup/Restore Phase 3: Merge backup imagesCritical.
HBASE-15134Add visibility into Flush and Compaction queuesMajorCompaction, metrics, regionserver
HBASE-15968New behavior of versions considering mvcc and ts rather than ts onlyMajor.
HBASE-15943Add page displaying JVM process metricsMajorOperability, UI
HBASE-17928Shell tool to clear compaction queuesMajorCompaction, Operability
HBASE-18226Disable reverse DNS lookup at HMaster and use the hostname provided by RegionServerMajor.
HBASE-13784Add Async Client Table APIMajor.
HBASE-17849PE tool random read is not totally randomMajorPerformance, test
HBASE-15576Scanning cursor to prevent blocking long time on ResultScanner.next()Major.
HBASE-16961FileSystem QuotasMajor.
HBASE-17757Unify blocksize after encoding to decrease memory fragmentMajor.
HBASE-17542Move backup system table into separate namespaceMajor.
HBASE-14141HBase Backup/Restore Phase 3: Filter WALs on backup to include only edits from backed up tablesBlocker.
HBASE-17758[RSGROUP] Add shell command to move servers and tables at the same timeMajorrsgroup
HBASE-17737Thrift2 proxy should support scan timeRange per column familyMajorThrift
HBASE-16981Expand Mob Compaction Partition policy from daily to weekly, monthlyMajormob
HBASE-9774HBase native metrics and metric collection for coprocessorsMajorCoprocessors, metrics
HBASE-17174Refactor the AsyncProcess, BufferedMutatorImpl, and HTableMinor.
HBASE-15432TableInputFormat - support multi column family scanMajor.
HBASE-17181Let HBase thrift2 support TThreadedSelectorServerMinorThrift
HBASE-17151New API to create HFile.Reader without instantiating block cacheMajor.
HBASE-16463Improve transparent table/CF encryption with Commons CryptoMajorencryption
HBASE-16751Add tuning information to HBase BookMinor.
HBASE-16677Add table size (total store file size) to table pageMinorwebsite
HBASE-16447Replication by namespaces config in peerCriticalReplication
HBASE-16388Prevent client threads being blocked by only one slow region serverMajor.
HBASE-16213A new HFileBlock structure for fast random getMajorPerformance
HBASE-12721Create Docker container cluster infrastructure to enable better testingMajorbuild, community, documentation, test
HBASE-3727MultiHFileOutputFormatMinor.
HBASE-15881Allow BZIP2 compressionMajorHFile
HBASE-10358Shell changes for setting consistency per requestMajorshell
HBASE-15892submit-patch.py: Single command line to make patch, upload it to jira, and update review boardTrivial.
HBASE-15228Add the methods to RegionObserver to trigger start/complete restoring WALsMajorCoprocessors
HBASE-15847VerifyReplication prefix filteringMajorReplication
HBASE-15798Add Async RpcChannels to all RpcClientsMajor.
HBASE-15281Allow the FileSystem inside HFileSystem to be wrappedMajorFilesystem Integration, hbase
HBASE-15592Print Procedure WAL contentMajor.
HBASE-6721RegionServer Group based AssignmentMajorregionserver
HBASE-15136Explore different queuing behaviors while busyCriticalIPC/RPC
HBASE-15181A simple implementation of date based tiered compactionMajorCompaction
HBASE-13259mmap() based BucketCache IOEngineCriticalBlockCache
HBASE-15135Add metrics for storefile ageMajor.
HBASE-14355Scan different TimeRange for each column familyMajorClient, regionserver, Scanners
HBASE-11262Avoid empty columns while doing bulk-loadMajor.
HBASE-15036Update HBase Spark documentation to include bulk load with thin recordsMajor.
HBASE-14980Project AstroMajordocumentation
HBASE-13153Bulk Loaded HFile ReplicationMajorReplication
HBASE-12911Client-side metricsMajorClient, Operability, Performance
HBASE-14529Respond to SIGHUP to reload configMajorOperability
HBASE-14459Add request and response sizes metricsMajormetrics
HBASE-14456Implement a namespace-based region grouping strategy for RegionGroupingProviderMajor.
HBASE-14154DFS Replication should be configurable at column family levelMinor.
HBASE-13702ImportTsv: Add dry-run functionality and log bad rowsMajor.
HBASE-13639SyncTable - rsync for HBase tablesMajormapreduce, Operability, tooling
HBASE-10070HBase read high-availability using timeline-consistent region replicasMajorAdmin, API, LatencyResilience
HBASE-13356HBase should provide an InputFormat supporting multiple scans in mapreduce jobs over snapshotsMinormapreduce
HBASE-5980Scanner responses from RS should include metrics on rows/KVs filteredMinorClient, metrics, Operability, regionserver
HBASE-13698Add RegionLocator methods to Thrift2 proxy.MajorThrift
HBASE-13071Hbase Streaming Scan FeatureMajor.
HBASE-13090Progress heartbeats for long running scannersMajor.
HBASE-13412Region split decisions should have jitterMajorregionserver
HBASE-12972Region, a supportable public/evolving subset of HRegionMajor.
HBASE-13170Allow block cache to be externalMajorio
HBASE-5238Add a log4j category for all edits to META/ROOTMinorregionserver
HBASE-13063Allow to turn off memstore replication for region replicasMinorregionserver, Replication
HBASE-13057Provide client utility to easily enable and disable table replicationMajorReplication
HBASE-12869Add a REST API implementation of the ClusterManager interfaceMajorintegration tests
HBASE-12944Support patches to branches in precommit jenkins buildMajor.
HBASE-12268Add support for Scan.setRowPrefixFilter to shellMajorshell
HBASE-5162Basic client pushback mechanismMajor.

IMPROVEMENTS:

JIRASummaryPriorityComponent
HBASE-19994Create a new class for RPC throttling exception, make it retryable.Major.
HBASE-20409Set hbase.client.meta.operation.timeout in TestClientOperationTimeoutTrivialtest
HBASE-17449Add explicit document on different timeout settingsCriticaldocumentation
HBASE-18784Use of filesystem that requires hflush / hsync / append / etc should query outputstream capabilitiesMajorFilesystem Integration
HBASE-15466precommit should not run all java goals when given a docs-only patchMajorbuild
HBASE-20135NullPointerException during reading bloom filter when upgraded from hbase-1 to hbase-2Minor.
HBASE-17165Add retry to LoadIncrementalHFiles toolCriticalhbase, HFile, tooling
HBASE-18467nightly job needs to run all stages and then comment on jiraCriticalcommunity, test
HBASE-17448Export metrics from RecoverableZooKeeperMajorZookeeper
HBASE-20055Remove declaration of un-thrown exceptions and unused setRegionStateBackToOpen() from MergeTableRegionsProcedureMinoramv2
HBASE-18020Update API Compliance Checker to Incorporate Improvements Done in HadoopMajorAPI, community
HBASE-20065Revisit the timestamp usage in MetaTableAccessorMajor.
HBASE-18294Reduce global heap pressure: flush based on heap occupancyMajor.
HBASE-19680BufferedMutatorImpl#mutate should wait the result from AP in order to throw the failed mutationsMajor.
HBASE-19988HRegion#lockRowsAndBuildMiniBatch() is too chatty when interrupted while waiting for a row lockMinoramv2
HBASE-19915From split/ merge procedures daughter/ merged regions get created in OFFLINE stateMajor.
HBASE-19917Improve RSGroupBasedLoadBalancer#filterServers() to be more efficientMinorrsgroup
HBASE-19904Break dependency of WAL constructor on ReplicationMajorReplication, wal
HBASE-19912The flag “writeToWAL” of Region#checkAndRowMutate is uselessMinor.
HBASE-19861Avoid using RPCs when querying table infos for master status pagesMajorUI
HBASE-19770Add ‘--return-values’ option to Shell to print return values of commands in interactive modeCriticalshell
HBASE-19823Make RawCellBuilderFactory LimitedPrivate.UNITTESTMinor.
HBASE-19820Restore public constructor of MiniHBaseCluster (API compat)Major.
HBASE-19736Remove BaseLogCleanerDelegate deprecated #isLogDeletable(FileStatus) and use #isFileDeletable(FileStatus) insteadMinor.
HBASE-19739Include thrift IDL files in HBase binary distributionMinorThrift
HBASE-19789Not exclude flaky tests from nightly buildsMajor.
HBASE-19758Split TestHCM to several smaller testsMajortest
HBASE-19751Use RegionInfo directly instead of an identifier and a namespace when getting WALMajorwal
HBASE-19139Create Async Admin methods for Clear Block CacheMajorAdmin
HBASE-19702Improve RSGroupInfo constructorsMinor.
HBASE-19684BlockCacheKey toString PerformanceTrivialhbase
HBASE-19358Improve the stability of splitting log when do fail overMajorMTTR
HBASE-19723hbase-thrift declares slf4j-api twiceTrivialThrift
HBASE-19651Remove LimitInputStreamMinorhbase
HBASE-19473Miscellaneous changes to ClientScannerTrivialhbase
HBASE-19613Miscellaneous changes to WALSplitterTrivialhbase
HBASE-18806VerifyRep by snapshot need not to restore snapshot for each mapperMajorReplication
HBASE-18011Refactor RpcServerMajorIPC/RPC
HBASE-19641AsyncHBaseAdmin should use exponential backoff when polling the procedure resultMajorasyncclient, proc-v2
HBASE-19675Miscellaneous HStore Class ImprovementsMinorhbase
HBASE-19683Remove Superfluous Methods From String ClassTrivialhbase
HBASE-19676CleanerChore logging improvementsTrivialhbase
HBASE-19486Periodically ensure records are not buffered too long by BufferedMutatorMajorClient
HBASE-19679Superusers Logging and Data StructuresTrivialhbase
HBASE-19677Miscellaneous HFileCleaner ImprovementsTrivialhbase
HBASE-19649Use singleton feature for ImmutableSegmentTrivial.
HBASE-8518Get rid of hbase.hstore.compaction.complete settingMinor.
HBASE-19659Enable -x in make_rc.sh so logs where it is in executionTrivialbuild
HBASE-19647Logging cleanups; emit regionname when RegionTooBusyException inside RetriesExhausted... make netty connect/disconnect TRACE-levelMajor.
HBASE-19545Replace getBytes(StandardCharsets.UTF_8) with Bytes.toBytesMinor.
HBASE-19615CompositeImmutableSegment ArrayList Instead of LinkedListTrivialhbase
HBASE-19621Revisit the methods in ReplicationPeerConfigBuilderMinor.
HBASE-19618Remove replicationQueuesClient.class/replicationQueues.class config and remove table based ReplicationQueuesClient/ReplicationQueues implementationMajor.
HBASE-19576Introduce builder for ReplicationPeerConfig and make it immutableMajor.
HBASE-19590Remove the duplicate code in deprecated ReplicationAdminMinor.
HBASE-19570Add hadoop3 tests to Nightly master/branch-2 runsCritical.
HBASE-19571Minor refactor of Nightly run scriptsMinor.
HBASE-19491Exclude flaky tests from nightly master runMajor.
HBASE-15482Provide an option to skip calculating block locations for SnapshotInputFormatMinormapreduce
HBASE-19531Remove needless volatile declarationTrivial.
HBASE-19521HBase mob compaction need to check hfile versionCriticalCompaction, mob
HBASE-14790Implement a new DFSOutputStream for logging WAL onlyMajorwal
HBASE-19472Remove ArrayUtil ClassMajorhbase
HBASE-19489Check against only the latest maintenance release in pre-commit hadoopcheck.Minor.
HBASE-17425Fix calls to deprecated APIs in TestUpdateConfigurationTrivialClient
HBASE-19464Replace StringBuffer with StringBuilder for hbase-commonTrivialhbase
HBASE-19463Make CPEnv#getConnection return a facade that throws Unsupported if CP calls #closeMajorCoprocessors
HBASE-19180Remove unused imports from AlwaysPassesTrivialbuild
HBASE-18169Coprocessor fix and cleanup before 2.0.0 releaseBlockerCoprocessors
HBASE-19448Replace StringBuffer with StringBuilder for hbase-serverTrivialhbase
HBASE-19432Roll the specified writer in HFileOutputFormat2Major.
HBASE-19290Reduce zk request when doing split logMajor.
HBASE-19336Improve rsgroup to allow assign all tables within a specified namespace by only writing namespaceMajorrsgroup
HBASE-19367Refactoring in RegionStates, and RSProcedureDispatcherMinor.
HBASE-19382Update report-flakies.py script to handle yetus buildsMajor.
HBASE-19252Move the transform logic of FilterList into transformCell() method to avoid extra ref to question cellMinor.
HBASE-19372Remove the Span object in SyncFuture as it is useless nowMajortracing, wal
HBASE-18090Improve TableSnapshotInputFormat to allow more multiple mappers per regionMajormapreduce
HBASE-16868Add a replicate_all flag to avoid misuse the namespaces and table-cfs config of replication peerCriticalReplication
HBASE-19311Promote TestAcidGuarantees to LargeTests and start mini cluster once to make it fasterMajortest
HBASE-19293Support adding a new replication peer in disabled stateMajor.
HBASE-16574Add backup / restore feature to refguideMajor.
HBASE-19274Log IOException when unable to determine the size of committed fileTrivial.
HBASE-19251Merge RawAsyncTable and AsyncTableMajorasyncclient, Client
HBASE-19262Revisit checkstyle rulesMajorbuild
HBASE-18601Update Htrace to 4.2Majordependencies, tracing
HBASE-19227Nightly jobs should archive JVM dumpstream filesCriticalbuild
HBASE-12350Backport error-prone build support to branch-1 and branch-2Minor.
HBASE-19228nightly job should gather machine stats.Majorbuild
HBASE-19186Unify to use bytes to show size in master/rs uiMinor.
HBASE-19027Honor the CellComparator of ScanInfo in scanning over a storeMajor.
HBASE-13622document upgrade rollbackMajordocumentation
HBASE-18925Need updated mockito for using java optionalMajor.
HBASE-19140hbase-cleanup.sh uses deprecated call to remove files in hdfsTrivialscripts
HBASE-17065Perform more effective sorting for RPC Handler TasksMinor.
HBASE-18870Hbase Backup should set the details to MR job nameMinor.
HBASE-18602rsgroup cleanup unassign codeMinorrsgroup
HBASE-19110Add default for Server#isStopping & #getFileSystemMinor.
HBASE-19091Code annotation wrote “BinaryComparator” instead of “LongComparator”MinorClient
HBASE-18994Decide if META/System tables should use Compacting Memstore or Default MemstoreMajor.
HBASE-19051Add new split algorithm for num stringMinor.
HBASE-18824Add meaningful comment to HConstants.LATEST_TIMESTAMP to explain why it is MAX_VALUEMinor.
HBASE-10367RegionServer graceful stop / decommissioningMajor.
HBASE-18986Remove unnecessary null check after CellUtil.cloneQualifier()Minor.
HBASE-15410Utilize the max seek value when all Filters in MUST_PASS_ALL FilterList return SEEK_NEXT_USING_HINTMajor.
HBASE-18843Add DistCp support to incremental backup with bulk loadingMajor.
HBASE-16010Put draining function through Admin APIMinor.
HBASE-18899Make Fileinfo more readable in HFilePrettyPrinterMajorHFile
HBASE-16894Create more than 1 split per region, generalize HBASE-12590Major.
HBASE-18929Hbase backup command doesn’t show debug option to enable backup in debug modeMinor.
HBASE-18814Make ScanMetrics enabled and add counter <HBase Counters, ROWS_SCANNED> into the MapReduce Job over snapshotMinormapreduce
HBASE-18559Add histogram to MetricsConnection to track concurrent calls per serverMinorClient
HBASE-18436Add client-side hedged read metricsMinor.
HBASE-13844Move static helper methods from KeyValue into CellUtilsMinor.
HBASE-18884Coprocessor Design Improvements follow up of HBASE-17732MajorCoprocessors
HBASE-18652Expose individual cache stats in a CombinedCache through JMXMajorregionserver
HBASE-18651Let ChaosMonkeyRunner expose the chaos monkey runner it createsMajor.
HBASE-11462MetaTableAccessor shouldn't use ZooKeeeperMajorClient, Zookeeper
HBASE-18478Allow users to remove RegionFinder from LoadBalancer calculations if no locality possibleMajorBalancer
HBASE-18849expand “thirdparty” reference to give examples of setting netty location in common testing modulesCriticaldocumentation, thirdparty
HBASE-18609Apply ClusterStatus#getClusterStatus(EnumSet<Option>) in code baseMajor.
HBASE-18795Expose KeyValue.getBuffer() for tests aloneMajor.
HBASE-18772[JDK8] Replace AtomicLong with LongAdderTrivial.
HBASE-14996Some more API cleanup for 2.0Blocker.
HBASE-18683Upgrade hbase to commons-math 3Major.
HBASE-13271Table#puts(List<Put>) operation is indeterminate; needs fixingCriticalAPI
HBASE-10240Remove 0.94->0.96 migration codeCritical.
HBASE-18662The default values for many configuration items in the code are not consistent with hbase-default.xmlMinor.
HBASE-18621Refactor ClusterOptions before applying to code baseMajor.
HBASE-18778Use Comparator for StealJobQueueMajorCompaction
HBASE-18737Display configured max size of memstore and cache on RS UIMinor.
HBASE-18674upgrade hbase to commons-lang3Major.
HBASE-18746Throw exception with job.getStatus().getFailureInfo() when ExportSnapshot failsMinormapreduce, snapshots
HBASE-18740Upgrade Zookeeper version to 3.4.10Major.
HBASE-18699Copy LoadIncrementalHFiles to another package and mark the old one as deprecatedMajormapreduce
HBASE-18675Making {max,min}SessionTimeout configurable for MiniZooKeeperClusterMinortest, Zookeeper
HBASE-17826Backup: submit M/R job to a particular Yarn queueMajor.
HBASE-18677typo in namespace docsTrivialdocumentation
HBASE-18701Optimize reference guide to use cell acl convenientlyTrivial.
HBASE-18519Use builder pattern to create cellMajor.
HBASE-18673Some more unwanted reference to unshaded PB classesMinor.
HBASE-18224Upgrade jettyCriticaldependencies
HBASE-18532Improve cache related stats rendered on RS UIMajorregionserver, UI
HBASE-18629Enhance ChaosMonkeyRunner with interruptibilityMajor.
HBASE-18631Allow configuration of ChaosMonkey properties via hbase-siteMinorintegration tests
HBASE-18573Update Append and Delete to use Mutation#getCellList(family)Minor.
HBASE-18251Remove unnecessary traversing to the first and last keys in the CellSetMajor.
HBASE-18581Remove dead code and some tidy up in BaseLoadBalancerMinorBalancer
HBASE-18504Add documentation for WAL compressionMinordocumentation
HBASE-17064Add TaskMonitor#getTasks() variant which accepts type selectionMinor.
HBASE-2631Decide between “InMB” and “MB” as suffix for field names in ClusterStatus objectsMinor.
HBASE-18533Expose BucketCache values to be configuredMajorBucketCache
HBASE-18303Clean up some parameterized test declarationsMinortest
HBASE-18522Add RowMutations support to BatchMajor.
HBASE-18566[RSGROUP]Log the client IP/port of the rsgroup adminMajorrsgroup
HBASE-15511ClusterStatus should be able to return responses by scopeMajor.
HBASE-18555Remove redundant familyMap.put() from addxxx() of sub-classes of Mutation and QueryMinorClient
HBASE-18387[Thrift] Make principal configurable in DemoClient.javaMinor.
HBASE-18548Move sources of important Jenkins jobs into source controlCriticaldocumentation, scripts
HBASE-18248Warn if monitored RPC task has been tied up beyond a configurable thresholdMajor.
HBASE-18485Performance issue: ClientAsyncPrefetchScanner is slower than ClientSimpleScannerMajor.
HBASE-18426nightly job should use independent stages to check supported jdksCriticalcommunity, test
HBASE-14220nightly tests should verify src tgz generates and builds correctlyMinorbuild
HBASE-18520Add jmx value to determine true Master Start timeMinormetrics
HBASE-16893Use Collection.removeIf instead of Iterator.remove in DependentColumnFilterMinor.
HBASE-16116Remove redundant pattern *.imlTrivial.
HBASE-18261[AMv2] Create new RecoverMetaProcedure and use it from ServerCrashProcedure and HMaster.finishActiveMasterInitialization()Majoramv2
HBASE-18402Thrift2 should support DeleteFamilyVersion typeMajorThrift
HBASE-18434Address some alerts raised by lgtm.comMajor.
HBASE-18023Log multi-* requests for more than threshold number of rowsMinorregionserver
HBASE-15816Provide client with ability to set priority on OperationsMajor.
HBASE-18389Remove byte[] from formal parameter of sizeOf() of ClassSize, ClassSize.MemoryLayout and ClassSize.UnsafeLayoutMinorutil
HBASE-18412[Shell] Support unset of list of configuration for a tableMinor.
HBASE-16312update jquery versionCriticaldependencies, UI
HBASE-18332Upgrade asciidoctor-maven-pluginMinorwebsite
HBASE-18339Update test-patch to use hadoop 3.0.0-alpha4Majortest
HBASE-18004getRegionLocations needs to be called once in ScannerCallableWithReplicas#call()MinorClient
HBASE-18307Share the same EventLoopGroup for NettyRpcServer, NettyRpcClient and AsyncFSWALProvider at RS sideMajorio, rpc, wal
HBASE-18083Make large/small file clean thread number configurable in HFileCleanerMajor.
HBASE-16730Exclude junit as a transitive dependency from hadoop-commonTrivialhbase
HBASE-15062IntegrationTestMTTR conditionally run some testsMinorintegration tests
HBASE-11707Using Map instead of list in FailedServers of RpcClientMinorClient
HBASE-18286Create static empty byte array to save memoryTrivialcommunity
HBASE-17995improve log messages during snapshot related testsTrivialintegration tests, mapreduce, snapshots, test
HBASE-15391Avoid too large “deleted from META” info logMinor.
HBASE-16585Rewrite the delegation token tests with Parameterized patternMajorsecurity, test
HBASE-13197Connection API cleanupMajorAPI
HBASE-15756Pluggable RpcServerCriticalPerformance, rpc
HBASE-17110Improve SimpleLoadBalancer to always take server-level balance into accountMajorBalancer
HBASE-18022Refine the error message issued with TableNotFoundException when expected table is not the same as the one fetched from metaMinor.
HBASE-18281Performance update in StoreFileWriter.java for string replacementTrivialcommunity
HBASE-18041Add pylintrc file to HBaseMajorcommunity
HBASE-18275Formatting and grammar mistakes in schemadoc chapterTrivialdocumentation
HBASE-18164Much faster locality cost function and candidate generatorCriticalBalancer
HBASE-16351do dependency license check via enforcer pluginMajorbuild, dependencies
HBASE-18252Resolve BaseLoadBalancer bad practice warningsMinor.
HBASE-18033Update supplemental models for new deps in Hadoop trunkCriticaldependencies
HBASE-17959Canary timeout should be configurable on a per-table basisMinorcanary
HBASE-17777TestMemstoreLAB#testLABThreading runs too long for a small testMinortest
HBASE-18101Fix type mismatch on container access in QuotaCache#choreTrivial.
HBASE-18001Extend the “count” shell command to support specified conditionsMinorshell
HBASE-18094Display the return value of the command appendMajorshell
HBASE-18075Support namespaces and tables with non-latin alphabetical charactersMajorClient
HBASE-18067Support a default converter for data read shell commandsMinorshell
HBASE-18019Close redundant memstore scannersMajor.
HBASE-17910Use separated StoreFileReader for streaming readMajorregionserver, scan, Scanners
HBASE-18043Institute a hard limit for individual cell size that cannot be overridden by clientsMajorIPC/RPC, regionserver
HBASE-17343Make Compacting Memstore default in 2.0 with BASIC as the default typeBlockerregionserver
HBASE-18021Add more info in timed out RetriesExhaustedException for read replica client get processing,MinorClient
HBASE-18017Reduce frequency of setStoragePolicy failure warningsMinor.
HBASE-14925Develop HBase shell command/tool to list table's region info through command lineMajorshell
HBASE-17924Consider sorting the row order when processing multi() ops before taking rowlocksMajor.
HBASE-18015Storage class aware block placement for procedure v2 WALsMinor.
HBASE-18007Clean up rest module codeTrivial.
HBASE-17990Refactor TestFSUtils to use BeforeTrivial.
HBASE-16466HBase snapshots support in VerifyReplication tool to reduce load on live HBase cluster with large tablesMajorhbase
HBASE-12870“Major compaction triggered” and “Skipping major compaction” messages lack the region informationMajorCompaction
HBASE-17973Create shell command to identify regions with poor localityMajorshell
HBASE-17979HBase Shell ‘list’ Command Help Doc ImprovementsMinorshell
HBASE-17875Document why objects over 10MB are not well-suited for hbaseMajordocumentation, mob
HBASE-8486IS_ROOT isnt needed in HTableDescriptor.Minor.
HBASE-17817Make Regionservers log which tables it removed coprocessors from when abortingMajorCoprocessors, regionserver
HBASE-17835Spelling mistakes in the Java sourceTrivialdocumentation
HBASE-17962Improve documentation on Rest interfaceTrivialdocumentation, REST
HBASE-17877Improve HBase's byte[] comparatorMajorutil
HBASE-9899for idempotent operation dups, return the result instead of throwing conflict exceptionMajor.
HBASE-17514Warn when Thrift Server 1 is configured for proxy users but not the HTTP transportMinorThrift, Usability
HBASE-17944Removed unused JDK version parsing from ClassSize.Minorbuild
HBASE-17912Avoid major compactions on region server startupMajorCompaction
HBASE-17888Add generic methods for updating metrics on start and end of a procedure executionMajorproc-v2
HBASE-16469Several log refactoring/improvement suggestionsMajorOperability
HBASE-17836CellUtil#estimatedSerializedSizeOf is slow when input is ByteBufferCellMinor.
HBASE-16969RegionCoprocessorServiceExec should override the toString() for debuggingMinor.
HBASE-17854Use StealJobQueue in HFileCleaner after HBASE-17215Major.
HBASE-17215Separate small/large file delete threads in HFileCleaner to accelerate archived hfile cleanup speedMajor.
HBASE-17831Support small scan in thrift2MajorThrift
HBASE-17623Reuse the bytes array when building the hfile blockMajorHFile
HBASE-17815Remove the unused field in PrefixTreeSeekerTrivial.
HBASE-17778Remove the testing code in the AsyncRequestFutureImplTrivial.
HBASE-15339Improve DateTieredCompactionPolicyMajorCompaction
HBASE-17747Support both weak and soft object poolMajor.
HBASE-15429Add a split policy for busy regionsMajorregionserver
HBASE-17731Fractional latency reporting in MultiThreadedActionTrivial.
HBASE-16977VerifyReplication should log a printable representation of the row keysMinorReplication
HBASE-15941HBCK repair should not unsplit healthy splitted regionMajorhbck
HBASE-17532Replace explicit type with diamond operatorTrivialbuild
HBASE-17734Guard against possibly copying the qualifier in the ScanDeleteTrackerMinor.
HBASE-17690Clean up MOB codeMajormob
HBASE-16188Add EventCounter information to log4j properties fileMinor.
HBASE-17689Add support for table.existsAll in thrift2 THBaseserviceMajorThrift
HBASE-17634Clean up the usage of Result.isPartialMajorscan
HBASE-17654RSGroup code refactoringMajorrsgroup
HBASE-17057Minor compactions should also drop page cache behind readsMajorCompaction
HBASE-17676Get class name once for all in AbstractFSWALMajorPerformance
HBASE-13718Add a pretty printed table description to the table detail page of HBase's masterMinorhbase
HBASE-17172Optimize mob compaction with _del filesMajormob
HBASE-17627Active workers metric for thriftMajorThrift
HBASE-17637Update progress more frequently in IntegrationTestBigLinkedList.Generator.persistMinor.
HBASE-17605Refactor procedure framework codeMajorproc-v2
HBASE-17280Add mechanism to control hbase cleaner behaviorMinorClient, hbase, shell
HBASE-17613avoid copy of family when initializing the FSWALEntryMinor.
HBASE-17437Support specifying a WAL directory outside of the root directoryMajorFilesystem Integration, wal
HBASE-17592Fix typo in IPCUtil and RpcConnectionTrivial.
HBASE-17588Remove unused imports brought in by HBASE-17437Trivial.
HBASE-17552Update developer section in hbase bookMajor.
HBASE-17543Create additional ReplicationEndpoint WALEntryFilters by configurationMajorReplication
HBASE-17569HBase-Procedure module need to support mvn clean test -PskipProcedureTests to skip unit testMinorproc-v2
HBASE-17555Change calls to deprecated getHBaseAdmin to getAdminMinor.
HBASE-17563Foreach and switch in RootDocProcessor and StabilityOptionsTrivial.
HBASE-17515Reduce memory footprint of RegionLoads kept by StochasticLoadBalancerMajor.
HBASE-17462Use sliding window for read/write request costs in StochasticLoadBalancerMajor.
HBASE-16698Performance issue: handlers stuck waiting for CountDownLatch inside WALKey#getWriteEntry under high writing workloadMajorPerformance
HBASE-17404Replace explicit type with diamond operator in hbase-annotationsTrivial.
HBASE-10699Optimize some code; set capacity on arraylist when possible; use isEmpty; reduce allocationsMajor.
HBASE-17488WALEdit should be lazily instantiatedTrivial.
HBASE-17408Introduce per request limit by number of mutationsMajor.
HBASE-17291Remove ImmutableSegment#getKeyValueScannerMajorScanners
HBASE-17314Limit total buffered size for all replication sourcesMajorReplication
HBASE-17348Remove the unused hbase.replication from javadoc/comment/book completelyTrivial.
HBASE-15924Enhance hbase services autorestart capability to hbase-daemon.shMajor.
HBASE-17292Add observer notification before bulk loaded hfile is moved to region directoryMajor.
HBASE-17332Replace HashMap to Array for DataBlockEncoding.idToEncodingMajor.
HBASE-17331Avoid busy waiting in ThrottledInputStreamMinor.
HBASE-17318Increment does not add new column if the increment amount is zero at first time writingMajor.
HBASE-17298remove unused code in HRegion#doMiniBatchMutationMinorregionserver
HBASE-17296Provide per peer throttling for replicationMajorReplication
HBASE-17276Reduce log spam from WrongRegionException in large multi()'sMinorregionserver
HBASE-17241Avoid compacting already compacted mob files with _del filesMajormob
HBASE-17207Arrays.asList() with too few argumentsTrivial.
HBASE-16700Allow for coprocessor whitelistingMinorCoprocessors
HBASE-17239Add UnsafeByteOperations#wrap(ByteInput, int offset, int len) APIMajorProtobufs
HBASE-17245Replace HTableDescriptor#htd.getColumnFamilies().length with a low-cost implementationMinor.
HBASE-14882Provide a Put API that adds the provided family, qualifier, value without copyingMajor.
HBASE-17243Reuse CompactionPartitionId and avoid creating MobFileName in PartitionedMobCompactor to avoid unnecessary new objectsMinormob
HBASE-17194Assign the new region to the idle server after splittingMinor.
HBASE-17232Replace HashSet with ArrayList to accumulate delayed scanners in KVHeap and StoreScanner.Major.
HBASE-17161MOB : Make ref cell creation more efficientMajor.
HBASE-17235Improvement in creation of CIS for onheap buffer casesMajorrpc
HBASE-17191Make use of UnsafeByteOperations#unsafeWrap(ByteBuffer buffer) in PBUtil#toCell(Cell cell)Major.
HBASE-17205Add a metric for the duration of region in transitionMinorRegion Assignment
HBASE-17216A Few Fields Can Be Safely Made StaticMajor.
HBASE-17212Should add null checker on table name in HTable constructor and RegionServerCallableMajor.
HBASE-17184Code cleanup of LruBlockCacheTrivial.
HBASE-17211Add more details in log when UnknownScannerException thrown in ScannerCallableMinorOperability
HBASE-17178Add region balance throttlingMajorBalancer
HBASE-16302age of last shipped op and age of last applied op should be histogramsMajorReplication
HBASE-16561Add metrics about read/write/scan queue length and active read/write/scan handler countMinorIPC/RPC, metrics
HBASE-17086Add comments to explain why Cell#getTagsLength() returns an int, rather than a shortMinorInterface
HBASE-17176Reuse the builder in RequestConverterMinor.
HBASE-17157Increase the default mergeable threshold for mob compactionMajormob
HBASE-17129Remove public from methods in DataType interfaceMinor.
HBASE-17123Add postBulkLoadHFile variant that notifies the final paths for the hfilesMajor.
HBASE-17126Expose KeyValue#checkParameters() and checkForTagsLength() to be used by other Cell implementationsMinorClient, regionserver
HBASE-17088Refactor RWQueueRpcExecutor/BalancedQueueRpcExecutor/RpcExecutorMajorrpc
HBASE-16708Expose endpoint Coprocessor name in “responseTooSlow” log messagesMajor.
HBASE-17037Enhance LoadIncrementalHFiles API to convey loaded filesMajor.
HBASE-17077Don't copy the replication queue belonging to the peer which has been deletedMinor.
HBASE-17047Add an API to get HBase connection cache statisticsMinorspark
HBASE-17063Cleanup TestHRegion : remove duplicate variables for method name and two unused params in initRegionMinor.
HBASE-17026VerifyReplication log should distinguish whether good row key is result of revalidationMinor.
HBASE-16840Reuse cell's timestamp and type in ScanQueryMatcherMinor.
HBASE-17005Improve log message in MobFileCacheTrivialmob
HBASE-17004Refactor IntegrationTestManyRegions to use @ClassRule for timing outMinorintegration tests
HBASE-16946Provide Raw scan as an option in VerifyReplicationMinorhbase
HBASE-17013Add constructor to RowMutations for initializing the capacity of internal listMinor.
HBASE-17006Add names to threads for better debugability of thread dumpsMinorOperability
HBASE-17014Add clearly marked starting and shutdown log messages for all services.MinorOperability
HBASE-16950Print raw stats in the end of procedure performance tools for parsing results from scriptsTrivial.
HBASE-16783Use ByteBufferPool for the header and message during Rpc responseMinor.
HBASE-16562ITBLL should fail to start if misconfiguredMajorintegration tests
HBASE-16414Improve performance for RPC encryption with Apache Common CryptoMajorIPC/RPC
HBASE-16854Refactor the org.apache.hadoop.hbase.client.ActionMinor.
HBASE-16774[shell] Add coverage to TestShell when ZooKeeper is not reachableMajorshell, test
HBASE-16844Procedure V2: DispatchMergingRegionsProcedure to use base class StateMachineProcedure for abort and rollbackTrivialmaster, proc-v2
HBASE-16818Avoid multiple copies of binary data during the conversion from Result to RowMajorspark
HBASE-16821Enhance LoadIncrementalHFiles API to convey missing hfiles if anyMajor.
HBASE-15921Add first AsyncTable impl and create TableImpl based on itMajorClient
HBASE-16792Reuse KeyValue.KeyOnlyKeyValue in BufferedDataBlockEncoder.SeekerStateMinor.
HBASE-16784Make use of ExtendedCell#write(OutputStream os) for the default HFileWriter#append()Major.
HBASE-16809Save one cell length calculation in HeapMemStoreLAB#copyCellIntoMinor.
HBASE-16661Add last major compaction age to per-region metricsMinor.
HBASE-16773AccessController should access local region if possibleMajor.
HBASE-16657Expose per-region last major compaction timestamp in RegionServer UIMinorregionserver, UI
HBASE-16772Add verbose option to VerifyReplication for logging good rowsMinorReplication, Usability
HBASE-16690Move znode path configs to a separated classMajorZookeeper
HBASE-16672Add option for bulk load to always copy hfile(s) instead of renamingMajor.
HBASE-16720Sort build ids in flaky dashboardMinor.
HBASE-16691Optimize KeyOnlyFilter by utilizing KeyOnlyCellMajor.
HBASE-16714Procedure V2 - use base class to remove duplicate set up test code in table DDL proceduresMajorproc-v2, test
HBASE-16694Reduce garbage for onDiskChecksum in HFileBlockMinor.
HBASE-16705Eliminate long to Long auto boxing in LongComparatorMinorFilters
HBASE-16692Make ByteBufferUtils#equals safer and correctMajor.
HBASE-16667Building with JDK 8: ignoring option MaxPermSize=256mMinorbuild
HBASE-16423Add re-compare option to VerifyReplication to avoid occasional inconsistent rowsMinorReplication
HBASE-16680Reduce garbage in BufferChainMinor.
HBASE-16659Use CellUtil.createFirstOnRow instead of KeyValueUtil.createFirstOnRow in some places.Minor.
HBASE-16646Enhance LoadIncrementalHFiles API to accept store file paths as inputMajor.
HBASE-16658Optimize UTF8 string/byte conversionsMinor.
HBASE-16640TimeoutBlockingQueue#remove() should return whether the entry is removedMinor.
HBASE-15949Cleanup TestRegionServerMetricsMinor.
HBASE-16381Shell deleteall command should support row key prefixesMinorshell
HBASE-16616Rpc handlers stuck on ThreadLocalMap.expungeStaleEntryMajorPerformance
HBASE-16086TableCfWALEntryFilter and ScopeWALEntryFilter should not redundantly iterate over cells.Major.
HBASE-16541Avoid unnecessary cell copy in Result#compareResultsMajor.
HBASE-16399Provide an API to get list of failed regions and servername in CanaryMajorcanary
HBASE-16502Reduce garbage in BufferedDataBlockEncoderMajor.
HBASE-16509Add option to LoadIncrementalHFiles which allows skipping unmatched column familiesMajor.
HBASE-16224Reduce the number of RPCs for the large PUTsMinorClient
HBASE-16508Move UnexpectedStateException to commonTrivial.
HBASE-16486Unify system table creation using the same createSystemTable API.Minorproc-v2
HBASE-16448Custom metrics for custom replication endpointsMajorReplication
HBASE-16450Shell tool to dump replication queuesMajorOperability, Replication
HBASE-16455Provide API for obtaining all the WAL filesMajor.
HBASE-16422Tighten our guarantees on compatibility across patch versionsMajordocumentation
HBASE-16434Improve flaky dashboardMinor.
HBASE-16419check REPLICATION_SCOPE's value more stringentlyMajor.
HBASE-16385Have hbase-rest pull hbase.rest.port from Constants.javaMinorREST
HBASE-16379[replication] Minor improvement to replication/copy_tables_desc.rbTrivialReplication, shell
HBASE-14345Consolidate printUsage in IntegrationTestLoadAndVerifyTrivialintegration tests
HBASE-16299Update REST API scanner with ability to do reverse scanMinorREST
HBASE-12770Don't transfer all the queued hlogs of a dead server to the same alive serverMinorReplication
HBASE-15882Upgrade to yetus precommit 0.3.0Criticalbuild
HBASE-8386deprecate TableMapReduce.addDependencyJars(Configuration, class<?> ...)Majormapreduce
HBASE-16287LruBlockCache size should not exceed acceptableSize too manyMajorBlockCache
HBASE-16225Refactor ScanQueryMatcherMajorregionserver, Scanners
HBASE-14881Provide a Put API that uses the provided row without copingMajor.
HBASE-16256Purpose of EnvironmentEdge, EnvironmentEdgeManagerTrivialdocumentation, regionserver
HBASE-16275Change ServerManager#onlineServers from ConcurrentHashMap to ConcurrentSkipListMapMinor.
HBASE-14743Add metrics around HeapMemoryManagerMinor.
HBASE-16266Do not throw ScannerTimeoutException when catch UnknownScannerExceptionMajorClient, Scanners
HBASE-16008A robust way deal with early termination of HBCKMajorhbck
HBASE-13701Consolidate SecureBulkLoadEndpoint into HBase core as default for bulk loadMajor.
HBASE-16052Improve HBaseFsck ScalabilityMajorhbck
HBASE-16241Allow specification of annotations to use when running check_compatibility.shMajorscripts
HBASE-16231Integration tests should support client keytab login for secure clustersMajorintegration tests
HBASE-16220Demote log level for “HRegionFileSystem - No StoreFiles for” messages to TRACEMinor.
HBASE-16087Replication shouldn't start on a master if if only hosts system tablesMajor.
HBASE-14548Expand how table coprocessor jar and dependency path can be specifiedMajorCoprocessors
HBASE-16108RowCounter should support multiple key rangesMajor.
HBASE-16140bump owasp.esapi from 2.1.0 to 2.1.0.1Majordependencies
HBASE-16114Get regionLocation of required regions only for MR jobsMinormapreduce
HBASE-16147Shell command for getting compaction stateMajorshell
HBASE-16124Make check_compatibility.sh less verbose when building HBaseMinorbuild, test
HBASE-16149Log the underlying RPC exception in RpcRetryingCallerImplMinor.
HBASE-16130Add comments to ProcedureStoreTrackerMinor.
HBASE-16139Use CellUtil instead of KeyValueUtil in ImportMinor.
HBASE-14007Writing to table through MR should fail upfront if table does not exist/is disabledMinormapreduce
HBASE-16089Add on FastPath for CoDelMajor.
HBASE-15353Add metric for number of CallQueueTooBigExceptionsMinorIPC/RPC, metrics
HBASE-16085Add on metric for failed compactionsMajor.
HBASE-15870Specify columns in REST multi getsMinorREST
HBASE-14397PrefixFilter doesn't filter all remaining rows if the prefix is longer than rowkey being comparedMinorFilters
HBASE-16042Add support in PE tool for InMemory CompactionMajor.
HBASE-15600Add provision for adding mutations to memstore or able to write to same region in batchMutate coprocessor hooksMajor.
HBASE-16018Better documentation of ReplicationPeersMinor.
HBASE-16048Tag InternalScanner with LimitedPrivate(HBaseInterfaceAudience.COPROC)Major.
HBASE-5291Add Kerberos HTTP SPNEGO authentication support to HBase web consolesMajormaster, regionserver, security
HBASE-16033Add more details in logging of responseTooSlow/TooLargeMajorOperability
HBASE-16026Master UI should display status of additional ZK switchesMajor.
HBASE-16004Update to Netty 4.1.1Major.
HBASE-15981Stripe and Date-tiered compactions inaccurately suggest disabling table in docsMinordocumentation
HBASE-15849Shell Cleanup: Simplify handling of commands' runtimeMinor.
HBASE-15931Add log for long-running tasks in AsyncProcessCriticalOperability
HBASE-15727Canary Tool for ZookeeperMajor.
HBASE-15910Update hbase ref guide to explain submit-patch.pyMajordocumentation
HBASE-15890Allow thrift to set/unset “cacheBlocks” for ScansMajorThrift
HBASE-15854Log the cause of SASL connection failuresMinorsecurity
HBASE-15837Memstore size accounting is wrong if postBatchMutate() throws exceptionMajorregionserver
HBASE-15471Add num calls in priority and general queue to RS UIMajorUI
HBASE-15802ConnectionUtils should use ThreadLocalRandom instead of RandomMinor.
HBASE-15529Override needBalance in StochasticLoadBalancerMinor.
HBASE-15864Reuse the testing helper to wait regions in transitionTrivialtest
HBASE-15843Replace RegionState.getRegionInTransition() Map with a SetTrivialmaster, Region Assignment
HBASE-15593Time limit of scanning should be offered by clientMajor.
HBASE-15667Add more clarity to Reference Guide related to importing Eclipse FormatterTrivialdocumentation
HBASE-15842SnapshotInfo should display ownership informationMajor.
HBASE-13532Make UnknownScannerException logging less scaryTrivial.
HBASE-15808Reduce potential bulk load intermediate space usage and wasteMinor.
HBASE-15415Improve Master WebUI snapshot informationMinormaster, snapshots
HBASE-15609Remove PB references from Result, DoubleColumnInterpreter and any such public facing class for 2.0Blocker.
HBASE-15791Improve javadoc in ScheduledChoreMinormaster
HBASE-15793Port over AsyncCall improvementsMajorrpc
HBASE-15794Fix Findbugs instanceof always true issue in MultiServerCallableMinor.
HBASE-15795Cleanup all classes in package org.apache.hadoop.hbase.ipc for code styleMinor.
HBASE-15745Refactor RPC classes to better accept async changes.Major.
HBASE-15773CellCounter improvementsMajormapreduce
HBASE-15759RegionObserver.preStoreScannerOpen() doesn't have acces to current readpointMinorCoprocessors
HBASE-15608Remove PB references from SnapShot related ExceptionsBlocker.
HBASE-15767Upgrade httpclient dependencyMajorbuild, dependencies
HBASE-15768fix capitalization of ZooKeeper usageTrivialdocumentation
HBASE-15720Print row locks at the debug dump pageMajor.
HBASE-15744Port over small format/text improvements from HBASE-13784Trivial.
HBASE-15551Make call queue too big exception use servernameMinor.
HBASE-15706HFilePrettyPrinter should print out nicely formatted tagsMinorHFile
HBASE-15686Add override mechanism for the exempt classes when dynamically loading table coprocessorMajorCoprocessors
HBASE-15680Examples in shell help message for TIMERANGE scanner specifications should use milliseconds instead of secondsTrivialshell
HBASE-15688Use MasterServices directly instead of casting to HMaster when possibleTrivialmaster
HBASE-15641Shell “alter” should do a single modifyTable operationMajorshell
HBASE-15614Report metrics from JvmPauseMonitorMajormetrics, regionserver
HBASE-13129Add troubleshooting hints around WAL retention from replicationMajordocumentation, Replication
HBASE-15632Undo the checking of lastStoreFlushTimeMap.isEmpty() introduced in HBASE-13145Minorregionserver
HBASE-14985TimeRange constructors should set allTime when appropriateMinor.
HBASE-15605Remove PB references from HCD and HTD for 2.0Blocker.
HBASE-15507Online modification of enabled ReplicationPeerConfigMajorReplication
HBASE-15612Minor improvements to CellCounter and RowCounter documentationTrivialdocumentation, mapreduce
HBASE-15586Unify human readable numbers in the web UIMajor.
HBASE-15606Limit creating zk connection in HBaseAdmin#getCompactionState() only to case when ‘hbase:meta’ is checked.MinorAdmin
HBASE-15396Enhance mapreduce.TableSplit to add encoded region nameMinormapreduce
HBASE-15571Make MasterProcedureManagerHost accessible through MasterServicesMajor.
HBASE-15569Make Bytes.toStringBinary fasterMinorPerformance
HBASE-14983Create metrics for per block type hit/miss ratiosMajormetrics
HBASE-15191CopyTable and VerifyReplication - Option to specify batch size, versionsMinorReplication
HBASE-15508Add command for exporting snapshot in hbase command scriptMinorhbase, scripts, snapshots
HBASE-15496Throw RowTooBigException only for user scan/getMinorScanners
HBASE-15526Make SnapshotManager accessible through MasterServicesMajor.
HBASE-15486Avoid multiple disable/enable balancer calls while running rolling-restart.sh --gracefulMinorscripts
HBASE-15300Upgrade to zookeeper 3.4.8Minor.
HBASE-14703HTable.mutateRow does not collect statsMajorClient
HBASE-15475Allow TimestampsFilter to provide a seek hintMajorClient, Filters, regionserver
HBASE-15212RPCServer should enforce max request sizeMajor.
HBASE-15447Improve javadocs description for Delete methodsMinorAPI, documentation
HBASE-15478add comments to FSHLog explaining why syncRunnerIndex won't overflowMinorwal
HBASE-14963Remove use of Guava Stopwatch from HBase client codeMajorClient
HBASE-15451Remove unnecessary wait in MVCCMajor.
HBASE-15456CreateTableProcedure/ModifyTableProcedure needs to fail when there is no family in table descriptorMinormaster
HBASE-12940Expose listPeerConfigs and getPeerConfig to the HBase shellMajorshell
HBASE-15470Add a setting for Priority queue lengthMajorIPC/RPC, Region Assignment
HBASE-15413Procedure-V2: print out ProcedureInfo during traceTrivialproc-v2
HBASE-15243Utilize the lowest seek value when all Filters in MUST_PASS_ONE FilterList return SEEK_NEXT_USING_HINTMajor.
HBASE-15338Add a option to disable the data block cache for testing the performance of underlying file systemMinorintegration tests
HBASE-15356Remove unused ImportsTrivial.
HBASE-14099StoreFile.passesKeyRangeFilter need not create Cells from the Scan's start and stop RowMajorPerformance, Scanners
HBASE-15315Remove always set super user call as high priorityMajor.
HBASE-15222Use less contended classes for metricsCriticalmetrics
HBASE-15312Update the dependences of pom for mini cluster in HBase BookMinordocumentation
HBASE-15306Make RPC call queue length dynamically configurableMajorIPC/RPC
HBASE-11927Use Native Hadoop Library for HFile checksum (And flip default from CRC32 to CRC32C)MajorPerformance
HBASE-15301Remove the never-thrown NamingException from TableInputFormatBase#reverseDNS method signatureMinor.
HBASE-15219Canary tool does not return non-zero exit code when one of regions is in stuck stateCriticalcanary
HBASE-15223Make convertScanToString public for SparkMajor.
HBASE-15229Canary Tools should not call System.Exit on errorCriticalcanary
HBASE-11792Organize PerformanceEvaluation usage outputMinorPerformance, test
HBASE-15201Add hbase-spark to hbase assemblyMinor.
HBASE-15211Don't run the CatalogJanitor if there are regions in transitionMajormaster
HBASE-15197Expose filtered read requests metric to metrics framework and Web UIMinor.
HBASE-15177Reduce garbage created under high loadMajor.
HBASE-13376Improvements to Stochastic load balancerMinorBalancer
HBASE-15129Set default value for hbase.fs.tmp.dir rather than fully depend on hbase-default.xmlMajormapreduce
HBASE-14969Add throughput controller for flushMajorregionserver
HBASE-15123Remove duplicate code in LocalHBaseCluster and minor formattingMinor.
HBASE-14865Support passing multiple QOPs to SaslClient/Server via hbase.rpc.protectionMajorsecurity
HBASE-15119Include git SHA in check_compatibility reportsMinorbuild
HBASE-13525Update test-patch to leverage Apache YetusMajorbuild
HBASE-15076Add getScanner(Scan scan, List<KeyValueScanner> additionalScanners) API into Region interfaceCriticalregionserver
HBASE-15068Add metrics for region normalization plansMajor.
HBASE-14468Compaction improvements: FIFO compaction policyMajorCompaction, Performance
HBASE-15066Small improvements to Canary toolMajor.
HBASE-14524Short-circuit comparison of rows in CellComparatorMajorPerformance, Scanners
HBASE-15038ExportSnapshot should support separate configurations for source and destination clustersMajormapreduce, snapshots
HBASE-15060Cull TestHFileWriterV2 and HFileWriterFactoryMajorHFile
HBASE-15044Region normalization should be allowed when underlying namespace has quotaMajorBalancer
HBASE-14796Enhance the Gets in the connectorMinor.
HBASE-13322Replace explicit HBaseAdmin creation with connection#getAdmin()Minor.
HBASE-14800Expose checkAndMutate via Thrift2MajorThrift
HBASE-14684Try to remove all MiniMapReduceCluster in unit testsCriticaltest
HBASE-13158When client supports CellBlock, return the result Cells as controller payload for get(Get) API alsoMajor.
HBASE-14976Add RPC call queues to the web uiMinorUI
HBASE-15005Use value array in computing block length for 1.2 and 1.3Majorregionserver
HBASE-14978Don't allow Multi to retain too many blocksBlockerio, IPC/RPC, regionserver
HBASE-14780Integration Tests that run with ChaosMonkey need to specify CFsMajorintegration tests
HBASE-14951Make hbase.regionserver.maxlogs obsoleteMinorPerformance, wal
HBASE-14984Allow memcached block cache to set optimze to falseMajorBlockCache
HBASE-13425Documentation nit in REST Gateway impersonation sectionMinordocumentation
HBASE-14795Enhance the spark-hbase scan operationsMinor.
HBASE-14946Don‘t allow multi’s to over run the max result size.CriticalClient, IPC/RPC
HBASE-14906Improvements on FlushLargeStoresPolicyMajor.
HBASE-14866VerifyReplication should use peer configuration in peer connectionMajorReplication
HBASE-7171Initial web UI for region/memstore/storefiles detailsMajorUI
HBASE-14719Add metric for number of MasterProcWALsMajor.
HBASE-14580Make the HBaseMiniCluster compliant with KerberosMajorsecurity, test
HBASE-14749Make changes to region_mover.rb to use RegionMover Java toolMajor.
HBASE-14891Add log for uncaught exception in RegionServerMetricsWrapperRunnableMinormetrics
HBASE-14859Better checkstyle reportingMinor.
HBASE-14826Small improvement in KVHeap seek() APIMinor.
HBASE-14860Improve BoundedByteBufferPool; make locklessMinor.
HBASE-14871Allow specifying the base branch for make_patchMajor.
HBASE-14821CopyTable should allow overriding more config properties for peer clusterMajormapreduce
HBASE-13347Deprecate FirstKeyValueMatchingQualifiersFilterMinor.
HBASE-14862Add support for reporting p90 for histogram metricsMinormetrics
HBASE-14172Upgrade existing thrift binding using thrift 0.9.3 compiler.Minor.
HBASE-14829Add more checkstylesMajor.
HBASE-14805status should show the master in shellMajorshell
HBASE-14708Use copy on write Map for region location cacheCriticalClient
HBASE-14766In WALEntryFilter, cell.getFamily() needs to be replaced with the new low-cost implementationMajor.
HBASE-14387Compaction improvements: Maximum off-peak compaction sizeMajorCompaction, Performance
HBASE-14693Add client-side metrics for received pushback signalsMajorClient, metrics
HBASE-14765Remove snappy profileMajorbuild
HBASE-14752Add example of using the HBase client in a multi-threaded environmentMinorClient
HBASE-14666Remove deprecated HBaseTestingUtility#deleteTable methodsMajortest
HBASE-12986Compaction pressure based client pushbackMajor.
HBASE-12822Option for Unloading regions through region_mover.rb without AcknowledgingMinor.
HBASE-13742buildbot should run link checker over bookMajordocumentation
HBASE-14700Support a “permissive” mode for secure clusters to allow “simple” auth clientsMajorsecurity
HBASE-14715Add javadocs to DelegatingRetryingCallableTrivialClient
HBASE-13014Java Tool For Region MovingMajor.
HBASE-14731Add -DuseMob option to ITBLLMajor.
HBASE-14687Un-synchronize BufferedMutatorCriticalClient, Performance
HBASE-14721Memstore add cells - Avoid many garbageMajorregionserver
HBASE-14714some cleanup to snapshot codeTrivialsnapshots
HBASE-14675Exorcise deprecated Put#add(...) and replace with Put#addColumn(...)Major.
HBASE-14672Exorcise deprecated Delete#delete* apisMajor.
HBASE-12769Replication fails to delete all corresponding zk nodes when peer is removedMinorReplication
HBASE-14696Support setting allowPartialResults in mapreduce MappersMajormapreduce
HBASE-14266RegionServers have a lock contention of Configuration.getPropsCriticalregionserver
HBASE-14683Batching in buffered mutator is awful when adding lists of mutations.MajorClient
HBASE-14670Remove deprecated HBaseTestCase from TestBlocksReadMajortest
HBASE-14669remove unused import and fix javadocTrivial.
HBASE-14671Remove deprecated HBaseTestCase/Put/Delete apis from TestGetClosestAtOrBeforeMajortest
HBASE-14665Remove deprecated HBaseTestingUtility#createTable methodsMajortest
HBASE-14668Remove deprecated HBaseTestCase dependency from TestHFileMajortest
HBASE-14643Avoid Splits from once again opening a closed reader for fetching the first and last keyMajorregionserver
HBASE-14586Use a maven profile to run Jacoco analysisMinorpom
HBASE-14268Improve KeyLockerMinorutil
HBASE-14588Stop accessing test resources from within src folderMajorbuild, test
HBASE-14587Attach a test-sources.jar for hbase-serverMajorbuild
HBASE-14582Regionserver status webpage bucketcache list can become hugeMajorregionserver
HBASE-14517Show regionserver's version in master status pageMinormonitoring
HBASE-14565Make ZK connection timeout configurable in MiniZooKeeperClusterMajor.
HBASE-14574TableOutputFormat#getRecordWriter javadoc misleadsMajor.
HBASE-14573Edit on the ByteBufferedCell javadocMajordocumentation
HBASE-14436HTableDescriptor#addCoprocessor will always make RegionCoprocessorHost create new ConfigurationMinorCoprocessors
HBASE-14520Optimize the number of calls for tags creation in bulk loadMajor.
HBASE-14547Add more debug/trace to zk-procedureTrivialsnapshots
HBASE-14230replace reflection in FSHlog with HdfsDataOutputStream#getCurrentBlockReplication()Minorwal
HBASE-14478A ThreadPoolExecutor with a LinkedBlockingQueue cannot execute tasks concurrentlyMajorregionserver
HBASE-14455Try to get rid of unused HConnection instanceMinor.
HBASE-14193Remove support for direct upgrade from pre-0.96 versionsMinor.
HBASE-14461Cleanup IncreasingToUpperBoundRegionSplitPolicyMinor.
HBASE-14448Refine RegionGroupingProvider Phase-2: remove provider nesting and formalize wal group nameMajor.
HBASE-14082Add replica id to JMX metrics namesMajormetrics
HBASE-14334Move Memcached block cache in to it's own optional module.MajorBlockCache, build, Operability
HBASE-14306Refine RegionGroupingProvider: fix issues and make it more scalableMajorwal
HBASE-6617ReplicationSourceManager should be able to track multiple WAL pathsMajorReplication
HBASE-14314Metrics for block cache should take region replicas into accountMajormetrics, regionserver
HBASE-12988[Replication]Parallel apply edits across regionsMajorReplication
HBASE-14261Enhance Chaos Monkey framework by adding zookeeper and datanode fault injections.Majorintegration tests
HBASE-7972Add a configuration for the TCP backlog in the Thrift serverMajorThrift
HBASE-14332Show the table state when we encounter exception while disabling / enabling tableMinor.
HBASE-14325Add snapshotinfo command to hbase scriptMinorscripts
HBASE-14309Allow load balancer to operate when there is region in transition by adding force flagMajor.
HBASE-14078improve error message when HMaster can't bind to portMajormaster
HBASE-13127Add timeouts on all tests so less zombie sightingsMajortest
HBASE-13996Add write sniffing in canaryMajorcanary
HBASE-14260don't build javadocs for hbase-protocol moduleMajorbuild, documentation
HBASE-14148Web UI Framable PageMajorsecurity, UI
HBASE-14165The initial size of RWQueueRpcExecutor.queues should be (numWriteQueues + numReadQueues + numScanQueues)MinorIPC/RPC
HBASE-14203remove duplicate code getTableDescriptor in HTableTrivial.
HBASE-13914Minor improvements to dev-support/publish_hbase_website.shMinorwebsite
HBASE-12812Update Netty dependency to latest releaseMajor.
HBASE-13985Add configuration to skip validating HFile format when bulk loadingMinor.
HBASE-14122Client API for determining if server side supports cell level securityMinor.
HBASE-14194Undeprecate methods in ThriftServerRunner.HBaseHandlerTrivial.
HBASE-12256Update patch submission guidelines to call out binary file supportMinordocumentation
HBASE-13965Stochastic Load Balancer JMX MetricsMajorBalancer, metrics
HBASE-14164Display primary region replicas distribution on table.jspMinor.
HBASE-14097Log link to client scan troubleshooting section when scanner exceptions happen.Trivial.
HBASE-14152Fix the warnings in Checkstyle and FindBugs brought in by merging hbase-11339Majormob
HBASE-14151Remove the unnecessary file ProtobufUtil.java.rej which is brought in by merging hbase-11339Majormob
HBASE-14058Stabilizing default heap memory tunerMajorregionserver
HBASE-14110Add CostFunction for balancing primary region replicasMajorBalancer
HBASE-8642[Snapshot] List and delete snapshot by tableMajorsnapshots
HBASE-14045Bumping thrift version to 0.9.2.Major.
HBASE-12596bulkload needs to follow localityMajorHFile, regionserver
HBASE-13927Allow hbase-daemon.sh to conditionally redirect the log or notMajorshell
HBASE-14002Add --noReplicationSetup option to IntegrationTestReplicationMajorintegration tests
HBASE-13925Use zookeeper multi to clear znodes in ZKProcedureUtilMajorZookeeper
HBASE-13500Deprecate KVComparator and move to CellComparatorMajor.
HBASE-14015Allow setting a richer state value when toString a pv2Minorproc-v2
HBASE-13980Distinguish blockedFlushCount vs unblockedFlushCount when tuning heap memoryMinor.
HBASE-13670[HBase MOB] ExpiredMobFileCleaner tool deletes mob files later for one more day after they are expiredMajordocumentation, mob
HBASE-13943Get rid of KeyValue#heapSizeWithoutTagsMajor.
HBASE-14001Optimize write(OutputStream out, boolean withTags) for SizeCachedNoTagsKeyValueMinor.
HBASE-13103[ergonomics] add region size balancing as a feature of masterMajorBalancer, Usability
HBASE-13900duplicate methods between ProtobufMagic and ProtobufUtilMinor.
HBASE-13931Move Unsafe based operations to UnsafeAccessMajor.
HBASE-13917Remove string comparison to identify request priorityMinorregionserver
HBASE-13876Improving performance of HeapMemoryManagerMinorhbase, regionserver
HBASE-13247Change BufferedMutatorExample to use addColumn() since add() is deprecatedTrivialClient
HBASE-13894Avoid visitor alloc each call of ByteBufferArray get/putMultiple()Minorregionserver
HBASE-13829Add more ThrottleTypeMajorClient
HBASE-13755Provide single super user check implementationMajorsecurity
HBASE-13848Access InfoServer SSL passwords through Credential Provder APIMajorsecurity
HBASE-13828Add group permissions testing coverage to AC.Majortest
HBASE-13846Run MiniCluster on top of other MiniDfsClusterMinortest
HBASE-13816Build shaded modules only in release profileMajorbuild
HBASE-13344Add enforcer rule that matches our JDK support statementMinorbuild
HBASE-13761Optimize FuzzyRowFilterMinorFilters
HBASE-13710Remove use of Hadoop's ReflectionUtil in favor of our own.Minor.
HBASE-13780Default to 700 for HDFS root dir permissions for secure deploymentsMajorOperability, security
HBASE-13671More classes to add to the invoking repository of org.apache.hadoop.hbase.mapreduce.driverMajormapreduce
HBASE-13745Say why a flush was requested in log messageMinorOperability
HBASE-13645Rename *column methods in MasterObserver to *columnFamilyMinor.
HBASE-13725[documentation] Pseudo-Distributed Local Install can link to hadoop instructionsMinor.
HBASE-13656Rename getDeadServers to getDeadServersSize in AdminMinor.
HBASE-13675ProcedureExecutor completion report should be at DEBUG log levelMinor.
HBASE-13673WALProcedureStore procedure is chattyMinor.
HBASE-13677RecoverableZookeeper WARNs on expected eventsMinor.
HBASE-13684Allow mlockagent to be used when not starting as rootMinor.
HBASE-13655Deprecate duplicate getCompression methods in HColumnDescriptorMinor.
HBASE-13251Correct ‘HBase, MapReduce, and the CLASSPATH’ section in HBase Ref GuideMajordocumentation
HBASE-13598Make hbase assembly ‘attach’ to the projectMinor.
HBASE-12415Add add(byte[][] arrays) to Bytes.MajorAPI, Client
HBASE-13358Upgrade VisibilityClient API to accept Connection object.MinorAPI, security
HBASE-13420RegionEnvironment.offerExecutionLatency Blocks Threads under Heavy LoadMajorCoprocessors, metrics, Performance
HBASE-13351Annotate internal MasterRpcServices methods with admin priorityMajormaster
HBASE-13431Allow to skip store file range check based on column family while creating reference files in HRegionFileSystem#splitStoreFileMajor.
HBASE-13578Remove Arrays.asList().subList() from FSHLog.offer()Trivialwal
HBASE-13518Typo in hbase.hconnection.meta.lookup.threads.core parameterMajor.
HBASE-13516Increase PermSize to 128MBMajor.
HBASE-13255Bad grammar in RegionServer status pageTrivialmonitoring
HBASE-13334FindBugs should create precise report for new bugs introducedMinorbuild
HBASE-13550[Shell] Support unset of a list of table attributesMinor.
HBASE-13552ChoreService shutdown message could be more informativeTrivial.
HBASE-13534Change HBase master WebUI to explicitly mention if it is a backup masterMinormaster, UI
HBASE-13456Improve HFilePrettyPrinter first hbase:meta region processingMinorutil
HBASE-12987HBCK should print status while scanning over many regionsMajorhbck, Usability
HBASE-13350Add a debug-warn if we fail HTD checks even if table.sanity.checks is falseTrivialmaster, Operability
HBASE-13453Master should not bind to region server portsCritical.
HBASE-13419Thrift gateway should propagate text from exception causes.MajorThrift
HBASE-13436Include user name in ADE for scansMinor.
HBASE-13381Expand TestSizeFailures to include small scansMinortest
HBASE-13270Setter for Result#getStats is #addResults; confusing!MajorClient
HBASE-13362Set max result size from client only (like scanner caching).Major.
HBASE-11864Enhance HLogPrettyPrinter to print information from WAL HeaderMinor.
HBASE-13370PE tool could give option for using Explicit Column Tracker which leads to seeksMajor.
HBASE-6919Remove unnecessary throws IOException from Bytes.readVLongMinor.
HBASE-12891Parallel execution for Hbck checkRegionConsistencyMajorhbck
HBASE-13341Add option to disable filtering on interface annotations for the API compatibility reportMinor.
HBASE-13340Include LimitedPrivate interfaces in the API compatibility reportMinorAPI
HBASE-13366Throw DoNotRetryIOException instead of read only IOExceptionMinor.
HBASE-13345Fix LocalHBaseCluster so that different region server impl can be used for different slavesMinor.
HBASE-13348Separate the thread number configs for meta server and server operationsMinormaster
HBASE-12975Supportable SplitTransaction and RegionMergeTransaction interfacesMajor.
HBASE-13369Expose scanNext stats to region server levelMajor.
HBASE-13222Provide means of non-destructive balancer inspectionMinorBalancer
HBASE-13316Reduce the downtime on planned moves of regionsMinorBalancer
HBASE-13342Fix incorrect interface annotationsMajor.
HBASE-13199Some small improvements on canary toolMajor.
HBASE-13286Minimum timeout for a rpc call could be 1 ms instead of 2 secondsMinorClient
HBASE-13241Add tests for group level grantsCriticalsecurity, test
HBASE-13235Revisit the security auditing semantics.Major.
HBASE-13216Add version info in RPC connection headerMinorClient, IPC/RPC
HBASE-13109Make better SEEK vs SKIP decisions during scanningMajor.
HBASE-13256HBaseConfiguration#checkDefaultsVersion(Configuration) has spelling errorTrivialClient
HBASE-13223Add testMoveMeta to IntegrationTestMTTRMajorintegration tests
HBASE-13240add an exemption to test-patch for build-only changes.Minorbuild
HBASE-13236Clean up m2e-related warnings/errors from pomsMinorbuild
HBASE-13162Add capability for cleaning hbase acls to hbase cleanup script.Minor.
HBASE-12405WAL accounting by StoreMajorwal
HBASE-13185Document hbase.regionserver.thrift.framed.max_frame_size_in_mb more clearlyTrivialdocumentation
HBASE-13183Make ZK tickTime configurable in standalone HBaseMinormaster
HBASE-12706Support multiple port numbers in ZK quorum stringCritical.
HBASE-13142[PERF] Reuse the IPCUtil#buildCellBlock bufferMajorPerformance
HBASE-13122Improve efficiency for return codes of some filtersMajorFilters
HBASE-13128Make HBCK's lock file retry creation and deletionMinorhbck
HBASE-13100Shell command to retrieve table splitsMinorshell
HBASE-13132Improve RemoveColumn action debug messageTrivialintegration tests
HBASE-13138Clean up TestMasterObserver (debug, trying to figure why fails)Majortest
HBASE-13120Allow disabling hadoop classpath and native library lookupMajorhbase
HBASE-13086Show ZK root node on Master WebUIMinormaster
HBASE-13080Hbase shell message containing extra quote at the end of error message.Trivial.
HBASE-13054Provide more tracing information for locking/latching events.Major.
HBASE-13056Refactor table.jsp code to remove repeated code and make it easier to add new checksMajor.
HBASE-13002Make encryption cipher configurableMajor.
HBASE-13059Set executable bit for scripts in dev-supportTrivialscripts
HBASE-13044Configuration option for disabling coprocessor loadingMinor.
HBASE-13018WALSplitter should not try to get table states while splitting METACritical.
HBASE-13016Clean up remnants of table states stored in table descriptorsMajor.
HBASE-12035Keep table state in METACriticalClient, master
HBASE-12982Adding timeouts to TestChoreServiceMajor.
HBASE-12957region_mover#isSuccessfulScan may be extremely slow on region with lots of expired dataMinorscripts
HBASE-8329Limit compaction speedMajorCompaction
HBASE-12808Use Java API Compliance Checker for binary/source compatibilityMajortest
HBASE-12627Add back snapshot batching facility from HBASE-11360 dropped by HBASE-11742Majormaster, scaling
HBASE-12896checkstyle report diff toolMinorbuild
HBASE-12887Cleanup many checkstyle errors in o.a.h.h.clientMinorbuild, Client
HBASE-12840Improve unit test coverage of the client pushback mechanismMajor.
HBASE-12620Add HBASE-11639 related items to Ref GuideMajordocumentation
HBASE-7541Convert all tests that use HBaseTestingUtility.createMultiRegions to HBA.createTableMajor.
HBASE-11144Filter to support scanning multiple row key rangesMajorFilters
HBASE-12839Remove synchronization in ServerStatisticsTrackerMinor.
HBASE-12796Clean up HTable and HBaseAdmin deprecated constructor usageMajor.
HBASE-12761On region jump ClientScanners should get next row start key instead of a skip.Major.
HBASE-11869Support snapshot ownerMinor.
HBASE-12429Add port to ClusterManager's actions.Majorintegration tests
HBASE-12590A solution for data skew in HBase-Mapreduce JobMajormapreduce
HBASE-12223MultiTableInputFormatBase.getSplits is too slowMinorClient
HBASE-10201Port ‘Make flush decisions per column family’ to trunkMajorwal
HBASE-12601Explain how to grant/revoke permission to a group/namespace in grant/revoke command usageMinordocumentation, security, shell
HBASE-12650Move ServerName to hbase-common moduleBlocker.
HBASE-12559Provide LoadBalancer with online configuration capabilityMajor.
HBASE-11939Document compressed blockcacheMajordocumentation
HBASE-12207A script to help keep your Git repo freshMajordocumentation, scripts
HBASE-12251[book] Hadoop compat matrix 0.94 section needs cleaned upMajordocumentation
HBASE-12220Add hedgedReads and hedgedReadWins metricsMajor.
HBASE-12195Fix dev-support/findHangingTestsMinortest
HBASE-12003Fix SecureBulkLoadEndpoint class javadoc formattingTrivialdocumentation, security
HBASE-6290Add a function a mark a server as dead and start the recovery the processMinormonitoring
HBASE-11862Get rid of Writables in HTableDescriptor, HColumnDescriptorMinor.
HBASE-11760Tighten up region state transitionMajorRegion Assignment
HBASE-11611Clean up ZK-based region assignmentMajorRegion Assignment
HBASE-11585PE: Allows warm-upTrivialtest
HBASE-3135Make our MR jobs implement Tool and use ToolRunner so can do -D trickery, etc.Major.
HBASE-11548[PE] Add ‘cycling’ test N times and unit tests for size/zipf/valueSize calculationsTrivialtest
HBASE-11400Edit, consolidate, and update Compression and data encoding docsMinordocumentation
HBASE-5696Use Hadoop's DataOutputOutputStream instead of have a copy localMajor.
HBASE-11344Hide row keys and such from the web UIsMajor.
HBASE-6580Deprecate HTablePool in favor of HConnection.getTable(...)Major.

BUG FIXES:

JIRASummaryPriorityComponent
HBASE-19924hbase rpc throttling does not work for multi() with request count rater.Majorrpc
HBASE-20293get_splits returns duplicate split points when region replication is onMinorshell
HBASE-20464Disable IMCMajorin-memory-compaction
HBASE-20442clean up incorrect use of commons-collections 3Majordependencies, thirdparty
HBASE-20440Clean up incorrect use of commons-lang 2.yMajordependencies
HBASE-20439Clean up incorrect use of commons-logging in hbase-serverMinordependencies, logging
HBASE-20398Redirect doesn't work on web UIMajorUI
HBASE-20399Fix merge layoutMinorUI
HBASE-20233[metrics] Ill-formatted numRegions metric in “Hadoop:service=HBase,name=RegionServer,sub=Regions” mbeanTrivialmetrics, Operability
HBASE-20410upgrade protoc compiler to 3.5.1-1Criticalbuild, dependencies, Protobufs
HBASE-20224Web UI is broken in standalone modeBlockerUI, Usability
HBASE-20394HBase over rides the value of HBASE_OPTS (if any) set by clientMinorOperability
HBASE-20397Make it more explicit that monkey.properties is found on CLASSPATHTrivial.
HBASE-20376RowCounter and CellCounter documentations are incorrectMinordocumentation, mapreduce
HBASE-20330ProcedureExecutor.start() gets stuck in recover lease on store.Majorproc-v2
HBASE-20350NullPointerException in Scanner during close()Blocker.
HBASE-20280Fix possibility of deadlocking in refreshFileConnections when prefetch is enabledMajorBucketCache
HBASE-20310[hbck] bin/hbase hbck -metaonly shows false inconsistency on HBase 2Majorhbck
HBASE-20219An error occurs when scanning with reversed=true and loadColumnFamiliesOnDemand=trueCriticalphoenix
HBASE-20358Fix bin/hbase thrift usage textMinor.
HBASE-20382If RSGroups not enabled, rsgroup.jsp prints stack traceMajorrsgroup, UI
HBASE-20385Purge md5-making from our little make_rc.sh scriptMinor.
HBASE-20384[AMv2] Logging format improvements; use encoded name rather than full region name marking transitionsMinor.
HBASE-20182Can not locate region after split and mergeBlockerRegion Assignment
HBASE-20363TestNamespaceAuditor.testRegionMerge is flakyMajortest
HBASE-20362TestMasterShutdown.testMasterShutdownBeforeStartingAnyRegionServer is flakyMajortest
HBASE-20295TableOutputFormat.checkOutputSpecs throw NullPointerException ExceptionMajormapreduce
HBASE-20343[DOC] fix log directory pathsCriticaldocumentation
HBASE-16499slow replication for small HBase clustersCriticalReplication
HBASE-17518HBase Reference Guide has a syntax errorMinordocumentation
HBASE-20231Not able to delete column family from a row using RemoteHTableMajorREST
HBASE-20259Doc configs for in-memory-compaction and add detail to in-memory-compaction loggingCritical.
HBASE-17631Canary interval too lowMajorcanary
HBASE-20282Provide short name invocations for useful toolsMajordocumentation, tooling
HBASE-20314Precommit build for master branch fails because of surefire fork failsMajorbuild
HBASE-20261Table page (table.jsp) in Master UI does not show replicaIds for hbase meta tableMinorUI
HBASE-20229ConnectionImplementation.locateRegions() returns duplicated entries when region replication is onMajor.
HBASE-20308test Dockerfile needs to include gitBlockerbuild, test
HBASE-20130Use defaults (16020 & 16030) as base ports when the RS is bound to localhostCriticaldocumentation
HBASE-20111Able to split region explicitly even on shouldSplit return false from split policyCritical.
HBASE-20292Wrong URLs in the descriptions for update_all_config and update_config commands in shellTrivialshell
HBASE-13300Fix casing in getTimeStamp() and setTimestamp() for MutationsCriticalAPI
HBASE-20237Put back getClosestRowBefore and throw UnknownProtocolException instead... for asynchbase clientCriticalcompatibility, Operability
HBASE-20090Properly handle Preconditions check failure in MemStoreFlusher$FlushHandler.runMajor.
HBASE-19639ITBLL can't go big because RegionTooBusyException... Above memstore limitBlocker.
HBASE-20213[LOGGING] Aligning formatting and logging less (compactions, in-memory compactions)Majorlogging
HBASE-20141Fix TooManyFiles exception when RefreshingChannels in FileIOEngineMajorBucketCache
HBASE-18216[AMv2] Workaround for HBASE-18152, corrupt procedure WALMajorproc-v2
HBASE-20200list_procedures fails in shellMajorshell
HBASE-20185Fix ACL check for MasterRpcServices#execProcedureMajor.
HBASE-20146Regions are stuck while opening when WAL is disabledCriticalwal
HBASE-20187Shell startup fails with IncompatibleClassChangeErrorBlockershell
HBASE-20189Typo in Required Java Version error message while building HBase.Trivialbuild
HBASE-20078MultiByteBuff : bug in reading primitives when individual buffers are too smallMajor.
HBASE-19075Task tabs on master UI cause page scrollMajormaster
HBASE-20104Fix infinite loop of RIT when creating table on a rsgroup that has no online serversMajorrsgroup
HBASE-19802Wrong usage messages on shell commands (grant/revoke namespace syntax)Minorshell
HBASE-20153enable error-prone analysis in precommitMajorcommunity
HBASE-20024TestMergeTableRegionsProcedure is STILL flakeyMajor.
HBASE-19598Fix TestAssignmentManagerMetrics flaky testMajortest
HBASE-20162[nightly] depending on pipeline execution we sometimes refer to the wrong workspaceCriticaltest
HBASE-20164failed hadoopcheck should add footer linkMajorcommunity
HBASE-20160TestRestartCluster.testRetainAssignmentOnRestart uses the wrong condition to decide whether the assignment is finishedMajorRegion Assignment
HBASE-20114Fix IllegalFormatConversionException in rsgroup.jspMajorUI
HBASE-20144The shutdown of master will hang if there are no live region serverMajorRecovery
HBASE-19987update error-prone to 2.2.0Major.
HBASE-20108`hbase zkcli` falls into a non-interactive prompt after HBASE-15199CriticalUsability
HBASE-19814Release hbase-2.0.0-beta-2; “rolling upgrade” releaseBlocker.
HBASE-20134support scripts use hard-coded /tmpMinorwebsite
HBASE-20070website generation is failingBlockerwebsite
HBASE-19147All branch-2 unit tests passBlockertest
HBASE-20110Findbugs in zk and mr caused nightly #409 branch-2 to failMajorfindbugs
HBASE-19656Disable TestAssignmentManagerMetrics for beta-1Major.
HBASE-19863java.lang.IllegalStateException: isDelete failed when SingleColumnValueFilter is usedMajorFilters
HBASE-20106API Compliance checker should fall back to specifying origin as remote repoMajorAPI, community
HBASE-20066Region sequence id may go backward after split or mergeCritical.
HBASE-20086PE randomSeekScan fails with ClassNotFoundExceptionMajor.
HBASE-20074[FindBugs] Same code on both branches in CompactingMemStore#initMemStoreCompactorMajorfindbugs
HBASE-19974Fix decommissioned servers cannot be removed by remove_servers_rsgroup methodsMajorrsgroup
HBASE-20043ITBLL fails against hadoop3Majorintegration tests
HBASE-19583update RM list to remove EOM versionsMinorcommunity, documentation
HBASE-19728Add lock to filesCompacting in all place.Major.
HBASE-20061HStore synchronized member variable filesCompacting should be privateMajorregionserver
HBASE-20062findbugs is not running on precommit checksBlockercommunity, test
HBASE-20054Forward port HBASE-18282 ReplicationLogCleaner can delete WALs not yet replicated in case of KeeperExceptionMajor.
HBASE-20049Region replicas of SPLIT and MERGED regions are kept in in-memory states until restarting masterMajorread replicas
HBASE-19767Master web UI shows negative values for Remaining KVsMajor.
HBASE-19391Calling HRegion#initializeRegionInternals from a region replica can still re-create a region directoryMajor.
HBASE-19166AsyncProtobufLogWriter persists ProtobufLogWriter as class name for backward compatibilityBlockerwal
HBASE-20027Add test TestClusterPortAssignmentMajor.
HBASE-19953Avoid calling post* hook when procedure failsCriticalmaster, proc-v2
HBASE-20037Race when calling SequenceIdAccounting.resetHighestBlockerwal
HBASE-19991lots of hbase-rest test failures against hadoop 3MajorREST, test
HBASE-19920TokenUtil.obtainToken unnecessarily creates a local directoryMajor.
HBASE-20017BufferedMutatorImpl submit the same mutation repeatedlyBlockerClient
HBASE-20032Receving multiple warnings for missing reporting.plugins.plugin.versionMinorhbase
HBASE-19954Separate TestBlockReorder into individual tests to avoid ShutdownHook suppression error against hadoop3Major.
HBASE-20023CompactionTool command line examples are incorrectTrivialhbase
HBASE-14897TestTableLockManager.testReapAllTableLocks is flakeyMajor.
HBASE-20020Make sure we throw DoNotRetryIOException when ConnectionImplementation is closedCriticalClient
HBASE-19980NullPointerException when restoring a snapshot after splitting a regionMajorsnapshots
HBASE-19998Flakey TestVisibilityLabelsWithDefaultVisLabelServiceMajorflakey, test
HBASE-19996Some nonce procs might not be cleaned up (follow up HBASE-19756)Major.
HBASE-18282ReplicationLogCleaner can delete WALs not yet replicated in case of a KeeperExceptionCriticalReplication
HBASE-19979ReplicationSyncUp tool may leak Zookeeper connectionMajorReplication
HBASE-19876The exception happening in converting pb mutation to hbase.mutation messes up the CellScannerCritical.
HBASE-19977FileMmapEngine allocation of byte buffers should be synchronizedMajor.
HBASE-19986If HBaseTestClassRule timesout a test, thread dump.Major.
HBASE-19968MapReduce test fails with NoClassDefFoundError against hadoop3Major.
HBASE-160601.x clients cannot access table state talking to 2.0 clusterBlocker.
HBASE-19972Should rethrow the RetriesExhaustedWithDetailsException when failed to apply the batch in ReplicationSinkCriticalReplication
HBASE-19964TestWriteHeavyIncrementObserver failsMajortest
HBASE-19966The WriteEntry for WALKey maybe null if we failed to call WAL.appendMajorwal
HBASE-19937Ensure createRSGroupTable be called after ProcedureExecutor and LoadBalancer are initializedMajorrsgroup
HBASE-19929Call RS.stop on a session expired RS may hangMajorwal
HBASE-19900Region-level exception destroy the result of batchCritical.
HBASE-19941Flaky TestCreateTableProcedure times out in nightly, needs to LargeTestsMajortest
HBASE-19934HBaseSnapshotException when read replicas is enabled and online snapshot is taken after region splittingMajorsnapshots
HBASE-19939TestSplitTableRegionProcedure#testSplitWithoutPONR() and testRecoveryAndDoubleExecution() are failing with NPEMajoramv2
HBASE-19907TestMetaWithReplicas still flakeyMajor.
HBASE-19907TestMetaWithReplicas still flakeyMajor.
HBASE-19926Use a separated class to implement the WALActionListener for ReplicationMajorReplication, wal
HBASE-19703Functionality added as part of HBASE-12583 is not working after moving the split code to masterMajor.
HBASE-19658Fix and reenable TestCompactingToCellFlatMapMemStore#testFlatteningToJumboCellChunkMapMajortest
HBASE-19905ReplicationSyncUp tool will not exit if a peer replication is disabledMajorReplication
HBASE-19726Failed to start HMaster due to infinite retrying on meta assignMajor.
HBASE-19919Tidying up loggingMajor.
HBASE-19901Up yetus proclimit on nightliesMajor.
HBASE-19884BucketEntryGroup's equals, hashCode and compareTo methods are not consistentMajor.
HBASE-19906TestZooKeeper TimeoutMajor.
HBASE-19892Checking ‘patch attach’ and yetus 0.7.0 and move to Yetus 0.7.0Major.
HBASE-19871delete.rb should require user to provide the columnMajorshell
HBASE-19818Scan time limit not work if the filter always filter row keyMajor.
HBASE-19756Master NPE during completed failed proc evictionMajor.
HBASE-17079HBase build fails on windows, hbase-archetype-builder is reason for failureMajorbuild
HBASE-19853duplicate slf4j declaration in mapreduce pomMinordependencies
HBASE-19838Can not shutdown backup master cleanly when it has already tried to become the active masterCriticalmaster
HBASE-19780Change execution phase of checkstyle plugin back to default ‘verify’Major.
HBASE-19774incorrect behavior of locateRegionInMetaMajor.
HBASE-17513Thrift Server 1 uses different QOP settings than RPC and Thrift Server 2 and can easily be misconfigured so there is no encryption when the operator expects it.Criticaldocumentation, security, Thrift, Usability
HBASE-19836Fix TestZooKeeper.testLogSplittingAfterMasterRecoveryDueToZKExpiryMajortest
HBASE-19794TestZooKeeper hangsCritical.
HBASE-19828Flakey TestRegionsOnMasterOptions.testRegionsOnAllServersMajor.
HBASE-19829hadoop-minicluster pulls zookeeper:test-jar:tests 3.4.6Minor.
HBASE-19163“Maximum lock count exceeded” from region server's batch processingMajorregionserver
HBASE-19757System table gets stuck after enabling region server group feature in secure clusterCritical.
HBASE-19825Fix hadoop3 compat test failuresMajorpom
HBASE-19822HFileCleaner threads stick around after shutdown stuck on queue#takeMajor.
HBASE-19815Flakey TestAssignmentManager.testAssignWithRandExecMajorflakey, test
HBASE-19821TestCleanerChore#testOnConfigurationChange() requires at least 4 processors to get passedMinortest
HBASE-19806Lower max versions for table column family of hbase:metaTrivial.
HBASE-19812TestFlushSnapshotFromClient fails because of failing region.flushMajor.
HBASE-19816Replication sink list is not updated on UnknownHostExceptionMajorReplication
HBASE-19784stop-hbase gives unfriendly message when local hbase isn't runningMinorscripts
HBASE-19196Release hbase-2.0.0-beta-1; the “Finish-line” releaseBlocker.
HBASE-19808Reenable TestMultiParallelMajortest
HBASE-19792TestReplicationSmallTests.testDisableEnable failsMajortest
HBASE-19797Operator priority leads to wrong logic in ReplicationSourceWALReaderMajor.
HBASE-19732Replica regions does not return back the MSLAB chunks to poolCritical.
HBASE-19768RegionServer startup failing when DN is deadCritical.
HBASE-19752RSGroupBasedLoadBalancer#getMisplacedRegions() should handle the case where rs group cannot be determinedMajor.
HBASE-11409Add more flexibility for input directory structure to LoadIncrementalHFilesMajor.
HBASE-19694The initialization order for a fresh cluster is incorrectCritical.
HBASE-19769IllegalAccessError on package-private Hadoop metrics2 classes in MapReduce jobsCriticalmapreduce, metrics
HBASE-19775hbase shell doesn't handle the exceptions that are wrapped in java.io.UncheckedIOExceptionMajorshell
HBASE-19771restore_snapshot shell command gives wrong namespace if the namespace doesn't existMinor.
HBASE-19773Adding javadoc around getting instance of RawCellBuilderMinor.
HBASE-19685Fix TestFSErrorsExposed#testFullSystemBubblesFSErrorsMajortest
HBASE-19755Error message for non-existent namespace is inaccurateMinor.
HBASE-19749Revisit logic of UserScanQueryMatcher#mergeFilterResponse methodMajor.
HBASE-19740Repeated error message for NamespaceExistExceptionMinor.
HBASE-19734IntegrationTestReplication broken w/ separate clustersCriticalintegration tests
HBASE-19729UserScanQueryMatcher#mergeFilterResponse should return INCLUDE_AND_SEEK_NEXT_ROW when filterResponse is INCLUDE_AND_SEEK_NEXT_ROWMajor.
HBASE-19744Fix flakey TestZKLeaderManagerMajortest
HBASE-19717IntegrationTestDDLMasterFailover is using outdated values for DataBlockEncodingMajorintegration tests
HBASE-19424Metrics servlet throws NPEMinor.
HBASE-19712Fix TestSnapshotQuotaObserverChore#testSnapshotSizeMajortest
HBASE-19696Filter returning INCLUDE_AND_NEXT_COL doesn't skip remaining versions when scan has explicit columnsCritical.
HBASE-19721Unnecessary stubbings detected in test class: TestReversedScannerCallableMajortest
HBASE-19714`status ‘detailed’` invokes nonexistent “getRegionsInTransition” method on ClusterStatusCriticalshell
HBASE-19709Guard against a ThreadPool size of 0 in CleanerChoreCritical.
HBASE-19383[1.2] java.lang.AssertionError: expected:<2> but was:<1> at org.apache.hadoop.hbase.TestChoreService.testTriggerNowFailsWhenNotScheduled(TestChoreService.java:707)Majortest
HBASE-19688TimeToLiveProcedureWALCleaner should extends BaseLogCleanerDelegateMinor.
HBASE-18452VerifyReplication by Snapshot should cache HDFS token before submit job for kerberos env.Major.
HBASE-19588Additional jar dependencies needed for mapreduce PerformanceEvaluationMinortest
HBASE-19490Rare failure in TestRateLimiterMajortest
HBASE-19691Do not require ADMIN permission for obtaining ClusterStatusCritical.
HBASE-19392TestReplicaWithCluster#testReplicaGetWithPrimaryAndMetaDown failure in masterMinorregionserver
HBASE-19654Remove misleading and chatty debug message in ReplicationLogCleanerMajor.
HBASE-19666TestDefaultCompactSelection test failedCriticaltest
HBASE-19671Fix TestMultiParallel#testActiveThreadsCountMinortest
HBASE-19672Correct comments for default values of major compaction in SortedCompactionPolicy#getNextMajorCompactTime()Minor.
HBASE-19643Need to update cache location when get error in AsyncBatchRpcRetryingCallerMajor.
HBASE-19619Modify replication_admin.rb to use ReplicationPeerConfigBuilderCritical.
HBASE-19624TestIOFencing hangsMajor.
HBASE-19496Reusing the ByteBuffer in rpc layer corrupt the ServerLoad and RegionLoadBlocker.
HBASE-19457Debugging flaky TestTruncateTableProcedure#testRecoveryAndDoubleExecutionPreserveSplitsMajor.
HBASE-19608Race in MasterRpcServices.getProcedureResultMajorproc-v2
HBASE-19593Possible NPE if wal is closed during waledit append.Major.
HBASE-19589New regions should always be added with state CLOSED (followup of HBASE-19530)Major.
HBASE-17248SimpleRegionNormalizer javadoc correctionTrivialmaster
HBASE-19148Reevaluate default values of configurationsBlockerdefaults
HBASE-19578MasterProcWALs cleaning is incorrectCriticalamv2
HBASE-19559Fix TestLogRolling.testLogRollOnDatanodeDeathMajortest, wal
HBASE-19218Master stuck thinking hbase:namespace is assigned after restart preventing intializationCritical.
HBASE-19542fix TestSafemodeBringsDownMasterMajor.
HBASE-19563A few hbase-procedure classes missing @InterfaceAudience annotationMinorproc-v2
HBASE-19561maxCacheSize in CacheEvictionStats can't be accumulated repeatedly When dealing with each regionMajor.
HBASE-19558TestRegionsOnMasterOptions hack so it works reliabllyMajortest
HBASE-19555TestSplitTransactionOnCluster is flakyMajortest
HBASE-19532AssignProcedure#COMPARATOR may produce incorrect sort orderCritical.
HBASE-19549Change path comparison in CommonFSUtilsMajor.
HBASE-19546TestMasterReplication.testCyclicReplication2 uses wrong assertionMajorReplication, test
HBASE-19522The complete order may be wrong in AsyncBufferedMutatorImplMajor.
HBASE-19530New regions should always be added with state CLOSEDMajor.
HBASE-19509RSGroupAdminEndpoint#preCreateTable triggers TableNotFoundExceptionMinor.
HBASE-18352Enable TestMasterOperationsForRegionReplicas#testCreateTableWithMultipleReplicas disabled by Proc-V2 AM in HBASE-14614Majortest
HBASE-18838shaded artifacts are incorrect when built against hadoop 3CriticalClient
HBASE-18946Stochastic load balancer assigns replica regions to the same RSMajor.
HBASE-19516IntegrationTestBulkLoad and IntegrationTestImportTsv run into ‘java.lang.RuntimeException: DistributedHBaseCluster@1bb564e2 not an instance of MiniHBaseCluster’Major.
HBASE-19513Fix the wrapped AsyncFSOutput implementationMajorwal
HBASE-19511Splits causes blocks to be cached again and so such blocks cannot be evicted from bucket cacheCriticalBucketCache
HBASE-19510TestDistributedLogSplitting is flakey for AsyncFSWALCriticalRecovery, test
HBASE-19287master hangs forever if RecoverMeta send assign meta region request to target server failMajorproc-v2
HBASE-19503Fix TestWALOpenAfterDNRollingStart for AsyncFSWALMajorReplication, wal
HBASE-19434create_namespace command for existing namespace does not throw useful error messageMinor.
HBASE-19484The value array written by ExtendedCell#write is out of boundsBlocker.
HBASE-19508ReadOnlyConfiguration throws exception if any Configuration in current context calls addDefautlResourceMajorconf
HBASE-19456RegionMover's region server hostname option is no longer case insensitiveMajortooling
HBASE-19495Fix failed ut TestShellMajor.
HBASE-19394Support multi-homing env for the publication of RS status with multicast (hbase.status.published)MajorClient, master
HBASE-19493Make TestWALMonotonicallyIncreasingSeqId also work with AsyncFSWALMajortest
HBASE-19371Running WALPerformanceEvaluation against asyncfswal throws exceptionsMajor.
HBASE-19134Make WALKey an Interface; expose Read-Only version to CPsMajorCoprocessors, wal
HBASE-19461TestRSGroups is brokeMajortest
HBASE-19433ChangeSplitPolicyAction modifies an immutable HTableDescriptorCriticalintegration tests
HBASE-19454Debugging TestDistributedLogSplitting#testThreeRSAbortMajor.
HBASE-19349Introduce wrong version depencency of servlet-api jarCritical.
HBASE-19435Reopen Files for ClosedChannelException in BucketCacheMajorBucketCache
HBASE-12444Total number of requests overflow because it's intMinorhbck, master, regionserver
HBASE-19447INFO level logging of GetClusterStatus from HMaster is too chattyMajor.
HBASE-19417Remove boolean return value from postBulkLoadHFile hookMajor.
HBASE-19445PerformanceEvaluation NPE processing split policy optionTrivial.
HBASE-19023Usage for rowcounter in refguide is out of sync with codeMajor.
HBASE-19422using hadoop-profile property leads to confusing failuresMajor.
HBASE-19384Results returned by preAppend hook in a coprocessor are replaced with null from other coprocessor even on bypassCriticalCoprocessors
HBASE-19431The tag array written by IndividualBytesFieldCell#write is out of boundsCritical.
HBASE-18942hbase-hadoop2-compat module ignores hadoop-3 profileMajor.
HBASE-19056TestCompactionInDeadRegionServer is top of the flakies charts!Majortest
HBASE-19339Eager policy results in the negative size of memstoreCritical.
HBASE-16239Better logging for RPC related exceptionsMajor.
HBASE-19396Fix flaky test TestHTableMultiplexerFlushCacheMinortest
HBASE-19406Fix CompactionRequest equals and hashCodeMajor.
HBASE-19285Add per-table latency histogramsCriticalmetrics
HBASE-19390Revert to older version of Jetty 9.3Major.
HBASE-19385[1.3] TestReplicator failed 1.3 nightlyMajortest
HBASE-19350TestMetaWithReplicas is flakyMajor.
HBASE-19388Incorrect value is being set for Compaction Pressure in RegionLoadStats object inside HRegion classMinorregionserver
HBASE-19386HBase UnsafeAvailChecker returns false on Arm64Minor.
HBASE-19363Tests under TestCheckAndMutate are identicalMinor.
HBASE-19035Miss metrics when coprocessor use region scanner to read dataMajor.
HBASE-19351Deprecated is missing in Table implementationsMinor.
HBASE-19355Missing dependency on hbase-zookeeper module causes CopyTable to failMajor.
HBASE-19335Fix waitUntilAllRegionsAssignedMajor.
HBASE-19318MasterRpcServices#getSecurityCapabilities explicitly checks for the HBase AccessController implementationCriticalmaster, security
HBASE-19319Fix bug in synchronizing over ProcedureEventMajor.
HBASE-19325Pass a list of server name to postClearDeadServersMajor.
HBASE-19337AsyncMetaTableAccessor may hang when call ScanController.terminate many timesMajor.
HBASE-19332DumpReplicationQueues misreports total WAL sizeTrivialReplication
HBASE-19310Verify IntegrationTests don't rely on Rules outside of JUnit contextCriticalintegration tests
HBASE-19317Increase “yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage” to avoid host-related failures on MiniMRClusterMajorintegration tests, test
HBASE-19330Remove duplicated dependency from hbase-restTrivialdependencies
HBASE-19321ZKAsyncRegistry ctor would hang when zookeeper cluster is not availableMajor.
HBASE-19315Incorrect snapshot version is used for 2.0.0-beta-1Minor.
HBASE-19304KEEP_DELETED_CELLS should ignore caseBlockerregionserver
HBASE-19260Add lock back to avoid parallel accessing meta to locate regionMajor.
HBASE-19181LogRollBackupSubprocedure will fail if we use AsyncFSWAL instead of FSHLogMajorbackup&restore
HBASE-18356Enable TestFavoredStochasticBalancerPickers#testPickers that was disabled by Proc-V2 AM in HBASE-14614Majortest
HBASE-18357Enable disabled tests in TestHCM that were disabled by Proc-V2 AM in HBASE-14614Majortest
HBASE-19223Remove references to Date Tiered compaction from branch-1.2 and branch-1.1 ref guideCriticalCompaction, documentation
HBASE-19255PerformanceEvaluation class not found when run PE testMajor.
HBASE-19245MultiTableInputFormatBase#getSplits creates a Connection per TableMinormapreduce
HBASE-12091Optionally ignore edits for dropped tables for replication.Major.
HBASE-19210TestNamespacesInstanceResource failsMajor.
HBASE-19249test for “hbase antipatterns” should check _count_ of occurance rather than text ofCriticalbuild
HBASE-19240Fix error-prone errors, part four?Major.
HBASE-19215Incorrect exception handling on the client causes incorrect call timeouts and byte buffer allocations on the serverMajorrpc
HBASE-19250TestClientClusterStatus is flakyTrivial.
HBASE-19246Trivial fix in findHangingTests.pyTrivial.
HBASE-19244Fix simple typos in HBASE-15518 descriptionsTrivial.
HBASE-19089Fix the list of included moduleSets in src and binary tarsMajorbuild
HBASE-19229Nightly script to check source artifact should not do a destructive git operation without opt-inCriticalbuild
HBASE-19199RatioBasedCompactionPolicy#shouldPerformMajorCompaction() always return true when only one file needs to compactMajor.
HBASE-19195More error-prone fixesMajor.
HBASE-19165TODO Handle stuck in transition: rit=OPENING, location=ve0538....Criticalmigration
HBASE-19184clean up nightly source artifact test to match expectations from switch to git-archiveCriticalbuild
HBASE-19211B&R: update configuration string in BackupRestoreConstantsMinor.
HBASE-19194TestRSGroupsBase has some always false checksBlockerrsgroup, test
HBASE-19088move_tables_rsgroup will throw an exception when the table is disabledMajorrsgroup
HBASE-19198TestIPv6NIOServerSocketChannel fails; unable to bindMinortest
HBASE-19102TestZooKeeperMainServer fails with KeeperException$ConnectionLossExceptionMajor.
HBASE-18844Release hbase-2.0.0-alpha-4; Theme “Coprocessor API Cleanup”Major.
HBASE-19111Add missing CellUtil#isPut(Cell) methodsCriticalClient
HBASE-19160Re-expose CellComparatorCritical.
HBASE-19185ClassNotFoundException: com.fasterxml.jackson.*Criticalmapreduce
HBASE-18983Upgrade to latest error-proneMajorbuild
HBASE-19178table.rb use undefined method ‘getType’ for Cell interfaceTrivial.
HBASE-19117Avoid NPE occurring while active master diesMinor.
HBASE-19173Configure IntegrationTestRSGroup automatically for minicluster modeMinorrsgroup, test
HBASE-19144[RSgroups] Retry assignments in FAILED_OPEN state when servers (re)join the clusterMajorrsgroup
HBASE-19124Move HBase-Nightly source artifact creation test from JenkinsFile to a script in dev-supportMajortest
HBASE-19156Duplicative regions_per_server options on LoadTestToolTrivialtest
HBASE-19118Use SaslUtil to set Sasl.QOP in ‘Thrift’MajorThrift
HBASE-19150TestSnapshotWithAcl is flakyMinor.
HBASE-19120IllegalArgumentException from ZNodeClearer when master shuts downMajor.
HBASE-19065HRegion#bulkLoadHFiles() should wait for concurrent Region#flush() to finishMajor.
HBASE-19100Missing break in catch block of InterruptedException in HRegion#waitForFlushesAndCompactionsMajor.
HBASE-19137Nightly test should make junit reports optional rather than attempt archive after reporting.Criticalbuild
HBASE-19135TestWeakObjectPool time outMajor.
HBASE-19138Rare failure in TestLruBlockCacheTrivialtest
HBASE-19030nightly runs should attempt to log test results after archivingCriticaltest
HBASE-19130Typo in HStore.initializeRegionInternals for replaying walCriticalRecovery
HBASE-19087Log an Optional's value/null instead of Optional[value]/Optional.empty.Major.
HBASE-19129TestChoreService is flaky (branch-1 / branch-1.4)Trivial.
HBASE-19119hbase-http shouldn't have a native profileBlockerbuild
HBASE-18438Precommit doesn't warn about unused importsCriticalbuild
HBASE-18922Fix all dead links in our HBase bookMajordocumentation
HBASE-19094NPE in RSGroupStartupWorker.waitForGroupTableOnline during master startupMinor.
HBASE-13346Clean up Filter package for post 1.0 s/KeyValue/Cell/gCriticalAPI, Filters
HBASE-19098Python based compatiblity checker fails if git repo does not have a remote named ‘origin’Criticaltooling
HBASE-19077Have Region*CoprocessorEnvironment provide an ImmutableOnlineRegionsCriticalCoprocessors
HBASE-19073Cleanup CoordinatedStateManagerMajor.
HBASE-19054Switch precommit docker image to one based on maven imagesMajorbuild, community
HBASE-19018Use of hadoop internals that require bouncycastle should declare bouncycastle dependencyCriticaldependencies, test
HBASE-19021Restore a few important missing logics for balancer in 2.0Critical.
HBASE-19066Correct the directory of openjdk-8 for jenkinsMajorbuild
HBASE-16290Dump summary of callQueue content; can help debuggingMajorOperability
HBASE-18846Accommodate the hbase-indexer/lily/SEP consumer deploy-typeMajor.
HBASE-19072Missing break in catch block of InterruptedException in HRegion#waitForFlushes()Major.
HBASE-19058The wget isn't installed in building docker imageMajorbuild
HBASE-19039refactor shadedjars test to only run on java changes.Majorbuild
HBASE-19060“Hadoop check” test is running all the time instead of just when changes to javaCriticalbuild
HBASE-19061enforcer NPE on hbase-shaded-invariantsBlockerbuild
HBASE-19014surefire fails; When writing xml report stdout/stderr ... No such file or directoryMajor.
HBASE-19042Oracle Java 8u144 downloader broken in precommit checkBlockerbuild
HBASE-19020TestXmlParsing exception checking relies on a particular xml implementation without declaring it.Majordependencies, REST
HBASE-19038precommit mvn install should run from root on patchMajorbuild
HBASE-19032Set Content-Type header for patches uploaded by submit-patch.pyMajor.
HBASE-18350RSGroups are broken under AMv2Blockerrsgroup
HBASE-18990ServerLoad doesn't override #equals which leads to #equals in ClusterStatus always falseTrivial.
HBASE-19017[AMv2] EnableTableProcedure is not retaining the assignmentsMajorRegion Assignment
HBASE-19016Coordinate storage policy property name for table schema and bulkloadMinor.
HBASE-18997Remove the redundant methods in RegionInfoMajor.
HBASE-18355Enable export snapshot tests that were disabled by Proc-V2 AM in HBASE-14614Majortest
HBASE-18505Our build/yetus personality will run tests on individual modules and then on all (i.e. ‘root’). Should do one or otherCriticalbuild
HBASE-18998processor.getRowsToLock() always assumes there is some row being lockedMajor.
HBASE-18992Comparators passed to the Memstore's flattened segments seems to be wrongMajor.
HBASE-17590Drop cache hint should work for StoreFile write pathMajor.
HBASE-18975Fix backup / restore hadoop3 incompatibilityBlocker.
HBASE-18904Missing break in NEXT_ROW case of FilterList#mergeReturnCodeForOrOperator()Minor.
HBASE-18934precommit on branch-1 isn't supposed to run against hadoop 3Criticaltest
HBASE-18973clean up maven warnings about pom well-formedness for master/branch-2Minorbuild
HBASE-18958Remove the IS annotation from SpaceLimitingExceptionTrivial.
HBASE-18921Result.current() throws ArrayIndexOutOfBoundsException after calling advance()Minor.
HBASE-18940branch-2 (and probably others) fail check of generated source artifactCriticalbuild
HBASE-18874HMaster abort message will be skipped if Throwable is passed nullMinor.
HBASE-18941Confusing logging error around rerun of restore on an existing table.Minor.
HBASE-18932Backups masking exception in a scenario and though it fails , it shows success message.Major.
HBASE-18606Tests in hbase-spark module fail with UnsatisfiedLinkErrorCriticalspark, test
HBASE-18928Backup delete command shows wrong number of deletes requestedMinor.
HBASE-18490Modifying a table descriptor to enable replicas does not create replica regionsMajorRegion Assignment
HBASE-18913TestShell fails because NoMethodError: undefined method parseColumnMajorshell
HBASE-18894null pointer exception in list_regions in shell commandMajor.
HBASE-17441precommit test “hadoopcheck” not properly testing Hadoop 3 profileBlockerbuild
HBASE-18845TestReplicationSmallTests fails after HBASE-14004MajorReplication
HBASE-18887After full backup passed on hdfs root and incremental failed, full backup cannot be cleanedMajor.
HBASE-18888StealJobQueue should call super() to init the PriorityBlockingQueueMajor.
HBASE-18885HFileOutputFormat2 hardcodes default FileOutputCommitterMajormapreduce
HBASE-18880Failed to start rest server if the value of hbase.rest.threads.max is too small.CriticalREST
HBASE-18762Canary sink type cast errorMajor.
HBASE-18830TestCanaryTool does not check Canary monitor's error codeMajor.
HBASE-18876Backup create command fails to take queue parameter as optionMajor.
HBASE-18796Admin#isTableAvailable returns incorrect result before daughter regions are openedMajor.
HBASE-18866clean up warnings about proto syntaxMinorProtobufs
HBASE-18787Fix the “dependencies connecting to an HBase cluster”Minordocumentation
HBASE-18853hbase-protocol-shaded includes protobuf (since we moved to hbase-thirdparty)Majorthirdparty
HBASE-18852Take down the hbasecon asia banner on home pageMajorwebsite
HBASE-18851LICENSE failure after HADOOP-14799 with Hadoop 3Criticalbuild
HBASE-18832LTT fails with casting exception for HColumnDescriptorMajor.
HBASE-18803Mapreduce job get failed caused by NoClassDefFoundError: org/apache/commons/lang3/ArrayUtilsMajor.
HBASE-18808Ineffective config check in BackupLogCleaner#getDeletableFiles()Major.
HBASE-18836Note need for explicit javax.el and exclude from shaded artifactsBlockerClient
HBASE-18834fix shellcheck warning on hbase personalityMinortest
HBASE-18831Add explicit dependency on javax.elMajordependencies
HBASE-18641Include block content verification logic used in lruCache in bucketCacheMinorregionserver
HBASE-14004[Replication] Inconsistency between Memstore and WAL may result in data in remote cluster that is not in the originCriticalregionserver, Replication
HBASE-18801Bulk load cleanup may falsely deem file deletion successfulMajor.
HBASE-18813TestCanaryTool fails on branch-1 / branch-1.4Major.
HBASE-18818TestConnectionImplemenation failsMajortest
HBASE-16611Flakey org.apache.hadoop.hbase.client.TestReplicasClient.testCancelOfMultiGetMajor.
HBASE-18723[pom cleanup] Do a pass with dependency:analyze; remove unused and explicity list the dependencies we exploitMajorpom
HBASE-18789Displays the reporting interval of each RS on the Master pageMajor.
HBASE-18771Incorrect StoreFileRefresh leading to split and compaction failuresBlocker.
HBASE-18791HBASE_HOME/lib does not contain hbase-mapreduce-${project.version}-tests.jarMajor.
HBASE-17853Link to “Why does HBase care about /etc/hosts?” does not workTrivialdocumentation
HBASE-18759Fix hbase-shaded-check-invariants failureBlockerClient, mapreduce
HBASE-18765The value of balancerRan is true even though no plans are executedMinorrsgroup
HBASE-18543Re-enable test master.TestMasterFailover on masterMajoramv2
HBASE-17713the interface ‘/version/cluster’ with header ‘Accept: application/json’ return is not JSON but plain textMinorREST
HBASE-18757Fix Improper bitwise & in BucketCache offset calculationMajorBucketCache
HBASE-18743HFiles in use by a table which has the same name and namespace with a default table cloned from snapshot may be deleted when that snapshot and default table are deletedCriticalhbase
HBASE-15497Incorrect javadoc for atomicity guarantee of Increment and AppendMinordocumentation
HBASE-16390Fix documentation around setAutoFlushMinordocumentation
HBASE-18741Remove cancel command from backup codeMajor.
HBASE-18461Build broken If the username contains a backslashMinor.
HBASE-18306Get rid of TableDescriptor#getConfigurationCritical.
HBASE-15947Classes used only for tests included in main code baseTrivialbuild, test
HBASE-18714The dropBehind and readahead don't be applied when useHBaseChecksum is enabledMinor.
HBASE-14745Shade the last few dependencies in hbase-shaded-clientBlockerClient, dependencies
HBASE-18665ReversedScannerCallable invokes getRegionLocations incorrectlyCritical.
HBASE-18568Correct metric of numRegionsCriticalmetrics
HBASE-18369hbase thrift web-ui not availableMajorThrift
HBASE-18640Move mapreduce out of hbase-server into separate hbase-mapreduce moduleMajor.
HBASE-18633Add more info to understand the source/scenario of large batch requests exceeding thresholdMajor.
HBASE-18635Fix asciidoc warningsMajor.
HBASE-18671Support Append/Increment in rest apiMajorREST
HBASE-16722Document: Broken link in CatalogJanitorTrivialdocumentation
HBASE-18679YARN may null Counters object and cause an NPE in ITBLLTrivialintegration tests
HBASE-18607fix submit-patch.py to support utf8Trivial.
HBASE-18287Remove log warning in PartitionedMobCompactor.java#getFileStatusMinormob
HBASE-18647Parameter cacheBlocks does not take effect in REST API for scanMajorREST
HBASE-18628ZKPermissionWatcher blocks all ZK notificationsCriticalregionserver
HBASE-18614Setting BUCKET_CACHE_COMBINED_KEY to false disables stats on RS UIMajorregionserver
HBASE-18575[AMv2] Enable and fix TestRestartCluster#testRetainAssignmentOnRestart on masterCriticalamv2
HBASE-18655TestAsyncClusterAdminApi2 failing sometimesMajor.
HBASE-18615hbase-rest tests fail in hbase-2.0.0-alpha2Blockertest
HBASE-18644Duplicate “compactionQueueLength” metric in Region Server metricsMinormetrics
HBASE-16615Fix flaky TestScannerHeartbeatMessagesMajorClient, Scanners
HBASE-18627Fix TestRegionServerReadRequestMetricsMajortest
HBASE-18634Fix client.TestClientClusterStatusMajortest
HBASE-18637Update the link of “Bending time in HBase”Trivialdocumentation
HBASE-18471The DeleteFamily cell is skipped when StoreScanner seeks to next columnCriticalDeletes, hbase, scan
HBASE-18572Delete can't remove the cells which have no visibility labelCritical.
HBASE-18617FuzzyRowKeyFilter should not modify the filter pairsMinor.
HBASE-18125HBase shell disregards spaces at the end of a split key in a split fileMajorshell
HBASE-18587Fix Flaky TestFileIOEngineMajorBucketCache, test
HBASE-18431Mitigate compatibility concerns between branch-1.3 and branch-1.4Blocker.
HBASE-18493[AMv2] On region server crash do not process system table regions through AssignmentManager.checkIfShouldMoveSystemRegionAsync()Criticalamv2
HBASE-18598AsyncNonMetaRegionLocator use FIFO algorithm to get a candidate locate requestMinorasyncclient
HBASE-18437Revoke access permissions of a user from a table does not work as expectedMajorsecurity
HBASE-18526FIFOCompactionPolicy pre-check uses wrong scopeMajormaster
HBASE-18599Add missing @Deprecated annotationsMinor.
HBASE-17803PE always re-creates table when we specify the split policyMinor.
HBASE-18592[hbase-thirdparty] Doc on new hbase-thirdparty dependency for the refguideMajordocumentation
HBASE-18557change splitable to mergeable in MergeTableRegionsProcedureMajor.
HBASE-18025CatalogJanitor should collect outdated RegionStates from the AMMajorread replicas
HBASE-18551[AMv2] UnassignProcedure and crashed regionserversMajoramv2
HBASE-18390Sleep too long when finding region location failedMajorClient
HBASE-18563Fix RAT License complaint about website jenkins scriptsTrivial.
HBASE-18024HRegion#initializeRegionInternals should not re-create .hregioninfo file when the region directory no longer existsMajorRegion Assignment, regionserver
HBASE-18560Test master.assignment.TestAssignmentManager hangs on master and its in flaky listMajor.
HBASE-18262name of parameter quote need update in hbase-default.xmlMinor.
HBASE-18525TestAssignmentManager#testSocketTimeout fails in master branchMajor.
HBASE-18492[AMv2] Embed code for selecting highest versioned region server for system table regions in AssignmentManager.processAssignQueue()Majoramv2
HBASE-18516[AMv2] Remove dead code in ServerManager resulted mostly from AMv2 refactoringMajor.
HBASE-18470Remove the redundant comma from RetriesExhaustedWithDetailsException#getDescMinorClient
HBASE-17056Remove checked in PB generated filesCritical.
HBASE-18480The cost of BaseLoadBalancer.cluster is changed even if the rollback is doneMajorBalancer
HBASE-18491[AMv2] Fail UnassignProcedure if source Region Server is not online.Criticalamv2
HBASE-18487Minor fixes in row lock implementationMajor.
HBASE-18475MasterProcedureScheduler incorrectly passes null Procedure to table lockingMajorproc-v2
HBASE-18259HBase book link to “beginner” issues includes resolved issuesMajordocumentation
HBASE-18481The autoFlush flag was not used in PE toolMinor.
HBASE-18406In ServerCrashProcedure.java start(MasterProcedureEnv) is a no-opMajor.
HBASE-18473VC.listLabels() erroneously closes any connectionMajorClient
HBASE-17131Avoid livelock caused by HRegion#processRowsWithLocksMajorregionserver
HBASE-18185IntegrationTestTimeBoundedRequestsWithRegionReplicas unbalanced tests fails with AssertionErrorMinorintegration tests
HBASE-18362hbck should not report split replica parent region from meta as errorsMinorhbck
HBASE-17839“Data Model” section: Table 1 has only 5 data rows instead 6.Trivialdocumentation
HBASE-18445Upgrading Guava broke hadoop-3.0 profileBlockerbuild, dependencies, hadoop3
HBASE-18449Fix client.locking.TestEntityLocks#testHeartbeatExceptionMinortest
HBASE-18447MetricRegistryInfo#hashCode uses hashCode instead of toHashCodeMinor.
HBASE-18441ZookeeperWatcher#interruptedException should throw exceptionMajor.
HBASE-18054log when we add/remove failed servers in clientMajorClient, Operability
HBASE-18427minor cleanup around AssignmentManagerMinoramv2
HBASE-18323Remove multiple ACLs for the same user in kerberosMinor.
HBASE-18354Fix TestMasterMetrics that were disabled by Proc-V2 AM in HBASE-14614Majortest
HBASE-18433Convenience method for creating simple ColumnFamilyDescriptorMajorClient
HBASE-18430Typo in “contributing to documentation” pageMajordocumentation
HBASE-18404Small typo on ACID documentation pageTrivialdocumentation
HBASE-16993BucketCache throw java.io.IOException: Invalid HFile block magic when configuring hbase.bucketcache.bucket.sizesMajorBucketCache
HBASE-18337hbase-shaded-server brings in signed jarsMajorshading
HBASE-18330NPE in ReplicationZKLockCleanerChoreMajormaster, Replication
HBASE-18393hbase shell non-interactive brokenBlockerscripts, shell
HBASE-17648HBase Table-level synchronization fails between two secured(kerberized) clustersCriticalmapreduce, Operability, security, tooling
HBASE-16090ResultScanner is not closed in SyncTable#finishRemainingHashRanges()Majormapreduce, Operability, tooling
HBASE-15548SyncTable: sourceHashDir is supposed to be optional but won't work withoutCriticalmapreduce, Operability, tooling
HBASE-18377Error handling for FileNotFoundException should consider RemoteException in openReader()Major.
HBASE-18260Address new license dependencies from hadoop3-alpha4Majordependencies
HBASE-18177FanOutOneBlockAsyncDFSOutputHelper fails to compile against Hadoop 3Majorwal
HBASE-18358Backport HBASE-18099 ‘FlushSnapshotSubprocedure should wait for concurrent Region#flush() to finish’ to branch-1.3Criticalsnapshots
HBASE-18348The implementation of AsyncTableRegionLocator does not follow the javadocCriticalasyncclient, Client
HBASE-18292Fix flaky test hbase.master.locking.TestLockProcedure#testLocalMasterLockRecovery()Major.
HBASE-17705Procedure execution must fail fast if procedure is not registeredBlocker.
HBASE-18341Update findHangingTests.py script to match changed consoleText of trunk buildMajor.
HBASE-18335clean up configuration guideMajordocumentation
HBASE-18329update links in config guide to point to java 8 referencesMajordocumentation
HBASE-18312Ineffective handling of FileNotFoundException in FileLink$FileLinkInputStream.tryOpen()Major.
HBASE-17931Assign system tables to servers with highest versionBlockerRegion Assignment, scan
HBASE-18325Disable flakey TestMasterProcedureWalLeaseMajortest
HBASE-16120Add shell test for truncate_preserveMinor.
HBASE-18301Enable TestSimpleRegionNormalizerOnCluster#testRegionNormalizationMergeOnCluster that was disabled by Proc-V2 AM in HBASE-14614Majortest
HBASE-18310LoadTestTool unable to write dataMajorutil
HBASE-18320Address maven-site-plugin upgrade stepsBlockerwebsite
HBASE-18311clean up the quickstart guideMajordocumentation
HBASE-13866Add endpoint coprocessor to the section hbase.coprocessor.region.classes in HBase bookTrivialdocumentation
HBASE-18302Protobuf section in the docs needs some clean upBlockerdocumentation
HBASE-16192Fix the potential problems in TestAcidGuaranteesMajor.
HBASE-17982Is the word “occured” should be "occurred ?Trivialhbase
HBASE-18290Fix TestAddColumnFamilyProcedure and TestDeleteTableProcedureMajortest
HBASE-18278[AMv2] Enable and fix uni test hbase.master.procedure.TestServerCrashProcedure#testRecoveryAndDoubleExecutionOnRsWithMetaMajor.
HBASE-18244org.apache.hadoop.hbase.client.rsgroup.TestShellRSGroups hangs/failsMajortest
HBASE-18230Generated LICENSE file includes unsubstituted Velocity variablesMajorbuild
HBASE-18274hbase autorestart will overwrite the gc logMajorhbase
HBASE-18265Correct the link unuseful in regionServer's region state UITrivialUI
HBASE-18263Resolve NPE in backup Master UI when access to procedures.jspTrivialUI
HBASE-18254ServerCrashProcedure checks and waits for meta initialized, instead should check and wait for meta loadedMajoramv2
HBASE-18235LoadBalancer.BOGUS_SERVER_NAME should not have a bogus hostnameMajor.
HBASE-18212In Standalone mode with local filesystem HBase logs Warning message:Failed to invoke ‘unbuffer’ method in class class org.apache.hadoop.fs.FSDataInputStreamMinorOperability
HBASE-17988get-active-master.rb and draining_servers.rb no longer workCriticalscripts
HBASE-18180Possible connection leak while closing BufferedMutator in TableOutputFormatMajormapreduce
HBASE-18227[AMv2] Fix test hbase.coprocessor.TestCoprocessorMetrics#testRegionObserverAfterRegionClosedMajoramv2
HBASE-18225Fix findbugs regression calling toString() on an arrayTrivial.
HBASE-18166[AMv2] We are splitting already-split filesMajorRegion Assignment
HBASE-18209Include httpclient / httpcore jars in build artifactsMajor.
HBASE-18219Fix typo in constant HConstants.HBASE_CLIENT_MEAT_REPLICA_SCAN_TIMEOUTMinor.
HBASE-18200Set hadoop check versions for branch-2 and branch-2.x in pre commitMajorbuild
HBASE-18207branch-2 build fails in the checkstyle phaseMajor.
HBASE-18137Replication gets stuck for empty WALsCriticalReplication
HBASE-18199Race in NettyRpcConnection may cause call stuck in BufferCallBeforeInitHandler foreverMajorIPC/RPC
HBASE-18192Replication drops recovered queues on region server shutdownBlockerReplication
HBASE-18092Removing a peer does not properly clean up the ReplicationSourceManager state and metricsMajorReplication
HBASE-18193Master web UI presents the incorrect number of regionsMinor.
HBASE-18195Remove redundant single quote from start message for HMaster and HRegionServerMinormaster, regionserver
HBASE-18141Regionserver fails to shutdown when abort triggered in RegionScannerImpl during RPC callCriticalregionserver, security
HBASE-15302Reenable the other tests disabled by HBASE-14678Majortest
HBASE-18184Add hbase-hadoop2-compat jar as MapReduce job dependencyMinormapreduce
HBASE-18149The setting rules for table-scope attributes and family-scope attributes should keep consistentMajorshell
HBASE-18158Two running in-memory compaction threads may lose dataMajor.
HBASE-18145The flush may cause the corrupt data for readingBlocker.
HBASE-18132Low replication should be checked in period in case of datanode rolling upgradeMajor.
HBASE-9393Hbase does not closing a closed socket resulting in many CLOSE_WAITCritical.
HBASE-18005read replica: handle the case that region server hosting both primary replica and meta region is downMajor.
HBASE-18030Per Cell TTL tags may get duplicated with increments/Append causing tags length overflowCriticalhbase, regionserver
HBASE-18155TestMasterProcedureWalLease is flakeyMajoramv2
HBASE-18111Replication stuck when cluster connection is closedMajor.
HBASE-18143[AMv2] Backoff on failed report of region transition quickly goes to astronomical time scaleCriticalRegion Assignment
HBASE-18129truncate_preserve fails when the truncate method doesn't exists on the masterMajorshell
HBASE-18122Scanner id should include ServerName of region serverMajor.
HBASE-18027Replication should respect RPC size limits when batching editsMajorReplication
HBASE-18042Client Compatibility breaks between versions 1.2 and 1.3Criticalregionserver, scan
HBASE-18118Default storage policy if not configured cannot be “NONE”Minorwal
HBASE-16011TableSnapshotScanner and TableSnapshotInputFormat can produce duplicate rowsMajorsnapshots
HBASE-18120Fix TestAsyncRegionAdminApiMajortest
HBASE-18113Handle old client without include_stop_row flag when startRow equals endRowMajor.
HBASE-17997In dev environment, add jruby-complete jar to classpath only when jruby is neededMajor.
HBASE-18099FlushSnapshotSubprocedure should wait for concurrent Region#flush() to finishCriticalsnapshots
HBASE-18084Improve CleanerChore to clean from directory which consumes more disk spaceMajor.
HBASE-18085Prevent parallel purge in ObjectPoolMajor.
HBASE-18093Overloading the meaning of ‘enabled’ in Quota Manager to indicate either quota disabled or quota manager not ready is not goodMinormaster
HBASE-18077Update JUnit license to EPL from CPLBlockerbuild, community
HBASE-18069Fix flaky test TestReplicationAdminWithClusters#testDisableAndEnableReplicationTrivialtest
HBASE-15616Allow null qualifier for all table operationsMajorClient
HBASE-18081The way we process connection preamble in SimpleRpcServer is brokenMajorIPC/RPC
HBASE-18035Meta replica does not give any primaryOperationTimeout to primary meta regionCritical.
HBASE-18071Fix flaky test TestStochasticLoadBalancer#testBalanceClusterMajorBalancer
HBASE-18058Zookeeper retry sleep time should have an upper limitMajor.
HBASE-17286LICENSE.txt in binary tarball contains only ASL textBlockerbuild, community
HBASE-18049It is not necessary to re-open the region when MOB files cannot be foundMajorScanners
HBASE-18053AsyncTableResultScanner will hang when scan wrong column familyMajorClient
HBASE-18051balance_rsgroup still run when the Load Balancer is not enabled.Majorrsgroup
HBASE-17352Fix hbase-assembly build with bash 4Minor.
HBASE-18055Releasing L2 cache HFileBlocks before shipped() when switching from pread to stream causes result corruptionMajorregionserver, Scanners
HBASE-18000Make sure we always return the scanner id with ScanResponseMajorregionserver
HBASE-18026ProtobufUtil seems to do extra array copyingMinor.
HBASE-16356REST API scanner: row prefix filter and custom filter parameters are mutually exclusiveMinorREST
HBASE-8758Error in RegionCoprocessorHost class preScanner method documentation.MinorCoprocessors, documentation
HBASE-17471Region Seqid will be out of order in WAL if using mvccPreAssignCriticalwal
HBASE-17964ensure hbase-metrics-api is included in mapreduce job classpathsBlockermapreduce
HBASE-17991Add more details about compaction queue on /dumpMinor.
HBASE-17228precommit grep -c ERROR may grab non errorsMinorbuild, community, test
HBASE-17958Avoid passing unexpected cell to ScanQueryMatcher when optimize SEEK to SKIPMajor.
HBASE-17985Inline package manage updates with package installation in Yetus DockerfileBlocker.
HBASE-17957Custom metrics of replicate endpoints don't prepend “source.” to global metricsMinorReplication
HBASE-17862Condition that always returns trueTrivialClient
HBASE-14286Correct typo in argument name for WALSplitter.writeRegionSequenceIdFileTrivial.
HBASE-17879Avoid NPE in snapshot.jsp when accessing without any request parameterTrivialUI
HBASE-17975TokenUtil.obtainToken squashes remote exceptionsBlockermapreduce, security
HBASE-17970Set yarn.app.mapreduce.am.staging-dir when starting MiniMRClusterMajormapreduce, snapshots, test
HBASE-17950Write the chunkId also as Int instead of long into the first byte of the chunkMajor.
HBASE-17904Get runs into NoSuchElementException when using Read Replica, with hbase. ipc.client.specificThreadForWriting to be true and hbase.rpc.client.impl to be org.apache.hadoop.hbase.ipc.RpcClientImplMajorClient, IPC/RPC
HBASE-17947Location of Examples.proto is wrong in comment of RowCountEndPoint.javaTrivialCoprocessors
HBASE-17302The region flush request disappeared from flushQueueMajor.
HBASE-17943The in-memory flush size is different for each CompactingMemStore located in the same regionMajorregionserver
HBASE-17946Shell command compact_rs don't workMajorshell
HBASE-17941CellArrayMap#getCell may throw IndexOutOfBoundsExceptionMinor.
HBASE-13288Fix naming of parameter in Delete constructorTrivialAPI
HBASE-17937Memstore size becomes negative in case of expensive postPut/Delete Coprocessor callMajorregionserver
HBASE-17940HMaster can not start due to Jasper related classes conflictBlockerdependencies, pom
HBASE-17936Refine sum endpoint example in ref guideMinordocumentation
HBASE-17930Avoid using Canary.sniff in HBaseTestingUtilityMajorcanary, test
HBASE-16875Changed try-with-resources in the docs to recommended wayTrivialdocumentation
HBASE-17366Run TestHFile#testReaderWithoutBlockCache failesTrivialtest
HBASE-15535Correct link to TrafodionMinordocumentation
HBASE-17903Corrected the alias for the link of HBASE-6580Trivialdocumentation
HBASE-17816HRegion#mutateRowWithLocks should update writeRequestCount metricMajormetrics
HBASE-17905[hbase-spark] bulkload does not work when table not existMajor.
HBASE-17863Procedure V2: Proc Executor cleanup. Split FINISHED state to two states: SUCCESS and FAILED.Majorproc-v2
HBASE-17886Fix compatibility of ServerSideScanMetricsBlocker.
HBASE-17869UnsafeAvailChecker wrongly returns false on ppcMinor.
HBASE-17871scan#setBatch(int) call leads wrong result of VerifyReplicationMinor.
HBASE-15871Memstore flush doesn't finish because of backwardseek() in memstore scanner.MajorScanners
HBASE-17785RSGroupBasedLoadBalancer fails to assign new table regions when cloning snapshotMajor.
HBASE-17698ReplicationEndpoint choosing sinksMajorReplication
HBASE-16780Since move to protobuf3.1, Cells are limited to 64MB where previous they had no limitCriticalProtobufs
HBASE-17821The CompoundConfiguration#toString is wrongTrivial.
HBASE-17660HFileSplitter is not being applied during full table restoreMajor.
HBASE-17287Master becomes a zombie if filesystem object closesBlockermaster
HBASE-17807correct the value of zookeeper.session.timeout in hbase docTrivialdocumentation
HBASE-17798RpcServer.Listener.Reader can abort due to CancelledKeyExceptionMajor.
HBASE-17812Remove RpcConnection from pool in AbstractRpcClient.cancelConnectionsMajorClient, rpc
HBASE-16014Get and Put constructor argument lists are divergentMajor.
HBASE-17582Drop page cache hint is brokenCriticalCompaction, io
HBASE-16084Clean up the stale references in javadocMinor.
HBASE-17426Inconsistent environment variable names for enabling JMXMajor.
HBASE-17792Use a shared thread pool for AtomicityWriter, AtomicGetReader, AtomicScanReader's connections in TestAcidGuaranteesMinor.
HBASE-17723ClientAsyncPrefetchScanner may end prematurely when the size of the cache is oneMajor.
HBASE-17779disable_table_replication returns misleading message and does not turn off replicationMajorReplication
HBASE-17780BoundedByteBufferPool “At capacity” messages are not actionableMinor.
HBASE-17501NullPointerException after Datanodes Decommissioned and TerminatedMinorFilesystem Integration, Operability
HBASE-17773VerifyReplication tool wrongly emits warning “ERROR: Invalid argument ‘--recomparesleep=xx’”Trivial.
HBASE-17746TestSimpleRpcScheduler.testCoDelScheduling is brokenMajorintegration tests
HBASE-17772IntegrationTestRSGroup won't runMinorrsgroup
HBASE-17712Remove/Simplify the logic of RegionScannerImpl.handleFileNotFoundMajorregionserver
HBASE-17763IPCUtil.wrapException will wrap DoNotRetryIOException with IOExceptionMajorIPC/RPC
HBASE-17736Some options can't be configured by the shellMinor.
HBASE-17761Test TestRemoveRegionMetrics.testMoveRegion fails intermittently because of race conditionMajorRegion Assignment
HBASE-17760HDFS Balancer doc is misleadingMinordocumentation
HBASE-17718Difference between RS's servername and its ephemeral node cause SSH stop workingMajor.
HBASE-17729Missing shortcuts for some useful HCD optionsTrivialshell
HBASE-17717Incorrect ZK ACL set for HBase superuserCriticalsecurity, Zookeeper
HBASE-17460enable_table_replication can not perform cyclic replication of a tableCriticalReplication
HBASE-16630Fragmentation in long running Bucket CacheCriticalBucketCache
HBASE-17722Metrics subsystem stop/start messages add a lot of useless bulk to operational loggingTrivialmetrics
HBASE-17710HBase in standalone mode creates directories with 777 permissionMajorregionserver
HBASE-17673Monitored RPC Handler not shown in the WebUIMinor.
HBASE-17688MultiRowRangeFilter not working correctly if given same start and stop RowKeyMinor.
HBASE-17699Fix TestLockProcedureBlockerproc-v2
HBASE-17674Major compaction may be cancelled in CompactionCheckerMajorCompaction
HBASE-17682Region stuck in merging_new state indefinitelyMajor.
HBASE-17069RegionServer writes invalid META entries for split daughters in some circumstancesBlockerwal
HBASE-17677ServerName parsing from directory name should be more robust to errors from guava's HostAndPortMajorwal
HBASE-13882Fix RegionSplitPolicy section in HBase bookTrivialdocumentation
HBASE-17675ReplicationEndpoint should choose new sinks if a SaslException occursMajor.
HBASE-15328Unvalidated Redirect in HMasterMinorsecurity
HBASE-17661fix the queue length passed to FastPathBalancedQueueRpcExecutorMinor.
HBASE-17653HBASE-17624 rsgroup synchronizations will (distributed) deadlockMajorrsgroup
HBASE-17658Fix bookkeeping error with max regions for a tableMajorBalancer
HBASE-17421Update refguide w.r.t. MOB SweeperMajordocumentation, mob
HBASE-17649REST API for scan should return 410 when table is disabledMajor.
HBASE-17640Unittest error in TestMobCompactor with different timezoneMinormob
HBASE-17624Address late review of HBASE-6721, rsgroups featureMajorrsgroup
HBASE-17639Do not stop server if ReplicationSourceManager's waitUntilCanBePushed throws InterruptedExceptionMajorReplication
HBASE-17558ZK dumping jsp should escape htmlMinorsecurity, UI
HBASE-9702Change unittests that use “table” or “testtable” to use method names.Majortest
HBASE-17611Thrift 2 per-call latency metrics are capped at ~ 2 secondsMajormetrics, Thrift
HBASE-17603REST API for scan should return 404 when table does not existBlockerREST, scan
HBASE-17638Remove duplicated initialization of CacheConfig in HRegionServerMinor.
HBASE-17622Add hbase-metrics package to TableMapReduceUtilTrivialmapreduce
HBASE-17616Incorrect actions performed by CMMajor.
HBASE-17105Annotate RegionServerObserverMajor.
HBASE-17381ReplicationSourceWorkerThread can die due to unhandled exceptionsMajorReplication
HBASE-17565StochasticLoadBalancer may incorrectly skip balancing due to skewed multiplier sumCritical.
HBASE-17606Fix failing TestRpcControllerFactory introduced by HBASE-17508MajorClient, scan
HBASE-17187DoNotRetryExceptions from coprocessors should bubble up to the applicationMajor.
HBASE-17578Thrift per-method metrics should still update in the case of exceptionsMajorThrift
HBASE-17593Fix build with hadoop 3 profileMajor.
HBASE-17601close() in TableRecordReaderImpl assumes the split has startedMinorhadoop2
HBASE-17587Do not Rethrow DoNotRetryIOException as UnknownScannerExceptionMajorCoprocessors, regionserver, rpc
HBASE-17581mvn clean test -PskipXXXTests does not work properly for some modulesMajor.
HBASE-16621HBCK should have -fixHFileLinksMajor.
HBASE-17522RuntimeExceptions from MemoryMXBean should not take down server processMajorregionserver
HBASE-17197hfile does not work in 2.0MajorHFile
HBASE-17538HDFS.setStoragePolicy() logs errors on local fsMajor.
HBASE-16785We are not running all testsMajorbuild, test
HBASE-17540Change SASL server GSSAPI callback log line from DEBUG to TRACE in RegionServer to reduce log volumes in DEBUG modeMinorregionserver
HBASE-17271hbase-thrift QA tests only run one testMajor.
HBASE-17407Correct update of maxFlushedSeqId in HRegionMajorwal
HBASE-17489ClientScanner may send a next request to a RegionScanner which has been exhaustedCriticalClient, scan
HBASE-17357PerformanceEvaluation parameters parsing triggers NPE.MinorPerformance, test
HBASE-17496RSGroup shell commands:get_server_rsgroup don't work and commands display an incorrect result sizeMajorshell
HBASE-17486Tighten the contract for batch client methodsTrivialAPI
HBASE-17482mvcc mechanism fails when using mvccPreAssignCritical.
HBASE-17469Properly handle empty TableName in TablePermission#readFields and #writeMajorfindbugs
HBASE-17475Stack overflow in AsyncProcess if retry too muchMajorAPI, Client
HBASE-17464Fix HBaseTestingUtility.getNewDataTestDirOnTestFS to always return a unique pathMinortest
HBASE-17450TablePermission#equals throws NPE after namespace support was addedMajorfindbugs
HBASE-17452Failed taking snapshot - region Manifest proto-message too largeMajorsnapshots
HBASE-17434New Synchronization Scheme for Compaction PipelineMajor.
HBASE-17445Count size of serialized exceptions in checking max result size quotaMajor.
HBASE-17429HBase bulkload cannot support HDFS viewFsMajor.
HBASE-17435Call to preCommitStoreFile() hook encounters SaslException in secure deploymentMajor.
HBASE-17430dead links in ref guide to class javadocs that moved out of user APIs.Majordocumentation, website
HBASE-17424Protect REST client against malicious XML responses.MajorREST
HBASE-17351Enforcer plugin fails with NullPointerExceptionCriticalbuild
HBASE-17290Potential loss of data for replication of bulk loaded hfilesMajor.
HBASE-17390Online update of configuration for all servers leaves out mastersMajor.
HBASE-17403ClientAsyncPrefetchScanner doesn’t load any data if the MaxResultSize is too smallMajor.
HBASE-17387Reduce the overhead of exception report in RegionActionResult for multi()Minor.
HBASE-17385Change usage documentation from bin/hbase to hbase in various toolsMajor.
HBASE-17374ZKPermissionWatcher crashed when grant after region closeCriticalregionserver
HBASE-17376ClientAsyncPrefetchScanner may fail due to too many rowsMajor.
HBASE-17330SnapshotFileCache will always refresh the file cacheMinorsnapshots
HBASE-16663JMX ConnectorServer stopped when unauthorized user try to stop HM/RS/clusterCriticalmetrics, security
HBASE-17341Add a timeout during replication endpoint terminationCritical.
HBASE-17328Properly dispose of looped replication peersCriticalReplication
HBASE-17347ExportSnapshot may write snapshot info file to wrong directory when specifying target nameMinorsnapshots
HBASE-17344The regionserver web UIs miss the coprocessors of RegionServerCoprocessorHost.Minor.
HBASE-17333HBASE-17294 always ensures CompactingMemstore is defaultCritical.
HBASE-17326Fix findbugs warning in BufferedMutatorParamsMajor.
HBASE-17309Fix connection leaks in TestAcidGuaranteesMinorintegration tests
HBASE-17297Single Filter in parenthesis cannot be parsed correctlyMajorFilters
HBASE-17237Override the correct compact method in HMobStoreMajormob
HBASE-16985TestClusterId failed due to wrong hbase rootdirMinortest
HBASE-15437Response size calculated in RPCServer for warning tooLarge responses does NOT count CellScanner payloadMajorIPC/RPC
HBASE-17256Rpc handler monitoring will be removed when the task queue is fullMajor.
HBASE-17170HBase is also retrying DoNotRetryIOException because of class loader differences.Major.
HBASE-17252Wrong arguments for ValueAndTagRewriteCell in CellUtilMajor.
HBASE-16841Data loss in MOB files after cloning a snapshot and deleting that snapshotBlockermob, snapshots
HBASE-17118StoreScanner leaked in KeyValueHeapMajor.
HBASE-17231Region#getCellCompartor sp?Trivial.
HBASE-16886hbase-client: scanner with reversed=true and small=true gets no resultMajor.
HBASE-17112Prevent setting timestamp of delta operations the same as previous value'sMajor.
HBASE-16209Provide an ExponentialBackOffPolicy sleep between failed region open requestsMajor.
HBASE-17206FSHLog may roll a new writer successfully with unflushed entriesCriticalwal
HBASE-17224There are lots of spelling errors in the HBase logging and exception messagesTrivialClient, io, mapreduce, master, regionserver, security, wal
HBASE-17192remove use of scala-tools.org from pomBlockerspark, website
HBASE-17186MasterProcedureTestingUtility#testRecoveryAndDoubleExecution displays stale procedure state infoMinorproc-v2, test
HBASE-17072CPU usage starts to climb up to 90-100% when using G1GC; purge ThreadLocal usageCriticalPerformance, regionserver
HBASE-17116[PerformanceEvaluation] Add option to configure block sizeTrivialtooling
HBASE-17127Locate region should fail fast if underlying Connection already closedMajor.
HBASE-17144Possible offheap read ByteBuffers leakMajorrpc
HBASE-17160Undo unnecessary inter-module dependency; spark to hbase-it and hbase-it to shellMinor.
HBASE-17171IntegrationTestTimeBoundedRequestsWithRegionReplicas fails with obtuse error when readers have no time to runMinorintegration tests
HBASE-17158Avoid deadlock caused by HRegion#doDeltaMajor.
HBASE-17166ITBLL fails on master unable to find hbase-protocol-shaded contentMajor.
HBASE-17095The ClientSimpleScanner keeps retrying if the hfile is corrupt or cannot foundMajorregionserver, scan
HBASE-16989RowProcess#postBatchMutate doesn’t be executed before the mvcc transaction completionMajor.
HBASE-17058Lower epsilon used for jitter verification from HBASE-15324MajorCompaction
HBASE-17082ForeignExceptionUtil isn’t packaged when building shaded protocol with -Pcompile-protobufMajor.
HBASE-17091IntegrationTestZKAndFSPermissions failed with ‘KeeperException$NoNodeException’Major.
HBASE-17092Both LoadIncrementalHFiles#doBulkLoad() methods should set return valueMajor.
HBASE-17044Fix merge failed before creating merged region leaves meta inconsistentCriticalregionserver
HBASE-17074PreCommit job always fails because of OOMCriticalbuild
HBASE-16345RpcRetryingCallerWithReadReplicas#call() should catch some RegionServer ExceptionsMajorClient
HBASE-17062RegionSplitter throws ClassCastExceptionMinorutil
HBASE-16962Add readPoint to preCompactScannerOpen() and preFlushScannerOpen() APIMajor.
HBASE-17039SimpleLoadBalancer schedules large amount of invalid region movesMajorBalancer
HBASE-17020keylen in midkey() dont computed correctlyMajorHFile
HBASE-16938TableCFsUpdater maybe failed due to no write permission on peerNodeMajorReplication
HBASE-17052compile-protobuf profile does not compile protobufs in some modules anymoreMajor.
HBASE-17054Compactor#preCreateCoprocScanner should be passed userMajor.
HBASE-16983TestMultiTableSnapshotInputFormat failing with Unable to create region directory: /tmp/...Minortest
HBASE-17042Remove ‘public’ keyword from MasterObserver interfaceMinorCoprocessors
HBASE-17033LogRoller makes a lot of allocations unnecessarilyMajor.
HBASE-16992The usage of mutation from CP is weird.Minor.
HBASE-17032CallQueueTooBigException and CallDroppedException should not be triggering PFFEMajorClient
HBASE-16960RegionServer hang when abortingCritical.
HBASE-14329Report region in transition only ever operates on one regionMajorRegion Assignment
HBASE-16964Successfully archived files are not cleared from compacted store file list if archiving of any file failsBlockerregionserver
HBASE-16976hbase-protocol-shaded module generates classes to wrong directoryMinorbuild
HBASE-16931Setting cell's seqId to zero in compaction flow might cause RS down.Criticalregionserver
HBASE-16980TestRowProcessorEndpoint failing consistentlyMajor.
HBASE-16966Re-enable TestSimpleRpcScheduler#testCoDelScheduling in master branchMajortest
HBASE-16974Update os-maven-plugin to 1.4.1.final+ for building shade file on RHEL/CentOSMinor.
HBASE-16971The passed durability of Append/Increment isn't used in wal syncMajor.
HBASE-16743TestSimpleRpcScheduler#testCoDelScheduling is brokeMajorrpc
HBASE-16948Fix inconsistency between HRegion and Region javadoc on getRowLockMajor.
HBASE-16949Fix RAT License complaint about the hbase-protocol-shaded/src/main/patches contentMajor.
HBASE-16939ExportSnapshot: set owner and permission on right directoryMinor.
HBASE-16000Table#checkAndPut() docs are too vagueMinordocumentation
HBASE-16880Correct the javadoc/behaviour of the APIs in ByteBufferUtilsMajor.
HBASE-16930AssignmentManager#checkWals() function can recur infinitelyMajorRegion Assignment
HBASE-16887Allow setting different hadoopcheck versions in precommit for different branchesMajorbuild
HBASE-15684Fix the broken log file size accountingMajorwal
HBASE-16870Add the metrics of replication sources which were transformed from other dead rs to ReplicationLoadMinorReplication
HBASE-16815Low scan ratio in RPC queue tuning triggers divide by zero exceptionMajorregionserver, rpc
HBASE-16829DemoClient should detect secure modeMajor.
HBASE-16754Regions failing compaction due to referencing non-existent store fileBlocker.
HBASE-15348Fix tests broken by recent metrics re-workMajormetrics, test
HBASE-16910Avoid NPE when starting StochasticLoadBalancerMinorBalancer
HBASE-16701TestHRegion and TestHRegionWithInMemoryFlush timing outMajorregionserver, test
HBASE-16889Proc-V2: verifyTables in the IntegrationTestDDLMasterFailover test after each table DDL is incorrectMajorproc-v2
HBASE-16884Add HBase-2.0.x to the hadoop version support matrix in our documentationBlockerdocumentation
HBASE-16752Upgrading from 1.2 to 1.3 can lead to replication failures due to difference in RPC size limitMajorReplication, rpc
HBASE-16578Mob data loss after mob compaction and normal compactionMajormob
HBASE-16824Writer.flush() can be called on already closed streams in WAL rollMajorwal
HBASE-16866Avoid NPE in AsyncRequestFutureImpl#updateStatsMinor.
HBASE-16733add hadoop 3.0.0-alpha1 to precommit checksMajorbuild, hadoop3
HBASE-16283Batch Append/Increment will always fail if set ReturnResults to falseMinorAPI
HBASE-16712fix hadoop-3.0 profile mvn installMajorbuild, hadoop3
HBASE-16721Concurrency issue in WAL unflushed seqId trackingCriticalwal
HBASE-16326CellModel / RowModel should override ‘equals’, ‘hashCode’ and ‘toString’TrivialREST
HBASE-16855Avoid NPE in MetricsConnection’s constructionMinor.
HBASE-16856Exception message in SyncRunner.run() should print currentSequenceMinorwal
HBASE-16853Regions are assigned to Region Servers in /hbase/draining after HBase Master failoverMajorBalancer, Region Assignment
HBASE-16810HBase Balancer throws ArrayIndexOutOfBoundsException when regionservers are in /hbase/draining znode and unloadedMajorBalancer
HBASE-16664Timeout logic in AsyncProcess is brokenMajor.
HBASE-16724Snapshot owner can't cloneMajorsnapshots
HBASE-16807RegionServer will fail to report new active Hmaster until HMaster/RegionServer failoverMajorregionserver
HBASE-16716OfflineMetaRepair leaves empty directory inside /hbase/WALs which remains foreverMinorhbck
HBASE-16746The log of “region close” should differ from “region move”Minor.
HBASE-16808Included the generated, shaded java files from “HBASE-15638 Shade protobuf” in our src assemblyBlocker.
HBASE-16731Inconsistent results from the Get/Scan if we use the empty FilterListMinor.
HBASE-16801The Append/Increment may return the data from futureCritical.
HBASE-15109HM/RS failed to start when “fs.hdfs.impl.disable.cache” is set to trueCriticalregionserver
HBASE-16622Fix some issues with the HBase reference guideMajordocumentation
HBASE-16793Exclude shaded protobuf files from rat checkMajorbuild
HBASE-16699Overflows in AverageIntervalRateLimiter's refill() and getWaitInterval()Major.
HBASE-16771VerifyReplication should increase GOODROWS counter if re-comparison passesMajor.
HBASE-16768Inconsistent results from the Append/IncrementMinor.
HBASE-16767Mob compaction needs to clean up files in /hbase/mobdir/.tmp and /hbase/mobdir/.tmp/.bulkload when running into IO exceptionsMajormob
HBASE-16681Fix flaky TestReplicationSourceManagerZkImplMajor.
HBASE-16753There is a mismatch between suggested Java version in hbase-env.shMinorscripts
HBASE-16644Errors when reading legit HFile Trailer of old (v2.0) format fileCriticalHFile
HBASE-16763Remove unintentional dependency on net.sf.ehcache.search.ResultsMajor.
HBASE-16764hbase-protocol-shaded generate-shaded-classes profile unpacks shaded java files into wrong locationMajorbuild
HBASE-16739Timed out exception message should include encoded region nameMinor.
HBASE-16678MapReduce jobs do not update counters from ScanMetricsMajor.
HBASE-16732Avoid possible NPE in MetaTableLocatorMinor.
HBASE-16723RMI registry is not destroyed after stopping JMX Connector ServerMajormetrics
HBASE-16711Fix hadoop-3.0 profile compileMajorbuild, hadoop3
HBASE-16696After HBASE-16604 - does not release blocks in case of scanner exceptionCritical.
HBASE-16682Fix Shell tests failure. NoClassDefFoundError for MiniKdcMajor.
HBASE-16660ArrayIndexOutOfBounds during the majorCompactionCheck in DateTieredCompactionCriticalCompaction
HBASE-16643Reverse scanner heap creation may not allow MSLAB closure due to improper ref counting of segmentsCritical.
HBASE-16649Truncate table with splits preserved can cause both data loss and truncated data appeared againMajor.
HBASE-16704Scan will be broken while working with DBE and KeyValueCodecWithTagsMajor.
HBASE-16645Wrong range of Cells is caused by CellFlatMap#tailMap, headMap, and SubMapMajor.
HBASE-16665Check whether KeyValueUtil.createXXX could be replaced by CellUtil without copyMajor.
HBASE-16697bump TestRegionServerMetrics to LargeTestsTrivialtest
HBASE-16679Flush throughput controller: Minor perf change and fix flaky TestFlushWithThroughputControllerMajor.
HBASE-16693The commit of HBASE-16604 creates a unrelated folderCritical.
HBASE-16688Split TestMasterFailoverWithProceduresMajorproc-v2, test
HBASE-16604Scanner retries on IOException can cause the scans to miss dataCriticalregionserver, Scanners
HBASE-16662Fix open POODLE vulnerabilitiesMajorREST, Thrift
HBASE-16675Average region size may be incorrect when there is region whose RegionLoad cannot be retrievedMajor.
HBASE-16670Make RpcServer#processRequest logic more robustMinor.
HBASE-12088Remove un-used profiles in non-root pomsMajor.
HBASE-16669fix flaky TestAdmin#testmergeRegionsMajortest
HBASE-16294hbck reporting “No HDFS region dir found” for replicasMinorhbck
HBASE-12949Scanner can be stuck in infinite loop if the HFile is corruptedMajor.
HBASE-16654Better handle channelInactive and close for netty rpc clientMajor.
HBASE-16540Scan should do additional validation on start and stop rowMajorClient
HBASE-16647hbck should do offline reference repair before online repairMajor.
HBASE-16551Cleanup SplitLogManager and CatalogJanitorTrivialmaster
HBASE-16635RpcClient under heavy load leaks some netty bytebufMinor.
HBASE-16165Decrease RpcServer.callQueueSize before writeResponse causes OOMMinorIPC/RPC, rpc
HBASE-16624MVCC DeSerialization bug in the HFileScannerImplBlockerHFile
HBASE-16612Use array to cache Types for KeyValue.Type.codeToTypeMinor.
HBASE-16491A few org.apache.hadoop.hbase.rsgroup classes missing @InterfaceAudience annotationMinorAPI, regionserver
HBASE-16609Fake cells EmptyByteBufferedCell created in read path not implementing SettableSequenceIdMajor.
HBASE-16614Use daemon thread for netty event loopMajorIPC/RPC, rpc
HBASE-15624Move master branch/hbase-2.0.0 to jdk-8 onlyBlockerbuild
HBASE-16576Shell add_peer doesn't allow setting cluster_key for custom endpointsMajorshell
HBASE-16309TestDefaultCompactSelection.testCompactionRatio is flakyMajorCompaction, test
HBASE-16589Adjust log level for FATAL messages from HBaseReplicationEndpoint that are not fatalTrivial.
HBASE-16544Remove or Clarify ‘Using Amazon S3 Storage’ section in the reference guideMajordocumentation, Filesystem Integration
HBASE-16572Sync method in RecoverableZooKeeper failed to pass callback function inMinorZookeeper
HBASE-16460Can‘t rebuild the BucketAllocator’s data structures when BucketCache uses FileIOEngineMajorBucketCache
HBASE-16556The read/write timeout are not used in HTable.delete(List), HTable.get(List), and HTable.existsAll(List)Minor.
HBASE-16538Version mismatch in HBaseConfiguration.checkDefaultsVersionMajor.
HBASE-16552MiniHBaseCluster#getServerWith() does not ignore stopped RSsTrivialtest
HBASE-16547hbase-archetype-builder shell scripts assume bash is installed in /binTrivial.
HBASE-16375Mapreduce mini cluster using HBaseTestingUtility not setting correct resourcemanager and jobhistory webapp address of MapReduceTestingShimMinor.
HBASE-16527IOExceptions from DFS client still can cause CatalogJanitor to delete referenced filesMajor.
HBASE-15278AsyncRPCClient hangs if Connection closes before RPC call responseBlockerrpc, test
HBASE-16528Procedure-V2: ServerCrashProcedure misses owner informationMajorhbase, master, proc-v2
HBASE-16535Use regex to exclude generated classes for findbugsMajorfindbugs
HBASE-16515AsyncProcess has incorrent count of tasks if the backoff policy is enabledMinor.
HBASE-16490Fix race condition between SnapshotManager and SnapshotCleanerMajor.
HBASE-16409Row key for bad row should be properly delimited in VerifyReplicationMinor.
HBASE-16495When accessed via Thrift, all column families have timeToLive equal to -1MinorThrift
HBASE-16304HRegion#RegionScannerImpl#handleFileNotFoundException may lead to deadlock when trying to obtain write lock on updatesLockCritical.
HBASE-16270Handle duplicate clearing of snapshot in region replicasMajorReplication
HBASE-16471Region Server metrics context will be wrong when machine hostname contain “master” wordMinormetrics
HBASE-16456Fix findbugs warnings in hbase-rsgroup moduleMinor.
HBASE-16464archive folder grows bigger and bigger due to corrupt snapshot under tmp dirMajorsnapshots
HBASE-16360TableMapReduceUtil addHBaseDependencyJars has the wrong class name for PrefixTreeCodecMinormapreduce
HBASE-16446append_peer_tableCFs failed when there already have this table's partial cfs in the peerMinorReplication
HBASE-16454Compactor‘s shipping logic decision should be based on the current store’s block sizeMinor.
HBASE-16444CellUtil#estimatedSerializedSizeOfKey() should consider KEY_INFRASTRUCTURE_SIZEMinor.
HBASE-7621REST client (RemoteHTable) doesn't support binary row keysMajorREST
HBASE-16430Fix RegionServer Group's bug when moving multiple tablesMajormaster
HBASE-16429FSHLog: deadlock if rollWriter called when ring buffer filled with appendsCritical.
HBASE-16384Update report-flakies.py script to allow specifying a list of build ids to be excludedMajor.
HBASE-15635Mean age of Blocks in cache (seconds) on webUI should be greater than zeroMajor.
HBASE-16341Missing bit on “Regression: Random Read/WorkloadC slower in 1.x than 0.98”Majorrpc
HBASE-16267Remove commons-httpclient dependency from hbase-rest moduleCritical.
HBASE-16389Thread leak in CoprocessorHost#getTable(TableName) APIMajor.
HBASE-16363Correct javadoc for qualifier length and value length in Cell interfaceMinordocumentation
HBASE-16368test*WhenRegionMove in TestPartialResultsFromClientSide is flakyMajorScanners
HBASE-16310Revisit the logic of filterRowKey for FiltersMajor.
HBASE-16361Revert of HBASE-16317, “revert all ESAPI...” broke TestLogLevelMajordependencies, UI
HBASE-16367Race between master and region server initialization may lead to premature server abortMajor.
HBASE-16303FilterList with MUST_PASS_ONE optimizationMajorFilters
HBASE-15866Split hbase.rpc.timeout into *.read.timeout and *.write.timeoutMajor.
HBASE-16362Mob compaction does not set cacheBlocks to false when creating StoreScannerMajorCompaction, regionserver
HBASE-16359NullPointerException in RSRpcServices.openRegion()Major.
HBASE-15461ref guide has bad links to blogs originally posted on cloudera websiteMajorwebsite
HBASE-15574Minor typo on HRegionServerCommandLine.javaTrivial.
HBASE-16350Undo server abort from HBASE-14968Major.
HBASE-16271Fix logging and re-run the test in IntegrationTestBulkLoadMajor.
HBASE-16347Unevaluated expressions in bookMajordocumentation, website
HBASE-16301Trigger flush without waiting when compaction is disabled on a tableMinor.
HBASE-16319Fix TestCacheOnWrite after HBASE-16288Trivial.
HBASE-16315RegionSizeCalculator prints region names as binary without escapesTrivial.
HBASE-16284Unauthorized client can shutdown the clusterMajor.
HBASE-16296Reverse scan performance degrades when using filter listsMajorFilters
HBASE-16288HFile intermediate block level indexes might recurse forever creating multi TB filesCriticalHFile
HBASE-16234Expect and handle nulls when assigning replicasMajorRegion Assignment
HBASE-16306Add specific imports to avoid namespace clash in defaultSource.scalaMinor.
HBASE-16300LruBlockCache.CACHE_FIXED_OVERHEAD should calculate LruBlockCache size correctlyMajor.
HBASE-16289AsyncProcess stuck messages need to print region/serverCriticalOperability
HBASE-16096Replication keeps accumulating znodesMajorReplication
HBASE-16293TestSnapshotFromMaster#testSnapshotHFileArchiving flakeyMajortest
HBASE-16281TestMasterReplication is flakyMajor.
HBASE-16221Thrift server drops connection on long scansMajorThrift
HBASE-16272Overflow in ServerName's compareTo methodMajorhbase
HBASE-16244LocalHBaseCluster start timeout should be configurableMajorhbase
HBASE-16238It's useless to catch SESSIONEXPIRED exception and retry in RecoverableZooKeeperMinorZookeeper
HBASE-16172Unify the retry logic in ScannerCallableWithReplicas and RpcRetryingCallerWithReadReplicasMajor.
HBASE-16110AsyncFS WAL doesn't work with Hadoop 2.8+Blockerwal
HBASE-16076Cannot configure split policy in HBase shellMinordocumentation
HBASE-16144Replication queue's lock will live forever if RS acquiring the lock has died prematurelyMajor.
HBASE-16235TestSnapshotFromMaster#testSnapshotHFileArchiving will fail if there are too many hfilesTrivial.
HBASE-16183Correct errors in example programs of coprocessor in Ref GuideMinordocumentation
HBASE-16095Add priority to TableDescriptor and priority region open thread poolMajor.
HBASE-16227[Shell] Column value formatter not working in scansMajor.
HBASE-16211JMXCacheBuster restarting the metrics system might cause tests to hangMajor.
HBASE-16150Remove ConcurrentIndexMajor.
HBASE-16207can't restore snapshot without “Admin” permissionMajormaster, snapshots
HBASE-16184Shell test fails due to rLoadSink being nilMajor.
HBASE-16055PutSortReducer loses any Visibility/acl attribute set on the PutsCriticalsecurity
HBASE-16081Replication remove_peer gets stuck and blocks WAL rollingBlockerregionserver, Replication
HBASE-16044Fix ‘hbase shell’ output parsing in graceful_stop.shCriticalscripts, shell
HBASE-16160Get the UnsupportedOperationException when using delegation token with encryptionBlocker.
HBASE-16074ITBLL fails, reports lost big or tiny familiesBlockerintegration tests
HBASE-16201NPE in RpcServer causing intermittent UT failure of TestMasterReplication#testHFileCyclicReplicationMajor.
HBASE-16171Fix the potential problems in TestHCM.testConnectionCloseAllowsInterruptMajor.
HBASE-15925compat-module maven variable not evaluatedBlockerbuild
HBASE-16187Fix typo in blog post for metrics2Majorwebsite
HBASE-16190IntegrationTestDDLMasterFailover failed with IllegalArgumentException: n must be positiveMinor.
HBASE-16182Increase IntegrationTestRpcClient timeoutMajor.
HBASE-16157The incorrect block cache count and size are caused by removing duplicate block key in the LruBlockCacheTrivial.
HBASE-16177In dev mode thrift server can't be runMajor.
HBASE-16091Canary takes lot more time when there are delete markers in the tableMajorcanary
HBASE-16132Scan does not return all the result when regionserver is busyMajorClient
HBASE-16135PeerClusterZnode under rs of removed peer may never be deletedMajorReplication
HBASE-15844We should respect hfile.block.index.cacheonwrite when write intermediate index BlockMajor.
HBASE-16159OutOfMemory exception when using AsyncRpcClient with encryption to read rpc responseMajor.
HBASE-16125RegionMover uses hardcoded, Unix-style tmp folder - breaks WindowsMajor.
HBASE-16133RSGroupBasedLoadBalancer.retainAssignment() might miss a regionMajor.
HBASE-16129check_compatibility.sh is broken when using Java API Compliance Checker v1.7Majortest
HBASE-15976RegionServerMetricsWrapperRunnable will be failure when disable blockcache.Major.
HBASE-16122PerformanceEvaluation should provide user friendly hint when client threads argument is missingMinor.
HBASE-16069Typo “trapsparently” in item 3 of chapter 87.2 of Reference GuideMinordocumentation
HBASE-16109Add Interface audience annotation to a few classesMinor.
HBASE-16111Truncate preserve shell command is brokenMajorshell
HBASE-16103Procedure v2 - TestCloneSnapshotProcedure relies on execution orderMinorproc-v2, test
HBASE-16040Remove configuration “hbase.replication”Major.
HBASE-16070Mapreduce Serialization classes do not have Interface audienceMajor.
HBASE-16012Major compaction can't work due to obsolete scanner read point in RegionServerMajorCompaction, Scanners
HBASE-16062Improper error handling in WAL Reader/Writer creationMajor.
HBASE-16032Possible memory leak in StoreScannerMajor.
HBASE-16035Nested AutoCloseables might not all get closedMajor.
HBASE-15783AccessControlConstants#OP_ATTRIBUTE_ACL_STRATEGY_CELL_FIRST not used any more.Major.
HBASE-16059Region normalizer fails to trigger merge action where one of the regions is emptyMajormaster
HBASE-14485ConnectionImplementation leaks on construction failureMajorClient
HBASE-16054OutOfMemory exception when using AsyncRpcClient with encryptionMajor.
HBASE-16066Resolve RpC_REPEATED_CONDITIONAL_TEST findbugs warnings in HMasterMajor.
HBASE-16058TestHRegion fails on 1.4 buildsMajortest
HBASE-15467Remove 1.x/2.0 TableDescriptor incompatibilityMajormaster, regionserver
HBASE-16061Allow logging to a buffered consoleMajor.
HBASE-16053Master code is not setting the table in ENABLING state in create tableMajor.
HBASE-16045endtime argument for VerifyReplication was incorrectly specified in usageMajor.
HBASE-15977Failed variable substitution on home pageMajorwebsite
HBASE-16047TestFastFail is broken againMajortest
HBASE-15908Checksum verification is broken due to incorrect passing of ByteBuffers in DataChecksumBlockerHFile
HBASE-16031Documents about “hbase.replication” default value seems wrongMajordocumentation
HBASE-16017HBase TableOutputFormat has connection leak in getRecordWriterMajormapreduce
HBASE-15746Remove extra RegionCoprocessor preClose() in RSRpcServices#closeRegionMinorCoprocessors, regionserver
HBASE-16021graceful_stop.sh: Wrap variables in double quote to avoid “[: too many arguments” errorMinorscripts
HBASE-16016AssignmentManager#waitForAssignment could have unexpected negative deadlineMajor.
HBASE-16007Job's Configuration should be passed to TableMapReduceUtil#addDependencyJars() in WALPlayerMajor.
HBASE-14644Region in transition metric is brokenMajor.
HBASE-15946Eliminate possible security concerns in RS web UI's store file metricsMajor.
HBASE-15990The priority value of subsequent coprocessors in the Coprocessor.Priority.SYSTEM list are not incremented by oneMinor.
HBASE-15952Bulk load data replication is not working when RS user does not have permission on hfile-refs nodeMajorReplication
HBASE-15975logic in TestHTableDescriptor#testAddCoprocessorWithSpecStr is wrongTrivialtest
HBASE-15959Fix flaky test TestRegionServerMetrics.testMobMetricsMajor.
HBASE-15957RpcClientImpl.close never ends in some circumstancesMajorClient, rpc
HBASE-15803ZooKeeperWatcher's constructor can leak a ZooKeeper instance with throwing ZooKeeperConnectionException when canCreateBaseZNode is trueMinor.
HBASE-15698Increment TimeRange not serialized to serverBlocker.
HBASE-15965Shell test changes. Use @shell.command instead directly calling functions in admin.rb and other libraries.Major.
HBASE-15954REST server should log requests with TRACE instead of DEBUGMajor.
HBASE-15889String case conversions are locale-sensitive, used without localeMinorlocalization
HBASE-15955Disable action in CatalogJanitor#setEnabled should wait for active cleanup scan to finishMajormaster
HBASE-15929There are two classes with name TestRegionServerMetricsMajor.
HBASE-15845Shell Cleanup : move formatter to commands.rb; move one of the two hbase.rb to hbase_constants.rbMinorshell
HBASE-15933NullPointerException may be thrown from SimpleRegionNormalizer#getRegionSize()Major.
HBASE-15938submit-patch.py: Don't crash if there are tests with same name. Refactor: Split out html template to separate file.Major.
HBASE-15944Spark test flooding mvn output. Redirect test logs to file.Major.
HBASE-15858Some region server group shell commands don't workMajor.
HBASE-15932Shell test fails due to uninitialized constantMajor.
HBASE-15907Missing documentation of create table split optionsMajordocumentation
HBASE-15918Cleanup excludes/includes file after use in hbase-personality.sh to avoid asf license error.Major.
HBASE-15897Fix a wrong comment about QOS orderTrivial.
HBASE-15909Use Yetus' patch naming rules in submit-patch.pyMajor.
HBASE-15912REST module has 2 extant results in findbugsMajor.
HBASE-15891Closeable resources potentially not getting closed if exception is thrownMinor.
HBASE-15693Reconsider the ImportOrder rule of checkstyleMajorbuild
HBASE-11625Reading datablock throws “Invalid HFile block magic” and can not switch to hdfs checksumMajorHFile
HBASE-15830Sasl encryption doesn't work with AsyncRpcChannelImplMajor.
HBASE-15884NPE in StoreFileScanner#skipKVsNewerThanReadpoint during reverse scanMajorScanners
HBASE-15880RpcClientImpl#tracedWriteRequest incorrectly closes HTrace spanMajortracing
HBASE-14818user_permission does not list namespace permissionsMinorhbase
HBASE-15856Cached Connection instances can wind up with addresses never resolvedCriticalClient
HBASE-15863Typo in Put.java class documentationTrivialdocumentation, java
HBASE-15465userPermission returned by getUserPermission() for the selected namespace does not have namespace setMinorProtobufs
HBASE-15617Canary in regionserver mode might not enumerate all regionserversMinor.
HBASE-15850Localize the configuration change in testCheckTableLocks to reduce flakiness of TestHBaseFsck test suiteMajorhbck
HBASE-15841Performance Evaluation tool total rows may not be set correctlyMinor.
HBASE-15824LocalHBaseCluster gets bind exception in master info portMajor.
HBASE-15784Misuse core/maxPoolSize of LinkedBlockingQueue in ThreadPoolExecutorMajorClient, Replication, Thrift
HBASE-15834Correct Bloom filter documentation in section 96.4 of Reference GuideMinordocumentation
HBASE-15769Perform validation on cluster key for add_peerMinor.
HBASE-15848Fix possible null point dereference in RSGroupBasedLoadBalancer#getMisplacedRegions()Trivialregionserver
HBASE-15840WAL.proto compilation broken for cppMajor.
HBASE-15725make_patch.sh should add the branch name when -b is passed.Majortooling
HBASE-15828fix extant findbugMajorfindbugs
HBASE-15615Wrong sleep time when RegionServerCallable need retryMajorClient
HBASE-15811Batch Get after batch Put does not fetch all CellsBlockerClient
HBASE-15742Reduce allocation of objects in metricsMajor.
HBASE-15799Two Shell ‘close_region’ Example Syntaxes Don't WorkMinorshell
HBASE-15801Upgrade checkstyle for all branchesMajorbuild
HBASE-15797TestIPCUtil fails after HBASE-15795Major.
HBASE-15236Inconsistent cell reads over multiple bulk-loaded HFilesMajor.
HBASE-15807Update report-flakies.py to look for “FAILED” status in test reportMinor.
HBASE-15738Ensure artifacts in project dist area include required md5 fileBlockerbuild, community
HBASE-15796TestMetaCache fails after HBASE-15745Major.
HBASE-15781Remove unused TableEventHandler and TotesHRegionInfoTrivialmaster
HBASE-15782TestShell fails due to some moved typesMajor.
HBASE-15669HFile size is not considered correctly in a replication requestMajorReplication
HBASE-15292Refined ZooKeeperWatcher to prevent ZooKeeper's callback while constructionMinorZookeeper
HBASE-15563‘counter’ may overflow in BoundedGroupingStrategyMinorwal
HBASE-15755SnapshotDescriptionUtils and SnapshotTestingUtils do not have any Interface audience markedMajor.
HBASE-15741Provide backward compatibility for HBase coprocessor service namesBlockerCoprocessors
HBASE-15613TestNamespaceCommand times outMajor.
HBASE-15528Clean up outdated entries in hbase-default.xmlMinor.
HBASE-15752ClassNotFoundException is encountered when custom WAL codec is not found in WALPlayer jobMajor.
HBASE-15714We are calling checkRow() twice in doMiniBatchMutation()Majorregionserver
HBASE-15703Deadline scheduler needs to return to the client info about skipped calls, not just drop themCriticalIPC/RPC
HBASE-15357TableInputFormatBase getSplitKey does not handle signed bytes correctlyMajormapreduce
HBASE-15711Add client side property to allow logging details for batch errorsMajor.
HBASE-15732hbase-rsgroups should be in the assemblyMajor.
HBASE-15676FuzzyRowFilter fails and matches all the rows in the table if the mask consists of all 0sMajorFilters
HBASE-15697Excessive TestHRegion running time on branch-1Major.
HBASE-15685Typo in REST documentationMinordocumentation
HBASE-15708Docker for dev-support scriptsMajor.
HBASE-15707ImportTSV bulk output does not support tags with hfile.format.version=3Majormapreduce
HBASE-15645hbase.rpc.timeout is not used in operations of HTableCritical.
HBASE-15634TestDateTieredCompactionPolicy#negativeForMajor is flakyMajortest
HBASE-15710Include issue servers information in RetriesExhaustedWithDetailsException messageMinor.
HBASE-14252RegionServers fail to start when setting hbase.ipc.server.callqueue.scan.ratio to 0Majorregionserver
HBASE-15699Can not sync AsyncFSWAL if no edit is appendedMajorwal
HBASE-15360Fix flaky TestSimpleRpcSchedulerCriticaltest
HBASE-15670Add missing Snapshot.proto to the maven profile for compiling protobufMajor.
HBASE-15674HRegionLocator#getAllRegionLocations should put the results in cacheMajor.
HBASE-15672hadoop.hbase.security.visibility.TestVisibilityLabelsWithDeletes failsMajortest
HBASE-15673[PE tool] Fix latency metrics for multiGetMajorPerformance
HBASE-14898Correct Bloom filter documentation in the bookMinor.
HBASE-15664Use Long.MAX_VALUE instead of HConstants.FOREVER in CompactionPolicyMajorCompaction
HBASE-15668HFileReplicator$Copier fails to replicate other hfiles in the request when a hfile in not found in FS anywhereTrivialReplication
HBASE-15287mapreduce.RowCounter returns incorrect result with binary row key inputsMajormapreduce, util
HBASE-15187Integrate CSRF prevention filter to REST gatewayMajor.
HBASE-15650Remove TimeRangeTracker as point of contention when many threads reading a StoreFileMajorPerformance
HBASE-15622Superusers does not consider the keytab credentialsCriticalsecurity
HBASE-15405Synchronize final results logging single thread in PE, fix wrong defaults in help messageMinorPerformance
HBASE-15504Fix Balancer in 1.3 not moving regions off overloaded regionserverMajor.
HBASE-15637TSHA Thrift-2 server should allow limiting call queue sizeMajorThrift
HBASE-15639Unguarded access to stackIndexes in Procedure#toStringDetails()Minor.
HBASE-15636hard coded wait time out value in HBaseTestingUtility#waitUntilAllRegionsAssigned might cause test failureMinorintegration tests, test
HBASE-15621Suppress Hbase SnapshotHFile cleaner error messages when a snaphot is going onMinorsnapshots
HBASE-15627Miss space and closing quote in AccessController#checkSystemOrSuperUserMinorsecurity
HBASE-15093Replication can report incorrect size of log queue for the global source when multiwal is enabledMinorReplication
HBASE-15591ServerCrashProcedure not yieldingMajor.
HBASE-15623Update refguide to change hadoop <= 2.3.x from NT to X for hbase-1.2.xMajordocumentation
HBASE-15587FSTableDescriptors.getDescriptor() logs stack trace erronouslyMajor.
HBASE-15485Filter.reset() should not be called between batchesMajor.
HBASE-15578Handle HBASE-15234 for ReplicationHFileCleanerMajorReplication
HBASE-15582SnapshotManifestV1 too verbose when there are no regionsTrivialmaster, snapshots
HBASE-15424Add bulk load hfile-refs for replication in ZK after the event is appended in the WALMinorReplication
HBASE-15234ReplicationLogCleaner can abort due to transient ZK issuesCriticalmaster, Replication
HBASE-15567TestReplicationShell broken by recent replication changesMinorReplication, shell
HBASE-15324Jitter may cause desiredMaxFileSize overflow in ConstantSizeRegionSplitPolicy and trigger unexpected splitMajor.
HBASE-15566Add timeouts on TestMobFlushSnapshotFromClient and TestRegionMergeTransactionOnClusterMajor.
HBASE-15559BaseMasterAndRegionObserver doesn't implement all the methodsMajor.
HBASE-15327Canary will always invoke admin.balancer() in each sniffing period when writeSniffing is enabledMinorcanary
HBASE-15295MutateTableAccess.multiMutate() does not get high priority causing a deadlockMajor.
HBASE-15515Improve LocalityBasedCandidateGenerator in BalancerMinor.
HBASE-14256Flush task message may be confusing when region is recoveredMajorregionserver
HBASE-15520Fix broken TestAsyncIPCMajor.
HBASE-15064BufferUnderflowException after last Cell fetched from an HFile Block served from L2 offheap cacheCriticalio
HBASE-15325ResultScanner allowing partial result will miss the rest of the row if the region is moved between two rpc requestsCriticaldataloss, Scanners
HBASE-15433SnapshotManager#restoreSnapshot not update table and region count quota correctly when encountering exceptionMajorsnapshots
HBASE-15441Fix WAL splitting when region has moved multiple timesBlockerRecovery, wal
HBASE-15430Failed taking snapshot - Manifest proto-message too largeCriticalsnapshots
HBASE-15463Region normalizer should check whether split/merge is enabledMinor.
HBASE-15439getMaximumAllowedTimeBetweenRuns in ScheduledChore ignores the TimeUnitMajormaster, mob, regionserver
HBASE-15379Fake cells created in read path not implementing SettableSequenceIdMajor.
HBASE-15425Failing to write bulk load event marker in the WAL is ignoredMajor.
HBASE-15378Scanner cannot handle heartbeat message with no resultsCriticaldataloss, Scanners
HBASE-15271Spark Bulk Load: Need to write HFiles to tmp location then rename to protect from Spark Executor FailuresMajor.
HBASE-15364Fix unescaped < characters in JavadocMajorAPI, documentation
HBASE-15137CallTimeoutException and CallQueueTooBigException should trigger PFFEMajor.
HBASE-15393Enable table replication command will fail when parent znode is not default in peer clusterMajorReplication
HBASE-15397Create bulk load replication znode(hfile-refs) in ZK replication queue by defaultMajorReplication
HBASE-15329Cross-Site Scripting: Reflected in table.jspMinorsecurity, UI
HBASE-15128Disable region splits and merges switch in masterMajor.
HBASE-15358canEnforceTimeLimitFromScope should use timeScope instead of sizeScopeMajorScanners
HBASE-15332Document how to take advantage of HDFS-6133 in HBaseMajordocumentation
HBASE-15319clearJmxCache does not take effect actuallyMajormetrics
HBASE-15247InclusiveStopFilter does not respect reverse Filter propertyMajorFilters
HBASE-15285Forward-port respect for isReturnResult from HBASE-15095MajorClient
HBASE-15298Fix missing or wrong asciidoc anchors in the reference guideMinordocumentation
HBASE-15259WALEdits under replay will also be replicatedMinor.
HBASE-15251During a cluster restart, Hmaster thinks it is a failover by mistakeMajormaster
HBASE-15289Add details about how to get usage instructions for Import and Export utilitiesMajordocumentation
HBASE-13883Fix Memstore Flush section in HBase bookMajordocumentation
HBASE-15250Fix links that are currently redirected from old URLsMajordocumentation, website
HBASE-15279OrderedBytes.isEncodedValue does not check for int8 and int16 typesMajor.
HBASE-15276TestFlushSnapshotFromClient hungMajor.
HBASE-15198RPC client not using Codec and CellBlock for puts by defaultCritical.
HBASE-15122Servlets generate XSS_REQUEST_PARAMETER_TO_SERVLET_WRITER findbugs warningsCriticalUI
HBASE-15079TestMultiParallel.validateLoadedData AssertionError: nullMajorClient, flakey, test
HBASE-13839Fix AssgnmentManagerTmpl.jamon issues (coloring, content etc.)Majormaster, UI
HBASE-15252Data loss when replaying wal if HDFS timeoutBlockerwal
HBASE-15221HTableMultiplexer improvements (stale region locations and resource leaks)CriticalClient
HBASE-15253Small bug in CellUtil.matchingRow(Cell, byte[])Minor.
HBASE-14192Fix REST Cluster constructor with String ListMinorREST
HBASE-15216Canary does not accept config params from command lineMajorcanary
HBASE-15231Make TableState.State privateMajorAPI
HBASE-15214Valid mutate Ops fail with RPC Codec in use and region moves acrossCritical.
HBASE-14770RowCounter argument input parse errorMinormapreduce
HBASE-15209disable table in HBaseTestingUtility.truncateTableMinor.
HBASE-15218On RS crash and replay of WAL, loosing all Tags in CellsBlockerRecovery, regionserver, security
HBASE-15200ZooKeeper znode ACL checks should only compare the shortnameMinorsecurity
HBASE-15206Flakey testSplitDaughtersNotInMeta testMinorflakey
HBASE-15196HBASE-15158 Preamble 2 of 2:Add Increment testsMajor.
HBASE-15186HBASE-15158 Preamble 1 of 2: fix findbugs, add javadoc, change Region#getReadpoint to #getReadPoint, and some utilMajor.
HBASE-15190Monkey dies when running on shared cluster (gives up when can't kill the other fellows processes)Majorintegration tests
HBASE-15195Don't run findbugs on hbase-it; it has nothing in src/main/javaMajorfindbugs
HBASE-14810Update Hadoop support description to explain “not tested” vs “not supported”Criticaldocumentation
HBASE-15019Replication stuck when HDFS is restartedMajorReplication, wal
HBASE-15173Execute mergeRegions RPC call as the request userMinor.
HBASE-15146Don't block on Reader threads queueing to a scheduler queueBlocker.
HBASE-15145HBCK and Replication should authenticate to zookepeer using server principalMajor.
HBASE-15164Fix broken links found via LinkLintMajordocumentation
HBASE-15132Master region merge RPC should authorize user requestMajor.
HBASE-13082Coarsen StoreScanner locks to RegionScannerMajorPerformance, Scanners
HBASE-15148Resolve IS2_INCONSISTENT_SYNC findbugs warning in AuthenticationTokenSecretManagerMajor.
HBASE-15133Data loss after compaction when a row has more than Integer.MAX_VALUE columnsMajorCompaction
HBASE-15152Automatically include prefix-tree module in MR jobs if presentMajormapreduce
HBASE-15147Shell should use Admin.listTableNames() instead of Admin.listTables()Major.
HBASE-15126HBaseFsck's checkRegionBoundaries function sets incorrect ‘storesFirstKey’Majorhbck
HBASE-15139Connection manager doesn't pass client metrics to RpcClientMajorClient, metrics
HBASE-15098Normalizer switch in configuration is not usedBlockermaster
HBASE-15101Leaked References to StoreFile.Reader after HBASE-13082CriticalHFile, io
HBASE-15102HeapMemoryTuner can “overtune” memstore size and suddenly drop it into blocking zoneCriticalregionserver
HBASE-14771RpcServer#getRemoteAddress always returns nullMinorIPC/RPC
HBASE-14512Cache UGI groupsMajorPerformance, security
HBASE-15104Occasional failures due to NotServingRegionException in IT testsMajorintegration tests
HBASE-15117Resolve ICAST findbugs warnings in current codesMinor.
HBASE-15085IllegalStateException was thrown when scanning on bulkloaded HFilesCritical.
HBASE-15083Gets from Multiactions are not counted in metrics for gets.Major.
HBASE-15052Use EnvironmentEdgeManager in ReplicationSourceTrivialReplication
HBASE-15057local-master-backup.sh doesn't start HMaster correctlyMajorshell
HBASE-15065SimpleRegionNormalizer should return multiple normalization plans in one runMajor.
HBASE-14975Don‘t color the total RIT line yellow if it’s zeroMajorUI
HBASE-15027Refactor the way the CompactedHFileDischarger threads are createdMajor.
HBASE-15070DistributedHBaseCluster#restoreRegionServers() starts new RS process on master serverMinorintegration tests
HBASE-14867SimpleRegionNormalizer needs to have better heuristics to trigger merge operationMajormaster
HBASE-14987Compaction marker whose region name doesn‘t match current region’s needs to be handledMajor.
HBASE-15063Bug in MultiByteBuf#toBytesCriticalio, Performance
HBASE-15050Block Ref counting does not work in Region Split cases.Critical.
HBASE-15011turn off the jdk8 javadoc linter. :(Blockerbuild, documentation
HBASE-15043region_status.rb broken with TypeError: no public constructors for Java::OrgApacheHadoopHbaseClient::HBaseAdminMajorscripts
HBASE-15026The default value of “hbase.regions.slop” in hbase-default.xml is obsoleteMinorBalancer
HBASE-15035bulkloading hfiles with tags that require splits do not preserve tagsBlockerHFile
HBASE-15039HMaster and RegionServers should try to refresh token keys from zk when facing InvalidTokenMajor.
HBASE-14940Make our unsafe based ops more safeMajor.
HBASE-14717enable_table_replication command should only create specified table for a peer clusterMajorReplication
HBASE-15032hbase shell scan filter string assumes UTF-8 encodingMajorshell
HBASE-15034IntegrationTestDDLMasterFailover does not clean created namespacesMinorintegration tests
HBASE-15030Deadlock in master TableNamespaceManager while running IntegrationTestDDLMasterFailoverMajorproc-v2
HBASE-15021hadoopqa doing false positivesMajor.
HBASE-15028Minor fix on RegionGroupingProviderMinorwal
HBASE-14977ChoreService.shutdown may result in ConcurrentModificationExceptionMinorutil
HBASE-15014Fix filterCellByStore in WALsplitter is awful for performanceCriticalMTTR, Recovery, wal
HBASE-15001Thread Safety issues in ReplicationSinkManager and HBaseInterClusterReplicationEndpointBlockerReplication
HBASE-14654Reenable TestMultiParallel#testActiveThreadsCountMajortest
HBASE-15022undefined method `getZooKeeperClusterKey' for Java::OrgApacheHadoopHbaseZookeeper::ZKUtil:ClassMajorshell
HBASE-14991Fix the feature warning in scala codeMinor.
HBASE-15015Checktyle plugin shouldn't check Jamon-generated Java classesMinorbuild
HBASE-14822Renewing leases of scanners doesn't workMajor.
HBASE-13907Document how to deploy a coprocessorMajordocumentation
HBASE-14990Tests in BaseTestHBaseFsck are run by its subclasses redundantlyMinortest
HBASE-14999Remove ref to org.mortbay.log.LogMinordependencies
HBASE-15000Fix javadoc warn in LoadIncrementalHFilesTrivial.
HBASE-14974Total number of Regions in Transition number on UI incorrectTrivialUI
HBASE-14952hbase-assembly source artifact has some incorrect modulesBlockerbuild, dependencies
HBASE-14807TestWALLockup is flakeyMajorflakey, test
HBASE-14843TestWALProcedureStore.testLoad is flakeyBlockerproc-v2
HBASE-14838Clarify that SimpleRegionNormalizer does not merge empty (<1MB) regionsTrivialdocumentation, regionserver
HBASE-13976release manager list in ref guide is missing 0.94 lineMajordocumentation
HBASE-14968ConcurrentModificationException in region close resulting in the region staying in closing stateMajorRegion Assignment, regionserver
HBASE-14929There is a space missing from Table “foo” is not currently available.Trivial.
HBASE-14936CombinedBlockCache should overwrite CacheStats#rollMetricsPeriod()MajorBlockCache
HBASE-14701Fix flakey Failed tests: TestMobFlushSnapshotFromClient>TestFlushSnapshotFromClient.testSkipFlushTableSnapshot:199 nullMajortest
HBASE-14953HBaseInterClusterReplicationEndpoint: Do not retry the whole batch of edits in case of RejectedExecutionExceptionCriticalReplication
HBASE-14960Fallback to using default RPCControllerFactory if class cannot be loadedMajor.
HBASE-14769Remove unused functions and duplicate javadocs from HBaseAdminMajor.
HBASE-14901There is duplicated code to create/manage encryption keysMinorencryption
HBASE-14941locate_region shell commandTrivialshell
HBASE-14942Allow turning off BoundedByteBufferPoolMajor.
HBASE-14954IllegalArgumentException was thrown when doing online configuration change in CompactSplitThreadMajorCompaction, regionserver
HBASE-14804HBase shell's create table command ignores ‘NORMALIZATION_ENABLED’ attributeMinorshell
HBASE-14917Log in console if individual tests in test-patch.sh fail or passMinor.
HBASE-14930check_compatibility.sh needs smarter exit codesMajor.
HBASE-14923VerifyReplication should not mask the exception during result comparisonMinortooling
HBASE-14922Delayed flush doesn't work causing flush storms.Majorregionserver
HBASE-14926Hung ThriftServer; no timeout on read from client; if client crashes, worker thread gets stuck readingMajorThrift
HBASE-14928Start row should be set for query through HBase REST gateway involving globbing optionMajorREST
HBASE-14907NPE of MobUtils.hasMobColumns in Build failed in Jenkins: HBase-Trunk_matrix » latest1.8,Hadoop #513Majormob
HBASE-14904Mark Base[En|De]coder LimitedPrivate and fix binary compat issueMajor.
HBASE-13857Slow WAL Append count in ServerMetricsTmpl.jamon is hardcoded to zeroMajorregionserver, UI
HBASE-14905VerifyReplication does not honour versions optionMajortooling
HBASE-14541TestHFileOutputFormat.testMRIncrementalLoadWithSplit failed due to too many splits and few retriesMajorHFile, test
HBASE-14462rolling_restart.sh --master-only throws “line 142: test: 0: unary operator expected”Major.
HBASE-14896Resolve Javadoc warnings in WALKey and RegionMoverMinor.
HBASE-14531graceful_stop.sh “if [ “$local” ]” condition unexpected behaviourMajorscripts
HBASE-14890Fix javadoc checkstyle errorsMajor.
HBASE-14894Fix misspellings of threshold in log4j.properties files for testsTrivial.
HBASE-14523rolling-restart.sh --graceful will start regionserver process on master nodeMajorscripts
HBASE-14893Race between mutation on region and region closing operation leads to NotServingRegionExceptionMajor.
HBASE-14664Master failover issue: Backup master is unable to start if active master is killed and started in short time intervalCriticalmaster
HBASE-14777Fix Inter Cluster Replication Future ordering issuesCriticalReplication
HBASE-14885NullPointerException in HMaster#normalizeRegions() due to missing TableDescriptorMajormaster
HBASE-14689Addendum and unit test for HBASE-13471Major.
HBASE-14463Severe performance downgrade when parallel reading a single key from BucketCacheMajor.
HBASE-14861HBASE_ZNODE_FILE on master server is overwritten by regionserver process in case of master-rs collocationMajorOperability
HBASE-14825HBase Ref Guide corrections of typos/misspellingsMinordocumentation
HBASE-14737Clear cachedMaxVersions when HColumnDescriptor#setValue(VERSIONS, value) is calledMajor.
HBASE-14799Commons-collections object deserialization remote command execution vulnerabilityCriticaldependencies, security
HBASE-14840Sink cluster reports data replication request as success though the data is not replicatedMajorReplication
HBASE-14712MasterProcWALs never clean upBlockerproc-v2
HBASE-14761Deletes with and without visibility expression do not delete the matching mutationMajorsecurity
HBASE-14782FuzzyRowFilter skips valid rowsMajorFilters
HBASE-14824HBaseAdmin.mergeRegions should recognize both full region names and encoded region namesMinorAdmin
HBASE-14815TestMobExportSnapshot.testExportFailure timeout occasionallyMajor.
HBASE-14823HBase Ref Guide RefactoringMajordocumentation
HBASE-14812Fix ResultBoundedCompletionService deadlockMajorClient, Thrift
HBASE-14793Allow limiting size of block into L1 block cache.MajorBlockCache
HBASE-14806Missing sources.jar for several modules when building HBaseMajorpom
HBASE-14809Grant / revoke Namespace admin permission to groupMajorsecurity
HBASE-14802Replaying server crash recovery procedure after a failover causes incorrect handling of deadserversMajormaster
HBASE-13982Add info for visibility labels/cell TTLs to ImportTsvMajormapreduce
HBASE-14797Last round of CSS fix-upsMajorwebsite
HBASE-14788Splitting a region does not support the hbase.rs.evictblocksonclose config when closing source regionMajorregionserver
HBASE-14778Make block cache hit percentages not integer in the metrics systemMajorBlockCache, metrics
HBASE-14784Port conflict is not resolved in HBaseTestingUtility.randomFreePort()Minortest
HBASE-14787Remove obsolete ConnectionImplementation.refCountTrivial.
HBASE-14781Turn per cf flushing on for ITBLL by defaultMajorintegration tests
HBASE-14774Raise the font size on high-DPI small-screen devices like iphone 6+Majorwebsite
HBASE-14767Remove deprecated functions from HBaseAdminMajor.
HBASE-14759Avoid using Math.abs when selecting SyncRunner in FSHLogMajorwal
HBASE-14632Region server aborts due to unguarded dereference of ReaderMajorregionserver
HBASE-14706RegionLocationFinder should return multiple servernames by top hostMajorBalancer
HBASE-14755Fix some broken links and HTML problemsMajordocumentation
HBASE-14773Fix HBase shell tests are skipped when skipping server tests.Majortest
HBASE-14768bin/graceful_stop.sh logs nothing as a balancer state to be storedTrivialscripts
HBASE-14723Fix IT tests split too many timesMajorintegration tests
HBASE-14733Minor typo in alter_namespace.rbTrivialshell
HBASE-14754TestFastFailWithoutTestUtil failing on trunk now in #testPreemptiveFastFailException50TimesMajorflakey, test
HBASE-14751Book seems to be brokenMajor.
HBASE-14742TestHeapMemoryManager is flakeyMajortest
HBASE-14739Fix broken link to Javadoc that is suppressed because it is generated codeTrivialdocumentation
HBASE-14532[book] dfs.client.read.shortcircuit is referenced as hbase-site.xml config and not described in section 7Minordocumentation
HBASE-14711Remove or annotated deprecated methods in HRegionInfoMajorhbase
HBASE-14557MapReduce WALPlayer issue with NoTagsKeyValueBlockertooling
HBASE-14650Reenable TestNamespaceAuditorMajor.
HBASE-14660AssertionError found when using offheap BucketCache with assertion enabledMajor.
HBASE-14695Fix some easy HTML warningsMinordocumentation
HBASE-14425In Secure Zookeeper cluster superuser will not have sufficient permission if multiple values are configured in “hbase.superuser”Majorsecurity, Zookeeper
HBASE-14674Rpc handler / task monitoring seems to be broken after 0.98Major.
HBASE-14705Javadoc for KeyValue constructor is not correct.Minor.
HBASE-14680Two configs for snapshot timeout and better defaultsMajorsnapshots
HBASE-14349pre-commit zombie finder is overly broadCriticalbuild
HBASE-14694Scan copy constructor doesn't handle allowPartialResultsMajorClient
HBASE-14257Periodic flusher only handles hbase:meta, not other system tablesMajorregionserver
HBASE-14682CM restore functionality for regionservers is brokenMajorintegration tests
HBASE-14283Reverse scan doesn’t work with HFile inline index/bloom blocksMajor.
HBASE-13318RpcServer.getListenerAddress should handle when the accept channel is closedMinor.
HBASE-14661RegionServer link is not opening, in HBase Table page.MinorUI
HBASE-14690Fix css so there's no left/right scroll barMajorUI
HBASE-14624BucketCache.freeBlock is too expensiveMajorBlockCache
HBASE-14676HBaseTestCase clean out: Purge Incommon Interface and Table and Region implementationsMajor.
HBASE-14343Fix debug message in SimpleRegionNormalizer for small regionsTrivialregionserver
HBASE-14681Upgrade Checkstyle plugin to 2.16Majorbuild
HBASE-14667HBaseFsck constructors have divergedMinorhbck
HBASE-14658Allow loading a MonkeyFactory by class nameMajorintegration tests, test
HBASE-14603Lots of work on the POM to enhance Javadocs, XrefsMajordocumentation
HBASE-14326HBase book: fix definition of max min size to compactMajordocumentation
HBASE-14663HStore::close does not honor config hbase.rs.evictblocksoncloseMinorBlockCache, regionserver
HBASE-14427Fix ‘should’ assertions in TestFastFailMinortest
HBASE-14633Try fluid width UIMajorUI
HBASE-14366NPE in case visibility expression is not present in labels table during importtsv runMinor.
HBASE-14604Improve MoveCostFunction in StochasticLoadBalancerMajorBalancer
HBASE-14606TestSecureLoadIncrementalHFiles tests timed out in trunk build on apacheMajortest
HBASE-12558Disable TestHCM.testClusterStatus Unexpected exception, expected<org.apache.hadoop.hbase.regionserver.RegionServerStoppedException> but was<junit.framework.AssertionFailedError>Majortest
HBASE-14458AsyncRpcClient#createRpcChannel() should check and remove dead channel before creating new one to same serverCriticalIPC/RPC
HBASE-14634Disable flakey TestSnapshotCloneIndependence.testOnlineSnapshotDeleteIndependentMajortest
HBASE-14621ReplicationLogCleaner gets stuck when a regionserver crashesCriticalReplication
HBASE-14625Chaos Monkey should shut down fasterMajorintegration tests, test
HBASE-14597Fix Groups cache in multi-threaded envMajor.
HBASE-14474DeadLock in RpcClientImpl.Connection.close()BlockerIPC/RPC
HBASE-14594Use new DNS API introduced in HADOOP-12437Majorutil
HBASE-14521Unify the semantic of hbase.client.retries.numberMajor.
HBASE-14608testWalRollOnLowReplication has some risk to assert failed after HBASE-14600Majortest
HBASE-14598ByteBufferOutputStream grows its HeapByteBuffer beyond JVM limitationsMajorClient, io
HBASE-14591Region with reference hfile may split after a forced split in IncreasingToUpperBoundRegionSplitPolicyCriticalregionserver
HBASE-14599Modify site config to use protocol-relative URLs for CSS/JSBlockerdocumentation
HBASE-14501NPE in replication when HDFS transparent encryption is enabled.CriticalReplication, security
HBASE-14211Add more rigorous integration tests of splitsMajorintegration tests, test
HBASE-14592BatchRestartRsAction always restarts 0 RS when running SlowDeterministicMonkeyMajorintegration tests
HBASE-14577HBase shell help for scan and returning a column family has a typoTrivialshell
HBASE-14578URISyntaxException during snapshot restore for table with user defined namespaceMajorsnapshots
HBASE-14581Znode cleanup throws auth exception in secure modeMajorsecurity, Zookeeper
HBASE-13858RS/MasterDumpServlet dumps threads before its “Stacks” headerTrivialmaster, regionserver, UI
HBASE-14525Append and increment operation throws NullPointerException on non-existing column families.Minorshell
HBASE-14497Reverse Scan threw StackOverflow caused by readPt checkingMajor.
HBASE-14346Typo in FamilyFilterTrivialdocumentation
HBASE-12983HBase book mentions hadoop.ssl.enabled when it should be hbase.ssl.enabledMajordocumentation
HBASE-12615Document GC conserving guidelines for contributorsMajordocumentation
HBASE-14555Deadlock in MVCC branch-1.2 toString()Criticalregionserver
HBASE-14347Add a switch to DynamicClassLoader to disable itMajorClient, defaults, regionserver
HBASE-14544Allow HConnectionImpl to not refresh the dns on errorsMajorClient
HBASE-14367Add normalization support to shellMajorBalancer, shell
HBASE-14545TestMasterFailover often times outMajortest
HBASE-14499Master coprocessors shutdown will not happen on master abortMajormaster
HBASE-13770Programmatic JAAS configuration option for secure zookeeper may be brokenMajorOperability, security
HBASE-14292Call Me Maybe HBase links haved movedMinordocumentation
HBASE-13744TestCorruptedRegionStoreFile is flakyMajortest
HBASE-13143TestCacheOnWrite is flaky and needs a dietCriticaltest
HBASE-14475Region split requests are always audited with “hbase” user rather than request userMajorregionserver, security
HBASE-14494Wrong usage messages on shell commandsMinorshell
HBASE-14518Give TestScanEarlyTermination the same treatment as ‘HBASE-14378 Get TestAccessController* passing again...’ -- up priority handlersMajortest
HBASE-14394Properly close the connection after reading records from table.Minormapreduce
HBASE-14510Can not set coprocessor from Shell after HBASE-14224MajorCoprocessors, shell
HBASE-14362org.apache.hadoop.hbase.master.procedure.TestWALProcedureStoreOnHDFS is super duper flakyCriticaltest
HBASE-14473Compute region locality in parallelMajorBalancer
HBASE-14437ArithmeticException in ReplicationInterClusterEndpointMinorReplication
HBASE-14500Remove load of deprecated MOB ruby scripts after HBASE-14227Majorshell
HBASE-14489postScannerFilterRow consumes a lot of CPUMajorCoprocessors, Performance
HBASE-14370Use separate thread for calling ZKPermissionWatcher#refreshNodes()Major.
HBASE-14492Increase REST server header buffer size from 8k to 64kMajorREST
HBASE-14471Thrift - HTTP Error 413 full HEAD if using kerberos authenticationMajorThrift
HBASE-14469Fix some comment, validation and logging around memstore lower limit configurationMinor.
HBASE-14486Disable TestRegionPlacement, a flakey test for an unfinished featureMajortest
HBASE-13324o.a.h.h.Coprocessor should be LimitedPrivate(“Coprocessor”)MinorAPI
HBASE-14445ExportSnapshot does not honor -chmod optionMajorsnapshots
HBASE-14338License notification misspells ‘Asciidoctor’Minor.
HBASE-14280Bulk Upload from HA cluster to remote HA hbase cluster failsMinorhadoop2, regionserver
HBASE-14431AsyncRpcClient#removeConnection() never removes connection from connections pool if server failsCriticalIPC/RPC
HBASE-14449Rewrite deadlock prevention for concurrent connection closeMajormaster, metrics
HBASE-13250chown of ExportSnapshot does not cover all path and filesCriticalsnapshots
HBASE-14411Fix unit test failures when using multiwal as default WAL providerMajor.
HBASE-14429Checkstyle report is brokenMinorscripts
HBASE-14400Fix HBase RPC protection documentationCriticalencryption, IPC/RPC, security
HBASE-14145Allow the Canary in regionserver mode to try all regions on the server, not just oneMajorcanary, util
HBASE-14380Correct data gets skipped along with bad data in importTsv bulk load thru TsvImporterTextMapperMajormapreduce, tooling
HBASE-14307Incorrect use of positional read api in HFileBlockMajorio
HBASE-14392[tests] TestLogRollingNoCluster fails on master from time to timeMajortest
HBASE-14382TestInterfaceAudienceAnnotations should hadoop-compt module resourcesMinortest
HBASE-14385Close the sockets that is missing in connection closure.MinorClient
HBASE-14393Have TestHFileEncryption clean up after itself so it don't go all zombie on usMajortest
HBASE-14384Trying to run canary locally with -regionserver option causes exceptionMajorcanary
HBASE-14317Stuck FSHLog: bad disk (HDFS-8960) and can't roll WALBlockerwal
HBASE-14327TestIOFencing#testFencingAroundCompactionAfterWALSync is flakyCriticaltest
HBASE-14359HTable#close will hang forever if unchecked error/exception thrown in AsyncProcess#sendMultiActionMajorClient
HBASE-14229Flushing canceled by coprocessor still leads to memstoreSize set downMajorregionserver
HBASE-14337build error on masterMajor.
HBASE-14354Minor improvements for usage of the mlock agentTrivialhbase, regionserver
HBASE-13221HDFS Transparent Encryption breaks WAL writing in Hadoop 2.6.0Criticaldocumentation, wal
HBASE-14258Make region_mover.rb script case insensitive with regard to hostnameMinor.
HBASE-14315Save one call to KeyValueHeap.peek per rowMajor.
HBASE-14313After a Connection sees ConnectionClosingException it never recoversCriticalClient
HBASE-13339Update default Hadoop version to latest for masterBlockerbuild
HBASE-14269FuzzyRowFilter omits certain rows when multiple fuzzy keys existMajorFilters
HBASE-14302TableSnapshotInputFormat should not create back references when restoring snapshotMajor.
HBASE-14224Fix coprocessor handling of duplicate classesCriticalCoprocessors
HBASE-13480ShortCircuitConnection doesn't short-circuit all calls as expectedCriticalClient
HBASE-14273Rename MVCC to MVCC: From MultiVersionConsistencyControl to MultiVersionConcurrencyControlMajorregionserver
HBASE-14291NPE On StochasticLoadBalancer Balance Involving RS With No RegionsMinorBalancer
HBASE-14250branch-1.1 hbase-server test-jar has incorrect LICENSEBlockerbuild
HBASE-14251javadoc jars use LICENSE/NOTICE from primary artifactBlockerbuild
HBASE-14249shaded jar modules create spurious source and test jars with incorrect LICENSE/NOTICE infoMajorbuild
HBASE-14243Incorrect NOTICE file in hbase-it test-jarBlockerbuild
HBASE-14234Procedure-V2: Exception encountered in WALProcedureStore#rollWriter() should be properly handledMinorproc-v2
HBASE-14241Fix deadlock during cluster shutdown due to concurrent connection closeCriticalmaster, metrics
HBASE-14228Close BufferedMutator and connection in MultiTableOutputFormatMinormapreduce
HBASE-14166Per-Region metrics can be staleMajormetrics
HBASE-10844Coprocessor failure during batchmutation leaves the memstore datastructs in an inconsistent stateMajorregionserver
HBASE-13966Limit column width in table.jspMinorOperability, UI
HBASE-14219src tgz no longer builds after HBASE-14085Blockerbuild
HBASE-14214list_labels shouldn't raise ArgumentError if no labels are definedMinor.
HBASE-14054Acknowledged writes may get lost if regionserver clock is set backwardsMajorregionserver
HBASE-14098Allow dropping caches behind compactionsMajorCompaction, hadoop2, HFile
HBASE-14196Thrift server idle connection timeout issueMajorThrift
HBASE-14209TestShell visibility tests failingMajorsecurity, shell
HBASE-14201hbck should not take a lock unless fixing errorsMajorhbck, util
HBASE-13889Fix hbase-shaded-client artifact so it works on hbase-downstreamerCriticalClient
HBASE-14208Remove yarn dependencies on -common and -clientMajorbuild, Client
HBASE-14206MultiRowRangeFilter returns records whose rowKeys are out of allowed rangesCriticalFilters
HBASE-13062Add documentation coverage for configuring dns server with thrift and rest gatewaysMinordocumentation
HBASE-5878Use getVisibleLength public api from HdfsDataInputStream from Hadoop-2.Majorwal
HBASE-14092hbck should run without locks by default and only disable the balancer when necessaryMajorhbck, util
HBASE-13924Description for hbase.dynamic.jars.dir is wrongMajor.
HBASE-12865WALs may be deleted before they are replicated to peersCriticalReplication
HBASE-13825Use ProtobufUtil#mergeFrom and ProtobufUtil#mergeDelimitedFrom in place of builder methods of same nameMajorutil
HBASE-13865Increase the default value for hbase.hregion.memstore.block.multipler from 2 to 4 (part 2)Trivialregionserver
HBASE-14178regionserver blocks because of waiting for offsetLockMajorregionserver
HBASE-14183[Shell] Scanning hbase meta table is failing in master branchMajorshell
HBASE-14021Quota table has a wrong description on the UIMinorUI
HBASE-14185Incorrect region names logged by MemStoreFlusherMinorregionserver
HBASE-13864HColumnDescriptor should parse the output from master and from describe for TTLMajorshell
HBASE-14162Fixing maven target for regenerating thrift classes fails against 0.9.2Blockerbuild, Thrift
HBASE-14168Avoid useless retry for DoNotRetryIOException in TableRecordReaderImplMinormapreduce
HBASE-14173includeMVCCReadpoint parameter in DefaultCompactor#createTmpWriter() represents no-opMajor.
HBASE-14155StackOverflowError in reverse scanCriticalregionserver, Scanners
HBASE-14153Typo in ProcedureManagerHost.MASTER_PROCEUDRE_CONF_KEYTrivial.
HBASE-14157Interfaces implemented by subclasses should be checked when registering CoprocessorServiceMajorCoprocessors
HBASE-14024ImportTsv is not loading hbase-default.xmlCriticalmapreduce
HBASE-14156Fix test failure in TestOpenTableInCoprocessorMajor.
HBASE-14146Once replication sees an error it slows down foreverMajorReplication
HBASE-14115Fix resource leak in HMasterCommandLineMajormaster, tooling
HBASE-14119Show meaningful error messages instead of stack traces in hbase shell commands. Fixing few commands in this jira.Minor.
HBASE-14065ref guide section on release candidate generation refers to old doc filesMajordocumentation
HBASE-14000Region server failed to report to Master and was stuck in reportForDuty retry loopMajorregionserver
HBASE-14106TestProcedureRecovery is flakyMajorproc-v2, test
HBASE-14076ResultSerialization and MutationSerialization can throw InvalidProtocolBufferException when serializing a cell larger than 64MBMajor.
HBASE-13971Flushes stuck since 6 hours on a regionserver.Criticalregionserver
HBASE-14050NPE in org.apache.hadoop.hbase.ipc.RpcServer$Connection.readAndProcessMinor.
HBASE-14100Fix high priority findbugs warningsMajorregionserver
HBASE-14089Remove unnecessary draw of system entropy from RecoverableZooKeeperMinor.
HBASE-14094Procedure.proto can't be compiled to C++Majorproc-v2, Protobufs
HBASE-14077Add package to hbase-protocol protobuf files.MajorProtobufs
HBASE-14041Client MetaCache is cleared if a ThrottlingException is thrownMinorClient
HBASE-13897OOM may occur when Import imports a row with too many KeyValuesMajor.
HBASE-14073TestRemoteTable.testDelete failed in the latest trunk codeMajorREST
HBASE-13997ScannerCallableWithReplicas cause Infinitely blockingMinorClient
HBASE-14029getting started for standalone still references hadoop-version-specific binary artifactsMajordocumentation
HBASE-14042Fix FATAL level logging in FSHLog where logged for non fatal exceptionsMajorOperability, wal
HBASE-13337Table regions are not assigning back, after restarting all regionservers at once.BlockerRegion Assignment
HBASE-13561ITBLL.Verify doesn't actually evaluate counters after job completesMajorintegration tests
HBASE-13988Add exception handler for lease threadMinor.
HBASE-13352Add hbase.import.version to Import usage.Major.
HBASE-14012Double Assignment and Dataloss when ServerCrashProcedure runs during Master failoverBlockermaster, Region Assignment
HBASE-13329ArrayIndexOutOfBoundsException in CellComparator#getMinimumMidpointArrayCriticalregionserver
HBASE-14011MultiByteBuffer position based reads does not work correctlyMajor.
HBASE-13861BucketCacheTmpl.jamon has wrong bucket free and used labelsMajorregionserver, UI
HBASE-14010TestRegionRebalancing.testRebalanceOnRegionServerNumberChange fails; cluster not balancedMajortest
HBASE-14005Set permission to .top hfile in LoadIncrementalHFilesTrivial.
HBASE-13970NPE during compaction in trunkMajorregionserver
HBASE-13895DATALOSS: Region assigned before WAL replay when abortCriticalRecovery, Region Assignment, wal
HBASE-13978Variable never assigned in SimpleTotalOrderPartitioner.getPartition()Majormapreduce
HBASE-13995ServerName is not fully case insensitiveMajorRegion Assignment
HBASE-13959Region splitting uses a single thread in most common casesCriticalregionserver
HBASE-13989Threshold for combined MemStore and BlockCache percentages is not checkedMajorregionserver
HBASE-13930Exclude Findbugs packages from shaded jarsMajorbuild, Client
HBASE-13863Multi-wal feature breaks reported number and size of HLogsMajorregionserver, UI
HBASE-13974TestRateLimiter#testFixedIntervalResourceAvailability may failMinortest
HBASE-13969AuthenticationTokenSecretManager is never stopped in RPCServerMinor.
HBASE-13923Loaded region coprocessors are not reported in shell status commandMajorregionserver, shell
HBASE-13893Replace HTable with Table in client testsMajorClient, test
HBASE-13835KeyValueHeap.current might be in heap when exception happens in pollRealKVMajorScanners
HBASE-13945Prefix_Tree seekBefore() does not work correctlyMajorio
HBASE-13958RESTApiClusterManager calls kill() instead of suspend() and resume()Minorintegration tests
HBASE-13938Deletes done during the region merge transaction may get eclipsedMajormaster, regionserver
HBASE-13933DBE‘s seekBefore with tags corrupts the tag’s offset information thus leading to incorrect resultsCriticalio
HBASE-13877Interrupt to flush from TableFlushProcedure causes dataloss in ITBLLBlockerintegration tests, proc-v2
HBASE-13918Fix hbase:namespace description in webUITrivialhbase
HBASE-13885ZK watches leaks during snapshotsCriticalsnapshots
HBASE-13737[HBase MOB] MOBTable cloned from a snapshot leads to data loss, when that actual snapshot and main table is deleted.Criticalmob
HBASE-13913RAT exclusion list missing asciidoctor support filesMajor.
HBASE-13279Add src/main/asciidoc/asciidoctor.css to RAT exclusion list in POMMinordocumentation
HBASE-13821WARN if hbase.bucketcache.percentage.in.combinedcache is setMinorregionserver, Usability
HBASE-13888Fix refill bug from HBASE-13686Majorregionserver
HBASE-13905TestRecoveredEdits.testReplayWorksThoughLotsOfFlushing failing consistently on branch-1.1Criticalregionserver, test
HBASE-13833LoadIncrementalHFile.doBulkLoad(Path,HTable) doesn't handle unmanaged connections when using SecureBulkLoadMajortooling
HBASE-13901Error while calling watcher on creating and deleting an HBase tableMinor.
HBASE-13892Scanner with all results filtered out results in NPECriticalClient
HBASE-13560Large compaction queue should steal from small compaction queue when idleMajorCompaction
HBASE-13878Set hbase.fs.tmp.dir config in HBaseTestingUtility.java for Phoenix UT to useMinortest
HBASE-13873LoadTestTool addAuthInfoToConf throws UnsupportedOperationExceptionMajorintegration tests
HBASE-13875Clock skew between master and region server may render restored region without server addressMajorsnapshots
HBASE-13845Expire of one region server carrying meta can bring down the masterMajormaster
HBASE-13847getWriteRequestCount function in HRegionServer uses int variable to return the count.Majorhbase, regionserver
HBASE-13811Splitting WALs, we are filtering out too many edits -> DATALOSSCriticalwal
HBASE-13853ITBLL improvements after HBASE-13811Blockerintegration tests, tooling, wal
HBASE-13686Fail to limit rate in RateLimiterMajorClient
HBASE-13851RpcClientImpl.close() can hang with cancelled replica RPCsMajorIPC/RPC
HBASE-13834Evict count not properly passed to HeapMemoryTuner.Majorhbase, regionserver
HBASE-13729Old hbase.regionserver.global.memstore.upperLimit and lowerLimit properties are ignored if presentCriticalregionserver
HBASE-13789ForeignException should not be sent to the clientMinorClient, master
HBASE-13779Calling table.exists() before table.get() end up with an empty ResultMajorClient
HBASE-13831TestHBaseFsck#testParallelHbck is flaky against hadoop 2.6+Minorhbck, test
HBASE-13826Unable to create table when group acls are appropriately set.Majorsecurity
HBASE-13824TestGenerateDelegationToken: Master fails to start in Windows environmentMinortest
HBASE-13647Default value for hbase.client.operation.timeout is too highBlockerClient
HBASE-13820Zookeeper is failing to startCritical.
HBASE-13638Put copy constructor is shallowMajorClient
HBASE-13809TestRowTooBig should use HDFS directory for its region directoryMinortest
HBASE-13812Deleting of last Column Family of a table should not be allowedMajormaster
HBASE-13813Fix Javadoc warnings in Procedure.javaMinordocumentation
HBASE-13776Setting illegal versions for HColumnDescriptor does not throw IllegalArgumentExceptionMajorAPI
HBASE-13802Procedure V2: Master fails to come up due to rollback of create namespace tableMajormaster, proc-v2
HBASE-13796ZKUtil doesn't clean quorum setting properlyMinor.
HBASE-13800TestStore#testDeleteExpiredStoreFiles should create unique data/log directory for each callMinortest
HBASE-13797Fix resource leak in HBaseFsckMinor.
HBASE-13801Hadoop src checksum is shown instead of HBase src checksum in master / RS UIMajorUI
HBASE-13723In table.rb scanners are never closed.Majorshell
HBASE-13777Table fragmentation display triggers NPE on master status pageMajorUI
HBASE-13778BoundedByteBufferPool incorrectly increasing runningAverage buffer lengthMajorio, util
HBASE-13732TestHBaseFsck#testParallelWithRetriesHbck fails intermittentlyMinorhbck, test
HBASE-13768ZooKeeper znodes are bootstrapped with insecure ACLs in a secure configurationBlockersecurity, Zookeeper
HBASE-13767Allow ZKAclReset to set and not just clear ZK ACLsTrivialOperability, Zookeeper
HBASE-13746list_replicated_tables command is not listing table in hbase shell.Majorshell
HBASE-13760Cleanup Findbugs keySet iterator warningsMinor.
HBASE-13734Improper timestamp checking with VisibilityScanDeleteTrackerMajorsecurity
HBASE-13604bin/hbase mapredcp does not include yammer-metrics jarMinor.
HBASE-13703ReplicateContext should not be a member of ReplicationSourceMinor.
HBASE-13733Failed MiniZooKeeperCluster startup did not shutdown ZK serversMajorZookeeper
HBASE-13741Disable TestRegionObserverInterface#testRecovery and testLegacyRecoveryMinor.
HBASE-13731TestReplicationAdmin should clean up MiniZKCluster resourceTrivialtest
HBASE-13709Updates to meta table server columns may be eclipsedMajorIPC/RPC, regionserver
HBASE-13721Improve shell scan performances when using LIMITMajorshell
HBASE-13700Allow Thrift2 HSHA server to have configurable threadsMajorThrift
HBASE-13719Asynchronous scanner -- cache size-in-bytes bug fixMajor.
HBASE-13618ReplicationSource is too eager to remove sinksMinor.
HBASE-13711Provide an API to set min and max versions in HColumnDescriptorMinor.
HBASE-13722Avoid non static method from BloomFilterUtilTrivial.
HBASE-13704Hbase throws OutOfOrderScannerNextException when MultiRowRangeFilter is usedMajorClient
HBASE-13717TestBoundedRegionGroupingProvider#setMembershipDedups need to set HDFS diretory for WALMinorwal
HBASE-13693[HBase MOB] Mob files are not encrypting.Majormob
HBASE-13694CallQueueSize is incorrectly decremented until the response is sentMajorIPC/RPC, master, regionserver
HBASE-13668TestFlushRegionEntry is flakyMinor.
HBASE-13699Expand information about HBase quotasMajordocumentation
HBASE-13651Handle StoreFileScanner FileNotFoundExceptionMinor.
HBASE-11830TestReplicationThrottler.testThrottling failed on virtual boxesMinortest
HBASE-13663HMaster fails to restart ‘HMaster: Failed to become active master’Majorhbase
HBASE-13217Procedure fails due to ZK issueMajor.
HBASE-13662RSRpcService.scan() throws an OutOfOrderScannerNext if the scan has a retriable failureMajorIPC/RPC, regionserver
HBASE-13533section on configuring ~/.m2/settings.xml has no anchorTrivialdocumentation
HBASE-13661Correct binary compatibility issues discovered in 1.1.0RC0Major.
HBASE-13606AssignmentManager.assign() is not sync in both pathMajorRegion Assignment
HBASE-13635Regions stuck in transition because master is incorrectly assumed deadMajormaster, regionserver
HBASE-13634Avoid unsafe reference equality checks to EMPTY byte[]MajorCompaction, Scanners
HBASE-1989Admin (et al.) not accurate with Column vs. Column-Family usageMinorClient
HBASE-13580region_mover.rb broken with TypeError: no public constructors for Java::OrgApacheHadoopHbaseClient::HTableMajorscripts
HBASE-13611update clover to work for current versionsMinorbuild
HBASE-13653Uninitialized HRegionServer#walFactory may result in NullPointerException at region server startup​Majorhbase
HBASE-13612TestRegionFavoredNodes doesn't guard against setup failureMinortest
HBASE-13649CellComparator.compareTimestamps javadoc inconsistent and wrongMinordocumentation
HBASE-13648test-patch.sh should ignore ‘protobuf.generated’Minorbuild
HBASE-13630Remove dead code in BufferedDataEncoderMinor.
HBASE-13576HBCK enhancement: Failure in checking one region should not fail the entire HBCK operation.Majorhbck
HBASE-13625Use HDFS for HFileOutputFormat2 partitioner's pathMajormapreduce
HBASE-13633draining_servers.rb broken with NoMethodError: undefined method ‘getServerInfo’Majorscripts
HBASE-13628Use AtomicLong as size in BoundedConcurrentLinkedQueueMajorutil
HBASE-13617TestReplicaWithCluster.testChangeTable timeoutMajortest
HBASE-13599The Example Provided in Section 69: Examples of the Documentation Does Not CompileMinordocumentation
HBASE-13333Renew Scanner Lease without advancing the RegionScannerMajor.
HBASE-13607TestSplitLogManager.testGetPreviousRecoveryMode consistently failingMinortest
HBASE-12413Mismatch in the equals and hashcode methods of KeyValueMinor.
HBASE-13312SmallScannerCallable does not increment scan metricsMajorClient, Scanners
HBASE-13608413 Error with Stargate through Knox, using AD, SPNEGO, and Pre-AuthMajorREST
HBASE-13601Connection leak during log splittingMajorwal
HBASE-13600check_compatibility.sh should ignore shaded jarsMinorbuild
HBASE-13595Fix Javadoc warn induced in Bytes.javaTrivial.
HBASE-13564Master MBeans are not publishedMajormaster, metrics
HBASE-13596src assembly does not buildMajorbuild
HBASE-13594MultiRowRangeFilter shouldn't call HBaseZeroCopyByteString.wrap() directlyMajor.
HBASE-13577Documentation is pointing to wrong port for Master Web UIMinordocumentation
HBASE-13585HRegionFileSystem#splitStoreFile() finishes without closing the file handle in some situationMajorregionserver
HBASE-13589[WINDOWS] hbase.cmd script is brokenMajor.
HBASE-13417batchCoprocessorService() does not handle NULL keysMinorCoprocessors
HBASE-13517Publish a client artifact with shaded dependenciesMajor.
HBASE-13575TestChoreService has to make sure that the opened ChoreService is closed for each unit testTrivial.
HBASE-13394Failed to recreate a table when quota is enabledMajorsecurity
HBASE-13490foreground daemon start re-executes ulimit outputMinorscripts
HBASE-13359Update ACL matrix to include table owner.Minordocumentation
HBASE-13149HBase MR is broken on Hadoop 2.5+ YarnBlocker.
HBASE-13546NPE on region server status page if all masters are downMajorregionserver
HBASE-13555StackServlet produces 500 errorMajor.
HBASE-13523API Doumentation formatting is brokenMinordocumentation
HBASE-13528A bug on selecting compaction poolMinorCompaction
HBASE-13526TestRegionServerReportForDuty can be flaky: hang or timeoutMinortest
HBASE-13527The default value for hbase.client.scanner.max.result.size is never actually set on ScansMajor.
HBASE-13437ThriftServer leaks ZooKeeper connectionsMajorThrift
HBASE-13524TestReplicationAdmin fails on JDK 1.8Major.
HBASE-13499AsyncRpcClient test cases failure in powerpcMajorIPC/RPC
HBASE-13471Fix a possible infinite loop in doMiniBatchMutationMajor.
HBASE-13520NullPointerException in TagRewriteCellMajor.
HBASE-13482Phoenix is failing to scan tables on secure environments.Major.
HBASE-13430HFiles that are in use by a table cloned from a snapshot may be deleted when that snapshot is deletedCriticalhbase
HBASE-13491Issue in FuzzyRowFilter#getNextForFuzzyRuleMajorFilters
HBASE-13477Create metrics on failed requestsMajor.
HBASE-13486region_status.rb broken with NameError: uninitialized constant IOExceptionMajorscripts
HBASE-13473deleted cells come back alive after the stripe compactionBlockerCompaction
HBASE-12006[JDK 8] KeyStoreTestUtil#generateCertificate fails due to “subject class type invalid”Minor.
HBASE-13460Revise the MetaLookupPool executor-related defaults (introduced in HBASE-13036)Major.
HBASE-13475Small spelling mistake in region_mover#isSuccessfulScan causes NoMethodErrorTrivialscripts
HBASE-13301Possible memory leak in BucketCacheMajorBlockCache
HBASE-13457SnapshotExistsException doesn't honor the DoNotRetryTrivialClient
HBASE-13423Remove duplicate entry for hbase.regionserver.regionSplitLimit in hbase-default.xmlMinorhbase
HBASE-13275Setting hbase.security.authorization to false does not disable authorizationMajorsecurity
HBASE-11544[Ergonomics] hbase.client.scanner.caching is dogged and will try to return batch even if it means OOMECritical.
HBASE-13414TestHCM no longer needs to test for JRE 6.Minortest
HBASE-13377Canary may generate false alarm on the first region when there are many delete markersMajormonitoring
HBASE-13289typo in splitSuccessCount metricMajormetrics
HBASE-13299Add setReturnResults() to Increment, like Append hasCriticalAPI
HBASE-13410Bug in KeyValueUtil.oswrite() for non Keyvalue casesMajor.
HBASE-13411Misleading error message when request size quota limit exceedsMinor.
HBASE-13409Add categories to uncategorized testsTrivial.
HBASE-13374Small scanners (with particular configurations) do not return all rowsBlocker.
HBASE-13406TestAccessController is flaky when create is slowMinorsecurity, test
HBASE-13397Purge duplicate rpc request thread localMajorIPC/RPC
HBASE-13382IntegrationTestBigLinkedList should use SecureRandomMajorintegration tests
HBASE-13385TestGenerateDelegationToken is broken with hadoop 2.8.0Majortest
HBASE-13388Handling NullPointer in ZKProcedureMemberRpcs while getting ZNode dataMinor.
HBASE-13058Hbase shell command ‘scan’ for non existent table shows unnecessary info for one unrelated existent table.TrivialClient
HBASE-13091Split ZK Quorum on Master WebUIMinor.
HBASE-13384Fix Javadoc warnings introduced by HBASE-12972Trivial.
HBASE-13368Hash.java is declared as public Interface - but it should be PrivateTrivial.
HBASE-13383TestRegionServerObserver.testCoprocessorHooksInRegionsMerge zombie after HBASE-12975Major.
HBASE-13296Fix the deletion of acl notify nodes for namespace.Minor.
HBASE-12954Ability impaired using HBase on multihomed hostsMinor.
HBASE-13317Region server reportForDuty stuck looping if there is a master changeMajorregionserver
HBASE-13371Fix typo in TestAsyncIPCMajortest
HBASE-13364Make using the default javac on by defaultMajorbuild
HBASE-12993Use HBase 1.0 interfaces in hbase-thriftMajor.
HBASE-13262ResultScanner doesn't return all rows in ScanBlockerClient
HBASE-13357If maxTables/maxRegions exceeds quota in a namespace, throw QuotaExceededExceptionMinor.
HBASE-13355QA bot reports checking javac twiceMinor.
HBASE-13328LoadIncrementalHFile.doBulkLoad(Path,HTable) should handle managed connectionsMajor.
HBASE-13295TestInfoServers hangMajortest
HBASE-8725Add total time RPC call metricsMajormetrics
HBASE-13265Make thrift2 usable from c++Major.
HBASE-13326Disabled table can't be enabled after HBase is restartedBlocker.
HBASE-13325Protocol Buffers 2.5 no longer available for download on code.google.comMajor.
HBASE-13294Fix the critical ancient loopholes in security testing infrastructure.Major.
HBASE-13311TestQuotaThrottle flaky on slow machineMinortest
HBASE-13305Get(Get get) is not copying the row keyMajorAPI
HBASE-13331Exceptions from DFS client can cause CatalogJanitor to delete referenced filesBlockermaster
HBASE-13273Make Result.EMPTY_RESULT read-only; currently it can be modifiedMajor.
HBASE-13321Fix flaky TestHBaseFsckMinortest
HBASE-13314Fix NPE in HMaster.getClusterStatus()Minor.
HBASE-13281‘hbase.bucketcache.size’ description in hbase book is not correctMajordocumentation
HBASE-13315BufferedMutator should be @InterfaceAudience.PublicMajor.
HBASE-13309Some tests do not reset EnvironmentEdgeManagerMinortest
HBASE-13308Fix flaky TestEndToEndSplitTransactionMajorflakey, test
HBASE-13282Fix the minor issues of running Canary on kerberized environmentMinor.
HBASE-12867Shell does not support custom replication endpoint specificationMajor.
HBASE-13274Fix misplaced deprecation in Delete#addXYZMajorAPI
HBASE-13114[UNITTEST] TestEnableTableHandler.testDeleteForSureClearsAllTableRowsFromMetaMajortest
HBASE-13285Fix flaky getRegions() in TestAccessController.setUp()Minortest
HBASE-13188java.lang.ArithmeticException issue in BoundedByteBufferPool.putBufferMajor.
HBASE-13200Improper configuration can leads to endless lease recovery during failoverMajorMTTR
HBASE-13253LoadIncrementalHFiles unify hfiles discoveryMajorClient, mapreduce
HBASE-13229Specify bash for local-regionservers.sh and local-master-backup.shMinorscripts
HBASE-13176Flakey TestZooKeeper test.Major.
HBASE-13093Local mode HBase instance doesn't shut down.Major.
HBASE-12908Typos in MemStoreFlusher javadocsTrivialdocumentation
HBASE-13254EnableTableHandler#prepare would not throw TableNotFoundException during recoveryMinor.
HBASE-13193RegionScannerImpl filters should not be reset if a partial Result is returnedMajor.
HBASE-13246Correct the assertion for namespace permissions in tearDown method of TestAccessControllerMinorsecurity, test
HBASE-13239HBase grant at specific column level does not work for GroupsMajorhbase
HBASE-13242TestPerColumnFamilyFlush.testFlushingWhenLogRolling hungMajortest
HBASE-13227LoadIncrementalHFile should skip non-files inside a possible family-dirMinorClient, mapreduce
HBASE-13232ConnectionManger : Batch pool threads and metaLookup pool threads should use different name patternTrivial.
HBASE-13097Use same EventLoopGroup for different AsyncRpcClients if possibleMajorIPC/RPC, test
HBASE-13136TestSplitLogManager.testGetPreviousRecoveryMode is flakeyMajor.
HBASE-13224Minor formatting issue when logging a namespace scope in AuthResult#toContextStringTrivialCoprocessors, security
HBASE-13194TableNamespaceManager not ready cause MasterQuotaManager initialization failMajormaster
HBASE-13218Correct the syntax shown for using ExportSnapshot tool in the bookMinordocumentation
HBASE-13167The check for balancerCutoffTime is buggyTrivialBalancer
HBASE-13192IntegrationTestBulkLoad doesn't wait for table modification sometimes leading to spurious test failuresMajor.
HBASE-13191mvn site fails on jenkins due to permgenMajor.
HBASE-13208Patch build should match the patch filename and not the whole relative URL in findBranchNameFromPatchNameTrivial.
HBASE-13206Fix TableLock tableName log formatTrivial.
HBASE-13165Fix docs and scripts for default max heaps size after HBASE-11804Minordocumentation, scripts
HBASE-13174Apply HBASE-11804 to Windows scriptsMajorscripts
HBASE-13196Add info about default number of versions when using the export toolMajordocumentation
HBASE-13181TestHRegionReplayEvents.testReplayBulkLoadEvent fails frequently.Minor.
HBASE-13186HBase build error due to checkstyleMajorbuild
HBASE-12931The existing KeyValues in memstore are not removed completely after inserting cell into memStoreMinor.
HBASE-12723Update ACL matrix to reflect realityMajor.
HBASE-13023Document multiWALMajordocumentation, wal
HBASE-12468AUTHORIZATIONS should be part of Visibility Label DocsMajordocumentation
HBASE-13135Move replication ops mgmt stuff from Javadoc to Ref GuideMajordocumentation, Replication
HBASE-12969Parameter Validation is not there for shell script, local-master-backup.sh and local-regionservers.shMinorscripts
HBASE-13084Add labels to VisibilityLabelsCache asynchronously causes TestShell flakeyMajortest
HBASE-13150TestMasterObserver failing disable table at end of testMajortest
HBASE-13163Add HBase version to header and footer of HTML and PDF docsMajordocumentation
HBASE-13076Table can be forcibly enabled in AssignmentManager during table disabling.Majormaster, Region Assignment
HBASE-13155Fix TestPrefixTreeMajortest
HBASE-13156Fix minor rat violation recently introduced (asciidoctor.css).Major.
HBASE-13052Explain each region split policyMajordocumentation
HBASE-13146Race Condition in ScheduledChore and ChoreServiceMajorregionserver
HBASE-13145TestNamespaceAuditor.testRegionMerge is flakyMajortest
HBASE-13139Clean up missing JAVA_HOME message in bin/hbase-config.shTrivialshell
HBASE-13115Fix the usage of remote user in thrift doAs implementation.Major.
HBASE-13141IntegrationTestAcidGuarantees returns incorrect values for getColumnFamiliesMajorintegration tests
HBASE-13134mutateRow and checkAndMutate apis don't throw region level exceptionsMajor.
HBASE-13123Minor bug in ROW bloom filterMinor.
HBASE-13133NPE when running TestSplitLogManagerMajor.
HBASE-13131ReplicationAdmin leaks connections if there's an error in the constructorCriticalReplication
HBASE-12924HRegionServer#MovedRegionsCleaner Chore does not startMinor.
HBASE-13119FileLink should implement equalsMajor.
HBASE-13112quota.rb, security.rb and visibility_labels.rb leak connectionMajorshell
HBASE-13111truncate_preserve command is failing with undefined method errorMajorshell
HBASE-13102Fix Pseudo-distributed Mode which was broken in 1.0.0Major.
HBASE-13048Use hbase.crypto.wal.algorithm in SecureProtobufLogReader while decrypting the dataMinor.
HBASE-13085Security issue in the implementation of Rest gataway ‘doAs’ proxy user supportCriticalREST, security
HBASE-13077BoundedCompletionService doesn't pass trace info to serverMajorhbase
HBASE-13083Master can be dead-locked while assigning META.Majormaster, Region Assignment
HBASE-12953RegionServer is not functionally working with AysncRpcClient in secure modeCriticalsecurity
HBASE-13001NullPointer in master logs for table.jspTrivial.
HBASE-13032Migration of states should be performed once META is assigned and onlined.Major.
HBASE-13070Fix possibly zero length family and qualifier is TestCacheOnWriteMajortest
HBASE-13081Branch precommit builds are not updating to branch head before patch applicationMajor.
HBASE-13069Thrift Http Server returns an error code of 500 instead of 401 when authentication failsMinor.
HBASE-13072BucketCache.evictBlock returns true if block does not existMajorBlockCache
HBASE-13075TableInputFormatBase spuriously warning about multiple initializeTable callsMinormapreduce
HBASE-13036Meta scanner should use its own threadpoolMajor.
HBASE-13065Increasing -Xmx when running TestDistributedLogSplittingMajortest
HBASE-13066Fix typo in AsyncRpcChannelMajorIPC/RPC
HBASE-12102Duplicate keys in HBase.RegionServer metrics JSONMinor.
HBASE-13061RegionStates can remove wrong region from server holdingsMajorRegion Assignment
HBASE-13050Hbase shell create_namespace command throws ArrayIndexOutOfBoundException for (invalid) empty text input.Trivial.
HBASE-12948Calling Increment#addColumn on the same column multiple times produces wrong resultCriticalClient, regionserver
HBASE-13040Possible failure of TestHMasterRPCExceptionMajortest
HBASE-13055HRegion FIXED_OVERHEAD missed one booleanMajor.
HBASE-12412update the ref guide(currently Example 10.2) to show “update an existing CF” with the new API modifyFamily in masterMinordocumentation
HBASE-13041TestEnableTableHandler should not call AssignmentManager#assign concurrently with masterMajorintegration tests
HBASE-13047Add “HBase Configuration” link missing on the table details pagesTrivialOperability
HBASE-13011TestLoadIncrementalHFiles is flakey when using AsyncRpcClient as client implementationMajor.
HBASE-13049wal_roll ruby command doesn't work.Majorshell
HBASE-13029Table state should be deleted from META as a last operation in DeleteTableHandlerMajormaster
HBASE-13007Fix the test timeouts being caused by ChoreServiceMajor.
HBASE-12920hadoopqa should compile with different hadoop versionsMajor.
HBASE-12999Make foreground_start return the correct exit codeMajorshell
HBASE-13004Make possible to explain why HBaseTestingUtility.waitFor failsMinortest
HBASE-12961Negative values in read and write region server metricsMinorregionserver
HBASE-12964Add the ability for hbase-daemon.sh to start in the foregroundMajor.
HBASE-7332[webui] HMaster webui should display the number of regions a table has.MinorUI
HBASE-12951TestHCM.testConnectionClose is flakey when using AsyncRpcClient as client implementationMajorIPC/RPC
HBASE-12877Hbase documentation- a referenced link is not workingMinordocumentation
HBASE-12922Post-asciidoc conversion fix-ups part 2Majordocumentation
HBASE-12902Post-asciidoc conversion fix-upsMajordocumentation
HBASE-12903Fix configuration which enables secure bulk loadMajorCoprocessors, documentation
HBASE-12871Document JDK versions supported by each release missing in new documentationMinordocumentation
HBASE-12845ByteBufferOutputStream should grow as direct buffer if the initial buffer is also direct BBMinor.
HBASE-12858Remove unneeded files under src/main/docbkxMajordocumentation
HBASE-11983HRegion constructors should not create HLogMajorwal
HBASE-12849LoadIncrementalHFiles should use unmanaged connection in branch-1Majormapreduce
HBASE-12777Multi-page book has broken links that work in the single-page versionMajordocumentation
HBASE-12838After HBASE-5162 RSRpcServices accidentally applies mutations twiceMajor.
HBASE-12775CompressionTest ate my HFile (sigh!)Majortest
HBASE-12772TestPerColumnFamilyFlush failingMajortest
HBASE-12749Tighten HFileLink api to enable non-snapshot usesMajorsnapshots
HBASE-12734TestPerColumnFamilyFlush.testCompareStoreFileCount is flakeyMinor.
HBASE-12703Cleanup TestClientPushback for repeatabilityMinortest
HBASE-12688Update site with a bootstrap-based UIMajorwebsite
HBASE-12682compaction thread throttle value is not correct in hbase-default.xmlMajorregionserver
HBASE-12690list_quotas command is failing with not able to load Java classMajorshell
HBASE-12687Book is missing stylingMajordocumentation
HBASE-12693[docs] nit fix in HBase and MapReduce sectionMajordocumentation
HBASE-12677Update replication docs to clarify terminologyMajordocumentation
HBASE-9763Scan javadoc doesn't fully capture semantics of start and stop rowMinordocumentation
HBASE-11153Document that http webUI's should redirect to https when enabledMinordocumentation, master, regionserver, UI
HBASE-12540TestRegionServerMetrics#testMobMetrics test failureMajortest
HBASE-12628Update instructions for running shell tests using maven.Minordocumentation, shell
HBASE-12553request value is not consistent for restoreSnapshot in audit logsMinorsecurity
HBASE-12548Improve debuggability of IntegrationTestTimeBoundedRequestsWithRegionReplicasMinor.
HBASE-12603Remove javadoc warnings introduced due to removal of unused importsMajor.
HBASE-12474Incorrect handling of default namespace in user_permission command.Minor.
HBASE-12552listSnapshots should list only owned snapshots for non-super userMajorsnapshots
HBASE-12073Shell command user_permission fails on the table created by user if he is not global admin.Minor.
HBASE-12535NPE in WALFactory close under contention for getInstanceMajorReplication, wal
HBASE-12532TestFilter failing occasionally with ExitCodeException doing chmod since HBASE-10378Majortest
HBASE-12421Clarify ACL concepts and best practicesMajordocumentation, security
HBASE-12488Small bug in publish_hbase_website.sh scriptMinorscripts
HBASE-12347Fix the edge case where Hadoop QA's parsing of attached patches breaks the JIRA status checker in dev-support/rebase_all_git_branches.shMinorscripts
HBASE-12409Add actual tunable parameters for finding optimal # of regions per RSMajordocumentation, Performance
HBASE-12397CopyTable fails to compile with the Hadoop 1 profileMajor.
HBASE-12418Multiple branches for MOB feature breaking git for case insensitive filesystemsBlocker.
HBASE-12380TestRegionServerNoMaster#testMultipleOpen is flaky after HBASE-11760Majortest
HBASE-12326Document scanner timeout workarounds in troubleshooting sectionMajordocumentation
HBASE-12283Clean up some checkstyle errorsMajor.
HBASE-12307Remove unused Imports in hbase-client and hbase-commonMinor.
HBASE-12192Remove EventHandlerListenerMajormaster
HBASE-12186Formatting error in Table 8.2. Examples of Visibility ExpressionsMajordocumentation
HBASE-12216Lower closed region logging levelMinor.
HBASE-12201Close the writers in the MOB sweep toolMinor.
HBASE-11998Document a workflow for cherry-picking a fix to a different branchMajordocumentation
HBASE-12193Add missing docbook file to gitMajordocumentation
HBASE-12172Disable flakey TestRegionReplicaReplicationEndpoint and make fixing it a blocker on 1.0Majortest
HBASE-11957Backport to 0.94 HBASE-5974 Scanner retry behavior with RPC timeout on next() seems incorrectCritical.
HBASE-12030Wrong compaction report and assert when MOB compaction switches to minorCriticalCompaction, regionserver
HBASE-12005Split/merge fails if master restarts before PONRMajor.
HBASE-12027The ZooKeeperWatcher in HMobStore only uses the default confMajor.
HBASE-11987Make zk-less table states backward compatible.Major.
HBASE-11968If MOB is enabled, it should make sure hfile v3 is being used.Major.
HBASE-11721jdiff script no longer works as usage instructions indicateMajorscripts
HBASE-8674JUnit and Surefire TRUNK-HBASE-2 plugins need a new homeMajorbuild
HBASE-11855HBase handbook chapter 18.9 out of dateMinordocumentation
HBASE-11689Track meta in transitionMajorRegion Assignment
HBASE-11834TestHRegionBusyWait.testParallelAppendWithMemStoreFlush fails sporadicallyMajortest
HBASE-11732Should not preemptively offline a regionMajorRegion Assignment
HBASE-11658Piped commands to hbase shell should return non-zero if shell command failed.Majorshell
HBASE-11333Remove deprecated class MetaMigrationConvertingToPBTrivialmaster
HBASE-11661Quickstart chapter claims standalone mode has multiple processesMinordocumentation
HBASE-11629Operational concerns for Replication should call out ZooKeeperMajordocumentation, Replication
HBASE-11640Add syntax highlighting support to HBase Ref Guide programlistingsMajordocumentation
HBASE-11648Typo of config: hbase.hstore.compaction.ratio in book.xmlMinorCompaction
HBASE-11539Expand info about contributing to and building documentationMajordocumentation
HBASE-11316Expand info about compactions beyond HBASE-11120MajorCompaction, documentation
HBASE-11522Move Replication information into the Ref GuideMajordocumentation
HBASE-11560hbase.regionserver.global.memstore.size is documented twiceMajor.
HBASE-11529Images and CSS still don't work properly on both html and html-single bookMajordocumentation
HBASE-11521Modify pom.xml to copy the images/ and css/ directories to the right location for the Ref Guide to see them correctlyCriticaldocumentation
HBASE-8473add note to ref guide about snapshots and ec2 reverse dns requirements.Majordocumentation, snapshots
HBASE-11499AsyncProcess.buildDetailedErrorMessage concatenates strings using + in a loopTrivialClient
HBASE-11500Possible null pointer dereference of regionLocation in ReversedScannerCallableMinorClient

TESTS:

JIRASummaryPriorityComponent
HBASE-20228[Umbrella] Verify 1.2.7 shell works against 2.0.0 serverBlockershell
HBASE-20272TestAsyncTable#testCheckAndMutateWithTimeRange fails due to TableExistsExceptionMajor.
HBASE-20107Add a test case for HBASE-14317Minorwal
HBASE-20052TestRegionOpen#testNonExistentRegionReplica fails due to NPEMajor.
HBASE-20031Unable to run integration test using mvn due to missing HBaseClassTestRuleMajor.
HBASE-19949TestRSGroupsWithACL fails with ExceptionInInitializerErrorMajor.
HBASE-19869Wrong class name used in TestLockManagerTrivial.
HBASE-19832TestConfServlet#testWriteJson fails against hadoop3 due to spelling changeMinor.
HBASE-19514Use random port for TestJMXListenerMinor.
HBASE-19289CommonFSUtils$StreamLacksCapabilityException: hflush when running test against hadoop3 beta1Critical.
HBASE-19342fix TestTableBasedReplicationSourceManagerImpl#testRemovePeerMetricsCleanupMajortest
HBASE-19266TestAcidGuarantees should cover adaptive in-memory compactionMinor.
HBASE-19288Intermittent test failure in TestHStore.testRunDoubleMemStoreCompactorsMajortest
HBASE-19299Assert only one Connection is constructed when calculating splits in a MultiTableInputFormatMinortest
HBASE-19273IntegrationTestBulkLoad#installSlowingCoproc() uses read-only HTableDescriptorMajor.
HBASE-19248TestZooKeeper#testMultipleZK fails due to missing method getKeepAliveZooKeeperWatcherCriticalZookeeper
HBASE-19237TestMaster.testMasterOpsWhileSplitting failsMajor.
HBASE-16051TestScannerHeartbeatMessages fails on some machinesMajortest
HBASE-19026TestLockProcedure#testRemoteNamespaceLockRecovery fails in masterMajor.
HBASE-18902TestCoprocessorServiceBackwardCompatibility failsMajor.
HBASE-18632TestMultiParallel#testFlushCommitsWithAbort fails in master branchMajortest
HBASE-18147nightly job to check health of active branchesMajorcommunity, test
HBASE-17806TestRSGroups#testMoveServersAndTables is flaky in master branchMajor.
HBASE-17703TestThriftServerCmdLine is flaky in master branchMajor.
HBASE-17672“Grant should set access rights appropriately” test failsMajor.
HBASE-17657TestZKAsyncRegistry is flakyMajor.
HBASE-17628Local mode of mini cluster shouldn't use hdfsMinor.
HBASE-17474Reduce frequency of NoSuchMethodException when calling setStoragePolicy()Minor.
HBASE-17371Enhance ‘HBaseContextSuite @ distributedScan to test HBase client’ with filterMinor.
HBASE-17246TestSerialReplication#testRegionMerge fails in master branchMajor.
HBASE-17189TestMasterObserver#wasModifyTableActionCalled uses wrong variablesMinortest
HBASE-17080rest.TestTableResource fails in master branchMajor.
HBASE-17120TestAssignmentListener#testAssignmentListener failsMinor.
HBASE-16975Disable two subtests of TestSerialReplicationMinor.
HBASE-16274Add more peer tests to replication_admin_testMinor.
HBASE-16781Fix flaky TestMasterProcedureWalLeaseMinorproc-v2, test
HBASE-16794TestDispatchMergingRegionsProcedure#testMergeRegionsConcurrently is flakyMinortest
HBASE-16791Fix TestDispatchMergingRegionsProcedureMinortest
HBASE-16777Fix flaky TestMasterProcedureEventsTrivialproc-v2, test
HBASE-16778Move testIllegalTableDescriptor out from TestFromClientSideTrivialtest
HBASE-16776Remove duplicated versions of countRow() in testsTrivialtest
HBASE-16725Don't let flushThread hang in TestHRegionMinor.
HBASE-16671Split TestExportSnapshotMinorsnapshots, test
HBASE-16349TestClusterId may hang during cluster shutdownMinor.
HBASE-16634Speedup TestExportSnapshotMinorsnapshots, test
HBASE-16639TestProcedureInMemoryChore#testChoreAddAndRemove occasionally failsMinor.
HBASE-16418Reduce duration of sleep waiting for region reopen in IntegrationTestBulkLoad#installSlowingCoproc()Minor.
HBASE-16185TestReplicationSmallTests fails in master branchMajor.
HBASE-16049TestRowProcessorEndpoint is failing on Apache BuildsMajor.
HBASE-15939Two shell test failures on masterMajor.
HBASE-15923Shell rows counter test failsMajor.
HBASE-15760TestBlockEvictionFromClient#testParallelGetsAndScanWithWrappedRegionScanner fails in master branchMinor.
HBASE-15679Assertion on wrong variable in TestReplicationThrottler#testThrottlingMinor.
HBASE-13372Unit tests for SplitTransaction and RegionMergeTransaction listenersMajor.
HBASE-15420TestCacheConfig failed after HBASE-15338Minortest
HBASE-15192TestRegionMergeTransactionOnCluster#testCleanMergeReference is flakyMinor.
HBASE-14584TestNamespacesInstanceModel fails on jdk8MajorREST, test
HBASE-14758Add UT case for unchecked error/exception thrown in AsyncProcess#sendMultiActionMinorClient, test
HBASE-14728TestRowCounter is broken in masterMajor.
HBASE-14688Cleanup MOB testsTrivialmob
HBASE-14466Remove duplicated code from MOB snapshot testsTrivialmob, test
HBASE-14344Add timeouts to TestHttpServerLifecycleMinortest
HBASE-14310test-patch.sh should handle spurious non-zero exit code from mavenMinor.
HBASE-14293TestStochasticBalancerJmxMetrics intermittently fails due to port conflictMinor.
HBASE-14277TestRegionServerHostname.testRegionServerHostname may fail at host with a case sensitive nameMinortest
HBASE-14210Create test for cell level ACLs involving user groupMajortest
HBASE-14200Separate RegionReplica subtests of TestStochasticLoadBalancer into TestStochasticLoadBalancer2Minor.
HBASE-14197TestRegionServerHostname#testInvalidRegionServerHostnameAbortsServer fails in JenkinsMinor.
HBASE-13940IntegrationTestBulkLoad needs option to specify output folders used by testMajorintegration tests
HBASE-13609TestFastFail is still failingMajortest
HBASE-13591TestHBaseFsck is flakeyMajorhbck
HBASE-13413Create an integration test for ReplicationMinorintegration tests
HBASE-13280TestSecureRPC failedMinor.
HBASE-13182Test NamespaceAuditor/AccessController create/delete table is flakyMinortest
HBASE-13179TestMasterObserver deleteTable is flakyMinortest
HBASE-13106Ensure endpoint-only table coprocessors can be dynamically loadedTrivial.
HBASE-12992TestChoreService doesn't close services, that can break test on slow virtual hosts.Major.
HBASE-12764TestPerColumnFamilyFlush#testCompareStoreFileCount may fail due to new table not availableMinor.
HBASE-11867TestSplitLogManager.testUnassignedTimeout is flakyMinor.
HBASE-11866TestDistributedLogSplitting is flakyMinor.
HBASE-11673TestIOFencing#testFencingAroundCompactionAfterWALSync failsMajor.
HBASE-4744Remove @Ignore for testLogRollAfterSplitStartCritical.
HBASE-11616TestNamespaceUpgrade fails in trunkMajor.
HBASE-11039[VisibilityController] Integration test for labeled data set mixing and filtered exciseCritical.
HBASE-11461Compilation errors are not posted back to JIRA during QA runMinor.

SUB-TASKS:

JIRASummaryPriorityComponent
HBASE-20059Make sure documentation is updated for the offheap Bucket cache usageCriticaldocumentation
HBASE-20454[DOC] Add note on perf to upgrade sectionMajor.
HBASE-20347[DOC] upgrade section should warn about logging changesCriticaldocumentation, logging
HBASE-20349[DOC] upgrade guide should call out removal of prefix-tree data block encodingCriticaldocumentation
HBASE-17554Figure 2.0.0 Hadoop Version Support; update refguideBlockerdocumentation
HBASE-20253Error message is missing for restore_snapshotMinorshell
HBASE-20380Put up 2.0.0RC0Major.
HBASE-20149Purge dev javadoc from bin tarball (or make a separate tarball of javadoc)Criticalbuild, community, documentation
HBASE-18828[2.0] Generate CHANGES.txtBlocker.
HBASE-20287After cluster startup list_regions command fails on disabled tableMinorshell
HBASE-20258Shell hangs when scanning a disabled tableMajor.
HBASE-20354[DOC] quickstart guide needs to include note about durability checks for standalone modeBlockerdocumentation, hadoop3
HBASE-17730[DOC] Migration to 2.0 for coprocessorsBlockerdocumentation, migration
HBASE-20337Update the doc on how to setup shortcircuit reads; its staleMajor.
HBASE-20298Doc change in read/write/total accounting metricsCriticaldocumentation
HBASE-16848Usage for show_peer_tableCFs command doesn't include peerMinor.
HBASE-20254Incorrect help message for merge_regionMinorshell
HBASE-17819Reduce the heap overhead for BucketCacheCriticalBucketCache
HBASE-20245HTrace commands do not workMajor.
HBASE-20241splitormerge_enabled does not workCriticalshell
HBASE-20202[AMv2] Don't move region if its a split parent or offlinedCriticalamv2
HBASE-20247Set version as 2.0.0 in branch-2.0 in prep for first RCMajor.
HBASE-20232[LOGGING] Formatting around close and flushMajor.
HBASE-20190Fix default for MIGRATE_TABLE_STATE_FROM_ZK_KEYCritical.
HBASE-20180Avoid Class::newInstanceMajor.
HBASE-20178[AMv2] Throw exception if hostile environmentMajoramv2
HBASE-20173[AMv2] DisableTableProcedure concurrent to ServerCrashProcedure can deadlockCriticalamv2
HBASE-19093Check Admin/Table to ensure all operations go via AccessControlBlocker.
HBASE-19114Split out o.a.h.h.zookeeper from hbase-server and hbase-clientMajor.
HBASE-18758[TEST][compat 1-2] Test delegation tokens continue to work when hbase1 going against hbase2 clusterCriticalAPI
HBASE-20113Move branch-2 version from 2.0.0-beta-2-SNAPSHOT to 2.0.0-beta-2Major.
HBASE-20100TestEnableTableProcedure flakeyMajoramv2, flakey
HBASE-19400Add missing security checks in MasterRpcServicesMajor.
HBASE-20069fix existing findbugs errors in hbase-serverCriticalfindbugs
HBASE-20036TestAvoidCellReferencesIntoShippedBlocks timed outMajor.
HBASE-20083Fix findbugs error for ReplicationSyncUpMajorfindbugs
HBASE-20019Document the ColumnValueFilterMinordocumentation
HBASE-20048Revert serial replication featureBlockerReplication
HBASE-20044TestClientClusterStatus is flakeyMajorflakey
HBASE-19554AbstractTestDLS.testThreeRSAbort sometimes fails in pre commitMajorRecovery, wal
HBASE-20038TestLockProcedure.testTimeout is flakeyMajorproc-v2, test
HBASE-20041cannot start mini mapreduce cluster for ITsMajor.
HBASE-20035.TestQuotaStatusRPCs.testQuotaStatusFromMaster failed with NPEs and RuntimeExceptionsMajor.
HBASE-20039move testhbasetestingutility mr tests to hbase-mapreduceMajor.
HBASE-20021TestFromClientSideWithCoprocessor is flakeyMajor.
HBASE-20029@Ignore TestQuotaThrottle and TestReplicasClient#testCancelOfMultiGetMajor.
HBASE-20015TestMergeTableRegionsProcedure and TestRegionMergeTransactionOnCluster flakeyMajorflakey
HBASE-20013TestZKPermissionWatcher is flakeyMajorflakey
HBASE-20014TestAdmin1 Times outMajor.
HBASE-19978The keepalive logic is incomplete in ProcedureExecutorMajor.
HBASE-20011Disable TestRestoreSnapshotFromClientWithRegionReplicas; it is flakey. Needs attention.Majorread replicas
HBASE-19903Split TestShell so it will not time outMajorshell, test
HBASE-20000Remove the quantum logic in FairQueue, always put high priority queue in frontMajorproc-v2
HBASE-19116Currently the tail of hfiles with CellComparator* classname makes it so hbase1 can't open hbase2 written hfiles; fixCriticalHFile, migration
HBASE-19965Fix flaky TestAsyncRegionAdminApiCritical.
HBASE-19960Doc test timeouts and test categories in hbase2Major.
HBASE-19942Fix flaky TestSimpleRpcSchedulerMajor.
HBASE-19956Remove category as a consideration timing out tests; set all test to timeout at 10minutes regardlessMajor.
HBASE-19951Cleanup the explicit timeout value for test methodMajor.
HBASE-19791TestZKAsyncRegistry hangsCritical.
HBASE-19840Flakey TestMetaWithReplicasMajorflakey, test
HBASE-19927TestFullLogReconstruction flakeyMajorwal
HBASE-19841Tests against hadoop3 fail with StreamLacksCapabilityExceptionMajor.
HBASE-19944Fix timeout TestVisibilityLabelsWithCustomVisLabServiceMajor.
HBASE-19931TestMetaWithReplicas failing 100% of the time in testHBaseFsckWithMetaReplicasMajor.
HBASE-19837Flakey TestRegionLoadMajorflakey, test
HBASE-19803False positive for the HBASE-Find-Flaky-Tests jobMajor.
HBASE-19910TestBucketCache TimesOutMajor.
HBASE-19916TestCacheOnWrite Times OutMajor.
HBASE-19914Refactor TestVisibilityLabelsOnNewVersionBehaviorTableMajortest
HBASE-19868TestCoprocessorWhitelistMasterObserver is flakeyMajorflakey, test
HBASE-19908TestCoprocessorShortCircuitRPC Timeout....Major.
HBASE-19909TestRegionLocationFinder TimeoutMajor.
HBASE-19928TestVisibilityLabelsOnNewVersionBehaviorTable failsMajortest
HBASE-19918Promote TestAsyncClusterAdminApi to LargeTestsMajortest
HBASE-19896Fix ScanInfo.customize() to update only the requested optionsMajorCoprocessors
HBASE-19895Add keepDeletedCells option in ScanOptions for customizing scanInfo in pre-hooksMajorCoprocessors
HBASE-19913Split TestStochasticLoadBalancer2Majortest
HBASE-19839Flakey TestMergeTableRegionsProcedure & TestSplitTableRegionProcedureMajorflakey, test
HBASE-19911Convert some tests from small to medium because they are timing out: TestNettyRpcServer, TestClientClusterStatus, TestCheckTestClassesMajor.
HBASE-19887Do not overwrite the surefire junit listener property in the pom of sub modulesMajorbuild
HBASE-19891Up nightly test run timeout from 6 hours to 8Major.
HBASE-19811Fix findbugs and error-prone warnings in hbase-server (branch-2)Major.
HBASE-19885Promote TestAssignmentManager to LargeTestsMajor.
HBASE-19866TestRegionServerReportForDuty doesn't timeoutMajorrpc
HBASE-19882Promote TestProcedureManager to MediumTestsMajortest
HBASE-19877hbase-common and hbase-zookeeper don't add the log4j.properties to the resource path for testingCriticaltest
HBASE-19870Fix the NPE in ReadOnlyZKClient#runMajor.
HBASE-19881Promote TestRegionReplicaReplicationEndpoint to LargeTestsMajortest
HBASE-19880Promote TestFuzzyRowFilterEndToEnd to LargeTestsMajortest
HBASE-19879Promote TestAcidGuaranteesXXX to LargeTestsMajortest
HBASE-19867Split TestStochasticLoadBalancer into several small testsMajortest
HBASE-19862Fix TestTokenAuthentication - fake RegionCoprocessorEnvironment is not of type HasRegionServerServicesMajor.
HBASE-19846Fix findbugs and error-prone warnings in hbase-rest (branch-2)Major.
HBASE-19845Fix findbugs and error-prone warnings in hbase-rsgroup (branch-2)Major.
HBASE-19847Fix findbugs and error-prone warnings in hbase-thrift (branch-2)Major.
HBASE-19827Addendum for Flakey TestAssignmentManagerMajorflakey, test
HBASE-18963Remove MultiRowMutationProcessor and implement mutateRows... methods using batchMutate()Majorregionserver
HBASE-19527Make ExecutorService threads daemon=true.Major.
HBASE-19810Fix findbugs and error-prone warnings in hbase-metrics (branch-2)Major.
HBASE-19809Fix findbugs and error-prone warnings in hbase-procedure (branch-2)Major.
HBASE-19793Minor improvements on Master/RS startupMajor.
HBASE-19795Move the tests which only need zookeeper in TestZooKeeper to hbase-zookeeper moduleMajor.
HBASE-19772Do not close connection to zk when there are still pending request in ReadOnlyZKClientMajorZookeeper
HBASE-19787Fix or disable tests broken in branch-2 so can cut beta-1Critical.
HBASE-19746Add default impl to Cell#getTypeCritical.
HBASE-19743Disable TestMemstoreLABWithoutPoolMajortest
HBASE-19731TestFromClientSide#testCheckAndDeleteWithCompareOp and testNullQualifier are flakeyCriticaltest
HBASE-19604Fix Checkstyle errors in hbase-protocol-shadedMinor.
HBASE-19581Fix Checkstyle error in hbase-external-blockcacheTrivial.
HBASE-19667Get rid of MasterEnvironment#supportGroupCPsMajorCoprocessors
HBASE-19670Workaround: Purge User API building from branch-2 so can make a beta-1Majorwebsite
HBASE-19428Deprecate the compareTo(Row)Major.
HBASE-19282CellChunkMap Benchmarking and User InterfaceMajor.
HBASE-19660Up default retries from 10 to 15 and blocking store files limit from 10 to 16Major.
HBASE-19133Transfer big cells or upserted/appended cells into MSLAB upon flattening to CellChunkMapMajor.
HBASE-19653Reduce the default hbase.client.start.log.errors.counterTrivialdefaults
HBASE-19626Rename Cell.DataType to Cell.TypeMinor.
HBASE-19648Move branch-2 version from 2.0.0-beta-1-SNAPSHOT to 2.0.0-beta-1Major.
HBASE-19609Fix Checkstyle errors in hbase-metricsMinormetrics
HBASE-19628ByteBufferCell should extend ExtendedCellMajor.
HBASE-19629RawCell#getTags should return the Iterator<Tag> in order to avoid iterating through whole tag array at onceMajor.
HBASE-19605Fix Checkstyle errors in hbase-metrics-apiMinormetrics
HBASE-19602Cleanup the usage of ReplicationAdmin from documentMinor.
HBASE-19502Make sure we have closed all StoreFileScanners if we fail to open any StoreFileScannersMajorregionserver, Scanners
HBASE-19591Cleanup the usage of ReplicationAdmin from hbase-shellMajor.
HBASE-10092Move to slf4jCritical.
HBASE-19575add copy constructor to MutationMajor.
HBASE-19566Fix Checkstyle errors in hbase-client-projectTrivial.
HBASE-19567ClassNotFoundException: org.apache.hadoop.hbase.KeyValue$RawBytesComparator starting 2.0.0 over a 0.98.25 data.MajorHFile
HBASE-19468FNFE during scans and flushesCriticalregionserver, Scanners
HBASE-19556Remove TestAssignmentManager#testGoodSplit, which no longer make senseMinor.
HBASE-19494Create simple WALKey filter that can be plugged in on the Replication SinkMajorReplication
HBASE-19480Enable Checkstyle in hbase-annotationsTrivial.
HBASE-19481Enable Checkstyle in hbase-error-proneTrivial.
HBASE-19538Remove unnecessary semicolons in hbase-clientMinor.
HBASE-19539Remove unnecessary semicolons in hbase-commonMinor.
HBASE-18440ITs and Actions modify immutable TableDescriptorsMajorintegration tests
HBASE-19112Suspect methods on Cell to be deprecatedBlockerClient
HBASE-19474Bring down number of Checkstyle errors in hbase-zookeeperMinorZookeeper
HBASE-19479Fix Checkstyle error in hbase-shellTrivialshell
HBASE-19497Fix findbugs and error-prone warnings in hbase-common (branch-2)Major.
HBASE-19498Fix findbugs and error-prone warnings in hbase-client (branch-2)Major.
HBASE-19272Deal with HBCK tests disabled by HBASE-14614 AMv2 when HBCK works again...Majorhbck
HBASE-15536Make AsyncFSWAL as our default WALCriticalwal
HBASE-19505Disable ByteBufferPool by default at HMMajor.
HBASE-19462Deprecate all addImmutable methods in PutMajor.
HBASE-19000Group multiple block cache clear requests per serverMajor.
HBASE-19213Align check and mutate operations in Table and AsyncTableMinorAPI
HBASE-19427Add TimeRange support into Append to optimize for countersMajor.
HBASE-16890Analyze the performance of AsyncWAL and fix the sameBlockerwal
HBASE-19375Fix import order in hbase-thriftTrivialThrift
HBASE-19373Fix Checkstyle error in hbase-annotationsTrivial.
HBASE-19360Remove unused imports from hbase-zookeeper moduleMinorZookeeper
HBASE-19301Provide way for CPs to create short circuited connection with custom configurationsMajorCoprocessors
HBASE-19439Mark ShortCircuitMasterConnection with InterfaceAudience PrivateMajor.
HBASE-19430Remove the SettableTimestamp and SettableSequenceIdMajor.
HBASE-19295The Configuration returned by CPEnv should be read-only.MajorCoprocessors
HBASE-18112Write RequestTooBigException back to client for NettyRpcServerMajorIPC/RPC
HBASE-19426Move has() and setTimestamp() to MutationMajorClient
HBASE-19399Purge curator dependency from hbase-clientMajorClient, Zookeeper
HBASE-19344improve asyncWAL by using Independent thread for netty #IO in FanOutOneBlockAsyncDFSOutputMajorwal
HBASE-19346Use EventLoopGroup to create AsyncFSOutputMajorwal
HBASE-19362Remove unused imports from hbase-thrift moduleMinorThrift
HBASE-19096Add RowMutions batch support in AsyncTableMajor.
HBASE-17049Do not issue sync request when there are still entries in ringbufferCriticalwal
HBASE-19242Add MOB compact support for AsyncAdminBlockerAdmin, mob
HBASE-19122preCompact and preFlush can bypass by returning null scanner; shut it downCriticalCoprocessors, Scanners
HBASE-19313Call blockUntilConnected when constructing ZKAsyncRegistry(temporary workaround)Majorasyncclient, Client, Zookeeper
HBASE-19269Reenable TestShellRSGroupsMajortest
HBASE-19276RegionPlan should correctly implement equals and hashCodeMajor.
HBASE-18911Unify Admin and AsyncAdmin's methods nameMajor.
HBASE-19268Enable Replica tests that were disabled by Proc-V2 AM in HBASE-14614Majortest
HBASE-19009implement modifyTable and enable/disableTableReplication for AsyncAdminMajor.
HBASE-18964Deprecate RowProcessor and processRowsWithLocks() APIs that take RowProcessor as an argumentMajorregionserver
HBASE-19270Reenable TestRegionMergeTransactionOnCluster#testMergeWithReplicas disable by HBASE-14614MajorRegion Assignment
HBASE-19278Reenable cleanup in test teardown in TestAccessController3 disabled by HBASE-14614MajorRegion Assignment
HBASE-19235CoprocessorEnvironment should be exposed to CPsMinorCoprocessors
HBASE-19243Start mini cluster once before class for TestFIFOCompactionPolicyMajortest
HBASE-18423Fix TestMetaWithReplicasMajortest
HBASE-18962Support atomic BatchOperations through batchMutate()Majorregionserver
HBASE-19127Set State.SPLITTING, MERGING, MERGING_NEW, SPLITTING_NEW properly in RegionStatesNodeMajor.
HBASE-19220Async tests time out talking to zk; ‘clusterid came back null’Majortest
HBASE-19002Introduce more examples to show how to intercept normal region operationsMinorCoprocessors
HBASE-18624Added support for clearing BlockCache based on table nameMajor.
HBASE-19203Update Hadoop version used for build to 2.7.4Major.
HBASE-18961doMiniBatchMutate() is big, split it into smaller methodsMajorregionserver
HBASE-19197Move version on branch-2 from 2.0.0-alpha4 to 2.0.0-beta-1.SNAPSHOTMajor.
HBASE-18950Remove Optional parameters in AsyncAdmin interfaceBlockerClient
HBASE-19131Add the ClusterStatus hook and cleanup other hooks which can be replaced by ClusterStatus hookMajorCoprocessors
HBASE-19095Add CP hooks in RegionObserver for in memory compactionMajorCoprocessors
HBASE-19152Update refguide ‘how to build an RC’ and the make_rc.sh scriptTrivialbuild
HBASE-18972Use Builder pattern to remove nullable parameters for coprocessor methods in RawAsyncTable interfaceBlockerClient
HBASE-19141[compat 1-2] getClusterStatus always return empty ClusterStatusCriticalAPI
HBASE-18770Remove bypass method in ObserverContext and implement the ‘bypass’ logic case by caseCriticalCoprocessors
HBASE-18375The pool chunks from ChunkCreator are deallocated while in pool because there is no reference to themCritical.
HBASE-19136Set branch-2 version to 2.0.0-alpha4 from 2.0.0-alpha4-SNAPSHOTMajor.
HBASE-19031Align exist method in Table and AsyncTable interfacesCriticalasyncclient, Client
HBASE-18995Move methods that are for internal usage from CellUtil to Private util classCritical.
HBASE-18906Provide Region#waitForFlushes APICriticalCoprocessors
HBASE-19090Add config ‘hbase.systemtables.compacting.memstore.type’ to hbase-default.xmlMajor.
HBASE-19048Cleanup MasterObserver hooks which takes IA private paramsMajorCoprocessors
HBASE-19029Align RPC timout methods in Table and AsyncTableBaseCriticalasyncclient, Client
HBASE-19057Fix other code review comments about FilterList ImprovementBlockerFilters
HBASE-19074Miscellaneous Observer cleanupsMajorCoprocessors
HBASE-19070temporarily make the mvnsite nightly test non-voting.Majorbuild
HBASE-18754Get rid of Writable from TimeRangeTrackerMajor.
HBASE-19053Split out o.a.h.h.http from hbase-server into a separate moduleMajor.
HBASE-19069Do not wrap the original CompactionLifeCycleTracker when calling CP hooksBlockerCompaction, Coprocessors
HBASE-18873Hide protobufs in GlobalQuotaSettingsCritical.
HBASE-19010Reimplement getMasterInfoPort for AdminMajorClient
HBASE-19045Deprecate RegionObserver#postInstantiateDeleteTrackerMajorCoprocessors
HBASE-18977Reenable test of filterlist using MUST_PASS_ONE and two familyfiltersBlockerFilters
HBASE-18945Make a IA.LimitedPrivate interface for CellComparatorMajor.
HBASE-18960A few bug fixes and minor improvements around batchMutate()Majorregionserver
HBASE-18914Remove AsyncAdmin's methods which were already deprecated in Admin interfaceMajor.
HBASE-18954Make *CoprocessorHost classes privateMajorCoprocessors
HBASE-18966Use non-sync TimeRangeTracker as a replacement for TimeRange in ImmutableSegmentMajor.
HBASE-18747Introduce new example and helper classes to tell CP users how to do filtering on scannersCriticalCoprocessors
HBASE-18411Dividing FiterList into two separate sub-classes: FilterListWithOR , FilterListWithANDMajorFilters
HBASE-18108Procedure WALs are archived but not cleaned; fixBlockerproc-v2
HBASE-18867maven enforcer plugin needs update to work with jdk9Blockerbuild
HBASE-18981Address issues found by error-prone in hbase-clientTrivial.
HBASE-18980Address issues found by error-prone in hbase-hadoop2-compatTrivial.
HBASE-18951Use Builder pattern to remove nullable parameters for checkAndXXX methods in RawAsyncTable/AsyncTable interfaceBlockerasyncclient, Client
HBASE-18160Fix incorrect logic in FilterList.filterKeyValueMajorFilters
HBASE-17678FilterList with MUST_PASS_ONE may lead to redundant cells returnedMajorFilters
HBASE-18957add test that confirms 2 FamilyFilters in a FilterList using MUST_PASS_ONE operator will return results that match either of the FamilyFilters and revert as needed to make it pass.CriticalFilters
HBASE-18949Remove the CompactionRequest parameter in preCompactSelectionMajorCoprocessors
HBASE-18752Recalculate the TimeRange in flushing snapshot to store fileMajor.
HBASE-18909Deprecate Admin's methods which used String regexMajorAdmin
HBASE-18931Make ObserverContext an interface and remove private/testing methodsMajorCoprocessors
HBASE-18933set version number to 2.0.0-alpha4-SNAPSHOT following release of alpha3Blockerbuild
HBASE-18815We need to pass something like CompactionRequest in CP to give user some information about the compactionMajorCoprocessors
HBASE-18105[AMv2] Split/Merge need cleanup; currently they diverge and do not fully embrace AMv2 worldMajorRegion Assignment
HBASE-18753Introduce the unsynchronized TimeRangeTrackerMajor.
HBASE-18010Connect CellChunkMap to be used for flattening in CompactingMemStoreMajor.
HBASE-18807Remove PB references from Observers for QuotasMajor.
HBASE-18786FileNotFoundException should not be silently handled for primary region replicasMajorregionserver, Scanners
HBASE-18823Apply RegionInfo to MasterObserver/RegionObserver/WALObserverMajorCoprocessors
HBASE-17980Any HRegionInfo we give out should be immutableMajor.
HBASE-18821Enforcer plugin NPEs again when generating siteMajorwebsite
HBASE-18820assembly is missing hbase-replicationMajorbuild
HBASE-18819Set version number to 2.0.0-alpha3 from 2.0.0-alpha3-SNAPSHOTMajor.
HBASE-14998Unify synchronous and asynchronous methods in Admin and cleanupBlocker.
HBASE-18718Document the coprocessor.ExportMajorCoprocessors, documentation, tooling
HBASE-18750Cleanup the docs saying “HTable use write buffer”Minordocumentation
HBASE-18779Move CompareOperator to hbase-client moduleCritical.
HBASE-18769Make CompareFilter use generic CompareOperator instead of internal enumMajor.
HBASE-14997Move compareOp and Comparators out of filter to client packageCritical.
HBASE-18697Need a shaded hbase-mapreduce moduleMajormapreduce
HBASE-18749Apply the CF specific TimeRange from Scan to filter the segment scannerMinor.
HBASE-18739Make all TimeRange Constructors InterfaceAudience Private.MajorAPI
HBASE-18721Cleanup unused configs and private declarationMinor.
HBASE-18700Document the new changes on mapreduce stuffsMajormapreduce
HBASE-18698MapreduceDependencyClasspathTool does not include hbase-server as a dependencyMajormapreduce
HBASE-18692[compat 1-2] ByteBufferUtils.copyFromBufferToBuffer goes from void to intMajorAPI
HBASE-18691[compat 1-2] HCD remove and removeConfiguration change return typeMajorAPI
HBASE-18688Upgrade commons-codec to 1.10Majordependencies
HBASE-16324Remove LegacyScanQueryMatcherCriticalCompaction, regionserver
HBASE-18687Add @since 2.0.0 to new classesMajorAPI
HBASE-18448EndPoint example for refreshing HFiles for storesMinorCoprocessors
HBASE-18656Address issues found by error-prone in hbase-commonMajorbuild
HBASE-18658Purge hokey hbase Service implementation; use (internal) Guava Service insteadMajor.
HBASE-18347Implement a BufferedMutator for async clientMajorasyncclient, Client
HBASE-18503Change ***Util and Master to use TableDescriptor and ColumnFamilyDescriptorMajor.
HBASE-18103[AMv2] If Master gives OPEN to another, if original eventually succeeds, Master will kill itCriticalmaster, proc-v2
HBASE-18489Expose scan cursor in RawScanResultConsumerMajorasyncclient, Client, scan
HBASE-18608AsyncConnection should return AsyncAdmin interface instead of the implemenationMajorClient
HBASE-18595Set version in branch-2 from 2.0.0-alpha2-SNAPSHOT to 2.0.0-alpha2Major.
HBASE-18553Expose scan cursor for asynchronous scannerMajor.
HBASE-17994Add async client test to Performance Evaluation toolMajor.
HBASE-18424Fix TestAsyncTableGetMultiThreadedMajortest
HBASE-18238Address ruby static analysis for bin directoryMajor.
HBASE-18593Tell m2eclipse what to do w/ replacer pluginTrivialbuild
HBASE-18271Shade nettyBlockerrpc
HBASE-18398Snapshot operation fails with FileNotFoundExceptionMajorsnapshots
HBASE-18315Eliminate the findbugs warnings for hbase-restMajor.
HBASE-18102[SHELL] Purge close_region command that allows by-pass of MasterMajorOperability, shell
HBASE-18231Deprecate and throw unsupported operation when Admin#closeRegion is called.CriticalAdmin
HBASE-18367Reduce ProcedureInfo usageMajormaster, proc-v2
HBASE-18107[AMv2] Remove DispatchMergingRegionsRequest & DispatchMergingRegionsMajorRegion Assignment
HBASE-18428IntegrationTestDDLMasterFailover uses old-style immutable column descriptorsMajorintegration tests
HBASE-18419Update IntegrationTestIngestWithMOB and Actions to use ColumnFamily builders for modificationCriticalintegration tests
HBASE-18420Some methods of Admin don't use ColumnFamilyDescriptorMajor.
HBASE-17738BucketCache startup is slowMajorBucketCache
HBASE-18308Eliminate the findbugs warnings for hbase-serverMajor.
HBASE-18052Add document for async adminMajorClient
HBASE-18229create new Async Split API to embrace AM v2Criticalproc-v2
HBASE-18342Add coprocessor service support for async adminMajorClient
HBASE-17922TestRegionServerHostname always fails against hadoop 3.0.0-alpha2Majorhadoop3
HBASE-18365Eliminate the findbugs warnings for hbase-commonMajor.
HBASE-18343Track the remaining unimplemented methods for async adminMajorClient
HBASE-18268Eliminate the findbugs warnings for hbase-clientMajorClient
HBASE-18295The result contains the cells across different rowsBlockerScanners
HBASE-18318Implement updateConfiguration/stopMaster/stopRegionServer/shutdown methodsMajorClient
HBASE-18316Implement async admin operations for draining region serversMajorClient
HBASE-18317Implement async admin operations for Normalizer/CleanerChore/CatalogJanitorMajorClient
HBASE-18319Implement getClusterStatus/getRegionLoad/getCompactionState/getLastMajorCompactionTimestamp methodsMajorClient
HBASE-18002Investigate why bucket cache filling up in file mode in an exisiting file is slowerMajorBucketCache
HBASE-17201Edit of HFileBlock comments and javadocMajordocumentation
HBASE-18240Add hbase-thirdparty, a project with hbase utility including an hbase-shaded-thirdparty module with guava, netty, etc.Majordependencies, shading
HBASE-18297Provide a AsyncAdminBuilder to create new AsyncAdmin instanceMajorClient
HBASE-18314Eliminate the findbugs warnings for hbase-examplesMajor.
HBASE-18264Update pom pluginsMajor.
HBASE-18283Provide a construct method which accept a thread pool for AsyncAdminMajorClient
HBASE-18293Only add the spotbugs dependency when jdk8 is activeMajorbuild
HBASE-18239Address ruby static analysis for shell moduleMajor.
HBASE-14902Revert some of the stringency recently introduced by checkstyle tighteningMajor.
HBASE-18272Fix issue about RSGroupBasedLoadBalancer#roundRobinAssignment where BOGUS_SERVER_NAME is involved in two groupsMajorBalancer
HBASE-18234Revisit the async admin apiMajorClient
HBASE-18221Switch from pread to stream should happen under HStore's reentrant lockMajorScanners
HBASE-16242Upgrade Avro to 1.7.7Majordependencies
HBASE-18104[AMv2] Enable aggregation of RPCs (assigns/unassigns, etc.)MajorRegion Assignment
HBASE-18213Add documentation about the new async clientMajorasyncclient, Client, documentation
HBASE-18220Compaction scanners need not reopen storefile scanners while trying to switch over from pread to streamMajorCompaction
HBASE-17008Examples to make AsyncClient go down easyCriticalasyncclient, Client
HBASE-18109Assign system tables first (priority)CriticalRegion Assignment
HBASE-18008Any HColumnDescriptor we give out should be immutableMajor.
HBASE-18190Set version in branch-2 to 2.0.0-alpha-1Major.
HBASE-18191Include hbase-metrics-* in assemblyMajor.
HBASE-16392Backup delete fault toleranceMajor.
HBASE-15160Put back HFile's HDFS op latency sampling code and add metrics for monitoringCritical.
HBASE-16549Procedure v2 - Add new AM metricsMajorproc-v2, Region Assignment
HBASE-15995Separate replication WAL reading from shippingMajorReplication
HBASE-17530Readd TestMergeTableRegionsProcedure mistakenly removed by HBASE-16786Criticaltest
HBASE-16543Separate Create/Modify Table operations from open/reopen regionsMajormaster
HBASE-16261MultiHFileOutputFormat EnhancementMajorhbase, mapreduce
HBASE-18115Move SaslServer creation to HBaseSaslRpcServerMajorIPC/RPC
HBASE-18114Update the config of TestAsync*AdminApi to make test stableMajorClient
HBASE-17066Procedure v2 - Add handling of merge region transition to the new AMMajorproc-v2, Region Assignment
HBASE-18091Add API for who currently holds a lock on namespace/ table/ region and log when state is LOCK_EVENT_WAITMajorproc-v2
HBASE-18013Write response directly instead of creating a fake call when setup connectionMajorIPC/RPC
HBASE-17850Backup system repair utilityMajor.
HBASE-18068Fix flaky test TestAsyncSnapshotAdminApiMajorClient
HBASE-18016Implement abort for TruncateTableProcedureMajorproc-v2
HBASE-18018Support abort for all procedures by defaultMajorproc-v2
HBASE-16851User-facing documentation for the In-Memory Compaction featureMajor.
HBASE-16436Add the CellChunkMap variantMajorregionserver
HBASE-18012Move RpcServer.Connection to a separated fileMajorIPC/RPC
HBASE-17938General fault - tolerance framework for backup/restore operationsMajor.
HBASE-17786Create LoadBalancer perf-tests (test balancer algorithm decoupled from workload)MajorBalancer, proc-v2
HBASE-17887Row-level consistency is broken for readBlockerregionserver
HBASE-17917Use pread by default for all user scan and switch to streaming read if neededMajorscan
HBASE-17977Enabled Master observer to delete quotas on table deletion by defaultMajor.
HBASE-17667Implement async flush/compact region methodsMajorAdmin, asyncclient, Client
HBASE-17978Investigate hbase superuser permissions in the face of quota violationMajor.
HBASE-17981Roll list_quota_violations into list_quota_snapshotsMajor.
HBASE-17867Implement async procedure RPC API(list/exec/abort/isFinished)MajorClient
HBASE-17263Netty based rpc server implMajorPerformance, rpc
HBASE-17976Remove stability annotation from public audience-marked classesMajor.
HBASE-17955Commit Reviewboard comments from VladMajor.
HBASE-17920TestFSHDFSUtils always fails against hadoop 3.0.0-alpha2Majorhadoop3
HBASE-17865Implement async listSnapshot/deleteSnapshot methods.MajorClient
HBASE-16942Add FavoredStochasticLoadBalancer and FN Candidate generatorsMajorFavoredNodes
HBASE-17873Change the IA.Public annotation to IA.Private for unstable APIBlockerAPI
HBASE-15583Any HTableDescriptor we give out should be immutableMinor.
HBASE-15143Procedure v2 - Web UI displaying queuesMinorproc-v2, UI
HBASE-17952The new options for PE tool do not workMajorPerformance, test
HBASE-16314Retry on table snapshot failure during full backupMajor.
HBASE-17864Implement async snapshot/cloneSnapshot/restoreSnapshot methodsMajorClient
HBASE-17915Implement async replication admin methodsMajorClient
HBASE-17929Add more options for PE toolMajorPerformance, test
HBASE-16438Create a cell type so that chunk id is embedded in itMajorregionserver
HBASE-17925mvn assembly:single fails against hadoop3-alpha2Majorhadoop3
HBASE-17866Implement async setQuota/getQuota methods.MajorClient
HBASE-17897StripeStoreFileManager#nonOpenRowCompare use the wrong comparison functionMajor.
HBASE-17895TestAsyncProcess#testAction fails if unsafe support is falseTrivialtest
HBASE-17896The FIXED_OVERHEAD of Segment is incorrectMinor.
HBASE-16477Remove Writable interface and related code from WALEdit/WALKeyMajorwal
HBASE-17872The MSLABImpl generates the invaild cells when unsafe is not availbleCritical.
HBASE-17881Remove the ByteBufferCellImplMinortest
HBASE-17858Update refguide about the IS annotation if necessaryMajorAPI, documentation
HBASE-16217Identify calling user in ObserverContextMajorCoprocessors, security
HBASE-17857Remove IS annotations from IA.Public classesMajorAPI
HBASE-17859ByteBufferUtils#compareTo is wrongCritical.
HBASE-17668Implement async assgin/offline/move/unassign methodsMajorAdmin, asyncclient, Client
HBASE-17855Fix typo in async client implementationMajorasyncclient, Client
HBASE-17844Subset of HBASE-14614, Procedure v2: Core Assignment Manager (non-critical related changes)MajorRegion Assignment
HBASE-17520Implement isTableEnabled/Disabled/Available methodsMajorClient
HBASE-17765Reviving the merge possibility in the CompactingMemStoreMajor.
HBASE-13395Remove HTableInterfaceMajorAPI
HBASE-17669Implement async mergeRegion/splitRegion methods.MajorAdmin, asyncclient, Client
HBASE-17809cleanup unused classMajor.
HBASE-17805We should remove BoundedByteBufferPool because it is replaced by ByteBufferPoolMinor.
HBASE-17447Automatically delete quota when table is deletedMajor.
HBASE-17003Update book for filesystem use quotasMajordocumentation
HBASE-17794Remove lingering “violation” in favor of the accurate “snapshot”Trivial.
HBASE-17691Add ScanMetrics support for async scanMajorClient
HBASE-15314Allow more than one backing file in bucketcacheMajorBucketCache
HBASE-17790Mark ReplicationAdmin's peerAdded and listReplicationPeers as DeprecatedMinorReplication
HBASE-17740Correct the semantic of batch and partial for async clientCriticalasyncclient, Client, scan
HBASE-17338Treat Cell data size under global memstore heap size only when that Cell can not be copied to MSLABMajorregionserver
HBASE-17745Support short circuit connection for master servicesMajor.
HBASE-17600Implement get/create/modify/delete/list namespace admin operationsMajorClient
HBASE-17002[Master] Report quotas and active violations on Master UI and JMX metricsMajormaster, UI
HBASE-17568Expire region reports in the HMasterMajor.
HBASE-15484Correct the semantic of batch and partialBlockerClient, scan
HBASE-17602Tweak chore delay/period defaultsTrivial.
HBASE-17516Table quota not taking precedence over namespace quotaMajor.
HBASE-17646Implement Async getRegion methodMajorasyncclient
HBASE-17662Disable in-memory flush when replaying from WALMajor.
HBASE-17428Expand on shell commands for detailed insightMajorshell
HBASE-16991Make the initialization of AsyncConnection asynchronousMinorClient
HBASE-17608Add suspend support for RawScanResultConsumerMajorasyncclient, Client, scan
HBASE-17561table status page should escape values that may contain arbitrary characters.Majormaster, UI
HBASE-17210Set timeout on trying rowlock according to client's RPC timeoutMajor.
HBASE-17478Avoid sending FSUtilization reports to master when quota support is not enabledTrivial.
HBASE-17025[Shell] Support space quota get/set via the shellMajorshell
HBASE-17644Always create ByteBufferCells after copying to MSLABMajorregionserver
HBASE-17619Add async admin Impl which connect to RegionServer and implement close region methods.Majorasyncclient
HBASE-17656Move new Address class from util to net packageMinorrsgroup
HBASE-17583Add inclusive/exclusive support for startRow and endRow of scan for sync clientMajorClient, scan
HBASE-17259Missing functionality to remove space quotaMajor.
HBASE-17001[RegionServer] Implement enforcement of quota violation policiesMajorregionserver
HBASE-17575Run critical tests with each of the Inmemory Compaction Policies enabled (Towards Making BASIC the Default In-Memory Compaction Policy)Majortest
HBASE-17484Add non cached version of OffheapKV for write pathMajorregionserver
HBASE-17389Convert all internal usages from ReplicationAdmin to AdminMajor.
HBASE-17402TestAsyncTableScan sometimes hangsMajorClient
HBASE-17350Fixup of regionserver group-based assignmentCriticalregionserver, rsgroup
HBASE-16999[Master] Inform RegionServers on size quota violationsMajor.
HBASE-17596Implement add/delete/modify column family methodsMajorClient
HBASE-17349Add doc for regionserver group-based assignmentCriticalregionserver, rsgroup
HBASE-17511Implement enable/disable table methodsMajorClient
HBASE-17281FN should use datanode port from hdfs configurationMinorFavoredNodes
HBASE-17198FN updates during region merge (follow up to Procedure v2 merge)MajorFavoredNodes
HBASE-17101FavoredNodes should not apply to system tablesMajorFavoredNodes
HBASE-17346Add coprocessor service supportMajorasyncclient, Client, Coprocessors
HBASE-17566Jetty upgrade fixesMajorREST, UI
HBASE-17562Remove documentation for coprocessor execution times after HBASE-14205MajorCoprocessors, Performance, regionserver
HBASE-16998[Master] Analyze table use reports and update quota violationsMajor.
HBASE-17557HRegionServer#reportRegionSizesForQuotas() should respond to UnsupportedOperationExceptionMajor.
HBASE-17526Procedure v2 - cleanup isSuspended from MasterProcedureScheduler#QueueMinorproc-v2
HBASE-17500Implement getTable/creatTable/deleteTable/truncateTable methodsMajorClient
HBASE-17045Unify the implementation of small scan and regular scanMajorClient, scan
HBASE-17443Move listReplicated/enableTableRep/disableTableRep methods from ReplicationAdmin to AdminMajor.
HBASE-17492Fix the compacting memstore part in hbase shell ruby scriptMajor.
HBASE-17491Remove all setters from HTable interface and introduce a TableBuilder to build Table instanceMajor.
HBASE-17067Procedure v2 - remove tryAcquire*Lock and use wait/wake to make framework event basedMajorproc-v2
HBASE-17367Make HTable#getBufferedMutator thread safeMajor.
HBASE-17497Add first async MetaTableAccessor impl and Implement tableExists methodMajorClient
HBASE-17498Implement listTables and listTableNames methodsMajorClient
HBASE-16831Procedure V2 - Remove org.apache.hadoop.hbase.zookeeper.lockMinor.
HBASE-16867Procedure V2 - Check ACLs for remote HBaseLockMajor.
HBASE-17480Remove split region code from Region ServerMajorRegion Assignment
HBASE-17396Add first async admin impl and implement balance methodsMajorClient
HBASE-17483Add equals/hashcode for OffheapKeyValueMajorregionserver
HBASE-17081Flush the entire CompactingMemStore content to diskMajor.
HBASE-17372Make AsyncTable thread safeMajorasyncclient, Client
HBASE-16744Procedure V2 - Lock procedures to allow clients to acquire locks on tables/namespaces/regionsMajor.
HBASE-17416Use isEmpty instead of size() == 0 in hbase-protocol-shadedMinor.
HBASE-14061Support CF-level Storage PolicyMajorHFile, regionserver
HBASE-17337list replication peers request should be routed through masterMajor.
HBASE-12148Remove TimeRangeTracker as point of contention when many threads writing a StoreMajorPerformance
HBASE-15172Support setting storage policy in bulkloadMajor.
HBASE-17388Move ReplicationPeer and other replication related PB messages to the replication.protoMajorReplication
HBASE-17409Re-fix XSS request issue in JMXJsonServletMajorsecurity, UI
HBASE-17410Use isEmpty instead of size() == 0 in hbase-clientMinorClient
HBASE-17373Reverse the order of snapshot creation in the CompactingMemStoreMajor.
HBASE-17336get/update replication peer config requests should be routed through masterMajor.
HBASE-17149Procedure V2 - Fix nonce submission to avoid unnecessary calling coprocessor multiple timesMajorproc-v2
HBASE-17320Add inclusive/exclusive support for startRow and endRow of scanMajorClient, scan
HBASE-17090Procedure v2 - fast wake if nothing else is runningMajorproc-v2
HBASE-17068Procedure v2 - inherit region locksMajormaster, proc-v2
HBASE-16524Procedure v2 - Compute WALs cleanup on wal modification and not on every syncMinorproc-v2
HBASE-17345Implement batchMajorasyncclient, Client
HBASE-17335enable/disable replication peer requests should be routed through masterMajor.
HBASE-17334Add locate row before/after support for AsyncRegionLocatorMajorClient
HBASE-17262Refactor RpcServer so as to make it extendable and/or pluggableMajorrpc
HBASE-11392add/remove peer requests should be routed through masterCritical.
HBASE-17107FN info should be cleaned up on region/table cleanupMajorFavoredNodes
HBASE-17142Implement multi getMajorasyncclient, Client
HBASE-17282Reduce the redundant requests to meta tableMajorClient
HBASE-17148Procedure v2 - add bulk proc submitMinormaster, proc-v2
HBASE-16398optimize HRegion computeHDFSBlocksDistributionMajorregionserver
HBASE-15787Change the flush related heuristics to work with offheap size configuredMajorregionserver
HBASE-17000[RegionServer] Compute region filesystem space use and report to MasterMajorregionserver
HBASE-17316Addendum to HBASE-17294, ‘External Configuration for Memory Compaction’Major.
HBASE-17313Add BufferedMutatorParams#clone methodMajorClient
HBASE-17277Allow alternate BufferedMutator implementationMajor.
HBASE-17294External Configuration for Memory CompactionMajor.
HBASE-16336Removing peers seems to be leaving spare queuesMajorReplication
HBASE-17251Add a timeout parameter when locating regionMajorasyncclient, Client
HBASE-16941FavoredNodes - Split/Merge code pathsMajorFavoredNodes
HBASE-17260Procedure v2 - Add setOwner() overload taking a User instanceTrivialproc-v2
HBASE-16996Implement storage/retrieval of filesystem-use quotas into quota tableMajor.
HBASE-17111Use Apache CLI in SnapshotInfo toolMajor.
HBASE-16648[JDK8] Use computeIfAbsent instead of get and putIfAbsentMajorPerformance
HBASE-17167Pass mvcc to client when scanMajorClient, scan
HBASE-17012Handle Offheap cells in CompressedKvEncoderMajorregionserver
HBASE-17048Calcuate suitable ByteBuf size when allocating send buffer in FanOutOneBlockAsyncDFSOutputMajorwal
HBASE-17183Handle ByteBufferCell while making TagRewriteCellMajorregionserver
HBASE-17162Avoid unconditional call to getXXXArray() in write pathMajorregionserver
HBASE-17169Remove Cell variants with ShareableMemoryMajorregionserver
HBASE-16984Implement getScannerMajorClient
HBASE-15786Create DBB backed MSLAB poolMajorregionserver
HBASE-17141Introduce a more user-friendly implementation of AsyncTableMajorasyncclient, Client
HBASE-16995Build client Java API and client protobuf messagesMajorClient
HBASE-17139Remove sweep tool related configs from hbase-default.xmlMajor.
HBASE-16956Refactor FavoredNodePlan to use regionNames as keysMinorFavoredNodes
HBASE-17085AsyncFSWAL may issue unnecessary AsyncDFSOutput.syncMajorwal
HBASE-16169Make RegionSizeCalculator scalableMajormapreduce, scaling
HBASE-17073Increase the max number of buffers in ByteBufferPoolMajor.
HBASE-17087Enable Aliasing for CodedInputStream created by ByteInputByteString#newCodedInputMajorregionserver
HBASE-17089Add doc on experience running with hedged readsMajordocumentation
HBASE-15788Use Offheap ByteBuffers from BufferPool to read RPC requests.Majorregionserver
HBASE-16838Implement basic scanMajorasyncclient, Client
HBASE-17071Do not initialize MemstoreChunkPool when use mslab option is turned offMajor.
HBASE-16570Compute region locality in parallel at startupMajor.
HBASE-17053Remove LogRollerExitedCheckerMajorwal
HBASE-17035Check why we roll a wal writer at 10MB when the configured roll size is 120M+ with AsyncFSWALMajorwal
HBASE-17021Use RingBuffer to reduce the contention in AsyncFSWALMajorwal
HBASE-16982Better integrate Apache CLI in AbstractHBaseToolMajor.
HBASE-17050Upgrade Apache CLI version from 1.2 to 1.3.1Minor.
HBASE-17030Procedure v2 - A couple of tweaks to the SplitTableRegionProcedureTrivialproc-v2
HBASE-16937Replace SnapshotType protobuf conversion when we can directly use the pojo objectTrivialsnapshots
HBASE-16892Use TableName instead of String in SnapshotDescriptionTrivialsnapshots
HBASE-16865Procedure v2 - Inherit lock from root procMajorproc-v2
HBASE-16970Clarify misleading Scan.java comment about cachingTrivial.
HBASE-16986Add note on how scanner caching has changed since 0.98 to refguidMinordocumentation
HBASE-16608Introducing the ability to merge ImmutableSegments without copy-compaction or SQM usageMajor.
HBASE-16945Implement AsyncRegionLocatorMajorClient
HBASE-16968Refactor FanOutOneBlockAsyncDFSOutputMajorio, wal
HBASE-16954Unify HTable#checkAndDelete with APMinor.
HBASE-16891Try copying to the Netty ByteBuf directly from the WALEditMajorwal
HBASE-16932Implement small scanMajorClient
HBASE-16835Revisit the zookeeper usage at client sideMajorClient, Zookeeper
HBASE-15709Handle large edits for asynchronous WALCriticalio, wal
HBASE-15789PB related changes to work with offheapMajorregionserver
HBASE-16871Procedure v2 - add waiting procs back to the queue after restartMajorproc-v2
HBASE-16872Implement mutateRow and checkAndMutateMajorClient
HBASE-16874Fix TestMasterFailoverWithProcedures and ensure single proc-executor for kill/restart testsMinorproc-v2
HBASE-16864Procedure v2 - Fix StateMachineProcedure support for child procs at last stepMajorproc-v2
HBASE-16837Implement checkAndPut and checkAndDeleteMajorClient
HBASE-16836Implement increment and appendMajorClient
HBASE-16846Procedure v2 - executor cleanupMinorproc-v2
HBASE-16834Add AsyncConnection support for ConnectionFactoryMajorClient
HBASE-16839Procedure v2 - Move all protobuf handling to ProcedureUtilMinorproc-v2
HBASE-16642Procedure V2: Use DelayQueue instead of TimeoutBlockingQueueMinorproc-v2
HBASE-16813Procedure v2 - Move ProcedureEvent to hbase-procedure moduleMajorproc-v2
HBASE-16735Procedure v2 - Fix yield while holding locksMajorproc-v2
HBASE-16505Save deadline in RpcCallContext according to request's timeoutMajor.
HBASE-15561See how G1GC works with MSLAB and chunk poolMajor.
HBASE-16802Procedure v2 - group procedure cleaningTrivialproc-v2
HBASE-16146Counters are expensive...Majormetrics
HBASE-16788Race in compacted file deletion between HStore close() and closeAndArchiveCompactedFiles()Blockerregionserver
HBASE-14734BindException when setting up MiniKdcMajorflakey, test
HBASE-15984Given failure to parse a given WAL that was closed cleanly, replay the WAL.CriticalReplication
HBASE-15721Optimization in cloning cells into MSLABMajorregionserver
HBASE-16372References to previous cell in read path should be avoidedBlockerScanners
HBASE-16759Avoid ByteString.copyFrom usage wherever possibleMajorProtobufs
HBASE-16758Bring back HBaseZeroCopyByteStringer stuffMajorProtobufs
HBASE-16760Deprecate ByteString related methods in Bytes.javaMajorProtobufs
HBASE-16741Amend the generate protobufs out-of-band build step to include shade, pulling in protobuf source and a hook for patching protobufMajorProtobufs
HBASE-16264Figure how to deal with endpoints and shaded pbCriticalCoprocessors, Protobufs
HBASE-16742Add chapter for devs on how we do protobufs going forwardMajordocumentation
HBASE-16738L1 cache caching shared memory HFile block when blocks promoted from L2 to L1Majorregionserver, Scanners
HBASE-16134Introduce Cell extension for server side.Majorregionserver
HBASE-16695Procedure v2 - Support for parent holding locksMajorproc-v2
HBASE-16587Procedure v2 - Cleanup suspended proc executionMajorproc-v2
HBASE-16651LRUBlockCache#returnBlock should try return block to Victim Handler L2 cache.Majorregionserver, Scanners
HBASE-16554Procedure V2 - Recover ‘updated’ part of WAL tracker if trailer is corrupted.Major.
HBASE-7612[JDK8] Replace use of high-scale-lib counters with intrinsic facilitiesTrivialmetrics
HBASE-16534Procedure v2 - Perf Tool for SchedulerMajorproc-v2, tooling
HBASE-16586Procedure v2 - Cleanup sched wait/lock semanticMajorproc-v2
HBASE-16626User customized RegionScanner from 1.X is incompatible with 2.0.0's off-heap partMajorOffheaping
HBASE-16618Procedure v2 - Add base class for table and ns proceduresMinormaster, proc-v2
HBASE-16229Cleaning up size and heapSize calculationMajor.
HBASE-16592Unify Delete request with APMajor.
HBASE-16596Reduce redundant interfaces in AsyncProcessMajor.
HBASE-16530Reduce DBE code duplicationMajorPerformance
HBASE-16445Refactor and reimplement RpcClientMajorIPC/RPC, rpc
HBASE-16516Revisit the implementation of PayloadCarryingRpcControllerMajorrpc
HBASE-16101Procedure v2 - Perf Tool for WALMajorproc-v2, tooling
HBASE-16311Audit log for delete snapshot operation is missing in case of snapshot owner deleting the sameMinorsnapshots
HBASE-16519Procedure v2 - Avoid sync wait on DDLs operationMajormaster, proc-v2
HBASE-16507Procedure v2 - Force DDL operation to always roll forwardMinormaster, proc-v2
HBASE-16526Add more ipc testsMajorrpc, test
HBASE-16532Procedure-V2: Enforce procedure ownership at submissionMajorproc-v2
HBASE-16531Move cell block related code out of IPCUtilMajorrpc
HBASE-16533Procedure v2 - Extract chore from the executorMinorproc-v2
HBASE-16522Procedure v2 - Cache system user and avoid IOExceptionMajormaster, proc-v2
HBASE-16082Procedure v2 - Move out helpers from MasterProcedureSchedulerTrivialproc-v2
HBASE-16510Reset RpcController before retryMajorrpc
HBASE-16407Handle MemstoreChunkPool size when HeapMemoryManager tunes memoryMajor.
HBASE-16433Remove AsyncRpcChannel related stuffsMajorrpc
HBASE-16474Remove dfs.support.append related code and documentationMajorfs, regionserver, wal
HBASE-16451Procedure v2 - Test WAL protobuf entry size limitMinorproc-v2
HBASE-14921Inmemory Compaction Optimizations; Segment StructureMajor.
HBASE-16485Procedure V2 - Add support to addChildProcedure() as last “step” in StateMachineProcedureMinorproc-v2
HBASE-16440MemstoreChunkPool might cross its maxCount of chunks to poolMajor.
HBASE-16318fail build if license isn't in whitelistMajorbuild, dependencies
HBASE-16452Procedure v2 - Make ProcedureWALPrettyPrinter extend ToolMinorproc-v2
HBASE-16405Change read path Bloom check to work with Cells with out any copyMajorCompaction
HBASE-16094Procedure v2 - Improve cleaning up of proc walsMajorproc-v2
HBASE-16378Procedure v2 - Make ProcedureException extend HBaseExceptionTrivialproc-v2
HBASE-16404Make DeleteBloomFilters work with BloomContextMinorCompaction
HBASE-15554StoreFile$Writer.appendGeneralBloomFilter generates extra KVMajorPerformance
HBASE-16308Contain protobuf referencesMajorProtobufs
HBASE-16285Drop RPC requests if it must be considered as timeout at clientMajor.
HBASE-16263Move all to do w/ protobuf -- *.proto files and generated classes -- under hbase-protocolMajorProtobufs
HBASE-16317revert all ESAPI changesBlockerdependencies, security
HBASE-16286When TagRewriteCell are not copied to MSLAB, deep clone it while adding to MemstoreMajorregionserver
HBASE-16280Use hash based map in SequenceIdAccountingMajorwal
HBASE-16205When Cells are not copied to MSLAB, deep clone it while adding to MemstoreCriticalregionserver
HBASE-14552Procedure V2: Reimplement DispatchMergingRegionHandlerMajorproc-v2
HBASE-16236Typo in javadoc of InstancePendingTrivialZookeeper
HBASE-16233Procedure V2: Support acquire/release shared table lock concurrentlyMajorproc-v2
HBASE-16219Move meta bootstrap out of HMasterTrivialmaster, Region Assignment
HBASE-15305Fix a couple of incorrect anchors in HBase ref guideMajordocumentation
HBASE-16195Should not add chunk into chunkQueue if not using chunk pool in HeapMemStoreLABMajor.
HBASE-16208Make TableBasedReplicationQueuesImpl check that queue exists before attempting to remove itMajorReplication
HBASE-16214Add in UI description of Replication TableMinorReplication
HBASE-16092Procedure v2 - complete child procedure supportMinorproc-v2
HBASE-16194Should count in MSLAB chunk allocation into heap size change when adding duplicate cellsMajorregionserver
HBASE-16176Bug fixes/improvements on HBASE-15650 Remove TimeRangeTracker as point of contention when many threads reading a StoreFileMajorPerformance
HBASE-15935Have a separate Walker task running concurrently with GeneratorMinorintegration tests
HBASE-16162Compacting Memstore : unnecessary push of active segments to pipelineCritical.
HBASE-15985clarify promises about edits from replication in ref guideMajordocumentation, Replication
HBASE-16163Compacting Memstore : CompactionPipeline#addFirst can use LinkedList#addFirstMinor.
HBASE-16164Missing close of new compacted segments in few occasions which might leak MSLAB chunks from poolCritical.
HBASE-16155Compacting Memstore : Few log improvementsMinor.
HBASE-16153Correct the config name ‘hbase.memestore.inmemoryflush.threshold.factor’Trivial.
HBASE-16143Change MemstoreScanner constructor to accept List<KeyValueScanner>Minor.
HBASE-16121Require only MasterServices to the ServerManager constructorTrivialmaster
HBASE-16068Procedure v2 - use consts for conf properties in testsTrivialproc-v2, test
HBASE-16083Fix table based replication related configsTrivialReplication
HBASE-16080Fix flakey testsCriticalReplication
HBASE-16036Fix ReplicationTableBase initialization to make it non-blockingMajorReplication
HBASE-14878maven archetype: client application with shaded jarsMajorbuild, Usability
HBASE-14877maven archetype: client applicationMajorbuild, Usability
HBASE-16056Procedure v2 - fix master crash for FileNotFoundMinorproc-v2
HBASE-16038Ignore JVM crashes or machine shutdown failures in report-flakiesMajor.
HBASE-15999NPE in MemstoreCompactorCritical.
HBASE-16034Fix ProcedureTestingUtility#LoadCounter.setMaxProcId()Minorproc-v2, test
HBASE-15974Create a ReplicationQueuesClientHBaseImplMajorReplication
HBASE-16023Fastpath for the FIFO rpcschedulerMajorPerformance, rpc
HBASE-15525OutOfMemory could occur when using BoundedByteBufferPool during RPC burstsCriticalIPC/RPC
HBASE-15991CompactingMemstore#InMemoryFlushRunnable should implement Comparable/ComparatorCritical.
HBASE-15272Add error handling for split and compact actions in table.jspMajorUI
HBASE-15994Allow selection of RpcSchedulersMajor.
HBASE-15107Procedure V2 - Procedure Queue with RegionsMajorproc-v2
HBASE-15948Port “HADOOP-9956 RPC listener inefficiently assigns connections to readers”MajorIPC/RPC
HBASE-15174Client Public API should not have PB objects in 2.0Blocker.
HBASE-15883Adding WAL files and tracking offsets in HBase.MajorReplication
HBASE-15927Remove HMaster.assignRegion()Trivialtest
HBASE-15917Flaky tests dashboardMajor.
HBASE-15919Document @Rule vs @ClassRule. Also clarify timeout limits are on TestCase.Minor.
HBASE-15915Set timeouts on hanging testsMajor.
HBASE-15896Add timeout tests to flaky list from report-flakies.pyMajortest
HBASE-14920Compacting MemstoreMajor.
HBASE-15872Split TestWALProcedureStoreTrivialproc-v2, test
HBASE-15865Move TestTableDeleteFamilyHandler and TestTableDescriptorModification handler tests to procedureTrivialtest
HBASE-15651Add report-flakies.py to use jenkins api to get failing testsMajor.
HBASE-15825Fix the null pointer in DynamicLogicExpressionSuiteMajor.
HBASE-15813Rename DefaultWALProvider to a more specific name and clean up unnecessary reference to itMajorwal
HBASE-15785Unnecessary lock in ByteBufferArrayMajorregionserver, Scanners
HBASE-15740Replication source.shippedKBs metric is undercounting because it is in KBMajor.
HBASE-15776Replace master.am.getTableStateManager() with the direct master.getTableStateManager()Trivialmaster
HBASE-15778replace master.am and master.sm direct access with getter callsTrivialmaster
HBASE-15743Add Transparent Data Encryption support for FanOutOneBlockAsyncDFSOutputMajorwal
HBASE-15763Isolate Wal related stuff from MasterFileSystemTrivialmaster, wal
HBASE-15754Add testcase for AES encryptionMajorwal
HBASE-15337Document date tiered compaction in the bookMajordocumentation
HBASE-15675Add more details about region on table.jspMajor.
HBASE-15658RegionServerCallable / RpcRetryingCaller clear meta cache on retriesCriticalClient
HBASE-15735Tightening of the CP contractMajorregionserver, Scanners
HBASE-15477Do not save ‘next block header’ when we cache hfileblocksMajorBlockCache, Performance
HBASE-15689Changes to hbase-personality.sh to include/exclude flaky testsMajor.
HBASE-15628Implement an AsyncOutputStream which can work with any FileSystem implementationMajor.
HBASE-15579Procedure V2 - Remove synchronized around nonce in Procedure submitTrivialproc-v2
HBASE-15392Single Cell Get reads two HFileBlocksMajorBucketCache
HBASE-15671Add per-table metrics on memstore, storefile and regionsizeMajor.
HBASE-15366Add doc, trace-level logging, and test around hfileblockMajorBlockCache
HBASE-15683Min latency in latency histograms are emitted as Long.MAX_VALUEMajor.
HBASE-15368Add pluggable window supportMajorCompaction
HBASE-15663Hook up JvmPauseMonitor to ThriftServerMajormetrics, Thrift
HBASE-15662Hook up JvmPauseMonitor to REST serverMajormetrics, REST
HBASE-15518Add Per-Table metrics backMajor.
HBASE-15640L1 cache doesn't give fair warning that it is showing partial stats only when it hits limitMajorBlockCache
HBASE-15386PREFETCH_BLOCKS_ON_OPEN in HColumnDescriptor is ignoredMajorBucketCache
HBASE-15665Support using different StoreFileComparators for different CompactionPoliciesMajorCompaction
HBASE-15527Refactor Compactor related classesMajorCompaction
HBASE-15407Add SASL support for fan out OutputStreamMajorutil, wal
HBASE-15380Purge rollback support in Store etc.Major.
HBASE-15537Make multi WAL work with WALs other than FSHLogMajor.
HBASE-15400Use DateTieredCompactor for Date Tiered CompactionMajorCompaction
HBASE-15369Handle NPE in region.jspMinorUI
HBASE-15505ReplicationPeerConfig should be builder-styleMajor.
HBASE-15293Handle TableNotFound and IllegalArgument exceptions in table.jspMajorUI
HBASE-15538Implement secure async protobuf wal writerMajorwal
HBASE-15389Write out multiple files when compactionMajorCompaction
HBASE-15384Avoid using ‘/tmp’ directory in TestBulkLoadMajortest
HBASE-15524Fix NPE in client-side metricsCriticalClient, metrics
HBASE-15495Connection leak in FanOutOneBlockAsyncDFSOutputHelperMajor.
HBASE-15416TestHFileBackedByBucketCache is flakey since it went inCriticalBucketCache
HBASE-15412Add average region size metricMajor.
HBASE-15488Add ACL for setting split merge switchMajor.
HBASE-15464Flush / Compaction metrics revisitedMajormetrics
HBASE-15460Fix infer issues in hbase-commonMajor.
HBASE-15479No more garbage or beware of autoboxingMajorClient
HBASE-15334Add avro support for spark hbase connectorMajor.
HBASE-15390Unnecessary MetaCache evictions cause elevated number of requests to metaBlockerClient
HBASE-15180Reduce garbage created while reading Cells from Codec DecoderMajorregionserver
HBASE-15435Add WAL (in bytes) written metricMajor.
HBASE-15113Procedure v2 - Speedup eviction of sys operation resultsMinorproc-v2
HBASE-15422Procedure v2 - Avoid double yieldMajorproc-v2
HBASE-15421Convert TestStoreScanner to junit4 from junit3 and clean up close of scannersMinortest
HBASE-15354Use same criteria for clearing meta cache for all operationsMajorClient
HBASE-15373DEPRECATED_NAME_OF_NO_LIMIT_THROUGHPUT_CONTROLLER_CLASS value is wrong in CompactionThroughputControllerFactoryMinorCompaction
HBASE-15375Do not write to ‘/tmp’ in TestRegionMoverMajortest
HBASE-15359Simplifying Segment hierarchyMajor.
HBASE-15371Procedure V2 - Completed support parent-child procedureMajorproc-v2
HBASE-15365Do not write to ‘/tmp’ in TestHBaseConfigurationMajortest
HBASE-15346add 1.3 RM to docsMajordocumentation
HBASE-15351Fix description of hbase.bucketcache.size in hbase-default.xmlMajordocumentation
HBASE-15205Do not find the replication scope for every WAL#append()Minorregionserver
HBASE-15311Prevent NPE in BlockCacheViewTmplMajorUI
HBASE-15144Procedure v2 - Web UI displaying Store stateMinorproc-v2, UI
HBASE-15264Implement a fan out HDFS OutputStreamMajorutil, wal
HBASE-15016StoreServices facility in RegionMajor.
HBASE-15232Exceptions returned over multi RPC don't automatically trigger region location reloadsMajorClient
HBASE-14949Resolve name conflict when splitting if there are duplicated WAL entriesMajorwal
HBASE-15270Use appropriate encoding for “filter” field in TaskMonitorTmpl.jamonMajorUI
HBASE-15263TestIPv6NIOServerSocketChannel.testServerSocketFromLocalhostResolution can hang indefinetlyMajor.
HBASE-15244More doc around native lib setup and check and crcMajordocumentation, Performance
HBASE-15203Reduce garbage created by path.toString() during Checksum verificationMinorregionserver
HBASE-14919Infrastructure refactoring for In-Memory FlushMajor.
HBASE-15204Try to estimate the cell count for adding into WALEditMajorregionserver
HBASE-15239Remove unused LoadBalancer.immediateAssignment()TrivialBalancer
HBASE-15238HFileReaderV2 prefetch overreaches; runs off the end of the dataMajor.
HBASE-15046Perf test doing all mutation steps under row lockMajorPerformance
HBASE-15158Change order in which we do write pipeline operations; do all under row locks!MajorPerformance
HBASE-15163Add sampling code and metrics for get/scan/multi/mutate count separatelyMajor.
HBASE-15157Add *PerformanceTest for Append, CheckAnd*MajorPerformance, test
HBASE-15094Selection of WAL files eligible for incremental backup is brokenMajor.
HBASE-15210Undo aggressive load balancer logging at tens of lines per millisecondMajorBalancer
HBASE-15202Reduce garbage while setting responseMinorregionserver
HBASE-15194TestStochasticLoadBalancer.testRegionReplicationOnMidClusterSameHosts flaky on trunkMajorflakey, test
HBASE-14841Allow Dictionary to work with BytebufferedCellsMajorregionserver, Scanners
HBASE-15142Procedure v2 - Basic WebUI listing the proceduresMinorproc-v2, UI
HBASE-15171Avoid counting duplicate kv and generating lots of small hfiles in PutSortReducerMajor.
HBASE-15106Procedure V2 - Procedure Queue pass Procedure for better debuggabilityMajorproc-v2
HBASE-14221Reduce the number of time row comparison is done in a ScanMajorScanners
HBASE-15118Fix findbugs complaint in hbase-serverMajorbuild
HBASE-15115Fix findbugs complaints in hbase-clientMajorbuild
HBASE-14962TestSplitWalDataLoss fails on all branchesBlockertest
HBASE-15114NPE when IPC server ByteBuffer reservoir is turned offMajor.
HBASE-15105Procedure V2 - Procedure Queue with NamespacesMajorproc-v2
HBASE-14837Procedure V2 - Procedure Queue ImprovementMinorproc-v2
HBASE-15095isReturnResult=false on fast path in branch-1.1 and branch-1.0 is not respectedMajorPerformance
HBASE-15087Fix hbase-common findbugs complaintsMajorbuild
HBASE-15077Support OffheapKV write in compaction with out copying data on heapMajorregionserver, Scanners
HBASE-12593Tags to work with ByteBufferMajorregionserver, Scanners
HBASE-14488Procedure V2 - shell command to abort a procedureMajorproc-v2
HBASE-14487Procedure V2 - shell command to list all proceduresMajorproc-v2, shell
HBASE-14108Procedure V2 - Administrative Task: provide an API to abort a procedureMajorproc-v2
HBASE-14432Procedure V2 - enforce ACL on procedure admin tasksMajorproc-v2
HBASE-14107Procedure V2 - Administrative Task: Provide an API to List all proceduresMajorproc-v2
HBASE-15023Reenable TestShell and TestStochasticLoadBalancerMajortest
HBASE-14908TestRowCounter flakey especially on branch-1Majorflakey, test
HBASE-14863Add missing test/resources/log4j files in hbase modulesTrivialtest
HBASE-14947Procedure V2 - WALProcedureStore improvementsBlockerproc-v2
HBASE-14895Seek only to the newly flushed file on scanner reset on flushMajor.
HBASE-14655Narrow the scope of doAs() calls to region observer notifications for compactionBlockerCoprocessors, security
HBASE-14631Region merge request should be audited with request user through proper scope of doAs() calls to region observer notificationsBlockerCoprocessors, security
HBASE-14605Split fails due to ‘No valid credentials’ error when SecureBulkLoadEndpoint#start tries to access hdfsBlockerCoprocessors, security
HBASE-14772Improve zombie detector; be more discerningMajortest
HBASE-14884TestSplitTransactionOnCluster.testSSHCleanupDaugtherRegionsOfAbortedSplit is flakeyMajorflakey, test
HBASE-14909NPE testing for RITMajortest
HBASE-14575Relax region read lock for compactionsMajorCompaction, regionserver
HBASE-14819hbase-it tests failing with OOME; permgenMajortest
HBASE-14832Ensure write paths work with ByteBufferedCells in case of compactionMinorregionserver, Scanners
HBASE-14798NPE reporting server load causes regionserver abort; causes TestAcidGuarantee to failMajortest
HBASE-14794Cleanup TestAtomicOperation, TestImportExport, and TestMetaWithReplicasMajorflakey, test
HBASE-14785Hamburger menu for mobile siteMajorwebsite
HBASE-14786TestProcedureAdmin hangsMajorhangingTests, test
HBASE-14589Looking for the surefire-killer; builds being killed...ExecutionException: java.lang.RuntimeException: The forked VM terminated without properly saying goodbye. VM crash or System.exit called?Majortest
HBASE-14725Vet categorization of tests so they for sure go into the right small/medium/large bucketsMajortest
HBASE-14638Move Jython info from the Wiki to the Ref GuideMajordocumentation
HBASE-14639Move Scala info from Wiki to Ref GuideMajordocumentation
HBASE-13478Document the change of default master ports being used .Minordocumentation
HBASE-14641Move JDO example from Wiki to Ref GuideMajordocumentation
HBASE-14640Move Cascading info from Wiki to Ref GuideMajordocumentation
HBASE-14720Make TestHCM and TestMetaWithReplicas large tests rather than mediumsMajorhangingTests, test
HBASE-14710Add category-based timeouts to MR testsMajorhangingTests, mapreduce, test
HBASE-14709Parent change breaks graceful_stop.sh on a clusterMajorOperability
HBASE-14702TestZKProcedureControllers.testZKCoordinatorControllerWithSingleMemberCohort is a flakeyMajorflakey, test
HBASE-14698Set category timeouts on TestScanner and TestNamespaceAuditorMajortest
HBASE-14648Reenable TestWALProcedureStoreOnHDFS#testWalRollOnLowReplicationCriticaltest
HBASE-14685Procedure Id is not set for MasterRpcServices#modifyTableMajormaster, proc-v2
HBASE-14535Integration test for rpc connection concurrency / deadlock testingMajorIPC/RPC
HBASE-14657Remove unneeded API from EncodedSeekerMajorio
HBASE-13538Procedure v2 - client add/delete/modify column family sync (incompatible with branch-1.x)Majorproc-v2
HBASE-14662Fix NPE in HFileOutputFormat2Major.
HBASE-14636Clear HFileScannerImpl#prevBlocks in between Compaction flowBlockerregionserver, Scanners
HBASE-14595For Wiki contents that are also in the Ref Guide, replace content with a URLMajordocumentation
HBASE-14646Move TestCellACLs from medium to large categoryMinortest
HBASE-14647Disable TestWALProcedureStoreOnHDFS#testWalRollOnLowReplicationMajortest
HBASE-14637Loosen TestChoreService assert AND have TestDataBlockEncoders do less work (and add timeouts)Majortest
HBASE-14627Move Stargate docs to Ref GuideMajordocumentation
HBASE-14607Convert SupportingProjects wiki page to a site pageMajordocumentation
HBASE-14570Split TestHBaseFsck in order to help with hanging testsMajortest
HBASE-14602Convert HBasePoweredBy Wiki page to a hbase.apache.org pageMajordocumentation
HBASE-14596TestCellACLs failing... on1.2 buildsMajortest
HBASE-14600Make #testWalRollOnLowReplication looser stillMajortest
HBASE-13819Make RPC layer CellBlock buffer a DirectByteBufferMajorScanners
HBASE-14558Document ChaosMonkey enhancements from HBASE-14261Majordocumentation
HBASE-14590Shorten ByteBufferedCell#getXXXPositionInByteBuffer method nameMajorregionserver, Scanners
HBASE-14585Clean up TestSnapshotCloneIndependenceMajorflakey, test
HBASE-14567Tuneup hanging test TestMobCompactor and TestMobSweeperMajortest
HBASE-14572TestImportExport#testImport94Table can't find its src data fileMajortest
HBASE-14571Purge TestProcessBasedCluster; it does nothing and then failsMajortest
HBASE-14519Purge TestFavoredNodeAssignmentHelper, a test for an abandoned feature that can hangMajortest
HBASE-14563Disable zombie TestHFileOutputFormat2Majortest
HBASE-14561Disable zombie TestReplicationShellMajortest
HBASE-14559branch-1 test tweeks; disable assert explicit region lands post-restart and up a few handlersMajortest
HBASE-14480Small optimization in SingleByteBuffMajorregionserver, Scanners
HBASE-14539Slight improvement of StoreScanner.optimizeMinorPerformance, Scanners
HBASE-14543Have findHangingTests.py dump more infoMajortooling
HBASE-14513TestBucketCache runs obnoxious 1k threads in a unit testMajortest
HBASE-14495TestHRegion#testFlushCacheWhileScanning goes zombieMajortest
HBASE-14507Disable TestDistributedLogSplitting#testWorkerAbort Its flakey with tenuous chance of successMajortest
HBASE-14398Create the fake keys required in the scan path to avoid copy to byte[]Major.
HBASE-14430TestHttpServerLifecycle#testStartedServerIsAlive times outMajortest
HBASE-14212Add IT test for procedure-v2-based namespace DDLMajorproc-v2
HBASE-14051Undo workarounds in IntegrationTestDDLMasterFailover for client double submitMajormaster
HBASE-12748RegionCoprocessorHost.execOperation creates too many iterator objectsMajor.
HBASE-14378Get TestAccessController* passing again on branch-1Major.
HBASE-14484Follow-on from HBASE-14421, just disable TestFastFail* until someone digs in and fixes itMajortest
HBASE-14464Removed unused fs codeMinorregionserver
HBASE-14472TestHCM and TestRegionServerNoMaster fixesMinortest
HBASE-14147REST Support for NamespacesMinorREST
HBASE-14447Spark tests failing: bind exception when putting up info serverMinortest
HBASE-14278Fix NPE that is showing up since HBASE-14274 went inMajortest
HBASE-14433Set down the client executor core thread count from 256 in testsMajortest
HBASE-14401Stamp failed appends with sequenceid too.... Cleans up latchesMajortest, wal
HBASE-14435thrift tests don't have test-specific hbase-site.xml so ‘BindException: Address already in use’ because info port is not turned offMajortest
HBASE-14428Upgrade our surefire-plugin from 2.18 to 2.18.1Majortest
HBASE-14421TestFastFail* are flakeyMajortest
HBASE-14423TestStochasticBalancerJmxMetrics.testJmxMetrics_PerTableMode:183 NullPointerMajortest
HBASE-14395Short circuit last byte check in CellUtil#matchingXXX methods for ByteBufferedCellsMajorregionserver, Scanners
HBASE-14368New TestWALLockup broken by addendum added to parent issueMajortest
HBASE-14322Master still not using more than it's priority threadsMajorIPC/RPC, master
HBASE-13212Procedure V2 - master Create/Modify/Delete namespaceMajormaster
HBASE-14239Branch-1.2 AM can get stuck when meta movesMajorRegion Assignment
HBASE-14274Deadlock in region metrics on shutdown: MetricsRegionSourceImpl vs MetricsRegionAggregateSourceImplMajortest
HBASE-14186Read mvcc vlong optimizationMajorPerformance, Scanners
HBASE-14144Bloomfilter path to work with Byte buffered cellsMajorregionserver, Scanners
HBASE-14087ensure correct ASF policy compliant headers on source/docsBlockerbuild
HBASE-14202Reduce garbage we createMajorregionserver, Scanners
HBASE-14105Add shell tests for SnapshotMajortest
HBASE-14188Read path optimizations after HBASE-11425 profilingMajorScanners
HBASE-14176Add missing headers to META-INF filesTrivialbuild
HBASE-14086remove unused bundled dependenciesBlockerdocumentation
HBASE-14063Use BufferBackedCell in read path after HBASE-12213 and HBASE-12295Majorregionserver, Scanners
HBASE-12295Prevent block eviction under us if reads are in progress from the BBsMajorregionserver, Scanners
HBASE-14116Change ByteBuff.getXXXStrictlyForward to relative position based readsMajor.
HBASE-12374Change DBEs to work with new BB based cellMajorregionserver, Scanners
HBASE-14120ByteBufferUtils#compareTo small optimizationMajorregionserver, Scanners
HBASE-14104Add vectorportal.com to NOTICES.txt as src of our logoMajordocumentation
HBASE-14102Add thank you to our thanks page for vectorportal.comMajor.
HBASE-12015Not cleaning Mob data when Mob CF is removed from tableMajor.
HBASE-13993WALProcedureStore fencing is not effective if new WAL rollsMajormaster
HBASE-13387Add ByteBufferedCell an extension to CellMajorregionserver, Scanners
HBASE-13832Procedure V2: master fail to start due to WALProcedureStore sync failures when HDFS data nodes count is lowBlockermaster, proc-v2
HBASE-13415Procedure V2 - Use nonces for double submits from clientBlockermaster
HBASE-14017Procedure v2 - MasterProcedureQueue fix concurrency issue on table queue deletionBlockerproc-v2
HBASE-14020Unsafe based optimized write in ByteBufferOutputStreamMajorScanners
HBASE-13998Remove CellComparator#compareRows(byte[] left, int loffset, int llength, byte[] right, int roffset, int rlength)Major.
HBASE-13977Convert getKey and related APIs to CellMajor.
HBASE-14013Retry when RegionServerNotYetRunningException rather than go ahead with assign so for sure we don't skip WAL replayMajorRegion Assignment
HBASE-13975add 1.2 RM to docsMajordocumentation
HBASE-13911add 1.2 to prereq tables in ref guideBlockerdocumentation
HBASE-13990clean up remaining errors for maven site goalMajordocumentation
HBASE-14003work around jdk8 spec bug in WALPerfEvalCriticaltest
HBASE-13939Make HFileReaderImpl.getFirstKeyInBlock() to return a CellMinor.
HBASE-13614Avoid temp KeyOnlyKeyValue temp objects creations in read hot pathCritical.
HBASE-12345Unsafe based ByteBuffer ComparatorMajorregionserver, Scanners
HBASE-13922Do not reset mvcc in compactions for mob-enabled columnMajormob
HBASE-13968Remove deprecated methods from BufferedMutator classMajorAPI
HBASE-13973Update documentation for 10070 Phase 2 changesMajor.
HBASE-13967add jdk profiles for jdk.tools dependencyMajor.
HBASE-13950Add a NoopProcedureStore for testingTrivialproc-v2
HBASE-13920Exclude Java files generated from protobuf from javadocMinor.
HBASE-13932Add mob integrity check in HFilePrettyPrinterMajormob
HBASE-13898correct additional javadoc failures under java 8Minordocumentation
HBASE-13728Remove use of Hadoop's GenericOptionsParserBlocker.
HBASE-13448New Cell implementation with cached component offsets/lengthsBlockerScanners
HBASE-13926Close the scanner only after Call#setResponseMajorregionserver, Scanners
HBASE-13916Create MultiByteBuffer an aggregation of ByteBuffersMajorregionserver, Scanners
HBASE-13470High level Integration test for master DDL operationsMajormaster
HBASE-13886Return empty value when the mob file is corrupt instead of throwing exceptionsMajormob
HBASE-13910add branch-1.2 to precommit branchesMajorbuild
HBASE-13899Jacoco instrumentation fails under jdk8Majorbuild, test
HBASE-13569correct errors reported with mvn siteMinordocumentation
HBASE-13855Race in multi threaded PartitionedMobCompactor causes NPECriticalmob
HBASE-13871Change RegionScannerImpl to deal with Cell instead of byte[], int, intMajorregionserver, Scanners
HBASE-13836Do not reset the mvcc for bulk loaded mob reference cells in readingMajormob
HBASE-13451Make the HFileBlockIndex blockKeys to Cells so that it could be easy to use in the CellComparatorsMajor.
HBASE-13856Wrong mob metrics names in TestRegionServerMetricsMajormob
HBASE-13806Check the mob files when there are mob-enabled columns in HFileCorruptionCheckerMajormob
HBASE-13827Delayed scanner close in KeyValueHeap and StoreScannerMajorregionserver, Scanners
HBASE-13817ByteBufferOuputStream - add writeInt supportMajorScanners
HBASE-13804Revert the changes in pom.xmlMajormob
HBASE-13803Disable the MobCompactionChore when the interval is not larger than 0Majormob
HBASE-13805Use LimitInputStream in hbase-common instead of ProtobufUtil.LimitedInputStreamMajormob
HBASE-13759Improve procedure yieldingTrivialproc-v2
HBASE-13790Remove the DeleteTableHandlerMajormob
HBASE-13616Move ServerShutdownHandler to Pv2Majorproc-v2
HBASE-13476Procedure V2 - Add Replay Order logic for child proceduresMajorproc-v2
HBASE-13763Handle the rename, annotation and typo stuff in MOBMajormob
HBASE-13754Allow non KeyValue Cell types also to oswriteMajorScanners
HBASE-13393Optimize memstore flushing to avoid writing tag information to hfiles when no tags are present.MajorHFile, Performance
HBASE-13658Improve the test run time for TestAccessController classMajortest
HBASE-13762Use the same HFileContext with store files in mob filesMajormob
HBASE-13720Mob files are not encrypting in mob compaction and SweeperMajorregionserver, Scanners
HBASE-13739Remove KeyValueUtil.ensureKeyValue(cell) from MOB code.Majormob
HBASE-13641Deperecate Filter#filterRowKey(byte[] buffer, int offset, int length) in favor of filterRowKey(Cell firstRowCell)MajorFilters, regionserver, Scanners
HBASE-13736Add delay for the first execution of ExpiredMobFileCleanerChore and MobFileCompactorChoreMajormob
HBASE-13642Deprecate RegionObserver#postScannerFilterRow CP hook with byte[],int,int args in favor of taking Cell argMajorCoprocessors, regionserver, Scanners
HBASE-13679Change ColumnTracker and SQM to deal with Cell instead of byte[], int, intMajorregionserver, Scanners
HBASE-13531Flakey failures of TestAcidGuarantees#testMobScanAtomicityMajorregionserver, Scanners
HBASE-13510Purge ByteBloomFilterMajor.
HBASE-13398Document HBase QuotaMajordocumentation
HBASE-13201Remove HTablePool from thrift-serverMajor.
HBASE-13571Procedure v2 - client modify table sync (incompatible with branch-1.x)Minorproc-v2
HBASE-13593Quota support for namespace should take snapshot restore and clone into accountMajorsnapshots
HBASE-13620Bring back the removed VisibilityClient methods and mark them as deprecated.Minor.
HBASE-13464Remove deprecations for 2.0.0 - Part 1Major.
HBASE-13501Deprecate/Remove getComparator() in HRegionInfo.Major.
HBASE-13497Remove MVCC stamps from HFile when that is safeMajorScanners
HBASE-13184Document turning off memstore for region replicasCriticaldocumentation, Replication
HBASE-13537Procedure V2 - Change the admin interface for async operations to return Future (incompatible with branch-1.x)Majorproc-v2
HBASE-13572Procedure v2 - client truncate table sync (incompatible with branch-1.x)Minorproc-v2
HBASE-13551Procedure V2 - Procedure classes should not be InterfaceAudience.PublicBlockermaster
HBASE-13563Add missing table owner to AC tests.Minor.
HBASE-13466Document deprecations in 1.x - Part 1Major.
HBASE-13536Cleanup the handlers that are no longer being used.Majorproc-v2
HBASE-13450Purge RawBytescomparator from the writers and readers for HBASE-10800Major.
HBASE-13529Procedure v2 - WAL ImprovementsBlockerproc-v2
HBASE-13496Make Bytes$LexicographicalComparerHolder$UnsafeComparer::compareTo inlineableMajorScanners
HBASE-13502Deprecate/remove getRowComparator() in TableNameMajor.
HBASE-13515Handle FileNotFoundException in region replica replay for flush/compaction eventsMajor.
HBASE-13514Fix test failures in TestScannerHeartbeatMessages caused by incorrect setting of hbase.rpc.timeoutMinor.
HBASE-13498Add more docs and a basic check for storage policy handlingMinorwal
HBASE-13481Master should respect master (old) DNS/bind related configurationsMajor.
HBASE-13307Making methods under ScannerV2#next inlineable, fasterMajorScanners
HBASE-13455Procedure V2 - master truncate tableMinormaster
HBASE-13290Procedure v2 - client enable/disable table syncMajorClient
HBASE-13211Procedure V2 - master Enable/Disable tableMajormaster
HBASE-13210Procedure V2 - master Modify tableMajormaster
HBASE-13209Procedure V2 - master Add/Modify/Delete Column FamilyMajormaster
HBASE-13204Procedure v2 - client create/delete table syncMinormaster
HBASE-13203Procedure v2 - master create/delete tableMinormaster
HBASE-13202Procedure v2 - core frameworkMajormaster, proc-v2
HBASE-13447Bypass logic in TimeRange.compareMinorScanners
HBASE-13313Skip the disabled table in mob compaction chore and MasterRpcServicesMajorregionserver, Scanners
HBASE-13429Remove deprecated seek/reseek methods from HFileScannerMajorregionserver, Scanners
HBASE-13421Reduce the number of object creations introduced by HBASE-11544 in scan RPC hot code pathsMajor.
HBASE-13302fix new javadoc warns introduced by mob.Majorregionserver, Scanners
HBASE-13277add mob_threshold option to load test toolMajorregionserver, Scanners
HBASE-13252Get rid of managed connections and connection cachingMajorAPI
HBASE-13335Update ClientSmallScanner and ClientSmallReversedScannerMajorClient
HBASE-13213Split out locality metrics among primary and secondary regionMajor.
HBASE-13303Fix size calculation of results on the region serverMajorClient
HBASE-13332Fix the usage of doAs/runAs in Visibility Controller tests.Major.
HBASE-13327Use Admin in ConnectionCacheMajor.
HBASE-13258Promote TestHRegion to LargeTestsMajortest
HBASE-13006Document visibility label support for groupsMinor.
HBASE-13230[mob] reads hang when trying to read rows with large mobs (>10MB)Majormob
HBASE-13244Test delegation token generation with kerberos enabledMajorsecurity, test
HBASE-13226Document enable_table_replication and disable_table_replication shell commandsMinordocumentation
HBASE-13169ModifyTable increasing the region replica count should also auto-setup RRREMajor.
HBASE-13121Async wal replication for region replicas and dist log replay does not work togetherMajor.
HBASE-13095Document how to retrieve replication stats from HBase ShellMajordocumentation, Replication
HBASE-13164Update TestUsersOperationsWithSecureHadoop to use MiniKdcMajorsecurity, test
HBASE-12562Handling memory pressure for secondary region replicasMajor.
HBASE-13151IllegalArgumentException in compaction when table has a namespaceMajorregionserver, Scanners
HBASE-13107Refactor MOB Snapshot logic to reduce code duplication.Majormob, snapshots
HBASE-13157Add mob compaction actions and monkeys to Chaos MonkeyMajorintegration tests, mob
HBASE-12332[mob] improve how we resolve mobfiles in readsMajormob
HBASE-13154Add support for mob in TestAcidGuarantees and IntegrationTestAcidGuaranteesMajorintegration tests, mob
HBASE-13012Add shell commands to trigger the mob file compactorMajorregionserver, Scanners
HBASE-11580Failover handling for secondary region replicasMajor.
HBASE-13152NPE in ExpiredMobFileCleanerChoreMajorregionserver, Scanners
HBASE-11571Bulk load handling from secondary region replicasMajor.
HBASE-12670Add unit tests that exercise the added hfilelink link mob pathsMajorregionserver, Scanners
HBASE-13130Add timeouts on TestMasterObserver, a frequent zombie showMajortest
HBASE-13117improve mob sweeper javadocMajormob
HBASE-13067Fix caching of stubs to allow IP address changes of restarted remote serversMajor.
HBASE-12561Replicas of regions can be cached from different instances of the table in MetaCacheMajor.
HBASE-12714RegionReplicaReplicationEndpoint should not set the RPC CodecMajor.
HBASE-11842Integration test for async wal replication to secondary regionsMajor.
HBASE-13013Add read lock to ExpiredMobFileCleanerChoreMajormaster
HBASE-12425Document the phases of the split transactionMajordocumentation
HBASE-11569Flush / Compaction handling from secondary region replicasMajor.
HBASE-11910Document Premptive Call Me Maybe HBase findings in the online manualMajor.
HBASE-11567Write bulk load COMMIT events to WALMajor.
HBASE-11568Async WAL replication for region replicasMajor.
HBASE-11861Native MOB Compaction mechanisms.Majorregionserver, Scanners
HBASE-10942support parallel request cancellation for multi-getMajor.
HBASE-12936Quota support for namespace should take region merge into accountMajor.
HBASE-11574hbase:meta's regions can be replicatedMajor.
HBASE-11908Region replicas should be added to the meta table at the time of table creationMajor.
HBASE-7847Use zookeeper multi to clear znodesMajor.
HBASE-12669Have compaction scanner save info about delete markersMajorregionserver, Scanners
HBASE-8410Basic quota support for namespacesMajor.
HBASE-12820Use table lock instead of MobZookeeperMajorregionserver, Scanners
HBASE-12848Utilize Flash storage for WALMajor.
HBASE-12708Document newly introduced params for using Thrift-over-HTTPS.Minordocumentation, Thrift
HBASE-11533AsciiDoctor POCMinorbuild, documentation
HBASE-12695JDK 1.8 compilation brokenCriticalbuild
HBASE-12331Shorten the mob snapshot unit testsMajormob
HBASE-12698Add mob cell count to the metadata of each mob fileMajorregionserver
HBASE-12758treat mob region as any other region when generating rs manifest.Majormob, snapshots
HBASE-12012Improve cancellation for the scan RPCsMajor.
HBASE-12738Chunk Ref Guide into file-per-chapterMajordocumentation
HBASE-12528Document the newly introduced params for providing principal and keytabs.Minordocumentation
HBASE-12691sweep job needs to exit non-zero if job fails for any reason.Majormob
HBASE-12648Document per cell TTLsMinordocumentation
HBASE-12646SnapshotInfo tool does not find mob data in snapshotsMajormob, snapshots
HBASE-11903Directly invoking split & merge of replica regions should be disallowedMajor.
HBASE-12523Update checkstyle plugin rules to match our useMinorbuild
HBASE-12591Ignore the count of mob compaction metrics when there is issueMinorregionserver
HBASE-12543Incorrect log info in the store compaction of mobMinorregionserver
HBASE-12487Explicitly flush the file name in sweep jobMajorregionserver, Scanners
HBASE-12486Move the mob table name tag to the 2nd oneMajorregionserver, Scanners
HBASE-12489Incorrect ‘mobFileCacheMissCount’ calculated in the mob metricsMajorregionserver, Scanners
HBASE-12382Restore incremental compilationMajor.
HBASE-12343Document recommended configuration for 0.98 from HBASE-11964Major.
HBASE-4625Convert @deprecated HBaseTestCase tests JUnit4 style testsMinor.
HBASE-12392Incorrect implementation of CompactionRequest.isRetainDeleteMarkersCriticalregionserver, Scanners
HBASE-12391Correct a typo in the mob metricsMinorregionserver, Scanners
HBASE-11683Metrics for MOBMajorregionserver, Scanners
HBASE-11912Catch some bad practices at compile time with error-proneMajor.
HBASE-11645Snapshot for MOBMajorsnapshots
HBASE-12093Support the mob attributes in hbase shell when create/alter tableMajorshell
HBASE-12085mob status should print human readable numbers.Majormob, UI
HBASE-12080Shorten the run time of integration test by default when using mvn failsafe:integration-testMajortest
HBASE-12066Avoid major compaction in TestMobSweeperMajorCompaction, mob
HBASE-11644External MOB compaction toolsMajorCompaction, master
HBASE-11472Remove ZKTableStateClientSideReader classMajorClient, Consensus, Zookeeper
HBASE-11598Add simple rpc throttlingMinor.
HBASE-8139Allow job names to be overriddenMajormapreduce, Usability
HBASE-11646Handle the MOB in compactionMajorCompaction
HBASE-11986Document MOB in Ref GuideMajordocumentation
HBASE-12000isMob and mobThreshold do not follow column descriptor property naming conventionsMajorregionserver, Scanners
HBASE-11975Remove the explicit list of maven repositories in pom.xmlMajor.
HBASE-7767Get rid of ZKTable, and table enable/disable state in ZKMajorZookeeper
HBASE-11647MOB integration testingMajorPerformance, test
HBASE-11911Break up tests into more fine grained categoriesMajor.
HBASE-11901Improve the value size of the reference cell in mob columnMajor.
HBASE-11786Document web UI for tracking time spent in coprocessorsMinorCoprocessors, documentation
HBASE-11643Read and write MOB in HBaseMajorregionserver, Scanners
HBASE-11779Document the new requirement to set JAVA_HOME before starting HBaseMajordocumentation
HBASE-11607Document HBase metricsMajordocumentation, metrics
HBASE-10674HBCK should be updated to do replica related checksMajor.
HBASE-4624Remove and convert @deprecated RemoteExceptionHandler.decodeRemoteException callsMajor.
HBASE-11261Handle splitting/merging of regions that have region_replication greater than oneMajor.

OTHER:

JIRASummaryPriorityComponent
HBASE-8770deletes and puts with the same ts should be resolved according to mvcc/seqNumBlocker.
HBASE-20067Clean up findbugs warningsCritical.
HBASE-10403Simplify offheap cache configurationMinorio
HBASE-19976Dead lock if the worker threads in procedure executor are exhaustedCritical.
HBASE-19948Since HBASE-19873, HBaseClassTestRule, Small/Medium/Large has different semanticMajor.
HBASE-19296Fix findbugs and error-prone warnings (branch-2)Major.
HBASE-19425Align the methods in Put/Delete/Increment/AppendMajor.
HBASE-19627Stabilize the method signature for Cell and its implCritical.
HBASE-18429ITs attempt to modify immutable table/column descriptorsCriticalintegration tests
HBASE-18110[AMv2] Reenable tests temporarily disabledBlockerRegion Assignment
HBASE-18978Align the methods in Table and AsyncTableCriticalasyncclient, Client
HBASE-18805Unify Admin and AsyncAdminMajor.
HBASE-18703Inconsistent behavior for preBatchMutate in doMiniBatchMutate and processRowsWithLocksCriticalCoprocessors
HBASE-18926Cleanup Optional<T> from method paramsMajor.
HBASE-17143Scan improvementBlockerClient, scan
HBASE-18751Revisit the TimeRange and TimeRangeTrackerMajor.
HBASE-7320Remove KeyValue.getBuffer()Blocker.
HBASE-10462Recategorize some of the client facing Public / Private interfacesBlockerClient
HBASE-18696Fix the problems when introducing the new hbase-mapreduce moduleBlockermapreduce
HBASE-18501Use TableDescriptor and ColumnFamilyDescriptor as far as possibleCritical.
HBASE-18266Eliminate the warnings from the spotbugsMajor.
HBASE-17359Implement async adminMajorClient
HBASE-15086Fix findbugs complaint so yetus reports more greenMajorbuild
HBASE-6581Build with hadoop.profile=3.0Major.
HBASE-16617Procedure V2 - ImprovementsMinormaster, proc-v2
HBASE-16833Implement asynchronous hbase client based on HBASE-15921MajorClient
HBASE-18037Do not expose implementation classes to CPBlockerCoprocessors
HBASE-15179Cell/DBB end-to-end on the write-pathMajorregionserver
HBASE-16145MultiRowRangeFilter constructor shouldn't throw IOExceptionMinor.
HBASE-16567Upgrade to protobuf-3.1.xCriticalProtobufs
HBASE-11871Avoid usage of KeyValueUtil#ensureKeyValueMajorregionserver
HBASE-16432Revisit the asynchronous ipc implementationMajorrpc
HBASE-14460[Perf Regression] Merge of MVCC and SequenceId (HBASE-8763) slowed Increments, CheckAndPuts, batch operationsCriticalPerformance
HBASE-11425Cell/DBB end-to-end on the read-pathMajorregionserver, Scanners
HBASE-14457Umbrella: Improve Multiple WAL for production usageMajor.
HBASE-14420Zombie Stomping SessionCriticaltest
HBASE-14869Better request latency and size histogramsMajor.
HBASE-11339HBase MOBMajorregionserver, Scanners
HBASE-13747Promote Java 8 to “yes” in support matrixCriticaljava
HBASE-7781Update security unit tests to use a KDC if availableBlockersecurity, test
HBASE-12859New master API to track major compaction completionMajor.
HBASE-18792hbase-2 needs to defend against hbck operationsBlockerhbck
HBASE-19963TestFSHDFSUtils assumes wrong default port for Hadoop 3.0.1+Majortest
HBASE-20386[DOC] Align WALPlayer help text and refguideMinordocumentation
HBASE-20365start branch-2.0 specific website sectionCriticaldocumentation, website
HBASE-14175Adopt releasedocmaker for better generated release notesCritical.
HBASE-14348Update download mirror linkMajordocumentation, website
HBASE-20299Update MOB in hbase refguideMinormob
HBASE-20132Change the “KV” to “Cell” for web UIMinor.
HBASE-20199Add test to prevent further permission regression around table flush and snapshotCriticaltest
HBASE-20223Use hbase-thirdparty 2.1.0Blockerdependencies
HBASE-19158Ref guide needs upgrade updateBlockerdocumentation
HBASE-20212Make all Public classes have InterfaceAudience categoryCriticalUsability
HBASE-20246Remove the spark moduleBlocker.
HBASE-19552update hbase to use new thirdparty libsMajordependencies, thirdparty
HBASE-20171Remove o.a.h.h.ProcedureStateMinor.
HBASE-15151Rely on nightly tests for findbugs compliance on existing branchCriticalbuild, test
HBASE-20075remove logic for branch-1.1 nightly testingMinortest
HBASE-20072remove 1.1 release line from the prerequisite tablesMajorcommunity, documentation
HBASE-18882[TEST] Run MR branch-1 jobs against hbase2 clusterCriticalmapreduce, test
HBASE-20093Replace ServerLoad by ServerMetrics for ServerManagerMajor.
HBASE-20097Merge TableDescriptors#getAll and TableDescriptors#getAllDescriptors into oneMinor.
HBASE-20084Refactor the RSRpcServices#doBatchOpMinorregionserver
HBASE-20092Fix TestRegionMetrics#testRegionMetricsMinortest
HBASE-20088Update copyright notices to year 2018Minor.
HBASE-20089make_rc.sh should name SHA-512 checksum files with the extension .sha512Minor.
HBASE-18596[TEST] A hbase1 cluster should be able to replicate to a hbase2 cluster; verifyBlocker.
HBASE-19947MR jobs using ITU use wrong filesystemCriticalintegration tests
HBASE-19946TestPerColumnFamilyFlush and TestWalAndCompactingMemStoreFlush fail against h3Majortest
HBASE-19922ProtobufUtils::PRIMITIVES is unusedMajorProtobufs
HBASE-19720Rename WALKey#getTabnename to WALKey#getTableNameMajor.
HBASE-15042refactor so that site materials are in the Standard Maven PlaceMinorbuild, website
HBASE-19596RegionMetrics/ServerMetrics/ClusterMetrics should apply to all public classesCriticalClient
HBASE-19620Add UT to confirm the race in MasterRpcServices.getProcedureResultMinorproc-v2, test
HBASE-19652Turn down CleanerChore logging; too chattyMajor.
HBASE-19644add the checkstyle rule to reject the illegal importsMajor.
HBASE-19637Add .checkstyle to gitignoreMajorbuild
HBASE-19550Wrap the cell passed via Mutation#add(Cell) to be of ExtendedCellMajor.
HBASE-18970The version of jruby we use now can't get interactive input from promptCriticalshell
HBASE-19548Backport the missed doc fix from master to branch-2Major.
HBASE-19526Update hadoop version to 3.0 GAMajorbuild, dependencies
HBASE-19477Move and align documentation in hbase-annotationsTrivial.
HBASE-19267Eclipse project import issues on 2.0Majorbuild
HBASE-19512Move EventType and ExecutorType from hbase-client to hbase-serverMajorregionserver
HBASE-19485Minor improvement to TestCompactedHFilesDischargerTrivial.
HBASE-18988Add release managers to reference guideTrivialdocumentation
HBASE-19410Move zookeeper related UTs to hbase-zookeeper and mark them as ZKTestsMajortest, Zookeeper
HBASE-19323Make netty engine default in hbase2Majorrpc
HBASE-19416Document dynamic configurations currently supportMinordocumentation
HBASE-19298CellScanner and CellScannable should be declared as IA.PublicMajor.
HBASE-19408Remove WALActionsListener.BaseTrivial.
HBASE-19407[branch-2] Remove backup/restoreBlocker.
HBASE-19328Remove asked if splittable log messagesMinorproc-v2
HBASE-19200make hbase-client only depend on ZKAsyncRegistry and ZNodePathsMajorClient, Zookeeper
HBASE-19123Purge ‘complete’ support from Coprocesor ObserversMajorCoprocessors
HBASE-19241Improve javadoc for AsyncAdmin and cleanup warnings for the implementation classesMajordocumentation
HBASE-14350Procedure V2 Phase 2: Assignment ManagerBlockermaster, proc-v2
HBASE-19224LICENSE failure for Hadoop 3.1 on dnsjavaMajorbuild
HBASE-18817Pull hbase-spark module out of branch-2Blockerspark
HBASE-19217Update supplemental-models.xml for jetty-sslengineMajor.
HBASE-19179Remove hbase-prefix-treeCritical.
HBASE-19176Remove hbase-native-client from branch-2Major.
HBASE-19097update testing to use Apache Yetus Test Patch version 0.6.0Majorbuild
HBASE-19049Update kerby to 1.0.1 GA releaseMajordependencies
HBASE-16338update jackson to 2.yMajordependencies
HBASE-19007Align Services Interfaces in Master and RegionServerBlocker.
HBASE-19043Purge TableWrapper and CoprocessorHConnnectionMajorCoprocessors
HBASE-18991Remove RegionMergeRequestTrivial.
HBASE-18927Add the DataType which is subset of KeyValue#Type to CellBuilder for building cellMajor.
HBASE-18833Ensure precommit personality is up to date on all active branchesCriticaltest
HBASE-10504Define Replication InterfaceBlockerReplication
HBASE-18767Release hbase-2.0.0-alpha-3; Theme “Scrubbed API”Major.
HBASE-18835The return type of ExtendedCell#deepClone should be ExtendedCell rather than CellMajor.
HBASE-18766Make TableSnapshotScanner Audience PrivateMajor.
HBASE-18782Module untangling workMajor.
HBASE-18421update hadoop prerequisites docs to call out 2.8.1Majorcommunity, dependencies, documentation
HBASE-13868Correct “Disable automatic splitting” section in HBase bookTrivialdocumentation
HBASE-17972Remove mergePool from CompactSplitThreadMinorregionserver
HBASE-18768Move TestTableName to hbase-common from hbase-serverMajor.
HBASE-17967clean up documentation references to -ROOT- table.Minordocumentation
HBASE-18710Move on to hbase-thirdparty 1.0.1 (it was just released).Majorhbase-thirdparty
HBASE-18705bin/hbase does not find cached_classpath.txtMajor.
HBASE-18611Copy all tests from o.a.h.h.p.TestProtobufUtil to o.a.h.h.s.p.TestProtobufUtilMinorProtobufs, test
HBASE-18670Add .DS_Store to .gitignoreMinorcommunity
HBASE-17614Move Backup/Restore into separate moduleBlocker.
HBASE-18660Remove duplicate code from the checkAndPut method in HTableTrivial.
HBASE-18653Undo hbase2 check against < hadoop2.6.x; i.e. implement agreed drop of hadoop 2.4 and 2.5 support in hbase2Majorbuild
HBASE-18630Prune dependencies; as is branch-2 has duplicatesMajordependencies
HBASE-18594Release hbase-2.0.0-alpha2Major.
HBASE-18623Frequent failed to parse at EOF warnings from WALEntryStreamMinor.
HBASE-18518Remove jersey1* dependencies from project and jersey1* jars from lib dirMajordependencies, pom, REST
HBASE-18544Move the HRegion#addRegionToMETA to TestDefaultMemStoreMinorregionserver
HBASE-18582Correct the docs for Mutation#setCellVisibilityMinordocumentation
HBASE-18588Verify we're using netty .so epolling on linux post HBASE-18271Majortest
HBASE-18514Backport space quota “phase2” work to branch-2Blocker.
HBASE-18527update nightly builds to compensate for jenkins plugin upgradesBlockercommunity, test
HBASE-18515Introduce Delete.add as a replacement for Delete#addDeleteMarkerMajorClient
HBASE-16100Procedure V2 - ToolsMinorproc-v2, tooling
HBASE-15141Procedure V2 - Web UIBlockerproc-v2, UI
HBASE-18465[AMv2] remove old split region code that is no longer neededMajorAdmin, rpc
HBASE-16728Add hadoop.profile=3.0 pass to precommit checks.Majorbuild, hadoop3
HBASE-18384Add link to refguide schema section on apache blog on hbase application archetypesMinordocumentation
HBASE-18344Introduce Append.addColumn as a replacement for Append.addTrivial.
HBASE-18364Downgrade surefireMajor.
HBASE-18291Regenerate thrift2 python examplesMinor.
HBASE-18288Declared dependency on specific javax.ws.rsMajordependencies, REST
HBASE-18284Update hbasecon asia logo on home page of hbase.apache.orgMajor.
HBASE-12794Guidelines for filing JIRA issuesMajordocumentation
HBASE-18258Take down hbasecon2017 logo from hbase.apache.org and put up hbaseconasia2017 instead.Major.
HBASE-17954Switch findbugs implementation to spotbugsMajorbuild, community, test
HBASE-17898Update dependenciesCritical.
HBASE-18187Release hbase-2.0.0-alpha1Major.
HBASE-18096Limit HFileUtil visibility and add missing annotationsTrivial.
HBASE-13074Cleaned up usage of hbase.master.lease.thread.wakefrequencyTrivialwal
HBASE-17968Update copyright year in NOTICE fileTrivialbuild
HBASE-17965Canary tool should print the regionserver name on failureMinor.
HBASE-17828Revisit the IS annotation and the documentationCriticalAPI
HBASE-16215clean up references for EOM release linesMajorcommunity, website
HBASE-17847update documentation to include positions on recent Hadoop releasesCriticalcommunity, documentation
HBASE-17834close stale github PRsMinorcommunity
HBASE-17802Add note that minor versions can add methods to InterfacesMajordocumentation
HBASE-17782Extend IdReadWriteLock to support using both weak and soft referenceMajor.
HBASE-17618Refactor the implementation of modify table and delete column in MOBMajormob
HBASE-17609Allow for region merging in the UIMajor.
HBASE-16812Clean up the locks in MOBMinormob
HBASE-17502Document hadoop pre-2.6.1 and Java 1.8 Kerberos problem in our hadoop support matrixMajor.
HBASE-16710Add ZStandard Codec to Compression.javaMinor.
HBASE-17401Remove unnecessary semicolons in hbase-annotationsTrivial.
HBASE-17397AggregationClient cleanupMinor.
HBASE-16869Typo in “Disabling Blockcache” docTrivialdocumentation
HBASE-17272Doc how to run Standalone HBase over an HDFS instance; all daemons in one JVM but persisting to an HDFS instanceMajordocumentation
HBASE-17121Undo the building of xref as part of site buildMajor.
HBASE-16335update to latest apache parent pomMajorbuild, dependencies
HBASE-17046Add 1.1 doc to hbase.apache.orgMajorwebsite
HBASE-16955Fixup precommit protoc check to do new distributed protos and pb 3.1.0 buildMajorbuild, Protobufs
HBASE-16413Add apache-hbase.slack.com #users channel to ref guideMinordocumentation
HBASE-16952Replace hadoop-maven-plugins with protobuf-maven-plugin for building protosMajorbuild
HBASE-16811Remove mob sweep jobMinor.
HBASE-16591Add a docker file only contains java 8 for running pre commit on masterBlockerbuild
HBASE-16518Remove old .arcconfig fileTrivialtooling
HBASE-16376Document implicit side-effects on partial results when calling Scan#setBatch(int)MinorAPI, documentation
HBASE-16467Move AbstractHBaseTool to hbase-commonTrivial.
HBASE-16260Audit dependencies for Category-XCriticalcommunity, dependencies
HBASE-16426Remove company affiliations from committer listMajordocumentation, website
HBASE-16354Clean up defunct GitHub PRsMajorcommunity
HBASE-15656Fix unused protobuf warning in Admin.protoMinor.
HBASE-16073update compatibility_checker for jacc dropping comma sep argsCriticalbuild, documentation
HBASE-15989Remove hbase.online.schema.update.enableMajor.
HBASE-15888Extend HBASE-12769 for bulk load data replicationMajorReplication
HBASE-15895remove unmaintained jenkins build analysis tool.Minorbuild
HBASE-14635Fix flaky test TestSnapshotCloneIndependenceMajortest
HBASE-4368Expose processlist in shell (per regionserver and perhaps by cluster)Majorshell
HBASE-15646Add some docs about exporting and importing snapshots using S3Majordocumentation, snapshots
HBASE-15729Remove old JDiff wrapper scripts in dev-supportMinorbuild, community
HBASE-15644Add maven-scala-plugin for scaladocMajorbuild
HBASE-15494Close obviated PRs on githubMajorcommunity
HBASE-14678Experiment: Temporarily disable balancer and a few others to see if root of crashed/timedout JVMsCriticaltest
HBASE-15502Skeleton unit test to copy/pasteMajordocumentation
HBASE-15220Change two logs in SimpleRegionNormalizer to INFO levelMinor.
HBASE-15017Close out GitHub pull requests that aren't likely to update into a usable patchTrivialcommunity
HBASE-14526Remove delayed rpcMajor.
HBASE-15099Move RegionStateListener class out of quotas packageMinor.
HBASE-15007update Hadoop support matrix to list 2.6.1+ as supportedMajordocumentation, Operability
HBASE-15003Remove BoundedConcurrentLinkedQueue and associated testMinorutil
HBASE-11985Document sizing rules of thumbMajordocumentation
HBASE-14994Clean up some broken links and references to old APIsMajordocumentation
HBASE-14534Bump yammer/coda/dropwizard metrics dependency versionMinor.
HBASE-14851Add test showing how to use TTL from thriftMajortest, Thrift
HBASE-14516categorize hadoop-compat testsCriticalbuild, hadoop2, test
HBASE-14308HTableDescriptor WARN is not actionableMinorUsability
HBASE-14732Update HBase website skin and CSSMajordocumentation
HBASE-14764Stop using post-site targetMajordocumentation
HBASE-14713Remove simple deprecated-since-1.0 code in hbase-server from hbase 2.0Major.
HBASE-14762Update docs about publishing website to show gitsubpub method instead of svnsubpubCriticaldocumentation
HBASE-14481Decommission HBase wikiBlockerdocumentation
HBASE-11720Set up jenkins job to build site documentationMinorbuild, documentation
HBASE-14026Clarify “Web API” in version and compatibility docsCriticaldocumentation
HBASE-13867Add endpoint coprocessor guide to HBase bookMajorCoprocessors, documentation
HBASE-14652Improve / update publish-website script in dev-supportMajorscripts
HBASE-14493Upgrade the jamon-runtime dependencyMinor.
HBASE-14502Purge use of jmock and remove as dependencyMajortest
HBASE-14271Improve Nexus staging instructionsMinorbuild, documentation
HBASE-14424Document that DisabledRegionSplitPolicy blocks manual splitsMinordocumentation
HBASE-14482Add hadoop 2.6.1 to the test-patch build listMinorbuild
HBASE-14227Fold special cased MOB APIs into existing APIsBlockermob
HBASE-14361ReplicationSink should create Connection instances lazilyMajorReplication
HBASE-14253update docs + build for maven 3.0.4+Majorbuild, documentation
HBASE-14318make_rc.sh should purge/re-resolve dependencies from local repositoryMajorbuild
HBASE-14290Spin up less threads in testsMajortest
HBASE-14091Update site documentation with code of conduct and project policy for transgressionsMajordocumentation, website
HBASE-14288Upgrade asciidoctor plugin to v1.5.2.1Minorbuild
HBASE-14085Correct LICENSE and NOTICE files in artifactsBlockerbuild
HBASE-13089Fix test compilation error on building against htrace-3.2.0-incubatingMinor.
HBASE-14081(outdated) references to SVN/trunk in documentationMinordocumentation, website
HBASE-14071Document troubleshooting unexpected filesystem usage by snapshots and WALsMajor.
HBASE-13446Add docs warning about missing data for downstream on versions prior to HBASE-13262Criticaldocumentation
HBASE-14057HBase shell user_permission should list super users defined on hbase-site.xmlMinorshell
HBASE-11276Add back support for running ChaosMonkey as standalone toolMinor.
HBASE-14052Mark a few methods in CellUtil audience private since only make sense internally to hbaseTrivialAPI
HBASE-14053Disable DLR in branch-1+MajorRecovery
HBASE-13869Fix typo in HBase bookTrivialdocumentation
HBASE-13964Skip region normalization for tables under namespace quotaMajorBalancer, Usability
HBASE-13948Expand hadoop2 versions built on the pre-commitMajorbuild
HBASE-13956Add myself as 1.1 release managerTrivialwebsite
HBASE-13915Remove EOL HBase versions from java and hadoop prereq tablesMajordocumentation
HBASE-13929make_rc.sh publishes empty shaded artifactsMinorbuild
HBASE-13666book.pdf is not renamed during site buildMajorwebsite
HBASE-13660Add link to cloud bigtable schema modeling guide into our refguideMajordocumentation
HBASE-13799javadoc how Scan gets polluted when used; if you set attributes or ask for scan metricsMinordocumentation
HBASE-13726stop using Hadoop's IOUtilsMajordependencies
HBASE-13716Stop using Hadoop's FSConstantsBlockerFilesystem Integration
HBASE-13582Update docs for HTraceMinordocumentation
HBASE-13713See about dropping ClassLoaderBase#getClassLoadingLockMinor.
HBASE-13586Update book on Hadoop and Java supported versions for 1.1.xMajordocumentation
HBASE-11677Make Logger instance modifiers consistentMinorutil
HBASE-13554Update book clarifying API stability guaranteesMajordocumentation
HBASE-13487Doc KEEP_DELETED_CELLSMajordocumentation
HBASE-13187Add ITBLL that exercises per CF flushCriticalintegration tests
HBASE-13361Remove or undeprecate {get|set}ScannerCaching in HTableMinorClient
HBASE-13310Fix high priority findbugs warningsMajor.
HBASE-13257Show coverage report on jenkinsMinor.
HBASE-13233add hbase-11339 branch to the patch testing scriptMinor.
HBASE-13237Improve trademark marks on the hbase.apache.org homepageMinordocumentation
HBASE-13234Improve the obviousness of the download link on hbase.apache.orgMinordocumentation
HBASE-7126Update website with info on how to report security bugsCriticaldocumentation
HBASE-12466Document visibility scan label generator usage and behaviorMajordocumentation, security
HBASE-13177Document HBASE-13012Majordocumentation, mob
HBASE-11670Build PDF of Ref GuideMinordocumentation
HBASE-12180Fix and reenable TestRegionReplicaReplicationEndpointMajortest
HBASE-12995Document that HConnection#getTable methods do not check table existence since 0.98.1Trivial.
HBASE-13079Add an admonition to Scans example that the results scanner should be closedMajordocumentation
HBASE-12168Document Rest gateway SPNEGO-based authentication for clientMajordocumentation, REST, security
HBASE-12701Document how to set the split policy on a given tableMajordocumentation
HBASE-12783Create efficient RegionLocator implementationMajor.
HBASE-12785Use FutureTask to timeout the attempt to get the lock for hbckMinor.
HBASE-12623Remove pre-0.96 to 0.96 upgrade codeMajor.
HBASE-12589Forward-port fix for TestFromClientSideWithCoprocessor.testMaxKeyValueSizeMajortest
HBASE-12515update test-patch to use gitMinorbuild
HBASE-12438Add -Dsurefire.rerunFailingTestsCount=2 to patch build runs so flakies get rerunMajortest
HBASE-12362Interim documentation of important master and regionserver metricsMajordocumentation
HBASE-12239Document hedged readsMajordocumentation
HBASE-11791Update docs on visibility tags and ACLs, transparent encryption, secure bulk uploadMajordocumentation
HBASE-11961Document region state transitionsMinor.
HBASE-11619Remove unused test class from TestHLogSplitTrivialwal
HBASE-4593Design and document the official procedure for posting patches, commits, commit messages, etc. to smooth process and make integration with tools easierMajordocumentation
HBASE-11729Document HFile v3Trivialdocumentation, HFile
HBASE-11606Enable ZK-less region assignment by defaultMinor.
HBASE-10398HBase book updates for Replication after HBASE-10322Majordocumentation
HBASE-11459Add more doc on compression codecs, how to hook up native lib, lz4, etc.Minordocumentation
HBASE-8450Update hbase-default.xml and general recommendations to better suit current hw, h2, experience, etc.CriticalUsability

NOTE: Below pre-2.0.0 changes were generated otherwise. Imported as-is, unaltered.

Release Notes - HBase - Version 1.0.0 02/20/2015

** Sub-task
    * [HBASE-11852] - Still see "UnsupportedOperationException: CollectionUsage threshold is not supported"
    * [HBASE-12485] - Maintain SeqId monotonically increasing
    * [HBASE-12511] - namespace permissions - add support from table creation privilege in a namespace 'C'
    * [HBASE-12568] - Adopt Semantic Versioning and document it in the book
    * [HBASE-12575] - Sanity check table coprocessor classes are loadable
    * [HBASE-12606] - Sanity check encryption configuration before opening WAL or onlining regions
    * [HBASE-12679] - Add HBaseInterfaceAudience.TOOLS and move some of the Public classes to LimitedPrivate
    * [HBASE-12704] - Add demo client which uses doAs functionality on Thrift-over-HTTPS.
    * [HBASE-12730] - Backport HBASE-5162 (Basic client pushback mechanism) to branch-1
    * [HBASE-12735] - Refactor TAG so it can live as unit test and as an integration test
    * [HBASE-12763] - Make it so there must be WALs for a server to be marked dead
    * [HBASE-12776] - SpliTransaction: Log number of files to be split
    * [HBASE-12779] - SplitTransaction: Add metrics
    * [HBASE-12793] - [hbck] closeRegionSilentlyAndWait() should log cause of IOException and retry until  hbase.hbck.close.timeout expires
    * [HBASE-12802] - Remove unnecessary Table.flushCommits()
    * [HBASE-12926] - Backport HBASE-12688 (Update site with a bootstrap-based UI) for HBASE-12918
    * [HBASE-12980] - Delete of a table may not clean all rows from hbase:meta

** Bug
    * [HBASE-8026] - HBase Shell docs for scan command does not reference VERSIONS
    * [HBASE-9431] - Set  'hbase.bulkload.retries.number' to 10 as HBASE-8450 claims
    * [HBASE-9910] - TestHFilePerformance and HFilePerformanceEvaluation should be merged in a single HFile performance test class.
    * [HBASE-10499] - In write heavy scenario one of the regions does not get flushed causing RegionTooBusyException
    * [HBASE-10528] - DefaultBalancer selects plans to move regions onto draining nodes
    * [HBASE-11979] - Compaction progress reporting is wrong
    * [HBASE-12028] - Abort the RegionServer, when it's handler threads die
    * [HBASE-12070] - Add an option to hbck to fix ZK inconsistencies
    * [HBASE-12108] - HBaseConfiguration: set classloader before loading xml files
    * [HBASE-12267] - Replace HTable constructor in mapreduce.* classes with ConnectionFactory
    * [HBASE-12270] - A bug in the bucket cache, with cache blocks on write enabled
    * [HBASE-12339] - WAL performance evaluation tool doesn't roll logs
    * [HBASE-12348] - preModifyColumn and preDeleteColumn in AC denies user to perform its operation though it has required rights
    * [HBASE-12393] - The regionserver web will throw exception if we disable block cache
    * [HBASE-12422] - Use ConnectionFactory in HTable constructors
    * [HBASE-12431] - Use of getColumnLatestCell(byte[], int, int, byte[], int, int) is Not Thread Safe
    * [HBASE-12454] - Setting didPerformCompaction early in HRegion#compact
    * [HBASE-12467] - Master joins cluster but never completes initialization
    * [HBASE-12480] - Regions in FAILED_OPEN/FAILED_CLOSE should be processed on master failover
    * [HBASE-12564] - consolidate the getTableDescriptors() semantic
    * [HBASE-12565] - Race condition in HRegion.batchMutate()  causes partial data to be written when region closes
    * [HBASE-12574] - Update replication metrics to not do so many map look ups.
    * [HBASE-12585] - Fix refguide so it does hbase 1.0 style API everywhere with callout on how we used to do it in pre-1.0
    * [HBASE-12607] - TestHBaseFsck#testParallelHbck fails running against hadoop 2.6.0
    * [HBASE-12611] - Create autoCommit() method and remove clearBufferOnFail
    * [HBASE-12617] - Running IntegrationTestBigLinkedList against cluster getting not an instance of org.apache.hadoop.hbase.MiniHBaseCluster
    * [HBASE-12618] - Add 'Namespace' to headers while displaying user permissions.
    * [HBASE-12622] - user_permission should require global admin to display global and ns permissions
    * [HBASE-12632] - ThrottledInputStream/ExportSnapshot does not throttle
    * [HBASE-12634] -  Fix the AccessController#requireGlobalPermission(ns) with NS
    * [HBASE-12635] - Delete acl notify znode of table after the table is deleted
    * [HBASE-12637] - Compilation with Hadoop-2.4- is broken
    * [HBASE-12642] - LoadIncrementalHFiles does not throw exception after hitting hbase.bulkload.retries.number setting
    * [HBASE-12644] - Visibility Labels: issue with storing super users in labels table
    * [HBASE-12647] - Truncate table should work with C as well
    * [HBASE-12652] - Allow unmanaged connections in MetaTableAccessor
    * [HBASE-12655] - WALPerformanceEvaluation miscalculates append/sync statistics for multiple regions
    * [HBASE-12661] - rat check fails for several files
    * [HBASE-12662] - region_status.rb is failing with NoMethodError
    * [HBASE-12663] - unify getTableDescriptors() and listTableDescriptorsByNamespace()
    * [HBASE-12664] - TestDefaultLoadBalancer.testBalanceCluster fails in CachedDNSToSwitchMapping
    * [HBASE-12665] - When aborting, dump metrics
    * [HBASE-12666] - TestAssignmentManager hanging; add timeouts
    * [HBASE-12671] - HBASE-12652 broke branch-1 builds (TestAssignmentManager fails)
    * [HBASE-12674] - Add permission check to getNamespaceDescriptor()
    * [HBASE-12675] - Use interface methods in shell scripts
    * [HBASE-12681] - truncate_preserve command fails with undefined method `getTable' error
    * [HBASE-12683] - Compilation with hadoop-2.7.0-SNAPSHOT is broken
    * [HBASE-12686] - Failures in split before PONR not clearing the daughter regions from regions in transition during rollback
    * [HBASE-12692] - NPE from SnapshotManager#stop
    * [HBASE-12694] - testTableExistsIfTheSpecifiedTableRegionIsSplitParent in TestSplitTransactionOnCluster class leaves regions in transition
    * [HBASE-12696] - Possible NPE in HRegionFileSystem#splitStoreFile when skipStoreFileRangeCheck in splitPolicy return true
    * [HBASE-12697] - Don't use RegionLocationFinder if localityCost == 0
    * [HBASE-12699] - undefined method `setAsyncLogFlush' exception thrown when setting DEFERRED_LOG_FLUSH=>true
    * [HBASE-12711] - Fix new findbugs warnings in hbase-thrift module
    * [HBASE-12715] - getLastSequenceId always returns -1
    * [HBASE-12716] - A bug in RegionSplitter.UniformSplit algorithm
    * [HBASE-12718] - Convert TestAcidGuarantees from a unit test to an integration test
    * [HBASE-12728] - buffered writes substantially less useful after removal of HTablePool
    * [HBASE-12732] - Log messages in FileLink$FileLinkInputStream#tryOpen are reversed
    * [HBASE-12739] - Avoid too large identifier of ZooKeeperWatcher
    * [HBASE-12740] - Improve performance of TestHBaseFsck
    * [HBASE-12741] - AccessController contains a javadoc issue
    * [HBASE-12742] - ClusterStatusPublisher crashes with a IPv6 network interface.
    * [HBASE-12744] - hbase-default.xml lists hbase.regionserver.global.memstore.size twice
    * [HBASE-12746] - [1.0.0RC0] Distributed Log Replay is on (HBASE-12577 was insufficient)
    * [HBASE-12747] - IntegrationTestMTTR will OOME if launched with mvn verify
    * [HBASE-12750] - getRequestsCount() in ClusterStatus returns total number of request
    * [HBASE-12767] - Fix a StoreFileScanner NPE in reverse scan flow
    * [HBASE-12771] - TestFailFast#testFastFail failing
    * [HBASE-12774] - Fix the inconsistent permission checks for bulkloading.
    * [HBASE-12781] - thrift2 listen port will bind always to the passed command line address
    * [HBASE-12782] - ITBLL fails for me if generator does anything but 5M per maptask
    * [HBASE-12791] - HBase does not attempt to clean up an aborted split when the regionserver shutting down
    * [HBASE-12798] - Map Reduce jobs should not create Tables in setConf()
    * [HBASE-12801] - Failed to truncate a table while maintaing binary region boundaries
    * [HBASE-12804] - ImportTsv fails to delete partition files created by it
    * [HBASE-12810] - Update to htrace-incubating
    * [HBASE-12811] - [AccessController] NPE while scanning a table with user not having READ permission on the namespace
    * [HBASE-12817] - Data missing while scanning using PREFIX_TREE data block encoding
    * [HBASE-12819] - ExportSnapshot doesn't close FileSystem instances
    * [HBASE-12824] - CompressionTest fails with org.apache.hadoop.hbase.io.hfile.AbstractHFileReader$NotSeekedException: Not seeked to a key/value
    * [HBASE-12831] - Changing the set of vis labels a user has access to doesn't generate an audit log event
    * [HBASE-12832] - Describe table from shell no longer shows Table's attributes, only CF attributes
    * [HBASE-12833] - [shell] table.rb leaks connections
    * [HBASE-12835] - HBASE-12422 changed new HTable(Configuration) to not use managed Connections anymore
    * [HBASE-12837] - ReplicationAdmin leaks zk connections
    * [HBASE-12844] - ServerManager.isServerReacable() should sleep between retries
    * [HBASE-12847] - TestZKLessSplitOnCluster frequently times out in 0.98 builds
    * [HBASE-12862] - Uppercase "wals" in RegionServer webUI
    * [HBASE-12863] - Master info port on RS UI is always 0
    * [HBASE-12864] - IntegrationTestTableSnapshotInputFormat fails
    * [HBASE-12874] - LoadIncrementalHFiles should use unmanaged connection
    * [HBASE-12878] - Incorrect HFile path in TestHFilePerformance print output (fix for easier debugging)
    * [HBASE-12881] - TestFastFail is not compatible with surefire.rerunFailingTestsCount
    * [HBASE-12886] - Correct tag option name in PerformanceEvaluation
    * [HBASE-12892] - Add a class to allow taking a snapshot from the command line
    * [HBASE-12897] - Minimum memstore size is a percentage
    * [HBASE-12898] - Add in used undeclared dependencies
    * [HBASE-12901] - Possible deadlock while onlining a region and get region plan for other region run parallel
    * [HBASE-12904] - Threading issues in region_mover.rb
    * [HBASE-12915] - Disallow small scan with batching
    * [HBASE-12916] - No access control for replicating WAL entries
    * [HBASE-12917] - HFilePerformanceEvaluation Scan tests fail with StackOverflowError due to recursive call in createCell function
    * [HBASE-12918] - Backport asciidoc changes
    * [HBASE-12919] - Compilation with Hadoop-2.4- is broken again
    * [HBASE-12925] - Use acl cache for doing access control checks in prepare and clean phases of Bulkloading.
    * [HBASE-12942] - After disabling the hfile block cache, Regionserver UI is throwing java.lang.NullPointerException
    * [HBASE-12956] - Binding to 0.0.0.0 is broken after HBASE-10569
    * [HBASE-12958] - SSH doing hbase:meta get but hbase:meta not assigned
    * [HBASE-12962] - TestHFileBlockIndex.testBlockIndex() commented out during HBASE-10531
    * [HBASE-12966] - NPE in HMaster while recovering tables in Enabling state
    * [HBASE-12971] - Replication stuck due to large default value for replication.source.maxretriesmultiplier
    * [HBASE-12976] - Set default value for hbase.client.scanner.max.result.size
    * [HBASE-12978] - Region goes permanently offline (WAS: hbase:meta has a row missing hregioninfo and it causes my long-running job to fail)
    * [HBASE-12984] - SSL cannot be used by the InfoPort after removing deprecated code in HBASE-10336
    * [HBASE-12985] - Javadoc warning and findbugs fixes to get us green again
    * [HBASE-12989] - region_mover.rb unloadRegions method uses ArrayList concurrently resulting in errors
    * [HBASE-12991] - Use HBase 1.0 interfaces in hbase-rest
    * [HBASE-12996] - Reversed field on Filter should be transient
    * [HBASE-12998] - Compilation with Hdfs-2.7.0-SNAPSHOT is broken after HDFS-7647
    * [HBASE-13003] - Get tests in TestHFileBlockIndex back
    * [HBASE-13009] - HBase REST UI inaccessible
    * [HBASE-13010] - HFileOutputFormat2 partitioner's path is hard-coded as '/tmp'
    * [HBASE-13026] - Wrong error message in case incorrect snapshot name OR Incorrect table name
    * [HBASE-13027] - mapreduce.TableInputFormatBase should create its own Connection if needed
    * [HBASE-13028] - Cleanup mapreduce API changes
    * [HBASE-13030] - [1.0.0 polish] Make ScanMetrics public again and align Put 'add' with Get, Delete, etc., addColumn
    * [HBASE-13037] - LoadIncrementalHFile should try to verify the content of unmatched families
    * [HBASE-13038] - Fix the java doc warning continuously reported by Hadoop QA
    * [HBASE-13039] - Add patchprocess/* to .gitignore to fix builds of branches

** Improvement
    * [HBASE-5699] - Run with > 1 WAL in HRegionServer
    * [HBASE-11195] - Potentially improve block locality during major compaction for old regions
    * [HBASE-11412] - Minimize a number of hbase-client transitive dependencies
    * [HBASE-11639] - [Visibility controller] Replicate the visibility of Cells as strings
    * [HBASE-12071] - Separate out thread pool for Master <-> RegionServer communication
    * [HBASE-12121] - maven release plugin does not allow for customized goals
    * [HBASE-12204] - Backport HBASE-12016 'Reduce number of versions in Meta table. Make it configurable' to branch-1
    * [HBASE-12373] - Provide a command to list visibility labels
    * [HBASE-12583] - Allow creating reference files even the split row not lies in the storefile range if required
    * [HBASE-12597] - Add RpcClient interface and enable changing of RpcClient implementation
    * [HBASE-12608] - region_mover.rb does not log moving region count correctly when loading regions
    * [HBASE-12630] - Provide capability for dropping malfunctioning ConfigurationObserver automatically
    * [HBASE-12640] - Add Thrift-over-HTTPS and doAs support for Thrift Server
    * [HBASE-12641] - Grant all permissions of hbase zookeeper node to hbase superuser in a secure cluster
    * [HBASE-12651] - Backport HBASE-12559 'Provide LoadBalancer with online configuration capability' to branch-1
    * [HBASE-12653] - Move TestRegionServerOnlineConfigChange & TestConfigurationManager to Junit4 tests
    * [HBASE-12659] - Replace the method calls to grant and revoke in shell scripts with AccessControlClient
    * [HBASE-12668] - Adapt PayloadCarryingRpcController so it can also be used in async way
    * [HBASE-12676] - Fix the misleading ASCII art in IntegrationTestBigLinkedList
    * [HBASE-12678] - HBCK should print command line arguments
    * [HBASE-12680] - Refactor base ClusterManager in HBase to not have the notion of sending a signal.
    * [HBASE-12719] - Add test WAL provider to quantify FSHLog overhead in the absence of HDFS.
    * [HBASE-12720] - Make InternalScan LimitedPrivate
    * [HBASE-12736] - Let MetaScanner recycle a given Connection
    * [HBASE-12745] - Visibility Labels:  support visibility labels for user groups.
    * [HBASE-12762] - Region with no hfiles will have the highest locality cost in LocalityCostFunction
    * [HBASE-12768] - Support enable cache_data_on_write in Shell while creating table
    * [HBASE-12773] - Add warning message when user is trying to bulkload a large HFile.
    * [HBASE-12825] - CallRunner exception messages should include destination host:port
    * [HBASE-12893] - IntegrationTestBigLinkedListWithVisibility should use buffered writes
    * [HBASE-12899] - HBase should prefix htrace configuration keys with "hbase.htrace" rather than just "hbase."
    * [HBASE-12929] - TableMapReduceUtil.initTableMapperJob unnecessarily limits the types of outputKeyClass and outputValueClass
    * [HBASE-12973] - RegionCoprocessorEnvironment should provide HRegionInfo directly
    * [HBASE-12979] - Use setters instead of return values for handing back statistics from HRegion methods
    * [HBASE-12997] - FSHLog should print pipeline on low replication
    * [HBASE-13008] - Better default for hbase.regionserver.regionSplitLimit parameter.

** New Feature
    * [HBASE-9531] - a command line (hbase shell) interface to retreive the replication metrics and show replication lag
    * [HBASE-10560] - Per cell TTLs
    * [HBASE-12709] - [mvn] Add unit test excludes command line flag to the build.
    * [HBASE-12731] - Heap occupancy based client pushback

** Task
    * [HBASE-12493] - User class should provide a way to re-use existing token
    * [HBASE-12567] - Track remaining issues for HBase-1.0
    * [HBASE-12624] - Remove rename_snapshot.rb from code as there is no equivalent renameSnapshot api in Admin class
    * [HBASE-12625] - Deprecate certain methods in classes annotated with InterfaceAudience.Public in branch-1
    * [HBASE-12689] - Move version on from 0.99.2 to HBASE-1.0.0-SNAPSHOT
    * [HBASE-12724] - Upgrade the interface audience of RegionScanner from Private to LimitedPrivate
    * [HBASE-12726] - Backport to branch-1.0 addendum for "Minimize a number of hbase-client transitive dependencies"
    * [HBASE-12788] - Promote Abortable to LimitedPrivate
    * [HBASE-12834] - Promote ScanType to LimitedPrivate

** Test
    * [HBASE-12163] - Move test annotation classes to the same package as in master
    * [HBASE-12645] - HBaseTestingUtility is using ${$HOME} for rootDir
    * [HBASE-12685] - TestSplitLogManager#testLogFilesAreArchived sometimes times out due to race condition
    * [HBASE-12799] - ITAG fails with java.lang.RuntimeException if table does not exist
    * [HBASE-12885] - Unit test for RAW / VERSIONS scanner specifications

Release Notes - HBase - Version 0.99.2 12/07/2014

** Sub-task
    * [HBASE-10671] - Add missing InterfaceAudience annotations for classes in hbase-common and hbase-client modules
    * [HBASE-11164] - Document and test rolling updates from 0.98 -> 1.0
    * [HBASE-11915] - Document and test 0.94 -> 1.0.0 update
    * [HBASE-11964] - Improve spreading replication load from failed regionservers
    * [HBASE-12075] - Preemptive Fast Fail
    * [HBASE-12128] - Cache configuration and RpcController selection for Table in Connection
    * [HBASE-12147] - Porting Online Config Change from 89-fb
    * [HBASE-12202] - Support DirectByteBuffer usage in HFileBlock
    * [HBASE-12214] - Visibility Controller in the peer cluster should be able to extract visibility tags from the replicated cells
    * [HBASE-12288] - Support DirectByteBuffer usage in DataBlock Encoding area
    * [HBASE-12297] - Support DBB usage in Bloom and HFileIndex area
    * [HBASE-12313] - Redo the hfile index length optimization so cell-based rather than serialized KV key
    * [HBASE-12353] - Turn down logging on some spewing unit tests
    * [HBASE-12354] - Update dependencies in time for 1.0 release
    * [HBASE-12355] - Update maven plugins
    * [HBASE-12363] - Improve how KEEP_DELETED_CELLS works with MIN_VERSIONS
    * [HBASE-12379] - Try surefire 2.18-SNAPSHOT
    * [HBASE-12400] - Fix refguide so it does connection#getTable rather than new HTable everywhere: first cut!
    * [HBASE-12404] - Task 5 from parent: Replace internal HTable constructor use with HConnection#getTable (0.98, 0.99)
    * [HBASE-12471] - Task 4. replace internal ConnectionManager#{delete,get}Connection use with #close, #createConnection (0.98, 0.99) under src/main/java
    * [HBASE-12517] - Several HConstant members are assignable
    * [HBASE-12518] - Task 4 polish. Remove CM#{get,delete}Connection
    * [HBASE-12519] - Remove tabs used as whitespace
    * [HBASE-12526] - Remove unused imports
    * [HBASE-12577] - Disable distributed log replay by default



** Bug
    * [HBASE-7211] - Improve hbase ref guide for the testing part.
    * [HBASE-9003] - TableMapReduceUtil should not rely on org.apache.hadoop.util.JarFinder#getJar
    * [HBASE-9117] - Remove HTablePool and all HConnection pooling related APIs
    * [HBASE-9157] - ZKUtil.blockUntilAvailable loops forever with non-recoverable errors
    * [HBASE-9527] - Review all old api that takes a table name as a byte array and ensure none can pass ns + tablename
    * [HBASE-10536] - ImportTsv should fail fast if any of the column family passed to the job is not present in the table
    * [HBASE-10780] - HFilePrettyPrinter#processFile should return immediately if file does not exist
    * [HBASE-11099] - Two situations where we could open a region with smaller sequence number
    * [HBASE-11562] - CopyTable should provide an option to shuffle the mapper tasks
    * [HBASE-11835] - Wrong managenement of non expected calls in the client
    * [HBASE-12017] - Use Connection.createTable() instead of HTable constructors.
    * [HBASE-12029] - Use Table and RegionLocator in HTable.getRegionLocations()
    * [HBASE-12053] - SecurityBulkLoadEndPoint set 777 permission on input data files
    * [HBASE-12072] - Standardize retry handling for master operations
    * [HBASE-12083] - Deprecate new HBaseAdmin() in favor of Connection.getAdmin()
    * [HBASE-12142] - Truncate command does not preserve ACLs table
    * [HBASE-12194] - Make TestEncodedSeekers faster
    * [HBASE-12219] - Cache more efficiently getAll() and get() in FSTableDescriptors
    * [HBASE-12226] - TestAccessController#testPermissionList failing on master
    * [HBASE-12229] - NullPointerException in SnapshotTestingUtils
    * [HBASE-12234] - Make TestMultithreadedTableMapper a little more stable.
    * [HBASE-12237] - HBaseZeroCopyByteString#wrap() should not be called in hbase-client code
    * [HBASE-12238] - A few ugly exceptions on startup
    * [HBASE-12240] - hbase-daemon.sh should remove pid file if process not found running
    * [HBASE-12241] - The crash of regionServer when taking deadserver's replication queue breaks replication
    * [HBASE-12242] - Fix new javadoc warnings in Admin, etc.
    * [HBASE-12246] - Compilation with hadoop-2.3.x and 2.2.x is broken
    * [HBASE-12247] - Replace setHTable() with initializeTable() in TableInputFormat.
    * [HBASE-12248] - broken link in hbase shell help
    * [HBASE-12252] - IntegrationTestBulkLoad fails with illegal partition error
    * [HBASE-12257] - TestAssignmentManager unsynchronized access to regionPlans
    * [HBASE-12258] - Make TestHBaseFsck less flaky
    * [HBASE-12261] - Add checkstyle to HBase build process
    * [HBASE-12263] - RegionServer listens on localhost in distributed cluster when DNS is unavailable
    * [HBASE-12265] - HBase shell 'show_filters' points to internal Facebook URL
    * [HBASE-12274] - Race between RegionScannerImpl#nextInternal() and RegionScannerImpl#close() may produce null pointer exception
    * [HBASE-12277] - Refactor bulkLoad methods in AccessController to its own interface
    * [HBASE-12278] - Race condition in TestSecureLoadIncrementalHFilesSplitRecovery
    * [HBASE-12279] - Generated thrift files were generated with the wrong parameters
    * [HBASE-12281] - ClonedPrefixTreeCell should implement HeapSize
    * [HBASE-12285] - Builds are failing, possibly because of SUREFIRE-1091
    * [HBASE-12294] - Can't build the docs after the hbase-checkstyle module was added
    * [HBASE-12301] - user_permission command does not show global permissions
    * [HBASE-12302] - VisibilityClient getAuths does not propagate remote service exception correctly
    * [HBASE-12304] - CellCounter will throw AIOBE when output directory is not specified
    * [HBASE-12306] - CellCounter output's wrong value for Total Families Across all Rows in output file
    * [HBASE-12308] - Fix typo in hbase-rest profile name
    * [HBASE-12312] - Another couple of createTable race conditions
    * [HBASE-12314] - Add chaos monkey policy to execute two actions concurrently
    * [HBASE-12315] - Fix 0.98 Tests after checkstyle got parented
    * [HBASE-12316] - test-patch.sh (Hadoop-QA) outputs the wrong release audit warnings URL
    * [HBASE-12318] - Add license header to checkstyle xml files
    * [HBASE-12319] - Inconsistencies during region recovery due to close/open of a region during recovery
    * [HBASE-12322] - Add clean up command to ITBLL
    * [HBASE-12327] - MetricsHBaseServerSourceFactory#createContextName has wrong conditions
    * [HBASE-12329] - Table create with duplicate column family names quietly succeeds
    * [HBASE-12334] - Handling of DeserializationException causes needless retry on failure
    * [HBASE-12336] - RegionServer failed to shutdown for NodeFailoverWorker thread
    * [HBASE-12337] - Import tool fails with NullPointerException if clusterIds is not initialized
    * [HBASE-12346] - Scan's default auths behavior under Visibility labels
    * [HBASE-12352] - Add hbase-annotation-tests to runtime classpath so can run hbase it tests.
    * [HBASE-12356] - Rpc with region replica does not propagate tracing spans
    * [HBASE-12359] - MulticastPublisher should specify IPv4/v6 protocol family when creating multicast channel
    * [HBASE-12366] - Add login code to HBase Canary tool.
    * [HBASE-12372] - [WINDOWS] Enable log4j configuration in hbase.cmd
    * [HBASE-12375] - LoadIncrementalHFiles fails to load data in table when CF name starts with '_'
    * [HBASE-12377] - HBaseAdmin#deleteTable fails when META region is moved around the same timeframe
    * [HBASE-12384] - TestTags can hang on fast test hosts
    * [HBASE-12386] - Replication gets stuck following a transient zookeeper error to remote peer cluster
    * [HBASE-12398] - Region isn't assigned in an extreme race condition
    * [HBASE-12399] - Master startup race between metrics and RpcServer
    * [HBASE-12402] - ZKPermissionWatcher race condition in refreshing the cache leaving stale ACLs and causing AccessDenied
    * [HBASE-12407] - HConnectionKey doesn't contain CUSTOM_CONTROLLER_CONF_KEY in CONNECTION_PROPERTIES
    * [HBASE-12414] - Move HFileLink.exists() to base class
    * [HBASE-12417] - Scan copy constructor does not retain small attribute
    * [HBASE-12419] - "Partial cell read caused by EOF" ERRORs on replication source during replication
    * [HBASE-12420] - BucketCache logged startup message is egregiously large
    * [HBASE-12423] - Use a non-managed Table in TableOutputFormat
    * [HBASE-12428] - region_mover.rb script is broken if port is not specified
    * [HBASE-12440] - Region may remain offline on clean startup under certain race condition
    * [HBASE-12445] - hbase is removing all remaining cells immediately after the cell marked with marker = KeyValue.Type.DeleteColumn via PUT
    * [HBASE-12448] - Fix rate reporting in compaction progress DEBUG logging
    * [HBASE-12449] - Use the max timestamp of current or old cell's timestamp in HRegion.append()
    * [HBASE-12450] - Unbalance chaos monkey might kill all region servers without starting them back
    * [HBASE-12459] - Use a non-managed Table in mapred.TableOutputFormat
    * [HBASE-12460] - Moving Chore to hbase-common module.
    * [HBASE-12461] - FSVisitor logging is excessive
    * [HBASE-12464] - meta table region assignment stuck in the FAILED_OPEN state due to region server not fully ready to serve
    * [HBASE-12478] - HBASE-10141 and MIN_VERSIONS are not compatible
    * [HBASE-12479] - Backport HBASE-11689 (Track meta in transition) to 0.98 and branch-1
    * [HBASE-12490] - Replace uses of setAutoFlush(boolean, boolean)
    * [HBASE-12491] - TableMapReduceUtil.findContainingJar() NPE
    * [HBASE-12495] - Use interfaces in the shell scripts
    * [HBASE-12513] - Graceful stop script does not restore the balancer state
    * [HBASE-12514] - Cleanup HFileOutputFormat legacy code
    * [HBASE-12520] - Add protected getters on TableInputFormatBase
    * [HBASE-12533] - staging directories are not deleted after secure bulk load
    * [HBASE-12536] - Reduce the effective scope of GLOBAL CREATE and ADMIN permission
    * [HBASE-12537] - HBase should log the remote host on replication error
    * [HBASE-12539] - HFileLinkCleaner logs are uselessly noisy
    * [HBASE-12541] - Add misc debug logging to hanging tests in TestHCM and TestBaseLoadBalancer
    * [HBASE-12544] - ops_mgt.xml missing in branch-1
    * [HBASE-12550] - Check all storefiles are referenced before splitting
    * [HBASE-12560] - [WINDOWS] Append the classpath from Hadoop to HBase classpath in bin/hbase.cmd
    * [HBASE-12576] - Add metrics for rolling the HLog if there are too few DN's in the write pipeline
    * [HBASE-12580] - Zookeeper instantiated even though we might not need it in the shell
    * [HBASE-12581] - TestCellACLWithMultipleVersions failing since task 5 HBASE-12404 (HBASE-12404 addendum)
    * [HBASE-12584] - Fix branch-1 failing since task 5 HBASE-12404 (HBASE-12404 addendum)
    * [HBASE-12595] - Use Connection.getTable() in table.rb
    * [HBASE-12600] - Remove REPLAY tag dependency in Distributed Replay Mode
    * [HBASE-12610] - Close connection in TableInputFormatBase
    * [HBASE-12611] - Create autoCommit() method and remove clearBufferOnFail
    * [HBASE-12614] - Potentially unclosed StoreFile(s) in DefaultCompactor#compact()
    * [HBASE-12616] - We lost the IntegrationTestBigLinkedList COMMANDS in recent usage refactoring




** Improvement
    * [HBASE-2609] - Harmonize the Get and Delete operations
    * [HBASE-4955] - Use the official versions of surefire & junit
    * [HBASE-8361] - Bulk load and other utilities should not create tables for user
    * [HBASE-8572] - Enhance delete_snapshot.rb to call snapshot deletion API with regex
    * [HBASE-10082] - Describe 'table' output is all on one line, could use better formatting
    * [HBASE-10483] - Provide API for retrieving info port when hbase.master.info.port is set to 0
    * [HBASE-11639] - [Visibility controller] Replicate the visibility of Cells as strings
    * [HBASE-11870] - Optimization : Avoid copy of key and value for tags addition in AC and VC
    * [HBASE-12161] - Add support for grant/revoke on namespaces in AccessControlClient
    * [HBASE-12243] - HBaseFsck should auto set ignorePreCheckPermission to true if no fix option is set.
    * [HBASE-12249] - Script to help you adhere to the patch-naming guidelines
    * [HBASE-12264] - ImportTsv should fail fast if output is not specified and table does not exist
    * [HBASE-12271] - Add counters for files skipped during snapshot export
    * [HBASE-12272] - Generate Thrift code through maven
    * [HBASE-12328] - Need to separate JvmMetrics for Master and RegionServer
    * [HBASE-12389] - Reduce the number of versions configured for the ACL table
    * [HBASE-12390] - Change revision style from svn to git
    * [HBASE-12411] - Optionally enable p-reads and private readers for compactions
    * [HBASE-12416] - RegionServerCallable should report what host it was communicating with
    * [HBASE-12424] - Finer grained logging and metrics for split transactions
    * [HBASE-12432] - RpcRetryingCaller should log after fixed number of retries like AsyncProcess
    * [HBASE-12434] - Add a command to compact all the regions in a regionserver
    * [HBASE-12447] - Add support for setTimeRange for RowCounter and CellCounter
    * [HBASE-12455] - Add 'description' to bean and attribute output when you do /jmx?description=true
    * [HBASE-12529] - Use ThreadLocalRandom for RandomQueueBalancer
    * [HBASE-12569] - Control MaxDirectMemorySize in the same manner as heap size

** New Feature
    * [HBASE-8707] - Add LongComparator for filter
    * [HBASE-12286] - [shell] Add server/cluster online load of configuration changes
    * [HBASE-12361] - Show data locality of region in table page
    * [HBASE-12496] - A blockedRequestsCount metric








** Task
    * [HBASE-10200] - Better error message when HttpServer fails to start due to java.net.BindException
    * [HBASE-10870] - Deprecate and replace HCD methods that have a 'should' prefix with a 'get' instead
    * [HBASE-12250] - Adding an endpoint for updating the regionserver config
    * [HBASE-12344] - Split up TestAdmin
    * [HBASE-12381] - Add maven enforcer rules for build assumptions
    * [HBASE-12388] - Document that WALObservers don't get empty edits.
    * [HBASE-12427] - Change branch-1 version from 0.99.2-SNAPSHOT to 0.99.3-SNAPSHOT
    * [HBASE-12442] - Bring KeyValue#createFirstOnRow() back to branch-1 as deprecated methods
    * [HBASE-12456] - Update surefire from 2.18-SNAPSHOT to 2.18
    * [HBASE-12516] - Clean up master so QA Bot is in known good state
    * [HBASE-12522] - Backport WAL refactoring to branch-1


** Test
    * [HBASE-12317] - Run IntegrationTestRegionReplicaPerf w.o mapred
    * [HBASE-12335] - IntegrationTestRegionReplicaPerf is flaky
    * [HBASE-12367] - Integration tests should not restore the cluster if the CM is not destructive
    * [HBASE-12378] - Add a test to verify that the read-replica is able to read after a compaction
    * [HBASE-12401] - Add some timestamp signposts in IntegrationTestMTTR
    * [HBASE-12403] - IntegrationTestMTTR flaky due to aggressive RS restart timeout
    * [HBASE-12472] - Improve debuggability of IntegrationTestBulkLoad
    * [HBASE-12549] - Fix TestAssignmentManagerOnCluster#testAssignRacingWithSSH() flaky test
    * [HBASE-12554] - TestBaseLoadBalancer may timeout due to lengthy rack lookup

** Umbrella
    * [HBASE-10602] - Cleanup HTable public interface
    * [HBASE-10856] - Prep for 1.0



Release Notes - HBase - Version 0.99.1 10/15/2014

** Sub-task
    * [HBASE-11160] - Undo append waiting on region edit/sequence id update
    * [HBASE-11178] - Remove deprecation annotations from mapred namespace
    * [HBASE-11738] - Document improvements to LoadTestTool and PerformanceEvaluation
    * [HBASE-11872] - Avoid usage of KeyValueUtil#ensureKeyValue from Compactor
    * [HBASE-11874] - Support Cell to be passed to StoreFile.Writer rather than KeyValue
    * [HBASE-11917] - Deprecate / Remove HTableUtil
    * [HBASE-11920] - Add CP hooks for ReplicationEndPoint
    * [HBASE-11930] - Document new permission check to roll WAL writer
    * [HBASE-11980] - Change sync to hsync, remove unused InfoServer, and reference our httpserver instead of hadoops
    * [HBASE-11997] - CopyTable with bulkload
    * [HBASE-12023] - HRegion.applyFamilyMapToMemstore creates too many iterator objects.
    * [HBASE-12046] - HTD/HCD setters should be builder-style
    * [HBASE-12047] - Avoid usage of KeyValueUtil#ensureKeyValue in simple cases
    * [HBASE-12050] - Avoid KeyValueUtil#ensureKeyValue from DefaultMemStore
    * [HBASE-12051] - Avoid KeyValueUtil#ensureKeyValue from DefaultMemStore
    * [HBASE-12059] - Create hbase-annotations module
    * [HBASE-12062] - Fix usage of Collections.toArray
    * [HBASE-12068] - [Branch-1] Avoid need to always do KeyValueUtil#ensureKeyValue for Filter transformCell
    * [HBASE-12069] - Finish making HFile.Writer Cell-centric; undo APIs that expect KV serializations.
    * [HBASE-12076] - Move InterfaceAudience imports to hbase-annotations
    * [HBASE-12077] - FilterLists create many ArrayList$Itr objects per row.
    * [HBASE-12079] - Deprecate KeyValueUtil#ensureKeyValue(s)
    * [HBASE-12082] - Find a way to set timestamp on Cells on the server
    * [HBASE-12086] - Fix bugs in HTableMultiplexer
    * [HBASE-12096] - In ZKSplitLog Coordination and AggregateImplementation replace enhaced for statements with basic for statement to avoid unnecessary object allocation
    * [HBASE-12104] - Some optimization and bugfix for HTableMultiplexer
    * [HBASE-12110] - Fix .arcconfig
    * [HBASE-12112] - Avoid KeyValueUtil#ensureKeyValue some more simple cases
    * [HBASE-12115] - Fix NumberFormat Exception in TableInputFormatBase.
    * [HBASE-12189] - Fix new issues found by coverity static analysis
    * [HBASE-12210] - Avoid KeyValue in Prefix Tree

** Bug
    * [HBASE-6994] - minor doc update about DEFAULT_ACCEPTABLE_FACTOR
    * [HBASE-8808] - Use Jacoco to generate Unit Test coverage reports
    * [HBASE-8936] - Fixing TestSplitLogWorker while running Jacoco tests.
    * [HBASE-9005] - Improve documentation around KEEP_DELETED_CELLS, time range scans, and delete markers
    * [HBASE-9513] - Why is PE#RandomSeekScanTest way slower in 0.96 than in 0.94?
    * [HBASE-10314] - Add Chaos Monkey that doesn't touch the master
    * [HBASE-10748] - hbase-daemon.sh fails to execute with 'sh' command
    * [HBASE-10757] - Change HTable class doc so it sends people to HCM getting instances
    * [HBASE-11145] - UNEXPECTED!!! when HLog sync: Queue full
    * [HBASE-11266] - Remove shaded references to logger
    * [HBASE-11394] - Replication can have data loss if peer id contains hyphen "-"
    * [HBASE-11401] - Late-binding sequenceid presumes a particular KeyValue mvcc format hampering experiment
    * [HBASE-11405] - Multiple invocations of hbck in parallel disables balancer permanently
    * [HBASE-11804] - Raise default heap size if unspecified
    * [HBASE-11815] - Flush and compaction could just close the tmp writer if there is an exception
    * [HBASE-11890] - HBase REST Client is hard coded to http protocol
    * [HBASE-11906] - Meta data loss with distributed log replay
    * [HBASE-11967] - HMaster in standalone won't go down if it gets 'Unhandled exception'
    * [HBASE-11974] - When a disabled table is scanned, NotServingRegionException is thrown instead of TableNotEnabledException
    * [HBASE-11982] - Bootstraping hbase:meta table creates a WAL file in region dir
    * [HBASE-11988] - AC/VC system table create on postStartMaster fails too often in test
    * [HBASE-11991] - Region states may be out of sync
    * [HBASE-11994] - PutCombiner floods the M/R log with repeated log messages.
    * [HBASE-12007] - StochasticBalancer should avoid putting user regions on master
    * [HBASE-12019] - hbase-daemon.sh overwrite HBASE_ROOT_LOGGER and HBASE_SECURITY_LOGGER variables
    * [HBASE-12024] - Fix javadoc warning
    * [HBASE-12025] - TestHttpServerLifecycle.testStartedServerWithRequestLog hangs frequently
    * [HBASE-12034] - If I kill single RS in branch-1, all regions end up on Master!
    * [HBASE-12038] - Replace internal uses of signatures with byte[] and String tableNames to use the TableName equivalents.
    * [HBASE-12041] - AssertionError in HFilePerformanceEvaluation.UniformRandomReadBenchmark
    * [HBASE-12042] - Replace internal uses of HTable(Configuration, String) with HTable(Configuration, TableName)
    * [HBASE-12043] - REST server should respond with FORBIDDEN(403) code on AccessDeniedException
    * [HBASE-12044] - REST delete operation should not retry disableTable for DoNotRetryIOException
    * [HBASE-12045] - REST proxy users configuration in hbase-site.xml is ignored
    * [HBASE-12052] - BulkLoad Failed due to no write permission on input files
    * [HBASE-12054] - bad state after NamespaceUpgrade with reserved table names
    * [HBASE-12056] - RPC logging too much in DEBUG mode
    * [HBASE-12064] - hbase.master.balancer.stochastic.numRegionLoadsToRemember is not used
    * [HBASE-12065] -  Import tool is not restoring multiple DeleteFamily markers of a row
    * [HBASE-12067] - Remove deprecated metrics classes.
    * [HBASE-12078] - Missing Data when scanning using PREFIX_TREE DATA-BLOCK-ENCODING
    * [HBASE-12095] - SecureWALCellCodec should handle the case where encryption is disabled
    * [HBASE-12098] - User granted namespace table create permissions can't create a table
    * [HBASE-12099] - TestScannerModel fails if using jackson 1.9.13
    * [HBASE-12106] - Move test annotations to test artifact
    * [HBASE-12109] - user_permission command for namespace does not return correct result
    * [HBASE-12119] - Master regionserver web UI NOT_FOUND
    * [HBASE-12120] - HBase shell doesn't allow deleting of a cell by user with W-only permissions to it
    * [HBASE-12122] - Try not to assign user regions to master all the time
    * [HBASE-12123] - Failed assertion in BucketCache after 11331
    * [HBASE-12124] - Closed region could stay closed if master stops at bad time
    * [HBASE-12126] - Region server coprocessor endpoint
    * [HBASE-12130] - HBASE-11980 calls hflush and hsync doing near double the syncing work
    * [HBASE-12134] - publish_website.sh script is too optimistic
    * [HBASE-12135] - Website is broken
    * [HBASE-12136] - Race condition between client adding tableCF replication znode and  server triggering TableCFsTracker
    * [HBASE-12137] - Alter table add cf doesn't do compression test
    * [HBASE-12139] - StochasticLoadBalancer doesn't work on large lightly loaded clusters
    * [HBASE-12140] - Add ConnectionFactory.createConnection() to create using default HBaseConfiguration.
    * [HBASE-12145] - Fix javadoc and findbugs so new folks aren't freaked when they see them
    * [HBASE-12146] - RegionServerTracker should escape data in log messages
    * [HBASE-12149] - TestRegionPlacement is failing undeterministically
    * [HBASE-12151] - Make dev scripts executable
    * [HBASE-12153] - Fixing TestReplicaWithCluster
    * [HBASE-12156] - TableName cache isn't used for one of valueOf methods.
    * [HBASE-12158] - TestHttpServerLifecycle.testStartedServerWithRequestLog goes zombie on occasion
    * [HBASE-12160] - Make Surefire's argLine configurable in the command line
    * [HBASE-12164] - Check for presence of user Id in SecureBulkLoadEndpoint#secureBulkLoadHFiles() is inaccurate
    * [HBASE-12165] - TestEndToEndSplitTransaction.testFromClientSideWhileSplitting fails
    * [HBASE-12166] - TestDistributedLogSplitting.testMasterStartsUpWithLogReplayWork
    * [HBASE-12167] - NPE in AssignmentManager
    * [HBASE-12170] - TestReplicaWithCluster.testReplicaAndReplication timeouts
    * [HBASE-12181] - Some tests create a table and try to use it before regions get assigned
    * [HBASE-12183] - FuzzyRowFilter doesn't support reverse scans
    * [HBASE-12184] - ServerShutdownHandler throws NPE
    * [HBASE-12191] - Make TestCacheOnWrite faster.
    * [HBASE-12196] - SSH should retry in case failed to assign regions
    * [HBASE-12197] - Move REST
    * [HBASE-12198] - Fix the bug of not updating location cache
    * [HBASE-12199] - Make TestAtomicOperation and TestEncodedSeekers faster
    * [HBASE-12200] - When an RPC server handler thread dies, throw exception
    * [HBASE-12206] - NPE in RSRpcServices
    * [HBASE-12209] - NPE in HRegionServer#getLastSequenceId
    * [HBASE-12218] - Make HBaseCommonTestingUtil#deleteDir try harder

** Improvement
    * [HBASE-10153] - improve VerifyReplication to compute BADROWS more accurately
    * [HBASE-10411] - [Book] Add a kerberos 'request is a replay (34)' issue at troubleshooting section
    * [HBASE-11796] - Add client support for atomic checkAndMutate
    * [HBASE-11879] - Change TableInputFormatBase to take interface arguments
    * [HBASE-11907] - Use the joni byte[] regex engine in place of j.u.regex in RegexStringComparator
    * [HBASE-11948] - graceful_stop.sh should use hbase-daemon.sh when executed on the decomissioned node
    * [HBASE-12010] - Use TableName.META_TABLE_NAME instead of indirectly from HTableDescriptor
    * [HBASE-12011] - Add namespace column during display of user tables
    * [HBASE-12013] - Make region_mover.rb support multiple regionservers per host
    * [HBASE-12021] - Hbase shell does not respect the HBASE_OPTS set by the user in console
    * [HBASE-12032] - Script to stop regionservers via RPC
    * [HBASE-12049] - Help for alter command is a bit confusing
    * [HBASE-12090] - Bytes: more Unsafe, more Faster
    * [HBASE-12118] - Explain how to grant permission to a namespace in grant command usage
    * [HBASE-12176] - WALCellCodec Encoders support for non-KeyValue Cells
    * [HBASE-12212] - HBaseTestingUtility#waitUntilAllRegionsAssigned should wait for RegionStates
    * [HBASE-12220] - Add hedgedReads and hedgedReadWins metrics

** New Feature
    * [HBASE-11990] - Make setting the start and stop row for a specific prefix easier
    * [HBASE-11995] - Use Connection and ConnectionFactory where possible
    * [HBASE-12127] - Move the core Connection creation functionality into ConnectionFactory
    * [HBASE-12133] - Add FastLongHistogram for metric computation
    * [HBASE-12143] - Minor fix for Table code

** Task
    * [HBASE-9004] - Fix Documentation around Minor compaction and ttl
    * [HBASE-11692] - Document how and why to do a manual region split
    * [HBASE-11730] - Document release managers for non-deprecated branches
    * [HBASE-11761] - Add a FAQ item for updating a maven-managed application from 0.94 -> 0.96+
    * [HBASE-11960] - Provide a sample to show how to use Thrift client authentication
    * [HBASE-11978] - Backport 'HBASE-7767 Get rid of ZKTable, and table enable/disable state in ZK' to 1.0
    * [HBASE-11981] - Document how to find the units of measure for a given HBase metric

** Test
    * [HBASE-11798] - TestBucketWriterThread may hang due to WriterThread stopping prematurely
    * [HBASE-11838] - Enable PREFIX_TREE in integration tests
    * [HBASE-12008] - Remove IntegrationTestImportTsv#testRunFromOutputCommitter
    * [HBASE-12055] - TestBucketWriterThread hangs flakily based on timing


Release Notes - HBase - Version 0.99.0 9/22/2014

** Sub-task
    * [HBASE-2251] - PE defaults to 1k rows - uncommon use case, and easy to hit benchmarks
    * [HBASE-5175] - Add DoubleColumnInterpreter
    * [HBASE-6873] - Clean up Coprocessor loading failure handling
    * [HBASE-8541] - implement flush-into-stripes in stripe compactions
    * [HBASE-9149] - javadoc cleanup of to reflect .META. rename to hbase:meta
    * [HBASE-9261] - Add cp hooks after {start|close}RegionOperation
    * [HBASE-9489] - Add cp hooks in online merge before and after setting PONR
    * [HBASE-9846] - Integration test and LoadTestTool support for cell ACLs
    * [HBASE-9858] - Integration test and LoadTestTool support for cell Visibility
    * [HBASE-9889] - Make sure we clean up scannerReadPoints upon any exceptions
    * [HBASE-9941] - The context ClassLoader isn't set while calling into a coprocessor
    * [HBASE-9966] - Create IntegrationTest for Online Bloom Filter Change
    * [HBASE-9977] - Define C interface of HBase Client Asynchronous APIs
    * [HBASE-10043] - Fix Potential Resouce Leak in MultiTableInputFormatBase
    * [HBASE-10094] - Add batching to HLogPerformanceEvaluation
    * [HBASE-10110] - Fix Potential Resource Leak in StoreFlusher
    * [HBASE-10124] - Make Sub Classes Static When Possible
    * [HBASE-10143] - Clean up dead local stores in FSUtils
    * [HBASE-10150] - Write attachment Id of tested patch into JIRA comment
    * [HBASE-10156] - FSHLog Refactor (WAS -> Fix up the HBASE-8755 slowdown when low contention)
    * [HBASE-10158] - Add sync rate histogram to HLogPE
    * [HBASE-10169] - Batch coprocessor
    * [HBASE-10297] - LoadAndVerify Integration Test for cell visibility
    * [HBASE-10347] - HRegionInfo changes for adding replicaId and MetaEditor/MetaReader changes for region replicas
    * [HBASE-10348] - HTableDescriptor changes for region replicas
    * [HBASE-10350] - Master/AM/RegionStates changes to create and assign region replicas
    * [HBASE-10351] - LoadBalancer changes for supporting region replicas
    * [HBASE-10352] - Region and RegionServer changes for opening region replicas, and refreshing store files
    * [HBASE-10354] - Add an API for defining consistency per request
    * [HBASE-10355] - Failover RPC's from client using region replicas
    * [HBASE-10356] - Failover RPC's for multi-get
    * [HBASE-10357] - Failover RPC's for scans
    * [HBASE-10359] - Master/RS WebUI changes for region replicas
    * [HBASE-10361] - Enable/AlterTable support for region replicas
    * [HBASE-10362] - HBCK changes for supporting region replicas
    * [HBASE-10391] - Deprecate KeyValue#getBuffer
    * [HBASE-10420] - Replace KV.getBuffer with KV.get{Row|Family|Qualifier|Value|Tags}Array
    * [HBASE-10513] - Provide user documentation for region replicas
    * [HBASE-10517] - NPE in MetaCache.clearCache()
    * [HBASE-10519] - Add handling for swallowed InterruptedException thrown by Thread.sleep in rest related files
    * [HBASE-10520] - Add handling for swallowed InterruptedException thrown by Thread.sleep in MiniZooKeeperCluster
    * [HBASE-10521] - Add handling for swallowed InterruptedException thrown by Thread.sleep in RpcServer
    * [HBASE-10522] - Correct wrong handling and add proper handling for swallowed InterruptedException thrown by Thread.sleep in client
    * [HBASE-10523] - Correct wrong handling and add proper handling for swallowed InterruptedException thrown by Thread.sleep in util
    * [HBASE-10524] - Correct wrong handling and add proper handling for swallowed InterruptedException thrown by Thread.sleep in regionserver
    * [HBASE-10526] - Using Cell instead of KeyValue in HFileOutputFormat
    * [HBASE-10529] - Make Cell extend Cloneable
    * [HBASE-10530] - Add util methods in CellUtil
    * [HBASE-10531] - Revisit how the key byte[] is passed to HFileScanner.seekTo and reseekTo
    * [HBASE-10532] - Make KeyValueComparator in KeyValue to accept Cell instead of KeyValue.
    * [HBASE-10550] - Register HBase tokens with ServiceLoader
    * [HBASE-10561] - Forward port: HBASE-10212 New rpc metric: number of active handler
    * [HBASE-10572] - Create an IntegrationTest for region replicas
    * [HBASE-10573] - Use Netty 4
    * [HBASE-10616] - Integration test for multi-get calls
    * [HBASE-10620] - LoadBalancer.needsBalance() should check for co-located region replicas as well
    * [HBASE-10630] - NullPointerException in ConnectionManager$HConnectionImplementation.locateRegionInMeta() due to missing region info
    * [HBASE-10633] - StoreFileRefresherChore throws ConcurrentModificationException sometimes
    * [HBASE-10634] - Multiget doesn't fully work
    * [HBASE-10648] - Pluggable Memstore
    * [HBASE-10650] - Fix incorrect handling of IE that restores current thread's interrupt status within while/for loops in RegionServer
    * [HBASE-10651] - Fix incorrect handling of IE that restores current thread's interrupt status within while/for loops in Replication
    * [HBASE-10652] - Fix incorrect handling of IE that restores current thread's interrupt status within while/for loops in rpc
    * [HBASE-10661] - TestStochasticLoadBalancer.testRegionReplicationOnMidClusterWithRacks() is flaky
    * [HBASE-10672] - Table snapshot should handle tables whose REGION_REPLICATION is greater than one
    * [HBASE-10680] - Check if the block keys, index keys can be used as Cells instead of byte[]
    * [HBASE-10688] - Add a draining_node script to manage nodes in draining mode
    * [HBASE-10691] - test-patch.sh should continue even if compilation against hadoop 1.0 / 1.1 fails
    * [HBASE-10697] - Convert TestSimpleTotalOrderPartitioner to junit4 test
    * [HBASE-10701] - Cache invalidation improvements from client side
    * [HBASE-10704] - BaseLoadBalancer#roundRobinAssignment() may add same region to assignment plan multiple times
    * [HBASE-10717] - TestFSHDFSUtils#testIsSameHdfs fails with IllegalArgumentException running against hadoop 2.3
    * [HBASE-10723] - Convert TestExplicitColumnTracker to junit4 test
    * [HBASE-10729] - Enable table doesn't balance out replicas evenly if the replicas were unassigned earlier
    * [HBASE-10734] - Fix RegionStates.getRegionAssignments to not add duplicate regions
    * [HBASE-10741] - Deprecate HTablePool and HTableFactory
    * [HBASE-10743] - Replica map update is problematic in RegionStates
    * [HBASE-10750] - Pluggable MemStoreLAB
    * [HBASE-10778] - Unique keys accounting in MultiThreadedReader is incorrect
    * [HBASE-10779] - Doc hadoop1 deprecated in 0.98 and NOT supported in hbase 1.0
    * [HBASE-10781] - Remove hadoop-one-compat module and all references to hadoop1
    * [HBASE-10791] - Add integration test to demonstrate performance improvement
    * [HBASE-10794] - multi-get should handle replica location missing from cache
    * [HBASE-10796] - Set default log level as INFO
    * [HBASE-10801] - Ensure DBE interfaces can work with Cell
    * [HBASE-10810] - LoadTestTool should share the connection and connection pool
    * [HBASE-10815] - Master regionserver should be rolling-upgradable
    * [HBASE-10817] - Add some tests on a real cluster for replica: multi master, replication
    * [HBASE-10818] - Add integration test for bulkload with replicas
    * [HBASE-10822] - Thread local addendum to HBASE-10656 Counter
    * [HBASE-10841] - Scan,Get,Put,Delete,etc setters should consistently return this
    * [HBASE-10855] - Enable hfilev3 by default
    * [HBASE-10858] - TestRegionRebalancing is failing
    * [HBASE-10859] - Use HFileLink in opening region files from secondaries
    * [HBASE-10888] - Enable distributed log replay as default
    * [HBASE-10915] - Decouple region closing (HM and HRS) from ZK
    * [HBASE-10918] - [VisibilityController] System table backed ScanLabelGenerator
    * [HBASE-10929] - Change ScanQueryMatcher to use Cells instead of KeyValue.
    * [HBASE-10930] - Change Filters and GetClosestRowBeforeTracker to work with Cells
    * [HBASE-10957] - HBASE-10070: HMaster can abort with NPE in #rebuildUserRegions
    * [HBASE-10962] - Decouple region opening (HM and HRS) from ZK
    * [HBASE-10963] - Refactor cell ACL tests
    * [HBASE-10972] - OOBE in prefix key encoding
    * [HBASE-10985] - Decouple Split Transaction from Zookeeper
    * [HBASE-10993] - Deprioritize long-running scanners
    * [HBASE-11025] - Infrastructure for pluggable consensus service
    * [HBASE-11027] - Remove kv.isDeleteXX() and related methods and use CellUtil apis.
    * [HBASE-11053] - Change DeleteTracker APIs to work with Cell
    * [HBASE-11054] - Create new hook in StoreScanner to help user creating his own delete tracker
    * [HBASE-11059] - ZK-less region assignment
    * [HBASE-11069] - Decouple region merging from ZooKeeper
    * [HBASE-11072] - Abstract WAL splitting from ZK
    * [HBASE-11077] - [AccessController] Restore compatible early-out access denial
    * [HBASE-11088] - Support Visibility Expression Deletes in Shell
    * [HBASE-11092] - Server interface should have method getConsensusProvider()
    * [HBASE-11094] - Distributed log replay is incompatible for rolling restarts
    * [HBASE-11098] - Improve documentation around our blockcache options
    * [HBASE-11101] - Documentation review
    * [HBASE-11102] - Document JDK versions supported by each release
    * [HBASE-11108] - Split ZKTable into interface and implementation
    * [HBASE-11109] - flush region sequence id may not be larger than all edits flushed
    * [HBASE-11135] - Change region sequenceid generation so happens earlier in the append cycle rather than just before added to file
    * [HBASE-11140] - LocalHBaseCluster should create ConsensusProvider per each server
    * [HBASE-11161] - Provide example of POJO encoding with protobuf
    * [HBASE-11171] - More doc improvements on block cache options
    * [HBASE-11214] - Fixes for scans on a replicated table
    * [HBASE-11229] - Change block cache percentage metrics to be doubles rather than ints
    * [HBASE-11280] - Document distributed log replay and distributed log splitting
    * [HBASE-11307] - Deprecate SlabCache
    * [HBASE-11318] - Classes in security subpackages missing @InterfaceAudience annotations.
    * [HBASE-11332] - Fix for metas location cache from HBASE-10785
    * [HBASE-11367] - Pluggable replication endpoint
    * [HBASE-11372] - Remove SlabCache
    * [HBASE-11384] - [Visibility Controller]Check for users covering authorizations for every mutation
    * [HBASE-11395] - Add logging for HBase table operations
    * [HBASE-11471] - Move TableStateManager and ZkTableStateManager and Server to hbase-server
    * [HBASE-11483] - Check the rest of the book for new XML validity errors and fix
    * [HBASE-11508] - Document changes to IPC config parameters from HBASE-11492
    * [HBASE-11511] - Write flush events to WAL
    * [HBASE-11512] - Write region open/close events to WAL
    * [HBASE-11520] - Simplify offheap cache config by removing the confusing "hbase.bucketcache.percentage.in.combinedcache"
    * [HBASE-11559] - Add dumping of DATA block usage to the BlockCache JSON report.
    * [HBASE-11572] - Add support for doing get/scans against a particular replica_id
    * [HBASE-11573] - Report age on eviction
    * [HBASE-11610] - Enhance remote meta updates
    * [HBASE-11651] - Add conf which disables MetaMigrationConvertingToPB check (for experts only)
    * [HBASE-11722] - Document new shortcut commands introduced by HBASE-11649
    * [HBASE-11734] - Document changed behavior of hbase.hstore.time.to.purge.deletes
    * [HBASE-11736] - Document SKIP_FLUSH snapshot option
    * [HBASE-11737] - Document callQueue improvements from HBASE-11355 and HBASE-11724
    * [HBASE-11739] - Document blockCache contents report in the UI
    * [HBASE-11740] - RegionStates.getRegionAssignments() gets stuck on clone
    * [HBASE-11752] - Document blockcache prefetch option
    * [HBASE-11753] - Document HBASE_SHELL_OPTS environment variable
    * [HBASE-11781] - Document new TableMapReduceUtil scanning options
    * [HBASE-11784] - Document global configuration for maxVersion
    * [HBASE-11822] - Convert EnvironmentEdge#getCurrentTimeMillis to getCurrentTime
    * [HBASE-11919] - Remove the deprecated pre/postGet CP hook
    * [HBASE-11923] - Potential race condition in RecoverableZookeeper.checkZk()
    * [HBASE-11934] - Support KeyValueCodec to encode non KeyValue cells.
    * [HBASE-11941] - Rebuild site because of major structural changes to HTML
    * [HBASE-11963] - Synchronize peer cluster replication connection attempts

** Brainstorming
    * [HBASE-9507] - Promote methods of WALActionsListener to WALObserver
    * [HBASE-11209] - Increase the default value for hbase.hregion.memstore.block.multipler from 2 to 4

** Bug
    * [HBASE-3787] - Increment is non-idempotent but client retries RPC
    * [HBASE-4931] - CopyTable instructions could be improved.
    * [HBASE-5356] - region_mover.rb can hang if table region it belongs to is deleted.
    * [HBASE-6506] - Setting CACHE_BLOCKS to false in an hbase shell scan doesn't work
    * [HBASE-6642] - enable_all,disable_all,drop_all can call "list" command with regex directly.
    * [HBASE-6701] - Revisit thrust of paragraph on splitting
    * [HBASE-7226] - HRegion.checkAndMutate uses incorrect comparison result for <, <=, > and >=
    * [HBASE-7963] - HBase VerifyReplication not working when security enabled
    * [HBASE-8112] - Deprecate HTable#batch(final List<? extends Row>)
    * [HBASE-8269] - Fix data locallity documentation.
    * [HBASE-8304] - Bulkload fails to remove files if fs.default.name / fs.defaultFS is configured without default port
    * [HBASE-8529] - checkOpen is missing from multi, mutate, get and multiGet etc.
    * [HBASE-8701] - distributedLogReplay need to apply wal edits in the receiving order of those edits
    * [HBASE-8713] - [hadoop1] Log spam each time the WAL is rolled
    * [HBASE-8803] - region_mover.rb should move multiple regions at a time
    * [HBASE-8817] - Enhance The Apache HBase Reference Guide
    * [HBASE-9151] - HBCK cannot fix when meta server znode deleted, this can happen if all region servers stopped and there are no logs to split.
    * [HBASE-9292] - Syncer fails but we won't go down
    * [HBASE-9294] - NPE in /rs-status during RS shutdown
    * [HBASE-9346] - HBCK should provide an option to check if regions boundaries are the same in META and in stores.
    * [HBASE-9445] - Snapshots should create column family dirs for empty regions
    * [HBASE-9473] - Change UI to list 'system tables' rather than 'catalog tables'.
    * [HBASE-9485] - TableOutputCommitter should implement recovery if we don't want jobs to start from 0 on RM restart
    * [HBASE-9708] - Improve Snapshot Name Error Message
    * [HBASE-9721] - RegionServer should not accept regionOpen RPC intended for another(previous) server
    * [HBASE-9745] - Append HBASE_CLASSPATH to end of Java classpath and use another env var for prefix
    * [HBASE-9746] - RegionServer can't start when replication tries to replicate to an unknown host
    * [HBASE-9754] - Eliminate threadlocal from MVCC code
    * [HBASE-9778] - Add hint to ExplicitColumnTracker to avoid seeking
    * [HBASE-9990] - HTable uses the conf for each "newCaller"
    * [HBASE-10018] - Remove region location prefetching
    * [HBASE-10061] - TableMapReduceUtil.findOrCreateJar calls updateMap(null, ) resulting in thrown NPE
    * [HBASE-10069] - Potential duplicate calls to log#appendNoSync() in HRegion#doMiniBatchMutation()
    * [HBASE-10073] - Revert HBASE-9718 (Add a test scope dependency on org.slf4j:slf4j-api to hbase-client)
    * [HBASE-10079] - Race in TableName cache
    * [HBASE-10080] - Unnecessary call to locateRegion when creating an HTable instance
    * [HBASE-10084] - [WINDOWS] bin\hbase.cmd should allow whitespaces in java.library.path and classpath
    * [HBASE-10087] - Store should be locked during a memstore snapshot
    * [HBASE-10090] - Master could hang in assigning meta
    * [HBASE-10097] - Remove a region name string creation in HRegion#nextInternal
    * [HBASE-10098] - [WINDOWS] pass in native library directory from hadoop for unit tests
    * [HBASE-10099] - javadoc warning introduced by LabelExpander 188: warning - @return tag has no arguments
    * [HBASE-10101] - testOfflineRegionReAssginedAfterMasterRestart times out sometimes.
    * [HBASE-10103] - TestNodeHealthCheckChore#testRSHealthChore: Stoppable must have been stopped
    * [HBASE-10107] - [JDK7] TestHBaseSaslRpcClient.testHBaseSaslRpcClientCreation failing on Jenkins
    * [HBASE-10108] - NullPointerException thrown while use Canary with '-regionserver' option
    * [HBASE-10112] - Hbase rest query params for maxVersions and maxValues are not parsed
    * [HBASE-10114] - _scan_internal() in table.rb should accept argument that specifies reverse scan
    * [HBASE-10117] - Avoid synchronization in HRegionScannerImpl.isFilterDone
    * [HBASE-10118] - Major compact keeps deletes with future timestamps
    * [HBASE-10120] - start-hbase.sh doesn't respect --config in non-distributed mode
    * [HBASE-10123] - Change default ports; move them out of linux ephemeral port range
    * [HBASE-10132] - sun.security.pkcs11.wrapper.PKCS11Exception: CKR_ARGUMENTS_BAD
    * [HBASE-10135] - Remove ? extends from HLogSplitter#getOutputCounts
    * [HBASE-10137] - GeneralBulkAssigner with retain assignment plan can be used in EnableTableHandler to bulk assign the regions
    * [HBASE-10138] - incorrect or confusing test value is used in block caches
    * [HBASE-10142] - TestLogRolling#testLogRollOnDatanodeDeath test failure
    * [HBASE-10146] - Bump HTrace version to 2.04
    * [HBASE-10148] - [VisibilityController] Tolerate regions in recovery
    * [HBASE-10149] - TestZKPermissionsWatcher.testPermissionsWatcher test failure
    * [HBASE-10155] - HRegion isRecovering state is wrongly coming in postOpen hook
    * [HBASE-10161] - [AccessController] Tolerate regions in recovery
    * [HBASE-10163] - Example Thrift DemoClient is flaky
    * [HBASE-10176] - Canary#sniff() should close the HTable instance
    * [HBASE-10178] - Potential null object dereference in TablePermission#equals()
    * [HBASE-10179] - HRegionServer underreports readRequestCounts by 1 under certain conditions
    * [HBASE-10182] - Potential null object deference in AssignmentManager#handleRegion()
    * [HBASE-10186] - region_mover.rb broken because ServerName constructor is changed to private
    * [HBASE-10187] - AccessController#preOpen - Include 'labels' table also into special tables list.
    * [HBASE-10193] - Cleanup HRegion if one of the store fails to open at region initialization
    * [HBASE-10194] - [Usability]: Instructions in CompactionTool no longer accurate because of namespaces
    * [HBASE-10196] - Enhance HBCK to understand the case after online region merge
    * [HBASE-10205] - ConcurrentModificationException in BucketAllocator
    * [HBASE-10207] - ZKVisibilityLabelWatcher : Populate the labels cache on startup
    * [HBASE-10210] - during master startup, RS can be you-are-dead-ed by master in error
    * [HBASE-10215] - TableNotFoundException should be thrown after removing stale znode in ETH
    * [HBASE-10219] - HTTPS support for HBase in RegionServerListTmpl.jamon
    * [HBASE-10220] - Put all test service principals into the superusers list
    * [HBASE-10221] - Region from coprocessor invocations can be null on failure
    * [HBASE-10223] - [VisibilityController] cellVisibility presence check on Delete mutation is wrong
    * [HBASE-10225] - Bug in calls to RegionObsever.postScannerFilterRow
    * [HBASE-10226] - [AccessController] Namespace grants not always checked
    * [HBASE-10231] - Potential NPE in HBaseFsck#checkMetaRegion()
    * [HBASE-10232] - Remove native profile from hbase-shell
    * [HBASE-10233] - VisibilityController is too chatty at DEBUG level
    * [HBASE-10249] - TestReplicationSyncUpTool fails because failover takes too long
    * [HBASE-10251] - Restore API Compat for PerformanceEvaluation.generateValue()
    * [HBASE-10260] - Canary Doesn't pick up Configuration properly.
    * [HBASE-10264] - [MapReduce]: CompactionTool in mapred mode is missing classes in its classpath
    * [HBASE-10267] - TestNamespaceCommands occasionally fails
    * [HBASE-10268] - TestSplitLogWorker occasionally fails
    * [HBASE-10271] - [regression] Cannot use the wildcard address since HBASE-9593
    * [HBASE-10272] - Cluster becomes nonoperational if the node hosting the active Master AND ROOT/META table goes offline
    * [HBASE-10274] - MiniZookeeperCluster should close ZKDatabase when shutdown ZooKeeperServers
    * [HBASE-10284] - Build broken with svn 1.8
    * [HBASE-10292] - TestRegionServerCoprocessorExceptionWithAbort fails occasionally
    * [HBASE-10298] - TestIOFencing occasionally fails
    * [HBASE-10302] - Fix rat check issues in hbase-native-client.
    * [HBASE-10304] - Running an hbase job jar: IllegalAccessError: class com.google.protobuf.ZeroCopyLiteralByteString cannot access its superclass com.google.protobuf.LiteralByteString
    * [HBASE-10307] - IntegrationTestIngestWithEncryption assumes localhost cluster
    * [HBASE-10310] - ZNodeCleaner session expired for /hbase/master
    * [HBASE-10312] - Flooding the cluster with administrative actions leads to collapse
    * [HBASE-10313] - Duplicate servlet-api jars in hbase 0.96.0
    * [HBASE-10315] - Canary shouldn't exit with 3 if there is no master running.
    * [HBASE-10316] - Canary#RegionServerMonitor#monitorRegionServers() should close the scanner returned by table.getScanner()
    * [HBASE-10317] - getClientPort method of MiniZooKeeperCluster does not always return the correct value
    * [HBASE-10318] - generate-hadoopX-poms.sh expects the version to have one extra '-'
    * [HBASE-10320] - Avoid ArrayList.iterator() ExplicitColumnTracker
    * [HBASE-10321] - CellCodec has broken the 96 client to 98 server compatibility
    * [HBASE-10322] - Strip tags from KV while sending back to client on reads
    * [HBASE-10326] - Super user should be able scan all the cells irrespective of the visibility labels
    * [HBASE-10327] - Remove remove(K, V) from type PoolMap<K,V>
    * [HBASE-10329] - Fail the writes rather than proceeding silently to prevent data loss when AsyncSyncer encounters null writer and its writes aren't synced by other Asyncer
    * [HBASE-10330] - TableInputFormat/TableRecordReaderImpl leaks HTable
    * [HBASE-10332] - Missing .regioninfo file during daughter open processing
    * [HBASE-10333] - Assignments are not retained on a cluster start
    * [HBASE-10334] - RegionServer links in table.jsp is broken
    * [HBASE-10335] - AuthFailedException in zookeeper may block replication forever
    * [HBASE-10336] - Remove deprecated usage of Hadoop HttpServer in InfoServer
    * [HBASE-10337] - HTable.get() uninteruptible
    * [HBASE-10338] - Region server fails to start with AccessController coprocessor if installed into RegionServerCoprocessorHost
    * [HBASE-10339] - Mutation::getFamilyMap method was lost in 98
    * [HBASE-10349] - Table became unusable when master balanced its region after table was dropped
    * [HBASE-10365] - HBaseFsck should clean up connection properly when repair is completed
    * [HBASE-10370] - Compaction in out-of-date Store causes region split failure
    * [HBASE-10371] - Compaction creates empty hfile, then selects this file for compaction and creates empty hfile and over again
    * [HBASE-10375] - hbase-default.xml hbase.status.multicast.address.port does not match code
    * [HBASE-10384] - Failed to increment serveral columns in one Increment
    * [HBASE-10392] - Correct references to hbase.regionserver.global.memstore.upperLimit
    * [HBASE-10397] - Fix findbugs introduced from HBASE-9426
    * [HBASE-10400] - [hbck] Continue if region dir missing on region merge attempt
    * [HBASE-10401] - [hbck] perform overlap group merges in parallel
    * [HBASE-10407] - String Format Exception
    * [HBASE-10412] - Distributed log replay : Cell tags getting missed
    * [HBASE-10413] - Tablesplit.getLength returns 0
    * [HBASE-10417] - index is not incremented in PutSortReducer#reduce()
    * [HBASE-10422] - ZeroCopyLiteralByteString.zeroCopyGetBytes has an unusable prototype and conflicts with AsyncHBase
    * [HBASE-10426] - user_permission in security.rb calls non-existent UserPermission#getTable method
    * [HBASE-10428] - Test jars should have scope test
    * [HBASE-10429] - Make Visibility Controller to throw a better msg if it is of type RegionServerCoprocessor
    * [HBASE-10431] - Rename com.google.protobuf.ZeroCopyLiteralByteString
    * [HBASE-10432] - Rpc retries non-recoverable error
    * [HBASE-10433] - SecureProtobufWALReader does not handle unencrypted WALs if configured to encrypt
    * [HBASE-10434] - Store Tag compression information for a WAL in its header
    * [HBASE-10435] - Lower the log level of Canary region server match
    * [HBASE-10436] - restore regionserver lists removed from hbase 0.96+ jmx
    * [HBASE-10438] - NPE from LRUDictionary when size reaches the max init value
    * [HBASE-10441] - [docs] nit default max versions is now 1 instead of 3 after HBASE-8450
    * [HBASE-10442] - prepareDelete() isn't called before doPreMutationHook for a row deletion case
    * [HBASE-10443] - IndexOutOfBoundExceptions when processing compressed tags in HFile
    * [HBASE-10446] - Backup master gives Error 500 for debug dump
    * [HBASE-10447] - Memstore flusher scans storefiles also when the scanner heap gets reset
    * [HBASE-10448] - ZKUtil create and watch methods don't set watch in some cases
    * [HBASE-10449] - Wrong execution pool configuration in HConnectionManager
    * [HBASE-10451] - Enable back Tag compression on HFiles
    * [HBASE-10452] - Fix potential bugs in exception handlers
    * [HBASE-10454] - Tags presence file info can be wrong in HFiles when PrefixTree encoding is used
    * [HBASE-10455] - cleanup InterruptedException management
    * [HBASE-10456] - Balancer should not run if it's just turned off.
    * [HBASE-10458] - Typo in book chapter 9 architecture.html
    * [HBASE-10459] - Broken link F.1. HBase Videos
    * [HBASE-10460] - Return value of Scan#setSmall() should be void
    * [HBASE-10461] - table.close() in TableEventHandler#reOpenAllRegions() should be enclosed in finally block
    * [HBASE-10469] - Hbase book client.html has a broken link
    * [HBASE-10470] - Import generates huge log file while importing large amounts of data
    * [HBASE-10472] - Manage the interruption in ZKUtil#getData
    * [HBASE-10476] - HBase Master log grows very fast after stopped hadoop (due to connection exception)
    * [HBASE-10477] - Regression from HBASE-10337
    * [HBASE-10478] - Hbase book presentations page has broken link
    * [HBASE-10481] - API Compatibility JDiff script does not properly handle arguments in reverse order
    * [HBASE-10482] - ReplicationSyncUp doesn't clean up its ZK, needed for tests
    * [HBASE-10485] - PrefixFilter#filterKeyValue() should perform filtering on row key
    * [HBASE-10486] - ProtobufUtil Append & Increment deserialization lost cell level timestamp
    * [HBASE-10488] - 'mvn site' is broken due to org.apache.jasper.JspC not found
    * [HBASE-10490] - Simplify RpcClient code
    * [HBASE-10493] - InclusiveStopFilter#filterKeyValue() should perform filtering on row key
    * [HBASE-10495] - upgrade script is printing usage two times with help option.
    * [HBASE-10500] - Some tools OOM when BucketCache is enabled
    * [HBASE-10501] - Improve IncreasingToUpperBoundRegionSplitPolicy to avoid too many regions
    * [HBASE-10506] - Fail-fast if client connection is lost before the real call be executed in RPC layer
    * [HBASE-10510] - HTable is not closed in LoadTestTool#loadTable()
    * [HBASE-10514] - Forward port HBASE-10466, possible data loss when failed flushes
    * [HBASE-10516] - Refactor code where Threads.sleep is called within a while/for loop
    * [HBASE-10525] - Allow the client to use a different thread for writing to ease interrupt
    * [HBASE-10533] - commands.rb is giving wrong error messages on exceptions
    * [HBASE-10534] - Rowkey in TsvImporterTextMapper initializing with wrong length
    * [HBASE-10537] - Let the ExportSnapshot mapper fail and retry on error
    * [HBASE-10539] - HRegion.addAndGetGlobalMemstoreSize returns previous size
    * [HBASE-10545] - RS Hangs waiting on region to close on shutdown; has to timeout before can go down
    * [HBASE-10546] - Two scanner objects are open for each hbase map task but only one scanner object is closed
    * [HBASE-10547] - TestFixedLengthWrapper#testReadWrite occasionally fails with the IBM JDK
    * [HBASE-10548] - Correct commons-math dependency version
    * [HBASE-10549] - When there is a hole, LoadIncrementalHFiles will hang in an infinite loop.
    * [HBASE-10552] - HFilePerformanceEvaluation.GaussianRandomReadBenchmark fails sometimes.
    * [HBASE-10556] - Possible data loss due to non-handled DroppedSnapshotException for user-triggered flush from client/shell
    * [HBASE-10563] - Set name for FlushHandler thread
    * [HBASE-10564] - HRegionServer.nextLong should be removed since it's not used anywhere, or should be used somewhere it meant to
    * [HBASE-10565] - FavoredNodesPlan accidentally uses an internal Netty type
    * [HBASE-10566] - cleanup rpcTimeout in the client
    * [HBASE-10567] - Add overwrite manifest option to ExportSnapshot
    * [HBASE-10575] - ReplicationSource thread can't be terminated if it runs into the loop to contact peer's zk ensemble and fails continuously
    * [HBASE-10579] - [Documentation]: ExportSnapshot tool package incorrectly documented
    * [HBASE-10580] - IntegrationTestingUtility#restoreCluster leak resource when running in a mini cluster mode
    * [HBASE-10581] - ACL znode are left without PBed during upgrading hbase0.94* to hbase0.96+
    * [HBASE-10582] - 0.94->0.96 Upgrade: ACL can't be repopulated when ACL table contains row for table '-ROOT' or '.META.'
    * [HBASE-10585] - Avoid early creation of Node objects in LRUDictionary.BidirectionalLRUMap
    * [HBASE-10586] - hadoop2-compat IPC metric registred twice
    * [HBASE-10587] - Master metrics clusterRequests is wrong
    * [HBASE-10593] - FileInputStream in JenkinsHash#main() is never closed
    * [HBASE-10594] - Speed up TestRestoreSnapshotFromClient
    * [HBASE-10598] - Written data can not be read out because MemStore#timeRangeTracker might be updated concurrently
    * [HBASE-10600] - HTable#batch() should perform validation on empty Put
    * [HBASE-10604] - Fix parseArgs javadoc
    * [HBASE-10606] - Bad timeout in RpcRetryingCaller#callWithRetries w/o parameters
    * [HBASE-10608] - Acquire the FS Delegation Token for Secure ExportSnapshot
    * [HBASE-10611] - Description for hbase:acl table is wrong on master-status#catalogTables
    * [HBASE-10614] - Master could not be stopped
    * [HBASE-10618] - User should not be allowed to disable/drop visibility labels table
    * [HBASE-10621] - Unable to grant user permission to namespace
    * [HBASE-10622] - Improve log and Exceptions in Export Snapshot
    * [HBASE-10624] - Fix 2 new findbugs warnings introduced by HBASE-10598
    * [HBASE-10627] - A logic mistake in HRegionServer isHealthy
    * [HBASE-10631] - Avoid extra seek on FileLink open
    * [HBASE-10632] - Region lost in limbo after ArrayIndexOutOfBoundsException during assignment
    * [HBASE-10637] - rpcClient: Setup the iostreams when writing
    * [HBASE-10639] - Unload script displays wrong counts (off by one) when unloading regions
    * [HBASE-10644] - TestSecureExportSnapshot#testExportFileSystemState fails on hadoop-1
    * [HBASE-10656] -  high-scale-lib's Counter depends on Oracle (Sun) JRE, and also has some bug
    * [HBASE-10660] - MR over snapshots can OOM when alternative blockcache is enabled
    * [HBASE-10662] - RegionScanner is never closed if the region has been moved-out or re-opened when performing scan request
    * [HBASE-10665] - TestCompaction and TestCompactionWithCoprocessor run too long
    * [HBASE-10666] - TestMasterCoprocessorExceptionWithAbort hangs at shutdown
    * [HBASE-10668] - TestExportSnapshot runs too long
    * [HBASE-10669] - [hbck tool] Usage is wrong for hbck tool for -sidelineCorruptHfiles option
    * [HBASE-10675] - IntegrationTestIngestWithACL should allow User to be passed as Parameter
    * [HBASE-10677] - boundaries check in hbck throwing IllegalArgumentException
    * [HBASE-10679] - Both clients get wrong scan results if the first scanner expires and the second scanner is created with the same scannerId on the same region
    * [HBASE-10682] - region_mover.rb throws "can't convert nil into String" for regions moved
    * [HBASE-10685] - [WINDOWS] TestKeyStoreKeyProvider fails on windows
    * [HBASE-10686] - [WINDOWS] TestStripeStoreFileManager fails on windows
    * [HBASE-10687] - Fix description about HBaseLocalFileSpanReceiver in reference manual
    * [HBASE-10692] - The Multi TableMap job don't support the security HBase cluster
    * [HBASE-10694] - TableSkewCostFunction#cost() casts integral division result to double
    * [HBASE-10705] - CompactionRequest#toString() may throw NullPointerException
    * [HBASE-10706] - Disable writeToWal in tests where possible
    * [HBASE-10714] - SyncFuture hangs when sequence is 0
    * [HBASE-10715] - TimeRange has a poorly formatted error message
    * [HBASE-10716] - [Configuration]: hbase.regionserver.region.split.policy should be part of hbase-default.xml
    * [HBASE-10718] - TestHLogSplit fails when it sets a KV size to be negative
    * [HBASE-10720] - rpcClient: Wrong log level when closing the connection
    * [HBASE-10726] - Fix java.lang.ArrayIndexOutOfBoundsException in StochasticLoadBalancer$LocalityBasedCandidateGenerator
    * [HBASE-10731] - Fix environment variables typos in scripts
    * [HBASE-10735] - [WINDOWS] Set -XX:MaxPermSize for unit tests
    * [HBASE-10736] - Fix Javadoc warnings introduced in HBASE-10169
    * [HBASE-10737] - HConnectionImplementation should stop RpcClient on close
    * [HBASE-10738] - AssignmentManager should shut down executors on stop
    * [HBASE-10739] - RS web UI NPE if master shuts down sooner
    * [HBASE-10745] - Access ShutdownHook#fsShutdownHooks should be synchronized
    * [HBASE-10749] - CellComparator.compareStatic() compares type wrongly
    * [HBASE-10751] - TestHRegion testWritesWhileScanning occasional fail since HBASE-10514 went in
    * [HBASE-10755] - MetricsRegionSourceImpl creates metrics that start with a lower case
    * [HBASE-10760] - Wrong methods' names in ClusterLoadState class
    * [HBASE-10762] - clone_snapshot doesn't check for missing namespace
    * [HBASE-10766] - SnapshotCleaner allows to delete referenced files
    * [HBASE-10770] - Don't exit from the Canary daemon mode if no regions are present
    * [HBASE-10792] - RingBufferTruck does not release its payload
    * [HBASE-10793] - AuthFailed as a valid zookeeper state
    * [HBASE-10799] - [WINDOWS] TestImportTSVWithVisibilityLabels.testBulkOutputWithTsvImporterTextMapper  fails on windows
    * [HBASE-10802] - CellComparator.compareStaticIgnoreMvccVersion compares type wrongly
    * [HBASE-10804] - Add a validations step to ExportSnapshot
    * [HBASE-10805] - Speed up KeyValueHeap.next() a bit
    * [HBASE-10806] - Two protos missing in hbase-protocol/pom.xml
    * [HBASE-10809] - HBaseAdmin#deleteTable fails when META region happen to move around same time
    * [HBASE-10814] - RpcClient: some calls can get stuck when connection is closing
    * [HBASE-10825] - Add copy-from option to ExportSnapshot
    * [HBASE-10829] - Flush is skipped after log replay if the last recovered edits file is skipped
    * [HBASE-10830] - Integration test MR jobs attempt to load htrace jars from the wrong location
    * [HBASE-10831] - IntegrationTestIngestWithACL is not setting up LoadTestTool correctly
    * [HBASE-10833] - Region assignment may fail during cluster start up
    * [HBASE-10838] - Insufficient AccessController covering permission check
    * [HBASE-10839] - NullPointerException in construction of RegionServer in Security Cluster
    * [HBASE-10840] - Fix findbug warn induced by HBASE-10569
    * [HBASE-10845] - Memstore snapshot size isn't updated in DefaultMemStore#rollback()
    * [HBASE-10846] - Links between active and backup masters are broken
    * [HBASE-10848] - Filter SingleColumnValueFilter combined with NullComparator does not work
    * [HBASE-10849] - Fix increased javadoc warns
    * [HBASE-10850] - essential column family optimization is broken
    * [HBASE-10851] - Wait for regionservers to join the cluster
    * [HBASE-10853] - NPE in RSRpcServices.get on trunk
    * [HBASE-10854] - [VisibilityController] Apply MAX_VERSIONS from schema or request when scanning
    * [HBASE-10860] - Insufficient AccessController covering permission check
    * [HBASE-10862] - Update config field names in hbase-default.xml description for hbase.hregion.memstore.block.multiplier
    * [HBASE-10863] - Scan doesn't return rows for user who has authorization by visibility label in secure deployment
    * [HBASE-10864] - Spelling nit
    * [HBASE-10890] - ExportSnapshot needs to add acquired token to job
    * [HBASE-10895] - unassign a region fails due to the hosting region server is in FailedServerList
    * [HBASE-10897] - On master start, deadlock if refresh UI
    * [HBASE-10899] - [AccessController] Apply MAX_VERSIONS from schema or request when scanning
    * [HBASE-10903] - HBASE-10740 regression; cannot pass commands for zk to run
    * [HBASE-10917] - Fix hbase book "Tests" page
    * [HBASE-10922] - Log splitting status should always be closed
    * [HBASE-10931] - Enhance logs
    * [HBASE-10941] - default for max version isn't updated in doc after change on 0.96
    * [HBASE-10948] - Fix hbase table file 'x' mode
    * [HBASE-10949] - Reversed scan could hang
    * [HBASE-10954] - Fix TestCloseRegionHandler.testFailedFlushAborts
    * [HBASE-10955] - HBCK leaves the region in masters in-memory RegionStates if region hdfs dir is lost
    * [HBASE-10958] - [dataloss] Bulk loading with seqids can prevent some log entries from being replayed
    * [HBASE-10964] - Delete mutation is not consistent with Put wrt timestamp
    * [HBASE-10966] - RowCounter misinterprets column names that have colons in their qualifier
    * [HBASE-10967] - CatalogTracker.waitForMeta should not wait indefinitely silently
    * [HBASE-10968] - Null check in TableSnapshotInputFormat#TableSnapshotRegionRecordReader#initialize() is redundant
    * [HBASE-10970] - [AccessController] Issues with covering cell permission checks
    * [HBASE-10976] - Start CatalogTracker after cluster ID is available
    * [HBASE-10979] - Fix AnnotationReadingPriorityFunction "scan" handling
    * [HBASE-10995] - Fix resource leak related to unclosed HBaseAdmin
    * [HBASE-11005] - Remove dead code in HalfStoreFileReader#getScanner#seekBefore()
    * [HBASE-11009] - We sync every hbase:meta table write twice
    * [HBASE-11011] - Avoid extra getFileStatus() calls on Region startup
    * [HBASE-11012] - InputStream is not properly closed in two methods of JarFinder
    * [HBASE-11018] - ZKUtil.getChildDataAndWatchForNewChildren() will not return null as indicated
    * [HBASE-11028] - FSLog: Avoid an extra sync if the current transaction is already sync'd
    * [HBASE-11030] - HBaseTestingUtility.getMiniHBaseCluster should be able to return null
    * [HBASE-11036] - Online schema change with region merge may cause data loss
    * [HBASE-11038] - Filtered scans can bypass metrics collection
    * [HBASE-11049] - HBase WALPlayer needs to add credentials to job to play to table
    * [HBASE-11052] - Sending random data crashes thrift service
    * [HBASE-11055] - Extends the sampling size
    * [HBASE-11064] - Odd behaviors of TableName for empty namespace
    * [HBASE-11081] - Trunk Master won't start; looking for Constructor that takes conf only
    * [HBASE-11082] - Potential unclosed TraceScope in FSHLog#replaceWriter()
    * [HBASE-11096] - stop method of Master and RegionServer coprocessor  is not invoked
    * [HBASE-11112] - PerformanceEvaluation should document --multiGet option on its printUsage.
    * [HBASE-11117] - [AccessController] checkAndPut/Delete hook should check only Read permission
    * [HBASE-11118] - non environment variable solution for "IllegalAccessError: class com.google.protobuf.ZeroCopyLiteralByteString cannot access its superclass com.google.protobuf.LiteralByteString"
    * [HBASE-11120] - Update documentation about major compaction algorithm
    * [HBASE-11133] - Add an option to skip snapshot verification after Export
    * [HBASE-11139] - BoundedPriorityBlockingQueue#poll() should check the return value from awaitNanos()
    * [HBASE-11143] - Improve replication metrics
    * [HBASE-11149] - Wire encryption is broken
    * [HBASE-11150] - Images in website are broken
    * [HBASE-11155] - Fix Validation Errors in Ref Guide
    * [HBASE-11162] - RegionServer webui uses the default master info port irrespective of the user configuration.
    * [HBASE-11168] - [docs] Remove references to RowLocks in post 0.96 docs.
    * [HBASE-11169] - nit: fix incorrect javadoc in OrderedBytes about BlobVar and BlobCopy
    * [HBASE-11176] - Make /src/main/xslt/configuration_to_docbook_section.xsl produce better Docbook
    * [HBASE-11177] - 'hbase.rest.filter.classes' exists in hbase-default.xml twice
    * [HBASE-11185] - Parallelize Snapshot operations
    * [HBASE-11186] - Improve TestExportSnapshot verifications
    * [HBASE-11189] - Subprocedure should be marked as complete upon failure
    * [HBASE-11190] - Fix easy typos in documentation
    * [HBASE-11194] - [AccessController] issue with covering permission check in case of concurrent op on same row
    * [HBASE-11196] - Update description of -ROOT- in ref guide
    * [HBASE-11202] - Cleanup on HRegion class
    * [HBASE-11212] - Fix increment index in KeyValueSortReducer
    * [HBASE-11215] - Deprecate void setAutoFlush(boolean autoFlush, boolean clearBufferOnFail)
    * [HBASE-11217] - Race between SplitLogManager task creation + TimeoutMonitor
    * [HBASE-11218] - Data loss in HBase standalone mode
    * [HBASE-11226] - Document and increase the default value for hbase.hstore.flusher.count
    * [HBASE-11234] - FastDiffDeltaEncoder#getFirstKeyInBlock returns wrong result
    * [HBASE-11237] - Bulk load initiated by user other than hbase fails
    * [HBASE-11238] - Add info about SlabCache and BucketCache to Ref Guide
    * [HBASE-11239] - Forgot to svn add test that was part of HBASE-11171, TestCacheConfig
    * [HBASE-11248] - KeyOnlyKeyValue#toString() passes wrong offset to keyToString()
    * [HBASE-11251] - LoadTestTool should grant READ permission for the users that are given READ access for specific cells
    * [HBASE-11252] - Fixing new javadoc warnings in master branch
    * [HBASE-11253] - IntegrationTestWithCellVisibilityLoadAndVerify failing since HBASE-10326
    * [HBASE-11255] - Negative request num in region load
    * [HBASE-11260] - hbase-default.xml refers to hbase.regionserver.global.memstore.upperLimit which is deprecated
    * [HBASE-11267] - Dynamic metrics2 metrics may consume large amount of heap memory
    * [HBASE-11268] - HTablePool is now a deprecated class, should update docs to reflect this
    * [HBASE-11273] - Fix jersey and slf4j deps
    * [HBASE-11275] - [AccessController] postCreateTable hook fails when another CP creates table on their startup
    * [HBASE-11277] - RPCServer threads can wedge under high load
    * [HBASE-11279] - Block cache could be disabled by mistake
    * [HBASE-11285] - Expand coprocs info in Ref Guide
    * [HBASE-11297] - Remove some synchros in the rpcServer responder
    * [HBASE-11298] - Simplification in RpcServer code
    * [HBASE-11302] - ReplicationSourceManager#sources is not thread safe
    * [HBASE-11310] - Delete's copy constructor should copy the attributes also
    * [HBASE-11311] - Secure Bulk Load does not execute chmod 777 on the files
    * [HBASE-11312] - Minor refactoring of TestVisibilityLabels class
    * [HBASE-11320] - Reenable bucket cache logging
    * [HBASE-11324] - Update 2.5.2.8. Managed Compactions
    * [HBASE-11327] - ExportSnapshot hit stackoverflow error when target snapshotDir doesn't contain uri
    * [HBASE-11329] - Minor fixup of new blockcache tab number formatting
    * [HBASE-11335] - Fix the TABLE_DIR param in TableSnapshotInputFormat
    * [HBASE-11337] - Document how to create, modify, delete a table using Java
    * [HBASE-11338] - Expand documentation on bloom filters
    * [HBASE-11340] - Remove references to xcievers in documentation
    * [HBASE-11341] - ZKProcedureCoordinatorRpcs should respond only to members
    * [HBASE-11342] - The method isChildReadLock in class ZKInterProcessLockBase is wrong
    * [HBASE-11347] - For some errors, the client can retry infinitely
    * [HBASE-11353] - Wrong Write Request Count
    * [HBASE-11363] - Access checks in preCompact and preCompactSelection are out of sync
    * [HBASE-11371] - Typo in Thrift2 docs
    * [HBASE-11373] - hbase-protocol compile failed for name conflict of RegionTransition
    * [HBASE-11374] - RpcRetryingCaller#callWithoutRetries has a timeout of zero
    * [HBASE-11378] - TableMapReduceUtil overwrites user supplied options for multiple tables/scaners job
    * [HBASE-11380] - HRegion lock object is not being released properly, leading to snapshot failure
    * [HBASE-11382] - Adding unit test for HBASE-10964 (Delete mutation is not consistent with Put wrt timestamp)
    * [HBASE-11387] - metrics: wrong totalRequestCount
    * [HBASE-11391] - Thrift table creation will fail with default TTL with sanity checks
    * [HBASE-11396] - Invalid meta entries can lead to unstartable master
    * [HBASE-11397] - When merging expired stripes, we need to create an empty file to preserve metadata.
    * [HBASE-11399] - Improve Quickstart chapter and move Pseudo-distributed and distributed to it
    * [HBASE-11403] - Fix race conditions around Object#notify
    * [HBASE-11413] - [findbugs] RV: Negating the result of compareTo()/compare()
    * [HBASE-11418] - build target "site" doesn't respect hadoop-two.version property
    * [HBASE-11422] - Specification of scope is missing for certain Hadoop dependencies
    * [HBASE-11423] - Visibility label and per cell ACL feature not working with HTable#mutateRow() and MultiRowMutationEndpoint
    * [HBASE-11424] - Avoid usage of CellUtil#getTagArray(Cell cell) within server
    * [HBASE-11430] - lastFlushSeqId has been updated wrongly during region open
    * [HBASE-11432] - [AccessController] Remove cell first strategy
    * [HBASE-11433] - LruBlockCache does not respect its configurable parameters
    * [HBASE-11435] - Visibility labelled cells fail to getting replicated
    * [HBASE-11439] - StripeCompaction may not obey the OffPeak rule to compaction
    * [HBASE-11442] - ReplicationSourceManager doesn't cleanup the queues for recovered sources
    * [HBASE-11445] - TestZKProcedure#testMultiCohortWithMemberTimeoutDuringPrepare is flaky
    * [HBASE-11448] - Fix javadoc warnings
    * [HBASE-11449] - IntegrationTestIngestWithACL fails to use different users after HBASE-10810
    * [HBASE-11457] - Increment HFile block encoding IVs accounting for ciper's internal use
    * [HBASE-11458] - NPEs if RegionServer cannot initialize
    * [HBASE-11460] - Deadlock in HMaster on masterAndZKLock in HConnectionManager
    * [HBASE-11463] - (findbugs) HE: Class defines equals() and uses Object.hashCode()
    * [HBASE-11465] - [VisibilityController] Reserved tags check not happening for Append/Increment
    * [HBASE-11475] - Distributed log replay should also replay compaction events
    * [HBASE-11476] - Expand 'Conceptual View' section of Data Model chapter
    * [HBASE-11477] - book.xml has Docbook validity issues (again)
    * [HBASE-11481] - TableSnapshotInputFormat javadoc wrongly claims HBase "enforces security"
    * [HBASE-11487] - ScanResponse carries non-zero cellblock for CloseScanRequest (ScanRequest with close_scanner = true)
    * [HBASE-11488] - cancelTasks in SubprocedurePool can hang during task error
    * [HBASE-11489] - ClassNotFoundException while running IT tests in trunk using 'mvn verify'
    * [HBASE-11492] - Hadoop configuration overrides some ipc parameters including tcpNoDelay
    * [HBASE-11493] - Autorestart option is not working because of stale znode  "shutdown"
    * [HBASE-11496] - HBASE-9745 broke cygwin CLASSPATH translation
    * [HBASE-11502] - Track down broken images in Ref Guide
    * [HBASE-11505] - 'snapshot' shell command shadows 'snapshot' shell when 'help' is invoked
    * [HBASE-11506] - IntegrationTestWithCellVisibilityLoadAndVerify allow User to be passed as arg
    * [HBASE-11509] - Forward port HBASE-11039 to trunk and branch-1 after HBASE-11489
    * [HBASE-11510] - Visibility serialization format tag gets duplicated in Append/Increment'ed cells
    * [HBASE-11514] - Fix findbugs warnings in blockcache
    * [HBASE-11517] - TestReplicaWithCluster turns zombie
    * [HBASE-11518] - doc update for how to create non-shared HConnection
    * [HBASE-11523] - JSON serialization of PE Options is broke
    * [HBASE-11525] - Region server holding in region states is out of sync with meta
    * [HBASE-11527] - Cluster free memory limit check should consider L2 block cache size also when L2 cache is onheap.
    * [HBASE-11530] - RegionStates adds regions to wrong servers
    * [HBASE-11531] - RegionStates for regions under region-in-transition znode are not updated on startup
    * [HBASE-11534] - Remove broken JAVA_HOME autodetection in hbase-config.sh
    * [HBASE-11535] - ReplicationPeer map is not thread safe
    * [HBASE-11536] - Puts of region location to Meta may be out of order which causes inconsistent of region location
    * [HBASE-11537] - Avoid synchronization on instances of ConcurrentMap
    * [HBASE-11540] - Document HBASE-11474
    * [HBASE-11541] - Wrong result when scaning meta with startRow
    * [HBASE-11545] - mapred.TableSnapshotInputFormat is missing InterfaceAudience annotation
    * [HBASE-11550] - Custom value for BUCKET_CACHE_BUCKETS_KEY should be sorted
    * [HBASE-11551] - BucketCache$WriterThread.run() doesn't handle exceptions correctly
    * [HBASE-11554] - Remove Reusable poolmap Rpc client type.
    * [HBASE-11555] - TableSnapshotRegionSplit should be public
    * [HBASE-11558] - Caching set on Scan object gets lost when using TableMapReduceUtil in 0.95+
    * [HBASE-11561] - deprecate ImmutableBytesWritable.getSize and replace with getLength
    * [HBASE-11564] - Improve cancellation management in the rpc layer
    * [HBASE-11565] - Stale connection could stay for a while
    * [HBASE-11575] - Pseudo distributed mode does not work as documented
    * [HBASE-11579] - CopyTable should check endtime value only if != 0
    * [HBASE-11582] - Fix Javadoc warning in DataInputInputStream and CacheConfig
    * [HBASE-11586] - HFile's HDFS op latency sampling code is not used
    * [HBASE-11588] - RegionServerMetricsWrapperRunnable misused the 'period' parameter
    * [HBASE-11589] - AccessControlException should be a not retriable exception
    * [HBASE-11591] - Scanner fails to retrieve KV  from bulk loaded file with highest sequence id than the cell's mvcc in a non-bulk loaded file
    * [HBASE-11593] - TestCacheConfig failing consistently in precommit builds
    * [HBASE-11594] - Unhandled NoNodeException in distributed log replay mode
    * [HBASE-11603] - Apply version of HADOOP-8027 to our JMXJsonServlet
    * [HBASE-11609] - LoadIncrementalHFiles fails if the namespace is specified
    * [HBASE-11617] - incorrect AgeOfLastAppliedOp and AgeOfLastShippedOp in replication Metrics when no new replication OP
    * [HBASE-11620] - Record the class name of Writer in WAL header so that only proper Reader can open the WAL file
    * [HBASE-11627] - RegionSplitter's rollingSplit terminated with "/ by zero", and the _balancedSplit file was not deleted properly
    * [HBASE-11632] - Region split needs to clear force split flag at the end of SplitRequest run
    * [HBASE-11659] - Region state RPC call is not idempotent
    * [HBASE-11662] - Launching shell with long-form --debug fails
    * [HBASE-11668] - Re-add HBASE_LIBRARY_PATH to bin/hbase
    * [HBASE-11671] - TestEndToEndSplitTransaction fails on master
    * [HBASE-11678] - BucketCache ramCache fills heap after running a few hours
    * [HBASE-11687] - No need to abort on postOpenDeployTasks exception if region opening is cancelled
    * [HBASE-11703] - Meta region state could be corrupted
    * [HBASE-11705] - callQueueSize should be decremented in a fail-fast scenario
    * [HBASE-11708] - RegionSplitter incorrectly calculates splitcount
    * [HBASE-11709] - TestMasterShutdown can fail sometime
    * [HBASE-11716] - LoadTestDataGeneratorWithVisibilityLabels should handle Delete mutations
    * [HBASE-11717] - Remove unused config 'hbase.offheapcache.percentage' from hbase-default.xml and book
    * [HBASE-11718] - Remove some logs in RpcClient.java
    * [HBASE-11719] - Remove some unused paths in AsyncClient
    * [HBASE-11725] - Backport failover checking change to 1.0
    * [HBASE-11726] - Master should fail-safe if starting with a pre 0.96 layout
    * [HBASE-11727] - Assignment wait time error in case of ServerNotRunningYetException
    * [HBASE-11728] - Data loss while scanning using PREFIX_TREE DATA-BLOCK-ENCODING
    * [HBASE-11733] - Avoid copy-paste in Master/Region CoprocessorHost
    * [HBASE-11744] - RpcServer code should not use a collection from netty internal
    * [HBASE-11745] - FilterAllFilter should return ReturnCode.SKIP
    * [HBASE-11755] - VisibilityController returns the wrong value for preBalanceSwitch()
    * [HBASE-11766] - Backdoor CoprocessorHConnection is no longer being used for local writes
    * [HBASE-11770] - TestBlockCacheReporting.testBucketCache is not stable
    * [HBASE-11772] - Bulk load mvcc and seqId issues with native hfiles
    * [HBASE-11773] - Wrong field used for protobuf construction in RegionStates.
    * [HBASE-11782] - Document that hbase.MetaMigrationConvertingToPB needs to be set to true for migrations pre 0.96
    * [HBASE-11787] - TestRegionLocations is not categorized
    * [HBASE-11788] - hbase is not deleting the cell when a Put with a KeyValue, KeyValue.Type.Delete is submitted
    * [HBASE-11789] - LoadIncrementalHFiles is not picking up the -D option
    * [HBASE-11794] - StripeStoreFlusher causes NullPointerException
    * [HBASE-11797] - Create Table interface to replace HTableInterface
    * [HBASE-11802] - Scan copy constructor doesn't copy reversed member variable
    * [HBASE-11813] - CellScanner#advance may overflow stack
    * [HBASE-11814] - TestAssignmentManager.testCloseFailed() and testOpenCloseRacing() is flaky
    * [HBASE-11816] - Initializing custom Metrics implementation failed in Mapper or Reducer
    * [HBASE-11820] - ReplicationSource : Set replication codec class as RPC codec class on a clonned Configuration
    * [HBASE-11823] - Cleanup javadoc warnings.
    * [HBASE-11832] - maven release plugin overrides command line arguments
    * [HBASE-11836] - IntegrationTestTimeBoundedMultiGetRequestsWithRegionReplicas tests simple get by default
    * [HBASE-11839] - TestRegionRebalance is flakey
    * [HBASE-11844] - region_mover.rb load enters an infinite loop if region already present on target server
    * [HBASE-11851] - RpcClient can try to close a connection not ready to close
    * [HBASE-11856] - hbase-common needs a log4j.properties resource for handling unit test logging output
    * [HBASE-11857] - Restore ReaderBase.initAfterCompression() and WALCellCodec.create(Configuration, CompressionContext)
    * [HBASE-11859] - 'hadoop jar' references in documentation should mention hbase-server.jar, not hbase.jar
    * [HBASE-11863] - WAL files are not archived and stays in the WAL directory after splitting
    * [HBASE-11876] - RegionScanner.nextRaw(...) should not update metrics
    * [HBASE-11878] - TestVisibilityLabelsWithDistributedLogReplay#testAddVisibilityLabelsOnRSRestart sometimes fails due to VisibilityController not yet initialized
    * [HBASE-11880] - NPE in MasterStatusServlet
    * [HBASE-11882] - Row level consistency may not be maintained with bulk load and compaction
    * [HBASE-11886] - The creator of the table should have all permissions on the table
    * [HBASE-11887] - Memory retention in branch-1; millions of instances of LiteralByteString for column qualifier and value
    * [HBASE-11892] - configs contain stale entries
    * [HBASE-11893] - RowTooBigException should be in hbase-client module
    * [HBASE-11896] - LoadIncrementalHFiles fails in secure mode if the namespace is specified
    * [HBASE-11898] - CoprocessorHost.Environment should cache class loader instance
    * [HBASE-11905] - Add orca to server UIs and update logo.
    * [HBASE-11921] - Minor fixups that come of testing branch-1
    * [HBASE-11932] - Stop the html-single from building a html-single of every chapter and cluttering the docbkx directory
    * [HBASE-11936] - IsolationLevel must be attribute of a Query not a Scan
    * [HBASE-11946] - Get xref and API docs to build properly again
    * [HBASE-11947] - NoSuchElementException in balancer for master regions
    * [HBASE-11949] - Setting hfile.block.cache.size=0 doesn't actually disable blockcache
    * [HBASE-11959] - TestAssignmentManagerOnCluster is flaky
    * [HBASE-11972] - The "doAs user" used in the update to hbase:acl table RPC is incorrect
    * [HBASE-11976] - Server startcode is not checked for bulk region assignment
    * [HBASE-11984] - TestClassFinder failing on occasion
    * [HBASE-11989] - IntegrationTestLoadAndVerify cannot be configured anymore on distributed mode

** Improvement
    * [HBASE-2217] - VM OPTS for shell only
    * [HBASE-3270] - When we create the .version file, we should create it in a tmp location and then move it into place
    * [HBASE-4163] - Create Split Strategy for YCSB Benchmark
    * [HBASE-4495] - CatalogTracker has an identity crisis; needs to be cut-back in scope
    * [HBASE-5349] - Automagically tweak global memstore and block cache sizes based on workload
    * [HBASE-5923] - Cleanup checkAndXXX logic
    * [HBASE-6626] - Add a chapter on HDFS in the troubleshooting section of the HBase reference guide.
    * [HBASE-6990] - Pretty print TTL
    * [HBASE-7088] - Duplicate code in RowCounter
    * [HBASE-7849] - Provide administrative limits around bulkloads of files into a single region
    * [HBASE-7910] - Dont use reflection for security
    * [HBASE-7987] - Snapshot Manifest file instead of multiple empty files
    * [HBASE-8076] - add better doc for HBaseAdmin#offline API.
    * [HBASE-8298] - In shell, provide alias of 'desc' for 'describe'
    * [HBASE-8315] - Documentation should have more information of LRU Stats
    * [HBASE-8332] - Add truncate as HMaster method
    * [HBASE-8495] - Change ownership of the directory to bulk load
    * [HBASE-8604] - improve reporting of incorrect peer address in replication
    * [HBASE-8755] - A new write thread model for HLog to improve the overall HBase write throughput
    * [HBASE-8763] - Combine MVCC and SeqId
    * [HBASE-8807] - HBase MapReduce Job-Launch Documentation Misplaced
    * [HBASE-8970] - [book] Filter language documentation is hidden
    * [HBASE-9343] - Implement stateless scanner for Stargate
    * [HBASE-9345] - Add support for specifying filters in scan
    * [HBASE-9426] - Make custom distributed barrier procedure pluggable
    * [HBASE-9501] - Provide throttling for replication
    * [HBASE-9524] - Multi row get does not return any results even if any one of the rows specified in the query is missing and improve exception handling
    * [HBASE-9542] - Have Get and MultiGet do cellblocks, currently they are pb all the time
    * [HBASE-9829] - make the compaction logging less confusing
    * [HBASE-9857] - Blockcache prefetch option
    * [HBASE-9866] - Support the mode where REST server authorizes proxy users
    * [HBASE-9892] - Add info port to ServerName to support multi instances in a node
    * [HBASE-9999] - Add support for small reverse scan
    * [HBASE-10010] - eliminate the put latency spike on the new log file beginning
    * [HBASE-10048] - Add hlog number metric in regionserver
    * [HBASE-10074] - consolidate and improve capacity/sizing documentation
    * [HBASE-10086] - [book] document the  HBase canary tool usage in the HBase Book
    * [HBASE-10116] - SlabCache metrics improvements
    * [HBASE-10128] - Improve the copy table doc to include information about versions
    * [HBASE-10141] - instead of putting expired store files thru compaction, just archive them
    * [HBASE-10157] - Provide CP hook post log replay
    * [HBASE-10164] - Allow heapsize of different units to be passed as HBASE_HEAPSIZE
    * [HBASE-10173] - Need HFile version check in security coprocessors
    * [HBASE-10175] - 2-thread ChaosMonkey steps on its own toes
    * [HBASE-10202] - Documentation is lacking information about rolling-restart.sh script.
    * [HBASE-10211] - Improve AccessControl documentation in hbase book
    * [HBASE-10213] - Add read log size per second metrics for replication source
    * [HBASE-10228] - Support setCellVisibility and setAuthorizations in Shell
    * [HBASE-10229] - Support OperationAttributes in Increment and Append in Shell
    * [HBASE-10239] - Improve determinism and debugability of TestAccessController
    * [HBASE-10252] - Don't write back to WAL/memstore when Increment amount is zero (mostly for query rather than update intention)
    * [HBASE-10263] - make LruBlockCache single/multi/in-memory ratio user-configurable and provide preemptive mode for in-memory type block
    * [HBASE-10265] - Upgrade to commons-logging 1.1.3
    * [HBASE-10277] - refactor AsyncProcess
    * [HBASE-10289] - Avoid random port usage by default JMX Server. Create Custome JMX server
    * [HBASE-10323] - Auto detect data block encoding in HFileOutputFormat
    * [HBASE-10324] - refactor deferred-log-flush/Durability related interface/code/naming to align with changed semantic of the new write thread model
    * [HBASE-10331] - Insure security tests use SecureTestUtil methods for grants
    * [HBASE-10344] - Improve write performance by ignoring sync to hdfs when an asyncer's writes have been synced by other asyncer
    * [HBASE-10346] - Add Documentation for stateless scanner
    * [HBASE-10368] - Add Mutation.setWriteToWAL() back to 0.98
    * [HBASE-10373] - Add more details info for ACL group in HBase book
    * [HBASE-10389] - Add namespace help info in table related shell commands
    * [HBASE-10395] - endTime won't be set in VerifyReplication if startTime is not set
    * [HBASE-10419] - Add multiget support to PerformanceEvaluation
    * [HBASE-10423] - Report back the message of split or rollback failure to the master
    * [HBASE-10427] - clean up HRegionLocation/ServerName usage
    * [HBASE-10430] - Support compressTags in shell for enabling tag encoding
    * [HBASE-10471] - Remove HTD.isAsyncLogFlush() from trunk
    * [HBASE-10479] - HConnection interface is public but is used internally, and contains a bunch of methods
    * [HBASE-10487] - Avoid allocating new KeyValue and according bytes-copying for appended kvs which don't have existing values
    * [HBASE-10498] - Add new APIs to load balancer interface
    * [HBASE-10511] - Add latency percentiles on PerformanceEvaluation
    * [HBASE-10518] - DirectMemoryUtils.getDirectMemoryUsage spams when none is configured
    * [HBASE-10569] - Co-locate meta and master
    * [HBASE-10570] - Allow overrides of Surefire secondPartForkMode and testFailureIgnore
    * [HBASE-10589] - Reduce unnecessary TestRowProcessorEndpoint resource usage
    * [HBASE-10590] - Update contents about tracing in the Reference Guide
    * [HBASE-10591] - Sanity check table configuration in createTable
    * [HBASE-10592] - Refactor PerformanceEvaluation tool
    * [HBASE-10597] - IOEngine#read() should return the number of bytes transferred
    * [HBASE-10599] - Replace System.currentMillis() with EnvironmentEdge.currentTimeMillis in memstore flusher and related places
    * [HBASE-10603] - Deprecate RegionSplitter CLI tool
    * [HBASE-10615] - Make LoadIncrementalHFiles skip reference files
    * [HBASE-10638] - Improve error message when there is no region server available for move
    * [HBASE-10641] - Configurable Bucket Sizes in bucketCache
    * [HBASE-10663] - Some code cleanup of class Leases and ScannerListener.leaseExpired
    * [HBASE-10678] - Make verifyrep tool implement toolrunner
    * [HBASE-10690] - Drop Hadoop-1 support
    * [HBASE-10693] - Correct declarations of Atomic* fields from 'volatile' to 'final'
    * [HBASE-10744] - AM#CloseRegion no need to retry on FailedServerException
    * [HBASE-10746] - Bump the version of HTrace to 3.0
    * [HBASE-10752] - Port HBASE-10270 'Remove DataBlockEncoding from BlockCacheKey' to trunk
    * [HBASE-10769] - hbase/bin/hbase-cleanup.sh has wrong usage string
    * [HBASE-10771] - Primitive type put/get APIs in ByteRange
    * [HBASE-10785] - Metas own location should be cached
    * [HBASE-10788] - Add 99th percentile of latency in PE
    * [HBASE-10797] - Add support for -h and --help to rolling_restart.sh and fix the usage string output
    * [HBASE-10813] - Possible over-catch of exceptions
    * [HBASE-10823] - Resolve LATEST_TIMESTAMP to current server time before scanning for ACLs
    * [HBASE-10835] - DBE encode path improvements
    * [HBASE-10842] - Some loggers not declared static final
    * [HBASE-10861] - Extend ByteRange to create Mutable and Immutable ByteRange
    * [HBASE-10871] - Indefinite OPEN/CLOSE wait on busy RegionServers
    * [HBASE-10873] - Control number of regions assigned to backup masters
    * [HBASE-10883] - Restrict the universe of labels and authorizations
    * [HBASE-10884] - [REST] Do not disable block caching when scanning
    * [HBASE-10885] - Support visibility expressions on Deletes
    * [HBASE-10887] - tidy ThriftUtilities format
    * [HBASE-10892] - [Shell] Add support for globs in user_permission
    * [HBASE-10902] - Make Secure Bulk Load work across remote secure clusters
    * [HBASE-10911] - ServerShutdownHandler#toString shows meaningless message
    * [HBASE-10916] - [VisibilityController] Stackable ScanLabelGenerators
    * [HBASE-10923] - Control where to put meta region
    * [HBASE-10925] - Do not OOME, throw RowTooBigException instead
    * [HBASE-10926] - Use global procedure to flush table memstore cache
    * [HBASE-10934] - Provide Admin interface to abstract HBaseAdmin
    * [HBASE-10950] - Add  a configuration point for MaxVersion of Column Family
    * [HBASE-10951] - Use PBKDF2 to generate test encryption keys in the shell
    * [HBASE-10952] - [REST] Let the user turn off block caching if desired
    * [HBASE-10960] - Enhance HBase Thrift 1 to include "append" and "checkAndPut" operations
    * [HBASE-10984] - Add description about setting up htrace-zipkin to documentation
    * [HBASE-11000] - Add autoflush option to PerformanceEvaluation
    * [HBASE-11001] - Shell support for granting cell permissions for testing
    * [HBASE-11002] - Shell support for changing cell visibility for testing
    * [HBASE-11004] - Extend traces through FSHLog#sync
    * [HBASE-11007] - BLOCKCACHE in schema descriptor seems not aptly named
    * [HBASE-11008] - Align bulk load, flush, and compact to require Action.CREATE
    * [HBASE-11026] - Provide option to filter out all rows in PerformanceEvaluation tool
    * [HBASE-11044] - [Shell] Show groups for user in 'whoami' output
    * [HBASE-11047] - Remove TimeoutMontior
    * [HBASE-11048] - Support setting custom priority per client RPC
    * [HBASE-11068] - Update code to use Admin factory method instead of constructor
    * [HBASE-11074] - Have PE emit histogram stats as it runs rather than dump once at end of test
    * [HBASE-11083] - ExportSnapshot should provide capability to limit bandwidth consumption
    * [HBASE-11086] - Add htrace support for PerfEval
    * [HBASE-11119] - Update ExportSnapShot to optionally not use a tmp file on external file system
    * [HBASE-11123] - Upgrade instructions from 0.94 to 0.98
    * [HBASE-11126] - Add RegionObserver pre hooks that operate under row lock
    * [HBASE-11128] - Add -target option to ExportSnapshot to export with a different name
    * [HBASE-11134] - Add a -list-snapshots option to SnapshotInfo
    * [HBASE-11136] - Add permission check to roll WAL writer
    * [HBASE-11137] - Add mapred.TableSnapshotInputFormat
    * [HBASE-11151] - move tracing modules from hbase-server to hbase-common
    * [HBASE-11167] - Avoid usage of java.rmi package Exception in MemStore
    * [HBASE-11201] - Enable global procedure members to return values to procedure master
    * [HBASE-11211] - LoadTestTool option for specifying number of regions per server
    * [HBASE-11219] - HRegionServer#createRegionLoad() should reuse RegionLoad.Builder instance when called in a loop
    * [HBASE-11220] - Add listeners to ServerManager and AssignmentManager
    * [HBASE-11240] - Print hdfs pipeline when hlog's sync is slow
    * [HBASE-11259] - Compression.java different compressions load system classpath differently causing errors
    * [HBASE-11304] - Enable HBaseAdmin.execProcedure to return data from procedure execution
    * [HBASE-11305] - Remove bunch of unused imports in HConnectionManager
    * [HBASE-11315] - Keeping MVCC for configurable longer time
    * [HBASE-11319] - No need to use favored node mapping initialization to find all regions
    * [HBASE-11326] - Use an InputFormat for ExportSnapshot
    * [HBASE-11331] - [blockcache] lazy block decompression
    * [HBASE-11344] - Hide row keys and such from the web UIs
    * [HBASE-11348] - Make frequency and sleep times of  chaos monkeys configurable
    * [HBASE-11349] - [Thrift] support authentication/impersonation
    * [HBASE-11350] - [PE] Allow random value size
    * [HBASE-11355] - a couple of callQueue related improvements
    * [HBASE-11362] - Minor improvements to LoadTestTool and PerformanceEvaluation
    * [HBASE-11370] - SSH doesn't need to scan meta if not using ZK for assignment
    * [HBASE-11376] - Presplit table in IntegrationTestBigLinkedList's Generator tool
    * [HBASE-11390] - PerformanceEvaluation: add an option to use a single connection
    * [HBASE-11398] - Print the stripes' state with file size info
    * [HBASE-11407] - hbase-client should not require Jackson for pure HBase queries be executed
    * [HBASE-11415] - [PE] Dump config before running test
    * [HBASE-11421] - HTableInterface javadoc correction
    * [HBASE-11434] - [AccessController] Disallow inbound cells with reserved tags
    * [HBASE-11436] - Support start Row and stop Row in HBase Export
    * [HBASE-11437] - Modify cell tag handling code to treat the length as unsigned
    * [HBASE-11438] - [Visibility Controller] Support UTF8 character as Visibility Labels
    * [HBASE-11440] - Make KeyValueCodecWithTags as the default codec for replication in trunk
    * [HBASE-11444] - Remove use of reflection for User#getShortName
    * [HBASE-11446] - Reduce the frequency of RNG calls in SecureWALCellCodec#EncryptedKvEncoder
    * [HBASE-11450] - Improve file size info in SnapshotInfo tool
    * [HBASE-11452] - add getUserPermission feature in AccessControlClient as client API
    * [HBASE-11473] - Add BaseWALObserver class
    * [HBASE-11474] - [Thrift2] support authentication/impersonation
    * [HBASE-11491] - Add an option to sleep randomly during the tests with the PE tool
    * [HBASE-11497] - Expose RpcScheduling implementations as LimitedPrivate interfaces
    * [HBASE-11513] - Combine SingleMultiple Queue RpcExecutor into a single class
    * [HBASE-11516] - Track time spent in executing coprocessors in each region.
    * [HBASE-11553] - Abstract visibility label related services into an interface
    * [HBASE-11566] - make ExportSnapshot extendable by removing 'final'
    * [HBASE-11583] - Refactoring out the configuration changes for enabling VisibilityLabels in the unit tests.
    * [HBASE-11623] - mutateRowsWithLocks might require updatesLock.readLock with waitTime=0
    * [HBASE-11630] - Refactor TestAdmin to use Admin interface instead of HBaseAdmin
    * [HBASE-11631] - Wait a little till server is online in assigning meta
    * [HBASE-11649] - Add shortcut commands to bin/hbase for test tools
    * [HBASE-11650] - Write hbase.id to a temporary location and move into place
    * [HBASE-11657] - Put HTable region methods in an interface
    * [HBASE-11664] - Build broken - TestVisibilityWithCheckAuths
    * [HBASE-11667] - Comment ClientScanner logic for NSREs.
    * [HBASE-11674] - LoadIncrementalHFiles should be more verbose after unrecoverable error
    * [HBASE-11679] - Replace "HTable" with "HTableInterface" where backwards-compatible
    * [HBASE-11696] - Make CombinedBlockCache resizable.
    * [HBASE-11697] - Improve the 'Too many blocks' message on UI blockcache status page
    * [HBASE-11701] - Start and end of memstore flush log should be on the same level
    * [HBASE-11702] - Better introspection of long running compactions
    * [HBASE-11706] - Set versions for VerifyReplication
    * [HBASE-11731] - Add option to only run a subset of the shell tests
    * [HBASE-11748] - Cleanup and add pool usage tracing to Compression
    * [HBASE-11749] - Better error logging when coprocessors loading has failed.
    * [HBASE-11754] - [Shell] Record table property SPLITS_FILE in descriptor
    * [HBASE-11757] - Provide a common base abstract class for both RegionObserver and MasterObserver
    * [HBASE-11774] - Avoid allocating unnecessary tag iterators
    * [HBASE-11777] - Find a way to set sequenceId on Cells on the server
    * [HBASE-11790] - Bulk load should use HFileOutputFormat2 in all cases
    * [HBASE-11805] - KeyValue to Cell Convert in WALEdit APIs
    * [HBASE-11810] - Access SSL Passwords through Credential Provider API
    * [HBASE-11821] - [ImportTSV] Abstract labels tags creation into pluggable Interface
    * [HBASE-11825] - Create Connection and ConnectionManager
    * [HBASE-11826] - Split each tableOrRegionName admin methods into two targetted methods
    * [HBASE-11828] - callers of SeverName.valueOf should use equals and not ==
    * [HBASE-11845] - HFile tool should implement Tool, disable blockcache by default
    * [HBASE-11846] - HStore#assertBulkLoadHFileOk should log if a full HFile verification will be performed during a bulkload
    * [HBASE-11847] - HFile tool should be able to print block headers
    * [HBASE-11865] - Result implements CellScannable; rather it should BE a CellScanner
    * [HBASE-11873] - Hbase Version CLI enhancement
    * [HBASE-11877] - Make TableSplit more readable
    * [HBASE-11891] - Introduce HBaseInterfaceAudience level to denote class names that appear in configs.
    * [HBASE-11897] - Add append and remove peer table-cfs cmds for replication

** New Feature
    * [HBASE-4089] - blockCache contents report
    * [HBASE-6104] - Require EXEC permission to call coprocessor endpoints
    * [HBASE-7667] - Support stripe compaction
    * [HBASE-7840] - Enhance the java it framework to start & stop a distributed hbase & hadoop cluster
    * [HBASE-8751] - Enable peer cluster to choose/change the ColumnFamilies/Tables it really want to replicate from a source cluster
    * [HBASE-9047] - Tool to handle finishing replication when the cluster is offline
    * [HBASE-10119] - Allow HBase coprocessors to clean up when they fail
    * [HBASE-10151] - No-op HeapMemoryTuner
    * [HBASE-10416] - Improvements to the import flow
    * [HBASE-10881] - Support reverse scan in thrift2
    * [HBASE-10935] - support snapshot policy where flush memstore can be skipped to prevent production cluster freeze
    * [HBASE-11724] - Add to RWQueueRpcExecutor the ability to split get and scan handlers
    * [HBASE-11885] - Provide a Dockerfile to easily build and run HBase from source
    * [HBASE-11909] - Region count listed by HMaster UI and hbck are different

** Task
    * [HBASE-4456] - [doc] Add a section about RS failover
    * [HBASE-4920] - We need a mascot, a totem
    * [HBASE-5697] - Audit HBase for usage of deprecated hadoop 0.20.x property names.
    * [HBASE-6139] - Add troubleshooting section for CentOS 6.2 page allocation failure issue
    * [HBASE-6192] - Document ACL matrix in the book
    * [HBASE-7394] - Document security config requirements from HBASE-7357
    * [HBASE-8035] - Add site target check to precommit tests
    * [HBASE-8844] - Document the removal of replication state AKA start/stop_replication
    * [HBASE-9580] - Document the meaning of @InterfaceAudience in hbase ref guide
    * [HBASE-9733] - Book should have individual Disqus comment per page
    * [HBASE-9875] - NamespaceJanitor chore is not used
    * [HBASE-10134] - Fix findbug warning in VisibilityController
    * [HBASE-10159] - Replaced deprecated interface Closeable
    * [HBASE-10206] - Explain tags in the hbase book
    * [HBASE-10246] - Wrap long lines in recently added source files
    * [HBASE-10364] - Allow configuration option for parent znode in LoadTestTool
    * [HBASE-10388] - Add export control notice in README
    * [HBASE-10439] - Document how to configure REST server impersonation
    * [HBASE-10473] - Add utility for adorning http Context
    * [HBASE-10601] - Upgrade hadoop dependency to 2.3.0 release
    * [HBASE-10609] - Remove filterKeyValue(Cell ignored) from FilterBase
    * [HBASE-10612] - Remove unnecessary dependency on org.eclipse.jdt:core
    * [HBASE-10670] - HBaseFsck#connect() should use new connection
    * [HBASE-10700] - IntegrationTestWithCellVisibilityLoadAndVerify should allow current user to be the admin
    * [HBASE-10740] - Upgrade zookeeper to 3.4.6 release
    * [HBASE-10786] - If snapshot verification fails with 'Regions moved', the message should contain the name of region causing the failure
    * [HBASE-10787] - TestHCM#testConnection* take too long
    * [HBASE-10821] - Make ColumnInterpreter#getValue() abstract
    * [HBASE-10824] - Enhance detection of protobuf generated code in line length check
    * [HBASE-10889] - test-patch.sh should exclude thrift generated code from long line detection
    * [HBASE-10906] - Change error log for NamingException in TableInputFormatBase to WARN level
    * [HBASE-10912] - setUp / tearDown in TestSCVFWithMiniCluster should be done once per run
    * [HBASE-10956] - Upgrade hadoop-2 dependency to 2.4.0
    * [HBASE-11016] - Remove Filter#filterRow(List)
    * [HBASE-11032] - Replace deprecated methods in FileSystem with their replacements
    * [HBASE-11050] - Replace empty catch block in TestHLog#testFailedToCreateHLogIfParentRenamed with @Test(expected=)
    * [HBASE-11076] - Update refguide on getting 0.94.x to run on hadoop 2.2.0+
    * [HBASE-11090] - Backport HBASE-11083 ExportSnapshot should provide capability to limit bandwidth consumption
    * [HBASE-11107] - Provide utility method equivalent to 0.92's Result.getBytes().getSize()
    * [HBASE-11154] - Document how to use Reverse Scan API
    * [HBASE-11199] - One-time effort to pretty-print the Docbook XML, to make further patch review easier
    * [HBASE-11203] - Clean up javadoc and findbugs warnings in trunk
    * [HBASE-11204] - Document bandwidth consumption limit feature for ExportSnapshot
    * [HBASE-11227] - Mention 8- and 16-bit fixed-with encodings in OrderedBytes docstring
    * [HBASE-11230] - Remove getRowOrBefore from HTableInterface and HTable
    * [HBASE-11317] - Expand unit testing to cover Mockito and MRUnit and give more examples
    * [HBASE-11364] - [BlockCache] Add a flag to cache data blocks in L1 if multi-tier cache
    * [HBASE-11600] - DataInputputStream and DoubleOutputStream are no longer being used
    * [HBASE-11604] - Disable co-locating meta/master by default
    * [HBASE-11621] - Make MiniDFSCluster run faster
    * [HBASE-11666] - Enforce JDK7 javac for builds on branch-1 and master
    * [HBASE-11682] - Explain hotspotting
    * [HBASE-11723] - Document all options of bin/hbase command
    * [HBASE-11735] - Document Configurable Bucket Sizes in bucketCache
    * [HBASE-11762] - Record the class name of Codec in WAL header
    * [HBASE-11800] - Coprocessor service methods in HTableInterface should be annotated public
    * [HBASE-11849] - Clean up orphaned private audience classes
    * [HBASE-11858] - Audit regionserver classes that are missing InterfaceAudience

** Test
    * [HBASE-8889] - TestIOFencing#testFencingAroundCompaction occasionally fails
    * [HBASE-9928] - TestHRegion should clean up test-data directory upon completion
    * [HBASE-9953] - PerformanceEvaluation: Decouple data size from client concurrency
    * [HBASE-10044] - test-patch.sh should accept documents by known file extensions
    * [HBASE-10130] - TestSplitLogManager#testTaskResigned fails sometimes
    * [HBASE-10180] - TestByteBufferIOEngine#testByteBufferIOEngine occasionally fails
    * [HBASE-10189] - Intermittent TestReplicationSyncUpTool failure
    * [HBASE-10301] - TestAssignmentManagerOnCluster#testOpenCloseRacing fails intermittently
    * [HBASE-10377] - Add test for HBASE-10370 Compaction in out-of-date Store causes region split failure
    * [HBASE-10394] - Test for Replication with tags
    * [HBASE-10406] - Column family option is not effective in IntegrationTestSendTraceRequests
    * [HBASE-10408] - Intermittent TestDistributedLogSplitting#testLogReplayForDisablingTable failure
    * [HBASE-10440] - integration tests fail due to nonce collisions
    * [HBASE-10465] - TestZKPermissionsWatcher.testPermissionsWatcher fails sometimes
    * [HBASE-10475] - TestRegionServerCoprocessorExceptionWithAbort may timeout due to concurrent lease removal
    * [HBASE-10480] - TestLogRollPeriod#testWithEdits may fail due to insufficient waiting
    * [HBASE-10543] - Two rare test failures with TestLogsCleaner and TestSplitLogWorker
    * [HBASE-10635] - thrift#TestThriftServer fails due to TTL validity check
    * [HBASE-10649] - TestMasterMetrics fails occasionally
    * [HBASE-10764] - TestLoadIncrementalHFilesSplitRecovery#testBulkLoadPhaseFailure takes too long
    * [HBASE-10767] - Load balancer may interfere with tests in TestHBaseFsck
    * [HBASE-10774] - Restore TestMultiTableInputFormat
    * [HBASE-10782] - Hadoop2 MR tests fail occasionally because of mapreduce.jobhistory.address is no set in job conf
    * [HBASE-10828] - TestRegionObserverInterface#testHBase3583 should wait for all regions to be assigned
    * [HBASE-10852] - TestDistributedLogSplitting#testDisallowWritesInRecovering occasionally fails
    * [HBASE-10867] - TestRegionPlacement#testRegionPlacement occasionally fails
    * [HBASE-10868] - TestAtomicOperation should close HRegion instance after each subtest
    * [HBASE-10988] - Properly wait for server in TestThriftServerCmdLine
    * [HBASE-11010] - TestChangingEncoding is unnecessarily slow
    * [HBASE-11019] - incCount() method should be properly stubbed in HConnectionTestingUtility#getMockedConnectionAndDecorate()
    * [HBASE-11037] - Race condition in TestZKBasedOpenCloseRegion
    * [HBASE-11051] - checkJavacWarnings in test-patch.sh should bail out early if there is compilation error
    * [HBASE-11057] - Improve TestShell coverage of grant and revoke comamnds
    * [HBASE-11104] - IntegrationTestImportTsv#testRunFromOutputCommitter misses credential initialization
    * [HBASE-11152] - test-patch.sh should be able to handle the case where $TERM is not defined
    * [HBASE-11166] - Categorize tests in hbase-prefix-tree module
    * [HBASE-11328] - testMoveRegion could fail
    * [HBASE-11345] - Add an option not to restore cluster after an IT test
    * [HBASE-11375] - Validate compile-protobuf profile in test-patch.sh
    * [HBASE-11404] - TestLogLevel should stop the server at the end
    * [HBASE-11443] - TestIOFencing#testFencingAroundCompactionAfterWALSync times out
    * [HBASE-11615] - TestZKLessAMOnCluster.testForceAssignWhileClosing failed on Jenkins
    * [HBASE-11713] - Adding hbase shell unit test coverage for visibility labels.
    * [HBASE-11918] - TestVisibilityLabelsWithDistributedLogReplay#testAddVisibilityLabelsOnRSRestart sometimes fails due to VisibilityController initialization not being recognized
    * [HBASE-11942] - Fix TestHRegionBusyWait
    * [HBASE-11966] - Minor error in TestHRegion.testCheckAndMutate_WithCorrectValue()

** Umbrella
    * [HBASE-7319] - Extend Cell usage through read path
    * [HBASE-9945] - Coprocessor loading and execution improvements
    * [HBASE-10909] - Abstract out ZooKeeper usage in HBase - phase 1