Package | Description |
---|---|
org.apache.hadoop.io |
Generic i/o code for use when reading and writing data to the network,
to databases, and to files.
|
org.apache.hadoop.mapred | |
org.apache.hadoop.mapred.join | |
org.apache.hadoop.mapred.lib | |
org.apache.hadoop.mapred.lib.aggregate | |
org.apache.hadoop.mapreduce | |
org.apache.hadoop.mapreduce.lib.aggregate | |
org.apache.hadoop.mapreduce.lib.join | |
org.apache.hadoop.mapreduce.lib.output | |
org.apache.hadoop.mapreduce.lib.partition | |
org.apache.hadoop.record |
(DEPRECATED) Hadoop record I/O contains classes and a record description language
translator for simplifying serialization and deserialization of records in a
language-neutral manner.
|
org.apache.hadoop.record.meta |
Modifier and Type | Class and Description |
---|---|
class |
BooleanWritable
A WritableComparable for booleans.
|
class |
BytesWritable
A byte sequence that is usable as a key or value.
|
class |
ByteWritable
A WritableComparable for a single byte.
|
class |
DoubleWritable
Writable for Double values.
|
class |
FloatWritable
A WritableComparable for floats.
|
class |
IntWritable
A WritableComparable for ints.
|
class |
LongWritable
A WritableComparable for longs.
|
class |
MD5Hash
A Writable for MD5 hash values.
|
class |
NullWritable
Singleton Writable with no data.
|
class |
ShortWritable
A WritableComparable for shorts.
|
class |
Text
This class stores text using standard UTF8 encoding.
|
class |
VIntWritable
A WritableComparable for integer values stored in variable-length format.
|
class |
VLongWritable
A WritableComparable for longs in a variable-length format.
|
Modifier and Type | Method and Description |
---|---|
WritableComparable |
SortedMapWritable.firstKey() |
WritableComparable |
SortedMapWritable.lastKey() |
WritableComparable |
WritableComparator.newKey()
Construct a new
WritableComparable instance. |
Modifier and Type | Method and Description |
---|---|
Comparator<? super WritableComparable> |
SortedMapWritable.comparator() |
Set<Map.Entry<WritableComparable,Writable>> |
SortedMapWritable.entrySet() |
Class<? extends WritableComparable> |
WritableComparator.getKeyClass()
Returns the WritableComparable implementation class.
|
SortedMap<WritableComparable,Writable> |
SortedMapWritable.headMap(WritableComparable toKey) |
Set<WritableComparable> |
SortedMapWritable.keySet() |
SortedMap<WritableComparable,Writable> |
SortedMapWritable.subMap(WritableComparable fromKey,
WritableComparable toKey) |
SortedMap<WritableComparable,Writable> |
SortedMapWritable.tailMap(WritableComparable fromKey) |
Modifier and Type | Method and Description |
---|---|
int |
WritableComparator.compare(WritableComparable a,
WritableComparable b)
Compare two WritableComparables.
|
int |
WritableComparator.compare(WritableComparable a,
WritableComparable b)
Compare two WritableComparables.
|
SortedMap<WritableComparable,Writable> |
SortedMapWritable.headMap(WritableComparable toKey) |
Writable |
SortedMapWritable.put(WritableComparable key,
Writable value) |
SortedMap<WritableComparable,Writable> |
SortedMapWritable.subMap(WritableComparable fromKey,
WritableComparable toKey) |
SortedMap<WritableComparable,Writable> |
SortedMapWritable.subMap(WritableComparable fromKey,
WritableComparable toKey) |
SortedMap<WritableComparable,Writable> |
SortedMapWritable.tailMap(WritableComparable fromKey) |
Modifier and Type | Method and Description |
---|---|
static WritableComparator |
WritableComparator.get(Class<? extends WritableComparable> c)
For backwards compatibility.
|
static WritableComparator |
WritableComparator.get(Class<? extends WritableComparable> c,
Configuration conf)
Get a comparator for a
WritableComparable implementation. |
void |
SortedMapWritable.putAll(Map<? extends WritableComparable,? extends Writable> t) |
Constructor and Description |
---|
WritableComparator(Class<? extends WritableComparable> keyClass)
Construct for a
WritableComparable implementation. |
WritableComparator(Class<? extends WritableComparable> keyClass,
boolean createInstances) |
WritableComparator(Class<? extends WritableComparable> keyClass,
Configuration conf,
boolean createInstances) |
Modifier and Type | Method and Description |
---|---|
static <K extends WritableComparable,V extends Writable> |
MapFileOutputFormat.getEntry(org.apache.hadoop.io.MapFile.Reader[] readers,
Partitioner<K,V> partitioner,
K key,
V value)
Get an entry from output generated by this class.
|
Modifier and Type | Method and Description |
---|---|
RecordWriter<WritableComparable,Writable> |
MapFileOutputFormat.getRecordWriter(FileSystem ignored,
JobConf job,
String name,
Progressable progress) |
static Class<? extends WritableComparable> |
SequenceFileAsBinaryOutputFormat.getSequenceFileOutputKeyClass(JobConf conf)
Get the key class for the
SequenceFile |
Modifier and Type | Interface and Description |
---|---|
interface |
ComposableInputFormat<K extends WritableComparable,V extends Writable>
Refinement of InputFormat requiring implementors to provide
ComposableRecordReader instead of RecordReader.
|
interface |
ComposableRecordReader<K extends WritableComparable,V extends Writable>
Additional operations required of a RecordReader to participate in a join.
|
class |
CompositeInputFormat<K extends WritableComparable>
An InputFormat capable of performing joins over a set of data sources sorted
and partitioned the same way.
|
class |
CompositeRecordReader<K extends WritableComparable,V extends Writable,X extends Writable>
A RecordReader that can effect joins of RecordReaders sharing a common key
type and partitioning.
|
class |
InnerJoinRecordReader<K extends WritableComparable>
Full inner join.
|
class |
JoinRecordReader<K extends WritableComparable>
Base class for Composite joins returning Tuples of arbitrary Writables.
|
class |
MultiFilterRecordReader<K extends WritableComparable,V extends Writable>
Base class for Composite join returning values derived from multiple
sources, but generally not tuples.
|
class |
OuterJoinRecordReader<K extends WritableComparable>
Full outer join.
|
class |
OverrideRecordReader<K extends WritableComparable,V extends Writable>
Prefer the "rightmost" data source for this key.
|
class |
WrappedRecordReader<K extends WritableComparable,U extends Writable>
Proxy class for a RecordReader participating in the join framework.
|
Modifier and Type | Class and Description |
---|---|
class |
TotalOrderPartitioner<K extends WritableComparable<?>,V>
Partitioner effecting a total order by reading split points from
an externally generated source.
|
Modifier and Type | Class and Description |
---|---|
class |
ValueAggregatorCombiner<K1 extends WritableComparable,V1 extends Writable>
This class implements the generic combiner of Aggregate.
|
class |
ValueAggregatorJobBase<K1 extends WritableComparable,V1 extends Writable>
This abstract class implements some common functionalities of the
the generic mapper, reducer and combiner classes of Aggregate.
|
class |
ValueAggregatorMapper<K1 extends WritableComparable,V1 extends Writable>
This class implements the generic mapper of Aggregate.
|
class |
ValueAggregatorReducer<K1 extends WritableComparable,V1 extends Writable>
This class implements the generic reducer of Aggregate.
|
Modifier and Type | Class and Description |
---|---|
class |
ID
A general identifier, which internally stores the id
as an integer.
|
class |
JobID
JobID represents the immutable and unique identifier for
the job.
|
class |
TaskAttemptID
TaskAttemptID represents the immutable and unique identifier for
a task attempt.
|
class |
TaskID
TaskID represents the immutable and unique identifier for
a Map or Reduce Task.
|
Modifier and Type | Class and Description |
---|---|
class |
ValueAggregatorCombiner<K1 extends WritableComparable<?>,V1 extends Writable>
This class implements the generic combiner of Aggregate.
|
class |
ValueAggregatorJobBase<K1 extends WritableComparable<?>,V1 extends Writable>
This abstract class implements some common functionalities of the
the generic mapper, reducer and combiner classes of Aggregate.
|
class |
ValueAggregatorMapper<K1 extends WritableComparable<?>,V1 extends Writable>
This class implements the generic mapper of Aggregate.
|
class |
ValueAggregatorReducer<K1 extends WritableComparable<?>,V1 extends Writable>
This class implements the generic reducer of Aggregate.
|
Modifier and Type | Class and Description |
---|---|
class |
ComposableInputFormat<K extends WritableComparable<?>,V extends Writable>
Refinement of InputFormat requiring implementors to provide
ComposableRecordReader instead of RecordReader.
|
class |
ComposableRecordReader<K extends WritableComparable<?>,V extends Writable>
Additional operations required of a RecordReader to participate in a join.
|
class |
CompositeInputFormat<K extends WritableComparable>
An InputFormat capable of performing joins over a set of data sources sorted
and partitioned the same way.
|
class |
CompositeRecordReader<K extends WritableComparable<?>,V extends Writable,X extends Writable>
A RecordReader that can effect joins of RecordReaders sharing a common key
type and partitioning.
|
class |
InnerJoinRecordReader<K extends WritableComparable<?>>
Full inner join.
|
class |
JoinRecordReader<K extends WritableComparable<?>>
Base class for Composite joins returning Tuples of arbitrary Writables.
|
class |
MultiFilterRecordReader<K extends WritableComparable<?>,V extends Writable>
Base class for Composite join returning values derived from multiple
sources, but generally not tuples.
|
class |
OuterJoinRecordReader<K extends WritableComparable<?>>
Full outer join.
|
class |
OverrideRecordReader<K extends WritableComparable<?>,V extends Writable>
Prefer the "rightmost" data source for this key.
|
class |
WrappedRecordReader<K extends WritableComparable<?>,U extends Writable>
Proxy class for a RecordReader participating in the join framework.
|
Modifier and Type | Field and Description |
---|---|
protected K |
CompositeRecordReader.key |
Modifier and Type | Field and Description |
---|---|
protected Class<? extends WritableComparable> |
CompositeRecordReader.keyclass |
Modifier and Type | Method and Description |
---|---|
static <K extends WritableComparable<?>,V extends Writable> |
MapFileOutputFormat.getEntry(org.apache.hadoop.io.MapFile.Reader[] readers,
Partitioner<K,V> partitioner,
K key,
V value)
Get an entry from output generated by this class.
|
Modifier and Type | Method and Description |
---|---|
RecordWriter<WritableComparable<?>,Writable> |
MapFileOutputFormat.getRecordWriter(TaskAttemptContext context) |
static Class<? extends WritableComparable> |
SequenceFileAsBinaryOutputFormat.getSequenceFileOutputKeyClass(JobContext job)
Get the key class for the
SequenceFile |
Modifier and Type | Class and Description |
---|---|
class |
TotalOrderPartitioner<K extends WritableComparable<?>,V>
Partitioner effecting a total order by reading split points from
an externally generated source.
|
Modifier and Type | Class and Description |
---|---|
class |
Record
Deprecated.
Replaced by Avro.
|
Constructor and Description |
---|
RecordComparator(Class<? extends WritableComparable> recordClass)
Deprecated.
Construct a raw
Record comparison implementation. |
Modifier and Type | Class and Description |
---|---|
class |
RecordTypeInfo
Deprecated.
Replaced by Avro.
|
Copyright © 2015 Apache Software Foundation. All rights reserved.