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.examples.dancing This package is a distributed implementation of Knuth's dancing links algorithm that can run under Hadoop. 
org.apache.hadoop.hbase Provides Hbase, the Hadoop simple database. 
org.apache.hadoop.hbase.io   
org.apache.hadoop.hbase.mapred   
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 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.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.streaming Hadoop Streaming is a utility which allows users to create and run Map-Reduce jobs with any executables (e.g. 
org.apache.hadoop.tools   
org.apache.hadoop.util Common utilities. 
org.onelab.filter   
 

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 DataJoinReducerBase.map(WritableComparable arg0, Writable arg1, OutputCollector arg2, Reporter arg3)
           
 void DataJoinMapperBase.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 void DataJoinReducerBase.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 void DataJoinMapperBase.reduce(WritableComparable arg0, Iterator arg1, OutputCollector arg2, Reporter arg3)
           
 

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
 

Method parameters in org.apache.hadoop.examples with type arguments of type WritableComparable
 void PiEstimator.PiReducer.reduce(LongWritable key, Iterator<LongWritable> values, OutputCollector<WritableComparable,Writable> output, Reporter reporter)
          Reduce method.
 

Uses of WritableComparable in org.apache.hadoop.examples.dancing
 

Methods in org.apache.hadoop.examples.dancing with parameters of type WritableComparable
 void DistributedPentomino.PentMap.map(WritableComparable key, Text value, OutputCollector<Text,Text> output, Reporter reporter)
          Break the prefix string into moves (a sequence of integer row ids that will be selected for each column in order).
 

Uses of WritableComparable in org.apache.hadoop.hbase
 

Classes in org.apache.hadoop.hbase that implement WritableComparable
 class BloomFilterDescriptor
          Supplied as a parameter to HColumnDescriptor to specify what kind of bloom filter to use for a column, and its configuration parameters.
 class HColumnDescriptor
          An HColumnDescriptor contains information about a column family such as the number of versions, compression settings, etc.
 class HLogKey
          A Key for an entry in the change log.
 class HRegionInfo
          HRegion information.
 class HServerAddress
          HServerAddress is a "label" for a HBase server that combines the host name and port number.
 class HServerLoad
          This class encapsulates metrics for determining the load on a HRegionServer
 class HStoreKey
          A Key for a stored row
 class HTableDescriptor
          HTableDescriptor contains the name of an HTable, and its column families.
 

Uses of WritableComparable in org.apache.hadoop.hbase.io
 

Classes in org.apache.hadoop.hbase.io that implement WritableComparable
 class ImmutableBytesWritable
          A byte sequence that is usable as a key or value.
 class TextSequence
          As CharSequence is to String, so is TextSequence to Text (except a TextSequence is a Text whereas a String is a CharSequence).
 

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

Classes in org.apache.hadoop.hbase.mapred with type parameters of type WritableComparable
 class TableMap<K extends WritableComparable,V extends Writable>
          Scan an HBase table to sort by a specified sort column.
 class TableReduce<K extends WritableComparable,V extends Writable>
          Write a table, sorting by the input key
 

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 NullWritable
          Singleton Writable with no data.
 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 SortedMapWritable.firstKey()
          
 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.getClosest(WritableComparable key, Writable val, boolean before)
          Finds the record that is the closest match to the specified key.
 WritableComparable SortedMapWritable.lastKey()
          
 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 that return types with arguments of type WritableComparable
 Comparator<? super WritableComparable> SortedMapWritable.comparator()
          
 Set<Map.Entry<WritableComparable,Writable>> SortedMapWritable.entrySet()
          
 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)
          
 

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 WritableComparator.compare(WritableComparable a, WritableComparable b)
          Compare two WritableComparables.
 int LongWritable.DecreasingComparator.compare(WritableComparable a, WritableComparable b)
           
 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.
 WritableComparable MapFile.Reader.getClosest(WritableComparable key, Writable val, boolean before)
          Finds the record that is the closest match to the specified key.
 SortedMap<WritableComparable,Writable> SortedMapWritable.headMap(WritableComparable toKey)
          
 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.
 Writable SortedMapWritable.put(WritableComparable key, Writable value)
          
 boolean SetFile.Reader.seek(WritableComparable key)
           
 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.
 SortedMap<WritableComparable,Writable> SortedMapWritable.subMap(WritableComparable fromKey, WritableComparable toKey)
          
 SortedMap<WritableComparable,Writable> SortedMapWritable.tailMap(WritableComparable fromKey)
          
 

