Release Notes - HBase - Version 1.2.0 - HTML format

Sub-task

  • [HBASE-12748] - RegionCoprocessorHost.execOperation creates too many iterator objects
  • [HBASE-13393] - Optimize memstore flushing to avoid writing tag information to hfiles when no tags are present.
  • [HBASE-13415] - Procedure V2 - Use nonces for double submits from client
  • [HBASE-13470] - High level Integration test for master DDL operations
  • [HBASE-13476] - Procedure V2 - Add Replay Order logic for child procedures
  • [HBASE-13497] - Remove MVCC stamps from HFile when that is safe
  • [HBASE-13536] - Cleanup the handlers that are no longer being used.
  • [HBASE-13563] - Add missing table owner to AC tests.
  • [HBASE-13569] - correct errors reported with mvn site
  • [HBASE-13579] - Avoid isCellTTLExpired() for NO-TAG cases
  • [HBASE-13593] - Quota support for namespace should take snapshot restore and clone into account
  • [HBASE-13616] - Move ServerShutdownHandler to Pv2
  • [HBASE-13658] - Improve the test run time for TestAccessController class
  • [HBASE-13748] - ensure post-commit builds for branch-1 include both java 7 and java 8
  • [HBASE-13750] - set up jenkins builds that run branch-1 ITs with java 8
  • [HBASE-13759] - Improve procedure yielding
  • [HBASE-13832] - Procedure V2: master fail to start due to WALProcedureStore sync failures when HDFS data nodes count is low
  • [HBASE-13898] - correct additional javadoc failures under java 8
  • [HBASE-13899] - Jacoco instrumentation fails under jdk8
  • [HBASE-13912] - add branch-1.2 post-commit builds
  • [HBASE-13920] - Exclude Java files generated from protobuf from javadoc
  • [HBASE-13937] - Partially revert HBASE-13172
  • [HBASE-13950] - Add a NoopProcedureStore for testing
  • [HBASE-13963] - avoid leaking jdk.tools
  • [HBASE-13967] - add jdk profiles for jdk.tools dependency
  • [HBASE-13973] - Update documentation for 10070 Phase 2 changes
  • [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-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-14025] - Update CHANGES.txt for 1.2
  • [HBASE-14086] - remove unused bundled dependencies
  • [HBASE-14087] - ensure correct ASF policy compliant headers on source/docs
  • [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-14147] - REST Support for Namespaces
  • [HBASE-14176] - Add missing headers to META-INF files
  • [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-14378] - Get TestAccessController* passing again on branch-1
  • [HBASE-14401] - Stamp failed appends with sequenceid too.... Cleans up latches
  • [HBASE-14421] - TestFastFail* are flakey
  • [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-14465] - Backport 'Allow rowlock to be reader/write' to branch-1
  • [HBASE-14472] - TestHCM and TestRegionServerNoMaster fixes
  • [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-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-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-14571] - Purge TestProcessBasedCluster; it does nothing and then fails
  • [HBASE-14572] - TestImportExport#testImport94Table can't find its src data file
  • [HBASE-14585] - Clean up TestSnapshotCloneIndependence
  • [HBASE-14596] - TestCellACLs failing... on1.2 builds
  • [HBASE-14600] - Make #testWalRollOnLowReplication looser still
  • [HBASE-14605] - Split fails due to 'No valid credentials' error when SecureBulkLoadEndpoint#start tries to access hdfs
  • [HBASE-14622] - Purge TestZkLess* tests from branch-1
  • [HBASE-14631] - Region merge request should be audited with request user through proper scope of doAs() calls to region observer notifications
  • [HBASE-14637] - Loosen TestChoreService assert AND have TestDataBlockEncoders do less work (and add timeouts)
  • [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-14656] - Move TestAssignmentManager from medium to large category
  • [HBASE-14657] - Remove unneeded API from EncodedSeeker
  • [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-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-14837] - Procedure V2 - Procedure Queue Improvement
  • [HBASE-14863] - Add missing test/resources/log4j files in hbase modules
  • [HBASE-14883] - TestSplitTransactionOnCluster#testFailedSplit flakey
  • [HBASE-14908] - TestRowCounter flakey especially on branch-1
  • [HBASE-14909] - NPE testing for RIT
  • [HBASE-14915] - Hanging test : org.apache.hadoop.hbase.mapreduce.TestImportExport
  • [HBASE-14947] - Procedure V2 - WALProcedureStore improvements
  • [HBASE-14962] - TestSplitWalDataLoss fails on all branches
  • [HBASE-15023] - Reenable TestShell and TestStochasticLoadBalancer
  • [HBASE-15087] - Fix hbase-common findbugs complaints
  • [HBASE-15091] - Forward-port to 1.2+ HBASE-15031 "Fix merge of MVCC and SequenceID performance regression in branch-1.0 for Increments"
  • [HBASE-15106] - Procedure V2 - Procedure Queue pass Procedure for better debuggability
  • [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-15157] - Add *PerformanceTest for Append, CheckAnd*
  • [HBASE-15210] - Undo aggressive load balancer logging at tens of lines per millisecond
  • [HBASE-15224] - Undo "hbase.increment.fast.but.narrow.consistency" option; it is not necessary since HBASE-15213
  • [HBASE-15238] - HFileReaderV2 prefetch overreaches; runs off the end of the data
  • [HBASE-15263] - TestIPv6NIOServerSocketChannel.testServerSocketFromLocalhostResolution can hang indefinetly
  • [HBASE-15270] - Use appropriate encoding for "filter" field in TaskMonitorTmpl.jamon
  • [HBASE-16180] - Fix ST_WRITE_TO_STATIC_FROM_INSTANCE_METHOD findbugs introduced by parent

