001/**
002 * Licensed to the Apache Software Foundation (ASF) under one
003 * or more contributor license agreements.  See the NOTICE file
004 * distributed with this work for additional information
005 * regarding copyright ownership.  The ASF licenses this file
006 * to you under the Apache License, Version 2.0 (the
007 * "License"); you may not use this file except in compliance
008 * with the License.  You may obtain a copy of the License at
009 *
010 *     http://www.apache.org/licenses/LICENSE-2.0
011 *
012 * Unless required by applicable law or agreed to in writing, software
013 * distributed under the License is distributed on an "AS IS" BASIS,
014 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
015 * See the License for the specific language governing permissions and
016 * limitations under the License.
017 */
018package org.apache.hadoop.hbase.regionserver;
019
020import java.io.IOException;
021import org.apache.hadoop.hbase.HBaseClassTestRule;
022import org.apache.hadoop.hbase.HBaseTestingUtility;
023import org.apache.hadoop.hbase.TableName;
024import org.apache.hadoop.hbase.client.Durability;
025import org.apache.hadoop.hbase.client.Put;
026import org.apache.hadoop.hbase.testclassification.LargeTests;
027import org.apache.hadoop.hbase.testclassification.VerySlowRegionServerTests;
028import org.apache.hadoop.hbase.util.Bytes;
029import org.apache.hadoop.hbase.wal.WAL;
030import org.apache.hadoop.hbase.wal.WALFactory;
031import org.junit.Assert;
032import org.junit.ClassRule;
033import org.junit.Test;
034import org.junit.experimental.categories.Category;
035import org.slf4j.Logger;
036import org.slf4j.LoggerFactory;
037
038
039/**
040 * A test similar to TestHRegion, but with in-memory flush families.
041 * Also checks wal truncation after in-memory compaction.
042 */
043@Category({VerySlowRegionServerTests.class, LargeTests.class})
044@SuppressWarnings("deprecation")
045public class TestHRegionWithInMemoryFlush extends TestHRegion {
046
047  @ClassRule
048  public static final HBaseClassTestRule CLASS_RULE =
049      HBaseClassTestRule.forClass(TestHRegionWithInMemoryFlush.class);
050
051  // Do not spin up clusters in here. If you need to spin up a cluster, do it
052  // over in TestHRegionOnCluster.
053  private static final Logger LOG = LoggerFactory.getLogger(TestHRegionWithInMemoryFlush.class);
054
055  /**
056   * @return A region on which you must call
057   *         {@link HBaseTestingUtility#closeRegionAndWAL(HRegion)} when done.
058   */
059  @Override
060  public HRegion initHRegion(TableName tableName, byte[] startKey, byte[] stopKey,
061      boolean isReadOnly, Durability durability, WAL wal, byte[]... families) throws IOException {
062    boolean[] inMemory = new boolean[families.length];
063    for(int i = 0; i < inMemory.length; i++) {
064      inMemory[i] = true;
065    }
066    return TEST_UTIL.createLocalHRegionWithInMemoryFlags(tableName, startKey, stopKey,
067        isReadOnly, durability, wal, inMemory, families);
068  }
069
070  /**
071   * A test case of HBASE-21041
072   * @throws Exception Exception
073   */
074  @Override
075  @Test
076  public void testFlushAndMemstoreSizeCounting() throws Exception {
077    byte[] family = Bytes.toBytes("family");
078    this.region = initHRegion(tableName, method, CONF, family);
079    final WALFactory wals = new WALFactory(CONF, method);
080    int count = 0;
081    try {
082      for (byte[] row : HBaseTestingUtility.ROWS) {
083        Put put = new Put(row);
084        put.addColumn(family, family, row);
085        region.put(put);
086        //In memory flush every 1000 puts
087        if (count++ % 1000 == 0) {
088          ((CompactingMemStore) (region.getStore(family).memstore))
089              .flushInMemory();
090        }
091      }
092      region.flush(true);
093      // After flush, data size should be zero
094      Assert.assertEquals(0, region.getMemStoreDataSize());
095      // After flush, a new active mutable segment is created, so the heap size
096      // should equal to MutableSegment.DEEP_OVERHEAD
097      Assert.assertEquals(MutableSegment.DEEP_OVERHEAD, region.getMemStoreHeapSize());
098      // After flush, offheap size should be zero
099      Assert.assertEquals(0, region.getMemStoreOffHeapSize());
100
101    } finally {
102      HBaseTestingUtility.closeRegionAndWAL(this.region);
103      this.region = null;
104      wals.close();
105    }
106  }
107}
108