Method parameters in org.apache.hadoop.io with type arguments of type WritableComparable
 void SortedMapWritable.putAll(Map<? extends WritableComparable,? extends Writable> t)
          
 

Uses of WritableComparable in org.apache.hadoop.mapred
 

Classes in org.apache.hadoop.mapred with type parameters of type WritableComparable
 class FileInputFormat<K extends WritableComparable,V extends Writable>
          A base class for file-based InputFormat.
 interface InputFormat<K extends WritableComparable,V extends Writable>
          InputFormat describes the input-specification for a Map-Reduce job.
 interface Mapper<K1 extends WritableComparable,V1 extends Writable,K2 extends WritableComparable,V2 extends Writable>
          Maps input key/value pairs to a set of intermediate key/value pairs.
 interface Mapper<K1 extends WritableComparable,V1 extends Writable,K2 extends WritableComparable,V2 extends Writable>
          Maps input key/value pairs to a set of intermediate key/value pairs.
 interface MapRunnable<K1 extends WritableComparable,V1 extends Writable,K2 extends WritableComparable,V2 extends Writable>
          Expert: Generic interface for Mappers.
 interface MapRunnable<K1 extends WritableComparable,V1 extends Writable,K2 extends WritableComparable,V2 extends Writable>
          Expert: Generic interface for Mappers.
 class MapRunner<K1 extends WritableComparable,V1 extends Writable,K2 extends WritableComparable,V2 extends Writable>
          Default MapRunnable implementation.
 class MapRunner<K1 extends WritableComparable,V1 extends Writable,K2 extends WritableComparable,V2 extends Writable>
          Default MapRunnable implementation.
 class MultiFileInputFormat<K extends WritableComparable,V extends Writable>
          An abstract InputFormat that returns MultiFileSplit's in MultiFileInputFormat.getSplits(JobConf, int) method.
 interface OutputCollector<K extends WritableComparable,V extends Writable>
          Collects the <key, value> pairs output by Mappers and Reducers.
 interface OutputFormat<K extends WritableComparable,V extends Writable>
          OutputFormat describes the output-specification for a Map-Reduce job.
 class OutputFormatBase<K extends WritableComparable,V extends Writable>
          A base class for OutputFormat.
 interface Partitioner<K2 extends WritableComparable,V2 extends Writable>
          Partitions the key space.
 interface RecordReader<K extends WritableComparable,V extends Writable>
          RecordReader reads <key, value> pairs from an InputSplit.
 interface RecordWriter<K extends WritableComparable,V extends Writable>
          RecordWriter writes the output <key, value> pairs to an output file.
 interface Reducer<K2 extends WritableComparable,V2 extends Writable,K3 extends WritableComparable,V3 extends Writable>
          Reduces a set of intermediate values which share a key to a smaller set of values.
 interface Reducer<K2 extends WritableComparable,V2 extends Writable,K3 extends WritableComparable,V3 extends Writable>
          Reduces a set of intermediate values which share a key to a smaller set of values.
 class SequenceFileInputFilter<K extends WritableComparable,V extends Writable>
          A class that allows a map/red job to work on a sample of sequence files.
 class SequenceFileInputFormat<K extends WritableComparable,V extends Writable>
          An InputFormat for SequenceFiles.
 class SequenceFileRecordReader<K extends WritableComparable,V extends Writable>
          An RecordReader for SequenceFiles.
 class TextOutputFormat<K extends WritableComparable,V extends Writable>
          An OutputFormat that writes plain text files.
