IntegrationTestBigLinkedList.Generator.GeneratorMapper.ConcurrentWalker, IntegrationTestBigLinkedList.Generator.GeneratorMapper.ContinuousConcurrentWalker
Modifier and Type | Field and Description |
---|---|
(package private) org.apache.hadoop.hbase.client.BufferedMutator[] |
tables |
bigValue, conf, connection, count, current, first, flushedLoops, flushedLoopsLock, i, id, multipleUnevenColumnFamilies, mutator, numNodes, numWalkers, prev, tinyValue, walkers, walkersStop, width, wrap
Constructor and Description |
---|
VisibilityGeneratorMapper() |
Modifier and Type | Method and Description |
---|---|
protected void |
cleanup(org.apache.hadoop.mapreduce.Mapper.Context context) |
protected void |
instantiateHTable() |
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) |
map
org.apache.hadoop.hbase.client.BufferedMutator[] tables
VisibilityGeneratorMapper()
protected void setup(org.apache.hadoop.mapreduce.Mapper.Context context) throws IOException, InterruptedException
setup
in class IntegrationTestBigLinkedList.Generator.GeneratorMapper
IOException
InterruptedException
protected void instantiateHTable() throws IOException
instantiateHTable
in class IntegrationTestBigLinkedList.Generator.GeneratorMapper
IOException
protected void cleanup(org.apache.hadoop.mapreduce.Mapper.Context context) throws IOException, InterruptedException
cleanup
in class IntegrationTestBigLinkedList.Generator.GeneratorMapper
IOException
InterruptedException
protected void persist(org.apache.hadoop.mapreduce.Mapper.Context output, long count, byte[][] prev, byte[][] current, byte[] id) throws IOException
persist
in class IntegrationTestBigLinkedList.Generator.GeneratorMapper
IOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.