Uses of Interface
org.apache.hadoop.io.WritableComparable

Packages that use WritableComparable
org.apache.hadoop.contrib.utils.join   
org.apache.hadoop.dfs A distributed implementation of FileSystem
org.apache.hadoop.examples Hadoop example code. 
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 A system for scalable, fault-tolerant, distributed computation over large data collections. 
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.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.streaming   
org.apache.hadoop.tools   
org.apache.hadoop.util Common utilities. 
 

Uses of WritableComparable in org.apache.hadoop.contrib.utils.join
 

Methods in org.apache.hadoop.contrib.utils.join with parameters of type WritableComparable
protected  void DataJoinReducerBase.collect(WritableComparable key, TaggedMapOutput aRecord, OutputCollector output, Reporter reporter)
          The subclass can overwrite this method to perform additional filtering and/or other processing logic before a value is collected.
 void DataJoinMapperBase.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 void DataJoinReducerBase.map(WritableComparable arg0, Writable arg1, OutputCollector arg2, Reporter arg3)
           
 void DataJoinMapperBase.reduce(WritableComparable arg0, Iterator arg1, OutputCollector arg2, Reporter arg3)
           
 void DataJoinReducerBase.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 

Uses of WritableComparable in org.apache.hadoop.dfs
 

Classes in org.apache.hadoop.dfs that implement WritableComparable
 class DatanodeDescriptor
          DatanodeDescriptor tracks stats on a given DataNode, such as available storage capacity, last update time, etc., and maintains a set of blocks stored on the datanode.
 class DatanodeID
          DatanodeID is composed of the data node name (hostname:portNumber) and the data storage ID, which it currently represents.
 class DatanodeInfo
          DatanodeInfo represents the status of a DataNode.
 

Uses of WritableComparable in org.apache.hadoop.examples
 

Methods in org.apache.hadoop.examples with parameters of type WritableComparable
 void PiEstimator.PiMapper.map(WritableComparable key, Writable val, OutputCollector out, Reporter reporter)
          Map method.
 void WordCount.MapClass.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 void PiEstimator.PiReducer.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
          Reduce method.
 void WordCount.Reduce.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 

Uses of WritableComparable in org.apache.hadoop.io
 

Classes in org.apache.hadoop.io that implement WritableComparable
 class BooleanWritable
          A WritableComparable for booleans.
 class BytesWritable
          A byte sequence that is usable as a key or value.
 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 Text
          This class stores text using standard UTF8 encoding.
 class UTF8
          Deprecated. replaced by Text
 class VIntWritable
          A WritableComparable for integer values stored in variable-length format.
 class VLongWritable
          A WritableComparable for longs in a variable-length format.
 

Methods in org.apache.hadoop.io that return WritableComparable
 WritableComparable SetFile.Reader.get(WritableComparable key)
          Read the matching key from a set into key.
 WritableComparable MapFile.Reader.getClosest(WritableComparable key, Writable val)
          Finds the record that is the closest match to the specified key.
 WritableComparable MapFile.Reader.midKey()
          Get the key at approximately the middle of the file.
 WritableComparable WritableComparator.newKey()
          Construct a new WritableComparable instance.
 

Methods in org.apache.hadoop.io with parameters of type WritableComparable
 void SetFile.Writer.append(WritableComparable key)
          Deprecated. Append a key to a set.
 void MapFile.Writer.append(WritableComparable key, Writable val)
          Append a key/value pair to the map.
 int LongWritable.DecreasingComparator.compare(WritableComparable a, WritableComparable b)
           
 int WritableComparator.compare(WritableComparable a, WritableComparable b)
          Compare two WritableComparables.
 void MapFile.Reader.finalKey(WritableComparable key)
          Reads the final key from the file.
 WritableComparable SetFile.Reader.get(WritableComparable key)
          Read the matching key from a set into key.
 Writable MapFile.Reader.get(WritableComparable key, Writable val)
          Return the value for the named key, or null if none exists.
 WritableComparable MapFile.Reader.getClosest(WritableComparable key, Writable val)
          Finds the record that is the closest match to the specified key.
 boolean SetFile.Reader.next(WritableComparable key)
          Read the next key in a set into key.
 boolean MapFile.Reader.next(WritableComparable key, Writable val)
          Read the next key/value pair in the map into key and val.
 boolean MapFile.Reader.seek(WritableComparable key)
          Positions the reader at the named key, or if none such exists, at the first entry after the named key.
 boolean SetFile.Reader.seek(WritableComparable key)
           
 

Uses of WritableComparable in org.apache.hadoop.mapred
 