protected static class TextOutputFormat.LineRecordWriter<K extends WritableComparable,V extends Writable>
           
 

Methods in org.apache.hadoop.mapred with type parameters of type WritableComparable
static
<K extends WritableComparable,V extends Writable>
Writable
MapFileOutputFormat.getEntry(MapFile.Reader[] readers, Partitioner<K,V> partitioner, K key, V value)
          Get an entry from output generated by this class.
 

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()
          Get the key class for the job output data.
 

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)
          Set the key class for the job output data.
 

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

Classes in org.apache.hadoop.mapred.join with type parameters of type WritableComparable
 interface ComposableInputFormat<K extends WritableComparable,V extends Writable>
          Refinement of InputFormat requiring implementors to provide ComposableRecordReader instead of RecordReader.
 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.
 

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

Classes in org.apache.hadoop.mapred.lib with type parameters of type WritableComparable
 class FieldSelectionMapReduce<K extends WritableComparable,V extends Writable>
          This class implements a mapper/reducer class that can be used to perform field selections in a manner similar to unix cut.
 class HashPartitioner<K2 extends WritableComparable,V2 extends Writable>
          Partition keys by their Object.hashCode().
 class IdentityMapper<K extends WritableComparable,V extends Writable>
          Implements the identity function, mapping inputs directly to outputs.
 class IdentityReducer<K extends WritableComparable,V extends Writable>
          Performs no reduction, writing all input values directly to the output.
 class InverseMapper<K extends WritableComparable,V extends WritableComparable>
          A Mapper that swaps keys and values.
 class InverseMapper<K extends WritableComparable,V extends WritableComparable>
          A Mapper that swaps keys and values.
 class KeyFieldBasedPartitioner<K2 extends WritableComparable,V2 extends Writable>
           
 class LongSumReducer<K extends WritableComparable>
          A Reducer that sums long values.
 class MultithreadedMapRunner<K1 extends WritableComparable,V1 extends Writable,K2 extends WritableComparable,V2 extends Writable>
          Multithreaded implementation for @link org.apache.hadoop.mapred.MapRunnable.
 class MultithreadedMapRunner<K1 extends WritableComparable,V1 extends Writable,K2 extends WritableComparable,V2 extends Writable>
          Multithreaded implementation for @link org.apache.hadoop.mapred.MapRunnable.
 class NullOutputFormat<K extends WritableComparable,V extends Writable>
          Consume all outputs and put them in /dev/null.
 class RegexMapper<K extends WritableComparable>
          A Mapper that extracts text matching a regular expression.
 class TokenCountMapper<K extends WritableComparable>
          A Mapper that maps text values into pairs.
 

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

Classes in org.apache.hadoop.mapred.lib.aggregate with type parameters of type WritableComparable
 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.
 

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.record.meta
 

Classes in org.apache.hadoop.record.meta that implement WritableComparable
 class RecordTypeInfo
          A record's Type Information object which can read/write itself.
 

Uses of WritableComparable in org.apache.hadoop.streaming
 

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
 

Classes in org.apache.hadoop.tools with type parameters of type WritableComparable
static class Logalyzer.LogRegexMapper<K extends WritableComparable>
          A Mapper that extracts text matching a regular expression.
 

Uses of WritableComparable in org.apache.hadoop.util
 

Method parameters in org.apache.hadoop.util with type arguments of type WritableComparable
 void CopyFiles.FSCopyFilesMapper.map(LongWritable key, org.apache.hadoop.util.CopyFiles.FilePair value, OutputCollector<WritableComparable,Text> out, Reporter reporter)
          Map method.
 

Uses of WritableComparable in org.onelab.filter
 

Classes in org.onelab.filter that implement WritableComparable
 class Key
          The general behavior of a key that must be stored in a filter.
 



Copyright © 2006 The Apache Software Foundation