| 
 | |||||||||
| PREV NEXT | FRAMES NO FRAMES | ||||||||
| Packages that use Pair | |
|---|---|
| org.apache.crunch | Client-facing API and core abstractions. | 
| org.apache.crunch.contrib.bloomfilter | Support for creating Bloom Filters. | 
| org.apache.crunch.contrib.text | |
| org.apache.crunch.fn | Commonly used functions for manipulating collections. | 
| org.apache.crunch.impl.mem | In-memory Pipeline implementation for rapid prototyping and testing. | 
| org.apache.crunch.lib | Joining, sorting, aggregating, and other commonly used functionality. | 
| org.apache.crunch.lib.join | Inner and outer joins on collections. | 
| org.apache.crunch.types | Common functionality for business object serialization. | 
| org.apache.crunch.types.avro | Business object serialization using Apache Avro. | 
| org.apache.crunch.types.writable | Business object serialization using Hadoop's Writables framework. | 
| org.apache.crunch.util | An assorted set of utilities. | 
| Uses of Pair in org.apache.crunch | 
|---|
| Methods in org.apache.crunch that return Pair | ||
|---|---|---|
| static
 | Pair.of(T first,
   U second) | |
| Methods in org.apache.crunch that return types with arguments of type Pair | ||
|---|---|---|
| 
 | PTable.cogroup(PTable<K,U> other)Co-group operation with the given table on common keys. | |
| 
 | PTable.join(PTable<K,U> other)Perform an inner join on this table and the one passed in as an argument on their common keys. | |
| static
 | CombineFn.pairAggregator(CombineFn.AggregatorFactory<V1> a1,
               CombineFn.AggregatorFactory<V2> a2)Deprecated. Use Aggregators.pairAggregator(Aggregator, Aggregator) | |
|  Iterable<Pair<V1,V2>> | CombineFn.PairAggregator.results()Deprecated. | |
| Methods in org.apache.crunch with parameters of type Pair | |
|---|---|
|  int | Pair.compareTo(Pair<K,V> o) | 
|  void | CombineFn.AggregatorCombineFn.process(Pair<K,Iterable<V>> input,
        Emitter<Pair<K,V>> emitter)Deprecated. | 
|  void | CombineFn.PairAggregator.update(Pair<V1,V2> value)Deprecated. | 
| Method parameters in org.apache.crunch with type arguments of type Pair | ||
|---|---|---|
|  PTable<K,V> | PTable.filter(FilterFn<Pair<K,V>> filterFn)Apply the given filter function to this instance and return the resulting PTable. | |
|  PTable<K,V> | PTable.filter(String name,
       FilterFn<Pair<K,V>> filterFn)Apply the given filter function to this instance and return the resulting PTable. | |
| 
 | PCollection.parallelDo(DoFn<S,Pair<K,V>> doFn,
           PTableType<K,V> type)Similar to the other parallelDoinstance, but returns aPTableinstance instead of aPCollection. | |
| 
 | PCollection.parallelDo(String name,
           DoFn<S,Pair<K,V>> doFn,
           PTableType<K,V> type)Similar to the other parallelDoinstance, but returns aPTableinstance instead of aPCollection. | |
| 
 | PCollection.parallelDo(String name,
           DoFn<S,Pair<K,V>> doFn,
           PTableType<K,V> type,
           ParallelDoOptions options)Similar to the other parallelDoinstance, but returns aPTableinstance instead of aPCollection. | |
|  void | CombineFn.AggregatorCombineFn.process(Pair<K,Iterable<V>> input,
        Emitter<Pair<K,V>> emitter)Deprecated. | |
| Uses of Pair in org.apache.crunch.contrib.bloomfilter | 
|---|
| Method parameters in org.apache.crunch.contrib.bloomfilter with type arguments of type Pair | |
|---|---|
|  void | BloomFilterFn.cleanup(Emitter<Pair<String,org.apache.hadoop.util.bloom.BloomFilter>> emitter) | 
|  void | BloomFilterFn.process(S input,
        Emitter<Pair<String,org.apache.hadoop.util.bloom.BloomFilter>> emitter) | 
