Uses of Class
org.apache.hadoop.mrunit.types.Pair

Packages that use Pair
org.apache.hadoop.mrunit
org.apache.hadoop.mrunit.mapreduce   
org.apache.hadoop.mrunit.mapreduce.mock   
org.apache.hadoop.mrunit.mock   
org.apache.hadoop.mrunit.types   
 

Uses of Pair in org.apache.hadoop.mrunit
 

Fields in org.apache.hadoop.mrunit with type parameters of type Pair
protected  List<Pair<Enum,Long>> TestDriver.expectedEnumCounters
           
protected  List<Pair<K2,V2>> TestDriver.expectedOutputs
           
protected  List<Pair<Pair<String,String>,Long>> TestDriver.expectedStringCounters
           
protected  List<Pair<Pair<String,String>,Long>> TestDriver.expectedStringCounters
           
protected  List<Pair<K1,V1>> MapReduceDriverBase.inputList
           
 

Methods in org.apache.hadoop.mrunit that return Pair
static Pair<org.apache.hadoop.io.Text,org.apache.hadoop.io.Text> TestDriver.parseTabbedPair(String tabSeparatedPair)
          Split "key \t val" into Pair(Text(key), Text(val))
 

Methods in org.apache.hadoop.mrunit that return types with arguments of type Pair
 List<Pair<Enum,Long>> TestDriver.getExpectedEnumCounters()
           
 List<Pair<K2,V2>> TestDriver.getExpectedOutputs()
           
 List<Pair<Pair<String,String>,Long>> TestDriver.getExpectedStringCounters()
           
 List<Pair<Pair<String,String>,Long>> TestDriver.getExpectedStringCounters()
           
 List<Pair<org.apache.hadoop.mapred.Mapper,org.apache.hadoop.mapred.Reducer>> PipelineMapReduceDriver.getMapReducePipeline()
           
abstract  List<Pair<K3,V3>> MapReduceDriverBase.run()
           
 List<Pair<K3,V3>> MapReduceDriver.run()
           
 List<Pair<K2,V2>> PipelineMapReduceDriver.run()
           
 List<Pair<K2,V2>> MapDriver.run()
           
 List<Pair<K2,V2>> ReduceDriver.run()
           
abstract  List<Pair<K2,V2>> TestDriver.run()
          Runs the test but returns the result set instead of validating it (ignores any addOutput(), etc calls made before this)
abstract  List<Pair<K2,V2>> ReduceDriverBase.run()
           
abstract  List<Pair<K2,V2>> MapDriverBase.run()
           
 List<Pair<K2,List<V2>>> MapReduceDriverBase.shuffle(List<Pair<K2,V2>> mapOutputs)
          Take the outputs from the Mapper, combine all values for the same key, and sort them by key.
 

Methods in org.apache.hadoop.mrunit with parameters of type Pair
 void MapReduceDriverBase.addInput(Pair<K1,V1> input)
          Adds an input to send to the Mapper
 void PipelineMapReduceDriver.addInput(Pair<K1,V1> input)
          Adds an input to send to the Mapper
 void PipelineMapReduceDriver.addMapReduce(Pair<org.apache.hadoop.mapred.Mapper,org.apache.hadoop.mapred.Reducer> p)
          Add a Mapper and Reducer instance to the pipeline to use with this test driver
 void PipelineMapReduceDriver.addOutput(Pair<K2,V2> outputRecord)
          Adds an output (k, v) pair we expect from the Reducer
 void ReduceDriverBase.addOutput(Pair<K2,V2> outputRecord)
          Adds an output (k, v) pair we expect from the Reducer
 void MapDriverBase.addOutput(Pair<K2,V2> outputRecord)
          Adds an output (k, v) pair we expect from the Mapper
 void MapReduceDriverBase.addOutput(Pair<K3,V3> outputRecord)
          Adds an output (k, v) pair we expect from the Reducer
 void MapDriverBase.setInput(Pair<K1,V1> inputRecord)
          Sets the input to send to the mapper
 MapReduceDriver<K1,V1,K2,V2,K3,V3> MapReduceDriver.withInput(Pair<K1,V1> input)
          Identical to addInput() but returns self for fluent programming style
 PipelineMapReduceDriver<K1,V1,K2,V2> PipelineMapReduceDriver.withInput(Pair<K1,V1> input)
          Identical to addInput() but returns self for fluent programming style
 MapDriver<K1,V1,K2,V2> MapDriver.withInput(Pair<K1,V1> inputRecord)
          Identical to setInput() but returns self for fluent programming style
 PipelineMapReduceDriver<K1,V1,K2,V2> PipelineMapReduceDriver.withMapReduce(Pair<org.apache.hadoop.mapred.Mapper,org.apache.hadoop.mapred.Reducer> p)
          Add a Mapper and Reducer instance to the pipeline to use with this test driver using fluent style
 PipelineMapReduceDriver<K1,V1,K2,V2> PipelineMapReduceDriver.withOutput(Pair<K2,V2> outputRecord)
          Works like addOutput(), but returns self for fluent style
 MapDriver<K1,V1,K2,V2> MapDriver.withOutput(Pair<K2,V2> outputRecord)
          Works like addOutput(), but returns self for fluent style
 ReduceDriver<K1,V1,K2,V2> ReduceDriver.withOutput(Pair<K2,V2> outputRecord)
          Works like addOutput(), but returns self for fluent style
 MapReduceDriver<K1,V1,K2,V2,K3,V3> MapReduceDriver.withOutput(Pair<K3,V3> outputRecord)
          Works like addOutput(), but returns self for fluent style
 

