Release Notes - HBase - Version 1.4.0 - HTML format

Sub-task

  • [HBASE-12148] - Remove TimeRangeTracker as point of contention when many threads writing a Store
  • [HBASE-15160] - Put back HFile's HDFS op latency sampling code and add metrics for monitoring
  • [HBASE-15342] - create branch-1.3 and update branch-1 poms to 1.4.0-SNAPSHOT
  • [HBASE-15386] - PREFETCH_BLOCKS_ON_OPEN in HColumnDescriptor is ignored
  • [HBASE-15484] - Correct the semantic of batch and partial
  • [HBASE-15662] - Hook up JvmPauseMonitor to REST server
  • [HBASE-15663] - Hook up JvmPauseMonitor to ThriftServer
  • [HBASE-15675] - Add more details about region on table.jsp
  • [HBASE-15691] - Port HBASE-10205 (ConcurrentModificationException in BucketAllocator) to branch-1
  • [HBASE-15927] - Remove HMaster.assignRegion()
  • [HBASE-15994] - Allow selection of RpcSchedulers
  • [HBASE-15995] - Separate replication WAL reading from shipping
  • [HBASE-16092] - Procedure v2 - complete child procedure support
  • [HBASE-16236] - Typo in javadoc of InstancePending
  • [HBASE-16242] - Upgrade Avro to 1.7.7
  • [HBASE-16280] - Use hash based map in SequenceIdAccounting
  • [HBASE-16311] - Audit log for delete snapshot operation is missing in case of snapshot owner deleting the same
  • [HBASE-16336] - Removing peers seems to be leaving spare queues
  • [HBASE-16398] - optimize HRegion computeHDFSBlocksDistribution
  • [HBASE-16451] - Procedure v2 - Test WAL protobuf entry size limit
  • [HBASE-16505] - Save deadline in RpcCallContext according to request's timeout
  • [HBASE-16530] - Reduce DBE code duplication
  • [HBASE-16533] - Procedure v2 - Extract chore from the executor
  • [HBASE-16570] - Compute region locality in parallel at startup
  • [HBASE-17167] - Pass mvcc to client when scan
  • [HBASE-17210] - Set timeout on trying rowlock according to client's RPC timeout
  • [HBASE-17508] - Unify the implementation of small scan and regular scan for sync client
  • [HBASE-17561] - table status page should escape values that may contain arbitrary characters.
  • [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-17595] - Add partial result support for small/limited scan
  • [HBASE-17599] - Use mayHaveMoreCellsInRow instead of isPartial
  • [HBASE-17793] - Backport ScanResultCache related code to branch-1
  • [HBASE-17887] - Row-level consistency is broken for read
  • [HBASE-17925] - mvn assembly:single fails against hadoop3-alpha2
  • [HBASE-18268] - Eliminate the findbugs warnings for hbase-client
  • [HBASE-18293] - Only add the spotbugs dependency when jdk8 is active
  • [HBASE-18295] - The result contains the cells across different rows
  • [HBASE-18308] - Eliminate the findbugs warnings for hbase-server
  • [HBASE-18315] - Eliminate the findbugs warnings for hbase-rest
  • [HBASE-18365] - Eliminate the findbugs warnings for hbase-common
  • [HBASE-18398] - Snapshot operation fails with FileNotFoundException
  • [HBASE-18448] - EndPoint example for refreshing HFiles for stores
  • [HBASE-18458] - Refactor TestRegionServerHostname to make it robust (Port HBASE-17922 to branch-1)
  • [HBASE-18552] - Backport the server side change in HBASE-18489 to branch-1
  • [HBASE-18656] - Address issues found by error-prone in hbase-common
  • [HBASE-18786] - FileNotFoundException should not be silently handled for primary region replicas
  • [HBASE-18867] - maven enforcer plugin needs update to work with jdk9
  • [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-18980] - Address issues found by error-prone in hbase-hadoop2-compat
  • [HBASE-19070] - temporarily make the mvnsite nightly test non-voting.
  • [HBASE-19113] - Restore dropped constants from TableInputFormatBase for compatibility
  • [HBASE-19131] - Add the ClusterStatus hook and cleanup other hooks which can be replaced by ClusterStatus hook
  • [HBASE-19182] - Add deprecation in branch-1 for hbase-prefix-tree so some heads up it removed in hbase2
  • [HBASE-19203] - Update Hadoop version used for build to 2.7.4
  • [HBASE-19205] - Backport HBASE-18441 ZookeeperWatcher#interruptedException should throw exception
  • [HBASE-19243] - Start mini cluster once before class for TestFIFOCompactionPolicy
  • [HBASE-19276] - RegionPlan should correctly implement equals and hashCode
  • [HBASE-19348] - Fix error-prone errors for branch-1
  • [HBASE-19354] - [branch-1] Build using a jdk that is beyond ubuntu trusty's openjdk-151
  • [HBASE-19366] - Backport to branch-1 HBASE-19035 Miss metrics when coprocessor use region scanner to read data
  • [HBASE-19368] - [nightly] Make xml test non-voting in branch-1.2
  • [HBASE-19373] - Fix Checkstyle error in hbase-annotations