| Uses of Pair in org.apache.crunch.contrib.text | 
|---|
| Methods in org.apache.crunch.contrib.text that return types with arguments of type Pair | ||
|---|---|---|
| static
 | Extractors.xpair(TokenizerFactory scannerFactory,
      Extractor<K> one,
      Extractor<V> two)Returns an Extractor for pairs of the given types that uses the given TokenizerFactoryfor parsing the sub-fields. | |
| Method parameters in org.apache.crunch.contrib.text with type arguments of type Pair | ||
|---|---|---|
| static
 | Parse.parseTable(String groupName,
           PCollection<String> input,
           Extractor<Pair<K,V>> extractor)Parses the lines of the input PCollection<String>and returns aPTable<K, V>using
 the givenExtractor<Pair<K, V>>. | |
| static
 | Parse.parseTable(String groupName,
           PCollection<String> input,
           PTypeFamily ptf,
           Extractor<Pair<K,V>> extractor)Parses the lines of the input PCollection<String>and returns aPTable<K, V>using
 the givenExtractor<Pair<K, V>>that uses the givenPTypeFamily. | |
| Uses of Pair in org.apache.crunch.fn | 
|---|
| Methods in org.apache.crunch.fn that return Pair | |
|---|---|
|  Pair<S,T> | PairMapFn.map(Pair<K,V> input) | 
|  Pair<K,V> | ExtractKeyFn.map(V input) | 
| Methods in org.apache.crunch.fn that return types with arguments of type Pair | ||
|---|---|---|
| static
 | Aggregators.pairAggregator(Aggregator<V1> a1,
               Aggregator<V2> a2)Apply separate aggregators to each component of a Pair. | |
| Methods in org.apache.crunch.fn with parameters of type Pair | |
|---|---|
|  Pair<S,T> | PairMapFn.map(Pair<K,V> input) | 
|  void | MapKeysFn.process(Pair<K1,V> input,
        Emitter<Pair<K2,V>> emitter) | 
|  void | MapValuesFn.process(Pair<K,V1> input,
        Emitter<Pair<K,V2>> emitter) | 
| Method parameters in org.apache.crunch.fn with type arguments of type Pair | |
|---|---|
|  void | PairMapFn.cleanup(Emitter<Pair<S,T>> emitter) | 
|  void | MapKeysFn.process(Pair<K1,V> input,
        Emitter<Pair<K2,V>> emitter) | 
|  void | MapValuesFn.process(Pair<K,V1> input,
        Emitter<Pair<K,V2>> emitter) | 
| Uses of Pair in org.apache.crunch.impl.mem | 
|---|
| Method parameters in org.apache.crunch.impl.mem with type arguments of type Pair | ||
|---|---|---|
| static
 | MemPipeline.tableOf(Iterable<Pair<S,T>> pairs) | |
| static
 | MemPipeline.typedTableOf(PTableType<S,T> ptype,
             Iterable<Pair<S,T>> pairs) | |
| Uses of Pair in org.apache.crunch.lib | 
|---|
| Methods in org.apache.crunch.lib that return Pair | ||
|---|---|---|
| static
 | PTables.getDetachedValue(PTableType<K,V> tableType,
                 Pair<K,V> value)Create a detached value for a table Pair. | |
| static
 | PTables.getGroupedDetachedValue(PGroupedTableType<K,V> groupedTableType,
                        Pair<K,Iterable<V>> value)Created a detached value for a PGroupedTablevalue. | |
| Methods in org.apache.crunch.lib that return types with arguments of type Pair | ||
|---|---|---|
| static
 | Cogroup.cogroup(PTable<K,U> left,
        PTable<K,V> right)Co-groups the two PTablearguments. | |
