| 
 | ||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
| Packages that use LongWritable | |
|---|---|
| org.apache.hadoop.examples | Hadoop example code. | 
| 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.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.lib | Library of generally useful mappers, reducers, and partitioners. | 
| org.apache.hadoop.mapred.lib.db | org.apache.hadoop.mapred.lib.db Package | 
| org.apache.hadoop.mapreduce.lib.db | |
| org.apache.hadoop.mapreduce.lib.input | |
| 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. | 
| Uses of LongWritable in org.apache.hadoop.examples | 
|---|
| Methods in org.apache.hadoop.examples with parameters of type LongWritable | |
|---|---|
|  void | PiEstimator.PiMapper.map(LongWritable offset,
    LongWritable size,
    OutputCollector<BooleanWritable,LongWritable> out,
    Reporter reporter)Map method. | 
|  void | SecondarySort.MapClass.map(LongWritable inKey,
    Text inValue,
    Mapper.Context context) | 
| Method parameters in org.apache.hadoop.examples with type arguments of type LongWritable | |
|---|---|
|  void | PiEstimator.PiMapper.map(LongWritable offset,
    LongWritable size,
    OutputCollector<BooleanWritable,LongWritable> out,
    Reporter reporter)Map method. | 
|  void | MultiFileWordCount.MapClass.map(MultiFileWordCount.WordOffset key,
    Text value,
    OutputCollector<Text,LongWritable> output,
    Reporter reporter) | 
|  void | PiEstimator.PiReducer.reduce(BooleanWritable isInside,
       Iterator<LongWritable> values,
       OutputCollector<WritableComparable<?>,Writable> output,
       Reporter reporter)Accumulate number of points inside/outside results from the mappers. | 
| Uses of LongWritable in org.apache.hadoop.examples.terasort | 
|---|
| Methods in org.apache.hadoop.examples.terasort with parameters of type LongWritable | |
|---|---|
|  void | TeraGen.SortGenMapper.map(LongWritable row,
    NullWritable ignored,
    OutputCollector<Text,Text> output,
    Reporter reporter) | 
| Uses of LongWritable in org.apache.hadoop.mapred | 
|---|
| Methods in org.apache.hadoop.mapred that return LongWritable | |
|---|---|
|  LongWritable | LineRecordReader.createKey() | 
| Methods in org.apache.hadoop.mapred that return types with arguments of type LongWritable | |
|---|---|
|  RecordReader<LongWritable,Text> | TextInputFormat.getRecordReader(InputSplit genericSplit,
                JobConf job,
                Reporter reporter) | 
| Methods in org.apache.hadoop.mapred with parameters of type LongWritable | |
|---|---|
|  boolean | LineRecordReader.next(LongWritable key,
     Text value)Read a line. | 
| Uses of LongWritable in org.apache.hadoop.mapred.lib | 
|---|
| Methods in org.apache.hadoop.mapred.lib that return types with arguments of type LongWritable | |
|---|---|
|  RecordReader<LongWritable,Text> | NLineInputFormat.getRecordReader(InputSplit genericSplit,
                JobConf job,
                Reporter reporter) | 
| Method parameters in org.apache.hadoop.mapred.lib with type arguments of type LongWritable | |
|---|---|
|  void | TokenCountMapper.map(K key,
    Text value,
    OutputCollector<Text,LongWritable> output,
    Reporter reporter) | 
|  void | RegexMapper.map(K key,
    Text value,
    OutputCollector<Text,LongWritable> output,
    Reporter reporter) | 
|  void | LongSumReducer.reduce(K key,
       Iterator<LongWritable> values,
       OutputCollector<K,LongWritable> output,
       Reporter reporter) | 
|  void | LongSumReducer.reduce(K key,
       Iterator<LongWritable> values,
       OutputCollector<K,LongWritable> output,
       Reporter reporter) | 
