static class IntegrationTestBigLinkedList.Generator.GeneratorMapper extends org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.NullWritable,org.apache.hadoop.io.NullWritable,org.apache.hadoop.io.NullWritable>
[ . . . ] represents one batch of random longs of length WIDTH
                _________________________
               |                  ______ |
               |                 |      ||
             .-+-----------------+-----.||
             | |                 |     |||
 first   = [ . . . . . . . . . . . ]   |||
             ^ ^ ^ ^ ^ ^ ^ ^ ^ ^ ^     |||
             | | | | | | | | | | |     |||
 prev    = [ . . . . . . . . . . . ]   |||
             ^ ^ ^ ^ ^ ^ ^ ^ ^ ^ ^     |||
             | | | | | | | | | | |     |||
 current = [ . . . . . . . . . . . ]   |||
                                       |||
 ...                                   |||
                                       |||
 last    = [ . . . . . . . . . . . ]   |||
             ^ ^ ^ ^ ^ ^ ^ ^ ^ ^ ^_____|||
             |                 |________||
             |___________________________|
 | Modifier and Type | Class and Description | 
|---|---|
static class  | 
IntegrationTestBigLinkedList.Generator.GeneratorMapper.ConcurrentWalker  | 
class  | 
IntegrationTestBigLinkedList.Generator.GeneratorMapper.ContinuousConcurrentWalker
Randomly selects and walks a random flushed loop concurrently with the Generator Mapper by
 spawning ConcurrentWalker's with specified StartNodes. 
 | 
| Modifier and Type | Field and Description | 
|---|---|
(package private) byte[] | 
bigValue  | 
(package private) org.apache.hadoop.conf.Configuration | 
conf  | 
(package private) org.apache.hadoop.hbase.client.Connection | 
connection  | 
(package private) long | 
count  | 
(package private) byte[][] | 
current  | 
(package private) byte[][] | 
first  | 
(package private) List<Long> | 
flushedLoops  | 
(package private) int | 
i  | 
(package private) byte[] | 
id  | 
(package private) boolean | 
multipleUnevenColumnFamilies  | 
(package private) org.apache.hadoop.hbase.client.BufferedMutator | 
mutator  | 
(package private) long | 
numNodes  | 
(package private) int | 
numWalkers  | 
(package private) byte[][] | 
prev  | 
(package private) byte[] | 
tinyValue  | 
(package private) List<Thread> | 
walkers  | 
(package private) boolean | 
walkersStop  | 
(package private) int | 
width  | 
(package private) long | 
wrap  | 
| Constructor and Description | 
|---|
GeneratorMapper()  | 
| Modifier and Type | Method and Description | 
|---|---|
private void | 
addFlushed(byte[] rowKey)  | 
private static <T> void | 
circularLeftShift(T[] first)  | 
protected void | 
cleanup(org.apache.hadoop.mapreduce.Mapper.Context context)  | 
protected void | 
instantiateHTable()  | 
private void | 
joinWalkers()  | 
protected void | 
map(org.apache.hadoop.io.BytesWritable key,
   org.apache.hadoop.io.NullWritable value,
   org.apache.hadoop.mapreduce.Mapper.Context output)  | 
protected void | 
persist(org.apache.hadoop.mapreduce.Mapper.Context output,
       long count,
       byte[][] prev,
       byte[][] current,
       byte[] id)  | 
protected void | 
setup(org.apache.hadoop.mapreduce.Mapper.Context context)  | 
private void | 
startWalkers(int numWalkers,
            org.apache.hadoop.conf.Configuration conf,
            org.apache.hadoop.mapreduce.Mapper.Context context)  | 
byte[][] first
byte[][] prev
byte[][] current
byte[] id
long count
int i
org.apache.hadoop.hbase.client.BufferedMutator mutator
org.apache.hadoop.hbase.client.Connection connection
long numNodes
long wrap
int width
boolean multipleUnevenColumnFamilies
byte[] tinyValue
byte[] bigValue
org.apache.hadoop.conf.Configuration conf
volatile boolean walkersStop
int numWalkers
volatile List<Long> flushedLoops
GeneratorMapper()
protected void setup(org.apache.hadoop.mapreduce.Mapper.Context context) throws IOException, InterruptedException
setup in class org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.NullWritable,org.apache.hadoop.io.NullWritable,org.apache.hadoop.io.NullWritable>IOExceptionInterruptedExceptionprotected void instantiateHTable() throws IOException
IOExceptionprotected void cleanup(org.apache.hadoop.mapreduce.Mapper.Context context) throws IOException, InterruptedException
cleanup in class org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.NullWritable,org.apache.hadoop.io.NullWritable,org.apache.hadoop.io.NullWritable>IOExceptionInterruptedExceptionprotected void map(org.apache.hadoop.io.BytesWritable key, org.apache.hadoop.io.NullWritable value, org.apache.hadoop.mapreduce.Mapper.Context output) throws IOException
map in class org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.NullWritable,org.apache.hadoop.io.NullWritable,org.apache.hadoop.io.NullWritable>IOExceptionprivate static <T> void circularLeftShift(T[] first)
private void addFlushed(byte[] rowKey)
protected void persist(org.apache.hadoop.mapreduce.Mapper.Context output, long count, byte[][] prev, byte[][] current, byte[] id) throws IOException
IOExceptionprivate void startWalkers(int numWalkers, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.mapreduce.Mapper.Context context)
private void joinWalkers()
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.