Method parameters in org.apache.hadoop.mrunit with type arguments of type Pair
static
<K1,V1,K2,V2>
PipelineMapReduceDriver<K1,V1,K2,V2>
PipelineMapReduceDriver.newPipelineMapReduceDriver(List<Pair<org.apache.hadoop.mapred.Mapper,org.apache.hadoop.mapred.Reducer>> pipeline)
          Returns a new PipelineMapReduceDriver without having to specify the generic types on the right hand side of the object create statement.
 List<Pair<K2,List<V2>>> MapReduceDriverBase.shuffle(List<Pair<K2,V2>> mapOutputs)
          Take the outputs from the Mapper, combine all values for the same key, and sort them by key.
protected  void TestDriver.validate(List<Pair<K2,V2>> outputs, boolean orderMatters)
          check the outputs against the expected inputs in record
 

Constructor parameters in org.apache.hadoop.mrunit with type arguments of type Pair
PipelineMapReduceDriver(List<Pair<org.apache.hadoop.mapred.Mapper,org.apache.hadoop.mapred.Reducer>> pipeline)
           
 

Uses of Pair in org.apache.hadoop.mrunit.mapreduce
 

Methods in org.apache.hadoop.mrunit.mapreduce that return types with arguments of type Pair
 List<Pair<K3,V3>> MapReduceDriver.run()
           
 List<Pair<K2,V2>> MapDriver.run()
           
 List<Pair<K2,V2>> ReduceDriver.run()
           
 

Methods in org.apache.hadoop.mrunit.mapreduce with parameters of type Pair
 MapReduceDriver<K1,V1,K2,V2,K3,V3> MapReduceDriver.withInput(Pair<K1,V1> input)
          Identical to addInput() but returns self for fluent programming style
 MapDriver<K1,V1,K2,V2> MapDriver.withInput(Pair<K1,V1> inputRecord)
          Identical to setInput() but returns self for fluent programming style
 MapDriver<K1,V1,K2,V2> MapDriver.withOutput(Pair<K2,V2> outputRecord)
          Works like addOutput(), but returns self for fluent style
 ReduceDriver<K1,V1,K2,V2> ReduceDriver.withOutput(Pair<K2,V2> outputRecord)
          Works like addOutput(), but returns self for fluent style
 MapReduceDriver<K1,V1,K2,V2,K3,V3> MapReduceDriver.withOutput(Pair<K3,V3> outputRecord)
          Works like addOutput(), but returns self for fluent style
 

Uses of Pair in org.apache.hadoop.mrunit.mapreduce.mock
 

Fields in org.apache.hadoop.mrunit.mapreduce.mock declared as Pair
protected  Pair<KEYIN,List<VALUEIN>> MockReduceContextWrapper.currentKeyValue
           
protected  Pair<KEYIN,VALUEIN> MockMapContextWrapper.currentKeyValue
           
 

Fields in org.apache.hadoop.mrunit.mapreduce.mock with type parameters of type Pair
protected  List<Pair<KEYIN,List<VALUEIN>>> MockReduceContextWrapper.inputs
           
protected  List<Pair<KEYIN,VALUEIN>> MockMapContextWrapper.inputs
           
protected  List<Pair<KEYOUT,VALUEOUT>> MockContextWrapper.outputs
           
 

Methods in org.apache.hadoop.mrunit.mapreduce.mock that return types with arguments of type Pair
 List<Pair<KEYOUT,VALUEOUT>> MockReduceContextWrapper.getOutputs()
           
 List<Pair<KEYOUT,VALUEOUT>> MockMapContextWrapper.getOutputs()
           
 

Constructor parameters in org.apache.hadoop.mrunit.mapreduce.mock with type arguments of type Pair
MockMapContextWrapper(List<Pair<KEYIN,VALUEIN>> inputs, org.apache.hadoop.mapreduce.Counters counters, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.mapreduce.InputSplit inputSplit)
           
MockReduceContextWrapper(List<Pair<KEYIN,List<VALUEIN>>> inputs, org.apache.hadoop.mapreduce.Counters counters, org.apache.hadoop.conf.Configuration conf)
           
 

Uses of Pair in org.apache.hadoop.mrunit.mock
 

Methods in org.apache.hadoop.mrunit.mock that return types with arguments of type Pair
 List<Pair<K,V>> MockOutputCollector.getOutputs()
           
 

Uses of Pair in org.apache.hadoop.mrunit.types
 

Methods in org.apache.hadoop.mrunit.types with parameters of type Pair
 int Pair.FirstElemComparator.compare(Pair<S,T> p1, Pair<S,T> p2)
           
 int Pair.FirstElemComparator.compare(Pair<S,T> p1, Pair<S,T> p2)
           
 int Pair.SecondElemComparator.compare(Pair<S,T> p1, Pair<S,T> p2)
           
 int Pair.SecondElemComparator.compare(Pair<S,T> p1, Pair<S,T> p2)
           
 int Pair.compareTo(Pair<S,T> p)
           
 



Copyright © 2012 The Apache Software Foundation. All Rights Reserved.