You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by zh...@apache.org on 2018/07/05 09:45:49 UTC

[2/3] hbase git commit: HBASE-20832 Generate CHANGES.md and RELEASENOTES.md for 2.1.0

http://git-wip-us.apache.org/repos/asf/hbase/blob/6983f134/CHANGES.txt
----------------------------------------------------------------------
diff --git a/CHANGES.txt b/CHANGES.txt
deleted file mode 100755
index 52d2120..0000000
--- a/CHANGES.txt
+++ /dev/null
@@ -1,4455 +0,0 @@
-HBase Change Log
-Release 0.93.0 - Unreleased
-  *DO NOT ADD ISSUES HERE ON COMMIT ANY MORE.  WE'LL GENERATE THE LIST
-  FROM JIRA INSTEAD WHEN WE MAKE A RELEASE*
-
-Release 0.92.1 - Unreleased
-  BUG FIXES
-   HBASE-5176  AssignmentManager#getRegion: logging nit  adds a redundant '+' (Karthik K)
-   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-5255  Use singletons for OperationStatus to save memory (Benoit)
-   HBASE-5345  CheckAndPut doesn't work when value is empty byte[] (Evert Arckens)
-   HBASE-5466  Opening a table also opens the metatable and never closes it
-               (Ashley Taylor)
-
-  TESTS
-   HBASE-5223  TestMetaReaderEditor is missing call to CatalogTracker.stop()
-
-Release 0.92.0 - 01/23/2012
-  INCOMPATIBLE CHANGES
-   HBASE-2002  Coprocessors: Client side support; Support RPC interface
-               changes at runtime (Gary Helmling via Andrew Purtell)
-   HBASE-3677  Generate a globally unique cluster ID (changed
-               ClusterStatus serialization)
-   HBASE-3762  HTableFactory.releaseHTableInterface() should throw IOException
-               instead of wrapping in RuntimeException (Ted Yu via garyh)
-   HBASE-3629  Update our thrift to 0.6 (Moaz Reyad)
-   HBASE-1502  Remove need for heartbeats in HBase
-   HBASE-451   Remove HTableDescriptor from HRegionInfo (Subbu M Iyer)
-   HBASE-451   Remove HTableDescriptor from HRegionInfo
-               addendum that fixes TestTableMapReduce
-   HBASE-3534  Action should not store or serialize regionName (Ted Yu)
-   HBASE-4197  RegionServer expects all scanner to be subclasses of
-               HRegion.RegionScanner (Lars Hofhansl)
-   HBASE-4233  Update protobuf dependency to 2.4.0a (todd)
-   HBASE-4299  Update to Avro 1.5.3 and use Avro Maven plugin to generate
-               Avro classes. (Alejandro Abdelnur)
-   HBASE-4369  Deprecate HConnection#getZookeeperWatcher in prep for HBASE-1762
-   HBASE-4247  Add isAborted method to the Abortable interface
-               (Akash Ashok)
-   HBASE-4503  Purge deprecated HBaseClusterTestCase
-   HBASE-4374  Up default regions size from 256M to 1G
-   HBASE-4648  Bytes.toBigDecimal() doesn't use offset (Bryan Keller via Lars H)
-   HBASE-4715  Remove stale broke .rb scripts from bin dir
-   HBASE-3433  Remove the KV copy of every KV in Scan; introduced by HBASE-3232 (Lars H)
-   HBASE-5017  Bump the default hfile.block.cache.size because of HFileV2
-
-  BUG FIXES
-   HBASE-3280  YouAreDeadException being swallowed in HRS getMaster
-   HBASE-3282  Need to retain DeadServers to ensure we don't allow
-               previously expired RS instances to rejoin cluster
-   HBASE-3283  NPE in AssignmentManager if processing shutdown of RS who
-               doesn't have any regions assigned to it
-   HBASE-3173  HBase 2984 breaks ability to specify BLOOMFILTER &
-               COMPRESSION via shell
-   HBASE-3310  Failing creating/altering table with compression agrument from
-               the HBase shell (Igor Ranitovic via Stack)
-   HBASE-3317  Javadoc and Throws Declaration for Bytes.incrementBytes() is
-               Wrong (Ed Kohlwey via Stack)
-   HBASE-1888  KeyValue methods throw NullPointerException instead of
-               IllegalArgumentException during parameter sanity check
-   HBASE-3337  Restore HBCK fix of unassignment and dupe assignment for new
-               master
-   HBASE-3332  Regions stuck in transition after RS failure
-   HBASE-3418  Increment operations can break when qualifiers are split
-               between memstore/snapshot and storefiles
-   HBASE-3403  Region orphaned after failure during split
-   HBASE-3492  NPE while splitting table with empty column family store
-   HBASE-3400  Coprocessor Support for Generic Interfaces
-               (Ed Kohlwey via Gary Helmling)
-   HBASE-3552  Coprocessors are unable to load if RegionServer is launched
-               using a different classloader than system default
-   HBASE-3578  TableInputFormat does not setup the configuration for HBase
-               mapreduce jobs correctly (Dan Harvey via Stack)
-   HBASE-3601  TestMasterFailover broken in TRUNK
-   HBASE-3605  Fix balancer log message
-   HBASE-3538  Column families allow to have slashes in name (Ian Knome via Stack)
-   HBASE-3313  Table name isn't checked in isTableEnabled/isTableDisabled
-               (Ted Yu via Stack)
-   HBASE-3514  Speedup HFile.Writer append (Matteo Bertozzi via Ryan)
-   HBASE-3665  tighten assertions for testBloomFilterSize
-   HBASE-3662  REST server does not respect client supplied max versions when
-               creating scanner
-   HBASE-3641  LruBlockCache.CacheStats.getHitCount() is not using the
-               correct variable
-   HBASE-3532  HRegion#equals is broken (Ted Yu via Stack)
-   HBASE-3697  Admin actions that use MetaReader to iterate regions need to
-               skip offline ones
-   HBASE-3583  Coprocessors: scannerNext and scannerClose hooks are called
-               when HRegionInterface#get is invoked (Mingjie Lai via
-               Andrew Purtell)
-   HBASE-3688  Setters of class HTableDescriptor do not work properly
-   HBASE-3702  Fix NPE in Exec method parameter serialization
-   HBASE-3709  HFile compression not sharing configuration
-   HBASE-3711  importtsv fails if rowkey length exceeds MAX_ROW_LENGTH
-               (Kazuki Ohta via todd)
-   HBASE-3716  Intermittent TestRegionRebalancing failure
-               (Ted Yu via Stack)
-   HBASE-3712  HTable.close() doesn't shutdown thread pool
-               (Ted Yu via Stack)
-   HBASE-3238  HBase needs to have the CREATE permission on the parent of its
-               ZooKeeper parent znode (Alex Newman via Stack)
-   HBASE-3728  NPE in HTablePool.closeTablePool (Ted Yu via Stack)
-   HBASE-3733  MemStoreFlusher.flushOneForGlobalPressure() shouldn't
-               be using TreeSet for HRegion (Ted Yu via J-D)
-   HBASE-3739  HMaster.getProtocolVersion() should distinguish
-               HMasterInterface and HMasterRegionInterface versions
-   HBASE-3723  Major compact should be done when there is only one storefile
-               and some keyvalue is outdated (Zhou Shuaifeng via Stack)
-   HBASE-3624  Only one coprocessor of each priority can be loaded for a table
-   HBASE-3598  Broken formatting in LRU stats output (Erik Onnen)
-   HBASE-3758  Delete triggers pre/postScannerOpen upcalls of RegionObserver
-               (Mingjie Lai via garyh)
-   HBASE-3790  Fix NPE in ExecResult.write() with null return value
-   HBASE-3781  hbase shell cannot start "NoMethodError: undefined method
-               `close' for nil:NilClass" (Mikael Sitruk)
-   HBASE-3802  Redundant list creation in HRegion
-   HBASE-3788  Two error handlings in AssignmentManager.setOfflineInZooKeeper()
-               (Ted Yu)
-   HBASE-3800  HMaster is not able to start due to AlreadyCreatedException
-   HBASE-3806  distributed log splitting double escapes task names
-               (Prakash Khemani)
-   HBASE-3819  TestSplitLogWorker has too many SLWs running -- makes for
-               contention and occasional failures
-   HBASE-3210  HBASE-1921 for the new master
-   HBASE-3827  hbase-1502, removing heartbeats, broke master joining a running
-               cluster and was returning master hostname for rs to use
-   HBASE-3829  TestMasterFailover failures in jenkins
-   HBASE-3843  splitLogWorker starts too early (Prakash Khemani)
-   HBASE-3838  RegionCoprocesorHost.preWALRestore throws npe in case there is
-               no RegionObserver registered (Himanshu Vashishtha)
-   HBASE-3847  Turn off DEBUG logging of RPCs in WriteableRPCEngine on TRUNK
-   HBASE-3777  Redefine Identity Of HBase Configuration (Karthick Sankarachary)
-   HBASE-3849  Fix master ui; hbase-1502 broke requests/second
-   HBASE-3853  Fix TestInfoServers to pass after HBASE-3835 (todd)
-   HBASE-3862  Race conditions in aggregate calculation (John Heitmann)
-   HBASE-3865  Failing TestWALReplay
-   HBASE-3864  Rename of hfile.min.blocksize.size in HBASE-2899 reverted in
-               HBASE-1861 (Aaron T. Myers)
-   HBASE-3876  TestCoprocessorInterface.testCoprocessorInterface broke on
-               jenkins and local
-   HBASE-3897  Docs (notsoquick guide) suggest invalid XML (Philip Zeyliger)
-   HBASE-3898  TestSplitTransactionOnCluster broke in TRUNK
-   HBASE-3826  Minor compaction needs to check if still over
-               compactionThreshold after compacting (Nicolas Spiegelberg)  
-   HBASE-3912  [Stargate] Columns not handle by Scan
-   HBASE-3903  A successful write to client write-buffer may be lost or not
-               visible (Doug Meil)
-   HBASE-3894  Thread contention over row locks set monitor (Dave Latham)
-   HBASE-3959  hadoop-snappy version in the pom.xml is incorrect
-               (Alejandro Abdelnur)
-   HBASE-3971  Compression.java uses ClassLoader.getSystemClassLoader()
-               to load codec (Alejandro Abdelnur)
-   HBASE-3979  Trivial fixes in code, document (Ming Ma)
-   HBASE-3794  Ability to Discard Bad HTable Puts
-   HBASE-3923  HBASE-1502 Broke Shell's status 'simple' and 'detailed'
-   HBASE-3978  Rowlock lease renew doesn't work when custom coprocessor
-               indicates to bypass default action (Ming Ma)
-   HBASE-3963  Schedule all log-spliiting at startup all at once (mingjian)
-   HBASE-3983  list command in shell seems broken
-   HBASE-3793  HBASE-3468 Broke checkAndPut with null value (Ming Ma)
-   HBASE-3889  NPE in Distributed Log Splitting (Anirudh Todi)
-   HBASE-4000  You can't specify split points when you create a table in
-               the shell (Joey Echeverria)
-   HBASE-4029  Inappropriate checking of Logging Mode in HRegionServer
-               (Akash Ashok via Ted Yu)
-   HBASE-4037  Add timeout annotations to preempt surefire killing
-               all tests
-   HBASE-4024  Major compaction may not be triggered, even though region
-               server log says it is triggered (Ted Yu)
-   HBASE-4016  HRegion.incrementColumnValue() doesn't have a consistent
-               behavior when the field that we are incrementing is less
-               than 8 bytes long (Li Pi)
-   HBASE-4012  Further optimize byte comparison methods (Ted Yu)
-   HBASE-4037  Add timeout annotations to preempt surefire killing
-               all tests - TestFullLogReconstruction
-   HBASE-4051  [Coprocessors] Table coprocessor loaded twice when region is
-               initialized
-   HBASE-4059  If a region is split during RS shutdown process, the daughter
-               regions are NOT made online by master
-   HBASE-3904  HBA.createTable(final HTableDescriptor desc, byte [][] splitKeys)
-               should be synchronous
-   HBASE-4053  Most of the regions were added into AssignmentManager#servers twice
-   HBASE-4061  getTableDirs is missing directories to skip
-   HBASE-3867  when cluster is stopped and server which hosted meta region is
-               removed from cluster, master breaks down after restarting cluster.
-   HBASE-4074  When a RS has hostname with uppercase letter, there are two
-               RS entries in master (Weihua via Ted Yu)
-   HBASE-4077  Deadlock if WrongRegionException is thrown from getLock in
-               HRegion.delete (Adam Warrington via Ted Yu)
-   HBASE-3893  HRegion.internalObtainRowLock shouldn't wait forever
-   HBASE-4075  A bug in TestZKBasedOpenCloseRegion (Jieshan Bean via Ted Yu)
-   HBASE-4087  HBaseAdmin should perform validation of connection it holds
-   HBASE-4052  Enabling a table after master switch does not allow table scan,
-               throwing NotServingRegionException (ramkrishna via Ted Yu)
-   HBASE-4112  Creating table may throw NullPointerException (Jinchao via Ted Yu)
-   HBASE-4093  When verifyAndAssignRoot throws exception, the deadServers state
-               cannot be changed (fulin wang via Ted Yu)
-   HBASE-4118  method regionserver.MemStore#updateColumnValue: the check for 
-               qualifier and family is missing (N Keywal via Ted Yu)
-   HBASE-4127  Don't modify table's name away in HBaseAdmin
-   HBASE-4105  Stargate does not support Content-Type: application/json and
-               Content-Encoding: gzip in parallel
-   HBASE-4116  [stargate] StringIndexOutOfBoundsException in row spec parse
-               (Allan Yan)
-   HBASE-3845  data loss because lastSeqWritten can miss memstore edits
-               (Prakash Khemani and ramkrishna.s.vasudevan)
-   HBASE-4083  If Enable table is not completed and is partial, then scanning of
-               the table is not working (ramkrishna.s.vasudevan)
-   HBASE-4138  If zookeeper.znode.parent is not specifed explicitly in Client
-               code then HTable object loops continuously waiting for the root region
-               by using /hbase as the base node.(ramkrishna.s.vasudevan)
-   HBASE-4032  HBASE-451 improperly breaks public API HRegionInfo#getTableDesc
-   HBASE-4003  Cleanup Calls Conservatively On Timeout (Karthick)
-   HBASE-3857  Fix TestHFileBlock.testBlockHeapSize test failure (Mikhail)
-   HBASE-4150  Don't enforce pool size limit with ThreadLocalPool
-               (Karthick Sankarachary via garyh)
-   HBASE-4171  HBase shell broken in trunk (Lars Hofhansl)
-   HBASE-4162  Fix TestHRegionInfo.testGetSetOfHTD: delete /tmp/hbase-<username>
-               if it already exists (Mikhail Bautin)
-   HBASE-4179  Failed to run RowCounter on top of Hadoop branch-0.22
-               (Michael Weng)
-   HBASE-4181  HConnectionManager can't find cached HRegionInterface and makes clients
-               work very slow (Jia Liu)
-   HBASE-4156  ZKConfig defaults clientPort improperly (Michajlo Matijkiw)
-   HBASE-4184  CatalogJanitor doesn't work properly when "fs.default.name" isn't
-               set in config file (Ming Ma)
-   HBASE-4186  No region is added to regionsInTransitionInRS
-   HBASE-4194  RegionSplitter: Split on under-loaded region servers first
-   HBASE-2399  Forced splits only act on the first family in a table (Ming Ma)
-   HBASE-4211  Do init-sizing of the StringBuilder making a ServerName
-               (Benoît Sigoure)
-   HBASE-4175  Fix FSUtils.createTableDescriptor() (Ramkrishna)
-   HBASE-4008  Problem while stopping HBase (Akash Ashok)
-   HBASE-4065  TableOutputFormat ignores failure to create table instance
-               (Brock Noland)
-   HBASE-4167  Potential leak of HTable instances when using HTablePool with
-               PoolType.ThreadLocal (Karthick Sankarachary)
-   HBASE-4239  HBASE-4012 introduced duplicate variable Bytes.LONG_BYTES
-   HBASE-4225  NoSuchColumnFamilyException in multi doesn't say which family
-               is bad (Ramkrishna Vasudevan)
-   HBASE-4220  Lots of DNS queries from client
-   HBASE-4253  Intermittent test failure because of missing config parameter in new
-               HTable(tablename) (Ramkrishna)
-   HBASE-4217  HRS.closeRegion should be able to close regions with only
-               the encoded name (ramkrishna.s.vasudevan)
-   HBASE-3229  HBASE-3229 Table creation, though using "async" call to master,
-               can actually run for a while and cause RPC timeout (Ming Ma)
-   HBASE-4252  TestLogRolling's low-probability failure (Jieshan Bean)
-   HBASE-4278  Race condition in Slab.java that occurs due to spinlock unlocking
-               early (Li Pi)
-   HBASE-4269  Add tests and restore semantics to TableInputFormat/TableRecordReader
-               (Jonathan Hsieh)
-   HBASE-4290  HLogSplitter doesn't mark its MonitoredTask as complete in
-               non-distributed case (todd)
-   HBASE-4303  HRegionInfo.toString has bad quoting (todd)
-   HBASE-4307  race condition in CacheTestUtils (Li Pi)
-   HBASE-4310  SlabCache metrics bugfix (Li Pi)
-   HBASE-4283  HBaseAdmin never recovers from restarted cluster (Lars Hofhansl)
-   HBASE-4315  RPC logging too verbose (todd)
-   HBASE-4273  java.lang.NullPointerException when a table is being disabled and
-               HMaster restarts (Ming Ma)
-   HBASE-4027  Off Heap Cache never creates Slabs (Li Pi)
-   HBASE-4265  zookeeper.KeeperException$NodeExistsException if HMaster restarts
-               while table is being disabled (Ming Ma)
-   HBASE-4338  Package build for rpm and deb are broken (Eric Yang)
-   HBASE-4309  slow query log metrics spewing warnings (Riley Patterson)
-   HBASE-4302  Only run Snappy compression tests if Snappy is available
-               (Alejandro Abdelnur via todd)
-   HBASE-4271  Clean up coprocessor handling of table operations
-               (Ming Ma via garyh)
-   HBASE-4341  HRS#closeAllRegions should take care of HRS#onlineRegions's
-               weak consistency (Jieshan Bean)
-   HBASE-4297  TableMapReduceUtil overwrites user supplied options
-               (Jan Lukavsky)
-   HBASE-4015  Refactor the TimeoutMonitor to make it less racy
-               (ramkrishna.s.vasudevan)
-   HBASE-4350  Fix a Bloom filter bug introduced by HFile v2 and
-               TestMultiColumnScanner that caught it (Mikhail Bautin)
-   HBASE-4007  distributed log splitting can get indefinitely stuck
-               (Prakash Khemani)
-   HBASE-4301  META migration from 0.90 to trunk fails (Subbu Iyer)
-   HBASE-4331  Bypassing default actions in prePut fails sometimes with
-               HTable client (Lars Hofhansl via garyh)
-   HBASE-4340  Hbase can't balance if ServerShutdownHandler encountered
-               exception (Jinchao Gao)
-   HBASE-4394  Add support for seeking hints to FilterList
-   HBASE-4406  TestOpenRegionHandler failing after HBASE-4287 (todd)
-   HBASE-4330  Fix races in slab cache (Li Pi & Todd)
-   HBASE-4383  SlabCache reports negative heap sizes (Li Pi)
-   HBASE-4351  If from Admin we try to unassign a region forcefully,
-               though a valid region name is given the master is not able
-               to identify the region to unassign (Ramkrishna)
-   HBASE-4363  [replication] ReplicationSource won't close if failing
-               to contact the sink (JD and Lars Hofhansl)
-   HBASE-4390  [replication] ReplicationSource's UncaughtExceptionHandler
-               shouldn't join
-   HBASE-4395  EnableTableHandler races with itself
-   HBASE-4414  Region splits by size not being triggered
-   HBASE-4322  HBASE-4322 [hbck] Update checkIntegrity/checkRegionChain
-               to present more accurate region split problem 
-               (Jon Hseih)
-   HBASE-4417  HBaseAdmin.checkHBaseAvailable() doesn't close ZooKeeper connections
-               (Stefan Seelmann)
-   HBASE-4195  Possible inconsistency in a memstore read after a reseek,
-               possible performance improvement (nkeywal)
-   HBASE-4420  MasterObserver preMove() and postMove() should throw
-               IOException instead of UnknownRegionException
-   HBASE-4419  Resolve build warning messages (Praveen Patibandia)
-   HBASE-4428  Two methods in CacheTestUtils don't call setDaemon() on the threads
-   HBASE-4400  .META. getting stuck if RS hosting it is dead and znode state is in
-               RS_ZK_REGION_OPENED (Ramkrishna)
-   HBASE-3421  Very wide rows -- 30M plus -- cause us OOME (Nate Putnam)
-   HBASE-4153  Handle RegionAlreadyInTransitionException in AssignmentManager
-               (Ramkrishna)
-   HBASE-4452  Possibility of RS opening a region though tickleOpening fails due to
-               znode version mismatch (Ramkrishna)
-   HBASE-4446  Rolling restart RSs scenario, regions could stay in OPENING state
-               (Ming Ma)
-   HBASE-4468  Wrong resource name in an error massage: webapps instead of
-               hbase-webapps (nkeywal)
-   HBASE-4472  MiniHBaseCluster.shutdown() doesn't work if no active master
-   HBASE-4455  Rolling restart RSs scenario, -ROOT-, .META. regions are lost in
-               AssignmentManager (Ming Ma)
-   HBASE-4513  NOTICES.txt refers to Facebook for Thrift
-   HBASE-3130  [replication] ReplicationSource can't recover from session
-               expired on remote clusters (Chris Trezzo via JD)
-   HBASE-4212  TestMasterFailover fails occasionally (Gao Jinchao)
-   HBASE-4412  No need to retry scan operation on the same server in case of
-               RegionServerStoppedException (Ming Ma)
-   HBASE-4476  Compactions must fail if column tracker gets columns out of order
-               (Mikhail Bautin)
-   HBASE-4209  The HBase hbase-daemon.sh SIGKILLs master when stopping it
-               (Roman Shaposhnik)
-   HBASE-4496  HFile V2 does not honor setCacheBlocks when scanning (Lars and Mikhail)
-   HBASE-4531  hbase-4454 failsafe broke mvn site; back it out or fix
-               (Akash Ashok)
-   HBASE-4334  HRegion.get never validates row (Lars Hofhansl)
-   HBASE-4494  AvroServer:: get fails with NPE on a non-existent row
-               (Kay Kay)
-   HBASE-4481  TestMergeTool failed in 0.92 build 20
-   HBASE-4386  Fix a potential NPE in TaskMonitor (todd)
-   HBASE-4402  Retaining locality after restart broken
-   HBASE-4482  Race Condition Concerning Eviction in SlabCache (Li Pi)
-   HBASE-4547  TestAdmin failing in 0.92 because .tableinfo not found
-   HBASE-4540  OpenedRegionHandler is not enforcing atomicity of the operation
-               it is performing(Ram)
-   HBASE-4335  Splits can create temporary holes in .META. that confuse clients
-               and regionservers (Lars H)
-   HBASE-4555  TestShell seems passed, but actually errors seen in test output
-               file (Mingjie Lai)
-   HBASE-4582  Store.java cleanup (failing TestHeapSize and has warnings)
-   HBASE-4556  Fix all incorrect uses of InternalScanner.next(...) (Lars H)
-   HBASE-4078  Validate store files after flush/compaction
-   HBASE-3417  CacheOnWrite is using the temporary output path for block
-               names, need to use a more consistent block naming scheme (jgray)
-   HBASE-4551  Fix pom and some test cases to compile and run against
-               Hadoop 0.23 (todd)
-   HBASE-3446  ProcessServerShutdown fails if META moves, orphaning lots of
-               regions
-   HBASE-4589  CacheOnWrite broken in some cases because it can conflict
-               with evictOnClose (jgray)
-   HBASE-4579  CST.requestCompaction semantics changed, logs are now
-               spammed when too many store files
-   HBASE-4620  I broke the build when I submitted HBASE-3581 (Send length
-               of the rpc response)
-   HBASE-4621  TestAvroServer fails quite often intermittently (Akash Ashok)
-   HBASE-4378  [hbck] Does not complain about regions with startkey==endkey.
-               (Jonathan Hsieh)
-   HBASE-4459  HbaseObjectWritable code is a byte, we will eventually run out of codes
-   HBASE-4430  Disable TestSlabCache and TestSingleSizedCache temporarily to
-               see if these are cause of build box failure though all tests
-               pass (Li Pi)
-   HBASE-4510  Check and workaround usage of internal HDFS APIs in HBase
-               (Harsh)
-   HBASE-4595  HFilePrettyPrinter Scanned kv count always 0 (Matteo Bertozzi)
-   HBASE-4580  Some invalid zk nodes were created when a clean cluster restarts
-               (Gaojinchao)
-   HBASE-4588  The floating point arithmetic to validate memory allocation
-               configurations need to be done as integers (dhruba)
-   HBASE-4647  RAT finds about 40 files missing licenses
-   HBASE-4642  Add Apache License Header
-   HBASE-4591  TTL for old HLogs should be calculated from last modification time.
-   HBASE-4578  NPE when altering a table that has moving regions (gaojinchao)
-   HBASE-4070  Improve region server metrics to report loaded coprocessors to
-               master (Eugene Koontz via apurtell)
-   HBASE-3512  Shell support for listing currently loaded coprocessors (Eugene
-               Koontz via apurtell)
-   HBASE-4670  Fix javadoc warnings
-   HBASE-4367  Deadlock in MemStore flusher due to JDK internally synchronizing
-               on current thread
-   HBASE-4645  Edits Log recovery losing data across column families
-   HBASE-4634  "test.build.data" property overused leading to write data at the
-               wrong place (nkeywal)
-   HBASE-4388  Second start after migration from 90 to trunk crashes
-   HBASE-4685  TestDistributedLogSplitting.testOrphanLogCreation failing because
-               of ArithmeticException: / by zero.
-   HBASE-4300  Start of new-version master fails if old master's znode is
-               hanging around
-   HBASE-4679  Thrift null mutation error
-   HBASE-4304  requestsPerSecond counter stuck at 0 (Li Pi)
-   HBASE-4692  HBASE-4300 broke the build
-   HBASE-4641  Block cache can be mistakenly instantiated on Master (jgray)
-   HBASE-4687  regionserver may miss zk-heartbeats to master when replaying
-               edits at region open (prakash via jgray)
-   HBASE-4701  TestMasterObserver fails up on jenkins
-   HBASE-4700  TestSplitTransactionOnCluster fails on occasion when it tries
-               to move a region
-   HBASE-4613  hbase.util.Threads#threadDumpingIsAlive sleeps 1 second,
-               slowing down the shutdown by 0.5s
-   HBASE-4552  multi-CF bulk load is not atomic across column families (Jonathan Hsieh)
-   HBASE-4710  UnknownProtocolException should abort client retries
-   HBASE-4695  WAL logs get deleted before region server can fully flush
-               (gaojinchao)
-   HBASE-4708  Revert safemode related pieces of hbase-4510 (Harsh J)
-   HBASE-3515  [replication] ReplicationSource can miss a log after RS comes out of GC
-   HBASE-4713  Raise debug level to warn on ExecutionException in
-               HConnectionManager$HConnectionImplementation (Lucian George Iordache)
-   HBASE-4716  Improve locking for single column family bulk load
-   HBASE-4609  ThriftServer.getRegionInfo() is expecting old ServerName format, need to
-               use new Addressing class instead (Jonathan Gray)
-   HBASE-4719  HBase script assumes pre-Hadoop 0.21 layout of jar files
-               (Roman Shposhnik)
-   HBASE-4553  The update of .tableinfo is not atomic; we remove then rename
-   HBASE-4725  NPE in AM#updateTimers
-   HBASE-4745  LRU statistics thread should be a daemon
-   HBASE-4749  TestMasterFailover#testMasterFailoverWithMockedRITOnDeadRS
-               occasionally fails
-   HBASE-4753  org.apache.hadoop.hbase.regionserver.TestHRegionInfo#testGetSetOfHTD
-               throws NPE on trunk (nkeywal)
-   HBASE-4754  FSTableDescriptors.getTableInfoPath() should handle FileNotFoundException
-   HBASE-4740  [bulk load] the HBASE-4552 API can't tell if errors on region server are recoverable
-               (Jonathan Hsieh)
-   HBASE-4741  Online schema change doesn't return errors
-   HBASE-4734  [bulk load] Warn if bulk load directory contained no files
-   HBASE-4723  Loads of NotAllMetaRegionsOnlineException traces when starting
-               the master
-   HBASE-4511  There is data loss when master failovers
-   HBASE-4577  Region server reports storefileSizeMB bigger than
-               storefileUncompressedSizeMB (gaojinchao)
-   HBASE-4478  Improve AssignmentManager.handleRegion so that it can process certain ZK state
-               in the case of RS offline
-   HBASE-4777  Write back to client 'incompatible' if we show up with wrong version
-   HBASE-4775  Remove -ea from all but tests; enable it if you need it testing
-   HBASE-4784  Void return types not handled correctly for CoprocessorProtocol
-               methods
-   HBASE-4792  SplitRegionHandler doesn't care if it deletes the znode or not,
-               leaves the parent region stuck offline
-   HBASE-4793  HBase shell still using deprecated methods removed in HBASE-4436
-   HBASE-4801  alter_status shell prints sensible message at completion
-   HBASE-4796  Race between SplitRegionHandlers for the same region kills the master
-   HBASE-4816  Regionserver wouldn't go down because split happened exactly at same
-               time we issued bulk user region close call on our way out
-   HBASE-4815  Disable online altering by default, create a config for it
-   HBASE-4623  Remove @deprecated Scan methods in 0.90 from TRUNK and 0.92
-   HBASE-4842  [hbck] Fix intermittent failures on TestHBaseFsck.testHBaseFsck
-               (Jon Hsieh)
-   HBASE-4308  Race between RegionOpenedHandler and AssignmentManager (Ram)
-   HBASE-4857  Recursive loop on KeeperException in
-               AuthenticationTokenSecretManager/ZKLeaderManager
-   HBASE-4739  Master dying while going to close a region can leave it in transition
-               forever (Gao Jinchao)
-   HBASE-4855  SplitLogManager hangs on cluster restart due to batch.installed doubly counted
-   HBASE-4877  TestHCM failing sporadically on jenkins and always for me on an
-               ubuntu machine
-   HBASE-4878  Master crash when splitting hlog may cause data loss (Chunhui Shen)
-   HBASE-4945  NPE in HRegion.bulkLoadHFiles (Andrew P and Lars H)
-   HBASE-4942  HMaster is unable to start of HFile V1 is used (Honghua Zhu)
-   HBASE-4610  Port HBASE-3380 (Master failover can split logs of live servers) to 92/trunk
-   HBASE-4946  HTable.coprocessorExec (and possibly coprocessorProxy) does not work with
-               dynamically loaded coprocessors (Andrei Dragomir)
-   HBASE-5026  Add coprocessor hook to HRegionServer.ScannerListener.leaseExpired()
-   HBASE-4935  hbase 0.92.0 doesn't work going against 0.20.205.0, its packaged hadoop
-   HBASE-5078  DistributedLogSplitter failing to split file because it has edits for
-               lots of regions
-   HBASE-5077  SplitLogWorker fails to let go of a task, kills the RS
-   HBASE-5096  Replication does not handle deletes correctly. (Lars H)
-   HBASE-5103  Fix improper master znode deserialization (Jonathan Hsieh)
-   HBASE-5099  ZK event thread waiting for root region assignment may block server
-               shutdown handler for the region sever the root region was on (Jimmy)
-   HBASE-5100  Rollback of split could cause closed region to be opened again (Chunhui)
-   HBASE-4397  -ROOT-, .META. tables stay offline for too long in recovery phase after all RSs
-               are shutdown at the same time (Ming Ma)
-   HBASE-5094  The META can hold an entry for a region with a different server name from the one  
-               actually in the AssignmentManager thus making the region inaccessible. (Ram)
-   HBASE-5081  Distributed log splitting deleteNode races against splitLog retry (Prakash)
-   HBASE-4357  Region stayed in transition - in closing state (Ming Ma)
-   HBASE-5088  A concurrency issue on SoftValueSortedMap (Jieshan Bean and Lars H)
-   HBASE-5152  Region is on service before completing initialization when doing rollback of split,
-               it will affect read correctness (Chunhui)
-   HBASE-5137  MasterFileSystem.splitLog() should abort even if waitOnSafeMode() throws IOException(Ted)
-   HBASE-5121  MajorCompaction may affect scan's correctness (chunhui shen and Lars H)
-   HBASE-5143  Fix config typo in pluggable load balancer factory (Harsh J)
-   HBASE-5196  Failure in region split after PONR could cause region hole (Jimmy Xiang)
-
-  TESTS
-   HBASE-4450  test for number of blocks read: to serve as baseline for expected
-               blocks read and for catching regressions (Kannan)
-   HBASE-4492  TestRollingRestart fails intermittently (Ted Yu and Ram)
-   HBASE-4512  JVMClusterUtil throwing wrong exception when master thread cannot be created (Ram)
-   HBASE-4479  TestMasterFailover failure in Hbase-0.92#17(Ram)
-   HBASE-4651  ConcurrentModificationException might be thrown in
-               TestHCM.testConnectionUniqueness (Jinchao)
-   HBASE-4518  TestServerCustomProtocol fails intermittently
-   HBASE-4790  Occasional TestDistributedLogSplitting failure (Jinchao)
-   HBASE-4864  TestMasterObserver#testRegionTransitionOperations occasionally
-               fails (Gao Jinchao)
-   HBASE-4868  TestOfflineMetaRebuildBase#testMetaRebuild occasionally fails
-               (Gao Jinchao)
-   HBASE-4874  Run tests with non-secure random, some tests hang otherwise (Lars H)
-   HBASE-5112  TestReplication#queueFailover flaky due to potentially
-               uninitialized Scan (Jimmy Xiang)
-   HBASE-5113  TestDrainingServer expects round robin region assignment but misses a
-               config parameter
-   HBASE-5105  TestImportTsv failed with hadoop 0.22 (Ming Ma)
-
-  IMPROVEMENTS
-   HBASE-3290  Max Compaction Size (Nicolas Spiegelberg via Stack)  
-   HBASE-3292  Expose block cache hit/miss/evict counts into region server
-               metrics
-   HBASE-2936  Differentiate between daemon & restart sleep periods
-   HBASE-3316  Add support for Java Serialization to HbaseObjectWritable
-               (Ed Kohlwey via Stack)
-   HBASE-1861  Multi-Family support for bulk upload tools
-   HBASE-3308  SplitTransaction.splitStoreFiles slows splits a lot
-   HBASE-3328  Added Admin API to specify explicit split points
-   HBASE-3377  Upgrade Jetty to 6.1.26
-   HBASE-3393  Update Avro gateway to use Avro 1.4.1 and the new
-               server.join() method (Jeff Hammerbacher via Stack)
-   HBASE-3433  KeyValue API to explicitly distinguish between deep & shallow
-               copies
-   HBASE-3522  Unbundle our RPC versioning; rather than a global for all 4
-               Interfaces -- region, master, region to master, and
-               coprocesssors -- instead version each individually
-   HBASE-3520  Update our bundled hadoop from branch-0.20-append to latest
-               (rpc version 43)
-   HBASE-3563  [site] Add one-page-only version of hbase doc
-   HBASE-3564  DemoClient.pl - a demo client in Perl
-   HBASE-3560  the hbase-default entry of "hbase.defaults.for.version" 
-               causes tests not to run via not-maven
-   HBASE-3513  upgrade thrift to 0.5.0 and use mvn version
-   HBASE-3533  Allow HBASE_LIBRARY_PATH env var to specify extra locations
-               of native lib
-   HBASE-3631  CLONE - HBase 2984 breaks ability to specify BLOOMFILTER &
-               COMPRESSION via shell
-   HBASE-3630  DemoClient.Java is outdated (Moaz Reyed via Stack)
-   HBASE-3618  Add to HBase book, 'schema' chapter - pre-creating regions and
-               key types (Doug Meil via Stack)
-   HBASE-2495  Allow record filtering with selected row key values in HBase
-               Export (Subbu M Iyer via Stack)
-   HBASE-3440  Clean out load_table.rb and make sure all roads lead to
-               completebulkload tool (Vidhyashankar Venkataraman via Stack)
-   HBASE-3653  Parallelize Server Requests on HBase Client
-   HBASE-3657  reduce copying of HRegionInfo's (Ted Yu via Stack)
-   HBASE-3422  Balancer will try to rebalance thousands of regions in one go;
-               needs an upper bound added (Ted Yu via Stack)
-   HBASE-3676  Update region server load for AssignmentManager through
-               regionServerReport() (Ted Yu via Stack)
-   HBASE-3468  Enhance checkAndPut and checkAndDelete with comparators
-   HBASE-3683  NMapInputFormat should use a different config param for
-               number of maps
-   HBASE-3673  Reduce HTable Pool Contention Using Concurrent Collections
-               (Karthick Sankarachary via Stack)
-   HBASE-3474  HFileOutputFormat to use column family's compression algorithm
-   HBASE-3541  REST Multi Gets (Elliott Clark via Stack)
-   HBASE-3052  Add ability to have multiple ZK servers in a quorum in
-               MiniZooKeeperCluster for test writing (Liyin Tang via Stack)
-   HBASE-3693  isMajorCompaction() check triggers lots of listStatus DFS RPC
-               calls from HBase (Liyin Tang via Stack)
-   HBASE-3717  deprecate HTable isTableEnabled() methods in favor of
-               HBaseAdmin methods (David Butler via Stack)
-   HBASE-3720  Book.xml - porting conceptual-view / physical-view sections of
-               HBaseArchitecture wiki (Doug Meil via Stack)
-   HBASE-3705  Allow passing timestamp into importtsv (Andy Sautins via Stack)
-   HBASE-3715  Book.xml - adding architecture section on client, adding section
-               on spec-ex under mapreduce (Doug Meil via Stack)
-   HBASE-3684  Support column range filter (Jerry Chen via Stack)
-   HBASE-3647  Distinguish read and write request count in region
-               (Ted Yu via Stack)
-   HBASE-3704  Show per region request count in table.jsp
-               (Ted Yu via Stack)
-   HBASE-3694  high multiput latency due to checking global mem store size
-               in a synchronized function (Liyin Tang via Stack)
-   HBASE-3710  Book.xml - fill out descriptions of metrics
-               (Doug Meil via Stack)
-   HBASE-3738  Book.xml - expanding Architecture Client section
-               (Doug Meil via Stack)
-   HBASE-3587  Eliminate use of read-write lock to guard loaded
-               coprocessor collection
-   HBASE-3729  Get cells via shell with a time range predicate
-               (Ted Yu via Stack)
-   HBASE-3764  Book.xml - adding 2 FAQs (SQL and arch question)
-   HBASE-3770  Make FilterList accept var arg Filters in its constructor
-               as a convenience (Erik Onnen via Stack)
-   HBASE-3769  TableMapReduceUtil is inconsistent with other table-related
-               classes that accept byte[] as a table name (Erik Onnen via Stack)
-   HBASE-3768  Add best practice to book for loading row key only
-               (Erik Onnen via Stack)
-   HBASE-3765  metrics.xml - small format change and adding nav to hbase
-               book metrics section (Doug Meil)
-   HBASE-3759  Eliminate use of ThreadLocals for CoprocessorEnvironment
-               bypass() and complete() 
-   HBASE-3701  revisit ArrayList creation (Ted Yu via Stack)
-   HBASE-3753  Book.xml - architecture, adding more Store info (Doug Meil)
-   HBASE-3784  book.xml - adding small subsection in architecture/client on
-               filters (Doug Meil)
-   HBASE-3785  book.xml - moving WAL into architecture section, plus adding
-               more description on what it does (Doug Meil)
-   HBASE-3699  Make RegionServerServices and MasterServices extend Server
-               (Erik Onnen)
-   HBASE-3757  Upgrade to ZK 3.3.3
-   HBASE-3609  Improve the selection of regions to balance; part 2 (Ted Yu)
-   HBASE-2939  Allow Client-Side Connection Pooling (Karthik Sankarachary)
-   HBASE-3798  [REST] Allow representation to elide row key and column key
-   HBASE-3812  Tidy up naming consistency and documentation in coprocessor
-               framework (Mingjie Lai)
-   HBASE-1512  Support aggregate functions (Himanshu Vashishtha)
-   HBASE-3796  Per-Store Enties in Compaction Queue
-   HBASE-3670  Fix error handling in get(List<Get> gets)
-               (Harsh J Chouraria)
-   HBASE-3835  Switch master and region server pages to Jamon-based templates
-   HBASE-3721  Speedup LoadIncrementalHFiles (Ted Yu)
-   HBASE-3855  Performance degradation of memstore because reseek is linear
-               (dhruba borthakur)
-   HBASE-3797  StoreFile Level Compaction Locking
-   HBASE-1476  Multithreaded Compactions
-   HBASE-3877  Determine Proper Defaults for Compaction ThreadPools
-   HBASE-3880  Make mapper function in ImportTSV plug-able (Bill Graham)
-   HBASE-2938  HBASE-2938 Add Thread-Local Behavior To HTable Pool
-               (Karthick Sankarachary)
-   HBASE-3811  Allow adding attributes to Scan (Alex Baranau)
-   HBASE-3841  HTable and HTableInterface docs are inconsistent with
-               one another (Harsh J Chouraria)
-   HBASE-2937  Facilitate Timeouts In HBase Client (Karthick Sankarachary)
-   HBASE-3921  Allow adding arbitrary blobs to Put (dhruba borthakur)
-   HBASE-3931  Allow adding attributes to Get
-   HBASE-3942  The thrift scannerOpen functions should support row caching
-               (Adam Worthington)
-   HBASE-2556  Add convenience method to HBaseAdmin to get a collection of
-               HRegionInfo objects for each table (Ming Ma)
-   HBASE-3952  Guava snuck back in as a dependency via hbase-3777
-   HBASE-3808  Implement Executor.toString for master handlers at least
-               (Brock Noland)
-   HBASE-3873  Mavenize Hadoop Snappy JAR/SOs project dependencies
-               (Alejandro Abdelnur)
-   HBASE-3941  "hbase version" command line should print version info
-               (Jolly Chen)
-   HBASE-3961  Add Delete.setWriteToWAL functionality (Bruno Dumon)
-   HBASE-3928  Some potential performance improvements to Bytes/KeyValue
-   HBASE-3982  Improvements to TestHFileSeek
-   HBASE-3940  HBase daemons should log version info at startup and possibly
-               periodically (Li Pi)
-   HBASE-3789  Cleanup the locking contention in the master
-   HBASE-3927  Display total uncompressed byte size of a region in web UI
-   HBASE-4011  New MasterObserver hook: post startup of active master
-   HBASE-3994  SplitTransaction has a window where clients can
-               get RegionOfflineException
-   HBASE-4010  HMaster.createTable could be heavily optimized
-   HBASE-3506  Ability to disable, drop and enable tables using regex expression
-               (Joey Echeverria via Ted Yu)
-   HBASE-3516  Coprocessors: add test cases for loading coprocessor jars
-               (Mingjie Lai via garyh)
-   HBASE-4036  Implementing a MultipleColumnPrefixFilter (Anirudh Todi)
-   HBASE-4048  [Coprocessors] Support configuration of coprocessor at load time
-   HBASE-3240  Improve documentation of importtsv and bulk loads.
-               (Aaron T. Myers via todd)
-   HBASE-4054  Usability improvement to HTablePool (Daniel Iancu)
-   HBASE-4079  HTableUtil - helper class for loading data (Doug Meil via Ted Yu)
-   HBASE-3871  Speedup LoadIncrementalHFiles by parallelizing HFile splitting
-   HBASE-4081  Issues with HRegion.compactStores methods (Ming Ma)
-   HBASE-3465  Hbase should use a HADOOP_HOME environment variable if available
-               (Alejandro Abdelnur)
-   HBASE-3899  enhance HBase RPC to support free-ing up server handler threads
-               even if response is not ready (Vlad Dogaru)
-   HBASE-4142  Advise against large batches in javadoc for HTable#put(List<Put>)
-   HBASE-4139  [stargate] Update ScannerModel with support for filter package
-               additions
-   HBASE-1938  Make in-memory table scanning faster (nkeywal)
-   HBASE-4143  HTable.doPut(List) should check the writebuffer length every so often
-               (Doug Meil via Ted Yu)
-   HBASE-3065  Retry all 'retryable' zk operations; e.g. connection loss (Liyin Tang)
-   HBASE-3810  Registering a coprocessor in HTableDescriptor should be easier
-               (Mingjie Lai via garyh)
-   HBASE-4158  Upgrade pom.xml to surefire 2.9 (Aaron Kushner & Mikhail)
-   HBASE-3899  Add ability for delayed RPC calls to set return value
-               immediately at call return. (Vlad Dogaru via todd)
-   HBASE-4169  FSUtils LeaseRecovery for non HDFS FileSystems (Lohit Vijayarenu)
-   HBASE-3807  Fix units in RS UI metrics (subramanian raghunathan)
-   HBASE-4193  Enhance RPC debug logging to provide more details on
-               call contents
-   HBASE-4190  Coprocessors: pull up some cp constants from cp package to
-               o.a.h.h.HConstants (Mingjie Lai)
-   HBASE-4227  Modify the webUI so that default values of column families are
-               not shown (Nileema Shingte)
-   HBASE-4229  Replace Jettison JSON encoding with Jackson in HLogPrettyPrinter
-               (Riley Patterson)
-   HBASE-4230  Compaction threads need names
-   HBASE-4236  Don't lock the stream while serializing the response (Benoit Sigoure)
-   HBASE-4237  Directly remove the call being handled from the map of outstanding RPCs
-               (Benoit Sigoure)
-   HBASE-4199  blockCache summary - backend (Doug Meil)
-   HBASE-4240  Allow Loadbalancer to be pluggable
-   HBASE-4244  Refactor bin/hbase help
-   HBASE-4241  Optimize flushing of the Memstore (Lars Hofhansl)
-   HBASE-4248  Enhancements for Filter Language exposing HBase filters through
-               the Thrift API (Anirudh Todi)
-   HBASE-3900  Expose progress of a major compaction in UI and/or in shell
-               (Brad Anderson)
-   HBASE-4291  Improve display of regions in transition in UI to be more
-               readable (todd)
-   HBASE-4281  Add facility to dump current state of all executors (todd)
-   HBASE-4275  RS should communicate fatal "aborts" back to the master (todd)
-   HBASE-4263  New config property for user-table only RegionObservers
-               (Lars Hofhansl)
-   HBASE-4257  Limit the number of regions in transitions displayed on
-               master webpage. (todd)
-   HBASE-1730  Online Schema Changes
-   HBASE-4206  jenkins hash implementation uses longs unnecessarily
-               (Ron Yang)
-   HBASE-3842  Refactor Coprocessor Compaction API
-   HBASE-4312  Deploy new hbase logo
-   HBASE-4327  Compile HBase against hadoop 0.22 (Joep Rottinghuis)
-   HBASE-4339  Improve eclipse documentation and project file generation
-               (Eric Charles)
-   HBASE-4342  Update Thrift to 0.7.0 (Moaz Reyad)
-   HBASE-4260  Expose a command to manually trigger an HLog roll
-               (ramkrishna.s.vasudevan)
-   HBASE-4347  Remove duplicated code from Put, Delete, Get, Scan, MultiPut
-               (Lars Hofhansl)
-   HBASE-4359  Show dead RegionServer names in the HMaster info page
-               (Harsh J)
-   HBASE-4287  If region opening fails, change region in transition into
-               a FAILED_OPEN state so that it can be retried quickly. (todd)
-   HBASE-4381  Refactor split decisions into a split policy class. (todd)
-   HBASE-4373  HBaseAdmin.assign() does not use force flag (Ramkrishna)
-   HBASE-4425  Provide access to RpcServer instance from RegionServerServices
-   HBASE-4411  When copying tables/CFs, allow CF names to be changed
-               (David Revell)
-   HBASE-4424  Provide coprocessors access to createTable() via 
-               MasterServices
-   HBASE-4432  Enable/Disable off heap cache with config (Li Pi)
-   HBASE-4434  seek optimization: don't do eager HFile Scanner
-               next() unless the next KV is needed
-               (Kannan Muthukkaruppan)
-   HBASE-4280  [replication] ReplicationSink can deadlock itself via handlers
-   HBASE-4014  Coprocessors: Flag the presence of coprocessors in logged
-               exceptions (Eugene Koontz)
-   HBASE-4449  LoadIncrementalHFiles should be able to handle CFs with blooms
-               (David Revell)
-   HBASE-4454  Add failsafe plugin to build and rename integration tests
-               (Jesse Yates)
-   HBASE-4499  [replication] Source shouldn't update ZK if it didn't progress
-               (Chris Trezzo via JD)
-   HBASE-2794  Utilize ROWCOL bloom filter if multiple columns within same family
-               are requested in a Get (Mikhail Bautin)
-   HBASE-4487  The increment operation can release the rowlock before sync-ing
-               the Hlog (dhruba borthakur)
-   HBASE-4526  special case for stopping master in hbase-daemon.sh is no longer
-               required (Roman Shaposhnik)
-   HBASE-4520  Better handling of Bloom filter type discrepancy between HFile
-               and CF config (Mikhail Bautin)
-   HBASE-4558  Refactor TestOpenedRegionHandler and TestOpenRegionHandler.(Ram)
-   HBASE-4558  Addendum for TestMasterFailover (Ram) - Breaks the build
-   HBASE-4568  Make zk dump jsp response faster
-   HBASE-4606  Remove spam in HCM and fix a list.size == 0
-   HBASE-3581  hbase rpc should send size of response
-   HBASE-4585  Avoid seek operation when current kv is deleted(Liyin Tang)
-   HBASE-4486  Improve Javadoc for HTableDescriptor (Akash Ashok)
-   HBASE-4604  hbase.client.TestHTablePool could start a single
-               cluster instead of one per method (nkeywal)
-   HBASE-3929  Add option to HFile tool to produce basic stats (Matteo
-               Bertozzi and todd via todd)
-   HBASE-4694  Some cleanup of log messages in RS and M
-   HBASE-4603  Uneeded sleep time for tests in
-               hbase.master.ServerManager#waitForRegionServers (nkeywal)
-   HBASE-4703  Improvements in tests (nkeywal)
-   HBASE-4611  Add support for Phabricator/Differential as an alternative code review tool
-   HBASE-3939  Some crossports of Hadoop IPC fixes
-   HBASE-4756  Enable tab-completion in HBase shell (Ryan Thiessen)
-   HBASE-4759  Migrate from JUnit 4.8.2 to JUnit 4.10 (nkeywal)
-   HBASE-4554  Allow set/unset coprocessor table attributes from shell
-               (Mingjie Lai)
-   HBASE-4779  TestHTablePool, TestScanWithBloomError, TestRegionSplitCalculator are
-               not tagged and TestPoolMap should not use TestSuite (N Keywal)
-   HBASE-4805  Allow better control of resource consumption in HTable (Lars H)
-   HBASE-4903  Return a result from RegionObserver.preIncrement
-               (Daniel Gómez Ferro via Lars H)
-   HBASE-4683  Always cache index and bloom blocks
-
-  TASKS
-   HBASE-3559  Move report of split to master OFF the heartbeat channel
-   HBASE-3573  Move shutdown messaging OFF hearbeat; prereq for fix of
-               hbase-1502
-   HBASE-3071  Graceful decommissioning of a regionserver
-   HBASE-3970  Address HMaster crash/failure half way through meta migration
-               (Subbu M Iyer)
-   HBASE-4013  Make ZooKeeperListener Abstract (Akash Ashok via Ted Yu)
-   HBASE-4025  Server startup fails during startup due to failure in loading
-               all table descriptors. (Subbu Iyer via Ted Yu)
-   HBASE-4017  BlockCache interface should be truly modular (Li Pi)
-   HBASE-4152  Rename o.a.h.h.regionserver.wal.WALObserver to
-               o.a.h.h.regionserver.wal.WALActionsListener
-   HBASE-4039  Users should be able to choose custom TableInputFormats without
-               modifying TableMapReduceUtil.initTableMapperJob() (Brock Noland)
-   HBASE-4185  Add doc for new hfilev2 format
-   HBASE-4315  RS requestsPerSecond counter seems to be off (subramanian raghunathan)
-   HBASE-4289  Move spinlock to SingleSizeCache rather than the slab allocator
-               (Li Pi)
-   HBASE-4296  Deprecate HTable[Interface].getRowOrBefore(...) (Lars Hofhansl)
-   HBASE-2195  Support cyclic replication (Lars Hofhansl)
-   HBASE-2196  Support more than one slave cluster (Lars Hofhansl)
-   HBASE-4429  Provide synchronous balanceSwitch()
-   HBASE-4437  Update hadoop in 0.92 (0.20.205?)
-   HBASE-4656  Note how dfs.support.append has to be enabled in 0.20.205.0
-               clusters
-   HBASE-4699  Cleanup the UIs
-   HBASE-4552  Remove trivial 0.90 deprecated code from 0.92 and trunk.
-               (Jonathan Hsieh)
-   HBASE-4714  Don't ship w/ icms enabled by default
-   HBASE-4747  Upgrade maven surefire plugin to 2.10
-   HBASE-4288  "Server not running" exception during meta verification causes RS abort
-   HBASE-4856  Upgrade zookeeper to 3.4.0 release
-   HBASE-5111  Upgrade zookeeper to 3.4.2 release
-   HBASE-5125  Upgrade hadoop to 1.0.0
-
-  NEW FEATURES
-   HBASE-2001  Coprocessors: Colocate user code with regions (Mingjie Lai via
-               Andrew Purtell)
-   HBASE-3287  Add option to cache blocks on hfile write and evict blocks on
-               hfile close
-   HBASE-3335  Add BitComparator for filtering (Nathaniel Cook via Stack)
-   HBASE-3260  Coprocessors: Add explicit lifecycle management
-   HBASE-3256  Coprocessors: Coprocessor host and observer for HMaster
-   HBASE-3345  Coprocessors: Allow observers to completely override base
-               function
-   HBASE-2824  A filter that randomly includes rows based on a configured
-               chance (Ferdy via Andrew Purtell)
-   HBASE-3455  Add memstore-local allocation buffers to combat heap
-               fragmentation in the region server. Enabled by default as of
-               0.91
-   HBASE-3257  Coprocessors: Extend server side API to include HLog operations
-               (Mingjie Lai via Andrew Purtell)
-   HBASE-3606  Create an package integration project (Eric Yang via Ryan)
-   HBASE-3488  Add CellCounter to count multiple versions of rows
-               (Subbu M. Iyer via Stack)
-   HBASE-1364  [performance] Distributed splitting of regionserver commit logs
-               (Prakash Khemani)
-   HBASE-3836  Add facility to track currently progressing actions and
-               workflows. (todd)
-   HBASE-3837  Show regions in transition on the master web page (todd)
-   HBASE-3839  Add monitoring of currently running tasks to the master and
-               RS web UIs
-   HBASE-3691  Add compressor support for 'snappy', google's compressor
-               (Nichole Treadway and Nicholas Telford)
-   HBASE-2233  Support both Hadoop 0.20 and 0.22
-   HBASE-3857  Change the HFile Format (Mikhail & Liyin)
-   HBASE-4114  Metrics for HFile HDFS block locality (Ming Ma)
-   HBASE-4176  Exposing HBase Filters to the Thrift API (Anirudh Todi)
-   HBASE-4221  Changes necessary to build and run against Hadoop 0.23
-               (todd)
-   HBASE-4071  Data GC: Remove all versions > TTL EXCEPT the last
-               written version (Lars Hofhansl)
-   HBASE-4242  Add documentation for HBASE-4071 (Lars Hofhansl)
-   HBASE-4027  Enable direct byte buffers LruBlockCache (Li Pi)
-   HBASE-4117  Slow Query Log and Client Operation Fingerprints
-               (Riley Patterson)
-   HBASE-4292  Add a debugging dump servlet to the master and regionserver
-               (todd)
-   HBASE-4057  Implement HBase version of "show processlist" (Riley Patterson)
-   HBASE-4219  Per Column Family Metrics
-   HBASE-4219  Addendum for failure of TestHFileBlock
-   HBASE-4377  [hbck] Offline rebuild .META. from fs data only
-               (Jonathan Hsieh)
-   HBASE-4298  Support to drain RS nodes through ZK (Aravind Gottipati)
-   HBASE-2742  Provide strong authentication with a secure RPC engine
-   HBASE-3025  Coprocessor based access control
-
-Release 0.90.7 - Unreleased
-
-  BUG FIXES
-   HBASE-5271  Result.getValue and Result.getColumnLatest return the wrong column (Ghais Issa)
-
-Release 0.90.6 - Unreleased
-
-  BUG FIXES
-   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-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-5327  Print a message when an invalid hbase.rootdir is passed (Jimmy Xiang)
-
-Release 0.90.5 - Released
-
-  BUG FIXES
-   HBASE-4160  HBase shell move and online may be unusable if region name
-               or server includes binary-encoded data (Jonathan Hsieh)
-   HBASE-4168  A client continues to try and connect to a powered down
-               regionserver (Anirudh Todi)
-   HBASE-4196  TableRecordReader may skip first row of region (Ming Ma)
-   HBASE-4170  createTable java doc needs to be improved (Mubarak Seyed)
-   HBASE-4144  RS does not abort if the initialization of RS fails
-               (ramkrishna.s.vasudevan)
-   HBASE-4148  HFileOutputFormat doesn't fill in TIMERANGE_KEY metadata
-               (Jonathan Hsieh)
-   HBASE-4159  HBaseServer - IPC Reader threads are not daemons (Douglas
-               Campbell)
-   HBASE-4095  Hlog may not be rolled in a long time if checkLowReplication's
-               request of LogRoll is blocked (Jieshan Bean)
-   HBASE-4253  TestScannerTimeOut.test3686a and TestHTablePool.
-               testReturnDifferentTable() failure because of using new
-               HTable(tablename) (ramkrishna.s.vasudevan)
-   HBASE-4124  ZK restarted while a region is being assigned, new active HM
-               re-assigns it but the RS warns 'already online on this server'
-               (Gaojinchao)
-   HBASE-4294  HLogSplitter sleeps with 1-second granularity (todd)
-   HBASE-4270  IOE ignored during flush-on-close causes dataloss
-   HBASE-4180  HBase should check the isSecurityEnabled flag before login
-   HBASE-4325  Improve error message when using STARTROW for meta scans
-               (Jonathan Hsieh)
-   HBASE-4238  CatalogJanitor can clear a daughter that split before
-               processing its parent
-   HBASE-4445  Not passing --config when checking if distributed mode or not
-   HBASE-4453  TestReplication failing up on builds.a.o because already
-               running zk with new format root servername
-   HBASE-4387  Error while syncing: DFSOutputStream is closed
-               (Lars Hofhansl)
-   HBASE-4295  rowcounter does not return the correct number of rows in
-               certain circumstances (David Revell)
-   HBASE-4515  User.getCurrent() can fail to initialize the current user
-   HBASE-4473  NPE when executors are down but events are still coming in
-   HBASE-4537  TestUser imports breaking build against secure Hadoop
-   HBASE-4501  [replication] Shutting down a stream leaves recovered
-               sources running
-   HBASE-4563  When error occurs in this.parent.close(false) of split,
-               the split region cannot write or read (bluedavy via Lars H)
-   HBASE-4570. Fix a race condition that could cause inconsistent results
-               from scans during concurrent writes. (todd and Jonathan Jsieh
-               via todd)
-   HBASE-4562  When split doing offlineParentInMeta encounters error, it'll
-               cause data loss (bluedavy via Lars H)
-   HBASE-4800  Result.compareResults is incorrect (James Taylor and Lars H)
-   HBASE-4848  TestScanner failing because hostname can't be null
-   HBASE-4862  Splitting hlog and opening region concurrently may cause data loss
-               (Chunhui Shen)
-   HBASE-4773  HBaseAdmin may leak ZooKeeper connections (Xufeng)
-
-  IMPROVEMENT
-   HBASE-4205  Enhance HTable javadoc (Eric Charles)
-   HBASE-4222  Make HLog more resilient to write pipeline failures
-   HBASE-4293  More verbose logging in ServerShutdownHandler for meta/root
-               cases (todd)
-   HBASE-4276  AssignmentManager debug logs should be at INFO level for
-               META/ROOT regions (todd)
-   HBASE-4323  Add debug logging when AssignmentManager can't make a plan
-               for a region (todd)
-   HBASE-4313  Refactor TestHBaseFsck to make adding individual hbck tests
-               easier (Jonathan Hsieh)
-   HBASE-4272. Add -metaonly flag to hbck feature to only inspect and try
-               to repair META and ROOT. (todd)
-   HBASE-4321. Add a more comprehensive region split calculator for future use
-               in hbck. (Jonathan Hsieh)
-   HBASE-4384  Hard to tell what causes failure in CloseRegionHandler#getCurrentVersion
-               (Harsh J)
-   HBASE-4375  [hbck] Add region coverage visualization to hbck
-               (Jonathan Hsieh)
-   HBASE-4506  [hbck] Allow HBaseFsck to be instantiated without connecting
-               (Jonathan Hsieh)
-   HBASE-4509  [hbck] Improve region map output
-               (Jonathan Hsieh)
-   HBASE-4806  Fix logging message in HbaseObjectWritable
-               (Jonathan Hsieh via todd)
-
-Release 0.90.4 - August 10, 2011
-
-  BUG FIXES
-   HBASE-3878  Hbase client throws NoSuchElementException (Ted Yu)
-   HBASE-3881  Add disable balancer in graceful_stop.sh script
-   HBASE-3895  Fix order of parameters after HBASE-1511
-   HBASE-3874  ServerShutdownHandler fails on NPE if a plan has a random
-               region assignment
-   HBASE-3902  Add Bytes.toBigDecimal and Bytes.toBytes(BigDecimal)
-               (Vaibhav Puranik)
-   HBASE-3820  Splitlog() executed while the namenode was in safemode may
-               cause data-loss (Jieshan Bean)
-   HBASE-3905  HBaseAdmin.createTableAsync() should check for invalid split
-               keys (Ted Yu)
-   HBASE-3908  TableSplit not implementing "hashCode" problem (Daniel Iancu)
-   HBASE-3915  Binary row keys in hbck and other miscellaneous binary key
-               display issues
-   HBASE-3914  ROOT region appeared in two regionserver's onlineRegions at
-               the same time (Jieshan Bean)
-   HBASE-3934  MemStoreFlusher.getMemStoreLimit() doesn't honor defaultLimit
-               (Ted Yu)
-   HBASE-3946  The splitted region can be online again while the standby
-               hmaster becomes the active one (Jieshan Bean)
-   HBASE-3916  Fix the default bind address of ThriftServer to be wildcard
-               instead of localhost. (Li Pi)
-   HBASE-3985  Same Region could be picked out twice in LoadBalance
-               (Jieshan Bean)
-   HBASE-3987  Fix a NullPointerException on a failure to load Bloom filter data
-               (Mikhail Bautin)
-   HBASE-3948  Improve split/compact result page for RegionServer status page
-               (Li Pi)
-   HBASE-3988  Infinite loop for secondary master (Liyin Tang)
-   HBASE-3995  HBASE-3946 broke TestMasterFailover
-   HBASE-2077  NullPointerException with an open scanner that expired causing
-               an immediate region server shutdown -- part 2.
-   HBASE-4005  close_region bugs
-   HBASE-4028  Hmaster crashes caused by splitting log.
-               (gaojinchao via Ted Yu)
-   HBASE-4035  Fix local-master-backup.sh - parameter order wrong
-               (Lars George via Ted Yu)
-   HBASE-4020  "testWritesWhileGetting" unit test needs to be fixed.
-               (Vandana Ayyalasomayajula via Ted Yu)
-   HBASE-3984  CT.verifyRegionLocation isn't doing a very good check,
-               can delay cluster recovery
-   HBASE-4045  [replication] NPE in ReplicationSource when ZK is gone
-   HBASE-4034  HRegionServer should be stopped even if no META regions
-               are hosted by the HRegionServer (Akash Ashok)
-   HBASE-4033  The shutdown RegionServer could be added to
-               AssignmentManager.servers again (Jieshan Bean)
-   HBASE-4088  npes in server shutdown
-   HBASE-3872  Hole in split transaction rollback; edits to .META. need
-               to be rolled back even if it seems like they didn't make it
-   HBASE-4101  Regionserver Deadlock (ramkrishna.s.vasudevan)
-   HBASE-4115  HBase shell assign and unassign unusable if region name
-               includes binary-encoded data (Ryan Brush)
-   HBASE-4126  Make timeoutmonitor timeout after 30 minutes instead of 3
-   HBASE-4129  HBASE-3872 added a warn message 'CatalogJanitor: Daughter regiondir
-               does not exist' that is triggered though its often legit that daughter
-               is not present
-
-  IMPROVEMENT
-   HBASE-3882  hbase-config.sh needs to be updated so it can auto-detects the
-               sun jre provided by RHEL6 (Roman Shaposhnik)
-   HBASE-3920  HLog hbase.regionserver.flushlogentries no longer supported
-               (Dave Latham)
-   HBASE-3919  More places output binary data to text (Dave Latham)
-   HBASE-3873  HBase IRB shell: Don't pretty-print the output when stdout
-               isn't a TTY (Benoît Sigoure)
-   HBASE-3969  Outdated data can not be cleaned in time (Zhou Shuaifeng)
-   HBASE-3968  HLog Pretty Printer (Riley Patterson)
-
-Release 0.90.3 - May 19th, 2011
-
-  BUG FIXES
-   HBASE-3746  Clean up CompressionTest to not directly reference
-               DistributedFileSystem (todd)
-   HBASE-3734  HBaseAdmin creates new configurations in getCatalogTracker
-   HBASE-3756  Can't move META or ROOT from shell
-   HBASE-3740  hbck doesn't reset the number of errors when retrying
-   HBASE-3744  createTable blocks until all regions are out of transition
-               (Ted Yu via Stack)
-   HBASE-3750  HTablePool.putTable() should call releaseHTableInterface()
-               for discarded tables (Ted Yu via garyh)
-   HBASE-3755  Catch zk's ConnectionLossException and augment error
-               message with more help
-   HBASE-3722  A lot of data is lost when name node crashed (gaojinchao)
-   HBASE-3771  All jsp pages don't clean their HBA
-   HBASE-3685  when multiple columns are combined with TimestampFilter, only
-               one column is returned (Jerry Chen)
-   HBASE-3708  createAndFailSilent is not so silent; leaves lots of logging
-               in ensemble logs (Dmitriy Ryaboy)
-   HBASE-3783  hbase-0.90.2.jar exists in hbase root and in 'lib/'
-   HBASE-3539  Improve shell help to reflect all possible options
-               (Harsh J Chouraria)
-   HBASE-3817  HBase Shell has an issue accepting FILTER for the 'scan' command.
-               (Harsh J Chouraria)
-   HBASE-3634  Fix JavaDoc for put(List<Put> puts) in HTableInterface
-               (Harsh J Chouraria)
-   HBASE-3749  Master can't exit when open port failed (gaojinchao)
-   HBASE-3794  TestRpcMetrics fails on machine where region server is running
-               (Alex Newman)
-   HBASE-3741  Make HRegionServer aware of the regions it's opening/closing
-   HBASE-3597  ageOfLastAppliedOp should update after cluster replication
-               failures
-   HBASE-3821  "NOT flushing memstore for region" keep on printing for half
-               an hour (zhoushuaifeng)
-
-  IMPROVEMENTS
-   HBASE-3747  ReplicationSource should differanciate remote and local exceptions
-   HBASE-3652  Speed up tests by lowering some sleeps
-   HBASE-3767  Improve how HTable handles threads used for multi actions
-   HBASE-3795  Remove the "Cache hit for row" message
-   HBASE-3580  Remove RS from DeadServer when new instance checks in
-   HBASE-2470  Add Scan.setTimeRange() support in Shell (Harsh J Chouraria)
-   HBASE-3805  Log RegionState that are processed too late in the master
-   HBASE-3695  Some improvements to Hbck to test the entire region chain in
-                Meta and provide better error reporting (Marc Limotte)
-   HBASE-3813  Change RPC callQueue size from 'handlerCount *
-               MAX_QUEUE_SIZE_PER_HANDLER;'
-   HBASE-3860  HLog shouldn't create a new HBC when rolling
-
-  TASKS
-   HBASE-3748  Add rolling of thrift/rest daemons to graceful_stop.sh script
-   HBASE-3846  Set RIT timeout higher
-
-Release 0.90.2 - 20110408
-  
-  BUG FIXES
-   HBASE-3545  Possible liveness issue with MasterServerAddress in
-               HRegionServer getMaster (Greg Bowyer via Stack)
-   HBASE-3548  Fix type in documentation of pseudo distributed mode
-   HBASE-3553  HTable ThreadPoolExecutor does not properly initialize
-               for hbase.htable.threads.max threads
-               (Himanshu Vashishtha via garyh)
-   HBASE-3566  writeToWAL is not serialized for increment operation
-   HBASE-3576  MasterAddressTracker is registered to ZooKeeperWatcher twice
-   HBASE-3561  OPTS arguments are duplicated
-   HBASE-3572  memstore lab can leave half inited data structs (bad!)
-   HBASE-3589  test jar should not include mapred-queues.xml and
-               log4j.properties
-   HBASE-3593  DemoClient.cpp is outdated
-   HBASE-3591  completebulkload doesn't honor generic -D options
-   HBASE-3594  Rest server fails because of missing asm jar
-   HBASE-3582  Allow HMaster and HRegionServer to login from keytab
-               when on secure Hadoop
-   HBASE-3608  MemstoreFlusher error message doesnt include exception!
-   HBASE-1960  Master should wait for DFS to come up when creating
-               hbase.version; use alternate strategy for waiting for DNs
-   HBASE-3612  HBaseAdmin::isTableAvailable returns true when the table does
-               not exit
-   HBASE-3626  Update instructions in thrift demo files (Moaz Reyad via Stack)
-   HBASE-3633  ZKUtil::createSetData should only create a node when it
-               nonexists (Guanpeng Xu via Stack)
-   HBASE-3636  a bug about deciding whether this key is a new key for the ROWCOL
-               bloomfilter (Liyin Tang via Stack)
-   HBASE-3639  FSUtils.getRootDir should qualify path
-   HBASE-3648  [replication] failover is sloppy with znodes
-   HBASE-3613  NPE in MemStoreFlusher
-   HBASE-3650  HBA.delete can return too fast
-   HBASE-3659  Fix TestHLog to pass on newer versions of Hadoop
-   HBASE-3595  get_counter broken in shell
-   HBASE-3664  [replication] Adding a slave when there's none may kill the cluster
-   HBASE-3671  Split report before we finish parent region open; workaround
-               till 0.92; Race between split and OPENED processing
-   HBASE-3674  Treat ChecksumException as we would a ParseException splitting
-               logs; else we replay split on every restart
-   HBASE-3621  The timeout handler in AssignmentManager does an RPC while
-               holding lock on RIT; a big no-no (Ted Yu via Stack)
-   HBASE-3575  Update rename table script
-   HBASE-3687  Bulk assign on startup should handle a ServerNotRunningException
-   HBASE-3617  NoRouteToHostException during balancing will cause Master abort
-               (Ted Yu via Stack)
-   HBASE-3668  CatalogTracker.waitForMeta can wait forever and totally stall a RS
-   HBASE-3627  NPE in EventHandler when region already reassigned
-   HBASE-3660  HMaster will exit when starting with stale data in cached locations
-               such as -ROOT- or .META.
-   HBASE-3654  Weird blocking between getOnlineRegion and createRegionLoad
-               (Subbu M Iyer via Stack)
-   HBASE-3666  TestScannerTimeout fails occasionally
-   HBASE-3497  TableMapReduceUtil.initTableReducerJob broken due to setConf 
-               method in TableOutputFormat
-   HBASE-3686  ClientScanner skips too many rows on recovery if using scanner
-               caching (Sean Sechrist via Stack)
-
-  IMPROVEMENTS
-   HBASE-3542  MultiGet methods in Thrift
-   HBASE-3586  Improve the selection of regions to balance (Ted Yu via Andrew
-               Purtell)  
-   HBASE-3603  Remove -XX:+HeapDumpOnOutOfMemoryError autodump of heap option
-               on OOME
-   HBASE-3285  Hlog recovery takes too much time
-   HBASE-3623  Allow non-XML representable separator characters in the ImportTSV tool
-               (Harsh J Chouraria via Stack)
-   HBASE-3620  Make HBCK utility faster
-   HBASE-3625  improve/fix support excluding Tests via Maven -D property
-               (Alejandro Abdelnur via todd)
-   HBASE-3437  Support Explict Split Points from the Shell
-   HBASE-3448  RegionSplitter, utility class to manually split tables
-   HBASE-3610  Improve RegionSplitter performance
-   HBASE-3496  HFile CLI Improvements
-   HBASE-3596  [replication] Wait a few seconds before transferring queues
-   HBASE-3600  Update our jruby to 1.6.0
-   HBASE-3640  [replication] Transferring queues shouldn't be done inline with RS startup
-   HBASE-3658  Alert when heap is over committed (Subbu M Iyer via Stack)
-   HBASE-3681  Check the sloppiness of the region load before balancing (Ted Yu via JD)
-   HBASE-3703  hbase-config.sh needs to be updated so it can auto-detect
-               the sun jdk provided by RHEL6 (Bruno Mahe via todd)
-
-Release 0.90.1 - February 9th, 2011
-
-  NEW FEATURES
-   HBASE-3455  Add memstore-local allocation buffers to combat heap
-               fragmentation in the region server. Experimental / disabled
-               by default in 0.90.1
-  
-  BUG FIXES
-   HBASE-3445  Master crashes on data that was moved from different host
-   HBASE-3449  Server shutdown handlers deadlocked waiting for META
-   HBASE-3456  Fix hardcoding of 20 second socket timeout down in HBaseClient
-   HBASE-3476  HFile -m option need not scan key values
-               (Prakash Khemani via Lars George)
-   HBASE-3481  max seq id in flushed file can be larger than its correct value 
-               causing data loss during recovery
-   HBASE-3493  HMaster sometimes hangs during initialization due to missing
-               notify call (Bruno Dumon via Stack)
-   HBASE-3483  Memstore lower limit should trigger asynchronous flushes
-   HBASE-3494  checkAndPut implementation doesnt verify row param and writable 
-               row are the same
-   HBASE-3416  For intra-row scanning, the update readers notification resets
-               the query matcher and can lead to incorrect behavior
-   HBASE-3495  Shell is failing on subsequent split calls
-   HBASE-3502  Can't open region because can't open .regioninfo because
-               AlreadyBeingCreatedException
-   HBASE-3501  Remove the deletion limit in LogCleaner
-   HBASE-3500  Documentation update for replicatio
-   HBASE-3419  If re-transition to OPENING during log replay fails, server
-               aborts. Instead, should just cancel region open.
-   HBASE-3524  NPE from CompactionChecker
-   HBASE-3531  When under global memstore pressure, dont try to flush
-               unflushable regions.
-   HBASE-3550  FilterList reports false positives (Bill Graham via Andrew
-               Purtell)
-
-  IMPROVEMENTS
-   HBASE-3305  Allow round-robin distribution for table created with
-               multiple regions (ted yu via jgray)
-   HBASE-3508  LruBlockCache statistics thread should have a name
-   HBASE-3511  Allow rolling restart to apply to only RS or only masters
-   HBASE-3510  Add thread name for IPC reader threads
-   HBASE-3509  Add metric for flush queue length
-   HBASE-3517  Store build version in hbase-default.xml and verify at runtime
-
-Release 0.90.0 - January 19th, 2011
-  INCOMPATIBLE CHANGES
-   HBASE-1822  Remove the deprecated APIs
-   HBASE-1848  Fixup shell for HBASE-1822
-   HBASE-1854  Remove the Region Historian
-   HBASE-1930  Put.setTimeStamp misleading (doesn't change timestamp on
-               existing KeyValues, not copied in copy constructor)
-               (Dave Latham via Stack)
-   HBASE-1360  move up to Thrift 0.2.0 (Kay Kay and Lars Francke via Stack)
-   HBASE-2212  Refactor out lucene dependencies from HBase
-               (Kay Kay via Stack)
-   HBASE-2219  stop using code mapping for method names in the RPC
-   HBASE-1728  Column family scoping and cluster identification
-   HBASE-2099  Move build to Maven (Paul Smith via Stack)
-   HBASE-2260  Remove all traces of Ant and Ivy (Lars Francke via Stack)
-   HBASE-2255  take trunk back to hadoop 0.20
-   HBASE-2378  Bulk insert with multiple reducers broken due to improper
-               ImmutableBytesWritable comparator (Todd Lipcon via Stack)
-   HBASE-2392  Upgrade to ZooKeeper 3.3.0
-   HBASE-2294  Enumerate ACID properties of HBase in a well defined spec
-               (Todd Lipcon via Stack)
-   HBASE-2541  Remove transactional contrib (Clint Morgan via Stack)
-   HBASE-2542  Fold stargate contrib into core
-   HBASE-2565  Remove contrib module from hbase
-   HBASE-2397  Bytes.toStringBinary escapes printable chars
-   HBASE-2771  Update our hadoop jar to be latest from 0.20-append branch
-   HBASE-2803  Remove remaining Get code from Store.java,etc
-   HBASE-2553  Revisit IncrementColumnValue implementation in 0.22
-   HBASE-2692  Master rewrite and cleanup for 0.90
-               (Karthik Ranganathan, Jon Gray & Stack)
-   HBASE-2961  Close zookeeper when done with it (HCM, Master, and RS)
-   HBASE-2641  HBASE-2641 Refactor HLog splitLog, hbase-2437 continued;
-               break out split code as new classes
-               (James Kennedy via Stack)
-
-  BUG FIXES
-   HBASE-1791  Timeout in IndexRecordWriter (Bradford Stephens via Andrew
-               Purtell)
-   HBASE-1737  Regions unbalanced when adding new node (recommit)
-   HBASE-1792  [Regression] Cannot save timestamp in the future
-   HBASE-1793  [Regression] HTable.get/getRow with a ts is broken
-   HBASE-1698  Review documentation for o.a.h.h.mapreduce
-   HBASE-1798  [Regression] Unable to delete a row in the future
-   HBASE-1790  filters are not working correctly (HBASE-1710 HBASE-1807 too)
-   HBASE-1779  ThriftServer logged error if getVer() result is empty
-   HBASE-1778  Improve PerformanceEvaluation (Schubert Zhang via Stack)
-   HBASE-1751  Fix KeyValue javadoc on getValue for client-side
-   HBASE-1795  log recovery doesnt reset the max sequence id, new logfiles can
-               get tossed as 'duplicates'
-   HBASE-1794  recovered log files are not inserted into the storefile map
-   HBASE-1824  [stargate] default timestamp should be LATEST_TIMESTAMP
-   HBASE-1740  ICV has a subtle race condition only visible under high load
-   HBASE-1808  [stargate] fix how columns are specified for scanners
-   HBASE-1828  CompareFilters are broken from client-side
-   HBASE-1836  test of indexed hbase broken
-   HBASE-1838  [javadoc] Add javadoc to Delete explaining behavior when no
-               timestamp provided
-   HBASE-1821  Filtering by SingleColumnValueFilter bug
-   HBASE-1840  RowLock fails when used with IndexTable
-               (Keith Thomas via Stack)
-   HBASE-818   HFile code review and refinement (Schubert Zhang via Stack)
-   HBASE-1830  HbaseObjectWritable methods should allow null HBCs
-               for when Writable is not Configurable (Stack via jgray)
-   HBASE-1847  Delete latest of a null qualifier when non-null qualifiers
-               exist throws a RuntimeException 
-   HBASE-1850  src/examples/mapred do not compile after HBASE-1822
-   HBASE-1853  Each time around the regionserver core loop, we clear the
-               messages to pass master, even if we failed to deliver them
-   HBASE-1815  HBaseClient can get stuck in an infinite loop while attempting
-               to contact a failed regionserver
-   HBASE-1856  HBASE-1765 broke MapReduce when using Result.list()
-               (Lars George via Stack)
-   HBASE-1857  WrongRegionException when setting region online after .META.
-               split (Cosmin Lehane via Stack)
-   HBASE-1809  NPE thrown in BoundedRangeFileInputStream
-   HBASE-1859  Misc shell fixes patch (Kyle Oba via Stack)
-   HBASE-1865  0.20.0 TableInputFormatBase NPE
-   HBASE-1866  Scan(Scan) copy constructor does not copy value of
-               cacheBlocks
-   HBASE-1869  IndexedTable delete fails when used in conjunction with
-               RowLock (Keith Thomas via Stack)
-   HBASE-1858  Master can't split logs created by THBase (Clint Morgan via
-               Andrew Purtell)
-   HBASE-1871  Wrong type used in TableMapReduceUtil.initTableReduceJob()
-               (Lars George via Stack)
-   HBASE-1883  HRegion passes the wrong minSequenceNumber to
-               doReconstructionLog (Clint Morgan via Stack)
-   HBASE-1878  BaseScanner results can't be trusted at all (Related to
-               hbase-1784)
-   HBASE-1831  Scanning API must be reworked to allow for fully functional
-               Filters client-side
-   HBASE-1890  hbase-1506 where assignment is done at regionserver doesn't
-               work
-   HBASE-1889  ClassNotFoundException on trunk for REST
-   HBASE-1905  Remove unused config. hbase.hstore.blockCache.blockSize
-   HBASE-1906  FilterList of prefix and columnvalue not working properly with
-               deletes and multiple values
-   HBASE-1896  WhileMatchFilter.reset should call encapsulated filter reset
-   HBASE-1912  When adding a secondary index to an existing table, it will
-               cause NPE during re-indexing (Mingjui Ray Liao via Andrew
-               Purtell)
-   HBASE-1916  FindBugs and javac warnings cleanup
-   HBASE-1908  ROOT not reassigned if only one regionserver left
-   HBASE-1915  HLog.sync is called way too often, needs to be only called one
-               time per RPC
-   HBASE-1777  column length is not checked before saved to memstore
-   HBASE-1925  IllegalAccessError: Has not been initialized (getMaxSequenceId)
-   HBASE-1929  If hbase-default.xml is not in CP, zk session timeout is 10
-               seconds!
-   HBASE-1927  Scanners not closed properly in certain circumstances
-   HBASE-1934  NullPointerException in ClientScanner (Andrew Purtell via Stack)
-   HBASE-1946  Unhandled exception at regionserver (Dmitriy Lyfar via Stack)
-   HBASE-1682  IndexedRegion does not properly handle deletes
-               (Andrew McCall via Clint Morgan and Stack)
-   HBASE-1953  Overhaul of overview.html (html fixes, typos, consistency) -
-               no content changes (Lars Francke via Stack)
-   HBASE-1954  Transactional scans do not see newest put (Clint Morgan via
-               Stack)
-   HBASE-1919  code: HRS.delete seems to ignore exceptions it shouldnt
-   HBASE-1951  Stack overflow when calling HTable.checkAndPut() 
-               when deleting a lot of values
-   HBASE-1781  Weird behavior of WildcardColumnTracker.checkColumn(), 
-               looks like recursive loop
-   HBASE-1949  KeyValue expiration by Time-to-Live during major compaction is
-               broken (Gary Helmling via Stack)
-   HBASE-1957  Get-s can't set a Filter
-   HBASE-1928  ROOT and META tables stay in transition state (making the system
-               not usable) if the designated regionServer dies before the
-               assignment is complete (Yannis Pavlidis via Stack)
-   HBASE-1962  Bulk loading script makes regions incorrectly (loadtable.rb)
-   HBASE-1966  Apply the fix from site/ to remove the forrest dependency on
-               Java 5
-   HBASE-1967  [Transactional] client.TestTransactions.testPutPutScan fails
-               sometimes -- Temporary fix
-   HBASE-1841  If multiple of same key in an hfile and they span blocks, may
-               miss the earlier keys on a lookup
-               (Schubert Zhang via Stack)
-   HBASE-1977  Add ts and allow setting VERSIONS when scanning in shell
-   HBASE-1979  MurmurHash does not yield the same results as the reference C++
-               implementation when size % 4 >= 2 (Olivier Gillet via Andrew
-               Purtell)
-   HBASE-1999  When HTable goes away, close zk session in shutdown hook or
-               something...
-   HBASE-1997  zk tick time bounds maximum zk session time
-   HBASE-2003  [shell] deleteall ignores column if specified
-   HBASE-2018  Updates to .META. blocked under high MemStore load
-   HBASE-1994  Master will lose hlog entries while splitting if region has
-               empty oldlogfile.log (Lars George via Stack)
-   HBASE-2022  NPE in housekeeping kills RS
-   HBASE-2034  [Bulk load tools] loadtable.rb calls an undefined method
-               'descendingIterator' (Ching-Shen Chen via Stack)
-   HBASE-2033  Shell scan 'limit' is off by one
-   HBASE-2040  Fixes to group commit
-   HBASE-2047  Example command in the "Getting Started" 
-               documentation doesn't work (Benoit Sigoure via JD)
-   HBASE-2048  Small inconsistency in the "Example API Usage"
-               (Benoit Sigoure via JD)
-   HBASE-2044  HBASE-1822 removed not-deprecated APIs
-   HBASE-1960  Master should wait for DFS to come up when creating
-               hbase.version
-   HBASE-2054  memstore size 0 is >= than blocking -2.0g size
-   HBASE-2064  Cannot disable a table if at the same the Master is moving 
-               its regions around
-   HBASE-2065  Cannot disable a table if any of its region is opening 
-               at the same time
-   HBASE-2026  NPE in StoreScanner on compaction
-   HBASE-2072  fs.automatic.close isn't passed to FileSystem
-   HBASE-2075  Master requires HDFS superuser privileges due to waitOnSafeMode
-   HBASE-2077  NullPointerException with an open scanner that expired causing 
-               an immediate region server shutdown (Sam Pullara via JD)
-   HBASE-2078  Add JMX settings as commented out lines to hbase-env.sh
-               (Lars George via JD)
-   HBASE-2082  TableInputFormat is ignoring input scan's stop row setting
-               (Scott Wang via Andrew Purtell)
-   HBASE-2068  MetricsRate is missing "registry" parameter
-               (Lars George and Gary Helmling via Stack)
-   HBASE-2093  [stargate] RowSpec parse bug
-   HBASE-2114  Can't start HBase in trunk (JD and Kay Kay via JD)
-   HBASE-2115  ./hbase shell would not launch due to missing jruby dependency
-               (Kay Kay via JD)
-   HBASE-2101  KeyValueSortReducer collapses all values to last passed
-   HBASE-2119  Fix top-level NOTICES.txt file. Its stale.
-   HBASE-2120  [stargate] Unable to delete column families (Greg Lu via Andrew
-               Purtell)
-   HBASE-2123  Remove 'master' command-line option from PE
-   HBASE-2024  [stargate] Deletes not working as expected (Greg Lu via Andrew
-               Purtell)
-   HBASE-2122  [stargate] Initializing scanner column families doesn't work
-               (Greg Lu via Andrew Purtell)
-   HBASE-2124  Useless exception in HMaster on startup
-   HBASE-2127  randomWrite mode of PerformanceEvaluation benchmark program
-               writes only to a small range of keys (Kannan Muthukkaruppan
-               via Stack)
-   HBASE-2126  Fix build break - ec2 (Kay Kay via JD)
-   HBASE-2134  Ivy nit regarding checking with latest snapshots (Kay Kay via
-               Andrew Purtell)
-   HBASE-2138  unknown metrics type (Stack via JD)
-   HBASE-2137  javadoc warnings from 'javadoc' target (Kay Kay via Stack)
-   HBASE-2135  ant javadoc complains about missing classe (Kay Kay via Stack)
-   HBASE-2130  bin/* scripts - not to include lib/test/**/*.jar
-               (Kay Kay via Stack)
-   HBASE-2140  findbugs issues - 2 performance warnings as suggested by
-               findbugs (Kay Kay via Stack)
-   HBASE-2139  findbugs task in build.xml (Kay Kay via Stack)
-   HBASE-2147  run zookeeper in the same jvm as master during non-distributed
-               mode
-   HBASE-65    Thrift Server should have an option to bind to ip address
-               (Lars Francke via Stack)
-   HBASE-2146  RPC related metrics are missing in 0.20.3 since recent changes
-               (Gary Helmling via Lars George)
-   HBASE-2150  Deprecated HBC(Configuration) constructor doesn't call this()
-   HBASE-2154  Fix Client#next(int) javadoc
-   HBASE-2152  Add default jmxremote.{access|password} files into conf
-               (Lars George and Gary Helmling via Stack)
-   HBASE-2156  HBASE-2037 broke Scan - only a test for trunk
-   HBASE-2057  Cluster won't stop (Gary Helmling and JD via JD)
-   HBASE-2160  Can't put with ts in shell
-   HBASE-2144  Now does \x20 for spaces
-   HBASE-2163  ZK dependencies - explicitly add them until ZK artifacts are
-               published to mvn repository (Kay Kay via Stack)
-   HBASE-2164  Ivy nit - clean up configs (Kay Kay via Stack)
-   HBASE-2184  Calling HTable.getTableDescriptor().* on a full cluster takes
-               a long time (Cristian Ivascu via Stack)
-   HBASE-2193  Better readability of - hbase.regionserver.lease.period
-               (Kay Kay via Stack)
-   HBASE-2199  hbase.client.tableindexed.IndexSpecification, lines 72-73
-               should be reversed (Adrian Popescu via Stack)
-   HBASE-2224  Broken build: TestGetRowVersions.testGetRowMultipleVersions
-   HBASE-2129  ant tar build broken since switch to Ivy (Kay Kay via Stack)
-   HBASE-2226  HQuorumPeerTest doesnt run because it doesnt start with the
-               word Test
-   HBASE-2230  SingleColumnValueFilter has an ungaurded debug log message
-   HBASE-2258  The WhileMatchFilter doesn't delegate the call to filterRow()
-   HBASE-2259  StackOverflow in ExplicitColumnTracker when row has many columns
-   HBASE-2268  [stargate] Failed tests and DEBUG output is dumped to console
-               since move to Mavenized build 
-   HBASE-2276  Hbase Shell hcd() method is broken by the replication scope 
-               parameter (Alexey Kovyrin via Lars George)
-   HBASE-2244  META gets inconsistent in a number of crash scenarios
-   HBASE-2284  fsWriteLatency metric may be incorrectly reported 
-               (Kannan Muthukkaruppan via Stack)
-   HBASE-2063  For hfileoutputformat, on timeout/failure/kill clean up
-               half-written hfile (Ruslan Salyakhov via Stack)
-   HBASE-2281  Hbase shell does not work when started from the build dir
-               (Alexey Kovyrin via Stack)
-   HBASE-2293  CME in RegionManager#isMetaServer
-   HBASE-2261  The javadoc in WhileMatchFilter and it's tests in TestFilter
-               are not accurate/wrong
-   HBASE-2299  [EC2] mapreduce fixups for PE
-   HBASE-2295  Row locks may deadlock with themselves
-               (dhruba borthakur via Stack)
-   HBASE-2308  Fix the bin/rename_table.rb script, make it work again
-   HBASE-2307  hbase-2295 changed hregion size, testheapsize broke... fix it
-   HBASE-2269  PerformanceEvaluation "--nomapred" may assign duplicate random
-               seed over multiple testing threads (Tatsuya Kawano via Stack) 
-   HBASE-2287  TypeError in shell (Alexey Kovyrin via Stack)
-   HBASE-2023  Client sync block can cause 1 thread of a multi-threaded client
-               to block all others (Karthik Ranganathan via Stack)
-   HBASE-2305  Client port for ZK has no default (Suraj Varma via Stack)
-   HBASE-2323  filter.RegexStringComparator does not work with certain bytes
-               (Benoit Sigoure via Stack)
-   HBASE-2313  Nit-pick about hbase-2279 shell fixup, if you do get wi

<TRUNCATED>