Bug

  • [HBASE-7621] - REST client (RemoteHTable) doesn't support binary row keys
  • [HBASE-8758] - Error in RegionCoprocessorHost class preScanner method documentation.
  • [HBASE-9393] - Region Server fails to properly close socket resulting in many CLOSE_WAIT to Data Nodes
  • [HBASE-12088] - Remove un-used profiles in non-root poms
  • [HBASE-12091] - Optionally ignore edits for dropped tables for replication.
  • [HBASE-12949] - Scanner can be stuck in infinite loop if the HFile is corrupted
  • [HBASE-14329] - Report region in transition only ever operates on one region
  • [HBASE-14499] - Master coprocessors shutdown will not happen on master abort
  • [HBASE-14753] - TestShell is not invoked anymore
  • [HBASE-15109] - HM/RS failed to start when "fs.hdfs.impl.disable.cache" is set to true
  • [HBASE-15187] - Integrate CSRF prevention filter to REST gateway
  • [HBASE-15236] - Inconsistent cell reads over multiple bulk-loaded HFiles
  • [HBASE-15302] - Reenable the other tests disabled by HBASE-14678
  • [HBASE-15328] - Unvalidated Redirect in HMaster
  • [HBASE-15497] - Incorrect javadoc for atomicity guarantee of Increment and Append
  • [HBASE-15528] - Clean up outdated entries in hbase-default.xml
  • [HBASE-15548] - SyncTable: sourceHashDir is supposed to be optional but won't work without
  • [HBASE-15635] - Mean age of Blocks in cache (seconds) on webUI should be greater than zero
  • [HBASE-15711] - Add client side property to allow logging details for batch errors
  • [HBASE-15725] - make_patch.sh should add the branch name when -b is passed.
  • [HBASE-15769] - Perform validation on cluster key for add_peer
  • [HBASE-15783] - AccessControlConstants#OP_ATTRIBUTE_ACL_STRATEGY_CELL_FIRST not used any more.
  • [HBASE-15803] - ZooKeeperWatcher's constructor can leak a ZooKeeper instance with throwing ZooKeeperConnectionException when canCreateBaseZNode is true
  • [HBASE-15815] - Region mover script sometimes reports stuck region where only one server was involved
  • [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-15866] - Split hbase.rpc.timeout into *.read.timeout and *.write.timeout
  • [HBASE-15889] - String case conversions are locale-sensitive, used without locale
  • [HBASE-15933] - NullPointerException may be thrown from SimpleRegionNormalizer#getRegionSize()
  • [HBASE-15947] - Classes used only for tests included in main code base
  • [HBASE-15950] - Fix memstore size estimates to be more tighter
  • [HBASE-15965] - Shell test changes. Use @shell.command instead directly calling functions in admin.rb and other libraries.
  • [HBASE-15990] - The priority value of subsequent coprocessors in the Coprocessor.Priority.SYSTEM list are not incremented by one
  • [HBASE-16011] - TableSnapshotScanner and TableSnapshotInputFormat can produce duplicate rows
  • [HBASE-16045] - endtime argument for VerifyReplication was incorrectly specified in usage
  • [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-16070] - Mapreduce Serialization classes do not have Interface audience
  • [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-16118] - TestHFileOutputFormat2 is broken
  • [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-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-16172] - Unify the retry logic in ScannerCallableWithReplicas and RpcRetryingCallerWithReadReplicas
  • [HBASE-16182] - Increase IntegrationTestRpcClient timeout
  • [HBASE-16209] - Provide an ExponentialBackOffPolicy sleep between failed region open requests
  • [HBASE-16235] - TestSnapshotFromMaster#testSnapshotHFileArchiving will fail if there are too many hfiles
  • [HBASE-16244] - LocalHBaseCluster start timeout should be configurable
  • [HBASE-16293] - TestSnapshotFromMaster#testSnapshotHFileArchiving flakey
  • [HBASE-16309] - TestDefaultCompactSelection.testCompactionRatio is flaky
  • [HBASE-16345] - RpcRetryingCallerWithReadReplicas#call() should catch some RegionServer Exceptions
  • [HBASE-16353] - Deprecate / Remove Get.isClosestRowBefore()
  • [HBASE-16356] - REST API scanner: row prefix filter and custom filter parameters are mutually exclusive
  • [HBASE-16359] - NullPointerException in RSRpcServices.openRegion()
  • [HBASE-16367] - Race between master and region server initialization may lead to premature server abort
  • [HBASE-16377] - ServerName check is ineffective in region_mover.rb
  • [HBASE-16409] - Row key for bad row should be properly delimited in VerifyReplication
  • [HBASE-16444] - CellUtil#estimatedSerializedSizeOfKey() should consider KEY_INFRASTRUCTURE_SIZE
  • [HBASE-16495] - When accessed via Thrift, all column families have timeToLive equal to -1
  • [HBASE-16515] - AsyncProcess has incorrent count of tasks if the backoff policy is enabled
  • [HBASE-16538] - Version mismatch in HBaseConfiguration.checkDefaultsVersion
  • [HBASE-16540] - Scan should do additional validation on start and stop row
  • [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-16611] - Flakey org.apache.hadoop.hbase.client.TestReplicasClient.testCancelOfMultiGet
  • [HBASE-16612] - Use array to cache Types for KeyValue.Type.codeToType
  • [HBASE-16615] - Fix flaky TestScannerHeartbeatMessages
  • [HBASE-16621] - HBCK should have -fixHFileLinks
  • [HBASE-16630] - Fragmentation in long running Bucket Cache
  • [HBASE-16647] - hbck should do offline reference repair before online repair
  • [HBASE-16653] - Backport HBASE-11393 to all branches which support namespace
  • [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-16716] - OfflineMetaRepair leaves empty directory inside /hbase/WALs which remains forever
  • [HBASE-16724] - Snapshot owner can't clone
  • [HBASE-16731] - Inconsistent results from the Get/Scan if we use the empty FilterList
  • [HBASE-16739] - Timed out exception message should include encoded region name
  • [HBASE-16762] - NullPointerException is thrown when constructing sourceTable in verifyrep
  • [HBASE-16768] - Inconsistent results from the Append/Increment
  • [HBASE-16771] - VerifyReplication should increase GOODROWS counter if re-comparison passes
  • [HBASE-16801] - The Append/Increment may return the data from future
  • [HBASE-16815] - Low scan ratio in RPC queue tuning triggers divide by zero exception
  • [HBASE-16816] - HMaster.move() should throw exception if region to move is not online
  • [HBASE-16829] - DemoClient should detect secure mode
  • [HBASE-16855] - Avoid NPE in MetricsConnection’s construction
  • [HBASE-16856] - Exception message in SyncRunner.run() should print currentSequence
  • [HBASE-16870] - Add the metrics of replication sources which were transformed from other dead rs to ReplicationLoad
  • [HBASE-16886] - hbase-client: scanner with reversed=true and small=true gets no result
  • [HBASE-16910] - Avoid NPE when starting StochasticLoadBalancer
  • [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-16962] - Add readPoint to preCompactScannerOpen() and preFlushScannerOpen() API
  • [HBASE-16983] - TestMultiTableSnapshotInputFormat failing with Unable to create region directory: /tmp/...
  • [HBASE-16985] - TestClusterId failed due to wrong hbase rootdir
  • [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-17033] - LogRoller makes a lot of allocations unnecessarily
  • [HBASE-17039] - SimpleLoadBalancer schedules large amount of invalid region moves
  • [HBASE-17054] - Compactor#preCreateCoprocScanner should be passed user
  • [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-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-17127] - Locate region should fail fast if underlying Connection already closed
  • [HBASE-17131] - Avoid livelock caused by HRegion#processRowsWithLocks
  • [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-17187] - DoNotRetryExceptions from coprocessors should bubble up to the application
  • [HBASE-17206] - FSHLog may roll a new writer successfully with unflushed entries
  • [HBASE-17256] - Rpc handler monitoring will be removed when the task queue is full
  • [HBASE-17264] - Processing RIT with offline state will always fail to open the first time
  • [HBASE-17265] - Region left unassigned in master failover when region failed to open
  • [HBASE-17275] - Assign timeout may cause region to be unassigned forever
  • [HBASE-17286] - LICENSE.txt in binary tarball contains only ASL text
  • [HBASE-17287] - Master becomes a zombie if filesystem object closes
  • [HBASE-17289] - Avoid adding a replication peer named "lock"
  • [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-17330] - SnapshotFileCache will always refresh the file cache
  • [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-17374] - ZKPermissionWatcher crashed when grant after region close
  • [HBASE-17381] - ReplicationSourceWorkerThread can die due to unhandled exceptions
  • [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-17426] - Inconsistent environment variable names for enabling JMX
  • [HBASE-17427] - region_mover.rb may move region onto the same server
  • [HBASE-17429] - HBase bulkload cannot support HDFS viewFs
  • [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-17489] - ClientScanner may send a next request to a RegionScanner which has been exhausted
  • [HBASE-17501] - NullPointerException after Datanodes Decommissioned and Terminated
  • [HBASE-17504] - The passed durability of Increment is ignored when syncing WAL
  • [HBASE-17510] - DefaultMemStore gets the wrong heap size after rollback
  • [HBASE-17519] - Rollback the removed cells
  • [HBASE-17522] - RuntimeExceptions from MemoryMXBean should not take down server process
  • [HBASE-17534] - SecureBulkLoadClient squashes DoNotRetryIOExceptions from the server
  • [HBASE-17540] - Change SASL server GSSAPI callback log line from DEBUG to TRACE in RegionServer to reduce log volumes in DEBUG mode
  • [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-17587] - Do not Rethrow DoNotRetryIOException as UnknownScannerException
  • [HBASE-17590] - Drop cache hint should work for StoreFile write path
  • [HBASE-17597] - TestMetaWithReplicas.testMetaTableReplicaAssignment is flaky
  • [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-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-17617] - Backport HBASE-16731 (Inconsistent results from the Get/Scan if we use the empty FilterList) to branch-1
  • [HBASE-17639] - Do not stop server if ReplicationSourceManager's waitUntilCanBePushed throws InterruptedException
  • [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-17658] - Fix bookkeeping error with max regions for a table
  • [HBASE-17661] - fix the queue length passed to FastPathBalancedQueueRpcExecutor
  • [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-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-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-17761] - Test TestRemoveRegionMetrics.testMoveRegion fails intermittently because of race condition
  • [HBASE-17764] - Solve TestMultiSlaveReplication flakiness
  • [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-17798] - RpcServer.Listener.Reader can abort due to CancelledKeyException
  • [HBASE-17803] - PE always re-creates table when we specify the split policy
  • [HBASE-17816] - HRegion#mutateRowWithLocks should update writeRequestCount metric
  • [HBASE-17821] - The CompoundConfiguration#toString is wrong
  • [HBASE-17861] - Regionserver down when checking the permission of staging dir if hbase.rootdir is on S3
  • [HBASE-17862] - Condition that always returns true
  • [HBASE-17869] - UnsafeAvailChecker wrongly returns false on ppc
  • [HBASE-17871] - scan#setBatch(int) call leads wrong result of VerifyReplication
  • [HBASE-17886] - Fix compatibility of ServerSideScanMetrics
  • [HBASE-17893] - Allow HBase to build against Hadoop 2.8.0
  • [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-17930] - Avoid using Canary.sniff in HBaseTestingUtility
  • [HBASE-17931] - Assign system tables to servers with highest version
  • [HBASE-17937] - Memstore size becomes negative in case of expensive postPut/Delete Coprocessor call
  • [HBASE-17958] - Avoid passing unexpected cell to ScanQueryMatcher when optimize SEEK to SKIP
  • [HBASE-17985] - Inline package manage updates with package installation in Yetus Dockerfile
  • [HBASE-17991] - Add more details about compaction queue on /dump
  • [HBASE-17993] - Delete useless info log in RpcServer.processResponse
  • [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-18014] - A case of Region remain unassigned when table enabled
  • [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-18026] - ProtobufUtil seems to do extra array copying
  • [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-18036] - HBase 1.x : Data locality is not maintained after cluster restart or SSH
  • [HBASE-18042] - Client Compatibility breaks between versions 1.2 and 1.3
  • [HBASE-18054] - log when we add/remove failed servers in client
  • [HBASE-18058] - Zookeeper retry sleep time should have an upper limit
  • [HBASE-18066] - Get with closest_row_before on "hbase:meta" can return empty Cell during region merge/split
  • [HBASE-18069] - Fix flaky test TestReplicationAdminWithClusters#testDisableAndEnableReplication
  • [HBASE-18077] - Update JUnit license to EPL from CPL
  • [HBASE-18081] - The way we process connection preamble in SimpleRpcServer is broken
  • [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-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-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-18150] - hbase.version file is created under both hbase.rootdir and hbase.wal.dir
  • [HBASE-18159] - Use OpenJDK7 instead of Oracle JDK7 in pre commit docker file
  • [HBASE-18167] - OfflineMetaRepair tool may cause HMaster abort always
  • [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-18197] - Avoided to call job.waitForCompletion(true) two times
  • [HBASE-18199] - Race in NettyRpcConnection may cause call stuck in BufferCallBeforeInitHandler forever
  • [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-18219] - Fix typo in constant HConstants.HBASE_CLIENT_MEAT_REPLICA_SCAN_TIMEOUT
  • [HBASE-18230] - Generated LICENSE file includes unsubstituted Velocity variables
  • [HBASE-18233] - We shouldn't wait for readlock in doMiniBatchMutation in case of deadlock
  • [HBASE-18247] - Hbck to fix the case that replica region shows as key in the meta table
  • [HBASE-18255] - Time-Delayed HBase Performance Degradation with Java 7
  • [HBASE-18267] - The result from the postAppend is ignored
  • [HBASE-18323] - Remove multiple ACLs for the same user in kerberos
  • [HBASE-18330] - NPE in ReplicationZKLockCleanerChore
  • [HBASE-18340] - TestXXXProcedure tests hanging or failing on branch-1 (branch-1.4)
  • [HBASE-18346] - TestRSKilledWhenInitializing failing on branch-1 (branch-1.4)
  • [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-18377] - Error handling for FileNotFoundException should consider RemoteException in openReader()
  • [HBASE-18390] - Sleep too long when finding region location failed
  • [HBASE-18431] - Mitigate compatibility concerns between branch-1.3 and branch-1.4
  • [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-18447] - MetricRegistryInfo#hashCode uses hashCode instead of toHashCode
  • [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-18473] - VC.listLabels() erroneously closes any connection
  • [HBASE-18476] - HTable#put should call RS#mutate rather than RS#multi
  • [HBASE-18479] - should apply HBASE-18255 to HBASE_MASTER_OPTS too
  • [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-18505] - Our build/yetus personality will run tests on individual modules and then on all (i.e. 'root'). Should do one or other
  • [HBASE-18512] - Region Server will abort with IllegalStateException if HDFS umask has limited scope
  • [HBASE-18526] - FIFOCompactionPolicy pre-check uses wrong scope
  • [HBASE-18568] - Correct metric of numRegions
  • [HBASE-18572] - Delete can't remove the cells which have no visibility label
  • [HBASE-18577] - shaded client includes several non-relocated third party dependencies
  • [HBASE-18587] - Fix Flaky TestFileIOEngine
  • [HBASE-18589] - branch-1.4 build compile is broken
  • [HBASE-18607] - fix submit-patch.py to support utf8
  • [HBASE-18614] - Setting BUCKET_CACHE_COMBINED_KEY to false disables stats on RS UI
  • [HBASE-18616] - Shell warns about already initialized constants at startup
  • [HBASE-18617] - FuzzyRowKeyFilter should not modify the filter pairs
  • [HBASE-18626] - Handle the incompatible change about the replication TableCFs' config
  • [HBASE-18628] - ZKPermissionWatcher blocks all ZK notifications
  • [HBASE-18633] - Add more info to understand the source/scenario of large batch requests exceeding threshold
  • [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-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-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-18762] - Canary sink type cast error
  • [HBASE-18771] - Incorrect StoreFileRefresh leading to split and compaction failures
  • [HBASE-18789] - Displays the reporting interval of each RS on the Master page
  • [HBASE-18796] - Admin#isTableAvailable returns incorrect result before daughter regions are opened
  • [HBASE-18801] - Bulk load cleanup may falsely deem file deletion successful
  • [HBASE-18810] - TestClientScannerRPCTimeout failing in branch-1 / branch-1.4
  • [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-18885] - HFileOutputFormat2 hardcodes default FileOutputCommitter
  • [HBASE-18890] - Backport HBASE-14499 (Master coprocessors shutdown will not happen on master abort) to branch-1
  • [HBASE-18921] - Result.current() throws ArrayIndexOutOfBoundsException after calling advance()
  • [HBASE-18923] - TestTableResource flaky on branch-1
  • [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-18942] - hbase-hadoop2-compat module ignores hadoop-3 profile
  • [HBASE-18959] - Backport HBASE-18874 (HMaster abort message will be skipped if Throwable is passed null) to branch-1
  • [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-19020] - TestXmlParsing exception checking relies on a particular xml implementation without declaring it.
  • [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-19055] - Backport HBASE-19042 to other active branches
  • [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-19088] - move_tables_rsgroup will throw an exception when the table is disabled
  • [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-19102] - TestZooKeeperMainServer fails with KeeperException$ConnectionLossException
  • [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-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-19150] - TestSnapshotWithAcl is flaky
  • [HBASE-19156] - Duplicative regions_per_server options on LoadTestTool
  • [HBASE-19173] - Configure IntegrationTestRSGroup automatically for minicluster mode
  • [HBASE-19184] - clean up nightly source artifact test to match expectations from switch to git-archive
  • [HBASE-19188] - Build fails on branch-1 using maven-3.5.2
  • [HBASE-19194] - TestRSGroupsBase has some always false checks
  • [HBASE-19195] - More error-prone fixes
  • [HBASE-19198] - TestIPv6NIOServerSocketChannel fails; unable to bind
  • [HBASE-19215] - Incorrect exception handling on the client causes incorrect call timeouts and byte buffer allocations on the server
  • [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-19245] - MultiTableInputFormatBase#getSplits creates a Connection per Table
  • [HBASE-19249] - test for "hbase antipatterns" should check _count_ of occurance rather than text of
  • [HBASE-19250] - TestClientClusterStatus is flaky
  • [HBASE-19260] - Add lock back to avoid parallel accessing meta to locate region
  • [HBASE-19285] - Add per-table latency histograms
  • [HBASE-19300] - TestMultithreadedTableMapper fails in branch-1.4
  • [HBASE-19325] - Pass a list of server name to postClearDeadServers
  • [HBASE-19350] - TestMetaWithReplicas is flaky
  • [HBASE-19376] - Fix more binary compatibility problems with branch-1.4 / branch-1
  • [HBASE-19379] - TestEndToEndSplitTransaction fails with NPE
  • [HBASE-19381] - TestGlobalThrottler doesn't make progress (branch-1.4)
  • [HBASE-19385] - [1.3] TestReplicator failed 1.3 nightly
  • [HBASE-19388] - Incorrect value is being set for Compaction Pressure in RegionLoadStats object inside HRegion class
  • [HBASE-19393] - HTTP 413 FULL head while accessing HBase UI using SSL.
  • [HBASE-19395] - [branch-1] TestEndToEndSplitTransaction.testMasterOpsWhileSplitting fails with NPE
  • [HBASE-19396] - Fix flaky test TestHTableMultiplexerFlushCache
  • [HBASE-19406] - Fix CompactionRequest equals and hashCode
  • [HBASE-19421] - branch-1 does not compile against Hadoop 3.0.0
  • [HBASE-19422] - using hadoop-profile property leads to confusing failures
  • [HBASE-19429] - Release build fails in checkstyle phase of site target (branch-1)
  • [HBASE-19435] - Reopen Files for ClosedChannelException in BucketCache
  • [HBASE-19440] - Not able to enable balancer with RSGroups once disabled
  • [HBASE-19442] - Backport HBASE-19065 to branch-1 (HRegion#bulkLoadHFiles() should wait for concurrent Region#flush() to finish)
  • [HBASE-19445] - PerformanceEvaluation NPE processing split policy option
  • [HBASE-19446] - Misspelled 'default' in SimpleRpcScheduler
  • [HBASE-19447] - INFO level logging of GetClusterStatus from HMaster is too chatty
  • [HBASE-19465] - Required httpcore and httpclient jars not included in binary distribution
  • [HBASE-19467] - rsgroups shell commands don't properly display elapsed time

New Feature

  • [HBASE-15134] - Add visibility into Flush and Compaction queues
  • [HBASE-15576] - Scanning cursor to prevent blocking long time on ResultScanner.next()
  • [HBASE-15631] - Backport Regionserver Groups (HBASE-6721) to branch-1
  • [HBASE-15633] - Backport HBASE-15507 to branch-1
  • [HBASE-15847] - VerifyReplication prefix filtering
  • [HBASE-16213] - A new HFileBlock structure for fast random get
  • [HBASE-16388] - Prevent client threads being blocked by only one slow region server
  • [HBASE-16677] - Add table size (total store file size) to table page
  • [HBASE-17181] - Let HBase thrift2 support TThreadedSelectorServer
  • [HBASE-17737] - Thrift2 proxy should support scan timeRange per column family
  • [HBASE-17757] - Unify blocksize after encoding to decrease memory fragment
  • [HBASE-18060] - Backport to branch-1 HBASE-9774 HBase native metrics and metric collection for coprocessors
  • [HBASE-18131] - Add an hbase shell command to clear deadserver list in ServerManager
  • [HBASE-18226] - Disable reverse DNS lookup at HMaster and use the hostname provided by RegionServer
  • [HBASE-18875] - Thrift server supports read-only mode
  • [HBASE-19189] - Ad-hoc test job for running a subset of tests lots of times
  • [HBASE-19326] - Remove decommissioned servers from rsgroup

Improvement

  • [HBASE-11013] - Clone Snapshots on Secure Cluster Should provide option to apply Retained User Permissions
  • [HBASE-12350] - Backport error-prone build support to branch-1 and branch-2
  • [HBASE-12770] - Don't transfer all the queued hlogs of a dead server to the same alive server
  • [HBASE-12870] - "Major compaction triggered" and "Skipping major compaction" messages lack the region information
  • [HBASE-13718] - Add a pretty printed table description to the table detail page of HBase's master
  • [HBASE-14007] - Writing to table through MR should fail upfront if table does not exist/is disabled
  • [HBASE-14220] - nightly tests should verify src tgz generates and builds correctly
  • [HBASE-14548] - Expand how table coprocessor jar and dependency path can be specified
  • [HBASE-14574] - TableOutputFormat#getRecordWriter javadoc misleads
  • [HBASE-14871] - Allow specifying the base branch for make_patch
  • [HBASE-14925] - Develop HBase shell command/tool to list table's region info through command line
  • [HBASE-14985] - TimeRange constructors should set allTime when appropriate
  • [HBASE-15191] - CopyTable and VerifyReplication - Option to specify batch size, versions
  • [HBASE-15243] - Utilize the lowest seek value when all Filters in MUST_PASS_ONE FilterList return SEEK_NEXT_USING_HINT
  • [HBASE-15429] - Add a split policy for busy regions
  • [HBASE-15451] - Remove unnecessary wait in MVCC
  • [HBASE-15496] - Throw RowTooBigException only for user scan/get
  • [HBASE-15529] - Override needBalance in StochasticLoadBalancer
  • [HBASE-15571] - Make MasterProcedureManagerHost accessible through MasterServices
  • [HBASE-15614] - Report metrics from JvmPauseMonitor
  • [HBASE-15686] - Add override mechanism for the exempt classes when dynamically loading table coprocessor
  • [HBASE-15727] - Canary Tool for Zookeeper
  • [HBASE-15802] - ConnectionUtils should use ThreadLocalRandom instead of Random
  • [HBASE-15816] - Provide client with ability to set priority on Operations
  • [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-15924] - Enhance hbase services autorestart capability to hbase-daemon.sh
  • [HBASE-15941] - HBCK repair should not unsplit healthy splitted region
  • [HBASE-16008] - A robust way deal with early termination of HBCK
  • [HBASE-16052] - Improve HBaseFsck Scalability
  • [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-16147] - Shell command for getting compaction state
  • [HBASE-16188] - Add EventCounter information to log4j properties file
  • [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-16262] - Update RegionsInTransition UI for branch-1
  • [HBASE-16275] - Change ServerManager#onlineServers from ConcurrentHashMap to ConcurrentSkipListMap
  • [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-16351] - do dependency license check via enforcer plugin
  • [HBASE-16399] - Provide an API to get list of failed regions and servername in Canary
  • [HBASE-16419] - check REPLICATION_SCOPE's value more stringently
  • [HBASE-16423] - Add re-compare option to VerifyReplication to avoid occasional inconsistent rows
  • [HBASE-16448] - Custom metrics for custom replication endpoints
  • [HBASE-16455] - Provide API for obtaining all the WAL files
  • [HBASE-16469] - Several log refactoring/improvement suggestions
  • [HBASE-16502] - Reduce garbage in BufferedDataBlockEncoder
  • [HBASE-16508] - Move UnexpectedStateException to common
  • [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-16585] - Rewrite the delegation token tests with Parameterized pattern
  • [HBASE-16616] - Rpc handlers stuck on ThreadLocalMap.expungeStaleEntry
  • [HBASE-16640] - TimeoutBlockingQueue#remove() should return whether the entry is removed
  • [HBASE-16672] - Add option for bulk load to always copy hfile(s) instead of renaming
  • [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-16705] - Eliminate long to Long auto boxing in LongComparator
  • [HBASE-16708] - Expose endpoint Coprocessor name in "responseTooSlow" log messages
  • [HBASE-16755] - Honor flush policy under global memstore pressure
  • [HBASE-16772] - Add verbose option to VerifyReplication for logging good rows
  • [HBASE-16773] - AccessController should access local region if possible
  • [HBASE-16832] - Reduce the default number of versions in Meta table for branch-1
  • [HBASE-16840] - Reuse cell's timestamp and type in ScanQueryMatcher
  • [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-16969] - RegionCoprocessorServiceExec should override the toString() for debugging
  • [HBASE-16977] - VerifyReplication should log a printable representation of the row keys
  • [HBASE-17026] - VerifyReplication log should distinguish whether good row key is result of revalidation
  • [HBASE-17057] - Minor compactions should also drop page cache behind reads
  • [HBASE-17077] - Don't copy the replication queue belonging to the peer which has been deleted
  • [HBASE-17088] - Refactor RWQueueRpcExecutor/BalancedQueueRpcExecutor/RpcExecutor
  • [HBASE-17178] - Add region balance throttling
  • [HBASE-17205] - Add a metric for the duration of region in transition
  • [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-17276] - Reduce log spam from WrongRegionException in large multi()'s
  • [HBASE-17280] - Add mechanism to control hbase cleaner behavior
  • [HBASE-17292] - Add observer notification before bulk loaded hfile is moved to region directory
  • [HBASE-17296] - Provide per peer throttling for replication
  • [HBASE-17318] - Increment does not add new column if the increment amount is zero at first time writing
  • [HBASE-17332] - Replace HashMap to Array for DataBlockEncoding.idToEncoding
  • [HBASE-17437] - Support specifying a WAL directory outside of the root directory
  • [HBASE-17448] - Export metrics from RecoverableZooKeeper
  • [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-17494] - Guard against cloning family of all cells if no data need be replicated
  • [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-17543] - Create additional ReplicationEndpoint WALEntryFilters by configuration
  • [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-17689] - Add support for table.existsAll in thrift2 THBaseservice
  • [HBASE-17716] - Formalize Scan Metric names
  • [HBASE-17731] - Fractional latency reporting in MultiThreadedAction
  • [HBASE-17778] - Remove the testing code in the AsyncRequestFutureImpl
  • [HBASE-17817] - Make Regionservers log which tables it removed coprocessors from when aborting
  • [HBASE-17831] - Support small scan in thrift2
  • [HBASE-17835] - Spelling mistakes in the Java source
  • [HBASE-17877] - Improve HBase's byte[] comparator
  • [HBASE-17912] - Avoid major compactions on region server startup
  • [HBASE-17916] - Error message not clear when the permission of staging dir is not as expected
  • [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-17995] - improve log messages during snapshot related tests
  • [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-18023] - Log multi-* requests for more than threshold number of rows
  • [HBASE-18041] - Add pylintrc file to HBase
  • [HBASE-18043] - Institute a hard limit for individual cell size that cannot be overridden by clients
  • [HBASE-18090] - Improve TableSnapshotInputFormat to allow more multiple mappers per region
  • [HBASE-18094] - Display the return value of the command append
  • [HBASE-18164] - Much faster locality cost function and candidate generator
  • [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-18286] - Create static empty byte array to save memory
  • [HBASE-18374] - RegionServer Metrics improvements
  • [HBASE-18387] - [Thrift] Make principal configurable in DemoClient.java
  • [HBASE-18426] - nightly job should use independent stages to check supported jdks
  • [HBASE-18436] - Add client-side hedged read metrics
  • [HBASE-18469] - Correct RegionServer metric of totalRequestCount
  • [HBASE-18478] - Allow users to remove RegionFinder from LoadBalancer calculations if no locality possible
  • [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-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-18573] - Update Append and Delete to use Mutation#getCellList(family)
  • [HBASE-18602] - rsgroup cleanup unassign code
  • [HBASE-18631] - Allow configuration of ChaosMonkey properties via hbase-site
  • [HBASE-18652] - Expose individual cache stats in a CombinedCache through JMX
  • [HBASE-18675] - Making {max,min}SessionTimeout configurable for MiniZooKeeperCluster
  • [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-18814] - Make ScanMetrics enabled and add counter <HBase Counters, ROWS_SCANNED> into the MapReduce Job over snapshot
  • [HBASE-18993] - Backport patches in HBASE-18410 to branch-1.x branches.
  • [HBASE-19051] - Add new split algorithm for num string
  • [HBASE-19052] - FixedFileTrailer should recognize CellComparatorImpl class in branch-1.x
  • [HBASE-19091] - Code annotation wrote "BinaryComparator" instead of "LongComparator"
  • [HBASE-19140] - hbase-cleanup.sh uses deprecated call to remove files in hdfs
  • [HBASE-19180] - Remove unused imports from AlwaysPasses
  • [HBASE-19228] - nightly job should gather machine stats.
  • [HBASE-19239] - Fix findbugs and error-prone warnings (branch-1)
  • [HBASE-19262] - Revisit checkstyle rules

Test

  • [HBASE-16349] - TestClusterId may hang during cluster shutdown
  • [HBASE-16418] - Reduce duration of sleep waiting for region reopen in IntegrationTestBulkLoad#installSlowingCoproc()
  • [HBASE-16639] - TestProcedureInMemoryChore#testChoreAddAndRemove occasionally fails
  • [HBASE-16725] - Don't let flushThread hang in TestHRegion
  • [HBASE-17189] - TestMasterObserver#wasModifyTableActionCalled uses wrong variables
  • [HBASE-17703] - TestThriftServerCmdLine is flaky in master branch
  • [HBASE-18147] - nightly job to check health of active branches
  • [HBASE-18979] - TestInterfaceAudienceAnnotations fails on branch-1.3

Task

  • [HBASE-4368] - Expose processlist in shell (per regionserver and perhaps by cluster)
  • [HBASE-14635] - Fix flaky test TestSnapshotCloneIndependence
  • [HBASE-16335] - update to latest apache parent pom
  • [HBASE-16459] - Remove unused hbase shell --format option
  • [HBASE-16584] - Backport the new ipc implementation in HBASE-16432 to branch-1
  • [HBASE-17609] - Allow for region merging in the UI
  • [HBASE-17954] - Switch findbugs implementation to spotbugs
  • [HBASE-17965] - Canary tool should print the regionserver name on failure
  • [HBASE-17968] - Update copyright year in NOTICE file
  • [HBASE-18096] - Limit HFileUtil visibility and add missing annotations
  • [HBASE-18527] - update nightly builds to compensate for jenkins plugin upgrades
  • [HBASE-18582] - Correct the docs for Mutation#setCellVisibility
  • [HBASE-18623] - Frequent failed to parse at EOF warnings from WALEntryStream
  • [HBASE-18670] - Add .DS_Store to .gitignore
  • [HBASE-18690] - Replace o.a.h.c.InterfaceAudience by o.a.h.h.c.InterfaceAudience
  • [HBASE-18833] - Ensure precommit personality is up to date on all active branches
  • [HBASE-18996] - Backport HBASE-17703 (TestThriftServerCmdLine is flaky in master branch) to branch-1
  • [HBASE-19097] - update testing to use Apache Yetus Test Patch version 0.6.0
  • [HBASE-19099] - Evaluate the remaining API compatibility concerns between branch-1.3 and branch-1.4 / branch-1
  • [HBASE-19217] - Update supplemental-models.xml for jetty-sslengine
  • [HBASE-19232] - Fix shaded-check-invariants (check-jar-contents) failure on branch-1
  • [HBASE-19419] - Remove hbase-native-client from branch-1
  • [HBASE-19420] - Backport HBASE-19152 (Update refguide 'how to build an RC' and the make_rc.sh script) to branch-1

Umbrella

  • [HBASE-18266] - Eliminate the warnings from the spotbugs

Edit/Copy Release Notes

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