Version 0.94.0

RELEASED

Start date not set

Released: 14/May/12

Release Notes

Performance ReleaseShow more
PTKeySummaryAssigneeStatus
BlockerBugHBASE-2856TestAcidGuarantee broken on trunk Amitanand AiyerClosed
BlockerBugHBASE-4078Silent Data Offlining During HDFS FlakinessPritam DamaniaClosed
BlockerBugHBASE-4890fix possible NPE in HConnectionManagerMichael StackClosed
BlockerImprovementHBASE-4995Increase zk maxClientCnxns to give us some head roomMichael StackClosed
BlockerImprovementHBASE-5017Bump the default hfile.block.cache.size because of HFileV2Jean-Daniel CryansClosed
BlockerBugHBASE-5055Build against hadoop 0.22 brokenMichael StackClosed
BlockerBugHBASE-5120Timeout monitor races with table disable handlerramkrishna.s.vasudevanClosed
BlockerBugHBASE-5141Memory leak in MonitoredRPCHandlerImplJean-Daniel CryansClosed
BlockerSub-taskHBASE-5143Fix config typo in pluggable load balancer factoryHarsh JClosed
BlockerBugHBASE-5267Add a configuration to disable the slab cache by defaultLi PiClosed
BlockerBugHBASE-5288Security source code dirs missing from 0.92.0 release tarballs.Jonathan HsiehClosed
BlockerBugHBASE-5364Fix source files missing licenses in 0.92 and trunkElliott Neil ClarkClosed
BlockerBugHBASE-5552Clean up our jmx view; its a bit of a messMichael StackClosed
BlockerBugHBASE-5603rolling-restart.sh script hangs when attempting to detect expiration of /hbase/master znode.Jonathan HsiehClosed
BlockerBugHBASE-5639The logic used in waiting for region servers during startup is brokenJean-Daniel CryansClosed
BlockerSub-taskHBASE-5641decayingSampleTick1 prevents HBase from shutting down.Lars HofhanslClosed
BlockerBugHBASE-5665Repeated split causes HRegionServer failures and breaks table Cosmin LeheneClosed
BlockerBugHBASE-5720HFileDataBlockEncoderImpl uses wrong header size when reading HFiles with no checksumsMatt CorganClosed
BlockerBugHBASE-5782Edits can be appended out of seqid order since HBASE-4487Lars HofhanslClosed
BlockerBugHBASE-5861Hadoop 23 compilation broken due to tests introduced in HBASE-5604Jonathan HsiehClosed
BlockerBugHBASE-5864Error while reading from hfile in 0.94ramkrishna.s.vasudevanClosed
BlockerBugHBASE-5885Invalid HFile block magic on Local file SystemElliott Neil ClarkClosed
CriticalImprovementHBASE-1744Thrift server to match the new java api.Tim SellClosed
CriticalImprovementHBASE-2418add support for ZooKeeper authenticationEugene Joseph KoontzClosed
CriticalImprovementHBASE-3433Remove the KV copy of every KV in Scan; introduced by HBASE-3232Lars HofhanslClosed
CriticalBugHBASE-3443ICV optimization to look in memstore first and then store files (HBASE-3082) does not work when deletes are in the mixLars HofhanslClosed
CriticalImprovementHBASE-3850Log more details when a scanner lease expiresDarren HaasClosed
CriticalTaskHBASE-4256Intra-row scanning (part deux)Dave RevellClosed
CriticalImprovementHBASE-4365Add a decent heuristic for region sizeMichael StackClosed
CriticalBugHBASE-4729Clash between region unassign and splitting kills the masterMichael StackClosed
CriticalBugHBASE-4792SplitRegionHandler doesn't care if it deletes the znode or not, leaves the parent region stuck offlineJean-Daniel CryansClosed
CriticalBugHBASE-4797[availability] Skip recovered.edits files with edits we know older than what region currently hasJimmy XiangClosed
CriticalBugHBASE-4853HBASE-4789 does overzealous pruning of seqidsMichael StackClosed
CriticalBugHBASE-5003If the master is started with a wrong root dir, it gets stuck and can't be killedShaneal ManekClosed
CriticalImprovementHBASE-5021Enforce upper bound on timestampNicolas SpiegelbergClosed
CriticalBugHBASE-5088A concurrency issue on SoftValueSortedMapLars HofhanslClosed
CriticalBugHBASE-5121MajorCompaction may affect scan's correctnessChunhui ShenClosed
CriticalTaskHBASE-5294Make sure javadoc is included in tarball bundle when we releaseShaneal ManekClosed
CriticalBugHBASE-5387Reuse compression streams in HFileBlock.WriterMikhail GryzykhinClosed
CriticalBugHBASE-5415FSTableDescriptors should handle random folders in hbase.root.dir betterJean-Daniel CryansClosed
CriticalBugHBASE-5480Fixups to MultithreadedTableMapper for Hadoop 0.23.2+Andrew Kyle PurtellClosed
CriticalBugHBASE-5606SplitLogManger async delete node hangs log splitting when ZK connection is lost Prakash KhemaniClosed
CriticalBugHBASE-5611Replayed edits from regions that failed to open during recovery aren't removed from the global MemStore sizeJieshan BeanClosed
CriticalBugHBASE-5623Race condition when rolling the HLog and hlogFlushEnis SoztutarClosed
CriticalImprovementHBASE-5671hbase.metrics.showTableName should be true by defaultEnis SoztutarClosed
CriticalImprovementHBASE-5682Allow HConnectionImplementation to recover from ZK connection loss (for 0.94 only)Lars HofhanslClosed
CriticalBugHBASE-5689Skipping RecoveredEdits may cause data lossChunhui ShenClosed
CriticalBugHBASE-5690compression does not work in Store.java of 0.94Honghua ZhuClosed
CriticalBugHBASE-5781Zookeeper session got closed while trying to assign the region to RS using hbck -fixJonathan HsiehClosed
CriticalImprovementHBASE-5862After Region Close remove the Operation Metrics.Elliott Neil ClarkClosed
CriticalBugHBASE-5871Usability regression, we don't parse compression algos anymoreLars HofhanslClosed
CriticalBugHBASE-5897prePut coprocessor hook causing substantial CPU usageTodd LipconClosed
MajorImprovementHBASE-3373Allow regions to be load-balanced by tableTed YuClosed
MajorImprovementHBASE-3512Coprocessors: Shell support for listing currently loaded coprocessor setEugene Joseph KoontzClosed
MajorImprovementHBASE-3565Add metrics to keep track of slow HLog appendsMubarak SeyedClosed
MajorNew FeatureHBASE-3584Allow atomic put/delete in one callLars HofhanslClosed
MajorNew FeatureHBASE-3856Build a tree structure data block index inside of the HFileLiyin TangClosed
MajorBugHBASE-3987Fix a NullPointerException on a failure to load Bloom filter dataMikhail GryzykhinClosed
MajorImprovementHBASE-4058Extend TestHBaseFsck with a complete .META. recovery scenarioMichael StackClosed
MajorBugHBASE-4065TableOutputFormat ignores failure to create table instanceBrock NolandClosed
MajorImprovementHBASE-4070[Coprocessors] Improve region server metrics to report loaded coprocessors to masterEugene Joseph KoontzClosed
MajorImprovementHBASE-4076hbase should pick up HADOOP_CONF_DIR on its classpathUnassignedClosed
MajorBugHBASE-4083If Enable table is not completed and is partial, then scanning of the table is not working ramkrishna.s.vasudevanClosed
MajorNew FeatureHBASE-4102atomicAppend: A put that appends to the latest version of a cell; i.e. reads current value then adds the bytes offered by the client to the tail and writes out a new entryLars HofhanslClosed
MajorBugHBASE-4105Stargate does not support Content-Type: application/json and Content-Encoding: gzip in parallelAndrew Kyle PurtellClosed
MajorBugHBASE-4116[stargate] StringIndexOutOfBoundsException in row spec parseUnassignedClosed
MajorImprovementHBASE-4131Make the Replication Service pluggable via a standard interface definitionDhruba BorthakurClosed
MajorImprovementHBASE-4132Extend the WALActionsListener API to accomodate log archivalDhruba BorthakurClosed
MajorImprovementHBASE-4145Provide metrics for hbase clientMing MaClosed
MajorImprovementHBASE-4213Support for fault tolerant, instant schema updates with out master's intervention (i.e with out enable/disable and bulk assign/unassign) through ZK.Subbu M IyerClosed
MajorImprovementHBASE-4218Data Block Encoding of KeyValues (aka delta encoding / prefix compressionMikhail GryzykhinClosed
MajorNew FeatureHBASE-4219Add Per-Column Family MetricsDavid GoodeClosed
MajorBugHBASE-4326Tests that use HBaseTestingUtility.startMiniCluster(n) should shutdown with HBaseTestingUtility.shutdownMiniCluster.Nicolas LiochonClosed
MajorSub-taskHBASE-4345Ensure that Scanners that read from the storefiles respect MVCCAmitanand AiyerClosed
MajorNew FeatureHBASE-4393Implement a canary monitoring programMatteo BertozziClosed
MajorBugHBASE-4397-ROOT-, .META. tables stay offline for too long in recovery phase after all RSs are shutdown at the same timeMing MaClosed
MajorBugHBASE-4398If HRegionPartitioner is used in MapReduce, client side configurations are overwritten by hbase-site.xml.Takuya UeshinClosed
MajorImprovementHBASE-4418Show all the hbase configuration in the web uiLiyin TangClosed
MajorTaskHBASE-4429Provide synchronous balanceSwitch()Ted YuClosed
MajorNew FeatureHBASE-4460Support running an embedded ThriftServer within a RegionServerJonathan GrayClosed
MajorImprovementHBASE-4461Expose getRowOrBefore via ThriftJonathan GrayClosed
MajorImprovementHBASE-4463Run more aggressive compactions during off peak hoursKarthik RanganathanClosed
MajorImprovementHBASE-4465Lazy-seek optimization for StoreFile scannersMikhail GryzykhinClosed
MajorImprovementHBASE-4469Avoid top row seek by looking up ROWCOL bloomfilterLiyin TangClosed
MajorBugHBASE-4476Compactions must fail if column tracker gets columns out of orderMikhail GryzykhinClosed
MajorBugHBASE-4478Improve AssignmentManager.handleRegion so that it can process certain ZK state in the case of RS offlineramkrishna.s.vasudevanClosed
MajorSub-taskHBASE-4485Eliminate window of missing DataAmitanand AiyerClosed
MajorImprovementHBASE-4487The increment operation can release the rowlock before sync-ing the HlogDhruba BorthakurClosed
MajorImprovementHBASE-4489Better key splitting in RegionSplitterDave RevellClosed
MajorBugHBASE-4496HFile V2 does not honor setCacheBlocks when scanning.Mikhail GryzykhinClosed
MajorImprovementHBASE-451925s sleep when expiring sessions in testsNicolas LiochonClosed
MajorImprovementHBASE-4528The put operation can release the rowlock before sync-ing the HlogDhruba BorthakurClosed
MajorImprovementHBASE-4532Avoid top row seek by dedicated bloom filter for delete family bloom filterLiyin TangClosed
MajorTestHBASE-4534A new unit test for lazy seek and StoreScanner in generalMikhail GryzykhinClosed
MajorNew FeatureHBASE-4536Allow CF to retain deleted rowsLars HofhanslClosed
MajorImprovementHBASE-4542add filter info to slow query loggingMadhuwanti VaidyaClosed
MajorSub-taskHBASE-4544Rename RWCC to MVCCAmitanand AiyerClosed
MajorTestHBASE-4545TestHLog doesn't clean up after itselfGary HelmlingClosed
MajorImprovementHBASE-4554Allow set/unset coprocessor table attributes from shell.Mingjie LaiClosed
MajorBugHBASE-4556Fix all incorrect uses of InternalScanner.next(...)Lars HofhanslClosed
MajorImprovementHBASE-4568Make zk dump jsp response more quicklyLiyin TangClosed
MajorImprovementHBASE-4585Avoid next operations (and instead reseek) when current kv is deletedLiyin TangClosed
MajorImprovementHBASE-4605ConstraintsJesse YatesClosed
MajorNew FeatureHBASE-4608HLog CompressionLi PiClosed
MajorBugHBASE-4610Port HBASE-3380 (Master failover can split logs of live servers) to 92/trunk (definitely bring in config params, decide if we need to do more to fix the bug)Jonathan GrayClosed
MajorTaskHBASE-4611Add support for Phabricator/Differential as an alternative code review toolNicolas SpiegelbergClosed
MajorBugHBASE-4626Filters unnecessarily copy byte arrays...Lars HofhanslClosed
MajorImprovementHBASE-4627Ability to specify a custom start/end to RegionSplitterNicolas SpiegelbergClosed
MajorImprovementHBASE-4628Enhance Table Create Presplit Functionality within the HBase ShellNicolas SpiegelbergClosed
MajorNew FeatureHBASE-4629enable automated patch testing for hbaseGiridharan KesavanClosed
MajorBugHBASE-4645Edits Log recovery losing data across column familiesAmitanand AiyerClosed
MajorBugHBASE-4648Bytes.toBigDecimal() doesn't use offsetUnassignedClosed
MajorImprovementHBASE-4657Improve the efficiency of our MR jobs with a few configurationsLars HofhanslClosed
MajorBugHBASE-4658Put attributes are not exposed via the ThriftServerDhruba BorthakurClosed
MajorSub-taskHBASE-4661Ability to export the list of files for a some or all column families for a given regionMadhuwanti VaidyaClosed
MajorBugHBASE-4679Thrift null mutation errorNicolas SpiegelbergClosed
MajorSub-taskHBASE-4682Support deleted rows using Import/ExportLars HofhanslClosed
MajorImprovementHBASE-4696HRegionThriftServer' might have to indefinitely do redirtectsJonathan GrayClosed
MajorNew FeatureHBASE-4698Let the HFile Pretty Printer print all the key values for a specific row.Liyin TangClosed
MajorBugHBASE-4745LRU Statistics thread should be daemonAndrew Kyle PurtellClosed
MajorImprovementHBASE-4746Use a random ZK client port in unit tests so we can run them in parallelMikhail GryzykhinClosed
MajorTaskHBASE-4751Make TestAdmin#testEnableTableRoundRobinAssignment friendly to concurrent testsJieshan BeanClosed
MajorNew FeatureHBASE-4768Per-(table, columnFamily) metrics with configurable table name inclusionMikhail GryzykhinClosed
MajorBugHBASE-4769Abort RegionServer Immediately on OOMENicolas SpiegelbergClosed
MajorBugHBASE-4776HLog.closed should be checked inside of updateLockPrakash KhemaniClosed
MajorBugHBASE-4778Don't ignore corrupt StoreFiles when opening a regionMikhail GryzykhinClosed
MajorBugHBASE-4805Allow better control of resource consumption in HTableLars HofhanslClosed
MajorBugHBASE-4819TestShell broke in trunk; typoMichael StackClosed
MajorBugHBASE-4825TestRegionServersMetrics and TestZKLeaderManager are not categorized (small/medium/large)Nicolas LiochonClosed
MajorBugHBASE-4826Modify hbasetests.sh to take into account the new pom.xml with surefireNicolas LiochonClosed
MajorImprovementHBASE-4863Make Thrift server thread pool bounded and add a command-line UI testMikhail GryzykhinClosed
MajorBugHBASE-4874Run tests with non-secure random, some tests hang otherwiseLars HofhanslClosed
MajorBugHBASE-4878Master crash when splitting hlog may cause data lossChunhui ShenClosed
MajorSub-taskHBASE-4908HBase cluster test tool (port from 0.89-fb)Mikhail GryzykhinClosed
MajorSub-taskHBASE-4911Clean shutdownUnassignedClosed
MajorBugHBASE-4932Block cache can be mistakenly instantiated by toolsPrakash KhemaniClosed
MajorImprovementHBASE-4933Ability to calculate the blockcache hit ratio for the last few minutesDhruba BorthakurClosed
MajorBugHBASE-4936Cached HRegionInterface connections crash when getting UnknownHost exceptionsAndrei DragomirClosed
MajorBugHBASE-4937Error in Quick Start Shell ExercisesMichael StackClosed
MajorBugHBASE-4942HMaster is unable to start of HFile V1 is usedHonghua ZhuClosed
MajorBugHBASE-4946HTable.coprocessorExec (and possibly coprocessorProxy) does not work with dynamically loaded coprocessors (from hdfs or local system), because the RPC system tries to deserialize an unknown class. Andrei DragomirClosed
MajorImprovementHBASE-4964Add builddate, make less sections in toc, and add header and footer customizationsUnassignedClosed
MajorTaskHBASE-4968Add to troubleshooting workaround for direct buffer oome's.Michael StackClosed
MajorSub-taskHBASE-4979Setting KEEP_DELETE_CELLS fails in shellLars HofhanslClosed
MajorSub-taskHBASE-4981add raw scan support to shellLars HofhanslClosed
MajorBugHBASE-4993Performance regression in minicluster creationNicolas LiochonClosed
MajorBugHBASE-5010Filter HFiles based on TTLMikhail GryzykhinClosed
MajorTaskHBASE-5011Move test-util.sh from src/test/bin to dev-toolsUnassignedClosed
MajorImprovementHBASE-5014PutSortReducer should adhere to memory limitsDhruba BorthakurClosed
MajorBugHBASE-5026Add coprocessor hook to HRegionServer.ScannerListener.leaseExpired()Liu JiaClosed
MajorBugHBASE-5027HConnection.create(final Connection conf) does not clone, it creates a new Configuration reading *.xmls and then does a merge.Nicolas LiochonClosed
MajorImprovementHBASE-5033Opening/Closing store in parallel to reduce region open/close timeLiyin TangClosed
MajorBugHBASE-5041Major compaction on non existing table does not throw error Shrijeet PaliwalClosed
MajorImprovementHBASE-5064utilize surefire tests parallelizationNicolas LiochonClosed
MajorBugHBASE-5068RC1 can not build its hadoop-0.23 profileRoman ShaposhnikClosed
MajorImprovementHBASE-5074support checksums in HBase block cacheDhruba BorthakurClosed
MajorTaskHBASE-5084Allow different HTable instances to share one ExecutorServiceLars HofhanslClosed
MajorBugHBASE-5085fix test-patch script from setting the ulimitGiridharan KesavanClosed
MajorSub-taskHBASE-5096Replication does not handle deletes correctly.Lars HofhanslClosed
MajorBugHBASE-5097RegionObserver implementation whose preScannerOpen and postScannerOpen Impl return null can stall the system initialization through NPEramkrishna.s.vasudevanClosed
MajorBugHBASE-5099ZK event thread waiting for root region assignment may block server shutdown handler for the region sever the root region was onJimmy XiangClosed
MajorBugHBASE-5100Rollback of split could cause closed region to be opened againChunhui ShenClosed
MajorTaskHBASE-5111Upgrade zookeeper to 3.4.2 releaseUnassignedClosed
MajorNew FeatureHBASE-5128[uber hbck] Online automated repair of table integrity and region consistency problemsJonathan HsiehClosed
MajorImprovementHBASE-5134Remove getRegionServerWithoutRetries and getRegionServerWithRetries from HConnection InterfaceMichael StackClosed
MajorBugHBASE-5152Region is on service before completing initialization when doing rollback of split, it will affect read correctness Chunhui ShenClosed
MajorBugHBASE-5172HTableInterface should extend java.io.CloseableMichael StackClosed
MajorTaskHBASE-5173Commit hbase-4480 findHangingTest.sh script under dev-supportUnassignedClosed
MajorImprovementHBASE-5186Add metrics to ThriftServerScott ChenClosed
MajorImprovementHBASE-5190Limit the IPC queue size based on calls' payload sizeJean-Daniel CryansClosed
MajorBugHBASE-5195[Coprocessors] preGet hook does not allow overriding or wrapping filter on incoming GetAndrew Kyle PurtellClosed
MajorBugHBASE-5196Failure in region split after PONR could cause region holeJimmy XiangClosed
MajorImprovementHBASE-5197[replication] Handle socket timeouts in ReplicationSource to prevent DDOSJean-Daniel CryansClosed
MajorImprovementHBASE-5199Delete out of TTL store files before compaction selectionLiyin TangClosed
MajorBugHBASE-5200AM.ProcessRegionInTransition() and AM.handleRegion() race thus leaving the region assignment inconsistentramkrishna.s.vasudevanClosed
MajorImprovementHBASE-5201Utilize TThreadedSelectorServer and remove redundant code in ThriftServer and HRegionThriftServerScott ChenClosed
MajorSub-taskHBASE-5203Group atomic put/delete operation into a single WALEdit to handle region server failures.Lars HofhanslClosed
MajorBugHBASE-5206Port HBASE-5155 to 0.92, 0.94, and TRUNKAshutosh JindalClosed
MajorImprovementHBASE-5209HConnection/HMasterInterface should allow for way to get hostname of currently active master in multi-master HBase setupDavid S. WangClosed
MajorBugHBASE-5212Fix test TestTableMapReduce against 0.23.Gregory ChananClosed
MajorBugHBASE-5221bin/hbase script doesn't look for Hadoop jars in the right place in trunk layoutJimmy XiangClosed
MajorTestHBASE-5223TestMetaReaderEditor is missing call to CatalogTracker.stop()Ted YuClosed
MajorBugHBASE-5228[REST] Rip out "transform" featureAndrew Kyle PurtellClosed
MajorNew FeatureHBASE-5229Provide basic building blocks for "multi-row" local transactions.Lars HofhanslClosed
MajorTaskHBASE-5256Use WritableUtils.readVInt() in RegionLoad.readFields()Mubarak SeyedClosed
MajorImprovementHBASE-5259Normalize the RegionLocation in TableInputFormat by the reverse DNS lookup.Liyin TangClosed
MajorTaskHBASE-5264Add 0.92.0 upgrade guideUnassignedClosed
MajorBugHBASE-5271Result.getValue and Result.getColumnLatest return the wrong column.Ghais IssaClosed
MajorBugHBASE-5281Should a failure in creating an unassigned node abort the master?Harsh JClosed
MajorBugHBASE-5282Possible file handle leak with truncated HLog file.Jonathan HsiehClosed
MajorBugHBASE-5283Request counters may become negative for heavily loaded regionsMubarak SeyedClosed
MajorBugHBASE-5286bin/hbase's logic of adding Hadoop jar files to the classpath is fragile when presented with split packaged Hadoop 0.23 installationRoman ShaposhnikClosed
MajorImprovementHBASE-5298Add thrift metrics to thrift2Scott ChenClosed
MajorImprovementHBASE-5304Pluggable split key policyLars HofhanslClosed
MajorBugHBASE-5317Fix TestHFileOutputFormat to work against hadoop 0.23Gregory ChananClosed
MajorBugHBASE-5327Print a message when an invalid hbase.rootdir is passedJimmy XiangClosed
MajorBugHBASE-5331Off by one bug in util.HMergeUnassignedClosed
MajorBugHBASE-5345CheckAndPut doesn't work when value is empty byte[]Evert ArckensClosed
MajorSub-taskHBASE-5346 Fix testColumnFamilyCompression and test_TIMERANGE in TestHFileOutputFormatGregory ChananClosed
MajorBugHBASE-5350Fix jamon generated package namesJesse YatesClosed
1200 of 423