Uses of Class
org.apache.hadoop.io.IntWritable

Packages that use IntWritable
org.apache.hadoop.examples Hadoop example code. 
org.apache.hadoop.mapreduce.lib.reduce   
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. 
 

Uses of IntWritable in org.apache.hadoop.examples
 

Methods in org.apache.hadoop.examples that return types with arguments of type IntWritable
 RecordReader<IntWritable,IntWritable> SleepJob.SleepInputFormat.getRecordReader(InputSplit ignored, JobConf conf, Reporter reporter)
           
 RecordReader<IntWritable,IntWritable> SleepJob.SleepInputFormat.getRecordReader(InputSplit ignored, JobConf conf, Reporter reporter)
           
 

Methods in org.apache.hadoop.examples with parameters of type IntWritable
 int SleepJob.getPartition(IntWritable k, NullWritable v, int numPartitions)
           
 int SecondarySort.FirstPartitioner.getPartition(SecondarySort.IntPair key, IntWritable value, int numPartitions)
           
 void SleepJob.map(IntWritable key, IntWritable value, OutputCollector<IntWritable,NullWritable> output, Reporter reporter)
           
 void SleepJob.reduce(IntWritable key, Iterator<NullWritable> values, OutputCollector<NullWritable,NullWritable> output, Reporter reporter)
           
 

Method parameters in org.apache.hadoop.examples with type arguments of type IntWritable
 void SleepJob.map(IntWritable key, IntWritable value, OutputCollector<IntWritable,NullWritable> output, Reporter reporter)
           
 void SecondarySort.Reduce.reduce(SecondarySort.IntPair key, Iterable<IntWritable> values, Reducer.Context context)
           
 void WordCount.IntSumReducer.reduce(Text key, Iterable<IntWritable> values, Reducer.Context context)
           
 

Uses of IntWritable in org.apache.hadoop.mapreduce.lib.reduce
 

Method parameters in org.apache.hadoop.mapreduce.lib.reduce with type arguments of type IntWritable
 void IntSumReducer.reduce(Key key, Iterable<IntWritable> values, Reducer.Context context)
           
 

Uses of IntWritable in org.apache.hadoop.typedbytes
 

Methods in org.apache.hadoop.typedbytes that return IntWritable
 IntWritable TypedBytesWritableInput.readInt()
           
 IntWritable TypedBytesWritableInput.readInt(IntWritable iw)
           
 

Methods in org.apache.hadoop.typedbytes with parameters of type IntWritable
 IntWritable TypedBytesWritableInput.readInt(IntWritable iw)
           
 void TypedBytesWritableOutput.writeInt(IntWritable iw)
           
 

Uses of IntWritable in org.apache.hadoop.util
 

Constructor parameters in org.apache.hadoop.util with type arguments of type IntWritable
MergeSort(Comparator<IntWritable> comparator)
           
 



Copyright © 2009 The Apache Software Foundation