HFileOutputFormat2
instead.@Deprecated @InterfaceAudience.Public @InterfaceStability.Stable public class HFileOutputFormat extends org.apache.hadoop.mapreduce.lib.output.FileOutputFormat<ImmutableBytesWritable,KeyValue>
Using this class as part of a MapReduce job is best done
using configureIncrementalLoad(Job, HTable)
.
KeyValueSortReducer
Modifier and Type | Field and Description |
---|---|
static String |
DATABLOCK_ENCODING_OVERRIDE_CONF_KEY
Deprecated.
|
private static org.apache.commons.logging.Log |
LOG
Deprecated.
|
Constructor and Description |
---|
HFileOutputFormat()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
(package private) static void |
configureBlockSize(Table table,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
Serialize column family to block size map to configuration.
|
(package private) static void |
configureBloomType(Table table,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
Serialize column family to bloom type map to configuration.
|
(package private) static void |
configureCompression(Table table,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
|
(package private) static void |
configureDataBlockEncoding(Table table,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
Serialize column family to data block encoding map to configuration.
|
static void |
configureIncrementalLoad(org.apache.hadoop.mapreduce.Job job,
HTable table)
Deprecated.
Configure a MapReduce Job to perform an incremental load into the given
table.
|
(package private) static void |
configurePartitioner(org.apache.hadoop.mapreduce.Job job,
List<ImmutableBytesWritable> splitPoints)
Deprecated.
Configure
job with a TotalOrderPartitioner, partitioning against
splitPoints . |
(package private) static Map<byte[],Integer> |
createFamilyBlockSizeMap(org.apache.hadoop.conf.Configuration conf)
Deprecated.
Runs inside the task to deserialize column family to block size
map from the configuration.
|
(package private) static Map<byte[],BloomType> |
createFamilyBloomTypeMap(org.apache.hadoop.conf.Configuration conf)
Deprecated.
Runs inside the task to deserialize column family to bloom filter type
map from the configuration.
|
(package private) static Map<byte[],Compression.Algorithm> |
createFamilyCompressionMap(org.apache.hadoop.conf.Configuration conf)
Deprecated.
Runs inside the task to deserialize column family to compression algorithm
map from the configuration.
|
(package private) static Map<byte[],DataBlockEncoding> |
createFamilyDataBlockEncodingMap(org.apache.hadoop.conf.Configuration conf)
Deprecated.
Runs inside the task to deserialize column family to data block encoding
type map from the configuration.
|
org.apache.hadoop.mapreduce.RecordWriter<ImmutableBytesWritable,KeyValue> |
getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context)
Deprecated.
|
checkOutputSpecs, getCompressOutput, getDefaultWorkFile, getOutputCommitter, getOutputCompressorClass, getOutputName, getOutputPath, getPathForWorkFile, getUniqueFile, getWorkOutputPath, setCompressOutput, setOutputCompressorClass, setOutputName, setOutputPath
private static final org.apache.commons.logging.Log LOG
public static final String DATABLOCK_ENCODING_OVERRIDE_CONF_KEY
public org.apache.hadoop.mapreduce.RecordWriter<ImmutableBytesWritable,KeyValue> getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context) throws IOException, InterruptedException
getRecordWriter
in class org.apache.hadoop.mapreduce.lib.output.FileOutputFormat<ImmutableBytesWritable,KeyValue>
IOException
InterruptedException
public static void configureIncrementalLoad(org.apache.hadoop.mapreduce.Job job, HTable table) throws IOException
IOException
static Map<byte[],Compression.Algorithm> createFamilyCompressionMap(org.apache.hadoop.conf.Configuration conf)
conf
- to read the serialized values fromstatic Map<byte[],BloomType> createFamilyBloomTypeMap(org.apache.hadoop.conf.Configuration conf)
conf
- to read the serialized values fromstatic Map<byte[],Integer> createFamilyBlockSizeMap(org.apache.hadoop.conf.Configuration conf)
conf
- to read the serialized values fromstatic Map<byte[],DataBlockEncoding> createFamilyDataBlockEncodingMap(org.apache.hadoop.conf.Configuration conf)
conf
- to read the serialized values fromstatic void configurePartitioner(org.apache.hadoop.mapreduce.Job job, List<ImmutableBytesWritable> splitPoints) throws IOException
job
with a TotalOrderPartitioner, partitioning against
splitPoints
. Cleans up the partitions file after job exists.IOException
static void configureCompression(Table table, org.apache.hadoop.conf.Configuration conf) throws IOException
IOException
static void configureBlockSize(Table table, org.apache.hadoop.conf.Configuration conf) throws IOException
table
- to read the properties fromconf
- to persist serialized values intoIOException
- on failure to read column family descriptorsstatic void configureBloomType(Table table, org.apache.hadoop.conf.Configuration conf) throws IOException
table
- to read the properties fromconf
- to persist serialized values intoIOException
- on failure to read column family descriptorsstatic void configureDataBlockEncoding(Table table, org.apache.hadoop.conf.Configuration conf) throws IOException
table
- to read the properties fromconf
- to persist serialized values intoIOException
- on failure to read column family descriptorsCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.