CDH 5.13.2 Release Notes
The following lists all Apache HBase Jiras included in CDH 5.13.2
that are not included in the Apache HBase base version 1.2.0. The
hbase-1.2.0-cdh5.13.2.CHANGES.txt
file lists all changes included in CDH 5.13.2. The patch for each
change can be found in the cloudera/patches directory in the release tarball.
Changes Not In Apache HBase 1.2.0
HBase
Bug
- [HBASE-18625] - Splitting of region with replica, doesn't update region list in serverHolding. A server crash leads to overlap.
- [HBASE-14252] - RegionServers fail to start when setting hbase.ipc.server.callqueue.scan.ratio to 0
- [HBASE-16980] - TestRowProcessorEndpoint failing consistently
- [HBASE-19215] - Incorrect exception handling on the client causes incorrect call timeouts and byte buffer allocations on the server
- [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-18568] - Correct metric of numRegions
- [HBASE-18577] - shaded client includes several non-relocated third party dependencies
- [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-18665] - ReversedScannerCallable invokes getRegionLocations incorrectly
- [HBASE-18487] - Minor fixes in row lock implementation
- [HBASE-16090] - ResultScanner is not closed in SyncTable#finishRemainingHashRanges()
- [HBASE-18099] - FlushSnapshotSubprocedure should wait for concurrent Region#flush() to finish
- [HBASE-17341] - Add a timeout during replication endpoint termination
- [HBASE-18024] - HRegion#initializeRegionInternals should not re-create .hregioninfo file when the region directory no longer exists
- [HBASE-18390] - Sleep too long when finding region location failed
- [HBASE-18230] - Generated LICENSE file includes unsubstituted Velocity variables
- [HBASE-18005] - read replica: handle the case that region server hosting both primary replica and meta region is down
- [HBASE-18025] - CatalogJanitor should collect outdated RegionStates from the AM
- [HBASE-18081] - The way we process connection preamble in SimpleRpcServer is broken
- [HBASE-17352] - Fix hbase-assembly build with bash 4
- [HBASE-18137] - Replication gets stuck for empty WALs
- [HBASE-18255] - Time-Delayed HBase Performance Degradation with Java 7
- [HBASE-18066] - Get with closest_row_before on "hbase:meta" can return empty Cell during region merge/split
- [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-18122] - Scanner id should include ServerName of region server
- [HBASE-18192] - Replication drops recovered queues on region server shutdown
- [HBASE-17287] - Master becomes a zombie if filesystem object closes
- [HBASE-18030] - Per Cell TTL tags may get duplicated with increments/Append causing tags length overflow
- [HBASE-18036] - HBase 1.x : Data locality is not maintained after cluster restart or SSH
- [HBASE-17698] - ReplicationEndpoint choosing sinks
- [HBASE-17534] - SecureBulkLoadClient squashes DoNotRetryIOExceptions from the server
- [HBASE-17648] - HBase Table-level synchronization fails between two secured(kerberized) clusters
- [HBASE-15548] - SyncTable: sourceHashDir is supposed to be optional but won't work without
- [HBASE-18035] - Meta replica does not give any primaryOperationTimeout to primary meta region
- [HBASE-18077] - Update JUnit license to EPL from CPL
- [HBASE-9393] - Hbase does not closing a closed socket resulting in many CLOSE_WAIT
- [HBASE-18247] - Hbck to fix the case that replica region shows as key in the meta table
- [HBASE-18362] - hbck should not report split replica parent region from meta as errors
- [HBASE-18185] - IntegrationTestTimeBoundedRequestsWithRegionReplicas unbalanced tests fails with AssertionError
- [HBASE-17131] - Avoid livelock caused by HRegion#processRowsWithLocks
- [HBASE-17587] - Do not Rethrow DoNotRetryIOException as UnknownScannerException
- [HBASE-16739] - Timed out exception message should include encoded region name
- [HBASE-17773] - VerifyReplication tool wrongly emits warning "ERROR: Invalid argument '--recomparesleep=xx'"
- [HBASE-16409] - Row key for bad row should be properly delimited in VerifyReplication
- [HBASE-16045] - endtime argument for VerifyReplication was incorrectly specified in usage
- [HBASE-17574] - Clean up how to run tests under hbase-spark module
- [HBASE-17501] - NullPointerException after Datanodes Decommissioned and Terminated
- [HBASE-17736] - Some options can't be configured by the shell
- [HBASE-17970] - Set yarn.app.mapreduce.am.staging-dir when starting MiniMRCluster
- [HBASE-16775] - Flakey test with TestExportSnapshot#testExportRetry and TestMobExportSnapshot#testExportRetry
- [HBASE-17682] - Region stuck in merging_new state indefinitely
- [HBASE-17798] - RpcServer.Listener.Reader can abort due to CancelledKeyException
- [HBASE-16630] - Fragmentation in long running Bucket Cache
- [HBASE-17764] - Solve TestMultiSlaveReplication flakiness
- [HBASE-17673] - Monitored RPC Handler not shown in the WebUI
- [HBASE-17803] - PE always re-creates table when we specify the split policy
- [HBASE-17710] - HBase in standalone mode creates directories with 777 permission
- [HBASE-17688] - MultiRowRangeFilter not working correctly if given same start and stop RowKey
- [HBASE-17729] - Missing shortcuts for some useful HCD options
- [HBASE-17712] - Remove/Simplify the logic of RegionScannerImpl.handleFileNotFound
- [HBASE-17761] - Test TestRemoveRegionMetrics.testMoveRegion fails intermittently because of race condition
- [HBASE-17722] - Metrics subsystem stop/start messages add a lot of useless bulk to operational logging
- [HBASE-17780] - BoundedByteBufferPool "At capacity" messages are not actionable
- [HBASE-17717] - Incorrect ZK ACL set for HBase superuser
- [HBASE-17779] - disable_table_replication returns misleading message and does not turn off replication
- [HBASE-17460] - enable_table_replication can not perform cyclic replication of a table
- [HBASE-17772] - IntegrationTestRSGroup won't run
- [HBASE-14968] - ConcurrentModificationException in region close resulting in the region staying in closing state
- [HBASE-17792] - Use a shared thread pool for AtomicityWriter, AtomicGetReader, AtomicScanReader's connections in TestAcidGuarantees
- [HBASE-16368] - test*WhenRegionMove in TestPartialResultsFromClientSide is flaky
- [HBASE-16754] - Regions failing compaction due to referencing non-existent store file
- [HBASE-16931] - Setting cell's seqId to zero in compaction flow might cause RS down.
- [HBASE-17328] - Properly dispose of looped replication peers
- [HBASE-16960] - RegionServer hang when aborting
- [HBASE-16663] - JMX ConnectorServer stopped when unauthorized user try to stop HM/RS/cluster
- [HBASE-16721] - Concurrency issue in WAL unflushed seqId tracking
- [HBASE-15955] - Disable action in CatalogJanitor#setEnabled should wait for active cleanup scan to finish
- [HBASE-15125] - HBaseFsck's adoptHdfsOrphan function creates region with wrong end key boundary
- [HBASE-16032] - Possible memory leak in StoreScanner
- [HBASE-16604] - Scanner retries on IOException can cause the scans to miss data
- [HBASE-17265] - Region left unassigned in master failover when region failed to open
- [HBASE-12949] - Scanner can be stuck in infinite loop if the HFile is corrupted
- [HBASE-16238] - It's useless to catch SESSIONEXPIRED exception and retry in RecoverableZooKeeper
- [HBASE-16807] - RegionServer will fail to report new active Hmaster until HMaster/RegionServer failover
- [HBASE-17675] - ReplicationEndpoint should choose new sinks if a SaslException occurs
- [HBASE-17069] - RegionServer writes invalid META entries for split daughters in some circumstances
- [HBASE-16289] - AsyncProcess stuck messages need to print region/server
- [HBASE-16765] - New SteppingRegionSplitPolicy, avoid too aggressive spread of regions for small tables.
- [HBASE-16429] - FSHLog: deadlock if rollWriter called when ring buffer filled with appends
- [HBASE-16304] - HRegion#RegionScannerImpl#handleFileNotFoundException may lead to deadlock when trying to obtain write lock on updatesLock
- [HBASE-16062] - Improper error handling in WAL Reader/Writer creation
- [HBASE-17023] - Region left unassigned due to AM and SSH each thinking others would do the assignment work
- [HBASE-15587] - FSTableDescriptors.getDescriptor() logs stack trace erronously
- [HBASE-15613] - TestNamespaceCommand times out
- [HBASE-17044] - Fix merge failed before creating merged region leaves meta inconsistent
- [HBASE-17206] - FSHLog may roll a new writer successfully with unflushed entries
- [HBASE-15325] - ResultScanner allowing partial result will miss the rest of the row if the region is moved between two rpc requests
- [HBASE-15645] - hbase.rpc.timeout is not used in operations of HTable
- [HBASE-16662] - Fix open POODLE vulnerabilities
- [HBASE-17624] - Address late review of HBASE-6721, rsgroups feature
- [HBASE-15441] - Fix WAL splitting when region has moved multiple times
- [HBASE-15322] - Operations using Unsafe path broken for platforms not having sun.misc.Unsafe
- [HBASE-16649] - Truncate table with splits preserved can cause both data loss and truncated data appeared again
- [HBASE-16527] - IOExceptions from DFS client still can cause CatalogJanitor to delete referenced files
- [HBASE-17238] - Wrong in-memory hbase:meta location causing SSH failure
- [HBASE-16165] - Decrease RpcServer.callQueueSize before writeResponse causes OOM
- [HBASE-17275] - Assign timeout may cause region to be unassigned forever
- [HBASE-17381] - ReplicationSourceWorkerThread can die due to unhandled exceptions
- [HBASE-15295] - MutateTableAccess.multiMutate() does not get high priority causing a deadlock
- [HBASE-17677] - ServerName parsing from directory name should be more robust to errors from guava's HostAndPort
- [HBASE-16460] - Can't rebuild the BucketAllocator's data structures when BucketCache uses FileIOEngine
- [HBASE-17020] - keylen in midkey() dont computed correctly
- [HBASE-16237] - Blocks for hbase:meta table are not cached in L1 cache
- [HBASE-15328] - Unvalidated Redirect in HMaster
- [HBASE-17640] - Unittest error in TestMobCompactor with different timezone
- [HBASE-17558] - ZK dumping jsp should escape html
- [HBASE-15378] - Scanner cannot handle heartbeat message with no results
- [HBASE-17522] - RuntimeExceptions from MemoryMXBean should not take down server process
- [HBASE-17452] - Failed taking snapshot - region Manifest proto-message too large
- [HBASE-17309] - Fix connection leaks in TestAcidGuarantees
- [HBASE-16841] - Data loss in MOB files after cloning a snapshot and deleting that snapshot
- [HBASE-17072] - CPU usage starts to climb up to 90-100% when using G1GC; purge ThreadLocal usage
- [HBASE-15769] - Perform validation on cluster key for add_peer
- [HBASE-15393] - Enable table replication command will fail when parent znode is not default in peer cluster
- [HBASE-15324] - Jitter may cause desiredMaxFileSize overflow in ConstantSizeRegionSplitPolicy and trigger unexpected split
- [HBASE-15430] - Failed taking snapshot - Manifest proto-message too large
- [HBASE-16345] - RpcRetryingCallerWithReadReplicas#call() should catch some RegionServer Exceptions
- [HBASE-16172] - Unify the retry logic in ScannerCallableWithReplicas and RpcRetryingCallerWithReadReplicas
- [HBASE-16270] - Handle duplicate clearing of snapshot in region replicas
- [HBASE-16824] - Writer.flush() can be called on already closed streams in WAL roll
- [HBASE-16699] - Overflows in AverageIntervalRateLimiter's refill() and getWaitInterval()
- [HBASE-16767] - Mob compaction needs to clean up files in /hbase/mobdir/.tmp and /hbase/mobdir/.tmp/.bulkload when running into IO exceptions
- [HBASE-16294] - hbck reporting "No HDFS region dir found" for replicas
- [HBASE-15297] - error message is wrong when a wrong namspace is specified in grant in hbase shell
- [HBASE-15856] - Cached Connection instances can wind up with addresses never resolved
- [HBASE-16490] - Fix race condition between SnapshotManager and SnapshotCleaner
- [HBASE-16195] - Should not add chunk into chunkQueue if not using chunk pool in HeapMemStoreLAB
- [HBASE-16194] - Should count in MSLAB chunk allocation into heap size change when adding duplicate cells
- [HBASE-16464] - archive folder grows bigger and bigger due to corrupt snapshot under tmp dir
- [HBASE-16284] - Unauthorized client can shutdown the cluster
- [HBASE-16360] - TableMapReduceUtil addHBaseDependencyJars has the wrong class name for PrefixTreeCodec
- [HBASE-16135] - PeerClusterZnode under rs of removed peer may never be deleted
- [HBASE-16288] - HFile intermediate block level indexes might recurse forever creating multi TB files
- [HBASE-16096] - Replication keeps accumulating znodes
- [HBASE-16207] - can't restore snapshot without "Admin" permission
- [HBASE-16227] - [Shell] Column value formatter not working in scans
- [HBASE-14818] - user_permission does not list namespace permissions
- [HBASE-15465] - userPermission returned by getUserPermission() for the selected namespace does not have namespace set
- [HBASE-16093] - Splits failed before creating daughter regions leave meta inconsistent
- [HBASE-16035] - Nested AutoCloseables might not all get closed
- [HBASE-15891] - Closeable resources potentially not getting closed if exception is thrown
- [HBASE-14644] - Region in transition metric is broken
- [HBASE-15746] - Remove extra RegionCoprocessor preClose() in RSRpcServices#closeRegion
- [HBASE-15873] - ACL for snapshot restore / clone is not enforced
- [HBASE-15946] - Eliminate possible security concerns in RS web UI's store file metrics
- [HBASE-15925] - compat-module maven variable not evaluated
- [HBASE-15889] - String case conversions are locale-sensitive, used without locale
- [HBASE-15698] - Increment TimeRange not serialized to server
- [HBASE-15621] - Suppress Hbase SnapshotHFile cleaner error messages when a snaphot is going on
- [HBASE-11625] - Reading datablock throws "Invalid HFile block magic" and can not switch to hdfs checksum
- [HBASE-15236] - Inconsistent cell reads over multiple bulk-loaded HFiles
- [HBASE-15622] - Superusers does not consider the keytab credentials
- [HBASE-11403] - Fix race conditions around Object#notify
- [HBASE-15439] - getMaximumAllowedTimeBetweenRuns in ScheduledChore ignores the TimeUnit
- [HBASE-15707] - ImportTSV bulk output does not support tags with hfile.format.version=3
- [HBASE-15673] - [PE tool] Fix latency metrics for multiGet
- [HBASE-15405] - Synchronize final results logging single thread in PE, fix wrong defaults in help message
- [HBASE-15591] - ServerCrashProcedure not yielding
- [HBASE-15582] - SnapshotManifestV1 too verbose when there are no regions
- [HBASE-15234] - ReplicationLogCleaner can abort due to transient ZK issues
- [HBASE-15271] - Spark Bulk Load: Need to write HFiles to tmp location then rename to protect from Spark Executor Failures
- [HBASE-15184] - SparkSQL Scan operation doesn't work on kerberos cluster
- [HBASE-15310] - hbase-spark module has compilation failures with clover profile
- [HBASE-14991] - Fix the feature warning in scala code
- [HBASE-14894] - Fix misspellings of threshold in log4j.properties files for tests
- [HBASE-14406] - The dataframe datasource filter is wrong, and will result in data loss or unexpected behavior
- [HBASE-14377] - JavaHBaseContextSuite not being run
- [HBASE-12749] - Tighten HFileLink api to enable non-snapshot uses
- [HBASE-14302] - TableSnapshotInputFormat should not create back references when restoring snapshot
- [HBASE-6778] - Deprecate Chore; its a thread per task when we should have one thread to do all tasks
- [HBASE-14098] - Allow dropping caches behind compactions
- [HBASE-13737] - [HBase MOB] MOBTable cloned from a snapshot leads to data loss, when that actual snapshot and main table is deleted.
- [HBASE-13230] - [mob] reads hang when trying to read rows with large mobs (>10MB)
- [HBASE-12540] - TestRegionServerMetrics#testMobMetrics test failure
- [HBASE-12201] - Close the writers in the MOB sweep tool
- [HBASE-12030] - Wrong compaction report and assert when MOB compaction switches to minor
- [HBASE-12027] - The ZooKeeperWatcher in HMobStore only uses the default conf
- [HBASE-11968] - If MOB is enabled, it should make sure hfile v3 is being used.
- [HBASE-10018] - Remove region location prefetching
- [HBASE-10123] - Change default ports; move them out of linux ephemeral port range
- [HBASE-15095] - isReturnResult=false on fast path in branch-1.1 and branch-1.0 is not respected
Improvement
- [HBASE-18675] - Making {max,min}SessionTimeout configurable for MiniZooKeeperCluster
- [HBASE-17047] - Add an API to get HBase connection cache statistics
- [HBASE-16638] - Reduce the number of Connection's created in classes of hbase-spark module
- [HBASE-16351] - do dependency license check via enforcer plugin
- [HBASE-12770] - Don't transfer all the queued hlogs of a dead server to the same alive server
- [HBASE-18021] - Add more info in timed out RetriesExhaustedException for read replica client get processing,
- [HBASE-15720] - Print row locks at the debug dump page
- [HBASE-16033] - Add more details in logging of responseTooSlow/TooLarge
- [HBASE-16772] - Add verbose option to VerifyReplication for logging good rows
- [HBASE-16423] - Add re-compare option to VerifyReplication to avoid occasional inconsistent rows
- [HBASE-15837] - Memstore size accounting is wrong if postBatchMutate() throws exception
- [HBASE-16977] - VerifyReplication should log a printable representation of the row keys
- [HBASE-17731] - Fractional latency reporting in MultiThreadedAction
- [HBASE-17877] - Improve HBase's byte[] comparator
- [HBASE-15941] - HBCK repair should not unsplit healthy splitted region
- [HBASE-16052] - Improve HBaseFsck Scalability
- [HBASE-16561] - Add metrics about read/write/scan queue length and active read/write/scan handler count
- [HBASE-15353] - Add metric for number of CallQueueTooBigException's
- [HBASE-14983] - Create metrics for per block type hit/miss ratios
- [HBASE-16266] - Do not throw ScannerTimeoutException when catch UnknownScannerException
- [HBASE-17654] - RSGroup code refactoring
- [HBASE-15315] - Remove always set super user call as high priority
- [HBASE-17561] - table status page should escape values that may contain arbitrary characters.
- [HBASE-17409] - Re-fix XSS request issue in JMXJsonServlet
- [HBASE-17243] - Reuse CompactionPartitionId and avoid creating MobFileName in PartitionedMobCompactor to avoid unnecessary new objects
- [HBASE-17437] - Support specifying a WAL directory outside of the root directory
- [HBASE-17241] - Avoid compacting already compacted mob files with _del files
- [HBASE-12940] - Expose listPeerConfigs and getPeerConfig to the HBase shell
- [HBASE-15507] - Online modification of enabled ReplicationPeerConfig
- [HBASE-15396] - Enhance mapreduce.TableSplit to add encoded region name
- [HBASE-15526] - Make SnapshotManager accessible through MasterServices
- [HBASE-16450] - Shell tool to dump replication queues
- [HBASE-16379] - [replication] Minor improvement to replication/copy_tables_desc.rb
- [HBASE-15808] - Reduce potential bulk load intermediate space usage and waste
- [HBASE-14963] - Remove use of Guava Stopwatch from HBase client code
- [HBASE-16140] - bump owasp.esapi from 2.1.0 to 2.1.0.1
- [HBASE-15496] - Throw RowTooBigException only for user scan/get
- [HBASE-15663] - Hook up JvmPauseMonitor to ThriftServer
- [HBASE-15662] - Hook up JvmPauseMonitor to REST server
- [HBASE-15614] - Report metrics from JvmPauseMonitor
- [HBASE-15222] - Use less contended classes for metrics
- [HBASE-13532] - Make UnknownScannerException logging less scary
- [HBASE-15415] - Improve Master WebUI snapshot information
- [HBASE-15791] - Improve javadoc in ScheduledChore
- [HBASE-15456] - CreateTableProcedure/ModifyTableProcedure needs to fail when there is no family in table descriptor
- [HBASE-15479] - No more garbage or beware of autoboxing
- [HBASE-15413] - Procedure-V2: print out ProcedureInfo during trace
- [HBASE-15349] - Update surefire version to 2.19.1
- [HBASE-14719] - Add metric for number of MasterProcWALs
- [HBASE-12769] - Replication fails to delete all corresponding zk nodes when peer is removed
- [HBASE-15282] - Bump hbase-spark to use Spark 1.6.0
- [HBASE-15201] - Add hbase-spark to hbase assembly
- [HBASE-14159] - Resolve warning introduced by HBase-Spark module
- [HBASE-14796] - Enhance the Gets in the connector
- [HBASE-14795] - Enhance the spark-hbase scan operations
- [HBASE-14158] - Add documentation for Initial Release for HBase-Spark Module integration
- [HBASE-14515] - Allow spark module unit tests to be skipped with a profile
- [HBASE-14865] - Support passing multiple QOPs to SaslClient/Server via hbase.rpc.protection
- [HBASE-14684] - Try to remove all MiniMapReduceCluster in unit tests
- [HBASE-8329] - Limit compaction speed
- [HBASE-13109] - Make better SEEK vs SKIP decisions during scanning
- [HBASE-13670] - [HBase MOB] ExpiredMobFileCleaner tool deletes mob files later for one more day after they are expired
- [HBASE-10471] - Remove HTD.isAsyncLogFlush() from trunk
- [HBASE-12220] - Add hedgedReads and hedgedReadWins metrics
New Feature
- [HBASE-15780] - Expose AuthUtil as IA.Public
- [HBASE-16981] - Expand Mob Compaction Partition policy from daily to weekly, monthly
- [HBASE-6721] - RegionServer Group based Assignment
- [HBASE-12133] - Add FastLongHistogram for metric computation
- [HBASE-15481] - Add pre/post roll to WALObserver
- [HBASE-15592] - Print Procedure WAL content
- [HBASE-15036] - Update HBase Spark documentation to include bulk load with thin records
- [HBASE-14849] - Add option to set block cache to false on SparkSQL executions
- [HBASE-14340] - Add second bulk load option to Spark Bulk Load to send puts as the value
- [HBASE-14181] - Add Spark DataFrame DataSource to HBase-Spark Module
- [HBASE-14150] - Add BulkLoad functionality to HBase-Spark Module
- [HBASE-13992] - Integrate SparkOnHBase into HBase
- [HBASE-12363] - Improve how KEEP_DELETED_CELLS works with MIN_VERSIONS
Task
- [HBASE-18096] - Limit HFileUtil visibility and add missing annotations
- [HBASE-11393] - Replication TableCfs should be a PB object rather than a string
- [HBASE-16318] - fail build if license isn't in whitelist
- [HBASE-16340] - ensure no Xerces jars included
- [HBASE-16321] - Ensure findbugs jsr305 jar isn't present
- [HBASE-16317] - revert all ESAPI changes
- [HBASE-16056] - Procedure v2 - fix master crash for FileNotFound
- [HBASE-16034] - Fix ProcedureTestingUtility#LoadCounter.setMaxProcId()
- [HBASE-15872] - Split TestWALProcedureStore
- [HBASE-15113] - Procedure v2 - Speedup eviction of sys operation results
- [HBASE-15422] - Procedure v2 - Avoid double yield
- [HBASE-15144] - Procedure v2 - Web UI displaying Store state
- [HBASE-15142] - Procedure v2 - Basic WebUI listing the procedures
- [HBASE-5697] - Audit HBase for usage of deprecated hadoop 0.20.x property names.
Umbrella
- [HBASE-15354] - Use same criteria for clearing meta cache for all operations
- [HBASE-15691] - Port HBASE-10205 (ConcurrentModificationException in BucketAllocator) to branch-1
- [HBASE-15464] - Flush / Compaction metrics revisited
- [HBASE-15377] - Per-RS Get metric is time based, per-region metric is size-based
- [HBASE-15376] - ScanNext metric is size-based while every other per-operation metric is time based
- [HBASE-15435] - Add WAL (in bytes) written metric
- [HBASE-16146] - Counters are expensive...
- [HBASE-15683] - Min latency in latency histograms are emitted as Long.MAX_VALUE
- [HBASE-16023] - Fastpath for the FIFO rpcscheduler
- [HBASE-14447] - Spark tests failing: bind exception when putting up info server
- [HBASE-12015] - Not cleaning Mob data when Mob CF is removed from table
- [HBASE-11339] - HBase MOB
- [HBASE-12080] - Shorten the run time of integration test by default when using mvn failsafe:integration-test
- [HBASE-13932] - Add mob integrity check in HFilePrettyPrinter
- [HBASE-13886] - Return empty value when the mob file is corrupt instead of throwing exceptions
- [HBASE-13855] - Race in multi threaded PartitionedMobCompactor causes NPE
- [HBASE-13806] - Check the mob files when there are mob-enabled columns in HFileCorruptionChecker
- [HBASE-13531] - Flakey failures of TestAcidGuarantees#testMobScanAtomicity
- [HBASE-13313] - Skip the disabled table in mob compaction chore and MasterRpcServices
- [HBASE-13302] - fix new javadoc warns introduced by mob.
- [HBASE-13277] - add mob_threshold option to load test tool
- [HBASE-13151] - IllegalArgumentException in compaction when table has a namespace
- [HBASE-13107] - Refactor MOB Snapshot logic to reduce code duplication.
- [HBASE-13157] - Add mob compaction actions and monkeys to Chaos Monkey
- [HBASE-12332] - [mob] improve how we resolve mobfiles in reads
- [HBASE-13154] - Add support for mob in TestAcidGuarantees and IntegrationTestAcidGuarantees
- [HBASE-13152] - NPE in ExpiredMobFileCleanerChore
- [HBASE-12670] - Add unit tests that exercise the added hfilelink link mob paths
- [HBASE-13012] - Add shell commands to trigger the mob file compactor
- [HBASE-13117] - improve mob sweeper javadoc
- [HBASE-13013] - Add read lock to ExpiredMobFileCleanerChore
- [HBASE-11861] - Native MOB Compaction mechanisms.
- [HBASE-12820] - Use table lock instead of MobZookeeper
- [HBASE-12669] - Have compaction scanner save info about delete markers
- [HBASE-12698] - Add mob cell count to the metadata of each mob file
- [HBASE-12691] - sweep job needs to exit non-zero if job fails for any reason.
- [HBASE-12543] - Incorrect log info in the store compaction of mob
- [HBASE-12331] - Shorten the mob snapshot unit tests
- [HBASE-12758] - treat mob region as any other region when generating rs manifest.
- [HBASE-12646] - SnapshotInfo tool does not find mob data in snapshots
- [HBASE-11645] - Snapshot for MOB
- [HBASE-12487] - Explicitly flush the file name in sweep job
- [HBASE-12591] - Ignore the count of mob compaction metrics when there is issue
- [HBASE-12489] - Incorrect 'mobFileCacheMissCount' calculated in the mob metrics
- [HBASE-12391] - Correct a typo in the mob metrics
- [HBASE-11683] - Metrics for MOB
- [HBASE-12486] - Move the mob table name tag to the 2nd one
- [HBASE-12392] - Incorrect implementation of CompactionRequest.isRetainDeleteMarkers
- [HBASE-12093] - Support the mob attributes in hbase shell when create/alter table
- [HBASE-12085] - mob status should print human readable numbers.
- [HBASE-12066] - Avoid major compaction in TestMobSweeper
- [HBASE-11644] - External MOB compaction tools
- [HBASE-11646] - Handle the MOB in compaction
- [HBASE-12000] - isMob and mobThreshold do not follow column descriptor property naming conventions
- [HBASE-11647] - MOB integration testing
- [HBASE-11901] - Improve the value size of the reference cell in mob column
- [HBASE-11643] - Read and write MOB in HBase
- [HBASE-12046] - HTD/HCD setters should be builder-style