public static class IntegrationTestBigLinkedList.Verify.VerifyReducer extends org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable>
Modifier and Type | Field and Description |
---|---|
private org.apache.hadoop.hbase.client.Connection |
connection |
private org.apache.hadoop.io.BytesWritable |
LOSTFAM |
private ArrayList<byte[]> |
refs |
private AtomicInteger |
rows |
private org.apache.hadoop.io.BytesWritable |
UNREF |
Constructor and Description |
---|
VerifyReducer() |
Modifier and Type | Method and Description |
---|---|
static byte[] |
addPrefixFlag(int ordinal,
byte[] r) |
protected void |
cleanup(org.apache.hadoop.mapreduce.Reducer.Context context) |
private StringBuilder |
dumpExtraInfoOnRefs(org.apache.hadoop.io.BytesWritable key,
org.apache.hadoop.mapreduce.Reducer.Context context,
List<byte[]> refs)
Dump out extra info around references if there are any.
|
static byte[] |
getRowOnly(org.apache.hadoop.io.BytesWritable bw) |
void |
reduce(org.apache.hadoop.io.BytesWritable key,
Iterable<org.apache.hadoop.io.BytesWritable> values,
org.apache.hadoop.mapreduce.Reducer.Context context) |
protected void |
setup(org.apache.hadoop.mapreduce.Reducer.Context context) |
static IntegrationTestBigLinkedList.Verify.Counts |
whichType(byte[] bs) |
private final org.apache.hadoop.io.BytesWritable UNREF
private final org.apache.hadoop.io.BytesWritable LOSTFAM
private AtomicInteger rows
private org.apache.hadoop.hbase.client.Connection connection
public VerifyReducer()
protected void setup(org.apache.hadoop.mapreduce.Reducer.Context context) throws IOException, InterruptedException
setup
in class org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable>
IOException
InterruptedException
protected void cleanup(org.apache.hadoop.mapreduce.Reducer.Context context) throws IOException, InterruptedException
cleanup
in class org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable>
IOException
InterruptedException
public static byte[] addPrefixFlag(int ordinal, byte[] r)
ordinal
- r
- ordinal
as prefix on front taking up
Bytes.SIZEOF_SHORT bytes followed by r
public static IntegrationTestBigLinkedList.Verify.Counts whichType(byte[] bs)
bs
- addPrefixFlag(int, byte[])
public static byte[] getRowOnly(org.apache.hadoop.io.BytesWritable bw)
bw
- public void reduce(org.apache.hadoop.io.BytesWritable key, Iterable<org.apache.hadoop.io.BytesWritable> values, org.apache.hadoop.mapreduce.Reducer.Context context) throws IOException, InterruptedException
reduce
in class org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable>
IOException
InterruptedException
private StringBuilder dumpExtraInfoOnRefs(org.apache.hadoop.io.BytesWritable key, org.apache.hadoop.mapreduce.Reducer.Context context, List<byte[]> refs) throws IOException
IOException
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.