Apache HBase Changelog

What's new in Apache HBase 2.1.4

Mar 27, 2019
  • These release notes cover new developer and user-facing incompatibilities, important issues, features, and major improvements.

New in Apache HBase 1.3.1 (Apr 21, 2017)

  • Sub-task:
  • [HBASE-15386] - PREFETCH_BLOCKS_ON_OPEN in HColumnDescriptor is ignored
  • [HBASE-17060] - backport HBASE-16570 to 1.3.1
  • [HBASE-17561] - table status page should escape values that may contain arbitrary characters.
  • Bug:
  • [HBASE-14753] - TestShell is not invoked anymore
  • [HBASE-15328] - Unvalidated Redirect in HMaster
  • [HBASE-15635] - Mean age of Blocks in cache (seconds) on webUI should be greater than zero
  • [HBASE-16630] - Fragmentation in long running Bucket Cache
  • [HBASE-16886] - hbase-client: scanner with reversed=true and small=true gets no result
  • [HBASE-16939] - ExportSnapshot: set owner and permission on right directory
  • [HBASE-16948] - Fix inconsistency between HRegion and Region javadoc on getRowLock
  • [HBASE-17059] - backport HBASE-17039 to 1.3.1
  • [HBASE-17069] - RegionServer writes invalid META entries for split daughters in some circumstances
  • [HBASE-17070] - backport HBASE-17020 to 1.3.1
  • [HBASE-17112] - Prevent setting timestamp of delta operations the same as previous value's
  • [HBASE-17175] - backport HBASE-17127 to 1.3.1
  • [HBASE-17187] - DoNotRetryExceptions from coprocessors should bubble up to the application
  • [HBASE-17227] - Backport HBASE-17206 to branch-1.3
  • [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-17287] - Master becomes a zombie if filesystem object closes
  • [HBASE-17289] - Avoid adding a replication peer named "lock"
  • [HBASE-17357] - PerformanceEvaluation parameters parsing triggers NPE.
  • [HBASE-17381] - ReplicationSourceWorkerThread can die due to unhandled exceptions
  • [HBASE-17387] - Reduce the overhead of exception report in RegionActionResult for multi()
  • [HBASE-17445] - Count size of serialized exceptions in checking max result size quota
  • [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-17522] - RuntimeExceptions from MemoryMXBean should not take down server process
  • [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-17572] - HMaster: Caught throwable while processing event C_M_MERGE_REGION
  • [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-17604] - Backport HBASE-15437 (fix request and response size metrics) to branch-1
  • [HBASE-17611] - Thrift 2 per-call latency metrics are capped at ~ 2 seconds
  • [HBASE-17616] - Incorrect actions performed by CM
  • [HBASE-17649] - REST API for scan should return 410 when table is disabled
  • [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-17716] - Formalize Scan Metric names
  • [HBASE-17717] - Incorrect ZK ACL set for HBase superuser
  • [HBASE-17722] - Metrics subsystem stop/start messages add a lot of useless bulk to operational logging
  • [HBASE-17780] - BoundedByteBufferPool "At capacity" messages are not actionable
  • [HBASE-17813] - backport HBASE-16983 to branch-1.3
  • [HBASE-17868] - Backport HBASE-10205 to branch-1.3
  • [HBASE-17886] - Fix compatibility of ServerSideScanMetrics
  • Improvement:
  • [HBASE-12770] - Don't transfer all the queued hlogs of a dead server to the same alive server
  • [HBASE-15429] - Add a split policy for busy regions
  • [HBASE-15941] - HBCK repair should not unsplit healthy splitted region
  • [HBASE-16562] - ITBLL should fail to start if misconfigured
  • [HBASE-16755] - Honor flush policy under global memstore pressure
  • [HBASE-16773] - AccessController should access local region if possible
  • [HBASE-16947] - Some improvements for DumpReplicationQueues tool
  • [HBASE-16977] - VerifyReplication should log a printable representation of the row keys
  • [HBASE-17057] - Minor compactions should also drop page cache behind reads
  • [HBASE-17579] - Backport HBASE-16302 to 1.3.1
  • [HBASE-17627] - Active workers metric for thrift
  • [HBASE-17637] - Update progress more frequently in IntegrationTestBigLinkedList.Generator.persist
  • [HBASE-17837] - Backport HBASE-15314 to branch-1.3
  • Task:
  • [HBASE-17609] - Allow for region merging in the UI

New in Apache HBase 1.3.0 (Jan 18, 2017)

  • Sub-task:
  • [HBASE-13212] - Procedure V2 - master Create/Modify/Delete namespace
  • [HBASE-13819] - Make RPC layer CellBlock buffer a DirectByteBuffer
  • [HBASE-13909] - create 1.2 branch
  • [HBASE-14051] - Undo workarounds in IntegrationTestDDLMasterFailover for client double submit
  • [HBASE-14212] - Add IT test for procedure-v2-based namespace DDL
  • [HBASE-14423] - TestStochasticBalancerJmxMetrics.testJmxMetrics_PerTableMode:183 NullPointer
  • [HBASE-14464] - Removed unused fs code
  • [HBASE-14575] - Relax region read lock for compactions
  • [HBASE-14662] - Fix NPE in HFileOutputFormat2
  • [HBASE-14734] - BindException when setting up MiniKdc
  • [HBASE-14786] - TestProcedureAdmin hangs
  • [HBASE-14877] - maven archetype: client application
  • [HBASE-14878] - maven archetype: client application with shaded jars
  • [HBASE-14949] - Resolve name conflict when splitting if there are duplicated WAL entries
  • [HBASE-14955] - OOME: cannot create native thread is back
  • [HBASE-15105] - Procedure V2 - Procedure Queue with Namespaces
  • [HBASE-15113] - Procedure v2 - Speedup eviction of sys operation results
  • [HBASE-15142] - Procedure v2 - Basic WebUI listing the procedures
  • [HBASE-15144] - Procedure v2 - Web UI displaying Store state
  • [HBASE-15163] - Add sampling code and metrics for get/scan/multi/mutate count separately
  • [HBASE-15171] - Avoid counting duplicate kv and generating lots of small hfiles in PutSortReducer
  • [HBASE-15194] - TestStochasticLoadBalancer.testRegionReplicationOnMidClusterSameHosts flaky on trunk
  • [HBASE-15202] - Reduce garbage while setting response
  • [HBASE-15203] - Reduce garbage created by path.toString() during Checksum verification
  • [HBASE-15204] - Try to estimate the cell count for adding into WALEdit
  • [HBASE-15232] - Exceptions returned over multi RPC don't automatically trigger region location reloads
  • [HBASE-15311] - Prevent NPE in BlockCacheViewTmpl
  • [HBASE-15347] - Update CHANGES.txt for 1.3
  • [HBASE-15351] - Fix description of hbase.bucketcache.size in hbase-default.xml
  • [HBASE-15354] - Use same criteria for clearing meta cache for all operations
  • [HBASE-15365] - Do not write to '/tmp' in TestHBaseConfiguration
  • [HBASE-15366] - Add doc, trace-level logging, and test around hfileblock
  • [HBASE-15368] - Add pluggable window support
  • [HBASE-15371] - Procedure V2 - Completed support parent-child procedure
  • [HBASE-15373] - DEPRECATED_NAME_OF_NO_LIMIT_THROUGHPUT_CONTROLLER_CLASS value is wrong in CompactionThroughputControllerFactory
  • [HBASE-15376] - ScanNext metric is size-based while every other per-operation metric is time based
  • [HBASE-15377] - Per-RS Get metric is time based, per-region metric is size-based
  • [HBASE-15384] - Avoid using '/tmp' directory in TestBulkLoad
  • [HBASE-15389] - Write out multiple files when compaction
  • [HBASE-15390] - Unnecessary MetaCache evictions cause elevated number of requests to meta
  • [HBASE-15392] - Single Cell Get reads two HFileBlocks
  • [HBASE-15400] - Use DateTieredCompactor for Date Tiered Compaction
  • [HBASE-15412] - Add average region size metric
  • [HBASE-15422] - Procedure v2 - Avoid double yield
  • [HBASE-15435] - Add WAL (in bytes) written metric
  • [HBASE-15460] - Fix infer issues in hbase-common
  • [HBASE-15464] - Flush / Compaction metrics revisited
  • [HBASE-15477] - Do not save 'next block header' when we cache hfileblocks
  • [HBASE-15479] - No more garbage or beware of autoboxing
  • [HBASE-15488] - Add ACL for setting split merge switch
  • [HBASE-15518] - Add Per-Table metrics back
  • [HBASE-15524] - Fix NPE in client-side metrics
  • [HBASE-15527] - Refactor Compactor related classes
  • [HBASE-15537] - Make multi WAL work with WALs other than FSHLog
  • [HBASE-15640] - L1 cache doesn't give fair warning that it is showing partial stats only when it hits limit
  • [HBASE-15658] - RegionServerCallable / RpcRetryingCaller clear meta cache on retries
  • [HBASE-15665] - Support using different StoreFileComparators for different CompactionPolicies
  • [HBASE-15671] - Add per-table metrics on memstore, storefile and regionsize
  • [HBASE-15683] - Min latency in latency histograms are emitted as Long.MAX_VALUE
  • [HBASE-15713] - Backport "HBASE-15477 Do not save 'next block header' when we cache hfileblocks"
  • [HBASE-15740] - Replication source.shippedKBs metric is undercounting because it is in KB
  • [HBASE-15865] - Move TestTableDeleteFamilyHandler and TestTableDescriptorModification handler tests to procedure
  • [HBASE-15872] - Split TestWALProcedureStore
  • [HBASE-15878] - Deprecate doBulkLoad(Path hfofDir, final HTable table) in branch-1 (even though its 'late')
  • [HBASE-15935] - Have a separate Walker task running concurrently with Generator
  • [HBASE-15971] - Regression: Random Read/WorkloadC slower in 1.x than 0.98
  • [HBASE-15984] - Given failure to parse a given WAL that was closed cleanly, replay the WAL.
  • [HBASE-16023] - Fastpath for the FIFO rpcscheduler
  • [HBASE-16034] - Fix ProcedureTestingUtility#LoadCounter.setMaxProcId()
  • [HBASE-16056] - Procedure v2 - fix master crash for FileNotFound
  • [HBASE-16068] - Procedure v2 - use consts for conf properties in test
  • [HBASE-16101] - Procedure v2 - Perf Tool for WAL
  • [HBASE-16146] - Counters are expensive...
  • [HBASE-16176] - Bug fixes/improvements on HBASE-15650 Remove TimeRangeTracker as point of contention when many threads reading a StoreFile
  • [HBASE-16180] - Fix ST_WRITE_TO_STATIC_FROM_INSTANCE_METHOD findbugs introduced by parent
  • [HBASE-16189] - [Rolling Upgrade] 2.0 hfiles cannot be opened by 1.x servers
  • [HBASE-16194] - Should count in MSLAB chunk allocation into heap size change when adding duplicate cells
  • [HBASE-16195] - Should not add chunk into chunkQueue if not using chunk pool in HeapMemStoreLAB
  • [HBASE-16285] - Drop RPC requests if it must be considered as timeout at client
  • [HBASE-16317] - revert all ESAPI changes
  • [HBASE-16318] - fail build if license isn't in whitelist
  • [HBASE-16321] - Ensure findbugs jsr305 jar isn't present
  • [HBASE-16452] - Procedure v2 - Make ProcedureWALPrettyPrinter extend Tool
  • [HBASE-16485] - Procedure V2 - Add support to addChildProcedure() as last "step" in StateMachineProcedure
  • [HBASE-16522] - Procedure v2 - Cache system user and avoid IOException
  • [HBASE-16970] - Clarify misleading Scan.java comment about caching
  • [HBASE-17017] - Remove the current per-region latency histogram metrics
  • [HBASE-17149] - Procedure V2 - Fix nonce submission to avoid unnecessary calling coprocessor multiple times
  • Bug:
  • [HBASE-11625] - Reading datablock throws "Invalid HFile block magic" and can not switch to hdfs checksum
  • [HBASE-12865] - WALs may be deleted before they are replicated to peers
  • [HBASE-13082] - Coarsen StoreScanner locks to RegionScanner
  • [HBASE-13897] - OOM may occur when Import imports a row with too many KeyValues
  • [HBASE-14077] - Add package to hbase-protocol protobuf files.
  • [HBASE-14094] - Procedure.proto can't be compiled to C++
  • [HBASE-14143] - remove obsolete maven repositories
  • [HBASE-14162] - Fixing maven target for regenerating thrift classes fails against 0.9.2
  • [HBASE-14252] - RegionServers fail to start when setting hbase.ipc.server.callqueue.scan.ratio to 0
  • [HBASE-14256] - Flush task message may be confusing when region is recovered
  • [HBASE-14349] - pre-commit zombie finder is overly broad
  • [HBASE-14370] - Use separate thread for calling ZKPermissionWatcher#refreshNodes()
  • [HBASE-14411] - Fix unit test failures when using multiwal as default WAL provider
  • [HBASE-14485] - ConnectionImplementation leaks on construction failure
  • [HBASE-14497] - Reverse Scan threw StackOverflow caused by readPt checking
  • [HBASE-14525] - Append and increment operation throws NullPointerException on non-existing column families.
  • [HBASE-14536] - Balancer & SSH interfering with each other leading to unavailability
  • [HBASE-14604] - Improve MoveCostFunction in StochasticLoadBalancer
  • [HBASE-14644] - Region in transition metric is broken
  • [HBASE-14818] - user_permission does not list namespace permissions
  • [HBASE-14970] - Backport HBASE-13082 and its sub-jira to branch-1
  • [HBASE-14975] - Don't color the total RIT line yellow if it's zero
  • [HBASE-15000] - Fix javadoc warn in LoadIncrementalHFiles
  • [HBASE-15026] - The default value of "hbase.regions.slop" in hbase-default.xml is obsolete
  • [HBASE-15028] - Minor fix on RegionGroupingProvider
  • [HBASE-15030] - Deadlock in master TableNamespaceManager while running IntegrationTestDDLMasterFailover
  • [HBASE-15034] - IntegrationTestDDLMasterFailover does not clean created namespaces
  • [HBASE-15093] - Replication can report incorrect size of log queue for the global source when multiwal is enabled
  • [HBASE-15125] - HBaseFsck's adoptHdfsOrphan function creates region with wrong end key boundary
  • [HBASE-15128] - Disable region splits and merges switch in master
  • [HBASE-15132] - Master region merge RPC should authorize user request
  • [HBASE-15137] - CallTimeoutException and CallQueueTooBigException should trigger PFFE
  • [HBASE-15173] - Execute mergeRegions RPC call as the request user
  • [HBASE-15234] - ReplicationLogCleaner can abort due to transient ZK issues
  • [HBASE-15247] - InclusiveStopFilter does not respect reverse Filter property
  • [HBASE-15287] - mapreduce.RowCounter returns incorrect result with binary row key inputs
  • [HBASE-15290] - Hbase Rest CheckAndAPI should save other cells along with compared cell
  • [HBASE-15292] - Refined ZooKeeperWatcher to prevent ZooKeeper's callback while construction
  • [HBASE-15295] - MutateTableAccess.multiMutate() does not get high priority causing a deadlock
  • [HBASE-15297] - error message is wrong when a wrong namspace is specified in grant in hbase shell
  • [HBASE-15319] - clearJmxCache does not take effect actually
  • [HBASE-15322] - Operations using Unsafe path broken for platforms not having sun.misc.Unsafe
  • [HBASE-15323] - Hbase Rest CheckAndDeleteAPi should be able to delete more cells
  • [HBASE-15324] - Jitter may cause desiredMaxFileSize overflow in ConstantSizeRegionSplitPolicy and trigger unexpected split
  • [HBASE-15325] - ResultScanner allowing partial result will miss the rest of the row if the region is moved between two rpc requests
  • [HBASE-15327] - Canary will always invoke admin.balancer() in each sniffing period when writeSniffing is enabled
  • [HBASE-15348] - Fix tests broken by recent metrics re-work
  • [HBASE-15357] - TableInputFormatBase getSplitKey does not handle signed bytes correctly
  • [HBASE-15358] - canEnforceTimeLimitFromScope should use timeScope instead of sizeScope
  • [HBASE-15360] - Fix flaky TestSimpleRpcScheduler
  • [HBASE-15378] - Scanner cannot handle heartbeat message with no results
  • [HBASE-15393] - Enable table replication command will fail when parent znode is not default in peer cluster
  • [HBASE-15397] - Create bulk load replication znode(hfile-refs) in ZK replication queue by default
  • [HBASE-15405] - Synchronize final results logging single thread in PE, fix wrong defaults in help message
  • [HBASE-15406] - Split / merge switch left disabled after early termination of hbck
  • [HBASE-15424] - Add bulk load hfile-refs for replication in ZK after the event is appended in the WAL
  • [HBASE-15425] - Failing to write bulk load event marker in the WAL is ignored
  • [HBASE-15430] - Failed taking snapshot - Manifest proto-message too large
  • [HBASE-15433] - SnapshotManager#restoreSnapshot not update table and region count quota correctly when encountering exception
  • [HBASE-15439] - getMaximumAllowedTimeBetweenRuns in ScheduledChore ignores the TimeUnit
  • [HBASE-15441] - Fix WAL splitting when region has moved multiple times
  • [HBASE-15463] - Region normalizer should check whether split/merge is enabled
  • [HBASE-15465] - userPermission returned by getUserPermission() for the selected namespace does not have namespace set
  • [HBASE-15485] - Filter.reset() should not be called between batches
  • [HBASE-15490] - Remove duplicated CompactionThroughputControllerFactory in branch-1
  • [HBASE-15504] - Fix Balancer in 1.3 not moving regions off overloaded regionserver
  • [HBASE-15515] - Improve LocalityBasedCandidateGenerator in Balancer
  • [HBASE-15520] - Fix broken TestAsyncIPC
  • [HBASE-15559] - BaseMasterAndRegionObserver doesn't implement all the methods
  • [HBASE-15563] - 'counter' may overflow in BoundedGroupingStrategy
  • [HBASE-15574] - Minor typo on HRegionServerCommandLine.java
  • [HBASE-15578] - Handle HBASE-15234 for ReplicationHFileCleaner
  • [HBASE-15582] - SnapshotManifestV1 too verbose when there are no regions
  • [HBASE-15587] - FSTableDescriptors.getDescriptor() logs stack trace erronously
  • [HBASE-15591] - ServerCrashProcedure not yielding
  • [HBASE-15593] - Time limit of scanning should be offered by client
  • [HBASE-15613] - TestNamespaceCommand times out
  • [HBASE-15615] - Wrong sleep time when RegionServerCallable need retry
  • [HBASE-15617] - Canary in regionserver mode might not enumerate all regionservers
  • [HBASE-15621] - Suppress Hbase SnapshotHFile cleaner error messages when a snaphot is going on
  • [HBASE-15622] - Superusers does not consider the keytab credentials
  • [HBASE-15627] - Miss space and closing quote in AccessController#checkSystemOrSuperUser
  • [HBASE-15634] - TestDateTieredCompactionPolicy#negativeForMajor is flaky
  • [HBASE-15636] - hard coded wait time out value in HBaseTestingUtility#waitUntilAllRegionsAssigned might cause test failure
  • [HBASE-15637] - TSHA Thrift-2 server should allow limiting call queue size
  • [HBASE-15639] - Unguarded access to stackIndexes in Procedure#toStringDetails()
  • [HBASE-15645] - hbase.rpc.timeout is not used in operations of HTable
  • [HBASE-15650] - Remove TimeRangeTracker as point of contention when many threads reading a StoreFile
  • [HBASE-15664] - Use Long.MAX_VALUE instead of HConstants.FOREVER in CompactionPolicy
  • [HBASE-15668] - HFileReplicator$Copier fails to replicate other hfiles in the request when a hfile in not found in FS anywhere
  • [HBASE-15669] - HFile size is not considered correctly in a replication request
  • [HBASE-15670] - Add missing Snapshot.proto to the maven profile for compiling protobuf
  • [HBASE-15672] - hadoop.hbase.security.visibility.TestVisibilityLabelsWithDeletes fails
  • [HBASE-15673] - [PE tool] Fix latency metrics for multiGet
  • [HBASE-15674] - HRegionLocator#getAllRegionLocations should put the results in cache
  • [HBASE-15676] - FuzzyRowFilter fails and matches all the rows in the table if the mask consists of all 0s
  • [HBASE-15693] - Reconsider the ImportOrder rule of checkstyle
  • [HBASE-15697] - Excessive TestHRegion running time on branch-1
  • [HBASE-15698] - Increment TimeRange not serialized to server
  • [HBASE-15703] - Deadline scheduler needs to return to the client info about skipped calls, not just drop them
  • [HBASE-15707] - ImportTSV bulk output does not support tags with hfile.format.version=3
  • [HBASE-15710] - Include issue servers information in RetriesExhaustedWithDetailsException message
  • [HBASE-15714] - We are calling checkRow() twice in doMiniBatchMutation()
  • [HBASE-15738] - Ensure artifacts in project dist area include required md5 file
  • [HBASE-15741] - Provide backward compatibility for HBase coprocessor service names
  • [HBASE-15742] - Reduce allocation of objects in metrics
  • [HBASE-15746] - Remove extra RegionCoprocessor preClose() in RSRpcServices#closeRegion
  • [HBASE-15752] - ClassNotFoundException is encountered when custom WAL codec is not found in WALPlayer job
  • [HBASE-15755] - SnapshotDescriptionUtils and SnapshotTestingUtils do not have any Interface audience marked
  • [HBASE-15775] - Canary launches two AuthUtil Chores
  • [HBASE-15801] - Upgrade checkstyle for all branches
  • [HBASE-15811] - Batch Get after batch Put does not fetch all Cells
  • [HBASE-15824] - LocalHBaseCluster gets bind exception in master info port
  • [HBASE-15840] - WAL.proto compilation broken for cpp
  • [HBASE-15841] - Performance Evaluation tool total rows may not be set correctly
  • [HBASE-15850] - Localize the configuration change in testCheckTableLocks to reduce flakiness of TestHBaseFsck test suite
  • [HBASE-15856] - Cached Connection instances can wind up with addresses never resolved
  • [HBASE-15873] - ACL for snapshot restore / clone is not enforced
  • [HBASE-15876] - Remove doBulkLoad(Path hfofDir, final HTable table) though it has not been through a full deprecation cycle
  • [HBASE-15880] - RpcClientImpl#tracedWriteRequest incorrectly closes HTrace span
  • [HBASE-15884] - NPE in StoreFileScanner#skipKVsNewerThanReadpoint during reverse scan
  • [HBASE-15908] - Checksum verification is broken due to incorrect passing of ByteBuffers in DataChecksum
  • [HBASE-15913] - Sasl encryption doesn't work with AsyncRpcChannel
  • [HBASE-15920] - Backport submit-patch.py to branch-1 and earlier branches.
  • [HBASE-15925] - compat-module maven variable not evaluated
  • [HBASE-15946] - Eliminate possible security concerns in RS web UI's store file metrics
  • [HBASE-15952] - Bulk load data replication is not working when RS user does not have permission on hfile-refs node
  • [HBASE-15954] - REST server should log requests with TRACE instead of DEBUG
  • [HBASE-15955] - Disable action in CatalogJanitor#setEnabled should wait for active cleanup scan to finish
  • [HBASE-15957] - RpcClientImpl.close never ends in some circumstances
  • [HBASE-15975] - logic in TestHTableDescriptor#testAddCoprocessorWithSpecStr is wrong
  • [HBASE-15976] - RegionServerMetricsWrapperRunnable will be failure when disable blockcache.
  • [HBASE-16007] - Job's Configuration should be passed to TableMapReduceUtil#addDependencyJars() in WALPlayer
  • [HBASE-16012] - Major compaction can't work due to obsolete scanner read point in RegionServer
  • [HBASE-16016] - AssignmentManager#waitForAssignment could have unexpected negative deadline
  • [HBASE-16017] - HBase TableOutputFormat has connection leak in getRecordWriter
  • [HBASE-16024] - Revert HBASE-15406 from branch-1.3
  • [HBASE-16032] - Possible memory leak in StoreScanner
  • [HBASE-16033] - Add more details in logging of responseTooSlow/TooLarge
  • [HBASE-16047] - TestFastFail is broken again
  • [HBASE-16061] - Allow logging to a buffered console
  • [HBASE-16062] - Improper error handling in WAL Reader/Writer creation
  • [HBASE-16074] - ITBLL fails, reports lost big or tiny families
  • [HBASE-16081] - Replication remove_peer gets stuck and blocks WAL rolling
  • [HBASE-16093] - Splits failed before creating daughter regions leave meta inconsistent
  • [HBASE-16095] - Add priority to TableDescriptor and priority region open thread pool
  • [HBASE-16096] - Replication keeps accumulating znodes
  • [HBASE-16129] - check_compatibility.sh is broken when using Java API Compliance Checker v1.7
  • [HBASE-16132] - Scan does not return all the result when regionserver is busy
  • [HBASE-16135] - PeerClusterZnode under rs of removed peer may never be deleted
  • [HBASE-16144] - Replication queue's lock will live forever if RS acquiring the lock has died prematurely
  • [HBASE-16150] - Remove ConcurrentIndex
  • [HBASE-16160] - Get the UnsupportedOperationException when using delegation token with encryption
  • [HBASE-16165] - Decrease RpcServer.callQueueSize before writeResponse causes OOM
  • [HBASE-16177] - In dev mode thrift server can't be run
  • [HBASE-16190] - IntegrationTestDDLMasterFailover failed with IllegalArgumentException: n must be positive
  • [HBASE-16201] - NPE in RpcServer causing intermittent UT failure of TestMasterReplication#testHFileCyclicReplication
  • [HBASE-16207] - can't restore snapshot without "Admin" permission
  • [HBASE-16211] - JMXCacheBuster restarting the metrics system might cause tests to hang
  • [HBASE-16221] - Thrift server drops connection on long scans
  • [HBASE-16227] - [Shell] Column value formatter not working in scans
  • [HBASE-16237] - Blocks for hbase:meta table are not cached in L1 cache
  • [HBASE-16238] - It's useless to catch SESSIONEXPIRED exception and retry in RecoverableZooKeeper
  • [HBASE-16270] - Handle duplicate clearing of snapshot in region replicas
  • [HBASE-16271] - Fix logging and re-run the test in IntegrationTestBulkLoad
  • [HBASE-16272] - Overflow in ServerName's compareTo method
  • [HBASE-16281] - TestMasterReplication is flaky
  • [HBASE-16284] - Unauthorized client can shutdown the cluster
  • [HBASE-16288] - HFile intermediate block level indexes might recurse forever creating multi TB files
  • [HBASE-16289] - AsyncProcess stuck messages need to print region/server
  • [HBASE-16294] - hbck reporting "No HDFS region dir found" for replicas
  • [HBASE-16296] - Reverse scan performance degrades when using filter lists
  • [HBASE-16300] - LruBlockCache.CACHE_FIXED_OVERHEAD should calculate LruBlockCache size correctly
  • [HBASE-16301] - Trigger flush without waiting when compaction is disabled on a table
  • [HBASE-16303] - FilterList with MUST_PASS_ONE optimization
  • [HBASE-16304] - HRegion#RegionScannerImpl#handleFileNotFoundException may lead to deadlock when trying to obtain write lock on updatesLock
  • [HBASE-16315] - RegionSizeCalculator prints region names as binary without escapes
  • [HBASE-16319] - Fix TestCacheOnWrite after HBASE-16288
  • [HBASE-16341] - Missing bit on "Regression: Random Read/WorkloadC slower in 1.x than 0.98"
  • [HBASE-16350] - Undo server abort from HBASE-14968
  • [HBASE-16355] - hbase-client dependency on hbase-common test-jar should be test scope
  • [HBASE-16360] - TableMapReduceUtil addHBaseDependencyJars has the wrong class name for PrefixTreeCodec
  • [HBASE-16363] - Correct javadoc for qualifier length and value length in Cell interface
  • [HBASE-16368] - test*WhenRegionMove in TestPartialResultsFromClientSide is flaky
  • [HBASE-16373] - precommit needs a dockerfile with hbase prereqs
  • [HBASE-16375] - Mapreduce mini cluster using HBaseTestingUtility not setting correct resourcemanager and jobhistory webapp address of MapReduceTestingShim
  • [HBASE-16429] - FSHLog: deadlock if rollWriter called when ring buffer filled with appends
  • [HBASE-16460] - Can't rebuild the BucketAllocator's data structures when BucketCache uses FileIOEngine
  • [HBASE-16464] - archive folder grows bigger and bigger due to corrupt snapshot under tmp dir
  • [HBASE-16471] - Region Server metrics context will be wrong when machine hostname contain "master" word
  • [HBASE-16527] - IOExceptions from DFS client still can cause CatalogJanitor to delete referenced files
  • [HBASE-16528] - Procedure-V2: ServerCrashProcedure misses owner information
  • [HBASE-16535] - Use regex to exclude generated classes for findbugs
  • [HBASE-16547] - hbase-archetype-builder shell scripts assume bash is installed in /bin
  • [HBASE-16552] - MiniHBaseCluster#getServerWith() does not ignore stopped RSs
  • [HBASE-16589] - Adjust log level for FATAL messages from HBaseReplicationEndpoint that are not fatal
  • [HBASE-16604] - Scanner retries on IOException can cause the scans to miss data
  • [HBASE-16613] - Return the unused ByteBuffer to BoundedByteBufferPool when no cell is retrieved from the CellScanner
  • [HBASE-16644] - Errors when reading legit HFile Trailer of old (v2.0) format file
  • [HBASE-16649] - Truncate table with splits preserved can cause both data loss and truncated data appeared again
  • [HBASE-16660] - ArrayIndexOutOfBounds during the majorCompactionCheck in DateTieredCompaction
  • [HBASE-16662] - Fix open POODLE vulnerabilities
  • [HBASE-16663] - JMX ConnectorServer stopped when unauthorized user try to stop HM/RS/cluster
  • [HBASE-16664] - Timeout logic in AsyncProcess is broken
  • [HBASE-16678] - MapReduce jobs do not update counters from ScanMetrics
  • [HBASE-16679] - Flush throughput controller: Minor perf change and fix flaky TestFlushWithThroughputController
  • [HBASE-16681] - Fix flaky TestReplicationSourceManagerZkImpl
  • [HBASE-16682] - Fix Shell tests failure. NoClassDefFoundError for MiniKdc
  • [HBASE-16699] - Overflows in AverageIntervalRateLimiter's refill() and getWaitInterval()
  • [HBASE-16701] - TestHRegion and TestHRegionWithInMemoryFlush timing out
  • [HBASE-16721] - Concurrency issue in WAL unflushed seqId tracking
  • [HBASE-16723] - RMI registry is not destroyed after stopping JMX Connector Server
  • [HBASE-16732] - Avoid possible NPE in MetaTableLocator
  • [HBASE-16743] - TestSimpleRpcScheduler#testCoDelScheduling is broke
  • [HBASE-16752] - Upgrading from 1.2 to 1.3 can lead to replication failures due to difference in RPC size limit
  • [HBASE-16754] - Regions failing compaction due to referencing non-existent store file
  • [HBASE-16765] - New SteppingRegionSplitPolicy, avoid too aggressive spread of regions for small tables.
  • [HBASE-16788] - Race in compacted file deletion between HStore close() and closeAndArchiveCompactedFiles()
  • [HBASE-16807] - RegionServer will fail to report new active Hmaster until HMaster/RegionServer failover
  • [HBASE-16810] - HBase Balancer throws ArrayIndexOutOfBoundsException when regionservers are in /hbase/draining znode and unloaded
  • [HBASE-16824] - Writer.flush() can be called on already closed streams in WAL roll
  • [HBASE-16830] - RSRpcServices#openRegion() should handle the case where table descriptor is null
  • [HBASE-16852] - TestDefaultCompactSelection failed on branch-1.3
  • [HBASE-16853] - Regions are assigned to Region Servers in /hbase/draining after HBase Master failover
  • [HBASE-16889] - Proc-V2: verifyTables in the IntegrationTestDDLMasterFailover test after each table DDL is incorrect
  • [HBASE-16931] - Setting cell's seqId to zero in compaction flow might cause RS down.
  • [HBASE-16960] - RegionServer hang when aborting
  • [HBASE-16964] - Successfully archived files are not cleared from compacted store file list if archiving of any file fails
  • [HBASE-16980] - TestRowProcessorEndpoint failing consistently
  • [HBASE-17023] - Region left unassigned due to AM and SSH each thinking others would do the assignment work
  • [HBASE-17032] - CallQueueTooBigException and CallDroppedException should not be triggering PFFE
  • [HBASE-17042] - Remove 'public' keyword from MasterObserver interface
  • [HBASE-17044] - Fix merge failed before creating merged region leaves meta inconsistent
  • [HBASE-17058] - Lower epsilon used for jitter verification from HBASE-15324
  • [HBASE-17074] - PreCommit job always fails because of OOM
  • [HBASE-17091] - IntegrationTestZKAndFSPermissions failed with 'KeeperException'
  • [HBASE-17224] - Fix lots of spelling errors in HBase logging and exception messages
  • [HBASE-17238] - Wrong in-memory hbase:meta location causing SSH failure
  • [HBASE-17328] - Properly dispose of looped replication peers
  • [HBASE-17341] - Add a timeout during replication endpoint termination
  • Improvement:
  • [HBASE-7972] - Add a configuration for the TCP backlog in the Thrift server
  • [HBASE-8386] - deprecate TableMapReduce.addDependencyJars(Configuration, class ...)
  • [HBASE-8642] - [Snapshot] List and delete snapshot by table
  • [HBASE-9899] - for idempotent operation dups, return the result instead of throwing conflict exception
  • [HBASE-12596] - bulkload needs to follow locality
  • [HBASE-12769] - Replication fails to delete all corresponding zk nodes when peer is removed
  • [HBASE-12940] - Expose listPeerConfigs and getPeerConfig to the HBase shell
  • [HBASE-13158] - When client supports CellBlock, return the result Cells as controller payload for get(Get) API also
  • [HBASE-13347] - Deprecate FirstKeyValueMatchingQualifiersFilter
  • [HBASE-13532] - Make UnknownScannerException logging less scary
  • [HBASE-13965] - Stochastic Load Balancer JMX Metrics
  • [HBASE-14045] - Bumping thrift version to 0.9.2.
  • [HBASE-14058] - Stabilizing default heap memory tuner
  • [HBASE-14078] - improve error message when HMaster can't bind to port
  • [HBASE-14164] - Display primary region replicas distribution on table.jsp
  • [HBASE-14165] - The initial size of RWQueueRpcExecutor.queues should be (numWriteQueues + numReadQueues + numScanQueues)
  • [HBASE-14306] - Refine RegionGroupingProvider: fix issues and make it more scalable
  • [HBASE-14309] - Allow load balancer to operate when there is region in transition by adding force flag
  • [HBASE-14345] - Consolidate printUsage in IntegrationTestLoadAndVerify
  • [HBASE-14397] - PrefixFilter doesn't filter all remaining rows if the prefix is longer than rowkey being compared
  • [HBASE-14448] - Refine RegionGroupingProvider Phase-2: remove provider nesting and formalize wal group name
  • [HBASE-14565] - Make ZK connection timeout configurable in MiniZooKeeperCluster
  • [HBASE-14703] - HTable.mutateRow does not collect stats
  • [HBASE-14719] - Add metric for number of MasterProcWALs
  • [HBASE-14800] - Expose checkAndMutate via Thrift2
  • [HBASE-14963] - Remove use of Guava Stopwatch from HBase client code
  • [HBASE-14969] - Add throughput controller for flush
  • [HBASE-14983] - Create metrics for per block type hit/miss ratios
  • [HBASE-15066] - Small improvements to Canary tool
  • [HBASE-15068] - Add metrics for region normalization plans
  • [HBASE-15119] - Include git SHA in check_compatibility reports
  • [HBASE-15123] - Remove duplicate code in LocalHBaseCluster and minor formatting
  • [HBASE-15177] - Reduce garbage created under high load
  • [HBASE-15212] - RRCServer should enforce max request size
  • [HBASE-15222] - Use less contended classes for metrics
  • [HBASE-15223] - Make convertScanToString public for Spark
  • [HBASE-15306] - Make RPC call queue length dynamically configurable
  • [HBASE-15315] - Remove always set super user call as high priority
  • [HBASE-15353] - Add metric for number of CallQueueTooBigException's
  • [HBASE-15396] - Enhance mapreduce.TableSplit to add encoded region name
  • [HBASE-15413] - Procedure-V2: print out ProcedureInfo during trace
  • [HBASE-15415] - Improve Master WebUI snapshot information
  • [HBASE-15456] - CreateTableProcedure/ModifyTableProcedure needs to fail when there is no family in table descriptor
  • [HBASE-15470] - Add a setting for Priority queue length
  • [HBASE-15471] - Add num calls in priority and general queue to RS UI
  • [HBASE-15475] - Allow TimestampsFilter to provide a seek hint
  • [HBASE-15478] - add comments to FSHLog explaining why syncRunnerIndex won't overflow
  • [HBASE-15508] - Add command for exporting snapshot in hbase command script
  • [HBASE-15526] - Make SnapshotManager accessible through MasterServices
  • [HBASE-15551] - Make call queue too big exception use servername
  • [HBASE-15569] - Make Bytes.toStringBinary faster
  • [HBASE-15586] - Unify human readable numbers in the web UI
  • [HBASE-15600] - Add provision for adding mutations to memstore or able to write to same region in batchMutate coprocessor hooks
  • [HBASE-15605] - Remove PB references from HCD and HTD for 2.0
  • [HBASE-15607] - Remove PB references from Admin for 2.0
  • [HBASE-15608] - Remove PB references from SnapShot related Exceptions
  • [HBASE-15609] - Remove PB references from Result, DoubleColumnInterpreter and any such public facing class for 2.0
  • [HBASE-15632] - Undo the checking of lastStoreFlushTimeMap.isEmpty() introduced in HBASE-13145
  • [HBASE-15641] - Shell "alter" should do a single modifyTable operation
  • [HBASE-15720] - Print row locks at the debug dump page
  • [HBASE-15773] - CellCounter improvements
  • [HBASE-15791] - Improve javadoc in ScheduledChore
  • [HBASE-15808] - Reduce potential bulk load intermediate space usage and waste
  • [HBASE-15837] - Memstore size accounting is wrong if postBatchMutate() throws exception
  • [HBASE-15854] - Log the cause of SASL connection failures
  • [HBASE-15864] - Reuse the testing helper to wait regions in transition
  • [HBASE-15870] - Specify columns in REST multi gets
  • [HBASE-15890] - Allow thrift to set/unset "cacheBlocks" for Scans
  • [HBASE-15931] - Add log for long-running tasks in AsyncProcess
  • [HBASE-16026] - Master UI should display status of additional ZK switches
  • [HBASE-16048] - Tag InternalScanner with LimitedPrivate(HBaseInterfaceAudience.COPROC)
  • [HBASE-16085] - Add on metric for failed compactions
  • [HBASE-16086] - TableCfWALEntryFilter and ScopeWALEntryFilter should not redundantly iterate over cells.
  • [HBASE-16087] - Replication shouldn't start on a master if if only hosts system tables
  • [HBASE-16089] - Add on FastPath for CoDel
  • [HBASE-16124] - Make check_compatibility.sh less verbose when building HBase
  • [HBASE-16140] - bump owasp.esapi from 2.1.0 to 2.1.0.1
  • [HBASE-16149] - Log the underlying RPC exception in RpcRetryingCallerImpl
  • [HBASE-16231] - Integration tests should support client keytab login for secure clusters
  • [HBASE-16241] - Allow specification of annotations to use when running check_compatibility.sh
  • [HBASE-16256] - Purpose of EnvironmentEdge, EnvironmentEdgeManager
  • [HBASE-16266] - Do not throw ScannerTimeoutException when catch UnknownScannerException
  • [HBASE-16287] - LruBlockCache size should not exceed acceptableSize too many
  • [HBASE-16379] - [replication] Minor improvement to replication/copy_tables_desc.rb
  • [HBASE-16385] - Have hbase-rest pull hbase.rest.port from Constants.java
  • [HBASE-16450] - Shell tool to dump replication queues
  • [HBASE-16486] - Unify system table creation using the same createSystemTable API.
  • [HBASE-16657] - Expose per-region last major compaction timestamp in RegionServer UI
  • [HBASE-16661] - Add last major compaction age to per-region metrics
  • [HBASE-16667] - Building with JDK 8: ignoring option MaxPermSize=256m
  • [HBASE-16972] - Log more details for Scan#next request when responseTooSlow
  • [HBASE-17006] - Add names to threads for better debugability of thread dumps
  • [HBASE-17004] - Refactor IntegrationTestManyRegions to use @ClassRule for timing out
  • New Feature:
  • [HBASE-10358] - Shell changes for setting consistency per request
  • [HBASE-11262] - Avoid empty columns while doing bulk-load
  • [HBASE-12133] - Add FastLongHistogram for metric computation
  • [HBASE-13153] - Bulk Loaded HFile Replication
  • [HBASE-13702] - ImportTsv: Add dry-run functionality and log bad rows
  • [HBASE-14456] - Implement a namespace-based region grouping strategy for RegionGroupingProvider
  • [HBASE-15135] - Add metrics for storefile age
  • [HBASE-15136] - Explore different queuing behaviors while busy
  • [HBASE-15181] - A simple implementation of date based tiered compaction
  • [HBASE-15281] - Allow the FileSystem inside HFileSystem to be wrapped
  • [HBASE-15481] - Add pre/post roll to WALObserver
  • [HBASE-15592] - Print Procedure WAL content
  • [HBASE-15780] - Expose AuthUtil as IA.Public
  • [HBASE-15881] - Allow BZIP2 compression
  • Task:
  • [HBASE-14057] - HBase shell user_permission should list super users defined on hbase-site.xml
  • [HBASE-15729] - Remove old JDiff wrapper scripts in dev-support
  • [HBASE-15888] - Extend HBASE-12769 for bulk load data replication
  • [HBASE-15895] - remove unmaintained jenkins build analysis tool.
  • [HBASE-16073] - update compatibility_checker for jacc dropping comma sep args
  • [HBASE-16154] - bring non-master branches up to date wrt check_compatibility script
  • [HBASE-16260] - Audit dependencies for Category-X
  • [HBASE-16340] - ensure no Xerces jars included
  • [HBASE-16376] - Document implicit side-effects on partial results when calling Scan#setBatch(int)
  • [HBASE-16467] - Move AbstractHBaseTool to hbase-common
  • [HBASE-16518] - Remove old .arcconfig file
  • Test:
  • [HBASE-13372] - Unit tests for SplitTransaction and RegionMergeTransaction listeners
  • [HBASE-14293] - TestStochasticBalancerJmxMetrics intermittently fails due to port conflict
  • [HBASE-15679] - Assertion on wrong variable in TestReplicationThrottler#testThrottling
  • [HBASE-15923] - Shell rows counter test fails
  • [HBASE-16049] - TestRowProcessorEndpoint is failing on Apache Builds
  • [HBASE-16051] - TestScannerHeartbeatMessages fails on some machines
  • Umbrella:
  • [HBASE-14457] - Umbrella: Improve Multiple WAL for production usage

New in Apache HBase 1.2.4 (Nov 7, 2016)

  • Sub-task:
  • [HBASE-14734] - BindException when setting up MiniKdc
  • [HBASE-15984] - Given failure to parse a given WAL that was closed cleanly, replay the WAL.
  • [HBASE-16101] - Procedure v2 - Perf Tool for WAL
  • [HBASE-16522] - Procedure v2 - Cache system user and avoid IOException
  • [HBASE-16970] - Clarify misleading Scan.java comment about caching
  • Bug:
  • [HBASE-16165] - Decrease RpcServer.callQueueSize before writeResponse causes OOM
  • [HBASE-16294] - hbck reporting "No HDFS region dir found" for replicas
  • [HBASE-16373] - precommit needs a dockerfile with hbase prereqs
  • [HBASE-16375] - Mapreduce mini cluster using HBaseTestingUtility not setting correct resourcemanager and jobhistory webapp address of MapReduceTestingShim
  • [HBASE-16460] - Can't rebuild the BucketAllocator's data structures when BucketCache uses FileIOEngine
  • [HBASE-16527] - IOExceptions from DFS client still can cause CatalogJanitor to delete referenced files
  • [HBASE-16528] - Procedure-V2: ServerCrashProcedure misses owner information
  • [HBASE-16535] - Use regex to exclude generated classes for findbugs
  • [HBASE-16538] - Version mismatch in HBaseConfiguration.checkDefaultsVersion
  • [HBASE-16552] - MiniHBaseCluster#getServerWith() does not ignore stopped RSs
  • [HBASE-16589] - Adjust log level for FATAL messages from HBaseReplicationEndpoint that are not fatal
  • [HBASE-16604] - Scanner retries on IOException can cause the scans to miss data
  • [HBASE-16613] - Return the unused ByteBuffer to BoundedByteBufferPool when no cell is retrieved from the CellScanner
  • [HBASE-16649] - Truncate table with splits preserved can cause both data loss and truncated data appeared again
  • [HBASE-16662] - Fix open POODLE vulnerabilities
  • [HBASE-16663] - JMX ConnectorServer stopped when unauthorized user try to stop HM/RS/cluster
  • [HBASE-16678] - MapReduce jobs do not update counters from ScanMetrics
  • [HBASE-16682] - Fix Shell tests failure. NoClassDefFoundError for MiniKdc
  • [HBASE-16699] - Overflows in AverageIntervalRateLimiter's refill() and getWaitInterval()
  • [HBASE-16701] - TestHRegion and TestHRegionWithInMemoryFlush timing out
  • [HBASE-16721] - Concurrency issue in WAL unflushed seqId tracking
  • [HBASE-16723] - RMI registry is not destroyed after stopping JMX Connector Server
  • [HBASE-16732] - Avoid possible NPE in MetaTableLocator
  • [HBASE-16754] - Regions failing compaction due to referencing non-existent store file
  • [HBASE-16765] - New SteppingRegionSplitPolicy, avoid too aggressive spread of regions for small tables.
  • [HBASE-16807] - RegionServer will fail to report new active Hmaster until HMaster/RegionServer failover
  • [HBASE-16815] - Low scan ratio in RPC queue tuning triggers divide by zero exception
  • [HBASE-16824] - Writer.flush() can be called on already closed streams in WAL roll
  • [HBASE-16830] - RSRpcServices#openRegion() should handle the case where table descriptor is null
  • [HBASE-16870] - Add the metrics of replication sources which were transformed from other dead rs to ReplicationLoad
  • [HBASE-16889] - Proc-V2: verifyTables in the IntegrationTestDDLMasterFailover test after each table DDL is incorrect
  • [HBASE-16931] - Setting cell's seqId to zero in compaction flow might cause RS down.
  • [HBASE-16939] - ExportSnapshot: set owner and permission on right directory
  • [HBASE-16948] - Fix inconsistency between HRegion and Region javadoc on getRowLock
  • [HBASE-16960] - RegionServer hang when aborting
  • Improvement:
  • [HBASE-15315] - Remove always set super user call as high priority
  • [HBASE-16033] - Add more details in logging of responseTooSlow/TooLarge
  • [HBASE-16667] - Building with JDK 8: ignoring option MaxPermSize=256m
  • [HBASE-16972] - Log more details for Scan#next request when responseTooSlow
  • [HBASE-17004] - Refactor IntegrationTestManyRegions to use @ClassRule for timing out
  • [HBASE-17006] - Add names to threads for better debugability of thread dumps
  • Task:
  • [HBASE-16340] - ensure no Xerces jars included
  • [HBASE-16518] - Remove old .arcconfig file
  • [HBASE-16748] - Release 1.2.4
  • [HBASE-16749] - HBase root pom.xml contains repo from people.apache.org/~garyh

New in Apache HBase 1.2.3 (Sep 13, 2016)

  • Sub-task:
  • [HBASE-16101] - Procedure v2 - Perf Tool for WAL
  • [HBASE-16189] - [Rolling Upgrade] 2.0 hfiles cannot be opened by 1.x servers
  • [HBASE-16194] - Should count in MSLAB chunk allocation into heap size change when adding duplicate cells
  • [HBASE-16195] - Should not add chunk into chunkQueue if not using chunk pool in HeapMemStoreLAB
  • [HBASE-16317] - revert all ESAPI changes
  • [HBASE-16318] - fail build if license isn't in whitelist
  • [HBASE-16321] - Ensure findbugs jsr305 jar isn't present
  • [HBASE-16452] - Procedure v2 - Make ProcedureWALPrettyPrinter extend Tool
  • [HBASE-16522] - Procedure v2 - Cache system user and avoid IOException
  • Bug:
  • [HBASE-14753] - TestShell is not invoked anymore
  • [HBASE-15635] - Mean age of Blocks in cache (seconds) on webUI should be greater than zero
  • [HBASE-15775] - Canary launches two AuthUtil Chores
  • [HBASE-16132] - Scan does not return all the result when regionserver is busy
  • [HBASE-16135] - PeerClusterZnode under rs of removed peer may never be deleted
  • [HBASE-16144] - Replication queue's lock will live forever if RS acquiring the lock has died prematurely
  • [HBASE-16190] - IntegrationTestDDLMasterFailover failed with IllegalArgumentException: n must be positive
  • [HBASE-16201] - NPE in RpcServer causing intermittent UT failure of TestMasterReplication#testHFileCyclicReplication
  • [HBASE-16207] - can't restore snapshot without "Admin" permission
  • [HBASE-16227] - [Shell] Column value formatter not working in scans
  • [HBASE-16237] - Blocks for hbase:meta table are not cached in L1 cache
  • [HBASE-16270] - Handle duplicate clearing of snapshot in region replicas
  • [HBASE-16272] - Overflow in ServerName's compareTo method
  • [HBASE-16281] - TestMasterReplication is flaky
  • [HBASE-16284] - Unauthorized client can shutdown the cluster
  • [HBASE-16288] - HFile intermediate block level indexes might recurse forever creating multi TB files
  • [HBASE-16289] - AsyncProcess stuck messages need to print region/server
  • [HBASE-16296] - Reverse scan performance degrades when using filter lists
  • [HBASE-16300] - LruBlockCache.CACHE_FIXED_OVERHEAD should calculate LruBlockCache size correctly
  • [HBASE-16304] - HRegion#RegionScannerImpl#handleFileNotFoundException may lead to deadlock when trying to obtain write lock on updatesLock
  • [HBASE-16315] - RegionSizeCalculator prints region names as binary without escapes
  • [HBASE-16319] - Fix TestCacheOnWrite after HBASE-16288
  • [HBASE-16350] - Undo server abort from HBASE-14968
  • [HBASE-16363] - Correct javadoc for qualifier length and value length in Cell interface
  • [HBASE-16368] - test*WhenRegionMove in TestPartialResultsFromClientSide is flaky
  • [HBASE-16420] - Fix source incompatibility of Table interface
  • [HBASE-16429] - FSHLog: deadlock if rollWriter called when ring buffer filled with appends
  • [HBASE-16464] - archive folder grows bigger and bigger due to corrupt snapshot under tmp dir
  • [HBASE-16471] - Region Server metrics context will be wrong when machine hostname contain "master" word
  • [HBASE-16528] - Procedure-V2: ServerCrashProcedure misses owner information
  • [HBASE-16538] - Version mismatch in HBaseConfiguration.checkDefaultsVersion
  • [HBASE-16552] - MiniHBaseCluster#getServerWith() does not ignore stopped RSs
  • Improvement:
  • [HBASE-14345] - Consolidate printUsage in IntegrationTestLoadAndVerify
  • [HBASE-15931] - Add log for long-running tasks in AsyncProcess
  • [HBASE-16241] - Allow specification of annotations to use when running check_compatibility.sh
  • [HBASE-16256] - Purpose of EnvironmentEdge, EnvironmentEdgeManager
  • [HBASE-16266] - Do not throw ScannerTimeoutException when catch UnknownScannerException
  • [HBASE-16287] - LruBlockCache size should not exceed acceptableSize too many
  • [HBASE-16379] - [replication] Minor improvement to replication/copy_tables_desc.rb
  • [HBASE-16385] - Have hbase-rest pull hbase.rest.port from Constants.java
  • Task:
  • [HBASE-16260] - Audit dependencies for Category-X
  • [HBASE-16376] - Document implicit side-effects on partial results when calling Scan#setBatch(int)
  • [HBASE-16467] - Move AbstractHBaseTool to hbase-common
  • [HBASE-16518] - Remove old .arcconfig file

New in Apache HBase 1.2.2 (Jul 14, 2016)

  • Sub-task:
  • [HBASE-15386] - PREFETCH_BLOCKS_ON_OPEN in HColumnDescriptor is ignored
  • [HBASE-15640] - L1 cache doesn't give fair warning that it is showing partial stats only when it hits limit
  • [HBASE-15872] - Split TestWALProcedureStore
  • [HBASE-15878] - Deprecate doBulkLoad(Path hfofDir, final HTable table) in branch-1 (even though its 'late')
  • [HBASE-16034] - Fix ProcedureTestingUtility#LoadCounter.setMaxProcId()
  • [HBASE-16056] - Procedure v2 - fix master crash for FileNotFound
  • [HBASE-16068] - Procedure v2 - use consts for conf properties in tests
  • Bug:
  • [HBASE-11625] - Reading datablock throws "Invalid HFile block magic" and can not switch to hdfs checksum
  • [HBASE-14644] - Region in transition metric is broken
  • [HBASE-14818] - user_permission does not list namespace permissions
  • [HBASE-15234] - ReplicationLogCleaner can abort due to transient ZK issues
  • [HBASE-15465] - userPermission returned by getUserPermission() for the selected namespace does not have namespace set
  • [HBASE-15485] - Filter.reset() should not be called between batches
  • [HBASE-15582] - SnapshotManifestV1 too verbose when there are no regions
  • [HBASE-15587] - FSTableDescriptors.getDescriptor() logs stack trace erronously
  • [HBASE-15591] - ServerCrashProcedure not yielding
  • [HBASE-15596] - hbAdmin is not closed after LoadIncrementalHFiles completes
  • [HBASE-15613] - TestNamespaceCommand times out
  • [HBASE-15615] - Wrong sleep time when RegionServerCallable need retry
  • [HBASE-15617] - Canary in regionserver mode might not enumerate all regionservers
  • [HBASE-15621] - Suppress Hbase SnapshotHFile cleaner error messages when a snaphot is going on
  • [HBASE-15622] - Superusers does not consider the keytab credentials
  • [HBASE-15627] - Miss space and closing quote in AccessController#checkSystemOrSuperUser
  • [HBASE-15636] - hard coded wait time out value in HBaseTestingUtility#waitUntilAllRegionsAssigned might cause test failure
  • [HBASE-15645] - hbase.rpc.timeout is not used in operations of HTable
  • [HBASE-15670] - Add missing Snapshot.proto to the maven profile for compiling protobuf
  • [HBASE-15674] - HRegionLocator#getAllRegionLocations should put the results in cache
  • [HBASE-15676] - FuzzyRowFilter fails and matches all the rows in the table if the mask consists of all 0s
  • [HBASE-15693] - Reconsider the ImportOrder rule of checkstyle
  • [HBASE-15698] - Increment TimeRange not serialized to server
  • [HBASE-15738] - Ensure artifacts in project dist area include required md5 file
  • [HBASE-15742] - Reduce allocation of objects in metrics
  • [HBASE-15746] - Remove extra RegionCoprocessor preClose() in RSRpcServices#closeRegion
  • [HBASE-15755] - SnapshotDescriptionUtils and SnapshotTestingUtils do not have any Interface audience marked
  • [HBASE-15801] - Upgrade checkstyle for all branches
  • [HBASE-15811] - Batch Get after batch Put does not fetch all Cells
  • [HBASE-15824] - LocalHBaseCluster gets bind exception in master info port
  • [HBASE-15827] - Backport HBASE-15125 'HBaseFsck's adoptHdfsOrphan function creates region with wrong end key boundary' to 1.2
  • [HBASE-15841] - Performance Evaluation tool total rows may not be set correctly
  • [HBASE-15850] - Localize the configuration change in testCheckTableLocks to reduce flakiness of TestHBaseFsck test suite
  • [HBASE-15856] - Cached Connection instances can wind up with addresses never resolved
  • [HBASE-15873] - ACL for snapshot restore / clone is not enforced
  • [HBASE-15880] - RpcClientImpl#tracedWriteRequest incorrectly closes HTrace span
  • [HBASE-15920] - Backport submit-patch.py to branch-1 and earlier branches.
  • [HBASE-15925] - compat-module maven variable not evaluated
  • [HBASE-15946] - Eliminate possible security concerns in RS web UI's store file metrics
  • [HBASE-15954] - REST server should log requests with TRACE instead of DEBUG
  • [HBASE-15955] - Disable action in CatalogJanitor#setEnabled should wait for active cleanup scan to finish
  • [HBASE-15957] - RpcClientImpl.close never ends in some circumstances
  • [HBASE-15975] - logic in TestHTableDescriptor#testAddCoprocessorWithSpecStr is wrong
  • [HBASE-15976] - RegionServerMetricsWrapperRunnable will be failure when disable blockcache.
  • [HBASE-16012] - Major compaction can't work due to obsolete scanner read point in RegionServer
  • [HBASE-16016] - AssignmentManager#waitForAssignment could have unexpected negative deadline
  • [HBASE-16032] - Possible memory leak in StoreScanner
  • [HBASE-16062] - Improper error handling in WAL Reader/Writer creation
  • [HBASE-16093] - Splits failed before creating daughter regions leave meta inconsistent
  • [HBASE-16129] - check_compatibility.sh is broken when using Java API Compliance Checker v1.7
  • Improvement:
  • [HBASE-13532] - Make UnknownScannerException logging less scary
  • [HBASE-15119] - Include git SHA in check_compatibility reports
  • [HBASE-15551] - Make call queue too big exception use servername
  • [HBASE-15569] - Make Bytes.toStringBinary faster
  • [HBASE-15720] - Print row locks at the debug dump page
  • [HBASE-15791] - Improve javadoc in ScheduledChore
  • [HBASE-15808] - Reduce potential bulk load intermediate space usage and waste
  • [HBASE-15837] - Memstore size accounting is wrong if postBatchMutate() throws exception
  • [HBASE-15854] - Log the cause of SASL connection failures
  • [HBASE-16124] - Make check_compatibility.sh less verbose when building HBase
  • [HBASE-16140] - bump owasp.esapi from 2.1.0 to 2.1.0.1
  • New Feature:
  • [HBASE-15592] - Print Procedure WAL content
  • Task:
  • [HBASE-15729] - Remove old JDiff wrapper scripts in dev-support
  • [HBASE-15895] - remove unmaintained jenkins build analysis tool.
  • [HBASE-16019] - Cut HBase 1.2.2 release
  • [HBASE-16073] - update compatibility_checker for jacc dropping comma sep args
  • [HBASE-16154] - bring non-master branches up to date wrt check_compatibility script

New in Apache HBase 1.1.3 (Jan 29, 2016)

  • Sub-task:
  • [HBASE-13415] - Procedure V2 - Use nonces for double submits from client
  • [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-14221] - Reduce the number of time row comparison is done in a Scan
  • [HBASE-14374] - Backport parent 'HBASE-14317 Stuck FSHLog' issue to 1.1
  • [HBASE-14428] - Upgrade our surefire-plugin from 2.18 to 2.18.1
  • [HBASE-14432] - Procedure V2 - enforce ACL on procedure admin tasks
  • [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-14538] - Remove TestVisibilityLabelsWithDistributedLogReplay, a test for an unsupported feature
  • [HBASE-14539] - Slight improvement of StoreScanner.optimize
  • [HBASE-14571] - Purge TestProcessBasedCluster; it does nothing and then fails
  • [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-14655] - Narrow the scope of doAs() calls to region observer notifications for compaction
  • [HBASE-14657] - Remove unneeded API from EncodedSeeker
  • [HBASE-14709] - Parent change breaks graceful_stop.sh on a cluster
  • [HBASE-14863] - Add missing test/resources/log4j files in hbase modules
  • [HBASE-14947] - Procedure V2 - WALProcedureStore improvements
  • [HBASE-15031] - Fix merge of MVCC and SequenceID performance regression in branch-1.0 for Increments
  • [HBASE-15095] - isReturnResult=false on fast path in branch-1.1 and branch-1.0 is not respected
  • Brainstorming:
  • [HBASE-14869] - Better request latency and size histograms
  • Bug:
  • [HBASE-13143] - TestCacheOnWrite is flaky and needs a diet
  • [HBASE-13250] - chown of ExportSnapshot does not cover all path and files
  • [HBASE-13318] - RpcServer.getListenerAddress should handle when the accept channel is closed
  • [HBASE-13324] - o.a.h.h.Coprocessor should be LimitedPrivate("Coprocessor")
  • [HBASE-13330] - Region left unassigned due to AM & SSH each thinking the assignment would be done by the other
  • [HBASE-13480] - ShortCircuitConnection doesn't short-circuit all calls as expected
  • [HBASE-13770] - Programmatic JAAS configuration option for secure zookeeper may be broken
  • [HBASE-13982] - Add info for visibility labels/cell TTLs to ImportTsv
  • [HBASE-14224] - Fix coprocessor handling of duplicate classes
  • [HBASE-14229] - Flushing canceled by coprocessor still leads to memstoreSize set down
  • [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-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-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-14327] - TestIOFencing#testFencingAroundCompactionAfterWALSync is flaky
  • [HBASE-14338] - License notification misspells 'Asciidoctor'
  • [HBASE-14342] - Recursive call in RegionMergeTransactionImpl.getJournal()
  • [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-14380] - Correct data gets skipped along with bad data in importTsv bulk load thru TsvImporterTextMapper
  • [HBASE-14382] - TestInterfaceAudienceAnnotations should hadoop-compt module resources
  • [HBASE-14385] - Close the sockets that is missing in connection closure.
  • [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-14431] - AsyncRpcClient#removeConnection() never removes connection from connections pool if server fails
  • [HBASE-14445] - ExportSnapshot does not honor -chmod option
  • [HBASE-14449] - Rewrite deadlock prevention for concurrent connection close
  • [HBASE-14471] - Thrift - HTTP Error 413 full HEAD if using kerberos authentication
  • [HBASE-14474] - DeadLock in RpcClientImpl.Connection.close()
  • [HBASE-14475] - Region split requests are always audited with "hbase" user rather than request user
  • [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-14531] - graceful_stop.sh "if [ "$local" ]" condition unexpected behaviour
  • [HBASE-14536] - Balancer & SSH interfering with each other leading to unavailability
  • [HBASE-14545] - TestMasterFailover often times out
  • [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-14594] - Use new DNS API introduced in HADOOP-12437
  • [HBASE-14598] - ByteBufferOutputStream grows its HeapByteBuffer beyond JVM limitations
  • [HBASE-14621] - ReplicationLogCleaner gets stuck when a regionserver crashes
  • [HBASE-14624] - BucketCache.freeBlock is too expensive
  • [HBASE-14632] - Region server aborts due to unguarded dereference of Reader
  • [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-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-14733] - Minor typo in alter_namespace.rb
  • [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-14782] - FuzzyRowFilter skips valid rows
  • [HBASE-14799] - Commons-collections object deserialization remote command execution vulnerability
  • [HBASE-14806] - Missing sources.jar for several modules when building HBase
  • [HBASE-14809] - Grant / revoke Namespace admin permission to group
  • [HBASE-14822] - Renewing leases of scanners doesn't work
  • [HBASE-14840] - Sink cluster reports data replication request as success though the data is not replicated
  • [HBASE-14843] - TestWALProcedureStore.testLoad is flakey
  • [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-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-14923] - VerifyReplication should not mask the exception during result comparison
  • [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-14952] - hbase-assembly source artifact has some incorrect modules
  • [HBASE-14954] - IllegalArgumentException was thrown when doing online configuration change in CompactSplitThread
  • [HBASE-14968] - ConcurrentModificationException in region close resulting in the region staying in closing state
  • [HBASE-14977] - ChoreService.shutdown may result in ConcurrentModificationException
  • [HBASE-14989] - Implementation of Mutation.getWriteToWAL() is backwards
  • [HBASE-15018] - Inconsistent way of handling TimeoutException in the rpc client implementations
  • [HBASE-15021] - hadoopqa doing false positives
  • [HBASE-15035] - bulkloading hfiles with tags that require splits do not preserve tags
  • [HBASE-15052] - Use EnvironmentEdgeManager in ReplicationSource
  • [HBASE-15083] - Gets from Multiactions are not counted in metrics for gets.
  • [HBASE-15085] - IllegalStateException was thrown when scanning on bulkloaded HFiles
  • [HBASE-15104] - Occasional failures due to NotServingRegionException in IT tests
  • Improvement:
  • [HBASE-13127] - Add timeouts on all tests so less zombie sightings
  • [HBASE-14261] - Enhance Chaos Monkey framework by adding zookeeper and datanode fault injections.
  • [HBASE-14325] - Add snapshotinfo command to hbase script
  • [HBASE-14436] - HTableDescriptor#addCoprocessor will always make RegionCoprocessorHost create new Configuration
  • [HBASE-14461] - Cleanup IncreasingToUpperBoundRegionSplitPolicy
  • [HBASE-14582] - Regionserver status webpage bucketcache list can become huge
  • [HBASE-14586] - Use a maven profile to run Jacoco analysis
  • [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-14696] - Support setting allowPartialResults in mapreduce Mappers
  • [HBASE-14715] - Add javadocs to DelegatingRetryingCallable
  • [HBASE-14730] - region server needs to log warnings when there are attributes configured for cells with hfile v2
  • [HBASE-14780] - Integration Tests that run with ChaosMonkey need to specify CFs
  • Task:
  • [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-14516] - categorize hadoop-compat tests
  • Test:
  • [HBASE-14277] - TestRegionServerHostname.testRegionServerHostname may fail at host with a case sensitive name
  • [HBASE-14344] - Add timeouts to TestHttpServerLifecycle
  • [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

New in Apache HBase 1.1.1 (Aug 19, 2015)

  • Sub-task:
  • [HBASE-13470] - High level Integration test for master DDL operations
  • [HBASE-13497] - Remove MVCC stamps from HFile when that is safe
  • [HBASE-13579] - Avoid isCellTTLExpired() for NO-TAG cases
  • [HBASE-13593] - Quota support for namespace should take snapshot restore and clone into account
  • [HBASE-13658] - Improve the test run time for TestAccessController class
  • [HBASE-13937] - Partially revert HBASE-13172
  • Bug:
  • [HBASE-11830] - TestReplicationThrottler.testThrottling failed on virtual boxes
  • [HBASE-12413] - Mismatch in the equals and hashcode methods of KeyValue
  • [HBASE-13200] - Improper configuration can leads to endless lease recovery during failover
  • [HBASE-13217] - Procedure fails due to ZK issue
  • [HBASE-13312] - SmallScannerCallable does not increment scan metrics
  • [HBASE-13325] - Protocol Buffers 2.5 no longer available for download on code.google.com
  • [HBASE-13333] - Renew Scanner Lease without advancing the RegionScanner
  • [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-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-13628] - Use AtomicLong as size in BoundedConcurrentLinkedQueue
  • [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-13647] - Default value for hbase.client.operation.timeout is too high
  • [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-13703] - ReplicateContext should not be a member of ReplicationSource
  • [HBASE-13704] - Hbase throws OutOfOrderScannerNextException when MultiRowRangeFilter is used
  • [HBASE-13709] - Updates to meta table server columns may be eclipsed
  • [HBASE-13711] - Provide an API to set min and max versions in HColumnDescriptor
  • [HBASE-13717] - TestBoundedRegionGroupingProvider#setMembershipDedups need to set HDFS diretory for WAL
  • [HBASE-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-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-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-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-13821] - WARN if hbase.bucketcache.percentage.in.combinedcache is set
  • [HBASE-13822] - shell is broken with NoMethodError
  • [HBASE-13824] - TestGenerateDelegationToken: Master fails to start in Windows environment
  • [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-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-13851] - RpcClientImpl.close() can hang with cancelled replica RPCs
  • [HBASE-13853] - ITBLL improvements after HBASE-13811
  • [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-13885] - ZK watches leaks during snapshots
  • [HBASE-13892] - Scanner with all results filtered out results in NPE
  • [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-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
  • Improvement:
  • [HBASE-12415] - Add add(byte[][] arrays) to Bytes.
  • [HBASE-13247] - Change BufferedMutatorExample to use addColumn() since add() is deprecated
  • [HBASE-13344] - Add enforcer rule that matches our JDK support statement
  • [HBASE-13366] - Throw DoNotRetryIOException instead of read only IOException
  • [HBASE-13420] - RegionEnvironment.offerExecutionLatency Blocks Threads under Heavy Load
  • [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-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-13846] - Run MiniCluster on top of other MiniDfsCluster
  • [HBASE-13894] - Avoid visitor alloc each call of ByteBufferArray get/putMultiple()
  • Task:
  • [HBASE-13666] - book.pdf is not renamed during site build
  • [HBASE-13697] - publish updated ref guide with prereq tables for 1.1 release train
  • [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
  • Test:
  • [HBASE-13591] - TestHBaseFsck is flakey
  • [HBASE-13609] - TestFastFail is still failing
  • [HBASE-13940] - IntegrationTestBulkLoad needs option to specify output folders used by test

New in Apache HBase 1.1.0 (May 15, 2015)

  • Sub-task:
  • [HBASE-7847] - Use zookeeper multi to clear znodes
  • [HBASE-10674] - HBCK should be updated to do replica related checks
  • [HBASE-10942] - support parallel request cancellation for multi-get
  • [HBASE-11261] - Handle splitting/merging of regions that have region_replication greater than one
  • [HBASE-11567] - Write bulk load COMMIT events to WAL
  • [HBASE-11568] - Async WAL replication for region replicas
  • [HBASE-11569] - Flush / Compaction handling from secondary region replicas
  • [HBASE-11571] - Bulk load handling from secondary region replicas
  • [HBASE-11574] - hbase:meta's regions can be replicated
  • [HBASE-11580] - Failover handling for secondary region replicas
  • [HBASE-11598] - Add simple rpc throttling
  • [HBASE-11842] - Integration test for async wal replication to secondary regions
  • [HBASE-11903] - Directly invoking split & merge of replica regions should be disallowed
  • [HBASE-11908] - Region replicas should be added to the meta table at the time of table creation
  • [HBASE-12012] - Improve cancellation for the scan RPCs
  • [HBASE-12511] - namespace permissions - add support from table creation privilege in a namespace 'C'
  • [HBASE-12561] - Replicas of regions can be cached from different instances of the table in MetaCache
  • [HBASE-12562] - Handling memory pressure for secondary region replicas
  • [HBASE-12708] - Document newly introduced params for using Thrift-over-HTTPS.
  • [HBASE-12714] - RegionReplicaReplicationEndpoint should not set the RPC Codec
  • [HBASE-12730] - Backport HBASE-5162 (Basic client pushback mechanism) to branch-1
  • [HBASE-12735] - Refactor TAG so it can live as unit test and as an integration test
  • [HBASE-12763] - Make it so there must be WALs for a server to be marked dead
  • [HBASE-12776] - SpliTransaction: Log number of files to be split
  • [HBASE-12779] - SplitTransaction: Add metrics
  • [HBASE-12793] - [hbck] closeRegionSilentlyAndWait() should log cause of IOException and retry until hbase.hbck.close.timeout expires
  • [HBASE-12802] - Remove unnecessary Table.flushCommits()
  • [HBASE-12848] - Utilize Flash storage for WAL
  • [HBASE-12926] - Backport HBASE-12688 (Update site with a bootstrap-based UI) for HBASE-12918
  • [HBASE-12980] - Delete of a table may not clean all rows from hbase:meta
  • [HBASE-13006] - Document visibility label support for groups
  • [HBASE-13067] - Fix caching of stubs to allow IP address changes of restarted remote servers
  • [HBASE-13108] - Reduce Connection creations in TestAcidGuarantees
  • [HBASE-13121] - Async wal replication for region replicas and dist log replay does not work together
  • [HBASE-13130] - Add timeouts on TestMasterObserver, a frequent zombie show
  • [HBASE-13164] - Update TestUsersOperationsWithSecureHadoop to use MiniKdc
  • [HBASE-13169] - ModifyTable increasing the region replica count should also auto-setup RRRE
  • [HBASE-13201] - Remove HTablePool from thrift-server
  • [HBASE-13202] - Procedure v2 - core framework
  • [HBASE-13203] - Procedure v2 - master create/delete table
  • [HBASE-13204] - Procedure v2 - client create/delete table sync
  • [HBASE-13209] - Procedure V2 - master Add/Modify/Delete Column Family
  • [HBASE-13210] - Procedure V2 - master Modify table
  • [HBASE-13211] - Procedure V2 - master Enable/Disable table
  • [HBASE-13213] - Split out locality metrics among primary and secondary region
  • [HBASE-13244] - Test delegation token generation with kerberos enabled
  • [HBASE-13290] - Procedure v2 - client enable/disable table sync
  • [HBASE-13303] - Fix size calculation of results on the region server
  • [HBASE-13307] - Making methods under ScannerV2#next inlineable, faster
  • [HBASE-13327] - Use Admin in ConnectionCache
  • [HBASE-13332] - Fix the usage of doAs/runAs in Visibility Controller tests.
  • [HBASE-13335] - Update ClientSmallScanner and ClientSmallReversedScanner
  • [HBASE-13386] - Backport HBASE-12601 to all active branches other than master
  • [HBASE-13421] - Reduce the number of object creations introduced by HBASE-11544 in scan RPC hot code paths
  • [HBASE-13447] - Bypass logic in TimeRange.compare
  • [HBASE-13455] - Procedure V2 - master truncate table
  • [HBASE-13466] - Document deprecations in 1.x - Part 1
  • [HBASE-13469] - [branch-1.1] Procedure V2 - Make procedure v2 configurable in branch-1.1
  • [HBASE-13481] - Master should respect master (old) DNS/bind related configurations
  • [HBASE-13496] - Make Bytes$LexicographicalComparerHolder$UnsafeComparer::compareTo inlineable
  • [HBASE-13498] - Add more docs and a basic check for storage policy handling
  • [HBASE-13502] - Deprecate/remove getRowComparator() in TableName
  • [HBASE-13514] - Fix test failures in TestScannerHeartbeatMessages caused by incorrect setting of hbase.rpc.timeout
  • [HBASE-13515] - Handle FileNotFoundException in region replica replay for flush/compaction events
  • [HBASE-13529] - Procedure v2 - WAL Improvements
  • [HBASE-13551] - Procedure V2 - Procedure classes should not be InterfaceAudience.Public
  • Brainstorming
  • [HBASE-12859] - New master API to track major compaction completion
  • Bug
  • [HBASE-6778] - Deprecate Chore; its a thread per task when we should have one thread to do all tasks
  • [HBASE-7332] - [webui] HMaster webui should display the number of regions a table has.
  • [HBASE-8026] - HBase Shell docs for scan command does not reference VERSIONS
  • [HBASE-8725] - Add total time RPC call metrics
  • [HBASE-9738] - Delete table and loadbalancer interference
  • [HBASE-9910] - TestHFilePerformance and HFilePerformanceEvaluation should be merged in a single HFile performance test class.
  • [HBASE-10499] - In write heavy scenario one of the regions does not get flushed causing RegionTooBusyException
  • [HBASE-10528] - DefaultBalancer selects plans to move regions onto draining nodes
  • [HBASE-10728] - get_counter value is never used.
  • [HBASE-11542] - Unit Test KeyStoreTestUtil.java compilation failure in IBM JDK
  • [HBASE-11544] - [Ergonomics] hbase.client.scanner.caching is dogged and will try to return batch even if it means OOME
  • [HBASE-12006] - [JDK 8] KeyStoreTestUtil#generateCertificate fails due to "subject class type invalid"
  • [HBASE-12028] - Abort the RegionServer, when it's handler threads die
  • [HBASE-12070] - Add an option to hbck to fix ZK inconsistencies
  • [HBASE-12102] - Duplicate keys in HBase.RegionServer metrics JSON
  • [HBASE-12108] - HBaseConfiguration: set classloader before loading xml files
  • [HBASE-12270] - A bug in the bucket cache, with cache blocks on write enabled
  • [HBASE-12339] - WAL performance evaluation tool doesn't roll logs
  • [HBASE-12393] - The regionserver web will throw exception if we disable block cache
  • [HBASE-12480] - Regions in FAILED_OPEN/FAILED_CLOSE should be processed on master failover
  • [HBASE-12548] - Improve debuggability of IntegrationTestTimeBoundedRequestsWithRegionReplicas
  • [HBASE-12574] - Update replication metrics to not do so many map look ups.
  • [HBASE-12585] - Fix refguide so it does hbase 1.0 style API everywhere with callout on how we used to do it in pre-1.0
  • [HBASE-12607] - TestHBaseFsck#testParallelHbck fails running against hadoop 2.6.0
  • [HBASE-12644] - Visibility Labels: issue with storing super users in labels table
  • [HBASE-12694] - testTableExistsIfTheSpecifiedTableRegionIsSplitParent in TestSplitTransactionOnCluster class leaves regions in transition
  • [HBASE-12697] - Don't use RegionLocationFinder if localityCost == 0
  • [HBASE-12711] - Fix new findbugs warnings in hbase-thrift module
  • [HBASE-12715] - getLastSequenceId always returns -1
  • [HBASE-12716] - A bug in RegionSplitter.UniformSplit algorithm
  • [HBASE-12717] - Pre-split algorithm in HBaseAdmin.create() can not find the split point
  • [HBASE-12718] - Convert TestAcidGuarantees from a unit test to an integration test
  • [HBASE-12728] - buffered writes substantially less useful after removal of HTablePool
  • [HBASE-12732] - Log messages in FileLink$FileLinkInputStream#tryOpen are reversed
  • [HBASE-12734] - TestPerColumnFamilyFlush.testCompareStoreFileCount is flakey
  • [HBASE-12739] - Avoid too large identifier of ZooKeeperWatcher
  • [HBASE-12740] - Improve performance of TestHBaseFsck
  • [HBASE-12741] - AccessController contains a javadoc issue
  • [HBASE-12742] - ClusterStatusPublisher crashes with a IPv6 network interface.
  • [HBASE-12743] - [ITBLL] Master fails rejoining cluster stuck splitting logs; Distributed log replay=true
  • [HBASE-12744] - hbase-default.xml lists hbase.regionserver.global.memstore.size twice
  • [HBASE-12747] - IntegrationTestMTTR will OOME if launched with mvn verify
  • [HBASE-12749] - Tighten HFileLink api to enable non-snapshot uses
  • [HBASE-12750] - getRequestsCount() in ClusterStatus returns total number of request
  • [HBASE-12767] - Fix a StoreFileScanner NPE in reverse scan flow
  • [HBASE-12771] - TestFailFast#testFastFail failing
  • [HBASE-12772] - TestPerColumnFamilyFlush failing
  • [HBASE-12774] - Fix the inconsistent permission checks for bulkloading.
  • [HBASE-12781] - thrift2 listen port will bind always to the passed command line address
  • [HBASE-12782] - ITBLL fails for me if generator does anything but 5M per maptask
  • [HBASE-12791] - HBase does not attempt to clean up an aborted split when the regionserver shutting down
  • [HBASE-12798] - Map Reduce jobs should not create Tables in setConf()
  • [HBASE-12801] - Failed to truncate a table while maintaing binary region boundaries
  • [HBASE-12804] - ImportTsv fails to delete partition files created by it
  • [HBASE-12810] - Update to htrace-incubating
  • [HBASE-12811] - [AccessController] NPE while scanning a table with user not having READ permission on the namespace
  • [HBASE-12817] - Data missing while scanning using PREFIX_TREE data block encoding
  • [HBASE-12819] - ExportSnapshot doesn't close FileSystem instances
  • [HBASE-12824] - CompressionTest fails with org.apache.hadoop.hbase.io.hfile.AbstractHFileReader$NotSeekedException: Not seeked to a key/value
  • [HBASE-12831] - Changing the set of vis labels a user has access to doesn't generate an audit log event
  • [HBASE-12832] - Describe table from shell no longer shows Table's attributes, only CF attributes
  • [HBASE-12833] - [shell] table.rb leaks connections
  • [HBASE-12835] - HBASE-12422 changed new HTable(Configuration) to not use managed Connections anymore
  • [HBASE-12837] - ReplicationAdmin leaks zk connections
  • [HBASE-12844] - ServerManager.isServerReacable() should sleep between retries
  • [HBASE-12845] - ByteBufferOutputStream should grow as direct buffer if the initial buffer is also direct BB
  • [HBASE-12847] - TestZKLessSplitOnCluster frequently times out in 0.98 builds
  • [HBASE-12849] - LoadIncrementalHFiles should use unmanaged connection in branch-1
  • [HBASE-12862] - Uppercase "wals" in RegionServer webUI
  • [HBASE-12863] - Master info port on RS UI is always 0
  • [HBASE-12864] - IntegrationTestTableSnapshotInputFormat fails
  • [HBASE-12867] - Shell does not support custom replication endpoint specification
  • [HBASE-12878] - Incorrect HFile path in TestHFilePerformance print output (fix for easier debugging)
  • [HBASE-12881] - TestFastFail is not compatible with surefire.rerunFailingTestsCount
  • [HBASE-12886] - Correct tag option name in PerformanceEvaluation
  • [HBASE-12892] - Add a class to allow taking a snapshot from the command line
  • [HBASE-12897] - Minimum memstore size is a percentage
  • [HBASE-12898] - Add in used undeclared dependencies
  • [HBASE-12901] - Possible deadlock while onlining a region and get region plan for other region run parallel
  • [HBASE-12904] - Threading issues in region_mover.rb
  • [HBASE-12908] - Typos in MemStoreFlusher javadocs
  • [HBASE-12915] - Disallow small scan with batching
  • [HBASE-12916] - No access control for replicating WAL entries
  • [HBASE-12917] - HFilePerformanceEvaluation Scan tests fail with StackOverflowError due to recursive call in createCell function
  • [HBASE-12918] - Backport asciidoc changes
  • [HBASE-12919] - Compilation with Hadoop-2.4- is broken again
  • [HBASE-12924] - HRegionServer#MovedRegionsCleaner Chore does not start
  • [HBASE-12927] - TestFromClientSide#testScanMetrics() failing due to duplicate createTable commands
  • [HBASE-12931] - The existing KeyValues in memstore are not removed completely after inserting cell into memStore
  • [HBASE-12948] - Calling Increment#addColumn on the same column multiple times produces wrong result
  • [HBASE-12951] - TestHCM.testConnectionClose is flakey when using AsyncRpcClient as client implementation
  • [HBASE-12953] - RegionServer is not functionally working with AysncRpcClient in secure mode
  • [HBASE-12954] - Ability impaired using HBase on multihomed hosts
  • [HBASE-12956] - Binding to 0.0.0.0 is broken after HBASE-10569
  • [HBASE-12958] - SSH doing hbase:meta get but hbase:meta not assigned
  • [HBASE-12961] - Negative values in read and write region server metrics
  • [HBASE-12962] - TestHFileBlockIndex.testBlockIndex() commented out during HBASE-10531
  • [HBASE-12964] - Add the ability for hbase-daemon.sh to start in the foreground
  • [HBASE-12966] - NPE in HMaster while recovering tables in Enabling state
  • [HBASE-12969] - Parameter Validation is not there for shell script, local-master-backup.sh and local-regionservers.sh
  • [HBASE-12971] - Replication stuck due to large default value for replication.source.maxretriesmultiplier
  • [HBASE-12976] - Set default value for hbase.client.scanner.max.result.size
  • [HBASE-12978] - Region goes permanently offline (WAS: hbase:meta has a row missing hregioninfo and it causes my long-running job to fail)
  • [HBASE-12984] - SSL cannot be used by the InfoPort after removing deprecated code in HBASE-10336
  • [HBASE-12985] - Javadoc warning and findbugs fixes to get us green again
  • [HBASE-12989] - region_mover.rb unloadRegions method uses ArrayList concurrently resulting in errors
  • [HBASE-12991] - Use HBase 1.0 interfaces in hbase-rest
  • [HBASE-12993] - Use HBase 1.0 interfaces in hbase-thrift
  • [HBASE-12996] - Reversed field on Filter should be transient
  • [HBASE-12998] - Compilation with Hdfs-2.7.0-SNAPSHOT is broken after HDFS-7647
  • [HBASE-12999] - Make foreground_start return the correct exit code
  • [HBASE-13001] - NullPointer in master logs for table.jsp
  • [HBASE-13003] - Get tests in TestHFileBlockIndex back
  • [HBASE-13004] - Make possible to explain why HBaseTestingUtility.waitFor fails
  • [HBASE-13007] - Fix the test timeouts being caused by ChoreService
  • [HBASE-13009] - HBase REST UI inaccessible
  • [HBASE-13010] - HFileOutputFormat2 partitioner's path is hard-coded as '/tmp'
  • [HBASE-13011] - TestLoadIncrementalHFiles is flakey when using AsyncRpcClient as client implementation
  • [HBASE-13027] - mapreduce.TableInputFormatBase should create its own Connection if needed
  • [HBASE-13030] - [1.0.0 polish] Make ScanMetrics public again and align Put 'add' with Get, Delete, etc., addColumn
  • [HBASE-13032] - Migration of states should be performed once META is assigned and onlined.
  • [HBASE-13036] - Meta scanner should use its own threadpool
  • [HBASE-13038] - Fix the java doc warning continuously reported by Hadoop QA
  • [HBASE-13039] - Add patchprocess/* to .gitignore to fix builds of branches
  • [HBASE-13040] - Possible failure of TestHMasterRPCException
  • [HBASE-13047] - Add "HBase Configuration" link missing on the table details pages
  • [HBASE-13048] - Use hbase.crypto.wal.algorithm in SecureProtobufLogReader while decrypting the data
  • [HBASE-13049] - wal_roll ruby command doesn't work.
  • [HBASE-13050] - Hbase shell create_namespace command throws ArrayIndexOutOfBoundException for (invalid) empty text input.
  • [HBASE-13055] - HRegion FIXED_OVERHEAD missed one boolean
  • [HBASE-13058] - Hbase shell command 'scan' for non existent table shows unnecessary info for one unrelated existent table.
  • [HBASE-13061] - RegionStates can remove wrong region from server holdings
  • [HBASE-13065] - Increasing -Xmx when running TestDistributedLogSplitting
  • [HBASE-13066] - Fix typo in AsyncRpcChannel
  • [HBASE-13069] - Thrift Http Server returns an error code of 500 instead of 401 when authentication fails
  • [HBASE-13070] - Fix TestCacheOnWrite
  • [HBASE-13072] - BucketCache.evictBlock returns true if block does not exist
  • [HBASE-13075] - TableInputFormatBase spuriously warning about multiple initializeTable calls
  • [HBASE-13077] - BoundedCompletionService doesn't pass trace info to server
  • [HBASE-13083] - Master can be dead-locked while assigning META.
  • [HBASE-13084] - Add labels to VisibilityLabelsCache asynchronously causes TestShell flakey
  • [HBASE-13085] - Security issue in the implementation of Rest gataway 'doAs' proxy user support
  • [HBASE-13091] - Split ZK Quorum on Master WebUI
  • [HBASE-13093] - Local mode HBase instance doesn't shut down.
  • [HBASE-13097] - Use same EventLoopGroup for different AsyncRpcClients if possible
  • [HBASE-13102] - Fix Pseudo-distributed Mode which was broken in 1.0.0
  • [HBASE-13111] - truncate_preserve command is failing with undefined method error
  • [HBASE-13112] - quota.rb, security.rb and visibility_labels.rb leak connection
  • [HBASE-13114] - [UNITTEST] TestEnableTableHandler.testDeleteForSureClearsAllTableRowsFromMeta
  • [HBASE-13115] - Fix the usage of remote user in thrift doAs implementation.
  • [HBASE-13119] - FileLink should implement equals
  • [HBASE-13123] - Minor bug in ROW bloom filter
  • [HBASE-13131] - ReplicationAdmin leaks connections if there's an error in the constructor
  • [HBASE-13133] - NPE when running TestSplitLogManager
  • [HBASE-13134] - mutateRow and checkAndMutate apis don't throw region level exceptions
  • [HBASE-13136] - TestSplitLogManager.testGetPreviousRecoveryMode is flakey
  • [HBASE-13139] - Clean up missing JAVA_HOME message in bin/hbase-config.sh
  • [HBASE-13141] - IntegrationTestAcidGuarantees returns incorrect values for getColumnFamilies
  • [HBASE-13145] - TestNamespaceAuditor.testRegionMerge is flaky
  • [HBASE-13146] - Race Condition in ScheduledChore and ChoreService
  • [HBASE-13149] - HBase MR is broken on Hadoop 2.5+ Yarn
  • [HBASE-13155] - Fix TestPrefixTree
  • [HBASE-13156] - Fix minor rat violation recently introduced (asciidoctor.css).
  • [HBASE-13165] - Fix docs and scripts for default max heaps size after HBASE-11804
  • [HBASE-13172] - TestDistributedLogSplitting.testThreeRSAbort fails several times on branch-1
  • [HBASE-13174] - Apply HBASE-11804 to Windows scripts
  • [HBASE-13176] - Flakey TestZooKeeper test.
  • [HBASE-13181] - TestHRegionReplayEvents.testReplayBulkLoadEvent fails frequently.
  • [HBASE-13188] - java.lang.ArithmeticException issue in BoundedByteBufferPool.putBuffer
  • [HBASE-13193] - RegionScannerImpl filters should not be reset if a partial Result is returned
  • [HBASE-13206] - Fix TableLock tableName log format
  • [HBASE-13224] - Minor formatting issue when logging a namespace scope in AuthResult#toContextString
  • [HBASE-13227] - LoadIncrementalHFile should skip non-files inside a possible family-dir
  • [HBASE-13229] - Specify bash for local-regionservers.sh and local-master-backup.sh
  • [HBASE-13232] - ConnectionManger : Batch pool threads and metaLookup pool threads should use different name pattern
  • [HBASE-13239] - HBase grant at specific column level does not work for Groups
  • [HBASE-13242] - TestPerColumnFamilyFlush.testFlushingWhenLogRolling hung
  • [HBASE-13246] - Correct the assertion for namespace permissions in tearDown method of TestAccessController
  • [HBASE-13253] - LoadIncrementalHFiles unify hfiles discovery
  • [HBASE-13262] - ResultScanner doesn't return all rows in Scan
  • [HBASE-13265] - Make thrift2 usable from c++
  • [HBASE-13273] - Make Result.EMPTY_RESULT read-only; currently it can be modified
  • [HBASE-13274] - Fix misplaced deprecation in Delete#addXYZ
  • [HBASE-13275] - Setting hbase.security.authorization to false does not disable authorization
  • [HBASE-13282] - Fix the minor issues of running Canary on kerberized environment
  • [HBASE-13285] - Fix flaky getRegions() in TestAccessController.setUp()
  • [HBASE-13289] - typo in splitSuccessCount metric
  • [HBASE-13294] - Fix the critical ancient loopholes in security testing infrastructure.
  • [HBASE-13295] - TestInfoServers hang
  • [HBASE-13296] - Fix the deletion of acl notify nodes for namespace.
  • [HBASE-13298] - Clarify if Table.{set|get}WriteBufferSize() is deprecated or not
  • [HBASE-13299] - Add setReturnResults() to Increment, like Append has
  • [HBASE-13301] - Possible memory leak in BucketCache
  • [HBASE-13305] - Get(Get get) is not copying the row key
  • [HBASE-13308] - Fix flaky TestEndToEndSplitTransaction
  • [HBASE-13309] - Some tests do not reset EnvironmentEdgeManager
  • [HBASE-13314] - Fix NPE in HMaster.getClusterStatus()
  • [HBASE-13315] - BufferedMutator should be @InterfaceAudience.Public
  • [HBASE-13317] - Region server reportForDuty stuck looping if there is a master change
  • [HBASE-13321] - Fix flaky TestHBaseFsck
  • [HBASE-13326] - Disabled table can't be enabled after HBase is restarted
  • [HBASE-13328] - LoadIncrementalHFile.doBulkLoad(Path,HTable) should handle managed connections
  • [HBASE-13331] - Exceptions from DFS client can cause CatalogJanitor to delete referenced files
  • [HBASE-13371] - Fix typo in TestAsyncIPC
  • [HBASE-13374] - Small scanners (with particular configurations) do not return all rows
  • [HBASE-13382] - IntegrationTestBigLinkedList should use SecureRandom
  • [HBASE-13384] - Fix Javadoc warnings introduced by HBASE-12972
  • [HBASE-13385] - TestGenerateDelegationToken is broken with hadoop 2.8.0
  • [HBASE-13388] - Handling NullPointer in ZKProcedureMemberRpcs while getting ZNode data
  • [HBASE-13394] - Failed to recreate a table when quota is enabled
  • [HBASE-13397] - Purge duplicate rpc request thread local
  • [HBASE-13402] - [Backport 1.1] HBASE-12552: listSnapshots should list only owned snapshots for non-super user
  • [HBASE-13406] - TestAccessController is flaky when create is slow
  • [HBASE-13409] - Add categories to uncategorized tests
  • [HBASE-13410] - Bug in KeyValueUtil.oswrite() for non Keyvalue cases
  • [HBASE-13414] - TestHCM no longer needs to test for JRE 6.
  • [HBASE-13417] - batchCoprocessorService() does not handle NULL keys
  • [HBASE-13423] - Remove duplicate entry for hbase.regionserver.regionSplitLimit in hbase-default.xml
  • [HBASE-13430] - HFiles that are in use by a table cloned from a snapshot may be deleted when that snapshot is deleted
  • [HBASE-13437] - ThriftServer leaks ZooKeeper connections
  • [HBASE-13457] - SnapshotExistsException doesn't honor the DoNotRetry
  • [HBASE-13460] - Revise the MetaLookupPool executor-related defaults (introduced in HBASE-13036)
  • [HBASE-13463] - Quota needs to be updated only in case of successful region merge
  • [HBASE-13471] - Fix a possible infinite loop in doMiniBatchMutation
  • [HBASE-13473] - deleted cells come back alive after the stripe compaction
  • [HBASE-13475] - Small spelling mistake in region_mover#isSuccessfulScan causes NoMethodError
  • [HBASE-13477] - Create metrics on failed requests
  • [HBASE-13482] - Phoenix is failing to scan tables on secure environments.
  • [HBASE-13490] - foreground daemon start re-executes ulimit output
  • [HBASE-13491] - Issue in FuzzyRowFilter#getNextForFuzzyRule
  • [HBASE-13499] - AsyncRpcClient test cases failure in powerpc
  • [HBASE-13517] - Publish a client artifact with shaded dependencies
  • [HBASE-13520] - NullPointerException in TagRewriteCell
  • [HBASE-13524] - TestReplicationAdmin fails on JDK 1.8
  • [HBASE-13526] - TestRegionServerReportForDuty can be flaky: hang or timeout
  • [HBASE-13527] - The default value for hbase.client.scanner.max.result.size is never actually set on Scans
  • [HBASE-13528] - A bug on selecting compaction pool
  • [HBASE-13546] - NPE on region server status page if all masters are down
  • [HBASE-13555] - StackServlet produces 500 error
  • [HBASE-13575] - TestChoreService has to make sure that the opened ChoreService is closed for each unit test
  • [HBASE-13577] - Documentation is pointing to wrong port for Master Web UI
  • [HBASE-13585] - HRegionFileSystem#splitStoreFile() finishes without closing the file handle in some situation
  • [HBASE-13589] - [WINDOWS] hbase.cmd script is broken
  • [HBASE-13594] - MultiRowRangeFilter shouldn't call HBaseZeroCopyByteString.wrap() directly
  • [HBASE-13596] - src assembly does not build
  • [HBASE-13637] - branch-1.1 does not build against hadoop-2.2.
  • [HBASE-13661] - Correct binary compatibility issues discovered in 1.1.0RC0
  • Improvement:
  • [HBASE-5699] - Run with > 1 WAL in HRegionServer
  • [HBASE-6919] - Remove unnecessary throws IOException from Bytes.readVLong
  • [HBASE-7541] - Convert all tests that use HBaseTestingUtility.createMultiRegions to HBA.createTable
  • [HBASE-8329] - Limit compaction speed
  • [HBASE-10201] - Port 'Make flush decisions per column family' to trunk
  • [HBASE-11144] - Filter to support scanning multiple row key ranges
  • [HBASE-11864] - Enhance HLogPrettyPrinter to print information from WAL Header
  • [HBASE-11869] - Support snapshot owner
  • [HBASE-12071] - Separate out thread pool for Master RegionServer communication
  • [HBASE-12223] - MultiTableInputFormatBase.getSplits is too slow
  • [HBASE-12405] - WAL accounting by Store
  • [HBASE-12429] - Add port to ClusterManager's actions.
  • [HBASE-12608] - region_mover.rb does not log moving region count correctly when loading regions
  • [HBASE-12620] - Add HBASE-11639 related items to Ref Guide
  • [HBASE-12627] - Add back snapshot batching facility from HBASE-11360 dropped by HBASE-11742
  • [HBASE-12641] - Grant all permissions of hbase zookeeper node to hbase superuser in a secure cluster
  • [HBASE-12684] - Add new AsyncRpcClient
  • [HBASE-12706] - Support multiple port numbers in ZK quorum string
  • [HBASE-12719] - Add test WAL provider to quantify FSHLog overhead in the absence of HDFS.
  • [HBASE-12720] - Make InternalScan LimitedPrivate
  • [HBASE-12736] - Let MetaScanner recycle a given Connection
  • [HBASE-12745] - Visibility Labels: support visibility labels for user groups.
  • [HBASE-12761] - On region jump ClientScanners should get next row start key instead of a skip.
  • [HBASE-12762] - Region with no hfiles will have the highest locality cost in LocalityCostFunction
  • [HBASE-12768] - Support enable cache_data_on_write in Shell while creating table
  • [HBASE-12825] - CallRunner exception messages should include destination host:port
  • [HBASE-12891] - Parallel execution for Hbck checkRegionConsistency
  • [HBASE-12893] - IntegrationTestBigLinkedListWithVisibility should use buffered writes
  • [HBASE-12899] - HBase should prefix htrace configuration keys with "hbase.htrace" rather than just "hbase."
  • [HBASE-12929] - TableMapReduceUtil.initTableMapperJob unnecessarily limits the types of outputKeyClass and outputValueClass
  • [HBASE-12957] - region_mover#isSuccessfulScan may be extremely slow on region with lots of expired data
  • [HBASE-12973] - RegionCoprocessorEnvironment should provide HRegionInfo directly
  • [HBASE-12975] - Supportable SplitTransaction and RegionMergeTransaction interfaces
  • [HBASE-12979] - Use setters instead of return values for handing back statistics from HRegion methods
  • [HBASE-12982] - Adding timeouts to TestChoreService
  • [HBASE-12987] - HBCK should print status while scanning over many regions
  • [HBASE-12997] - FSHLog should print pipeline on low replication
  • [HBASE-13002] - Make encryption cipher configurable
  • [HBASE-13008] - Better default for hbase.regionserver.regionSplitLimit parameter.
  • [HBASE-13044] - Configuration option for disabling coprocessor loading
  • [HBASE-13054] - Provide more tracing information for locking/latching events.
  • [HBASE-13056] - Refactor table.jsp code to remove repeated code and make it easier to add new checks
  • [HBASE-13059] - Set executable bit for scripts in dev-support
  • [HBASE-13080] - Hbase shell message containing extra quote at the end of error message.
  • [HBASE-13086] - Show ZK root node on Master WebUI
  • [HBASE-13100] - Shell command to retrieve table splits
  • [HBASE-13109] - Make better SEEK vs SKIP decisions during scanning
  • [HBASE-13118] - [PE] Add being able to write many columns
  • [HBASE-13120] - Allow disabling hadoop classpath and native library lookup
  • [HBASE-13122] - Improve efficiency for return codes of some filters
  • [HBASE-13128] - Make HBCK's lock file retry creation and deletion
  • [HBASE-13132] - Improve RemoveColumn action debug message
  • [HBASE-13138] - Clean up TestMasterObserver (debug, trying to figure why fails)
  • [HBASE-13142] - [PERF] Reuse the IPCUtil#buildCellBlock buffer
  • [HBASE-13162] - Add capability for cleaning hbase acls to hbase cleanup script.
  • [HBASE-13168] - Backport HBASE-12590 "A solution for data skew in HBase-Mapreduce Job"
  • [HBASE-13171] - Change AccessControlClient methods to accept connection object to reduce setup time.
  • [HBASE-13183] - Make ZK tickTime configurable in standalone HBase
  • [HBASE-13189] - PrefixTreecell should implement HeapSize
  • [HBASE-13216] - Add version info in RPC connection header
  • [HBASE-13222] - Provide means of non-destructive balancer inspection
  • [HBASE-13223] - Add testMoveMeta to IntegrationTestMTTR
  • [HBASE-13235] - Revisit the security auditing semantics.
  • [HBASE-13236] - Clean up m2e-related warnings/errors from poms
  • [HBASE-13241] - Add tests for group level grants
  • [HBASE-13255] - Bad grammar in RegionServer status page
  • [HBASE-13256] - HBaseConfiguration#checkDefaultsVersion(Configuration) has spelling error
  • [HBASE-13270] - Setter for Result#getStats is #addResults; confusing!
  • [HBASE-13316] - Reduce the downtime on planned moves of regions
  • [HBASE-13342] - Fix incorrect interface annotations
  • [HBASE-13345] - Fix LocalHBaseCluster so that different region server impl can be used for different slaves
  • [HBASE-13350] - Add a debug-warn if we fail HTD checks even if table.sanity.checks is false
  • [HBASE-13351] - Annotate internal MasterRpcServices methods with admin priority
  • [HBASE-13362] - Set max result size from client only (like scanner caching).
  • [HBASE-13369] - Expose scanNext stats to region server level
  • [HBASE-13370] - PE tool could give option for using Explicit Column Tracker which leads to seeks
  • [HBASE-13381] - Expand TestSizeFailures to include small scans
  • [HBASE-13419] - Thrift gateway should propagate text from exception causes.
  • [HBASE-13431] - Allow to skip store file range check based on column family while creating reference files in HRegionFileSystem#splitStoreFile
  • [HBASE-13436] - Include user name in ADE for scans
  • [HBASE-13453] - Master should not bind to region server ports
  • [HBASE-13456] - Improve HFilePrettyPrinter first hbase:meta region processing
  • [HBASE-13516] - Increase PermSize to 128MB
  • [HBASE-13518] - Typo in hbase.hconnection.meta.lookup.threads.core parameter
  • [HBASE-13550] - [Shell] Support unset of a list of table attributes
  • [HBASE-13552] - ChoreService shutdown message could be more informative
  • [HBASE-13578] - Remove Arrays.asList().subList() from FSHLog.offer()
  • New Feature
  • [HBASE-9531] - a command line (hbase shell) interface to retreive the replication metrics and show replication lag
  • [HBASE-12268] - Add support for Scan.setRowPrefixFilter to shell
  • [HBASE-12709] - [mvn] Add unit test excludes command line flag to the build.
  • [HBASE-12731] - Heap occupancy based client pushback
  • [HBASE-12869] - Add a REST API implementation of the ClusterManager interface
  • [HBASE-12972] - Region, a supportable public/evolving subset of HRegion
  • [HBASE-13057] - Provide client utility to easily enable and disable table replication
  • [HBASE-13063] - Allow to turn off memstore replication for region replicas
  • [HBASE-13090] - Progress heartbeats for long running scanners
  • [HBASE-13170] - Allow block cache to be external
  • [HBASE-13412] - Region split decisions should have jitter
  • Task:
  • [HBASE-9604] - Add metric on short-circuit reads
  • [HBASE-12180] - Fix and reenable TestRegionReplicaReplicationEndpoint
  • [HBASE-12700] - Backport 'Make flush decisions per column family' from master
  • [HBASE-12783] - Create efficient RegionLocator implementation
  • [HBASE-12785] - Use FutureTask to timeout the attempt to get the lock for hbck
  • [HBASE-12788] - Promote Abortable to LimitedPrivate
  • [HBASE-12834] - Promote ScanType to LimitedPrivate
  • [HBASE-12995] - Document that HConnection#getTable methods do not check table existence since 0.98.1
  • [HBASE-13187] - Add ITBLL that exercises per CF flush
  • [HBASE-13205] - [branch-1] Backport HBASE-11598 Add simple rpc throttling
  • [HBASE-13380] - Cherry pick the HBASE-12808 compatibility checker tool back to 0.98+
  • [HBASE-13438] - [branch-1] Backport Basic quota support for namespaces
  • [HBASE-13584] - Disable distributed log replay by default for 1.1
  • [HBASE-13665] - Fix docs and site building on branch-1
  • Test:
  • [HBASE-7781] - Update security unit tests to use a KDC if available
  • [HBASE-12764] - TestPerColumnFamilyFlush#testCompareStoreFileCount may fail due to new table not available
  • [HBASE-12799] - ITAG fails with java.lang.RuntimeException if table does not exist
  • [HBASE-12876] - TestScannerWithBulkload should pass Table with unmanaged connection to LoadIncrementalHFiles#doBulkLoad()
  • [HBASE-12885] - Unit test for RAW / VERSIONS scanner specifications
  • [HBASE-12992] - TestChoreService doesn't close services, that can break test on slow virtual hosts.
  • [HBASE-13106] - Ensure endpoint-only table coprocessors can be dynamically loaded
  • [HBASE-13179] - TestMasterObserver deleteTable is flaky
  • [HBASE-13182] - Test NamespaceAuditor/AccessController create/delete table is flaky
  • [HBASE-13280] - TestSecureRPC failed
  • [HBASE-13413] - Create an integration test for Replication
  • Sub-task
  • [HBASE-7847] - Use zookeeper multi to clear znodes
  • [HBASE-10674] - HBCK should be updated to do replica related checks
  • [HBASE-10942] - support parallel request cancellation for multi-get
  • [HBASE-11261] - Handle splitting/merging of regions that have region_replication greater than one
  • [HBASE-11567] - Write bulk load COMMIT events to WAL
  • [HBASE-11568] - Async WAL replication for region replicas
  • [HBASE-11569] - Flush / Compaction handling from secondary region replicas
  • [HBASE-11571] - Bulk load handling from secondary region replicas
  • [HBASE-11574] - hbase:meta's regions can be replicated
  • [HBASE-11580] - Failover handling for secondary region replicas
  • [HBASE-11598] - Add simple rpc throttling
  • [HBASE-11842] - Integration test for async wal replication to secondary regions
  • [HBASE-11903] - Directly invoking split & merge of replica regions should be disallowed
  • [HBASE-11908] - Region replicas should be added to the meta table at the time of table creation
  • [HBASE-12012] - Improve cancellation for the scan RPCs
  • [HBASE-12511] - namespace permissions - add support from table creation privilege in a namespace 'C'
  • [HBASE-12561] - Replicas of regions can be cached from different instances of the table in MetaCache
  • [HBASE-12562] - Handling memory pressure for secondary region replicas
  • [HBASE-12708] - Document newly introduced params for using Thrift-over-HTTPS.
  • [HBASE-12714] - RegionReplicaReplicationEndpoint should not set the RPC Codec
  • [HBASE-12730] - Backport HBASE-5162 (Basic client pushback mechanism) to branch-1
  • [HBASE-12735] - Refactor TAG so it can live as unit test and as an integration test
  • [HBASE-12763] - Make it so there must be WALs for a server to be marked dead
  • [HBASE-12776] - SpliTransaction: Log number of files to be split
  • [HBASE-12779] - SplitTransaction: Add metrics
  • [HBASE-12793] - [hbck] closeRegionSilentlyAndWait() should log cause of IOException and retry until hbase.hbck.close.timeout expires
  • [HBASE-12802] - Remove unnecessary Table.flushCommits()
  • [HBASE-12848] - Utilize Flash storage for WAL
  • [HBASE-12926] - Backport HBASE-12688 (Update site with a bootstrap-based UI) for HBASE-12918
  • [HBASE-12980] - Delete of a table may not clean all rows from hbase:meta
  • [HBASE-13006] - Document visibility label support for groups
  • [HBASE-13067] - Fix caching of stubs to allow IP address changes of restarted remote servers
  • [HBASE-13108] - Reduce Connection creations in TestAcidGuarantees
  • [HBASE-13121] - Async wal replication for region replicas and dist log replay does not work together
  • [HBASE-13130] - Add timeouts on TestMasterObserver, a frequent zombie show
  • [HBASE-13164] - Update TestUsersOperationsWithSecureHadoop to use MiniKdc
  • [HBASE-13169] - ModifyTable increasing the region replica count should also auto-setup RRRE
  • [HBASE-13201] - Remove HTablePool from thrift-server
  • [HBASE-13202] - Procedure v2 - core framework
  • [HBASE-13203] - Procedure v2 - master create/delete table
  • [HBASE-13204] - Procedure v2 - client create/delete table sync
  • [HBASE-13209] - Procedure V2 - master Add/Modify/Delete Column Family
  • [HBASE-13210] - Procedure V2 - master Modify table
  • [HBASE-13211] - Procedure V2 - master Enable/Disable table
  • [HBASE-13213] - Split out locality metrics among primary and secondary region
  • [HBASE-13244] - Test delegation token generation with kerberos enabled
  • [HBASE-13290] - Procedure v2 - client enable/disable table sync
  • [HBASE-13303] - Fix size calculation of results on the region server
  • [HBASE-13307] - Making methods under ScannerV2#next inlineable, faster
  • [HBASE-13327] - Use Admin in ConnectionCache
  • [HBASE-13332] - Fix the usage of doAs/runAs in Visibility Controller tests.
  • [HBASE-13335] - Update ClientSmallScanner and ClientSmallReversedScanner
  • [HBASE-13386] - Backport HBASE-12601 to all active branches other than master
  • [HBASE-13421] - Reduce the number of object creations introduced by HBASE-11544 in scan RPC hot code paths
  • [HBASE-13447] - Bypass logic in TimeRange.compare
  • [HBASE-13455] - Procedure V2 - master truncate table
  • [HBASE-13466] - Document deprecations in 1.x - Part 1
  • [HBASE-13469] - [branch-1.1] Procedure V2 - Make procedure v2 configurable in branch-1.1
  • [HBASE-13481] - Master should respect master (old) DNS/bind related configurations
  • [HBASE-13496] - Make Bytes$LexicographicalComparerHolder$UnsafeComparer::compareTo inlineable
  • [HBASE-13498] - Add more docs and a basic check for storage policy handling
  • [HBASE-13502] - Deprecate/remove getRowComparator() in TableName
  • [HBASE-13514] - Fix test failures in TestScannerHeartbeatMessages caused by incorrect setting of hbase.rpc.timeout
  • [HBASE-13515] - Handle FileNotFoundException in region replica replay for flush/compaction events
  • [HBASE-13529] - Procedure v2 - WAL Improvements
  • [HBASE-13551] - Procedure V2 - Procedure classes should not be InterfaceAudience.Public
  • Brainstorming
  • [HBASE-12859] - New master API to track major compaction completion
  • Bug
  • [HBASE-6778] - Deprecate Chore; its a thread per task when we should have one thread to do all tasks
  • [HBASE-7332] - [webui] HMaster webui should display the number of regions a table has.
  • [HBASE-8026] - HBase Shell docs for scan command does not reference VERSIONS
  • [HBASE-8725] - Add total time RPC call metrics
  • [HBASE-9738] - Delete table and loadbalancer interference
  • [HBASE-9910] - TestHFilePerformance and HFilePerformanceEvaluation should be merged in a single HFile performance test class.
  • [HBASE-10499] - In write heavy scenario one of the regions does not get flushed causing RegionTooBusyException
  • [HBASE-10528] - DefaultBalancer selects plans to move regions onto draining nodes
  • [HBASE-10728] - get_counter value is never used.
  • [HBASE-11542] - Unit Test KeyStoreTestUtil.java compilation failure in IBM JDK
  • [HBASE-11544] - [Ergonomics] hbase.client.scanner.caching is dogged and will try to return batch even if it means OOME
  • [HBASE-12006] - [JDK 8] KeyStoreTestUtil#generateCertificate fails due to "subject class type invalid"
  • [HBASE-12028] - Abort the RegionServer, when it's handler threads die
  • [HBASE-12070] - Add an option to hbck to fix ZK inconsistencies
  • [HBASE-12102] - Duplicate keys in HBase.RegionServer metrics JSON
  • [HBASE-12108] - HBaseConfiguration: set classloader before loading xml files
  • [HBASE-12270] - A bug in the bucket cache, with cache blocks on write enabled
  • [HBASE-12339] - WAL performance evaluation tool doesn't roll logs
  • [HBASE-12393] - The regionserver web will throw exception if we disable block cache
  • [HBASE-12480] - Regions in FAILED_OPEN/FAILED_CLOSE should be processed on master failover
  • [HBASE-12548] - Improve debuggability of IntegrationTestTimeBoundedRequestsWithRegionReplicas
  • [HBASE-12574] - Update replication metrics to not do so many map look ups.
  • [HBASE-12585] - Fix refguide so it does hbase 1.0 style API everywhere with callout on how we used to do it in pre-1.0
  • [HBASE-12607] - TestHBaseFsck#testParallelHbck fails running against hadoop 2.6.0
  • [HBASE-12644] - Visibility Labels: issue with storing super users in labels table
  • [HBASE-12694] - testTableExistsIfTheSpecifiedTableRegionIsSplitParent in TestSplitTransactionOnCluster class leaves regions in transition
  • [HBASE-12697] - Don't use RegionLocationFinder if localityCost == 0
  • [HBASE-12711] - Fix new findbugs warnings in hbase-thrift module
  • [HBASE-12715] - getLastSequenceId always returns -1
  • [HBASE-12716] - A bug in RegionSplitter.UniformSplit algorithm
  • [HBASE-12717] - Pre-split algorithm in HBaseAdmin.create() can not find the split point
  • [HBASE-12718] - Convert TestAcidGuarantees from a unit test to an integration test
  • [HBASE-12728] - buffered writes substantially less useful after removal of HTablePool
  • [HBASE-12732] - Log messages in FileLink$FileLinkInputStream#tryOpen are reversed
  • [HBASE-12734] - TestPerColumnFamilyFlush.testCompareStoreFileCount is flakey
  • [HBASE-12739] - Avoid too large identifier of ZooKeeperWatcher
  • [HBASE-12740] - Improve performance of TestHBaseFsck
  • [HBASE-12741] - AccessController contains a javadoc issue
  • [HBASE-12742] - ClusterStatusPublisher crashes with a IPv6 network interface.
  • [HBASE-12743] - [ITBLL] Master fails rejoining cluster stuck splitting logs; Distributed log replay=true
  • [HBASE-12744] - hbase-default.xml lists hbase.regionserver.global.memstore.size twice
  • [HBASE-12747] - IntegrationTestMTTR will OOME if launched with mvn verify
  • [HBASE-12749] - Tighten HFileLink api to enable non-snapshot uses
  • [HBASE-12750] - getRequestsCount() in ClusterStatus returns total number of request
  • [HBASE-12767] - Fix a StoreFileScanner NPE in reverse scan flow
  • [HBASE-12771] - TestFailFast#testFastFail failing
  • [HBASE-12772] - TestPerColumnFamilyFlush failing
  • [HBASE-12774] - Fix the inconsistent permission checks for bulkloading.
  • [HBASE-12781] - thrift2 listen port will bind always to the passed command line address
  • [HBASE-12782] - ITBLL fails for me if generator does anything but 5M per maptask
  • [HBASE-12791] - HBase does not attempt to clean up an aborted split when the regionserver shutting down
  • [HBASE-12798] - Map Reduce jobs should not create Tables in setConf()
  • [HBASE-12801] - Failed to truncate a table while maintaing binary region boundaries
  • [HBASE-12804] - ImportTsv fails to delete partition files created by it
  • [HBASE-12810] - Update to htrace-incubating
  • [HBASE-12811] - [AccessController] NPE while scanning a table with user not having READ permission on the namespace
  • [HBASE-12817] - Data missing while scanning using PREFIX_TREE data block encoding
  • [HBASE-12819] - ExportSnapshot doesn't close FileSystem instances
  • [HBASE-12824] - CompressionTest fails with org.apache.hadoop.hbase.io.hfile.AbstractHFileReader$NotSeekedException: Not seeked to a key/value
  • [HBASE-12831] - Changing the set of vis labels a user has access to doesn't generate an audit log event
  • [HBASE-12832] - Describe table from shell no longer shows Table's attributes, only CF attributes
  • [HBASE-12833] - [shell] table.rb leaks connections
  • [HBASE-12835] - HBASE-12422 changed new HTable(Configuration) to not use managed Connections anymore
  • [HBASE-12837] - ReplicationAdmin leaks zk connections
  • [HBASE-12844] - ServerManager.isServerReacable() should sleep between retries
  • [HBASE-12845] - ByteBufferOutputStream should grow as direct buffer if the initial buffer is also direct BB
  • [HBASE-12847] - TestZKLessSplitOnCluster frequently times out in 0.98 builds
  • [HBASE-12849] - LoadIncrementalHFiles should use unmanaged connection in branch-1
  • [HBASE-12862] - Uppercase "wals" in RegionServer webUI
  • [HBASE-12863] - Master info port on RS UI is always 0
  • [HBASE-12864] - IntegrationTestTableSnapshotInputFormat fails
  • [HBASE-12867] - Shell does not support custom replication endpoint specification
  • [HBASE-12878] - Incorrect HFile path in TestHFilePerformance print output (fix for easier debugging)
  • [HBASE-12881] - TestFastFail is not compatible with surefire.rerunFailingTestsCount
  • [HBASE-12886] - Correct tag option name in PerformanceEvaluation
  • [HBASE-12892] - Add a class to allow taking a snapshot from the command line
  • [HBASE-12897] - Minimum memstore size is a percentage
  • [HBASE-12898] - Add in used undeclared dependencies
  • [HBASE-12901] - Possible deadlock while onlining a region and get region plan for other region run parallel
  • [HBASE-12904] - Threading issues in region_mover.rb
  • [HBASE-12908] - Typos in MemStoreFlusher javadocs
  • [HBASE-12915] - Disallow small scan with batching
  • [HBASE-12916] - No access control for replicating WAL entries
  • [HBASE-12917] - HFilePerformanceEvaluation Scan tests fail with StackOverflowError due to recursive call in createCell function
  • [HBASE-12918] - Backport asciidoc changes
  • [HBASE-12919] - Compilation with Hadoop-2.4- is broken again
  • [HBASE-12924] - HRegionServer#MovedRegionsCleaner Chore does not start
  • [HBASE-12927] - TestFromClientSide#testScanMetrics() failing due to duplicate createTable commands
  • [HBASE-12931] - The existing KeyValues in memstore are not removed completely after inserting cell into memStore
  • [HBASE-12948] - Calling Increment#addColumn on the same column multiple times produces wrong result
  • [HBASE-12951] - TestHCM.testConnectionClose is flakey when using AsyncRpcClient as client implementation
  • [HBASE-12953] - RegionServer is not functionally working with AysncRpcClient in secure mode
  • [HBASE-12954] - Ability impaired using HBase on multihomed hosts
  • [HBASE-12956] - Binding to 0.0.0.0 is broken after HBASE-10569
  • [HBASE-12958] - SSH doing hbase:meta get but hbase:meta not assigned
  • [HBASE-12961] - Negative values in read and write region server metrics
  • [HBASE-12962] - TestHFileBlockIndex.testBlockIndex() commented out during HBASE-10531
  • [HBASE-12964] - Add the ability for hbase-daemon.sh to start in the foreground
  • [HBASE-12966] - NPE in HMaster while recovering tables in Enabling state
  • [HBASE-12969] - Parameter Validation is not there for shell script, local-master-backup.sh and local-regionservers.sh
  • [HBASE-12971] - Replication stuck due to large default value for replication.source.maxretriesmultiplier
  • [HBASE-12976] - Set default value for hbase.client.scanner.max.result.size
  • [HBASE-12978] - Region goes permanently offline (WAS: hbase:meta has a row missing hregioninfo and it causes my long-running job to fail)
  • [HBASE-12984] - SSL cannot be used by the InfoPort after removing deprecated code in HBASE-10336
  • [HBASE-12985] - Javadoc warning and findbugs fixes to get us green again
  • [HBASE-12989] - region_mover.rb unloadRegions method uses ArrayList concurrently resulting in errors
  • [HBASE-12991] - Use HBase 1.0 interfaces in hbase-rest
  • [HBASE-12993] - Use HBase 1.0 interfaces in hbase-thrift
  • [HBASE-12996] - Reversed field on Filter should be transient
  • [HBASE-12998] - Compilation with Hdfs-2.7.0-SNAPSHOT is broken after HDFS-7647
  • [HBASE-12999] - Make foreground_start return the correct exit code
  • [HBASE-13001] - NullPointer in master logs for table.jsp
  • [HBASE-13003] - Get tests in TestHFileBlockIndex back
  • [HBASE-13004] - Make possible to explain why HBaseTestingUtility.waitFor fails
  • [HBASE-13007] - Fix the test timeouts being caused by ChoreService
  • [HBASE-13009] - HBase REST UI inaccessible
  • [HBASE-13010] - HFileOutputFormat2 partitioner's path is hard-coded as '/tmp'
  • [HBASE-13011] - TestLoadIncrementalHFiles is flakey when using AsyncRpcClient as client implementation
  • [HBASE-13027] - mapreduce.TableInputFormatBase should create its own Connection if needed
  • [HBASE-13030] - [1.0.0 polish] Make ScanMetrics public again and align Put 'add' with Get, Delete, etc., addColumn
  • [HBASE-13032] - Migration of states should be performed once META is assigned and onlined.
  • [HBASE-13036] - Meta scanner should use its own threadpool
  • [HBASE-13038] - Fix the java doc warning continuously reported by Hadoop QA
  • [HBASE-13039] - Add patchprocess/* to .gitignore to fix builds of branches
  • [HBASE-13040] - Possible failure of TestHMasterRPCException
  • [HBASE-13047] - Add "HBase Configuration" link missing on the table details pages
  • [HBASE-13048] - Use hbase.crypto.wal.algorithm in SecureProtobufLogReader while decrypting the data
  • [HBASE-13049] - wal_roll ruby command doesn't work.
  • [HBASE-13050] - Hbase shell create_namespace command throws ArrayIndexOutOfBoundException for (invalid) empty text input.
  • [HBASE-13055] - HRegion FIXED_OVERHEAD missed one boolean
  • [HBASE-13058] - Hbase shell command 'scan' for non existent table shows unnecessary info for one unrelated existent table.
  • [HBASE-13061] - RegionStates can remove wrong region from server holdings
  • [HBASE-13065] - Increasing -Xmx when running TestDistributedLogSplitting
  • [HBASE-13066] - Fix typo in AsyncRpcChannel
  • [HBASE-13069] - Thrift Http Server returns an error code of 500 instead of 401 when authentication fails
  • [HBASE-13070] - Fix TestCacheOnWrite
  • [HBASE-13072] - BucketCache.evictBlock returns true if block does not exist
  • [HBASE-13075] - TableInputFormatBase spuriously warning about multiple initializeTable calls
  • [HBASE-13077] - BoundedCompletionService doesn't pass trace info to server
  • [HBASE-13083] - Master can be dead-locked while assigning META.
  • [HBASE-13084] - Add labels to VisibilityLabelsCache asynchronously causes TestShell flakey
  • [HBASE-13085] - Security issue in the implementation of Rest gataway 'doAs' proxy user support
  • [HBASE-13091] - Split ZK Quorum on Master WebUI
  • [HBASE-13093] - Local mode HBase instance doesn't shut down.
  • [HBASE-13097] - Use same EventLoopGroup for different AsyncRpcClients if possible
  • [HBASE-13102] - Fix Pseudo-distributed Mode which was broken in 1.0.0
  • [HBASE-13111] - truncate_preserve command is failing with undefined method error
  • [HBASE-13112] - quota.rb, security.rb and visibility_labels.rb leak connection
  • [HBASE-13114] - [UNITTEST] TestEnableTableHandler.testDeleteForSureClearsAllTableRowsFromMeta
  • [HBASE-13115] - Fix the usage of remote user in thrift doAs implementation.
  • [HBASE-13119] - FileLink should implement equals
  • [HBASE-13123] - Minor bug in ROW bloom filter
  • [HBASE-13131] - ReplicationAdmin leaks connections if there's an error in the constructor
  • [HBASE-13133] - NPE when running TestSplitLogManager
  • [HBASE-13134] - mutateRow and checkAndMutate apis don't throw region level exceptions
  • [HBASE-13136] - TestSplitLogManager.testGetPreviousRecoveryMode is flakey
  • [HBASE-13139] - Clean up missing JAVA_HOME message in bin/hbase-config.sh
  • [HBASE-13141] - IntegrationTestAcidGuarantees returns incorrect values for getColumnFamilies
  • [HBASE-13145] - TestNamespaceAuditor.testRegionMerge is flaky
  • [HBASE-13146] - Race Condition in ScheduledChore and ChoreService
  • [HBASE-13149] - HBase MR is broken on Hadoop 2.5+ Yarn
  • [HBASE-13155] - Fix TestPrefixTree
  • [HBASE-13156] - Fix minor rat violation recently introduced (asciidoctor.css).
  • [HBASE-13165] - Fix docs and scripts for default max heaps size after HBASE-11804
  • [HBASE-13172] - TestDistributedLogSplitting.testThreeRSAbort fails several times on branch-1
  • [HBASE-13174] - Apply HBASE-11804 to Windows scripts
  • [HBASE-13176] - Flakey TestZooKeeper test.
  • [HBASE-13181] - TestHRegionReplayEvents.testReplayBulkLoadEvent fails frequently.
  • [HBASE-13188] - java.lang.ArithmeticException issue in BoundedByteBufferPool.putBuffer
  • [HBASE-13193] - RegionScannerImpl filters should not be reset if a partial Result is returned
  • [HBASE-13206] - Fix TableLock tableName log format
  • [HBASE-13224] - Minor formatting issue when logging a namespace scope in AuthResult#toContextString
  • [HBASE-13227] - LoadIncrementalHFile should skip non-files inside a possible family-dir
  • [HBASE-13229] - Specify bash for local-regionservers.sh and local-master-backup.sh
  • [HBASE-13232] - ConnectionManger : Batch pool threads and metaLookup pool threads should use different name pattern
  • [HBASE-13239] - HBase grant at specific column level does not work for Groups
  • [HBASE-13242] - TestPerColumnFamilyFlush.testFlushingWhenLogRolling hung
  • [HBASE-13246] - Correct the assertion for namespace permissions in tearDown method of TestAccessController
  • [HBASE-13253] - LoadIncrementalHFiles unify hfiles discovery
  • [HBASE-13262] - ResultScanner doesn't return all rows in Scan
  • [HBASE-13265] - Make thrift2 usable from c++
  • [HBASE-13273] - Make Result.EMPTY_RESULT read-only; currently it can be modified
  • [HBASE-13274] - Fix misplaced deprecation in Delete#addXYZ
  • [HBASE-13275] - Setting hbase.security.authorization to false does not disable authorization
  • [HBASE-13282] - Fix the minor issues of running Canary on kerberized environment
  • [HBASE-13285] - Fix flaky getRegions() in TestAccessController.setUp()
  • [HBASE-13289] - typo in splitSuccessCount metric
  • [HBASE-13294] - Fix the critical ancient loopholes in security testing infrastructure.
  • [HBASE-13295] - TestInfoServers hang
  • [HBASE-13296] - Fix the deletion of acl notify nodes for namespace.
  • [HBASE-13298] - Clarify if Table.{set|get}WriteBufferSize() is deprecated or not
  • [HBASE-13299] - Add setReturnResults() to Increment, like Append has
  • [HBASE-13301] - Possible memory leak in BucketCache
  • [HBASE-13305] - Get(Get get) is not copying the row key
  • [HBASE-13308] - Fix flaky TestEndToEndSplitTransaction
  • [HBASE-13309] - Some tests do not reset EnvironmentEdgeManager
  • [HBASE-13314] - Fix NPE in HMaster.getClusterStatus()
  • [HBASE-13315] - BufferedMutator should be @InterfaceAudience.Public
  • [HBASE-13317] - Region server reportForDuty stuck looping if there is a master change
  • [HBASE-13321] - Fix flaky TestHBaseFsck
  • [HBASE-13326] - Disabled table can't be enabled after HBase is restarted
  • [HBASE-13328] - LoadIncrementalHFile.doBulkLoad(Path,HTable) should handle managed connections
  • [HBASE-13331] - Exceptions from DFS client can cause CatalogJanitor to delete referenced files
  • [HBASE-13371] - Fix typo in TestAsyncIPC
  • [HBASE-13374] - Small scanners (with particular configurations) do not return all rows
  • [HBASE-13382] - IntegrationTestBigLinkedList should use SecureRandom
  • [HBASE-13384] - Fix Javadoc warnings introduced by HBASE-12972
  • [HBASE-13385] - TestGenerateDelegationToken is broken with hadoop 2.8.0
  • [HBASE-13388] - Handling NullPointer in ZKProcedureMemberRpcs while getting ZNode data
  • [HBASE-13394] - Failed to recreate a table when quota is enabled
  • [HBASE-13397] - Purge duplicate rpc request thread local
  • [HBASE-13402] - [Backport 1.1] HBASE-12552: listSnapshots should list only owned snapshots for non-super user
  • [HBASE-13406] - TestAccessController is flaky when create is slow
  • [HBASE-13409] - Add categories to uncategorized tests
  • [HBASE-13410] - Bug in KeyValueUtil.oswrite() for non Keyvalue cases
  • [HBASE-13414] - TestHCM no longer needs to test for JRE 6.
  • [HBASE-13417] - batchCoprocessorService() does not handle NULL keys
  • [HBASE-13423] - Remove duplicate entry for hbase.regionserver.regionSplitLimit in hbase-default.xml
  • [HBASE-13430] - HFiles that are in use by a table cloned from a snapshot may be deleted when that snapshot is deleted
  • [HBASE-13437] - ThriftServer leaks ZooKeeper connections
  • [HBASE-13457] - SnapshotExistsException doesn't honor the DoNotRetry
  • [HBASE-13460] - Revise the MetaLookupPool executor-related defaults (introduced in HBASE-13036)
  • [HBASE-13463] - Quota needs to be updated only in case of successful region merge
  • [HBASE-13471] - Fix a possible infinite loop in doMiniBatchMutation
  • [HBASE-13473] - deleted cells come back alive after the stripe compaction
  • [HBASE-13475] - Small spelling mistake in region_mover#isSuccessfulScan causes NoMethodError
  • [HBASE-13477] - Create metrics on failed requests
  • [HBASE-13482] - Phoenix is failing to scan tables on secure environments.
  • [HBASE-13490] - foreground daemon start re-executes ulimit output
  • [HBASE-13491] - Issue in FuzzyRowFilter#getNextForFuzzyRule
  • [HBASE-13499] - AsyncRpcClient test cases failure in powerpc
  • [HBASE-13517] - Publish a client artifact with shaded dependencies
  • [HBASE-13520] - NullPointerException in TagRewriteCell
  • [HBASE-13524] - TestReplicationAdmin fails on JDK 1.8
  • [HBASE-13526] - TestRegionServerReportForDuty can be flaky: hang or timeout
  • [HBASE-13527] - The default value for hbase.client.scanner.max.result.size is never actually set on Scans
  • [HBASE-13528] - A bug on selecting compaction pool
  • [HBASE-13546] - NPE on region server status page if all masters are down
  • [HBASE-13555] - StackServlet produces 500 error
  • [HBASE-13575] - TestChoreService has to make sure that the opened ChoreService is closed for each unit test
  • [HBASE-13577] - Documentation is pointing to wrong port for Master Web UI
  • [HBASE-13585] - HRegionFileSystem#splitStoreFile() finishes without closing the file handle in some situation
  • [HBASE-13589] - [WINDOWS] hbase.cmd script is broken
  • [HBASE-13594] - MultiRowRangeFilter shouldn't call HBaseZeroCopyByteString.wrap() directly
  • [HBASE-13596] - src assembly does not build
  • [HBASE-13637] - branch-1.1 does not build against hadoop-2.2.
  • [HBASE-13661] - Correct binary compatibility issues discovered in 1.1.0RC0
  • Improvement:
  • [HBASE-5699] - Run with > 1 WAL in HRegionServer
  • [HBASE-6919] - Remove unnecessary throws IOException from Bytes.readVLong
  • [HBASE-7541] - Convert all tests that use HBaseTestingUtility.createMultiRegions to HBA.createTable
  • [HBASE-8329] - Limit compaction speed
  • [HBASE-10201] - Port 'Make flush decisions per column family' to trunk
  • [HBASE-11144] - Filter to support scanning multiple row key ranges
  • [HBASE-11864] - Enhance HLogPrettyPrinter to print information from WAL Header
  • [HBASE-11869] - Support snapshot owner
  • [HBASE-12071] - Separate out thread pool for Master RegionServer communication
  • [HBASE-12223] - MultiTableInputFormatBase.getSplits is too slow
  • [HBASE-12405] - WAL accounting by Store
  • [HBASE-12429] - Add port to ClusterManager's actions.
  • [HBASE-12608] - region_mover.rb does not log moving region count correctly when loading regions
  • [HBASE-12620] - Add HBASE-11639 related items to Ref Guide
  • [HBASE-12627] - Add back snapshot batching facility from HBASE-11360 dropped by HBASE-11742
  • [HBASE-12641] - Grant all permissions of hbase zookeeper node to hbase superuser in a secure cluster
  • [HBASE-12684] - Add new AsyncRpcClient
  • [HBASE-12706] - Support multiple port numbers in ZK quorum string
  • [HBASE-12719] - Add test WAL provider to quantify FSHLog overhead in the absence of HDFS.
  • [HBASE-12720] - Make InternalScan LimitedPrivate
  • [HBASE-12736] - Let MetaScanner recycle a given Connection
  • [HBASE-12745] - Visibility Labels: support visibility labels for user groups.
  • [HBASE-12761] - On region jump ClientScanners should get next row start key instead of a skip.
  • [HBASE-12762] - Region with no hfiles will have the highest locality cost in LocalityCostFunction
  • [HBASE-12768] - Support enable cache_data_on_write in Shell while creating table
  • [HBASE-12825] - CallRunner exception messages should include destination host:port
  • [HBASE-12891] - Parallel execution for Hbck checkRegionConsistency
  • [HBASE-12893] - IntegrationTestBigLinkedListWithVisibility should use buffered writes
  • [HBASE-12899] - HBase should prefix htrace configuration keys with "hbase.htrace" rather than just "hbase."
  • [HBASE-12929] - TableMapReduceUtil.initTableMapperJob unnecessarily limits the types of outputKeyClass and outputValueClass
  • [HBASE-12957] - region_mover#isSuccessfulScan may be extremely slow on region with lots of expired data
  • [HBASE-12973] - RegionCoprocessorEnvironment should provide HRegionInfo directly
  • [HBASE-12975] - Supportable SplitTransaction and RegionMergeTransaction interfaces
  • [HBASE-12979] - Use setters instead of return values for handing back statistics from HRegion methods
  • [HBASE-12982] - Adding timeouts to TestChoreService
  • [HBASE-12987] - HBCK should print status while scanning over many regions
  • [HBASE-12997] - FSHLog should print pipeline on low replication
  • [HBASE-13002] - Make encryption cipher configurable
  • [HBASE-13008] - Better default for hbase.regionserver.regionSplitLimit parameter.
  • [HBASE-13044] - Configuration option for disabling coprocessor loading
  • [HBASE-13054] - Provide more tracing information for locking/latching events.
  • [HBASE-13056] - Refactor table.jsp code to remove repeated code and make it easier to add new checks
  • [HBASE-13059] - Set executable bit for scripts in dev-support
  • [HBASE-13080] - Hbase shell message containing extra quote at the end of error message.
  • [HBASE-13086] - Show ZK root node on Master WebUI
  • [HBASE-13100] - Shell command to retrieve table splits
  • [HBASE-13109] - Make better SEEK vs SKIP decisions during scanning
  • [HBASE-13118] - [PE] Add being able to write many columns
  • [HBASE-13120] - Allow disabling hadoop classpath and native library lookup
  • [HBASE-13122] - Improve efficiency for return codes of some filters
  • [HBASE-13128] - Make HBCK's lock file retry creation and deletion
  • [HBASE-13132] - Improve RemoveColumn action debug message
  • [HBASE-13138] - Clean up TestMasterObserver (debug, trying to figure why fails)
  • [HBASE-13142] - [PERF] Reuse the IPCUtil#buildCellBlock buffer
  • [HBASE-13162] - Add capability for cleaning hbase acls to hbase cleanup script.
  • [HBASE-13168] - Backport HBASE-12590 "A solution for data skew in HBase-Mapreduce Job"
  • [HBASE-13171] - Change AccessControlClient methods to accept connection object to reduce setup time.
  • [HBASE-13183] - Make ZK tickTime configurable in standalone HBase
  • [HBASE-13189] - PrefixTreecell should implement HeapSize
  • [HBASE-13216] - Add version info in RPC connection header
  • [HBASE-13222] - Provide means of non-destructive balancer inspection
  • [HBASE-13223] - Add testMoveMeta to IntegrationTestMTTR
  • [HBASE-13235] - Revisit the security auditing semantics.
  • [HBASE-13236] - Clean up m2e-related warnings/errors from poms
  • [HBASE-13241] - Add tests for group level grants
  • [HBASE-13255] - Bad grammar in RegionServer status page
  • [HBASE-13256] - HBaseConfiguration#checkDefaultsVersion(Configuration) has spelling error
  • [HBASE-13270] - Setter for Result#getStats is #addResults; confusing!
  • [HBASE-13316] - Reduce the downtime on planned moves of regions
  • [HBASE-13342] - Fix incorrect interface annotations
  • [HBASE-13345] - Fix LocalHBaseCluster so that different region server impl can be used for different slaves
  • [HBASE-13350] - Add a debug-warn if we fail HTD checks even if table.sanity.checks is false
  • [HBASE-13351] - Annotate internal MasterRpcServices methods with admin priority
  • [HBASE-13362] - Set max result size from client only (like scanner caching).
  • [HBASE-13369] - Expose scanNext stats to region server level
  • [HBASE-13370] - PE tool could give option for using Explicit Column Tracker which leads to seeks
  • [HBASE-13381] - Expand TestSizeFailures to include small scans
  • [HBASE-13419] - Thrift gateway should propagate text from exception causes.
  • [HBASE-13431] - Allow to skip store file range check based on column family while creating reference files in HRegionFileSystem#splitStoreFile
  • [HBASE-13436] - Include user name in ADE for scans
  • [HBASE-13453] - Master should not bind to region server ports
  • [HBASE-13456] - Improve HFilePrettyPrinter first hbase:meta region processing
  • [HBASE-13516] - Increase PermSize to 128MB
  • [HBASE-13518] - Typo in hbase.hconnection.meta.lookup.threads.core parameter
  • [HBASE-13550] - [Shell] Support unset of a list of table attributes
  • [HBASE-13552] - ChoreService shutdown message could be more informative
  • [HBASE-13578] - Remove Arrays.asList().subList() from FSHLog.offer()
  • New Feature:
  • [HBASE-9531] - a command line (hbase shell) interface to retreive the replication metrics and show replication lag
  • [HBASE-12268] - Add support for Scan.setRowPrefixFilter to shell
  • [HBASE-12709] - [mvn] Add unit test excludes command line flag to the build.
  • [HBASE-12731] - Heap occupancy based client pushback
  • [HBASE-12869] - Add a REST API implementation of the ClusterManager interface
  • [HBASE-12972] - Region, a supportable public/evolving subset of HRegion
  • [HBASE-13057] - Provide client utility to easily enable and disable table replication
  • [HBASE-13063] - Allow to turn off memstore replication for region replicas
  • [HBASE-13090] - Progress heartbeats for long running scanners
  • [HBASE-13170] - Allow block cache to be external
  • [HBASE-13412] - Region split decisions should have jitter
  • Task:
  • [HBASE-9604] - Add metric on short-circuit reads
  • [HBASE-12180] - Fix and reenable TestRegionReplicaReplicationEndpoint
  • [HBASE-12700] - Backport 'Make flush decisions per column family' from master
  • [HBASE-12783] - Create efficient RegionLocator implementation
  • [HBASE-12785] - Use FutureTask to timeout the attempt to get the lock for hbck
  • [HBASE-12788] - Promote Abortable to LimitedPrivate
  • [HBASE-12834] - Promote ScanType to LimitedPrivate
  • [HBASE-12995] - Document that HConnection#getTable methods do not check table existence since 0.98.1
  • [HBASE-13187] - Add ITBLL that exercises per CF flush
  • [HBASE-13205] - [branch-1] Backport HBASE-11598 Add simple rpc throttling
  • [HBASE-13380] - Cherry pick the HBASE-12808 compatibility checker tool back to 0.98+
  • [HBASE-13438] - [branch-1] Backport Basic quota support for namespaces
  • [HBASE-13584] - Disable distributed log replay by default for 1.1
  • [HBASE-13665] - Fix docs and site building on branch-1
  • Test:
  • [HBASE-7781] - Update security unit tests to use a KDC if available
  • [HBASE-12764] - TestPerColumnFamilyFlush#testCompareStoreFileCount may fail due to new table not available
  • [HBASE-12799] - ITAG fails with java.lang.RuntimeException if table does not exist
  • [HBASE-12876] - TestScannerWithBulkload should pass Table with unmanaged connection to LoadIncrementalHFiles#doBulkLoad()
  • [HBASE-12885] - Unit test for RAW / VERSIONS scanner specifications
  • [HBASE-12992] - TestChoreService doesn&#

New in Apache HBase 1.0.1 (Apr 29, 2015)

  • Sub-task:
  • [HBASE-13006] - Document visibility label support for groups
  • [HBASE-13292] - Undo parent from 0.98 and 1.0: setting hbase.client.scanner.max.result.size is considered harmful
  • [HBASE-13303] - Fix size calculation of results on the region server
  • [HBASE-13327] - Use Admin in ConnectionCache
  • [HBASE-13332] - Fix the usage of doAs/runAs in Visibility Controller tests.
  • [HBASE-13335] - Update ClientSmallScanner and ClientSmallReversedScanner
  • [HBASE-13386] - Backport HBASE-12601 to all active branches other than master
  • [HBASE-13479] - [branch-1.0] Master should not bind to region server ports
  • [HBASE-13481] - Master should respect master (old) DNS/bind related configurations
  • Bug:
  • [HBASE-10728] - get_counter value is never used.
  • [HBASE-11542] - Unit Test KeyStoreTestUtil.java compilation failure in IBM JDK
  • [HBASE-12006] - [JDK 8] KeyStoreTestUtil#generateCertificate fails due to "subject class type invalid"
  • [HBASE-12102] - Duplicate keys in HBase.RegionServer metrics JSON
  • [HBASE-12908] - Typos in MemStoreFlusher javadocs
  • [HBASE-12931] - The existing KeyValues in memstore are not removed completely after inserting cell into memStore
  • [HBASE-12948] - Calling Increment#addColumn on the same column multiple times produces wrong result
  • [HBASE-12969] - Parameter Validation is not there for shell script, local-master-backup.sh and local-regionservers.sh
  • [HBASE-12993] - Use HBase 1.0 interfaces in hbase-thrift
  • [HBASE-13001] - NullPointer in master logs for table.jsp
  • [HBASE-13040] - Possible failure of TestHMasterRPCException
  • [HBASE-13047] - Add "HBase Configuration" link missing on the table details pages
  • [HBASE-13048] - Use hbase.crypto.wal.algorithm in SecureProtobufLogReader while decrypting the data
  • [HBASE-13049] - wal_roll ruby command doesn't work.
  • [HBASE-13050] - Hbase shell create_namespace command throws ArrayIndexOutOfBoundException for (invalid) empty text input.
  • [HBASE-13055] - HRegion FIXED_OVERHEAD missed one boolean
  • [HBASE-13061] - RegionStates can remove wrong region from server holdings
  • [HBASE-13065] - Increasing -Xmx when running TestDistributedLogSplitting
  • [HBASE-13069] - Thrift Http Server returns an error code of 500 instead of 401 when authentication fails
  • [HBASE-13070] - Fix TestCacheOnWrite
  • [HBASE-13072] - BucketCache.evictBlock returns true if block does not exist
  • [HBASE-13075] - TableInputFormatBase spuriously warning about multiple initializeTable calls
  • [HBASE-13077] - BoundedCompletionService doesn't pass trace info to server
  • [HBASE-13083] - Master can be dead-locked while assigning META.
  • [HBASE-13085] - Security issue in the implementation of Rest gataway 'doAs' proxy user support
  • [HBASE-13091] - Split ZK Quorum on Master WebUI
  • [HBASE-13102] - Fix Pseudo-distributed Mode which was broken in 1.0.0
  • [HBASE-13111] - truncate_preserve command is failing with undefined method error
  • [HBASE-13112] - quota.rb, security.rb and visibility_labels.rb leak connection
  • [HBASE-13115] - Fix the usage of remote user in thrift doAs implementation.
  • [HBASE-13123] - Minor bug in ROW bloom filter
  • [HBASE-13131] - ReplicationAdmin leaks connections if there's an error in the constructor
  • [HBASE-13133] - NPE when running TestSplitLogManager
  • [HBASE-13134] - mutateRow and checkAndMutate apis don't throw region level exceptions
  • [HBASE-13136] - TestSplitLogManager.testGetPreviousRecoveryMode is flakey
  • [HBASE-13139] - Clean up missing JAVA_HOME message in bin/hbase-config.sh
  • [HBASE-13141] - IntegrationTestAcidGuarantees returns incorrect values for getColumnFamilies
  • [HBASE-13156] - Fix minor rat violation recently introduced (asciidoctor.css).
  • [HBASE-13165] - Fix docs and scripts for default max heaps size after HBASE-11804
  • [HBASE-13172] - TestDistributedLogSplitting.testThreeRSAbort fails several times on branch-1
  • [HBASE-13174] - Apply HBASE-11804 to Windows scripts
  • [HBASE-13176] - Flakey TestZooKeeper test.
  • [HBASE-13192] - IntegrationTestBulkLoad doesn't wait for table modification sometimes leading to spurious test failures
  • [HBASE-13206] - Fix TableLock tableName log format
  • [HBASE-13224] - Minor formatting issue when logging a namespace scope in AuthResult#toContextString
  • [HBASE-13227] - LoadIncrementalHFile should skip non-files inside a possible family-dir
  • [HBASE-13229] - Specify bash for local-regionservers.sh and local-master-backup.sh
  • [HBASE-13239] - HBase grant at specific column level does not work for Groups
  • [HBASE-13246] - Correct the assertion for namespace permissions in tearDown method of TestAccessController
  • [HBASE-13253] - LoadIncrementalHFiles unify hfiles discovery
  • [HBASE-13262] - ResultScanner doesn't return all rows in Scan
  • [HBASE-13265] - Make thrift2 usable from c++
  • [HBASE-13269] - Limit result array preallocation to avoid OOME with large scan caching values
  • [HBASE-13273] - Make Result.EMPTY_RESULT read-only; currently it can be modified
  • [HBASE-13274] - Fix misplaced deprecation in Delete#addXYZ
  • [HBASE-13275] - Setting hbase.security.authorization to false does not disable authorization
  • [HBASE-13282] - Fix the minor issues of running Canary on kerberized environment
  • [HBASE-13285] - Fix flaky getRegions() in TestAccessController.setUp()
  • [HBASE-13289] - typo in splitSuccessCount metric
  • [HBASE-13294] - Fix the critical ancient loopholes in security testing infrastructure.
  • [HBASE-13296] - Fix the deletion of acl notify nodes for namespace.
  • [HBASE-13298] - Clarify if Table.{set|get}WriteBufferSize() is deprecated or not
  • [HBASE-13301] - Possible memory leak in BucketCache
  • [HBASE-13305] - Get(Get get) is not copying the row key
  • [HBASE-13309] - Some tests do not reset EnvironmentEdgeManager
  • [HBASE-13314] - Fix NPE in HMaster.getClusterStatus()
  • [HBASE-13315] - BufferedMutator should be @InterfaceAudience.Public
  • [HBASE-13317] - Region server reportForDuty stuck looping if there is a master change
  • [HBASE-13326] - Disabled table can't be enabled after HBase is restarted
  • [HBASE-13331] - Exceptions from DFS client can cause CatalogJanitor to delete referenced files
  • [HBASE-13374] - Small scanners (with particular configurations) do not return all rows
  • [HBASE-13382] - IntegrationTestBigLinkedList should use SecureRandom
  • [HBASE-13388] - Handling NullPointer in ZKProcedureMemberRpcs while getting ZNode data
  • [HBASE-13409] - Add categories to uncategorized tests
  • [HBASE-13410] - Bug in KeyValueUtil.oswrite() for non Keyvalue cases
  • [HBASE-13414] - TestHCM no longer needs to test for JRE 6.
  • [HBASE-13423] - Remove duplicate entry for hbase.regionserver.regionSplitLimit in hbase-default.xml
  • [HBASE-13433] - Backward compatibility in 1.0.z for shell broken for get_counter
  • [HBASE-13457] - SnapshotExistsException doesn't honor the DoNotRetry
  • [HBASE-13473] - deleted cells come back alive after the stripe compaction
  • [HBASE-13491] - Issue in FuzzyRowFilter#getNextForFuzzyRule
  • Improvement:
  • [HBASE-13002] - Make encryption cipher configurable
  • [HBASE-13044] - Configuration option for disabling coprocessor loading
  • [HBASE-13054] - Provide more tracing information for locking/latching events.
  • [HBASE-13056] - Refactor table.jsp code to remove repeated code and make it easier to add new checks
  • [HBASE-13059] - Set executable bit for scripts in dev-support
  • [HBASE-13080] - Hbase shell message containing extra quote at the end of error message.
  • [HBASE-13086] - Show ZK root node on Master WebUI
  • [HBASE-13109] - Make better SEEK vs SKIP decisions during scanning
  • [HBASE-13118] - [PE] Add being able to write many columns
  • [HBASE-13120] - Allow disabling hadoop classpath and native library lookup
  • [HBASE-13132] - Improve RemoveColumn action debug message
  • [HBASE-13162] - Add capability for cleaning hbase acls to hbase cleanup script.
  • [HBASE-13168] - Backport HBASE-12590 "A solution for data skew in HBase-Mapreduce Job"
  • [HBASE-13183] - Make ZK tickTime configurable in standalone HBase
  • [HBASE-13189] - PrefixTreecell should implement HeapSize
  • [HBASE-13223] - Add testMoveMeta to IntegrationTestMTTR
  • [HBASE-13236] - Clean up m2e-related warnings/errors from poms
  • [HBASE-13241] - Add tests for group level grants
  • [HBASE-13342] - Fix incorrect interface annotations
  • [HBASE-13345] - Fix LocalHBaseCluster so that different region server impl can be used for different slaves
  • [HBASE-13362] - Set max result size from client only (like scanner caching).
  • [HBASE-13370] - PE tool could give option for using Explicit Column Tracker which leads to seeks
  • [HBASE-13381] - Expand TestSizeFailures to include small scans
  • [HBASE-13419] - Thrift gateway should propagate text from exception causes.
  • [HBASE-13436] - Include user name in ADE for scans
  • New Feature:
  • [HBASE-12869] - Add a REST API implementation of the ClusterManager interface
  • Task:
  • [HBASE-12995] - Document that HConnection#getTable methods do not check table existence since 0.98.1
  • [HBASE-13380] - Cherry pick the HBASE-12808 compatibility checker tool back to 0.98+
  • Test:
  • [HBASE-13106] - Ensure endpoint-only table coprocessors can be dynamically loaded

New in Apache HBase 1.0.0 (Feb 27, 2015)

  • Sub-task:
  • [HBASE-11852] - Still see "UnsupportedOperationException: CollectionUsage threshold is not supported"
  • [HBASE-12485] - Maintain SeqId monotonically increasing
  • [HBASE-12511] - namespace permissions - add support from table creation privilege in a namespace 'C'
  • [HBASE-12568] - Adopt Semantic Versioning and document it in the book
  • [HBASE-12575] - Sanity check table coprocessor classes are loadable
  • [HBASE-12606] - Sanity check encryption configuration before opening WAL or onlining regions
  • [HBASE-12679] - Add HBaseInterfaceAudience.TOOLS and move some of the Public classes to LimitedPrivate
  • [HBASE-12704] - Add demo client which uses doAs functionality on Thrift-over-HTTPS.
  • [HBASE-12730] - Backport HBASE-5162 (Basic client pushback mechanism) to branch-1
  • [HBASE-12735] - Refactor TAG so it can live as unit test and as an integration test
  • [HBASE-12763] - Make it so there must be WALs for a server to be marked dead
  • [HBASE-12776] - SpliTransaction: Log number of files to be split
  • [HBASE-12779] - SplitTransaction: Add metrics
  • [HBASE-12793] - [hbck] closeRegionSilentlyAndWait() should log cause of IOException and retry until hbase.hbck.close.timeout expires
  • [HBASE-12802] - Remove unnecessary Table.flushCommits()
  • [HBASE-12926] - Backport HBASE-12688 (Update site with a bootstrap-based UI) for HBASE-12918
  • [HBASE-12980] - Delete of a table may not clean all rows from hbase:meta
  • Bug:
  • [HBASE-8026] - HBase Shell docs for scan command does not reference VERSIONS
  • [HBASE-9431] - Set 'hbase.bulkload.retries.number' to 10 as HBASE-8450 claims
  • [HBASE-9910] - TestHFilePerformance and HFilePerformanceEvaluation should be merged in a single HFile performance test class.
  • [HBASE-10499] - In write heavy scenario one of the regions does not get flushed causing RegionTooBusyException
  • [HBASE-10528] - DefaultBalancer selects plans to move regions onto draining nodes
  • [HBASE-11979] - Compaction progress reporting is wrong
  • [HBASE-12028] - Abort the RegionServer, when it's handler threads die
  • [HBASE-12070] - Add an option to hbck to fix ZK inconsistencies
  • [HBASE-12108] - HBaseConfiguration: set classloader before loading xml files
  • [HBASE-12267] - Replace HTable constructor in mapreduce.* classes with ConnectionFactory
  • [HBASE-12270] - A bug in the bucket cache, with cache blocks on write enabled
  • [HBASE-12339] - WAL performance evaluation tool doesn't roll logs
  • [HBASE-12348] - preModifyColumn and preDeleteColumn in AC denies user to perform its operation though it has required rights
  • [HBASE-12393] - The regionserver web will throw exception if we disable block cache
  • [HBASE-12422] - Use ConnectionFactory in HTable constructors
  • [HBASE-12431] - Use of getColumnLatestCell(byte[], int, int, byte[], int, int) is Not Thread Safe
  • [HBASE-12454] - Setting didPerformCompaction early in HRegion#compact
  • [HBASE-12467] - Master joins cluster but never completes initialization
  • [HBASE-12480] - Regions in FAILED_OPEN/FAILED_CLOSE should be processed on master failover
  • [HBASE-12564] - consolidate the getTableDescriptors() semantic
  • [HBASE-12565] - Race condition in HRegion.batchMutate() causes partial data to be written when region closes
  • [HBASE-12574] - Update replication metrics to not do so many map look ups.
  • [HBASE-12585] - Fix refguide so it does hbase 1.0 style API everywhere with callout on how we used to do it in pre-1.0
  • [HBASE-12607] - TestHBaseFsck#testParallelHbck fails running against hadoop 2.6.0
  • [HBASE-12611] - Create autoCommit() method and remove clearBufferOnFail
  • [HBASE-12617] - Running IntegrationTestBigLinkedList against cluster getting not an instance of org.apache.hadoop.hbase.MiniHBaseCluster
  • [HBASE-12618] - Add 'Namespace' to headers while displaying user permissions.
  • [HBASE-12622] - user_permission should require global admin to display global and ns permissions
  • [HBASE-12632] - ThrottledInputStream/ExportSnapshot does not throttle
  • [HBASE-12634] - Fix the AccessController#requireGlobalPermission(ns) with NS
  • [HBASE-12635] - Delete acl notify znode of table after the table is deleted
  • [HBASE-12637] - Compilation with Hadoop-2.4- is broken
  • [HBASE-12642] - LoadIncrementalHFiles does not throw exception after hitting hbase.bulkload.retries.number setting
  • [HBASE-12644] - Visibility Labels: issue with storing super users in labels table
  • [HBASE-12647] - Truncate table should work with C as well
  • [HBASE-12652] - Allow unmanaged connections in MetaTableAccessor
  • [HBASE-12655] - WALPerformanceEvaluation miscalculates append/sync statistics for multiple regions
  • [HBASE-12661] - rat check fails for several files
  • [HBASE-12662] - region_status.rb is failing with NoMethodError
  • [HBASE-12663] - unify getTableDescriptors() and listTableDescriptorsByNamespace()
  • [HBASE-12664] - TestDefaultLoadBalancer.testBalanceCluster fails in CachedDNSToSwitchMapping
  • [HBASE-12665] - When aborting, dump metrics
  • [HBASE-12666] - TestAssignmentManager hanging; add timeouts
  • [HBASE-12671] - HBASE-12652 broke branch-1 builds (TestAssignmentManager fails)
  • [HBASE-12674] - Add permission check to getNamespaceDescriptor()
  • [HBASE-12675] - Use interface methods in shell scripts
  • [HBASE-12681] - truncate_preserve command fails with undefined method `getTable' error
  • [HBASE-12683] - Compilation with hadoop-2.7.0-SNAPSHOT is broken
  • [HBASE-12686] - Failures in split before PONR not clearing the daughter regions from regions in transition during rollback
  • [HBASE-12692] - NPE from SnapshotManager#stop
  • [HBASE-12694] - testTableExistsIfTheSpecifiedTableRegionIsSplitParent in TestSplitTransactionOnCluster class leaves regions in transition
  • [HBASE-12696] - Possible NPE in HRegionFileSystem#splitStoreFile when skipStoreFileRangeCheck in splitPolicy return true
  • [HBASE-12697] - Don't use RegionLocationFinder if localityCost == 0
  • [HBASE-12699] - undefined method `setAsyncLogFlush' exception thrown when setting DEFERRED_LOG_FLUSH=>true
  • [HBASE-12711] - Fix new findbugs warnings in hbase-thrift module
  • [HBASE-12715] - getLastSequenceId always returns -1
  • [HBASE-12716] - A bug in RegionSplitter.UniformSplit algorithm
  • [HBASE-12718] - Convert TestAcidGuarantees from a unit test to an integration test
  • [HBASE-12728] - buffered writes substantially less useful after removal of HTablePool
  • [HBASE-12732] - Log messages in FileLink$FileLinkInputStream#tryOpen are reversed
  • [HBASE-12739] - Avoid too large identifier of ZooKeeperWatcher
  • [HBASE-12740] - Improve performance of TestHBaseFsck
  • [HBASE-12741] - AccessController contains a javadoc issue
  • [HBASE-12742] - ClusterStatusPublisher crashes with a IPv6 network interface.
  • [HBASE-12744] - hbase-default.xml lists hbase.regionserver.global.memstore.size twice
  • [HBASE-12746] - [1.0.0RC0] Distributed Log Replay is on (HBASE-12577 was insufficient)
  • [HBASE-12747] - IntegrationTestMTTR will OOME if launched with mvn verify
  • [HBASE-12750] - getRequestsCount() in ClusterStatus returns total number of request
  • [HBASE-12767] - Fix a StoreFileScanner NPE in reverse scan flow
  • [HBASE-12771] - TestFailFast#testFastFail failing
  • [HBASE-12774] - Fix the inconsistent permission checks for bulkloading.
  • [HBASE-12781] - thrift2 listen port will bind always to the passed command line address
  • [HBASE-12782] - ITBLL fails for me if generator does anything but 5M per maptask
  • [HBASE-12791] - HBase does not attempt to clean up an aborted split when the regionserver shutting down
  • [HBASE-12798] - Map Reduce jobs should not create Tables in setConf()
  • [HBASE-12801] - Failed to truncate a table while maintaing binary region boundaries
  • [HBASE-12804] - ImportTsv fails to delete partition files created by it
  • [HBASE-12810] - Update to htrace-incubating
  • [HBASE-12811] - [AccessController] NPE while scanning a table with user not having READ permission on the namespace
  • [HBASE-12817] - Data missing while scanning using PREFIX_TREE data block encoding
  • [HBASE-12819] - ExportSnapshot doesn't close FileSystem instances
  • [HBASE-12824] - CompressionTest fails with org.apache.hadoop.hbase.io.hfile.AbstractHFileReader$NotSeekedException: Not seeked to a key/value
  • [HBASE-12831] - Changing the set of vis labels a user has access to doesn't generate an audit log event
  • [HBASE-12832] - Describe table from shell no longer shows Table's attributes, only CF attributes
  • [HBASE-12833] - [shell] table.rb leaks connections
  • [HBASE-12835] - HBASE-12422 changed new HTable(Configuration) to not use managed Connections anymore
  • [HBASE-12837] - ReplicationAdmin leaks zk connections
  • [HBASE-12844] - ServerManager.isServerReacable() should sleep between retries
  • [HBASE-12847] - TestZKLessSplitOnCluster frequently times out in 0.98 builds
  • [HBASE-12862] - Uppercase "wals" in RegionServer webUI
  • [HBASE-12863] - Master info port on RS UI is always 0
  • [HBASE-12864] - IntegrationTestTableSnapshotInputFormat fails
  • [HBASE-12874] - LoadIncrementalHFiles should use unmanaged connection
  • [HBASE-12878] - Incorrect HFile path in TestHFilePerformance print output (fix for easier debugging)
  • [HBASE-12881] - TestFastFail is not compatible with surefire.rerunFailingTestsCount
  • [HBASE-12886] - Correct tag option name in PerformanceEvaluation
  • [HBASE-12892] - Add a class to allow taking a snapshot from the command line
  • [HBASE-12897] - Minimum memstore size is a percentage
  • [HBASE-12898] - Add in used undeclared dependencies
  • [HBASE-12901] - Possible deadlock while onlining a region and get region plan for other region run parallel
  • [HBASE-12904] - Threading issues in region_mover.rb
  • [HBASE-12915] - Disallow small scan with batching
  • [HBASE-12916] - No access control for replicating WAL entries
  • [HBASE-12917] - HFilePerformanceEvaluation Scan tests fail with StackOverflowError due to recursive call in createCell function
  • [HBASE-12918] - Backport asciidoc changes
  • [HBASE-12919] - Compilation with Hadoop-2.4- is broken again
  • [HBASE-12925] - Use acl cache for doing access control checks in prepare and clean phases of Bulkloading.
  • [HBASE-12942] - After disabling the hfile block cache, Regionserver UI is throwing java.lang.NullPointerException
  • [HBASE-12956] - Binding to 0.0.0.0 is broken after HBASE-10569
  • [HBASE-12958] - SSH doing hbase:meta get but hbase:meta not assigned
  • [HBASE-12962] - TestHFileBlockIndex.testBlockIndex() commented out during HBASE-10531
  • [HBASE-12966] - NPE in HMaster while recovering tables in Enabling state
  • [HBASE-12971] - Replication stuck due to large default value for replication.source.maxretriesmultiplier
  • [HBASE-12976] - Set default value for hbase.client.scanner.max.result.size
  • [HBASE-12978] - Region goes permanently offline (WAS: hbase:meta has a row missing hregioninfo and it causes my long-running job to fail)
  • [HBASE-12984] - SSL cannot be used by the InfoPort after removing deprecated code in HBASE-10336
  • [HBASE-12985] - Javadoc warning and findbugs fixes to get us green again
  • [HBASE-12989] - region_mover.rb unloadRegions method uses ArrayList concurrently resulting in errors
  • [HBASE-12991] - Use HBase 1.0 interfaces in hbase-rest
  • [HBASE-12996] - Reversed field on Filter should be transient
  • [HBASE-12998] - Compilation with Hdfs-2.7.0-SNAPSHOT is broken after HDFS-7647
  • [HBASE-13003] - Get tests in TestHFileBlockIndex back
  • [HBASE-13009] - HBase REST UI inaccessible
  • [HBASE-13010] - HFileOutputFormat2 partitioner's path is hard-coded as '/tmp'
  • [HBASE-13026] - Wrong error message in case incorrect snapshot name OR Incorrect table name
  • [HBASE-13027] - mapreduce.TableInputFormatBase should create its own Connection if needed
  • [HBASE-13028] - Cleanup mapreduce API changes
  • [HBASE-13030] - [1.0.0 polish] Make ScanMetrics public again and align Put 'add' with Get, Delete, etc., addColumn
  • [HBASE-13037] - LoadIncrementalHFile should try to verify the content of unmatched families
  • [HBASE-13038] - Fix the java doc warning continuously reported by Hadoop QA
  • [HBASE-13039] - Add patchprocess/* to .gitignore to fix builds of branches
  • Improvement:
  • [HBASE-5699] - Run with > 1 WAL in HRegionServer
  • [HBASE-11195] - Potentially improve block locality during major compaction for old regions
  • [HBASE-11412] - Minimize a number of hbase-client transitive dependencies
  • [HBASE-11639] - [Visibility controller] Replicate the visibility of Cells as strings
  • [HBASE-12071] - Separate out thread pool for Master RegionServer communication
  • [HBASE-12121] - maven release plugin does not allow for customized goals
  • [HBASE-12204] - Backport HBASE-12016 'Reduce number of versions in Meta table. Make it configurable' to branch-1
  • [HBASE-12373] - Provide a command to list visibility labels
  • [HBASE-12583] - Allow creating reference files even the split row not lies in the storefile range if required
  • [HBASE-12597] - Add RpcClient interface and enable changing of RpcClient implementation
  • [HBASE-12608] - region_mover.rb does not log moving region count correctly when loading regions
  • [HBASE-12630] - Provide capability for dropping malfunctioning ConfigurationObserver automatically
  • [HBASE-12640] - Add Thrift-over-HTTPS and doAs support for Thrift Server
  • [HBASE-12641] - Grant all permissions of hbase zookeeper node to hbase superuser in a secure cluster
  • [HBASE-12651] - Backport HBASE-12559 'Provide LoadBalancer with online configuration capability' to branch-1
  • [HBASE-12653] - Move TestRegionServerOnlineConfigChange & TestConfigurationManager to Junit4 tests
  • [HBASE-12659] - Replace the method calls to grant and revoke in shell scripts with AccessControlClient
  • [HBASE-12668] - Adapt PayloadCarryingRpcController so it can also be used in async way
  • [HBASE-12676] - Fix the misleading ASCII art in IntegrationTestBigLinkedList
  • [HBASE-12678] - HBCK should print command line arguments
  • [HBASE-12680] - Refactor base ClusterManager in HBase to not have the notion of sending a signal.
  • [HBASE-12719] - Add test WAL provider to quantify FSHLog overhead in the absence of HDFS.
  • [HBASE-12720] - Make InternalScan LimitedPrivate
  • [HBASE-12736] - Let MetaScanner recycle a given Connection
  • [HBASE-12745] - Visibility Labels: support visibility labels for user groups.
  • [HBASE-12762] - Region with no hfiles will have the highest locality cost in LocalityCostFunction
  • [HBASE-12768] - Support enable cache_data_on_write in Shell while creating table
  • [HBASE-12773] - Add warning message when user is trying to bulkload a large HFile.
  • [HBASE-12825] - CallRunner exception messages should include destination host:port
  • [HBASE-12893] - IntegrationTestBigLinkedListWithVisibility should use buffered writes
  • [HBASE-12899] - HBase should prefix htrace configuration keys with "hbase.htrace" rather than just "hbase."
  • [HBASE-12929] - TableMapReduceUtil.initTableMapperJob unnecessarily limits the types of outputKeyClass and outputValueClass
  • [HBASE-12973] - RegionCoprocessorEnvironment should provide HRegionInfo directly
  • [HBASE-12979] - Use setters instead of return values for handing back statistics from HRegion methods
  • [HBASE-12997] - FSHLog should print pipeline on low replication
  • [HBASE-13008] - Better default for hbase.regionserver.regionSplitLimit parameter.
  • New Feature:
  • [HBASE-9531] - a command line (hbase shell) interface to retreive the replication metrics and show replication lag
  • [HBASE-10560] - Per cell TTLs
  • [HBASE-12709] - [mvn] Add unit test excludes command line flag to the build.
  • [HBASE-12731] - Heap occupancy based client pushback
  • Task:
  • [HBASE-12493] - User class should provide a way to re-use existing token
  • [HBASE-12567] - Track remaining issues for HBase-1.0
  • [HBASE-12624] - Remove rename_snapshot.rb from code as there is no equivalent renameSnapshot api in Admin class
  • [HBASE-12625] - Deprecate certain methods in classes annotated with InterfaceAudience.Public in branch-1
  • [HBASE-12689] - Move version on from 0.99.2 to HBASE-1.0.0-SNAPSHOT
  • [HBASE-12724] - Upgrade the interface audience of RegionScanner from Private to LimitedPrivate
  • [HBASE-12726] - Backport to branch-1.0 addendum for "Minimize a number of hbase-client transitive dependencies"
  • [HBASE-12788] - Promote Abortable to LimitedPrivate
  • [HBASE-12834] - Promote ScanType to LimitedPrivate
  • Test:
  • [HBASE-12163] - Move test annotation classes to the same package as in master
  • [HBASE-12645] - HBaseTestingUtility is using ${$HOME} for rootDir
  • [HBASE-12685] - TestSplitLogManager#testLogFilesAreArchived sometimes times out due to race condition
  • [HBASE-12799] - ITAG fails with java.lang.RuntimeException if table does not exist
  • [HBASE-12885] - Unit test for RAW / VERSIONS scanner specifications

New in Apache HBase 0.98.10.1 (Feb 16, 2015)

  • Improvement:
  • [HBASE-12979] - Use setters instead of return values for handing back statistics from HRegion methods

New in Apache HBase 0.99.1 Dev (Oct 29, 2014)

  • Sub-task:
  • [HBASE-11160] - Undo append waiting on region edit/sequence id update
  • [HBASE-11178] - Remove deprecation annotations from mapred namespace
  • [HBASE-11738] - Document improvements to LoadTestTool and PerformanceEvaluation
  • [HBASE-11872] - Avoid usage of KeyValueUtil#ensureKeyValue from Compactor
  • [HBASE-11874] - Support Cell to be passed to StoreFile.Writer rather than KeyValue
  • [HBASE-11917] - Deprecate / Remove HTableUtil
  • [HBASE-11920] - Add CP hooks for ReplicationEndPoint
  • [HBASE-11930] - Document new permission check to roll WAL writer
  • [HBASE-11980] - Change sync to hsync, remove unused InfoServer, and reference our httpserver instead of hadoops
  • [HBASE-11997] - CopyTable with bulkload
  • [HBASE-12023] - HRegion.applyFamilyMapToMemstore creates too many iterator objects.
  • [HBASE-12046] - HTD/HCD setters should be builder-style
  • [HBASE-12047] - Avoid usage of KeyValueUtil#ensureKeyValue in simple cases
  • [HBASE-12050] - Avoid KeyValueUtil#ensureKeyValue from DefaultMemStore
  • [HBASE-12051] - Avoid KeyValueUtil#ensureKeyValue from DefaultMemStore
  • [HBASE-12059] - Create hbase-annotations module
  • [HBASE-12062] - Fix usage of Collections.toArray
  • [HBASE-12068] - [Branch-1] Avoid need to always do KeyValueUtil#ensureKeyValue for Filter transformCell
  • [HBASE-12069] - Finish making HFile.Writer Cell-centric; undo APIs that expect KV serializations.
  • [HBASE-12076] - Move InterfaceAudience imports to hbase-annotations
  • [HBASE-12077] - FilterLists create many ArrayList$Itr objects per row.
  • [HBASE-12079] - Deprecate KeyValueUtil#ensureKeyValue(s)
  • [HBASE-12082] - Find a way to set timestamp on Cells on the server
  • [HBASE-12086] - Fix bugs in HTableMultiplexer
  • [HBASE-12096] - In ZKSplitLog Coordination and AggregateImplementation replace enhaced for statements with basic for statement to avoid unnecessary object allocation
  • [HBASE-12104] - Some optimization and bugfix for HTableMultiplexer
  • [HBASE-12110] - Fix .arcconfig
  • [HBASE-12112] - Avoid KeyValueUtil#ensureKeyValue some more simple cases
  • [HBASE-12115] - Fix NumberFormat Exception in TableInputFormatBase.
  • [HBASE-12189] - Fix new issues found by coverity static analysis
  • [HBASE-12210] - Avoid KeyValue in Prefix Tree
  • Bug:
  • [HBASE-6994] - minor doc update about DEFAULT_ACCEPTABLE_FACTOR
  • [HBASE-8808] - Use Jacoco to generate Unit Test coverage reports
  • [HBASE-8936] - Fixing TestSplitLogWorker while running Jacoco tests.
  • [HBASE-9005] - Improve documentation around KEEP_DELETED_CELLS, time range scans, and delete markers
  • [HBASE-9513] - Why is PE#RandomSeekScanTest way slower in 0.96 than in 0.94?
  • [HBASE-10314] - Add Chaos Monkey that doesn't touch the master
  • [HBASE-10748] - hbase-daemon.sh fails to execute with 'sh' command
  • [HBASE-10757] - Change HTable class doc so it sends people to HCM getting instances
  • [HBASE-11145] - UNEXPECTED!!! when HLog sync: Queue full
  • [HBASE-11266] - Remove shaded references to logger
  • [HBASE-11394] - Replication can have data loss if peer id contains hyphen "-"
  • [HBASE-11401] - Late-binding sequenceid presumes a particular KeyValue mvcc format hampering experiment
  • [HBASE-11405] - Multiple invocations of hbck in parallel disables balancer permanently
  • [HBASE-11804] - Raise default heap size if unspecified
  • [HBASE-11815] - Flush and compaction could just close the tmp writer if there is an exception
  • [HBASE-11890] - HBase REST Client is hard coded to http protocol
  • [HBASE-11906] - Meta data loss with distributed log replay
  • [HBASE-11967] - HMaster in standalone won't go down if it gets 'Unhandled exception'
  • [HBASE-11974] - When a disabled table is scanned, NotServingRegionException is thrown instead of TableNotEnabledException
  • [HBASE-11982] - Bootstraping hbase:meta table creates a WAL file in region dir
  • [HBASE-11988] - AC/VC system table create on postStartMaster fails too often in test
  • [HBASE-11991] - Region states may be out of sync
  • [HBASE-11994] - PutCombiner floods the M/R log with repeated log messages.
  • [HBASE-12007] - StochasticBalancer should avoid putting user regions on master
  • [HBASE-12019] - hbase-daemon.sh overwrite HBASE_ROOT_LOGGER and HBASE_SECURITY_LOGGER variables
  • [HBASE-12024] - Fix javadoc warning
  • [HBASE-12025] - TestHttpServerLifecycle.testStartedServerWithRequestLog hangs frequently
  • [HBASE-12034] - If I kill single RS in branch-1, all regions end up on Master!
  • [HBASE-12038] - Replace internal uses of signatures with byte[] and String tableNames to use the TableName equivalents.
  • [HBASE-12041] - AssertionError in HFilePerformanceEvaluation.UniformRandomReadBenchmark
  • [HBASE-12042] - Replace internal uses of HTable(Configuration, String) with HTable(Configuration, TableName)
  • [HBASE-12043] - REST server should respond with FORBIDDEN(403) code on AccessDeniedException
  • [HBASE-12044] - REST delete operation should not retry disableTable for DoNotRetryIOException
  • [HBASE-12045] - REST proxy users configuration in hbase-site.xml is ignored
  • [HBASE-12052] - BulkLoad Failed due to no write permission on input files
  • [HBASE-12054] - bad state after NamespaceUpgrade with reserved table names
  • [HBASE-12056] - RPC logging too much in DEBUG mode
  • [HBASE-12064] - hbase.master.balancer.stochastic.numRegionLoadsToRemember is not used
  • [HBASE-12065] - Import tool is not restoring multiple DeleteFamily markers of a row
  • [HBASE-12067] - Remove deprecated metrics classes.
  • [HBASE-12078] - Missing Data when scanning using PREFIX_TREE DATA-BLOCK-ENCODING
  • [HBASE-12095] - SecureWALCellCodec should handle the case where encryption is disabled
  • [HBASE-12098] - User granted namespace table create permissions can't create a table
  • [HBASE-12099] - TestScannerModel fails if using jackson 1.9.13
  • [HBASE-12106] - Move test annotations to test artifact
  • [HBASE-12109] - user_permission command for namespace does not return correct result
  • [HBASE-12119] - Master regionserver web UI NOT_FOUND
  • [HBASE-12120] - HBase shell doesn't allow deleting of a cell by user with W-only permissions to it
  • [HBASE-12122] - Try not to assign user regions to master all the time
  • [HBASE-12123] - Failed assertion in BucketCache after 11331
  • [HBASE-12124] - Closed region could stay closed if master stops at bad time
  • [HBASE-12126] - Region server coprocessor endpoint
  • [HBASE-12130] - HBASE-11980 calls hflush and hsync doing near double the syncing work
  • [HBASE-12134] - publish_website.sh script is too optimistic
  • [HBASE-12135] - Website is broken
  • [HBASE-12136] - Race condition between client adding tableCF replication znode and server triggering TableCFsTracker
  • [HBASE-12137] - Alter table add cf doesn't do compression test
  • [HBASE-12139] - StochasticLoadBalancer doesn't work on large lightly loaded clusters
  • [HBASE-12140] - Add ConnectionFactory.createConnection() to create using default HBaseConfiguration.
  • [HBASE-12145] - Fix javadoc and findbugs so new folks aren't freaked when they see them
  • [HBASE-12146] - RegionServerTracker should escape data in log messages
  • [HBASE-12149] - TestRegionPlacement is failing undeterministically
  • [HBASE-12151] - Make dev scripts executable
  • [HBASE-12153] - Fixing TestReplicaWithCluster
  • [HBASE-12156] - TableName cache isn't used for one of valueOf methods.
  • [HBASE-12158] - TestHttpServerLifecycle.testStartedServerWithRequestLog goes zombie on occasion
  • [HBASE-12160] - Make Surefire's argLine configurable in the command line
  • [HBASE-12164] - Check for presence of user Id in SecureBulkLoadEndpoint#secureBulkLoadHFiles() is inaccurate
  • [HBASE-12165] - TestEndToEndSplitTransaction.testFromClientSideWhileSplitting fails
  • [HBASE-12166] - TestDistributedLogSplitting.testMasterStartsUpWithLogReplayWork
  • [HBASE-12167] - NPE in AssignmentManager
  • [HBASE-12170] - TestReplicaWithCluster.testReplicaAndReplication timeouts
  • [HBASE-12181] - Some tests create a table and try to use it before regions get assigned
  • [HBASE-12183] - FuzzyRowFilter doesn't support reverse scans
  • [HBASE-12184] - ServerShutdownHandler throws NPE
  • [HBASE-12191] - Make TestCacheOnWrite faster.
  • [HBASE-12196] - SSH should retry in case failed to assign regions
  • [HBASE-12197] - Move REST
  • [HBASE-12198] - Fix the bug of not updating location cache
  • [HBASE-12199] - Make TestAtomicOperation and TestEncodedSeekers faster
  • [HBASE-12200] - When an RPC server handler thread dies, throw exception
  • [HBASE-12206] - NPE in RSRpcServices
  • [HBASE-12209] - NPE in HRegionServer#getLastSequenceId
  • [HBASE-12218] - Make HBaseCommonTestingUtil#deleteDir try harder
  • Improvement:
  • [HBASE-10153] - improve VerifyReplication to compute BADROWS more accurately
  • [HBASE-10411] - [Book] Add a kerberos 'request is a replay (34)' issue at troubleshooting section
  • [HBASE-11796] - Add client support for atomic checkAndMutate
  • [HBASE-11879] - Change TableInputFormatBase to take interface arguments
  • [HBASE-11907] - Use the joni byte[] regex engine in place of j.u.regex in RegexStringComparator
  • [HBASE-11948] - graceful_stop.sh should use hbase-daemon.sh when executed on the decomissioned node
  • [HBASE-12010] - Use TableName.META_TABLE_NAME instead of indirectly from HTableDescriptor
  • [HBASE-12011] - Add namespace column during display of user tables
  • [HBASE-12013] - Make region_mover.rb support multiple regionservers per host
  • [HBASE-12021] - Hbase shell does not respect the HBASE_OPTS set by the user in console
  • [HBASE-12032] - Script to stop regionservers via RPC
  • [HBASE-12049] - Help for alter command is a bit confusing
  • [HBASE-12090] - Bytes: more Unsafe, more Faster
  • [HBASE-12118] - Explain how to grant permission to a namespace in grant command usage
  • [HBASE-12176] - WALCellCodec Encoders support for non-KeyValue Cells
  • [HBASE-12212] - HBaseTestingUtility#waitUntilAllRegionsAssigned should wait for RegionStates
  • New Feature:
  • [HBASE-11990] - Make setting the start and stop row for a specific prefix easier
  • [HBASE-11995] - Use Connection and ConnectionFactory where possible
  • [HBASE-12127] - Move the core Connection creation functionality into ConnectionFactory
  • [HBASE-12133] - Add FastLongHistogram for metric computation
  • [HBASE-12143] - Minor fix for Table code
  • Task:
  • [HBASE-9004] - Fix Documentation around Minor compaction and ttl
  • [HBASE-11692] - Document how and why to do a manual region split
  • [HBASE-11730] - Document release managers for non-deprecated branches
  • [HBASE-11761] - Add a FAQ item for updating a maven-managed application from 0.94 -> 0.96+
  • [HBASE-11960] - Provide a sample to show how to use Thrift client authentication
  • [HBASE-11978] - Backport 'HBASE-7767 Get rid of ZKTable, and table enable/disable state in ZK' to 1.0
  • [HBASE-11981] - Document how to find the units of measure for a given HBase metric
  • Test:
  • [HBASE-11798] - TestBucketWriterThread may hang due to WriterThread stopping prematurely
  • [HBASE-11838] - Enable PREFIX_TREE in integration tests
  • [HBASE-12008] - Remove IntegrationTestImportTsv#testRunFromOutputCommitter
  • [HBASE-12055] - TestBucketWriterThread hangs flakily based on timing

New in Apache HBase 0.99.0 Dev (Sep 22, 2014)

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

New in Apache HBase 0.98.6.1 (Sep 20, 2014)

  • Sub-task:
  • [HBASE-11963] - Synchronize peer cluster replication connection attempts
  • Bug:
  • [HBASE-11972] - The "doAs user" used in the update to hbase:acl table RPC is incorrect
  • [HBASE-11976] - Server startcode is not checked for bulk region assignment

New in Apache HBase 0.98.6 (Sep 10, 2014)

  • Sub-task:
  • [HBASE-11059] - ZK-less region assignment
  • [HBASE-11546] - Backport ZK-less region assignment to 0.98
  • [HBASE-11610] - Enhance remote meta updates
  • [HBASE-11740] - RegionStates.getRegionAssignments() gets stuck on clone
  • Bug:
  • [HBASE-9746] - RegionServer can't start when replication tries to replicate to an unknown host
  • [HBASE-10205] - ConcurrentModificationException in BucketAllocator
  • [HBASE-11531] - RegionStates for regions under region-in-transition znode are not updated on startup
  • [HBASE-11535] - ReplicationPeer map is not thread safe
  • [HBASE-11536] - Puts of region location to Meta may be out of order which causes inconsistent of region location
  • [HBASE-11550] - Custom value for BUCKET_CACHE_BUCKETS_KEY should be sorted
  • [HBASE-11589] - AccessControlException should be a not retriable exception
  • [HBASE-11617] - incorrect AgeOfLastAppliedOp and AgeOfLastShippedOp in replication Metrics when no new replication OP
  • [HBASE-11627] - RegionSplitter's rollingSplit terminated with "/ by zero", and the _balancedSplit file was not deleted properly
  • [HBASE-11659] - Region state RPC call is not idempotent
  • [HBASE-11678] - BucketCache ramCache fills heap after running a few hours
  • [HBASE-11687] - No need to abort on postOpenDeployTasks exception if region opening is cancelled
  • [HBASE-11705] - callQueueSize should be decremented in a fail-fast scenario
  • [HBASE-11708] - RegionSplitter incorrectly calculates splitcount
  • [HBASE-11716] - LoadTestDataGeneratorWithVisibilityLabels should handle Delete mutations
  • [HBASE-11725] - Backport failover checking change to 1.0
  • [HBASE-11726] - Master should fail-safe if starting with a pre 0.96 layout
  • [HBASE-11727] - Assignment wait time error in case of ServerNotRunningYetException
  • [HBASE-11728] - Data loss while scanning using PREFIX_TREE DATA-BLOCK-ENCODING
  • [HBASE-11733] - Avoid copy-paste in Master/Region CoprocessorHost
  • [HBASE-11745] - FilterAllFilter should return ReturnCode.SKIP
  • [HBASE-11755] - VisibilityController returns the wrong value for preBalanceSwitch()
  • [HBASE-11766] - Backdoor CoprocessorHConnection is no longer being used for local writes
  • [HBASE-11773] - Wrong field used for protobuf construction in RegionStates.
  • [HBASE-11788] - hbase is not deleting the cell when a Put with a KeyValue, KeyValue.Type.Delete is submitted
  • [HBASE-11789] - LoadIncrementalHFiles is not picking up the -D option
  • [HBASE-11794] - StripeStoreFlusher causes NullPointerException
  • [HBASE-11802] - Scan copy constructor doesn't copy reversed member variable
  • [HBASE-11813] - CellScanner#advance may overflow stack
  • [HBASE-11814] - TestAssignmentManager.testCloseFailed() and testOpenCloseRacing() is flaky
  • [HBASE-11816] - Initializing custom Metrics implementation failed in Mapper or Reducer
  • [HBASE-11823] - Cleanup javadoc warnings.
  • [HBASE-11837] - Scanner from RegionCoprocessorEnvironment.getTable(TableName) returns no local data
  • [HBASE-11844] - region_mover.rb load enters an infinite loop if region already present on target server
  • [HBASE-11856] - hbase-common needs a log4j.properties resource for handling unit test logging output
  • [HBASE-11857] - Restore ReaderBase.initAfterCompression() and WALCellCodec.create(Configuration, CompressionContext)
  • [HBASE-11863] - WAL files are not archived and stays in the WAL directory after splitting
  • [HBASE-11868] - Data loss in hlog when the hdfs is unavailable
  • [HBASE-11876] - RegionScanner.nextRaw(...) should not update metrics
  • [HBASE-11878] - TestVisibilityLabelsWithDistributedLogReplay#testAddVisibilityLabelsOnRSRestart sometimes fails due to VisibilityController not yet initialized
  • [HBASE-11886] - The creator of the table should have all permissions on the table
  • [HBASE-11887] - Memory retention in branch-1; millions of instances of LiteralByteString for column qualifier and value
  • Improvement:
  • [HBASE-8298] - In shell, provide alias of 'desc' for 'describe'
  • [HBASE-11326] - Use an InputFormat for ExportSnapshot
  • [HBASE-11438] - [Visibility Controller] Support UTF8 character as Visibility Labels
  • [HBASE-11553] - Abstract visibility label related services into an interface
  • [HBASE-11667] - Comment ClientScanner logic for NSREs.
  • [HBASE-11674] - LoadIncrementalHFiles should be more verbose after unrecoverable error
  • [HBASE-11697] - Improve the 'Too many blocks' message on UI blockcache status page
  • [HBASE-11701] - Start and end of memstore flush log should be on the same level
  • [HBASE-11702] - Better introspection of long running compactions
  • [HBASE-11706] - Set versions for VerifyReplication
  • [HBASE-11731] - Add option to only run a subset of the shell tests
  • [HBASE-11742] - Backport HBASE-7987 and HBASE-11185 to 0.98
  • [HBASE-11748] - Cleanup and add pool usage tracing to Compression
  • [HBASE-11749] - Better error logging when coprocessors loading has failed.
  • [HBASE-11754] - [Shell] Record table property SPLITS_FILE in descriptor
  • [HBASE-11757] - Provide a common base abstract class for both RegionObserver and MasterObserver
  • [HBASE-11774] - Avoid allocating unnecessary tag iterators
  • [HBASE-11790] - Bulk load should use HFileOutputFormat2 in all cases
  • [HBASE-11810] - Access SSL Passwords through Credential Provider API
  • [HBASE-11821] - [ImportTSV] Abstract labels tags creation into pluggable Interface
  • [HBASE-11828] - callers of SeverName.valueOf should use equals and not ==
  • [HBASE-11841] - [0.98] Option for disabling location prefetch
  • [HBASE-11846] - HStore#assertBulkLoadHFileOk should log if a full HFile verification will be performed during a bulkload
  • [HBASE-11865] - Result implements CellScannable; rather it should BE a CellScanner
  • Task:
  • [HBASE-9875] - NamespaceJanitor chore is not used
  • [HBASE-11735] - Document Configurable Bucket Sizes in bucketCache
  • [HBASE-11762] - Record the class name of Codec in WAL header
  • [HBASE-11800] - Coprocessor service methods in HTableInterface should be annotated public
  • Test:
  • [HBASE-11615] - TestZKLessAMOnCluster.testForceAssignWhileClosing failed on Jenkins
  • [HBASE-11713] - Adding hbase shell unit test coverage for visibility labels.

New in Apache HBase 0.98.5 (Aug 13, 2014)

  • Sub-task:
  • [HBASE-11318] - Classes in security subpackages missing @InterfaceAudience annotations.
  • [HBASE-11384] - [Visibility Controller]Check for users covering authorizations for every mutation
  • [HBASE-11559] - Add dumping of DATA block usage to the BlockCache JSON report.
  • [HBASE-11651] - Add conf which disables MetaMigrationConvertingToPB check (for experts only)
  • [HBASE-11722] - Document new shortcut commands introduced by HBASE-11649
  • Bug:
  • [HBASE-11064] - Odd behaviors of TableName for empty namespace
  • [HBASE-11360] - SnapshotFileCache causes too many cache refreshes
  • [HBASE-11388] - The order parameter is wrong when invoking the constructor of the ReplicationPeer In the method "getPeer" of the class ReplicationPeersZKImpl
  • [HBASE-11518] - doc update for how to create non-shared HConnection
  • [HBASE-11534] - Remove broken JAVA_HOME autodetection in hbase-config.sh
  • [HBASE-11537] - Avoid synchronization on instances of ConcurrentMap
  • [HBASE-11541] - Wrong result when scaning meta with startRow
  • [HBASE-11545] - mapred.TableSnapshotInputFormat is missing InterfaceAudience annotation
  • [HBASE-11551] - BucketCache$WriterThread.run() doesn't handle exceptions correctly
  • [HBASE-11554] - Remove Reusable poolmap Rpc client type.
  • [HBASE-11555] - TableSnapshotRegionSplit should be public
  • [HBASE-11558] - Caching set on Scan object gets lost when using TableMapReduceUtil in 0.95+
  • [HBASE-11561] - deprecate ImmutableBytesWritable.getSize and replace with getLength
  • [HBASE-11565] - Stale connection could stay for a while
  • [HBASE-11579] - CopyTable should check endtime value only if != 0
  • [HBASE-11586] - HFile's HDFS op latency sampling code is not used
  • [HBASE-11588] - RegionServerMetricsWrapperRunnable misused the 'period' parameter
  • [HBASE-11594] - Unhandled NoNodeException in distributed log replay mode
  • [HBASE-11609] - LoadIncrementalHFiles fails if the namespace is specified
  • [HBASE-11620] - Record the class name of Writer in WAL header so that only proper Reader can open the WAL file
  • [HBASE-11632] - Region split needs to clear force split flag at the end of SplitRequest run
  • [HBASE-11654] - WAL Splitting dirs are not deleted after replay.
  • [HBASE-11662] - Launching shell with long-form --debug fails
  • [HBASE-11668] - Re-add HBASE_LIBRARY_PATH to bin/hbase
  • Improvement:
  • [HBASE-2217] - VM OPTS for shell only
  • [HBASE-3270] - When we create the .version file, we should create it in a tmp location and then move it into place
  • [HBASE-7910] - Dont use reflection for security
  • [HBASE-11480] - ClientScanner might not close the HConnection created in construction
  • [HBASE-11516] - Track time spent in executing coprocessors in each region.
  • [HBASE-11557] - Counter.class should always be added as dependencyJar
  • [HBASE-11566] - make ExportSnapshot extendable by removing 'final'
  • [HBASE-11583] - Refactoring out the configuration changes for enabling VisibilityLabels in the unit tests.
  • [HBASE-11623] - mutateRowsWithLocks might require updatesLock.readLock with waitTime=0
  • [HBASE-11649] - Add shortcut commands to bin/hbase for test tools
  • [HBASE-11650] - Write hbase.id to a temporary location and move into place
  • Task:
  • [HBASE-11621] - Make MiniDFSCluster run faster

New in Apache HBase 0.98.4 (Jul 23, 2014)

  • Sub-task:
  • [HBASE-11088]: Support Visibility Expression Deletes in Shell
  • [HBASE-11094]: Distributed log replay is incompatible for rolling restarts
  • [HBASE-11307]: Deprecate SlabCache
  • [HBASE-11395]: Add logging for HBase table operations
  • Bug:
  • [HBASE-10330]: TableInputFormat/TableRecordReaderImpl leaks HTable
  • [HBASE-10922]: Log splitting status should always be closed
  • [HBASE-11052]: Sending random data crashes thrift service
  • [HBASE-11118]: non environment variable solution for "IllegalAccessError: class com.google.protobuf.ZeroCopyLiteralByteString cannot access its superclass com.google.protobuf.LiteralByteString"
  • [HBASE-11162]: RegionServer webui uses the default master info port irrespective of the user configuration.
  • [HBASE-11194]: [AccessController] issue with covering permission check in case of concurrent op on same row
  • [HBASE-11294]: IntegrationTestIngestWithACL should automatically set the superuser when running on local minicluster
  • [HBASE-11302]: ReplicationSourceManager#sources is not thread safe
  • [HBASE-11310]: Delete's copy constructor should copy the attributes also
  • [HBASE-11311]: Secure Bulk Load does not execute chmod 777 on the files
  • [HBASE-11312]: Minor refactoring of TestVisibilityLabels class
  • [HBASE-11327]: ExportSnapshot hit stackoverflow error when target snapshotDir doesn't contain uri
  • [HBASE-11335]: Fix the TABLE_DIR param in TableSnapshotInputFormat
  • [HBASE-11341]: ZKProcedureCoordinatorRpcs should respond only to members
  • [HBASE-11342]: The method isChildReadLock in class ZKInterProcessLockBase is wrong
  • [HBASE-11347]: For some errors, the client can retry infinitely
  • [HBASE-11353]: Wrong Write Request Count
  • [HBASE-11363]: Access checks in preCompact and preCompactSelection are out of sync
  • [HBASE-11371]: Typo in Thrift2 docs
  • [HBASE-11374]: RpcRetryingCaller#callWithoutRetries has a timeout of zero
  • [HBASE-11378]: TableMapReduceUtil overwrites user supplied options for multiple tables/scaners job
  • [HBASE-11380]: HRegion lock object is not being released properly, leading to snapshot failure
  • [HBASE-11387]: metrics: wrong totalRequestCount
  • [HBASE-11391]: Thrift table creation will fail with default TTL with sanity checks
  • [HBASE-11396]: Invalid meta entries can lead to unstartable master
  • [HBASE-11397]: When merging expired stripes, we need to create an empty file to preserve metadata.
  • [HBASE-11403]: Fix race conditions around Object#notify
  • [HBASE-11413]: [findbugs] RV: Negating the result of compareTo()/compare()
  • [HBASE-11418]: build target "site" doesn't respect hadoop-two.version property
  • [HBASE-11422]: Specification of scope is missing for certain Hadoop dependencies
  • [HBASE-11423]: Visibility label and per cell ACL feature not working with HTable#mutateRow() and MultiRowMutationEndpoint
  • [HBASE-11424]: Avoid usage of CellUtil#getTagArray(Cell cell) within server
  • [HBASE-11430]: lastFlushSeqId has been updated wrongly during region open
  • [HBASE-11432]: [AccessController] Remove cell first strategy
  • [HBASE-11433]: LruBlockCache does not respect its configurable parameters
  • [HBASE-11435]: Visibility labelled cells fail to getting replicated
  • [HBASE-11439]: StripeCompaction may not obey the OffPeak rule to compaction
  • [HBASE-11442]: ReplicationSourceManager doesn't cleanup the queues for recovered sources
  • [HBASE-11457]: Increment HFile block encoding IVs accounting for ciper's internal use
  • [HBASE-11458]: NPEs if RegionServer cannot initialize
  • [HBASE-11460]: Deadlock in HMaster on masterAndZKLock in HConnectionManager
  • [HBASE-11465]: [VisibilityController] Reserved tags check not happening for Append/Increment
  • [HBASE-11475]: Distributed log replay should also replay compaction events
  • [HBASE-11481]: TableSnapshotInputFormat javadoc wrongly claims HBase "enforces security"
  • [HBASE-11487]: ScanResponse carries non-zero cellblock for CloseScanRequest (ScanRequest with close_scanner = true)
  • [HBASE-11488]: cancelTasks in SubprocedurePool can hang during task error
  • [HBASE-11492]: Hadoop configuration overrides some ipc parameters including tcpNoDelay
  • [HBASE-11493]: Autorestart option is not working because of stale znode "shutdown"
  • [HBASE-11496]: HBASE-9745 broke cygwin CLASSPATH translation
  • [HBASE-11505]: 'snapshot' shell command shadows 'snapshot' shell when 'help' is invoked
  • [HBASE-11506]: IntegrationTestWithCellVisibilityLoadAndVerify allow User to be passed as arg
  • [HBASE-11510]: Visibility serialization format tag gets duplicated in Append/Increment'ed cells
  • Improvement:
  • [HBASE-8495]: Change ownership of the directory to bulk load
  • [HBASE-10289]: Avoid random port usage by default JMX Server. Create Custome JMX server
  • [HBASE-10641]: Configurable Bucket Sizes in bucketCache
  • [HBASE-10871]: Indefinite OPEN/CLOSE wait on busy RegionServers
  • [HBASE-10885]: Support visibility expressions on Deletes
  • [HBASE-11126]: Add RegionObserver pre hooks that operate under row lock
  • [HBASE-11349]: [Thrift] support authentication/impersonation
  • [HBASE-11355]: a couple of callQueue related improvements
  • [HBASE-11362]: Minor improvements to LoadTestTool and PerformanceEvaluation
  • [HBASE-11376]: Presplit table in IntegrationTestBigLinkedList's Generator tool
  • [HBASE-11398]: Print the stripes' state with file size info
  • [HBASE-11407]: hbase-client should not require Jackson for pure HBase queries be executed
  • [HBASE-11434]: [AccessController] Disallow inbound cells with reserved tags
  • [HBASE-11436]: Support start Row and stop Row in HBase Export
  • [HBASE-11437]: Modify cell tag handling code to treat the length as unsigned
  • [HBASE-11444]: Remove use of reflection for User#getShortName
  • [HBASE-11446]: Reduce the frequency of RNG calls in SecureWALCellCodec#EncryptedKvEncoder
  • [HBASE-11450]: Improve file size info in SnapshotInfo tool
  • [HBASE-11452]: add getUserPermission feature in AccessControlClient as client API
  • [HBASE-11473]: Add BaseWALObserver class
  • [HBASE-11474]: [Thrift2] support authentication/impersonation
  • [HBASE-11497]: Expose RpcScheduling implementations as LimitedPrivate interfaces
  • [HBASE-11513]: Combine SingleMultiple Queue RpcExecutor into a single class
  • New Feature:
  • [HBASE-10935]: support snapshot policy where flush memstore can be skipped to prevent production cluster freeze
  • Task:
  • [HBASE-11366]: Backport HBASE-4089 (block cache contents report UI) to 0.98
  • Test:
  • [HBASE-11039]: [VisibilityController] Integration test for labeled data set mixing and filtered excise
  • [HBASE-11057]: Improve TestShell coverage of grant and revoke comamnds

New in Apache HBase 0.98.3 Dev (Jun 9, 2014)

  • Sub-task:
  • [HBASE-10561] - Forward port: HBASE-10212 New rpc metric: number of active handler
  • [HBASE-11161] - Provide example of POJO encoding with protobuf
  • Brainstorming:
  • [HBASE-11209] - Increase the default value for hbase.hregion.memstore.block.multipler from 2 to 4
  • Bug:
  • [HBASE-9445] - Snapshots should create column family dirs for empty regions
  • [HBASE-10251] - Restore API Compat for PerformanceEvaluation.generateValue()
  • [HBASE-10417] - index is not incremented in PutSortReducer#reduce()
  • [HBASE-10692] - The Multi TableMap job don't support the security HBase cluster
  • [HBASE-10831] - IntegrationTestIngestWithACL is not setting up LoadTestTool correctly
  • [HBASE-11096] - stop method of Master and RegionServer coprocessor is not invoked
  • [HBASE-11117] - [AccessController] checkAndPut/Delete hook should check only Read permission
  • [HBASE-11133] - Add an option to skip snapshot verification after Export
  • [HBASE-11143] - Improve replication metrics
  • [HBASE-11149] - Wire encryption is broken
  • [HBASE-11168] - [docs] Remove references to RowLocks in post 0.96 docs.
  • [HBASE-11169] - nit: fix incorrect javadoc in OrderedBytes about BlobVar and BlobCopy
  • [HBASE-11189] - Subprocedure should be marked as complete upon failure
  • [HBASE-11200] - AsyncWriter of FSHLog might throw ArrayIndexOutOfBoundsException
  • [HBASE-11212] - Fix increment index in KeyValueSortReducer
  • [HBASE-11217] - Race between SplitLogManager task creation + TimeoutMonitor
  • [HBASE-11226] - Document and increase the default value for hbase.hstore.flusher.count
  • [HBASE-11234] - FastDiffDeltaEncoder#getFirstKeyInBlock returns wrong result
  • [HBASE-11237] - Bulk load initiated by user other than hbase fails
  • [HBASE-11251] - LoadTestTool should grant READ permission for the users that are given READ access for specific cells
  • [HBASE-11253] - IntegrationTestWithCellVisibilityLoadAndVerify failing since HBASE-10326
  • [HBASE-11255] - Negative request num in region load
  • [HBASE-11267] - Dynamic metrics2 metrics may consume large amount of heap memory
  • [HBASE-11275] - [AccessController] postCreateTable hook fails when another CP creates table on their startup
  • [HBASE-11277] - RPCServer threads can wedge under high load
  • Improvement:
  • [HBASE-6990] - Pretty print TTL
  • [HBASE-9857] - Blockcache prefetch option
  • [HBASE-11048] - Support setting custom priority per client RPC
  • [HBASE-11119] - Update ExportSnapShot to optionally not use a tmp file on external file system
  • [HBASE-11128] - Add -target option to ExportSnapshot to export with a different name
  • [HBASE-11134] - Add a -list-snapshots option to SnapshotInfo
  • [HBASE-11137] - Add mapred.TableSnapshotInputFormat
  • [HBASE-11211] - LoadTestTool option for specifying number of regions per server
  • [HBASE-11219] - HRegionServer#createRegionLoad() should reuse RegionLoad.Builder instance when called in a loop
  • [HBASE-11220] - Add listeners to ServerManager and AssignmentManager
  • [HBASE-11259] - Compression.java different compressions load system classpath differently causing errors
  • Task:
  • [HBASE-11090] - Backport HBASE-11083 ExportSnapshot should provide capability to limit bandwidth consumption
  • [HBASE-11227] - Mention 8- and 16-bit fixed-with encodings in OrderedBytes docstring
  • [HBASE-11272] - Backport HBASE-11218 (Data loss in HBase standalone mode) to 0.98
  • Test:
  • [HBASE-11104] - IntegrationTestImportTsv#testRunFromOutputCommitter misses credential initialization
  • [HBASE-11166] - Categorize tests in hbase-prefix-tree module

New in Apache HBase 0.98.2 Dev (May 9, 2014)

  • Sub-task:
  • [HBASE-10918] - [VisibilityController] System table backed ScanLabelGenerator
  • [HBASE-10963] - Refactor cell ACL tests
  • [HBASE-10972] - OOBE in prefix key encoding
  • [HBASE-11053] - Change DeleteTracker APIs to work with Cell
  • [HBASE-11054] - Create new hook in StoreScanner to help user creating his own delete tracker
  • [HBASE-11077] - [AccessController] Restore compatible early-out access denial
  • Bug:
  • [HBASE-10118] - Major compact keeps deletes with future timestamps
  • [HBASE-10251] - Restore API Compat for PerformanceEvaluation.generateValue()
  • [HBASE-10312] - Flooding the cluster with administrative actions leads to collapse
  • [HBASE-10533] - commands.rb is giving wrong error messages on exceptions
  • [HBASE-10611] - Description for hbase:acl table is wrong on master-status#catalogTables
  • [HBASE-10705] - CompactionRequest#toString() may throw NullPointerException
  • [HBASE-10830] - Integration test MR jobs attempt to load htrace jars from the wrong location
  • [HBASE-10845] - Memstore snapshot size isn't updated in DefaultMemStore#rollback()
  • [HBASE-10848] - Filter SingleColumnValueFilter combined with NullComparator does not work
  • [HBASE-10850] - essential column family optimization is broken
  • [HBASE-10854] - [VisibilityController] Apply MAX_VERSIONS from schema or request when scanning
  • [HBASE-10860] - Insufficient AccessController covering permission check
  • [HBASE-10879] - user_permission shell command on namespace doesn't work
  • [HBASE-10890] - ExportSnapshot needs to add acquired token to job
  • [HBASE-10895] - unassign a region fails due to the hosting region server is in FailedServerList
  • [HBASE-10899] - [AccessController] Apply MAX_VERSIONS from schema or request when scanning
  • [HBASE-10903] - HBASE-10740 regression; cannot pass commands for zk to run
  • [HBASE-10949] - Reversed scan could hang
  • [HBASE-10958] - [dataloss] Bulk loading with seqids can prevent some log entries from being replayed
  • [HBASE-10964] - Delete mutation is not consistent with Put wrt timestamp
  • [HBASE-10966] - RowCounter misinterprets column names that have colons in their qualifier
  • [HBASE-10967] - CatalogTracker.waitForMeta should not wait indefinitely silently
  • [HBASE-10970] - [AccessController] Issues with covering cell permission checks
  • [HBASE-10979] - Fix AnnotationReadingPriorityFunction "scan" handling
  • [HBASE-11011] - Avoid extra getFileStatus() calls on Region startup
  • [HBASE-11030] - HBaseTestingUtility.getMiniHBaseCluster should be able to return null
  • [HBASE-11038] - Filtered scans can bypass metrics collection
  • [HBASE-11049] - HBase WALPlayer needs to add credentials to job to play to table
  • [HBASE-11061] - Port HBASE-10948 Fix hbase table file 'x' mode to 0.96 / 0.98
  • Improvement:
  • [HBASE-10823] - Resolve LATEST_TIMESTAMP to current server time before scanning for ACLs
  • [HBASE-10883] - Restrict the universe of labels and authorizations
  • [HBASE-10884] - [REST] Do not disable block caching when scanning
  • [HBASE-10892] - [Shell] Add support for globs in user_permission
  • [HBASE-10902] - Make Secure Bulk Load work across remote secure clusters
  • [HBASE-10916] - [VisibilityController] Stackable ScanLabelGenerators
  • [HBASE-10950] - Add a configuration point for MaxVersion of Column Family
  • [HBASE-10951] - Use PBKDF2 to generate test encryption keys in the shell
  • [HBASE-10952] - [REST] Let the user turn off block caching if desired
  • [HBASE-11001] - Shell support for granting cell permissions for testing
  • [HBASE-11002] - Shell support for changing cell visibility for testing
  • [HBASE-11008] - Align bulk load, flush, and compact to require Action.CREATE
  • [HBASE-11026] - Provide option to filter out all rows in PerformanceEvaluation tool
  • [HBASE-11044] - [Shell] Show groups for user in 'whoami' output
  • Task:
  • [HBASE-10906] - Change error log for NamingException in TableInputFormatBase to WARN level
  • [HBASE-10912] - setUp / tearDown in TestSCVFWithMiniCluster should be done once per run
  • Test:
  • [HBASE-10988] - Properly wait for server in TestThriftServerCmdLine
  • [HBASE-11010] - TestChangingEncoding is unnecessarily slow
  • [HBASE-11023] - Port HBASE-10488 "'mvn site' is broken due to org.apache.jasper.JspC not found" to 0.98
  • [HBASE-11037] - Race condition in TestZKBasedOpenCloseRegion

New in Apache HBase 0.98.1 Dev (Apr 7, 2014)

  • Sub-task:
  • [HBASE-5175] - Add DoubleColumnInterpreter
  • [HBASE-9966] - Create IntegrationTest for Online Bloom Filter Change
  • [HBASE-10169] - Batch coprocessor
  • [HBASE-10526] - Using Cell instead of KeyValue in HFileOutputFormat
  • [HBASE-10651] - Fix incorrect handling of IE that restores current thread's interrupt status within while/for loops in Replication
  • [HBASE-10697] - Convert TestSimpleTotalOrderPartitioner to junit4 test
  • [HBASE-10717] - TestFSHDFSUtils#testIsSameHdfs fails with IllegalArgumentException running against hadoop 2.3
  • [HBASE-10723] - Convert TestExplicitColumnTracker to junit4 test
  • [HBASE-10741] - Deprecate HTablePool and HTableFactory
  • Bug:
  • [HBASE-6642] - enable_all,disable_all,drop_all can call "list" command with regex directly.
  • [HBASE-8304] - Bulkload fails to remove files if fs.default.name / fs.defaultFS is configured without default port
  • [HBASE-8803] - region_mover.rb should move multiple regions at a time
  • [HBASE-9294] - NPE in /rs-status during RS shutdown
  • [HBASE-9708] - Improve Snapshot Name Error Message
  • [HBASE-9721] - RegionServer should not accept regionOpen RPC intended for another(previous) server
  • [HBASE-9778] - Add hint to ExplicitColumnTracker to avoid seeking
  • [HBASE-9990] - HTable uses the conf for each "newCaller"
  • [HBASE-10080] - Unnecessary call to locateRegion when creating an HTable instance
  • [HBASE-10097] - Remove a region name string creation in HRegion#nextInternal
  • [HBASE-10117] - Avoid synchronization in HRegionScannerImpl.isFilterDone
  • [HBASE-10313] - Duplicate servlet-api jars in hbase 0.96.0
  • [HBASE-10413] - Tablesplit.getLength returns 0
  • [HBASE-10432] - Rpc retries non-recoverable error
  • [HBASE-10436] - restore regionserver lists removed from hbase 0.96+ jmx
  • [HBASE-10451] - Enable back Tag compression on HFiles
  • [HBASE-10452] - Fix potential bugs in exception handlers
  • [HBASE-10453] - PrefixTree encoding for tags can honor HCD#shouldCompressTags()
  • [HBASE-10476] - HBase Master log grows very fast after stopped hadoop (due to connection exception)
  • [HBASE-10481] - API Compatibility JDiff script does not properly handle arguments in reverse order
  • [HBASE-10482] - ReplicationSyncUp doesn't clean up its ZK, needed for tests
  • [HBASE-10485] - PrefixFilter#filterKeyValue() should perform filtering on row key
  • [HBASE-10486] - ProtobufUtil Append & Increment deserialization lost cell level timestamp
  • [HBASE-10493] - InclusiveStopFilter#filterKeyValue() should perform filtering on row key
  • [HBASE-10495] - upgrade script is printing usage two times with help option.
  • [HBASE-10500] - Some tools OOM when BucketCache is enabled
  • [HBASE-10501] - Improve IncreasingToUpperBoundRegionSplitPolicy to avoid too many regions
  • [HBASE-10514] - Forward port HBASE-10466, possible data loss when failed flushes
  • [HBASE-10527] - TestTokenAuthentication fails with the IBM JDK
  • [HBASE-10534] - Rowkey in TsvImporterTextMapper initializing with wrong length
  • [HBASE-10537] - Let the ExportSnapshot mapper fail and retry on error
  • [HBASE-10539] - HRegion.addAndGetGlobalMemstoreSize returns previous size
  • [HBASE-10545] - RS Hangs waiting on region to close on shutdown; has to timeout before can go down
  • [HBASE-10546] - Two scanner objects are open for each hbase map task but only one scanner object is closed
  • [HBASE-10547] - TestFixedLengthWrapper#testReadWrite occasionally fails with the IBM JDK
  • [HBASE-10548] - Correct commons-math dependency version
  • [HBASE-10552] - HFilePerformanceEvaluation.GaussianRandomReadBenchmark fails sometimes.
  • [HBASE-10556] - Possible data loss due to non-handled DroppedSnapshotException for user-triggered flush from client/shell
  • [HBASE-10563] - Set name for FlushHandler thread
  • [HBASE-10564] - HRegionServer.nextLong should be removed since it's not used anywhere, or should be used somewhere it meant to
  • [HBASE-10565] - FavoredNodesPlan accidentally uses an internal Netty type
  • [HBASE-10567] - Add overwrite manifest option to ExportSnapshot
  • [HBASE-10575] - ReplicationSource thread can't be terminated if it runs into the loop to contact peer's zk ensemble and fails continuously
  • [HBASE-10579] - [Documentation]: ExportSnapshot tool package incorrectly documented
  • [HBASE-10580] - IntegrationTestingUtility#restoreCluster leak resource when running in a mini cluster mode
  • [HBASE-10581] - ACL znode are left without PBed during upgrading hbase0.94* to hbase0.96+
  • [HBASE-10582] - 0.94->0.96 Upgrade: ACL can't be repopulated when ACL table contains row for table '-ROOT' or '.META.'
  • [HBASE-10585] - Avoid early creation of Node objects in LRUDictionary.BidirectionalLRUMap
  • [HBASE-10586] - hadoop2-compat IPC metric registred twice
  • [HBASE-10587] - Master metrics clusterRequests is wrong
  • [HBASE-10594] - Speed up TestRestoreSnapshotFromClient
  • [HBASE-10598] - Written data can not be read out because MemStore#timeRangeTracker might be updated concurrently
  • [HBASE-10600] - HTable#batch() should perform validation on empty Put
  • [HBASE-10604] - Fix parseArgs javadoc
  • [HBASE-10608] - Acquire the FS Delegation Token for Secure ExportSnapshot
  • [HBASE-10614] - Master could not be stopped
  • [HBASE-10618] - User should not be allowed to disable/drop visibility labels table
  • [HBASE-10621] - Unable to grant user permission to namespace
  • [HBASE-10622] - Improve log and Exceptions in Export Snapshot
  • [HBASE-10624] - Fix 2 new findbugs warnings introduced by HBASE-10598
  • [HBASE-10627] - A logic mistake in HRegionServer isHealthy
  • [HBASE-10631] - Avoid extra seek on FileLink open
  • [HBASE-10632] - Region lost in limbo after ArrayIndexOutOfBoundsException during assignment
  • [HBASE-10639] - Unload script displays wrong counts (off by one) when unloading regions
  • [HBASE-10644] - TestSecureExportSnapshot#testExportFileSystemState fails on hadoop-1
  • [HBASE-10656] - high-scale-lib's Counter depends on Oracle (Sun) JRE, and also has some bug
  • [HBASE-10660] - MR over snapshots can OOM when alternative blockcache is enabled
  • [HBASE-10662] - RegionScanner is never closed if the region has been moved-out or re-opened when performing scan request
  • [HBASE-10665] - TestCompaction and TestCompactionWithCoprocessor run too long
  • [HBASE-10666] - TestMasterCoprocessorExceptionWithAbort hangs at shutdown
  • [HBASE-10668] - TestExportSnapshot runs too long
  • [HBASE-10669] - [hbck tool] Usage is wrong for hbck tool for -sidelineCorruptHfiles option
  • [HBASE-10675] - IntegrationTestIngestWithACL should allow User to be passed as Parameter
  • [HBASE-10677] - boundaries check in hbck throwing IllegalArgumentException
  • [HBASE-10679] - Both clients get wrong scan results if the first scanner expires and the second scanner is created with the same scannerId on the same region
  • [HBASE-10682] - region_mover.rb throws "can't convert nil into String" for regions moved
  • [HBASE-10685] - [WINDOWS] TestKeyStoreKeyProvider fails on windows
  • [HBASE-10686] - [WINDOWS] TestStripeStoreFileManager fails on windows
  • [HBASE-10694] - TableSkewCostFunction#cost() casts integral division result to double
  • [HBASE-10706] - Disable writeToWal in tests where possible
  • [HBASE-10716] - [Configuration]: hbase.regionserver.region.split.policy should be part of hbase-default.xml
  • [HBASE-10718] - TestHLogSplit fails when it sets a KV size to be negative
  • [HBASE-10726] - Fix java.lang.ArrayIndexOutOfBoundsException in StochasticLoadBalancer$LocalityBasedCandidateGenerator
  • [HBASE-10731] - Fix environment variables typos in scripts
  • [HBASE-10735] - [WINDOWS] Set -XX:MaxPermSize for unit tests
  • [HBASE-10736] - Fix Javadoc warnings introduced in HBASE-10169
  • [HBASE-10737] - HConnectionImplementation should stop RpcClient on close
  • [HBASE-10738] - AssignmentManager should shut down executors on stop
  • [HBASE-10739] - RS web UI NPE if master shuts down sooner
  • [HBASE-10745] - Access ShutdownHook#fsShutdownHooks should be synchronized
  • [HBASE-10749] - CellComparator.compareStatic() compares type wrongly
  • [HBASE-10751] - TestHRegion testWritesWhileScanning occasional fail since HBASE-10514 went in
  • [HBASE-10760] - Wrong methods' names in ClusterLoadState class
  • [HBASE-10762] - clone_snapshot doesn't check for missing namespace
  • [HBASE-10763] - Backport HBASE-10549(When there is a hole, LoadIncrementalHFiles will hang in an infinite loop.) to 0.98
  • [HBASE-10766] - SnapshotCleaner allows to delete referenced files
  • [HBASE-10770] - Don't exit from the Canary daemon mode if no regions are present
  • [HBASE-10793] - AuthFailed as a valid zookeeper state
  • [HBASE-10799] - [WINDOWS] TestImportTSVWithVisibilityLabels.testBulkOutputWithTsvImporterTextMapper fails on windows
  • [HBASE-10802] - CellComparator.compareStaticIgnoreMvccVersion compares type wrongly
  • [HBASE-10804] - Add a validations step to ExportSnapshot
  • [HBASE-10805] - Speed up KeyValueHeap.next() a bit
  • [HBASE-10806] - Two protos missing in hbase-protocol/pom.xml
  • [HBASE-10809] - HBaseAdmin#deleteTable fails when META region happen to move around same time
  • [HBASE-10825] - Add copy-from option to ExportSnapshot
  • [HBASE-10829] - Flush is skipped after log replay if the last recovered edits file is skipped
  • [HBASE-10833] - Region assignment may fail during cluster start up
  • [HBASE-10838] - Insufficient AccessController covering permission check
  • [HBASE-10862] - Update config field names in hbase-default.xml description for hbase.hregion.memstore.block.multiplier
  • [HBASE-10863] - Scan doesn't return rows for user who has authorization by visibility label in secure deployment
  • Improvement:
  • [HBASE-7849] - Provide administrative limits around bulkloads of files into a single region
  • [HBASE-8076] - add better doc for HBaseAdmin#offline API.
  • [HBASE-8604] - improve reporting of incorrect peer address in replication
  • [HBASE-9501] - Provide throttling for replication
  • [HBASE-9999] - Add support for small reverse scan
  • [HBASE-10389] - Add namespace help info in table related shell commands
  • [HBASE-10487] - Avoid allocating new KeyValue and according bytes-copying for appended kvs which don't have existing values
  • [HBASE-10498] - Add new APIs to load balancer interface
  • [HBASE-10511] - Add latency percentiles on PerformanceEvaluation
  • [HBASE-10518] - DirectMemoryUtils.getDirectMemoryUsage spams when none is configured
  • [HBASE-10570] - Allow overrides of Surefire secondPartForkMode and testFailureIgnore
  • [HBASE-10589] - Reduce unnecessary TestRowProcessorEndpoint resource usage
  • [HBASE-10592] - Refactor PerformanceEvaluation tool
  • [HBASE-10597] - IOEngine#read() should return the number of bytes transferred
  • [HBASE-10638] - Improve error message when there is no region server available for move
  • [HBASE-10678] - Make verifyrep tool implement toolrunner
  • [HBASE-10693] - Correct declarations of Atomic* fields from 'volatile' to 'final'
  • [HBASE-10744] - AM#CloseRegion no need to retry on FailedServerException
  • [HBASE-10769] - hbase/bin/hbase-cleanup.sh has wrong usage string
  • [HBASE-10797] - Add support for -h and --help to rolling_restart.sh and fix the usage string output
  • [HBASE-10812] - Backport HBASE-9426(Make custom distributed barrier procedure pluggable) to 0.98.x
  • [HBASE-10887] - tidy ThriftUtilities format
  • New Feature:
  • [HBASE-8751] - Enable peer cluster to choose/change the ColumnFamilies/Tables it really want to replicate from a source cluster
  • Task:
  • [HBASE-10612] - Remove unnecessary dependency on org.eclipse.jdt:core
  • [HBASE-10670] - HBaseFsck#connect() should use new connection
  • [HBASE-10700] - IntegrationTestWithCellVisibilityLoadAndVerify should allow current user to be the admin
  • [HBASE-10740] - Upgrade zookeeper to 3.4.6 release
  • [HBASE-10786] - If snapshot verification fails with 'Regions moved', the message should contain the name of region causing the failure
  • Test:
  • [HBASE-10543] - Two rare test failures with TestLogsCleaner and TestSplitLogWorker
  • [HBASE-10649] - TestMasterMetrics fails occasionally
  • [HBASE-10764] - TestLoadIncrementalHFilesSplitRecovery#testBulkLoadPhaseFailure takes too long
  • [HBASE-10767] - Load balancer may interfere with tests in TestHBaseFsck
  • [HBASE-10782] - Hadoop2 MR tests fail occasionally because of mapreduce.jobhistory.address is no set in job conf
  • [HBASE-10828] - TestRegionObserverInterface#testHBase3583 should wait for all regions to be assigned
  • [HBASE-10852] - TestDistributedLogSplitting#testDisallowWritesInRecovering occasionally fails
  • [HBASE-10868] - TestAtomicOperation should close HRegion instance after each subtest

New in Apache HBase 0.94.18 (Apr 7, 2014)

  • Bug:
  • [HBASE-9708] - Improve Snapshot Name Error Message
  • [HBASE-9778] - Add hint to ExplicitColumnTracker to avoid seeking
  • [HBASE-10514] - Forward port HBASE-10466, possible data loss when failed flushes
  • [HBASE-10549] - When there is a hole, LoadIncrementalHFiles will hang in an infinite loop.
  • [HBASE-10575] - ReplicationSource thread can't be terminated if it runs into the loop to contact peer's zk ensemble and fails continuously
  • [HBASE-10583] - backport HBASE-8402 to 0.94 - ScanMetrics depends on number of rpc calls to the server.
  • [HBASE-10594] - Speed up TestRestoreSnapshotFromClient
  • [HBASE-10598] - Written data can not be read out because MemStore#timeRangeTracker might be updated concurrently
  • [HBASE-10614] - Master could not be stopped
  • [HBASE-10622] - Improve log and Exceptions in Export Snapshot
  • [HBASE-10624] - Fix 2 new findbugs warnings introduced by HBASE-10598
  • [HBASE-10627] - A logic mistake in HRegionServer isHealthy
  • [HBASE-10631] - Avoid extra seek on FileLink open
  • [HBASE-10642] - Add M/R over snapshots to 0.94
  • [HBASE-10669] - [hbck tool] Usage is wrong for hbck tool for -sidelineCorruptHfiles option
  • [HBASE-10682] - region_mover.rb throws "can't convert nil into String" for regions moved
  • [HBASE-10712] - Backport HBASE-8304 to 0.94 and 0.96
  • [HBASE-10716] - [Configuration]: hbase.regionserver.region.split.policy should be part of hbase-default.xml
  • [HBASE-10718] - TestHLogSplit fails when it sets a KV size to be negative
  • [HBASE-10722] - [0.94] HRegion.computeHDFSBlocksDistribution does not account for links and reference files.
  • [HBASE-10731] - Fix environment variables typos in scripts
  • [HBASE-10738] - AssignmentManager should shut down executors on stop
  • [HBASE-10745] - Access ShutdownHook#fsShutdownHooks should be synchronized
  • [HBASE-10751] - TestHRegion testWritesWhileScanning occasional fail since HBASE-10514 went in
  • Improvement:
  • [HBASE-8604] - improve reporting of incorrect peer address in replication
  • Test:
  • [HBASE-9914] - Port fix for HBASE-9836 'Intermittent TestRegionObserverScannerOpenHook#testRegionObserverCompactionTimeStacking failure' to 0.94

New in Apache HBase 0.94.17 (Mar 1, 2014)

  • Bug:
  • [HBASE-7963] - HBase VerifyReplication not working when security enabled
  • [HBASE-10249] - TestReplicationSyncUpTool fails because failover takes too long
  • [HBASE-10274] - MiniZookeeperCluster should close ZKDatabase when shutdown ZooKeeperServers
  • [HBASE-10319] - HLog should roll periodically to allow DN decommission to eventually complete.
  • [HBASE-10320] - Avoid ArrayList.iterator() ExplicitColumnTracker
  • [HBASE-10335] - AuthFailedException in zookeeper may block replication forever
  • [HBASE-10340] - [BACKPORT] HBASE-9892 Add info port to ServerName to support multi instances in a node
  • [HBASE-10363] - [0.94] TestInputSampler and TestInputSamplerTool fail under hadoop 2.0/23 profiles.
  • [HBASE-10371] - Compaction creates empty hfile, then selects this file for compaction and creates empty hfile and over again
  • [HBASE-10383] - Secure Bulk Load for 'completebulkload' fails for version 0.94.15
  • [HBASE-10400] - [hbck] Continue if region dir missing on region merge attempt
  • [HBASE-10401] - [hbck] perform overlap group merges in parallel
  • [HBASE-10448] - ZKUtil create and watch methods don't set watch in some cases
  • [HBASE-10470] - Import generates huge log file while importing large amounts of data
  • [HBASE-10481] - API Compatibility JDiff script does not properly handle arguments in reverse order
  • [HBASE-10482] - ReplicationSyncUp doesn't clean up its ZK, needed for tests
  • [HBASE-10485] - PrefixFilter#filterKeyValue() should perform filtering on row key
  • [HBASE-10489] - TestImportExport fails in 0.94 with Hadoop2
  • [HBASE-10493] - InclusiveStopFilter#filterKeyValue() should perform filtering on row key
  • [HBASE-10501] - Improve IncreasingToUpperBoundRegionSplitPolicy to avoid too many regions
  • [HBASE-10505] - Import.filterKv does not call Filter.filterRowKey
  • [HBASE-10506] - Fail-fast if client connection is lost before the real call be executed in RPC layer
  • [HBASE-10508] - Backport HBASE-10365 'HBaseFsck should clean up connection properly when repair is completed' to 0.94 and 0.96
  • [HBASE-10539] - HRegion.addAndGetGlobalMemstoreSize returns previous size
  • [HBASE-10545] - RS Hangs waiting on region to close on shutdown; has to timeout before can go down
  • [HBASE-10546] - Two scanner objects are open for each hbase map task but only one scanner object is closed
  • [HBASE-10551] - Change local mode back to one RS thread by default
  • [HBASE-10552] - HFilePerformanceEvaluation.GaussianRandomReadBenchmark fails sometimes.
  • [HBASE-10555] - Backport HBASE-8519 to 0.94, Backup master will never come up if primary master dies during initialization
  • [HBASE-10562] - Fix TestMultiTableInputFormat for Hadoop 2 in 0.94
  • Improvement:
  • [HBASE-10212] - New rpc metric: number of active handler
  • [HBASE-10423] - Report back the message of split or rollback failure to the master
  • [HBASE-10457] - Print corrupted file information in SnapshotInfo tool without -file option
  • Task:
  • [HBASE-10473] - Add utility for adorning http Context
  • Test:
  • [HBASE-10480] - TestLogRollPeriod#testWithEdits may fail due to insufficient waiting

New in Apache HBase 0.94.16 (Feb 15, 2014)

  • Sub-task:
  • [HBASE-10257] - [0.94] Master aborts due to assignment race
  • Bug:
  • [HBASE-7226] - HRegion.checkAndMutate uses incorrect comparison result for =
  • [HBASE-8558] - Add timeout limit for HBaseClient dataOutputStream
  • [HBASE-8912] - [0.94] AssignmentManager throws IllegalStateException from PENDING_OPEN to OFFLINE
  • [HBASE-9346] - HBCK should provide an option to check if regions boundaries are the same in META and in stores.
  • [HBASE-10078] - Dynamic Filter - Not using DynamicClassLoader when using FilterList
  • [HBASE-10193] - Cleanup HRegion if one of the store fails to open at region initialization
  • [HBASE-10214] - Regionserver shutdown improperly and leaves the dir in .old not deleted
  • [HBASE-10215] - TableNotFoundException should be thrown after removing stale znode in ETH
  • [HBASE-10225] - Bug in calls to RegionObsever.postScannerFilterRow
  • [HBASE-10250] - [0.94] TestHLog fails occasionally
  • [HBASE-10268] - TestSplitLogWorker occasionally fails
  • [HBASE-10272] - Cluster becomes nonoperational if the node hosting the active Master AND ROOT/META table goes offline
  • [HBASE-10273] - AssignmentManager.regions and AssignmentManager.servers are not always updated in tandem
  • [HBASE-10279] - TestStore.testDeleteExpiredStoreFiles is flaky
  • [HBASE-10281] - TestMultiParallel.testFlushCommitsNoAbort fails frequently in 0.94
  • [HBASE-10284] - Build broken with svn 1.8
  • [HBASE-10286] - Revert HBASE-9593, breaks RS wildcard addresses
  • [HBASE-10306] - Backport HBASE-6820 to 0.94, MiniZookeeperCluster should ensure that ZKDatabase is closed upon shutdown()
  • Improvement:
  • [HBASE-10285] - All for configurable policies in ChaosMonkey
  • Test:
  • [HBASE-10259] - [0.94] Upgrade JUnit to 4.11

New in Apache HBase 0.94.15 (Jan 6, 2014)

  • Bug:
  • [HBASE-7886] - [replication] hlog zk node will not be deleted if client roll hlog
  • [HBASE-9485] - TableOutputCommitter should implement recovery if we don't want jobs to start from 0 on RM restart
  • [HBASE-9995] - Not stopping ReplicationSink when using custom implementation for the ReplicationSink
  • [HBASE-10014] - HRegion#doMiniBatchMutation rollbacks the memstore even if there is nothing to rollback.
  • [HBASE-10015] - Replace intrinsic locking with explicit locks in StoreScanner
  • [HBASE-10026] - HBaseAdmin#createTable could fail if region splits too fast
  • [HBASE-10046] - Unmonitored HBase service could accumulate Status objects and OOM
  • [HBASE-10057] - TestRestoreFlushSnapshotFromClient and TestRestoreSnapshotFromClient fail to finish occasionally
  • [HBASE-10061] - TableMapReduceUtil.findOrCreateJar calls updateMap(null, ) resulting in thrown NPE
  • [HBASE-10064] - AggregateClient.validateParameters can throw NPE
  • [HBASE-10089] - Metrics intern table names cause eventual permgen OOM in 0.94
  • [HBASE-10111] - Verify that a snapshot is not corrupted before restoring it
  • [HBASE-10112] - Hbase rest query params for maxVersions and maxValues are not parsed
  • [HBASE-10117] - Avoid synchronization in HRegionScannerImpl.isFilterDone
  • [HBASE-10120] - start-hbase.sh doesn't respect --config in non-distributed mode
  • [HBASE-10179] - HRegionServer underreports readRequestCounts by 1 under certain conditions
  • [HBASE-10181] - HBaseObjectWritable.readObject catches DoNotRetryIOException and wraps it back in a regular IOException
  • Improvement:
  • [HBASE-9931] - Optional setBatch for CopyTable to copy large rows in batches
  • [HBASE-10001] - Add a coprocessor to help testing the performances without taking into account the i/o
  • [HBASE-10007] - PerformanceEvaluation: Add sampling and latency collection to randomRead test
  • [HBASE-10010] - eliminate the put latency spike on the new log file beginning
  • [HBASE-10048] - Add hlog number metric in regionserver
  • [HBASE-10049] - Small improvments in region_mover.rb
  • [HBASE-10093] - Unregister ReplicationSource metric bean when the replication source thread is terminated
  • New Feature:
  • [HBASE-9047] - Tool to handle finishing replication when the cluster is offline
  • [HBASE-10119] - Allow HBase coprocessors to clean up when they fail
  • Task:
  • [HBASE-9927] - ReplicationLogCleaner#stop() calls HConnectionManager#deleteConnection() unnecessarily
  • [HBASE-9986] - Incorporate HTTPS support for HBase (0.94 port)
  • Test:
  • [HBASE-10058] - Test for HBASE-9915 (avoid reading index blocks)
  • [HBASE-10189] - Intermittent TestReplicationSyncUpTool failure

New in Apache HBase 0.96.1.1 Dev (Dec 20, 2013)

  • Bug:
  • [HBASE-10188] - Deprecate ServerName constructors, but make it public.

New in Apache HBase 0.96.1 Dev (Dec 17, 2013)

  • Sub-task:
  • [HBASE-9165] - Improvements to addDependencyJars
  • [HBASE-9907] - Rig to fake a cluster so can profile client behaviors
  • [HBASE-9917] - Fix it so Default Connection Pool does not spin up max threads even when not needed
  • [HBASE-9966] - Create IntegrationTest for Online Bloom Filter Change
  • [HBASE-10035] - Fix Potential Resource Leak in IPCUtils
  • [HBASE-10036] - Fix Potential Resource Leak in MetaReader
  • [HBASE-10037] - Fix potential Resource Leak in EncodedDataBlock
  • [HBASE-10038] - Fix potential Resource Leak in ZNodeCleaner
  • [HBASE-10039] - Fix potential Resource Leak in RpcServer
  • [HBASE-10094] - Add batching to HLogPerformanceEvaluation
  • Bug:
  • [HBASE-7600] - TestAdmin.testCreateBadTables is failing occasionally
  • [HBASE-8143] - HBase on Hadoop 2 with local short circuit reads (ssr) causes OOM
  • [HBASE-9138] - getHaseIntegrationTestingUtility() is misspelled
  • [HBASE-9322] - Contention on the SoftValueSortedMap with multiple clients
  • [HBASE-9563] - Autorestart doesn't work if zkcleaner fails
  • [HBASE-9593] - Region server left in online servers list forever if it went down after registering to master and before creating ephemeral node
  • [HBASE-9659] - some integration tests can no longer be run using maven
  • [HBASE-9694] - HBaseTestingUtility.createTable infinite loop
  • [HBASE-9710] - Use the region name, not the encoded name, when region is not on current server
  • [HBASE-9718] - Add a test scope dependency on org.slf4j:slf4j-api to hbase-client
  • [HBASE-9727] - HBase Rest Server - DELETE scanner operation is a no-op
  • [HBASE-9737] - Corrupt HFile cause resource leak leading to Region Server OOM
  • [HBASE-9745] - Append HBASE_CLASSPATH to end of Java classpath and use another env var for prefix
  • [HBASE-9747] - PrefixFilter with OR condition gives wrong results
  • [HBASE-9748] - Address outstanding comments raised for HBASE-9696
  • [HBASE-9751] - Excessive readpoints checks in StoreFileScanner
  • [HBASE-9753] - Excessive readpoint checks in MemstoreScanner
  • [HBASE-9755] - Cannot run classes in hbase-server tests jar from command line
  • [HBASE-9759] - Prevent random number collision in IntegrationTestBulkLoad
  • [HBASE-9765] - TestImportTsv.testBulkOutputWithTsvImporterTextMapper() may not be working correctly
  • [HBASE-9768] - Two issues in AsyncProcess
  • [HBASE-9773] - Master aborted when hbck asked the master to assign a region that was already online
  • [HBASE-9776] - Test Load And Verify Fails with TableNotEnabledException
  • [HBASE-9785] - Fix heap size reporting in HRegion
  • [HBASE-9786] - [hbck]: hbck -metaonly incorrectly reports inconsistent regions after HBASE-9698 fix
  • [HBASE-9788] - [WINDOWS] Update rest server class name
  • [HBASE-9791] - MR initializes scanner twice
  • [HBASE-9792] - Region states should update last assignments when a region is opened.
  • [HBASE-9793] - Offline a region before it's closed could cause double assignment
  • [HBASE-9796] - npe in RegionServerCallable
  • [HBASE-9798] - Include dependency hamcrest-core
  • [HBASE-9807] - block encoder unnecessarily copies the key for each reseek
  • [HBASE-9810] - Global memstore size will be calculated wrongly if replaying recovered edits throws exception
  • [HBASE-9813] - Log splitting doesn't prevent RS creating new hlog file
  • [HBASE-9821] - Scanner id could collide
  • [HBASE-9822] - IntegrationTestLazyCfLoading failed occasionally in a secure enviroment
  • [HBASE-9843] - Various fixes in client code
  • [HBASE-9848] - Make regionserver Canary exit with different exit codes
  • [HBASE-9849] - [REST] Forbidden schema delete in read only mode
  • [HBASE-9850] - Issues with UI for table compact/split operation completion. After split/compaction operation using UI, the page is not automatically redirecting back using IE8/Firefox.
  • [HBASE-9859] - Canary Shouldn't go off if the table being read from is disabled
  • [HBASE-9861] - Location does not have to be refreshed on regionTooBusy
  • [HBASE-9862] - manage error per server and per region in the protobuffed client
  • [HBASE-9865] - Reused WALEdits in replication may cause RegionServers to go OOM
  • [HBASE-9868] - Remove some array copy, especially around protobuf
  • [HBASE-9869] - Optimize HConnectionManager#getCachedLocation
  • [HBASE-9870] - HFileDataBlockEncoderImpl#diskToCacheFormat uses wrong format
  • [HBASE-9871] - PB issue : Increment attributes are not getting passed to server
  • [HBASE-9872] - ModifyTable does not modify the attributes of a newly modified/changed ColumnDescriptor
  • [HBASE-9885] - Avoid some Result creation in protobuf conversions
  • [HBASE-9886] - Optimize ServerName#compareTo
  • [HBASE-9890] - MR jobs are not working if started by a delegated user
  • [HBASE-9893] - Incorrect assert condition in OrderedBytes decoding
  • [HBASE-9895] - 0.96 Import utility can't import an exported file from 0.94
  • [HBASE-9900] - Fix unintended byte[].toString in AccessController
  • [HBASE-9901] - Add a toString in HTable, fix a log in AssignmentManager
  • [HBASE-9902] - Region Server is starting normally even if clock skew is more than default 30 seconds(or any configured). -> Regionserver node time is greater than master node time
  • [HBASE-9906] - Restore snapshot fails to restore the meta edits sporadically
  • [HBASE-9908] - [WINDOWS] Fix filesystem / classloader related unit tests
  • [HBASE-9909] - TestHFilePerformance should not be a unit test, but a tool
  • [HBASE-9915] - Performance: isSeeked() in EncodedScannerV2 always returns false
  • [HBASE-9918] - MasterAddressTracker & ZKNamespaceManager ZK listeners are missed after master recovery
  • [HBASE-9926] - Scanner doesn't check if a region is available
  • [HBASE-9947] - Add CM action for online compression algorithm change
  • [HBASE-9952] - Snapshot restore may fail due to NullPointerException
  • [HBASE-9956] - Remove keyLength cache from KeyValue
  • [HBASE-9957] - [WINDOWS] TestNamespaceUpgrade fails on windows
  • [HBASE-9958] - Remove some array copy, change lock scope in locateRegion
  • [HBASE-9959] - Remove some array copy - server side
  • [HBASE-9961] - [WINDOWS] Multicast should bind to local address
  • [HBASE-9970] - HBase BulkLoad, table is creating with the timestamp key also as a column to the table.
  • [HBASE-9973] - [ACL]: Users with 'Admin' ACL permission will lose permissions after upgrade to 0.96.x from 0.94.x or 0.92.x
  • [HBASE-9975] - Not starting ReplicationSink when using custom implementation for the ReplicationSink.
  • [HBASE-9976] - Don't create duplicated TableName objects
  • [HBASE-9978] - The client retries even if the method is not present on the server
  • [HBASE-9982] - TestClientNoCluster should use random numbers
  • [HBASE-9983] - Lower the memory footprint of HRegionLocation
  • [HBASE-9987] - Remove some synchronisation points in HConnectionManager
  • [HBASE-9988] - DOn't use HRI#getEncodedName in the client
  • [HBASE-9989] - Add a test on get in TestClientNoCluster
  • [HBASE-9992] - [hbck] Refactor so that arbitrary -D cmdline options are included
  • [HBASE-9995] - Not stopping ReplicationSink when using custom implementation for the ReplicationSink
  • [HBASE-10011] - Fix some findbugs in the client
  • [HBASE-10012] - Hide ServerName constructor
  • [HBASE-10013] - Enhance the message about ZK when there is an exception
  • [HBASE-10014] - HRegion#doMiniBatchMutation rollbacks the memstore even if there is nothing to rollback.
  • [HBASE-10015] - Replace intrinsic locking with explicit locks in StoreScanner
  • [HBASE-10026] - HBaseAdmin#createTable could fail if region splits too fast
  • [HBASE-10045] - HMaster's clear command could conflict with JMX ports
  • [HBASE-10046] - Unmonitored HBase service could accumulate Status objects and OOM
  • [HBASE-10050] - graceful_stop.sh syntax error
  • [HBASE-10051] - rolling-restart.sh have old value of "zookeeper.znode.unassiged" config causing infinite loop
  • [HBASE-10053] - ProtobufUtil#toMutationNoData interface change causes downstream project build break
  • [HBASE-10061] - TableMapReduceUtil.findOrCreateJar calls updateMap(null, ) resulting in thrown NPE
  • [HBASE-10073] - Revert HBASE-9718 (Add a test scope dependency on org.slf4j:slf4j-api to hbase-client)
  • [HBASE-10079] - Race in TableName cache
  • [HBASE-10085] - Some regions aren't re-assigned after a cluster restarts
  • [HBASE-10090] - Master could hang in assigning meta
  • [HBASE-10097] - Remove a region name string creation in HRegion#nextInternal
  • [HBASE-10101] - testOfflineRegionReAssginedAfterMasterRestart times out sometimes.
  • [HBASE-10103] - TestNodeHealthCheckChore#testRSHealthChore: Stoppable must have been stopped
  • [HBASE-10108] - NullPointerException thrown while use Canary with '-regionserver' option
  • [HBASE-10111] - Verify that a snapshot is not corrupted before restoring it
  • [HBASE-10112] - Hbase rest query params for maxVersions and maxValues are not parsed
  • Improvement:
  • [HBASE-4654] - [replication] Add a check to make sure we don't replicate to ourselves
  • [HBASE-5945] - Reduce buffer copies in IPC server response path
  • [HBASE-8438] - Extend bin/hbase to print a "mapreduce classpath"
  • [HBASE-8465] - Auto-drop rollback snapshot for snapshot restore
  • [HBASE-9221] - Provide interface for getting a User in the client
  • [HBASE-9570] - With AccessDeniedException, HBase shell would be better to just display the error message to be user friendly
  • [HBASE-9716] - LoadTestTool should provide default min and max settings to the data generator
  • [HBASE-9750] - Add retries around Action server stop/start
  • [HBASE-9771] - [WebUI] Humanize store and blockcache statistics on RS
  • [HBASE-9772] - Normalize new client default values
  • [HBASE-9784] - Switch to Hadoop-2.2
  • [HBASE-9831] - 'hbasefsck.numthreads' property isn't passed to hbck via cmdline -D option
  • [HBASE-9855] - evictBlocksByHfileName improvement for bucket cache
  • [HBASE-9867] - Save on array copies with a subclass of LiteralByteString
  • [HBASE-9924] - Avoid potential filename conflict in region_mover.rb
  • [HBASE-9931] - Optional setBatch for CopyTable to copy large rows in batches
  • [HBASE-9963] - Remove the ReentrantReadWriteLock in the MemStore
  • [HBASE-9998] - Fix javadoc warnings induced by commits
  • [HBASE-10001] - Add a coprocessor to help testing the performances without taking into account the i/o
  • [HBASE-10007] - PerformanceEvaluation: Add sampling and latency collection to randomRead test
  • [HBASE-10010] - eliminate the put latency spike on the new log file beginning
  • [HBASE-10020] - Add maven compile-protobuf profile
  • [HBASE-10022] - Fix the HE_EQUALS_USE_HASHCODE warning under hbase-hadoop1-compat
  • [HBASE-10024] - Add an interface to create put with immutable arrays
  • [HBASE-10048] - Add hlog number metric in regionserver
  • [HBASE-10074] - consolidate and improve capacity/sizing documentation
  • New Feature:
  • [HBASE-7525] - A canary monitoring program specifically for regionserver
  • [HBASE-9985] - Add HBase shell command to start/stop tracing
  • [HBASE-10119] - Allow HBase coprocessors to clean up when they fail
  • Task:
  • [HBASE-9757] - Reenable fast region move in SlowDeterministicMonkey
  • [HBASE-9758] - Log missing rows and their regions if ITBLL fails
  • [HBASE-9837] - Forward port HBASE-9080 'Retain assignment should be used when re-enabling table(s)'
  • [HBASE-9954] - Incorporate HTTPS support for HBase
  • Test:
  • [HBASE-8543] - fix coverage org.apache.hadoop.hbase.rest.client
  • [HBASE-8552] - fix coverage org.apache.hadoop.hbase.rest.filter
  • [HBASE-8556] - fix coverage org.apache.hadoop.hbase.metrics.histogram
  • [HBASE-8559] - increase unit-test coverage of package org.apache.hadoop.hbase.coprocessor
  • [HBASE-9692] - TestOrderedBytes doesn't display the arrays correctly
  • [HBASE-9720] - TestSplitTransactionOnCluster#testShutdownFixupWhenDaughterHasSplit occasionally times out
  • [HBASE-9827] - Intermittent TestLogRollingNoCluster#testContendedLogRolling failure
  • [HBASE-9836] - Intermittent TestRegionObserverScannerOpenHook#testRegionObserverCompactionTimeStacking failure
  • [HBASE-9851] - TestHBaseFsck.testQuarantineMissingHFile is flaky
  • [HBASE-9880] - client.TestAsyncProcess.testWithNoClearOnFail broke on 0.96 by HBASE-9867

New in Apache HBase 0.94.14 (Dec 4, 2013)

  • Bug;
  • getHaseIntegrationTestingUtility() is misspelled
  • Change Hadoop 1.2 dependency to 1.2.1
  • RegionTooBusyException should provide region name which was too busy
  • Minimize byte[] copies for 'smart' clients
  • [REST] Forbidden schema delete in read only mode
  • Issues with UI for table compact/split operation completion. After split/compaction operation using UI, the page is not automatically redirecting back using IE8/Firefox.
  • Reused WALEdits in replication may cause RegionServers to go OOM
  • ModifyTable does not modify the attributes of a newly modified/changed ColumnDescriptor
  • MR jobs are not working if started by a delegated user
  • Region Server is starting normally even if clock skew is more than default 30 seconds(or any configured). -> Regionserver node time is greater than master node time
  • Restore snapshot fails to restore the meta edits sporadically
  • Performance: isSeeked() in EncodedScannerV2 always returns false
  • Snapshot restore may fail due to NullPointerException
  • Remove keyLength cache from KeyValue
  • HBase BulkLoad, table is creating with the timestamp key also as a column to the table.
  • Port part of HBASE-9958 to 0.94 - change lock scope in locateRegion
  • Not starting ReplicationSink when using custom implementation for the ReplicationSink.
  • .94: HBASE-9865 breaks coprocessor compatibility with WALEdit.
  • Improvement:
  • [replication] Add a check to make sure we don't replicate to ourselves
  • Extend bin/hbase to print a "mapreduce classpath"
  • Backport -in_memory option support for LoadTestTool from trunk
  • 'hbasefsck.numthreads' property isn't passed to hbck via cmdline -D option
  • remove the inappropriate assert statement in Store.getSplitPoint()
  • Remove the ReentrantReadWriteLock in the MemStore
  • Test:
  • improve unit-test coverage of package org.apache.hadoop.hbase.master.metrics (0.94)
  • fix coverage org.apache.hadoop.hbase.rest.client
  • fix coverage org.apache.hadoop.hbase.rest.filter
  • fix coverage org.apache.hadoop.hbase.metrics.histogram
  • fix coverage org.apache.hadoop.hbase.rest.metrics
  • increase unit-test coverage of package org.apache.hadoop.hbase.coprocessor

New in Apache HBase 0.94.13 (Nov 8, 2013)

  • Sub-task:
  • [HBASE-9711]: Improve HBASE-9428: avoid copying bytes for RegexFilter unless necessary
  • Bug:
  • [HBASE-7600]: TestAdmin.testCreateBadTables is failing occasionally
  • [HBASE-8521]: Cells cannot be overwritten with bulk loaded HFiles
  • [HBASE-9430]: Memstore heapSize calculation: DEEP_OVERHEAD is incorrect
  • [HBASE-9504]: Backport HBASE-1212 to 0.94
  • [HBASE-9548]: Cleanup SnapshotTestingUtils
  • [HBASE-9607]: Data loss after snapshot restore into cloned table
  • [HBASE-9649]: HFilePrettyPrinter should not throw a NPE if FirstKey or LastKey is null.
  • [HBASE-9651]: Backport HBASE-3890 'Scheduled tasks in distributed log splitting not in sync with ZK' to 0.94
  • [HBASE-9727]: HBase Rest Server: DELETE scanner operation is a no-op
  • [HBASE-9731]: updatesBlockedSeconds RegionServer metric should not be a histogram
  • [HBASE-9732]: Static AtomicLong updated in StoreFileScanner every (re)seek
  • [HBASE-9737]: Corrupt HFile cause resource leak leading to Region Server OOM
  • [HBASE-9745]: Append HBASE_CLASSPATH to end of Java classpath and use another env var for prefix
  • [HBASE-9747]: PrefixFilter with OR condition gives wrong results
  • [HBASE-9751]: Excessive readpoints checks in StoreFileScanner
  • [HBASE-9753]: Excessive readpoint checks in MemstoreScanner
  • [HBASE-9783]: o.a.h.h.r.HRegion.mutateRow() with non-existent CF cause NPE
  • [HBASE-9789]: Change logging for Coprocessor exec call to trace
  • [HBASE-9807]: block encoder unnecessarily copies the key for each reseek
  • [HBASE-9842]: Backport HBASE-9593 and HBASE-8667 to 0.94
  • [HBASE-9847]: HConnectionImplementation does not connect to new active master
  • Improvement:
  • [HBASE-9221]: Provide interface for getting a User in the client
  • [HBASE-9488]: Improve performance for small scan
  • [HBASE-9716]: LoadTestTool should provide default min and max settings to the data generator
  • [HBASE-9749]: Custom threadpool for Coprocessor obtained HTables
  • Task:
  • [HBASE-9819]: Backport HBASE-8372 'Provide mutability to CompoundConfiguration' to 0.94
  • Test:
  • [HBASE-8553]: improve unit-test coverage of package org.apache.hadoop.hbase.mapreduce.hadoopbackport
  • [HBASE-9851]: TestHBaseFsck.testQuarantineMissingHFile is flaky
  • [HBASE-9852]: TestRpcMetrics.testCustomMetrics is flaky

New in Apache HBase 0.96.0 Dev (Oct 21, 2013)

  • The "Singularity", because you will have to start and stop your cluster bringing it up on 0.96.0. 0.96.0 requires Hadoop 1.0.0 at least. It will be supported on Hadoop 2.0.0 too. 0.96.0 is all protobufs all the time; all of its serializations to zookeeper, to the filesystem, and over rpc are protobufs. It runs on jdk7.
  • Metrics have been edited and converted to use Hadoop Metrics2. Has HBase Snapshots and PrefixTreeCompression, etc.

New in Apache HBase 0.94.12 (Sep 25, 2013)

  • Sub-task:
  • REST should use listTableNames to list tables
  • Thrift should use listTableNames to list tables
  • Bug:
  • Infinite loop possible in Master/Master replication
  • Fix the retrying logic of memstore flushes to avoid extra sleep
  • possible loss of data in snapshot taken after region split
  • Filter evaluates KVs outside requested columns
  • ServerCallable retries just once if timeout is not integer.max
  • Allow non-admin users to list all table names
  • Fix TestFSHDFSUtils against java7 test re-ordering
  • An Offline SplitParent Region can be assigned breaking split references
  • Multipage book is generated to the wrong location
  • isTableAvailable() may be stuck if an offline parent was never assigned
  • HConnectionManager#getZooKeeperWatcher() should be deprecated in 0.94
  • HBaseClient#setupIOStreams should handle all exceptions
  • Javadoc: Document that HBaseAdmin.flush(...) is synchronous
  • [0.94] ageOfLastShippedOp replication metric doesn't update if the slave regionserver is stalled
  • Default hbase.dynamic.jars.dir to hbase.rootdir/jars
  • Snapshot restore of table which splits after snapshot was taken encounters 'Region is not online'
  • ServerName is created using getLocalSocketAddress, breaks binding to the wildcard address. Revert HBASE-8640
  • SnapshotManager should check for directory existance before throwing a warning.
  • RegionServer not shutting down upon KeeperException in open region
  • [0.94] SecureServer.INSECURE_VERSIONS is declared incorrectly
  • Snapshots with the same name are allowed to proceed concurrently
  • In rpcServer, replicationQueue is initialized with the max queue size instead of the max queue lenght
  • Regex filters are at least an order of magnitude slower since 0.94.3
  • Add back MetaScanner.allTableRegions(Configuration conf,byte[] tablename,boolean offlined) method
  • Backport HBASE-8781 to 0.94
  • [0.94] Shell needs to fall back after HBASE-9182 if talking to older servers
  • Port HBASE-7113 'TestGzipFilter is flaky with jdk1.7' to 0.94
  • HBaseAdmin#isTableEnabled() should throw exception for non-existent table
  • Previous active master can still serves RPC request when it is trying recovering expired zk session
  • Do not enforce secure Hadoop for secure HBase
  • [0.94] Backport HBASE-9309 The links in the backup masters template are bad
  • Short-Circuit Coprocessor HTable access when on the same server
  • Add back WALEdit#get/setScopes method
  • Short-Circuit Coprocessor doesn't correctly lookup table when on server
  • Improvement:
  • Add more useful statistics in the HFile tool
  • Dropping a table always prints a TableInfoMissingException in the master log
  • Task:
  • Introduce/update a script to generate jdiff reports
  • Backport HBASE- 9208 "ReplicationLogCleaner slow at large scale"
  • Test:
  • TestCatalogTracker depends on the execution order

New in Apache HBase 0.94.10 (Jul 25, 2013)

  • Sub-task:
  • [HBASE-8774]: Add BatchSize and Filter to Thrift2
  • [HBASE-8819]: Port HBASE-5428 to Thrift 2
  • [HBASE-8826]: Ensure HBASE-8695 is covered in Thrift 2
  • [HBASE-8832]: Ensure HBASE-4658 is supported by Thrift 2
  • [HBASE-8876]: Addendum to HBASE-8774 Add BatchSize and Filter to Thrift2: Add BatchSize Test
  • [HBASE-8938]: Thrift2 does not close scanner instance
  • Bug:
  • [HBASE-8432]: a table with unbalanced regions will balance indefinitely with the 'org.apache.hadoop.hbase.master.DefaultLoadBalancer'
  • [HBASE-8678]: Wrongly delete cells in some case which can not be deleted
  • [HBASE-8695]: The HBase thrift service ignores XML configuration
  • [HBASE-8776]: tweak retry settings some more (on trunk and 0.94)
  • [HBASE-8782]: Thrift2 can not parse values when using framed transport
  • [HBASE-8794]: DependentColumnFilter.toString() throws NullPointerException
  • [HBASE-8811]: REST service ignores misspelled "check=" parameter, causing unexpected mutations
  • [HBASE-8814]: Possible NPE in split if a region has empty store files.
  • [HBASE-8858]: Backport hbase-6979 "recovered.edits file should not break distributed log splitting"
  • [HBASE-8910]: HMaster.abortNow shouldn't try to become a master again if it was stopped
  • [HBASE-8967]: Duplicate call to snapshotManager.stop() in HRegionServer
  • [HBASE-8968]: Avoid call to zk in HRegionServer#getMaster() to log the master address which already read from the zk.
  • [HBASE-8971]: Bump 0.94 version to 0.94.10-SNAPSHOT
  • [HBASE-8988]: Reuse the thread pool in the shell to not run out of threads
  • Improvement:
  • [HBASE-8599]: HLogs in ZK are not cleaned up when replication lag is minimal
  • [HBASE-8767]: Backport hbase-8001 and hbase-8012, avoid lazy seek
  • [HBASE-8806]: Row locks are acquired repeatedly in HRegion.doMiniBatchMutation for duplicate rows.
  • [HBASE-8809]: Include deletes in the scan (setRaw) method does not respect the time range or the filter
  • [HBASE-8847]: Filter.transform() always applies unconditionally, even when combined in a FilterList
  • [HBASE-8908]: Backport HBASE-8882 and HBASE-8904 (An Integration Test to Test MTTR) to 0.94
  • [HBASE-8921]: [thrift2] Add GenericOptionsParser to Thrift 2 server
  • [HBASE-8945]: Backport to 0.94: HBASE-7952 Remove update() and Improve ExplicitColumnTracker performance.
  • Task:
  • [HBASE-8829]: Improve failed TestMetaScanner assert message so can see where/why failure
  • Test:
  • [HBASE-7770]: minor integration test framework fixes
  • [HBASE-8885]: Fix and reenable TestGet failing#testDynamicFilter
  • [HBASE-8914]: [0.94] TestRegionServerCoprocessorExceptionWithAbort is flaky
  • [HBASE-8928]: Make ChaosMonkey & LoadTest tools extensible, to allow addition of more actions and policies.
  • [HBASE-8934]: Fix bunch of flaky tests
  • [HBASE-8969]: Backport HBASE-8535+HBASE-8586 TestHCM#testDeleteForZKConnLeak enhancement to 0.94

New in Apache HBase 0.94.7 (Apr 26, 2013)

  • Sub-task:
  • [HBASE-7615]: Add metrics for snapshots
  • [HBASE-7801]: Allow a deferred sync option per Mutation.
  • [HBASE-8210]: Backport the LoadTest portions of HBASE-7383
  • [HBASE-8316]: JoinedHeap for non essential column families should reseek instead of seek
  • Bug:
  • [HBASE-7401]: Remove warning message about running 'hbase migrate'
  • [HBASE-7658]: grant with an empty string as permission should throw an exception
  • [HBASE-7817]: Suggested JDWP debug options in hbase-env.sh are wrong
  • [HBASE-7824]: Improve master start up time when there is log splitting work
  • [HBASE-7925]: Back port HBASE-6881 into 0.94
  • [HBASE-7961]: truncate on disabled table should throw TableNotEnabledException.
  • [HBASE-8014]: Backport HBASE-6915 to 0.94.
  • [HBASE-8030]: znode path of online region servers is hard coded in rolling_restart.sh
  • [HBASE-8044]: split/flush/compact/major_compact from hbase shell does not work for region key with \x format
  • [HBASE-8081]: Backport HBASE-7213 (separate hlog for meta tables) to 0.94
  • [HBASE-8092]: bulk assignment in 0.94 doesn't handle ZK errors very well
  • [HBASE-8096]: [replication] NPE while replicating a log that is acquiring a new block from HDFS
  • [HBASE-8118]: TestTablePermission depends on the execution order
  • [HBASE-8125]: HBASE-7435 breaks BuiltInGzipDecompressor on Hadoop < 1.0.x
  • [HBASE-8127]: Region of a disabling or disabled table could be stuck in transition state when RS dies during Master initialization
  • [HBASE-8128]: HTable#put improvements
  • [HBASE-8131]: Create table handler needs to handle failure cases.
  • [HBASE-8142]: Sporadic TestZKProcedureControllers failures on trunk
  • [HBASE-8146]: IntegrationTestBigLinkedList does not work on distributed setup
  • [HBASE-8150]: server should not produce RAITE for already-opening region in 0.94 (because master retry logic handles this case poorly)
  • [HBASE-8151]: Decode memstoreTS in HFileReaderV2 only when necessary
  • [HBASE-8158]: Backport HBASE-8140 "TableMapReduceUtils#addDependencyJar fails when nested inside another MR job"
  • [HBASE-8160]: HMaster#move doesn't check if master initialized
  • [HBASE-8166]: Avoid writing the memstoreTS into HFiles when possible
  • [HBASE-8169]: TestMasterFailover#testMasterFailoverWithMockedRITOnDeadRS may fail due to regions randomly assigned to a RS
  • [HBASE-8170]: HbaseAdmin.createTable cannot handle creating three regions
  • [HBASE-8176]: Backport HBASE-5335 "Dynamic Schema Configurations" to 0.94
  • [HBASE-8179]: JSON formatting for cluster status is sort of broken
  • [HBASE-8188]: Avoid unnecessary row compare in StoreScanner
  • [HBASE-8192]: Logic errror causes infinite loop in HRegion.bulkLoadHFiles(List)
  • [HBASE-8207]: Replication could have data loss when machine name contains hyphen "-"
  • [HBASE-8208]: In some situations data is not replicated to slaves when deferredLogSync is enabled
  • [HBASE-8211]: Support for NN HA for 0.94
  • [HBASE-8212]: Introduce a new separator instead of hyphen('-') for renaming recovered queues' znodes
  • [HBASE-8213]: global authorization may lose efficacy
  • [HBASE-8215]: Removing existing .regioninfo in writeRegioninfoOnFilesystem
  • [HBASE-8222]: User class should implement equals() and hashCode()
  • [HBASE-8225]: [replication] minor code bug when registering ReplicationLogCleaner
  • [HBASE-8226]: HBaseTestingUtility#waitUntilAllRegionsAssigned won't return if it counts "too many" regions
  • [HBASE-8229]: Replication code logs like crazy if a target table cannot be found.
  • [HBASE-8230]: Possible NPE on regionserver abort if replication service has not been started
  • [HBASE-8231]: delete tests in table_tests.rb(TestShell) always running on empty table.
  • [HBASE-8232]: TestAccessController occasionally fails with IndexOutOfBoundsException
  • [HBASE-8246]: Backport HBASE-6318 to 0.94 where SplitLogWorker exits due to ConcurrentModificationException
  • [HBASE-8259]: Snapshot backport in 0.94.6 breaks rolling restarts
  • [HBASE-8266]: Master cannot start if TableNotFoundException is thrown while partial table recovery
  • [HBASE-8270]: Backport HBASE-8097 'MetaServerShutdownHandler may potentially keep bumping up DeadServer.numProcessing' to 0.94
  • [HBASE-8274]: Backport to 94: HBASE-7488 Implement HConnectionManager.locateRegions which is currently returning null
  • [HBASE-8276]: Backport hbase-6738 to 0.94 "Too aggressive task resubmission from the distributed log manager"
  • [HBASE-8285]: HBaseClient never recovers for single HTable.get() calls with no retries when regions move
  • [HBASE-8288]: HBaseFileSystem: Refactoring and correct semantics for createPath methods
  • [HBASE-8303]: Increse the test timeout to 60s when they are less than 20s
  • [HBASE-8313]: Add Bloom filter testing for HFileOutputFormat
  • [HBASE-8326]: mapreduce.TestTableInputFormatScan times out frequently
  • [HBASE-8352]: Rename '.snapshot' directory
  • [HBASE-8427]: Apache Rat is incorrectly excluding test source files
  • Improvement:
  • [HBASE-7410]: [snapshots] add snapshot/clone/restore/export docs to ref guide
  • [HBASE-7599]: Port HBASE-6066 (low hanging read path improvements) to 0.94
  • [HBASE-8148]: Allow IPC to bind on a specific address
  • [HBASE-8152]: Avoid creating empty reference file when splitkey is outside the key range of a store file
  • [HBASE-8174]: Backport HBASE-8161(setting blocking file count on table level doesn't work) to 0.94
  • [HBASE-8198]: Backport HBASE-8063(Filter HFiles based on first/last key) into 0.94
  • [HBASE-8199]: Eliminate exception for ExportSnapshot against the null table snapshot (with no data in)
  • [HBASE-8209]: Improve LoadTest extensibility
  • New Feature:
  • [HBASE-1936]: ClassLoader that loads from hdfs; useful adding filters to classpath without having to restart services
  • [HBASE-7415]: [snapshots] Add task information to snapshot operation
  • Task:
  • [HBASE-7929]: Reapply hbase-7507 "Make memstore flush be able to retry after exception" to 0.94 branch.
  • Test:
  • [HBASE-8106]: Test to check replication log znodes move is done correctly
  • [HBASE-8260]: create generic integration test for trunk and 94 that is more deterministic, can be run for longer and is less aggressive

New in Apache HBase 0.95.0 Dev (Apr 26, 2013)

  • Sub-task:
  • [HBASE-2611]: Handle RS that fails while processing the failure of another one
  • [HBASE-3776]: Add Bloom Filter Support to HFileOutputFormat
  • [HBASE-4285]: partitions file created in user's home directory by importtsv
  • [HBASE-4913]: Per-CF compaction Via the Shell
  • [HBASE-4990]: Document secure HBase setup
  • [HBASE-5151]: Rename "hbase.skip.errors" in HRegion as it is too general-sounding.
  • [HBASE-5342]: Grant/Revoke global permissions
  • [HBASE-5372]: Table mutation operations should check table level rights, not global rights
  • [HBASE-5385]: Delete table/column should delete stored permissions on -acl- table
  • [HBASE-5444]: Add PB-based calls to HMasterRegionInterface
  • [HBASE-5445]: Add PB-based calls to HMasterInterface
  • [HBASE-5446]: Replace serialization for client-facing ZK data with PBs
  • [HBASE-5447]: Support for custom filters with PB-based RPC
  • [HBASE-5448]: Support for dynamic coprocessor endpoints with PB-based RPC
  • [HBASE-5449]: Support for wire-compatible security functionality
  • [HBASE-5451]: Switch RPC call envelope/headers to PBs
  • [HBASE-5453]: Switch on-disk formats (reference files, HFile meta fields, etc) to PB
  • [HBASE-5523]: Fix Delete Timerange logic for KEEP_DELETED_CELLS
  • [HBASE-5619]: Create PB protocols for HRegionInterface
  • [HBASE-5620]: Convert the client protocol of HRegionInterface to PB
  • [HBASE-5621]: Convert admin protocol of HRegionInterface to PB
  • [HBASE-5638]: Backport to 0.90 and 0.92: NPE reading ZK config in HBase
  • [HBASE-5641]: decayingSampleTick1 prevents HBase from shutting down.
  • [HBASE-5642]: [findbugs] Exclude Thrift and Protobuf warnings
  • [HBASE-5644]: [findbugs] Fix null pointer warnings.
  • [HBASE-5645]: [findbugs] Fix correctness warnings
  • [HBASE-5652]: [findbugs] Fix lock release on all paths
  • [HBASE-5653]: [findbugs] fix perf warnings
  • [HBASE-5654]: [findbugs] Address dodgy bugs
  • [HBASE-5659]: TestAtomicOperation.testMultiRowMutationMultiThreads is still failing occasionally
  • [HBASE-5685]: [findbugs] Exclude Protobuf warnings from wire compat patches.
  • [HBASE-5705]: Introduce Protocol Buffer RPC engine
  • [HBASE-5732]: Remove the SecureRPCEngine and merge the security-related logic in the core engine
  • [HBASE-5785]: Adding unit tests for protbuf utils introduced for HRegionInterface pb conversion
  • [HBASE-5793]: TestHBaseFsck#TestNoHdfsTable test hangs after client retries increased
  • [HBASE-5937]: Refactor HLog into an interface.
  • [HBASE-6052]: Convert .META. and -ROOT- content to pb
  • [HBASE-6061]: Fix ACL "Admin" Table inconsistent permission check
  • [HBASE-6066]: some low hanging read path improvement ideas
  • [HBASE-6092]: Authorize flush, split, compact operations in AccessController
  • [HBASE-6157]: Revoke of Global permission is not taking effect without restart.
  • [HBASE-6188]: Remove the concept of table owner
  • [HBASE-6202]: Medium tests fail with jdk1.7
  • [HBASE-6203]: Create hbase-it module
  • [HBASE-6206]: Large tests fail with jdk1.7
  • [HBASE-6209]: ACL Corrections for AccessControllerProtocol apis
  • [HBASE-6224]: add Pre and Post coprocessor hooks for BulkLoad
  • [HBASE-6230]: [brainstorm] "Restore" snapshots for HBase 0.96
  • [HBASE-6238]: Grant on META not taking effect
  • [HBASE-6241]: HBaseCluster interface for interacting with the cluster from system tests
  • [HBASE-6252]: TABLE ADMIN should be allowed to relocate regions
  • [HBASE-6253]: Do not allow user to disable or drop ACL table
  • [HBASE-6282]: The introspection, etc. of objects in the RPC has to be handled for PB objects
  • [HBASE-6292]: Compact can skip the security access control
  • [HBASE-6302]: Document how to run integration tests
  • [HBASE-6353]: Snapshots shell
  • [HBASE-6355]: Allow HBase to compile against JDK7
  • [HBASE-6405]: Create Hadoop compatibilty modules and Metrics2 implementation of replication metrics
  • [HBASE-6408]: Naming and documenting of the hadoop-metrics2.properties file
  • [HBASE-6409]: Create histogram class for metrics 2
  • [HBASE-6410]: Move RegionServer Metrics to metrics2
  • [HBASE-6411]: Move Master Metrics to metrics 2
  • [HBASE-6412]: Move external servers to metrics2 (thrift,thrift2,rest)
  • [HBASE-6414]: Remove the WritableRpcEngine & associated Invocation classes
  • [HBASE-6501]: Integrate with unit-testing tools of hadoop's metrics2 framework
  • [HBASE-6524]: Hooks for hbase tracing
  • [HBASE-6568]: Extract daemon thread factory from HTable into its own class
  • [HBASE-6569]: Extract HStore interface from Store
  • [HBASE-6570]: Fix hfile/log cleaning delegate method naming
  • [HBASE-6571]: Generic multi-thread/cross-process error handling framework
  • [HBASE-6598]: Combine Master Metrics into a single class.
  • [HBASE-6601]: TestImportExport on Hadoop 2 must copy YARN configuration vars
  • [HBASE-6610]: HFileLink: Hardlink alternative for snapshot restore
  • [HBASE-6614]: General cleanup/optimizations of the protobuf RPC engine & associated RPC code
  • [HBASE-6630]: Port HBASE-6590 to trunk : Assign sequence number to bulk loaded files
  • [HBASE-6717]: Remove hadoop-metrics.properties when everything has moved over.
  • [HBASE-6718]: Clean up BaseMetricsSourceImpl
  • [HBASE-6765]: 'Take a snapshot' interface
  • [HBASE-6777]: Snapshot Restore interface
  • [HBASE-6785]: Convert AggregateProtocol to protobuf defined coprocessor service
  • [HBASE-6786]: Convert MultiRowMutationProtocol to protocol buffer service
  • [HBASE-6787]: Convert RowProcessorProtocol to protocol buffer service
  • [HBASE-6788]: Convert AuthenticationProtocol to protocol buffer service
  • [HBASE-6789]: Convert test CoprocessorProtocol implementations to protocol buffer services
  • [HBASE-6802]: Export Snapshot
  • [HBASE-6809]: Deprecate Old metrics classes.
  • [HBASE-6815]: [WINDOWS] Provide hbase scripts in order to start HBASE on Windows in a single user mode
  • [HBASE-6816]: [WINDOWS] line endings on checkout for .sh files
  • [HBASE-6825]: [WINDOWS] Java NIO socket channels does not work with Windows ipv6
  • [HBASE-6863]: Offline snapshots
  • [HBASE-6864]: Online snapshots scaffolding
  • [HBASE-6865]: Snapshot File Cleaners
  • [HBASE-6887]: Convert security-related shell commands to use PB-based AccessControlService
  • [HBASE-6917]: Trunk jdk7 build broke because we moved to zk 3.4.4
  • [HBASE-6921]: String and ConcurrentHashMap sizes change on jdk7; makes TestHeapSize fail; second attempt
  • [HBASE-6925]: Change socket write size from 8K to 64K for HBaseServer
  • [HBASE-6945]: Compilation errors when using non-Sun JDKs to build HBase-0.94
  • [HBASE-6957]: TestRowCounter consistently fails against hadoop-2.0
  • [HBASE-6965]: Generic MXBean Utility class to support all JDK vendors
  • [HBASE-7042]: Master Coprocessor Endpoint
  • [HBASE-7062]: Move HLog stats to metrics 2
  • [HBASE-7076]: Add test that increment/append properly integrate with MVCC
  • [HBASE-7077]: Test for: CheckAndPut should properly read MVCC
  • [HBASE-7078]: Add a test that append is atomic
  • [HBASE-7107]: Snapshot References Utils (FileSystem Visitor)
  • [HBASE-7109]: integration tests on cluster are not getting picked up from distribution
  • [HBASE-7113]: TestGzipFilter is flaky with jdk1.7
  • [HBASE-7121]: Fix TestHFileOutputFormat after moving RS to metrics2
  • [HBASE-7145]: ReusableStreamGzipCodec NPE upon reset with IBM JDK
  • [HBASE-7146]: Fix the wrong reference to getReader survived in theFSHLog javadoc
  • [HBASE-7174]: [snapshots] Refactor snapshot file cleaner cache to use the Snapshot FileVisitor
  • [HBASE-7185]: Create hbase-protocol module
  • [HBASE-7186]: Split Classes for Client/Server module split.
  • [HBASE-7187]: Create empty hbase-client module
  • [HBASE-7188]: Move classes into hbase-client
  • [HBASE-7200]: create integration test for balancing regions and killing region servers
  • [HBASE-7201]: Convert HLog / HFile metadata content to PB
  • [HBASE-7206]: Foreign Exception framework v2 (simplifies and replaces HBASE-6571)
  • [HBASE-7207]: Consolidate snapshot related classes into fewer packages
  • [HBASE-7208]: Transition Offline Snapshots to ForeignExceptions
  • [HBASE-7212]: Globally Barriered Procedure mechanism
  • [HBASE-7222]: Enforce PB ser/de for user code bits in the protocol implementations
  • [HBASE-7224]: Remove references to Writable in the ipc package
  • [HBASE-7225]: on trunk, integration tests are not packaged into distribution
  • [HBASE-7238]: Size based scan metric broken by protobufs
  • [HBASE-7240]: Cleanup old snapshots on start
  • [HBASE-7262]: Move HBaseRPC metrics to metrics2
  • [HBASE-7294]: Check for snapshot file cleaners on start
  • [HBASE-7306]: [shell] Count shell command to return ruby bindable value.
  • [HBASE-7311]: Add snapshot information to hbase master webui
  • [HBASE-7315]: Remove support for client-side RowLocks
  • [HBASE-7321]: Simple Flush Snapshot
  • [HBASE-7331]: Add access control for region open and close, row locking, and stopping the regionserver
  • [HBASE-7336]: HFileBlock.readAtOffset does not work well with multiple threads
  • [HBASE-7339]: Splitting a hfilelink causes region servers to go down.
  • [HBASE-7352]: clone operation from HBaseAdmin can hang forever.
  • [HBASE-7354]: Snapshot Info/Debug Tool
  • [HBASE-7365]: Safer table creation and deletion using .tmp dir
  • [HBASE-7367]: Snapshot coprocessor and ACL security
  • [HBASE-7371]: Blocksize in TestHFileBlock is unintentionally small
  • [HBASE-7387]: StoreScanner need to be able to be subclassed
  • [HBASE-7388]: Snapshot branch 12/18 rebase broke TestSnapshotFromMaster#testSnapshotHFileArchiving
  • [HBASE-7389]: HBASE-7365 Snapshot clone/restore followup
  • [HBASE-7399]: Health check chore for HMaster
  • [HBASE-7400]: ExportSnapshot mapper closes the FileSystem
  • [HBASE-7405]: Enforce PB ser/de for Aggregate protocol and associated ColumnInterpreter user code bits
  • [HBASE-7406]: Example health checker script
  • [HBASE-7414]: Convert some HFile metadata to PB
  • [HBASE-7419]: revisit hfilelink file name format.
  • [HBASE-7420]: TestSnapshotExceptionSnare and TestWALReferenceTask missing test annotation failing TestCheckTestClasses
  • [HBASE-7430]: TestSnapshotDescriptionUtils break compaction/scanner tests (EnvironmentEdge issue)
  • [HBASE-7431]: TestSplitTransactionOnCluster tests still flaky
  • [HBASE-7436]: Improve stack trace info dumped by ForeignExceptionSnare#rethrowException
  • [HBASE-7438]: TestSplitTransactionOnCluster has too many infinite loops
  • [HBASE-7439]: HFileLink should not use the configuration from the Filesystem
  • [HBASE-7452]: Change ForeignException#receive(String, FE) to only be #receive(FE)
  • [HBASE-7453]: HBASE-7423 snapshot followup
  • [HBASE-7454]: Move ErrorHandling protos from hbase-server to hbase-protocol
  • [HBASE-7471]: Enable Cleaners required for Snapshots by default
  • [HBASE-7480]: Explicit message for not allowed snapshot on meta tables
  • [HBASE-7484]: Fix Restore with schema changes
  • [HBASE-7496]: TestZKProcedure fails interrmittently.
  • [HBASE-7516]: Make compaction policy pluggable
  • [HBASE-7518]: Move AuthResult out of AccessController
  • [HBASE-7523]: Snapshot attempt with the name of a previously taken snapshots fails sometimes.
  • [HBASE-7533]: Write an RPC Specification for 0.96
  • [HBASE-7535]: Fix restore reference files
  • [HBASE-7536]: Add test that confirms that multiple concurrent snapshot requests are rejected.
  • [HBASE-7538]: Improve snapshot related error and exception messages
  • [HBASE-7547]: Fix findbugs warnings in snapshot classes
  • [HBASE-7548]: Fix javadoc warnings in snapshot classes
  • [HBASE-7558]: Client not able to access /hbase/unassigned in secure cluster
  • [HBASE-7559]: Add additional Snapshots Unit Test Coverage
  • [HBASE-7563]: move CompoundConfiguration to common and add string map support
  • [HBASE-7565]: [replication] Create an interface for the replication state node
  • [HBASE-7570]: rename user metadata dictionary in shell from CONFIG
  • [HBASE-7571]: add the notion of per-table or per-column family configuration
  • [HBASE-7583]: Fixes and cleanups
  • [HBASE-7603]: refactor storefile management in HStore in order to support things like LevelDB-style compactions
  • [HBASE-7604]: Remove duplicated code from HFileLink
  • [HBASE-7616]: NPE in ZKProcedureCoordinator$1.nodeCreated
  • [HBASE-7622]: Add table descriptor verification after snapshot restore
  • [HBASE-7625]: Remove duplicated logFSTree() from TestRestoreFlushSnapshotFromClient
  • [HBASE-7651]: RegionServerSnapshotManager fails with CancellationException if previous snapshot fails in per region task
  • [HBASE-7666]: More logging improvements in online snapshots code.
  • [HBASE-7674]: add shell documentation for HBASE-7571
  • [HBASE-7687]: TestCatalogTracker.testServerNotRunningIOException fails occasionally
  • [HBASE-7689]: CloneTableHandler notify completion too early
  • [HBASE-7703]: Eventually all online snapshots failing due to Timeout at same regionserver.
  • [HBASE-7720]: improve logging messages of failed snapshot attempts.
  • [HBASE-7733]: Fix flaky TestZKProcedure.testMultiCohortWithMemberTimeoutDuringPrepare
  • [HBASE-7739]: [snapshot 130201 merge] Fix TestSnapshotFromMaster failure
  • [HBASE-7742]: [snapshot 130201 merge] Fix TestHFileArchving#testArchiveOnTableDelete
  • [HBASE-7747]: Import tools should use a combiner to merge Puts
  • [HBASE-7752]: [snapshot 130201 merge] Fix TestStoreFile failure
  • [HBASE-7753]: [snapshot 130201 merge] Fix unresolved merge conflicts
  • [HBASE-7764]: [snapshot 130201 merge] Fix TestSnapshotCloneIndependence failure
  • [HBASE-7778]: [snapshot 130201 merge] Tests with sleep after minicluster shutdown fail due to interrupt flag.
  • [HBASE-7779]: [snapshot 130201 merge] Fix TestMultiParallel
  • [HBASE-7783]: [snapshot 130201 merge] Remove accidentally committed hbase-server/bin files
  • [HBASE-7784]: move the code related to compaction selection specific to default compaction policy, into default compaction policy (from HStore)
  • [HBASE-7788]: [snapshot 130201 merge] Fix flakey TestRestore*SnapshotFromClient#testCloneSnapshot
  • [HBASE-7795]: Race in the Restore Archiving
  • [HBASE-7796]: [snapshot 130201 merge] Fix TestSnapshotFromClient and TestFlushSnapshotFromClient
  • [HBASE-7807]: Introduce HRegionFileSystem and move region fs related code
  • [HBASE-7808]: Refactor Store to use HRegionFileSystem
  • [HBASE-7809]: Refactor Split/Merge to use HRegionFileSystem
  • [HBASE-7858]: cleanup before merging snapshots branch to trunk
  • [HBASE-7864]: Rename HMaster#listSnapshots as getCompletedSnapshots()
  • [HBASE-7889]: Fix javadoc warnings in snapshot classes, part 2
  • [HBASE-7899]: Cell block building tools: Cell codec and means of iterating an objects Cells
  • [HBASE-7900]: Have client Mutations (Put/Delete/etc.) and Result implement CellScanner Interface
  • [HBASE-7905]: Add passing of optional cell blocks over rpc
  • [HBASE-7934]: TableMapReduceUtil doesn't include all dependency jars in new modular build
  • [HBASE-7938]: Add integration test for ImportTsv/LoadIncrementalHFiles workflow
  • [HBASE-7944]: Replication leaks file reader resource & not reset currentNbOperations
  • [HBASE-7975]: ImportTsv documentation update for table creation
  • [HBASE-7996]: Clean up resource leak in MultiTableInputFormat
  • [HBASE-8006]: use FSUtils to get/set hbase.rootdir
  • [HBASE-8011]: Refactor ImportTsv
  • [HBASE-8070]: Rollback support for Increments
  • [HBASE-8094]: TestTableInputFormatScan doesn't assert anything
  • [HBASE-8101]: Cleanup: findbugs and javadoc warning fixes as well as making it illegal passing null row to Put/Delete, etc.
  • [HBASE-8156]: Support for Namenode HA for non-idempotent operations
  • [HBASE-8189]: Shell commands of online region merge
  • Bug:
  • [HBASE-1299]: JSPs don't HTML escape literals (ie: table names, region names, start & end keys)
  • [HBASE-1621]: merge tool should work on online cluster
  • [HBASE-2645]: HLog writer can do 1-2 sync operations after lease has been recovered for split process.
  • [HBASE-3170]: RegionServer confused about empty row keys
  • [HBASE-3443]: ICV optimization to look in memstore first and then store files (HBASE-3082) does not work when deletes are in the mix
  • [HBASE-3444]: Test to prove Bytes.toBytesBinary and Bytes.toStringBinary() is reversible
  • [HBASE-3585]: isLegalFamilyName() can throw ArrayOutOfBoundException
  • [HBASE-3870]: Purge copyrights from src headers
  • [HBASE-3890]: Scheduled tasks in distributed log splitting not in sync with ZK
  • [HBASE-4030]: LoadIncrementalHFiles fails with FileNotFoundException
  • [HBASE-4072]: Deprecate/disable and remove support for reading ZooKeeper zoo.cfg files from the classpath
  • [HBASE-4379]: [hbck] Does not complain about tables with no end region [Z,]
  • [HBASE-4470]: ServerNotRunningException coming out of assignRootAndMeta kills the Master
  • [HBASE-4538]: NPE in AssignmentManager#updateTimers
  • [HBASE-4575]: Inconsistent naming for ZK config parameters
  • [HBASE-4583]: Integrate RWCC with Append and Increment operations
  • [HBASE-4614]: Can't CopyTable between clusters if zoo.cfg is on the classpath
  • [HBASE-4709]: Hadoop metrics2 setup in test MiniDFSClusters spewing JMX errors
  • [HBASE-4802]: Disable show table metrics in bulk loader
  • [HBASE-4803]: Split log worker should terminate properly when waiting for znode
  • [HBASE-4891]: HTable.ClientScanner needs to clone the Scan object
  • [HBASE-4932]: Block cache can be mistakenly instantiated by tools
  • [HBASE-5071]: HFile has a possible cast issue.
  • [HBASE-5076]: HBase shell hangs when creating some 'illegal' tables.
  • [HBASE-5097]: RegionObserver implementation whose preScannerOpen and postScannerOpen Impl return null can stall the system initialization through NPE
  • [HBASE-5206]: Port HBASE-5155 to 0.92, 0.94, and TRUNK
  • [HBASE-5213]: "hbase master stop" does not bring down backup masters
  • [HBASE-5329]: addRowLock() may allocate duplicate lock id, causing the client to be blocked
  • [HBASE-5359]: Alter in the shell can be too quick and return before the table is altered
  • [HBASE-5412]: HBase book, section 2.6.4, has deficient list of client dependencies
  • [HBASE-5441]: HRegionThriftServer may not start because of a race-condition
  • [HBASE-5458]: Thread safety issues with Compression.Algorithm.GZ and CompressionTest
  • [HBASE-5480]: Fixups to MultithreadedTableMapper for Hadoop 0.23.2+
  • [HBASE-5486]: Warn message in HTable: Stringify the byte[]
  • [HBASE-5488]: OfflineMetaRepair doesn't support hadoop 0.20's fs.default.name property
  • [HBASE-5499]: dev-support/test-patch.sh does not have execute perms
  • [HBASE-5529]: MR test failures becuase MALLOC_ARENA_MAX is not set
  • [HBASE-5531]: Maven hadoop profile (version 23) needs to be updated with latest 23 snapshot
  • [HBASE-5546]: Master assigns region in the original region server when opening region failed
  • [HBASE-5553]: Revisit our jmx view
  • [HBASE-5562]: test-patch.sh reports a javadoc warning when there are no new javadoc warnings
  • [HBASE-5563]: HRegionInfo#compareTo should compare regionId as well
  • [HBASE-5564]: Bulkload is discarding duplicate records
  • [HBASE-5567]: test-patch.sh has logic error in findbugs check
  • [HBASE-5568]: Multi concurrent flushcache() for one region could cause data loss
  • [HBASE-5569]: Do not collect deleted KVs when they are still in use by a scanner.
  • [HBASE-5579]: A Delete Version could mask other values
  • [HBASE-5581]: Creating a table with invalid syntax does not give an error message when it fails
  • [HBASE-5586]: [replication] NPE in ReplicationSource when creating a stream to an inexistent cluster
  • [HBASE-5594]: Unable to stop a master that's waiting on -ROOT- during initialization
  • [HBASE-5596]: Few minor bugs from HBASE-5209
  • [HBASE-5598]: Analyse and fix the findbugs reporting by QA and add invalid bugs into findbugs-excludeFilter file
  • [HBASE-5603]: rolling-restart.sh script hangs when attempting to detect expiration of /hbase/master znode.
  • [HBASE-5606]: SplitLogManger async delete node hangs log splitting when ZK connection is lost
  • [HBASE-5611]: Replayed edits from regions that failed to open during recovery aren't removed from the global MemStore size
  • [HBASE-5613]: ThriftServer getTableRegions does not return serverName and port
  • [HBASE-5635]: If getTaskList() returns null, splitlogWorker would go down and it won't serve any requests
  • [HBASE-5636]: TestTableMapReduce doesn't work properly.
  • [HBASE-5656]: LoadIncrementalHFiles createTable should detect and set compression algorithm
  • [HBASE-5663]: MultithreadedTableMapper doesn't work.
  • [HBASE-5669]: AggregationClient fails validation for open stoprow scan
  • [HBASE-5672]: TestLruBlockCache#testBackgroundEvictionThread fails occasionally
  • [HBASE-5680]: Improve compatibility warning about HBase with Hadoop 0.23.x
  • [HBASE-5704]: HBASE-4398 mistakenly rolled back on trunk
  • [HBASE-5717]: Scanner metrics are only reported if you get to the end of a scanner
  • [HBASE-5722]: NPE in ZKUtil#getChildDataAndWatchForNewChildren when ZK not available or NW down.
  • [HBASE-5726]: TestSplitTransactionOnCluster occasionally failing
  • [HBASE-5727]: secure hbase build broke because of 'HBASE-5451 Switch RPC call envelope/headers to PBs'
  • [HBASE-5733]: AssignmentManager#processDeadServersAndRegionsInTransition can fail with NPE.
  • [HBASE-5736]: ThriftServerRunner.HbaseHandler.mutateRow() does not use ByteBuffer correctly
  • [HBASE-5740]: Compaction interruption may be due to balacing
  • [HBASE-5741]: ImportTsv does not check for table existence
  • [HBASE-5743]: Support GIT patches
  • [HBASE-5749]: "HBASE-5335 Dynamic Schema Config" broke build, missing change to HRegion heapsize
  • [HBASE-5755]: Region sever looking for master forever with cached stale data.
  • [HBASE-5757]: TableInputFormat should handle as many errors as possible
  • [HBASE-5759]: HBaseClient throws NullPointerException when EOFException should be used.
  • [HBASE-5772]: Unable to open the few links in http://hbase.apache.org/
  • [HBASE-5773]: HtablePool constructor not reading config files in certain cases
  • [HBASE-5780]: Fix race in HBase regionserver startup vs ZK SASL authentication
  • [HBASE-5781]: Zookeeper session got closed while trying to assign the region to RS using hbck -fix
  • [HBASE-5787]: Table owner can't disable/delete his/her own table
  • [HBASE-5794]: Jenkins builds timing out; undo setting hbase.client.retries.number to 100
  • [HBASE-5795]: HServerLoad$RegionLoad breaks 0.920.94 compatibility
  • [HBASE-5800]: Birds of a feather link on web page doesn't work.
  • [HBASE-5806]: Handle split region related failures on master restart and RS restart
  • [HBASE-5811]: TestLoadAndSwitchEncodeOnDisk fails sometimes
  • [HBASE-5817]: Fix uncategorized tests
  • [HBASE-5819]: SplitLogs function could leak resources
  • [HBASE-5824]: HRegion.incrementColumnValue is not used in trunk
  • [HBASE-5829]: Inconsistency between the "regions" map and the "servers" map in AssignmentManager
  • [HBASE-5830]: Cleanup SequenceFileLogWriter to use syncFs api from SequenceFile#Writer directly in trunk.
  • [HBASE-5837]: hbase shell deleteall to .META. allows insertion of malformed rowkey
  • [HBASE-5840]: Open Region FAILED_OPEN doesn't clear the TaskMonitor Status, keeps showing the old status
  • [HBASE-5848]: Create table with EMPTY_START_ROW passed as splitKey causes the HMaster to abort
  • [HBASE-5857]: RIT map in RS not getting cleared while region opening
  • [HBASE-5861]: Hadoop 23 compilation broken due to tests introduced in HBASE-5604
  • [HBASE-5864]: Error while reading from hfile in 0.94
  • [HBASE-5865]: test-util.sh broken with unittest updates
  • [HBASE-5866]: Canary in tool package but says its in tools.
  • [HBASE-5870]: Hadoop 23 compilation broken because JobTrackerRunner#getJobTracker() method is not found
  • [HBASE-5871]: Usability regression, we don't parse compression algos anymore
  • [HBASE-5873]: TimeOut Monitor thread should be started after atleast one region server registers.
  • [HBASE-5875]: Process RIT and Master restart may remove an online server considering it as a dead server
  • [HBASE-5876]: TestImportExport has been failing against hadoop 0.23 profile
  • [HBASE-5883]: Backup master is going down due to connection refused exception
  • [HBASE-5884]: MapReduce package info has broken link to bulk-loads
  • [HBASE-5885]: Invalid HFile block magic on Local file System
  • [HBASE-5894]: Table deletion failed but HBaseAdmin#deletetable reports it as success
  • [HBASE-5897]: prePut coprocessor hook causing substantial CPU usage
  • [HBASE-5902]: Some scripts are not executable
  • [HBASE-5908]: TestHLogSplit.testTralingGarbageCorruptionFileSkipErrorsPasses should not use append to corrupt the HLog
  • [HBASE-5909]: SlabStats should be a daemon thread
  • [HBASE-5916]: RS restart just before master intialization we make the cluster non operative
  • [HBASE-5918]: Master will block forever at startup if root server dies between assigning root and assigning meta
  • [HBASE-5922]: HalfStoreFileReader seekBefore causes StackOverflowError
  • [HBASE-5925]: Issue with only using the old config param hbase.hstore.compactionThreshold but not the corresponding new one
  • [HBASE-5927]: SSH and DisableTableHandler happening together does not clear the znode of the region and RIT map.
  • [HBASE-5928]: Hbck shouldn't npe when there are no tables.
  • [HBASE-5931]: HBase security profile doesn't compile
  • [HBASE-5962]: interop issue: RowMutations should be added at the end in HbaseObjectWriteable class
  • [HBASE-5963]: ClassCastException: FileSystem$Cache$ClientFinalizer cannot be cast to Thread
  • [HBASE-5964]: HFileSystem: "No FileSystem for scheme: hdfs"
  • [HBASE-5967]: OpenDataException because HBaseProtos.ServerLoad cannot be converted to an open data type
  • [HBASE-5971]: ServerLoad needs redo; can't be pb based
  • [HBASE-5974]: Scanner retry behavior with RPC timeout on next() seems incorrect
  • [HBASE-5975]: Failed suppression of fs shutdown hook with Hadoop 2.0.0
  • [HBASE-5986]: Clients can see holes in the META table when regions are being split
  • [HBASE-5990]: TestHCM failed with Hadoop 2.0.0
  • [HBASE-5992]: Generalization of region move implementation + manage draining servers in bulk assign
  • [HBASE-6002]: Possible chance of resource leak in HlogSplitter
  • [HBASE-6011]: Unable to start master in local mode
  • [HBASE-6012]: Handling RegionOpeningState for bulk assign
  • [HBASE-6018]: hbck fails with a RejectedExecutionException when >50 regions present
  • [HBASE-6021]: NullPointerException when running LoadTestTool without specifying compression type
  • [HBASE-6027]: Update the reference guide to reflect the changes in the security profile
  • [HBASE-6029]: HBCK doesn't recover Balance switch if exception occurs in onlineHbck()
  • [HBASE-6031]: RegionServer does not go down while aborting
  • [HBASE-6046]: Master retry on ZK session expiry causes inconsistent region assignments.
  • [HBASE-6047]: Put.has() can't determine result correctly
  • [HBASE-6049]: Serializing "List" containing null elements will cause NullPointerException in HbaseObjectWritable.writeObject()
  • [HBASE-6050]: HLogSplitter renaming recovered.edits and CJ removing the parent directory race, making the HBCK think cluster is inconsistent.
  • [HBASE-6059]: Replaying recovered edits would make deleted data exist again
  • [HBASE-6060]: Regions's in OPENING state from failed regionservers takes a long time to recover
  • [HBASE-6063]: Replication related failures on trunk after HBASE-5453
  • [HBASE-6065]: Log for flush would append a non-sequential edit in the hlog, leading to possible data loss
  • [HBASE-6069]: TableInputFormatBase#createRecordReader() doesn't initialize TableRecordReader which causes NPE
  • [HBASE-6070]: AM.nodeDeleted and SSH races creating problems for regions under SPLIT
  • [HBASE-6084]: Server Load does not display correctly on the ui
  • [HBASE-6087]: Add hbase-common module
  • [HBASE-6088]: Region splitting not happened for long time due to ZK exception while creating RS_ZK_SPLITTING node
  • [HBASE-6089]: SSH and AM.joinCluster causes Concurrent Modification exception.
  • [HBASE-6107]: Distributed log splitting hangs even there is no task under /hbase/splitlog
  • [HBASE-6108]: Use HRegion.closeHRegion instead of HRegion.close() and HRegion.getLog().close()
  • [HBASE-6112]: Fix hadoop-2.0 build
  • [HBASE-6113]: [eclipse] Fix eclipse import of hbase-assembly null pointer
  • [HBASE-6117]: Revisit default condition added to Switch cases in Trunk
  • [HBASE-6119]: Region server logs its own address at the end of getMaster()
  • [HBASE-6132]: ColumnCountGetFilter & PageFilter not working with FilterList
  • [HBASE-6138]: HadoopQA not running findbugs [Trunk]
  • [HBASE-6146]: Disabling of Catalog tables should not be allowed
  • [HBASE-6149]: Fix TestFSUtils creating dirs under top level dir
  • [HBASE-6150]: Remove empty files causing rat check fail
  • [HBASE-6156]: Improve multiop performances in HTable#flushCommits
  • [HBASE-6164]: Correct the bug in block encoding usage in bulkload
  • [HBASE-6167]: Fix xinclude for docs broke when we multi-moduled
  • [HBASE-6175]: TestFSUtils flaky on hdfs getFileStatus method
  • [HBASE-6178]: LoadTest tool no longer packaged after the modularization
  • [HBASE-6179]: Fix stylesheet broke since multimodule and address feedback gotten in new comment system
  • [HBASE-6195]: Increment data will be lost when the memstore is flushed
  • [HBASE-6196]: MR testcases TestImportExport does not run in Trunk with hadoop2.0
  • [HBASE-6197]: HRegion's append operation may lose data
  • [HBASE-6200]: KeyComparator.compareWithoutRow can be wrong when families have the same prefix
  • [HBASE-6227]: SSH and cluster startup causes data loss
  • [HBASE-6228]: Fixup daughters twice cause daughter region assigned twice
  • [HBASE-6229]: AM.assign() should not set table state to ENABLED directly.
  • [HBASE-6236]: Offline meta repair fails if the HBase base mount point is on a different cluster/volume than its parent in a ViewFS or similar FS
  • [HBASE-6237]: Fix race on ACL table creation in TestTablePermissions
  • [HBASE-6248]: Jetty init may fail if directory name contains "master"
  • [HBASE-6265]: Calling getTimestamp() on a KV in cp.prePut() causes KV not to be flushed
  • [HBASE-6269]: Lazyseek should use the maxSequenseId StoreFile's KeyValue as the latest KeyValue
  • [HBASE-6272]: In-memory region state is inconsistent
  • [HBASE-6281]: Assignment need not be called for disabling table regions during clean cluster start up.
  • [HBASE-6284]: Introduce HRegion#doMiniBatchMutation()
  • [HBASE-6285]: HBase master should log INFO message when it attempts to assign a region
  • [HBASE-6293]: HMaster does not go down while splitting logs even if explicit shutdown is called.
  • [HBASE-6303]: HCD.setCompressionType should use Enum support for storing compression types as strings
  • [HBASE-6306]: TestFSUtils fails against hadoop 2.0
  • [HBASE-6311]: Data error after majorCompaction caused by keeping MVCC for opened scanners
  • [HBASE-6316]: Confirm can upgrade to 0.96 from 0.94 by just stopping and restarting
  • [HBASE-6317]: Master clean start up and Partially enabled tables make region assignment inconsistent.
  • [HBASE-6318]: SplitLogWorker exited due to ConcurrentModificationException
  • [HBASE-6323]: [replication] most of the source metrics are wrong when there's multiple slaves
  • [HBASE-6325]: [replication] Race in ReplicationSourceManager.init can initiate a failover even if the node is alive
  • [HBASE-6326]: Avoid nested retry loops in HConnectionManager
  • [HBASE-6327]: HLog can be null when create table
  • [HBASE-6328]: FSHDFSUtils#recoverFileLease tries to rethrow InterruptedException but actually shallows it
  • [HBASE-6329]: Stopping META regionserver when splitting region could cause daughter region to be assigned twice
  • [HBASE-6336]: Split point should not be equal to start row or end row
  • [HBASE-6337]: [MTTR] Remove renaming tmp log file in SplitLogManager
  • [HBASE-6347]: -ROOT- and .META. are stale in table.jsp if they moved
  • [HBASE-6369]: HTable is not closed in AggregationClient
  • [HBASE-6375]: Master may be using a stale list of region servers for creating assignment plan during startup
  • [HBASE-6376]: bin/hbase command doesn't seem to be working
  • [HBASE-6377]: HBASE-5533 metrics miss all operations submitted via MultiAction
  • [HBASE-6380]: bulkload should update the store.storeSize
  • [HBASE-6381]: AssignmentManager should use the same logic for clean startup and failover
  • [HBASE-6389]: Modify the conditions to ensure that Master waits for sufficient number of Region Servers before starting region assignments
  • [HBASE-6392]: UnknownRegionException blocks hbck from sideline big overlap regions
  • [HBASE-6394]: verifyrep MR job map tasks throws NullPointerException
  • [HBASE-6396]: Fix NoSuchMethodError running against hadoop 2.0
  • [HBASE-6397]: [hbck] print out bulk load commands for sidelined regions if necessary
  • [HBASE-6406]: TestReplicationPeer.testResetZooKeeperSession and TestZooKeeper.testClientSessionExpired fail frequently
  • [HBASE-6420]: Gracefully shutdown logsyncer
  • [HBASE-6423]: Writes should not block reads on blocking updates to memstores
  • [HBASE-6429]: Filter with filterRow() returning true is incompatible with scan with limit
  • [HBASE-6431]: Some FilterList Constructors break addFilter
  • [HBASE-6439]: Ignore .archive directory as a table
  • [HBASE-6440]: SplitLogManager: log the exception when failed to finish split log file
  • [HBASE-6441]: MasterFS doesn't set scheme for internal FileSystem
  • [HBASE-6443]: HLogSplitter should ignore 0 length files
  • [HBASE-6445]: rat check fails if hs_err_pid26514.log dropped in tests
  • [HBASE-6455]: org.apache.hadoop.hbase.PerformanceEvaluation sets the map reduce output path as a child of input path
  • [HBASE-6468]: RowCounter may return incorrect result if column name is specified in command line
  • [HBASE-6479]: HFileReaderV1 caching the same parent META block could cause server abort when splitting
  • [HBASE-6481]: SkipFilter javadoc is incorrect
  • [HBASE-6487]: assign region doesn't check if the region is already assigned
  • [HBASE-6489]: Incorrect TaskTracker logfile name
  • [HBASE-6493]: HashSet of byte array is being used in couple of places
  • [HBASE-6495]: HBaseAdmin shouldn't expect HConnection to be an HConnectionImplementation
  • [HBASE-6499]: StoreScanner's QueryMatcher not reset on store update
  • [HBASE-6510]: Fix HConnection typo in TestFromClientSide
  • [HBASE-6513]: Test errors when building on MacOS
  • [HBASE-6518]: Bytes.toBytesBinary() incorrect trailing backslash escape
  • [HBASE-6528]: Raise the wait time for TestSplitLogWorker#testAcquireTaskAtStartup to reduce the failure probability
  • [HBASE-6564]: HDFS space is not reclaimed when a column family is deleted
  • [HBASE-6582]: Code generation does run under m2eclipse
  • [HBASE-6583]: Enhance Hbase load test tool to automatically create column families if not present
  • [HBASE-6584]: TestAssignmentManager#testDisablingTableRegionsAssignmentDuringCleanClusterStartup fails due to port 60000 already in use.
  • [HBASE-6604]: Bump log4j to 1.2.17
  • [HBASE-6607]: NullPointerException when accessing master web ui while master is initializing
  • [HBASE-6611]: Forcing region state offline cause double assignment
  • [HBASE-6622]: TestUpgradeFromHFileV1ToEncoding#testUpgrade fails in trunk
  • [HBASE-6634]: REST API ScannerModel's protobuf converter code duplicates the setBatch call
  • [HBASE-6637]: Move DaemonThreadFactory into Threads and Threads to hbase-common
  • [HBASE-6655]: thrift.TestThriftServerCmdLine takes too much time: 733.972 sec
  • [HBASE-6657]: Merge Filter and FilterBase
  • [HBASE-6658]: Rename WritableByteArrayComparable to something not mentioning Writable
  • [HBASE-6659]: Port HBASE-6508 Filter out edits at log split time
  • [HBASE-6665]: ROOT region should not be splitted even with META row as explicit split key
  • [HBASE-6667]: TestCatalogJanitor occasionally fails
  • [HBASE-6670]: Untangle mixture of protobuf and Writable reference / usage
  • [HBASE-6677]: Random ZooKeeper port in test can overrun max port
  • [HBASE-6682]: Bad characters in logs for server names: SplitLogManager: task following PBUF
  • [HBASE-6683]: Wrong warning in logs WARN org.apache.hadoop.ipc.HBaseServer: Methods length : 5
  • [HBASE-6684]: .META. timeout value is incorrect
  • [HBASE-6691]: HFile quarantine fails with missing files in hadoop 2.0
  • [HBASE-6692]: [shell] Cannot describe '.META.' or '-ROOT-' tables
  • [HBASE-6693]: Typo in Javadoc of AggregationClient.rowCount()
  • [HBASE-6697]: regionserver.TestPriorityRpc uses a fixed port (60020)
  • [HBASE-6700]: [replication] empty znodes created during queue failovers aren't deleted
  • [HBASE-6707]: TEST org.apache.hadoop.hbase.backup.example.TestZooKeeperTableArchiveClient.testMultipleTables flaps
  • [HBASE-6733]: [0.92 UNIT TESTS] TestReplication.queueFailover occasionally fails [Part-2]
  • [HBASE-6738]: Too aggressive task resubmission from the distributed log manager
  • [HBASE-6746]: Impacts of HBASE-6435 vs. HDFS 2.0 trunk
  • [HBASE-6748]: Endless recursive of deleteNode happened in SplitLogManager#DeleteAsyncCallback
  • [HBASE-6758]: [replication] The replication-executor should make sure the file that it is replicating is closed before declaring success on that file
  • [HBASE-6779]: Fix issues analysis.apache.org raises about StochasticLoadBalancer
  • [HBASE-6780]: On the master status page the Number of Requests per second is incorrect for RegionServer's
  • [HBASE-6781]: .archive directory should be added to HConstants.HBASE_NON_USER_TABLE_DIRS
  • [HBASE-6782]: HBase shell's 'status 'detailed'' should escape the printed keys
  • [HBASE-6794]: FilterBase should provide a default implementation of toByteArray
  • [HBASE-6795]: mvn compile fails on a fresh checkout with empty ~/.m2/repo
  • [HBASE-6801]: TestZooKeeperTableArchiveClient#testArchivingOnSingleTable sometimes fails in trunk
  • [HBASE-6806]: HBASE-4658 breaks backward compatibility / example scripts
  • [HBASE-6811]: TestDrainingServer#testDrainingServerWithAbort sometimes fails in trunk
  • [HBASE-6820]: [WINDOWS] MiniZookeeperCluster should ensure that ZKDatabase is closed upon shutdown()
  • [HBASE-6821]: [WINDOWS] In TestMetaMigrationConvertingToPB .META. table name causes file system problems on windows
  • [HBASE-6822]: [WINDOWS] MiniZookeeperCluster multiple daemons bind to the same port
  • [HBASE-6823]: [WINDOWS] TestSplitTransaction fails due to the Log handle not released by a call to DaughterOpener.start()
  • [HBASE-6824]: Introduce ${hbase.local.dir} and save coprocessor jars there
  • [HBASE-6826]: [WINDOWS] TestFromClientSide failures
  • [HBASE-6827]: [WINDOWS] TestScannerTimeout fails expecting a timeout
  • [HBASE-6828]: [WINDOWS] TestMemoryBoundedLogMessageBuffer failures
  • [HBASE-6829]: [WINDOWS] Tests should ensure that HLog is closed
  • [HBASE-6830]: [WINDOWS] Tests should not rely on local temp dir to be available in DFS
  • [HBASE-6831]: [WINDOWS] HBaseTestingUtility.expireSession() does not expire zookeeper session
  • [HBASE-6832]: [WINDOWS] Tests should use explicit timestamp for Puts, and not rely on implicit RS timing
  • [HBASE-6834]: HBaseClusterManager shell code breaks hadoop-2.0 build
  • [HBASE-6835]: HBaseAdmin.flush claims to be asynchronous but appears to be synchronous
  • [HBASE-6838]: Regionserver may generate identical scanner name
  • [HBASE-6843]: loading lzo error when using coprocessor
  • [HBASE-6846]: BitComparator bug: ArrayIndexOutOfBoundsException
  • [HBASE-6858]: Fix the incorrect BADVERSION checking in the recoverable zookeeper
  • [HBASE-6869]: Update our hadoop-2 to 2.0.1-alpha
  • [HBASE-6879]: Add HBase Code Template
  • [HBASE-6881]: All regionservers are marked offline even there is still one up
  • [HBASE-6894]: Adding metadata to a table in the shell is both arcane and painful
  • [HBASE-6904]: In the HBase shell, an error is thrown that states replication-related znodes already exist
  • [HBASE-6907]: KeyValue equals and compareTo methods should match
  • [HBASE-6915]: String and ConcurrentHashMap sizes change on jdk7; makes TestHeapSize fail
  • [HBASE-6918]: Debugging to help figure what is different up on jenkins when TestHeapSize runs
  • [HBASE-6926]: Cleanup some of the javadoc warnings.
  • [HBASE-6948]: shell create table script cannot handle split key which is expressed in raw bytes
  • [HBASE-6949]: Automatically delete empty directories in CleanerChore
  • [HBASE-6950]: TestAcidGuarantees system test now flushes too aggressively
  • [HBASE-6953]: Incorrect javadoc description of HFileOutputFormat regarding multiple column families
  • [HBASE-6958]: TestAssignmentManager sometimes fails
  • [HBASE-6962]: Upgrade hadoop 1 dependency to hadoop 1.1
  • [HBASE-6963]: unable to run hbck on a secure cluster
  • [HBASE-6971]: .META. directory does not contain .tableinfo serialization
  • [HBASE-6972]: HBase Shell deleteall should not require column to be defined
  • [HBASE-6974]: Metric for blocked updates
  • [HBASE-6978]: Minor typo in ReplicationSource SocketTimeoutException error handling
  • [HBASE-6989]: Avoid unneceseary regular expression matching in ruby code for "list" command
  • [HBASE-6991]: Escape "\" in Bytes.toStringBinary() and its counterpart Bytes.toBytesBinary()
  • [HBASE-6998]: Uncaught exception in main() makes the HMaster/HRegionServer process suspend
  • [HBASE-7000]: Fix the "INT_VACUOUS_COMPARISON" WARNING in KeyValue class
  • [HBASE-7001]: Fix the RCN Correctness Warning in MemStoreFlusher class
  • [HBASE-7002]: Fix all 4 findbug performance warnings
  • [HBASE-7005]: Upgrade Thrift lib to 0.9.0
  • [HBASE-7008]: Set scanner caching to a better default, disable Nagles
  • [HBASE-7018]: Fix and Improve TableDescriptor caching for bulk assignment
  • [HBASE-7019]: Can't pass SplitAlgo in hbase shell
  • [HBASE-7034]: Bad version, failed OPENING to OPENED but master thinks it is open anyways
  • [HBASE-7037]: ReplicationPeer logs at WARN level aborting server instead of at FATAL
  • [HBASE-7046]: Fix resource leak in TestHLogSplit#testOldRecoveredEditsFileSidelined
  • [HBASE-7048]: Regionsplitter requires the hadoop config path to be in hbase classpath
  • [HBASE-7051]: CheckAndPut should properly read MVCC
  • [HBASE-7056]: TestMetaMigrationConvertingToPB failed in HBase-TRUNK-on-Hadoop-2.0.0 two times consecutively
  • [HBASE-7060]: Region load balancing by table does not handle the case where a table's region count is lower than the number of the RS in the cluster
  • [HBASE-7070]: Scanner may retry forever after HBASE-5974
  • [HBASE-7083]: SSH#fixupDaughter should force re-assign missing daughter
  • [HBASE-7086]: Enhance ResourceChecker to log stack trace for potentially hanging threads
  • [HBASE-7091]: support custom GC options in hbase-env.sh
  • [HBASE-7092]: RegionServer OOM related to onlineregions
  • [HBASE-7095]: Cannot set 'lenAsVal' for KeyOnlyFilter from shell
  • [HBASE-7098]: Fix minor typos and formatting issues in HFileArchiver/HFileLink
  • [HBASE-7103]: Need to fail split if SPLIT znode is deleted even before the split is completed.
  • [HBASE-7104]: HBase includes multiple versions of netty: 3.5.0; 3.2.4; 3.2.2
  • [HBASE-7111]: hbase zkcli will not start if the zookeeper server chosen to connect to is unavailable
  • [HBASE-7114]: Increment does not extend Mutation but probably should
  • [HBASE-7130]: NULL qualifier is ignored
  • [HBASE-7134]: incrementColumnValue hooks no longer called from anywhere
  • [HBASE-7143]: TestMetaMigrationRemovingHTD fails when used with Hadoop 0.23/2.x
  • [HBASE-7148]: Some files in hbase-examples module miss license header
  • [HBASE-7153]: print gc option in hbase-env.sh affects hbase zkcli
  • [HBASE-7158]: Allow CopyTable to identify the source cluster (for replication scenarios)
  • [HBASE-7159]: Upgrade zookeeper dependency to 3.4.5
  • [HBASE-7165]: TestSplitLogManager.testUnassignedTimeout is flaky
  • [HBASE-7166]: TestSplitTransactionOnCluster tests are flaky
  • [HBASE-7168]: [dev] in the script called 'hbase', we don't check for errors when generating the classpath with mvn
  • [HBASE-7172]: TestSplitLogManager.testVanishingTaskZNode() fails when run individually and is flaky
  • [HBASE-7177]: TestZooKeeperScanPolicyObserver.testScanPolicyObserver is flaky
  • [HBASE-7180]: RegionScannerImpl.next() is inefficient.
  • [HBASE-7202]: Family Store Files are not archived on admin.deleteColumn()
  • [HBASE-7203]: Move example CoProcessor into hbase-examples
  • [HBASE-7205]: Coprocessor classloader is replicated for all regions in the HRegionServer
  • [HBASE-7214]: CleanerChore logs too much, so much so it obscures all else that is going on
  • [HBASE-7215]: Put, Delete, Increment, Result, all all HBase M/R classes still implement/use Writable
  • [HBASE-7229]: ClassFinder finds compat tests during mvn package, causing TestCheckTestClasses to fail
  • [HBASE-7232]: Remove HbaseMapWritable
  • [HBASE-7233]: Serializing KeyValues over RPC
  • [HBASE-7234]: Remove long-deprecated HServerAddress and HServerInfo Writables
  • [HBASE-7235]: TestMasterObserver is flaky
  • [HBASE-7243]: Test for creating a large number of regions
  • [HBASE-7256]: Quick Start Guide shows stable version as 0.95, in the stable folder it is 0.94
  • [HBASE-7258]: Hbase needs to create baseZNode recursively
  • [HBASE-7260]: Upgrade hadoop 1 dependency to hadoop 1.1.1
  • [HBASE-7264]: Improve Snappy installation documentation
  • [HBASE-7265]: Make Maven skip module test properties consistent
  • [HBASE-7268]: correct local region location cache information can be overwritten (or deleted) w/stale information from an old server
  • [HBASE-7269]: Testing in place does not work if not building with default profile
  • [HBASE-7270]: Remove MultiPut and MultiPutResponse to satisfy rat-check
  • [HBASE-7271]: Have a single executor for all zkWorkers in the assignment manager
  • [HBASE-7277]: Thrift default JMX port should be 10103 instead of 8093
  • [HBASE-7279]: Avoid copying the rowkey in RegionScanner, StoreScanner, and ScanQueryMatcher
  • [HBASE-7285]: HMaster fails to start with secure Hadoop
  • [HBASE-7290]: Online snapshots
  • [HBASE-7293]: [replication] Remove dead sinks from ReplicationSource.currentPeers and pick new ones
  • [HBASE-7299]: TestMultiParallel fails intermittently in trunk builds
  • [HBASE-7300]: HbckTestingUtil needs to keep a static executor to lower the number of threads used
  • [HBASE-7301]: Force ipv4 for unit tests
  • [HBASE-7305]: ZK based Read/Write locks for table operations
  • [HBASE-7307]: MetaReader.tableExists should not return false if the specified table regions has been split
  • [HBASE-7309]: Metrics refresh-task is not canceled when regions are closed, leaking HRegion objects
  • [HBASE-7314]: Can't start REST/Thrift server if HBASE_JMX_OPTS not set
  • [HBASE-7338]: Fix flaky condition for org.apache.hadoop.hbase.TestRegionRebalancing.testRebalanceOnRegionServerNumberChange
  • [HBASE-7342]: Split operation without split key incorrectly finds the middle key in off-by-one error
  • [HBASE-7355]: NPE in ClusterStatus PB conversion
  • [HBASE-7357]: HBaseClient and HBaseServer should use hbase.security.authentication when negotiating authentication
  • [HBASE-7363]: Fix javadocs warnings for hbase-server packages from master to end
  • [HBASE-7373]: table should not be required in AccessControlService
  • [HBASE-7376]: Acquiring readLock does not apply timeout in HRegion#flushcache
  • [HBASE-7382]: Port ZK.multi support from HBASE-6775 to 0.96
  • [HBASE-7383]: create integration test for HBASE-5416 (improving scan performance for certain filters)
  • [HBASE-7390]: Add extra test cases for assignement on the region server and fix the related issues
  • [HBASE-7407]: TestMasterFailover under tests some cases and over tests some others
  • [HBASE-7412]: Fix how HTableDescriptor handles default max file size and flush size
  • [HBASE-7421]: TestHFileCleaner->testHFileCleaning has an aggressive timeout
  • [HBASE-7423]: HFileArchiver should not use the configuration from the Filesystem
  • [HBASE-7435]: BuiltInGzipDecompressor is only released during full GC
  • [HBASE-7440]: ReplicationZookeeper#addPeer is racy
  • [HBASE-7443]: More findbugs fixes
  • [HBASE-7446]: Make the reference guide utf8 rather than 8859
  • [HBASE-7450]: orphan RPC connection in HBaseClient leaves "null" out member, causing NPE in HCM
  • [HBASE-7455]: Increase timeouts in TestReplication and TestSplitLogWorker
  • [HBASE-7457]: Fix javadoc warnings in hadoopqa tool, it complains about unsafe accesses
  • [HBASE-7458]: TestReplicationWithCompression fails intermittently in both PreCommit and trunk builds
  • [HBASE-7459]: NPE in HMaster TestlocalHBaseCluster
  • [HBASE-7464]: [REST] Sending HTML for errors is unhelpful
  • [HBASE-7467]: CleanerChore checkAndDeleteDirectory not deleting empty directories
  • [HBASE-7475]: TestUpgradeFromHFileV1ToEncoding.testUpgrade hangs
  • [HBASE-7476]: HBase shell count command doesn't escape binary output
  • [HBASE-7481]: Allow IOExceptions to be thrown from Filter methods
  • [HBASE-7482]: Port HBASE-7442 HBase remote CopyTable not working when security enabled to trunk
  • [HBASE-7485]: TestSplitLogManager is still flaky on windows
  • [HBASE-7486]: master pid file is not getting removed if we stop hbase from stop-hbase.sh
  • [HBASE-7488]: Implement HConnectionManager.locateRegions which is currently returning null
  • [HBASE-7489]: TestHCM is racy
  • [HBASE-7490]: dev-support script to generate protobuf code.
  • [HBASE-7495]: parallel seek in StoreScanner
  • [HBASE-7498]: Make REST server thread pool size configurable
  • [HBASE-7499]: TestScannerTimeout timeout is too aggressive.
  • [HBASE-7501]: Introduce MetaEditor method that both adds and deletes rows in .META. table
  • [HBASE-7502]: TestScannerTimeout fails on snapshot branch
  • [HBASE-7504]: -ROOT- may be offline forever after FullGC of RS
  • [HBASE-7505]: Server will hang when stopping cluster, caused by waiting for split threads
  • [HBASE-7506]: Judgment of carrying ROOT/META will become wrong when expiring server
  • [HBASE-7507]: Make memstore flush be able to retry after exception
  • [HBASE-7508]: Fix simple findbugs
  • [HBASE-7513]: HDFSBlocksDistribution shouldn't send NPEs when something goes wrong
  • [HBASE-7515]: Store.loadStoreFiles should close opened files if there's an exception
  • [HBASE-7520]: org.apache.hadoop.hbase.IntegrationTestRebalanceAndKillServersTargeted fails when I cd hbase-it and mvn verify
  • [HBASE-7524]: hbase-policy.xml is improperly set thus all rules in it can be by-passed
  • [HBASE-7527]: integration tests STILL won't run from tar.gz in trunk
  • [HBASE-7528]: Unhelpful NPE in hbck -repair when adopting orphans if no tableinfo is found.
  • [HBASE-7529]: Wrong ExecutorType for EventType.M_RS_OPEN_ROOT in trunk
  • [HBASE-7530]: [replication] Work around HDFS-4380 else we get NPEs
  • [HBASE-7531]: [replication] NPE in SequenceFileLogReader because ReplicationSource doesn't nullify the reader
  • [HBASE-7534]: [replication] TestReplication.queueFailover can fail because HBaseTestingUtility.createMultiRegions is dangerous
  • [HBASE-7537]: .regioninfo not created by createHRegion()
  • [HBASE-7542]: SCVF: Avoid sending two unwanted boolean values from client to RS
  • [HBASE-7545]: [replication] Break out TestReplication into manageable classes
  • [HBASE-7546]: Obtain a table read lock on region split operations
  • [HBASE-7549]: Make HTableInterface#batch() javadoc proper
  • [HBASE-7551]: nodeChildrenChange event may happen after the transition to RS_ZK_REGION_SPLITTING in SplitTransaction causing the SPLIT event to be missed in the master side.
  • [HBASE-7552]: Pass bufferSize param to FileLinkInputStream constructor within FileLink.open method, and remove unnecessary import packages.
  • [HBASE-7553]: TestServerCustomProtocol depends on the test methods execution order
  • [HBASE-7554]: TestZooKeeper depends on the execution order
  • [HBASE-7555]: Kill the remaining processus from other builds in the precommit env
  • [HBASE-7556]: TestAdmin depends on the execution order
  • [HBASE-7560]: TestCompactionState failures
  • [HBASE-7574]: Migrate to JUnit 4.11
  • [HBASE-7575]: FSUtils#getTableStoreFilePathMap should all ignore non-table folders
  • [HBASE-7578]: TestCatalogTracker hangs occasionally
  • [HBASE-7580]: TestAccessController fails in trunk
  • [HBASE-7581]: TestAccessController depends on the execution order
  • [HBASE-7584]: Improve TestAccessController.testAppend
  • [HBASE-7586]: Fix two findbugs warnings to get our count down to the tolerated number again
  • [HBASE-7587]: Fix two findbugs warning in RowResource
  • [HBASE-7588]: Fix two findbugs warning in MemStoreFlusher
  • [HBASE-7590]: Add a costless notifications mechanism from master to regionservers & clients
  • [HBASE-7594]: TestLocalHBaseCluster failing on ubuntu2
  • [HBASE-7595]: Fix one findbug warning in ReplicationSourceManager
  • [HBASE-7596]: Redundant FSTableDescriptor update
  • [HBASE-7597]: TestHBaseFsck#testRegionShouldNotBeDeployed seems to be flaky
  • [HBASE-7601]: Fix 8 remaining EQ findbug warnings from hbase-server.
  • [HBASE-7602]: TestFromClientSide.testPoolBehavior is incorrect
  • [HBASE-7619]: tiny correction in the book
  • [HBASE-7627]: UnsupportedOperationException in CatalogJanitor thread.
  • [HBASE-7635]: Proxy created by HFileSystem#createReorderingProxy() should implement Closeable
  • [HBASE-7637]: hbase-hadoop1-compat conflicts with -Dhadoop.profile=2.0
  • [HBASE-7642]: HBase shell cannot set Compression
  • [HBASE-7643]: HFileArchiver.resolveAndArchive() race condition may lead to snapshot data loss
  • [HBASE-7646]: Make forkedProcessTimeoutInSeconds configurable
  • [HBASE-7648]: TestAcidGuarantees.testMixedAtomicity hangs sometimes
  • [HBASE-7654]: Add List getCoprocessors() to HTableDescriptor
  • [HBASE-7656]: Clean up line endings to be LF in the repo
  • [HBASE-7657]: Make ModifyTableHandler synchronous
  • [HBASE-7665]: retry time sequence usage in HConnectionManager has off-by-one error
  • [HBASE-7669]: ROOT region wouldn't be handled by PRI-IPC-Handler
  • [HBASE-7670]: Synchronized operation in CatalogTracker would block handling ZK Event for long time
  • [HBASE-7671]: Flushing memstore again after last failure could cause data loss
  • [HBASE-7673]: Incorrect error logging when a replication peer is removed
  • [HBASE-7676]: [WINDOWS] TestClassFinder fails on Windows
  • [HBASE-7681]: Address some recent random test failures
  • [HBASE-7682]: Replace HRegion custom File-System debug, with FSUtils.logFileSystemState()
  • [HBASE-7688]: Master coprocessor RPCs don't propagate exceptions
  • [HBASE-7693]: Hostname returned by TableInputFormatBase.reverseDNS contains trailing period
  • [HBASE-7698]: race between RS shutdown thread and openregionhandler causes region to get stuck
  • [HBASE-7700]: TestColumnSeeking is mathematically bound to fail
  • [HBASE-7701]: Opening regions on dead server are not reassigned quickly
  • [HBASE-7702]: Adding filtering to Import jobs
  • [HBASE-7711]: rowlock release problem with thread interruptions in batchMutate
  • [HBASE-7715]: FSUtils#waitOnSafeMode can incorrectly loop on standby NN
  • [HBASE-7717]: Wait until regions are assigned in TestSplitTransactionOnCluster
  • [HBASE-7719]: HTableDescriptor.setDeferredLogFlush should be synchronized
  • [HBASE-7723]: Remove NameNode URI from ZK splitlogs
  • [HBASE-7725]: Add ability to create custom compaction request
  • [HBASE-7728]: deadlock occurs between hlog roller and hlog syncer
  • [HBASE-7729]: TestCatalogTrackerOnCluster.testbadOriginalRootLocation fails occasionally
  • [HBASE-7731]: Append/Increment methods in HRegion don't check whether the table is readonly or not
  • [HBASE-7736]: Port BigDecimalColumnInterpreter to 0.96
  • [HBASE-7740]: Recheck matching row for joined scanners
  • [HBASE-7751]: TestDelayedRpc occasionally fails in trunk
  • [HBASE-7756]: Strange code in ServerCallable#shouldRetry
  • [HBASE-7760]: tiny issue in ChaosMonkey: kills meta server instead of root
  • [HBASE-7761]: MemStore.USEMSLAB_DEFAULT is false, hbase-default.xml says it's true
  • [HBASE-7763]: Compactions not sorting based on size anymore.
  • [HBASE-7768]: zkcluster in local mode not seeing configurations in hbase-{site|default}.xml
  • [HBASE-7771]: Secure HBase Client in MR job causes tasks to wait forever
  • [HBASE-7772]: clusterId is not set in conf properly if only TableMapReduceUtil.initCredentials() is called
  • [HBASE-7776]: Use ErrorReporter/Log instead of System.out in hbck
  • [HBASE-7777]: HBCK check for lingering split parents should check for child regions
  • [HBASE-7785]: rolling-restart.sh script unable to check expiration of master znode
  • [HBASE-7786]: Consolidate HRegion creation/opening API
  • [HBASE-7787]: Remove HLogSplitter.RECOVERED_EDITS duplicate of HLog.RECOVERED_EDITS_DIR
  • [HBASE-7789]: Clean DeadServer.java and add a Jitter method in ConnectionUtils
  • [HBASE-7797]: Use consistent package name
  • [HBASE-7798]: ZKAssign logs the wrong server if the transition fails
  • [HBASE-7799]: reassigning region stuck in open still may not work correctly due to leftover ZK node
  • [HBASE-7800]: RegionMovedException can cause servers to play ping pong with client
  • [HBASE-7804]: Minor typo in Appendix B. hbck In Depth section of book
  • [HBASE-7813]: Bug in BulkDeleteEndpoint kills entire rows on COLUMN/VERSION Deletes
  • [HBASE-7829]: zookeeper kerberos conf keytab and principal parameters interchanged
  • [HBASE-7830]: Disable IntegrationTestRebalanceAndKillServersTargeted temporarily
  • [HBASE-7834]: Document Hadoop version support matrix in the book
  • [HBASE-7866]: TestSplitTransactionOnCluster.testSplitBeforeSettingSplittingInZK failed 3 times in a row
  • [HBASE-7867]: setPreallocSize is different with COMMENT in setupTestEnv in MiniZooKeeperCluster.java
  • [HBASE-7869]: Provide way to not start LogSyncer thread
  • [HBASE-7876]: Got exception when manually triggers a split on an empty region
  • [HBASE-7878]: recoverFileLease does not check return value of recoverLease
  • [HBASE-7879]: JUnit dependency in main from htrace
  • [HBASE-7883]: Update memstore size when removing the entries in append operation
  • [HBASE-7884]: ByteBloomFilter's performance can be improved by avoiding multiplication when generating hash
  • [HBASE-7901]: TestStore::testDeleteExpiredStoreFiles has a hidden issue
  • [HBASE-7911]: Remove duplicated code from CreateTableHandler
  • [HBASE-7913]: Secure Rest server should login before getting an instance of Rest servlet
  • [HBASE-7915]: Secure ThriftServer needs to login before calling HBaseHandler
  • [HBASE-7926]: SmallTests pollute the META descriptor
  • [HBASE-7933]: NPE in TableLockManager
  • [HBASE-7940]: Upgrade version to 0.97-SNAPSHOT in pom.xml files
  • [HBASE-7945]: Remove flaky TestCatalogTrackerOnCluster
  • [HBASE-7947]: Custom compaction requests should have test for adding to wrong list
  • [HBASE-7951]: TestNodeHealthCheckChore.testHealthChecker failed 0.95 build #3
  • [HBASE-7955]: Remove log "ERROR snapshot.SnapshotFileCache: Snapshot directory doesn't exist"
  • [HBASE-7956]: RegionCoprocessorRpcChannel should log rpc requests at TRACE level rather than DEBUG
  • [HBASE-7957]: CloneSnapshotHandler.prepare() is not called by SnapshotManager
  • [HBASE-7961]: truncate on disabled table should throw TableNotEnabledException.
  • [HBASE-7966]: ACL tests fail on trunk (flaky)
  • [HBASE-7968]: Packaging of Trunk and 0.95 does not create the dependent jars in the lib folder
  • [HBASE-7969]: Rename HBaseAdmin#getCompletedSnapshots as HBaseAdmin#listSnapshots
  • [HBASE-7981]: TestSplitTransactionOnCluster.testShutdownFixupWhenDaughterHasSplit failed in 0.95 build #11
  • [HBASE-7982]: TestReplicationQueueFailover* runs for a minute, spews 3/4million lines complaining 'Filesystem closed', has an NPE, and still passes?
  • [HBASE-7986]: [REST] Make HTablePool size configurable
  • [HBASE-7992]: provide pre/post region offline hooks for HMaster.offlineRegion()
  • [HBASE-7993]: add access control to HMaster offline region.
  • [HBASE-8002]: Make TimeOut Management for Assignment optional in master and regionservers
  • [HBASE-8004]: Creating an existing table from Shell does not throw TableExistsException
  • [HBASE-8005]: DemoClient.cpp can not be built correctly
  • [HBASE-8007]: Adopt TestLoadAndVerify from BigTop
  • [HBASE-8012]: Reseek should position to the beginning of file for the first time it is invoked with a KV smaller than the first KV in file
  • [HBASE-8021]: TestSplitTransactionOnCluster.testShouldThrowIOExceptionIfStoreFileSizeIsEmptyAndShouldSuccessfullyExecuteRollback() fails consistently
  • [HBASE-8022]: Site target fails
  • [HBASE-8025]: zkcli fails when SERVER_GC_OPTS is enabled
  • [HBASE-8027]: hbase-7994 redux; shutdown hbase-example unit tests
  • [HBASE-8030]: znode path of online region servers is hard coded in rolling_restart.sh
  • [HBASE-8032]: TestNodeHealthCheckChore.testHealthChecker failed 0.95 build #36
  • [HBASE-8033]: Break TestRestoreSnapshotFromClient into TestRestoreSnapshotFromClient and TestCloneSnapshotFromClient
  • [HBASE-8036]: ProtobufUtil.multi behavior is inconsistent in case of errors
  • [HBASE-8041]: WebUI doesn't display snapshots correctly
  • [HBASE-8042]: Offline Meta Repair no longer points to the correct location
  • [HBASE-8043]: Fix a few javadoc warnings...
  • [HBASE-8044]: split/flush/compact/major_compact from hbase shell does not work for region key with \x format
  • [HBASE-8050]: Small fix to book/hbase.tests.html
  • [HBASE-8051]: 0.95 build failing on site goal: 'failed to get report for org.apache.maven.plugins:maven-project-info-reports-plugin: Could not find goal 'dependency-info''
  • [HBASE-8052]: TestHBaseFsck#testQuarantineMissingFamdir fails sporadically
  • [HBASE-8055]: Null check missing in StoreFile.Reader.getMaxTimestamp()
  • [HBASE-8057]: RegionLoad needs a toString implementation
  • [HBASE-8058]: Upgrade site plugin; fix assembly doc up on jenkins builds
  • [HBASE-8062]: Replace HBaseFsck.debugLsr() in TestFlushSnapshotFromClient with FSUtils.logFileSystemState()
  • [HBASE-8068]: TestMasterMetricsWrapper failed in 0.95 #60 jenkins
  • [HBASE-8069]: TestHLog is dependent on the execution order
  • [HBASE-8097]: MetaServerShutdownHandler may potentially keep bumping up DeadServer.numProcessing
  • [HBASE-8099]: ReplicationZookeeper.copyQueuesFromRSUsingMulti should not return any queues if it failed to execute.
  • [HBASE-8108]: Add m2eclispe lifecycle mapping to hbase-common
  • [HBASE-8116]: TestSnapshotCloneIndependence fails in trunk builds intermittently
  • [HBASE-8118]: TestTablePermission depends on the execution order
  • [HBASE-8122]: TestAccessController depends on the execution order
  • [HBASE-8123]: Replace HashMap/HashSet with TreeMap/TreeSet where byte[] is used as key
  • [HBASE-8128]: HTable#put improvements
  • [HBASE-8130]: initialize TableLockManager before initializing AssignmentManager
  • [HBASE-8131]: Create table handler needs to handle failure cases.
  • [HBASE-8135]: Mutation should implement HeapSize
  • [HBASE-8138]: Using [packed=true] for repeated field of primitive numeric types (types which use the varint, 32-bit, or 64-bit wire types)
  • [HBASE-8140]: TableMapReduceUtils#addDependencyJar fails when nested inside another MR job
  • [HBASE-8141]: Remove accidental uses of org.mortbay.log.Log
  • [HBASE-8142]: Sporadic TestZKProcedureControllers failures on trunk
  • [HBASE-8144]: Limit number of attempts to assign a region
  • [HBASE-8146]: IntegrationTestBigLinkedList does not work on distributed setup
  • [HBASE-8151]: Decode memstoreTS in HFileReaderV2 only when necessary
  • [HBASE-8160]: HMaster#move doesn't check if master initialized
  • [HBASE-8161]: setting blocking file count on table level doesn't work
  • [HBASE-8164]: TestTableLockManager fails intermittently in trunk builds
  • [HBASE-8166]: Avoid writing the memstor

New in Apache HBase 0.90.6 (Apr 8, 2013)

  • INCOMPATIBLE CHANGES:
  • HBASE-5228 [REST] Rip out "transform" feature
  • BUG FIXES:
  • HBASE-5008 The clusters can't provide services because Region can't flush (Gaojinchao)
  • HBASE-5020 MetaReader#fullScan doesn't stop scanning when vistor returns false in 0.90 version (Chunhui Shen)
  • HBASE-4893 HConnectionImplementation is closed but not deleted (Mubarak)
  • HBASE-4970 Add a parameter so that keepAliveTime of Htable thread pool can be changed (gaojinchao)
  • HBASE-5060 HBase client is blocked forever (Jinchao)
  • HBASE-5073 Registered listeners not getting removed leading to memory leak in HBaseAdmin (Ramkrishna)
  • HBASE-5009 Failure of creating split dir if it already exists prevents splits from happening further
  • HBASE-5041 Major compaction on non existing table does not throw error (Shrijeet)
  • HBASE-5088 A concurrency issue on SoftValueSortedMap (Jieshan Bean and Lars H)
  • HBASE-5156 Backport HBASE-4899 - Region would be assigned twice easily with continually killing server and moving region in testing environment(Ram)
  • HBASE-5158 Backport HBASE-4878 - Master crash when splitting hlog may cause data loss (Ram)
  • HBASE-5168 Backport HBASE-5100 - Rollback of split could cause closed region to be opened again(Ram)
  • HBASE-5178 Backport HBASE-4101 - Regionserver Deadlock (Ram)
  • HBASE-5159 Backport HBASE-4079 - HTableUtil - helper class for loading data (Ram)
  • HBASE-5184 Backport HBASE-5152 - Region is on service before completing initialization when doing rollback of split, it will affect read correctness (Ram)
  • HBASE-5160 Backport HBASE-4397 - -ROOT-, .META. tables stay offline for too long in recovery phase after all RSs are shutdown at the same time (Ram)
  • HBASE-5160 Addendum adding the removed method in AssignmentManager (Ram)
  • HBASE-5192 Backport HBASE-4236 Don't lock the stream while serializing the response (Ram)
  • HBASE-5155 ServerShutDownHandler And Disable/Delete should not happen parallely leading to recreation of regions that were deleted (Ram)
  • HBASE-5153 Add retry logic in HConnectionImplementation#resetZooKeeperTrackers (Jieshan)
  • HBASE-5196 Failure in region split after PONR could cause region hole (Jimmy Xiang)
  • HBASE-5225 Backport HBASE-3845 -data loss because lastSeqWritten can miss memstore edits (Ram)
  • HBASE-5237 Addendum for HBASE-5160 and HBASE-4397 (Ram)
  • HBASE-5235 HLogSplitter writer thread's streams not getting closed when any of the writer threads has exceptions. (Ram)
  • HBASE-5243 LogSyncerThread not getting shutdown waiting for the interrupted flag (Ram)
  • HBASE-5269 IllegalMonitorStateException while retryin HLog split in 0.90 branch. (Ram)
  • HBASE-5137 MasterFileSystem.splitLog() should abort even if waitOnSafeMode() throws IOException (Ram)
  • HBASE-5271 Result.getValue and Result.getColumnLatest return the wrong column (Ghais Issa)
  • HBASE-5153 Addendum for 0.90 branch (Jieshan)
  • HBASE-5321 this.allRegionServersOffline not set to false after one RS comes online and assignment is done in 0.90. (Ram)
  • HBASE-5377 Fix licenses on the 0.90 branch.
  • HBASE-5379 Backport HBASE-4287 to 0.90 - If region opening fails, try to transition region back to "offline" in ZK
  • HBASE-5396 Handle the regions in regionPlans while processing ServerShutdownHandler(Jieshan)
  • HBASE-5364 Fix source files missing licenses in 0.92 and trunk; Addendum (Shaneal Manek)
  • HBASE-5490 Move the enum RS_ZK_REGION_FAILED_OPEN to the last of the enum list in 0.90 EventHandler (Ram)
  • IMPROVEMENT:
  • HBASE-5102 Change the default value of the property "hbase.connection.per.config" to false in hbase-default.xml
  • HBASE-5327 Print a message when an invalid hbase.rootdir is passed (Jimmy Xiang)
  • HBASE-5197 [replication] Handle socket timeouts in ReplicationSource to prevent DDOS
  • HBASE-5395 CopyTable needs to use GenericOptionsParser