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

Packages that use LongWritable
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   
org.apache.hadoop.mapred.lib   
org.apache.hadoop.mapred.lib.db   
org.apache.hadoop.mapreduce.lib.db   
org.apache.hadoop.mapreduce.lib.input   
org.apache.hadoop.mapreduce.lib.reduce   
 

Uses of LongWritable in org.apache.hadoop.io
 

Methods in org.apache.hadoop.io with parameters of type LongWritable
 int LongWritable.compareTo(LongWritable o)
          Compares two LongWritables.
 

Uses of LongWritable in org.apache.hadoop.mapred
 

Methods in org.apache.hadoop.mapred that return types with arguments of type LongWritable
 RecordReader<LongWritable,BytesWritable> FixedLengthInputFormat.getRecordReader(InputSplit genericSplit, JobConf job, Reporter reporter)
           
 RecordReader<LongWritable,Text> TextInputFormat.getRecordReader(InputSplit genericSplit, JobConf job, Reporter reporter)
           
 

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> CombineTextInputFormat.getRecordReader(InputSplit split, JobConf conf, Reporter reporter)
           
 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 RegexMapper.map(K key, Text value, OutputCollector<Text,LongWritable> output, Reporter reporter)
           
 void TokenCountMapper.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 types with arguments of type LongWritable
 RecordReader<LongWritable,T> DBInputFormat.getRecordReader(InputSplit split, JobConf job, Reporter reporter)
          Get the RecordReader for the given InputSplit.
 

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> OracleDataDrivenDBInputFormat.createDBRecordReader(org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit split, Configuration conf)
           
protected  RecordReader<LongWritable,T> DataDrivenDBInputFormat.createDBRecordReader(org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit split, Configuration conf)
           
protected  RecordReader<LongWritable,T> DBInputFormat.createDBRecordReader(org.apache.hadoop.mapreduce.lib.db.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 types with arguments of type LongWritable
 RecordReader<LongWritable,BytesWritable> FixedLengthInputFormat.createRecordReader(InputSplit split, TaskAttemptContext context)
           
 RecordReader<LongWritable,Text> CombineTextInputFormat.createRecordReader(InputSplit split, TaskAttemptContext context)
           
 RecordReader<LongWritable,Text> TextInputFormat.createRecordReader(InputSplit split, TaskAttemptContext context)
           
 RecordReader<LongWritable,Text> NLineInputFormat.createRecordReader(InputSplit genericSplit, 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, org.apache.hadoop.mapreduce.Reducer.Context context)
           
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.