| static
 | Cartesian.cross(PCollection<U> left,
      PCollection<V> right)Performs a full cross join on the specified PCollections (using the
 same strategy as Pig's CROSS operator). | |
| static
 | Cartesian.cross(PCollection<U> left,
      PCollection<V> right,
      int parallelism)Performs a full cross join on the specified PCollections (using the
 same strategy as Pig's CROSS operator). | |
| static
 | Cartesian.cross(PTable<K1,U> left,
      PTable<K2,V> right)Performs a full cross join on the specified PTables (using the same
 strategy as Pig's CROSS operator). | |
| static
 | Cartesian.cross(PTable<K1,U> left,
      PTable<K2,V> right)Performs a full cross join on the specified PTables (using the same
 strategy as Pig's CROSS operator). | |
| static
 | Cartesian.cross(PTable<K1,U> left,
      PTable<K2,V> right,
      int parallelism)Performs a full cross join on the specified PTables (using the same
 strategy as Pig's CROSS operator). | |
| static
 | Cartesian.cross(PTable<K1,U> left,
      PTable<K2,V> right,
      int parallelism)Performs a full cross join on the specified PTables (using the same
 strategy as Pig's CROSS operator). | |
| static
 | Join.fullJoin(PTable<K,U> left,
         PTable<K,V> right)Performs a full outer join on the specified PTables. | |
| static
 | Sample.groupedWeightedReservoirSample(PTable<Integer,Pair<T,N>> input,
                               int[] sampleSizes)The most general purpose of the weighted reservoir sampling patterns that allows us to choose a random sample of elements for each of N input groups. | |
| static
 | Sample.groupedWeightedReservoirSample(PTable<Integer,Pair<T,N>> input,
                               int[] sampleSizes,
                               Long seed)Same as the other groupedWeightedReservoirSample method, but include a seed for testing purposes. | |
| static
 | Join.innerJoin(PTable<K,U> left,
          PTable<K,V> right)Performs an inner join on the specified PTables. | |
| static
 | Join.join(PTable<K,U> left,
     PTable<K,V> right)Performs an inner join on the specified PTables. | |
| static
 | Join.join(PTable<K,U> left,
     PTable<K,V> right,
     JoinFn<K,U,V> joinFn) | |
| static
 | Join.leftJoin(PTable<K,U> left,
         PTable<K,V> right)Performs a left outer join on the specified PTables. | |
| static
 | Join.rightJoin(PTable<K,U> left,
          PTable<K,V> right)Performs a right outer join on the specified PTables. | |
| static
 | Sort.sortPairs(PCollection<Pair<U,V>> collection,
          Sort.ColumnOrder... columnOrders)Sorts the PCollectionofPairs using the specified column
 ordering. | |
| Methods in org.apache.crunch.lib with parameters of type Pair | ||
|---|---|---|
|  int | Aggregate.PairValueComparator.compare(Pair<K,V> left,
        Pair<K,V> right) | |
|  int | Aggregate.PairValueComparator.compare(Pair<K,V> left,
        Pair<K,V> right) | |
| static
 | PTables.getDetachedValue(PTableType<K,V> tableType,
                 Pair<K,V> value)Create a detached value for a table Pair. | |
| static
 | PTables.getGroupedDetachedValue(PGroupedTableType<K,V> groupedTableType,
                        Pair<K,Iterable<V>> value)Created a detached value for a PGroupedTablevalue. | |
|  void | Aggregate.TopKCombineFn.process(Pair<Integer,Iterable<Pair<K,V>>> input,
        Emitter<Pair<Integer,Pair<K,V>>> emitter) | |
|  void | Aggregate.TopKFn.process(Pair<K,V> input,
        Emitter<Pair<Integer,Pair<K,V>>> emitter) | |
| Method parameters in org.apache.crunch.lib with type arguments of type Pair | ||
|---|---|---|
| static
 | PTables.asPTable(PCollection<Pair<K,V>> pcollect)Convert the given PCollection<Pair<K, V>>to aPTable<K, V>. | |
|  void | Aggregate.TopKFn.cleanup(Emitter<Pair<Integer,Pair<K,V>>> emitter) | |
|  void | Aggregate.TopKFn.cleanup(Emitter<Pair<Integer,Pair<K,V>>> emitter) | |
| static
 | Sample.groupedWeightedReservoirSample(PTable<Integer,Pair<T,N>> input,
                               int[] sampleSizes)The most general purpose of the weighted reservoir sampling patterns that allows us to choose a random sample of elements for each of N input groups. | |
| static
 | Sample.groupedWeightedReservoirSample(PTable<Integer,Pair<T,N>> input,
                               int[] sampleSizes,
                               Long seed)Same as the other groupedWeightedReservoirSample method, but include a seed for testing purposes. | |
|  void | Aggregate.TopKCombineFn.process(Pair<Integer,Iterable<Pair<K,V>>> input,
        Emitter<Pair<Integer,Pair<K,V>>> emitter) | |
|  void | Aggregate.TopKCombineFn.process(Pair<Integer,Iterable<Pair<K,V>>> input,
        Emitter<Pair<Integer,Pair<K,V>>> emitter) | |
|  void | Aggregate.TopKCombineFn.process(Pair<Integer,Iterable<Pair<K,V>>> input,
        Emitter<Pair<Integer,Pair<K,V>>> emitter) | |
|  void | Aggregate.TopKFn.process(Pair<K,V> input,
        Emitter<Pair<Integer,Pair<K,V>>> emitter) | |
|  void | Aggregate.TopKFn.process(Pair<K,V> input,
        Emitter<Pair<Integer,Pair<K,V>>> emitter) | |
| static
 | SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
             DoFn<Pair<K,Iterable<Pair<V1,V2>>>,Pair<U,V>> doFn,
             PTableType<U,V> ptype)Perform a secondary sort on the given PTableinstance and then apply aDoFnto the resulting sorted data to yield an outputPTable<U, V>. | |
| static
 | SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
             DoFn<Pair<K,Iterable<Pair<V1,V2>>>,Pair<U,V>> doFn,
             PTableType<U,V> ptype)Perform a secondary sort on the given PTableinstance and then apply aDoFnto the resulting sorted data to yield an outputPTable<U, V>. | |
| static
 | SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
             DoFn<Pair<K,Iterable<Pair<V1,V2>>>,Pair<U,V>> doFn,
             PTableType<U,V> ptype)Perform a secondary sort on the given PTableinstance and then apply aDoFnto the resulting sorted data to yield an outputPTable<U, V>. | |
| static
 | SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
             DoFn<Pair<K,Iterable<Pair<V1,V2>>>,Pair<U,V>> doFn,
             PTableType<U,V> ptype)Perform a secondary sort on the given PTableinstance and then apply aDoFnto the resulting sorted data to yield an outputPTable<U, V>. | |
| static
 | SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
             DoFn<Pair<K,Iterable<Pair<V1,V2>>>,T> doFn,
             PType<T> ptype)Perform a secondary sort on the given PTableinstance and then apply aDoFnto the resulting sorted data to yield an outputPCollection<T>. | |
| static
 | SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
             DoFn<Pair<K,Iterable<Pair<V1,V2>>>,T> doFn,
             PType<T> ptype)Perform a secondary sort on the given PTableinstance and then apply aDoFnto the resulting sorted data to yield an outputPCollection<T>. | |