Methods in org.apache.hadoop.mapred that return WritableComparable
 WritableComparable SequenceFileRecordReader.createKey()
           
 WritableComparable SequenceFileAsTextRecordReader.createKey()
           
 WritableComparable LineRecordReader.createKey()
           
 WritableComparable RecordReader.createKey()
          Create an object of the appropriate type to be used as a key.
 

Methods in org.apache.hadoop.mapred that return types with arguments of type WritableComparable
 Class<? extends WritableComparable> JobConf.getMapOutputKeyClass()
          Get the key class for the map output data.
 Class<? extends WritableComparable> JobConf.getOutputKeyClass()
           
 

Methods in org.apache.hadoop.mapred with parameters of type WritableComparable
 void OutputCollector.collect(WritableComparable key, Writable value)
          Adds a key/value pair to the output.
static Writable MapFileOutputFormat.getEntry(MapFile.Reader[] readers, Partitioner partitioner, WritableComparable key, Writable value)
          Get an entry from output generated by this class.
 int Partitioner.getPartition(WritableComparable key, Writable value, int numPartitions)
          Returns the paritition number for a given entry given the total number of partitions.
 void Mapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
          Maps a single input key/value pair into intermediate key/value pairs.
 void Reducer.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
          Combines values for a given key.
 void TextOutputFormat.LineRecordWriter.write(WritableComparable key, Writable value)
           
 void RecordWriter.write(WritableComparable key, Writable value)
          Writes a key/value pair.
 

Method parameters in org.apache.hadoop.mapred with type arguments of type WritableComparable
 void JobConf.setMapOutputKeyClass(Class<? extends WritableComparable> theClass)
          Set the key class for the map output data.
 void JobConf.setOutputKeyClass(Class<? extends WritableComparable> theClass)
           
 

Uses of WritableComparable in org.apache.hadoop.mapred.lib
 

Methods in org.apache.hadoop.mapred.lib with parameters of type WritableComparable
 int HashPartitioner.getPartition(WritableComparable key, Writable value, int numReduceTasks)
          Use Object.hashCode() to partition.
 int KeyFieldBasedPartitioner.getPartition(WritableComparable key, Writable value, int numReduceTasks)
          Use Object.hashCode() to partition.
 void FieldSelectionMapReduce.map(WritableComparable key, Writable val, OutputCollector output, Reporter reporter)
          The identify function.
 void IdentityMapper.map(WritableComparable key, Writable val, OutputCollector output, Reporter reporter)
          The identify function.
 void RegexMapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 void InverseMapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
          The inverse function.
 void TokenCountMapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 void LongSumReducer.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 void FieldSelectionMapReduce.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 void IdentityReducer.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
          Writes all keys and values directly to output.
 

Uses of WritableComparable in org.apache.hadoop.mapred.lib.aggregate
 

Methods in org.apache.hadoop.mapred.lib.aggregate with parameters of type WritableComparable
 void ValueAggregatorMapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
          the map function.
 void ValueAggregatorReducer.map(WritableComparable arg0, Writable arg1, OutputCollector arg2, Reporter arg3)
          Do nothing.
 void ValueAggregatorCombiner.map(WritableComparable arg0, Writable arg1, OutputCollector arg2, Reporter arg3)
          Do nothing.
 void ValueAggregatorMapper.reduce(WritableComparable arg0, Iterator arg1, OutputCollector arg2, Reporter arg3)
          Do nothing.
 void ValueAggregatorReducer.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 void ValueAggregatorCombiner.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
          Combines values for a given key.
 

Uses of WritableComparable in org.apache.hadoop.record
 

Classes in org.apache.hadoop.record that implement WritableComparable
 class Record
          Abstract class that is extended by generated classes.
 

Uses of WritableComparable in org.apache.hadoop.streaming
 

Methods in org.apache.hadoop.streaming that return WritableComparable
 WritableComparable StreamBaseRecordReader.createKey()
           
 

Methods in org.apache.hadoop.streaming with parameters of type WritableComparable
 void PipeMapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 void PipeReducer.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 

Uses of WritableComparable in org.apache.hadoop.tools
 

Methods in org.apache.hadoop.tools with parameters of type WritableComparable
 void Logalyzer.LogRegexMapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 

Uses of WritableComparable in org.apache.hadoop.util
 

Methods in org.apache.hadoop.util with parameters of type WritableComparable
 void CopyFiles.FSCopyFilesMapper.map(WritableComparable key, Writable value, OutputCollector out, Reporter reporter)
          Map method.
 void CopyFiles.HTTPCopyFilesMapper.map(WritableComparable key, Writable val, OutputCollector out, Reporter reporter)
           
 



Copyright © 2006 The Apache Software Foundation