Version 0.95.2

RELEASED

Start date not set

Released: 15/Aug/13

Release Notes

Next in the 0.95 "Development" Series of releases. Serves as "rough cut" preview of what is coming in 0.96 which is known as the "Singularity", because you will have to start and stop your cluster bringing it up on 0.96.0. 0.96.0 will require Hadoop 1.0.0 at least. It will be supported on Hadoop 2.0.0 too. 0.96.0 will be all protobufs all the time; all of its serializations to zookeeper, to the filesystem, and over rpc will be protobufs. It runs on jdk7. Metrics will be edited and converted to use Hadoop Metrics2. A preview of HBase Snapshots and PrefixTreeCompression,Show more
PTKeySummaryAssigneeStatus
BlockerTaskHBASE-8224Publish hbase build against h1 and h2 adding '-hadoop1' or '-hadoop2' to version stringMichael StackClosed
BlockerSub-taskHBASE-8409Security support for namespacesVandana AyyalasomayajulaClosed
BlockerImprovementHBASE-8439[replication] Remove ReplicationZookeeper classChris TrezzoClosed
BlockerBugHBASE-8488HBase transitive dependencies not being pulled in when building apps like Flume which depend on HBaseMichael StackClosed
BlockerBugHBASE-8665bad compaction priority behavior in queue can cause store to be blockedSergey ShelukhinClosed
BlockerSub-taskHBASE-8693DataType: provide extensible type APINick DimidukClosed
BlockerBugHBASE-8723HBase Intgration tests are failing because of new defaults.Elliott Neil ClarkClosed
BlockerBugHBASE-9038Compaction WALEdit gives NPEs with Replication enabledJean-Daniel CryansClosed
BlockerBugHBASE-9098During recovery use ZK as the source of truth for region state Jeffrey ZhongClosed
BlockerBugHBASE-9129Scanner prefetching leaks scanners.Elliott Neil ClarkClosed
BlockerSub-taskHBASE-9130Invert the name of namespace commands to match the snapshots and replication formMichael StackClosed
BlockerBugHBASE-91562000ms timeout for some client callsNicolas LiochonClosed
BlockerBugHBASE-9164Convert List<? extends Cell> anti pattern to List<Cell> pattern.Jonathan HsiehClosed
BlockerBugHBASE-9227RESTServer should handle the loginUser correctlyDevaraj DasClosed
CriticalUmbrellaHBASE-6891Hadoop 2 unit test failuresJonathan HsiehClosed
CriticalBugHBASE-8021TestSplitTransactionOnCluster.testShouldThrowIOExceptionIfStoreFileSizeIsEmptyAndShouldSuccessfullyExecuteRollback() fails consistentlyramkrishna.s.vasudevanClosed
CriticalImprovementHBASE-8322Re-enable hbase checksums by defaultJean-Daniel CryansClosed
CriticalSub-taskHBASE-8344Improve the assignment when node failures happen to choose the secondary RS as the new primary RSDevaraj DasClosed
CriticalBugHBASE-8433CellComparator#compare returns incorrect result for faked KeyValueChunhui ShenClosed
CriticalBugHBASE-8436SeekBefore returns wrong result with PREFIX_TREE EncodingChunhui ShenClosed
CriticalBugHBASE-8615HLog Compression may fail due to Hadoop fs input stream returning partial bytesTed YuClosed
CriticalNew FeatureHBASE-8663a HBase Shell command to list the tables replicated from current clusterDemai NiClosed
CriticalBugHBASE-8667Master and Regionserver not able to communicate if both bound to different network interfaces on the same machine.rajeshbabuClosed
CriticalBugHBASE-8732HFileBlockDefaultEncodingContext isn't thread-safe but is used by all readers, breaks column encodingJean-Daniel CryansClosed
CriticalImprovementHBASE-8737[replication] Change replication RPC to use cell blocksMichael StackClosed
CriticalImprovementHBASE-8778Region assigments scan table directory making them slow for huge tablesDave LathamClosed
CriticalImprovementHBASE-8785revise zookeeper session timeout settingJean-Daniel CryansClosed
CriticalBugHBASE-8795bin/hbase zkcli cannot take arguments anymoreEnis SoztutarClosed
CriticalBugHBASE-8811REST service ignores misspelled "check=" parameter, causing unexpected mutationsChip SalzenbergClosed
CriticalBugHBASE-8874PutCombiner is skipping KeyValues while combining puts of same row during bulkloadrajeshbabuClosed
CriticalBugHBASE-8909HBASE-6170 broke "hbase.regionserver.lease.period" config, we should support it for BCEnis SoztutarClosed
CriticalBugHBASE-8964TestAccessController.testGlobalAuthorizationForNewRegisteredRSMichael StackClosed
CriticalBugHBASE-9041TestFlushSnapshotFromClient.testConcurrentSnapshottingAttempts failsMatteo BertozziClosed
CriticalTaskHBASE-9061Put back TestReplicationKillMasterRSCompressed when fixed over in HBASE-8615Ted YuClosed
CriticalBugHBASE-9115HTableInterface.append operation may overwrites valuesTed YuClosed
CriticalSub-taskHBASE-9128Drop the '.' prefix from names under hbase.rootdir after namespaces goes inMichael StackClosed
CriticalBugHBASE-9142Mutation#getFamilyMap() return type change between HBase 94 and 96 breaks downstream appsJonathan HsiehClosed
CriticalBugHBASE-9144Leases class has contention that's not neededElliott Neil ClarkClosed
CriticalBugHBASE-9152Not able to find HMaster and HRegionServer processes with grep by process name on ps result because of large classpath as argument.rajeshbabuClosed
CriticalBugHBASE-9158Serious bug in cyclic replicationLars HofhanslClosed
CriticalTestHBASE-9160TestNamespaceUpgrade fails on hadoop 2.1 due to existence of .snapshot directory in tar ballFrancis Christopher LiuClosed
CriticalBugHBASE-9170TestStoreFileBlockCacheSummary.testBlockCacheSummary broke since HBASE-8408 (Namespaces) in 0.95Michael StackClosed
CriticalBugHBASE-9173replication_admin#get_peer_state(id) in ruby script pointing to undefined method `getPeerState'Jean-Daniel CryansClosed
CriticalSub-taskHBASE-9187HBaseAdmin#testTableExists can go zombieMichael StackClosed
CriticalTaskHBASE-9229Fix release warningElliott Neil ClarkClosed
CriticalBugHBASE-9238bug in Mutation::getFamilyMapSergey ShelukhinClosed
MajorNew FeatureHBASE-4050Update HBase metrics framework to metrics2 frameworkElliott Neil ClarkClosed
MajorNew FeatureHBASE-5959Add other load balancersElliott Neil ClarkClosed
MajorImprovementHBASE-6295Possible performance improvement in client batch operations: presplit and send in backgroundNicolas LiochonClosed
MajorNew FeatureHBASE-6449Dapper like tracingJonathan LeavittClosed
MajorImprovementHBASE-6580Deprecate HTablePool in favor of HConnection.getTable(...)Lars HofhanslClosed
MajorSub-taskHBASE-7074Document Metrics 2Elliott Neil ClarkClosed
MajorImprovementHBASE-7183print WARN message if hbase.replication.sizeOfLogQueue is too bigMichael WebsterClosed
MajorBugHBASE-7391Review/improve HLog compression's memory consumptionramkrishna.s.vasudevanClosed
MajorBugHBASE-7401Remove warning message about running 'hbase migrate'Jonathan HsiehClosed
MajorBugHBASE-7634Replication handling of changes to peer clusters is inefficientGabriel ReidClosed
MajorBugHBASE-7639Enable online schema update by default Elliott Neil ClarkClosed
MajorImprovementHBASE-8001Avoid unnecessary lazy seekRaymond LiuClosed
MajorBugHBASE-8018Add "Flaky Testcase Detector" tool into dev-toolsJeffrey ZhongClosed
MajorBugHBASE-8060"Num compacting KVs" diverges from "num compacted KVs" over timeSergey ShelukhinClosed
MajorBugHBASE-8067TestHFileArchiving.testArchiveOnTableDelete sometimes failsMatteo BertozziClosed
MajorImprovementHBASE-8093Change the .META. table name for file system incompatibilityEnis SoztutarClosed
MajorBugHBASE-8192Logic errror causes infinite loop in HRegion.bulkLoadHFiles(List)Chenghao JiangClosed
MajorBugHBASE-8200Integration Test classes are not part of the default HBase classpathEnis SoztutarClosed
MajorSub-taskHBASE-8201OrderedBytes: an ordered encoding strategyNick DimidukClosed
MajorBugHBASE-8204Don't use hdfs append during lease recoveryNicolas LiochonClosed
MajorBugHBASE-8212Introduce a new separator instead of hyphen('-') for renaming recovered queues' znodesJieshan BeanClosed
MajorTaskHBASE-8219Align Offline Merge with Online MergeChunhui ShenClosed
MajorBugHBASE-8226HBaseTestingUtility#waitUntilAllRegionsAssigned won't return if it counts "too many" regionsAndrew Kyle PurtellClosed
MajorBugHBASE-8241Fix the bad dependency on netty from HDFSNicolas LiochonClosed
MajorTestHBASE-8260create generic integration test for trunk and 94 that is more deterministic, can be run for longer and is less aggressiveSergey ShelukhinClosed
MajorSub-taskHBASE-8375Durability setting per tableEnis SoztutarClosed
MajorSub-taskHBASE-8408Implement namespaceFrancis Christopher LiuClosed
MajorBugHBASE-8413Snapshot verify region will always fail if the HFile has been archivedJerry HeClosed
MajorBugHBASE-8432a table with unbalanced regions will balance indefinitely with the 'org.apache.hadoop.hbase.master.DefaultLoadBalancer'UnassignedClosed
MajorSub-taskHBASE-8453TestImportExport failing again due to configuration issuesUnassignedClosed
MajorBugHBASE-8455Update ExportSnapshot to reflect changes in HBASE-7419Matteo BertozziClosed
MajorBugHBASE-8494TestRemoteAdmin#testClusterStatus should not assume 'requests' does not changeAndrew Kyle PurtellClosed
MajorBugHBASE-8501The hbase zkcli will connection failure the first and the second ip from ZooKeeperMainServerArg return connection stringMichael StackClosed
MajorNew FeatureHBASE-8504HTable.getRegionsInRange() should provide a non-cached APIMatteo BertozziClosed
MajorBugHBASE-8548postOpen hook called twiceNicolas LiochonClosed
MajorBugHBASE-8579TestDelayedRpc falis from time to timeUnassignedClosed
MajorBugHBASE-8586Revisit of hbase-8483, "HConnectionManager can leak ZooKeeper connections when using deleteStaleConnection"UnassignedClosed
MajorImprovementHBASE-8599HLogs in ZK are not cleaned up when replication lag is minimalVarun SharmaClosed
MajorImprovementHBASE-8617Introducing a new config to disable writes during recovering Jeffrey ZhongClosed
MajorBugHBASE-8624bin/local-{master-backup|regionservers}.sh doesn't take --config argrajeshbabuClosed
MajorBugHBASE-8627HBCK can not fix meta not assigned issueAnoop Sam JohnClosed
MajorUmbrellaHBASE-8629More log edits: we log too muchMichael StackClosed
MajorBugHBASE-8639Poor performance of htable#getscanner in multithreaded environment due to DNS.getDefaultHost() being called in ScannerCallable#prepare()Ted YuClosed
MajorBugHBASE-8640ServerName in master may not initialize with the configured ipc address of hbase.master.ipc.addressrajeshbabuClosed
MajorTestHBASE-8646Intermittent TestIOFencing#testFencingAroundCompaction failure due to region getting stuck in compactionEnis SoztutarClosed
MajorImprovementHBASE-8660[rest] support secure REST accessUnassignedClosed
MajorSub-taskHBASE-8661[rest] support REST over httpsUnassignedClosed
MajorSub-taskHBASE-8662[rest] support impersonationJimmy XiangClosed
MajorBugHBASE-8666META region isn't fully recovered during master initialization when META region recovery had chained failuresJeffrey ZhongClosed
MajorBugHBASE-8672Create an Integration test for Bulk LoadsElliott Neil ClarkClosed
MajorBugHBASE-8678Wrongly delete cells in some case which can not be deletedJean-Marc SpaggiariClosed
MajorBugHBASE-8680distributedLogReplay performance regressionJeffrey ZhongClosed
MajorImprovementHBASE-8692[AccessController] Restrict HTableDescriptor enumerationAndrew Kyle PurtellClosed
MajorBugHBASE-8695The HBase thrift service ignores XML configurationLars GeorgeClosed
MajorImprovementHBASE-8696Fixup for logs that show when running hbase-it tests.Michael StackClosed
MajorBugHBASE-8698potential thread creation in MetaScanner.metaScanLars HofhanslClosed
MajorBugHBASE-8699Parameter to DistributedFileSystem#isFileClosed should be of type PathTed YuClosed
MajorBugHBASE-8700IntegrationTestBigLinkedList can fail due to random number collisionSergey ShelukhinClosed
MajorImprovementHBASE-8702Make WALEditCodec pluggableJesse YatesClosed
MajorSub-taskHBASE-8703[WINDOWS] Timed-out processes exit with non-zero code causing HealthChecker to report incorrectlyEnis SoztutarClosed
MajorBugHBASE-8706Some improvement in snapshotMatteo BertozziClosed
MajorBugHBASE-8712HFileLinkCleaner (FSUtils.listStatus) logs too much if links do not existsMatteo BertozziClosed
MajorImprovementHBASE-8716Fixups/Improvements for graceful_stop.sh/region_mover.rbMichael StackClosed
MajorBugHBASE-8719Fix responseTooSlow formattingJean-Daniel CryansClosed
MajorBugHBASE-8726Create an Integration Test for online schema changeElliott Neil ClarkClosed
MajorBugHBASE-8729distributedLogReplay may hang during chained region server failureJeffrey ZhongClosed
MajorBugHBASE-8733Update our hadoop2 in trunk and 0.95 to 2.0.5-alpha (We are currently 2.0.2)Michael StackClosed
MajorBugHBASE-8745Fix src assembly so includes top-level src dirMichael StackClosed
MajorBugHBASE-8749Potential race condition between FSUtils.renameAndSetModifyTime() and HFile/LogCleanerMatteo BertozziClosed
MajorBugHBASE-8750MetaServerShutdownHandler stucks if .META. assignment fails in previous attemptHimanshu VashishthaClosed
MajorNew FeatureHBASE-8753Provide new delete flag which can delete all cells under a column-family which have designated timestampHonghua FengClosed
MajorBugHBASE-8757ZK throws IllegalStateExceptionJimmy XiangClosed
MajorBugHBASE-8764Some MasterMonitorCallable should retryMichael StackClosed
MajorSub-taskHBASE-8766[WINDOWS] bin/hbase.cmd zkcli is brokenEnis SoztutarClosed
MajorImprovementHBASE-8768Improve bulk load performance by moving key value construction from map phase to reduce phase.rajeshbabuClosed
MajorSub-taskHBASE-8774Add BatchSize and Filter to Thrift2Hamed MadaniClosed
MajorBugHBASE-8776tweak retry settings some more (on trunk and 0.94)Sergey ShelukhinClosed
MajorSub-taskHBASE-8779Add mutateRow method support to Thrift2Hamed MadaniClosed
MajorBugHBASE-8782Thrift2 can not parse values when using framed transportHamed MadaniClosed
MajorBugHBASE-8786Creating a table with a Bloom filter on the shell is broken.Elliott Neil ClarkClosed
MajorBugHBASE-8788Edit of .proto files moving classes to better homesMichael StackClosed
MajorBugHBASE-8789Add max RPC version to meta-region-server zk node.Elliott Neil ClarkClosed
MajorBugHBASE-8790NullPointerException thrown when stopping regionserverLiang XieClosed
MajorBugHBASE-8791Precommit hadoopqa is broke since -r1491656Michael StackClosed
MajorTaskHBASE-8796Add mention of new builds mailing list to siteMichael StackClosed
MajorBugHBASE-8797Prevent merging regions from moving during online mergeJimmy XiangClosed
MajorBugHBASE-8799TestAccessController#testBulkLoad failing on trunk/0.95Andrew Kyle PurtellClosed
MajorImprovementHBASE-8800Return non-zero exit codes when a region server abortsJean-Daniel CryansClosed
MajorImprovementHBASE-8809Include deletes in the scan (setRaw) method does not respect the time range or the filterLars HofhanslClosed
MajorBugHBASE-8813Fix time b/w recoverLease invocations from HBASE 8449Varun SharmaClosed
MajorBugHBASE-8814Possible NPE in split if a region has empty store files.rajeshbabuClosed
MajorSub-taskHBASE-8819Port HBASE-5428 to Thrift 2Lars GeorgeClosed
MajorSub-taskHBASE-8826Ensure HBASE-8695 is covered in Thrift 2Lars GeorgeClosed
MajorTaskHBASE-8829Improve failed TestMetaScanner assert message so can see where/why failureMichael StackClosed
MajorSub-taskHBASE-8832Ensure HBASE-4658 is supported by Thrift 2Hamed MadaniClosed
MajorSub-taskHBASE-8838[WINDOWS] FileLink assumptions are broken under NTFSEnis SoztutarClosed
MajorBugHBASE-8842TestTokenAuthentication failing on hadoop2 build with "IllegalArgumentException: Can't get Kerberos realm"Michael StackClosed
MajorTestHBASE-8845Add integration test for split, online merge, and compactionJimmy XiangClosed
MajorBugHBASE-8846Revert the package name change for TableExistsExceptionDevaraj DasClosed
MajorBugHBASE-8853The client connection is not cut when receiving the failure notificationNicolas LiochonClosed
MajorBugHBASE-8854TestScannersFromClientSide.testScanBatch failed with 'There should have room before prefetching is submitted'Michael StackClosed
MajorBugHBASE-8856Crash when attempting split with DelimitedKeyPrefixRegionSplitPolicyRobert DyerClosed
MajorImprovementHBASE-8861Remove ReplicationState completelyChris TrezzoClosed
MajorBugHBASE-8867HLogUtils#getServerNameFromHLogDirectoryName does not take into account the -splitting extensionNicolas LiochonClosed
MajorBugHBASE-8871The region server can crash at startupNicolas LiochonClosed
MajorSub-taskHBASE-8876Addendum to HBASE-8774 Add BatchSize and Filter to Thrift2 - Add BatchSize TestLars GeorgeClosed
MajorBugHBASE-8877Reentrant row locksDave LathamClosed
MajorBugHBASE-8879Client Scanner spams the logs if there are lots of scanners.Elliott Neil ClarkClosed
MajorBugHBASE-8880Integration Tests shouldn't set the number or reties.Elliott Neil ClarkClosed
MajorBugHBASE-8882Create an Integration Test to Test MTTRElliott Neil ClarkClosed
MajorBugHBASE-8883TestAdmin.testCloseRegionWhenServerNameIsEmpty failed with ArrayIndexOutOfBoundsExceptionMichael StackClosed
MajorBugHBASE-8888Tweak retry settings some more, *some more*Michael StackClosed
MajorSub-taskHBASE-8890Fix Thrift 2 example class locationLars GeorgeClosed
MajorTaskHBASE-8895Misc: replace hbase.client.retries.number w/ define and remove unused importsMichael StackClosed
MajorImprovementHBASE-8898Minor reformatting of hbase-default.xml and removal of comments that say what the 'default' is (since rarely agrees w/ actual setting)Michael StackClosed
MajorBugHBASE-8902IntegrationTestBulkLoad takes way too longElliott Neil ClarkClosed
MajorBugHBASE-8904Clean up IntegrationTestMTTR and add small features.Elliott Neil ClarkClosed
MajorBugHBASE-8910HMaster.abortNow shouldn't try to become a master again if it was stoppedJean-Daniel CryansClosed
MajorBugHBASE-8917Minor cleanup and fixes for POMLars FranckeClosed
MajorBugHBASE-8920TestZKBasedOpenCloseRegion.testReOpenRegion fails occasionallyMichael StackClosed
MajorImprovementHBASE-8921[thrift2] Add GenericOptionsParser to Thrift 2 serverLars GeorgeClosed
MajorBugHBASE-8924Master Can fail to come up after chaos monkey if the sleep time is too short.Elliott Neil ClarkClosed
MajorTestHBASE-8928Make ChaosMonkey & LoadTest tools extensible, to allow addition of more actions and policies.gautamClosed
MajorBugHBASE-8931TestTableLockManager.testTableReadLock failsMichael StackClosed
MajorBugHBASE-8933TestSplitTransactionOnCluster fails because "Region not moved off .META. server"Michael StackClosed
MajorTestHBASE-8934Fix bunch of flaky testsEnis SoztutarClosed
MajorBugHBASE-8935IntegrationTestBigLinkedList fails under load on 0.94 due to some scan issues - add loggingSergey ShelukhinClosed
MajorSub-taskHBASE-8938Thrift2 does not close scanner instanceHamed MadaniClosed
MajorBugHBASE-8940TestRegionMergeTransactionOnCluster#testWholesomeMerge may fail due to race in opening regionChunhui ShenClosed
MajorTestHBASE-8941TestAccessController.testGlobalPermissionList failed with IndexOutOfBoundsExceptionMichael StackClosed
MajorSub-taskHBASE-8946Add a new function to Thrift 2 to open scanner, get results and close scannerHamed MadaniClosed
MajorSub-taskHBASE-8947Thrift 2 : Replace "bool writeToWAL" with "TDurability durability" Hamed MadaniClosed
MajorSub-taskHBASE-8948Bound table pool size in Thrift 2 serverLars GeorgeClosed
MajorBugHBASE-8952Missing error handling can cause RegionServer RPC thread to busy loop foreverBenoit SigoureClosed
MajorBugHBASE-8955TestStochasticLoadBalancer timedoutMichael StackClosed
MajorBugHBASE-8957TestDrainingServer. testDrainingServerWithAbort failsMichael StackClosed
MajorImprovementHBASE-8961Make TestReplicationQueueFailover less integration-y by splitting it upJean-Daniel CryansClosed
MajorBugHBASE-8965TestRemoteAdmin.testClusterStatus failsMichael StackClosed
MajorBugHBASE-8972TestCreateTableHandler.testMasterRestartAfterEnablingNodeIsCreated failedMichael StackClosed
MajorBugHBASE-8975NPE/HTTP 500 when opening the master's web UI too earlyJean-Daniel CryansClosed
MajorSub-taskHBASE-8977Disable TestLogRollAbortMichael StackClosed
MajorTaskHBASE-8978Restore TestLogRollAbort upon reviewGary HelmlingClosed
MajorSub-taskHBASE-8979JVMClusterUtil will join forever on a stuck regionserver <--- zombie maker!!!Michael StackClosed
MajorBugHBASE-8982Useless logs in ipc.RpcClient$Connection(584): Not able to close an output streamNicolas LiochonClosed
MajorBugHBASE-8985Not enough logging in SplitLogManagerNicolas LiochonClosed
MajorBugHBASE-8987ProtobufUtil.toException doesn't handle plain RemoteException, gets a NoSuchMethodExceptionMichael StackClosed
MajorBugHBASE-8988Reuse the thread pool in the shell to not run out of threadsJean-Daniel CryansClosed
MajorBugHBASE-8989TestFromClientSideWithCoprocessor.testClientPoolThreadLocal failsMichael StackClosed
MajorBugHBASE-8993TestHRegionOnCluster.testDataCorrectnessReplayingRecoveredEdits failsMichael StackClosed
MajorBugHBASE-8996TestHCM.testDeleteForZKConnLeak can go zombieUnassignedClosed
MajorBugHBASE-8998TestSnapshotCloneIndependence.testOnlineSnapshotMetadataChangesIndependent failsMatteo BertozziClosed
MajorBugHBASE-9001TestThriftServerCmdLine.testRunThriftServer[0] failedMichael StackClosed
MajorBugHBASE-9007TestReplicationKillSlaveRS.killOneSlaveRS failsJean-Daniel CryansClosed
MajorBugHBASE-9008Reenable TestReplicationKillSlaveRS.killOneSlaveRSJean-Daniel CryansClosed
1200 of 328