Uses of Package
org.apache.hadoop.io

Packages that use org.apache.hadoop.io
org.apache.hadoop.conf Configuration of system parameters. 
org.apache.hadoop.contrib.index.example   
org.apache.hadoop.contrib.index.mapred   
org.apache.hadoop.contrib.utils.join   
org.apache.hadoop.examples Hadoop example code. 
org.apache.hadoop.examples.dancing This package is a distributed implementation of Knuth's dancing links algorithm that can run under Hadoop. 
org.apache.hadoop.examples.terasort This package consists of 3 map/reduce applications for Hadoop to compete in the annual terabyte sort competition. 
org.apache.hadoop.fs An abstract file system API. 
org.apache.hadoop.fs.permission   
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.io.file.tfile   
org.apache.hadoop.io.serializer This package provides a mechanism for using different serialization frameworks in Hadoop. 
org.apache.hadoop.ipc Tools to help define network clients and servers. 
org.apache.hadoop.mapred A software framework for easily writing applications which process vast amounts of data (multi-terabyte data-sets) parallelly on large clusters (thousands of nodes) built of commodity hardware in a reliable, fault-tolerant manner. 
org.apache.hadoop.mapred.join Given a set of sorted datasets keyed with the same class and yielding equal partitions, it is possible to effect a join of those datasets prior to the map. 
org.apache.hadoop.mapred.lib Library of generally useful mappers, reducers, and partitioners. 
org.apache.hadoop.mapred.lib.aggregate Classes for performing various counting and aggregations. 
org.apache.hadoop.mapred.lib.db org.apache.hadoop.mapred.lib.db Package 
org.apache.hadoop.mapreduce   
org.apache.hadoop.mapreduce.lib.db   
org.apache.hadoop.mapreduce.lib.fieldsel   
org.apache.hadoop.mapreduce.lib.map   
org.apache.hadoop.mapreduce.lib.output   
org.apache.hadoop.mapreduce.lib.partition   
org.apache.hadoop.mapreduce.lib.reduce   
org.apache.hadoop.mapreduce.security   
org.apache.hadoop.mapreduce.security.token   
org.apache.hadoop.mapreduce.security.token.delegation   
org.apache.hadoop.mapreduce.split   
org.apache.hadoop.record 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   
org.apache.hadoop.security   
org.apache.hadoop.security.authorize   
org.apache.hadoop.security.token   
org.apache.hadoop.security.token.delegation   
org.apache.hadoop.streaming Hadoop Streaming is a utility which allows users to create and run Map-Reduce jobs with any executables (e.g. 
org.apache.hadoop.streaming.io   
org.apache.hadoop.typedbytes Typed bytes are sequences of bytes in which the first byte is a type code. 
org.apache.hadoop.util Common utilities. 
org.apache.hadoop.util.bloom   
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.conf
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.contrib.index.example
Closeable
          Deprecated. use java.io.Closeable
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.contrib.index.mapred
Closeable
          Deprecated. use java.io.Closeable
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
WritableComparable
          A Writable which is also Comparable.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.contrib.utils.join
Closeable
          Deprecated. use java.io.Closeable
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.examples
BooleanWritable
          A WritableComparable for booleans.
Closeable
          Deprecated. use java.io.Closeable
IntWritable
          A WritableComparable for ints.
LongWritable
          A WritableComparable for longs.
NullWritable
          Singleton Writable with no data.
RawComparator
           A Comparator that operates directly on byte representations of objects.
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
WritableComparable
          A Writable which is also Comparable.
WritableComparator
          A Comparator for WritableComparables.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.examples.dancing
Closeable
          Deprecated. use java.io.Closeable
Text
          This class stores text using standard UTF8 encoding.
WritableComparable
          A Writable which is also Comparable.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.examples.terasort
Closeable
          Deprecated. use java.io.Closeable
LongWritable
          A WritableComparable for longs.
NullWritable
          Singleton Writable with no data.
Text
          This class stores text using standard UTF8 encoding.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.fs
MD5Hash
          A Writable for MD5 hash values.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.fs.permission
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.io
AbstractMapWritable
          Abstract base class for MapWritable and SortedMapWritable Unlike org.apache.nutch.crawl.MapWritable, this class allows creation of MapWritable<Writable, MapWritable> so the CLASS_TO_ID and ID_TO_CLASS maps travel with the class instead of being static.
BinaryComparable
          Interface supported by WritableComparable types supporting ordering/permutation by a representative set of bytes.
BytesWritable
          A byte sequence that is usable as a key or value.
DataOutputBuffer
          A reusable DataOutput implementation that writes to an in-memory buffer.
LongWritable.Comparator
          A Comparator optimized for LongWritable.
MapFile
          A file-based map from keys to values.
MapFile.Reader
          Provide access to an existing map.
MapFile.Writer
          Writes a new map.
MapWritable
          A Writable Map.
MD5Hash
          A Writable for MD5 hash values.
NullWritable
          Singleton Writable with no data.
ObjectWritable
          A polymorphic Writable that writes an instance with it's class name.
OutputBuffer
          A reusable OutputStream implementation that writes to an in-memory buffer.
RawComparator
           A Comparator that operates directly on byte representations of objects.
ReadaheadPool
          Manages a pool of threads which can issue readahead requests on file descriptors.
ReadaheadPool.ReadaheadRequest
          An outstanding readahead request that has been submitted to the pool.
SequenceFile.CompressionType
          The compression type used to compress key/value pairs in the SequenceFile.
SequenceFile.Metadata
          The class encapsulating with the metadata of a file.
SequenceFile.Reader
          Reads key/value pairs from a sequence-format file.
SequenceFile.Sorter.RawKeyValueIterator
          The interface to iterate over raw keys/values of SequenceFiles.
SequenceFile.Sorter.SegmentDescriptor
          This class defines a merge segment.
SequenceFile.ValueBytes
          The interface to 'raw' values of SequenceFiles.
SequenceFile.Writer
          Write key/value pairs to a sequence-format file.
SortedMapWritable
          A Writable SortedMap.
Stringifier
          Stringifier interface offers two methods to convert an object to a string representation and restore the object given its string representation.
Text
          This class stores text using standard UTF8 encoding.
UTF8
          Deprecated. replaced by Text
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
WritableComparable
          A Writable which is also Comparable.
WritableComparator
          A Comparator for WritableComparables.
WritableFactory
          A factory for a class of Writable.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.io.file.tfile
BytesWritable
          A byte sequence that is usable as a key or value.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.io.serializer
RawComparator
           A Comparator that operates directly on byte representations of objects.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.ipc
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapred
BytesWritable
          A byte sequence that is usable as a key or value.
Closeable
          Deprecated. use java.io.Closeable
DataInputBuffer
          A reusable DataInput implementation that reads from an in-memory buffer.
LongWritable
          A WritableComparable for longs.
MapFile.Reader
          Provide access to an existing map.
RawComparator
           A Comparator that operates directly on byte representations of objects.
SequenceFile.CompressionType
          The compression type used to compress key/value pairs in the SequenceFile.
SequenceFile.Reader
          Reads key/value pairs from a sequence-format file.
SequenceFile.ValueBytes
          The interface to 'raw' values of SequenceFiles.
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
WritableComparable
          A Writable which is also Comparable.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapred.join
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
WritableComparable
          A Writable which is also Comparable.
WritableComparator
          A Comparator for WritableComparables.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapred.lib
Closeable
          Deprecated. use java.io.Closeable
LongWritable
          A WritableComparable for longs.
RawComparator
           A Comparator that operates directly on byte representations of objects.
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
WritableComparable
          A Writable which is also Comparable.
WritableComparator
          A Comparator for WritableComparables.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapred.lib.aggregate
Closeable
          Deprecated. use java.io.Closeable
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
WritableComparable
          A Writable which is also Comparable.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapred.lib.db
LongWritable
          A WritableComparable for longs.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapreduce
RawComparator
           A Comparator that operates directly on byte representations of objects.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
WritableComparable
          A Writable which is also Comparable.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapreduce.lib.db
LongWritable
          A WritableComparable for longs.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapreduce.lib.fieldsel
Text
          This class stores text using standard UTF8 encoding.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapreduce.lib.map
Text
          This class stores text using standard UTF8 encoding.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapreduce.lib.output
SequenceFile.Writer
          Write key/value pairs to a sequence-format file.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapreduce.lib.partition
BinaryComparable
          Interface supported by WritableComparable types supporting ordering/permutation by a representative set of bytes.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapreduce.lib.reduce
IntWritable
          A WritableComparable for ints.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapreduce.security
Text
          This class stores text using standard UTF8 encoding.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapreduce.security.token
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapreduce.security.token.delegation
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.mapreduce.split
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.record
RawComparator
           A Comparator that operates directly on byte representations of objects.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
WritableComparable
          A Writable which is also Comparable.
WritableComparator
          A Comparator for WritableComparables.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.record.meta
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
WritableComparable
          A Writable which is also Comparable.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.security
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.security.authorize
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.security.token
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.security.token.delegation
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.streaming
Closeable
          Deprecated. use java.io.Closeable
Text
          This class stores text using standard UTF8 encoding.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.streaming.io
BytesWritable
          A byte sequence that is usable as a key or value.
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.typedbytes
ArrayWritable
          A Writable for arrays containing instances of a class.
BinaryComparable
          Interface supported by WritableComparable types supporting ordering/permutation by a representative set of bytes.
BooleanWritable
          A WritableComparable for booleans.
BytesWritable
          A byte sequence that is usable as a key or value.
ByteWritable
          A WritableComparable for a single byte.
DoubleWritable
          Writable for Double values.
FloatWritable
          A WritableComparable for floats.
IntWritable
          A WritableComparable for ints.
LongWritable
          A WritableComparable for longs.
MapWritable
          A Writable Map.
SortedMapWritable
          A Writable SortedMap.
Text
          This class stores text using standard UTF8 encoding.
VIntWritable
          A WritableComparable for integer values stored in variable-length format.
VLongWritable
          A WritableComparable for longs in a variable-length format.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
WritableComparable
          A Writable which is also Comparable.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.util
IntWritable
          A WritableComparable for ints.
Text
          This class stores text using standard UTF8 encoding.
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
 

Classes in org.apache.hadoop.io used by org.apache.hadoop.util.bloom
Writable
          A serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.
WritableComparable
          A Writable which is also Comparable.
 



Copyright © 2009 The Apache Software Foundation