| static
 | SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
             DoFn<Pair<K,Iterable<Pair<V1,V2>>>,T> doFn,
             PType<T> ptype)Perform a secondary sort on the given PTableinstance and then apply aDoFnto the resulting sorted data to yield an outputPCollection<T>. | |
| static
 | Sort.sortPairs(PCollection<Pair<U,V>> collection,
          Sort.ColumnOrder... columnOrders)Sorts the PCollectionofPairs using the specified column
 ordering. | |
| static
 | Sample.weightedReservoirSample(PCollection<Pair<T,N>> input,
                        int sampleSize)Selects a weighted sample of the elements of the given PCollection, where the second term in
 the inputPairis a numerical weight. | |
| static
 | Sample.weightedReservoirSample(PCollection<Pair<T,N>> input,
                        int sampleSize,
                        Long seed)The weighted reservoir sampling function with the seed term exposed for testing purposes. | |
| Uses of Pair in org.apache.crunch.lib.join | 
|---|
| Methods in org.apache.crunch.lib.join that return types with arguments of type Pair | ||
|---|---|---|
| static
 | MapsideJoin.join(PTable<K,U> left,
     PTable<K,V> right)Join two tables using a map side join. | |
| Methods in org.apache.crunch.lib.join with parameters of type Pair | |
|---|---|
|  void | JoinFn.process(Pair<Pair<K,Integer>,Iterable<Pair<U,V>>> input,
        Emitter<Pair<K,Pair<U,V>>> emitter)Split up the input record to make coding a bit more manageable. | 
| Method parameters in org.apache.crunch.lib.join with type arguments of type Pair | |
|---|---|
|  void | LeftOuterJoinFn.cleanup(Emitter<Pair<K,Pair<U,V>>> emitter)Called during the cleanup of the MapReduce job this DoFnis
 associated with. | 
