You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@mahout.apache.org by sm...@apache.org on 2014/01/22 07:01:25 UTC

svn commit: r1560259 - in /mahout/trunk: ./ core/src/main/java/org/apache/mahout/fpm/ core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/ core/src/main/java/org/apache/mahout/fpm/pfpgrowth/...

Author: smarthi
Date: Wed Jan 22 06:01:24 2014
New Revision: 1560259

URL: http://svn.apache.org/r1560259
Log:
MAHOUT-1401: Resurrecting Frequent Pattern Mining

Added:
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/
      - copied from r1507954, mahout/trunk/core/src/main/java/org/apache/mahout/fpm/
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/
      - copied from r1507954, mahout/trunk/core/src/test/java/org/apache/mahout/fpm/
    mahout/trunk/examples/src/main/java/org/apache/mahout/fpm/
      - copied from r1507954, mahout/trunk/examples/src/main/java/org/apache/mahout/fpm/
Modified:
    mahout/trunk/CHANGELOG
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/AggregatorMapper.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/AggregatorReducer.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/CountDescendingPairComparator.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthDriver.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/MultiTransactionTreeIterator.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowth.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelCountingMapper.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelCountingReducer.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthCombiner.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthMapper.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthReducer.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/TransactionTree.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/TransactionTreeIterator.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/ContextStatusUpdater.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/ContextWriteOutputCollector.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/SequenceFileOutputCollector.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/StatusUpdater.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/TopKPatternsOutputConverter.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/TransactionIterator.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/integer/IntegerStringOutputConverter.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/string/StringOutputConverter.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/string/TopKStringPatterns.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPGrowth.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPTree.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPTreeDepthCache.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FrequentPatternMaxHeap.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/LeastKCache.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/Pattern.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPGrowthIds.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPGrowthObj.java
    mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPTree.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTest.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTest2.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTestVs.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthSyntheticDataTest.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthTest.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthTest2.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTest.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTest2.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTestVs.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthSynthDataTest2.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthTest.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthTest2.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/TransactionTreeTest.java
    mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FrequentPatternMaxHeapTest.java

Modified: mahout/trunk/CHANGELOG
URL: http://svn.apache.org/viewvc/mahout/trunk/CHANGELOG?rev=1560259&r1=1560258&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/CHANGELOG (original)
+++ mahout/trunk/CHANGELOG Wed Jan 22 06:01:24 2014
@@ -2,10 +2,12 @@ Mahout Change Log
 
 Release 0.9 - unreleased
 
-  MAHOUT-1398: FileDataModel should provide a constructor with a delimiterPattern (Roy Guo via ssc)
+  MAHOUT-1401: Resurrect Frequent Pattern mining (smarthi)
 
   MAHOUT-1400: Remove references to deprecated and removed algorithms from examples scripts (ssc)
 
+  MAHOUT-1398: FileDataModel should provide a constructor with a delimiterPattern (Roy Guo via ssc)
+
   MAHOUT-1396: Accidental use of commons-math won't work with next Hadoop 2 release (srowen)
 
   MAHOUT-1394: Undeprecate Lanczos (ssc)

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/AggregatorMapper.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/AggregatorMapper.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/AggregatorMapper.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/AggregatorMapper.java Wed Jan 22 06:01:24 2014
@@ -32,7 +32,6 @@ import org.apache.mahout.fpm.pfpgrowth.c
  * and select the top K frequent patterns
  * 
  */
