public class HiveAccumuloSplit
extends org.apache.hadoop.mapred.FileSplit
implements org.apache.hadoop.mapred.InputSplit
If the RangeInputSplit
is used directly, it will hit a branch of code in
HiveInputFormat.HiveInputSplit
which generates an invalid Path. Wrap it ourselves so that it doesn't
error
Constructor and Description |
---|
HiveAccumuloSplit() |
HiveAccumuloSplit(org.apache.accumulo.core.client.mapred.RangeInputSplit split,
org.apache.hadoop.fs.Path dummyPath) |
Modifier and Type | Method and Description |
---|---|
long |
getLength() |
String[] |
getLocations() |
org.apache.accumulo.core.client.mapred.RangeInputSplit |
getSplit() |
void |
readFields(DataInput in) |
String |
toString() |
void |
write(DataOutput out) |
public HiveAccumuloSplit()
public HiveAccumuloSplit(org.apache.accumulo.core.client.mapred.RangeInputSplit split, org.apache.hadoop.fs.Path dummyPath)
public org.apache.accumulo.core.client.mapred.RangeInputSplit getSplit()
public void readFields(DataInput in) throws IOException
readFields
in interface org.apache.hadoop.io.Writable
readFields
in class org.apache.hadoop.mapred.FileSplit
IOException
public String toString()
toString
in class org.apache.hadoop.mapred.FileSplit
public void write(DataOutput out) throws IOException
write
in interface org.apache.hadoop.io.Writable
write
in class org.apache.hadoop.mapred.FileSplit
IOException
public long getLength()
getLength
in interface org.apache.hadoop.mapred.InputSplit
getLength
in class org.apache.hadoop.mapred.FileSplit
public String[] getLocations() throws IOException
getLocations
in interface org.apache.hadoop.mapred.InputSplit
getLocations
in class org.apache.hadoop.mapred.FileSplit
IOException
Copyright © 2017 The Apache Software Foundation. All rights reserved.