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.conf.Configuration;
022import org.apache.hadoop.hbase.HBaseClassTestRule;
023import org.apache.hadoop.hbase.HBaseTestingUtility;
024import org.apache.hadoop.hbase.TableName;
025import org.apache.hadoop.hbase.client.Durability;
026import org.apache.hadoop.hbase.client.Put;
027import org.apache.hadoop.hbase.testclassification.LargeTests;
028import org.apache.hadoop.hbase.testclassification.VerySlowRegionServerTests;
029import org.apache.hadoop.hbase.util.Bytes;
030import org.apache.hadoop.hbase.wal.WAL;
031import org.apache.hadoop.hbase.wal.WALFactory;
032import org.junit.Assert;
033import org.junit.ClassRule;
034import org.junit.Test;
035import org.junit.experimental.categories.Category;
036import org.slf4j.Logger;
037import org.slf4j.LoggerFactory;
038
039/**
040 * A test similar to TestHRegion, but with in-memory flush families. Also checks wal truncation
041 * 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 {@link HBaseTestingUtility#closeRegionAndWAL(HRegion)}
057   *         when done.
058   */
059  @Override
060  public HRegion initHRegion(TableName tableName, byte[] startKey, byte[] stopKey,
061    Configuration conf, boolean isReadOnly, Durability durability, WAL wal, byte[]... families)
062    throws IOException {
063    boolean[] inMemory = new boolean[families.length];
064    for (int i = 0; i < inMemory.length; i++) {
065      inMemory[i] = true;
066    }
067    ChunkCreator.initialize(MemStoreLAB.CHUNK_SIZE_DEFAULT, false, 0, 0, 0, null,
068      MemStoreLAB.INDEX_CHUNK_SIZE_PERCENTAGE_DEFAULT);
069    return TEST_UTIL.createLocalHRegionWithInMemoryFlags(tableName, startKey, stopKey, conf,
070      isReadOnly, durability, wal, inMemory, families);
071  }
072
073  @Override
074  int getTestCountForTestWritesWhileScanning() {
075    return 10;
076  }
077
078  /**
079   * testWritesWhileScanning is flakey when called out of this class. Need to dig in. Meantime go
080   * easy on it. See if that helps.
081   */
082  @Override
083  int getNumQualifiersForTestWritesWhileScanning() {
084    return 10;
085  }
086
087  /**
088   * A test case of HBASE-21041
089   * @throws Exception Exception
090   */
091  @Override
092  @Test
093  public void testFlushAndMemstoreSizeCounting() throws Exception {
094    byte[] family = Bytes.toBytes("family");
095    this.region = initHRegion(tableName, method, CONF, family);
096    final WALFactory wals = new WALFactory(CONF, method);
097    int count = 0;
098    try {
099      for (byte[] row : HBaseTestingUtility.ROWS) {
100        Put put = new Put(row);
101        put.addColumn(family, family, row);
102        region.put(put);
103        // In memory flush every 1000 puts
104        if (count++ % 1000 == 0) {
105          ((CompactingMemStore) (region.getStore(family).memstore)).flushInMemory();
106        }
107      }
108      region.flush(true);
109      // After flush, data size should be zero
110      Assert.assertEquals(0, region.getMemStoreDataSize());
111      // After flush, a new active mutable segment is created, so the heap size
112      // should equal to MutableSegment.DEEP_OVERHEAD
113      Assert.assertEquals(MutableSegment.DEEP_OVERHEAD, region.getMemStoreHeapSize());
114      // After flush, offheap size should be zero
115      Assert.assertEquals(0, region.getMemStoreOffHeapSize());
116
117    } finally {
118      HBaseTestingUtility.closeRegionAndWAL(this.region);
119      this.region = null;
120      wals.close();
121    }
122  }
123}