-@Deprecated
 public class AggregatorMapper extends Mapper<Text,TopKStringPatterns,Text,TopKStringPatterns> {
   
   @Override

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/AggregatorReducer.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/AggregatorReducer.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/AggregatorReducer.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/AggregatorReducer.java Wed Jan 22 06:01:24 2014
@@ -30,7 +30,6 @@ import org.apache.mahout.fpm.pfpgrowth.c
  * containing that particular item
  * 
  */
-@Deprecated
 public class AggregatorReducer extends Reducer<Text,TopKStringPatterns,Text,TopKStringPatterns> {
   
   private int maxHeapSize = 50;

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/CountDescendingPairComparator.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/CountDescendingPairComparator.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/CountDescendingPairComparator.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/CountDescendingPairComparator.java Wed Jan 22 06:01:24 2014
@@ -27,7 +27,6 @@ import org.apache.mahout.common.Pair;
  * high count first (that is, descending), and for those of equal count, orders by the first element in the
  * pair, ascending. It is used in several places in the FPM code.
  */
-@Deprecated
 public final class CountDescendingPairComparator<A extends Comparable<? super A>,B extends Comparable<? super B>>
   implements Comparator<Pair<A,B>>, Serializable {
 

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthDriver.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthDriver.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthDriver.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthDriver.java Wed Jan 22 06:01:24 2014
@@ -45,7 +45,6 @@ import org.apache.mahout.fpm.pfpgrowth.f
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@Deprecated
 public final class FPGrowthDriver extends AbstractJob {
 
   private static final Logger log = LoggerFactory.getLogger(FPGrowthDriver.class);
@@ -177,8 +176,8 @@ public final class FPGrowthDriver extend
                 minSupport,
                 maxHeapSize,
                 features,
-                new StringOutputConverter(new SequenceFileOutputCollector<Text, TopKStringPatterns>(writer)),
-                new ContextStatusUpdater(null));
+                new StringOutputConverter(new SequenceFileOutputCollector<Text, TopKStringPatterns>(writer))
+        );
       } finally {
         Closeables.close(writer, false);
         Closeables.close(inputStream, true);

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/MultiTransactionTreeIterator.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/MultiTransactionTreeIterator.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/MultiTransactionTreeIterator.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/MultiTransactionTreeIterator.java Wed Jan 22 06:01:24 2014
@@ -26,7 +26,6 @@ import org.apache.mahout.math.list.IntAr
 /**
  * Iterates over multiple transaction trees to produce a single iterator of transactions
  */
-@Deprecated
 public final class MultiTransactionTreeIterator extends AbstractIterator<IntArrayList> {
   
   private final Iterator<Pair<IntArrayList,Long>> pIterator;

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowth.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowth.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowth.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowth.java Wed Jan 22 06:01:24 2014
@@ -55,7 +55,6 @@ import org.apache.mahout.math.list.IntAr
  * http://infolab.stanford.edu/~echang/recsys08-69.pdf
  * 
  */
-@Deprecated
 public final class PFPGrowth {
   
   public static final String ENCODING = "encoding";
@@ -65,11 +64,11 @@ public final class PFPGrowth {
   public static final String MAX_PER_GROUP = "maxPerGroup";
   public static final String OUTPUT = "output";
   public static final String MIN_SUPPORT = "minSupport";
-  public static final String MAX_HEAPSIZE = "maxHeapSize";
+  public static final String MAX_HEAP_SIZE = "maxHeapSize";
   public static final String INPUT = "input";
   public static final String PFP_PARAMETERS = "pfp.parameters";
   public static final String FILE_PATTERN = "part-*";
-  public static final String FPGROWTH = "fpgrowth";
+  public static final String FP_GROWTH = "fpgrowth";
   public static final String FREQUENT_PATTERNS = "frequentpatterns";
   public static final String PARALLEL_COUNTING = "parallelcounting";
   public static final String SPLIT_PATTERN = "splitPattern";
@@ -161,9 +160,7 @@ public final class PFPGrowth {
     return itemId / maxPerGroup;
   }
 
-  public static IntArrayList getGroupMembers(int groupId, 
-                                                   int maxPerGroup, 
-                                                   int numFeatures) {
+  public static IntArrayList getGroupMembers(int groupId, int maxPerGroup, int numFeatures) {
     int start = groupId * maxPerGroup;
     int end = start + maxPerGroup;
     if (end > numFeatures) {
@@ -197,14 +194,12 @@ public final class PFPGrowth {
   }
   
   /**
-   * @throws ClassNotFoundException 
- * @throws InterruptedException 
- * @throws IOException 
- * @params
-   *    input, output locations, additional parameters like minSupport(3), maxHeapSize(50), numGroups(1000)
-   * @conf
-   *    initial Hadoop configuration to use.
-   * 
+   * @param params params
+   * @param conf Configuration
+   * @throws ClassNotFoundException
+   * @throws InterruptedException
+   * @throws IOException
+   *
    * */
   public static void runPFPGrowth(Parameters params, Configuration conf) throws IOException,
                                                                         InterruptedException,
@@ -253,7 +248,7 @@ public final class PFPGrowth {
     conf.set("mapred.compress.map.output", "true");
     conf.set("mapred.output.compression.type", "BLOCK");
     
-    Path input = new Path(params.get(OUTPUT), FPGROWTH);
+    Path input = new Path(params.get(OUTPUT), FP_GROWTH);
     Job job = new Job(conf, "PFP Aggregator Driver running over input: " + input);
     job.setJarByClass(PFPGrowth.class);
     
@@ -332,7 +327,7 @@ public final class PFPGrowth {
     job.setOutputValueClass(TopKStringPatterns.class);
     
     FileInputFormat.addInputPath(job, input);
-    Path outPath = new Path(params.get(OUTPUT), FPGROWTH);
+    Path outPath = new Path(params.get(OUTPUT), FP_GROWTH);
     FileOutputFormat.setOutputPath(job, outPath);
     
     HadoopUtil.delete(conf, outPath);

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelCountingMapper.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelCountingMapper.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelCountingMapper.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelCountingMapper.java Wed Jan 22 06:01:24 2014
@@ -34,7 +34,6 @@ import org.apache.mahout.common.Paramete
  * WordCount example
  * 
  */
-@Deprecated
 public class ParallelCountingMapper extends Mapper<LongWritable,Text,Text,LongWritable> {
   
   private static final LongWritable ONE = new LongWritable(1);

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelCountingReducer.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelCountingReducer.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelCountingReducer.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelCountingReducer.java Wed Jan 22 06:01:24 2014
@@ -27,7 +27,6 @@ import org.apache.hadoop.mapreduce.Reduc
  *  sums up the item count and output the item and the count This can also be
  * used as a local Combiner. A simple summing reducer
  */
-@Deprecated
 public class ParallelCountingReducer extends Reducer<Text,LongWritable,Text,LongWritable> {
   
   @Override

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthCombiner.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthCombiner.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthCombiner.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthCombiner.java Wed Jan 22 06:01:24 2014
@@ -29,7 +29,6 @@ import org.apache.mahout.common.Pair;
  *  takes each group of dependent transactions and\ compacts it in a
  * TransactionTree structure
  */
-@Deprecated
 public class ParallelFPGrowthCombiner extends Reducer<IntWritable,TransactionTree,IntWritable,TransactionTree> {
   
   @Override

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthMapper.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthMapper.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthMapper.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthMapper.java Wed Jan 22 06:01:24 2014
@@ -36,7 +36,6 @@ import org.apache.mahout.math.set.OpenIn
  * outputs the group id as key and the transaction as value
  * 
  */
-@Deprecated
 public class ParallelFPGrowthMapper extends Mapper<LongWritable,Text,IntWritable,TransactionTree> {
 
   private final OpenObjectIntHashMap<String> fMap = new OpenObjectIntHashMap<String>();

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthReducer.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthReducer.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthReducer.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/ParallelFPGrowthReducer.java Wed Jan 22 06:01:24 2014
@@ -45,7 +45,6 @@ import org.apache.mahout.math.list.LongA
  * outputs the the Top K frequent Patterns for each group.
  * 
  */
-@Deprecated
 public final class ParallelFPGrowthReducer extends Reducer<IntWritable,TransactionTree,Text,TopKStringPatterns> {
 
   private final List<String> featureReverseMap = Lists.newArrayList();
@@ -105,8 +104,8 @@ public final class ParallelFPGrowthReduc
           PFPGrowth.getGroupMembers(key.get(), maxPerGroup, numFeatures),
           new IntegerStringOutputConverter(
               new ContextWriteOutputCollector<IntWritable, TransactionTree, Text, TopKStringPatterns>(context),
-              featureReverseMap),
-          new ContextStatusUpdater<IntWritable, TransactionTree, Text, TopKStringPatterns>(context));
+              featureReverseMap)
+      );
     } else {
       FPGrowth<Integer> fpGrowth = new FPGrowth<Integer>();
       fpGrowth.generateTopKFrequentPatterns(
@@ -135,7 +134,7 @@ public final class ParallelFPGrowthReduc
       freqList.add(e.getSecond());
     }
     
-    maxHeapSize = Integer.valueOf(params.get(PFPGrowth.MAX_HEAPSIZE, "50"));
+    maxHeapSize = Integer.valueOf(params.get(PFPGrowth.MAX_HEAP_SIZE, "50"));
     minSupport = Integer.valueOf(params.get(PFPGrowth.MIN_SUPPORT, "3"));
 
     maxPerGroup = params.getInt(PFPGrowth.MAX_PER_GROUP, 0);

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/TransactionTree.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/TransactionTree.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/TransactionTree.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/TransactionTree.java Wed Jan 22 06:01:24 2014
@@ -42,7 +42,6 @@ import org.slf4j.LoggerFactory;
  * Map/Reduce of {@link PFPGrowth} algorithm by reducing data size passed from the Mapper to the reducer where
  * {@link org.apache.mahout.fpm.pfpgrowth.fpgrowth.FPGrowth} mining is done
  */
-@Deprecated
 public final class TransactionTree implements Writable, Iterable<Pair<IntArrayList,Long>> {
 
   private static final Logger log = LoggerFactory.getLogger(TransactionTree.class);
@@ -167,9 +166,7 @@ public final class TransactionTree imple
   
   public Map<Integer,MutableLong> generateFList() {
     Map<Integer,MutableLong> frequencyList = Maps.newHashMap();
-    Iterator<Pair<IntArrayList,Long>> it = iterator();
-    while (it.hasNext()) {
-      Pair<IntArrayList,Long> p = it.next();
+    for (Pair<IntArrayList, Long> p : this) {
       IntArrayList items = p.getFirst();
       for (int idx = 0; idx < items.size(); idx++) {
         if (!frequencyList.containsKey(items.get(idx))) {

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/TransactionTreeIterator.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/TransactionTreeIterator.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/TransactionTreeIterator.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/TransactionTreeIterator.java Wed Jan 22 06:01:24 2014
@@ -29,7 +29,6 @@ import org.apache.mahout.common.Pair;
  * Generates a List of transactions view of Transaction Tree by doing Depth First Traversal on the tree
  * structure
  */
-@Deprecated
 final class TransactionTreeIterator extends AbstractIterator<Pair<IntArrayList,Long>> {
 
   private final Stack<int[]> depth = new Stack<int[]>();

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/ContextStatusUpdater.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/ContextStatusUpdater.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/ContextStatusUpdater.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/ContextStatusUpdater.java Wed Jan 22 06:01:24 2014
@@ -28,7 +28,6 @@ import org.apache.hadoop.mapreduce.Reduc
  * @param <K>
  * @param <V>
  */
-@Deprecated
 public class ContextStatusUpdater<IK extends Writable,IV extends Writable,K extends Writable,V extends Writable>
     implements StatusUpdater {
   

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/ContextWriteOutputCollector.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/ContextWriteOutputCollector.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/ContextWriteOutputCollector.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/ContextWriteOutputCollector.java Wed Jan 22 06:01:24 2014
@@ -34,7 +34,6 @@ import org.slf4j.LoggerFactory;
  * @param <K>
  * @param <V>
  */
-@Deprecated
 public class ContextWriteOutputCollector<IK extends Writable,IV extends Writable,K extends Writable,V extends Writable>
     implements OutputCollector<K,V> {
   

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/SequenceFileOutputCollector.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/SequenceFileOutputCollector.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/SequenceFileOutputCollector.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/SequenceFileOutputCollector.java Wed Jan 22 06:01:24 2014
@@ -29,7 +29,6 @@ import org.apache.hadoop.mapred.OutputCo
  * @param <K>
  * @param <V>
  */
-@Deprecated
 public class SequenceFileOutputCollector<K extends Writable,V extends Writable> implements
     OutputCollector<K,V> {
   private final SequenceFile.Writer writer;

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/StatusUpdater.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/StatusUpdater.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/StatusUpdater.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/StatusUpdater.java Wed Jan 22 06:01:24 2014
@@ -21,7 +21,6 @@ package org.apache.mahout.fpm.pfpgrowth.
  * An interface of a Status updater
  * 
  */
-@Deprecated
 public interface StatusUpdater {
   
   void update(String status);

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/TopKPatternsOutputConverter.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/TopKPatternsOutputConverter.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/TopKPatternsOutputConverter.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/TopKPatternsOutputConverter.java Wed Jan 22 06:01:24 2014
@@ -35,7 +35,6 @@ import org.apache.mahout.fpm.pfpgrowth.f
  * 
  * @param <A>
  */
-@Deprecated
 public final class TopKPatternsOutputConverter<A extends Comparable<? super A>> implements
     OutputCollector<Integer,FrequentPatternMaxHeap> {
   

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/TransactionIterator.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/TransactionIterator.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/TransactionIterator.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/TransactionIterator.java Wed Jan 22 06:01:24 2014
@@ -30,7 +30,6 @@ import org.apache.mahout.common.Pair;
  * Iterates over a Transaction and outputs the transaction integer id mapping and the support of the
  * transaction
  */
-@Deprecated
 public class TransactionIterator<T> extends ForwardingIterator<Pair<int[],Long>> {
 
   private final int[] transactionBuffer;

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/integer/IntegerStringOutputConverter.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/integer/IntegerStringOutputConverter.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/integer/IntegerStringOutputConverter.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/integer/IntegerStringOutputConverter.java Wed Jan 22 06:01:24 2014
@@ -30,7 +30,6 @@ import org.apache.mahout.fpm.pfpgrowth.c
  * Collects the Patterns with Integer id and Long support and converts them to Pattern of Strings based on a
  * reverse feature lookup map.
  */
-@Deprecated
 public final class IntegerStringOutputConverter implements
     OutputCollector<Integer,List<Pair<List<Integer>,Long>>> {
   

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/string/StringOutputConverter.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/string/StringOutputConverter.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/string/StringOutputConverter.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/string/StringOutputConverter.java Wed Jan 22 06:01:24 2014
@@ -28,7 +28,6 @@ import org.apache.mahout.common.Pair;
  * Collects a string pattern in a MaxHeap and outputs the top K patterns
  * 
  */
-@Deprecated
 public final class StringOutputConverter implements OutputCollector<String,List<Pair<List<String>,Long>>> {
   
   private final OutputCollector<Text,TopKStringPatterns> collector;

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/string/TopKStringPatterns.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/string/TopKStringPatterns.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/string/TopKStringPatterns.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/convertors/string/TopKStringPatterns.java Wed Jan 22 06:01:24 2014
@@ -32,7 +32,6 @@ import org.apache.mahout.common.Pair;
  * A class which collects Top K string patterns
  *
  */
-@Deprecated
 public final class TopKStringPatterns implements Writable {
   private final List<Pair<List<String>,Long>> frequentPatterns;
   

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPGrowth.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPGrowth.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPGrowth.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPGrowth.java Wed Jan 22 06:01:24 2014
@@ -50,7 +50,6 @@ import org.slf4j.LoggerFactory;
  *
  * @param <A> object type used as the cell items in a transaction list
  */
-@Deprecated
 public class FPGrowth<A extends Comparable<? super A>> {
 
   private static final Logger log = LoggerFactory.getLogger(FPGrowth.class);

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPTree.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPTree.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPTree.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPTree.java Wed Jan 22 06:01:24 2014
@@ -26,7 +26,6 @@ import java.util.TreeSet;
  * {@link FPGrowth} algorithm
  * 
  */
-@Deprecated
 public class FPTree {
   
   public static final int ROOTNODEID = 0;

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPTreeDepthCache.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPTreeDepthCache.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPTreeDepthCache.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FPTreeDepthCache.java Wed Jan 22 06:01:24 2014
@@ -25,7 +25,6 @@ import java.util.List;
  * Caches large FPTree {@link Object} for each level of the recursive
  * {@link FPGrowth} algorithm to reduce allocation overhead.
  */
-@Deprecated
 public class FPTreeDepthCache {
 
   private final LeastKCache<Integer,FPTree> firstLevelCache = new LeastKCache<Integer,FPTree>(5);

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FrequentPatternMaxHeap.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FrequentPatternMaxHeap.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FrequentPatternMaxHeap.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FrequentPatternMaxHeap.java Wed Jan 22 06:01:24 2014
@@ -24,7 +24,6 @@ import com.google.common.collect.Sets;
 import org.apache.mahout.math.map.OpenLongObjectHashMap;
 
 /**  keeps top K Attributes in a TreeSet */
-@Deprecated
 public final class FrequentPatternMaxHeap {
   
   private int count;

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/LeastKCache.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/LeastKCache.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/LeastKCache.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/LeastKCache.java Wed Jan 22 06:01:24 2014
@@ -23,7 +23,6 @@ import java.util.Collections;
 import java.util.Map;
 import java.util.PriorityQueue;
 
-@Deprecated
 public class LeastKCache<K extends Comparable<? super K>,V> {
   
   private final int capacity;

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/Pattern.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/Pattern.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/Pattern.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/Pattern.java Wed Jan 22 06:01:24 2014
@@ -26,7 +26,6 @@ import java.util.Arrays;
  * support(the number of times the pattern is seen in the dataset)
  * 
  */
-@Deprecated
 public class Pattern implements Comparable<Pattern> {
   
   private static final int DEFAULT_INITIAL_SIZE = 2;

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPGrowthIds.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPGrowthIds.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPGrowthIds.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPGrowthIds.java Wed Jan 22 06:01:24 2014
@@ -29,7 +29,6 @@ import com.google.common.collect.Maps;
 import org.apache.commons.lang3.mutable.MutableLong;
 import org.apache.hadoop.mapred.OutputCollector;
 import org.apache.mahout.common.Pair;
-import org.apache.mahout.fpm.pfpgrowth.convertors.StatusUpdater;
 import org.apache.mahout.fpm.pfpgrowth.convertors.TopKPatternsOutputConverter;
 import org.apache.mahout.math.list.LongArrayList;
 import org.apache.mahout.math.list.IntArrayList;
@@ -42,7 +41,6 @@ import  org.apache.mahout.fpm.pfpgrowth.
 /**
  * Implementation of PFGrowth Algorithm
  */
-@Deprecated
 public final class FPGrowthIds {
 
   private static final Logger log = LoggerFactory.getLogger(FPGrowthIds.class);
@@ -54,30 +52,30 @@ public final class FPGrowthIds {
    * Generate Top K Frequent Patterns for every feature in returnableFeatures
    * given a stream of transactions and the minimum support
    *
-   * @param transactionStream
-   *          Iterator of transaction
-   * @param attributeFrequency
-   *          list of frequent features and their support value
-   * @param minSupport
-   *          minimum support of the transactions
-   * @param k
-   *          Number of top frequent patterns to keep
-   * @param returnableFeatures
-   *          set of features for which the frequent patterns are mined. If the
-   *          set is empty or null, then top K patterns for every frequent item (an item
-   *          whose support> minSupport) is generated
-   * @param output
-   *          The output collector to which the the generated patterns are
-   *          written
-   * @throws IOException
+   *
+  * @param transactionStream
+  *          Iterator of transaction
+  * @param attributeFrequency
+  *          list of frequent features and their support value
+  * @param minSupport
+  *          minimum support of the transactions
+  * @param k
+  *          Number of top frequent patterns to keep
+  * @param returnableFeatures
+  *          set of features for which the frequent patterns are mined. If the
+  *          set is empty or null, then top K patterns for every frequent item (an item
+  *          whose support> minSupport) is generated
+  * @param output
+  *          The output collector to which the the generated patterns are
+  *          written
+  * @throws IOException
    */
   public static void generateTopKFrequentPatterns(Iterator<Pair<IntArrayList, Long>> transactionStream,
                                                   LongArrayList attributeFrequency,
                                                   long minSupport,
                                                   int k,
                                                   IntArrayList returnableFeatures,
-                                                  OutputCollector<Integer, List<Pair<List<Integer>, Long>>> output,
-                                                  StatusUpdater updater) throws IOException {
+                                                  OutputCollector<Integer, List<Pair<List<Integer>, Long>>> output) throws IOException {
 
     for (int i = 0; i < attributeFrequency.size(); i++) {
       if (attributeFrequency.get(i) < minSupport) {
@@ -99,7 +97,7 @@ public final class FPGrowthIds {
     log.info("Number of unique pruned items {}", attributeFrequency.size());
     generateTopKFrequentPatterns(transactionStream, attributeFrequency,
         minSupport, k, returnableFeatures,
-        new TopKPatternsOutputConverter<Integer>(output, new IdentityMapping()), updater);
+        new TopKPatternsOutputConverter<Integer>(output, new IdentityMapping()));
   }
 
   private static class IdentityMapping extends AbstractMap<Integer, Integer> {
@@ -119,6 +117,7 @@ public final class FPGrowthIds {
   /**
    * Top K FpGrowth Algorithm
    *
+   *
    * @param tree
    *          to be mined
    * @param minSupportValue
@@ -136,8 +135,7 @@ public final class FPGrowthIds {
                                                               long minSupportValue,
                                                               int k,
                                                               IntArrayList requiredFeatures,
-                                                              TopKPatternsOutputConverter<Integer> outputCollector,
-                                                              StatusUpdater updater) throws IOException {
+                                                              TopKPatternsOutputConverter<Integer> outputCollector) throws IOException {
 
     Map<Integer,FrequentPatternMaxHeap> patterns = Maps.newHashMap();
     requiredFeatures.sort();
@@ -146,7 +144,7 @@ public final class FPGrowthIds {
         log.info("Mining FTree Tree for all patterns with {}", attribute);
         MutableLong minSupport = new MutableLong(minSupportValue);
         FrequentPatternMaxHeap frequentPatterns = growth(tree, minSupport, k,
-                                                         attribute, updater);
+                                                         attribute);
         patterns.put(attribute, frequentPatterns);
         outputCollector.collect(attribute, frequentPatterns);
 
@@ -169,14 +167,13 @@ public final class FPGrowthIds {
    * @param attributeFrequency
    *          array representing the Frequency of the corresponding attribute id
    * @param minSupport
-   *          minimum support of the pattern to be mined
+ *          minimum support of the pattern to be mined
    * @param k
-   *          Max value of the Size of the Max-Heap in which Patterns are held
+*          Max value of the Size of the Max-Heap in which Patterns are held
    * @param returnFeatures
-   *          the id's of the features for which Top K patterns have to be mined
+*          the id's of the features for which Top K patterns have to be mined
    * @param topKPatternsOutputCollector
-   *          the outputCollector which transforms the given Pattern in integer
-   *          format to the corresponding A Format
+*          the outputCollector which transforms the given Pattern in integer
    */
   private static void generateTopKFrequentPatterns(
       Iterator<Pair<IntArrayList, Long>> transactions,
@@ -184,8 +181,7 @@ public final class FPGrowthIds {
       long minSupport,
       int k,
       IntArrayList returnFeatures,
-      TopKPatternsOutputConverter<Integer> topKPatternsOutputCollector,
-      StatusUpdater updater) throws IOException {
+      TopKPatternsOutputConverter<Integer> topKPatternsOutputCollector) throws IOException {
 
     FPTree tree = new FPTree(attributeFrequency, minSupport);
 
@@ -201,7 +197,7 @@ public final class FPGrowthIds {
       }
     }
 
-    fpGrowth(tree, minSupport, k, returnFeatures, topKPatternsOutputCollector, updater);
+    fpGrowth(tree, minSupport, k, returnFeatures, topKPatternsOutputCollector);
   }
 
   /** 
@@ -210,8 +206,7 @@ public final class FPGrowthIds {
   private static FrequentPatternMaxHeap growth(FPTree tree,
                                                MutableLong minSupportMutable,
                                                int k,
-                                               int currentAttribute,
-                                               StatusUpdater updater) {
+                                               int currentAttribute) {
 
     long currentAttributeCount = tree.headerCount(currentAttribute);
 
@@ -238,7 +233,7 @@ public final class FPGrowthIds {
 
     for (int attr : q.attrIterableRev())  {
       mergeHeap(suffixPats,
-                growth(q, minSupportMutable, k, attr, updater),
+                growth(q, minSupportMutable, k, attr),
                 currentAttribute,
                 currentAttributeCount, true);
     }

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPGrowthObj.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPGrowthObj.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPGrowthObj.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPGrowthObj.java Wed Jan 22 06:01:24 2014
@@ -37,7 +37,6 @@ import org.apache.hadoop.mapred.OutputCo
 import org.apache.mahout.common.Pair;
 import org.apache.mahout.common.iterator.sequencefile.SequenceFileIterable;
 import org.apache.mahout.fpm.pfpgrowth.CountDescendingPairComparator;
-import org.apache.mahout.fpm.pfpgrowth.convertors.StatusUpdater;
 import org.apache.mahout.fpm.pfpgrowth.convertors.TopKPatternsOutputConverter;
 import org.apache.mahout.fpm.pfpgrowth.convertors.TransactionIterator;
 import org.apache.mahout.fpm.pfpgrowth.convertors.string.TopKStringPatterns;
@@ -52,7 +51,6 @@ import  org.apache.mahout.fpm.pfpgrowth.
  *
  * @param <A> object type used as the cell items in a transaction list
  */
-@Deprecated
 public class FPGrowthObj<A extends Comparable<? super A>> {
 
   private static final Logger log = LoggerFactory.getLogger(FPGrowthObj.class);
@@ -108,30 +106,30 @@ public class FPGrowthObj<A extends Compa
    * Generate Top K Frequent Patterns for every feature in returnableFeatures
    * given a stream of transactions and the minimum support
    *
-   * @param transactionStream
-   *          Iterator of transaction
-   * @param frequencyList
-   *          list of frequent features and their support value
-   * @param minSupport
-   *          minimum support of the transactions
-   * @param k
-   *          Number of top frequent patterns to keep
-   * @param returnableFeatures
-   *          set of features for which the frequent patterns are mined. If the
-   *          set is empty or null, then top K patterns for every frequent item (an item
-   *          whose support> minSupport) is generated
-   * @param output
-   *          The output collector to which the the generated patterns are
-   *          written
-   * @throws IOException
+   *
+  * @param transactionStream
+  *          Iterator of transaction
+  * @param frequencyList
+  *          list of frequent features and their support value
+  * @param minSupport
+  *          minimum support of the transactions
+  * @param k
+  *          Number of top frequent patterns to keep
+  * @param returnableFeatures
+  *          set of features for which the frequent patterns are mined. If the
+  *          set is empty or null, then top K patterns for every frequent item (an item
+  *          whose support> minSupport) is generated
+  * @param output
+  *          The output collector to which the the generated patterns are
+  *          written
+  * @throws IOException
    */
-  public final void generateTopKFrequentPatterns(Iterator<Pair<List<A>,Long>> transactionStream,
+  public final void generateTopKFrequentPatterns(Iterator<Pair<List<A>, Long>> transactionStream,
                                                  Collection<Pair<A, Long>> frequencyList,
                                                  long minSupport,
                                                  int k,
                                                  Collection<A> returnableFeatures,
-                                                 OutputCollector<A,List<Pair<List<A>,Long>>> output,
-                                                 StatusUpdater updater) throws IOException {
+                                                 OutputCollector<A, List<Pair<List<A>, Long>>> output) throws IOException {
 
     Map<Integer,A> reverseMapping = Maps.newHashMap();
     Map<A,Integer> attributeIdMapping = Maps.newHashMap();
@@ -177,12 +175,13 @@ public class FPGrowthObj<A extends Compa
     generateTopKFrequentPatterns(new TransactionIterator<A>(transactionStream,
         attributeIdMapping), attributeFrequency, minSupport, k, 
         returnFeatures, new TopKPatternsOutputConverter<A>(output,
-            reverseMapping), updater);
+            reverseMapping));
   }
 
   /**
    * Top K FpGrowth Algorithm
    *
+   *
    * @param tree
    *          to be mined
    * @param minSupportValue
@@ -200,8 +199,7 @@ public class FPGrowthObj<A extends Compa
                                                        long minSupportValue,
                                                        int k,
                                                        Collection<Integer> requiredFeatures,
-                                                       TopKPatternsOutputConverter<A> outputCollector,
-                                                       StatusUpdater updater) throws IOException {
+                                                       TopKPatternsOutputConverter<A> outputCollector) throws IOException {
 
     Map<Integer,FrequentPatternMaxHeap> patterns = Maps.newHashMap();
     for (int attribute : tree.attrIterableRev()) {
@@ -209,7 +207,7 @@ public class FPGrowthObj<A extends Compa
         log.info("Mining FTree Tree for all patterns with {}", attribute);
         MutableLong minSupport = new MutableLong(minSupportValue);
         FrequentPatternMaxHeap frequentPatterns = growth(tree, minSupport, k,
-                                                         attribute, updater);
+                                                         attribute);
         patterns.put(attribute, frequentPatterns);
         outputCollector.collect(attribute, frequentPatterns);
 
@@ -230,23 +228,20 @@ public class FPGrowthObj<A extends Compa
    * @param attributeFrequency
    *          array representing the Frequency of the corresponding attribute id
    * @param minSupport
-   *          minimum support of the pattern to be mined
+ *          minimum support of the pattern to be mined
    * @param k
-   *          Max value of the Size of the Max-Heap in which Patterns are held
+*          Max value of the Size of the Max-Heap in which Patterns are held
    * @param returnFeatures
-   *          the id's of the features for which Top K patterns have to be mined
+*          the id's of the features for which Top K patterns have to be mined
    * @param topKPatternsOutputCollector
-   *          the outputCollector which transforms the given Pattern in integer
-   *          format to the corresponding A Format
-   * @return Top K frequent patterns for each attribute
+*          the outputCollector which transforms the given Pattern in integer
    */
   private void generateTopKFrequentPatterns(
-    Iterator<Pair<int[],Long>> transactions,
-    long[] attributeFrequency,
-    long minSupport,
-    int k,
-    Collection<Integer> returnFeatures, TopKPatternsOutputConverter<A> topKPatternsOutputCollector,
-    StatusUpdater updater) throws IOException {
+      Iterator<Pair<int[], Long>> transactions,
+      long[] attributeFrequency,
+      long minSupport,
+      int k,
+      Collection<Integer> returnFeatures, TopKPatternsOutputConverter<A> topKPatternsOutputCollector) throws IOException {
 
     FPTree tree = new FPTree(attributeFrequency, minSupport);
 
@@ -266,7 +261,7 @@ public class FPGrowthObj<A extends Compa
       }
     }
 
-    fpGrowth(tree, minSupport, k, returnFeatures, topKPatternsOutputCollector, updater);
+    fpGrowth(tree, minSupport, k, returnFeatures, topKPatternsOutputCollector);
   }
 
   /** 
@@ -275,8 +270,7 @@ public class FPGrowthObj<A extends Compa
   private static FrequentPatternMaxHeap growth(FPTree tree,
                                                MutableLong minSupportMutable,
                                                int k,
-                                               int currentAttribute,
-                                               StatusUpdater updater) {
+                                               int currentAttribute) {
 
     long currentAttributeCount = tree.headerCount(currentAttribute);
 
@@ -303,7 +297,7 @@ public class FPGrowthObj<A extends Compa
 
     for (int attr : q.attrIterableRev())  {
       mergeHeap(suffixPats,
-                growth(q, minSupportMutable, k, attr, updater),
+                growth(q, minSupportMutable, k, attr),
                 currentAttribute,
                 currentAttributeCount, true);
     }

Modified: mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPTree.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPTree.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPTree.java (original)
+++ mahout/trunk/core/src/main/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth2/FPTree.java Wed Jan 22 06:01:24 2014
@@ -30,7 +30,6 @@ import org.apache.mahout.math.map.OpenIn
 /**
  * A straightforward implementation of FPTrees as described in Han et. al.
  */
-@Deprecated
 public final class FPTree {
 
   private final AttrComparator attrComparator = new AttrComparator();

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTest.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTest.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTest.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTest.java Wed Jan 22 06:01:24 2014
@@ -35,7 +35,6 @@ import org.junit.Test;
 
 import com.google.common.io.Resources;
 
-@Deprecated
 public final class FPGrowthRetailDataTest extends MahoutTestCase {
 
   @Test

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTest2.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTest2.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTest2.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTest2.java Wed Jan 22 06:01:24 2014
@@ -29,13 +29,11 @@ import org.apache.mahout.common.MahoutTe
 import org.apache.mahout.common.Pair;
 import org.apache.mahout.common.iterator.FileLineIterable;
 import org.apache.mahout.common.iterator.StringRecordIterator;
-import org.apache.mahout.fpm.pfpgrowth.convertors.StatusUpdater;
 import org.apache.mahout.fpm.pfpgrowth.fpgrowth2.FPGrowthObj;
 import org.junit.Test;
 
 import com.google.common.io.Resources;
 
-@Deprecated
 public final class FPGrowthRetailDataTest2 extends MahoutTestCase {
 
   @Test
@@ -76,10 +74,6 @@ public final class FPGrowthRetailDataTes
           }
         }
         
-      }, new StatusUpdater() {
-        
-        @Override
-        public void update(String status) {}
       });
     
     assertEquals(Long.valueOf(pattern_41_36_39), results.get(returnableFeatures));

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTestVs.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTestVs.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTestVs.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthRetailDataTestVs.java Wed Jan 22 06:01:24 2014
@@ -40,7 +40,6 @@ import com.google.common.io.Resources;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@Deprecated
 public final class FPGrowthRetailDataTestVs extends MahoutTestCase {
 
   private static final Logger log = LoggerFactory.getLogger(PFPGrowthRetailDataTestVs.class);
@@ -120,7 +119,7 @@ public final class FPGrowthRetailDataTes
       fp2.generateFList(new StringRecordIterator(new FileLineIterable(Resources.getResource(inputFilename)
            .openStream()), "\\s+"), minSupport), minSupport, 100000,
         Sets.<String>newHashSet(),
-      new MapCollector(initialResults2), new DummyUpdater());
+      new MapCollector(initialResults2));
 
     Map<Set<String>, Long> results2;
     if (returnableFeatures.isEmpty()) {

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthSyntheticDataTest.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthSyntheticDataTest.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthSyntheticDataTest.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthSyntheticDataTest.java Wed Jan 22 06:01:24 2014
@@ -38,7 +38,6 @@ import org.junit.Test;
 
 import com.google.common.io.Resources;
 
-@Deprecated
 public final class FPGrowthSyntheticDataTest extends MahoutTestCase {
 
   @Test
@@ -97,11 +96,7 @@ public final class FPGrowthSyntheticData
                                         }
                                       }
         
-                                    }, new StatusUpdater() {
-        
-                                        @Override
-                                          public void update(String status) {}
-                                      });
+                                    });
 
     assertEquals(patternCnt_10_13, highestSupport(results, features_10_13));
     assertEquals(patternCnt_10_13_1669, highestSupport(results, returnableFeatures));
@@ -192,11 +187,7 @@ public final class FPGrowthSyntheticData
                                          }
                                        }
         
-                                     }, new StatusUpdater() {
-        
-                                         @Override
-                                           public void update(String status) {}
-                                       });
+                                     });
 
     Map<Set<String>, Long> results2;
     if (returnableFeatures.isEmpty()) {

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthTest.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthTest.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthTest.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthTest.java Wed Jan 22 06:01:24 2014
@@ -39,7 +39,6 @@ import org.apache.mahout.fpm.pfpgrowth.c
 import org.apache.mahout.fpm.pfpgrowth.fpgrowth.FPGrowth;
 import org.junit.Test;
 
-@Deprecated
 public final class FPGrowthTest extends MahoutTestCase {
 
   @Test

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthTest2.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthTest2.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthTest2.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/FPGrowthTest2.java Wed Jan 22 06:01:24 2014
@@ -32,14 +32,12 @@ import org.apache.hadoop.io.Text;
 import org.apache.hadoop.mapred.OutputCollector;
 import org.apache.mahout.common.MahoutTestCase;
 import org.apache.mahout.common.Pair;
-import org.apache.mahout.fpm.pfpgrowth.convertors.ContextStatusUpdater;
 import org.apache.mahout.fpm.pfpgrowth.convertors.SequenceFileOutputCollector;
 import org.apache.mahout.fpm.pfpgrowth.convertors.string.StringOutputConverter;
 import org.apache.mahout.fpm.pfpgrowth.convertors.string.TopKStringPatterns;
 import org.apache.mahout.fpm.pfpgrowth.fpgrowth2.FPGrowthObj;
 import org.junit.Test;
 
-@Deprecated
 public final class FPGrowthTest2 extends MahoutTestCase {
 
   @Test
@@ -70,8 +68,8 @@ public final class FPGrowthTest2 extends
         3,
         100,
         Sets.<String>newHashSet(),
-        new StringOutputConverter(new SequenceFileOutputCollector<Text,TopKStringPatterns>(writer)),
-        new ContextStatusUpdater(null));
+        new StringOutputConverter(new SequenceFileOutputCollector<Text,TopKStringPatterns>(writer))
+    );
     } finally {
       Closeables.close(writer, false);
     }
@@ -113,8 +111,8 @@ public final class FPGrowthTest2 extends
           2,
           100,
           Sets.<String>newHashSet(),
-          new StringOutputConverter(new SequenceFileOutputCollector<Text,TopKStringPatterns>(writer)),
-          new ContextStatusUpdater(null));
+          new StringOutputConverter(new SequenceFileOutputCollector<Text,TopKStringPatterns>(writer))
+      );
     } finally {
       Closeables.close(writer, false);
     }
@@ -151,8 +149,8 @@ public final class FPGrowthTest2 extends
           2,
           100,
           Sets.<String>newHashSet(),
-          new StringOutputConverter(new SequenceFileOutputCollector<Text,TopKStringPatterns>(writer)),
-          new ContextStatusUpdater(null));
+          new StringOutputConverter(new SequenceFileOutputCollector<Text,TopKStringPatterns>(writer))
+      );
     } finally {
       Closeables.close(writer, false);
     }
@@ -187,7 +185,7 @@ public final class FPGrowthTest2 extends
         3,
         100,
         null,
-        noOutput,
-        new ContextStatusUpdater(null));
+        noOutput
+    );
   }
 }

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTest.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTest.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTest.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTest.java Wed Jan 22 06:01:24 2014
@@ -45,7 +45,6 @@ import org.slf4j.LoggerFactory;
 
 import com.google.common.io.Resources;
 
-@Deprecated
 public class PFPGrowthRetailDataTest extends MahoutTestCase {
   
   private final Parameters params = new Parameters();
@@ -55,7 +54,7 @@ public class PFPGrowthRetailDataTest ext
   public void setUp() throws Exception {
     super.setUp();
     params.set(PFPGrowth.MIN_SUPPORT, "100");
-    params.set(PFPGrowth.MAX_HEAPSIZE, "10000");
+    params.set(PFPGrowth.MAX_HEAP_SIZE, "10000");
     params.set(PFPGrowth.NUM_GROUPS, "50");
     params.set(PFPGrowth.ENCODING, "UTF-8");
     File inputDir = getTestTempDir("transactions");
@@ -159,7 +158,7 @@ public class PFPGrowthRetailDataTest ext
       expectedResults.put(Sets.newHashSet(items), support);
     }
     Configuration conf = getConfiguration();
-    log.info("Starting Parallel Counting Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Starting Parallel Counting Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     PFPGrowth.startParallelCounting(params, conf);
 
     List<Pair<String,Long>> fList = PFPGrowth.readFList(params);
@@ -173,7 +172,7 @@ public class PFPGrowthRetailDataTest ext
     params.set(PFPGrowth.MAX_PER_GROUP, Integer.toString(maxPerGroup));
 
     PFPGrowth.startParallelFPGrowth(params, conf);
-    log.info("Starting Pattern Aggregation Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Starting Pattern Aggregation Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     PFPGrowth.startAggregating(params, conf);
     List<Pair<String,TopKStringPatterns>> frequentPatterns = PFPGrowth.readFrequentPattern(params);
     

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTest2.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTest2.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTest2.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTest2.java Wed Jan 22 06:01:24 2014
@@ -45,7 +45,6 @@ import org.slf4j.LoggerFactory;
 
 import com.google.common.io.Resources;
 
-@Deprecated
 public class PFPGrowthRetailDataTest2 extends MahoutTestCase {
   
   private final Parameters params = new Parameters();
@@ -55,7 +54,7 @@ public class PFPGrowthRetailDataTest2 ex
   public void setUp() throws Exception {
     super.setUp();
     params.set(PFPGrowth.MIN_SUPPORT, "100");
-    params.set(PFPGrowth.MAX_HEAPSIZE, "10000");
+    params.set(PFPGrowth.MAX_HEAP_SIZE, "10000");
     params.set(PFPGrowth.NUM_GROUPS, "50");
     params.set(PFPGrowth.ENCODING, "UTF-8");
     params.set(PFPGrowth.USE_FPG2, "true");
@@ -157,7 +156,7 @@ public class PFPGrowthRetailDataTest2 ex
       expectedResults.put(Sets.newHashSet(items), support);
     }
     Configuration conf = new Configuration();
-    log.info("Starting Parallel Counting Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Starting Parallel Counting Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     PFPGrowth.startParallelCounting(params, conf);
 
     List<Pair<String,Long>> fList = PFPGrowth.readFList(params);
@@ -171,9 +170,9 @@ public class PFPGrowthRetailDataTest2 ex
     }
     params.set(PFPGrowth.MAX_PER_GROUP, Integer.toString(maxPerGroup));
 
-    log.info("Starting Parallel FPGrowth Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Starting Parallel FPGrowth Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     PFPGrowth.startParallelFPGrowth(params, conf);
-    log.info("Starting Pattern Aggregation Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Starting Pattern Aggregation Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     PFPGrowth.startAggregating(params, conf);
     List<Pair<String,TopKStringPatterns>> frequentPatterns = PFPGrowth.readFrequentPattern(params);
     

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTestVs.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTestVs.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTestVs.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthRetailDataTestVs.java Wed Jan 22 06:01:24 2014
@@ -42,7 +42,6 @@ import com.google.common.io.Closeables;
 import com.google.common.io.Files;
 import com.google.common.io.Resources;
 
-@Deprecated
 public final class PFPGrowthRetailDataTestVs extends MahoutTestCase {
 
   private final Parameters paramsImpl1 = new Parameters();
@@ -56,13 +55,13 @@ public final class PFPGrowthRetailDataTe
     File input = new File(inputDir, "test.txt");
 
     paramsImpl1.set(PFPGrowth.MIN_SUPPORT, "100");
-    paramsImpl1.set(PFPGrowth.MAX_HEAPSIZE, "10000");
+    paramsImpl1.set(PFPGrowth.MAX_HEAP_SIZE, "10000");
     paramsImpl1.set(PFPGrowth.NUM_GROUPS, "50");
     paramsImpl1.set(PFPGrowth.ENCODING, "UTF-8");
     paramsImpl1.set(PFPGrowth.INPUT, input.getAbsolutePath());
 
     paramsImpl2.set(PFPGrowth.MIN_SUPPORT, "100");
-    paramsImpl2.set(PFPGrowth.MAX_HEAPSIZE, "10000");
+    paramsImpl2.set(PFPGrowth.MAX_HEAP_SIZE, "10000");
     paramsImpl2.set(PFPGrowth.NUM_GROUPS, "50");
     paramsImpl2.set(PFPGrowth.ENCODING, "UTF-8");
     paramsImpl2.set(PFPGrowth.INPUT, input.getAbsolutePath());

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthSynthDataTest2.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthSynthDataTest2.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthSynthDataTest2.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthSynthDataTest2.java Wed Jan 22 06:01:24 2014
@@ -38,7 +38,6 @@ import org.apache.mahout.common.Pair;
 import org.apache.mahout.common.Parameters;
 import org.apache.mahout.common.iterator.FileLineIterable;
 import org.apache.mahout.common.iterator.StringRecordIterator;
-import org.apache.mahout.fpm.pfpgrowth.convertors.StatusUpdater;
 import org.apache.mahout.fpm.pfpgrowth.convertors.string.TopKStringPatterns;
 import org.apache.mahout.fpm.pfpgrowth.fpgrowth2.FPGrowthObj;
 import org.junit.Test;
@@ -47,7 +46,6 @@ import org.slf4j.LoggerFactory;
 
 import com.google.common.io.Resources;
 
-@Deprecated
 public class PFPGrowthSynthDataTest2 extends MahoutTestCase {
   
   private final Parameters params = new Parameters();
@@ -57,7 +55,7 @@ public class PFPGrowthSynthDataTest2 ext
   public void setUp() throws Exception {
     super.setUp();
     params.set(PFPGrowth.MIN_SUPPORT, "100");
-    params.set(PFPGrowth.MAX_HEAPSIZE, "10000");
+    params.set(PFPGrowth.MAX_HEAP_SIZE, "10000");
     params.set(PFPGrowth.NUM_GROUPS, "50");
     params.set(PFPGrowth.ENCODING, "UTF-8");
     params.set(PFPGrowth.USE_FPG2, "true");
@@ -131,10 +129,6 @@ public class PFPGrowthSynthDataTest2 ext
           }
         }
         
-      }, new StatusUpdater() {
-        
-        @Override
-        public void update(String status) {}
       });
 
     for (Entry<Set<String>,Long> entry : parallelResult.entrySet()) {

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthTest.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthTest.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthTest.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthTest.java Wed Jan 22 06:01:24 2014
@@ -36,7 +36,6 @@ import org.junit.Test;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@Deprecated
 public final class PFPGrowthTest extends MahoutTestCase {
   
   private static final Logger log = LoggerFactory.getLogger(PFPGrowthTest.class);
@@ -47,7 +46,7 @@ public final class PFPGrowthTest extends
   public void setUp() throws Exception {
     super.setUp();
     params.set(PFPGrowth.MIN_SUPPORT, "3");
-    params.set(PFPGrowth.MAX_HEAPSIZE, "4");
+    params.set(PFPGrowth.MAX_HEAP_SIZE, "4");
     params.set(PFPGrowth.NUM_GROUPS, "2");
     params.set(PFPGrowth.ENCODING, "UTF-8");
     File inputDir = getTestTempDir("transactions");
@@ -104,9 +103,9 @@ public final class PFPGrowthTest extends
   @Test
   public void testStartParallelFPGrowthInSteps() throws Exception {
     Configuration conf = getConfiguration();
-    log.info("Starting Parallel Counting Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Starting Parallel Counting Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     PFPGrowth.startParallelCounting(params, conf);
-    log.info("Reading fList Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Reading fList Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     List<Pair<String,Long>> fList = PFPGrowth.readFList(params);
     log.info("{}", fList);
     assertEquals("[(B,6), (D,6), (A,5), (E,4), (C,3)]", fList.toString());
@@ -120,9 +119,9 @@ public final class PFPGrowthTest extends
     }
     params.set(PFPGrowth.MAX_PER_GROUP, Integer.toString(maxPerGroup));
 
-    log.info("Starting Parallel FPGrowth Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Starting Parallel FPGrowth Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     PFPGrowth.startParallelFPGrowth(params, conf);
-    log.info("Starting Pattern Aggregation Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Starting Pattern Aggregation Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     PFPGrowth.startAggregating(params, conf);
     List<Pair<String,TopKStringPatterns>> frequentPatterns = PFPGrowth.readFrequentPattern(params);
     assertEquals("[(A,([A],5), ([D, A],4), ([B, A],4), ([A, E],4)), "

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthTest2.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthTest2.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthTest2.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/PFPGrowthTest2.java Wed Jan 22 06:01:24 2014
@@ -36,7 +36,6 @@ import org.junit.Test;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@Deprecated
 public final class PFPGrowthTest2 extends MahoutTestCase {
   
   private static final Logger log = LoggerFactory.getLogger(PFPGrowthTest.class);
@@ -47,7 +46,7 @@ public final class PFPGrowthTest2 extend
   public void setUp() throws Exception {
     super.setUp();
     params.set(PFPGrowth.MIN_SUPPORT, "3");
-    params.set(PFPGrowth.MAX_HEAPSIZE, "4");
+    params.set(PFPGrowth.MAX_HEAP_SIZE, "4");
     params.set(PFPGrowth.NUM_GROUPS, "2");
     params.set(PFPGrowth.ENCODING, "UTF-8");
     params.set(PFPGrowth.USE_FPG2, "true");
@@ -105,9 +104,9 @@ public final class PFPGrowthTest2 extend
   @Test
   public void testStartParallelFPGrowthInSteps() throws Exception {
     Configuration conf = new Configuration();
-    log.info("Starting Parallel Counting Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Starting Parallel Counting Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     PFPGrowth.startParallelCounting(params, conf);
-    log.info("Reading fList Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Reading fList Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     List<Pair<String,Long>> fList = PFPGrowth.readFList(params);
     log.info("{}", fList);
     assertEquals("[(B,6), (D,6), (A,5), (E,4), (C,3)]", fList.toString());
@@ -121,9 +120,9 @@ public final class PFPGrowthTest2 extend
     }
     params.set(PFPGrowth.MAX_PER_GROUP, Integer.toString(maxPerGroup));
 
-    log.info("Starting Parallel FPGrowth Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Starting Parallel FPGrowth Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     PFPGrowth.startParallelFPGrowth(params, conf);
-    log.info("Starting Pattern Aggregation Test: {}", params.get(PFPGrowth.MAX_HEAPSIZE));
+    log.info("Starting Pattern Aggregation Test: {}", params.get(PFPGrowth.MAX_HEAP_SIZE));
     PFPGrowth.startAggregating(params, conf);
 
     List<Pair<String,TopKStringPatterns>> frequentPatterns = PFPGrowth.readFrequentPattern(params);

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/TransactionTreeTest.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/TransactionTreeTest.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/TransactionTreeTest.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/TransactionTreeTest.java Wed Jan 22 06:01:24 2014
@@ -29,7 +29,6 @@ import org.junit.Test;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@Deprecated
 public final class TransactionTreeTest extends MahoutTestCase {
 
   private static final Logger log = LoggerFactory.getLogger(TransactionTreeTest.class);

Modified: mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FrequentPatternMaxHeapTest.java
URL: http://svn.apache.org/viewvc/mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FrequentPatternMaxHeapTest.java?rev=1560259&r1=1507954&r2=1560259&view=diff
==============================================================================
--- mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FrequentPatternMaxHeapTest.java (original)
+++ mahout/trunk/core/src/test/java/org/apache/mahout/fpm/pfpgrowth/fpgrowth/FrequentPatternMaxHeapTest.java Wed Jan 22 06:01:24 2014
@@ -26,7 +26,6 @@ import org.apache.mahout.common.MahoutTe
 import org.apache.mahout.common.RandomUtils;
 import org.junit.Test;
 
-@Deprecated
 public final class FrequentPatternMaxHeapTest extends MahoutTestCase {
 
   @Test