public class HiveAccumuloRecordReader extends Object implements org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,AccumuloHiveRow>
Key Value pairs from AccumuloInputFormat to a
Writable for consumption by the AccumuloSerDe.| Constructor and Description |
|---|
HiveAccumuloRecordReader(org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,org.apache.accumulo.core.util.PeekingIterator<Map.Entry<org.apache.accumulo.core.data.Key,org.apache.accumulo.core.data.Value>>> recordReader,
int iteratorCount) |
| Modifier and Type | Method and Description |
|---|---|
void |
close() |
org.apache.hadoop.io.Text |
createKey() |
AccumuloHiveRow |
createValue() |
long |
getPos() |
float |
getProgress() |
boolean |
next(org.apache.hadoop.io.Text rowKey,
AccumuloHiveRow row) |
public HiveAccumuloRecordReader(org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,org.apache.accumulo.core.util.PeekingIterator<Map.Entry<org.apache.accumulo.core.data.Key,org.apache.accumulo.core.data.Value>>> recordReader, int iteratorCount)
public void close()
throws IOException
close in interface org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,AccumuloHiveRow>IOExceptionpublic org.apache.hadoop.io.Text createKey()
createKey in interface org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,AccumuloHiveRow>public AccumuloHiveRow createValue()
createValue in interface org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,AccumuloHiveRow>public long getPos()
throws IOException
getPos in interface org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,AccumuloHiveRow>IOExceptionpublic float getProgress()
throws IOException
getProgress in interface org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,AccumuloHiveRow>IOExceptionpublic boolean next(org.apache.hadoop.io.Text rowKey,
AccumuloHiveRow row)
throws IOException
next in interface org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,AccumuloHiveRow>IOExceptionCopyright © 2017 The Apache Software Foundation. All rights reserved.