| Uses of LongWritable in org.apache.hadoop.mapred.lib.db | 
|---|
| Methods in org.apache.hadoop.mapred.lib.db that return LongWritable | |
|---|---|
|  LongWritable | DBInputFormat.DBRecordReader.createKey()Create an object of the appropriate type to be used as a key. | 
| Methods in org.apache.hadoop.mapred.lib.db that return types with arguments of type LongWritable | |
|---|---|
|  RecordReader<LongWritable,T> | DBInputFormat.getRecordReader(InputSplit split,
                JobConf job,
                Reporter reporter)Get the RecordReaderfor the givenInputSplit. | 
| Methods in org.apache.hadoop.mapred.lib.db with parameters of type LongWritable | |
|---|---|
|  boolean | DBInputFormat.DBRecordReader.next(LongWritable key,
     T value)Reads the next key/value pair from the input for processing. | 
| Uses of LongWritable in org.apache.hadoop.mapreduce.lib.db | 
|---|
| Methods in org.apache.hadoop.mapreduce.lib.db that return LongWritable | |
|---|---|
|  LongWritable | DBRecordReader.getCurrentKey()Get the current key | 
| Methods in org.apache.hadoop.mapreduce.lib.db that return types with arguments of type LongWritable | |
|---|---|
| protected  RecordReader<LongWritable,T> | DBInputFormat.createDBRecordReader(DBInputFormat.DBInputSplit split,
                     Configuration conf) | 
| protected  RecordReader<LongWritable,T> | OracleDataDrivenDBInputFormat.createDBRecordReader(DBInputFormat.DBInputSplit split,
                     Configuration conf) | 
| protected  RecordReader<LongWritable,T> | DataDrivenDBInputFormat.createDBRecordReader(DBInputFormat.DBInputSplit split,
                     Configuration conf) | 
|  RecordReader<LongWritable,T> | DBInputFormat.createRecordReader(InputSplit split,
                   TaskAttemptContext context)Create a record reader for a given split. | 
| Methods in org.apache.hadoop.mapreduce.lib.db with parameters of type LongWritable | |
|---|---|
|  boolean | DBRecordReader.next(LongWritable key,
     T value)Deprecated. Use DBRecordReader.nextKeyValue() | 
| Uses of LongWritable in org.apache.hadoop.mapreduce.lib.input | 
|---|
| Methods in org.apache.hadoop.mapreduce.lib.input that return LongWritable | |
|---|---|
|  LongWritable | LineRecordReader.getCurrentKey() | 
| Methods in org.apache.hadoop.mapreduce.lib.input that return types with arguments of type LongWritable | |
|---|---|
|  RecordReader<LongWritable,Text> | NLineInputFormat.createRecordReader(InputSplit genericSplit,
                   TaskAttemptContext context) | 
|  RecordReader<LongWritable,Text> | TextInputFormat.createRecordReader(InputSplit split,
                   TaskAttemptContext context) | 
| Uses of LongWritable in org.apache.hadoop.mapreduce.lib.reduce | 
|---|
| Method parameters in org.apache.hadoop.mapreduce.lib.reduce with type arguments of type LongWritable | |
|---|---|
|  void | LongSumReducer.reduce(KEY key,
       Iterable<LongWritable> values,
       Reducer.Context context) | 
| Uses of LongWritable in org.apache.hadoop.typedbytes | 
|---|
| Methods in org.apache.hadoop.typedbytes that return LongWritable | |
|---|---|
|  LongWritable | TypedBytesWritableInput.readLong() | 
|  LongWritable | TypedBytesWritableInput.readLong(LongWritable lw) | 
| Methods in org.apache.hadoop.typedbytes with parameters of type LongWritable | |
|---|---|
|  LongWritable | TypedBytesWritableInput.readLong(LongWritable lw) | 
|  void | TypedBytesWritableOutput.writeLong(LongWritable lw) | 
| 
 | ||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||