|  void | LeftOuterJoinFn.cleanup(Emitter<Pair<K,Pair<U,V>>> emitter)Called during the cleanup of the MapReduce job this DoFnis
 associated with. | 
|  void | FullOuterJoinFn.cleanup(Emitter<Pair<K,Pair<U,V>>> emitter)Called during the cleanup of the MapReduce job this DoFnis
 associated with. | 
|  void | FullOuterJoinFn.cleanup(Emitter<Pair<K,Pair<U,V>>> emitter)Called during the cleanup of the MapReduce job this DoFnis
 associated with. | 
|  void | RightOuterJoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
|  void | RightOuterJoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
|  void | RightOuterJoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
|  void | LeftOuterJoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
|  void | LeftOuterJoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
|  void | LeftOuterJoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
| abstract  void | JoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
| abstract  void | JoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
| abstract  void | JoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
|  void | InnerJoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
|  void | InnerJoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
|  void | InnerJoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
|  void | FullOuterJoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
|  void | FullOuterJoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
|  void | FullOuterJoinFn.join(K key,
     int id,
     Iterable<Pair<U,V>> pairs,
     Emitter<Pair<K,Pair<U,V>>> emitter)Performs the actual joining. | 
|  void | JoinFn.process(Pair<Pair<K,Integer>,Iterable<Pair<U,V>>> input,
        Emitter<Pair<K,Pair<U,V>>> emitter)Split up the input record to make coding a bit more manageable. | 
|  void | JoinFn.process(Pair<Pair<K,Integer>,Iterable<Pair<U,V>>> input,
        Emitter<Pair<K,Pair<U,V>>> emitter)Split up the input record to make coding a bit more manageable. | 
|  void | JoinFn.process(Pair<Pair<K,Integer>,Iterable<Pair<U,V>>> input,
        Emitter<Pair<K,Pair<U,V>>> emitter)Split up the input record to make coding a bit more manageable. | 
|  void | JoinFn.process(Pair<Pair<K,Integer>,Iterable<Pair<U,V>>> input,
        Emitter<Pair<K,Pair<U,V>>> emitter)Split up the input record to make coding a bit more manageable. | 
| Uses of Pair in org.apache.crunch.types | 
|---|
| Fields in org.apache.crunch.types with type parameters of type Pair | |
|---|---|
| static TupleFactory<Pair> | TupleFactory.PAIR | 
| Methods in org.apache.crunch.types that return Pair | |
|---|---|
|  Pair<K,Iterable<V>> | PGroupedTableType.PairIterableMapFn.map(Pair<Object,Iterable<Object>> input) | 
| Methods in org.apache.crunch.types that return types with arguments of type Pair | ||
|---|---|---|
|  ReadableSourceTarget<Pair<K,Iterable<V>>> | PGroupedTableType.getDefaultFileSource(org.apache.hadoop.fs.Path path) | |
| 
 | PTypeFamily.pairs(PType<V1> p1,
      PType<V2> p2) | |
| Methods in org.apache.crunch.types with parameters of type Pair | |
|---|---|
|  Pair<K,Iterable<V>> | PGroupedTableType.PairIterableMapFn.map(Pair<Object,Iterable<Object>> input) | 
| Uses of Pair in org.apache.crunch.types.avro | 
|---|
| Methods in org.apache.crunch.types.avro that return types with arguments of type Pair | ||
|---|---|---|
| static
 | Avros.pairs(PType<V1> p1,
      PType<V2> p2) | |
| 
 | AvroTypeFamily.pairs(PType<V1> p1,
      PType<V2> p2) | |
| Uses of Pair in org.apache.crunch.types.writable | 
|---|
| Methods in org.apache.crunch.types.writable that return types with arguments of type Pair | ||
|---|---|---|
| static
 | Writables.pairs(PType<V1> p1,
      PType<V2> p2) | |
| 
 | WritableTypeFamily.pairs(PType<V1> p1,
      PType<V2> p2) | |
| Uses of Pair in org.apache.crunch.util | 
|---|
| Methods in org.apache.crunch.util that return types with arguments of type Pair | |
|---|---|
|  Iterator<Pair<S,T>> | Tuples.PairIterable.iterator() | 
| 
 | |||||||||
| PREV NEXT | FRAMES NO FRAMES | ||||||||