public class TestChangingEncoding extends Object
Modifier and Type | Field and Description |
---|---|
(package private) static String |
CF |
(package private) static byte[] |
CF_BYTES |
static HBaseClassTestRule |
CLASS_RULE |
private static org.apache.hadoop.conf.Configuration |
conf |
private static List<org.apache.hadoop.hbase.io.encoding.DataBlockEncoding> |
ENCODINGS_TO_ITERATE |
private org.apache.hadoop.hbase.HColumnDescriptor |
hcd |
private static org.slf4j.Logger |
LOG |
private static int |
NUM_COLS_PER_ROW |
private static int |
NUM_ROWS_PER_BATCH |
private int |
numBatchesWritten
A zero-based index of the current batch of test data being written
|
private org.apache.hadoop.hbase.TableName |
tableName |
private static HBaseTestingUtility |
TEST_UTIL |
private static int |
TIMEOUT_MS |
Constructor and Description |
---|
TestChangingEncoding() |
Modifier and Type | Method and Description |
---|---|
private void |
compactAndWait() |
private static List<org.apache.hadoop.hbase.io.encoding.DataBlockEncoding> |
createEncodingsToIterate() |
private static byte[] |
getQualifier(int j) |
private static byte[] |
getRowKey(int batchId,
int i) |
private static byte[] |
getValue(int batchId,
int i,
int j) |
private void |
prepareTest(String testId) |
private void |
setEncodingConf(org.apache.hadoop.hbase.io.encoding.DataBlockEncoding encoding,
boolean onlineChange) |
static void |
setUpBeforeClass() |
static void |
tearDownAfterClass() |
void |
testChangingEncoding() |
void |
testChangingEncodingWithCompaction() |
void |
testCrazyRandomChanges() |
private void |
verifyAllData() |
(package private) static void |
verifyTestDataBatch(org.apache.hadoop.hbase.TableName tableName,
int batchId) |
private void |
writeSomeNewData() |
(package private) static void |
writeTestDataBatch(org.apache.hadoop.hbase.TableName tableName,
int batchId) |
public static final HBaseClassTestRule CLASS_RULE
private static final org.slf4j.Logger LOG
static final String CF
static final byte[] CF_BYTES
private static final int NUM_ROWS_PER_BATCH
private static final int NUM_COLS_PER_ROW
private static final HBaseTestingUtility TEST_UTIL
private static final org.apache.hadoop.conf.Configuration conf
private static final int TIMEOUT_MS
private org.apache.hadoop.hbase.HColumnDescriptor hcd
private org.apache.hadoop.hbase.TableName tableName
private static final List<org.apache.hadoop.hbase.io.encoding.DataBlockEncoding> ENCODINGS_TO_ITERATE
private int numBatchesWritten
public TestChangingEncoding()
private static final List<org.apache.hadoop.hbase.io.encoding.DataBlockEncoding> createEncodingsToIterate()
private void prepareTest(String testId) throws IOException
IOException
public static void setUpBeforeClass() throws Exception
Exception
public static void tearDownAfterClass() throws Exception
Exception
private static byte[] getRowKey(int batchId, int i)
private static byte[] getQualifier(int j)
private static byte[] getValue(int batchId, int i, int j)
static void writeTestDataBatch(org.apache.hadoop.hbase.TableName tableName, int batchId) throws Exception
Exception
static void verifyTestDataBatch(org.apache.hadoop.hbase.TableName tableName, int batchId) throws Exception
Exception
private void writeSomeNewData() throws Exception
Exception
private void verifyAllData() throws Exception
Exception
private void setEncodingConf(org.apache.hadoop.hbase.io.encoding.DataBlockEncoding encoding, boolean onlineChange) throws Exception
Exception
public void testChangingEncoding() throws Exception
Exception
public void testChangingEncodingWithCompaction() throws Exception
Exception
private void compactAndWait() throws IOException, InterruptedException
IOException
InterruptedException
public void testCrazyRandomChanges() throws Exception
Exception
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.