Uses of Interface
org.apache.hadoop.io.RawComparator

Packages that use RawComparator
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.io.serializer This package provides a mechanism for using different serialization frameworks in Hadoop. 
org.apache.hadoop.mapred   
org.apache.hadoop.mapreduce   
org.apache.hadoop.mapreduce.lib.partition   
org.apache.hadoop.record (DEPRECATED) Hadoop record I/O contains classes and a record description language translator for simplifying serialization and deserialization of records in a language-neutral manner. 
 

Uses of RawComparator in org.apache.hadoop.io
 

Classes in org.apache.hadoop.io that implement RawComparator
 class WritableComparator
          A Comparator for WritableComparables.
 

Uses of RawComparator in org.apache.hadoop.io.serializer
 

Classes in org.apache.hadoop.io.serializer that implement RawComparator
 class org.apache.hadoop.io.serializer.DeserializerComparator<T>
           A RawComparator that uses a Deserializer to deserialize the objects to be compared so that the standard Comparator can be used to compare them.
 class JavaSerializationComparator<T extends Serializable & Comparable<T>>
           A RawComparator that uses a JavaSerialization Deserializer to deserialize objects that are then compared via their Comparable interfaces.
 

Uses of RawComparator in org.apache.hadoop.mapred
 

Methods in org.apache.hadoop.mapred that return RawComparator
 RawComparator JobConf.getCombinerKeyGroupingComparator()
          Get the user defined WritableComparable comparator for grouping keys of inputs to the combiner.
 RawComparator JobConf.getOutputKeyComparator()
          Get the RawComparator comparator used to compare keys.
 RawComparator JobConf.getOutputValueGroupingComparator()
          Get the user defined WritableComparable comparator for grouping keys of inputs to the reduce.
 

Method parameters in org.apache.hadoop.mapred with type arguments of type RawComparator
 void JobConf.setCombinerKeyGroupingComparator(Class<? extends RawComparator> theClass)
          Set the user defined RawComparator comparator for grouping keys in the input to the combiner.
 void JobConf.setOutputKeyComparatorClass(Class<? extends RawComparator> theClass)
          Set the RawComparator comparator used to compare keys.
 void JobConf.setOutputValueGroupingComparator(Class<? extends RawComparator> theClass)
          Set the user defined RawComparator comparator for grouping keys in the input to the reduce.
 

Uses of RawComparator in org.apache.hadoop.mapreduce
 

Methods in org.apache.hadoop.mapreduce that return RawComparator
 RawComparator<?> JobContext.getCombinerKeyGroupingComparator()
          Get the user defined RawComparator comparator for grouping keys of inputs to the combiner.
 RawComparator<?> JobContext.getGroupingComparator()
          Get the user defined RawComparator comparator for grouping keys of inputs to the reduce.
 RawComparator<?> JobContext.getSortComparator()
          Get the RawComparator comparator used to compare keys.
 

Method parameters in org.apache.hadoop.mapreduce with type arguments of type RawComparator
 void Job.setCombinerKeyGroupingComparatorClass(Class<? extends RawComparator> cls)
          Define the comparator that controls which keys are grouped together for a single call to combiner, Reducer.reduce(Object, Iterable, org.apache.hadoop.mapreduce.Reducer.Context)
 void Job.setGroupingComparatorClass(Class<? extends RawComparator> cls)
          Define the comparator that controls which keys are grouped together for a single call to Reducer.reduce(Object, Iterable, org.apache.hadoop.mapreduce.Reducer.Context)
 void Job.setSortComparatorClass(Class<? extends RawComparator> cls)
          Define the comparator that controls how the keys are sorted before they are passed to the Reducer.
 

Uses of RawComparator in org.apache.hadoop.mapreduce.lib.partition
 

Classes in org.apache.hadoop.mapreduce.lib.partition that implement RawComparator
 class KeyFieldBasedComparator<K,V>
          This comparator implementation provides a subset of the features provided by the Unix/GNU Sort.
 

Uses of RawComparator in org.apache.hadoop.record
 

Classes in org.apache.hadoop.record that implement RawComparator
 class RecordComparator
          Deprecated. Replaced by Avro.
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.