Release Notes - HBase - Version 2.0.0 - HTML format

Sub-task

  • [HBASE-4624] - Remove and convert @deprecated RemoteExceptionHandler.decodeRemoteException calls
  • [HBASE-4625] - Convert @deprecated HBaseTestCase tests JUnit4 style tests
  • [HBASE-7612] - [JDK8] Replace use of high-scale-lib counters with intrinsic facilities
  • [HBASE-7767] - Get rid of ZKTable, and table enable/disable state in ZK
  • [HBASE-7847] - Use zookeeper multi to clear znodes
  • [HBASE-8139] - Allow job names to be overridden
  • [HBASE-8410] - Basic quota support for namespaces
  • [HBASE-8593] - Type support in ImportTSV tool
  • [HBASE-10092] - Move to slf4j
  • [HBASE-10378] - Divide HLog interface into User and Implementor specific interfaces
  • [HBASE-10588] - Remove deprecated public facing classes/methods related to KeyValue
  • [HBASE-10674] - HBCK should be updated to do replica related checks
  • [HBASE-10800] - Use CellComparator instead of KVComparator
  • [HBASE-10942] - support parallel request cancellation for multi-get
  • [HBASE-10944] - Remove all kv.getBuffer() and kv.getRow() references existing in the code
  • [HBASE-11179] - API parity between mapred and mapreduce
  • [HBASE-11261] - Handle splitting/merging of regions that have region_replication greater than one
  • [HBASE-11392] - add/remove peer requests should be routed through master
  • [HBASE-11393] - Replication TableCfs should be a PB object rather than a string
  • [HBASE-11470] - Move Server interface to hbase-server
  • [HBASE-11472] - Remove ZKTableStateClientSideReader class
  • [HBASE-11533] - AsciiDoctor POC
  • [HBASE-11567] - Write bulk load COMMIT events to WAL
  • [HBASE-11568] - Async WAL replication for region replicas
  • [HBASE-11569] - Flush / Compaction handling from secondary region replicas
  • [HBASE-11571] - Bulk load handling from secondary region replicas
  • [HBASE-11574] - hbase:meta's regions can be replicated
  • [HBASE-11580] - Failover handling for secondary region replicas
  • [HBASE-11598] - Add simple rpc throttling
  • [HBASE-11607] - Document HBase metrics
  • [HBASE-11643] - Read and write MOB in HBase
  • [HBASE-11644] - External MOB compaction tools
  • [HBASE-11645] - Snapshot for MOB
  • [HBASE-11646] - Handle the MOB in compaction
  • [HBASE-11647] - MOB integration testing
  • [HBASE-11683] - Metrics for MOB
  • [HBASE-11779] - Document the new requirement to set JAVA_HOME before starting HBase
  • [HBASE-11786] - Document web UI for tracking time spent in coprocessors
  • [HBASE-11842] - Integration test for async wal replication to secondary regions
  • [HBASE-11861] - Native MOB Compaction mechanisms.
  • [HBASE-11901] - Improve the value size of the reference cell in mob column
  • [HBASE-11903] - Directly invoking split & merge of replica regions should be disallowed
  • [HBASE-11908] - Region replicas should be added to the meta table at the time of table creation
  • [HBASE-11910] - Document Premptive Call Me Maybe HBase findings in the online manual
  • [HBASE-11911] - Break up tests into more fine grained categories
  • [HBASE-11912] - Catch some bad practices at compile time with error-prone
  • [HBASE-11975] - Remove the explicit list of maven repositories in pom.xml
  • [HBASE-11986] - Document MOB in Ref Guide
  • [HBASE-12000] - isMob and mobThreshold do not follow column descriptor property naming conventions
  • [HBASE-12012] - Improve cancellation for the scan RPCs
  • [HBASE-12015] - Not cleaning Mob data when Mob CF is removed from table
  • [HBASE-12048] - Remove deprecated APIs from Filter
  • [HBASE-12066] - Avoid major compaction in TestMobSweeper
  • [HBASE-12080] - Shorten the run time of integration test by default when using mvn failsafe:integration-test
  • [HBASE-12084] - Remove deprecated APIs from Result
  • [HBASE-12085] - mob status should print human readable numbers.
  • [HBASE-12093] - Support the mob attributes in hbase shell when create/alter table
  • [HBASE-12094] - Clean the code after adding IS_MOB and MOB_THRESHOLD to column family
  • [HBASE-12111] - Remove deprecated APIs from Mutation(s)
  • [HBASE-12148] - Remove TimeRangeTracker as point of contention when many threads writing a Store
  • [HBASE-12260] - MasterServices needs a short-back-and-sides; pare-back exposure of internals and IA.Private classes
  • [HBASE-12295] - Prevent block eviction under us if reads are in progress from the BBs
  • [HBASE-12296] - Filters should work with ByteBufferedCell
  • [HBASE-12331] - Shorten the mob snapshot unit tests
  • [HBASE-12332] - [mob] improve how we resolve mobfiles in reads
  • [HBASE-12343] - Document recommended configuration for 0.98 from HBASE-11964
  • [HBASE-12345] - Unsafe based ByteBuffer Comparator
  • [HBASE-12374] - Change DBEs to work with new BB based cell
  • [HBASE-12382] - Restore incremental compilation
  • [HBASE-12391] - Correct a typo in the mob metrics
  • [HBASE-12392] - Incorrect implementation of CompactionRequest.isRetainDeleteMarkers
  • [HBASE-12425] - Document the phases of the split transaction
  • [HBASE-12486] - Move the mob table name tag to the 2nd one
  • [HBASE-12487] - Explicitly flush the file name in sweep job
  • [HBASE-12489] - Incorrect 'mobFileCacheMissCount' calculated in the mob metrics
  • [HBASE-12523] - Update checkstyle plugin rules to match our use
  • [HBASE-12528] - Document the newly introduced params for providing principal and keytabs.
  • [HBASE-12543] - Incorrect log info in the store compaction of mob
  • [HBASE-12561] - Replicas of regions can be cached from different instances of the table in MetaCache
  • [HBASE-12562] - Handling memory pressure for secondary region replicas
  • [HBASE-12591] - Ignore the count of mob compaction metrics when there is issue
  • [HBASE-12593] - Tags to work with ByteBuffer
  • [HBASE-12646] - SnapshotInfo tool does not find mob data in snapshots
  • [HBASE-12648] - Document per cell TTLs
  • [HBASE-12669] - Have compaction scanner save info about delete markers
  • [HBASE-12670] - Add unit tests that exercise the added hfilelink link mob paths
  • [HBASE-12673] - Add a UT to read mob file when the mob hfile moving from the mob dir to the archive dir
  • [HBASE-12691] - sweep job needs to exit non-zero if job fails for any reason.
  • [HBASE-12695] - JDK 1.8 compilation broken
  • [HBASE-12698] - Add mob cell count to the metadata of each mob file
  • [HBASE-12708] - Document newly introduced params for using Thrift-over-HTTPS.
  • [HBASE-12714] - RegionReplicaReplicationEndpoint should not set the RPC Codec
  • [HBASE-12738] - Chunk Ref Guide into file-per-chapter
  • [HBASE-12748] - RegionCoprocessorHost.execOperation creates too many iterator objects
  • [HBASE-12758] - treat mob region as any other region when generating rs manifest.
  • [HBASE-12820] - Use table lock instead of MobZookeeper
  • [HBASE-12848] - Utilize Flash storage for WAL
  • [HBASE-12936] - Quota support for namespace should take region merge into account
  • [HBASE-13006] - Document visibility label support for groups
  • [HBASE-13012] - Add shell commands to trigger the mob file compactor
  • [HBASE-13013] - Add read lock to ExpiredMobFileCleanerChore
  • [HBASE-13067] - Fix caching of stubs to allow IP address changes of restarted remote servers
  • [HBASE-13095] - Document how to retrieve replication stats from HBase Shell
  • [HBASE-13107] - Refactor MOB Snapshot logic to reduce code duplication.
  • [HBASE-13108] - Reduce Connection creations in TestAcidGuarantees
  • [HBASE-13117] - improve mob sweeper javadoc
  • [HBASE-13121] - Async wal replication for region replicas and dist log replay does not work together
  • [HBASE-13130] - Add timeouts on TestMasterObserver, a frequent zombie show
  • [HBASE-13151] - IllegalArgumentException in compaction when table has a namespace
  • [HBASE-13152] - NPE in ExpiredMobFileCleanerChore
  • [HBASE-13154] - Add support for mob in TestAcidGuarantees and IntegrationTestAcidGuarantees
  • [HBASE-13157] - Add mob compaction actions and monkeys to Chaos Monkey
  • [HBASE-13164] - Update TestUsersOperationsWithSecureHadoop to use MiniKdc
  • [HBASE-13169] - ModifyTable increasing the region replica count should also auto-setup RRRE
  • [HBASE-13184] - Document turning off memstore for region replicas
  • [HBASE-13198] - Remove HConnectionManager
  • [HBASE-13201] - Remove HTablePool from thrift-server
  • [HBASE-13202] - Procedure v2 - core framework
  • [HBASE-13203] - Procedure v2 - master create/delete table
  • [HBASE-13204] - Procedure v2 - client create/delete table sync
  • [HBASE-13209] - Procedure V2 - master Add/Modify/Delete Column Family
  • [HBASE-13210] - Procedure V2 - master Modify table
  • [HBASE-13211] - Procedure V2 - master Enable/Disable table
  • [HBASE-13212] - Procedure V2 - master Create/Modify/Delete namespace
  • [HBASE-13213] - Split out locality metrics among primary and secondary region
  • [HBASE-13214] - Remove deprecated and unused methods from HTable class
  • [HBASE-13226] - Document enable_table_replication and disable_table_replication shell commands
  • [HBASE-13230] - [mob] reads hang when trying to read rows with large mobs (>10MB)
  • [HBASE-13244] - Test delegation token generation with kerberos enabled
  • [HBASE-13248] - Make HConnectionImplementation top-level class.
  • [HBASE-13252] - Get rid of managed connections and connection caching
  • [HBASE-13258] - Promote TestHRegion to LargeTests
  • [HBASE-13277] - add mob_threshold option to load test tool
  • [HBASE-13290] - Procedure v2 - client enable/disable table sync
  • [HBASE-13302] - fix new javadoc warns introduced by mob.
  • [HBASE-13303] - Fix size calculation of results on the region server
  • [HBASE-13307] - Making methods under ScannerV2#next inlineable, faster
  • [HBASE-13313] - Skip the disabled table in mob compaction chore and MasterRpcServices
  • [HBASE-13327] - Use Admin in ConnectionCache
  • [HBASE-13332] - Fix the usage of doAs/runAs in Visibility Controller tests.
  • [HBASE-13335] - Update ClientSmallScanner and ClientSmallReversedScanner
  • [HBASE-13387] - Add ByteBufferedCell an extension to Cell
  • [HBASE-13393] - Optimize memstore flushing to avoid writing tag information to hfiles when no tags are present.
  • [HBASE-13395] - Remove HTableInterface
  • [HBASE-13398] - Document HBase Quota
  • [HBASE-13415] - Procedure V2 - Use nonces for double submits from client
  • [HBASE-13421] - Reduce the number of object creations introduced by HBASE-11544 in scan RPC hot code paths
  • [HBASE-13429] - Remove deprecated seek/reseek methods from HFileScanner
  • [HBASE-13447] - Bypass logic in TimeRange.compare
  • [HBASE-13448] - New Cell implementation with cached component offsets/lengths
  • [HBASE-13450] - Purge RawBytescomparator from the writers and readers for HBASE-10800
  • [HBASE-13451] - Make the HFileBlockIndex blockKeys to Cells so that it could be easy to use in the CellComparators
  • [HBASE-13455] - Procedure V2 - master truncate table
  • [HBASE-13464] - Remove deprecations for 2.0.0 - Part 1
  • [HBASE-13466] - Document deprecations in 1.x - Part 1
  • [HBASE-13470] - High level Integration test for master DDL operations
  • [HBASE-13476] - Procedure V2 - Add Replay Order logic for child procedures
  • [HBASE-13478] - Document the change of default master ports being used .
  • [HBASE-13481] - Master should respect master (old) DNS/bind related configurations
  • [HBASE-13496] - Make Bytes$LexicographicalComparerHolder$UnsafeComparer::compareTo inlineable
  • [HBASE-13497] - Remove MVCC stamps from HFile when that is safe
  • [HBASE-13498] - Add more docs and a basic check for storage policy handling
  • [HBASE-13501] - Deprecate/Remove getComparator() in HRegionInfo.
  • [HBASE-13502] - Deprecate/remove getRowComparator() in TableName
  • [HBASE-13510] - Purge ByteBloomFilter
  • [HBASE-13514] - Fix test failures in TestScannerHeartbeatMessages caused by incorrect setting of hbase.rpc.timeout
  • [HBASE-13515] - Handle FileNotFoundException in region replica replay for flush/compaction events
  • [HBASE-13529] - Procedure v2 - WAL Improvements
  • [HBASE-13531] - Flakey failures of TestAcidGuarantees#testMobScanAtomicity
  • [HBASE-13536] - Cleanup the handlers that are no longer being used.
  • [HBASE-13537] - Procedure V2 - Change the admin interface for async operations to return Future (incompatible with branch-1.x)
  • [HBASE-13538] - Procedure v2 - client add/delete/modify column family sync (incompatible with branch-1.x)
  • [HBASE-13551] - Procedure V2 - Procedure classes should not be InterfaceAudience.Public
  • [HBASE-13563] - Add missing table owner to AC tests.
  • [HBASE-13569] - correct errors reported with mvn site
  • [HBASE-13571] - Procedure v2 - client modify table sync (incompatible with branch-1.x)
  • [HBASE-13572] - Procedure v2 - client truncate table sync (incompatible with branch-1.x)
  • [HBASE-13579] - Avoid isCellTTLExpired() for NO-TAG cases
  • [HBASE-13593] - Quota support for namespace should take snapshot restore and clone into account
  • [HBASE-13614] - Avoid temp KeyOnlyKeyValue temp objects creations in read hot path
  • [HBASE-13616] - Move ServerShutdownHandler to Pv2
  • [HBASE-13620] - Bring back the removed VisibilityClient methods and mark them as deprecated.
  • [HBASE-13636] - Remove deprecation for HBASE-4072 (Reading of zoo.cfg)
  • [HBASE-13641] - Deperecate Filter#filterRowKey(byte[] buffer, int offset, int length) in favor of filterRowKey(Cell firstRowCell)
  • [HBASE-13642] - Deprecate RegionObserver#postScannerFilterRow CP hook with byte[],int,int args in favor of taking Cell arg
  • [HBASE-13658] - Improve the test run time for TestAccessController class
  • [HBASE-13679] - Change ColumnTracker and SQM to deal with Cell instead of byte[], int, int
  • [HBASE-13720] - Mob files are not encrypting in mob compaction and Sweeper
  • [HBASE-13728] - Remove use of Hadoop's GenericOptionsParser
  • [HBASE-13736] - Add delay for the first execution of ExpiredMobFileCleanerChore and MobFileCompactorChore
  • [HBASE-13739] - Remove KeyValueUtil.ensureKeyValue(cell) from MOB code.
  • [HBASE-13754] - Allow non KeyValue Cell types also to oswrite
  • [HBASE-13759] - Improve procedure yielding
  • [HBASE-13762] - Use the same HFileContext with store files in mob files
  • [HBASE-13763] - Handle the rename, annotation and typo stuff in MOB
  • [HBASE-13790] - Remove the DeleteTableHandler
  • [HBASE-13791] - Remove the DeleteTableHandler
  • [HBASE-13803] - Disable the MobCompactionChore when the interval is not larger than 0
  • [HBASE-13804] - Revert the changes in pom.xml
  • [HBASE-13805] - Use LimitInputStream in hbase-common instead of ProtobufUtil.LimitedInputStream
  • [HBASE-13806] - Check the mob files when there are mob-enabled columns in HFileCorruptionChecker
  • [HBASE-13817] - ByteBufferOuputStream - add writeInt support
  • [HBASE-13819] - Make RPC layer CellBlock buffer a DirectByteBuffer
  • [HBASE-13823] - Procedure V2: unnecessaery operations on AssignmentManager#recoverTableInDisablingState() and recoverTableInEnablingState()
  • [HBASE-13827] - Delayed scanner close in KeyValueHeap and StoreScanner
  • [HBASE-13832] - Procedure V2: master fail to start due to WALProcedureStore sync failures when HDFS data nodes count is low
  • [HBASE-13836] - Do not reset the mvcc for bulk loaded mob reference cells in reading
  • [HBASE-13855] - Race in multi threaded PartitionedMobCompactor causes NPE
  • [HBASE-13856] - Wrong mob metrics names in TestRegionServerMetrics
  • [HBASE-13871] - Change RegionScannerImpl to deal with Cell instead of byte[], int, int
  • [HBASE-13886] - Return empty value when the mob file is corrupt instead of throwing exceptions
  • [HBASE-13898] - correct additional javadoc failures under java 8
  • [HBASE-13899] - Jacoco instrumentation fails under jdk8
  • [HBASE-13910] - add branch-1.2 to precommit branches
  • [HBASE-13911] - add 1.2 to prereq tables in ref guide
  • [HBASE-13916] - Create MultiByteBuffer an aggregation of ByteBuffers
  • [HBASE-13920] - Exclude Java files generated from protobuf from javadoc
  • [HBASE-13922] - Do not reset mvcc in compactions for mob-enabled column
  • [HBASE-13926] - Close the scanner only after Call#setResponse
  • [HBASE-13932] - Add mob integrity check in HFilePrettyPrinter
  • [HBASE-13939] - Make HFileReaderImpl.getFirstKeyInBlock() to return a Cell
  • [HBASE-13950] - Add a NoopProcedureStore for testing
  • [HBASE-13954] - Remove HTableInterface#getRowOrBefore related server side code
  • [HBASE-13963] - avoid leaking jdk.tools
  • [HBASE-13967] - add jdk profiles for jdk.tools dependency
  • [HBASE-13968] - Remove deprecated methods from BufferedMutator class
  • [HBASE-13973] - Update documentation for 10070 Phase 2 changes
  • [HBASE-13975] - add 1.2 RM to docs
  • [HBASE-13977] - Convert getKey and related APIs to Cell
  • [HBASE-13983] - Doc how the oddball HTable methods getStartKey, getEndKey, etc. will be removed in 2.0.0
  • [HBASE-13990] - clean up remaining errors for maven site goal
  • [HBASE-13993] - WALProcedureStore fencing is not effective if new WAL rolls
  • [HBASE-13998] - Remove CellComparator#compareRows(byte[] left, int loffset, int llength, byte[] right, int roffset, int rlength)
  • [HBASE-14003] - work around jdk8 spec bug in WALPerfEval
  • [HBASE-14013] - Retry when RegionServerNotYetRunningException rather than go ahead with assign so for sure we don't skip WAL replay
  • [HBASE-14017] - Procedure v2 - MasterProcedureQueue fix concurrency issue on table queue deletion
  • [HBASE-14020] - Unsafe based optimized write in ByteBufferOutputStream
  • [HBASE-14051] - Undo workarounds in IntegrationTestDDLMasterFailover for client double submit
  • [HBASE-14061] - Support CF-level Storage Policy
  • [HBASE-14063] - Use BufferBackedCell in read path after HBASE-12213 and HBASE-12295
  • [HBASE-14086] - remove unused bundled dependencies
  • [HBASE-14087] - ensure correct ASF policy compliant headers on source/docs
  • [HBASE-14102] - Add thank you to our thanks page for vectorportal.com
  • [HBASE-14104] - Add vectorportal.com to NOTICES.txt as src of our logo
  • [HBASE-14105] - Add shell tests for Snapshot
  • [HBASE-14107] - Procedure V2 - Administrative Task: Provide an API to List all procedures
  • [HBASE-14108] - Procedure V2 - Administrative Task: provide an API to abort a procedure
  • [HBASE-14116] - Change ByteBuff.getXXXStrictlyForward to relative position based reads
  • [HBASE-14120] - ByteBufferUtils#compareTo small optimization
  • [HBASE-14144] - Bloomfilter path to work with Byte buffered cells
  • [HBASE-14147] - REST Support for Namespaces
  • [HBASE-14176] - Add missing headers to META-INF files
  • [HBASE-14186] - Read mvcc vlong optimization
  • [HBASE-14188] - Read path optimizations after HBASE-11425 profiling
  • [HBASE-14202] - Reduce garbage we create
  • [HBASE-14212] - Add IT test for procedure-v2-based namespace DDL
  • [HBASE-14221] - Reduce the number of time row comparison is done in a Scan
  • [HBASE-14239] - Branch-1.2 AM can get stuck when meta moves
  • [HBASE-14274] - Deadlock in region metrics on shutdown: MetricsRegionSourceImpl vs MetricsRegionAggregateSourceImpl
  • [HBASE-14278] - Fix NPE that is showing up since HBASE-14274 went in
  • [HBASE-14322] - Master still not using more than it's priority threads
  • [HBASE-14368] - New TestWALLockup broken by addendum added to parent issue
  • [HBASE-14378] - Get TestAccessController* passing again on branch-1
  • [HBASE-14395] - Short circuit last byte check in CellUtil#matchingXXX methods for ByteBufferedCells
  • [HBASE-14398] - Create the fake keys required in the scan path to avoid copy to byte[]
  • [HBASE-14401] - Stamp failed appends with sequenceid too.... Cleans up latches
  • [HBASE-14421] - TestFastFail* are flakey
  • [HBASE-14423] - TestStochasticBalancerJmxMetrics.testJmxMetrics_PerTableMode:183 NullPointer
  • [HBASE-14428] - Upgrade our surefire-plugin from 2.18 to 2.18.1
  • [HBASE-14430] - TestHttpServerLifecycle#testStartedServerIsAlive times out
  • [HBASE-14432] - Procedure V2 - enforce ACL on procedure admin tasks
  • [HBASE-14433] - Set down the client executor core thread count from 256 in tests
  • [HBASE-14435] - thrift tests don't have test-specific hbase-site.xml so 'BindException: Address already in use' because info port is not turned off
  • [HBASE-14447] - Spark tests failing: bind exception when putting up info server
  • [HBASE-14464] - Removed unused fs code
  • [HBASE-14472] - TestHCM and TestRegionServerNoMaster fixes
  • [HBASE-14480] - Small optimization in SingleByteBuff
  • [HBASE-14484] - Follow-on from HBASE-14421, just disable TestFastFail* until someone digs in and fixes it
  • [HBASE-14487] - Procedure V2 - shell command to list all procedures
  • [HBASE-14488] - Procedure V2 - shell command to abort a procedure
  • [HBASE-14495] - TestHRegion#testFlushCacheWhileScanning goes zombie
  • [HBASE-14507] - Disable TestDistributedLogSplitting#testWorkerAbort Its flakey with tenuous chance of success
  • [HBASE-14513] - TestBucketCache runs obnoxious 1k threads in a unit test
  • [HBASE-14519] - Purge TestFavoredNodeAssignmentHelper, a test for an abandoned feature that can hang
  • [HBASE-14535] - Integration test for rpc connection concurrency / deadlock testing
  • [HBASE-14539] - Slight improvement of StoreScanner.optimize
  • [HBASE-14543] - Have findHangingTests.py dump more info
  • [HBASE-14551] - Procedure v2 - Reimplement split
  • [HBASE-14552] - Procedure V2: Reimplement DispatchMergingRegionHandler
  • [HBASE-14558] - Document ChaosMonkey enhancements from HBASE-14261
  • [HBASE-14559] - branch-1 test tweeks; disable assert explicit region lands post-restart and up a few handlers
  • [HBASE-14561] - Disable zombie TestReplicationShell
  • [HBASE-14563] - Disable zombie TestHFileOutputFormat2
  • [HBASE-14567] - Tuneup hanging test TestMobCompactor and TestMobSweeper
  • [HBASE-14570] - Split TestHBaseFsck in order to help with hanging tests
  • [HBASE-14571] - Purge TestProcessBasedCluster; it does nothing and then fails
  • [HBASE-14572] - TestImportExport#testImport94Table can't find its src data file
  • [HBASE-14575] - Relax region read lock for compactions
  • [HBASE-14585] - Clean up TestSnapshotCloneIndependence
  • [HBASE-14589] - Looking 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?
  • [HBASE-14590] - Shorten ByteBufferedCell#getXXXPositionInByteBuffer method name
  • [HBASE-14595] - For Wiki contents that are also in the Ref Guide, replace content with a URL
  • [HBASE-14596] - TestCellACLs failing... on1.2 builds
  • [HBASE-14600] - Make #testWalRollOnLowReplication looser still
  • [HBASE-14601] - Create list of Wiki contents missing from the Ref Guide
  • [HBASE-14602] - Convert HBasePoweredBy Wiki page to a hbase.apache.org page
  • [HBASE-14605] - Split fails due to 'No valid credentials' error when SecureBulkLoadEndpoint#start tries to access hdfs
  • [HBASE-14607] - Convert SupportingProjects wiki page to a site page
  • [HBASE-14614] - Procedure v2: Core Assignment Manager
  • [HBASE-14615] - Procedure V2: Implement single region assignment procedure from Master-side
  • [HBASE-14616] - Procedure v2: Replace the old AM with the new AM
  • [HBASE-14617] - Procedure V2: Update ServerCrashProcedure to interact with assignment procedures
  • [HBASE-14618] - Procedure V2: Implement move shell command to use Proc-V2 assignment
  • [HBASE-14620] - Procedure V2: Update HBCK to incorporate the Proc-V2-based assignment
  • [HBASE-14627] - Move Stargate docs to Ref Guide
  • [HBASE-14631] - Region merge request should be audited with request user through proper scope of doAs() calls to region observer notifications
  • [HBASE-14636] - Clear HFileScannerImpl#prevBlocks in between Compaction flow
  • [HBASE-14637] - Loosen TestChoreService assert AND have TestDataBlockEncoders do less work (and add timeouts)
  • [HBASE-14638] - Move Jython info from the Wiki to the Ref Guide
  • [HBASE-14639] - Move Scala info from Wiki to Ref Guide
  • [HBASE-14640] - Move Cascading info from Wiki to Ref Guide
  • [HBASE-14641] - Move JDO example from Wiki to Ref Guide
  • [HBASE-14646] - Move TestCellACLs from medium to large category
  • [HBASE-14647] - Disable TestWALProcedureStoreOnHDFS#testWalRollOnLowReplication
  • [HBASE-14648] - Reenable TestWALProcedureStoreOnHDFS#testWalRollOnLowReplication
  • [HBASE-14655] - Narrow the scope of doAs() calls to region observer notifications for compaction
  • [HBASE-14657] - Remove unneeded API from EncodedSeeker
  • [HBASE-14662] - Fix NPE in HFileOutputFormat2
  • [HBASE-14685] - Procedure Id is not set for MasterRpcServices#modifyTable
  • [HBASE-14698] - Set category timeouts on TestScanner and TestNamespaceAuditor
  • [HBASE-14702] - TestZKProcedureControllers.testZKCoordinatorControllerWithSingleMemberCohort is a flakey
  • [HBASE-14709] - Parent change breaks graceful_stop.sh on a cluster
  • [HBASE-14710] - Add category-based timeouts to MR tests
  • [HBASE-14720] - Make TestHCM and TestMetaWithReplicas large tests rather than mediums
  • [HBASE-14725] - Vet categorization of tests so they for sure go into the right small/medium/large buckets
  • [HBASE-14734] - BindException when setting up MiniKdc
  • [HBASE-14772] - Improve zombie detector; be more discerning
  • [HBASE-14785] - Hamburger menu for mobile site
  • [HBASE-14786] - TestProcedureAdmin hangs
  • [HBASE-14794] - Cleanup TestAtomicOperation, TestImportExport, and TestMetaWithReplicas
  • [HBASE-14798] - NPE reporting server load causes regionserver abort; causes TestAcidGuarantee to fail
  • [HBASE-14819] - hbase-it tests failing with OOME; permgen
  • [HBASE-14832] - Ensure write paths work with ByteBufferedCells in case of compaction
  • [HBASE-14837] - Procedure V2 - Procedure Queue Improvement
  • [HBASE-14841] - Allow Dictionary to work with BytebufferedCells
  • [HBASE-14863] - Add missing test/resources/log4j files in hbase modules
  • [HBASE-14877] - maven archetype: client application
  • [HBASE-14878] - maven archetype: client application with shaded jars
  • [HBASE-14884] - TestSplitTransactionOnCluster.testSSHCleanupDaugtherRegionsOfAbortedSplit is flakey
  • [HBASE-14888] - ClusterSchema: Add Namespace Operations
  • [HBASE-14895] - Seek only to the newly flushed file on scanner reset on flush
  • [HBASE-14902] - Revert some of the stringency recently introduced by checkstyle tightening
  • [HBASE-14908] - TestRowCounter flakey especially on branch-1
  • [HBASE-14909] - NPE testing for RIT
  • [HBASE-14919] - Infrastructure refactoring for In-Memory Flush
  • [HBASE-14920] - Compacting Memstore
  • [HBASE-14921] - Inmemory Compaction Optimizations; Segment Structure
  • [HBASE-14947] - Procedure V2 - WALProcedureStore improvements
  • [HBASE-14949] - Resolve name conflict when splitting if there are duplicated WAL entries
  • [HBASE-14962] - TestSplitWalDataLoss fails on all branches
  • [HBASE-14997] - Move compareOp and Comparators out of filter to client package
  • [HBASE-14998] - Unify synchronous and asynchronous methods in Admin and cleanup
  • [HBASE-15016] - StoreServices facility in Region
  • [HBASE-15023] - Reenable TestShell and TestStochasticLoadBalancer
  • [HBASE-15046] - Perf test doing all mutation steps under row lock
  • [HBASE-15071] - Cleanup bypass semantic in MasterCoprocessorHost
  • [HBASE-15072] - Use protobuf for serialization/deserialization.
  • [HBASE-15077] - Support OffheapKV write in compaction with out copying data on heap
  • [HBASE-15082] - Fix merge of MVCC and SequenceID performance regression
  • [HBASE-15087] - Fix hbase-common findbugs complaints
  • [HBASE-15094] - Selection of WAL files eligible for incremental backup is broken
  • [HBASE-15095] - isReturnResult=false on fast path in branch-1.1 and branch-1.0 is not respected
  • [HBASE-15105] - Procedure V2 - Procedure Queue with Namespaces
  • [HBASE-15106] - Procedure V2 - Procedure Queue pass Procedure for better debuggability
  • [HBASE-15107] - Procedure V2 - Procedure Queue with Regions
  • [HBASE-15113] - Procedure v2 - Speedup eviction of sys operation results
  • [HBASE-15114] - NPE when IPC server ByteBuffer reservoir is turned off
  • [HBASE-15115] - Fix findbugs complaints in hbase-client
  • [HBASE-15118] - Fix findbugs complaint in hbase-server
  • [HBASE-15142] - Procedure v2 - Basic WebUI listing the procedures
  • [HBASE-15143] - Procedure v2 - Web UI displaying queues
  • [HBASE-15144] - Procedure v2 - Web UI displaying Store state
  • [HBASE-15157] - Add *PerformanceTest for Append, CheckAnd*
  • [HBASE-15158] - Change order in which we do write pipeline operations; do all under row locks!
  • [HBASE-15160] - Put back HFile's HDFS op latency sampling code and add metrics for monitoring
  • [HBASE-15163] - Add sampling code and metrics for get/scan/multi/mutate count separately
  • [HBASE-15171] - Avoid counting duplicate kv and generating lots of small hfiles in PutSortReducer
  • [HBASE-15172] - Support setting storage policy in bulkload
  • [HBASE-15174] - Client Public API should not have PB objects in 2.0
  • [HBASE-15180] - Reduce garbage created while reading Cells from Codec Decoder
  • [HBASE-15194] - TestStochasticLoadBalancer.testRegionReplicationOnMidClusterSameHosts flaky on trunk
  • [HBASE-15202] - Reduce garbage while setting response
  • [HBASE-15203] - Reduce garbage created by path.toString() during Checksum verification
  • [HBASE-15204] - Try to estimate the cell count for adding into WALEdit
  • [HBASE-15205] - Do not find the replication scope for every WAL#append()
  • [HBASE-15210] - Undo aggressive load balancer logging at tens of lines per millisecond
  • [HBASE-15215] - TestBlockEvictionFromClient is flaky in jdk1.7 build
  • [HBASE-15232] - Exceptions returned over multi RPC don't automatically trigger region location reloads
  • [HBASE-15238] - HFileReaderV2 prefetch overreaches; runs off the end of the data
  • [HBASE-15239] - Remove unused LoadBalancer.immediateAssignment()
  • [HBASE-15244] - More doc around native lib setup and check and crc
  • [HBASE-15263] - TestIPv6NIOServerSocketChannel.testServerSocketFromLocalhostResolution can hang indefinetly
  • [HBASE-15264] - Implement a fan out HDFS OutputStream
  • [HBASE-15265] - Implement an asynchronous FSHLog
  • [HBASE-15270] - Use appropriate encoding for "filter" field in TaskMonitorTmpl.jamon
  • [HBASE-15272] - Add error handling for split and compact actions in table.jsp
  • [HBASE-15277] - TestRegionMergeTransactionOnCluster.testWholesomeMerge fails with no connection to master
  • [HBASE-15293] - Handle TableNotFound and IllegalArgument exceptions in table.jsp
  • [HBASE-15305] - Fix a couple of incorrect anchors in HBase ref guide
  • [HBASE-15311] - Prevent NPE in BlockCacheViewTmpl
  • [HBASE-15314] - Allow more than one backing file in bucketcache
  • [HBASE-15334] - Add avro support for spark hbase connector
  • [HBASE-15337] - Document date tiered compaction in the book
  • [HBASE-15346] - add 1.3 RM to docs
  • [HBASE-15351] - Fix description of hbase.bucketcache.size in hbase-default.xml
  • [HBASE-15354] - Use same criteria for clearing meta cache for all operations
  • [HBASE-15359] - Simplifying Segment hierarchy
  • [HBASE-15365] - Do not write to '/tmp' in TestHBaseConfiguration
  • [HBASE-15366] - Add doc, trace-level logging, and test around hfileblock
  • [HBASE-15368] - Add pluggable window support
  • [HBASE-15369] - Handle NPE in region.jsp
  • [HBASE-15371] - Procedure V2 - Completed support parent-child procedure
  • [HBASE-15373] - DEPRECATED_NAME_OF_NO_LIMIT_THROUGHPUT_CONTROLLER_CLASS value is wrong in CompactionThroughputControllerFactory
  • [HBASE-15375] - Do not write to '/tmp' in TestRegionMover
  • [HBASE-15376] - ScanNext metric is size-based while every other per-operation metric is time based
  • [HBASE-15377] - Per-RS Get metric is time based, per-region metric is size-based
  • [HBASE-15380] - Purge rollback support in Store etc.
  • [HBASE-15384] - Avoid using '/tmp' directory in TestBulkLoad
  • [HBASE-15386] - PREFETCH_BLOCKS_ON_OPEN in HColumnDescriptor is ignored
  • [HBASE-15389] - Write out multiple files when compaction
  • [HBASE-15390] - Unnecessary MetaCache evictions cause elevated number of requests to meta
  • [HBASE-15392] - Single Cell Get reads two HFileBlocks
  • [HBASE-15400] - Use DateTieredCompactor for Date Tiered Compaction
  • [HBASE-15407] - Add SASL support for fan out OutputStream
  • [HBASE-15412] - Add average region size metric
  • [HBASE-15416] - TestHFileBackedByBucketCache is flakey since it went in
  • [HBASE-15421] - Convert TestStoreScanner to junit4 from junit3 and clean up close of scanners
  • [HBASE-15422] - Procedure v2 - Avoid double yield
  • [HBASE-15435] - Add WAL (in bytes) written metric
  • [HBASE-15460] - Fix infer issues in hbase-common
  • [HBASE-15464] - Flush / Compaction metrics revisited
  • [HBASE-15477] - Do not save 'next block header' when we cache hfileblocks
  • [HBASE-15479] - No more garbage or beware of autoboxing
  • [HBASE-15484] - Correct the semantic of batch and partial
  • [HBASE-15488] - Add ACL for setting split merge switch
  • [HBASE-15495] - Connection leak in FanOutOneBlockAsyncDFSOutputHelper
  • [HBASE-15505] - ReplicationPeerConfig should be builder-style
  • [HBASE-15513] - hbase.hregion.memstore.chunkpool.maxsize is 0.0 by default
  • [HBASE-15518] - Add Per-Table metrics back
  • [HBASE-15521] - Procedure V2 - RestoreSnapshot and CloneSnapshot
  • [HBASE-15524] - Fix NPE in client-side metrics
  • [HBASE-15525] - OutOfMemory could occur when using BoundedByteBufferPool during RPC bursts
  • [HBASE-15527] - Refactor Compactor related classes
  • [HBASE-15532] - core favored nodes enhancements
  • [HBASE-15536] - Make AsyncFSWAL as our default WAL
  • [HBASE-15537] - Make multi WAL work with WALs other than FSHLog
  • [HBASE-15538] - Implement secure async protobuf wal writer
  • [HBASE-15554] - StoreFile$Writer.appendGeneralBloomFilter generates extra KV
  • [HBASE-15561] - See how G1GC works with MSLAB and chunk pool
  • [HBASE-15568] - Procedure V2 - Remove CreateTableHandler in HBase Apache 2.0 release
  • [HBASE-15575] - Rename table DDL *Handler methods in MasterObserver to more meaningful names
  • [HBASE-15579] - Procedure V2 - Remove synchronized around nonce in Procedure submit
  • [HBASE-15583] - Any HTableDescriptor we give out should be immutable
  • [HBASE-15628] - Implement an AsyncOutputStream which can work with any FileSystem implementation
  • [HBASE-15640] - L1 cache doesn't give fair warning that it is showing partial stats only when it hits limit
  • [HBASE-15651] - Add report-flakies.py to use jenkins api to get failing tests
  • [HBASE-15658] - RegionServerCallable / RpcRetryingCaller clear meta cache on retries
  • [HBASE-15662] - Hook up JvmPauseMonitor to REST server
  • [HBASE-15663] - Hook up JvmPauseMonitor to ThriftServer
  • [HBASE-15665] - Support using different StoreFileComparators for different CompactionPolicies
  • [HBASE-15671] - Add per-table metrics on memstore, storefile and regionsize
  • [HBASE-15675] - Add more details about region on table.jsp
  • [HBASE-15683] - Min latency in latency histograms are emitted as Long.MAX_VALUE
  • [HBASE-15689] - Changes to hbase-personality.sh to include/exclude flaky tests
  • [HBASE-15709] - Handle large edits for asynchronous WAL
  • [HBASE-15721] - Optimization in cloning cells into MSLAB
  • [HBASE-15735] - Tightening of the CP contract
  • [HBASE-15740] - Replication source.shippedKBs metric is undercounting because it is in KB
  • [HBASE-15743] - Add Transparent Data Encryption support for FanOutOneBlockAsyncDFSOutput
  • [HBASE-15754] - Add testcase for AES encryption
  • [HBASE-15763] - Isolate Wal related stuff from MasterFileSystem
  • [HBASE-15776] - Replace master.am.getTableStateManager() with the direct master.getTableStateManager()
  • [HBASE-15778] - replace master.am and master.sm direct access with getter calls
  • [HBASE-15785] - Unnecessary lock in ByteBufferArray
  • [HBASE-15786] - Create DBB backed MSLAB pool
  • [HBASE-15787] - Change the flush related heuristics to work with offheap size configured
  • [HBASE-15788] - Use Offheap ByteBuffers from BufferPool to read RPC requests.
  • [HBASE-15789] - PB related changes to work with offheap
  • [HBASE-15813] - Rename DefaultWALProvider to a more specific name and clean up unnecessary reference to it
  • [HBASE-15825] - Fix the null pointer in DynamicLogicExpressionSuite
  • [HBASE-15865] - Move TestTableDeleteFamilyHandler and TestTableDescriptorModification handler tests to procedure
  • [HBASE-15872] - Split TestWALProcedureStore
  • [HBASE-15883] - Adding WAL files and tracking offsets in HBase.
  • [HBASE-15896] - Add timeout tests to flaky list from report-flakies.py
  • [HBASE-15915] - Set timeouts on hanging tests
  • [HBASE-15917] - Flaky tests dashboard
  • [HBASE-15919] - Document @Rule vs @ClassRule. Also clarify timeout limits are on TestCase.
  • [HBASE-15927] - Remove HMaster.assignRegion()
  • [HBASE-15935] - Have a separate Walker task running concurrently with Generator
  • [HBASE-15948] - Port "HADOOP-9956 RPC listener inefficiently assigns connections to readers"
  • [HBASE-15971] - Regression: Random Read/WorkloadC slower in 1.x than 0.98
  • [HBASE-15974] - Create a ReplicationQueuesClientHBaseImpl
  • [HBASE-15984] - Given failure to parse a given WAL that was closed cleanly, replay the WAL.
  • [HBASE-15985] - clarify promises about edits from replication in ref guide
  • [HBASE-15991] - CompactingMemstore#InMemoryFlushRunnable should implement Comparable/Comparator
  • [HBASE-15994] - Allow selection of RpcSchedulers
  • [HBASE-15995] - Separate replication WAL reading from shipping
  • [HBASE-15999] - NPE in MemstoreCompactor
  • [HBASE-16023] - Fastpath for the FIFO rpcscheduler
  • [HBASE-16034] - Fix ProcedureTestingUtility#LoadCounter.setMaxProcId()
  • [HBASE-16036] - Fix ReplicationTableBase initialization to make it non-blocking
  • [HBASE-16038] - Ignore JVM crashes or machine shutdown failures in report-flakies
  • [HBASE-16056] - Procedure v2 - fix master crash for FileNotFound
  • [HBASE-16068] - Procedure v2 - use consts for conf properties in tests
  • [HBASE-16080] - Fix flakey tests
  • [HBASE-16082] - Procedure v2 - Move out helpers from MasterProcedureScheduler
  • [HBASE-16083] - Fix table based replication related configs
  • [HBASE-16092] - Procedure v2 - complete child procedure support
  • [HBASE-16094] - Procedure v2 - Improve cleaning up of proc wals
  • [HBASE-16101] - Procedure v2 - Perf Tool for WAL
  • [HBASE-16119] - Procedure v2 - Reimplement merge
  • [HBASE-16121] - Require only MasterServices to the ServerManager constructor
  • [HBASE-16134] - Introduce Cell extension for server side.
  • [HBASE-16143] - Change MemstoreScanner constructor to accept List<KeyValueScanner>
  • [HBASE-16146] - Counters are expensive...
  • [HBASE-16153] - Correct the config name 'hbase.memestore.inmemoryflush.threshold.factor'
  • [HBASE-16155] - Compacting Memstore : Few log improvements
  • [HBASE-16156] - In write heavy scenario creating in memory flushes leads to contention
  • [HBASE-16162] - Compacting Memstore : unnecessary push of active segments to pipeline
  • [HBASE-16163] - Compacting Memstore : CompactionPipeline#addFirst can use LinkedList#addFirst
  • [HBASE-16164] - Missing close of new compacted segments in few occasions which might leak MSLAB chunks from pool
  • [HBASE-16166] - Create a memstore impl that does not compact but creates pipelines and flushes all segments from pipeline
  • [HBASE-16167] - Verify the sizing part of Compacting Memstore.
  • [HBASE-16169] - Make RegionSizeCalculator scalable
  • [HBASE-16176] - Bug fixes/improvements on HBASE-15650 Remove TimeRangeTracker as point of contention when many threads reading a StoreFile
  • [HBASE-16181] - Allow snapshot of hbase:backup table
  • [HBASE-16194] - Should count in MSLAB chunk allocation into heap size change when adding duplicate cells
  • [HBASE-16195] - Should not add chunk into chunkQueue if not using chunk pool in HeapMemStoreLAB
  • [HBASE-16205] - When Cells are not copied to MSLAB, deep clone it while adding to Memstore
  • [HBASE-16208] - Make TableBasedReplicationQueuesImpl check that queue exists before attempting to remove it
  • [HBASE-16214] - Add in UI description of Replication Table
  • [HBASE-16217] - Identify calling user in ObserverContext
  • [HBASE-16219] - Move meta bootstrap out of HMaster
  • [HBASE-16229] - Cleaning up size and heapSize calculation
  • [HBASE-16233] - Procedure V2: Support acquire/release shared table lock concurrently
  • [HBASE-16236] - Typo in javadoc of InstancePending
  • [HBASE-16242] - Upgrade Avro to 1.7.7
  • [HBASE-16257] - Move staging dir to be under hbase root dir
  • [HBASE-16261] - MultiHFileOutputFormat Enhancement
  • [HBASE-16263] - Move all to do w/ protobuf -- *.proto files and generated classes -- under hbase-protocol
  • [HBASE-16264] - Figure how to deal with endpoints and shaded pb
  • [HBASE-16280] - Use hash based map in SequenceIdAccounting
  • [HBASE-16285] - Drop RPC requests if it must be considered as timeout at client
  • [HBASE-16286] - When TagRewriteCell are not copied to MSLAB, deep clone it while adding to Memstore
  • [HBASE-16308] - Contain protobuf references
  • [HBASE-16311] - Audit log for delete snapshot operation is missing in case of snapshot owner deleting the same
  • [HBASE-16314] - Retry on table snapshot failure during full backup
  • [HBASE-16317] - revert all ESAPI changes
  • [HBASE-16318] - fail build if license isn't in whitelist
  • [HBASE-16321] - Ensure findbugs jsr305 jar isn't present
  • [HBASE-16324] - Remove LegacyScanQueryMatcher
  • [HBASE-16336] - Removing peers seems to be leaving spare queues
  • [HBASE-16372] - References to previous cell in read path should be avoided
  • [HBASE-16378] - Procedure v2 - Make ProcedureException extend HBaseException
  • [HBASE-16392] - Backup delete fault tolerance
  • [HBASE-16398] - optimize HRegion computeHDFSBlocksDistribution
  • [HBASE-16404] - Make DeleteBloomFilters work with BloomContext
  • [HBASE-16405] - Change read path Bloom check to work with Cells with out any copy
  • [HBASE-16407] - Handle MemstoreChunkPool size when HeapMemoryManager tunes memory
  • [HBASE-16417] - In-Memory MemStore Policy for Flattening and Compactions
  • [HBASE-16433] - Remove AsyncRpcChannel related stuffs
  • [HBASE-16435] - Implement RpcChannel for RpcClientImpl
  • [HBASE-16436] - Add the CellChunkMap variant
  • [HBASE-16437] - Refactor MSLAB and Chunkpool to create ChunkIds
  • [HBASE-16438] - Create a cell type so that chunk id is embedded in it
  • [HBASE-16440] - MemstoreChunkPool might cross its maxCount of chunks to pool
  • [HBASE-16445] - Refactor and reimplement RpcClient
  • [HBASE-16451] - Procedure v2 - Test WAL protobuf entry size limit
  • [HBASE-16452] - Procedure v2 - Make ProcedureWALPrettyPrinter extend Tool
  • [HBASE-16474] - Remove dfs.support.append related code and documentation
  • [HBASE-16475] - Remove SequenceFile based WAL
  • [HBASE-16476] - Remove HLogKey
  • [HBASE-16477] - Remove Writable interface and related code from WALEdit/WALKey
  • [HBASE-16479] - Move WALEdit from hbase.regionserver.wal package to hbase.wal package
  • [HBASE-16485] - Procedure V2 - Add support to addChildProcedure() as last "step" in StateMachineProcedure
  • [HBASE-16505] - Save deadline in RpcCallContext according to request's timeout
  • [HBASE-16507] - Procedure v2 - Force DDL operation to always roll forward
  • [HBASE-16510] - Reset RpcController before retry
  • [HBASE-16516] - Revisit the implementation of PayloadCarryingRpcController
  • [HBASE-16519] - Procedure v2 - Avoid sync wait on DDLs operation
  • [HBASE-16522] - Procedure v2 - Cache system user and avoid IOException
  • [HBASE-16524] - Procedure v2 - Compute WALs cleanup on wal modification and not on every sync
  • [HBASE-16526] - Add more ipc tests
  • [HBASE-16530] - Reduce DBE code duplication
  • [HBASE-16531] - Move cell block related code out of IPCUtil
  • [HBASE-16532] - Procedure-V2: Enforce procedure ownership at submission
  • [HBASE-16533] - Procedure v2 - Extract chore from the executor
  • [HBASE-16534] - Procedure v2 - Perf Tool for Scheduler
  • [HBASE-16543] - Separate Create/Modify Table operations from open/reopen regions
  • [HBASE-16548] - Procedure v2 - Add handling of split region transition to the new AM
  • [HBASE-16549] - Procedure v2 - Add new AM metrics
  • [HBASE-16554] - Procedure V2 - Recover 'updated' part of WAL tracker if trailer is corrupted.
  • [HBASE-16570] - Compute region locality in parallel at startup
  • [HBASE-16586] - Procedure v2 - Cleanup sched wait/lock semantic
  • [HBASE-16587] - Procedure v2 - Cleanup suspended proc execution
  • [HBASE-16592] - Unify Delete request with AP
  • [HBASE-16596] - Reduce redundant interfaces in AsyncProcess
  • [HBASE-16608] - Introducing the ability to merge ImmutableSegments without copy-compaction or SQM usage
  • [HBASE-16618] - Procedure v2 - Add base class for table and ns procedures
  • [HBASE-16626] - User customized RegionScanner from 1.X is incompatible with 2.0.0's off-heap part
  • [HBASE-16642] - Procedure V2: Use DelayQueue instead of TimeoutBlockingQueue
  • [HBASE-16648] - [JDK8] Use computeIfAbsent instead of get and putIfAbsent
  • [HBASE-16650] - Wrong usage of BlockCache eviction stat for heap memory tuning
  • [HBASE-16651] - LRUBlockCache#returnBlock should try return block to Victim Handler L2 cache.
  • [HBASE-16695] - Procedure v2 - Support for parent holding locks
  • [HBASE-16735] - Procedure v2 - Fix yield while holding locks
  • [HBASE-16738] - L1 cache caching shared memory HFile block when blocks promoted from L2 to L1
  • [HBASE-16741] - Amend the generate protobufs out-of-band build step to include shade, pulling in protobuf source and a hook for patching protobuf
  • [HBASE-16742] - Add chapter for devs on how we do protobufs going forward
  • [HBASE-16744] - Procedure V2 - Lock procedures to allow clients to acquire locks on tables/namespaces/regions
  • [HBASE-16747] - Track memstore data size and heap overhead separately
  • [HBASE-16758] - Bring back HBaseZeroCopyByteStringer stuff
  • [HBASE-16759] - Avoid ByteString.copyFrom usage wherever possible
  • [HBASE-16760] - Deprecate ByteString related methods in Bytes.java
  • [HBASE-16786] - Procedure V2 - Move ZK-lock's uses to Procedure framework locks (LockProcedure)
  • [HBASE-16788] - Race in compacted file deletion between HStore close() and closeAndArchiveCompactedFiles()
  • [HBASE-16799] - CP exposed Store should not expose unwanted APIs
  • [HBASE-16802] - Procedure v2 - group procedure cleaning
  • [HBASE-16813] - Procedure v2 - Move ProcedureEvent to hbase-procedure module
  • [HBASE-16831] - Procedure V2 - Remove org.apache.hadoop.hbase.zookeeper.lock
  • [HBASE-16834] - Add AsyncConnection support for ConnectionFactory
  • [HBASE-16835] - Revisit the zookeeper usage at client side
  • [HBASE-16836] - Implement increment and append
  • [HBASE-16837] - Implement checkAndPut and checkAndDelete
  • [HBASE-16838] - Implement basic scan
  • [HBASE-16839] - Procedure v2 - Move all protobuf handling to ProcedureUtil
  • [HBASE-16846] - Procedure v2 - executor cleanup
  • [HBASE-16848] - Usage for show_peer_tableCFs command doesn't include peer
  • [HBASE-16851] - User-facing documentation for the In-Memory Compaction feature
  • [HBASE-16864] - Procedure v2 - Fix StateMachineProcedure support for child procs at last step
  • [HBASE-16865] - Procedure v2 - Inherit lock from root proc
  • [HBASE-16867] - Procedure V2 - Check ACLs for remote HBaseLock
  • [HBASE-16871] - Procedure v2 - add waiting procs back to the queue after restart
  • [HBASE-16872] - Implement mutateRow and checkAndMutate
  • [HBASE-16874] - Fix TestMasterFailoverWithProcedures and ensure single proc-executor for kill/restart tests
  • [HBASE-16890] - Analyze the performance of AsyncWAL and fix the same
  • [HBASE-16891] - Try copying to the Netty ByteBuf directly from the WALEdit
  • [HBASE-16892] - Use TableName instead of String in SnapshotDescription
  • [HBASE-16932] - Implement small scan
  • [HBASE-16937] - Replace SnapshotType protobuf conversion when we can directly use the pojo object
  • [HBASE-16941] - FavoredNodes - Split/Merge code paths
  • [HBASE-16942] - Add FavoredStochasticLoadBalancer and FN Candidate generators
  • [HBASE-16945] - Implement AsyncRegionLocator
  • [HBASE-16954] - Unify HTable#checkAndDelete with AP
  • [HBASE-16956] - Refactor FavoredNodePlan to use regionNames as keys
  • [HBASE-16968] - Refactor FanOutOneBlockAsyncDFSOutput
  • [HBASE-16970] - Clarify misleading Scan.java comment about caching
  • [HBASE-16982] - Better integrate Apache CLI in AbstractHBaseTool
  • [HBASE-16984] - Implement getScanner
  • [HBASE-16986] - Add note on how scanner caching has changed since 0.98 to refguid
  • [HBASE-16991] - Make the initialization of AsyncConnection asynchronous
  • [HBASE-16995] - Build client Java API and client protobuf messages
  • [HBASE-16996] - Implement storage/retrieval of filesystem-use quotas into quota table
  • [HBASE-16997] - [Master] Collect table use information from RegionServers
  • [HBASE-16998] - [Master] Analyze table use reports and update quota violations
  • [HBASE-16999] - [Master] Inform RegionServers on size quota violations
  • [HBASE-17000] - [RegionServer] Compute region filesystem space use and report to Master
  • [HBASE-17001] - [RegionServer] Implement enforcement of quota violation policies
  • [HBASE-17002] - [Master] Report quotas and active violations on Master UI and JMX metrics
  • [HBASE-17003] - Update book for filesystem use quotas
  • [HBASE-17008] - Examples to make AsyncClient go down easy
  • [HBASE-17012] - Handle Offheap cells in CompressedKvEncoder
  • [HBASE-17017] - Remove the current per-region latency histogram metrics
  • [HBASE-17021] - Use RingBuffer to reduce the contention in AsyncFSWAL
  • [HBASE-17025] - [Shell] Support space quota get/set via the shell
  • [HBASE-17029] - Procedure v2 - A couple of tweaks to the SplitTableRegionProcedure
  • [HBASE-17030] - Procedure v2 - A couple of tweaks to the SplitTableRegionProcedure
  • [HBASE-17035] - Check why we roll a wal writer at 10MB when the configured roll size is 120M+ with AsyncFSWAL
  • [HBASE-17036] - Unify HTable#checkAndPut with AP
  • [HBASE-17045] - Unify the implementation of small scan and regular scan
  • [HBASE-17048] - Calcuate suitable ByteBuf size when allocating send buffer in FanOutOneBlockAsyncDFSOutput
  • [HBASE-17049] - Do not issue sync request when there are still entries in ringbuffer
  • [HBASE-17050] - Upgrade Apache CLI version from 1.2 to 1.3.1
  • [HBASE-17053] - Remove LogRollerExitedChecker
  • [HBASE-17066] - Procedure v2 - Add handling of merge region transition to the new AM
  • [HBASE-17067] - Procedure v2 - remove tryAcquire*Lock and use wait/wake to make framework event based
  • [HBASE-17068] - Procedure v2 - inherit region locks
  • [HBASE-17071] - Do not initialize MemstoreChunkPool when use mslab option is turned off
  • [HBASE-17073] - Increase the max number of buffers in ByteBufferPool
  • [HBASE-17081] - Flush the entire CompactingMemStore content to disk
  • [HBASE-17085] - AsyncFSWAL may issue unnecessary AsyncDFSOutput.sync
  • [HBASE-17087] - Enable Aliasing for CodedInputStream created by ByteInputByteString#newCodedInput
  • [HBASE-17089] - Add doc on experience running with hedged reads
  • [HBASE-17090] - Procedure v2 - fast wake if nothing else is running
  • [HBASE-17101] - FavoredNodes should not apply to system tables
  • [HBASE-17107] - FN info should be cleaned up on region/table cleanup
  • [HBASE-17111] - Use Apache CLI in SnapshotInfo tool
  • [HBASE-17132] - Cleanup deprecated code for WAL
  • [HBASE-17139] - Remove sweep tool related configs from hbase-default.xml
  • [HBASE-17141] - Introduce a more user-friendly implementation of AsyncTable
  • [HBASE-17142] - Implement multi get
  • [HBASE-17148] - Procedure v2 - add bulk proc submit
  • [HBASE-17149] - Procedure V2 - Fix nonce submission to avoid unnecessary calling coprocessor multiple times
  • [HBASE-17162] - Avoid unconditional call to getXXXArray() in write path
  • [HBASE-17167] - Pass mvcc to client when scan
  • [HBASE-17169] - Remove Cell variants with ShareableMemory
  • [HBASE-17183] - Handle ByteBufferCell while making TagRewriteCell
  • [HBASE-17198] - FN updates during region merge (follow up to Procedure v2 merge)
  • [HBASE-17201] - Edit of HFileBlock comments and javadoc
  • [HBASE-17210] - Set timeout on trying rowlock according to client's RPC timeout
  • [HBASE-17223] - Make COS#newInstance(ByteOutput, int) as public API.
  • [HBASE-17251] - Add a timeout parameter when locating region
  • [HBASE-17259] - Missing functionality to remove space quota
  • [HBASE-17260] - Procedure v2 - Add setOwner() overload taking a User instance
  • [HBASE-17262] - Refactor RpcServer so as to make it extendable and/or pluggable
  • [HBASE-17263] - Netty based rpc server impl
  • [HBASE-17277] - Allow alternate BufferedMutator implementation
  • [HBASE-17281] - FN should use datanode port from hdfs configuration
  • [HBASE-17282] - Reduce the redundant requests to meta table
  • [HBASE-17294] - External Configuration for Memory Compaction
  • [HBASE-17312] - [JDK8] Use default method for Observer Coprocessors
  • [HBASE-17313] - Add BufferedMutatorParams#clone method
  • [HBASE-17316] - Addendum to HBASE-17294, 'External Configuration for Memory Compaction'
  • [HBASE-17320] - Add inclusive/exclusive support for startRow and endRow of scan
  • [HBASE-17334] - Add locate row before/after support for AsyncRegionLocator
  • [HBASE-17335] - enable/disable replication peer requests should be routed through master
  • [HBASE-17336] - get/update replication peer config requests should be routed through master
  • [HBASE-17337] - list replication peers request should be routed through master
  • [HBASE-17338] - Treat Cell data size under global memstore heap size only when that Cell can not be copied to MSLAB
  • [HBASE-17345] - Implement batch
  • [HBASE-17346] - Add coprocessor service support
  • [HBASE-17349] - Add doc for regionserver group-based assignment
  • [HBASE-17350] - Fixup of regionserver group-based assignment
  • [HBASE-17367] - Make HTable#getBufferedMutator thread safe
  • [HBASE-17372] - Make AsyncTable thread safe
  • [HBASE-17373] - Reverse the order of snapshot creation in the CompactingMemStore
  • [HBASE-17388] - Move ReplicationPeer and other replication related PB messages to the replication.proto
  • [HBASE-17389] - Convert all internal usages from ReplicationAdmin to Admin
  • [HBASE-17396] - Add first async admin impl and implement balance methods
  • [HBASE-17402] - TestAsyncTableScan sometimes hangs
  • [HBASE-17409] - Re-fix XSS request issue in JMXJsonServlet
  • [HBASE-17410] - Use isEmpty instead of size() == 0 in hbase-client
  • [HBASE-17416] - Use isEmpty instead of size() == 0 in hbase-protocol-shaded
  • [HBASE-17428] - Expand on shell commands for detailed insight
  • [HBASE-17442] - Move most of the replication related classes from hbase-client to hbase-replication package
  • [HBASE-17443] - Move listReplicated/enableTableRep/disableTableRep methods from ReplicationAdmin to Admin
  • [HBASE-17447] - Automatically delete quota when table is deleted
  • [HBASE-17470] - Remove merge region code from region server
  • [HBASE-17478] - Avoid sending FSUtilization reports to master when quota support is not enabled
  • [HBASE-17480] - Remove split region code from Region Server
  • [HBASE-17483] - Add equals/hashcode for OffheapKeyValue
  • [HBASE-17484] - Add non cached version of OffheapKV for write path
  • [HBASE-17491] - Remove all setters from HTable interface and introduce a TableBuilder to build Table instance
  • [HBASE-17492] - Fix the compacting memstore part in hbase shell ruby script
  • [HBASE-17497] - Add first async MetaTableAccessor impl and Implement tableExists method
  • [HBASE-17498] - Implement listTables and listTableNames methods
  • [HBASE-17500] - Implement getTable/creatTable/deleteTable/truncateTable methods
  • [HBASE-17508] - Unify the implementation of small scan and regular scan for sync client
  • [HBASE-17511] - Implement enable/disable table methods
  • [HBASE-17516] - Table quota not taking precedence over namespace quota
  • [HBASE-17520] - Implement isTableEnabled/Disabled/Available methods
  • [HBASE-17526] - Procedure v2 - cleanup isSuspended from MasterProcedureScheduler#Queue
  • [HBASE-17530] - Readd TestMergeTableRegionsProcedure mistakenly removed by HBASE-16786
  • [HBASE-17535] - Remove backup manifest duplicates from backup file system
  • [HBASE-17554] - Figure 2.0.0 Hadoop Version Support; update refguide
  • [HBASE-17557] - HRegionServer#reportRegionSizesForQuotas() should respond to UnsupportedOperationException
  • [HBASE-17561] - table status page should escape values that may contain arbitrary characters.
  • [HBASE-17562] - Remove documentation for coprocessor execution times after HBASE-14205
  • [HBASE-17566] - Jetty upgrade fixes
  • [HBASE-17568] - Expire region reports in the HMaster
  • [HBASE-17570] - rsgroup server move can get stuck if unassigning fails
  • [HBASE-17571] - Add batch coprocessor service support
  • [HBASE-17575] - Run critical tests with each of the Inmemory Compaction Policies enabled (Towards Making BASIC the Default In-Memory Compaction Policy)
  • [HBASE-17580] - Tooling to move table out of FAILED_OPEN state
  • [HBASE-17583] - Add inclusive/exclusive support for startRow and endRow of scan for sync client
  • [HBASE-17584] - Expose ScanMetrics with ResultScanner rather than Scan
  • [HBASE-17589] - Add doc for regionserver groups feature
  • [HBASE-17595] - Add partial result support for small/limited scan
  • [HBASE-17596] - Implement add/delete/modify column family methods
  • [HBASE-17599] - Use mayHaveMoreCellsInRow instead of isPartial
  • [HBASE-17600] - Implement get/create/modify/delete/list namespace admin operations
  • [HBASE-17602] - Tweak chore delay/period defaults
  • [HBASE-17608] - Add suspend support for RawScanResultConsumer
  • [HBASE-17615] - Use nonce and procedure v2 for add/remove replication peer
  • [HBASE-17619] - Add async admin Impl which connect to RegionServer and implement close region methods.
  • [HBASE-17644] - Always create ByteBufferCells after copying to MSLAB
  • [HBASE-17646] - Implement Async getRegion method
  • [HBASE-17647] - OffheapKeyValue#heapSize() implementation is wrong
  • [HBASE-17656] - Move new Address class from util to net package
  • [HBASE-17662] - Disable in-memory flush when replaying from WAL
  • [HBASE-17667] - Implement async flush/compact region methods
  • [HBASE-17668] - Implement async assgin/offline/move/unassign methods
  • [HBASE-17669] - Implement async mergeRegion/splitRegion methods.
  • [HBASE-17678] - FilterList with MUST_PASS_ONE may lead to redundant cells returned
  • [HBASE-17691] - Add ScanMetrics support for async scan
  • [HBASE-17730] - [DOC] Migration to 2.0 for coprocessors
  • [HBASE-17738] - BucketCache startup is slow
  • [HBASE-17740] - Correct the semantic of batch and partial for async client
  • [HBASE-17745] - Support short circuit connection for master services
  • [HBASE-17765] - Reviving the merge possibility in the CompactingMemStore
  • [HBASE-17786] - Create LoadBalancer perf-tests (test balancer algorithm decoupled from workload)
  • [HBASE-17790] - Mark ReplicationAdmin's peerAdded and listReplicationPeers as Deprecated
  • [HBASE-17794] - Remove lingering "violation" in favor of the accurate "snapshot"
  • [HBASE-17805] - We should remove BoundedByteBufferPool because it is replaced by ByteBufferPool
  • [HBASE-17809] - cleanup unused class
  • [HBASE-17819] - Reduce the heap overhead for BucketCache
  • [HBASE-17838] - Replace fixed Executor Threads with dynamic thread pool
  • [HBASE-17844] - Subset of HBASE-14614, Procedure v2: Core Assignment Manager (non-critical related changes)
  • [HBASE-17850] - Backup system repair utility
  • [HBASE-17855] - Fix typo in async client implementation
  • [HBASE-17857] - Remove IS annotations from IA.Public classes
  • [HBASE-17858] - Update refguide about the IS annotation if necessary
  • [HBASE-17859] - ByteBufferUtils#compareTo is wrong
  • [HBASE-17864] - Implement async snapshot/cloneSnapshot/restoreSnapshot methods
  • [HBASE-17865] - Implement async listSnapshot/deleteSnapshot methods.
  • [HBASE-17866] - Implement async setQuota/getQuota methods.
  • [HBASE-17867] - Implement async procedure RPC API(list/exec/abort/isFinished)
  • [HBASE-17872] - The MSLABImpl generates the invaild cells when unsafe is not availble
  • [HBASE-17873] - Change the IA.Public annotation to IA.Private for unstable API
  • [HBASE-17881] - Remove the ByteBufferCellImpl
  • [HBASE-17887] - Row-level consistency is broken for read
  • [HBASE-17895] - TestAsyncProcess#testAction fails if unsafe support is false
  • [HBASE-17896] - The FIXED_OVERHEAD of Segment is incorrect
  • [HBASE-17897] - StripeStoreFileManager#nonOpenRowCompare use the wrong comparison function
  • [HBASE-17908] - Upgrade guava
  • [HBASE-17914] - Create a new reader instead of cloning a new StoreFile when compaction
  • [HBASE-17915] - Implement async replication admin methods
  • [HBASE-17917] - Use pread by default for all user scan and switch to streaming read if needed
  • [HBASE-17920] - TestFSHDFSUtils always fails against hadoop 3.0.0-alpha2
  • [HBASE-17922] - TestRegionServerHostname always fails against hadoop 3.0.0-alpha2
  • [HBASE-17925] - mvn assembly:single fails against hadoop3-alpha2
  • [HBASE-17929] - Add more options for PE tool
  • [HBASE-17938] - General fault - tolerance framework for backup/restore operations
  • [HBASE-17952] - The new options for PE tool do not work
  • [HBASE-17955] - Commit Reviewboard comments from Vlad
  • [HBASE-17976] - Remove stability annotation from public audience-marked classes
  • [HBASE-17977] - Enabled Master observer to delete quotas on table deletion by default
  • [HBASE-17978] - Investigate hbase superuser permissions in the face of quota violation
  • [HBASE-17980] - Any HRegionInfo we give out should be immutable
  • [HBASE-17981] - Roll list_quota_violations into list_quota_snapshots
  • [HBASE-17994] - Add async client test to Performance Evaluation tool
  • [HBASE-18002] - Investigate why bucket cache filling up in file mode in an exisiting file is slower
  • [HBASE-18003] - Fix flaky test TestAsyncTableAdminApi
  • [HBASE-18008] - Any HColumnDescriptor we give out should be immutable
  • [HBASE-18009] - Move RpcServer.Call to a separated file
  • [HBASE-18010] - Connect CellChunkMap to be used for flattening in CompactingMemStore
  • [HBASE-18012] - Move RpcServer.Connection to a separated file
  • [HBASE-18013] - Write response directly instead of creating a fake call when setup connection
  • [HBASE-18016] - Implement abort for TruncateTableProcedure
  • [HBASE-18018] - Support abort for all procedures by default
  • [HBASE-18038] - Rename StoreFile to HStoreFile and add a StoreFile interface for CP
  • [HBASE-18039] - Create a copy of AccessControl.proto under hbase-protocol-shaed module
  • [HBASE-18052] - Add document for async admin
  • [HBASE-18068] - Fix flaky test TestAsyncSnapshotAdminApi
  • [HBASE-18091] - Add API for who currently holds a lock on namespace/ table/ region and log when state is LOCK_EVENT_WAIT
  • [HBASE-18102] - [SHELL] Purge close_region command that allows by-pass of Master
  • [HBASE-18103] - [AMv2] If Master gives OPEN to another, if original eventually succeeds, Master will kill it
  • [HBASE-18104] - [AMv2] Enable aggregation of RPCs (assigns/unassigns, etc.)
  • [HBASE-18105] - [AMv2] Split/Merge need cleanup; currently they diverge and do not fully embrace AMv2 world
  • [HBASE-18106] - Redo ProcedureInfo and LockInfo
  • [HBASE-18107] - [AMv2] Remove DispatchMergingRegionsRequest & DispatchMergingRegions
  • [HBASE-18108] - Procedure WALs are archived but not cleaned; fix
  • [HBASE-18109] - Assign system tables first (priority)
  • [HBASE-18112] - Write RequestTooBigException back to client for NettyRpcServer
  • [HBASE-18114] - Update the config of TestAsync*AdminApi to make test stable
  • [HBASE-18115] - Move SaslServer creation to HBaseSaslRpcServer
  • [HBASE-18160] - Fix incorrect logic in FilterList.filterKeyValue
  • [HBASE-18183] - Region interface cleanup for CP expose
  • [HBASE-18190] - Set version in branch-2 to 2.0.0-alpha-1
  • [HBASE-18191] - Include hbase-metrics-* in assembly
  • [HBASE-18213] - Add documentation about the new async client
  • [HBASE-18220] - Compaction scanners need not reopen storefile scanners while trying to switch over from pread to stream
  • [HBASE-18221] - Switch from pread to stream should happen under HStore's reentrant lock
  • [HBASE-18229] - create new Async Split API to embrace AM v2
  • [HBASE-18231] - Deprecate and throw unsupported operation when Admin#closeRegion is called.
  • [HBASE-18234] - Revisit the async admin api
  • [HBASE-18238] - Address ruby static analysis for bin directory
  • [HBASE-18239] - Address ruby static analysis for shell module
  • [HBASE-18240] - Add hbase-thirdparty, a project with hbase utility including an hbase-shaded-thirdparty module with guava, netty, etc.
  • [HBASE-18241] - Change client.Table, client.Admin, Region, Store, and HBaseTestingUtility to not use HTableDescriptor or HColumnDescriptor
  • [HBASE-18264] - Update pom plugins
  • [HBASE-18268] - Eliminate the findbugs warnings for hbase-client
  • [HBASE-18271] - Shade netty
  • [HBASE-18272] - Fix issue about RSGroupBasedLoadBalancer#roundRobinAssignment where BOGUS_SERVER_NAME is involved in two groups
  • [HBASE-18283] - Provide a construct method which accept a thread pool for AsyncAdmin
  • [HBASE-18293] - Only add the spotbugs dependency when jdk8 is active
  • [HBASE-18295] - The result contains the cells across different rows
  • [HBASE-18297] - Provide a AsyncAdminBuilder to create new AsyncAdmin instance
  • [HBASE-18298] - RegionServerServices Interface cleanup for CP expose
  • [HBASE-18308] - Eliminate the findbugs warnings for hbase-server
  • [HBASE-18314] - Eliminate the findbugs warnings for hbase-examples
  • [HBASE-18315] - Eliminate the findbugs warnings for hbase-rest
  • [HBASE-18316] - Implement async admin operations for draining region servers
  • [HBASE-18317] - Implement async admin operations for Normalizer/CleanerChore/CatalogJanitor
  • [HBASE-18318] - Implement updateConfiguration/stopMaster/stopRegionServer/shutdown methods
  • [HBASE-18319] - Implement getClusterStatus/getRegionLoad/getCompactionState/getLastMajorCompactionTimestamp methods
  • [HBASE-18342] - Add coprocessor service support for async admin
  • [HBASE-18343] - Track the remaining unimplemented methods for async admin
  • [HBASE-18347] - Implement a BufferedMutator for async client
  • [HBASE-18365] - Eliminate the findbugs warnings for hbase-common
  • [HBASE-18367] - Reduce ProcedureInfo usage
  • [HBASE-18375] - The pool chunks from ChunkCreator are deallocated while in pool because there is no reference to them
  • [HBASE-18398] - Snapshot operation fails with FileNotFoundException
  • [HBASE-18411] - Dividing FiterList into two separate sub-classes: FilterListWithOR , FilterListWithAND
  • [HBASE-18419] - Update IntegrationTestIngestWithMOB and Actions to use ColumnFamily builders for modification
  • [HBASE-18420] - Some methods of Admin don't use ColumnFamilyDescriptor
  • [HBASE-18423] - Fix TestMetaWithReplicas
  • [HBASE-18424] - Fix TestAsyncTableGetMultiThreaded
  • [HBASE-18428] - IntegrationTestDDLMasterFailover uses old-style immutable column descriptors
  • [HBASE-18440] - ITs and Actions modify immutable TableDescriptors
  • [HBASE-18446] - Mark StoreFileScanner/StoreFileReader as IA.LimitedPrivate(Phoenix)
  • [HBASE-18448] - EndPoint example for refreshing HFiles for stores
  • [HBASE-18453] - CompactionRequest should not be exposed to user directly
  • [HBASE-18489] - Expose scan cursor in RawScanResultConsumer
  • [HBASE-18502] - Change MasterObserver to use TableDescriptor and ColumnFamilyDescriptor
  • [HBASE-18503] - Change ***Util and Master to use TableDescriptor and ColumnFamilyDescriptor
  • [HBASE-18524] - Test reenabling Master carrying regions
  • [HBASE-18528] - DON'T allow user to modify the passed table/column descriptor
  • [HBASE-18553] - Expose scan cursor for asynchronous scanner
  • [HBASE-18593] - Tell m2eclipse what to do w/ replacer plugin
  • [HBASE-18595] - Set version in branch-2 from 2.0.0-alpha2-SNAPSHOT to 2.0.0-alpha2
  • [HBASE-18608] - AsyncConnection should return AsyncAdmin interface instead of the implemenation
  • [HBASE-18624] - Added support for clearing BlockCache based on table name
  • [HBASE-18656] - Address issues found by error-prone in hbase-common
  • [HBASE-18658] - Purge hokey hbase Service implementation; use (internal) Guava Service instead
  • [HBASE-18681] - Introduce a new constructor for StoreScanner for MOB
  • [HBASE-18687] - Add @since 2.0.0 to new classes
  • [HBASE-18688] - Upgrade commons-codec to 1.10
  • [HBASE-18691] - [compat 1-2] HCD remove and removeConfiguration change return type
  • [HBASE-18692] - [compat 1-2] ByteBufferUtils.copyFromBufferToBuffer goes from void to int
  • [HBASE-18697] - Need a shaded hbase-mapreduce module
  • [HBASE-18698] - MapreduceDependencyClasspathTool does not include hbase-server as a dependency
  • [HBASE-18700] - Document the new changes on mapreduce stuffs
  • [HBASE-18718] - Document the coprocessor.Export
  • [HBASE-18721] - Cleanup unused configs and private declaration
  • [HBASE-18729] - [compat 1-2] The input type of Result#createCompleteResult is changed
  • [HBASE-18731] - [compat 1-2] Mark protected methods of QuotaSettings that touch Protobuf internals as IA.Private
  • [HBASE-18732] - [compat 1-2] HBASE-14047 removed Cell methods w/o deprecation cycle
  • [HBASE-18733] - [compat 1-2] Hide WALKey
  • [HBASE-18736] - Cleanup the HTD/HCD for Admin
  • [HBASE-18739] - Make all TimeRange Constructors InterfaceAudience Private.
  • [HBASE-18747] - Introduce new example and helper classes to tell CP users how to do filtering on scanners
  • [HBASE-18749] - Apply the CF specific TimeRange from Scan to filter the segment scanner
  • [HBASE-18750] - Cleanup the docs saying "HTable use write buffer"
  • [HBASE-18752] - Recalculate the TimeRange in flushing snapshot to store file
  • [HBASE-18753] - Introduce the unsynchronized TimeRangeTracker
  • [HBASE-18754] - Get rid of Writable from TimeRangeTracker
  • [HBASE-18758] - [TEST][compat 1-2] Test delegation tokens continue to work when hbase1 going against hbase2 cluster
  • [HBASE-18769] - Make CompareFilter use generic CompareOperator instead of internal enum
  • [HBASE-18770] - Remove bypass method in ObserverContext and implement the 'bypass' logic case by case
  • [HBASE-18779] - Move CompareOperator to hbase-client module
  • [HBASE-18780] - Remove HLogPrettyPrinter and hlog command
  • [HBASE-18786] - FileNotFoundException should not be silently handled for primary region replicas
  • [HBASE-18793] - Remove deprecated methods in RegionObserver
  • [HBASE-18794] - Remove deprecated methods in MasterObserver
  • [HBASE-18797] - Deprecate Filter#filterKeyValue and add Filter#filterCell
  • [HBASE-18798] - Remove the unused methods in RegionServerObserver
  • [HBASE-18807] - Remove PB references from Observers for Quotas
  • [HBASE-18815] - We need to pass something like CompactionRequest in CP to give user some information about the compaction
  • [HBASE-18819] - Set version number to 2.0.0-alpha3 from 2.0.0-alpha3-SNAPSHOT
  • [HBASE-18820] - assembly is missing hbase-replication
  • [HBASE-18821] - Enforcer plugin NPEs again when generating site
  • [HBASE-18823] - Apply RegionInfo to MasterObserver/RegionObserver/WALObserver
  • [HBASE-18825] - Use HStoreFile instead of StoreFile in our own code base and remove unnecessary methods in StoreFile interface
  • [HBASE-18826] - Use HStore instead of Store in our own code base and remove unnecessary methods in Store interface
  • [HBASE-18828] - [2.0] Generate CHANGES.txt
  • [HBASE-18839] - Apply RegionInfo to code base
  • [HBASE-18859] - Purge PB from BulkLoadObserver
  • [HBASE-18867] - maven enforcer plugin needs update to work with jdk9
  • [HBASE-18873] - Hide protobufs in GlobalQuotaSettings
  • [HBASE-18878] - Use Optional<T> return types when T can be null
  • [HBASE-18905] - Allow CPs to request flush on Region and know the completion of the requested flush
  • [HBASE-18906] - Provide Region#waitForFlushes API
  • [HBASE-18909] - Deprecate Admin's methods which used String regex
  • [HBASE-18911] - Unify Admin and AsyncAdmin's methods name
  • [HBASE-18912] - Update Admin methods to return Lists instead of arrays
  • [HBASE-18914] - Remove AsyncAdmin's methods which were already deprecated in Admin interface
  • [HBASE-18931] - Make ObserverContext an interface and remove private/testing methods
  • [HBASE-18933] - set version number to 2.0.0-alpha4-SNAPSHOT following release of alpha3
  • [HBASE-18945] - Make a IA.LimitedPrivate interface for CellComparator
  • [HBASE-18949] - Remove the CompactionRequest parameter in preCompactSelection
  • [HBASE-18950] - Remove Optional parameters in AsyncAdmin interface
  • [HBASE-18951] - Use Builder pattern to remove nullable parameters for checkAndXXX methods in RawAsyncTable/AsyncTable interface
  • [HBASE-18952] - Remove the Optional(Int) usage in the constructors of HStore
  • [HBASE-18954] - Make *CoprocessorHost classes private
  • [HBASE-18957] - add test that confirms 2 FamilyFilters in a FilterList using MUST_PASS_ONE operator will return results that match either of the FamilyFilters and revert as needed to make it pass.
  • [HBASE-18960] - A few bug fixes and minor improvements around batchMutate()
  • [HBASE-18961] - doMiniBatchMutate() is big, split it into smaller methods
  • [HBASE-18962] - Support atomic BatchOperations through batchMutate()
  • [HBASE-18963] - Remove MultiRowMutationProcessor and implement mutateRows... methods using batchMutate()
  • [HBASE-18964] - Deprecate RowProcessor and processRowsWithLocks() APIs that take RowProcessor as an argument
  • [HBASE-18966] - Use non-sync TimeRangeTracker as a replacement for TimeRange in ImmutableSegment
  • [HBASE-18972] - Use Builder pattern to remove nullable parameters for coprocessor methods in RawAsyncTable interface
  • [HBASE-18977] - Reenable test of filterlist using MUST_PASS_ONE and two familyfilters
  • [HBASE-18980] - Address issues found by error-prone in hbase-hadoop2-compat
  • [HBASE-18981] - Address issues found by error-prone in hbase-client
  • [HBASE-18989] - Polish the compaction related CP hooks
  • [HBASE-18995] - Move methods that are for internal usage from CellUtil to Private util class
  • [HBASE-19000] - Group multiple block cache clear requests per server
  • [HBASE-19001] - Remove the hooks in RegionObserver which are designed to construct a StoreScanner which is marked as IA.Private
  • [HBASE-19002] - Introduce more examples to show how to intercept normal region operations
  • [HBASE-19003] - Make sure all balancer actions respect decommissioned server
  • [HBASE-19009] - implement modifyTable and enable/disableTableReplication for AsyncAdmin
  • [HBASE-19010] - Reimplement getMasterInfoPort for Admin
  • [HBASE-19029] - Align RPC timout methods in Table and AsyncTableBase
  • [HBASE-19031] - Align exist method in Table and AsyncTable interfaces
  • [HBASE-19033] - Allow CP users to change versions and TTL before opening StoreScanner
  • [HBASE-19045] - Deprecate RegionObserver#postInstantiateDeleteTracker
  • [HBASE-19046] - RegionObserver#postCompactSelection Avoid passing shaded ImmutableList param
  • [HBASE-19047] - CP exposed Scanner types should not extend Shipper
  • [HBASE-19048] - Cleanup MasterObserver hooks which takes IA private params
  • [HBASE-19053] - Split out o.a.h.h.http from hbase-server into a separate module
  • [HBASE-19057] - Fix other code review comments about FilterList Improvement
  • [HBASE-19067] - Do not expose getHDFSBlockDistribution in StoreFile
  • [HBASE-19069] - Do not wrap the original CompactionLifeCycleTracker when calling CP hooks
  • [HBASE-19070] - temporarily make the mvnsite nightly test non-voting.
  • [HBASE-19074] - Miscellaneous Observer cleanups
  • [HBASE-19090] - Add config 'hbase.systemtables.compacting.memstore.type' to hbase-default.xml
  • [HBASE-19092] - Make Tag IA.LimitedPrivate and expose for CPs
  • [HBASE-19093] - Check Admin/Table to ensure all operations go via AccessControl
  • [HBASE-19095] - Add CP hooks in RegionObserver for in memory compaction
  • [HBASE-19096] - Add RowMutions batch support in AsyncTable
  • [HBASE-19112] - Suspect methods on Cell to be deprecated
  • [HBASE-19114] - Split out o.a.h.h.zookeeper from hbase-server and hbase-client
  • [HBASE-19116] - Currently the tail of hfiles with CellComparator* classname makes it so hbase1 can't open hbase2 written hfiles; fix
  • [HBASE-19122] - preCompact and preFlush can bypass by returning null scanner; shut it down
  • [HBASE-19127] - Set State.SPLITTING, MERGING, MERGING_NEW, SPLITTING_NEW properly in RegionStatesNode
  • [HBASE-19128] - Purge Distributed Log Replay from codebase, configurations, text; mark the feature as unsupported, broken.
  • [HBASE-19131] - Add the ClusterStatus hook and cleanup other hooks which can be replaced by ClusterStatus hook
  • [HBASE-19133] - Transfer big cells or upserted/appended cells into MSLAB upon flattening to CellChunkMap
  • [HBASE-19136] - Set branch-2 version to 2.0.0-alpha4 from 2.0.0-alpha4-SNAPSHOT
  • [HBASE-19141] - [compat 1-2] getClusterStatus always return empty ClusterStatus
  • [HBASE-19152] - Update refguide 'how to build an RC' and the make_rc.sh script
  • [HBASE-19172] - [rolling upgrade] Migrate region state from zk to hbase:meta
  • [HBASE-19197] - Move version on branch-2 from 2.0.0-alpha4 to 2.0.0-beta-1.SNAPSHOT
  • [HBASE-19203] - Update Hadoop version used for build to 2.7.4
  • [HBASE-19212] - Align coprocessor in Table and AsyncTable
  • [HBASE-19213] - Align check and mutate operations in Table and AsyncTable
  • [HBASE-19214] - Align scan in Table and AsyncTable
  • [HBASE-19220] - Async tests time out talking to zk; 'clusterid came back null'
  • [HBASE-19235] - CoprocessorEnvironment should be exposed to CPs
  • [HBASE-19242] - Add MOB compact support for AsyncAdmin
  • [HBASE-19243] - Start mini cluster once before class for TestFIFOCompactionPolicy
  • [HBASE-19268] - Enable Replica tests that were disabled by Proc-V2 AM in HBASE-14614
  • [HBASE-19269] - Reenable TestShellRSGroups
  • [HBASE-19270] - Reenable TestRegionMergeTransactionOnCluster#testMergeWithReplicas disable by HBASE-14614
  • [HBASE-19272] - Deal with HBCK tests disabled by HBASE-14614 AMv2 when HBCK works again...
  • [HBASE-19276] - RegionPlan should correctly implement equals and hashCode
  • [HBASE-19278] - Reenable cleanup in test teardown in TestAccessController3 disabled by HBASE-14614
  • [HBASE-19282] - CellChunkMap Benchmarking and User Interface
  • [HBASE-19295] - The Configuration returned by CPEnv should be read-only.
  • [HBASE-19301] - Provide way for CPs to create short circuited connection with custom configurations
  • [HBASE-19313] - Call blockUntilConnected when constructing ZKAsyncRegistry(temporary workaround)
  • [HBASE-19344] - improve asyncWAL by using Independent thread for netty #IO in FanOutOneBlockAsyncDFSOutput
  • [HBASE-19346] - Use EventLoopGroup to create AsyncFSOutput
  • [HBASE-19357] - Bucket cache no longer L2 for LRU cache
  • [HBASE-19359] - Revisit the default config of hbase client retries number
  • [HBASE-19360] - Remove unused imports from hbase-zookeeper module
  • [HBASE-19362] - Remove unused imports from hbase-thrift module
  • [HBASE-19373] - Fix Checkstyle error in hbase-annotations
  • [HBASE-19375] - Fix import order in hbase-thrift
  • [HBASE-19399] - Purge curator dependency from hbase-client
  • [HBASE-19400] - Add missing security checks in MasterRpcServices
  • [HBASE-19426] - Move has() and setTimestamp() to Mutation
  • [HBASE-19427] - Add TimeRange support into Append to optimize for counters
  • [HBASE-19428] - Deprecate the compareTo(Row)
  • [HBASE-19430] - Remove the SettableTimestamp and SettableSequenceId
  • [HBASE-19439] - Mark ShortCircuitMasterConnection with InterfaceAudience Private
  • [HBASE-19462] - Deprecate all addImmutable methods in Put
  • [HBASE-19468] - FNFE during scans and flushes
  • [HBASE-19474] - Bring down number of Checkstyle errors in hbase-zookeeper
  • [HBASE-19479] - Fix Checkstyle error in hbase-shell
  • [HBASE-19480] - Enable Checkstyle in hbase-annotations
  • [HBASE-19481] - Enable Checkstyle in hbase-error-prone
  • [HBASE-19494] - Create simple WALKey filter that can be plugged in on the Replication Sink
  • [HBASE-19497] - Fix findbugs and error-prone warnings in hbase-common (branch-2)
  • [HBASE-19498] - Fix findbugs and error-prone warnings in hbase-client (branch-2)
  • [HBASE-19501] - [AMv2] Retain assignment across restarts
  • [HBASE-19502] - Make sure we have closed all StoreFileScanners if we fail to open any StoreFileScanners
  • [HBASE-19505] - Disable ByteBufferPool by default at HM
  • [HBASE-19527] - Make ExecutorService threads daemon=true.
  • [HBASE-19538] - Remove unnecessary semicolons in hbase-client
  • [HBASE-19539] - Remove unnecessary semicolons in hbase-common
  • [HBASE-19554] - AbstractTestDLS.testThreeRSAbort sometimes fails in pre commit
  • [HBASE-19556] - Remove TestAssignmentManager#testGoodSplit, which no longer make sense
  • [HBASE-19566] - Fix Checkstyle errors in hbase-client-project
  • [HBASE-19567] - ClassNotFoundException: org.apache.hadoop.hbase.KeyValue$RawBytesComparator starting 2.0.0 over a 0.98.25 data.
  • [HBASE-19575] - add copy constructor to Mutation
  • [HBASE-19581] - Fix Checkstyle error in hbase-external-blockcache
  • [HBASE-19591] - Cleanup the usage of ReplicationAdmin from hbase-shell
  • [HBASE-19602] - Cleanup the usage of ReplicationAdmin from document
  • [HBASE-19604] - Fix Checkstyle errors in hbase-protocol-shaded
  • [HBASE-19605] - Fix Checkstyle errors in hbase-metrics-api
  • [HBASE-19609] - Fix Checkstyle errors in hbase-metrics
  • [HBASE-19626] - Rename Cell.DataType to Cell.Type
  • [HBASE-19628] - ByteBufferCell should extend ExtendedCell
  • [HBASE-19629] - RawCell#getTags should return the Iterator<Tag> in order to avoid iterating through whole tag array at once
  • [HBASE-19648] - Move branch-2 version from 2.0.0-beta-1-SNAPSHOT to 2.0.0-beta-1
  • [HBASE-19653] - Reduce the default hbase.client.start.log.errors.counter
  • [HBASE-19660] - Up default retries from 10 to 15 and blocking store files limit from 10 to 16
  • [HBASE-19667] - Get rid of MasterEnvironment#supportGroupCPs
  • [HBASE-19670] - Workaround: Purge User API building from branch-2 so can make a beta-1
  • [HBASE-19725] - Build fails, unable to read hbase/checkstyle-suppressions.xml "invalid distance too far back"
  • [HBASE-19731] - TestFromClientSide#testCheckAndDeleteWithCompareOp and testNullQualifier are flakey
  • [HBASE-19743] - Disable TestMemstoreLABWithoutPool
  • [HBASE-19746] - Add default impl to Cell#getType
  • [HBASE-19772] - Do not close connection to zk when there are still pending request in ReadOnlyZKClient
  • [HBASE-19779] - The chunk encountering the OOM will store in ChunkCreator forever
  • [HBASE-19786] - acl table is created by coprocessor inside Master start procedure; broke TestJMXConnectorServer
  • [HBASE-19787] - Fix or disable tests broken in branch-2 so can cut beta-1
  • [HBASE-19791] - TestZKAsyncRegistry hangs
  • [HBASE-19793] - Minor improvements on Master/RS startup
  • [HBASE-19795] - Move the tests which only need zookeeper in TestZooKeeper to hbase-zookeeper module
  • [HBASE-19803] - False positive for the HBASE-Find-Flaky-Tests job
  • [HBASE-19809] - Fix findbugs and error-prone warnings in hbase-procedure (branch-2)
  • [HBASE-19810] - Fix findbugs and error-prone warnings in hbase-metrics (branch-2)
  • [HBASE-19811] - Fix findbugs and error-prone warnings in hbase-server (branch-2)
  • [HBASE-19827] - Addendum for Flakey TestAssignmentManager
  • [HBASE-19834] - Signalling server-hosted-clients to abort retries
  • [HBASE-19837] - Flakey TestRegionLoad
  • [HBASE-19839] - Flakey TestMergeTableRegionsProcedure & TestSplitTableRegionProcedure
  • [HBASE-19840] - Flakey TestMetaWithReplicas
  • [HBASE-19841] - Tests against hadoop3 fail with StreamLacksCapabilityException
  • [HBASE-19845] - Fix findbugs and error-prone warnings in hbase-rsgroup (branch-2)
  • [HBASE-19846] - Fix findbugs and error-prone warnings in hbase-rest (branch-2)
  • [HBASE-19847] - Fix findbugs and error-prone warnings in hbase-thrift (branch-2)
  • [HBASE-19862] - Fix TestTokenAuthentication - fake RegionCoprocessorEnvironment is not of type HasRegionServerServices
  • [HBASE-19866] - TestRegionServerReportForDuty doesn't timeout
  • [HBASE-19867] - Split TestStochasticLoadBalancer into several small tests
  • [HBASE-19868] - TestCoprocessorWhitelistMasterObserver is flakey
  • [HBASE-19870] - Fix the NPE in ReadOnlyZKClient#run
  • [HBASE-19873] - Add a CategoryBasedTimeout ClassRule for all UTs
  • [HBASE-19877] - hbase-common and hbase-zookeeper don't add the log4j.properties to the resource path for testing
  • [HBASE-19879] - Promote TestAcidGuaranteesXXX to LargeTests
  • [HBASE-19880] - Promote TestFuzzyRowFilterEndToEnd to LargeTests
  • [HBASE-19881] - Promote TestRegionReplicaReplicationEndpoint to LargeTests
  • [HBASE-19882] - Promote TestProcedureManager to MediumTests
  • [HBASE-19885] - Promote TestAssignmentManager to LargeTests
  • [HBASE-19887] - Do not overwrite the surefire junit listener property in the pom of sub modules
  • [HBASE-19891] - Up nightly test run timeout from 6 hours to 8
  • [HBASE-19895] - Add keepDeletedCells option in ScanOptions for customizing scanInfo in pre-hooks
  • [HBASE-19896] - Fix ScanInfo.customize() to update only the requested options
  • [HBASE-19903] - Split TestShell so it will not time out
  • [HBASE-19908] - TestCoprocessorShortCircuitRPC Timeout....
  • [HBASE-19909] - TestRegionLocationFinder Timeout
  • [HBASE-19910] - TestBucketCache TimesOut
  • [HBASE-19911] - Convert some tests from small to medium because they are timing out: TestNettyRpcServer, TestClientClusterStatus, TestCheckTestClasses
  • [HBASE-19913] - Split TestStochasticLoadBalancer2
  • [HBASE-19914] - Refactor TestVisibilityLabelsOnNewVersionBehaviorTable
  • [HBASE-19916] - TestCacheOnWrite Times Out
  • [HBASE-19918] - Promote TestAsyncClusterAdminApi to LargeTests
  • [HBASE-19927] - TestFullLogReconstruction flakey
  • [HBASE-19928] - TestVisibilityLabelsOnNewVersionBehaviorTable fails
  • [HBASE-19931] - TestMetaWithReplicas failing 100% of the time in testHBaseFsckWithMetaReplicas
  • [HBASE-19940] - TestMetaShutdownHandler flakey
  • [HBASE-19942] - Fix flaky TestSimpleRpcScheduler
  • [HBASE-19944] - Fix timeout TestVisibilityLabelsWithCustomVisLabService
  • [HBASE-19951] - Cleanup the explicit timeout value for test method
  • [HBASE-19956] - Remove category as a consideration timing out tests; set all test to timeout at 10minutes regardless
  • [HBASE-19960] - Doc test timeouts and test categories in hbase2
  • [HBASE-19965] - Fix flaky TestAsyncRegionAdminApi
  • [HBASE-19978] - The keepalive logic is incomplete in ProcedureExecutor
  • [HBASE-20000] - Remove the quantum logic in FairQueue, always put high priority queue in front
  • [HBASE-20002] - Reserve worker thread in ProcedureExecutor for high priority procedures
  • [HBASE-20011] - Disable TestRestoreSnapshotFromClientWithRegionReplicas; it is flakey. Needs attention.
  • [HBASE-20013] - TestZKPermissionWatcher is flakey
  • [HBASE-20014] - TestAdmin1 Times out
  • [HBASE-20015] - TestMergeTableRegionsProcedure and TestRegionMergeTransactionOnCluster flakey
  • [HBASE-20019] - Document the ColumnValueFilter
  • [HBASE-20021] - TestFromClientSideWithCoprocessor is flakey
  • [HBASE-20029] - @Ignore TestQuotaThrottle and TestReplicasClient#testCancelOfMultiGet
  • [HBASE-20035] - .TestQuotaStatusRPCs.testQuotaStatusFromMaster failed with NPEs and RuntimeExceptions
  • [HBASE-20036] - TestAvoidCellReferencesIntoShippedBlocks timed out
  • [HBASE-20038] - TestLockProcedure.testTimeout is flakey
  • [HBASE-20039] - move testhbasetestingutility mr tests to hbase-mapreduce
  • [HBASE-20041] - cannot start mini mapreduce cluster for ITs
  • [HBASE-20044] - TestClientClusterStatus is flakey
  • [HBASE-20048] - Revert serial replication feature
  • [HBASE-20059] - Make sure documentation is updated for the offheap Bucket cache usage
  • [HBASE-20069] - fix existing findbugs errors in hbase-server
  • [HBASE-20083] - Fix findbugs error for ReplicationSyncUp
  • [HBASE-20100] - TestEnableTableProcedure flakey
  • [HBASE-20113] - Move branch-2 version from 2.0.0-beta-2-SNAPSHOT to 2.0.0-beta-2
  • [HBASE-20131] - NPE in MoveRegionProcedure via IntegrationTestLoadAndVerify with CM
  • [HBASE-20142] - Copy master doc into branch-2 and edit to make it suit 2.0.0
  • [HBASE-20149] - Purge dev javadoc from bin tarball (or make a separate tarball of javadoc)
  • [HBASE-20173] - [AMv2] DisableTableProcedure concurrent to ServerCrashProcedure can deadlock
  • [HBASE-20178] - [AMv2] Throw exception if hostile environment
  • [HBASE-20180] - Avoid Class::newInstance
  • [HBASE-20190] - Fix default for MIGRATE_TABLE_STATE_FROM_ZK_KEY
  • [HBASE-20202] - [AMv2] Don't move region if its a split parent or offlined
  • [HBASE-20232] - [LOGGING] Formatting around close and flush
  • [HBASE-20240] - CLONE - Add Per-Table metrics back
  • [HBASE-20241] - splitormerge_enabled does not work
  • [HBASE-20245] - HTrace commands do not work
  • [HBASE-20247] - Set version as 2.0.0 in branch-2.0 in prep for first RC
  • [HBASE-20248] - [ITBLL] UNREFERENCED rows
  • [HBASE-20253] - Error message is missing for restore_snapshot
  • [HBASE-20254] - Incorrect help message for merge_region
  • [HBASE-20258] - Shell hangs when scanning a disabled table
  • [HBASE-20276] - [shell] Revert shell REPL change and document
  • [HBASE-20287] - After cluster startup list_regions command fails on disabled table
  • [HBASE-20298] - Doc change in read/write/total accounting metrics
  • [HBASE-20319] - Run a check that branch-2.0 has all it needs from branch-2
  • [HBASE-20337] - Update the doc on how to setup shortcircuit reads; its stale
  • [HBASE-20347] - [DOC] upgrade section should warn about logging changes
  • [HBASE-20349] - [DOC] upgrade guide should call out removal of prefix-tree data block encoding
  • [HBASE-20354] - [DOC] quickstart guide needs to include note about durability checks for standalone mode
  • [HBASE-20380] - Put up 2.0.0RC0
  • [HBASE-20454] - [DOC] Add note on perf to upgrade section

Bug

  • [HBASE-1989] - Admin (et al.) not accurate with Column vs. Column-Family usage
  • [HBASE-4072] - Deprecate/disable and remove support for reading ZooKeeper zoo.cfg files from the classpath
  • [HBASE-5401] - PerformanceEvaluation generates 10x the number of expected mappers
  • [HBASE-5878] - Use getVisibleLength public api from HdfsDataInputStream from Hadoop-2.
  • [HBASE-6416] - hbck dies on NPE when a region folder exists but the table does not
  • [HBASE-6778] - Deprecate Chore; its a thread per task when we should have one thread to do all tasks
  • [HBASE-7326] - SortedCopyOnWriteSet is not thread safe due to leaked TreeSet implementations
  • [HBASE-7332] - [webui] HMaster webui should display the number of regions a table has.
  • [HBASE-7621] - REST client (RemoteHTable) doesn't support binary row keys
  • [HBASE-8028] - Append, Increment: Adding rollback support
  • [HBASE-8473] - add note to ref guide about snapshots and ec2 reverse dns requirements.
  • [HBASE-8674] - JUnit and Surefire TRUNK-HBASE-2 plugins need a new home
  • [HBASE-8725] - Add total time RPC call metrics
  • [HBASE-8758] - Error in RegionCoprocessorHost class preScanner method documentation.
  • [HBASE-8942] - DFS errors during a read operation (get/scan), may cause write outliers
  • [HBASE-9393] - Region Server fails to properly close socket resulting in many CLOSE_WAIT to Data Nodes
  • [HBASE-9702] - Change unittests that use "table" or "testtable" to use method names.
  • [HBASE-9763] - Scan javadoc doesn't fully capture semantics of start and stop row
  • [HBASE-10728] - get_counter value is never used.
  • [HBASE-10844] - Coprocessor failure during batchmutation leaves the memstore datastructs in an inconsistent state
  • [HBASE-11153] - Document that http webUI's should redirect to https when enabled
  • [HBASE-11316] - Expand info about compactions beyond HBASE-11120
  • [HBASE-11333] - Remove deprecated class MetaMigrationConvertingToPB
  • [HBASE-11409] - Add more flexibility for input directory structure to LoadIncrementalHFiles
  • [HBASE-11499] - AsyncProcess.buildDetailedErrorMessage concatenates strings using + in a loop
  • [HBASE-11500] - Possible null pointer dereference of regionLocation in ReversedScannerCallable
  • [HBASE-11521] - Modify pom.xml to copy the images/ and css/ directories to the right location for the Ref Guide to see them correctly
  • [HBASE-11522] - Move Replication information into the Ref Guide
  • [HBASE-11529] - Images and CSS still don't work properly on both html and html-single book
  • [HBASE-11539] - Expand info about contributing to and building documentation
  • [HBASE-11542] - Unit Test KeyStoreTestUtil.java compilation failure in IBM JDK
  • [HBASE-11544] - [Ergonomics] hbase.client.scanner.caching is dogged and will try to return batch even if it means OOME
  • [HBASE-11556] - Move HTablePool to hbase-thrift module.
  • [HBASE-11560] - hbase.regionserver.global.memstore.size is documented twice
  • [HBASE-11625] - Reading datablock throws "Invalid HFile block magic" and can not switch to hdfs checksum
  • [HBASE-11629] - Operational concerns for Replication should call out ZooKeeper
  • [HBASE-11640] - Add syntax highlighting support to HBase Ref Guide programlistings
  • [HBASE-11648] - Typo of config: hbase.hstore.compaction.ratio in book.xml
  • [HBASE-11658] - Piped commands to hbase shell should return non-zero if shell command failed.
  • [HBASE-11661] - Quickstart chapter claims standalone mode has multiple processes
  • [HBASE-11665] - TestRegionReplicas doesn't work for me
  • [HBASE-11689] - Track meta in transition
  • [HBASE-11711] - In some environment HBase MiniCluster fails to load because Master info port clobbering
  • [HBASE-11721] - jdiff script no longer works as usage instructions indicate
  • [HBASE-11732] - Should not preemptively offline a region
  • [HBASE-11830] - TestReplicationThrottler.testThrottling failed on virtual boxes
  • [HBASE-11834] - TestHRegionBusyWait.testParallelAppendWithMemStoreFlush fails sporadically
  • [HBASE-11850] - RpcClient can get stuck when closing
  • [HBASE-11855] - HBase handbook chapter 18.9 out of date
  • [HBASE-11957] - Backport to 0.94 HBASE-5974 Scanner retry behavior with RPC timeout on next() seems incorrect
  • [HBASE-11968] - If MOB is enabled, it should make sure hfile v3 is being used.
  • [HBASE-11983] - HRegion constructors should not create HLog
  • [HBASE-11987] - Make zk-less table states backward compatible.
  • [HBASE-11998] - Document a workflow for cherry-picking a fix to a different branch
  • [HBASE-12005] - Split/merge fails if master restarts before PONR
  • [HBASE-12006] - [JDK 8] KeyStoreTestUtil#generateCertificate fails due to "subject class type invalid"
  • [HBASE-12027] - The ZooKeeperWatcher in HMobStore only uses the default conf
  • [HBASE-12030] - Wrong compaction report and assert when MOB compaction switches to minor
  • [HBASE-12073] - Shell command user_permission fails on the table created by user if he is not global admin.
  • [HBASE-12088] - Remove un-used profiles in non-root poms
  • [HBASE-12091] - Optionally ignore edits for dropped tables for replication.
  • [HBASE-12102] - Duplicate keys in HBase.RegionServer metrics JSON
  • [HBASE-12172] - Disable flakey TestRegionReplicaReplicationEndpoint and make fixing it a blocker on 1.0
  • [HBASE-12186] - Formatting error in Table 8.2. Examples of Visibility Expressions
  • [HBASE-12192] - Remove EventHandlerListener
  • [HBASE-12193] - Add missing docbook file to git
  • [HBASE-12201] - Close the writers in the MOB sweep tool
  • [HBASE-12216] - Lower closed region logging level
  • [HBASE-12283] - Clean up some checkstyle errors
  • [HBASE-12307] - Remove unused Imports in hbase-client and hbase-common
  • [HBASE-12326] - Document scanner timeout workarounds in troubleshooting section
  • [HBASE-12347] - Fix the edge case where Hadoop QA's parsing of attached patches breaks the JIRA status checker in dev-support/rebase_all_git_branches.sh
  • [HBASE-12380] - TestRegionServerNoMaster#testMultipleOpen is flaky after HBASE-11760
  • [HBASE-12397] - CopyTable fails to compile with the Hadoop 1 profile
  • [HBASE-12409] - Add actual tunable parameters for finding optimal # of regions per RS
  • [HBASE-12412] - update the ref guide(currently Example 10.2) to show "update an existing CF" with the new API modifyFamily in master
  • [HBASE-12413] - Mismatch in the equals and hashcode methods of KeyValue
  • [HBASE-12418] - Multiple branches for MOB feature breaking git for case insensitive filesystems
  • [HBASE-12421] - Clarify ACL concepts and best practices
  • [HBASE-12444] - Total number of requests overflow because it's int
  • [HBASE-12468] - AUTHORIZATIONS should be part of Visibility Label Docs
  • [HBASE-12474] - Incorrect handling of default namespace in user_permission command.
  • [HBASE-12488] - Small bug in publish_hbase_website.sh script
  • [HBASE-12532] - TestFilter failing occasionally with ExitCodeException doing chmod since HBASE-10378
  • [HBASE-12535] - NPE in WALFactory close under contention for getInstance
  • [HBASE-12540] - TestRegionServerMetrics#testMobMetrics test failure
  • [HBASE-12542] - Delete a family of table online will crash regionserver
  • [HBASE-12548] - Improve debuggability of IntegrationTestTimeBoundedRequestsWithRegionReplicas
  • [HBASE-12552] - listSnapshots should list only owned snapshots for non-super user
  • [HBASE-12553] - request value is not consistent for restoreSnapshot in audit logs
  • [HBASE-12558] - Disable TestHCM.testClusterStatus Unexpected exception, expected<org.apache.hadoop.hbase.regionserver.RegionServerStoppedException> but was<junit.framework.AssertionFailedError>
  • [HBASE-12563] - After Starting up mini hbase cluster, Real Configuration of Cluster never set to HBaseTestingUtility
  • [HBASE-12603] - Remove javadoc warnings introduced due to removal of unused imports
  • [HBASE-12612] - WALFactory use in upgrade path must clean up properly
  • [HBASE-12615] - Document GC conserving guidelines for contributors
  • [HBASE-12628] - Update instructions for running shell tests using maven.
  • [HBASE-12656] - TestVisibilityLabelsWithDeletes is flaky
  • [HBASE-12677] - Update replication docs to clarify terminology
  • [HBASE-12682] - compaction thread throttle value is not correct in hbase-default.xml
  • [HBASE-12687] - Book is missing styling
  • [HBASE-12688] - Update site with a bootstrap-based UI
  • [HBASE-12690] - list_quotas command is failing with not able to load Java class
  • [HBASE-12693] - [docs] nit fix in HBase and MapReduce section
  • [HBASE-12703] - Cleanup TestClientPushback for repeatability
  • [HBASE-12717] - Pre-split algorithm in HBaseAdmin.create() can not find the split point
  • [HBASE-12723] - Update ACL matrix to reflect reality
  • [HBASE-12734] - TestPerColumnFamilyFlush.testCompareStoreFileCount is flakey
  • [HBASE-12743] - [ITBLL] Master fails rejoining cluster stuck splitting logs; Distributed log replay=true
  • [HBASE-12749] - Tighten HFileLink api to enable non-snapshot uses
  • [HBASE-12751] - Allow RowLock to be reader writer
  • [HBASE-12772] - TestPerColumnFamilyFlush failing
  • [HBASE-12775] - CompressionTest ate my HFile (sigh!)
  • [HBASE-12777] - Multi-page book has broken links that work in the single-page version
  • [HBASE-12838] - After HBASE-5162 RSRpcServices accidentally applies mutations twice
  • [HBASE-12845] - ByteBufferOutputStream should grow as direct buffer if the initial buffer is also direct BB
  • [HBASE-12849] - LoadIncrementalHFiles should use unmanaged connection in branch-1
  • [HBASE-12858] - Remove unneeded files under src/main/docbkx
  • [HBASE-12865] - WALs may be deleted before they are replicated to peers
  • [HBASE-12867] - Shell does not support custom replication endpoint specification
  • [HBASE-12871] - Document JDK versions supported by each release missing in new documentation
  • [HBASE-12877] - Hbase documentation- a referenced link is not working
  • [HBASE-12902] - Post-asciidoc conversion fix-ups
  • [HBASE-12903] - Fix configuration which enables secure bulk load
  • [HBASE-12908] - Typos in MemStoreFlusher javadocs
  • [HBASE-12920] - hadoopqa should compile with different hadoop versions
  • [HBASE-12922] - Post-asciidoc conversion fix-ups part 2
  • [HBASE-12924] - HRegionServer#MovedRegionsCleaner Chore does not start
  • [HBASE-12931] - The existing KeyValues in memstore are not removed completely after inserting cell into memStore
  • [HBASE-12948] - Calling Increment#addColumn on the same column multiple times produces wrong result
  • [HBASE-12949] - Scanner can be stuck in infinite loop if the HFile is corrupted
  • [HBASE-12951] - TestHCM.testConnectionClose is flakey when using AsyncRpcClient as client implementation
  • [HBASE-12953] - RegionServer is not functionally working with AysncRpcClient in secure mode
  • [HBASE-12954] - Ability impaired using HBase on multihomed hosts
  • [HBASE-12961] - Negative values in read and write region server metrics
  • [HBASE-12964] - Add the ability for hbase-daemon.sh to start in the foreground
  • [HBASE-12969] - Parameter Validation is not there for shell script, local-master-backup.sh and local-regionservers.sh
  • [HBASE-12983] - HBase book mentions hadoop.ssl.enabled when it should be hbase.ssl.enabled
  • [HBASE-12993] - Use HBase 1.0 interfaces in hbase-thrift
  • [HBASE-12999] - Make foreground_start return the correct exit code
  • [HBASE-13001] - NullPointer in master logs for table.jsp
  • [HBASE-13004] - Make possible to explain why HBaseTestingUtility.waitFor fails
  • [HBASE-13007] - Fix the test timeouts being caused by ChoreService
  • [HBASE-13011] - TestLoadIncrementalHFiles is flakey when using AsyncRpcClient as client implementation
  • [HBASE-13023] - Document multiWAL
  • [HBASE-13029] - Table state should be deleted from META as a last operation in DeleteTableHandler
  • [HBASE-13032] - Migration of states should be performed once META is assigned and onlined.
  • [HBASE-13036] - Meta scanner should use its own threadpool
  • [HBASE-13040] - Possible failure of TestHMasterRPCException
  • [HBASE-13041] - TestEnableTableHandler should not call AssignmentManager#assign concurrently with master
  • [HBASE-13047] - Add "HBase Configuration" link missing on the table details pages
  • [HBASE-13048] - Use hbase.crypto.wal.algorithm in SecureProtobufLogReader while decrypting the data
  • [HBASE-13049] - wal_roll ruby command doesn't work.
  • [HBASE-13050] - Hbase shell create_namespace command throws ArrayIndexOutOfBoundException for (invalid) empty text input.
  • [HBASE-13052] - Explain each region split policy
  • [HBASE-13055] - HRegion FIXED_OVERHEAD missed one boolean
  • [HBASE-13058] - Hbase shell command 'scan' for non existent table shows unnecessary info for one unrelated existent table.
  • [HBASE-13061] - RegionStates can remove wrong region from server holdings
  • [HBASE-13062] - Add documentation coverage for configuring dns server with thrift and rest gateways
  • [HBASE-13065] - Increasing -Xmx when running TestDistributedLogSplitting
  • [HBASE-13066] - Fix typo in AsyncRpcChannel
  • [HBASE-13069] - Thrift Http Server returns an error code of 500 instead of 401 when authentication fails
  • [HBASE-13070] - Fix possibly zero length family and qualifier is TestCacheOnWrite
  • [HBASE-13072] - BucketCache.evictBlock returns true if block does not exist
  • [HBASE-13075] - TableInputFormatBase spuriously warning about multiple initializeTable calls
  • [HBASE-13076] - Table can be forcibly enabled in AssignmentManager during table disabling.
  • [HBASE-13077] - BoundedCompletionService doesn't pass trace info to server
  • [HBASE-13081] - Branch precommit builds are not updating to branch head before patch application
  • [HBASE-13082] - Coarsen StoreScanner locks to RegionScanner
  • [HBASE-13083] - Master can be dead-locked while assigning META.
  • [HBASE-13084] - Add labels to VisibilityLabelsCache asynchronously causes TestShell flakey
  • [HBASE-13085] - Security issue in the implementation of Rest gataway 'doAs' proxy user support
  • [HBASE-13088] - HBase native API was not released
  • [HBASE-13091] - Split ZK Quorum on Master WebUI
  • [HBASE-13093] - Local mode HBase instance doesn't shut down.
  • [HBASE-13097] - Use same EventLoopGroup for different AsyncRpcClients if possible
  • [HBASE-13102] - Fix Pseudo-distributed Mode which was broken in 1.0.0
  • [HBASE-13111] - truncate_preserve command is failing with undefined method error
  • [HBASE-13112] - quota.rb, security.rb and visibility_labels.rb leak connection
  • [HBASE-13114] - [UNITTEST] TestEnableTableHandler.testDeleteForSureClearsAllTableRowsFromMeta
  • [HBASE-13115] - Fix the usage of remote user in thrift doAs implementation.
  • [HBASE-13119] - FileLink should implement equals
  • [HBASE-13123] - Minor bug in ROW bloom filter
  • [HBASE-13131] - ReplicationAdmin leaks connections if there's an error in the constructor
  • [HBASE-13133] - NPE when running TestSplitLogManager
  • [HBASE-13134] - mutateRow and checkAndMutate apis don't throw region level exceptions
  • [HBASE-13135] - Move replication ops mgmt stuff from Javadoc to Ref Guide
  • [HBASE-13136] - TestSplitLogManager.testGetPreviousRecoveryMode is flakey
  • [HBASE-13139] - Clean up missing JAVA_HOME message in bin/hbase-config.sh
  • [HBASE-13141] - IntegrationTestAcidGuarantees returns incorrect values for getColumnFamilies
  • [HBASE-13143] - TestCacheOnWrite is flaky and needs a diet
  • [HBASE-13145] - TestNamespaceAuditor.testRegionMerge is flaky
  • [HBASE-13146] - Race Condition in ScheduledChore and ChoreService
  • [HBASE-13149] - HBase MR is broken on Hadoop 2.5+ Yarn
  • [HBASE-13150] - TestMasterObserver failing disable table at end of test
  • [HBASE-13155] - Fix TestPrefixTree
  • [HBASE-13156] - Fix minor rat violation recently introduced (asciidoctor.css).
  • [HBASE-13163] - Add HBase version to header and footer of HTML and PDF docs
  • [HBASE-13165] - Fix docs and scripts for default max heaps size after HBASE-11804
  • [HBASE-13167] - The check for balancerCutoffTime is buggy
  • [HBASE-13174] - Apply HBASE-11804 to Windows scripts
  • [HBASE-13176] - Flakey TestZooKeeper test.
  • [HBASE-13181] - TestHRegionReplayEvents.testReplayBulkLoadEvent fails frequently.
  • [HBASE-13186] - HBase build error due to checkstyle
  • [HBASE-13188] - java.lang.ArithmeticException issue in BoundedByteBufferPool.putBuffer
  • [HBASE-13191] - mvn site fails on jenkins due to permgen
  • [HBASE-13192] - IntegrationTestBulkLoad doesn't wait for table modification sometimes leading to spurious test failures
  • [HBASE-13193] - RegionScannerImpl filters should not be reset if a partial Result is returned
  • [HBASE-13194] - TableNamespaceManager not ready cause MasterQuotaManager initialization fail
  • [HBASE-13196] - Add info about default number of versions when using the export tool
  • [HBASE-13200] - Improper configuration can leads to endless lease recovery during failover
  • [HBASE-13206] - Fix TableLock tableName log format
  • [HBASE-13208] - Patch build should match the patch filename and not the whole relative URL in findBranchNameFromPatchName
  • [HBASE-13217] - Procedure fails due to ZK issue
  • [HBASE-13218] - Correct the syntax shown for using ExportSnapshot tool in the book
  • [HBASE-13220] - set_quota should fail for non-existing table and namespace
  • [HBASE-13221] - HDFS Transparent Encryption breaks WAL writing in Hadoop 2.6.0
  • [HBASE-13224] - Minor formatting issue when logging a namespace scope in AuthResult#toContextString
  • [HBASE-13227] - LoadIncrementalHFile should skip non-files inside a possible family-dir
  • [HBASE-13229] - Specify bash for local-regionservers.sh and local-master-backup.sh
  • [HBASE-13232] - ConnectionManger : Batch pool threads and metaLookup pool threads should use different name pattern
  • [HBASE-13239] - HBase grant at specific column level does not work for Groups
  • [HBASE-13242] - TestPerColumnFamilyFlush.testFlushingWhenLogRolling hung
  • [HBASE-13246] - Correct the assertion for namespace permissions in tearDown method of TestAccessController
  • [HBASE-13250] - chown of ExportSnapshot does not cover all path and files
  • [HBASE-13253] - LoadIncrementalHFiles unify hfiles discovery
  • [HBASE-13254] - EnableTableHandler#prepare would not throw TableNotFoundException during recovery
  • [HBASE-13262] - ResultScanner doesn't return all rows in Scan
  • [HBASE-13265] - Make thrift2 usable from c++
  • [HBASE-13273] - Make Result.EMPTY_RESULT read-only; currently it can be modified
  • [HBASE-13274] - Fix misplaced deprecation in Delete#addXYZ
  • [HBASE-13275] - Setting hbase.security.authorization to false does not disable authorization
  • [HBASE-13279] - Add src/main/asciidoc/asciidoctor.css to RAT exclusion list in POM
  • [HBASE-13281] - 'hbase.bucketcache.size' description in hbase book is not correct
  • [HBASE-13282] - Fix the minor issues of running Canary on kerberized environment
  • [HBASE-13285] - Fix flaky getRegions() in TestAccessController.setUp()
  • [HBASE-13288] - Fix naming of parameter in Delete constructor
  • [HBASE-13289] - typo in splitSuccessCount metric
  • [HBASE-13294] - Fix the critical ancient loopholes in security testing infrastructure.
  • [HBASE-13295] - TestInfoServers hang
  • [HBASE-13296] - Fix the deletion of acl notify nodes for namespace.
  • [HBASE-13298] - Clarify if Table.{set|get}WriteBufferSize() is deprecated or not
  • [HBASE-13299] - Add setReturnResults() to Increment, like Append has
  • [HBASE-13300] - Fix casing in getTimeStamp() and setTimestamp() for Mutations
  • [HBASE-13301] - Possible memory leak in BucketCache
  • [HBASE-13305] - Get(Get get) is not copying the row key
  • [HBASE-13308] - Fix flaky TestEndToEndSplitTransaction
  • [HBASE-13309] - Some tests do not reset EnvironmentEdgeManager
  • [HBASE-13311] - TestQuotaThrottle flaky on slow machine
  • [HBASE-13312] - SmallScannerCallable does not increment scan metrics
  • [HBASE-13314] - Fix NPE in HMaster.getClusterStatus()
  • [HBASE-13315] - BufferedMutator should be @InterfaceAudience.Public
  • [HBASE-13317] - Region server reportForDuty stuck looping if there is a master change
  • [HBASE-13318] - RpcServer.getListenerAddress should handle when the accept channel is closed
  • [HBASE-13320] - 'hbase.bucketcache.size' configuration value is not correct in hbase-default.xml
  • [HBASE-13321] - Fix flaky TestHBaseFsck
  • [HBASE-13324] - o.a.h.h.Coprocessor should be LimitedPrivate("Coprocessor")
  • [HBASE-13325] - Protocol Buffers 2.5 no longer available for download on code.google.com
  • [HBASE-13326] - Disabled table can't be enabled after HBase is restarted
  • [HBASE-13328] - LoadIncrementalHFile.doBulkLoad(Path,HTable) should handle managed connections
  • [HBASE-13329] - ArrayIndexOutOfBoundsException in CellComparator#getMinimumMidpointArray
  • [HBASE-13331] - Exceptions from DFS client can cause CatalogJanitor to delete referenced files
  • [HBASE-13333] - Renew Scanner Lease without advancing the RegionScanner
  • [HBASE-13337] - Table regions are not assigning back, after restarting all regionservers at once.
  • [HBASE-13339] - Update default Hadoop version to latest for master
  • [HBASE-13346] - Clean up Filter package for post 1.0 s/KeyValue/Cell/g
  • [HBASE-13352] - Add hbase.import.version to Import usage.
  • [HBASE-13355] - QA bot reports checking javac twice
  • [HBASE-13357] - If maxTables/maxRegions exceeds quota in a namespace, throw QuotaExceededException
  • [HBASE-13359] - Update ACL matrix to include table owner.
  • [HBASE-13364] - Make using the default javac on by default
  • [HBASE-13368] - Hash.java is declared as public Interface - but it should be Private
  • [HBASE-13371] - Fix typo in TestAsyncIPC
  • [HBASE-13374] - Small scanners (with particular configurations) do not return all rows
  • [HBASE-13377] - Canary may generate false alarm on the first region when there are many delete markers
  • [HBASE-13382] - IntegrationTestBigLinkedList should use SecureRandom
  • [HBASE-13383] - TestRegionServerObserver.testCoprocessorHooksInRegionsMerge zombie after HBASE-12975
  • [HBASE-13384] - Fix Javadoc warnings introduced by HBASE-12972
  • [HBASE-13385] - TestGenerateDelegationToken is broken with hadoop 2.8.0
  • [HBASE-13388] - Handling NullPointer in ZKProcedureMemberRpcs while getting ZNode data
  • [HBASE-13394] - Failed to recreate a table when quota is enabled
  • [HBASE-13397] - Purge duplicate rpc request thread local
  • [HBASE-13406] - TestAccessController is flaky when create is slow
  • [HBASE-13409] - Add categories to uncategorized tests
  • [HBASE-13410] - Bug in KeyValueUtil.oswrite() for non Keyvalue cases
  • [HBASE-13411] - Misleading error message when request size quota limit exceeds
  • [HBASE-13414] - TestHCM no longer needs to test for JRE 6.
  • [HBASE-13417] - batchCoprocessorService() does not handle NULL keys
  • [HBASE-13423] - Remove duplicate entry for hbase.regionserver.regionSplitLimit in hbase-default.xml
  • [HBASE-13430] - HFiles that are in use by a table cloned from a snapshot may be deleted when that snapshot is deleted
  • [HBASE-13437] - ThriftServer leaks ZooKeeper connections
  • [HBASE-13457] - SnapshotExistsException doesn't honor the DoNotRetry
  • [HBASE-13460] - Revise the MetaLookupPool executor-related defaults (introduced in HBASE-13036)
  • [HBASE-13471] - Fix a possible infinite loop in doMiniBatchMutation
  • [HBASE-13473] - deleted cells come back alive after the stripe compaction
  • [HBASE-13475] - Small spelling mistake in region_mover#isSuccessfulScan causes NoMethodError
  • [HBASE-13477] - Create metrics on failed requests
  • [HBASE-13480] - ShortCircuitConnection doesn't short-circuit all calls as expected
  • [HBASE-13482] - Phoenix is failing to scan tables on secure environments.
  • [HBASE-13486] - region_status.rb broken with NameError: uninitialized constant IOException
  • [HBASE-13490] - foreground daemon start re-executes ulimit output
  • [HBASE-13491] - Issue in FuzzyRowFilter#getNextForFuzzyRule
  • [HBASE-13499] - AsyncRpcClient test cases failure in powerpc
  • [HBASE-13517] - Publish a client artifact with shaded dependencies
  • [HBASE-13520] - NullPointerException in TagRewriteCell
  • [HBASE-13523] - API Doumentation formatting is broken
  • [HBASE-13524] - TestReplicationAdmin fails on JDK 1.8
  • [HBASE-13526] - TestRegionServerReportForDuty can be flaky: hang or timeout
  • [HBASE-13527] - The default value for hbase.client.scanner.max.result.size is never actually set on Scans
  • [HBASE-13528] - A bug on selecting compaction pool
  • [HBASE-13533] - section on configuring ~/.m2/settings.xml has no anchor
  • [HBASE-13546] - NPE on region server status page if all masters are down
  • [HBASE-13555] - StackServlet produces 500 error
  • [HBASE-13556] - In assignment, treat system tables as 'special'; assign after hbase:meta and before user-space tables
  • [HBASE-13560] - Large compaction queue should steal from small compaction queue when idle
  • [HBASE-13561] - ITBLL.Verify doesn't actually evaluate counters after job completes
  • [HBASE-13564] - Master MBeans are not published
  • [HBASE-13575] - TestChoreService has to make sure that the opened ChoreService is closed for each unit test
  • [HBASE-13576] - HBCK enhancement: Failure in checking one region should not fail the entire HBCK operation.
  • [HBASE-13577] - Documentation is pointing to wrong port for Master Web UI
  • [HBASE-13580] - region_mover.rb broken with TypeError: no public constructors for Java::OrgApacheHadoopHbaseClient::HTable
  • [HBASE-13585] - HRegionFileSystem#splitStoreFile() finishes without closing the file handle in some situation
  • [HBASE-13589] - [WINDOWS] hbase.cmd script is broken
  • [HBASE-13594] - MultiRowRangeFilter shouldn't call HBaseZeroCopyByteString.wrap() directly
  • [HBASE-13595] - Fix Javadoc warn induced in Bytes.java
  • [HBASE-13596] - src assembly does not build
  • [HBASE-13599] - The Example Provided in Section 69: Examples of the Documentation Does Not Compile
  • [HBASE-13600] - check_compatibility.sh should ignore shaded jars
  • [HBASE-13601] - Connection leak during log splitting
  • [HBASE-13604] - bin/hbase mapredcp does not include yammer-metrics jar
  • [HBASE-13606] - AssignmentManager.assign() is not sync in both path
  • [HBASE-13607] - TestSplitLogManager.testGetPreviousRecoveryMode consistently failing
  • [HBASE-13608] - 413 Error with Stargate through Knox, using AD, SPNEGO, and Pre-Auth
  • [HBASE-13611] - update clover to work for current versions
  • [HBASE-13612] - TestRegionFavoredNodes doesn't guard against setup failure
  • [HBASE-13617] - TestReplicaWithCluster.testChangeTable timeout
  • [HBASE-13618] - ReplicationSource is too eager to remove sinks
  • [HBASE-13625] - Use HDFS for HFileOutputFormat2 partitioner's path
  • [HBASE-13628] - Use AtomicLong as size in BoundedConcurrentLinkedQueue
  • [HBASE-13630] - Remove dead code in BufferedDataEncoder
  • [HBASE-13633] - draining_servers.rb broken with NoMethodError: undefined method 'getServerInfo'
  • [HBASE-13634] - Avoid unsafe reference equality checks to EMPTY byte[]
  • [HBASE-13635] - Regions stuck in transition because master is incorrectly assumed dead
  • [HBASE-13638] - Put copy constructor is shallow
  • [HBASE-13646] - HRegion#execService should not try to build incomplete messages
  • [HBASE-13647] - Default value for hbase.client.operation.timeout is too high
  • [HBASE-13648] - test-patch.sh should ignore 'protobuf.generated'
  • [HBASE-13649] - CellComparator.compareTimestamps javadoc inconsistent and wrong
  • [HBASE-13651] - Handle StoreFileScanner FileNotFoundException
  • [HBASE-13653] - Uninitialized HRegionServer#walFactory may result in NullPointerException at region server startup​
  • [HBASE-13661] - Correct binary compatibility issues discovered in 1.1.0RC0
  • [HBASE-13662] - RSRpcService.scan() throws an OutOfOrderScannerNext if the scan has a retriable failure
  • [HBASE-13663] - HMaster fails to restart 'HMaster: Failed to become active master'
  • [HBASE-13668] - TestFlushRegionEntry is flaky
  • [HBASE-13686] - Fail to limit rate in RateLimiter
  • [HBASE-13693] - [HBase MOB] Mob files are not encrypting.
  • [HBASE-13694] - CallQueueSize is incorrectly decremented until the response is sent
  • [HBASE-13699] - Expand information about HBase quotas
  • [HBASE-13700] - Allow Thrift2 HSHA server to have configurable threads
  • [HBASE-13703] - ReplicateContext should not be a member of ReplicationSource
  • [HBASE-13704] - Hbase throws OutOfOrderScannerNextException when MultiRowRangeFilter is used
  • [HBASE-13706] - CoprocessorClassLoader should not exempt Hive classes
  • [HBASE-13709] - Updates to meta table server columns may be eclipsed
  • [HBASE-13711] - Provide an API to set min and max versions in HColumnDescriptor
  • [HBASE-13717] - TestBoundedRegionGroupingProvider#setMembershipDedups need to set HDFS diretory for WAL
  • [HBASE-13719] - Asynchronous scanner -- cache size-in-bytes bug fix
  • [HBASE-13721] - Improve shell scan performances when using LIMIT
  • [HBASE-13722] - Avoid non static method from BloomFilterUtil
  • [HBASE-13723] - In table.rb scanners are never closed.
  • [HBASE-13729] - Old hbase.regionserver.global.memstore.upperLimit and lowerLimit properties are ignored if present
  • [HBASE-13731] - TestReplicationAdmin should clean up MiniZKCluster resource
  • [HBASE-13732] - TestHBaseFsck#testParallelWithRetriesHbck fails intermittently
  • [HBASE-13733] - Failed MiniZooKeeperCluster startup did not shutdown ZK servers
  • [HBASE-13734] - Improper timestamp checking with VisibilityScanDeleteTracker
  • [HBASE-13737] - [HBase MOB] MOBTable cloned from a snapshot leads to data loss, when that actual snapshot and main table is deleted.
  • [HBASE-13741] - Disable TestRegionObserverInterface#testRecovery and testLegacyRecovery
  • [HBASE-13744] - TestCorruptedRegionStoreFile is flaky
  • [HBASE-13746] - list_replicated_tables command is not listing table in hbase shell.
  • [HBASE-13760] - Cleanup Findbugs keySet iterator warnings
  • [HBASE-13767] - Allow ZKAclReset to set and not just clear ZK ACLs
  • [HBASE-13768] - ZooKeeper znodes are bootstrapped with insecure ACLs in a secure configuration
  • [HBASE-13770] - Programmatic JAAS configuration option for secure zookeeper may be broken
  • [HBASE-13776] - Setting illegal versions for HColumnDescriptor does not throw IllegalArgumentException
  • [HBASE-13777] - Table fragmentation display triggers NPE on master status page
  • [HBASE-13778] - BoundedByteBufferPool incorrectly increasing runningAverage buffer length
  • [HBASE-13779] - Calling table.exists() before table.get() end up with an empty Result
  • [HBASE-13789] - ForeignException should not be sent to the client
  • [HBASE-13792] - Regionserver unable to report to master when master is restarted
  • [HBASE-13796] - ZKUtil doesn't clean quorum setting properly
  • [HBASE-13797] - Fix resource leak in HBaseFsck
  • [HBASE-13800] - TestStore#testDeleteExpiredStoreFiles should create unique data/log directory for each call
  • [HBASE-13801] - Hadoop src checksum is shown instead of HBase src checksum in master / RS UI
  • [HBASE-13802] - Procedure V2: Master fails to come up due to rollback of create namespace table
  • [HBASE-13809] - TestRowTooBig should use HDFS directory for its region directory
  • [HBASE-13811] - Splitting WALs, we are filtering out too many edits -> DATALOSS
  • [HBASE-13812] - Deleting of last Column Family of a table should not be allowed
  • [HBASE-13813] - Fix Javadoc warnings in Procedure.java
  • [HBASE-13820] - Zookeeper is failing to start
  • [HBASE-13821] - WARN if hbase.bucketcache.percentage.in.combinedcache is set
  • [HBASE-13824] - TestGenerateDelegationToken: Master fails to start in Windows environment
  • [HBASE-13825] - Use ProtobufUtil#mergeFrom and ProtobufUtil#mergeDelimitedFrom in place of builder methods of same name
  • [HBASE-13826] - Unable to create table when group acls are appropriately set.
  • [HBASE-13831] - TestHBaseFsck#testParallelHbck is flaky against hadoop 2.6+
  • [HBASE-13833] - LoadIncrementalHFile.doBulkLoad(Path,HTable) doesn't handle unmanaged connections when using SecureBulkLoad
  • [HBASE-13834] - Evict count not properly passed to HeapMemoryTuner.
  • [HBASE-13835] - KeyValueHeap.current might be in heap when exception happens in pollRealKV
  • [HBASE-13839] - Fix AssgnmentManagerTmpl.jamon issues (coloring, content etc.)
  • [HBASE-13843] - Fix internal constant text in ReplicationManager.java
  • [HBASE-13845] - Expire of one region server carrying meta can bring down the master
  • [HBASE-13847] - getWriteRequestCount function in HRegionServer uses int variable to return the count.
  • [HBASE-13849] - Remove restore and clone snapshot from the WebUI
  • [HBASE-13851] - RpcClientImpl.close() can hang with cancelled replica RPCs
  • [HBASE-13853] - ITBLL improvements after HBASE-13811
  • [HBASE-13857] - Slow WAL Append count in ServerMetricsTmpl.jamon is hardcoded to zero
  • [HBASE-13858] - RS/MasterDumpServlet dumps threads before its “Stacks” header
  • [HBASE-13861] - BucketCacheTmpl.jamon has wrong bucket free and used labels
  • [HBASE-13863] - Multi-wal feature breaks reported number and size of HLogs
  • [HBASE-13864] - HColumnDescriptor should parse the output from master and from describe for TTL
  • [HBASE-13865] - Increase the default value for hbase.hregion.memstore.block.multipler from 2 to 4 (part 2)
  • [HBASE-13866] - Add endpoint coprocessor to the section hbase.coprocessor.region.classes in HBase book
  • [HBASE-13873] - LoadTestTool addAuthInfoToConf throws UnsupportedOperationException
  • [HBASE-13875] - Clock skew between master and region server may render restored region without server address
  • [HBASE-13877] - Interrupt to flush from TableFlushProcedure causes dataloss in ITBLL
  • [HBASE-13878] - Set hbase.fs.tmp.dir config in HBaseTestingUtility.java for Phoenix UT to use
  • [HBASE-13882] - Fix RegionSplitPolicy section in HBase book
  • [HBASE-13883] - Fix Memstore Flush section in HBase book
  • [HBASE-13885] - ZK watches leaks during snapshots
  • [HBASE-13888] - Fix refill bug from HBASE-13686
  • [HBASE-13889] - Fix hbase-shaded-client artifact so it works on hbase-downstreamer
  • [HBASE-13892] - Scanner with all results filtered out results in NPE
  • [HBASE-13893] - Replace HTable with Table in client tests
  • [HBASE-13895] - DATALOSS: Region assigned before WAL replay when abort
  • [HBASE-13897] - OOM may occur when Import imports a row with too many KeyValues
  • [HBASE-13901] - Error while calling watcher on creating and deleting an HBase table
  • [HBASE-13905] - TestRecoveredEdits.testReplayWorksThoughLotsOfFlushing failing consistently on branch-1.1
  • [HBASE-13907] - Document how to deploy a coprocessor
  • [HBASE-13913] - RAT exclusion list missing asciidoctor support files
  • [HBASE-13918] - Fix hbase:namespace description in webUI
  • [HBASE-13923] - Loaded region coprocessors are not reported in shell status command
  • [HBASE-13924] - Description for hbase.dynamic.jars.dir is wrong
  • [HBASE-13930] - Exclude Findbugs packages from shaded jars
  • [HBASE-13933] - DBE's seekBefore with tags corrupts the tag's offset information thus leading to incorrect results
  • [HBASE-13938] - Deletes done during the region merge transaction may get eclipsed
  • [HBASE-13944] - Prefix_Tree seeks to null if the seeked Cell is greater than the last key in the file
  • [HBASE-13945] - Prefix_Tree seekBefore() does not work correctly
  • [HBASE-13958] - RESTApiClusterManager calls kill() instead of suspend() and resume()
  • [HBASE-13959] - Region splitting uses a single thread in most common cases
  • [HBASE-13966] - Limit column width in table.jsp
  • [HBASE-13969] - AuthenticationTokenSecretManager is never stopped in RPCServer
  • [HBASE-13970] - NPE during compaction in trunk
  • [HBASE-13971] - Flushes stuck since 6 hours on a regionserver.
  • [HBASE-13974] - TestRateLimiter#testFixedIntervalResourceAvailability may fail
  • [HBASE-13976] - release manager list in ref guide is missing 0.94 line
  • [HBASE-13978] - Variable never assigned in SimpleTotalOrderPartitioner.getPartition()
  • [HBASE-13982] - Add info for visibility labels/cell TTLs to ImportTsv
  • [HBASE-13988] - Add exception handler for lease thread
  • [HBASE-13989] - Threshold for combined MemStore and BlockCache percentages is not checked
  • [HBASE-13995] - ServerName is not fully case insensitive
  • [HBASE-13997] - ScannerCallableWithReplicas cause Infinitely blocking
  • [HBASE-14000] - Region server failed to report to Master and was stuck in reportForDuty retry loop
  • [HBASE-14004] - [Replication] Inconsistency between Memstore and WAL may result in data in remote cluster that is not in the origin
  • [HBASE-14005] - Set permission to .top hfile in LoadIncrementalHFiles
  • [HBASE-14010] - TestRegionRebalancing.testRebalanceOnRegionServerNumberChange fails; cluster not balanced
  • [HBASE-14011] - MultiByteBuffer position based reads does not work correctly
  • [HBASE-14012] - Double Assignment and Dataloss when ServerCrashProcedure runs during Master failover
  • [HBASE-14021] - Quota table has a wrong description on the UI
  • [HBASE-14024] - ImportTsv is not loading hbase-default.xml
  • [HBASE-14029] - getting started for standalone still references hadoop-version-specific binary artifacts
  • [HBASE-14038] - Incremental backup list set is ignored during backup
  • [HBASE-14041] - Client MetaCache is cleared if a ThrottlingException is thrown
  • [HBASE-14042] - Fix FATAL level logging in FSHLog where logged for non fatal exceptions
  • [HBASE-14050] - NPE in org.apache.hadoop.hbase.ipc.RpcServer$Connection.readAndProcess
  • [HBASE-14054] - Acknowledged writes may get lost if regionserver clock is set backwards
  • [HBASE-14065] - ref guide section on release candidate generation refers to old doc files
  • [HBASE-14073] - TestRemoteTable.testDelete failed in the latest trunk code
  • [HBASE-14076] - ResultSerialization and MutationSerialization can throw InvalidProtocolBufferException when serializing a cell larger than 64MB
  • [HBASE-14077] - Add package to hbase-protocol protobuf files.
  • [HBASE-14088] - Close Connection in LoadTestTool#applyColumnFamilyOptions
  • [HBASE-14089] - Remove unnecessary draw of system entropy from RecoverableZooKeeper
  • [HBASE-14092] - hbck should run without locks by default and only disable the balancer when necessary
  • [HBASE-14094] - Procedure.proto can't be compiled to C++
  • [HBASE-14098] - Allow dropping caches behind compactions
  • [HBASE-14100] - Fix high priority findbugs warnings
  • [HBASE-14106] - TestProcedureRecovery is flaky
  • [HBASE-14115] - Fix resource leak in HMasterCommandLine
  • [HBASE-14119] - Show meaningful error messages instead of stack traces in hbase shell commands. Fixing few commands in this jira.
  • [HBASE-14145] - Allow the Canary in regionserver mode to try all regions on the server, not just one
  • [HBASE-14146] - Once replication sees an error it slows down forever
  • [HBASE-14153] - Typo in ProcedureManagerHost.MASTER_PROCEUDRE_CONF_KEY
  • [HBASE-14155] - StackOverflowError in reverse scan
  • [HBASE-14156] - Fix test failure in TestOpenTableInCoprocessor
  • [HBASE-14157] - Interfaces implemented by subclasses should be checked when registering CoprocessorService
  • [HBASE-14162] - Fixing maven target for regenerating thrift classes fails against 0.9.2
  • [HBASE-14166] - Per-Region metrics can be stale
  • [HBASE-14168] - Avoid useless retry for DoNotRetryIOException in TableRecordReaderImpl
  • [HBASE-14173] - includeMVCCReadpoint parameter in DefaultCompactor#createTmpWriter() represents no-op
  • [HBASE-14178] - regionserver blocks because of waiting for offsetLock
  • [HBASE-14183] - [Shell] Scanning hbase meta table is failing in master branch
  • [HBASE-14185] - Incorrect region names logged by MemStoreFlusher
  • [HBASE-14192] - Fix REST Cluster constructor with String List
  • [HBASE-14196] - Thrift server idle connection timeout issue
  • [HBASE-14201] - hbck should not take a lock unless fixing errors
  • [HBASE-14205] - RegionCoprocessorHost System.nanoTime() performance bottleneck
  • [HBASE-14206] - MultiRowRangeFilter returns records whose rowKeys are out of allowed ranges
  • [HBASE-14208] - Remove yarn dependencies on -common and -client
  • [HBASE-14209] - TestShell visibility tests failing
  • [HBASE-14211] - Add more rigorous integration tests of splits
  • [HBASE-14214] - list_labels shouldn't raise ArgumentError if no labels are defined
  • [HBASE-14219] - src tgz no longer builds after HBASE-14085
  • [HBASE-14224] - Fix coprocessor handling of duplicate classes
  • [HBASE-14228] - Close BufferedMutator and connection in MultiTableOutputFormat
  • [HBASE-14229] - Flushing canceled by coprocessor still leads to memstoreSize set down
  • [HBASE-14234] - Procedure-V2: Exception encountered in WALProcedureStore#rollWriter() should be properly handled
  • [HBASE-14241] - Fix deadlock during cluster shutdown due to concurrent connection close
  • [HBASE-14243] - Incorrect NOTICE file in hbase-it test-jar
  • [HBASE-14249] - shaded jar modules create spurious source and test jars with incorrect LICENSE/NOTICE info
  • [HBASE-14250] - branch-1.1 hbase-server test-jar has incorrect LICENSE
  • [HBASE-14251] - javadoc jars use LICENSE/NOTICE from primary artifact
  • [HBASE-14252] - RegionServers fail to start when setting hbase.ipc.server.callqueue.scan.ratio to 0
  • [HBASE-14256] - Flush task message may be confusing when region is recovered
  • [HBASE-14257] - Periodic flusher only handles hbase:meta, not other system tables
  • [HBASE-14258] - Make region_mover.rb script case insensitive with regard to hostname
  • [HBASE-14269] - FuzzyRowFilter omits certain rows when multiple fuzzy keys exist
  • [HBASE-14273] - Rename MVCC to MVCC: From MultiVersionConsistencyControl to MultiVersionConcurrencyControl
  • [HBASE-14280] - Bulk Upload from HA cluster to remote HA hbase cluster fails
  • [HBASE-14283] - Reverse scan doesn’t work with HFile inline index/bloom blocks
  • [HBASE-14286] - Correct typo in argument name for WALSplitter.writeRegionSequenceIdFile
  • [HBASE-14291] - NPE On StochasticLoadBalancer Balance Involving RS With No Regions
  • [HBASE-14292] - Call Me Maybe HBase links haved moved
  • [HBASE-14302] - TableSnapshotInputFormat should not create back references when restoring snapshot
  • [HBASE-14307] - Incorrect use of positional read api in HFileBlock
  • [HBASE-14313] - After a Connection sees ConnectionClosingException it never recovers
  • [HBASE-14315] - Save one call to KeyValueHeap.peek per row
  • [HBASE-14317] - Stuck FSHLog: bad disk (HDFS-8960) and can't roll WAL
  • [HBASE-14326] - HBase book: fix definition of max min size to compact
  • [HBASE-14327] - TestIOFencing#testFencingAroundCompactionAfterWALSync is flaky
  • [HBASE-14329] - Report region in transition only ever operates on one region
  • [HBASE-14337] - build error on master
  • [HBASE-14338] - License notification misspells 'Asciidoctor'
  • [HBASE-14343] - Fix debug message in SimpleRegionNormalizer for small regions
  • [HBASE-14346] - Typo in FamilyFilter
  • [HBASE-14347] - Add a switch to DynamicClassLoader to disable it
  • [HBASE-14349] - pre-commit zombie finder is overly broad
  • [HBASE-14354] - Minor improvements for usage of the mlock agent
  • [HBASE-14359] - HTable#close will hang forever if unchecked error/exception thrown in AsyncProcess#sendMultiAction
  • [HBASE-14362] - org.apache.hadoop.hbase.master.procedure.TestWALProcedureStoreOnHDFS is super duper flaky
  • [HBASE-14366] - NPE in case visibility expression is not present in labels table during importtsv run
  • [HBASE-14367] - Add normalization support to shell
  • [HBASE-14370] - Use separate thread for calling ZKPermissionWatcher#refreshNodes()
  • [HBASE-14380] - Correct data gets skipped along with bad data in importTsv bulk load thru TsvImporterTextMapper
  • [HBASE-14382] - TestInterfaceAudienceAnnotations should hadoop-compt module resources
  • [HBASE-14384] - Trying to run canary locally with -regionserver option causes exception
  • [HBASE-14385] - Close the sockets that is missing in connection closure.
  • [HBASE-14392] - [tests] TestLogRollingNoCluster fails on master from time to time
  • [HBASE-14393] - Have TestHFileEncryption clean up after itself so it don't go all zombie on us
  • [HBASE-14394] - Properly close the connection after reading records from table.
  • [HBASE-14400] - Fix HBase RPC protection documentation
  • [HBASE-14411] - Fix unit test failures when using multiwal as default WAL provider
  • [HBASE-14425] - In Secure Zookeeper cluster superuser will not have sufficient permission if multiple values are configured in "hbase.superuser"
  • [HBASE-14427] - Fix 'should' assertions in TestFastFail
  • [HBASE-14429] - Checkstyle report is broken
  • [HBASE-14431] - AsyncRpcClient#removeConnection() never removes connection from connections pool if server fails
  • [HBASE-14437] - ArithmeticException in ReplicationInterClusterEndpoint
  • [HBASE-14445] - ExportSnapshot does not honor -chmod option
  • [HBASE-14449] - Rewrite deadlock prevention for concurrent connection close
  • [HBASE-14458] - AsyncRpcClient#createRpcChannel() should check and remove dead channel before creating new one to same server
  • [HBASE-14462] - rolling_restart.sh --master-only throws "line 142: test: 0: unary operator expected"
  • [HBASE-14463] - Severe performance downgrade when parallel reading a single key from BucketCache
  • [HBASE-14469] - Fix some comment, validation and logging around memstore lower limit configuration
  • [HBASE-14471] - Thrift - HTTP Error 413 full HEAD if using kerberos authentication
  • [HBASE-14473] - Compute region locality in parallel
  • [HBASE-14474] - DeadLock in RpcClientImpl.Connection.close()
  • [HBASE-14475] - Region split requests are always audited with "hbase" user rather than request user
  • [HBASE-14485] - ConnectionImplementation leaks on construction failure
  • [HBASE-14486] - Disable TestRegionPlacement, a flakey test for an unfinished feature
  • [HBASE-14489] - postScannerFilterRow consumes a lot of CPU
  • [HBASE-14492] - Increase REST server header buffer size from 8k to 64k
  • [HBASE-14494] - Wrong usage messages on shell commands
  • [HBASE-14497] - Reverse Scan threw StackOverflow caused by readPt checking
  • [HBASE-14499] - Master coprocessors shutdown will not happen on master abort
  • [HBASE-14500] - Remove load of deprecated MOB ruby scripts after HBASE-14227
  • [HBASE-14501] - NPE in replication when HDFS transparent encryption is enabled.
  • [HBASE-14510] - Can not set coprocessor from Shell after HBASE-14224
  • [HBASE-14512] - Cache UGI groups
  • [HBASE-14518] - Give TestScanEarlyTermination the same treatment as 'HBASE-14378 Get TestAccessController* passing again...' -- up priority handlers
  • [HBASE-14521] - Unify the semantic of hbase.client.retries.number
  • [HBASE-14523] - rolling-restart.sh --graceful will start regionserver process on master node
  • [HBASE-14525] - Append and increment operation throws NullPointerException on non-existing column families.
  • [HBASE-14531] - graceful_stop.sh "if [ "$local" ]" condition unexpected behaviour
  • [HBASE-14532] - [book] dfs.client.read.shortcircuit is referenced as hbase-site.xml config and not described in section 7
  • [HBASE-14541] - TestHFileOutputFormat.testMRIncrementalLoadWithSplit failed due to too many splits and few retries
  • [HBASE-14544] - Allow HConnectionImpl to not refresh the dns on errors
  • [HBASE-14545] - TestMasterFailover often times out
  • [HBASE-14555] - Deadlock in MVCC branch-1.2 toString()
  • [HBASE-14557] - MapReduce WALPlayer issue with NoTagsKeyValue
  • [HBASE-14577] - HBase shell help for scan and returning a column family has a typo
  • [HBASE-14578] - URISyntaxException during snapshot restore for table with user defined namespace
  • [HBASE-14581] - Znode cleanup throws auth exception in secure mode
  • [HBASE-14591] - Region with reference hfile may split after a forced split in IncreasingToUpperBoundRegionSplitPolicy
  • [HBASE-14592] - BatchRestartRsAction always restarts 0 RS when running SlowDeterministicMonkey
  • [HBASE-14594] - Use new DNS API introduced in HADOOP-12437
  • [HBASE-14597] - Fix Groups cache in multi-threaded env
  • [HBASE-14598] - ByteBufferOutputStream grows its HeapByteBuffer beyond JVM limitations
  • [HBASE-14599] - Modify site config to use protocol-relative URLs for CSS/JS
  • [HBASE-14603] - Lots of work on the POM to enhance Javadocs, Xrefs
  • [HBASE-14604] - Improve MoveCostFunction in StochasticLoadBalancer
  • [HBASE-14606] - TestSecureLoadIncrementalHFiles tests timed out in trunk build on apache
  • [HBASE-14608] - testWalRollOnLowReplication has some risk to assert failed after HBASE-14600
  • [HBASE-14621] - ReplicationLogCleaner gets stuck when a regionserver crashes
  • [HBASE-14624] - BucketCache.freeBlock is too expensive
  • [HBASE-14625] - Chaos Monkey should shut down faster
  • [HBASE-14632] - Region server aborts due to unguarded dereference of Reader
  • [HBASE-14633] - Try fluid width UI
  • [HBASE-14634] - Disable flakey TestSnapshotCloneIndependence.testOnlineSnapshotDeleteIndependent
  • [HBASE-14644] - Region in transition metric is broken
  • [HBASE-14650] - Reenable TestNamespaceAuditor
  • [HBASE-14654] - Reenable TestMultiParallel#testActiveThreadsCount
  • [HBASE-14658] - Allow loading a MonkeyFactory by class name
  • [HBASE-14660] - AssertionError found when using offheap BucketCache with assertion enabled
  • [HBASE-14661] - RegionServer link is not opening, in HBase Table page.
  • [HBASE-14663] - HStore::close does not honor config hbase.rs.evictblocksonclose
  • [HBASE-14664] - Master failover issue: Backup master is unable to start if active master is killed and started in short time interval
  • [HBASE-14667] - HBaseFsck constructors have diverged
  • [HBASE-14674] - Rpc handler / task monitoring seems to be broken after 0.98
  • [HBASE-14676] - HBaseTestCase clean out: Purge Incommon Interface and Table and Region implementations
  • [HBASE-14680] - Two configs for snapshot timeout and better defaults
  • [HBASE-14681] - Upgrade Checkstyle plugin to 2.16
  • [HBASE-14682] - CM restore functionality for regionservers is broken
  • [HBASE-14689] - Addendum and unit test for HBASE-13471
  • [HBASE-14690] - Fix css so there's no left/right scroll bar
  • [HBASE-14694] - Scan copy constructor doesn't handle allowPartialResults
  • [HBASE-14695] - Fix some easy HTML warnings
  • [HBASE-14701] - Fix flakey Failed tests: TestMobFlushSnapshotFromClient>TestFlushSnapshotFromClient.testSkipFlushTableSnapshot:199 null
  • [HBASE-14705] - Javadoc for KeyValue constructor is not correct.
  • [HBASE-14706] - RegionLocationFinder should return multiple servernames by top host
  • [HBASE-14711] - Remove or annotated deprecated methods in HRegionInfo
  • [HBASE-14712] - MasterProcWALs never clean up
  • [HBASE-14717] - enable_table_replication command should only create specified table for a peer cluster
  • [HBASE-14723] - Fix IT tests split too many times
  • [HBASE-14733] - Minor typo in alter_namespace.rb
  • [HBASE-14737] - Clear cachedMaxVersions when HColumnDescriptor#setValue(VERSIONS, value) is called
  • [HBASE-14739] - Fix broken link to Javadoc that is suppressed because it is generated code
  • [HBASE-14742] - TestHeapMemoryManager is flakey
  • [HBASE-14745] - Shade the last few dependencies in hbase-shaded-client
  • [HBASE-14751] - Book seems to be broken
  • [HBASE-14753] - TestShell is not invoked anymore
  • [HBASE-14754] - TestFastFailWithoutTestUtil failing on trunk now in #testPreemptiveFastFailException50Times
  • [HBASE-14755] - Fix some broken links and HTML problems
  • [HBASE-14759] - Avoid using Math.abs when selecting SyncRunner in FSHLog
  • [HBASE-14761] - Deletes with and without visibility expression do not delete the matching mutation
  • [HBASE-14763] - Remove usages of deprecated HConnection
  • [HBASE-14767] - Remove deprecated functions from HBaseAdmin
  • [HBASE-14768] - bin/graceful_stop.sh logs nothing as a balancer state to be stored
  • [HBASE-14769] - Remove unused functions and duplicate javadocs from HBaseAdmin
  • [HBASE-14770] - RowCounter argument input parse error
  • [HBASE-14771] - RpcServer#getRemoteAddress always returns null
  • [HBASE-14773] - Fix HBase shell tests are skipped when skipping server tests.
  • [HBASE-14774] - Raise the font size on high-DPI small-screen devices like iphone 6+
  • [HBASE-14777] - Fix Inter Cluster Replication Future ordering issues
  • [HBASE-14778] - Make block cache hit percentages not integer in the metrics system
  • [HBASE-14781] - Turn per cf flushing on for ITBLL by default
  • [HBASE-14782] - FuzzyRowFilter skips valid rows
  • [HBASE-14784] - Port conflict is not resolved in HBaseTestingUtility.randomFreePort()
  • [HBASE-14787] - Remove obsolete ConnectionImplementation.refCount
  • [HBASE-14788] - Splitting a region does not support the hbase.rs.evictblocksonclose config when closing source region
  • [HBASE-14793] - Allow limiting size of block into L1 block cache.
  • [HBASE-14797] - Last round of CSS fix-ups
  • [HBASE-14799] - Commons-collections object deserialization remote command execution vulnerability
  • [HBASE-14802] - Replaying server crash recovery procedure after a failover causes incorrect handling of deadservers
  • [HBASE-14804] - HBase shell's create table command ignores 'NORMALIZATION_ENABLED' attribute
  • [HBASE-14806] - Missing sources.jar for several modules when building HBase
  • [HBASE-14807] - TestWALLockup is flakey
  • [HBASE-14809] - Grant / revoke Namespace admin permission to group
  • [HBASE-14810] - Update Hadoop support description to explain "not tested" vs "not supported"
  • [HBASE-14812] - Fix ResultBoundedCompletionService deadlock
  • [HBASE-14815] - TestMobExportSnapshot.testExportFailure timeout occasionally
  • [HBASE-14818] - user_permission does not list namespace permissions
  • [HBASE-14822] - Renewing leases of scanners doesn't work
  • [HBASE-14823] - HBase Ref Guide Refactoring
  • [HBASE-14824] - HBaseAdmin.mergeRegions should recognize both full region names and encoded region names
  • [HBASE-14825] - HBase Ref Guide corrections of typos/misspellings
  • [HBASE-14838] - Clarify that SimpleRegionNormalizer does not merge empty (<1MB) regions
  • [HBASE-14840] - Sink cluster reports data replication request as success though the data is not replicated
  • [HBASE-14843] - TestWALProcedureStore.testLoad is flakey
  • [HBASE-14861] - HBASE_ZNODE_FILE on master server is overwritten by regionserver process in case of master-rs collocation
  • [HBASE-14867] - SimpleRegionNormalizer needs to have better heuristics to trigger merge operation
  • [HBASE-14885] - NullPointerException in HMaster#normalizeRegions() due to missing TableDescriptor
  • [HBASE-14890] - Fix javadoc checkstyle errors
  • [HBASE-14893] - Race between mutation on region and region closing operation leads to NotServingRegionException
  • [HBASE-14894] - Fix misspellings of threshold in log4j.properties files for tests
  • [HBASE-14896] - Resolve Javadoc warnings in WALKey and RegionMover
  • [HBASE-14897] - TestTableLockManager.testReapAllTableLocks is flakey
  • [HBASE-14898] - Correct Bloom filter documentation in the book
  • [HBASE-14901] - There is duplicated code to create/manage encryption keys
  • [HBASE-14904] - Mark Base[En|De]coder LimitedPrivate and fix binary compat issue
  • [HBASE-14905] - VerifyReplication does not honour versions option
  • [HBASE-14907] - NPE of MobUtils.hasMobColumns in Build failed in Jenkins: HBase-Trunk_matrix » latest1.8,Hadoop #513
  • [HBASE-14917] - Log in console if individual tests in test-patch.sh fail or pass
  • [HBASE-14922] - Delayed flush doesn't work causing flush storms.
  • [HBASE-14923] - VerifyReplication should not mask the exception during result comparison
  • [HBASE-14926] - Hung ThriftServer; no timeout on read from client; if client crashes, worker thread gets stuck reading
  • [HBASE-14928] - Start row should be set for query through HBase REST gateway involving globbing option
  • [HBASE-14929] - There is a space missing from Table "foo" is not currently available.
  • [HBASE-14930] - check_compatibility.sh needs smarter exit codes
  • [HBASE-14936] - CombinedBlockCache should overwrite CacheStats#rollMetricsPeriod()
  • [HBASE-14940] - Make our unsafe based ops more safe
  • [HBASE-14941] - locate_region shell command
  • [HBASE-14942] - Allow turning off BoundedByteBufferPool
  • [HBASE-14952] - hbase-assembly source artifact has some incorrect modules
  • [HBASE-14953] - HBaseInterClusterReplicationEndpoint: Do not retry the whole batch of edits in case of RejectedExecutionException
  • [HBASE-14954] - IllegalArgumentException was thrown when doing online configuration change in CompactSplitThread
  • [HBASE-14960] - Fallback to using default RPCControllerFactory if class cannot be loaded
  • [HBASE-14968] - ConcurrentModificationException in region close resulting in the region staying in closing state
  • [HBASE-14974] - Total number of Regions in Transition number on UI incorrect
  • [HBASE-14975] - Don't color the total RIT line yellow if it's zero
  • [HBASE-14977] - ChoreService.shutdown may result in ConcurrentModificationException
  • [HBASE-14987] - Compaction marker whose region name doesn't match current region's needs to be handled
  • [HBASE-14990] - Tests in BaseTestHBaseFsck are run by its subclasses redundantly
  • [HBASE-14991] - Fix the feature warning in scala code
  • [HBASE-14999] - Remove ref to org.mortbay.log.Log
  • [HBASE-15000] - Fix javadoc warn in LoadIncrementalHFiles
  • [HBASE-15001] - Thread Safety issues in ReplicationSinkManager and HBaseInterClusterReplicationEndpoint
  • [HBASE-15011] - turn off the jdk8 javadoc linter. :(
  • [HBASE-15014] - Fix filterCellByStore in WALsplitter is awful for performance
  • [HBASE-15015] - Checktyle plugin shouldn't check Jamon-generated Java classes
  • [HBASE-15018] - Inconsistent way of handling TimeoutException in the rpc client implementations
  • [HBASE-15019] - Replication stuck when HDFS is restarted
  • [HBASE-15020] - Remove DistributedLogReplay (a.k.a DLR)
  • [HBASE-15021] - hadoopqa doing false positives
  • [HBASE-15022] - undefined method `getZooKeeperClusterKey' for Java::OrgApacheHadoopHbaseZookeeper::ZKUtil:Class
  • [HBASE-15026] - The default value of "hbase.regions.slop" in hbase-default.xml is obsolete
  • [HBASE-15027] - Refactor the way the CompactedHFileDischarger threads are created
  • [HBASE-15028] - Minor fix on RegionGroupingProvider
  • [HBASE-15030] - Deadlock in master TableNamespaceManager while running IntegrationTestDDLMasterFailover
  • [HBASE-15032] - hbase shell scan filter string assumes UTF-8 encoding
  • [HBASE-15034] - IntegrationTestDDLMasterFailover does not clean created namespaces
  • [HBASE-15035] - bulkloading hfiles with tags that require splits do not preserve tags
  • [HBASE-15039] - HMaster and RegionServers should try to refresh token keys from zk when facing InvalidToken
  • [HBASE-15043] - region_status.rb broken with TypeError: no public constructors for Java::OrgApacheHadoopHbaseClient::HBaseAdmin
  • [HBASE-15050] - Block Ref counting does not work in Region Split cases.
  • [HBASE-15052] - Use EnvironmentEdgeManager in ReplicationSource
  • [HBASE-15057] - local-master-backup.sh doesn't start HMaster correctly
  • [HBASE-15063] - Bug in MultiByteBuf#toBytes
  • [HBASE-15064] - BufferUnderflowException after last Cell fetched from an HFile Block served from L2 offheap cache
  • [HBASE-15065] - SimpleRegionNormalizer should return multiple normalization plans in one run
  • [HBASE-15070] - DistributedHBaseCluster#restoreRegionServers() starts new RS process on master server
  • [HBASE-15074] - Zombie maker to test zombie detector
  • [HBASE-15079] - TestMultiParallel.validateLoadedData AssertionError: null
  • [HBASE-15083] - Gets from Multiactions are not counted in metrics for gets.
  • [HBASE-15085] - IllegalStateException was thrown when scanning on bulkloaded HFiles
  • [HBASE-15093] - Replication can report incorrect size of log queue for the global source when multiwal is enabled
  • [HBASE-15098] - Normalizer switch in configuration is not used
  • [HBASE-15100] - Master WALProcs still never clean up
  • [HBASE-15101] - Leaked References to StoreFile.Reader after HBASE-13082
  • [HBASE-15102] - HeapMemoryTuner can "overtune" memstore size and suddenly drop it into blocking zone
  • [HBASE-15104] - Occasional failures due to NotServingRegionException in IT tests
  • [HBASE-15109] - HM/RS failed to start when "fs.hdfs.impl.disable.cache" is set to true
  • [HBASE-15117] - Resolve ICAST findbugs warnings in current codes
  • [HBASE-15122] - Servlets generate XSS_REQUEST_PARAMETER_TO_SERVLET_WRITER findbugs warnings
  • [HBASE-15125] - HBaseFsck's adoptHdfsOrphan function creates region with wrong end key boundary
  • [HBASE-15126] - HBaseFsck's checkRegionBoundaries function sets incorrect 'storesFirstKey'
  • [HBASE-15128] - Disable region splits and merges switch in master
  • [HBASE-15132] - Master region merge RPC should authorize user request
  • [HBASE-15133] - Data loss after compaction when a row has more than Integer.MAX_VALUE columns
  • [HBASE-15137] - CallTimeoutException and CallQueueTooBigException should trigger PFFE
  • [HBASE-15139] - Connection manager doesn't pass client metrics to RpcClient
  • [HBASE-15145] - HBCK and Replication should authenticate to zookepeer using server principal
  • [HBASE-15146] - Don't block on Reader threads queueing to a scheduler queue
  • [HBASE-15147] - Shell should use Admin.listTableNames() instead of Admin.listTables()
  • [HBASE-15148] - Resolve IS2_INCONSISTENT_SYNC findbugs warning in AuthenticationTokenSecretManager
  • [HBASE-15152] - Automatically include prefix-tree module in MR jobs if present
  • [HBASE-15164] - Fix broken links found via LinkLint
  • [HBASE-15173] - Execute mergeRegions RPC call as the request user
  • [HBASE-15186] - HBASE-15158 Preamble 1 of 2: fix findbugs, add javadoc, change Region#getReadpoint to #getReadPoint, and some util
  • [HBASE-15187] - Integrate CSRF prevention filter to REST gateway
  • [HBASE-15190] - Monkey dies when running on shared cluster (gives up when can't kill the other fellows processes)
  • [HBASE-15193] - Rename ByteBufferInputStream in master
  • [HBASE-15195] - Don't run findbugs on hbase-it; it has nothing in src/main/java
  • [HBASE-15196] - HBASE-15158 Preamble 2 of 2:Add Increment tests
  • [HBASE-15198] - RPC client not using Codec and CellBlock for puts by default
  • [HBASE-15200] - ZooKeeper znode ACL checks should only compare the shortname
  • [HBASE-15206] - Flakey testSplitDaughtersNotInMeta test
  • [HBASE-15209] - disable table in HBaseTestingUtility.truncateTable
  • [HBASE-15214] - Valid mutate Ops fail with RPC Codec in use and region moves across
  • [HBASE-15216] - Canary does not accept config params from command line
  • [HBASE-15218] - On RS crash and replay of WAL, loosing all Tags in Cells
  • [HBASE-15221] - HTableMultiplexer improvements (stale region locations and resource leaks)
  • [HBASE-15231] - Make TableState.State private
  • [HBASE-15234] - ReplicationLogCleaner can abort due to transient ZK issues
  • [HBASE-15236] - Inconsistent cell reads over multiple bulk-loaded HFiles
  • [HBASE-15247] - InclusiveStopFilter does not respect reverse Filter property
  • [HBASE-15250] - Fix links that are currently redirected from old URLs
  • [HBASE-15251] - During a cluster restart, Hmaster thinks it is a failover by mistake
  • [HBASE-15252] - Data loss when replaying wal if HDFS timeout
  • [HBASE-15253] - Small bug in CellUtil.matchingRow(Cell, byte[])
  • [HBASE-15259] - WALEdits under replay will also be replicated
  • [HBASE-15271] - Spark Bulk Load: Need to write HFiles to tmp location then rename to protect from Spark Executor Failures
  • [HBASE-15276] - TestFlushSnapshotFromClient hung
  • [HBASE-15278] - AsyncRPCClient hangs if Connection closes before RPC call response
  • [HBASE-15279] - OrderedBytes.isEncodedValue does not check for int8 and int16 types
  • [HBASE-15285] - Forward-port respect for isReturnResult from HBASE-15095
  • [HBASE-15287] - mapreduce.RowCounter returns incorrect result with binary row key inputs
  • [HBASE-15289] - Add details about how to get usage instructions for Import and Export utilities
  • [HBASE-15290] - Hbase Rest CheckAndAPI should save other cells along with compared cell
  • [HBASE-15292] - Refined ZooKeeperWatcher to prevent ZooKeeper's callback while construction
  • [HBASE-15295] - MutateTableAccess.multiMutate() does not get high priority causing a deadlock
  • [HBASE-15297] - error message is wrong when a wrong namspace is specified in grant in hbase shell
  • [HBASE-15298] - Fix missing or wrong asciidoc anchors in the reference guide
  • [HBASE-15302] - Reenable the other tests disabled by HBASE-14678
  • [HBASE-15319] - clearJmxCache does not take effect actually
  • [HBASE-15322] - Operations using Unsafe path broken for platforms not having sun.misc.Unsafe
  • [HBASE-15323] - Hbase Rest CheckAndDeleteAPi should be able to delete more cells
  • [HBASE-15324] - Jitter may cause desiredMaxFileSize overflow in ConstantSizeRegionSplitPolicy and trigger unexpected split
  • [HBASE-15325] - ResultScanner allowing partial result will miss the rest of the row if the region is moved between two rpc requests
  • [HBASE-15327] - Canary will always invoke admin.balancer() in each sniffing period when writeSniffing is enabled
  • [HBASE-15328] - Unvalidated Redirect in HMaster
  • [HBASE-15329] - Cross-Site Scripting: Reflected in table.jsp
  • [HBASE-15332] - Document how to take advantage of HDFS-6133 in HBase
  • [HBASE-15348] - Fix tests broken by recent metrics re-work
  • [HBASE-15357] - TableInputFormatBase getSplitKey does not handle signed bytes correctly
  • [HBASE-15358] - canEnforceTimeLimitFromScope should use timeScope instead of sizeScope
  • [HBASE-15360] - Fix flaky TestSimpleRpcScheduler
  • [HBASE-15364] - Fix unescaped < characters in Javadoc
  • [HBASE-15378] - Scanner cannot handle heartbeat message with no results
  • [HBASE-15379] - Fake cells created in read path not implementing SettableSequenceId
  • [HBASE-15393] - Enable table replication command will fail when parent znode is not default in peer cluster
  • [HBASE-15397] - Create bulk load replication znode(hfile-refs) in ZK replication queue by default
  • [HBASE-15405] - Synchronize final results logging single thread in PE, fix wrong defaults in help message
  • [HBASE-15424] - Add bulk load hfile-refs for replication in ZK after the event is appended in the WAL
  • [HBASE-15425] - Failing to write bulk load event marker in the WAL is ignored
  • [HBASE-15430] - Failed taking snapshot - Manifest proto-message too large
  • [HBASE-15433] - SnapshotManager#restoreSnapshot not update table and region count quota correctly when encountering exception
  • [HBASE-15437] - Response size calculated in RPCServer for warning tooLarge responses does NOT count CellScanner payload
  • [HBASE-15439] - getMaximumAllowedTimeBetweenRuns in ScheduledChore ignores the TimeUnit
  • [HBASE-15441] - Fix WAL splitting when region has moved multiple times
  • [HBASE-15461] - ref guide has bad links to blogs originally posted on cloudera website
  • [HBASE-15463] - Region normalizer should check whether split/merge is enabled
  • [HBASE-15465] - userPermission returned by getUserPermission() for the selected namespace does not have namespace set
  • [HBASE-15467] - Remove 1.x/2.0 TableDescriptor incompatibility
  • [HBASE-15485] - Filter.reset() should not be called between batches
  • [HBASE-15497] - Incorrect javadoc for atomicity guarantee of Increment and Append
  • [HBASE-15504] - Fix Balancer in 1.3 not moving regions off overloaded regionserver
  • [HBASE-15515] - Improve LocalityBasedCandidateGenerator in Balancer
  • [HBASE-15520] - Fix broken TestAsyncIPC
  • [HBASE-15528] - Clean up outdated entries in hbase-default.xml
  • [HBASE-15535] - Correct link to Trafodion
  • [HBASE-15548] - SyncTable: sourceHashDir is supposed to be optional but won't work without
  • [HBASE-15559] - BaseMasterAndRegionObserver doesn't implement all the methods
  • [HBASE-15563] - 'counter' may overflow in BoundedGroupingStrategy
  • [HBASE-15566] - Add timeouts on TestMobFlushSnapshotFromClient and TestRegionMergeTransactionOnCluster
  • [HBASE-15567] - TestReplicationShell broken by recent replication changes
  • [HBASE-15574] - Minor typo on HRegionServerCommandLine.java
  • [HBASE-15578] - Handle HBASE-15234 for ReplicationHFileCleaner
  • [HBASE-15582] - SnapshotManifestV1 too verbose when there are no regions
  • [HBASE-15587] - FSTableDescriptors.getDescriptor() logs stack trace erronously
  • [HBASE-15591] - ServerCrashProcedure not yielding
  • [HBASE-15613] - TestNamespaceCommand times out
  • [HBASE-15615] - Wrong sleep time when RegionServerCallable need retry
  • [HBASE-15616] - Allow null qualifier for all table operations
  • [HBASE-15617] - Canary in regionserver mode might not enumerate all regionservers
  • [HBASE-15621] - Suppress Hbase SnapshotHFile cleaner error messages when a snaphot is going on
  • [HBASE-15622] - Superusers does not consider the keytab credentials
  • [HBASE-15623] - Update refguide to change hadoop <= 2.3.x from NT to X for hbase-1.2.x
  • [HBASE-15624] - Move master branch/hbase-2.0.0 to jdk-8 only
  • [HBASE-15627] - Miss space and closing quote in AccessController#checkSystemOrSuperUser
  • [HBASE-15634] - TestDateTieredCompactionPolicy#negativeForMajor is flaky
  • [HBASE-15635] - Mean age of Blocks in cache (seconds) on webUI should be greater than zero
  • [HBASE-15636] - hard coded wait time out value in HBaseTestingUtility#waitUntilAllRegionsAssigned might cause test failure
  • [HBASE-15637] - TSHA Thrift-2 server should allow limiting call queue size
  • [HBASE-15638] - Shade protobuf
  • [HBASE-15639] - Unguarded access to stackIndexes in Procedure#toStringDetails()
  • [HBASE-15645] - hbase.rpc.timeout is not used in operations of HTable
  • [HBASE-15650] - Remove TimeRangeTracker as point of contention when many threads reading a StoreFile
  • [HBASE-15664] - Use Long.MAX_VALUE instead of HConstants.FOREVER in CompactionPolicy
  • [HBASE-15668] - HFileReplicator$Copier fails to replicate other hfiles in the request when a hfile in not found in FS anywhere
  • [HBASE-15669] - HFile size is not considered correctly in a replication request
  • [HBASE-15670] - Add missing Snapshot.proto to the maven profile for compiling protobuf
  • [HBASE-15672] - hadoop.hbase.security.visibility.TestVisibilityLabelsWithDeletes fails
  • [HBASE-15673] - [PE tool] Fix latency metrics for multiGet
  • [HBASE-15674] - HRegionLocator#getAllRegionLocations should put the results in cache
  • [HBASE-15676] - FuzzyRowFilter fails and matches all the rows in the table if the mask consists of all 0s
  • [HBASE-15684] - Fix the broken log file size accounting
  • [HBASE-15685] - Typo in REST documentation
  • [HBASE-15693] - Reconsider the ImportOrder rule of checkstyle
  • [HBASE-15697] - Excessive TestHRegion running time on branch-1
  • [HBASE-15698] - Increment TimeRange not serialized to server
  • [HBASE-15699] - Can not sync AsyncFSWAL if no edit is appended
  • [HBASE-15703] - Deadline scheduler needs to return to the client info about skipped calls, not just drop them
  • [HBASE-15707] - ImportTSV bulk output does not support tags with hfile.format.version=3
  • [HBASE-15708] - Docker for dev-support scripts
  • [HBASE-15710] - Include issue servers information in RetriesExhaustedWithDetailsException message
  • [HBASE-15711] - Add client side property to allow logging details for batch errors
  • [HBASE-15714] - We are calling checkRow() twice in doMiniBatchMutation()
  • [HBASE-15725] - make_patch.sh should add the branch name when -b is passed.
  • [HBASE-15732] - hbase-rsgroups should be in the assembly
  • [HBASE-15738] - Ensure artifacts in project dist area include required md5 file
  • [HBASE-15741] - Provide backward compatibility for HBase coprocessor service names
  • [HBASE-15742] - Reduce allocation of objects in metrics
  • [HBASE-15746] - Remove extra RegionCoprocessor preClose() in RSRpcServices#closeRegion
  • [HBASE-15752] - ClassNotFoundException is encountered when custom WAL codec is not found in WALPlayer job
  • [HBASE-15755] - SnapshotDescriptionUtils and SnapshotTestingUtils do not have any Interface audience marked
  • [HBASE-15769] - Perform validation on cluster key for add_peer
  • [HBASE-15781] - Remove unused TableEventHandler and TotesHRegionInfo
  • [HBASE-15782] - TestShell fails due to some moved types
  • [HBASE-15783] - AccessControlConstants#OP_ATTRIBUTE_ACL_STRATEGY_CELL_FIRST not used any more.
  • [HBASE-15784] - Misuse core/maxPoolSize of LinkedBlockingQueue in ThreadPoolExecutor
  • [HBASE-15796] - TestMetaCache fails after HBASE-15745
  • [HBASE-15797] - TestIPCUtil fails after HBASE-15795
  • [HBASE-15799] - Two Shell 'close_region' Example Syntaxes Don't Work
  • [HBASE-15801] - Upgrade checkstyle for all branches
  • [HBASE-15803] - ZooKeeperWatcher's constructor can leak a ZooKeeper instance with throwing ZooKeeperConnectionException when canCreateBaseZNode is true
  • [HBASE-15807] - Update report-flakies.py to look for "FAILED" status in test report
  • [HBASE-15811] - Batch Get after batch Put does not fetch all Cells
  • [HBASE-15824] - LocalHBaseCluster gets bind exception in master info port
  • [HBASE-15828] - fix extant findbug
  • [HBASE-15830] - Sasl encryption doesn't work with AsyncRpcChannelImpl
  • [HBASE-15834] - Correct Bloom filter documentation in section 96.4 of Reference Guide
  • [HBASE-15835] - HBaseTestingUtility#startMiniCluster throws "HMasterAddress already in use" RuntimeException when a local instance of HBase is running
  • [HBASE-15840] - WAL.proto compilation broken for cpp
  • [HBASE-15841] - Performance Evaluation tool total rows may not be set correctly
  • [HBASE-15844] - We should respect hfile.block.index.cacheonwrite when write intermediate index Block
  • [HBASE-15845] - Shell Cleanup : move formatter to commands.rb; move one of the two hbase.rb to hbase_constants.rb
  • [HBASE-15848] - Fix possible null point dereference in RSGroupBasedLoadBalancer#getMisplacedRegions()
  • [HBASE-15850] - Localize the configuration change in testCheckTableLocks to reduce flakiness of TestHBaseFsck test suite
  • [HBASE-15853] - HBase backups fail if there is no /user/hbase directory on HDFS
  • [HBASE-15856] - Cached Connection instances can wind up with addresses never resolved
  • [HBASE-15858] - Some region server group shell commands don't work
  • [HBASE-15863] - Typo in Put.java class documentation
  • [HBASE-15866] - Split hbase.rpc.timeout into *.read.timeout and *.write.timeout
  • [HBASE-15871] - Memstore flush doesn't finish because of backwardseek() in memstore scanner.
  • [HBASE-15875] - Remove HTable references and HTableInterface
  • [HBASE-15876] - Remove doBulkLoad(Path hfofDir, final HTable table) though it has not been through a full deprecation cycle
  • [HBASE-15880] - RpcClientImpl#tracedWriteRequest incorrectly closes HTrace span
  • [HBASE-15884] - NPE in StoreFileScanner#skipKVsNewerThanReadpoint during reverse scan
  • [HBASE-15889] - String case conversions are locale-sensitive, used without locale
  • [HBASE-15891] - Closeable resources potentially not getting closed if exception is thrown
  • [HBASE-15897] - Fix a wrong comment about QOS order
  • [HBASE-15907] - Missing documentation of create table split options
  • [HBASE-15908] - Checksum verification is broken due to incorrect passing of ByteBuffers in DataChecksum
  • [HBASE-15909] - Use Yetus' patch naming rules in submit-patch.py
  • [HBASE-15912] - REST module has 2 extant results in findbugs
  • [HBASE-15918] - Cleanup excludes/includes file after use in hbase-personality.sh to avoid asf license error.
  • [HBASE-15925] - compat-module maven variable not evaluated
  • [HBASE-15929] - There are two classes with name TestRegionServerMetrics
  • [HBASE-15932] - Shell test fails due to uninitialized constant
  • [HBASE-15933] - NullPointerException may be thrown from SimpleRegionNormalizer#getRegionSize()
  • [HBASE-15938] - submit-patch.py: Don't crash if there are tests with same name. Refactor: Split out html template to separate file.
  • [HBASE-15944] - Spark test flooding mvn output. Redirect test logs to file.
  • [HBASE-15946] - Eliminate possible security concerns in RS web UI's store file metrics
  • [HBASE-15947] - Classes used only for tests included in main code base
  • [HBASE-15950] - Fix memstore size estimates to be more tighter
  • [HBASE-15952] - Bulk load data replication is not working when RS user does not have permission on hfile-refs node
  • [HBASE-15954] - REST server should log requests with TRACE instead of DEBUG
  • [HBASE-15955] - Disable action in CatalogJanitor#setEnabled should wait for active cleanup scan to finish
  • [HBASE-15957] - RpcClientImpl.close never ends in some circumstances
  • [HBASE-15959] - Fix flaky test TestRegionServerMetrics.testMobMetrics
  • [HBASE-15965] - Shell test changes. Use @shell.command instead directly calling functions in admin.rb and other libraries.
  • [HBASE-15975] - logic in TestHTableDescriptor#testAddCoprocessorWithSpecStr is wrong
  • [HBASE-15976] - RegionServerMetricsWrapperRunnable will be failure when disable blockcache.
  • [HBASE-15977] - Failed variable substitution on home page
  • [HBASE-15982] - Interface ReplicationEndpoint extends Guava's Service
  • [HBASE-15990] - The priority value of subsequent coprocessors in the Coprocessor.Priority.SYSTEM list are not incremented by one
  • [HBASE-15993] - Regex support in table names
  • [HBASE-16000] - Table#checkAndPut() docs are too vague
  • [HBASE-16007] - Job's Configuration should be passed to TableMapReduceUtil#addDependencyJars() in WALPlayer
  • [HBASE-16011] - TableSnapshotScanner and TableSnapshotInputFormat can produce duplicate rows
  • [HBASE-16012] - Major compaction can't work due to obsolete scanner read point in RegionServer
  • [HBASE-16014] - Get and Put constructor argument lists are divergent
  • [HBASE-16016] - AssignmentManager#waitForAssignment could have unexpected negative deadline
  • [HBASE-16017] - HBase TableOutputFormat has connection leak in getRecordWriter
  • [HBASE-16021] - graceful_stop.sh: Wrap variables in double quote to avoid "[: too many arguments" error
  • [HBASE-16031] - Documents about "hbase.replication" default value seems wrong
  • [HBASE-16032] - Possible memory leak in StoreScanner
  • [HBASE-16035] - Nested AutoCloseables might not all get closed
  • [HBASE-16040] - Remove configuration "hbase.replication"
  • [HBASE-16044] - Fix 'hbase shell' output parsing in graceful_stop.sh
  • [HBASE-16045] - endtime argument for VerifyReplication was incorrectly specified in usage
  • [HBASE-16047] - TestFastFail is broken again
  • [HBASE-16053] - Master code is not setting the table in ENABLING state in create table
  • [HBASE-16054] - OutOfMemory exception when using AsyncRpcClient with encryption
  • [HBASE-16055] - PutSortReducer loses any Visibility/acl attribute set on the Puts
  • [HBASE-16058] - TestHRegion fails on 1.4 builds
  • [HBASE-16059] - Region normalizer fails to trigger merge action where one of the regions is empty
  • [HBASE-16060] - 1.x clients cannot access table state talking to 2.0 cluster
  • [HBASE-16061] - Allow logging to a buffered console
  • [HBASE-16062] - Improper error handling in WAL Reader/Writer creation
  • [HBASE-16066] - Resolve RpC_REPEATED_CONDITIONAL_TEST findbugs warnings in HMaster
  • [HBASE-16069] - Typo "trapsparently" in item 3 of chapter 87.2 of Reference Guide
  • [HBASE-16070] - Mapreduce Serialization classes do not have Interface audience
  • [HBASE-16074] - ITBLL fails, reports lost big or tiny families
  • [HBASE-16076] - Cannot configure split policy in HBase shell
  • [HBASE-16081] - Replication remove_peer gets stuck and blocks WAL rolling
  • [HBASE-16084] - Clean up the stale references in javadoc
  • [HBASE-16090] - ResultScanner is not closed in SyncTable#finishRemainingHashRanges()
  • [HBASE-16091] - Canary takes lot more time when there are delete markers in the table
  • [HBASE-16095] - Add priority to TableDescriptor and priority region open thread pool
  • [HBASE-16096] - Replication keeps accumulating znodes
  • [HBASE-16103] - Procedure v2 - TestCloneSnapshotProcedure relies on execution order
  • [HBASE-16109] - Add Interface audience annotation to a few classes
  • [HBASE-16110] - AsyncFS WAL doesn't work with Hadoop 2.8+
  • [HBASE-16111] - Truncate preserve shell command is broken
  • [HBASE-16117] - Fix Connection leak in mapred.TableOutputFormat
  • [HBASE-16120] - Add shell test for truncate_preserve
  • [HBASE-16122] - PerformanceEvaluation should provide user friendly hint when client threads argument is missing
  • [HBASE-16125] - RegionMover uses hardcoded, Unix-style tmp folder - breaks Windows
  • [HBASE-16129] - check_compatibility.sh is broken when using Java API Compliance Checker v1.7
  • [HBASE-16132] - Scan does not return all the result when regionserver is busy
  • [HBASE-16133] - RSGroupBasedLoadBalancer.retainAssignment() might miss a region
  • [HBASE-16135] - PeerClusterZnode under rs of removed peer may never be deleted
  • [HBASE-16144] - Replication queue's lock will live forever if RS acquiring the lock has died prematurely
  • [HBASE-16150] - Remove ConcurrentIndex
  • [HBASE-16157] - The incorrect block cache count and size are caused by removing duplicate block key in the LruBlockCache
  • [HBASE-16159] - OutOfMemory exception when using AsyncRpcClient with encryption to read rpc response
  • [HBASE-16160] - Get the UnsupportedOperationException when using delegation token with encryption
  • [HBASE-16165] - Decrease RpcServer.callQueueSize before writeResponse causes OOM
  • [HBASE-16171] - Fix the potential problems in TestHCM.testConnectionCloseAllowsInterrupt
  • [HBASE-16172] - Unify the retry logic in ScannerCallableWithReplicas and RpcRetryingCallerWithReadReplicas
  • [HBASE-16177] - In dev mode thrift server can't be run
  • [HBASE-16182] - Increase IntegrationTestRpcClient timeout
  • [HBASE-16183] - Correct errors in example programs of coprocessor in Ref Guide
  • [HBASE-16184] - Shell test fails due to rLoadSink being nil
  • [HBASE-16186] - Fix AssignmentManager MBean name
  • [HBASE-16187] - Fix typo in blog post for metrics2
  • [HBASE-16190] - IntegrationTestDDLMasterFailover failed with IllegalArgumentException: n must be positive
  • [HBASE-16192] - Fix the potential problems in TestAcidGuarantees
  • [HBASE-16201] - NPE in RpcServer causing intermittent UT failure of TestMasterReplication#testHFileCyclicReplication
  • [HBASE-16207] - can't restore snapshot without "Admin" permission
  • [HBASE-16209] - Provide an ExponentialBackOffPolicy sleep between failed region open requests
  • [HBASE-16211] - JMXCacheBuster restarting the metrics system might cause tests to hang
  • [HBASE-16221] - Thrift server drops connection on long scans
  • [HBASE-16227] - [Shell] Column value formatter not working in scans
  • [HBASE-16234] - Expect and handle nulls when assigning replicas
  • [HBASE-16235] - TestSnapshotFromMaster#testSnapshotHFileArchiving will fail if there are too many hfiles
  • [HBASE-16238] - It's useless to catch SESSIONEXPIRED exception and retry in RecoverableZooKeeper
  • [HBASE-16239] - Better logging for RPC related exceptions
  • [HBASE-16244] - LocalHBaseCluster start timeout should be configurable
  • [HBASE-16267] - Remove commons-httpclient dependency from hbase-rest module
  • [HBASE-16270] - Handle duplicate clearing of snapshot in region replicas
  • [HBASE-16271] - Fix logging and re-run the test in IntegrationTestBulkLoad
  • [HBASE-16272] - Overflow in ServerName's compareTo method
  • [HBASE-16281] - TestMasterReplication is flaky
  • [HBASE-16283] - Batch Append/Increment will always fail if set ReturnResults to false
  • [HBASE-16284] - Unauthorized client can shutdown the cluster
  • [HBASE-16288] - HFile intermediate block level indexes might recurse forever creating multi TB files
  • [HBASE-16289] - AsyncProcess stuck messages need to print region/server
  • [HBASE-16290] - Dump summary of callQueue content; can help debugging
  • [HBASE-16292] - Can't start a local instance
  • [HBASE-16293] - TestSnapshotFromMaster#testSnapshotHFileArchiving flakey
  • [HBASE-16294] - hbck reporting "No HDFS region dir found" for replicas
  • [HBASE-16296] - Reverse scan performance degrades when using filter lists
  • [HBASE-16300] - LruBlockCache.CACHE_FIXED_OVERHEAD should calculate LruBlockCache size correctly
  • [HBASE-16301] - Trigger flush without waiting when compaction is disabled on a table
  • [HBASE-16303] - FilterList with MUST_PASS_ONE optimization
  • [HBASE-16304] - HRegion#RegionScannerImpl#handleFileNotFoundException may lead to deadlock when trying to obtain write lock on updatesLock
  • [HBASE-16306] - Add specific imports to avoid namespace clash in defaultSource.scala
  • [HBASE-16309] - TestDefaultCompactSelection.testCompactionRatio is flaky
  • [HBASE-16310] - Revisit the logic of filterRowKey for Filters
  • [HBASE-16315] - RegionSizeCalculator prints region names as binary without escapes
  • [HBASE-16319] - Fix TestCacheOnWrite after HBASE-16288
  • [HBASE-16326] - CellModel / RowModel should override 'equals', 'hashCode' and 'toString'
  • [HBASE-16341] - Missing bit on "Regression: Random Read/WorkloadC slower in 1.x than 0.98"
  • [HBASE-16345] - RpcRetryingCallerWithReadReplicas#call() should catch some RegionServer Exceptions
  • [HBASE-16347] - Unevaluated expressions in book
  • [HBASE-16350] - Undo server abort from HBASE-14968
  • [HBASE-16353] - Deprecate / Remove Get.isClosestRowBefore()
  • [HBASE-16355] - hbase-client dependency on hbase-common test-jar should be test scope
  • [HBASE-16356] - REST API scanner: row prefix filter and custom filter parameters are mutually exclusive
  • [HBASE-16359] - NullPointerException in RSRpcServices.openRegion()
  • [HBASE-16360] - TableMapReduceUtil addHBaseDependencyJars has the wrong class name for PrefixTreeCodec
  • [HBASE-16361] - Revert of HBASE-16317, "revert all ESAPI..." broke TestLogLevel
  • [HBASE-16362] - Mob compaction does not set cacheBlocks to false when creating StoreScanner
  • [HBASE-16363] - Correct javadoc for qualifier length and value length in Cell interface
  • [HBASE-16367] - Race between master and region server initialization may lead to premature server abort
  • [HBASE-16368] - test*WhenRegionMove in TestPartialResultsFromClientSide is flaky
  • [HBASE-16375] - Mapreduce mini cluster using HBaseTestingUtility not setting correct resourcemanager and jobhistory webapp address of MapReduceTestingShim
  • [HBASE-16384] - Update report-flakies.py script to allow specifying a list of build ids to be excluded
  • [HBASE-16386] - Fix findbug RV_RETURN_VALUE_IGNORED: Method ignores return value In HRegionServer
  • [HBASE-16389] - Thread leak in CoprocessorHost#getTable(TableName) API
  • [HBASE-16390] - Fix documentation around setAutoFlush
  • [HBASE-16409] - Row key for bad row should be properly delimited in VerifyReplication
  • [HBASE-16429] - FSHLog: deadlock if rollWriter called when ring buffer filled with appends
  • [HBASE-16430] - Fix RegionServer Group's bug when moving multiple tables
  • [HBASE-16444] - CellUtil#estimatedSerializedSizeOfKey() should consider KEY_INFRASTRUCTURE_SIZE
  • [HBASE-16446] - append_peer_tableCFs failed when there already have this table's partial cfs in the peer
  • [HBASE-16454] - Compactor's shipping logic decision should be based on the current store's block size
  • [HBASE-16456] - Fix findbugs warnings in hbase-rsgroup module
  • [HBASE-16460] - Can't rebuild the BucketAllocator's data structures when BucketCache uses FileIOEngine
  • [HBASE-16464] - archive folder grows bigger and bigger due to corrupt snapshot under tmp dir
  • [HBASE-16471] - Region Server metrics context will be wrong when machine hostname contain "master" word
  • [HBASE-16490] - Fix race condition between SnapshotManager and SnapshotCleaner
  • [HBASE-16491] - A few org.apache.hadoop.hbase.rsgroup classes missing @InterfaceAudience annotation
  • [HBASE-16495] - When accessed via Thrift, all column families have timeToLive equal to -1
  • [HBASE-16499] - slow replication for small HBase clusters
  • [HBASE-16515] - AsyncProcess has incorrent count of tasks if the backoff policy is enabled
  • [HBASE-16527] - IOExceptions from DFS client still can cause CatalogJanitor to delete referenced files
  • [HBASE-16528] - Procedure-V2: ServerCrashProcedure misses owner information
  • [HBASE-16535] - Use regex to exclude generated classes for findbugs
  • [HBASE-16538] - Version mismatch in HBaseConfiguration.checkDefaultsVersion
  • [HBASE-16540] - Scan should do additional validation on start and stop row
  • [HBASE-16544] - Remove or Clarify 'Using Amazon S3 Storage' section in the reference guide
  • [HBASE-16547] - hbase-archetype-builder shell scripts assume bash is installed in /bin
  • [HBASE-16551] - Cleanup SplitLogManager and CatalogJanitor
  • [HBASE-16552] - MiniHBaseCluster#getServerWith() does not ignore stopped RSs
  • [HBASE-16556] - The read/write timeout are not used in HTable.delete(List), HTable.get(List), and HTable.existsAll(List)
  • [HBASE-16572] - Sync method in RecoverableZooKeeper failed to pass callback function in
  • [HBASE-16576] - Shell add_peer doesn't allow setting cluster_key for custom endpoints
  • [HBASE-16578] - Mob data loss after mob compaction and normal compaction
  • [HBASE-16589] - Adjust log level for FATAL messages from HBaseReplicationEndpoint that are not fatal
  • [HBASE-16604] - Scanner retries on IOException can cause the scans to miss data
  • [HBASE-16609] - Fake cells EmptyByteBufferedCell created in read path not implementing SettableSequenceId
  • [HBASE-16611] - Flakey org.apache.hadoop.hbase.client.TestReplicasClient.testCancelOfMultiGet
  • [HBASE-16612] - Use array to cache Types for KeyValue.Type.codeToType
  • [HBASE-16614] - Use daemon thread for netty event loop
  • [HBASE-16615] - Fix flaky TestScannerHeartbeatMessages
  • [HBASE-16621] - HBCK should have -fixHFileLinks
  • [HBASE-16622] - Fix some issues with the HBase reference guide
  • [HBASE-16624] - MVCC DeSerialization bug in the HFileScannerImpl
  • [HBASE-16630] - Fragmentation in long running Bucket Cache
  • [HBASE-16635] - RpcClient under heavy load leaks some netty bytebuf
  • [HBASE-16643] - Reverse scanner heap creation may not allow MSLAB closure due to improper ref counting of segments
  • [HBASE-16644] - Errors when reading legit HFile Trailer of old (v2.0) format file
  • [HBASE-16645] - Wrong range of Cells is caused by CellFlatMap#tailMap, headMap, and SubMap
  • [HBASE-16647] - hbck should do offline reference repair before online repair
  • [HBASE-16649] - Truncate table with splits preserved can cause both data loss and truncated data appeared again
  • [HBASE-16654] - Better handle channelInactive and close for netty rpc client
  • [HBASE-16660] - ArrayIndexOutOfBounds during the majorCompactionCheck in DateTieredCompaction
  • [HBASE-16662] - Fix open POODLE vulnerabilities
  • [HBASE-16663] - JMX ConnectorServer stopped when unauthorized user try to stop HM/RS/cluster
  • [HBASE-16664] - Timeout logic in AsyncProcess is broken
  • [HBASE-16665] - Check whether KeyValueUtil.createXXX could be replaced by CellUtil without copy
  • [HBASE-16669] - fix flaky TestAdmin#testmergeRegions
  • [HBASE-16670] - Make RpcServer#processRequest logic more robust
  • [HBASE-16675] - Average region size may be incorrect when there is region whose RegionLoad cannot be retrieved
  • [HBASE-16678] - MapReduce jobs do not update counters from ScanMetrics
  • [HBASE-16679] - Flush throughput controller: Minor perf change and fix flaky TestFlushWithThroughputController
  • [HBASE-16681] - Fix flaky TestReplicationSourceManagerZkImpl
  • [HBASE-16682] - Fix Shell tests failure. NoClassDefFoundError for MiniKdc
  • [HBASE-16688] - Split TestMasterFailoverWithProcedures
  • [HBASE-16693] - The commit of HBASE-16604 creates a unrelated folder
  • [HBASE-16696] - After HBASE-16604 - does not release blocks in case of scanner exception
  • [HBASE-16697] - bump TestRegionServerMetrics to LargeTests
  • [HBASE-16699] - Overflows in AverageIntervalRateLimiter's refill() and getWaitInterval()
  • [HBASE-16701] - TestHRegion and TestHRegionWithInMemoryFlush timing out
  • [HBASE-16704] - Scan will be broken while working with DBE and KeyValueCodecWithTags
  • [HBASE-16711] - Fix hadoop-3.0 profile compile
  • [HBASE-16712] - fix hadoop-3.0 profile mvn install
  • [HBASE-16716] - OfflineMetaRepair leaves empty directory inside /hbase/WALs which remains forever
  • [HBASE-16718] - TestMobFlushSnapshotFromClient,TestFlushSnapshotFromClient, TestRestoreFlushSnapshotFromClient are failing in QA builds
  • [HBASE-16721] - Concurrency issue in WAL unflushed seqId tracking
  • [HBASE-16722] - Document: Broken link in CatalogJanitor
  • [HBASE-16723] - RMI registry is not destroyed after stopping JMX Connector Server
  • [HBASE-16724] - Snapshot owner can't clone
  • [HBASE-16731] - Inconsistent results from the Get/Scan if we use the empty FilterList
  • [HBASE-16732] - Avoid possible NPE in MetaTableLocator
  • [HBASE-16733] - add hadoop 3.0.0-alpha1 to precommit checks
  • [HBASE-16739] - Timed out exception message should include encoded region name
  • [HBASE-16743] - TestSimpleRpcScheduler#testCoDelScheduling is broke
  • [HBASE-16746] - The log of “region close” should differ from “region move”
  • [HBASE-16752] - Upgrading from 1.2 to 1.3 can lead to replication failures due to difference in RPC size limit
  • [HBASE-16753] - There is a mismatch between suggested Java version in hbase-env.sh
  • [HBASE-16754] - Regions failing compaction due to referencing non-existent store file
  • [HBASE-16763] - Remove unintentional dependency on net.sf.ehcache.search.Results
  • [HBASE-16764] - hbase-protocol-shaded generate-shaded-classes profile unpacks shaded java files into wrong location
  • [HBASE-16765] - New SteppingRegionSplitPolicy, avoid too aggressive spread of regions for small tables.
  • [HBASE-16767] - Mob compaction needs to clean up files in /hbase/mobdir/.tmp and /hbase/mobdir/.tmp/.bulkload when running into IO exceptions
  • [HBASE-16768] - Inconsistent results from the Append/Increment
  • [HBASE-16769] - Deprecate/remove PB references from MasterObserver and RegionServerObserver
  • [HBASE-16771] - VerifyReplication should increase GOODROWS counter if re-comparison passes
  • [HBASE-16780] - Since move to protobuf3.1, Cells are limited to 64MB where previous they had no limit
  • [HBASE-16785] - We are not running all tests
  • [HBASE-16793] - Exclude shaded protobuf files from rat check
  • [HBASE-16801] - The Append/Increment may return the data from future
  • [HBASE-16807] - RegionServer will fail to report new active Hmaster until HMaster/RegionServer failover
  • [HBASE-16808] - Included the generated, shaded java files from "HBASE-15638 Shade protobuf" in our src assembly
  • [HBASE-16810] - HBase Balancer throws ArrayIndexOutOfBoundsException when regionservers are in /hbase/draining znode and unloaded
  • [HBASE-16815] - Low scan ratio in RPC queue tuning triggers divide by zero exception
  • [HBASE-16824] - Writer.flush() can be called on already closed streams in WAL roll
  • [HBASE-16829] - DemoClient should detect secure mode
  • [HBASE-16841] - Data loss in MOB files after cloning a snapshot and deleting that snapshot
  • [HBASE-16853] - Regions are assigned to Region Servers in /hbase/draining after HBase Master failover
  • [HBASE-16855] - Avoid NPE in MetricsConnection’s construction
  • [HBASE-16856] - Exception message in SyncRunner.run() should print currentSequence
  • [HBASE-16858] - TestFuzzyRowFilterEndToEnd fails in QA builds
  • [HBASE-16866] - Avoid NPE in AsyncRequestFutureImpl#updateStats
  • [HBASE-16870] - Add the metrics of replication sources which were transformed from other dead rs to ReplicationLoad
  • [HBASE-16875] - Changed try-with-resources in the docs to recommended way
  • [HBASE-16880] - Correct the javadoc/behaviour of the APIs in ByteBufferUtils
  • [HBASE-16884] - Add HBase-2.0.x to the hadoop version support matrix in our documentation
  • [HBASE-16886] - hbase-client: scanner with reversed=true and small=true gets no result
  • [HBASE-16887] - Allow setting different hadoopcheck versions in precommit for different branches
  • [HBASE-16889] - Proc-V2: verifyTables in the IntegrationTestDDLMasterFailover test after each table DDL is incorrect
  • [HBASE-16910] - Avoid NPE when starting StochasticLoadBalancer
  • [HBASE-16929] - Move default method of shipped to Shipper interface
  • [HBASE-16930] - AssignmentManager#checkWals() function can recur infinitely
  • [HBASE-16931] - Setting cell's seqId to zero in compaction flow might cause RS down.
  • [HBASE-16938] - TableCFsUpdater maybe failed due to no write permission on peerNode
  • [HBASE-16939] - ExportSnapshot: set owner and permission on right directory
  • [HBASE-16948] - Fix inconsistency between HRegion and Region javadoc on getRowLock
  • [HBASE-16949] - Fix RAT License complaint about the hbase-protocol-shaded/src/main/patches content
  • [HBASE-16960] - RegionServer hang when aborting
  • [HBASE-16962] - Add readPoint to preCompactScannerOpen() and preFlushScannerOpen() API
  • [HBASE-16964] - Successfully archived files are not cleared from compacted store file list if archiving of any file fails
  • [HBASE-16966] - Re-enable TestSimpleRpcScheduler#testCoDelScheduling in master branch
  • [HBASE-16971] - The passed durability of Append/Increment isn't used in wal sync
  • [HBASE-16974] - Update os-maven-plugin to 1.4.1.final+ for building shade file on RHEL/CentOS
  • [HBASE-16976] - hbase-protocol-shaded module generates classes to wrong directory
  • [HBASE-16980] - TestRowProcessorEndpoint failing consistently
  • [HBASE-16983] - TestMultiTableSnapshotInputFormat failing with Unable to create region directory: /tmp/...
  • [HBASE-16985] - TestClusterId failed due to wrong hbase rootdir
  • [HBASE-16989] - RowProcess#postBatchMutate doesn’t be executed before the mvcc transaction completion
  • [HBASE-16992] - The usage of mutation from CP is weird.
  • [HBASE-16993] - BucketCache throw java.io.IOException: Invalid HFile block magic when configuring hbase.bucketcache.bucket.sizes
  • [HBASE-17020] - keylen in midkey() dont computed correctly
  • [HBASE-17032] - CallQueueTooBigException and CallDroppedException should not be triggering PFFE
  • [HBASE-17033] - LogRoller makes a lot of allocations unnecessarily
  • [HBASE-17039] - SimpleLoadBalancer schedules large amount of invalid region moves
  • [HBASE-17042] - Remove 'public' keyword from MasterObserver interface
  • [HBASE-17044] - Fix merge failed before creating merged region leaves meta inconsistent
  • [HBASE-17052] - compile-protobuf profile does not compile protobufs in some modules anymore
  • [HBASE-17054] - Compactor#preCreateCoprocScanner should be passed user
  • [HBASE-17056] - Remove checked in PB generated files
  • [HBASE-17058] - Lower epsilon used for jitter verification from HBASE-15324
  • [HBASE-17062] - RegionSplitter throws ClassCastException
  • [HBASE-17069] - RegionServer writes invalid META entries for split daughters in some circumstances
  • [HBASE-17072] - CPU usage starts to climb up to 90-100% when using G1GC; purge ThreadLocal usage
  • [HBASE-17074] - PreCommit job always fails because of OOM
  • [HBASE-17078] - hadoop.profile=3.0 profile build fails because hadoop-three-compat.xml does not exist
  • [HBASE-17079] - HBase build fails on windows, hbase-archetype-builder is reason for failure
  • [HBASE-17082] - ForeignExceptionUtil isn’t packaged when building shaded protocol with -Pcompile-protobuf
  • [HBASE-17091] - IntegrationTestZKAndFSPermissions failed with 'KeeperException$NoNodeException'
  • [HBASE-17092] - Both LoadIncrementalHFiles#doBulkLoad() methods should set return value
  • [HBASE-17095] - The ClientSimpleScanner keeps retrying if the hfile is corrupt or cannot found
  • [HBASE-17105] - Annotate RegionServerObserver
  • [HBASE-17112] - Prevent setting timestamp of delta operations the same as previous value's
  • [HBASE-17116] - [PerformanceEvaluation] Add option to configure block size
  • [HBASE-17118] - StoreScanner leaked in KeyValueHeap
  • [HBASE-17125] - Inconsistent result when use filter to read data
  • [HBASE-17127] - Locate region should fail fast if underlying Connection already closed
  • [HBASE-17131] - Avoid livelock caused by HRegion#processRowsWithLocks
  • [HBASE-17133] - Backup documentation update
  • [HBASE-17144] - Possible offheap read ByteBuffers leak
  • [HBASE-17158] - Avoid deadlock caused by HRegion#doDelta
  • [HBASE-17160] - Undo unnecessary inter-module dependency; spark to hbase-it and hbase-it to shell
  • [HBASE-17166] - ITBLL fails on master unable to find hbase-protocol-shaded content
  • [HBASE-17170] - HBase is also retrying DoNotRetryIOException because of class loader differences.
  • [HBASE-17171] - IntegrationTestTimeBoundedRequestsWithRegionReplicas fails with obtuse error when readers have no time to run
  • [HBASE-17186] - MasterProcedureTestingUtility#testRecoveryAndDoubleExecution displays stale procedure state info
  • [HBASE-17187] - DoNotRetryExceptions from coprocessors should bubble up to the application
  • [HBASE-17192] - remove use of scala-tools.org from pom
  • [HBASE-17197] - hfile does not work in 2.0
  • [HBASE-17206] - FSHLog may roll a new writer successfully with unflushed entries
  • [HBASE-17224] - There are lots of spelling errors in the HBase logging and exception messages
  • [HBASE-17228] - precommit grep -c ERROR may grab non errors
  • [HBASE-17231] - Region#getCellCompartor sp?
  • [HBASE-17237] - Override the correct compact method in HMobStore
  • [HBASE-17240] - ImportTsv encounters ClassNotFoundException for MasterProtos$MasterService$BlockingInterface
  • [HBASE-17248] - SimpleRegionNormalizer javadoc correction
  • [HBASE-17252] - Wrong arguments for ValueAndTagRewriteCell in CellUtil
  • [HBASE-17256] - Rpc handler monitoring will be removed when the task queue is full
  • [HBASE-17271] - hbase-thrift QA tests only run one test
  • [HBASE-17286] - LICENSE.txt in binary tarball contains only ASL text
  • [HBASE-17287] - Master becomes a zombie if filesystem object closes
  • [HBASE-17290] - Potential loss of data for replication of bulk loaded hfiles
  • [HBASE-17297] - Single Filter in parenthesis cannot be parsed correctly
  • [HBASE-17302] - The region flush request disappeared from flushQueue
  • [HBASE-17309] - Fix connection leaks in TestAcidGuarantees
  • [HBASE-17326] - Fix findbugs warning in BufferedMutatorParams
  • [HBASE-17328] - Properly dispose of looped replication peers
  • [HBASE-17330] - SnapshotFileCache will always refresh the file cache
  • [HBASE-17333] - HBASE-17294 always ensures CompactingMemstore is default
  • [HBASE-17341] - Add a timeout during replication endpoint termination
  • [HBASE-17344] - The regionserver web UIs miss the coprocessors of RegionServerCoprocessorHost.
  • [HBASE-17347] - ExportSnapshot may write snapshot info file to wrong directory when specifying target name
  • [HBASE-17351] - Enforcer plugin fails with NullPointerException
  • [HBASE-17352] - Fix hbase-assembly build with bash 4
  • [HBASE-17357] - PerformanceEvaluation parameters parsing triggers NPE.
  • [HBASE-17366] - Run TestHFile#testReaderWithoutBlockCache failes
  • [HBASE-17374] - ZKPermissionWatcher crashed when grant after region close
  • [HBASE-17376] - ClientAsyncPrefetchScanner may fail due to too many rows
  • [HBASE-17381] - ReplicationSourceWorkerThread can die due to unhandled exceptions
  • [HBASE-17385] - Change usage documentation from bin/hbase to hbase in various tools
  • [HBASE-17387] - Reduce the overhead of exception report in RegionActionResult for multi()
  • [HBASE-17390] - Online update of configuration for all servers leaves out masters
  • [HBASE-17403] - ClientAsyncPrefetchScanner doesn’t load any data if the MaxResultSize is too small
  • [HBASE-17407] - Correct update of maxFlushedSeqId in HRegion
  • [HBASE-17421] - Update refguide w.r.t. MOB Sweeper
  • [HBASE-17424] - Protect REST client against malicious XML responses.
  • [HBASE-17426] - Inconsistent environment variable names for enabling JMX
  • [HBASE-17429] - HBase bulkload cannot support HDFS viewFs
  • [HBASE-17430] - dead links in ref guide to class javadocs that moved out of user APIs.
  • [HBASE-17434] - New Synchronization Scheme for Compaction Pipeline
  • [HBASE-17435] - Call to preCommitStoreFile() hook encounters SaslException in secure deployment
  • [HBASE-17441] - precommit test "hadoopcheck" not properly testing Hadoop 3 profile
  • [HBASE-17445] - Count size of serialized exceptions in checking max result size quota
  • [HBASE-17450] - TablePermission#equals throws NPE after namespace support was added
  • [HBASE-17452] - Failed taking snapshot - region Manifest proto-message too large
  • [HBASE-17460] - enable_table_replication can not perform cyclic replication of a table
  • [HBASE-17464] - Fix HBaseTestingUtility.getNewDataTestDirOnTestFS to always return a unique path
  • [HBASE-17469] - Properly handle empty TableName in TablePermission#readFields and #write
  • [HBASE-17471] - Region Seqid will be out of order in WAL if using mvccPreAssign
  • [HBASE-17475] - Stack overflow in AsyncProcess if retry too much
  • [HBASE-17482] - mvcc mechanism fails when using mvccPreAssign
  • [HBASE-17486] - Tighten the contract for batch client methods
  • [HBASE-17489] - ClientScanner may send a next request to a RegionScanner which has been exhausted
  • [HBASE-17496] - RSGroup shell commands:get_server_rsgroup don't work and commands display an incorrect result size
  • [HBASE-17501] - NullPointerException after Datanodes Decommissioned and Terminated
  • [HBASE-17513] - Thrift Server 1 uses different QOP settings than RPC and Thrift Server 2 and can easily be misconfigured so there is no encryption when the operator expects it.
  • [HBASE-17518] - HBase Reference Guide has a syntax error
  • [HBASE-17522] - RuntimeExceptions from MemoryMXBean should not take down server process
  • [HBASE-17538] - HDFS.setStoragePolicy() logs errors on local fs
  • [HBASE-17540] - Change SASL server GSSAPI callback log line from DEBUG to TRACE in RegionServer to reduce log volumes in DEBUG mode
  • [HBASE-17545] - 'mvn test' does not run all the tests in hbase-endpoint
  • [HBASE-17558] - ZK dumping jsp should escape html
  • [HBASE-17565] - StochasticLoadBalancer may incorrectly skip balancing due to skewed multiplier sum
  • [HBASE-17578] - Thrift per-method metrics should still update in the case of exceptions
  • [HBASE-17581] - mvn clean test -PskipXXXTests does not work properly for some modules
  • [HBASE-17582] - Drop page cache hint is broken
  • [HBASE-17587] - Do not Rethrow DoNotRetryIOException as UnknownScannerException
  • [HBASE-17590] - Drop cache hint should work for StoreFile write path
  • [HBASE-17593] - Fix build with hadoop 3 profile
  • [HBASE-17601] - close() in TableRecordReaderImpl assumes the split has started
  • [HBASE-17603] - REST API for scan should return 404 when table does not exist
  • [HBASE-17606] - Fix failing TestRpcControllerFactory introduced by HBASE-17508
  • [HBASE-17607] - Rest api for scan should return 404 when table not exists
  • [HBASE-17611] - Thrift 2 per-call latency metrics are capped at ~ 2 seconds
  • [HBASE-17616] - Incorrect actions performed by CM
  • [HBASE-17622] - Add hbase-metrics package to TableMapReduceUtil
  • [HBASE-17624] - Address late review of HBASE-6721, rsgroups feature
  • [HBASE-17631] - Canary interval too low
  • [HBASE-17638] - Remove duplicated initialization of CacheConfig in HRegionServer
  • [HBASE-17639] - Do not stop server if ReplicationSourceManager's waitUntilCanBePushed throws InterruptedException
  • [HBASE-17640] - Unittest error in TestMobCompactor with different timezone
  • [HBASE-17648] - HBase Table-level synchronization fails between two secured(kerberized) clusters
  • [HBASE-17649] - REST API for scan should return 410 when table is disabled
  • [HBASE-17653] - HBASE-17624 rsgroup synchronizations will (distributed) deadlock
  • [HBASE-17658] - Fix bookkeeping error with max regions for a table
  • [HBASE-17660] - HFileSplitter is not being applied during full table restore
  • [HBASE-17661] - fix the queue length passed to FastPathBalancedQueueRpcExecutor
  • [HBASE-17670] - LruBlockCache with VictimHandler should evict from bucket cache also when eviction by filename happens
  • [HBASE-17673] - Monitored RPC Handler not shown in the WebUI
  • [HBASE-17674] - Major compaction may be cancelled in CompactionChecker
  • [HBASE-17675] - ReplicationEndpoint should choose new sinks if a SaslException occurs
  • [HBASE-17677] - ServerName parsing from directory name should be more robust to errors from guava's HostAndPort
  • [HBASE-17682] - Region stuck in merging_new state indefinitely
  • [HBASE-17688] - MultiRowRangeFilter not working correctly if given same start and stop RowKey
  • [HBASE-17698] - ReplicationEndpoint choosing sinks
  • [HBASE-17699] - Fix TestLockProcedure
  • [HBASE-17705] - Procedure execution must fail fast if procedure is not registered
  • [HBASE-17706] - TableSkewCostFunction improperly computes max skew
  • [HBASE-17710] - HBase in standalone mode creates directories with 777 permission
  • [HBASE-17712] - Remove/Simplify the logic of RegionScannerImpl.handleFileNotFound
  • [HBASE-17713] - the interface '/version/cluster' with header 'Accept: application/json' return is not JSON but plain text
  • [HBASE-17717] - Incorrect ZK ACL set for HBase superuser
  • [HBASE-17718] - Difference between RS's servername and its ephemeral node cause SSH stop working
  • [HBASE-17722] - Metrics subsystem stop/start messages add a lot of useless bulk to operational logging
  • [HBASE-17723] - ClientAsyncPrefetchScanner may end prematurely when the size of the cache is one
  • [HBASE-17729] - Missing shortcuts for some useful HCD options
  • [HBASE-17736] - Some options can't be configured by the shell
  • [HBASE-17746] - TestSimpleRpcScheduler.testCoDelScheduling is broken
  • [HBASE-17760] - HDFS Balancer doc is misleading
  • [HBASE-17761] - Test TestRemoveRegionMetrics.testMoveRegion fails intermittently because of race condition
  • [HBASE-17763] - IPCUtil.wrapException will wrap DoNotRetryIOException with IOException
  • [HBASE-17772] - IntegrationTestRSGroup won't run
  • [HBASE-17773] - VerifyReplication tool wrongly emits warning "ERROR: Invalid argument '--recomparesleep=xx'"
  • [HBASE-17779] - disable_table_replication returns misleading message and does not turn off replication
  • [HBASE-17780] - BoundedByteBufferPool "At capacity" messages are not actionable
  • [HBASE-17781] - TestAcidGuarantees is broken
  • [HBASE-17785] - RSGroupBasedLoadBalancer fails to assign new table regions when cloning snapshot
  • [HBASE-17792] - Use a shared thread pool for AtomicityWriter, AtomicGetReader, AtomicScanReader's connections in TestAcidGuarantees
  • [HBASE-17798] - RpcServer.Listener.Reader can abort due to CancelledKeyException
  • [HBASE-17803] - PE always re-creates table when we specify the split policy
  • [HBASE-17807] - correct the value of zookeeper.session.timeout in hbase doc
  • [HBASE-17811] - TestThriftHttpServer.testRunThriftServerWithHeaderBufferLength is broken in "branch-1"
  • [HBASE-17812] - Remove RpcConnection from pool in AbstractRpcClient.cancelConnections
  • [HBASE-17816] - HRegion#mutateRowWithLocks should update writeRequestCount metric
  • [HBASE-17821] - The CompoundConfiguration#toString is wrong
  • [HBASE-17839] - "Data Model" section: Table 1 has only 5 data rows instead 6.
  • [HBASE-17853] - Link to "Why does HBase care about /etc/hosts?" does not work
  • [HBASE-17862] - Condition that always returns true
  • [HBASE-17863] - Procedure V2: Proc Executor cleanup. Split FINISHED state to two states: SUCCESS and FAILED.
  • [HBASE-17869] - UnsafeAvailChecker wrongly returns false on ppc
  • [HBASE-17871] - scan#setBatch(int) call leads wrong result of VerifyReplication
  • [HBASE-17874] - Limiting of read request response size based on block size may go wrong when blocks are read from onheap or off heap bucket cache
  • [HBASE-17878] - java.lang.NoSuchMethodError: org.joda.time.format.DateTimeFormatter.withZoneUTC()Lorg/joda/time/format/DateTimeFormatter when starting HBase with hbase.rootdir on S3
  • [HBASE-17879] - Avoid NPE in snapshot.jsp when accessing without any request parameter
  • [HBASE-17886] - Fix compatibility of ServerSideScanMetrics
  • [HBASE-17900] - VerifyReplication - input param variables declared as static causing issues to run VerifyReplication multiple times in single JVM(mainly for unit tests)
  • [HBASE-17903] - Corrected the alias for the link of HBASE-6580
  • [HBASE-17904] - Get 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.RpcClientImpl
  • [HBASE-17905] - [hbase-spark] bulkload does not work when table not exist
  • [HBASE-17930] - Avoid using Canary.sniff in HBaseTestingUtility
  • [HBASE-17931] - Assign system tables to servers with highest version
  • [HBASE-17936] - Refine sum endpoint example in ref guide
  • [HBASE-17937] - Memstore size becomes negative in case of expensive postPut/Delete Coprocessor call
  • [HBASE-17940] - HMaster can not start due to Jasper related classes conflict
  • [HBASE-17941] - CellArrayMap#getCell may throw IndexOutOfBoundsException
  • [HBASE-17943] - The in-memory flush size is different for each CompactingMemStore located in the same region
  • [HBASE-17946] - Shell command compact_rs don't work
  • [HBASE-17947] - Location of Examples.proto is wrong in comment of RowCountEndPoint.java
  • [HBASE-17950] - Write the chunkId also as Int instead of long into the first byte of the chunk
  • [HBASE-17957] - Custom metrics of replicate endpoints don't prepend "source." to global metrics
  • [HBASE-17958] - Avoid passing unexpected cell to ScanQueryMatcher when optimize SEEK to SKIP
  • [HBASE-17964] - ensure hbase-metrics-api is included in mapreduce job classpaths
  • [HBASE-17970] - Set yarn.app.mapreduce.am.staging-dir when starting MiniMRCluster
  • [HBASE-17975] - TokenUtil.obtainToken squashes remote exceptions
  • [HBASE-17982] - Is the word "occured" should be "occurred ?
  • [HBASE-17985] - Inline package manage updates with package installation in Yetus Dockerfile
  • [HBASE-17988] - get-active-master.rb and draining_servers.rb no longer work
  • [HBASE-17991] - Add more details about compaction queue on /dump
  • [HBASE-17997] - In dev environment, add jruby-complete jar to classpath only when jruby is needed
  • [HBASE-18000] - Make sure we always return the scanner id with ScanResponse
  • [HBASE-18005] - read replica: handle the case that region server hosting both primary replica and meta region is down
  • [HBASE-18006] - AsyncClientScanner does not retry openScan RPCs
  • [HBASE-18024] - HRegion#initializeRegionInternals should not re-create .hregioninfo file when the region directory no longer exists
  • [HBASE-18025] - CatalogJanitor should collect outdated RegionStates from the AM
  • [HBASE-18027] - Replication should respect RPC size limits when batching edits
  • [HBASE-18030] - Per Cell TTL tags may get duplicated with increments/Append causing tags length overflow
  • [HBASE-18035] - Meta replica does not give any primaryOperationTimeout to primary meta region
  • [HBASE-18042] - Client Compatibility breaks between versions 1.2 and 1.3
  • [HBASE-18049] - It is not necessary to re-open the region when MOB files cannot be found
  • [HBASE-18051] - balance_rsgroup still run when the Load Balancer is not enabled.
  • [HBASE-18053] - AsyncTableResultScanner will hang when scan wrong column family
  • [HBASE-18054] - log when we add/remove failed servers in client
  • [HBASE-18055] - Releasing L2 cache HFileBlocks before shipped() when switching from pread to stream causes result corruption
  • [HBASE-18058] - Zookeeper retry sleep time should have an upper limit
  • [HBASE-18069] - Fix flaky test TestReplicationAdminWithClusters#testDisableAndEnableReplication
  • [HBASE-18071] - Fix flaky test TestStochasticLoadBalancer#testBalanceCluster
  • [HBASE-18077] - Update JUnit license to EPL from CPL
  • [HBASE-18081] - The way we process connection preamble in SimpleRpcServer is broken
  • [HBASE-18084] - Improve CleanerChore to clean from directory which consumes more disk space
  • [HBASE-18085] - Prevent parallel purge in ObjectPool
  • [HBASE-18088] - The version of scala plugin in the reporting section is missing
  • [HBASE-18092] - Removing a peer does not properly clean up the ReplicationSourceManager state and metrics
  • [HBASE-18093] - Overloading the meaning of 'enabled' in Quota Manager to indicate either quota disabled or quota manager not ready is not good
  • [HBASE-18099] - FlushSnapshotSubprocedure should wait for concurrent Region#flush() to finish
  • [HBASE-18111] - Replication stuck when cluster connection is closed
  • [HBASE-18113] - Handle old client without include_stop_row flag when startRow equals endRow
  • [HBASE-18118] - Default storage policy if not configured cannot be "NONE"
  • [HBASE-18120] - Fix TestAsyncRegionAdminApi
  • [HBASE-18122] - Scanner id should include ServerName of region server
  • [HBASE-18125] - HBase shell disregards spaces at the end of a split key in a split file
  • [HBASE-18129] - truncate_preserve fails when the truncate method doesn't exists on the master
  • [HBASE-18132] - Low replication should be checked in period in case of datanode rolling upgrade
  • [HBASE-18137] - Replication gets stuck for empty WALs
  • [HBASE-18141] - Regionserver fails to shutdown when abort triggered in RegionScannerImpl during RPC call
  • [HBASE-18142] - Deletion of a cell deletes the previous versions too
  • [HBASE-18143] - [AMv2] Backoff on failed report of region transition quickly goes to astronomical time scale
  • [HBASE-18145] - The flush may cause the corrupt data for reading
  • [HBASE-18149] - The setting rules for table-scope attributes and family-scope attributes should keep consistent
  • [HBASE-18155] - TestMasterProcedureWalLease is flakey
  • [HBASE-18158] - Two running in-memory compaction threads may lose data
  • [HBASE-18166] - [AMv2] We are splitting already-split files
  • [HBASE-18177] - FanOutOneBlockAsyncDFSOutputHelper fails to compile against Hadoop 3
  • [HBASE-18180] - Possible connection leak while closing BufferedMutator in TableOutputFormat
  • [HBASE-18184] - Add hbase-hadoop2-compat jar as MapReduce job dependency
  • [HBASE-18185] - IntegrationTestTimeBoundedRequestsWithRegionReplicas unbalanced tests fails with AssertionError
  • [HBASE-18192] - Replication drops recovered queues on region server shutdown
  • [HBASE-18193] - Master web UI presents the incorrect number of regions
  • [HBASE-18195] - Remove redundant single quote from start message for HMaster and HRegionServer
  • [HBASE-18199] - Race in NettyRpcConnection may cause call stuck in BufferCallBeforeInitHandler forever
  • [HBASE-18200] - Set hadoop check versions for branch-2 and branch-2.x in pre commit
  • [HBASE-18207] - branch-2 build fails in the checkstyle phase
  • [HBASE-18209] - Include httpclient / httpcore jars in build artifacts
  • [HBASE-18212] - In Standalone mode with local filesystem HBase logs Warning message:Failed to invoke 'unbuffer' method in class class org.apache.hadoop.fs.FSDataInputStream
  • [HBASE-18216] - [AMv2] Workaround for HBASE-18152, corrupt procedure WAL
  • [HBASE-18219] - Fix typo in constant HConstants.HBASE_CLIENT_MEAT_REPLICA_SCAN_TIMEOUT
  • [HBASE-18225] - Fix findbugs regression calling toString() on an array
  • [HBASE-18227] - [AMv2] Fix test hbase.coprocessor.TestCoprocessorMetrics#testRegionObserverAfterRegionClosed
  • [HBASE-18230] - Generated LICENSE file includes unsubstituted Velocity variables
  • [HBASE-18235] - LoadBalancer.BOGUS_SERVER_NAME should not have a bogus hostname
  • [HBASE-18244] - org.apache.hadoop.hbase.client.rsgroup.TestShellRSGroups hangs/fails
  • [HBASE-18246] - Proc-V2 AM: Maintain Data locality in ServerCrashProcedure
  • [HBASE-18254] - ServerCrashProcedure checks and waits for meta initialized, instead should check and wait for meta loaded
  • [HBASE-18259] - HBase book link to "beginner" issues includes resolved issues
  • [HBASE-18260] - Address new license dependencies from hadoop3-alpha4
  • [HBASE-18262] - name of parameter quote need update in hbase-default.xml
  • [HBASE-18263] - Resolve NPE in backup Master UI when access to procedures.jsp
  • [HBASE-18265] - Correct the link unuseful in regionServer's region state UI
  • [HBASE-18267] - The result from the postAppend is ignored
  • [HBASE-18274] - hbase autorestart will overwrite the gc log
  • [HBASE-18278] - [AMv2] Enable and fix uni test hbase.master.procedure.TestServerCrashProcedure#testRecoveryAndDoubleExecutionOnRsWithMeta
  • [HBASE-18282] - ReplicationLogCleaner can delete WALs not yet replicated in case of a KeeperException
  • [HBASE-18287] - Remove log warning in PartitionedMobCompactor.java#getFileStatus
  • [HBASE-18290] - Fix TestAddColumnFamilyProcedure and TestDeleteTableProcedure
  • [HBASE-18292] - Fix flaky test hbase.master.locking.TestLockProcedure#testLocalMasterLockRecovery()
  • [HBASE-18301] - Enable TestSimpleRegionNormalizerOnCluster#testRegionNormalizationMergeOnCluster that was disabled by Proc-V2 AM in HBASE-14614
  • [HBASE-18302] - Protobuf section in the docs needs some clean up
  • [HBASE-18306] - Get rid of TableDescriptor#getConfiguration
  • [HBASE-18310] - LoadTestTool unable to write data
  • [HBASE-18311] - clean up the quickstart guide
  • [HBASE-18312] - Ineffective handling of FileNotFoundException in FileLink$FileLinkInputStream.tryOpen()
  • [HBASE-18320] - Address maven-site-plugin upgrade steps
  • [HBASE-18323] - Remove multiple ACLs for the same user in kerberos
  • [HBASE-18325] - Disable flakey TestMasterProcedureWalLease
  • [HBASE-18329] - update links in config guide to point to java 8 references
  • [HBASE-18330] - NPE in ReplicationZKLockCleanerChore
  • [HBASE-18335] - clean up configuration guide
  • [HBASE-18337] - hbase-shaded-server brings in signed jars
  • [HBASE-18341] - Update findHangingTests.py script to match changed consoleText of trunk build
  • [HBASE-18348] - The implementation of AsyncTableRegionLocator does not follow the javadoc
  • [HBASE-18350] - RSGroups are broken under AMv2
  • [HBASE-18352] - Enable TestMasterOperationsForRegionReplicas#testCreateTableWithMultipleReplicas disabled by Proc-V2 AM in HBASE-14614
  • [HBASE-18353] - Enable TestCorruptedRegionStoreFile that were disabled by Proc-V2 AM in HBASE-14614
  • [HBASE-18354] - Fix TestMasterMetrics that were disabled by Proc-V2 AM in HBASE-14614
  • [HBASE-18355] - Enable export snapshot tests that were disabled by Proc-V2 AM in HBASE-14614
  • [HBASE-18356] - Enable TestFavoredStochasticBalancerPickers#testPickers that was disabled by Proc-V2 AM in HBASE-14614
  • [HBASE-18357] - Enable disabled tests in TestHCM that were disabled by Proc-V2 AM in HBASE-14614
  • [HBASE-18358] - Backport HBASE-18099 'FlushSnapshotSubprocedure should wait for concurrent Region#flush() to finish' to branch-1.3
  • [HBASE-18362] - hbck should not report split replica parent region from meta as errors
  • [HBASE-18369] - hbase thrift web-ui not available
  • [HBASE-18377] - Error handling for FileNotFoundException should consider RemoteException in openReader()
  • [HBASE-18390] - Sleep too long when finding region location failed
  • [HBASE-18393] - hbase shell non-interactive broken
  • [HBASE-18404] - Small typo on ACID documentation page
  • [HBASE-18406] - In ServerCrashProcedure.java start(MasterProcedureEnv) is a no-op
  • [HBASE-18427] - minor cleanup around AssignmentManager
  • [HBASE-18430] - Typo in "contributing to documentation" page
  • [HBASE-18431] - Mitigate compatibility concerns between branch-1.3 and branch-1.4
  • [HBASE-18433] - Convenience method for creating simple ColumnFamilyDescriptor
  • [HBASE-18437] - Revoke access permissions of a user from a table does not work as expected
  • [HBASE-18438] - Precommit doesn't warn about unused imports
  • [HBASE-18441] - ZookeeperWatcher#interruptedException should throw exception
  • [HBASE-18445] - Upgrading Guava broke hadoop-3.0 profile
  • [HBASE-18447] - MetricRegistryInfo#hashCode uses hashCode instead of toHashCode
  • [HBASE-18449] - Fix client.locking.TestEntityLocks#testHeartbeatException
  • [HBASE-18452] - VerifyReplication by Snapshot should cache HDFS token before submit job for kerberos env.
  • [HBASE-18461] - Build broken If the username contains a backslash
  • [HBASE-18470] - Remove the redundant comma from RetriesExhaustedWithDetailsException#getDesc
  • [HBASE-18471] - The DeleteFamily cell is skipped when StoreScanner seeks to next column
  • [HBASE-18472] - Add guava license and update supplemental-models.xml
  • [HBASE-18473] - VC.listLabels() erroneously closes any connection
  • [HBASE-18475] - MasterProcedureScheduler incorrectly passes null Procedure to table locking
  • [HBASE-18476] - HTable#put should call RS#mutate rather than RS#multi
  • [HBASE-18480] - The cost of BaseLoadBalancer.cluster is changed even if the rollback is done
  • [HBASE-18481] - The autoFlush flag was not used in PE tool
  • [HBASE-18487] - Minor fixes in row lock implementation
  • [HBASE-18490] - Modifying a table descriptor to enable replicas does not create replica regions
  • [HBASE-18491] - [AMv2] Fail UnassignProcedure if source Region Server is not online.
  • [HBASE-18492] - [AMv2] Embed code for selecting highest versioned region server for system table regions in AssignmentManager.processAssignQueue()
  • [HBASE-18493] - [AMv2] On region server crash do not process system table regions through AssignmentManager.checkIfShouldMoveSystemRegionAsync()
  • [HBASE-18505] - Our build/yetus personality will run tests on individual modules and then on all (i.e. 'root'). Should do one or other
  • [HBASE-18516] - [AMv2] Remove dead code in ServerManager resulted mostly from AMv2 refactoring
  • [HBASE-18517] - limit max log message width in log4j
  • [HBASE-18525] - TestAssignmentManager#testSocketTimeout fails in master branch
  • [HBASE-18526] - FIFOCompactionPolicy pre-check uses wrong scope
  • [HBASE-18543] - Re-enable test master.TestMasterFailover on master
  • [HBASE-18551] - [AMv2] UnassignProcedure and crashed regionservers
  • [HBASE-18557] - change splitable to mergeable in MergeTableRegionsProcedure
  • [HBASE-18560] - Test master.assignment.TestAssignmentManager hangs on master and its in flaky list
  • [HBASE-18563] - Fix RAT License complaint about website jenkins scripts
  • [HBASE-18568] - Correct metric of numRegions
  • [HBASE-18572] - Delete can't remove the cells which have no visibility label
  • [HBASE-18575] - [AMv2] Enable and fix TestRestartCluster#testRetainAssignmentOnRestart on master
  • [HBASE-18577] - shaded client includes several non-relocated third party dependencies
  • [HBASE-18587] - Fix Flaky TestFileIOEngine
  • [HBASE-18592] - [hbase-thirdparty] Doc on new hbase-thirdparty dependency for the refguide
  • [HBASE-18598] - AsyncNonMetaRegionLocator use FIFO algorithm to get a candidate locate request
  • [HBASE-18599] - Add missing @Deprecated annotations
  • [HBASE-18606] - Tests in hbase-spark module fail with UnsatisfiedLinkError
  • [HBASE-18607] - fix submit-patch.py to support utf8
  • [HBASE-18614] - Setting BUCKET_CACHE_COMBINED_KEY to false disables stats on RS UI
  • [HBASE-18615] - hbase-rest tests fail in hbase-2.0.0-alpha2
  • [HBASE-18617] - FuzzyRowKeyFilter should not modify the filter pairs
  • [HBASE-18627] - Fix TestRegionServerReadRequestMetrics
  • [HBASE-18628] - ZKPermissionWatcher blocks all ZK notifications
  • [HBASE-18633] - Add more info to understand the source/scenario of large batch requests exceeding threshold
  • [HBASE-18634] - Fix client.TestClientClusterStatus
  • [HBASE-18635] - Fix asciidoc warnings
  • [HBASE-18637] - Update the link of "Bending time in HBase"
  • [HBASE-18640] - Move mapreduce out of hbase-server into separate hbase-mapreduce module
  • [HBASE-18641] - Include block content verification logic used in lruCache in bucketCache
  • [HBASE-18644] - Duplicate "compactionQueueLength" metric in Region Server metrics
  • [HBASE-18647] - Parameter cacheBlocks does not take effect in REST API for scan
  • [HBASE-18655] - TestAsyncClusterAdminApi2 failing sometimes
  • [HBASE-18665] - ReversedScannerCallable invokes getRegionLocations incorrectly
  • [HBASE-18671] - Support Append/Increment in rest api
  • [HBASE-18679] - YARN may null Counters object and cause an NPE in ITBLL
  • [HBASE-18714] - The dropBehind and readahead don't be applied when useHBaseChecksum is enabled
  • [HBASE-18723] - [pom cleanup] Do a pass with dependency:analyze; remove unused and explicity list the dependencies we exploit
  • [HBASE-18741] - Remove cancel command from backup code
  • [HBASE-18743] - HFiles in use by a table which has the same name and namespace with a default table cloned from snapshot may be deleted when that snapshot and default table are deleted
  • [HBASE-18757] - Fix Improper bitwise & in BucketCache offset calculation
  • [HBASE-18759] - Fix hbase-shaded-check-invariants failure
  • [HBASE-18762] - Canary sink type cast error
  • [HBASE-18763] - quotas.TestQuotaThrottle failing on all nightly runs
  • [HBASE-18765] - The value of balancerRan is true even though no plans are executed
  • [HBASE-18771] - Incorrect StoreFileRefresh leading to split and compaction failures
  • [HBASE-18787] - Fix the "dependencies connecting to an HBase cluster"
  • [HBASE-18789] - Displays the reporting interval of each RS on the Master page
  • [HBASE-18791] - HBASE_HOME/lib does not contain hbase-mapreduce-${project.version}-tests.jar
  • [HBASE-18796] - Admin#isTableAvailable returns incorrect result before daughter regions are opened
  • [HBASE-18801] - Bulk load cleanup may falsely deem file deletion successful
  • [HBASE-18803] - Mapreduce job get failed caused by NoClassDefFoundError: org/apache/commons/lang3/ArrayUtils
  • [HBASE-18808] - Ineffective config check in BackupLogCleaner#getDeletableFiles()
  • [HBASE-18813] - TestCanaryTool fails on branch-1 / branch-1.4
  • [HBASE-18818] - TestConnectionImplemenation fails
  • [HBASE-18830] - TestCanaryTool does not check Canary monitor's error code
  • [HBASE-18831] - Add explicit dependency on javax.el
  • [HBASE-18832] - LTT fails with casting exception for HColumnDescriptor
  • [HBASE-18834] - fix shellcheck warning on hbase personality
  • [HBASE-18836] - Note need for explicit javax.el and exclude from shaded artifacts
  • [HBASE-18838] - shaded artifacts are incorrect when built against hadoop 3
  • [HBASE-18844] - Release hbase-2.0.0-alpha-4; Theme "Coprocessor API Cleanup"
  • [HBASE-18845] - TestReplicationSmallTests fails after HBASE-14004
  • [HBASE-18846] - Accommodate the hbase-indexer/lily/SEP consumer deploy-type
  • [HBASE-18851] - LICENSE failure after HADOOP-14799 with Hadoop 3
  • [HBASE-18852] - Take down the hbasecon asia banner on home page
  • [HBASE-18853] - hbase-protocol-shaded includes protobuf (since we moved to hbase-thirdparty)
  • [HBASE-18866] - clean up warnings about proto syntax
  • [HBASE-18874] - HMaster abort message will be skipped if Throwable is passed null
  • [HBASE-18876] - Backup create command fails to take queue parameter as option
  • [HBASE-18880] - Failed to start rest server if the value of hbase.rest.threads.max is too small.
  • [HBASE-18885] - HFileOutputFormat2 hardcodes default FileOutputCommitter
  • [HBASE-18887] - After full backup passed on hdfs root and incremental failed, full backup cannot be cleaned
  • [HBASE-18888] - StealJobQueue should call super() to init the PriorityBlockingQueue
  • [HBASE-18893] - Remove Add/Modify/DeleteColumnFamilyProcedure in favor of using ModifyTableProcedure
  • [HBASE-18894] - null pointer exception in list_regions in shell command
  • [HBASE-18896] - Work around incompatible change to DistCpOptions for hadoop-3
  • [HBASE-18904] - Missing break in NEXT_ROW case of FilterList#mergeReturnCodeForOrOperator()
  • [HBASE-18913] - TestShell fails because NoMethodError: undefined method parseColumn
  • [HBASE-18921] - Result.current() throws ArrayIndexOutOfBoundsException after calling advance()
  • [HBASE-18922] - Fix all dead links in our HBase book
  • [HBASE-18928] - Backup delete command shows wrong number of deletes requested
  • [HBASE-18932] - Backups masking exception in a scenario and though it fails , it shows success message.
  • [HBASE-18934] - precommit on branch-1 isn't supposed to run against hadoop 3
  • [HBASE-18940] - branch-2 (and probably others) fail check of generated source artifact
  • [HBASE-18941] - Confusing logging error around rerun of restore on an existing table.
  • [HBASE-18942] - hbase-hadoop2-compat module ignores hadoop-3 profile
  • [HBASE-18946] - Stochastic load balancer assigns replica regions to the same RS
  • [HBASE-18958] - Remove the IS annotation from SpaceLimitingException
  • [HBASE-18973] - clean up maven warnings about pom well-formedness for master/branch-2
  • [HBASE-18975] - Fix backup / restore hadoop3 incompatibility
  • [HBASE-18983] - Upgrade to latest error-prone
  • [HBASE-18984] - [AMv2] Retain assignment does not work well in AMv2
  • [HBASE-18990] - ServerLoad doesn't override #equals which leads to #equals in ClusterStatus always false
  • [HBASE-18992] - Comparators passed to the Memstore's flattened segments seems to be wrong
  • [HBASE-18997] - Remove the redundant methods in RegionInfo
  • [HBASE-18998] - processor.getRowsToLock() always assumes there is some row being locked
  • [HBASE-19014] - surefire fails; When writing xml report stdout/stderr ... No such file or directory
  • [HBASE-19016] - Coordinate storage policy property name for table schema and bulkload
  • [HBASE-19017] - [AMv2] EnableTableProcedure is not retaining the assignments
  • [HBASE-19018] - Use of hadoop internals that require bouncycastle should declare bouncycastle dependency
  • [HBASE-19020] - TestXmlParsing exception checking relies on a particular xml implementation without declaring it.
  • [HBASE-19021] - Restore a few important missing logics for balancer in 2.0
  • [HBASE-19023] - Usage for rowcounter in refguide is out of sync with code
  • [HBASE-19030] - nightly runs should attempt to log test results after archiving
  • [HBASE-19032] - Set Content-Type header for patches uploaded by submit-patch.py
  • [HBASE-19035] - Miss metrics when coprocessor use region scanner to read data
  • [HBASE-19038] - precommit mvn install should run from root on patch
  • [HBASE-19039] - refactor shadedjars test to only run on java changes.
  • [HBASE-19042] - Oracle Java 8u144 downloader broken in precommit check
  • [HBASE-19054] - Switch precommit docker image to one based on maven images
  • [HBASE-19056] - TestCompactionInDeadRegionServer is top of the flakies charts!
  • [HBASE-19058] - The wget isn't installed in building docker image
  • [HBASE-19060] - "Hadoop check" test is running all the time instead of just when changes to java
  • [HBASE-19061] - enforcer NPE on hbase-shaded-invariants
  • [HBASE-19065] - HRegion#bulkLoadHFiles() should wait for concurrent Region#flush() to finish
  • [HBASE-19066] - Correct the directory of openjdk-8 for jenkins
  • [HBASE-19072] - Missing break in catch block of InterruptedException in HRegion#waitForFlushes()
  • [HBASE-19073] - Cleanup CoordinatedStateManager
  • [HBASE-19075] - Task tabs on master UI cause page scroll
  • [HBASE-19077] - Have Region*CoprocessorEnvironment provide an ImmutableOnlineRegions
  • [HBASE-19085] - Fix findbug EQ_OVERRIDING_EQUALS_NOT_SYMMETRIC warning
  • [HBASE-19087] - Log an Optional's value/null instead of Optional[value]/Optional.empty.
  • [HBASE-19088] - move_tables_rsgroup will throw an exception when the table is disabled
  • [HBASE-19089] - Fix the list of included moduleSets in src and binary tars
  • [HBASE-19094] - NPE in RSGroupStartupWorker.waitForGroupTableOnline during master startup
  • [HBASE-19098] - Python based compatiblity checker fails if git repo does not have a remote named 'origin'
  • [HBASE-19100] - Missing break in catch block of InterruptedException in HRegion#waitForFlushesAndCompactions
  • [HBASE-19102] - TestZooKeeperMainServer fails with KeeperException$ConnectionLossException
  • [HBASE-19111] - Add missing CellUtil#isPut(Cell) methods
  • [HBASE-19117] - Avoid NPE occurring while active master dies
  • [HBASE-19118] - Use SaslUtil to set Sasl.QOP in 'Thrift'
  • [HBASE-19119] - hbase-http shouldn't have a native profile
  • [HBASE-19120] - IllegalArgumentException from ZNodeClearer when master shuts down
  • [HBASE-19124] - Move HBase-Nightly source artifact creation test from JenkinsFile to a script in dev-support
  • [HBASE-19129] - TestChoreService is flaky (branch-1 / branch-1.4)
  • [HBASE-19130] - Typo in HStore.initializeRegionInternals for replaying wal
  • [HBASE-19134] - Make WALKey an Interface; expose Read-Only version to CPs
  • [HBASE-19135] - TestWeakObjectPool time out
  • [HBASE-19137] - Nightly test should make junit reports optional rather than attempt archive after reporting.
  • [HBASE-19138] - Rare failure in TestLruBlockCache
  • [HBASE-19144] - [RSgroups] Retry assignments in FAILED_OPEN state when servers (re)join the cluster
  • [HBASE-19147] - All branch-2 unit tests pass
  • [HBASE-19148] - Reevaluate default values of configurations
  • [HBASE-19150] - TestSnapshotWithAcl is flaky
  • [HBASE-19156] - Duplicative regions_per_server options on LoadTestTool
  • [HBASE-19160] - Re-expose CellComparator
  • [HBASE-19163] - "Maximum lock count exceeded" from region server's batch processing
  • [HBASE-19165] - TODO Handle stuck in transition: rit=OPENING, location=ve0538....
  • [HBASE-19166] - AsyncProtobufLogWriter persists ProtobufLogWriter as class name for backward compatibility
  • [HBASE-19167] - RowCounter not working on 2.0.0-alpha3
  • [HBASE-19173] - Configure IntegrationTestRSGroup automatically for minicluster mode
  • [HBASE-19178] - table.rb use undefined method 'getType' for Cell interface
  • [HBASE-19181] - LogRollBackupSubprocedure will fail if we use AsyncFSWAL instead of FSHLog
  • [HBASE-19184] - clean up nightly source artifact test to match expectations from switch to git-archive
  • [HBASE-19185] - ClassNotFoundException: com.fasterxml.jackson.*
  • [HBASE-19193] - [AMv2] Master dies during Table Drop, new Master confused on what to do w/ Regions
  • [HBASE-19194] - TestRSGroupsBase has some always false checks
  • [HBASE-19195] - More error-prone fixes
  • [HBASE-19196] - Release hbase-2.0.0-beta-1; the "Finish-line" release
  • [HBASE-19198] - TestIPv6NIOServerSocketChannel fails; unable to bind
  • [HBASE-19199] - RatioBasedCompactionPolicy#shouldPerformMajorCompaction() always return true when only one file needs to compact
  • [HBASE-19210] - TestNamespacesInstanceResource fails
  • [HBASE-19211] - B&R: update configuration string in BackupRestoreConstants
  • [HBASE-19215] - Incorrect exception handling on the client causes incorrect call timeouts and byte buffer allocations on the server
  • [HBASE-19218] - Master stuck thinking hbase:namespace is assigned after restart preventing intialization
  • [HBASE-19221] - NoClassDefFoundError: org/hamcrest/SelfDescribing while running IT tests in 2.0-alpha4
  • [HBASE-19223] - Remove references to Date Tiered compaction from branch-1.2 and branch-1.1 ref guide
  • [HBASE-19229] - Nightly script to check source artifact should not do a destructive git operation without opt-in
  • [HBASE-19240] - Fix error-prone errors, part four?
  • [HBASE-19244] - Fix simple typos in HBASE-15518 descriptions
  • [HBASE-19245] - MultiTableInputFormatBase#getSplits creates a Connection per Table
  • [HBASE-19246] - Trivial fix in findHangingTests.py
  • [HBASE-19249] - test for "hbase antipatterns" should check _count_ of occurance rather than text of
  • [HBASE-19250] - TestClientClusterStatus is flaky
  • [HBASE-19255] - PerformanceEvaluation class not found when run PE test
  • [HBASE-19260] - Add lock back to avoid parallel accessing meta to locate region
  • [HBASE-19285] - Add per-table latency histograms
  • [HBASE-19287] - master hangs forever if RecoverMeta send assign meta region request to target server fail
  • [HBASE-19304] - KEEP_DELETED_CELLS should ignore case
  • [HBASE-19310] - Verify IntegrationTests don't rely on Rules outside of JUnit context
  • [HBASE-19312] - Find out why sometimes we need to spend more than one second to get the cluster id
  • [HBASE-19315] - Incorrect snapshot version is used for 2.0.0-beta-1
  • [HBASE-19317] - Increase "yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage" to avoid host-related failures on MiniMRCluster
  • [HBASE-19318] - MasterRpcServices#getSecurityCapabilities explicitly checks for the HBase AccessController implementation
  • [HBASE-19319] - Fix bug in synchronizing over ProcedureEvent
  • [HBASE-19321] - ZKAsyncRegistry ctor would hang when zookeeper cluster is not available
  • [HBASE-19325] - Pass a list of server name to postClearDeadServers
  • [HBASE-19330] - Remove duplicated dependency from hbase-rest
  • [HBASE-19332] - DumpReplicationQueues misreports total WAL size
  • [HBASE-19335] - Fix waitUntilAllRegionsAssigned
  • [HBASE-19337] - AsyncMetaTableAccessor may hang when call ScanController.terminate many times
  • [HBASE-19339] - Eager policy results in the negative size of memstore
  • [HBASE-19349] - Introduce wrong version depencency of servlet-api jar
  • [HBASE-19350] - TestMetaWithReplicas is flaky
  • [HBASE-19351] - Deprecated is missing in Table implementations
  • [HBASE-19355] - Missing dependency on hbase-zookeeper module causes CopyTable to fail
  • [HBASE-19363] - Tests under TestCheckAndMutate are identical
  • [HBASE-19371] - Running WALPerformanceEvaluation against asyncfswal throws exceptions
  • [HBASE-19383] - [1.2] java.lang.AssertionError: expected:<2> but was:<1> at org.apache.hadoop.hbase.TestChoreService.testTriggerNowFailsWhenNotScheduled(TestChoreService.java:707)
  • [HBASE-19384] - Results returned by preAppend hook in a coprocessor are replaced with null from other coprocessor even on bypass
  • [HBASE-19385] - [1.3] TestReplicator failed 1.3 nightly
  • [HBASE-19386] - HBase UnsafeAvailChecker returns false on Arm64
  • [HBASE-19388] - Incorrect value is being set for Compaction Pressure in RegionLoadStats object inside HRegion class
  • [HBASE-19390] - Revert to older version of Jetty 9.3
  • [HBASE-19391] - Calling HRegion#initializeRegionInternals from a region replica can still re-create a region directory
  • [HBASE-19392] - TestReplicaWithCluster#testReplicaGetWithPrimaryAndMetaDown failure in master
  • [HBASE-19394] - Support multi-homing env for the publication of RS status with multicast (hbase.status.published)
  • [HBASE-19396] - Fix flaky test TestHTableMultiplexerFlushCache
  • [HBASE-19406] - Fix CompactionRequest equals and hashCode
  • [HBASE-19412] - Fix TestBlockEvictionFromClient
  • [HBASE-19417] - Remove boolean return value from postBulkLoadHFile hook
  • [HBASE-19422] - using hadoop-profile property leads to confusing failures
  • [HBASE-19424] - Metrics servlet throws NPE
  • [HBASE-19431] - The tag array written by IndividualBytesFieldCell#write is out of bounds
  • [HBASE-19433] - ChangeSplitPolicyAction modifies an immutable HTableDescriptor
  • [HBASE-19434] - create_namespace command for existing namespace does not throw useful error message
  • [HBASE-19435] - Reopen Files for ClosedChannelException in BucketCache
  • [HBASE-19437] - Batch operation can't handle the null result for Append/Increment
  • [HBASE-19445] - PerformanceEvaluation NPE processing split policy option
  • [HBASE-19447] - INFO level logging of GetClusterStatus from HMaster is too chatty
  • [HBASE-19454] - Debugging TestDistributedLogSplitting#testThreeRSAbort
  • [HBASE-19456] - RegionMover's region server hostname option is no longer case insensitive
  • [HBASE-19457] - Debugging flaky TestTruncateTableProcedure#testRecoveryAndDoubleExecutionPreserveSplits
  • [HBASE-19461] - TestRSGroups is broke
  • [HBASE-19484] - The value array written by ExtendedCell#write is out of bounds
  • [HBASE-19490] - Rare failure in TestRateLimiter
  • [HBASE-19493] - Make TestWALMonotonicallyIncreasingSeqId also work with AsyncFSWAL
  • [HBASE-19495] - Fix failed ut TestShell
  • [HBASE-19496] - Reusing the ByteBuffer in rpc layer corrupt the ServerLoad and RegionLoad
  • [HBASE-19503] - Fix TestWALOpenAfterDNRollingStart for AsyncFSWAL
  • [HBASE-19508] - ReadOnlyConfiguration throws exception if any Configuration in current context calls addDefautlResource
  • [HBASE-19509] - RSGroupAdminEndpoint#preCreateTable triggers TableNotFoundException
  • [HBASE-19510] - TestDistributedLogSplitting is flakey for AsyncFSWAL
  • [HBASE-19511] - Splits causes blocks to be cached again and so such blocks cannot be evicted from bucket cache
  • [HBASE-19513] - Fix the wrapped AsyncFSOutput implementation
  • [HBASE-19516] - IntegrationTestBulkLoad and IntegrationTestImportTsv run into 'java.lang.RuntimeException: DistributedHBaseCluster@1bb564e2 not an instance of MiniHBaseCluster'
  • [HBASE-19522] - The complete order may be wrong in AsyncBufferedMutatorImpl
  • [HBASE-19530] - New regions should always be added with state CLOSED
  • [HBASE-19532] - AssignProcedure#COMPARATOR may produce incorrect sort order
  • [HBASE-19542] - fix TestSafemodeBringsDownMaster
  • [HBASE-19546] - TestMasterReplication.testCyclicReplication2 uses wrong assertion
  • [HBASE-19547] - HBase fails building on AArch64 due to asciidoctor-maven-plugin.
  • [HBASE-19549] - Change path comparison in CommonFSUtils
  • [HBASE-19555] - TestSplitTransactionOnCluster is flaky
  • [HBASE-19558] - TestRegionsOnMasterOptions hack so it works reliablly
  • [HBASE-19559] - Fix TestLogRolling.testLogRollOnDatanodeDeath
  • [HBASE-19561] - maxCacheSize in CacheEvictionStats can't be accumulated repeatedly When dealing with each region
  • [HBASE-19563] - A few hbase-procedure classes missing @InterfaceAudience annotation
  • [HBASE-19565] - TestSafemodeBringsDownMaster constantly hangs
  • [HBASE-19578] - MasterProcWALs cleaning is incorrect
  • [HBASE-19583] - update RM list to remove EOM versions
  • [HBASE-19588] - Additional jar dependencies needed for mapreduce PerformanceEvaluation
  • [HBASE-19589] - New regions should always be added with state CLOSED (followup of HBASE-19530)
  • [HBASE-19593] - Possible NPE if wal is closed during waledit append.
  • [HBASE-19598] - Fix TestAssignmentManagerMetrics flaky test
  • [HBASE-19600] - ITBLL failing on branch-2
  • [HBASE-19608] - Race in MasterRpcServices.getProcedureResult
  • [HBASE-19619] - Modify replication_admin.rb to use ReplicationPeerConfigBuilder
  • [HBASE-19624] - TestIOFencing hangs
  • [HBASE-19639] - ITBLL can't go big because RegionTooBusyException... Above memstore limit
  • [HBASE-19643] - Need to update cache location when get error in AsyncBatchRpcRetryingCaller
  • [HBASE-19654] - Remove misleading and chatty debug message in ReplicationLogCleaner
  • [HBASE-19656] - Disable TestAssignmentManagerMetrics for beta-1
  • [HBASE-19658] - Fix and reenable TestCompactingToCellFlatMapMemStore#testFlatteningToJumboCellChunkMap
  • [HBASE-19666] - TestDefaultCompactSelection test failed
  • [HBASE-19671] - Fix TestMultiParallel#testActiveThreadsCount
  • [HBASE-19672] - Correct comments for default values of major compaction in SortedCompactionPolicy#getNextMajorCompactTime()
  • [HBASE-19685] - Fix TestFSErrorsExposed#testFullSystemBubblesFSErrors
  • [HBASE-19688] - TimeToLiveProcedureWALCleaner should extends BaseLogCleanerDelegate
  • [HBASE-19691] - Do not require ADMIN permission for obtaining ClusterStatus
  • [HBASE-19694] - The initialization order for a fresh cluster is incorrect
  • [HBASE-19696] - Filter returning INCLUDE_AND_NEXT_COL doesn't skip remaining versions when scan has explicit columns
  • [HBASE-19703] - Functionality added as part of HBASE-12583 is not working after moving the split code to master
  • [HBASE-19706] - Cells are always eclipsed by Deleted cells even if in time range scan
  • [HBASE-19709] - Guard against a ThreadPool size of 0 in CleanerChore
  • [HBASE-19712] - Fix TestSnapshotQuotaObserverChore#testSnapshotSize
  • [HBASE-19713] - Enable TestInterfaceAudienceAnnotations
  • [HBASE-19714] - `status 'detailed'` invokes nonexistent "getRegionsInTransition" method on ClusterStatus
  • [HBASE-19716] - Fix flaky test master.assignment.TestAssignmentManager
  • [HBASE-19717] - IntegrationTestDDLMasterFailover is using outdated values for DataBlockEncoding
  • [HBASE-19721] - Unnecessary stubbings detected in test class: TestReversedScannerCallable
  • [HBASE-19726] - Failed to start HMaster due to infinite retrying on meta assign
  • [HBASE-19728] - Add lock to filesCompacting in all place.
  • [HBASE-19729] - UserScanQueryMatcher#mergeFilterResponse should return INCLUDE_AND_SEEK_NEXT_ROW when filterResponse is INCLUDE_AND_SEEK_NEXT_ROW
  • [HBASE-19732] - Replica regions does not return back the MSLAB chunks to pool
  • [HBASE-19734] - IntegrationTestReplication broken w/ separate clusters
  • [HBASE-19740] - Repeated error message for NamespaceExistException
  • [HBASE-19744] - Fix flakey TestZKLeaderManager
  • [HBASE-19749] - Revisit logic of UserScanQueryMatcher#mergeFilterResponse method
  • [HBASE-19752] - RSGroupBasedLoadBalancer#getMisplacedRegions() should handle the case where rs group cannot be determined
  • [HBASE-19755] - Error message for non-existent namespace is inaccurate
  • [HBASE-19756] - Master NPE during completed failed proc eviction
  • [HBASE-19757] - System table gets stuck after enabling region server group feature in secure cluster
  • [HBASE-19767] - Master web UI shows negative values for Remaining KVs
  • [HBASE-19768] - RegionServer startup failing when DN is dead
  • [HBASE-19769] - IllegalAccessError on package-private Hadoop metrics2 classes in MapReduce jobs
  • [HBASE-19771] - restore_snapshot shell command gives wrong namespace if the namespace doesn't exist
  • [HBASE-19773] - Adding javadoc around getting instance of RawCellBuilder
  • [HBASE-19774] - incorrect behavior of locateRegionInMeta
  • [HBASE-19775] - hbase shell doesn't handle the exceptions that are wrapped in java.io.UncheckedIOException
  • [HBASE-19780] - Change execution phase of checkstyle plugin back to default 'verify'
  • [HBASE-19783] - Change replication peer cluster key/endpoint from a not-null value to null is not allowed
  • [HBASE-19784] - stop-hbase gives unfriendly message when local hbase isn't running
  • [HBASE-19792] - TestReplicationSmallTests.testDisableEnable fails
  • [HBASE-19794] - TestZooKeeper hangs
  • [HBASE-19797] - Operator priority leads to wrong logic in ReplicationSourceWALReader
  • [HBASE-19802] - Wrong usage messages on shell commands (grant/revoke namespace syntax)
  • [HBASE-19806] - Lower max versions for table column family of hbase:meta
  • [HBASE-19808] - Reenable TestMultiParallel
  • [HBASE-19812] - TestFlushSnapshotFromClient fails because of failing region.flush
  • [HBASE-19814] - Release hbase-2.0.0-beta-2; "rolling upgrade" release
  • [HBASE-19815] - Flakey TestAssignmentManager.testAssignWithRandExec
  • [HBASE-19816] - Replication sink list is not updated on UnknownHostException
  • [HBASE-19818] - Scan time limit not work if the filter always filter row key
  • [HBASE-19821] - TestCleanerChore#testOnConfigurationChange() requires at least 4 processors to get passed
  • [HBASE-19822] - HFileCleaner threads stick around after shutdown stuck on queue#take
  • [HBASE-19825] - Fix hadoop3 compat test failures
  • [HBASE-19828] - Flakey TestRegionsOnMasterOptions.testRegionsOnAllServers
  • [HBASE-19829] - hadoop-minicluster pulls zookeeper:test-jar:tests 3.4.6
  • [HBASE-19836] - Fix TestZooKeeper.testLogSplittingAfterMasterRecoveryDueToZKExpiry
  • [HBASE-19838] - Can not shutdown backup master cleanly when it has already tried to become the active master
  • [HBASE-19853] - duplicate slf4j declaration in mapreduce pom
  • [HBASE-19863] - java.lang.IllegalStateException: isDelete failed when SingleColumnValueFilter is used
  • [HBASE-19871] - delete.rb should require user to provide the column
  • [HBASE-19876] - The exception happening in converting pb mutation to hbase.mutation messes up the CellScanner
  • [HBASE-19884] - BucketEntryGroup's equals, hashCode and compareTo methods are not consistent
  • [HBASE-19892] - Checking 'patch attach' and yetus 0.7.0 and move to Yetus 0.7.0
  • [HBASE-19900] - Region-level exception destroy the result of batch
  • [HBASE-19901] - Up yetus proclimit on nightlies
  • [HBASE-19905] - ReplicationSyncUp tool will not exit if a peer replication is disabled
  • [HBASE-19906] - TestZooKeeper Timeout
  • [HBASE-19907] - TestMetaWithReplicas still flakey
  • [HBASE-19919] - Tidying up logging
  • [HBASE-19920] - TokenUtil.obtainToken unnecessarily creates a local directory
  • [HBASE-19924] - hbase rpc throttling does not work for multi() with request count rater.
  • [HBASE-19926] - Use a separated class to implement the WALActionListener for Replication
  • [HBASE-19929] - Call RS.stop on a session expired RS may hang
  • [HBASE-19934] - HBaseSnapshotException when read replicas is enabled and online snapshot is taken after region splitting
  • [HBASE-19937] - Ensure createRSGroupTable be called after ProcedureExecutor and LoadBalancer are initialized
  • [HBASE-19939] - TestSplitTableRegionProcedure#testSplitWithoutPONR() and testRecoveryAndDoubleExecution() are failing with NPE
  • [HBASE-19941] - Flaky TestCreateTableProcedure times out in nightly, needs to LargeTests
  • [HBASE-19953] - Avoid calling post* hook when procedure fails
  • [HBASE-19954] - Separate TestBlockReorder into individual tests to avoid ShutdownHook suppression error against hadoop3
  • [HBASE-19964] - TestWriteHeavyIncrementObserver fails
  • [HBASE-19966] - The WriteEntry for WALKey maybe null if we failed to call WAL.append
  • [HBASE-19968] - MapReduce test fails with NoClassDefFoundError against hadoop3
  • [HBASE-19972] - Should rethrow the RetriesExhaustedWithDetailsException when failed to apply the batch in ReplicationSink
  • [HBASE-19974] - Fix decommissioned servers cannot be removed by remove_servers_rsgroup methods
  • [HBASE-19977] - FileMmapEngine allocation of byte buffers should be synchronized
  • [HBASE-19979] - ReplicationSyncUp tool may leak Zookeeper connection
  • [HBASE-19980] - NullPointerException when restoring a snapshot after splitting a region
  • [HBASE-19986] - If HBaseTestClassRule timesout a test, thread dump.
  • [HBASE-19987] - update error-prone to 2.2.0
  • [HBASE-19991] - lots of hbase-rest test failures against hadoop 3
  • [HBASE-19996] - Some nonce procs might not be cleaned up (follow up HBASE-19756)
  • [HBASE-19998] - Flakey TestVisibilityLabelsWithDefaultVisLabelService
  • [HBASE-20017] - BufferedMutatorImpl submit the same mutation repeatedly
  • [HBASE-20020] - Make sure we throw DoNotRetryIOException when ConnectionImplementation is closed
  • [HBASE-20023] - CompactionTool command line examples are incorrect
  • [HBASE-20024] - TestMergeTableRegionsProcedure is STILL flakey
  • [HBASE-20027] - Add test TestClusterPortAssignment
  • [HBASE-20032] - Receving multiple warnings for missing reporting.plugins.plugin.version
  • [HBASE-20037] - Race when calling SequenceIdAccounting.resetHighest
  • [HBASE-20043] - ITBLL fails against hadoop3
  • [HBASE-20049] - Region replicas of SPLIT and MERGED regions are kept in in-memory states until restarting master
  • [HBASE-20054] - Forward port HBASE-18282 ReplicationLogCleaner can delete WALs not yet replicated in case of KeeperException
  • [HBASE-20061] - HStore synchronized member variable filesCompacting should be private
  • [HBASE-20062] - findbugs is not running on precommit checks
  • [HBASE-20066] - Region sequence id may go backward after split or merge
  • [HBASE-20070] - website generation is failing
  • [HBASE-20074] - [FindBugs] Same code on both branches in CompactingMemStore#initMemStoreCompactor
  • [HBASE-20078] - MultiByteBuff : bug in reading primitives when individual buffers are too small
  • [HBASE-20086] - PE randomSeekScan fails with ClassNotFoundException
  • [HBASE-20090] - Properly handle Preconditions check failure in MemStoreFlusher$FlushHandler.run
  • [HBASE-20104] - Fix infinite loop of RIT when creating table on a rsgroup that has no online servers
  • [HBASE-20106] - API Compliance checker should fall back to specifying origin as remote repo
  • [HBASE-20108] - `hbase zkcli` falls into a non-interactive prompt after HBASE-15199
  • [HBASE-20110] - Findbugs in zk and mr caused nightly #409 branch-2 to fail
  • [HBASE-20111] - Able to split region explicitly even on shouldSplit return false from split policy
  • [HBASE-20114] - Fix IllegalFormatConversionException in rsgroup.jsp
  • [HBASE-20130] - Use defaults (16020 & 16030) as base ports when the RS is bound to localhost
  • [HBASE-20134] - support scripts use hard-coded /tmp
  • [HBASE-20141] - Fix TooManyFiles exception when RefreshingChannels in FileIOEngine
  • [HBASE-20144] - The shutdown of master will hang if there are no live region server
  • [HBASE-20146] - Regions are stuck while opening when WAL is disabled
  • [HBASE-20153] - enable error-prone analysis in precommit
  • [HBASE-20157] - WAL file might get broken
  • [HBASE-20160] - TestRestartCluster.testRetainAssignmentOnRestart uses the wrong condition to decide whether the assignment is finished
  • [HBASE-20162] - [nightly] depending on pipeline execution we sometimes refer to the wrong workspace
  • [HBASE-20164] - failed hadoopcheck should add footer link
  • [HBASE-20182] - Can not locate region after split and merge
  • [HBASE-20185] - Fix ACL check for MasterRpcServices#execProcedure
  • [HBASE-20187] - Shell startup fails with IncompatibleClassChangeError
  • [HBASE-20189] - Typo in Required Java Version error message while building HBase.
  • [HBASE-20200] - list_procedures fails in shell
  • [HBASE-20201] - HBase must provide commons-cli-1.4 for mapreduce jobs with H3
  • [HBASE-20203] - [AMv2] CODE-BUG: Uncaught runtime exception for pid=...., state=SUCCESS; AssignProcedure
  • [HBASE-20213] - [LOGGING] Aligning formatting and logging less (compactions, in-memory compactions)
  • [HBASE-20219] - An error occurs when scanning with reversed=true and loadColumnFamiliesOnDemand=true
  • [HBASE-20224] - Web UI is broken in standalone mode
  • [HBASE-20229] - ConnectionImplementation.locateRegions() returns duplicated entries when region replication is on
  • [HBASE-20231] - Not able to delete column family from a row using RemoteHTable
  • [HBASE-20233] - [metrics] Ill-formatted numRegions metric in "Hadoop:service=HBase,name=RegionServer,sub=Regions" mbean
  • [HBASE-20237] - Put back getClosestRowBefore and throw UnknownProtocolException instead... for asynchbase client
  • [HBASE-20259] - Doc configs for in-memory-compaction and add detail to in-memory-compaction logging
  • [HBASE-20261] - Table page (table.jsp) in Master UI does not show replicaIds for hbase meta table
  • [HBASE-20280] - Fix possibility of deadlocking in refreshFileConnections when prefetch is enabled
  • [HBASE-20282] - Provide short name invocations for useful tools
  • [HBASE-20292] - Wrong URLs in the descriptions for update_all_config and update_config commands in shell
  • [HBASE-20293] - get_splits returns duplicate split points when region replication is on
  • [HBASE-20295] - TableOutputFormat.checkOutputSpecs throw NullPointerException Exception
  • [HBASE-20308] - test Dockerfile needs to include git
  • [HBASE-20310] - [hbck] bin/hbase hbck -metaonly shows false inconsistency on HBase 2
  • [HBASE-20314] - Precommit build for master branch fails because of surefire fork fails
  • [HBASE-20330] - ProcedureExecutor.start() gets stuck in recover lease on store.
  • [HBASE-20343] - [DOC] fix log directory paths
  • [HBASE-20350] - NullPointerException in Scanner during close()
  • [HBASE-20351] - Shell dumps netty properties on startup
  • [HBASE-20353] - REST server startup fails
  • [HBASE-20358] - Fix bin/hbase thrift usage text
  • [HBASE-20362] - TestMasterShutdown.testMasterShutdownBeforeStartingAnyRegionServer is flaky
  • [HBASE-20363] - TestNamespaceAuditor.testRegionMerge is flaky
  • [HBASE-20376] - RowCounter and CellCounter documentations are incorrect
  • [HBASE-20382] - If RSGroups not enabled, rsgroup.jsp prints stack trace
  • [HBASE-20384] - [AMv2] Logging format improvements; use encoded name rather than full region name marking transitions
  • [HBASE-20385] - Purge md5-making from our little make_rc.sh script
  • [HBASE-20394] - HBase over rides the value of HBASE_OPTS (if any) set by client
  • [HBASE-20397] - Make it more explicit that monkey.properties is found on CLASSPATH
  • [HBASE-20398] - Redirect doesn't work on web UI
  • [HBASE-20399] - Fix merge layout
  • [HBASE-20410] - upgrade protoc compiler to 3.5.1-1
  • [HBASE-20427] - thrift.jsp displays "Framed transport" incorrectly
  • [HBASE-20439] - Clean up incorrect use of commons-logging in hbase-server
  • [HBASE-20440] - Clean up incorrect use of commons-lang 2.y
  • [HBASE-20442] - clean up incorrect use of commons-collections 3
  • [HBASE-20464] - Disable IMC
  • [HBASE-20465] - Fix TestEnableRSGroup flaky
  • [HBASE-21617] - HBase Bytes.putBigDecimal error

New Feature

  • [HBASE-3727] - MultiHFileOutputFormat
  • [HBASE-4224] - Need a flush by regionserver rather than by table option
  • [HBASE-5162] - Basic client pushback mechanism
  • [HBASE-5238] - Add a log4j category for all edits to META/ROOT
  • [HBASE-5980] - Scanner responses from RS should include metrics on rows/KVs filtered
  • [HBASE-6721] - RegionServer Group based Assignment
  • [HBASE-9774] - HBase native metrics and metric collection for coprocessors
  • [HBASE-10070] - HBase read high-availability using timeline-consistent region replicas
  • [HBASE-10358] - Shell changes for setting consistency per request
  • [HBASE-11262] - Avoid empty columns while doing bulk-load
  • [HBASE-12268] - Add support for Scan.setRowPrefixFilter to shell
  • [HBASE-12721] - Create Docker container cluster infrastructure to enable better testing
  • [HBASE-12869] - Add a REST API implementation of the ClusterManager interface
  • [HBASE-12911] - Client-side metrics
  • [HBASE-12944] - Support patches to branches in precommit jenkins build
  • [HBASE-12972] - Region, a supportable public/evolving subset of HRegion
  • [HBASE-13057] - Provide client utility to easily enable and disable table replication
  • [HBASE-13063] - Allow to turn off memstore replication for region replicas
  • [HBASE-13071] - Hbase Streaming Scan Feature
  • [HBASE-13090] - Progress heartbeats for long running scanners
  • [HBASE-13153] - Bulk Loaded HFile Replication
  • [HBASE-13170] - Allow block cache to be external
  • [HBASE-13259] - mmap() based BucketCache IOEngine
  • [HBASE-13356] - HBase should provide an InputFormat supporting multiple scans in mapreduce jobs over snapshots
  • [HBASE-13412] - Region split decisions should have jitter
  • [HBASE-13639] - SyncTable - rsync for HBase tables
  • [HBASE-13698] - Add RegionLocator methods to Thrift2 proxy.
  • [HBASE-13702] - ImportTsv: Add dry-run functionality and log bad rows
  • [HBASE-13784] - Add Async Client Table API
  • [HBASE-14125] - HBase Backup/Restore Phase 2: Cancel backup
  • [HBASE-14130] - HBase Backup/Restore Phase 2: Delete backup image
  • [HBASE-14131] - HBase Backup/Restore Phase 2: Describe backup image
  • [HBASE-14132] - HBase Backup/Restore Phase 2: History of backups
  • [HBASE-14133] - HBase Backup/Restore Phase 2: Status (and progress) of backup request
  • [HBASE-14134] - HBase Backup/Restore Phase 2: Backup sets management
  • [HBASE-14135] - HBase Backup/Restore Phase 3: Merge backup images
  • [HBASE-14137] - HBase Backup/Restore Phase 2: Backup throttling
  • [HBASE-14141] - HBase Backup/Restore Phase 3: Filter WALs on backup to include only edits from backed up tables
  • [HBASE-14154] - DFS Replication should be configurable at column family level
  • [HBASE-14355] - Scan different TimeRange for each column family
  • [HBASE-14417] - Incremental backup and bulk loading
  • [HBASE-14456] - Implement a namespace-based region grouping strategy for RegionGroupingProvider
  • [HBASE-14459] - Add request and response sizes metrics
  • [HBASE-14477] - Compaction improvements: Date tiered compaction policy
  • [HBASE-14529] - Respond to SIGHUP to reload config
  • [HBASE-14980] - Project Astro
  • [HBASE-15036] - Update HBase Spark documentation to include bulk load with thin records
  • [HBASE-15134] - Add visibility into Flush and Compaction queues
  • [HBASE-15135] - Add metrics for storefile age
  • [HBASE-15136] - Explore different queuing behaviors while busy
  • [HBASE-15181] - A simple implementation of date based tiered compaction
  • [HBASE-15228] - Add the methods to RegionObserver to trigger start/complete restoring WALs
  • [HBASE-15281] - Allow the FileSystem inside HFileSystem to be wrapped
  • [HBASE-15321] - Ability to open a HRegion from hdfs snapshot.
  • [HBASE-15432] - TableInputFormat - support multi column family scan
  • [HBASE-15481] - Add pre/post roll to WALObserver
  • [HBASE-15576] - Scanning cursor to prevent blocking long time on ResultScanner.next()
  • [HBASE-15592] - Print Procedure WAL content
  • [HBASE-15780] - Expose AuthUtil as IA.Public
  • [HBASE-15798] - Add Async RpcChannels to all RpcClients
  • [HBASE-15806] - An endpoint-based export tool
  • [HBASE-15847] - VerifyReplication prefix filtering
  • [HBASE-15881] - Allow BZIP2 compression
  • [HBASE-15892] - submit-patch.py: Single command line to make patch, upload it to jira, and update review board
  • [HBASE-15943] - Add page displaying JVM process metrics
  • [HBASE-15968] - New behavior of versions considering mvcc and ts rather than ts only
  • [HBASE-16213] - A new HFileBlock structure for fast random get
  • [HBASE-16388] - Prevent client threads being blocked by only one slow region server
  • [HBASE-16447] - Replication by namespaces config in peer
  • [HBASE-16463] - Improve transparent table/CF encryption with Commons Crypto
  • [HBASE-16677] - Add table size (total store file size) to table page
  • [HBASE-16751] - Add tuning information to HBase Book
  • [HBASE-16961] - FileSystem Quotas
  • [HBASE-16981] - Expand Mob Compaction Partition policy from daily to weekly, monthly
  • [HBASE-17076] - implement getAndPut() and getAndDelete()
  • [HBASE-17151] - New API to create HFile.Reader without instantiating block cache
  • [HBASE-17174] - Refactor the AsyncProcess, BufferedMutatorImpl, and HTable
  • [HBASE-17181] - Let HBase thrift2 support TThreadedSelectorServer
  • [HBASE-17542] - Move backup system table into separate namespace
  • [HBASE-17737] - Thrift2 proxy should support scan timeRange per column family
  • [HBASE-17757] - Unify blocksize after encoding to decrease memory fragment
  • [HBASE-17758] - [RSGROUP] Add shell command to move servers and tables at the same time
  • [HBASE-17849] - PE tool random read is not totally random
  • [HBASE-17928] - Shell tool to clear compaction queues
  • [HBASE-18131] - Add an hbase shell command to clear deadserver list in ServerManager
  • [HBASE-18161] - Incremental Load support for Multiple-Table HFileOutputFormat
  • [HBASE-18171] - Scanning cursor for async client
  • [HBASE-18226] - Disable reverse DNS lookup at HMaster and use the hostname provided by RegionServer
  • [HBASE-18546] - Always overwrite the TS for Append/Increment unless no existing cells are found
  • [HBASE-18875] - Thrift server supports read-only mode
  • [HBASE-19103] - Add BigDecimalComparator for filter
  • [HBASE-19189] - Ad-hoc test job for running a subset of tests lots of times
  • [HBASE-19326] - Remove decommissioned servers from rsgroup
  • [HBASE-19504] - Add TimeRange support into checkAndMutate
  • [HBASE-19528] - Major Compaction Tool
  • [HBASE-19799] - Add web UI to rsgroup
  • [HBASE-19844] - Shell should support flush by regionserver
  • [HBASE-19886] - Display maintenance mode in shell, web UI
  • [HBASE-19897] - RowMutations should follow the fluent pattern
  • [HBASE-19950] - Introduce a ColumnValueFilter

Improvement

  • [HBASE-2631] - Decide between "InMB" and "MB" as suffix for field names in ClusterStatus objects
  • [HBASE-3135] - Make our MR jobs implement Tool and use ToolRunner so can do -D trickery, etc.
  • [HBASE-3462] - Fix table.jsp in regards to splitting a region/table with an optional splitkey
  • [HBASE-3935] - HServerLoad.storefileIndexSizeMB should be changed to storefileIndexSizeKB
  • [HBASE-5291] - Add Kerberos HTTP SPNEGO authentication support to HBase web consoles
  • [HBASE-5696] - Use Hadoop's DataOutputOutputStream instead of have a copy local
  • [HBASE-6290] - Add a function a mark a server as dead and start the recovery the process
  • [HBASE-6580] - Deprecate HTablePool in favor of HConnection.getTable(...)
  • [HBASE-6617] - ReplicationSourceManager should be able to track multiple WAL paths
  • [HBASE-6919] - Remove unnecessary throws IOException from Bytes.readVLong
  • [HBASE-7171] - Initial web UI for region/memstore/storefiles details
  • [HBASE-7541] - Convert all tests that use HBaseTestingUtility.createMultiRegions to HBA.createTable
  • [HBASE-7782] - HBaseTestingUtility.truncateTable() not acting like CLI
  • [HBASE-7972] - Add a configuration for the TCP backlog in the Thrift server
  • [HBASE-8309] - TableLockManager: allow lock timeout to be set at the individual lock level
  • [HBASE-8329] - Limit compaction speed
  • [HBASE-8386] - deprecate TableMapReduce.addDependencyJars(Configuration, class<?> ...)
  • [HBASE-8486] - IS_ROOT isnt needed in HTableDescriptor.
  • [HBASE-8518] - Get rid of hbase.hstore.compaction.complete setting
  • [HBASE-8642] - [Snapshot] List and delete snapshot by table
  • [HBASE-9899] - for idempotent operation dups, return the result instead of throwing conflict exception
  • [HBASE-10201] - Port 'Make flush decisions per column family' to trunk
  • [HBASE-10240] - Remove 0.94->0.96 migration code
  • [HBASE-10367] - RegionServer graceful stop / decommissioning
  • [HBASE-10699] - Optimize some code; set capacity on arraylist when possible; use isEmpty; reduce allocations
  • [HBASE-11013] - Clone Snapshots on Secure Cluster Should provide option to apply Retained User Permissions
  • [HBASE-11144] - Filter to support scanning multiple row key ranges
  • [HBASE-11344] - Hide row keys and such from the web UIs
  • [HBASE-11400] - Edit, consolidate, and update Compression and data encoding docs
  • [HBASE-11462] - MetaTableAccessor shouldn't use ZooKeeeper
  • [HBASE-11548] - [PE] Add 'cycling' test N times and unit tests for size/zipf/valueSize calculations
  • [HBASE-11585] - PE: Allows warm-up
  • [HBASE-11611] - Clean up ZK-based region assignment
  • [HBASE-11707] - Using Map instead of list in FailedServers of RpcClient
  • [HBASE-11760] - Tighten up region state transition
  • [HBASE-11792] - Organize PerformanceEvaluation usage output
  • [HBASE-11843] - MapReduce classes shouldn't be in hbase-server
  • [HBASE-11862] - Get rid of Writables in HTableDescriptor, HColumnDescriptor
  • [HBASE-11864] - Enhance HLogPrettyPrinter to print information from WAL Header
  • [HBASE-11869] - Support snapshot owner
  • [HBASE-11927] - Use Native Hadoop Library for HFile checksum (And flip default from CRC32 to CRC32C)
  • [HBASE-11939] - Document compressed blockcache
  • [HBASE-12003] - Fix SecureBulkLoadEndpoint class javadoc formatting
  • [HBASE-12035] - Keep table state in META
  • [HBASE-12195] - Fix dev-support/findHangingTests
  • [HBASE-12203] - Remove Master from table status query path.
  • [HBASE-12207] - A script to help keep your Git repo fresh
  • [HBASE-12220] - Add hedgedReads and hedgedReadWins metrics
  • [HBASE-12223] - MultiTableInputFormatBase.getSplits is too slow
  • [HBASE-12251] - [book] Hadoop compat matrix 0.94 section needs cleaned up
  • [HBASE-12256] - Update patch submission guidelines to call out binary file support
  • [HBASE-12350] - Backport error-prone build support to branch-1 and branch-2
  • [HBASE-12405] - WAL accounting by Store
  • [HBASE-12415] - Add add(byte[][] arrays) to Bytes.
  • [HBASE-12429] - Add port to ClusterManager's actions.
  • [HBASE-12559] - Provide LoadBalancer with online configuration capability
  • [HBASE-12590] - A solution for data skew in HBase-Mapreduce Job
  • [HBASE-12596] - bulkload needs to follow locality
  • [HBASE-12601] - Explain how to grant/revoke permission to a group/namespace in grant/revoke command usage
  • [HBASE-12620] - Add HBASE-11639 related items to Ref Guide
  • [HBASE-12627] - Add back snapshot batching facility from HBASE-11360 dropped by HBASE-11742
  • [HBASE-12650] - Move ServerName to hbase-common module
  • [HBASE-12684] - Add new AsyncRpcClient
  • [HBASE-12706] - Support multiple port numbers in ZK quorum string
  • [HBASE-12761] - On region jump ClientScanners should get next row start key instead of a skip.
  • [HBASE-12769] - Replication fails to delete all corresponding zk nodes when peer is removed
  • [HBASE-12770] - Don't transfer all the queued hlogs of a dead server to the same alive server
  • [HBASE-12796] - Clean up HTable and HBaseAdmin deprecated constructor usage
  • [HBASE-12808] - Use Java API Compliance Checker for binary/source compatibility
  • [HBASE-12812] - Update Netty dependency to latest release
  • [HBASE-12822] - Option for Unloading regions through region_mover.rb without Acknowledging
  • [HBASE-12839] - Remove synchronization in ServerStatisticsTracker
  • [HBASE-12840] - Improve unit test coverage of the client pushback mechanism
  • [HBASE-12870] - "Major compaction triggered" and "Skipping major compaction" messages lack the region information
  • [HBASE-12887] - Cleanup many checkstyle errors in o.a.h.h.client
  • [HBASE-12888] - Display number of regions on the table jsp page.
  • [HBASE-12891] - Parallel execution for Hbck checkRegionConsistency
  • [HBASE-12894] - Upgrade Jetty to 9.2.6
  • [HBASE-12896] - checkstyle report diff tool
  • [HBASE-12940] - Expose listPeerConfigs and getPeerConfig to the HBase shell
  • [HBASE-12957] - region_mover#isSuccessfulScan may be extremely slow on region with lots of expired data
  • [HBASE-12975] - Supportable SplitTransaction and RegionMergeTransaction interfaces
  • [HBASE-12982] - Adding timeouts to TestChoreService
  • [HBASE-12986] - Compaction pressure based client pushback
  • [HBASE-12987] - HBCK should print status while scanning over many regions
  • [HBASE-12988] - [Replication]Parallel apply edits across regions
  • [HBASE-12990] - MetaScanner should be replaced by MetaTableAccessor
  • [HBASE-13002] - Make encryption cipher configurable
  • [HBASE-13014] - Java Tool For Region Moving
  • [HBASE-13016] - Clean up remnants of table states stored in table descriptors
  • [HBASE-13018] - WALSplitter should not try to get table states while splitting META
  • [HBASE-13044] - Configuration option for disabling coprocessor loading
  • [HBASE-13054] - Provide more tracing information for locking/latching events.
  • [HBASE-13056] - Refactor table.jsp code to remove repeated code and make it easier to add new checks
  • [HBASE-13059] - Set executable bit for scripts in dev-support
  • [HBASE-13080] - Hbase shell message containing extra quote at the end of error message.
  • [HBASE-13086] - Show ZK root node on Master WebUI
  • [HBASE-13100] - Shell command to retrieve table splits
  • [HBASE-13103] - [ergonomics] add region size balancing as a feature of master
  • [HBASE-13109] - Make better SEEK vs SKIP decisions during scanning
  • [HBASE-13118] - [PE] Add being able to write many columns
  • [HBASE-13120] - Allow disabling hadoop classpath and native library lookup
  • [HBASE-13122] - Improve efficiency for return codes of some filters
  • [HBASE-13127] - Add timeouts on all tests so less zombie sightings
  • [HBASE-13128] - Make HBCK's lock file retry creation and deletion
  • [HBASE-13129] - Add troubleshooting hints around WAL retention from replication
  • [HBASE-13132] - Improve RemoveColumn action debug message
  • [HBASE-13138] - Clean up TestMasterObserver (debug, trying to figure why fails)
  • [HBASE-13142] - [PERF] Reuse the IPCUtil#buildCellBlock buffer
  • [HBASE-13158] - When client supports CellBlock, return the result Cells as controller payload for get(Get) API also
  • [HBASE-13162] - Add capability for cleaning hbase acls to hbase cleanup script.
  • [HBASE-13171] - Change AccessControlClient methods to accept connection object to reduce setup time.
  • [HBASE-13183] - Make ZK tickTime configurable in standalone HBase
  • [HBASE-13185] - Document hbase.regionserver.thrift.framed.max_frame_size_in_mb more clearly
  • [HBASE-13189] - PrefixTreecell should implement HeapSize
  • [HBASE-13197] - Connection API cleanup
  • [HBASE-13199] - Some small improvements on canary tool
  • [HBASE-13216] - Add version info in RPC connection header
  • [HBASE-13222] - Provide means of non-destructive balancer inspection
  • [HBASE-13223] - Add testMoveMeta to IntegrationTestMTTR
  • [HBASE-13235] - Revisit the security auditing semantics.
  • [HBASE-13236] - Clean up m2e-related warnings/errors from poms
  • [HBASE-13240] - add an exemption to test-patch for build-only changes.
  • [HBASE-13241] - Add tests for group level grants
  • [HBASE-13247] - Change BufferedMutatorExample to use addColumn() since add() is deprecated
  • [HBASE-13251] - Correct 'HBase, MapReduce, and the CLASSPATH' section in HBase Ref Guide
  • [HBASE-13255] - Bad grammar in RegionServer status page
  • [HBASE-13256] - HBaseConfiguration#checkDefaultsVersion(Configuration) has spelling error
  • [HBASE-13270] - Setter for Result#getStats is #addResults; confusing!
  • [HBASE-13271] - Table#puts(List<Put>) operation is indeterminate; needs fixing
  • [HBASE-13286] - Minimum timeout for a rpc call could be 1 ms instead of 2 seconds
  • [HBASE-13316] - Reduce the downtime on planned moves of regions
  • [HBASE-13322] - Replace explicit HBaseAdmin creation with connection#getAdmin()
  • [HBASE-13334] - FindBugs should create precise report for new bugs introduced
  • [HBASE-13340] - Include LimitedPrivate interfaces in the API compatibility report
  • [HBASE-13341] - Add option to disable filtering on interface annotations for the API compatibility report
  • [HBASE-13342] - Fix incorrect interface annotations
  • [HBASE-13344] - Add enforcer rule that matches our JDK support statement
  • [HBASE-13345] - Fix LocalHBaseCluster so that different region server impl can be used for different slaves
  • [HBASE-13347] - Deprecate FirstKeyValueMatchingQualifiersFilter
  • [HBASE-13348] - Separate the thread number configs for meta server and server operations
  • [HBASE-13350] - Add a debug-warn if we fail HTD checks even if table.sanity.checks is false
  • [HBASE-13351] - Annotate internal MasterRpcServices methods with admin priority
  • [HBASE-13358] - Upgrade VisibilityClient API to accept Connection object.
  • [HBASE-13362] - Set max result size from client only (like scanner caching).
  • [HBASE-13366] - Throw DoNotRetryIOException instead of read only IOException
  • [HBASE-13369] - Expose scanNext stats to region server level
  • [HBASE-13370] - PE tool could give option for using Explicit Column Tracker which leads to seeks
  • [HBASE-13375] - Provide HBase superuser higher priority over other users in the RPC handling
  • [HBASE-13376] - Improvements to Stochastic load balancer
  • [HBASE-13381] - Expand TestSizeFailures to include small scans
  • [HBASE-13419] - Thrift gateway should propagate text from exception causes.
  • [HBASE-13420] - RegionEnvironment.offerExecutionLatency Blocks Threads under Heavy Load
  • [HBASE-13425] - Documentation nit in REST Gateway impersonation section
  • [HBASE-13431] - Allow to skip store file range check based on column family while creating reference files in HRegionFileSystem#splitStoreFile
  • [HBASE-13436] - Include user name in ADE for scans
  • [HBASE-13453] - Master should not bind to region server ports
  • [HBASE-13456] - Improve HFilePrettyPrinter first hbase:meta region processing
  • [HBASE-13500] - Deprecate KVComparator and move to CellComparator
  • [HBASE-13516] - Increase PermSize to 128MB
  • [HBASE-13518] - Typo in hbase.hconnection.meta.lookup.threads.core parameter
  • [HBASE-13525] - Update test-patch to leverage Apache Yetus
  • [HBASE-13530] - Add param for bulkload wait duration in HRegion.
  • [HBASE-13532] - Make UnknownScannerException logging less scary
  • [HBASE-13534] - Change HBase master WebUI to explicitly mention if it is a backup master
  • [HBASE-13550] - [Shell] Support unset of a list of table attributes
  • [HBASE-13552] - ChoreService shutdown message could be more informative
  • [HBASE-13578] - Remove Arrays.asList().subList() from FSHLog.offer()
  • [HBASE-13598] - Make hbase assembly 'attach' to the project
  • [HBASE-13622] - document upgrade rollback
  • [HBASE-13645] - Rename *column methods in MasterObserver to *columnFamily
  • [HBASE-13655] - Deprecate duplicate getCompression methods in HColumnDescriptor
  • [HBASE-13656] - Rename getDeadServers to getDeadServersSize in Admin
  • [HBASE-13670] - [HBase MOB] ExpiredMobFileCleaner tool deletes mob files later for one more day after they are expired
  • [HBASE-13671] - More classes to add to the invoking repository of org.apache.hadoop.hbase.mapreduce.driver
  • [HBASE-13673] - WALProcedureStore procedure is chatty
  • [HBASE-13675] - ProcedureExecutor completion report should be at DEBUG log level
  • [HBASE-13677] - RecoverableZookeeper WARNs on expected events
  • [HBASE-13684] - Allow mlockagent to be used when not starting as root
  • [HBASE-13701] - Consolidate SecureBulkLoadEndpoint into HBase core as default for bulk load
  • [HBASE-13710] - Remove use of Hadoop's ReflectionUtil in favor of our own.
  • [HBASE-13718] - Add a pretty printed table description to the table detail page of HBase's master
  • [HBASE-13725] - [documentation] Pseudo-Distributed Local Install can link to hadoop instructions
  • [HBASE-13742] - buildbot should run link checker over book
  • [HBASE-13745] - Say why a flush was requested in log message
  • [HBASE-13755] - Provide single super user check implementation
  • [HBASE-13761] - Optimize FuzzyRowFilter
  • [HBASE-13780] - Default to 700 for HDFS root dir permissions for secure deployments
  • [HBASE-13816] - Build shaded modules only in release profile
  • [HBASE-13828] - Add group permissions testing coverage to AC.
  • [HBASE-13829] - Add more ThrottleType
  • [HBASE-13844] - Move static helper methods from KeyValue into CellUtils
  • [HBASE-13846] - Run MiniCluster on top of other MiniDfsCluster
  • [HBASE-13848] - Access InfoServer SSL passwords through Credential Provder API
  • [HBASE-13876] - Improving performance of HeapMemoryManager
  • [HBASE-13894] - Avoid visitor alloc each call of ByteBufferArray get/putMultiple()
  • [HBASE-13900] - duplicate methods between ProtobufMagic and ProtobufUtil
  • [HBASE-13902] - Remove Sync RpcClientImpl
  • [HBASE-13914] - Minor improvements to dev-support/publish_hbase_website.sh
  • [HBASE-13917] - Remove string comparison to identify request priority
  • [HBASE-13925] - Use zookeeper multi to clear znodes in ZKProcedureUtil
  • [HBASE-13927] - Allow hbase-daemon.sh to conditionally redirect the log or not
  • [HBASE-13931] - Move Unsafe based operations to UnsafeAccess
  • [HBASE-13943] - Get rid of KeyValue#heapSizeWithoutTags
  • [HBASE-13965] - Stochastic Load Balancer JMX Metrics
  • [HBASE-13980] - Distinguish blockedFlushCount vs unblockedFlushCount when tuning heap memory
  • [HBASE-13985] - Add configuration to skip validating HFile format when bulk loading
  • [HBASE-13996] - Add write sniffing in canary
  • [HBASE-14001] - Optimize write(OutputStream out, boolean withTags) for SizeCachedNoTagsKeyValue
  • [HBASE-14002] - Add --noReplicationSetup option to IntegrationTestReplication
  • [HBASE-14007] - Writing to table through MR should fail upfront if table does not exist/is disabled
  • [HBASE-14015] - Allow setting a richer state value when toString a pv2
  • [HBASE-14027] - Clean up netty dependencies
  • [HBASE-14040] - Small refactoring in BackupHandler
  • [HBASE-14045] - Bumping thrift version to 0.9.2.
  • [HBASE-14047] - Cleanup deprecated APIs from Cell class
  • [HBASE-14058] - Stabilizing default heap memory tuner
  • [HBASE-14068] - How to Release docs should include pointers for making signed tags
  • [HBASE-14078] - improve error message when HMaster can't bind to port
  • [HBASE-14082] - Add replica id to JMX metrics names
  • [HBASE-14097] - Log link to client scan troubleshooting section when scanner exceptions happen.
  • [HBASE-14099] - StoreFile.passesKeyRangeFilter need not create Cells from the Scan's start and stop Row
  • [HBASE-14110] - Add CostFunction for balancing primary region replicas
  • [HBASE-14122] - Client API for determining if server side supports cell level security
  • [HBASE-14148] - Web UI Framable Page
  • [HBASE-14151] - Remove the unnecessary file ProtobufUtil.java.rej which is brought in by merging hbase-11339
  • [HBASE-14152] - Fix the warnings in Checkstyle and FindBugs brought in by merging hbase-11339
  • [HBASE-14164] - Display primary region replicas distribution on table.jsp
  • [HBASE-14165] - The initial size of RWQueueRpcExecutor.queues should be (numWriteQueues + numReadQueues + numScanQueues)
  • [HBASE-14172] - Upgrade existing thrift binding using thrift 0.9.3 compiler.
  • [HBASE-14193] - Remove support for direct upgrade from pre-0.96 versions
  • [HBASE-14194] - Undeprecate methods in ThriftServerRunner.HBaseHandler
  • [HBASE-14203] - remove duplicate code getTableDescriptor in HTable
  • [HBASE-14220] - nightly tests should verify src tgz generates and builds correctly
  • [HBASE-14230] - replace reflection in FSHlog with HdfsDataOutputStream#getCurrentBlockReplication()
  • [HBASE-14247] - Separate the old WALs into different regionserver directories
  • [HBASE-14255] - Simplify Cell creation post 1.0
  • [HBASE-14260] - don't build javadocs for hbase-protocol module
  • [HBASE-14261] - Enhance Chaos Monkey framework by adding zookeeper and datanode fault injections.
  • [HBASE-14266] - RegionServers have a lock contention of Configuration.getProps
  • [HBASE-14268] - Improve KeyLocker
  • [HBASE-14306] - Refine RegionGroupingProvider: fix issues and make it more scalable
  • [HBASE-14309] - Allow load balancer to operate when there is region in transition by adding force flag
  • [HBASE-14314] - Metrics for block cache should take region replicas into account
  • [HBASE-14325] - Add snapshotinfo command to hbase script
  • [HBASE-14332] - Show the table state when we encounter exception while disabling / enabling table
  • [HBASE-14334] - Move Memcached block cache in to it's own optional module.
  • [HBASE-14345] - Consolidate printUsage in IntegrationTestLoadAndVerify
  • [HBASE-14387] - Compaction improvements: Maximum off-peak compaction size
  • [HBASE-14397] - PrefixFilter doesn't filter all remaining rows if the prefix is longer than rowkey being compared
  • [HBASE-14436] - HTableDescriptor#addCoprocessor will always make RegionCoprocessorHost create new Configuration
  • [HBASE-14448] - Refine RegionGroupingProvider Phase-2: remove provider nesting and formalize wal group name
  • [HBASE-14455] - Try to get rid of unused HConnection instance
  • [HBASE-14461] - Cleanup IncreasingToUpperBoundRegionSplitPolicy
  • [HBASE-14467] - Compaction improvements: DefaultCompactor should not compact TTL-expired files
  • [HBASE-14468] - Compaction improvements: FIFO compaction policy
  • [HBASE-14478] - A ThreadPoolExecutor with a LinkedBlockingQueue cannot execute tasks concurrently
  • [HBASE-14490] - [RpcServer] reuse request read buffer
  • [HBASE-14517] - Show regionserver's version in master status page
  • [HBASE-14520] - Optimize the number of calls for tags creation in bulk load
  • [HBASE-14524] - Short-circuit comparison of rows in CellComparator
  • [HBASE-14547] - Add more debug/trace to zk-procedure
  • [HBASE-14548] - Expand how table coprocessor jar and dependency path can be specified
  • [HBASE-14565] - Make ZK connection timeout configurable in MiniZooKeeperCluster
  • [HBASE-14573] - Edit on the ByteBufferedCell javadoc
  • [HBASE-14574] - TableOutputFormat#getRecordWriter javadoc misleads
  • [HBASE-14580] - Make the HBaseMiniCluster compliant with Kerberos
  • [HBASE-14582] - Regionserver status webpage bucketcache list can become huge
  • [HBASE-14586] - Use a maven profile to run Jacoco analysis
  • [HBASE-14587] - Attach a test-sources.jar for hbase-server
  • [HBASE-14588] - Stop accessing test resources from within src folder
  • [HBASE-14643] - Avoid Splits from once again opening a closed reader for fetching the first and last key
  • [HBASE-14665] - Remove deprecated HBaseTestingUtility#createTable methods
  • [HBASE-14666] - Remove deprecated HBaseTestingUtility#deleteTable methods
  • [HBASE-14668] - Remove deprecated HBaseTestCase dependency from TestHFile
  • [HBASE-14669] - remove unused import and fix javadoc
  • [HBASE-14670] - Remove deprecated HBaseTestCase from TestBlocksRead
  • [HBASE-14671] - Remove deprecated HBaseTestCase/Put/Delete apis from TestGetClosestAtOrBefore
  • [HBASE-14672] - Exorcise deprecated Delete#delete* apis
  • [HBASE-14675] - Exorcise deprecated Put#add(...) and replace with Put#addColumn(...)
  • [HBASE-14683] - Batching in buffered mutator is awful when adding lists of mutations.
  • [HBASE-14684] - Try to remove all MiniMapReduceCluster in unit tests
  • [HBASE-14687] - Un-synchronize BufferedMutator
  • [HBASE-14693] - Add client-side metrics for received pushback signals
  • [HBASE-14696] - Support setting allowPartialResults in mapreduce Mappers
  • [HBASE-14700] - Support a "permissive" mode for secure clusters to allow "simple" auth clients
  • [HBASE-14703] - HTable.mutateRow does not collect stats
  • [HBASE-14708] - Use copy on write Map for region location cache
  • [HBASE-14714] - some cleanup to snapshot code
  • [HBASE-14715] - Add javadocs to DelegatingRetryingCallable
  • [HBASE-14719] - Add metric for number of MasterProcWALs
  • [HBASE-14721] - Memstore add cells - Avoid many garbage
  • [HBASE-14731] - Add -DuseMob option to ITBLL
  • [HBASE-14743] - Add metrics around HeapMemoryManager
  • [HBASE-14749] - Make changes to region_mover.rb to use RegionMover Java tool
  • [HBASE-14752] - Add example of using the HBase client in a multi-threaded environment
  • [HBASE-14765] - Remove snappy profile
  • [HBASE-14766] - In WALEntryFilter, cell.getFamily() needs to be replaced with the new low-cost implementation
  • [HBASE-14780] - Integration Tests that run with ChaosMonkey need to specify CFs
  • [HBASE-14790] - Implement a new DFSOutputStream for logging WAL only
  • [HBASE-14795] - Enhance the spark-hbase scan operations
  • [HBASE-14796] - Enhance the Gets in the connector
  • [HBASE-14800] - Expose checkAndMutate via Thrift2
  • [HBASE-14805] - status should show the master in shell
  • [HBASE-14821] - CopyTable should allow overriding more config properties for peer cluster
  • [HBASE-14826] - Small improvement in KVHeap seek() API
  • [HBASE-14829] - Add more checkstyles
  • [HBASE-14859] - Better checkstyle reporting
  • [HBASE-14860] - Improve BoundedByteBufferPool; make lockless
  • [HBASE-14862] - Add support for reporting p90 for histogram metrics
  • [HBASE-14865] - Support passing multiple QOPs to SaslClient/Server via hbase.rpc.protection
  • [HBASE-14866] - VerifyReplication should use peer configuration in peer connection
  • [HBASE-14871] - Allow specifying the base branch for make_patch
  • [HBASE-14881] - Provide a Put API that uses the provided row without coping
  • [HBASE-14882] - Provide a Put API that adds the provided family, qualifier, value without copying
  • [HBASE-14891] - Add log for uncaught exception in RegionServerMetricsWrapperRunnable
  • [HBASE-14906] - Improvements on FlushLargeStoresPolicy
  • [HBASE-14925] - Develop HBase shell command/tool to list table's region info through command line
  • [HBASE-14946] - Don't allow multi's to over run the max result size.
  • [HBASE-14951] - Make hbase.regionserver.maxlogs obsolete
  • [HBASE-14963] - Remove use of Guava Stopwatch from HBase client code
  • [HBASE-14969] - Add throughput controller for flush
  • [HBASE-14976] - Add RPC call queues to the web ui
  • [HBASE-14978] - Don't allow Multi to retain too many blocks
  • [HBASE-14983] - Create metrics for per block type hit/miss ratios
  • [HBASE-14984] - Allow memcached block cache to set optimze to false
  • [HBASE-14985] - TimeRange constructors should set allTime when appropriate
  • [HBASE-14996] - Some more API cleanup for 2.0
  • [HBASE-15005] - Use value array in computing block length for 1.2 and 1.3
  • [HBASE-15038] - ExportSnapshot should support separate configurations for source and destination clusters
  • [HBASE-15044] - Region normalization should be allowed when underlying namespace has quota
  • [HBASE-15060] - Cull TestHFileWriterV2 and HFileWriterFactory
  • [HBASE-15062] - IntegrationTestMTTR conditionally run some tests
  • [HBASE-15066] - Small improvements to Canary tool
  • [HBASE-15068] - Add metrics for region normalization plans
  • [HBASE-15076] - Add getScanner(Scan scan, List<KeyValueScanner> additionalScanners) API into Region interface
  • [HBASE-15111] - "hbase version" should write to stdout
  • [HBASE-15119] - Include git SHA in check_compatibility reports
  • [HBASE-15123] - Remove duplicate code in LocalHBaseCluster and minor formatting
  • [HBASE-15129] - Set default value for hbase.fs.tmp.dir rather than fully depend on hbase-default.xml
  • [HBASE-15177] - Reduce garbage created under high load
  • [HBASE-15191] - CopyTable and VerifyReplication - Option to specify batch size, versions
  • [HBASE-15197] - Expose filtered read requests metric to metrics framework and Web UI
  • [HBASE-15201] - Add hbase-spark to hbase assembly
  • [HBASE-15211] - Don't run the CatalogJanitor if there are regions in transition
  • [HBASE-15212] - RPCServer should enforce max request size
  • [HBASE-15219] - Canary tool does not return non-zero exit code when one of regions is in stuck state
  • [HBASE-15222] - Use less contended classes for metrics
  • [HBASE-15223] - Make convertScanToString public for Spark
  • [HBASE-15229] - Canary Tools should not call System.Exit on error
  • [HBASE-15243] - Utilize the lowest seek value when all Filters in MUST_PASS_ONE FilterList return SEEK_NEXT_USING_HINT
  • [HBASE-15296] - Break out writer and reader from StoreFile
  • [HBASE-15300] - Upgrade to zookeeper 3.4.8
  • [HBASE-15301] - Remove the never-thrown NamingException from TableInputFormatBase#reverseDNS method signature
  • [HBASE-15306] - Make RPC call queue length dynamically configurable
  • [HBASE-15312] - Update the dependences of pom for mini cluster in HBase Book
  • [HBASE-15315] - Remove always set super user call as high priority
  • [HBASE-15338] - Add a option to disable the data block cache for testing the performance of underlying file system
  • [HBASE-15339] - Improve DateTieredCompactionPolicy
  • [HBASE-15349] - Update surefire version to 2.19.1
  • [HBASE-15353] - Add metric for number of CallQueueTooBigExceptions
  • [HBASE-15356] - Remove unused Imports
  • [HBASE-15391] - Avoid too large "deleted from META" info log
  • [HBASE-15396] - Enhance mapreduce.TableSplit to add encoded region name
  • [HBASE-15410] - Utilize the max seek value when all Filters in MUST_PASS_ALL FilterList return SEEK_NEXT_USING_HINT
  • [HBASE-15413] - Procedure-V2: print out ProcedureInfo during trace
  • [HBASE-15415] - Improve Master WebUI snapshot information
  • [HBASE-15429] - Add a split policy for busy regions
  • [HBASE-15447] - Improve javadocs description for Delete methods
  • [HBASE-15451] - Remove unnecessary wait in MVCC
  • [HBASE-15456] - CreateTableProcedure/ModifyTableProcedure needs to fail when there is no family in table descriptor
  • [HBASE-15466] - precommit should not run all java goals when given a docs-only patch
  • [HBASE-15470] - Add a setting for Priority queue length
  • [HBASE-15471] - Add num calls in priority and general queue to RS UI
  • [HBASE-15475] - Allow TimestampsFilter to provide a seek hint
  • [HBASE-15478] - add comments to FSHLog explaining why syncRunnerIndex won't overflow
  • [HBASE-15482] - Provide an option to skip calculating block locations for SnapshotInputFormat
  • [HBASE-15486] - Avoid multiple disable/enable balancer calls while running rolling-restart.sh --graceful
  • [HBASE-15496] - Throw RowTooBigException only for user scan/get
  • [HBASE-15507] - Online modification of enabled ReplicationPeerConfig
  • [HBASE-15508] - Add command for exporting snapshot in hbase command script
  • [HBASE-15511] - ClusterStatus should be able to return responses by scope
  • [HBASE-15526] - Make SnapshotManager accessible through MasterServices
  • [HBASE-15529] - Override needBalance in StochasticLoadBalancer
  • [HBASE-15551] - Make call queue too big exception use servername
  • [HBASE-15569] - Make Bytes.toStringBinary faster
  • [HBASE-15571] - Make MasterProcedureManagerHost accessible through MasterServices
  • [HBASE-15586] - Unify human readable numbers in the web UI
  • [HBASE-15593] - Time limit of scanning should be offered by client
  • [HBASE-15600] - Add provision for adding mutations to memstore or able to write to same region in batchMutate coprocessor hooks
  • [HBASE-15605] - Remove PB references from HCD and HTD for 2.0
  • [HBASE-15606] - Limit creating zk connection in HBaseAdmin#getCompactionState() only to case when 'hbase:meta' is checked.
  • [HBASE-15607] - Remove PB references from Admin for 2.0
  • [HBASE-15608] - Remove PB references from SnapShot related Exceptions
  • [HBASE-15609] - Remove PB references from Result, DoubleColumnInterpreter and any such public facing class for 2.0
  • [HBASE-15610] - Remove deprecated HConnection for 2.0 thus removing all PB references for 2.0
  • [HBASE-15612] - Minor improvements to CellCounter and RowCounter documentation
  • [HBASE-15614] - Report metrics from JvmPauseMonitor
  • [HBASE-15632] - Undo the checking of lastStoreFlushTimeMap.isEmpty() introduced in HBASE-13145
  • [HBASE-15641] - Shell "alter" should do a single modifyTable operation
  • [HBASE-15667] - Add more clarity to Reference Guide related to importing Eclipse Formatter
  • [HBASE-15680] - Examples in shell help message for TIMERANGE scanner specifications should use milliseconds instead of seconds
  • [HBASE-15686] - Add override mechanism for the exempt classes when dynamically loading table coprocessor
  • [HBASE-15688] - Use MasterServices directly instead of casting to HMaster when possible
  • [HBASE-15706] - HFilePrettyPrinter should print out nicely formatted tags
  • [HBASE-15720] - Print row locks at the debug dump page
  • [HBASE-15727] - Canary Tool for Zookeeper
  • [HBASE-15744] - Port over small format/text improvements from HBASE-13784
  • [HBASE-15745] - Refactor RPC classes to better accept async changes.
  • [HBASE-15756] - Pluggable RpcServer
  • [HBASE-15759] - RegionObserver.preStoreScannerOpen() doesn't have acces to current readpoint
  • [HBASE-15767] - Upgrade httpclient dependency
  • [HBASE-15768] - fix capitalization of ZooKeeper usage
  • [HBASE-15773] - CellCounter improvements
  • [HBASE-15791] - Improve javadoc in ScheduledChore
  • [HBASE-15793] - Port over AsyncCall improvements
  • [HBASE-15794] - Fix Findbugs instanceof always true issue in MultiServerCallable
  • [HBASE-15795] - Cleanup all classes in package org.apache.hadoop.hbase.ipc for code style
  • [HBASE-15802] - ConnectionUtils should use ThreadLocalRandom instead of Random
  • [HBASE-15808] - Reduce potential bulk load intermediate space usage and waste
  • [HBASE-15816] - Provide client with ability to set priority on Operations
  • [HBASE-15837] - Memstore size accounting is wrong if postBatchMutate() throws exception
  • [HBASE-15842] - SnapshotInfo should display ownership information
  • [HBASE-15843] - Replace RegionState.getRegionInTransition() Map with a Set
  • [HBASE-15849] - Shell Cleanup: Simplify handling of commands' runtime
  • [HBASE-15854] - Log the cause of SASL connection failures
  • [HBASE-15864] - Reuse the testing helper to wait regions in transition
  • [HBASE-15870] - Specify columns in REST multi gets
  • [HBASE-15882] - Upgrade to yetus precommit 0.3.0
  • [HBASE-15890] - Allow thrift to set/unset "cacheBlocks" for Scans
  • [HBASE-15910] - Update hbase ref guide to explain submit-patch.py
  • [HBASE-15921] - Add first AsyncTable impl and create TableImpl based on it
  • [HBASE-15924] - Enhance hbase services autorestart capability to hbase-daemon.sh
  • [HBASE-15931] - Add log for long-running tasks in AsyncProcess
  • [HBASE-15941] - HBCK repair should not unsplit healthy splitted region
  • [HBASE-15949] - Cleanup TestRegionServerMetrics
  • [HBASE-15981] - Stripe and Date-tiered compactions inaccurately suggest disabling table in docs
  • [HBASE-16004] - Update to Netty 4.1.1
  • [HBASE-16008] - A robust way deal with early termination of HBCK
  • [HBASE-16010] - Put draining function through Admin API
  • [HBASE-16018] - Better documentation of ReplicationPeers
  • [HBASE-16026] - Master UI should display status of additional ZK switches
  • [HBASE-16033] - Add more details in logging of responseTooSlow/TooLarge
  • [HBASE-16042] - Add support in PE tool for InMemory Compaction
  • [HBASE-16048] - Tag InternalScanner with LimitedPrivate(HBaseInterfaceAudience.COPROC)
  • [HBASE-16052] - Improve HBaseFsck Scalability
  • [HBASE-16085] - Add on metric for failed compactions
  • [HBASE-16086] - TableCfWALEntryFilter and ScopeWALEntryFilter should not redundantly iterate over cells.
  • [HBASE-16087] - Replication shouldn't start on a master if if only hosts system tables
  • [HBASE-16089] - Add on FastPath for CoDel
  • [HBASE-16108] - RowCounter should support multiple key ranges
  • [HBASE-16114] - Get regionLocation of required regions only for MR jobs
  • [HBASE-16116] - Remove redundant pattern *.iml
  • [HBASE-16124] - Make check_compatibility.sh less verbose when building HBase
  • [HBASE-16130] - Add comments to ProcedureStoreTracker
  • [HBASE-16139] - Use CellUtil instead of KeyValueUtil in Import
  • [HBASE-16140] - bump owasp.esapi from 2.1.0 to 2.1.0.1
  • [HBASE-16147] - Shell command for getting compaction state
  • [HBASE-16149] - Log the underlying RPC exception in RpcRetryingCallerImpl
  • [HBASE-16188] - Add EventCounter information to log4j properties file
  • [HBASE-16196] - Update jruby to a newer version.
  • [HBASE-16220] - Demote log level for "HRegionFileSystem - No StoreFiles for" messages to TRACE
  • [HBASE-16224] - Reduce the number of RPCs for the large PUTs
  • [HBASE-16225] - Refactor ScanQueryMatcher
  • [HBASE-16231] - Integration tests should support client keytab login for secure clusters
  • [HBASE-16241] - Allow specification of annotations to use when running check_compatibility.sh
  • [HBASE-16256] - Purpose of EnvironmentEdge, EnvironmentEdgeManager
  • [HBASE-16266] - Do not throw ScannerTimeoutException when catch UnknownScannerException
  • [HBASE-16275] - Change ServerManager#onlineServers from ConcurrentHashMap to ConcurrentSkipListMap
  • [HBASE-16287] - LruBlockCache size should not exceed acceptableSize too many
  • [HBASE-16299] - Update REST API scanner with ability to do reverse scan
  • [HBASE-16302] - age of last shipped op and age of last applied op should be histograms
  • [HBASE-16312] - update jquery version
  • [HBASE-16348] - update jcoding and joni versions
  • [HBASE-16351] - do dependency license check via enforcer plugin
  • [HBASE-16379] - [replication] Minor improvement to replication/copy_tables_desc.rb
  • [HBASE-16381] - Shell deleteall command should support row key prefixes
  • [HBASE-16385] - Have hbase-rest pull hbase.rest.port from Constants.java
  • [HBASE-16399] - Provide an API to get list of failed regions and servername in Canary
  • [HBASE-16414] - Improve performance for RPC encryption with Apache Common Crypto
  • [HBASE-16419] - check REPLICATION_SCOPE's value more stringently
  • [HBASE-16422] - Tighten our guarantees on compatibility across patch versions
  • [HBASE-16423] - Add re-compare option to VerifyReplication to avoid occasional inconsistent rows
  • [HBASE-16434] - Improve flaky dashboard
  • [HBASE-16448] - Custom metrics for custom replication endpoints
  • [HBASE-16450] - Shell tool to dump replication queues
  • [HBASE-16455] - Provide API for obtaining all the WAL files
  • [HBASE-16466] - HBase snapshots support in VerifyReplication tool to reduce load on live HBase cluster with large tables
  • [HBASE-16469] - Several log refactoring/improvement suggestions
  • [HBASE-16486] - Unify system table creation using the same createSystemTable API.
  • [HBASE-16502] - Reduce garbage in BufferedDataBlockEncoder
  • [HBASE-16506] - Use subprocedure of Proc V2 for snapshot in BackupProcedure
  • [HBASE-16508] - Move UnexpectedStateException to common
  • [HBASE-16509] - Add option to LoadIncrementalHFiles which allows skipping unmatched column families
  • [HBASE-16541] - Avoid unnecessary cell copy in Result#compareResults
  • [HBASE-16561] - Add metrics about read/write/scan queue length and active read/write/scan handler count
  • [HBASE-16562] - ITBLL should fail to start if misconfigured
  • [HBASE-16574] - Add backup / restore feature to refguide
  • [HBASE-16585] - Rewrite the delegation token tests with Parameterized pattern
  • [HBASE-16598] - Enable zookeeper useMulti always and clean up in HBase code
  • [HBASE-16616] - Rpc handlers stuck on ThreadLocalMap.expungeStaleEntry
  • [HBASE-16640] - TimeoutBlockingQueue#remove() should return whether the entry is removed
  • [HBASE-16646] - Enhance LoadIncrementalHFiles API to accept store file paths as input
  • [HBASE-16657] - Expose per-region last major compaction timestamp in RegionServer UI
  • [HBASE-16658] - Optimize UTF8 string/byte conversions
  • [HBASE-16659] - Use CellUtil.createFirstOnRow instead of KeyValueUtil.createFirstOnRow in some places.
  • [HBASE-16661] - Add last major compaction age to per-region metrics
  • [HBASE-16666] - Add append and remove peer namespaces cmds for replication
  • [HBASE-16667] - Building with JDK 8: ignoring option MaxPermSize=256m
  • [HBASE-16672] - Add option for bulk load to always copy hfile(s) instead of renaming
  • [HBASE-16680] - Reduce garbage in BufferChain
  • [HBASE-16690] - Move znode path configs to a separated class
  • [HBASE-16691] - Optimize KeyOnlyFilter by utilizing KeyOnlyCell
  • [HBASE-16692] - Make ByteBufferUtils#equals safer and correct
  • [HBASE-16694] - Reduce garbage for onDiskChecksum in HFileBlock
  • [HBASE-16698] - Performance issue: handlers stuck waiting for CountDownLatch inside WALKey#getWriteEntry under high writing workload
  • [HBASE-16700] - Allow for coprocessor whitelisting
  • [HBASE-16705] - Eliminate long to Long auto boxing in LongComparator
  • [HBASE-16708] - Expose endpoint Coprocessor name in "responseTooSlow" log messages
  • [HBASE-16714] - Procedure V2 - use base class to remove duplicate set up test code in table DDL procedures
  • [HBASE-16720] - Sort build ids in flaky dashboard
  • [HBASE-16730] - Exclude junit as a transitive dependency from hadoop-common
  • [HBASE-16734] - add hadoop 3.0.0-alpha1 to post commit checks
  • [HBASE-16772] - Add verbose option to VerifyReplication for logging good rows
  • [HBASE-16773] - AccessController should access local region if possible
  • [HBASE-16774] - [shell] Add coverage to TestShell when ZooKeeper is not reachable
  • [HBASE-16783] - Use ByteBufferPool for the header and message during Rpc response
  • [HBASE-16784] - Make use of ExtendedCell#write(OutputStream os) for the default HFileWriter#append()
  • [HBASE-16792] - Reuse KeyValue.KeyOnlyKeyValue in BufferedDataBlockEncoder.SeekerState
  • [HBASE-16809] - Save one cell length calculation in HeapMemStoreLAB#copyCellInto
  • [HBASE-16818] - Avoid multiple copies of binary data during the conversion from Result to Row
  • [HBASE-16821] - Enhance LoadIncrementalHFiles API to convey missing hfiles if any
  • [HBASE-16840] - Reuse cell's timestamp and type in ScanQueryMatcher
  • [HBASE-16844] - Procedure V2: DispatchMergingRegionsProcedure to use base class StateMachineProcedure for abort and rollback
  • [HBASE-16854] - Refactor the org.apache.hadoop.hbase.client.Action
  • [HBASE-16868] - Add a replicate_all flag to avoid misuse the namespaces and table-cfs config of replication peer
  • [HBASE-16888] - Avoid unnecessary tags copy in Append
  • [HBASE-16893] - Use Collection.removeIf instead of Iterator.remove in DependentColumnFilter
  • [HBASE-16894] - Create more than 1 split per region, generalize HBASE-12590
  • [HBASE-16946] - Provide Raw scan as an option in VerifyReplication
  • [HBASE-16947] - Some improvements for DumpReplicationQueues tool
  • [HBASE-16950] - Print raw stats in the end of procedure performance tools for parsing results from scripts
  • [HBASE-16969] - RegionCoprocessorServiceExec should override the toString() for debugging
  • [HBASE-16972] - Log more details for Scan#next request when responseTooSlow
  • [HBASE-16977] - VerifyReplication should log a printable representation of the row keys
  • [HBASE-17004] - Refactor IntegrationTestManyRegions to use @ClassRule for timing out
  • [HBASE-17005] - Improve log message in MobFileCache
  • [HBASE-17006] - Add names to threads for better debugability of thread dumps
  • [HBASE-17013] - Add constructor to RowMutations for initializing the capacity of internal list
  • [HBASE-17014] - Add clearly marked starting and shutdown log messages for all services.
  • [HBASE-17026] - VerifyReplication log should distinguish whether good row key is result of revalidation
  • [HBASE-17034] - avoid unnecessary Get copy in HTable#exist
  • [HBASE-17037] - Enhance LoadIncrementalHFiles API to convey loaded files
  • [HBASE-17047] - Add an API to get HBase connection cache statistics
  • [HBASE-17057] - Minor compactions should also drop page cache behind reads
  • [HBASE-17063] - Cleanup TestHRegion : remove duplicate variables for method name and two unused params in initRegion
  • [HBASE-17064] - Add TaskMonitor#getTasks() variant which accepts type selection
  • [HBASE-17065] - Perform more effective sorting for RPC Handler Tasks
  • [HBASE-17077] - Don't copy the replication queue belonging to the peer which has been deleted
  • [HBASE-17083] - Enable hedged reads by default in hbase-2.0.0
  • [HBASE-17086] - Add comments to explain why Cell#getTagsLength() returns an int, rather than a short
  • [HBASE-17088] - Refactor RWQueueRpcExecutor/BalancedQueueRpcExecutor/RpcExecutor
  • [HBASE-17110] - Improve SimpleLoadBalancer to always take server-level balance into account
  • [HBASE-17123] - Add postBulkLoadHFile variant that notifies the final paths for the hfiles
  • [HBASE-17126] - Expose KeyValue#checkParameters() and checkForTagsLength() to be used by other Cell implementations
  • [HBASE-17129] - Remove public from methods in DataType interface
  • [HBASE-17157] - Increase the default mergeable threshold for mob compaction
  • [HBASE-17161] - MOB : Make ref cell creation more efficient
  • [HBASE-17165] - Add retry to LoadIncrementalHFiles tool
  • [HBASE-17172] - Optimize mob compaction with _del files
  • [HBASE-17176] - Reuse the builder in RequestConverter
  • [HBASE-17178] - Add region balance throttling
  • [HBASE-17184] - Code cleanup of LruBlockCache
  • [HBASE-17191] - Make use of UnsafeByteOperations#unsafeWrap(ByteBuffer buffer) in PBUtil#toCell(Cell cell)
  • [HBASE-17194] - Assign the new region to the idle server after splitting
  • [HBASE-17205] - Add a metric for the duration of region in transition
  • [HBASE-17207] - Arrays.asList() with too few arguments
  • [HBASE-17211] - Add more details in log when UnknownScannerException thrown in ScannerCallable
  • [HBASE-17212] - Should add null checker on table name in HTable constructor and RegionServerCallable
  • [HBASE-17215] - Separate small/large file delete threads in HFileCleaner to accelerate archived hfile cleanup speed
  • [HBASE-17216] - A Few Fields Can Be Safely Made Static
  • [HBASE-17221] - Abstract out an interface for RpcServer.Call
  • [HBASE-17232] - Replace HashSet with ArrayList to accumulate delayed scanners in KVHeap and StoreScanner.
  • [HBASE-17235] - Improvement in creation of CIS for onheap buffer cases
  • [HBASE-17239] - Add UnsafeByteOperations#wrap(ByteInput, int offset, int len) API
  • [HBASE-17241] - Avoid compacting already compacted mob files with _del files
  • [HBASE-17243] - Reuse CompactionPartitionId and avoid creating MobFileName in PartitionedMobCompactor to avoid unnecessary new objects
  • [HBASE-17245] - Replace HTableDescriptor#htd.getColumnFamilies().length with a low-cost implementation
  • [HBASE-17249] - Get/Scan's setTimeRange/setColumnFamilyTimeRange can take the TimeRange reference as the parameter instead of creating a new setColumnFamilyTimeRange instance
  • [HBASE-17276] - Reduce log spam from WrongRegionException in large multi()'s
  • [HBASE-17280] - Add mechanism to control hbase cleaner behavior
  • [HBASE-17291] - Remove ImmutableSegment#getKeyValueScanner
  • [HBASE-17292] - Add observer notification before bulk loaded hfile is moved to region directory
  • [HBASE-17296] - Provide per peer throttling for replication
  • [HBASE-17298] - remove unused code in HRegion#doMiniBatchMutation
  • [HBASE-17314] - Limit total buffered size for all replication sources
  • [HBASE-17318] - Increment does not add new column if the increment amount is zero at first time writing
  • [HBASE-17331] - Avoid busy waiting in ThrottledInputStream
  • [HBASE-17332] - Replace HashMap to Array for DataBlockEncoding.idToEncoding
  • [HBASE-17343] - Make Compacting Memstore default in 2.0 with BASIC as the default type
  • [HBASE-17348] - Remove the unused hbase.replication from javadoc/comment/book completely
  • [HBASE-17404] - Replace explicit type with diamond operator in hbase-annotations
  • [HBASE-17408] - Introduce per request limit by number of mutations
  • [HBASE-17425] - Fix calls to deprecated APIs in TestUpdateConfiguration
  • [HBASE-17437] - Support specifying a WAL directory outside of the root directory
  • [HBASE-17448] - Export metrics from RecoverableZooKeeper
  • [HBASE-17449] - Add explicit document on different timeout settings
  • [HBASE-17462] - Use sliding window for read/write request costs in StochasticLoadBalancer
  • [HBASE-17472] - Correct the semantic of permission grant
  • [HBASE-17488] - WALEdit should be lazily instantiated
  • [HBASE-17505] - Do not issue close scanner request if RS tells us there is no more results for this region
  • [HBASE-17514] - Warn when Thrift Server 1 is configured for proxy users but not the HTTP transport
  • [HBASE-17515] - Reduce memory footprint of RegionLoads kept by StochasticLoadBalancer
  • [HBASE-17532] - Replace explicit type with diamond operator
  • [HBASE-17543] - Create additional ReplicationEndpoint WALEntryFilters by configuration
  • [HBASE-17552] - Update developer section in hbase book
  • [HBASE-17555] - Change calls to deprecated getHBaseAdmin to getAdmin
  • [HBASE-17563] - Foreach and switch in RootDocProcessor and StabilityOptions
  • [HBASE-17569] - HBase-Procedure module need to support mvn clean test -PskipProcedureTests to skip unit test
  • [HBASE-17588] - Remove unused imports brought in by HBASE-17437
  • [HBASE-17591] - Update documentation to say distributed log replay defaults to 'false'
  • [HBASE-17592] - Fix typo in IPCUtil and RpcConnection
  • [HBASE-17605] - Refactor procedure framework code
  • [HBASE-17613] - avoid copy of family when initializing the FSWALEntry
  • [HBASE-17623] - Reuse the bytes array when building the hfile block
  • [HBASE-17627] - Active workers metric for thrift
  • [HBASE-17634] - Clean up the usage of Result.isPartial
  • [HBASE-17637] - Update progress more frequently in IntegrationTestBigLinkedList.Generator.persist
  • [HBASE-17654] - RSGroup code refactoring
  • [HBASE-17676] - Get class name once for all in AbstractFSWAL
  • [HBASE-17689] - Add support for table.existsAll in thrift2 THBaseservice
  • [HBASE-17690] - Clean up MOB code
  • [HBASE-17716] - Formalize Scan Metric names
  • [HBASE-17731] - Fractional latency reporting in MultiThreadedAction
  • [HBASE-17732] - Coprocessor Design Improvements
  • [HBASE-17734] - Guard against possibly copying the qualifier in the ScanDeleteTracker
  • [HBASE-17747] - Support both weak and soft object pool
  • [HBASE-17777] - TestMemstoreLAB#testLABThreading runs too long for a small test
  • [HBASE-17778] - Remove the testing code in the AsyncRequestFutureImpl
  • [HBASE-17815] - Remove the unused field in PrefixTreeSeeker
  • [HBASE-17817] - Make Regionservers log which tables it removed coprocessors from when aborting
  • [HBASE-17823] - Migrate to Apache Yetus Audience Annotations
  • [HBASE-17826] - Backup: submit M/R job to a particular Yarn queue
  • [HBASE-17831] - Support small scan in thrift2
  • [HBASE-17835] - Spelling mistakes in the Java source
  • [HBASE-17836] - CellUtil#estimatedSerializedSizeOf is slow when input is ByteBufferCell
  • [HBASE-17854] - Use StealJobQueue in HFileCleaner after HBASE-17215
  • [HBASE-17875] - Document why objects over 10MB are not well-suited for hbase
  • [HBASE-17877] - Improve HBase's byte[] comparator
  • [HBASE-17888] - Add generic methods for updating metrics on start and end of a procedure execution
  • [HBASE-17910] - Use separated StoreFileReader for streaming read
  • [HBASE-17912] - Avoid major compactions on region server startup
  • [HBASE-17924] - Consider sorting the row order when processing multi() ops before taking rowlocks
  • [HBASE-17944] - Removed unused JDK version parsing from ClassSize.
  • [HBASE-17956] - Raw scan should ignore TTL
  • [HBASE-17959] - Canary timeout should be configurable on a per-table basis
  • [HBASE-17962] - Improve documentation on Rest interface
  • [HBASE-17973] - Create shell command to identify regions with poor locality
  • [HBASE-17979] - HBase Shell 'list' Command Help Doc Improvements
  • [HBASE-17990] - Refactor TestFSUtils to use Before
  • [HBASE-17995] - improve log messages during snapshot related tests
  • [HBASE-18001] - Extend the "count" shell command to support specified conditions
  • [HBASE-18004] - getRegionLocations needs to be called once in ScannerCallableWithReplicas#call()
  • [HBASE-18007] - Clean up rest module code
  • [HBASE-18011] - Refactor RpcServer
  • [HBASE-18015] - Storage class aware block placement for procedure v2 WALs
  • [HBASE-18017] - Reduce frequency of setStoragePolicy failure warnings
  • [HBASE-18019] - Close redundant memstore scanners
  • [HBASE-18020] - Update API Compliance Checker to Incorporate Improvements Done in Hadoop
  • [HBASE-18021] - Add more info in timed out RetriesExhaustedException for read replica client get processing,
  • [HBASE-18022] - Refine the error message issued with TableNotFoundException when expected table is not the same as the one fetched from meta
  • [HBASE-18023] - Log multi-* requests for more than threshold number of rows
  • [HBASE-18033] - Update supplemental models for new deps in Hadoop trunk
  • [HBASE-18041] - Add pylintrc file to HBase
  • [HBASE-18043] - Institute a hard limit for individual cell size that cannot be overridden by clients
  • [HBASE-18067] - Support a default converter for data read shell commands
  • [HBASE-18075] - Support namespaces and tables with non-latin alphabetical characters
  • [HBASE-18083] - Make large/small file clean thread number configurable in HFileCleaner
  • [HBASE-18090] - Improve TableSnapshotInputFormat to allow more multiple mappers per region
  • [HBASE-18094] - Display the return value of the command append
  • [HBASE-18101] - Fix type mismatch on container access in QuotaCache#chore
  • [HBASE-18164] - Much faster locality cost function and candidate generator
  • [HBASE-18169] - Coprocessor fix and cleanup before 2.0.0 release
  • [HBASE-18224] - Upgrade jetty
  • [HBASE-18248] - Warn if monitored RPC task has been tied up beyond a configurable threshold
  • [HBASE-18251] - Remove unnecessary traversing to the first and last keys in the CellSet
  • [HBASE-18252] - Resolve BaseLoadBalancer bad practice warnings
  • [HBASE-18261] - [AMv2] Create new RecoverMetaProcedure and use it from ServerCrashProcedure and HMaster.finishActiveMasterInitialization()
  • [HBASE-18275] - Formatting and grammar mistakes in schemadoc chapter
  • [HBASE-18281] - Performance update in StoreFileWriter.java for string replacement
  • [HBASE-18286] - Create static empty byte array to save memory
  • [HBASE-18294] - Reduce global heap pressure: flush based on heap occupancy
  • [HBASE-18303] - Clean up some parameterized test declarations
  • [HBASE-18307] - Share the same EventLoopGroup for NettyRpcServer, NettyRpcClient and AsyncFSWALProvider at RS side
  • [HBASE-18309] - Support multi threads in CleanerChore
  • [HBASE-18332] - Upgrade asciidoctor-maven-plugin
  • [HBASE-18339] - Update test-patch to use hadoop 3.0.0-alpha4
  • [HBASE-18374] - RegionServer Metrics improvements
  • [HBASE-18387] - [Thrift] Make principal configurable in DemoClient.java
  • [HBASE-18389] - Remove byte[] from formal parameter of sizeOf() of ClassSize, ClassSize.MemoryLayout and ClassSize.UnsafeLayout
  • [HBASE-18402] - Thrift2 should support DeleteFamilyVersion type
  • [HBASE-18412] - [Shell] Support unset of list of configuration for a table
  • [HBASE-18426] - nightly job should use independent stages to check supported jdks
  • [HBASE-18434] - Address some alerts raised by lgtm.com
  • [HBASE-18436] - Add client-side hedged read metrics
  • [HBASE-18467] - nightly job needs to run all stages and then comment on jira
  • [HBASE-18469] - Correct RegionServer metric of totalRequestCount
  • [HBASE-18478] - Allow users to remove RegionFinder from LoadBalancer calculations if no locality possible
  • [HBASE-18485] - Performance issue: ClientAsyncPrefetchScanner is slower than ClientSimpleScanner
  • [HBASE-18500] - Performance issue: Don't use BufferedMutator for HTable's put method
  • [HBASE-18504] - Add documentation for WAL compression
  • [HBASE-18519] - Use builder pattern to create cell
  • [HBASE-18520] - Add jmx value to determine true Master Start time
  • [HBASE-18522] - Add RowMutations support to Batch
  • [HBASE-18532] - Improve cache related stats rendered on RS UI
  • [HBASE-18533] - Expose BucketCache values to be configured
  • [HBASE-18548] - Move sources of important Jenkins jobs into source control
  • [HBASE-18555] - Remove redundant familyMap.put() from addxxx() of sub-classes of Mutation and Query
  • [HBASE-18559] - Add histogram to MetricsConnection to track concurrent calls per server
  • [HBASE-18566] - [RSGROUP]Log the client IP/port of the rsgroup admin
  • [HBASE-18573] - Update Append and Delete to use Mutation#getCellList(family)
  • [HBASE-18581] - Remove dead code and some tidy up in BaseLoadBalancer
  • [HBASE-18601] - Update Htrace to 4.2
  • [HBASE-18602] - rsgroup cleanup unassign code
  • [HBASE-18609] - Apply ClusterStatus#getClusterStatus(EnumSet<Option>) in code base
  • [HBASE-18621] - Refactor ClusterOptions before applying to code base
  • [HBASE-18629] - Enhance ChaosMonkeyRunner with interruptibility
  • [HBASE-18631] - Allow configuration of ChaosMonkey properties via hbase-site
  • [HBASE-18649] - Deprecate KV Usage in MR to move to Cells in 3.0
  • [HBASE-18651] - Let ChaosMonkeyRunner expose the chaos monkey runner it creates
  • [HBASE-18652] - Expose individual cache stats in a CombinedCache through JMX
  • [HBASE-18662] - The default values for many configuration items in the code are not consistent with hbase-default.xml
  • [HBASE-18673] - Some more unwanted reference to unshaded PB classes
  • [HBASE-18674] - upgrade hbase to commons-lang3
  • [HBASE-18675] - Making {max,min}SessionTimeout configurable for MiniZooKeeperCluster
  • [HBASE-18677] - typo in namespace docs
  • [HBASE-18683] - Upgrade hbase to commons-math 3
  • [HBASE-18699] - Copy LoadIncrementalHFiles to another package and mark the old one as deprecated
  • [HBASE-18701] - Optimize reference guide to use cell acl conveniently
  • [HBASE-18704] - Upgrade hbase to commons-collections 4
  • [HBASE-18737] - Display configured max size of memstore and cache on RS UI
  • [HBASE-18740] - Upgrade Zookeeper version to 3.4.10
  • [HBASE-18746] - Throw exception with job.getStatus().getFailureInfo() when ExportSnapshot fails
  • [HBASE-18772] - [JDK8] Replace AtomicLong with LongAdder
  • [HBASE-18778] - Use Comparator for StealJobQueue
  • [HBASE-18784] - Use of filesystem that requires hflush / hsync / append / etc should query outputstream capabilities
  • [HBASE-18795] - Expose KeyValue.getBuffer() for tests alone
  • [HBASE-18806] - VerifyRep by snapshot need not to restore snapshot for each mapper
  • [HBASE-18814] - Make ScanMetrics enabled and add counter <HBase Counters, ROWS_SCANNED> into the MapReduce Job over snapshot
  • [HBASE-18824] - Add meaningful comment to HConstants.LATEST_TIMESTAMP to explain why it is MAX_VALUE
  • [HBASE-18843] - Add DistCp support to incremental backup with bulk loading
  • [HBASE-18849] - expand "thirdparty" reference to give examples of setting netty location in common testing modules
  • [HBASE-18870] - Hbase Backup should set the details to MR job name
  • [HBASE-18883] - Upgrade to Curator 4.0
  • [HBASE-18884] - Coprocessor Design Improvements follow up of HBASE-17732
  • [HBASE-18899] - Make Fileinfo more readable in HFilePrettyPrinter
  • [HBASE-18925] - Need updated mockito for using java optional
  • [HBASE-18929] - Hbase backup command doesn’t show debug option to enable backup in debug mode
  • [HBASE-18986] - Remove unnecessary null check after CellUtil.cloneQualifier()
  • [HBASE-18994] - Decide if META/System tables should use Compacting Memstore or Default Memstore
  • [HBASE-19027] - Honor the CellComparator of ScanInfo in scanning over a store
  • [HBASE-19051] - Add new split algorithm for num string
  • [HBASE-19091] - Code annotation wrote "BinaryComparator" instead of "LongComparator"
  • [HBASE-19110] - Add default for Server#isStopping & #getFileSystem
  • [HBASE-19139] - Create Async Admin methods for Clear Block Cache
  • [HBASE-19140] - hbase-cleanup.sh uses deprecated call to remove files in hdfs
  • [HBASE-19180] - Remove unused imports from AlwaysPasses
  • [HBASE-19186] - Unify to use bytes to show size in master/rs ui
  • [HBASE-19187] - Remove option to create on heap bucket cache
  • [HBASE-19227] - Nightly jobs should archive JVM dumpstream files
  • [HBASE-19228] - nightly job should gather machine stats.
  • [HBASE-19251] - Merge RawAsyncTable and AsyncTable
  • [HBASE-19252] - Move the transform logic of FilterList into transformCell() method to avoid extra ref to question cell
  • [HBASE-19262] - Revisit checkstyle rules
  • [HBASE-19274] - Log IOException when unable to determine the size of committed file
  • [HBASE-19290] - Reduce zk request when doing split log
  • [HBASE-19293] - Support adding a new replication peer in disabled state
  • [HBASE-19311] - Promote TestAcidGuarantees to LargeTests and start mini cluster once to make it faster
  • [HBASE-19336] - Improve rsgroup to allow assign all tables within a specified namespace by only writing namespace
  • [HBASE-19341] - Ensure CP can abort a Server
  • [HBASE-19358] - Improve the stability of splitting log when do fail over
  • [HBASE-19367] - Refactoring in RegionStates, and RSProcedureDispatcher
  • [HBASE-19372] - Remove the Span object in SyncFuture as it is useless now
  • [HBASE-19382] - Update report-flakies.py script to handle yetus builds
  • [HBASE-19432] - Roll the specified writer in HFileOutputFormat2
  • [HBASE-19448] - Replace StringBuffer with StringBuilder for hbase-server
  • [HBASE-19463] - Make CPEnv#getConnection return a facade that throws Unsupported if CP calls #close
  • [HBASE-19464] - Replace StringBuffer with StringBuilder for hbase-common
  • [HBASE-19472] - Remove ArrayUtil Class
  • [HBASE-19473] - Miscellaneous changes to ClientScanner
  • [HBASE-19483] - Add proper privilege check for rsgroup commands
  • [HBASE-19486] - Periodically ensure records are not buffered too long by BufferedMutator
  • [HBASE-19489] - Check against only the latest maintenance release in pre-commit hadoopcheck.
  • [HBASE-19491] - Exclude flaky tests from nightly master run
  • [HBASE-19492] - Add EXCLUDE_NAMESPACE and EXCLUDE_TABLECFS support to replication peer config
  • [HBASE-19521] - HBase mob compaction need to check hfile version
  • [HBASE-19531] - Remove needless volatile declaration
  • [HBASE-19545] - Replace getBytes(StandardCharsets.UTF_8) with Bytes.toBytes
  • [HBASE-19570] - Add hadoop3 tests to Nightly master/branch-2 runs
  • [HBASE-19571] - Minor refactor of Nightly run scripts
  • [HBASE-19576] - Introduce builder for ReplicationPeerConfig and make it immutable
  • [HBASE-19590] - Remove the duplicate code in deprecated ReplicationAdmin
  • [HBASE-19613] - Miscellaneous changes to WALSplitter
  • [HBASE-19615] - CompositeImmutableSegment ArrayList Instead of LinkedList
  • [HBASE-19618] - Remove replicationQueuesClient.class/replicationQueues.class config and remove table based ReplicationQueuesClient/ReplicationQueues implementation
  • [HBASE-19621] - Revisit the methods in ReplicationPeerConfigBuilder
  • [HBASE-19641] - AsyncHBaseAdmin should use exponential backoff when polling the procedure result
  • [HBASE-19647] - Logging cleanups; emit regionname when RegionTooBusyException inside RetriesExhausted... make netty connect/disconnect TRACE-level
  • [HBASE-19649] - Use singleton feature for ImmutableSegment
  • [HBASE-19651] - Remove LimitInputStream
  • [HBASE-19659] - Enable -x in make_rc.sh so logs where it is in execution
  • [HBASE-19675] - Miscellaneous HStore Class Improvements
  • [HBASE-19676] - CleanerChore logging improvements
  • [HBASE-19677] - Miscellaneous HFileCleaner Improvements
  • [HBASE-19679] - Superusers Logging and Data Structures
  • [HBASE-19680] - BufferedMutatorImpl#mutate should wait the result from AP in order to throw the failed mutations
  • [HBASE-19683] - Remove Superfluous Methods From String Class
  • [HBASE-19684] - BlockCacheKey toString Performance
  • [HBASE-19702] - Improve RSGroupInfo constructors
  • [HBASE-19723] - hbase-thrift declares slf4j-api twice
  • [HBASE-19736] - Remove BaseLogCleanerDelegate deprecated #isLogDeletable(FileStatus) and use #isFileDeletable(FileStatus) instead
  • [HBASE-19739] - Include thrift IDL files in HBase binary distribution
  • [HBASE-19751] - Use RegionInfo directly instead of an identifier and a namespace when getting WAL
  • [HBASE-19758] - Split TestHCM to several smaller tests
  • [HBASE-19770] - Add '--return-values' option to Shell to print return values of commands in interactive mode
  • [HBASE-19789] - Not exclude flaky tests from nightly builds
  • [HBASE-19820] - Restore public constructor of MiniHBaseCluster (API compat)
  • [HBASE-19823] - Make RawCellBuilderFactory LimitedPrivate.UNITTEST
  • [HBASE-19826] - Provide a option to see rows behind a delete in a time range queries
  • [HBASE-19861] - Avoid using RPCs when querying table infos for master status pages
  • [HBASE-19899] - Dump ulimit -a, fd count, and free output at end of build into system dir
  • [HBASE-19904] - Break dependency of WAL constructor on Replication
  • [HBASE-19912] - The flag "writeToWAL" of Region#checkAndRowMutate is useless
  • [HBASE-19915] - From split/ merge procedures daughter/ merged regions get created in OFFLINE state
  • [HBASE-19917] - Improve RSGroupBasedLoadBalancer#filterServers() to be more efficient
  • [HBASE-19988] - HRegion#lockRowsAndBuildMiniBatch() is too chatty when interrupted while waiting for a row lock
  • [HBASE-19994] - Create a new class for RPC throttling exception, make it retryable.
  • [HBASE-20055] - Remove declaration of un-thrown exceptions and unused setRegionStateBackToOpen() from MergeTableRegionsProcedure
  • [HBASE-20065] - Revisit the timestamp usage in MetaTableAccessor
  • [HBASE-20135] - NullPointerException during reading bloom filter when upgraded from hbase-1 to hbase-2
  • [HBASE-20409] - Set hbase.client.meta.operation.timeout in TestClientOperationTimeout
  • [HBASE-20438] - Add an HBase antipattern check for reintroducing commons-logging
  • [HBASE-20459] - Majority of scan CPU time in HBase-1 spent in size estimation

Test

  • [HBASE-4744] - Remove @Ignore for testLogRollAfterSplitStart
  • [HBASE-11039] - [VisibilityController] Integration test for labeled data set mixing and filtered excise
  • [HBASE-11461] - Compilation errors are not posted back to JIRA during QA run
  • [HBASE-11616] - TestNamespaceUpgrade fails in trunk
  • [HBASE-11673] - TestIOFencing#testFencingAroundCompactionAfterWALSync fails
  • [HBASE-11866] - TestDistributedLogSplitting is flaky
  • [HBASE-11867] - TestSplitLogManager.testUnassignedTimeout is flaky
  • [HBASE-12764] - TestPerColumnFamilyFlush#testCompareStoreFileCount may fail due to new table not available
  • [HBASE-12992] - TestChoreService doesn't close services, that can break test on slow virtual hosts.
  • [HBASE-13106] - Ensure endpoint-only table coprocessors can be dynamically loaded
  • [HBASE-13179] - TestMasterObserver deleteTable is flaky
  • [HBASE-13182] - Test NamespaceAuditor/AccessController create/delete table is flaky
  • [HBASE-13280] - TestSecureRPC failed
  • [HBASE-13372] - Unit tests for SplitTransaction and RegionMergeTransaction listeners
  • [HBASE-13413] - Create an integration test for Replication
  • [HBASE-13591] - TestHBaseFsck is flakey
  • [HBASE-13609] - TestFastFail is still failing
  • [HBASE-13940] - IntegrationTestBulkLoad needs option to specify output folders used by test
  • [HBASE-14197] - TestRegionServerHostname#testInvalidRegionServerHostnameAbortsServer fails in Jenkins
  • [HBASE-14200] - Separate RegionReplica subtests of TestStochasticLoadBalancer into TestStochasticLoadBalancer2
  • [HBASE-14210] - Create test for cell level ACLs involving user group
  • [HBASE-14277] - TestRegionServerHostname.testRegionServerHostname may fail at host with a case sensitive name
  • [HBASE-14293] - TestStochasticBalancerJmxMetrics intermittently fails due to port conflict
  • [HBASE-14310] - test-patch.sh should handle spurious non-zero exit code from maven
  • [HBASE-14344] - Add timeouts to TestHttpServerLifecycle
  • [HBASE-14466] - Remove duplicated code from MOB snapshot tests
  • [HBASE-14584] - TestNamespacesInstanceModel fails on jdk8
  • [HBASE-14688] - Cleanup MOB tests
  • [HBASE-14728] - TestRowCounter is broken in master
  • [HBASE-14758] - Add UT case for unchecked error/exception thrown in AsyncProcess#sendMultiAction
  • [HBASE-15192] - TestRegionMergeTransactionOnCluster#testCleanMergeReference is flaky
  • [HBASE-15420] - TestCacheConfig failed after HBASE-15338
  • [HBASE-15679] - Assertion on wrong variable in TestReplicationThrottler#testThrottling
  • [HBASE-15760] - TestBlockEvictionFromClient#testParallelGetsAndScanWithWrappedRegionScanner fails in master branch
  • [HBASE-15923] - Shell rows counter test fails
  • [HBASE-15939] - Two shell test failures on master
  • [HBASE-16049] - TestRowProcessorEndpoint is failing on Apache Builds
  • [HBASE-16051] - TestScannerHeartbeatMessages fails on some machines
  • [HBASE-16185] - TestReplicationSmallTests fails in master branch
  • [HBASE-16274] - Add more peer tests to replication_admin_test
  • [HBASE-16349] - TestClusterId may hang during cluster shutdown
  • [HBASE-16418] - Reduce duration of sleep waiting for region reopen in IntegrationTestBulkLoad#installSlowingCoproc()
  • [HBASE-16634] - Speedup TestExportSnapshot
  • [HBASE-16639] - TestProcedureInMemoryChore#testChoreAddAndRemove occasionally fails
  • [HBASE-16671] - Split TestExportSnapshot
  • [HBASE-16725] - Don't let flushThread hang in TestHRegion
  • [HBASE-16776] - Remove duplicated versions of countRow() in tests
  • [HBASE-16777] - Fix flaky TestMasterProcedureEvents
  • [HBASE-16778] - Move testIllegalTableDescriptor out from TestFromClientSide
  • [HBASE-16781] - Fix flaky TestMasterProcedureWalLease
  • [HBASE-16791] - Fix TestDispatchMergingRegionsProcedure
  • [HBASE-16794] - TestDispatchMergingRegionsProcedure#testMergeRegionsConcurrently is flaky
  • [HBASE-16975] - Disable two subtests of TestSerialReplication
  • [HBASE-17080] - rest.TestTableResource fails in master branch
  • [HBASE-17120] - TestAssignmentListener#testAssignmentListener fails
  • [HBASE-17189] - TestMasterObserver#wasModifyTableActionCalled uses wrong variables
  • [HBASE-17246] - TestSerialReplication#testRegionMerge fails in master branch
  • [HBASE-17371] - Enhance 'HBaseContextSuite @ distributedScan to test HBase client' with filter
  • [HBASE-17474] - Reduce frequency of NoSuchMethodException when calling setStoragePolicy()
  • [HBASE-17628] - Local mode of mini cluster shouldn't use hdfs
  • [HBASE-17657] - TestZKAsyncRegistry is flaky
  • [HBASE-17672] - "Grant should set access rights appropriately" test fails
  • [HBASE-17703] - TestThriftServerCmdLine is flaky in master branch
  • [HBASE-17806] - TestRSGroups#testMoveServersAndTables is flaky in master branch
  • [HBASE-17824] - Add test for multiple RS per host support
  • [HBASE-18147] - nightly job to check health of active branches
  • [HBASE-18632] - TestMultiParallel#testFlushCommitsWithAbort fails in master branch
  • [HBASE-18902] - TestCoprocessorServiceBackwardCompatibility fails
  • [HBASE-19026] - TestLockProcedure#testRemoteNamespaceLockRecovery fails in master
  • [HBASE-19237] - TestMaster.testMasterOpsWhileSplitting fails
  • [HBASE-19248] - TestZooKeeper#testMultipleZK fails due to missing method getKeepAliveZooKeeperWatcher
  • [HBASE-19266] - TestAcidGuarantees should cover adaptive in-memory compaction
  • [HBASE-19273] - IntegrationTestBulkLoad#installSlowingCoproc() uses read-only HTableDescriptor
  • [HBASE-19288] - Intermittent test failure in TestHStore.testRunDoubleMemStoreCompactors
  • [HBASE-19289] - CommonFSUtils$StreamLacksCapabilityException: hflush when running test against hadoop3 beta1
  • [HBASE-19299] - Assert only one Connection is constructed when calculating splits in a MultiTableInputFormat
  • [HBASE-19342] - fix TestTableBasedReplicationSourceManagerImpl#testRemovePeerMetricsCleanup
  • [HBASE-19514] - Use random port for TestJMXListener
  • [HBASE-19832] - TestConfServlet#testWriteJson fails against hadoop3 due to spelling change
  • [HBASE-19869] - Wrong class name used in TestLockManager
  • [HBASE-19949] - TestRSGroupsWithACL fails with ExceptionInInitializerError
  • [HBASE-20031] - Unable to run integration test using mvn due to missing HBaseClassTestRule
  • [HBASE-20052] - TestRegionOpen#testNonExistentRegionReplica fails due to NPE
  • [HBASE-20107] - Add a test case for HBASE-14317
  • [HBASE-20228] - [Umbrella] Verify 1.2.7 shell works against 2.0.0 server
  • [HBASE-20272] - TestAsyncTable#testCheckAndMutateWithTimeRange fails due to TableExistsException

Wish

  • [HBASE-16145] - MultiRowRangeFilter constructor shouldn't throw IOException
  • [HBASE-16729] - Define the behavior of (default) empty FilterList

Task

  • [HBASE-4368] - Expose processlist in shell (per regionserver and perhaps by cluster)
  • [HBASE-4593] - Design and document the official procedure for posting patches, commits, commit messages, etc. to smooth process and make integration with tools easier
  • [HBASE-7126] - Update website with info on how to report security bugs
  • [HBASE-8450] - Update hbase-default.xml and general recommendations to better suit current hw, h2, experience, etc.
  • [HBASE-9604] - Add metric on short-circuit reads
  • [HBASE-10398] - HBase book updates for Replication after HBASE-10322
  • [HBASE-10504] - Define Replication Interface
  • [HBASE-10607] - [JDK8] NoSuchMethodError involving ConcurrentHashMap.keySet if running on JRE 7
  • [HBASE-11045] - Replace deprecated method FileSystem#createNonRecursive
  • [HBASE-11276] - Add back support for running ChaosMonkey as standalone tool
  • [HBASE-11459] - Add more doc on compression codecs, how to hook up native lib, lz4, etc.
  • [HBASE-11606] - Enable ZK-less region assignment by default
  • [HBASE-11619] - Remove unused test class from TestHLogSplit
  • [HBASE-11670] - Build PDF of Ref Guide
  • [HBASE-11677] - Make Logger instance modifiers consistent
  • [HBASE-11720] - Set up jenkins job to build site documentation
  • [HBASE-11729] - Document HFile v3
  • [HBASE-11741] - Document the how users can use the Cell Visibility and authorizations with special characters
  • [HBASE-11791] - Update docs on visibility tags and ACLs, transparent encryption, secure bulk upload
  • [HBASE-11961] - Document region state transitions
  • [HBASE-11985] - Document sizing rules of thumb
  • [HBASE-12168] - Document Rest gateway SPNEGO-based authentication for client
  • [HBASE-12180] - Fix and reenable TestRegionReplicaReplicationEndpoint
  • [HBASE-12239] - Document hedged reads
  • [HBASE-12362] - Interim documentation of important master and regionserver metrics
  • [HBASE-12438] - Add -Dsurefire.rerunFailingTestsCount=2 to patch build runs so flakies get rerun
  • [HBASE-12466] - Document visibility scan label generator usage and behavior
  • [HBASE-12515] - update test-patch to use git
  • [HBASE-12586] - Task 6 & 7 from HBASE-9117, delete all public HTable constructors and delete ConnectionManager#{delete,get}Connection
  • [HBASE-12589] - Forward-port fix for TestFromClientSideWithCoprocessor.testMaxKeyValueSize
  • [HBASE-12623] - Remove pre-0.96 to 0.96 upgrade code
  • [HBASE-12701] - Document how to set the split policy on a given table
  • [HBASE-12783] - Create efficient RegionLocator implementation
  • [HBASE-12785] - Use FutureTask to timeout the attempt to get the lock for hbck
  • [HBASE-12794] - Guidelines for filing JIRA issues
  • [HBASE-12995] - Document that HConnection#getTable methods do not check table existence since 0.98.1
  • [HBASE-13074] - Cleaned up usage of hbase.master.lease.thread.wakefrequency
  • [HBASE-13079] - Add an admonition to Scans example that the results scanner should be closed
  • [HBASE-13089] - Fix test compilation error on building against htrace-3.2.0-incubating
  • [HBASE-13177] - Document HBASE-13012
  • [HBASE-13187] - Add ITBLL that exercises per CF flush
  • [HBASE-13233] - add hbase-11339 branch to the patch testing script
  • [HBASE-13234] - Improve the obviousness of the download link on hbase.apache.org
  • [HBASE-13237] - Improve trademark marks on the hbase.apache.org homepage
  • [HBASE-13257] - Show coverage report on jenkins
  • [HBASE-13310] - Fix high priority findbugs warnings
  • [HBASE-13361] - Remove or undeprecate {get|set}ScannerCaching in HTable
  • [HBASE-13373] - Squash HFileReaderV3 together with HFileReaderV2 and AbstractHFileReader; ditto for Scanners and BlockReader, etc.
  • [HBASE-13446] - Add docs warning about missing data for downstream on versions prior to HBASE-13262
  • [HBASE-13487] - Doc KEEP_DELETED_CELLS
  • [HBASE-13554] - Update book clarifying API stability guarantees
  • [HBASE-13582] - Update docs for HTrace
  • [HBASE-13586] - Update book on Hadoop and Java supported versions for 1.1.x
  • [HBASE-13660] - Add link to cloud bigtable schema modeling guide into our refguide
  • [HBASE-13666] - book.pdf is not renamed during site build
  • [HBASE-13713] - See about dropping ClassLoaderBase#getClassLoadingLock
  • [HBASE-13716] - Stop using Hadoop's FSConstants
  • [HBASE-13726] - stop using Hadoop's IOUtils
  • [HBASE-13799] - javadoc how Scan gets polluted when used; if you set attributes or ask for scan metrics
  • [HBASE-13867] - Add endpoint coprocessor guide to HBase book
  • [HBASE-13868] - Correct "Disable automatic splitting" section in HBase book
  • [HBASE-13869] - Fix typo in HBase book
  • [HBASE-13915] - Remove EOL HBase versions from java and hadoop prereq tables
  • [HBASE-13929] - make_rc.sh publishes empty shaded artifacts
  • [HBASE-13948] - Expand hadoop2 versions built on the pre-commit
  • [HBASE-13949] - Expand hadoop2 versions built on the pre-commit
  • [HBASE-13956] - Add myself as 1.1 release manager
  • [HBASE-13964] - Skip region normalization for tables under namespace quota
  • [HBASE-14026] - Clarify "Web API" in version and compatibility docs
  • [HBASE-14031] - HBase Backup/Restore Phase 1: Abstract DistCp in incremental backup
  • [HBASE-14033] - HBase Backup/Restore Phase1: Abstract WALPlayer (incremental restore)
  • [HBASE-14036] - HBase Backup/Restore Phase 1: Custom WAL archive cleaner
  • [HBASE-14052] - Mark a few methods in CellUtil audience private since only make sense internally to hbase
  • [HBASE-14053] - Disable DLR in branch-1+
  • [HBASE-14057] - HBase shell user_permission should list super users defined on hbase-site.xml
  • [HBASE-14071] - Document troubleshooting unexpected filesystem usage by snapshots and WALs
  • [HBASE-14081] - (outdated) references to SVN/trunk in documentation
  • [HBASE-14085] - Correct LICENSE and NOTICE files in artifacts
  • [HBASE-14091] - Update site documentation with code of conduct and project policy for transgressions
  • [HBASE-14175] - Adopt releasedocmaker for better generated release notes
  • [HBASE-14227] - Fold special cased MOB APIs into existing APIs
  • [HBASE-14253] - update docs + build for maven 3.0.4+
  • [HBASE-14271] - Improve Nexus staging instructions
  • [HBASE-14288] - Upgrade asciidoctor plugin to v1.5.2.1
  • [HBASE-14290] - Spin up less threads in tests
  • [HBASE-14308] - HTableDescriptor WARN is not actionable
  • [HBASE-14318] - make_rc.sh should purge/re-resolve dependencies from local repository
  • [HBASE-14348] - Update download mirror link
  • [HBASE-14350] - Procedure V2 Phase 2: Assignment Manager
  • [HBASE-14361] - ReplicationSink should create Connection instances lazily
  • [HBASE-14424] - Document that DisabledRegionSplitPolicy blocks manual splits
  • [HBASE-14481] - Decommission HBase wiki
  • [HBASE-14482] - Add hadoop 2.6.1 to the test-patch build list
  • [HBASE-14493] - Upgrade the jamon-runtime dependency
  • [HBASE-14502] - Purge use of jmock and remove as dependency
  • [HBASE-14516] - categorize hadoop-compat tests
  • [HBASE-14526] - Remove delayed rpc
  • [HBASE-14534] - Bump yammer/coda/dropwizard metrics dependency version
  • [HBASE-14635] - Fix flaky test TestSnapshotCloneIndependence
  • [HBASE-14652] - Improve / update publish-website script in dev-support
  • [HBASE-14678] - Experiment: Temporarily disable balancer and a few others to see if root of crashed/timedout JVMs
  • [HBASE-14713] - Remove simple deprecated-since-1.0 code in hbase-server from hbase 2.0
  • [HBASE-14732] - Update HBase website skin and CSS
  • [HBASE-14762] - Update docs about publishing website to show gitsubpub method instead of svnsubpub
  • [HBASE-14764] - Stop using post-site target
  • [HBASE-14851] - Add test showing how to use TTL from thrift
  • [HBASE-14994] - Clean up some broken links and references to old APIs
  • [HBASE-15003] - Remove BoundedConcurrentLinkedQueue and associated test
  • [HBASE-15007] - update Hadoop support matrix to list 2.6.1+ as supported
  • [HBASE-15017] - Close out GitHub pull requests that aren't likely to update into a usable patch
  • [HBASE-15042] - refactor so that site materials are in the Standard Maven Place
  • [HBASE-15099] - Move RegionStateListener class out of quotas package
  • [HBASE-15141] - Procedure V2 - Web UI
  • [HBASE-15151] - Rely on nightly tests for findbugs compliance on existing branch
  • [HBASE-15199] - Move jruby jar so only on hbase-shell module classpath; currently globally available
  • [HBASE-15220] - Change two logs in SimpleRegionNormalizer to INFO level
  • [HBASE-15494] - Close obviated PRs on github
  • [HBASE-15502] - Skeleton unit test to copy/paste
  • [HBASE-15644] - Add maven-scala-plugin for scaladoc
  • [HBASE-15646] - Add some docs about exporting and importing snapshots using S3
  • [HBASE-15656] - Fix unused protobuf warning in Admin.proto
  • [HBASE-15729] - Remove old JDiff wrapper scripts in dev-support
  • [HBASE-15888] - Extend HBASE-12769 for bulk load data replication
  • [HBASE-15895] - remove unmaintained jenkins build analysis tool.
  • [HBASE-15989] - Remove hbase.online.schema.update.enable
  • [HBASE-16073] - update compatibility_checker for jacc dropping comma sep args
  • [HBASE-16100] - Procedure V2 - Tools
  • [HBASE-16215] - clean up references for EOM release lines
  • [HBASE-16260] - Audit dependencies for Category-X
  • [HBASE-16332] - update LMAX disruptor to latest
  • [HBASE-16333] - update commons-* to latest
  • [HBASE-16335] - update to latest apache parent pom
  • [HBASE-16338] - update jackson to 2.y
  • [HBASE-16340] - ensure no Xerces jars included
  • [HBASE-16354] - Clean up defunct GitHub PRs
  • [HBASE-16376] - Document implicit side-effects on partial results when calling Scan#setBatch(int)
  • [HBASE-16413] - Add apache-hbase.slack.com #users channel to ref guide
  • [HBASE-16426] - Remove company affiliations from committer list
  • [HBASE-16459] - Remove unused hbase shell --format option
  • [HBASE-16467] - Move AbstractHBaseTool to hbase-common
  • [HBASE-16518] - Remove old .arcconfig file
  • [HBASE-16591] - Add a docker file only contains java 8 for running pre commit on master
  • [HBASE-16710] - Add ZStandard Codec to Compression.java
  • [HBASE-16728] - Add hadoop.profile=3.0 pass to precommit checks.
  • [HBASE-16811] - Remove mob sweep job
  • [HBASE-16812] - Clean up the locks in MOB
  • [HBASE-16869] - Typo in "Disabling Blockcache" doc
  • [HBASE-16952] - Replace hadoop-maven-plugins with protobuf-maven-plugin for building protos
  • [HBASE-16955] - Fixup precommit protoc check to do new distributed protos and pb 3.1.0 build
  • [HBASE-17046] - Add 1.1 doc to hbase.apache.org
  • [HBASE-17121] - Undo the building of xref as part of site build
  • [HBASE-17272] - Doc how to run Standalone HBase over an HDFS instance; all daemons in one JVM but persisting to an HDFS instance
  • [HBASE-17397] - AggregationClient cleanup
  • [HBASE-17401] - Remove unnecessary semicolons in hbase-annotations
  • [HBASE-17502] - Document hadoop pre-2.6.1 and Java 1.8 Kerberos problem in our hadoop support matrix
  • [HBASE-17553] - Make a 2.0.0 Release
  • [HBASE-17609] - Allow for region merging in the UI
  • [HBASE-17614] - Move Backup/Restore into separate module
  • [HBASE-17618] - Refactor the implementation of modify table and delete column in MOB
  • [HBASE-17782] - Extend IdReadWriteLock to support using both weak and soft reference
  • [HBASE-17802] - Add note that minor versions can add methods to Interfaces
  • [HBASE-17828] - Revisit the IS annotation and the documentation
  • [HBASE-17834] - close stale github PRs
  • [HBASE-17847] - update documentation to include positions on recent Hadoop releases
  • [HBASE-17898] - Update dependencies
  • [HBASE-17954] - Switch findbugs implementation to spotbugs
  • [HBASE-17965] - Canary tool should print the regionserver name on failure
  • [HBASE-17967] - clean up documentation references to -ROOT- table.
  • [HBASE-17968] - Update copyright year in NOTICE file
  • [HBASE-17972] - Remove mergePool from CompactSplitThread
  • [HBASE-18096] - Limit HFileUtil visibility and add missing annotations
  • [HBASE-18187] - Release hbase-2.0.0-alpha1
  • [HBASE-18257] - Cover exposed guava Service Interface in ReplicationEndpoint
  • [HBASE-18258] - Take down hbasecon2017 logo from hbase.apache.org and put up hbaseconasia2017 instead.
  • [HBASE-18284] - Update hbasecon asia logo on home page of hbase.apache.org
  • [HBASE-18288] - Declared dependency on specific javax.ws.rs
  • [HBASE-18291] - Regenerate thrift2 python examples
  • [HBASE-18344] - Introduce Append.addColumn as a replacement for Append.add
  • [HBASE-18364] - Downgrade surefire
  • [HBASE-18384] - Add link to refguide schema section on apache blog on hbase application archetypes
  • [HBASE-18421] - update hadoop prerequisites docs to call out 2.8.1
  • [HBASE-18465] - [AMv2] remove old split region code that is no longer needed
  • [HBASE-18511] - Default no regions on master
  • [HBASE-18514] - Backport space quota "phase2" work to branch-2
  • [HBASE-18515] - Introduce Delete.add as a replacement for Delete#addDeleteMarker
  • [HBASE-18518] - Remove jersey1* dependencies from project and jersey1* jars from lib dir
  • [HBASE-18527] - update nightly builds to compensate for jenkins plugin upgrades
  • [HBASE-18544] - Move the HRegion#addRegionToMETA to TestDefaultMemStore
  • [HBASE-18582] - Correct the docs for Mutation#setCellVisibility
  • [HBASE-18588] - Verify we're using netty .so epolling on linux post HBASE-18271
  • [HBASE-18594] - Release hbase-2.0.0-alpha2
  • [HBASE-18596] - [TEST] A hbase1 cluster should be able to replicate to a hbase2 cluster; verify
  • [HBASE-18611] - Copy all tests from o.a.h.h.p.TestProtobufUtil to o.a.h.h.s.p.TestProtobufUtil
  • [HBASE-18623] - Frequent failed to parse at EOF warnings from WALEntryStream
  • [HBASE-18630] - Prune dependencies; as is branch-2 has duplicates
  • [HBASE-18653] - Undo hbase2 check against < hadoop2.6.x; i.e. implement agreed drop of hadoop 2.4 and 2.5 support in hbase2
  • [HBASE-18660] - Remove duplicate code from the checkAndPut method in HTable
  • [HBASE-18670] - Add .DS_Store to .gitignore
  • [HBASE-18695] - Remove HTablePool
  • [HBASE-18705] - bin/hbase does not find cached_classpath.txt
  • [HBASE-18710] - Move on to hbase-thirdparty 1.0.1 (it was just released).
  • [HBASE-18766] - Make TableSnapshotScanner Audience Private
  • [HBASE-18767] - Release hbase-2.0.0-alpha-3; Theme "Scrubbed API"
  • [HBASE-18768] - Move TestTableName to hbase-common from hbase-server
  • [HBASE-18782] - Module untangling work
  • [HBASE-18783] - Declare the builder of ClusterStatus as IA.Private, and remove the Writables from ClusterStatus
  • [HBASE-18792] - hbase-2 needs to defend against hbck operations
  • [HBASE-18817] - Pull hbase-spark module out of branch-2
  • [HBASE-18833] - Ensure precommit personality is up to date on all active branches
  • [HBASE-18835] - The return type of ExtendedCell#deepClone should be ExtendedCell rather than Cell
  • [HBASE-18877] - Move Type out of KeyValue to Cell
  • [HBASE-18882] - [TEST] Run MR branch-1 jobs against hbase2 cluster
  • [HBASE-18897] - Substitute MemStore for Memstore
  • [HBASE-18927] - Add the DataType which is subset of KeyValue#Type to CellBuilder for building cell
  • [HBASE-18970] - The version of jruby we use now can't get interactive input from prompt
  • [HBASE-18988] - Add release managers to reference guide
  • [HBASE-18991] - Remove RegionMergeRequest
  • [HBASE-19007] - Align Services Interfaces in Master and RegionServer
  • [HBASE-19043] - Purge TableWrapper and CoprocessorHConnnection
  • [HBASE-19049] - Update kerby to 1.0.1 GA release
  • [HBASE-19050] - Improve javadoc of Scan#setMvccReadPoint
  • [HBASE-19097] - update testing to use Apache Yetus Test Patch version 0.6.0
  • [HBASE-19123] - Purge 'complete' support from Coprocesor Observers
  • [HBASE-19158] - Ref guide needs upgrade update
  • [HBASE-19176] - Remove hbase-native-client from branch-2
  • [HBASE-19179] - Remove hbase-prefix-tree
  • [HBASE-19200] - make hbase-client only depend on ZKAsyncRegistry and ZNodePaths
  • [HBASE-19217] - Update supplemental-models.xml for jetty-sslengine
  • [HBASE-19224] - LICENSE failure for Hadoop 3.1 on dnsjava
  • [HBASE-19241] - Improve javadoc for AsyncAdmin and cleanup warnings for the implementation classes
  • [HBASE-19267] - Eclipse project import issues on 2.0
  • [HBASE-19298] - CellScanner and CellScannable should be declared as IA.Public
  • [HBASE-19323] - Make netty engine default in hbase2
  • [HBASE-19328] - Remove asked if splittable log messages
  • [HBASE-19404] - Fix DisabledWALProvider
  • [HBASE-19407] - [branch-2] Remove backup/restore
  • [HBASE-19408] - Remove WALActionsListener.Base
  • [HBASE-19410] - Move zookeeper related UTs to hbase-zookeeper and mark them as ZKTests
  • [HBASE-19416] - Document dynamic configurations currently support
  • [HBASE-19477] - Move and align documentation in hbase-annotations
  • [HBASE-19485] - Minor improvement to TestCompactedHFilesDischarger
  • [HBASE-19512] - Move EventType and ExecutorType from hbase-client to hbase-server
  • [HBASE-19526] - Update hadoop version to 3.0 GA
  • [HBASE-19548] - Backport the missed doc fix from master to branch-2
  • [HBASE-19550] - Wrap the cell passed via Mutation#add(Cell) to be of ExtendedCell
  • [HBASE-19552] - update hbase to use new thirdparty libs
  • [HBASE-19596] - RegionMetrics/ServerMetrics/ClusterMetrics should apply to all public classes
  • [HBASE-19620] - Add UT to confirm the race in MasterRpcServices.getProcedureResult
  • [HBASE-19637] - Add .checkstyle to gitignore
  • [HBASE-19644] - add the checkstyle rule to reject the illegal imports
  • [HBASE-19652] - Turn down CleanerChore logging; too chatty
  • [HBASE-19657] - Reenable TestAssignmentManagerMetrics for beta-2
  • [HBASE-19720] - Rename WALKey#getTabnename to WALKey#getTableName
  • [HBASE-19922] - ProtobufUtils::PRIMITIVES is unused
  • [HBASE-19946] - TestPerColumnFamilyFlush and TestWalAndCompactingMemStoreFlush fail against h3
  • [HBASE-19947] - MR jobs using ITU use wrong filesystem
  • [HBASE-19963] - TestFSHDFSUtils assumes wrong default port for Hadoop 3.0.1+
  • [HBASE-20072] - remove 1.1 release line from the prerequisite tables
  • [HBASE-20075] - remove logic for branch-1.1 nightly testing
  • [HBASE-20084] - Refactor the RSRpcServices#doBatchOp
  • [HBASE-20088] - Update copyright notices to year 2018
  • [HBASE-20089] - make_rc.sh should name SHA-512 checksum files with the extension .sha512
  • [HBASE-20092] - Fix TestRegionMetrics#testRegionMetrics
  • [HBASE-20093] - Replace ServerLoad by ServerMetrics for ServerManager
  • [HBASE-20097] - Merge TableDescriptors#getAll and TableDescriptors#getAllDescriptors into one
  • [HBASE-20119] - Introduce a pojo class to carry coprocessor information in order to make TableDescriptorBuilder accept multiple cp at once
  • [HBASE-20132] - Change the "KV" to "Cell" for web UI
  • [HBASE-20171] - Remove o.a.h.h.ProcedureState
  • [HBASE-20199] - Add test to prevent further permission regression around table flush and snapshot
  • [HBASE-20212] - Make all Public classes have InterfaceAudience category
  • [HBASE-20223] - Use hbase-thirdparty 2.1.0
  • [HBASE-20246] - Remove the spark module
  • [HBASE-20299] - Update MOB in hbase refguide
  • [HBASE-20365] - start branch-2.0 specific website section
  • [HBASE-20386] - [DOC] Align WALPlayer help text and refguide
  • [HBASE-20441] - Use checkstyle to ban imports from commons-lang 2
  • [HBASE-20443] - Use checkstyle to ban imports from commons-collections 3

Brainstorming

  • [HBASE-8770] - deletes and puts with the same ts should be resolved according to mvcc/seqNum
  • [HBASE-12859] - New master API to track major compaction completion
  • [HBASE-14869] - Better request latency and size histograms

Umbrella

  • [HBASE-6581] - Build with hadoop.profile=3.0
  • [HBASE-7320] - Remove KeyValue.getBuffer()
  • [HBASE-7781] - Update security unit tests to use a KDC if available
  • [HBASE-10403] - Simplify offheap cache configuration
  • [HBASE-10462] - Recategorize some of the client facing Public / Private interfaces
  • [HBASE-11339] - HBase MOB
  • [HBASE-11425] - Cell/DBB end-to-end on the read-path
  • [HBASE-11871] - Avoid usage of KeyValueUtil#ensureKeyValue
  • [HBASE-13747] - Promote Java 8 to "yes" in support matrix
  • [HBASE-14420] - Zombie Stomping Session
  • [HBASE-14457] - Umbrella: Improve Multiple WAL for production usage
  • [HBASE-14460] - [Perf Regression] Merge of MVCC and SequenceId (HBASE-8763) slowed Increments, CheckAndPuts, batch operations
  • [HBASE-15086] - Fix findbugs complaint so yetus reports more green
  • [HBASE-15179] - Cell/DBB end-to-end on the write-path
  • [HBASE-16432] - Revisit the asynchronous ipc implementation
  • [HBASE-16567] - Upgrade to protobuf-3.1.x
  • [HBASE-16617] - Procedure V2 - Improvements
  • [HBASE-16833] - Implement asynchronous hbase client based on HBASE-15921
  • [HBASE-17143] - Scan improvement
  • [HBASE-17359] - Implement async admin
  • [HBASE-18037] - Do not expose implementation classes to CP
  • [HBASE-18110] - [AMv2] Reenable tests temporarily disabled
  • [HBASE-18266] - Eliminate the warnings from the spotbugs
  • [HBASE-18410] - FilterList Improvement.
  • [HBASE-18429] - ITs attempt to modify immutable table/column descriptors
  • [HBASE-18501] - Use TableDescriptor and ColumnFamilyDescriptor as far as possible
  • [HBASE-18696] - Fix the problems when introducing the new hbase-mapreduce module
  • [HBASE-18703] - Inconsistent behavior for preBatchMutate in doMiniBatchMutate and processRowsWithLocks
  • [HBASE-18751] - Revisit the TimeRange and TimeRangeTracker
  • [HBASE-18805] - Unify Admin and AsyncAdmin
  • [HBASE-18926] - Cleanup Optional<T> from method params
  • [HBASE-18978] - Align the methods in Table and AsyncTable
  • [HBASE-19296] - Fix findbugs and error-prone warnings (branch-2)
  • [HBASE-19425] - Align the methods in Put/Delete/Increment/Append
  • [HBASE-19627] - Stabilize the method signature for Cell and its impl
  • [HBASE-19948] - Since HBASE-19873, HBaseClassTestRule, Small/Medium/Large has different semantic
  • [HBASE-19976] - Dead lock if the worker threads in procedure executor are exhausted
  • [HBASE-20067] - Clean up findbugs warnings
  • [HBASE-20179] - [TESTING] Scale for 2.0.0

Edit/Copy Release Notes

The text area below allows the project release notes to be edited and copied to another document.