Bug

  • [HBASE-5878] - Use getVisibleLength public api from HdfsDataInputStream from Hadoop-2.
  • [HBASE-10844] - Coprocessor failure during batchmutation leaves the memstore datastructs in an inconsistent state
  • [HBASE-11658] - Piped commands to hbase shell should return non-zero if shell command failed.
  • [HBASE-11830] - TestReplicationThrottler.testThrottling failed on virtual boxes
  • [HBASE-12413] - Mismatch in the equals and hashcode methods of KeyValue
  • [HBASE-12865] - WALs may be deleted before they are replicated to peers
  • [HBASE-13143] - TestCacheOnWrite is flaky and needs a diet
  • [HBASE-13200] - Improper configuration can leads to endless lease recovery during failover
  • [HBASE-13217] - Procedure fails due to ZK issue
  • [HBASE-13250] - chown of ExportSnapshot does not cover all path and files
  • [HBASE-13312] - SmallScannerCallable does not increment scan metrics
  • [HBASE-13318] - RpcServer.getListenerAddress should handle when the accept channel is closed
  • [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-13329] - ArrayIndexOutOfBoundsException in CellComparator#getMinimumMidpointArray
  • [HBASE-13330] - Region left unassigned due to AM & SSH each thinking the assignment would be done by the other
  • [HBASE-13333] - Renew Scanner Lease without advancing the RegionScanner
  • [HBASE-13337] - Table regions are not assigning back, after restarting all regionservers at once.
  • [HBASE-13352] - Add hbase.import.version to Import usage.
  • [HBASE-13377] - Canary may generate false alarm on the first region when there are many delete markers
  • [HBASE-13411] - Misleading error message when request size quota limit exceeds
  • [HBASE-13480] - ShortCircuitConnection doesn't short-circuit all calls as expected
  • [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-13576] - HBCK enhancement: Failure in checking one region should not fail the entire HBCK operation.
  • [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-13626] - ZKTableStateManager logs table state changes at WARN
  • [HBASE-13632] - Backport HBASE-13368 to branch-1 and 0.98
  • [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-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-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-13664] - Use HBase 1.0 interfaces in ConnectionCache
  • [HBASE-13668] - TestFlushRegionEntry is flaky
  • [HBASE-13686] - Fail to limit rate in RateLimiter
  • [HBASE-13694] - CallQueueSize is incorrectly decremented until the response is sent
  • [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-13712] - Backport HBASE-13199 to branch-1
  • [HBASE-13717] - TestBoundedRegionGroupingProvider#setMembershipDedups need to set HDFS diretory for WAL
  • [HBASE-13721] - Improve shell scan performances when using LIMIT
  • [HBASE-13723] - In table.rb scanners are never closed.
  • [HBASE-13727] - Codehaus repository is out of service
  • [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-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-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-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-13810] - Table is left unclosed in VerifyReplication#Verifier
  • [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-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-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-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-13865] - Increase the default value for hbase.hregion.memstore.block.multipler from 2 to 4 (part 2)
  • [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-13881] - Bug in HTable#incrementColumnValue implementation
  • [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-13895] - DATALOSS: Region assigned before WAL replay when abort
  • [HBASE-13901] - Error while calling watcher on creating and deleting an HBase table
  • [HBASE-13904] - TestAssignmentManager.testBalanceOnMasterFailoverScenarioWithOfflineNode failing consistently on branch-1.1
  • [HBASE-13905] - TestRecoveredEdits.testReplayWorksThoughLotsOfFlushing failing consistently on branch-1.1
  • [HBASE-13906] - Improve handling of NeedUnmanagedConnectionException
  • [HBASE-13918] - Fix hbase:namespace description in webUI
  • [HBASE-13923] - Loaded region coprocessors are not reported in shell status command
  • [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-13935] - Orphaned namespace table ZK node should not prevent master to start
  • [HBASE-13938] - Deletes done during the region merge transaction may get eclipsed
  • [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-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-14005] - Set permission to .top hfile in LoadIncrementalHFiles
  • [HBASE-14010] - TestRegionRebalancing.testRebalanceOnRegionServerNumberChange fails; cluster not balanced
  • [HBASE-14012] - Double Assignment and Dataloss when ServerCrashProcedure runs during Master failover
  • [HBASE-14021] - Quota table has a wrong description on the UI
  • [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-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-14098] - Allow dropping caches behind compactions
  • [HBASE-14100] - Fix high priority findbugs warnings
  • [HBASE-14106] - TestProcedureRecovery is flaky
  • [HBASE-14109] - NPE if we don't load fully before we are shutdown
  • [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-14157] - Interfaces implemented by subclasses should be checked when registering CoprocessorService
  • [HBASE-14166] - Per-Region metrics can be stale
  • [HBASE-14168] - Avoid useless retry for DoNotRetryIOException in TableRecordReaderImpl
  • [HBASE-14178] - regionserver blocks because of waiting for offsetLock
  • [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-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-14238] - Branch-1.2 AM issues
  • [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-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-14287] - Bootstrapping a cluster leaves temporary WAL directory laying around
  • [HBASE-14291] - NPE On StochasticLoadBalancer Balance Involving RS With No Regions
  • [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-14327] - TestIOFencing#testFencingAroundCompactionAfterWALSync is flaky
  • [HBASE-14338] - License notification misspells 'Asciidoctor'
  • [HBASE-14342] - Recursive call in RegionMergeTransactionImpl.getJournal()
  • [HBASE-14343] - Fix debug message in SimpleRegionNormalizer for small regions
  • [HBASE-14347] - Add a switch to DynamicClassLoader to disable it
  • [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-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-14407] - NotServingRegion: hbase region closed forever
  • [HBASE-14425] - In Secure Zookeeper cluster superuser will not have sufficient permission if multiple values are configured in "hbase.superuser"
  • [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-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-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-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-14531] - graceful_stop.sh "if [ "$local" ]" condition unexpected behaviour
  • [HBASE-14536] - Balancer & SSH interfering with each other leading to unavailability
  • [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-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-14658] - Allow loading a MonkeyFactory by class name
  • [HBASE-14661] - RegionServer link is not opening, in HBase Table page.
  • [HBASE-14663] - HStore::close does not honor config hbase.rs.evictblocksonclose
  • [HBASE-14667] - HBaseFsck constructors have diverged
  • [HBASE-14674] - Rpc handler / task monitoring seems to be broken after 0.98
  • [HBASE-14680] - Two configs for snapshot timeout and better defaults
  • [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-14705] - Javadoc for KeyValue constructor is not correct.
  • [HBASE-14706] - RegionLocationFinder should return multiple servernames by top host
  • [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-14742] - TestHeapMemoryManager is flakey
  • [HBASE-14745] - Shade the last few dependencies in hbase-shaded-client
  • [HBASE-14754] - TestFastFailWithoutTestUtil failing on trunk now in #testPreemptiveFastFailException50Times
  • [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-14768] - bin/graceful_stop.sh logs nothing as a balancer state to be stored
  • [HBASE-14771] - RpcServer#getRemoteAddress always returns null
  • [HBASE-14773] - Fix HBase shell tests are skipped when skipping server tests.
  • [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-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-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-14812] - Fix ResultBoundedCompletionService deadlock
  • [HBASE-14822] - Renewing leases of scanners doesn't work
  • [HBASE-14824] - HBaseAdmin.mergeRegions should recognize both full region names and encoded region names
  • [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-14867] - SimpleRegionNormalizer needs to have better heuristics to trigger merge operation
  • [HBASE-14872] - Scan different timeRange per column family doesn't percolate down to the memstore
  • [HBASE-14875] - Forward port HBASE-14207 'Region was hijacked and remained in transition when RS failed to open a region and later regionplan changed to new RS on retry'
  • [HBASE-14885] - NullPointerException in HMaster#normalizeRegions() due to missing TableDescriptor
  • [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-14904] - Mark Base[En|De]coder LimitedPrivate and fix binary compat issue
  • [HBASE-14905] - VerifyReplication does not honour versions option
  • [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-14965] - Remove un-used hbase-spark in branch-1 +
  • [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-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-14989] - Implementation of Mutation.getWriteToWAL() is backwards
  • [HBASE-14999] - Remove ref to org.mortbay.log.Log
  • [HBASE-15001] - Thread Safety issues in ReplicationSinkManager and HBaseInterClusterReplicationEndpoint
  • [HBASE-15009] - Update test-patch.sh on branches; to fix curtailed build report
  • [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-15021] - hadoopqa doing false positives
  • [HBASE-15022] - undefined method `getZooKeeperClusterKey' for Java::OrgApacheHadoopHbaseZookeeper::ZKUtil:Class
  • [HBASE-15032] - hbase shell scan filter string assumes UTF-8 encoding
  • [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-15052] - Use EnvironmentEdgeManager in ReplicationSource
  • [HBASE-15057] - local-master-backup.sh doesn't start HMaster correctly
  • [HBASE-15058] - AssignmentManager should account for unsuccessful split correctly which initially passes quota check
  • [HBASE-15065] - SimpleRegionNormalizer should return multiple normalization plans in one run
  • [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-15098] - Normalizer switch in configuration is not used
  • [HBASE-15100] - Master WALProcs still never clean up
  • [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-15122] - Servlets generate XSS_REQUEST_PARAMETER_TO_SERVLET_WRITER findbugs warnings
  • [HBASE-15133] - Data loss after compaction when a row has more than Integer.MAX_VALUE columns
  • [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-15190] - Monkey dies when running on shared cluster (gives up when can't kill the other fellows processes)
  • [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-15252] - Data loss when replaying wal if HDFS timeout
  • [HBASE-15279] - OrderedBytes.isEncodedValue does not check for int8 and int16 types
  • [HBASE-15283] - Revert to IOException in TimeRange constructor to maintain API compat in 1.x line
  • [HBASE-15285] - Forward-port respect for isReturnResult from HBASE-15095

New Feature

  • [HBASE-5980] - Scanner responses from RS should include metrics on rows/KVs filtered
  • [HBASE-10070] - HBase read high-availability using timeline-consistent region replicas
  • [HBASE-12911] - Client-side metrics
  • [HBASE-13356] - HBase should provide an InputFormat supporting multiple scans in mapreduce jobs over snapshots
  • [HBASE-13639] - SyncTable - rsync for HBase tables
  • [HBASE-13698] - Add RegionLocator methods to Thrift2 proxy.
  • [HBASE-14154] - DFS Replication should be configurable at column family level
  • [HBASE-14355] - Scan different TimeRange for each column family
  • [HBASE-14459] - Add request and response sizes metrics
  • [HBASE-14529] - Respond to SIGHUP to reload config

Improvement

  • [HBASE-6617] - ReplicationSourceManager should be able to track multiple WAL paths
  • [HBASE-7171] - Initial web UI for region/memstore/storefiles details
  • [HBASE-11927] - Use Native Hadoop Library for HFile checksum (And flip default from CRC32 to CRC32C)
  • [HBASE-12415] - Add add(byte[][] arrays) to Bytes.
  • [HBASE-12986] - Compaction pressure based client pushback
  • [HBASE-12988] - [Replication]Parallel apply edits across regions
  • [HBASE-13103] - [ergonomics] add region size balancing as a feature of master
  • [HBASE-13127] - Add timeouts on all tests so less zombie sightings
  • [HBASE-13247] - Change BufferedMutatorExample to use addColumn() since add() is deprecated
  • [HBASE-13344] - Add enforcer rule that matches our JDK support statement
  • [HBASE-13358] - Upgrade VisibilityClient API to accept Connection object.
  • [HBASE-13366] - Throw DoNotRetryIOException instead of read only IOException
  • [HBASE-13375] - Provide HBase superuser higher priority over other users in the RPC handling
  • [HBASE-13376] - Improvements to Stochastic load balancer
  • [HBASE-13420] - RegionEnvironment.offerExecutionLatency Blocks Threads under Heavy Load
  • [HBASE-13534] - Change HBase master WebUI to explicitly mention if it is a backup master
  • [HBASE-13598] - Make hbase assembly 'attach' to the project
  • [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-13710] - Remove use of Hadoop's ReflectionUtil in favor of our own.
  • [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-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-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-13947] - Use MasterServices instead of Server in AssignmentManager
  • [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-14002] - Add --noReplicationSetup option to IntegrationTestReplication
  • [HBASE-14015] - Allow setting a richer state value when toString a pv2
  • [HBASE-14027] - Clean up netty dependencies
  • [HBASE-14058] - Stabilizing default heap memory tuner
  • [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-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-14172] - Upgrade existing thrift binding using thrift 0.9.3 compiler.
  • [HBASE-14194] - Undeprecate methods in ThriftServerRunner.HBaseHandler
  • [HBASE-14203] - remove duplicate code getTableDescriptor in HTable
  • [HBASE-14230] - replace reflection in FSHlog with HdfsDataOutputStream#getCurrentBlockReplication()
  • [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-14314] - Metrics for block cache should take region replicas into account
  • [HBASE-14325] - Add snapshotinfo command to hbase script
  • [HBASE-14334] - Move Memcached block cache in to it's own optional module.
  • [HBASE-14387] - Compaction improvements: Maximum off-peak compaction size
  • [HBASE-14436] - HTableDescriptor#addCoprocessor will always make RegionCoprocessorHost create new Configuration
  • [HBASE-14461] - Cleanup IncreasingToUpperBoundRegionSplitPolicy
  • [HBASE-14468] - Compaction improvements: FIFO compaction policy
  • [HBASE-14517] - Show regionserver's version in master status page
  • [HBASE-14547] - Add more debug/trace to zk-procedure
  • [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-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-14708] - Use copy on write Map for region location cache
  • [HBASE-14714] - some cleanup to snapshot code
  • [HBASE-14715] - Add javadocs to DelegatingRetryingCallable
  • [HBASE-14721] - Memstore add cells - Avoid many garbage
  • [HBASE-14730] - region server needs to log warnings when there are attributes configured for cells with hfile v2
  • [HBASE-14752] - Add example of using the HBase client in a multi-threaded environment
  • [HBASE-14765] - Remove snappy profile
  • [HBASE-14780] - Integration Tests that run with ChaosMonkey need to specify CFs
  • [HBASE-14805] - status should show the master in shell
  • [HBASE-14821] - CopyTable should allow overriding more config properties for peer cluster
  • [HBASE-14862] - Add support for reporting p90 for histogram metrics
  • [HBASE-14866] - VerifyReplication should use peer configuration in peer connection
  • [HBASE-14891] - Add log for uncaught exception in RegionServerMetricsWrapperRunnable
  • [HBASE-14946] - Don't allow multi's to over run the max result size.
  • [HBASE-14951] - Make hbase.regionserver.maxlogs obsolete
  • [HBASE-14976] - Add RPC call queues to the web ui
  • [HBASE-14978] - Don't allow Multi to retain too many blocks
  • [HBASE-14984] - Allow memcached block cache to set optimze to false
  • [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-15076] - Add getScanner(Scan scan, List<KeyValueScanner> additionalScanners) API into Region interface
  • [HBASE-15111] - "hbase version" should write to stdout
  • [HBASE-15129] - Set default value for hbase.fs.tmp.dir rather than fully depend on hbase-default.xml
  • [HBASE-15211] - Don't run the CatalogJanitor if there are regions in transition
  • [HBASE-15229] - Canary Tools should not call System.Exit on error

Test

  • [HBASE-13590] - TestEnableTableHandler.testEnableTableWithNoRegionServers is flakey
  • [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-14210] - Create test for cell level ACLs involving user group
  • [HBASE-14277] - TestRegionServerHostname.testRegionServerHostname may fail at host with a case sensitive name
  • [HBASE-14344] - Add timeouts to TestHttpServerLifecycle
  • [HBASE-14584] - TestNamespacesInstanceModel fails on jdk8
  • [HBASE-14758] - Add UT case for unchecked error/exception thrown in AsyncProcess#sendMultiAction
  • [HBASE-14839] - [branch-1] Backport test categories so that patch backport is easier

Task

  • [HBASE-11276] - Add back support for running ChaosMonkey as standalone tool
  • [HBASE-11677] - Make Logger instance modifiers consistent
  • [HBASE-13089] - Fix test compilation error on building against htrace-3.2.0-incubating
  • [HBASE-13666] - book.pdf is not renamed during site build
  • [HBASE-13716] - Stop using Hadoop's FSConstants
  • [HBASE-13726] - stop using Hadoop's IOUtils
  • [HBASE-13764] - Backport HBASE-7782 (HBaseTestingUtility.truncateTable() not acting like CLI) to branch-1.x
  • [HBASE-13799] - javadoc how Scan gets polluted when used; if you set attributes or ask for scan metrics
  • [HBASE-13929] - make_rc.sh publishes empty shaded artifacts
  • [HBASE-13964] - Skip region normalization for tables under namespace quota
  • [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-14066] - clean out old docbook docs from branch-1
  • [HBASE-14085] - Correct LICENSE and NOTICE files in artifacts
  • [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-14361] - ReplicationSink should create Connection instances lazily
  • [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-14678] - Experiment: Temporarily disable balancer and a few others to see if root of crashed/timedout JVMs
  • [HBASE-14851] - Add test showing how to use TTL from thrift
  • [HBASE-15003] - Remove BoundedConcurrentLinkedQueue and associated test
  • [HBASE-15099] - Move RegionStateListener class out of quotas package
  • [HBASE-15220] - Change two logs in SimpleRegionNormalizer to INFO level

Brainstorming

  • [HBASE-14869] - Better request latency and size histograms

Umbrella

  • [HBASE-13747] - Promote Java 8 to "yes" in support matrix
  • [HBASE-13908] - 1.2 release umbrella
  • [HBASE-14420] - Zombie Stomping Session
  • [HBASE-14460] - [Perf Regression] Merge of MVCC and SequenceId (HBASE-8763) slowed Increments, CheckAndPuts, batch operations

Edit/Copy Release Notes

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