Uses of Interface
org.apache.hadoop.mapred.JobConfigurable

Packages that use JobConfigurable
org.apache.hadoop.contrib.index.example   
org.apache.hadoop.contrib.index.mapred   
org.apache.hadoop.contrib.utils.join   
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.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.aggregate Classes for performing various counting and aggregations. 
org.apache.hadoop.mapred.lib.db org.apache.hadoop.mapred.lib.db Package 
org.apache.hadoop.streaming Hadoop Streaming is a utility which allows users to create and run Map-Reduce jobs with any executables (e.g. 
 

Uses of JobConfigurable in org.apache.hadoop.contrib.index.example
 

Classes in org.apache.hadoop.contrib.index.example that implement JobConfigurable
 class IdentityLocalAnalysis
          Identity local analysis maps inputs directly into outputs.
 class LineDocLocalAnalysis
          Convert LineDocTextAndOp to DocumentAndOp as required by ILocalAnalysis.
 

Uses of JobConfigurable in org.apache.hadoop.contrib.index.mapred
 

Subinterfaces of JobConfigurable in org.apache.hadoop.contrib.index.mapred
 interface ILocalAnalysis<K extends WritableComparable,V extends Writable>
          Application specific local analysis.
 

Classes in org.apache.hadoop.contrib.index.mapred that implement JobConfigurable
 class IndexUpdateCombiner
          This combiner combines multiple intermediate forms into one intermediate form.
 class IndexUpdateMapper<K extends WritableComparable,V extends Writable>
          This class applies local analysis on a key-value pair and then convert the result docid-operation pair to a shard-and-intermediate form pair.
 class IndexUpdatePartitioner
          This partitioner class puts the values of the same key - in this case the same shard - in the same partition.
 class IndexUpdateReducer
          This reducer applies to a shard the changes for it.
 

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

Classes in org.apache.hadoop.contrib.utils.join that implement JobConfigurable
 class DataJoinMapperBase
          This abstract class serves as the base class for the mapper class of a data join job.
 class DataJoinReducerBase
          This abstract class serves as the base class for the reducer class of a data join job.
 class JobBase
          A common base implementing some statics collecting mechanisms that are commonly used in a typical map/reduce job.
 

Uses of JobConfigurable in org.apache.hadoop.examples
 

Classes in org.apache.hadoop.examples that implement JobConfigurable
static class MultiFileWordCount.MapClass
          This Mapper is similar to the one in MultiFileWordCount.MapClass.
static class PiEstimator.PiMapper
          Mapper class for Pi estimation.
static class PiEstimator.PiReducer
          Reducer class for Pi estimation.
 class SleepJob
          Dummy class for testing MR framefork.
 

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

Classes in org.apache.hadoop.examples.dancing that implement JobConfigurable
static class DistributedPentomino.PentMap
          Each map takes a line, which represents a prefix move and finds all of the solutions that start with that prefix.
 

Uses of JobConfigurable in org.apache.hadoop.examples.terasort
 

Classes in org.apache.hadoop.examples.terasort that implement JobConfigurable
static class TeraGen.SortGenMapper
          The Mapper class that given a row number, will generate the appropriate output line.
 

Uses of JobConfigurable in org.apache.hadoop.mapred
 

Subinterfaces of JobConfigurable in org.apache.hadoop.mapred
 interface Mapper<K1,V1,K2,V2>
          Maps input key/value pairs to a set of intermediate key/value pairs.
 interface MapRunnable<K1,V1,K2,V2>
          Expert: Generic interface for Mappers.
 interface Partitioner<K2,V2>
          Partitions the key space.
 interface Reducer<K2,V2,K3,V3>
          Reduces a set of intermediate values which share a key to a smaller set of values.
 

Classes in org.apache.hadoop.mapred that implement JobConfigurable
 class KeyValueTextInputFormat
          An InputFormat for plain text files.
 class MapReduceBase
          Base class for Mapper and Reducer implementations.
 class MapRunner<K1,V1,K2,V2>
          Default MapRunnable implementation.
 class TextInputFormat
          An InputFormat for plain text files.
 

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

Classes in org.apache.hadoop.mapred.lib that implement JobConfigurable
 class BinaryPartitioner<V>
          Partition BinaryComparable keys using a configurable part of the bytes array returned by BinaryComparable.getBytes().
 class ChainMapper
          The ChainMapper class allows to use multiple Mapper classes within a single Map task.
 class ChainReducer
          The ChainReducer class allows to chain multiple Mapper classes after a Reducer within the Reducer task.
 class DelegatingMapper<K1,V1,K2,V2>
          An Mapper that delegates behaviour of paths to multiple other mappers.
 class FieldSelectionMapReduce<K,V>
          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,V2>
          Partition keys by their Object.hashCode().
 class IdentityMapper<K,V>
          Implements the identity function, mapping inputs directly to outputs.
 class IdentityReducer<K,V>
          Performs no reduction, writing all input values directly to the output.
 class InverseMapper<K,V>
          A Mapper that swaps keys and values.
 class KeyFieldBasedComparator<K,V>
          This comparator implementation provides a subset of the features provided by the Unix/GNU Sort.
 class KeyFieldBasedPartitioner<K2,V2>
          Defines a way to partition keys based on certain key fields (also see KeyFieldBasedComparator.
 class LongSumReducer<K>
          A Reducer that sums long values.
 class MultithreadedMapRunner<K1,V1,K2,V2>
          Multithreaded implementation for @link org.apache.hadoop.mapred.MapRunnable.
 class NLineInputFormat
          NLineInputFormat which splits N lines of input as one split.
 class RegexMapper<K>
          A Mapper that extracts text matching a regular expression.
 class TokenCountMapper<K>
          A Mapper that maps text values into pairs.
 class TotalOrderPartitioner<K extends WritableComparable,V>
          Partitioner effecting a total order by reading split points from an externally generated source.
 

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

Classes in org.apache.hadoop.mapred.lib.aggregate that implement JobConfigurable
 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 JobConfigurable in org.apache.hadoop.mapred.lib.db
 

Classes in org.apache.hadoop.mapred.lib.db that implement JobConfigurable
 class DBInputFormat<T extends DBWritable>
          A InputFormat that reads input data from an SQL table.
 

Uses of JobConfigurable in org.apache.hadoop.streaming
 

Classes in org.apache.hadoop.streaming that implement JobConfigurable
 class PipeCombiner
           
 class PipeMapper
          A generic Mapper bridge.
 class PipeMapRunner<K1,V1,K2,V2>
           
 class PipeReducer
          A generic Reducer bridge.
 class StreamInputFormat
          An input format that selects a RecordReader based on a JobConf property.
 



Copyright © 2009 The Apache Software Foundation