You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@systemml.apache.org by mb...@apache.org on 2017/10/13 03:46:32 UTC

[3/8] systemml git commit: [MINOR] Cleanup various issues raised by static code analysis, part 3

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRCache.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRCache.java b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRCache.java
index 66fc5cf..1b17aca 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRCache.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRCache.java
@@ -64,9 +64,9 @@ public abstract class MMCJMRCache
 		_bufferCapacity = buffCapacity;
 		_buffer = new Pair[_bufferCapacity];
 		for(int i=0; i<_bufferCapacity; i++)
-			_buffer[i] = new Pair<MatrixIndexes, MatrixValue>(new MatrixIndexes(), valueClass.newInstance());
+			_buffer[i] = new Pair<>(new MatrixIndexes(), valueClass.newInstance());
 		if( buffMap )
-			_bufferMap = new HashMap<MatrixIndexes, Integer>();
+			_bufferMap = new HashMap<>();
 	
 		//System.out.println("allocated buffer: "+_bufferCapacity);
 	}

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRCombinerReducerBase.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRCombinerReducerBase.java b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRCombinerReducerBase.java
index 57440b3..0e19fd3 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRCombinerReducerBase.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRCombinerReducerBase.java
@@ -49,8 +49,8 @@ public class MMCJMRCombinerReducerBase extends ReduceBase
 	protected byte tagForRight=1;
 	protected MatrixCharacteristics dim1;
 	protected MatrixCharacteristics dim2;
-//	protected int elementSize=8;
 
+	@Override
 	public void configure(JobConf job)
 	{
 		super.configure(job);

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRMapper.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRMapper.java b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRMapper.java
index b9e9723..f96e4ef 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRMapper.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMCJMRMapper.java
@@ -58,6 +58,7 @@ implements Mapper<Writable, Writable, Writable, Writable>
 		commonMap(rawKey, rawValue, out, reporter);
 	}
 
+	@Override
 	public void configure(JobConf job)
 	{
 		super.configure(job);

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMRJMRMapper.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMRJMRMapper.java b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMRJMRMapper.java
index af46b7d..c0455b3 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMRJMRMapper.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMRJMRMapper.java
@@ -109,6 +109,7 @@ implements Mapper<Writable, Writable, Writable, Writable>
 		
 	}
 	
+	@Override
 	public void configure(JobConf job)
 	{
 		super.configure(job);

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMRJMRReducer.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMRJMRReducer.java b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMRJMRReducer.java
index 2b500b7..4bcb9c6 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMRJMRReducer.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MMRJMRReducer.java
@@ -125,23 +125,20 @@ implements Reducer<TripleIndexes, TaggedMatrixValue, MatrixIndexes, MatrixValue>
 				OperationsOnMatrixValues.incrementalAggregation(out.getValue(), null, resultblock, 
 						((AggregateBinaryOperator) aggBinInstruction.getOperator()).aggOp, false);
 
-		//		System.out.println("agg: \n"+out.getValue());
 			} catch (Exception e) {
 				throw new IOException(e);
 			}
 		}
 	}
 	
+	@Override
 	public void close() throws IOException
 	{
 		long start=System.currentTimeMillis();
 		
-//		System.out.println("cacheValues before processReducerInstructions: \n"+cachedValues);
 		//perform mixed operations
 		processReducerInstructions();
 		
-//		System.out.println("cacheValues before output: \n"+cachedValues);
-		
 		//output results
 		outputResultsFromCachedValues(cachedReporter);
 		
@@ -150,7 +147,7 @@ implements Reducer<TripleIndexes, TaggedMatrixValue, MatrixIndexes, MatrixValue>
 		super.close();
 	}
 	
-
+	@Override
 	public void configure(JobConf job)
 	{
 		super.configure(job);

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MRBaseForCommonInstructions.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MRBaseForCommonInstructions.java b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MRBaseForCommonInstructions.java
index 2cd4bc6..dc18b1d 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MRBaseForCommonInstructions.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MRBaseForCommonInstructions.java
@@ -24,7 +24,7 @@ import java.io.IOException;
 import java.util.ArrayList;
 import java.util.HashMap;
 
-import org.apache.hadoop.filecache.DistributedCache;
+import org.apache.hadoop.mapreduce.filecache.DistributedCache;
 import org.apache.hadoop.fs.Path;
 import org.apache.hadoop.mapred.JobConf;
 import org.apache.hadoop.mapred.MapReduceBase;

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MRJobConfiguration.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MRJobConfiguration.java b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MRJobConfiguration.java
index 269fe52..378d1ef 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MRJobConfiguration.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MRJobConfiguration.java
@@ -30,7 +30,7 @@ import java.util.Map.Entry;
 import java.util.TreeMap;
 
 import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.filecache.DistributedCache;
+import org.apache.hadoop.mapreduce.filecache.DistributedCache;
 import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.fs.Path;
 import org.apache.hadoop.io.IntWritable;

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MapperBase.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MapperBase.java b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MapperBase.java
index 3b630ae..11ff6e7 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/mapred/MapperBase.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/mapred/MapperBase.java
@@ -174,6 +174,7 @@ public abstract class MapperBase extends MRBaseForCommonInstructions
 		return ret && count>0;
 	}
 	
+	@Override
 	public void configure(JobConf job)
 	{
 		super.configure(job);

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/mapred/ReduceBase.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/mapred/ReduceBase.java b/src/main/java/org/apache/sysml/runtime/matrix/mapred/ReduceBase.java
index eade689..80df55d 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/mapred/ReduceBase.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/mapred/ReduceBase.java
@@ -92,6 +92,7 @@ public class ReduceBase extends MRBaseForCommonInstructions
 		}
 	}
 	
+	@Override
 	public void configure(JobConf job)
 	{	
 		super.configure(job);
@@ -193,6 +194,7 @@ public class ReduceBase extends MRBaseForCommonInstructions
 		return ret;
 	}
 	
+	@Override
 	public void close() throws IOException
 	{
 		if(cachedReporter!=null)

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/sort/CompactInputFormat.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/sort/CompactInputFormat.java b/src/main/java/org/apache/sysml/runtime/matrix/sort/CompactInputFormat.java
index 350f65b..5582a76 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/sort/CompactInputFormat.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/sort/CompactInputFormat.java
@@ -50,12 +50,14 @@ public class CompactInputFormat<K extends WritableComparable, V extends Writable
 		job.setClass(VALUE_CLASS, valueClass, Writable.class);
 	}
 	
+	@Override
 	public RecordReader<K,V> getRecordReader(InputSplit split
 			, JobConf job, Reporter reporter) throws IOException {
-		return new CompactInputRecordReader<K,V>(job, (FileSplit) split);
+		return new CompactInputRecordReader<>(job, (FileSplit) split);
 	}
 	
 	//the files are not splitable
+	@Override
 	protected boolean isSplitable(FileSystem fs, Path filename)
 	{
 		return false;

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/sort/CompactOutputFormat.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/sort/CompactOutputFormat.java b/src/main/java/org/apache/sysml/runtime/matrix/sort/CompactOutputFormat.java
index cd730cb..de20b65 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/sort/CompactOutputFormat.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/sort/CompactOutputFormat.java
@@ -36,27 +36,26 @@ import org.apache.sysml.runtime.io.IOUtilFunctions;
 
 public class CompactOutputFormat<K extends Writable, V extends Writable> extends FileOutputFormat<K,V> 
 {
-
-	
 	static final String FINAL_SYNC_ATTRIBUTE = "final.sync";
 
-	  /**
-	   * Does the user want a final sync at close?
-	   * 
-	   * @param conf job configuration
-	   * @return true if final sync at close
-	   */
-	  public static boolean getFinalSync(JobConf conf) {
-	    return conf.getBoolean(FINAL_SYNC_ATTRIBUTE, false);
-	  }
+	/**
+	 * Does the user want a final sync at close?
+	 * 
+	 * @param conf job configuration
+	 * @return true if final sync at close
+	*/
+	public static boolean getFinalSync(JobConf conf) {
+		return conf.getBoolean(FINAL_SYNC_ATTRIBUTE, false);
+	}
 	
+	@Override
 	public RecordWriter<K,V> getRecordWriter(FileSystem ignored, JobConf job, String name, Progressable progress) 
 	throws IOException {
 		
 		Path file = FileOutputFormat.getTaskOutputPath(job, name);
 		FileSystem fs = file.getFileSystem(job);
 		FSDataOutputStream fileOut = fs.create(file, progress);
-		return new FixedLengthRecordWriter<K,V>(fileOut, job);
+		return new FixedLengthRecordWriter<>(fileOut, job);
 	}
 	
 	public static class FixedLengthRecordWriter<K extends Writable, V extends Writable> implements RecordWriter<K, V> {

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/sort/PickFromCompactInputFormat.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/sort/PickFromCompactInputFormat.java b/src/main/java/org/apache/sysml/runtime/matrix/sort/PickFromCompactInputFormat.java
index 0b7d5ac..a615741 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/sort/PickFromCompactInputFormat.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/sort/PickFromCompactInputFormat.java
@@ -57,6 +57,7 @@ public class PickFromCompactInputFormat extends FileInputFormat<MatrixIndexes, M
 	public static final String PARTITION_OF_ZERO="partition.of.zero";
 	public static final String NUMBER_OF_ZERO="number.of.zero";
 	
+	@Override
 	protected  boolean isSplitable(FileSystem fs, Path filename) {
 		return false;
 	}
@@ -128,23 +129,21 @@ public class PickFromCompactInputFormat extends FileInputFormat<MatrixIndexes, M
 			ArrayList<Pair<Integer, Integer>> vec=posMap.get(currentPart);
 			if(vec==null)
 			{
-				vec=new ArrayList<Pair<Integer, Integer>>();
+				vec=new ArrayList<>();
 				posMap.put(currentPart, vec);
 			}
 			
 			//set the actual position starting from 0
 			if(currentPart>0)
-				vec.add( new Pair<Integer, Integer>( (int)(pos-ranges[currentPart-1]-1), e.index));
+				vec.add( new Pair<>( (int)(pos-ranges[currentPart-1]-1), e.index));
 			else
-				vec.add( new Pair<Integer, Integer>( (int)pos-1,  e.index));
+				vec.add( new Pair<>( (int)pos-1,  e.index));
 		}
 	}
 	
 	public static Set<Integer> setPickRecordsInEachPartFile(JobConf job, NumItemsByEachReducerMetaData metadata, double[] probs)
 	{
-		HashMap<Integer, ArrayList<Pair<Integer, Integer>>> posMap
-		=new HashMap<Integer, ArrayList<Pair<Integer, Integer>>>();
-		
+		HashMap<Integer, ArrayList<Pair<Integer, Integer>>> posMap = new HashMap<>();
 		getPointsInEachPartFile(metadata.getNumItemsArray(), probs, posMap);
 		
 		for(Entry<Integer, ArrayList<Pair<Integer, Integer>>> e: posMap.entrySet())
@@ -209,6 +208,7 @@ public class PickFromCompactInputFormat extends FileInputFormat<MatrixIndexes, M
 		return sb.substring(0, sb.length()-1);
 	}
 
+	@Override
 	public RecordReader<MatrixIndexes, MatrixCell> getRecordReader(InputSplit split
 			, JobConf job, Reporter reporter) throws IOException {
 		if(job.getBoolean(INPUT_IS_VECTOR, true))
@@ -269,7 +269,7 @@ public class PickFromCompactInputFormat extends FileInputFormat<MatrixIndexes, M
 			String[] f2 = null;
 			
 			// Each field of the form: "pid,wt" where wt is the total wt until the part pid
-			partWeights = new HashMap<Integer,Double>();
+			partWeights = new HashMap<>();
 			for(int i=0; i < f1.length-1; i++) {
 				f2 = f1[i].split(",");
 				if(i==0) {

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/sort/SamplingSortMRInputFormat.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/sort/SamplingSortMRInputFormat.java b/src/main/java/org/apache/sysml/runtime/matrix/sort/SamplingSortMRInputFormat.java
index 3f6cd05..abaf272 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/sort/SamplingSortMRInputFormat.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/sort/SamplingSortMRInputFormat.java
@@ -71,7 +71,7 @@ extends SequenceFileInputFormat<K,V>
     {
 		if(reporter!=null)
 			reporter.setStatus(split.toString());
-		return new SequenceFileRecordReader<K,V>(job, (FileSplit) split);
+		return new SequenceFileRecordReader<>(job, (FileSplit) split);
     }
 
 	/**
@@ -188,7 +188,7 @@ extends SequenceFileInputFormat<K,V>
 
 	private static class Sampler implements IndexedSortable 
 	{
-		private ArrayList<WritableComparable> records = new ArrayList<WritableComparable>();
+		private ArrayList<WritableComparable> records = new ArrayList<>();
 		
 		@SuppressWarnings("unchecked")
 		public int compare(int i, int j) {
@@ -204,13 +204,12 @@ extends SequenceFileInputFormat<K,V>
 			records.set(i, right);
 		}
 		
-		public void addValue(WritableComparable r)
-		{
+		public void addValue(WritableComparable r) {
 			records.add(r);
 		}
 		
-		public String toString()
-		{
+		@Override
+		public String toString() {
 			return records.toString();
 		}
 
@@ -233,7 +232,7 @@ extends SequenceFileInputFormat<K,V>
 			//System.out.println("after sort: "+ toString());
 			float stepSize = numRecords / (float) numPartitions;
 			//System.out.println("Step size is " + stepSize);
-			ArrayList<WritableComparable> result = new ArrayList<WritableComparable>(numPartitions-1);
+			ArrayList<WritableComparable> result = new ArrayList<>(numPartitions-1);
 			for(int i=1; i < numPartitions; i++) {
 				result.add(records.get(Math.round(stepSize * i)));
 			}

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/matrix/sort/ValueSortReducer.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/matrix/sort/ValueSortReducer.java b/src/main/java/org/apache/sysml/runtime/matrix/sort/ValueSortReducer.java
index 13751c5..89857d0 100644
--- a/src/main/java/org/apache/sysml/runtime/matrix/sort/ValueSortReducer.java
+++ b/src/main/java/org/apache/sysml/runtime/matrix/sort/ValueSortReducer.java
@@ -43,8 +43,8 @@ public class ValueSortReducer<K extends WritableComparable, V extends Writable>
 	private boolean valueIsWeight=false;
 	private long count=0;
 	
-	public void configure(JobConf job)
-	{
+	@Override
+	public void configure(JobConf job) {
 		taskID=MapReduceTool.getUniqueKeyPerTask(job, false);
 		valueIsWeight=job.getBoolean(SortMR.VALUE_IS_WEIGHT, false);
 	}

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/transform/decode/DecoderFactory.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/transform/decode/DecoderFactory.java b/src/main/java/org/apache/sysml/runtime/transform/decode/DecoderFactory.java
index dcacd6d..5a351cb 100644
--- a/src/main/java/org/apache/sysml/runtime/transform/decode/DecoderFactory.java
+++ b/src/main/java/org/apache/sysml/runtime/transform/decode/DecoderFactory.java
@@ -45,7 +45,7 @@ public class DecoderFactory
 		{
 			//parse transform specification
 			JSONObject jSpec = new JSONObject(spec);
-			List<Decoder> ldecoders = new ArrayList<Decoder>();
+			List<Decoder> ldecoders = new ArrayList<>();
 		
 			//create decoders 'recode', 'dummy' and 'pass-through'
 			List<Integer> rcIDs = Arrays.asList(ArrayUtils.toObject(

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/transform/decode/DecoderRecode.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/transform/decode/DecoderRecode.java b/src/main/java/org/apache/sysml/runtime/transform/decode/DecoderRecode.java
index f6e8471..5a71444 100644
--- a/src/main/java/org/apache/sysml/runtime/transform/decode/DecoderRecode.java
+++ b/src/main/java/org/apache/sysml/runtime/transform/decode/DecoderRecode.java
@@ -78,7 +78,7 @@ public class DecoderRecode extends Decoder
 		//initialize recode maps according to schema
 		_rcMaps = new HashMap[_colList.length];
 		for( int j=0; j<_colList.length; j++ ) {
-			HashMap<Long, Object> map = new HashMap<Long, Object>();
+			HashMap<Long, Object> map = new HashMap<>();
 			for( int i=0; i<meta.getNumRows(); i++ ) {
 				if( meta.get(i, _colList[j]-1)==null )
 					break; //reached end of recode map

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderFactory.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderFactory.java b/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderFactory.java
index b8180f3..a776cb6 100644
--- a/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderFactory.java
+++ b/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderFactory.java
@@ -54,7 +54,7 @@ public class EncoderFactory
 		try {
 			//parse transform specification
 			JSONObject jSpec = new JSONObject(spec);
-			List<Encoder> lencoders = new ArrayList<Encoder>();
+			List<Encoder> lencoders = new ArrayList<>();
 		
 			//prepare basic id lists (recode, dummycode, pass-through)
 			//note: any dummycode column requires recode as preparation

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderMVImpute.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderMVImpute.java b/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderMVImpute.java
index ad155e9..53895b7 100644
--- a/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderMVImpute.java
+++ b/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderMVImpute.java
@@ -88,15 +88,15 @@ public class EncoderMVImpute extends Encoder
 		parseMethodsAndReplacments(parsedSpec);
 		
 		//create reuse histograms
-		_hist = new HashMap<Integer, HashMap<String,Long>>();
+		_hist = new HashMap<>();
 	}
-			
+	
 	public EncoderMVImpute(JSONObject parsedSpec, String[] colnames, String[] NAstrings, int clen)
 		throws JSONException 
 	{
-		super(null, clen);	
+		super(null, clen);
 		boolean isMV = parsedSpec.containsKey(TfUtils.TXMETHOD_IMPUTE);
-		boolean isSC = parsedSpec.containsKey(TfUtils.TXMETHOD_SCALE);		
+		boolean isSC = parsedSpec.containsKey(TfUtils.TXMETHOD_SCALE);
 		_NAstrings = NAstrings;
 		
 		if(!isMV) {
@@ -314,7 +314,7 @@ public class EncoderMVImpute extends Encoder
 				else if( _mvMethodList[j] == MVMethod.GLOBAL_MODE ) {
 					//compute global column mode (categorical), i.e., most frequent category
 					HashMap<String,Long> hist = _hist.containsKey(colID) ? 
-							_hist.get(colID) : new HashMap<String,Long>();
+							_hist.get(colID) : new HashMap<>();
 					for( int i=0; i<in.getNumRows(); i++ ) {
 						String key = String.valueOf(in.get(i, colID-1));
 						if( key != null && !key.isEmpty() ) {
@@ -358,6 +358,7 @@ public class EncoderMVImpute extends Encoder
 		return out;
 	}
 
+	@Override
 	public void initMetaData(FrameBlock meta) {
 		//init replacement lists, replace recoded values to
 		//apply mv imputation potentially after recoding

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderRecode.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderRecode.java b/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderRecode.java
index d090e66..8758e73 100644
--- a/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderRecode.java
+++ b/src/main/java/org/apache/sysml/runtime/transform/encode/EncoderRecode.java
@@ -37,7 +37,7 @@ public class EncoderRecode extends Encoder
 	private static final long serialVersionUID = 8213163881283341874L;
 	
 	//recode maps and custom map for partial recode maps 
-	private HashMap<Integer, HashMap<String, Long>> _rcdMaps  = new HashMap<Integer, HashMap<String, Long>>();
+	private HashMap<Integer, HashMap<String, Long>> _rcdMaps  = new HashMap<>();
 	private HashMap<Integer, HashSet<Object>> _rcdMapsPart = null;
 	
 	public EncoderRecode(JSONObject parsedSpec, String[] colnames, int clen)
@@ -105,7 +105,7 @@ public class EncoderRecode extends Encoder
 
 		//ensure allocated partial recode map
 		if( _rcdMapsPart == null )
-			_rcdMapsPart = new HashMap<Integer, HashSet<Object>>();
+			_rcdMapsPart = new HashMap<>();
 		
 		//construct partial recode map (tokens w/o codes)
 		//iterate over columns for sequential access
@@ -113,7 +113,7 @@ public class EncoderRecode extends Encoder
 			int colID = _colList[j]; //1-based
 			//allocate column map if necessary
 			if( !_rcdMapsPart.containsKey(colID) ) 
-				_rcdMapsPart.put(colID, new HashSet<Object>());
+				_rcdMapsPart.put(colID, new HashSet<>());
 			HashSet<Object> map = _rcdMapsPart.get(colID);
 			//probe and build column map
 			for( int i=0; i<in.getNumRows(); i++ )
@@ -178,6 +178,7 @@ public class EncoderRecode extends Encoder
 	 * 
 	 * @param meta frame block
 	 */
+	@Override
 	public void initMetaData( FrameBlock meta ) {
 		if( meta == null || meta.getNumRows()<=0 )
 			return;

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/transform/meta/TfMetaUtils.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/transform/meta/TfMetaUtils.java b/src/main/java/org/apache/sysml/runtime/transform/meta/TfMetaUtils.java
index 14a12b8..3d4353d 100644
--- a/src/main/java/org/apache/sysml/runtime/transform/meta/TfMetaUtils.java
+++ b/src/main/java/org/apache/sysml/runtime/transform/meta/TfMetaUtils.java
@@ -169,8 +169,8 @@ public class TfMetaUtils
 		
 		//read meta data (currently supported: recode, dummycode, bin, omit, impute)
 		//note: recode/binning and impute might be applied on the same column
-		HashMap<String,String> meta = new HashMap<String,String>();
-		HashMap<String,String> mvmeta = new HashMap<String,String>();
+		HashMap<String,String> meta = new HashMap<>();
+		HashMap<String,String> mvmeta = new HashMap<>();
 		int rows = 0;
 		for( int j=0; j<colnames.length; j++ ) {
 			String colName = colnames[j];
@@ -223,8 +223,8 @@ public class TfMetaUtils
 		
 		//read meta data (currently supported: recode, dummycode, bin, omit)
 		//note: recode/binning and impute might be applied on the same column
-		HashMap<String,String> meta = new HashMap<String,String>();
-		HashMap<String,String> mvmeta = new HashMap<String,String>();
+		HashMap<String,String> meta = new HashMap<>();
+		HashMap<String,String> mvmeta = new HashMap<>();
 		int rows = 0;
 		for( int j=0; j<colnames.length; j++ ) {
 			String colName = colnames[j];
@@ -289,7 +289,7 @@ public class TfMetaUtils
 			
 			InputStream is = new ByteArrayInputStream(map.getBytes("UTF-8"));
 			BufferedReader br = new BufferedReader(new InputStreamReader(is));
-			Pair<String,String> pair = new Pair<String,String>();
+			Pair<String,String> pair = new Pair<>();
 			String line; int rpos = 0; 
 			while( (line = br.readLine()) != null ) {
 				DecoderRecode.parseRecodeMapEntry(line, pair);

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/transform/meta/TfOffsetMap.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/transform/meta/TfOffsetMap.java b/src/main/java/org/apache/sysml/runtime/transform/meta/TfOffsetMap.java
index a486697..8fde769 100644
--- a/src/main/java/org/apache/sysml/runtime/transform/meta/TfOffsetMap.java
+++ b/src/main/java/org/apache/sysml/runtime/transform/meta/TfOffsetMap.java
@@ -36,12 +36,12 @@ public class TfOffsetMap implements Serializable
 	
 	public TfOffsetMap( List<Pair<Long,Long>> rmRows ) {
 		//sort input list of <key, rm rows per block>
-		TreeMap<Long, Long> tmap = new TreeMap<Long, Long>();
+		TreeMap<Long, Long> tmap = new TreeMap<>();
 		for( Pair<Long, Long> pair : rmRows )
 			tmap.put(pair.getKey(), pair.getValue());
 		
 		//compute shifted keys and build hash table
-		_map = new HashMap<Long, Long>();
+		_map = new HashMap<>();
 		long shift = 0;
 		for( Entry<Long, Long> e : tmap.entrySet() ) {
 			_map.put(e.getKey(), e.getKey()-shift);

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/util/NormalPRNGenerator.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/util/NormalPRNGenerator.java b/src/main/java/org/apache/sysml/runtime/util/NormalPRNGenerator.java
index ce6f7e0..69af6a6 100644
--- a/src/main/java/org/apache/sysml/runtime/util/NormalPRNGenerator.java
+++ b/src/main/java/org/apache/sysml/runtime/util/NormalPRNGenerator.java
@@ -28,22 +28,17 @@ import java.util.Random;
  * RandNPair, which uses Box-Muller method.
  */
 
-
 public class NormalPRNGenerator extends PRNGenerator
 {
-	//private long seed;
-	Random r;
+	private Random r;
 	private RandNPair pair;
-	boolean flag = false; // we use pair.N1 if flag=false, and pair.N2 otherwise
+	private boolean flag = false; // we use pair.N1 if flag=false, and pair.N2 otherwise
 	
 	public NormalPRNGenerator() {
 		super();
 	}
-
-	/*public NormalPRNGenerator(Random random) {
-		init(random);
-	}*/
 	
+	@Override
 	public void setSeed(long sd) {
 		//seed = s;
 		seed = sd;
@@ -53,6 +48,7 @@ public class NormalPRNGenerator extends PRNGenerator
 		pair.compute(r);
 	}
 	
+	@Override
 	public double nextDouble() {
 		double d;
 		if (!flag) {
@@ -65,5 +61,4 @@ public class NormalPRNGenerator extends PRNGenerator
 		flag = !flag;
 		return d;
 	}
-
 }

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/util/PoissonPRNGenerator.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/util/PoissonPRNGenerator.java b/src/main/java/org/apache/sysml/runtime/util/PoissonPRNGenerator.java
index 39de4c0..cf24d07 100644
--- a/src/main/java/org/apache/sysml/runtime/util/PoissonPRNGenerator.java
+++ b/src/main/java/org/apache/sysml/runtime/util/PoissonPRNGenerator.java
@@ -32,8 +32,8 @@ import org.apache.commons.math3.random.Well1024a;
 
 public class PoissonPRNGenerator extends PRNGenerator
 {
-	PoissonDistribution _pdist = null;
-	double _mean = Double.NaN;
+	private PoissonDistribution _pdist = null;
+	private double _mean = Double.NaN;
 
 	public PoissonPRNGenerator() {
 		// default mean and default seed
@@ -42,8 +42,7 @@ public class PoissonPRNGenerator extends PRNGenerator
 		setup(_mean, seed);
 	}
 	
-	public PoissonPRNGenerator(double mean) 
-	{
+	public PoissonPRNGenerator(double mean) {
 		// default seed
 		super();
 		_mean = mean;
@@ -52,7 +51,6 @@ public class PoissonPRNGenerator extends PRNGenerator
 
 	public void setup(double mean, long sd) {
 		seed = sd;
-		
 		SynchronizedRandomGenerator srg = new SynchronizedRandomGenerator(new Well1024a());
 		srg.setSeed(seed);
 		_pdist = new PoissonDistribution(srg, _mean, PoissonDistribution.DEFAULT_EPSILON, PoissonDistribution.DEFAULT_MAX_ITERATIONS);
@@ -67,10 +65,8 @@ public class PoissonPRNGenerator extends PRNGenerator
 		setup(mean, seed);
 	}
 	
+	@Override
 	public double nextDouble() {
 		return (double) _pdist.sample();
 	}
-	
-	
-
 }

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/runtime/util/UniformPRNGenerator.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/runtime/util/UniformPRNGenerator.java b/src/main/java/org/apache/sysml/runtime/util/UniformPRNGenerator.java
index 529ca03..9e819be 100644
--- a/src/main/java/org/apache/sysml/runtime/util/UniformPRNGenerator.java
+++ b/src/main/java/org/apache/sysml/runtime/util/UniformPRNGenerator.java
@@ -24,11 +24,10 @@ import java.util.Random;
 
 public class UniformPRNGenerator extends PRNGenerator {
 
-	Random runif = null;
+	private Random runif = null;
 	
-	public void setSeed(long sd) {
-		seed = sd;
-		runif = new Random(seed);
+	public UniformPRNGenerator() {
+		super();
 	}
 	
 	public UniformPRNGenerator(long sd) {
@@ -36,8 +35,10 @@ public class UniformPRNGenerator extends PRNGenerator {
 		setSeed(sd);
 	}
 
-	public UniformPRNGenerator() {
-		super();
+	@Override
+	public void setSeed(long sd) {
+		seed = sd;
+		runif = new Random(seed);
 	}
 
 	@Override

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/main/java/org/apache/sysml/udf/ExternalFunctionInvocationInstruction.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/udf/ExternalFunctionInvocationInstruction.java b/src/main/java/org/apache/sysml/udf/ExternalFunctionInvocationInstruction.java
index 476970a..93717e5 100644
--- a/src/main/java/org/apache/sysml/udf/ExternalFunctionInvocationInstruction.java
+++ b/src/main/java/org/apache/sysml/udf/ExternalFunctionInvocationInstruction.java
@@ -67,11 +67,12 @@ public class ExternalFunctionInvocationInstruction extends Instruction
 		return outputParams;
 	}
 
+	@Override
 	public String toString() {
 		return className + ELEMENT_DELIM + 
-		       configFile + ELEMENT_DELIM + 
-		       inputParams + ELEMENT_DELIM + 
-		       outputParams;
+			configFile + ELEMENT_DELIM + 
+			inputParams + ELEMENT_DELIM + 
+			outputParams;
 	}
 
 	@Override

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/AutomatedTestBase.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/AutomatedTestBase.java b/src/test/java/org/apache/sysml/test/integration/AutomatedTestBase.java
index 6a78011..d39e513 100644
--- a/src/test/java/org/apache/sysml/test/integration/AutomatedTestBase.java
+++ b/src/test/java/org/apache/sysml/test/integration/AutomatedTestBase.java
@@ -1712,18 +1712,13 @@ public abstract class AutomatedTestBase
 		}
 	}
 
-	private String getSourceDirectory(String testDirectory) {
+	private static String getSourceDirectory(String testDirectory) {
 		String sourceDirectory = "";
-
-		if (null != testDirectory)
-		{
+		if (null != testDirectory) {
 			if (testDirectory.endsWith("/"))
-			{
 				testDirectory = testDirectory.substring(0, testDirectory.length() - "/".length());
-			}
 			sourceDirectory = testDirectory.substring(0, testDirectory.lastIndexOf("/") + "/".length());
 		}
-
 		return sourceDirectory;
 	}
 

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/applications/ID3Test.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/applications/ID3Test.java b/src/test/java/org/apache/sysml/test/integration/applications/ID3Test.java
index c7d3cb4..a158f52 100644
--- a/src/test/java/org/apache/sysml/test/integration/applications/ID3Test.java
+++ b/src/test/java/org/apache/sysml/test/integration/applications/ID3Test.java
@@ -89,8 +89,8 @@ public abstract class ID3Test extends AutomatedTestBase
 		rCmd = getRCmd(inputDir(), expectedDir());
 
         // prepare training data set
-        double[][] X = round(getRandomMatrix(rows, cols, 1, 10, 1.0, 3));
-        double[][] y = round(getRandomMatrix(rows, 1, 1, 10, 1.0, 7));
+        double[][] X = TestUtils.round(getRandomMatrix(rows, cols, 1, 10, 1.0, 3));
+        double[][] y = TestUtils.round(getRandomMatrix(rows, 1, 1, 10, 1.0, 7));
         writeInputMatrixWithMTD("X", X, true);
         writeInputMatrixWithMTD("y", y, true);
         
@@ -114,12 +114,4 @@ public abstract class ID3Test extends AutomatedTestBase
         TestUtils.compareMatrices(nR, nSYSTEMML, Math.pow(10, -14), "nR", "nSYSTEMML");
         TestUtils.compareMatrices(eR, eSYSTEMML, Math.pow(10, -14), "eR", "eSYSTEMML");      
     }
-    
-    private double[][] round( double[][] data )
-	{
-		for( int i=0; i<data.length; i++ )
-			for( int j=0; j<data[i].length; j++ )
-				data[i][j] = Math.round(data[i][j]);
-		return data;
-	}
 }

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateCategoricalCategoricallTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateCategoricalCategoricallTest.java b/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateCategoricalCategoricallTest.java
index 506cf5e..2430d52 100644
--- a/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateCategoricalCategoricallTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateCategoricalCategoricallTest.java
@@ -82,11 +82,11 @@ public class BivariateCategoricalCategoricallTest extends AutomatedTestBase
 		fullRScriptName = CC_HOME + TEST_NOMINAL_NOMINAL + ".R";
 		rCmd = "Rscript" + " " + fullRScriptName + " " + inputDir() + " " + expectedDir();
 
-        double[][] A = getRandomMatrix(rows, 1, 1, ncatA, 1, 3);
-        double[][] B = getRandomMatrix(rows, 1, 1, ncatB, 1, 7);
-        round(A);
-        round(B);
-        
+		double[][] A = getRandomMatrix(rows, 1, 1, ncatA, 1, 3);
+		double[][] B = getRandomMatrix(rows, 1, 1, ncatB, 1, 7);
+		TestUtils.round(A);
+		TestUtils.round(B);
+
 		writeInputMatrix("A", A, true);
 		writeInputMatrix("B", B, true);
 
@@ -121,11 +121,6 @@ public class BivariateCategoricalCategoricallTest extends AutomatedTestBase
 		
 	}
 	
-	private void round(double[][] weight) {
-		for(int i=0; i<weight.length; i++)
-			weight[i][0]=Math.round(weight[i][0]);
-	}
-
 	@Test
 	public void testCategoricalCategoricalWithWeights() {
 		TestConfiguration config = getTestConfiguration(TEST_NOMINAL_NOMINAL_WEIGHTS);
@@ -141,18 +136,18 @@ public class BivariateCategoricalCategoricallTest extends AutomatedTestBase
 		fullRScriptName = CC_HOME + TEST_NOMINAL_NOMINAL_WEIGHTS + ".R";
 		rCmd = "Rscript" + " " + fullRScriptName + " " + inputDir() + " " + expectedDir();
 
-        double[][] A = getRandomMatrix(rows, 1, 1, ncatA, 1, System.currentTimeMillis());
-        double[][] B = getRandomMatrix(rows, 1, 1, ncatB, 1, System.currentTimeMillis()+1);
-        double[][] WM = getRandomMatrix(rows, 1, 1, maxW, 1, System.currentTimeMillis()+2);
-        round(A);
-        round(B);
-        round(WM);
-        
+		double[][] A = getRandomMatrix(rows, 1, 1, ncatA, 1, System.currentTimeMillis());
+		double[][] B = getRandomMatrix(rows, 1, 1, ncatB, 1, System.currentTimeMillis()+1);
+		double[][] WM = getRandomMatrix(rows, 1, 1, maxW, 1, System.currentTimeMillis()+2);
+		TestUtils.round(A);
+		TestUtils.round(B);
+		TestUtils.round(WM);
+
 		writeInputMatrix("A", A, true);
 		writeInputMatrix("B", B, true);
 		writeInputMatrix("WM", WM, true);
-        createHelperMatrix();
-        
+		createHelperMatrix();
+		
 		/*
 		 * Expected number of jobs:
 		 * Mean etc - 2 jobs (reblock & gmr)
@@ -210,11 +205,11 @@ public class BivariateCategoricalCategoricallTest extends AutomatedTestBase
 
 		// current test works only for 2x2 contingency tables => #categories must be 2
 		int numCat = 2;
-        double[][] A = getRandomMatrix(rows, 1, 1, numCat, 1, System.currentTimeMillis());
-        double[][] B = getRandomMatrix(rows, 1, 1, numCat, 1, System.currentTimeMillis()+1);
-        round(A);
-        round(B);
-        
+		double[][] A = getRandomMatrix(rows, 1, 1, numCat, 1, System.currentTimeMillis());
+		double[][] B = getRandomMatrix(rows, 1, 1, numCat, 1, System.currentTimeMillis()+1);
+		TestUtils.round(A);
+		TestUtils.round(B);
+
 		writeInputMatrix("A", A, true);
 		writeInputMatrix("B", B, true);
 

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateOrdinalOrdinalTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateOrdinalOrdinalTest.java b/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateOrdinalOrdinalTest.java
index d945904..45d8966 100644
--- a/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateOrdinalOrdinalTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateOrdinalOrdinalTest.java
@@ -68,11 +68,11 @@ public class BivariateOrdinalOrdinalTest extends AutomatedTestBase
 		fullRScriptName = OO_HOME + TEST_ORDINAL_ORDINAL + ".R";
 		rCmd = "Rscript" + " " + fullRScriptName + " " + inputDir() + " " + expectedDir();
 
-        double[][] A = getRandomMatrix(rows, 1, 1, ncatA, 1, System.currentTimeMillis());
-        double[][] B = getRandomMatrix(rows, 1, 1, ncatB, 1, System.currentTimeMillis()+1);
-        round(A);
-        round(B);
-        
+		double[][] A = getRandomMatrix(rows, 1, 1, ncatA, 1, System.currentTimeMillis());
+		double[][] B = getRandomMatrix(rows, 1, 1, ncatB, 1, System.currentTimeMillis()+1);
+		TestUtils.floor(A);
+		TestUtils.floor(B);
+
 		writeInputMatrix("A", A, true);
 		writeInputMatrix("B", B, true);
 
@@ -97,11 +97,6 @@ public class BivariateOrdinalOrdinalTest extends AutomatedTestBase
 		}
 	}
 	
-	private void round(double[][] weight) {
-		for(int i=0; i<weight.length; i++)
-			weight[i][0]=Math.floor(weight[i][0]);
-	}
-
 	@Test
 	public void testOrdinalOrdinalWithWeights() {
 		TestConfiguration config = getTestConfiguration(TEST_ORDINAL_ORDINAL_WEIGHTS);
@@ -117,13 +112,13 @@ public class BivariateOrdinalOrdinalTest extends AutomatedTestBase
 		fullRScriptName = OO_HOME + TEST_ORDINAL_ORDINAL_WEIGHTS + ".R";
 		rCmd = "Rscript" + " " + fullRScriptName + " " + inputDir() + " " + expectedDir();
 
-        double[][] A = getRandomMatrix(rows, 1, 1, ncatA, 1, System.currentTimeMillis());
-        double[][] B = getRandomMatrix(rows, 1, 1, ncatB, 1, System.currentTimeMillis());
-        double[][] WM = getRandomMatrix(rows, 1, 1, maxW, 1, System.currentTimeMillis());
-        round(A);
-        round(B);
-        round(WM);
-        
+		double[][] A = getRandomMatrix(rows, 1, 1, ncatA, 1, System.currentTimeMillis());
+		double[][] B = getRandomMatrix(rows, 1, 1, ncatB, 1, System.currentTimeMillis());
+		double[][] WM = getRandomMatrix(rows, 1, 1, maxW, 1, System.currentTimeMillis());
+		TestUtils.floor(A);
+		TestUtils.floor(B);
+		TestUtils.floor(WM);
+
 		writeInputMatrix("A", A, true);
 		writeInputMatrix("B", B, true);
 		writeInputMatrix("WM", WM, true);

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateScaleCategoricalTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateScaleCategoricalTest.java b/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateScaleCategoricalTest.java
index 90310c5..431be84 100644
--- a/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateScaleCategoricalTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateScaleCategoricalTest.java
@@ -73,18 +73,14 @@ public class BivariateScaleCategoricalTest extends AutomatedTestBase
 		fullRScriptName = SC_HOME + TEST_SCALE_NOMINAL + ".R";
 		rCmd = "Rscript" + " " + fullRScriptName + " " + inputDir() + " " + expectedDir();
 
-        double[][] A = getRandomMatrix(rows, 1, 1, ncatA, 1, System.currentTimeMillis()) ; 
-        round(A);
-        double[][] Y = getRandomMatrix(rows, 1, minVal, maxVal, 0.1, System.currentTimeMillis()) ; 
+		double[][] A = getRandomMatrix(rows, 1, 1, ncatA, 1, System.currentTimeMillis()) ; 
+		TestUtils.floor(A);
+		double[][] Y = getRandomMatrix(rows, 1, minVal, maxVal, 0.1, System.currentTimeMillis()) ; 
 
 		writeInputMatrix("A", A, true);
 		writeInputMatrix("Y", Y, true);
 
 		boolean exceptionExpected = false;
-		/*
-		 * Expected number of jobs:
-		 */
-		// int expectedNumberOfJobs = 5;
 		runTest(true, exceptionExpected, null, -1);
 		
 		runRScript(true);
@@ -106,11 +102,6 @@ public class BivariateScaleCategoricalTest extends AutomatedTestBase
 			TestUtils.compareMatrices(dmlfile, rfile, eps, file+"-DML", file+"-R");
 		}
 	}
-	
-	private void round(double[][] weight) {
-		for(int i=0; i<weight.length; i++)
-			weight[i][0]=Math.floor(weight[i][0]);
-	}
 
 	@Test
 	public void testScaleCategoricalWithWeights() {
@@ -129,12 +120,12 @@ public class BivariateScaleCategoricalTest extends AutomatedTestBase
 		fullRScriptName = SC_HOME + TEST_SCALE_NOMINAL_WEIGHTS + ".R";
 		rCmd = "Rscript" + " " + fullRScriptName + " " + inputDir() + " " + expectedDir();
 
-        double[][] A = getRandomMatrix(rows, 1, 1, ncatA, 1, System.currentTimeMillis());
-        double[][] Y = getRandomMatrix(rows, 1, minVal, maxVal, 0.1, System.currentTimeMillis());
-        double[][] WM = getRandomMatrix(rows, 1, 1, maxW, 1, System.currentTimeMillis());
-        round(A);
-        round(WM);
-        
+		double[][] A = getRandomMatrix(rows, 1, 1, ncatA, 1, System.currentTimeMillis());
+		double[][] Y = getRandomMatrix(rows, 1, minVal, maxVal, 0.1, System.currentTimeMillis());
+		double[][] WM = getRandomMatrix(rows, 1, 1, maxW, 1, System.currentTimeMillis());
+		TestUtils.floor(A);
+		TestUtils.floor(WM);
+
 		writeInputMatrix("A", A, true);
 		writeInputMatrix("Y", Y, true);
 		writeInputMatrix("WM", WM, true);

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateScaleScaleTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateScaleScaleTest.java b/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateScaleScaleTest.java
index 95e57e7..7c1bbc8 100644
--- a/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateScaleScaleTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/applications/descriptivestats/BivariateScaleScaleTest.java
@@ -103,11 +103,6 @@ public class BivariateScaleScaleTest extends AutomatedTestBase
 		}
 	}
 	
-	private void round(double[][] weight) {
-		for(int i=0; i<weight.length; i++)
-			weight[i][0]=Math.floor(weight[i][0]);
-	}
-
 	@Test
 	public void testPearsonRWithWeights() {
 
@@ -124,17 +119,15 @@ public class BivariateScaleScaleTest extends AutomatedTestBase
 		fullRScriptName = SS_HOME + TEST_SCALE_SCALE_WEIGHTS + ".R";
 		rCmd = "Rscript" + " " + fullRScriptName + " " + inputDir() + " " + expectedDir();
 
-		//long seed = System.currentTimeMillis();
-		//System.out.println("Seed = " + seed);
-        double[][] X = getRandomMatrix(rows, 1, minVal, maxVal, 0.1, System.currentTimeMillis());
-        double[][] Y = getRandomMatrix(rows, 1, minVal, maxVal, 0.1, System.currentTimeMillis());
-        double[][] WM = getRandomMatrix(rows, 1, 1, maxW, 1, System.currentTimeMillis());
-        round(WM);
-        
+		double[][] X = getRandomMatrix(rows, 1, minVal, maxVal, 0.1, System.currentTimeMillis());
+		double[][] Y = getRandomMatrix(rows, 1, minVal, maxVal, 0.1, System.currentTimeMillis());
+		double[][] WM = getRandomMatrix(rows, 1, 1, maxW, 1, System.currentTimeMillis());
+		TestUtils.floor(WM);
+
 		writeInputMatrix("X", X, true);
 		writeInputMatrix("Y", Y, true);
 		writeInputMatrix("WM", WM, true);
-        createHelperMatrix();
+		createHelperMatrix();
 		
 		boolean exceptionExpected = false;
 		/*

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForBivariateStatsTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForBivariateStatsTest.java b/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForBivariateStatsTest.java
index 3381436..bad8589 100644
--- a/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForBivariateStatsTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForBivariateStatsTest.java
@@ -138,15 +138,15 @@ public class ParForBivariateStatsTest extends AutomatedTestBase
 		{
 			Dkind[i]=(i%3)+1;//kind 1,2,3
 			if( Dkind[i]!=1 )
-				round(D,i); //for ordinal and categorical vars
+				TestUtils.floor(D,i); //for ordinal and categorical vars
 		}
 		writeInputMatrix("D", D, true);
 		
 		//generate attribute sets		
-        double[][] S1 = getRandomMatrix(1, cols2, 1, cols+1-eps, 1, 1112);
-        double[][] S2 = getRandomMatrix(1, cols2, 1, cols+1-eps, 1, 1113);
-        round(S1);
-        round(S2);
+		double[][] S1 = getRandomMatrix(1, cols2, 1, cols+1-eps, 1, 1112);
+		double[][] S2 = getRandomMatrix(1, cols2, 1, cols+1-eps, 1, 1113);
+		TestUtils.floor(S1);
+		TestUtils.floor(S2);
 		writeInputMatrix("S1", S1, true);
 		writeInputMatrix("S2", S2, true);	
 
@@ -175,15 +175,4 @@ public class ParForBivariateStatsTest extends AutomatedTestBase
 			TestUtils.compareMatrices(dmlfile, rfile, eps, "Stat-DML", "Stat-R");
 		}
 	}
-	
-	private void round(double[][] data) {
-		for(int i=0; i<data.length; i++)
-			for(int j=0; j<data[i].length; j++)
-				data[i][j]=Math.floor(data[i][j]);
-	}
-	
-	private void round(double[][] data, int col) {
-		for(int i=0; i<data.length; i++)
-			data[i][col]=Math.floor(data[i][col]);
-	}
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForCVMulticlassSVMTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForCVMulticlassSVMTest.java b/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForCVMulticlassSVMTest.java
index be5c771..fe53897 100644
--- a/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForCVMulticlassSVMTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForCVMulticlassSVMTest.java
@@ -143,8 +143,8 @@ public class ParForCVMulticlassSVMTest extends AutomatedTestBase
 		
 		//generate actual dataset
 		double[][] X = getRandomMatrix(rows, cols, 0, 1, sparsity, 7); 
-		double[][] y = round(getRandomMatrix(rows, 1, 0.51, numclasses+0.49, 1.0, 7)); 
-		double[][] P = round(getRandomMatrix(rows, 1, 0.51, k+0.49, 1.0, 3)); 
+		double[][] y = TestUtils.round(getRandomMatrix(rows, 1, 0.51, numclasses+0.49, 1.0, 7)); 
+		double[][] P = TestUtils.round(getRandomMatrix(rows, 1, 0.51, k+0.49, 1.0, 3)); 
 
 		MatrixCharacteristics mc1 = new MatrixCharacteristics(rows,cols,-1,-1);
 		writeInputMatrixWithMTD("X", X, true, mc1);
@@ -163,10 +163,4 @@ public class ParForCVMulticlassSVMTest extends AutomatedTestBase
 		HashMap<CellIndex, Double> rfile  = readRMatrixFromFS("stats");
 		TestUtils.compareMatrices(dmlfile, rfile, eps, "DML", "R");
 	}
-	
-	private double[][] round(double[][] data) {
-		for(int i=0; i<data.length; i++)
-			data[i][0]=Math.round(data[i][0]);
-		return data;
-	}
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForUnivariateStatsTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForUnivariateStatsTest.java b/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForUnivariateStatsTest.java
index 772b35b..4303e50 100644
--- a/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForUnivariateStatsTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/applications/parfor/ParForUnivariateStatsTest.java
@@ -143,7 +143,7 @@ public class ParForUnivariateStatsTest extends AutomatedTestBase
 		{
 			Dkind[i]=(i%3)+1;//kind 1,2,3
 			if( Dkind[i]!=1 )
-				round(D,i); //for ordinal and categorical vars
+				TestUtils.floor(D,i); //for ordinal and categorical vars
 		}
 		MatrixCharacteristics mc1 = new MatrixCharacteristics(rows,cols,-1,-1);
 		writeInputMatrixWithMTD("D", D, true, mc1);
@@ -172,9 +172,4 @@ public class ParForUnivariateStatsTest extends AutomatedTestBase
 			TestUtils.compareMatrices(dmlfile, rfile, eps, "Stat-DML", "Stat-R");
 		}
 	}
-	
-	private void round(double[][] data, int col) {
-		for(int i=0; i<data.length; i++)
-			data[i][col]=Math.floor(data[i][col]);
-	}
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix/UltraSparseMRMatrixMultiplicationTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix/UltraSparseMRMatrixMultiplicationTest.java b/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix/UltraSparseMRMatrixMultiplicationTest.java
index 71ca7a6..229b5d7 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix/UltraSparseMRMatrixMultiplicationTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix/UltraSparseMRMatrixMultiplicationTest.java
@@ -183,7 +183,7 @@ public class UltraSparseMRMatrixMultiplicationTest extends AutomatedTestBase
 			double[][] A = getRandomMatrix(rows, cols, 0, 1, sparseM1?sparsity2:sparsity1, 7); 
 			writeInputMatrix("A", A, true);
 			double[][] B = getRandomMatrix(rows, 1, 0.51, 3.49, 1.0, 3); 
-			B = round(B);
+			B = TestUtils.round(B);
 			writeInputMatrix("B", B, true);
 	
 			boolean exceptionExpected = false;
@@ -195,19 +195,10 @@ public class UltraSparseMRMatrixMultiplicationTest extends AutomatedTestBase
 			HashMap<CellIndex, Double> rfile  = readRMatrixFromFS("C");
 			TestUtils.compareMatrices(dmlfile, rfile, eps, "Stat-DML", "Stat-R");
 		}
-		finally
-		{
+		finally {
 			rtplatform = platformOld;
 			DMLScript.USE_LOCAL_SPARK_CONFIG = sparkConfigOld;
 			AggBinaryOp.FORCED_MMULT_METHOD = null;
 		}
 	}
-
-	
-	private double[][] round(double[][] data) {
-		for(int i=0; i<data.length; i++)
-			data[i][0]=Math.round(data[i][0]);
-		return data;
-	}
-	
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix_full_other/FullIntegerDivisionTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix_full_other/FullIntegerDivisionTest.java b/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix_full_other/FullIntegerDivisionTest.java
index 4b3f5b0..1597f32 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix_full_other/FullIntegerDivisionTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix_full_other/FullIntegerDivisionTest.java
@@ -387,56 +387,37 @@ public class FullIntegerDivisionTest extends AutomatedTestBase
 		}
 	}
 	
-	/**
-	 * 
-	 * @param name
-	 * @param matrix
-	 * @param includeR
-	 */
-	private void writeScalarInputMatrixWithMTD(String name, double[][] matrix, boolean includeR) 
+	private static void writeScalarInputMatrixWithMTD(String name, double[][] matrix, boolean includeR) 
 	{
-		try
-		{
+		try {
 			//write DML scalar
 			String fname = baseDirectory + INPUT_DIR + name; // + "/in";
 			MapReduceTool.deleteFileIfExistOnHDFS(fname);
 			MapReduceTool.writeDoubleToHDFS(matrix[0][0], fname);
 			MapReduceTool.writeScalarMetaDataFile(baseDirectory + INPUT_DIR + name + ".mtd", ValueType.DOUBLE);
 		
-			
 			//write R matrix
 			if( includeR ){
 				String completeRPath = baseDirectory + INPUT_DIR + name + ".mtx";
 				TestUtils.writeTestMatrix(completeRPath, matrix, true);
 			}
 		}
-		catch(IOException e)
-		{
+		catch(IOException e) {
 			e.printStackTrace();
 			throw new RuntimeException(e);
 		}
 	}
 	
-	/**
-	 * 
-	 * @param name
-	 * @return
-	 */
-	private HashMap<CellIndex,Double> readScalarMatrixFromHDFS(String name) 
-	{
+	private static HashMap<CellIndex,Double> readScalarMatrixFromHDFS(String name) {
 		HashMap<CellIndex,Double> dmlfile = new HashMap<CellIndex,Double>();
-		try
-		{
+		try {
 			Double val = MapReduceTool.readDoubleFromHDFSFile(baseDirectory + OUTPUT_DIR + name);
 			dmlfile.put(new CellIndex(1,1), val);
 		}
-		catch(IOException e)
-		{
+		catch(IOException e) {
 			e.printStackTrace();
 			throw new RuntimeException(e);
 		}
-		
 		return dmlfile;
 	}
-		
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix_full_other/FullPowerTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix_full_other/FullPowerTest.java b/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix_full_other/FullPowerTest.java
index b59fd26..3e0e48d 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix_full_other/FullPowerTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/binary/matrix_full_other/FullPowerTest.java
@@ -271,13 +271,7 @@ public class FullPowerTest extends AutomatedTestBase
 		}
 	}
 	
-	/**
-	 * 
-	 * @param name
-	 * @param matrix
-	 * @param includeR
-	 */
-	private void writeScalarInputMatrixWithMTD(String name, double[][] matrix, boolean includeR) 
+	private static void writeScalarInputMatrixWithMTD(String name, double[][] matrix, boolean includeR) 
 	{
 		try
 		{
@@ -301,26 +295,17 @@ public class FullPowerTest extends AutomatedTestBase
 		}
 	}
 	
-	/**
-	 * 
-	 * @param name
-	 * @return
-	 */
-	private HashMap<CellIndex,Double> readScalarMatrixFromHDFS(String name) 
+	private static HashMap<CellIndex,Double> readScalarMatrixFromHDFS(String name) 
 	{
 		HashMap<CellIndex,Double> dmlfile = new HashMap<CellIndex,Double>();
-		try
-		{
+		try {
 			Double val = MapReduceTool.readDoubleFromHDFSFile(baseDirectory + OUTPUT_DIR + name);
 			dmlfile.put(new CellIndex(1,1), val);
 		}
-		catch(IOException e)
-		{
+		catch(IOException e) {
 			e.printStackTrace();
 			throw new RuntimeException(e);
 		}
-		
 		return dmlfile;
 	}
-		
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/codegen/CPlanComparisonTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/codegen/CPlanComparisonTest.java b/src/test/java/org/apache/sysml/test/integration/functions/codegen/CPlanComparisonTest.java
index 01908b4..bc68e68 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/codegen/CPlanComparisonTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/codegen/CPlanComparisonTest.java
@@ -243,7 +243,7 @@ public class CPlanComparisonTest extends AutomatedTestBase
 			DataOpTypes.TRANSIENTREAD, "tmp", 77L, 7L, -1L, 1000L, 1000L);
 	}
 	
-	private Hop createDataOp(String name, DataType dt) {
+	private static Hop createDataOp(String name, DataType dt) {
 		return new DataOp(name, dt, ValueType.DOUBLE, 
 			DataOpTypes.TRANSIENTREAD, "tmp", 77L, 7L, -1L, 1000L, 1000L);
 	}

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/codegen/CPlanVectorPrimitivesTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/codegen/CPlanVectorPrimitivesTest.java b/src/test/java/org/apache/sysml/test/integration/functions/codegen/CPlanVectorPrimitivesTest.java
index 065233c..3b65281 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/codegen/CPlanVectorPrimitivesTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/codegen/CPlanVectorPrimitivesTest.java
@@ -646,7 +646,7 @@ public class CPlanVectorPrimitivesTest extends AutomatedTestBase
 	}
 	
 	@SuppressWarnings("incomplete-switch")
-	private void testVectorAggPrimitive(UnaryType aggtype, InputType type1)
+	private static void testVectorAggPrimitive(UnaryType aggtype, InputType type1)
 	{
 		try {
 			//generate input data
@@ -684,7 +684,7 @@ public class CPlanVectorPrimitivesTest extends AutomatedTestBase
 		}
 	}
 	
-	private void testVectorUnaryPrimitive(UnaryType utype, InputType type1)
+	private static void testVectorUnaryPrimitive(UnaryType utype, InputType type1)
 	{
 		try {
 			//generate input data
@@ -720,7 +720,7 @@ public class CPlanVectorPrimitivesTest extends AutomatedTestBase
 		}
 	}
 	
-	private void testVectorBinaryPrimitive(BinType bintype, InputType type1, InputType type2)
+	private static void testVectorBinaryPrimitive(BinType bintype, InputType type1, InputType type2)
 	{
 		try {
 			//generate input data (scalar later derived if needed)

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicCompressionTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicCompressionTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicCompressionTest.java
index 2d1b592..dc6ca57 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicCompressionTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicCompressionTest.java
@@ -135,12 +135,7 @@ public class BasicCompressionTest extends AutomatedTestBase
 		runCompressionTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runCompressionTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runCompressionTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicGetValueTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicGetValueTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicGetValueTest.java
index 47c9fcc..c789b0f 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicGetValueTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicGetValueTest.java
@@ -137,12 +137,7 @@ public class BasicGetValueTest extends AutomatedTestBase
 		runGetValueTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runGetValueTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runGetValueTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixAppendTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixAppendTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixAppendTest.java
index 3bd6f0c..83a1164 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixAppendTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixAppendTest.java
@@ -136,12 +136,7 @@ public class BasicMatrixAppendTest extends AutomatedTestBase
 		runMatrixAppendTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runMatrixAppendTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runMatrixAppendTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixCentralMomentTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixCentralMomentTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixCentralMomentTest.java
index b3dd43b..9ea28e5 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixCentralMomentTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixCentralMomentTest.java
@@ -138,12 +138,7 @@ public class BasicMatrixCentralMomentTest extends AutomatedTestBase
 		runMatrixAppendTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runMatrixAppendTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runMatrixAppendTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixMultChainTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixMultChainTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixMultChainTest.java
index fe46107..3a7322f 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixMultChainTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixMultChainTest.java
@@ -225,12 +225,8 @@ public class BasicMatrixMultChainTest extends AutomatedTestBase
 	public void testSparseConstDataWeightsNoCompression() {
 		runMatrixMultChainTest(SparsityType.SPARSE, ValueType.CONST, ChainType.XtwXv, false);
 	}
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runMatrixMultChainTest(SparsityType sptype, ValueType vtype, ChainType ctype, boolean compress)
+	
+	private static void runMatrixMultChainTest(SparsityType sptype, ValueType vtype, ChainType ctype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixQuantileTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixQuantileTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixQuantileTest.java
index 77fc471..1a2b697 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixQuantileTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixQuantileTest.java
@@ -135,12 +135,7 @@ public class BasicMatrixQuantileTest extends AutomatedTestBase
 		runMatrixAppendTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runMatrixAppendTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runMatrixAppendTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixTransposeSelfMultTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixTransposeSelfMultTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixTransposeSelfMultTest.java
index c00f25f..bd351b0 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixTransposeSelfMultTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixTransposeSelfMultTest.java
@@ -135,13 +135,8 @@ public class BasicMatrixTransposeSelfMultTest extends AutomatedTestBase
 	public void testSparseConstDataNoCompression() {
 		runTransposeSelfMatrixMultTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
-	
 
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runTransposeSelfMatrixMultTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runTransposeSelfMatrixMultTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixVectorMultTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixVectorMultTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixVectorMultTest.java
index 5a19f6e..537bef6 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixVectorMultTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicMatrixVectorMultTest.java
@@ -140,12 +140,7 @@ public class BasicMatrixVectorMultTest extends AutomatedTestBase
 		runMatrixVectorMultTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicScalarOperationsSparseUnsafeTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicScalarOperationsSparseUnsafeTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicScalarOperationsSparseUnsafeTest.java
index 218739b..eee2d30 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicScalarOperationsSparseUnsafeTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicScalarOperationsSparseUnsafeTest.java
@@ -138,12 +138,7 @@ public class BasicScalarOperationsSparseUnsafeTest extends AutomatedTestBase
 		runScalarOperationsTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runScalarOperationsTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runScalarOperationsTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicScalarOperationsTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicScalarOperationsTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicScalarOperationsTest.java
index ed6f25c..7a84e71 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicScalarOperationsTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicScalarOperationsTest.java
@@ -138,12 +138,7 @@ public class BasicScalarOperationsTest extends AutomatedTestBase
 		runScalarOperationsTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runScalarOperationsTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runScalarOperationsTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicTransposeSelfLeftMatrixMultTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicTransposeSelfLeftMatrixMultTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicTransposeSelfLeftMatrixMultTest.java
index eb53024..47a4e6b 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicTransposeSelfLeftMatrixMultTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicTransposeSelfLeftMatrixMultTest.java
@@ -136,12 +136,7 @@ public class BasicTransposeSelfLeftMatrixMultTest extends AutomatedTestBase
 		runTransposeSelfMatrixMultTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runTransposeSelfMatrixMultTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runTransposeSelfMatrixMultTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicUnaryAggregateTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicUnaryAggregateTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicUnaryAggregateTest.java
index 7f87219..df54964 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicUnaryAggregateTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicUnaryAggregateTest.java
@@ -1032,11 +1032,7 @@ public class BasicUnaryAggregateTest extends AutomatedTestBase
 		runUnaryAggregateTest(SparsityType.SPARSE, ValueType.CONST, AggType.MIN, false);
 	}
 	
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runUnaryAggregateTest(SparsityType sptype, ValueType vtype, AggType aggtype, boolean compress)
+	private static void runUnaryAggregateTest(SparsityType sptype, ValueType vtype, AggType aggtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicVectorMatrixMultTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicVectorMatrixMultTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicVectorMatrixMultTest.java
index 69a8016..29832f1 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicVectorMatrixMultTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/BasicVectorMatrixMultTest.java
@@ -140,12 +140,7 @@ public class BasicVectorMatrixMultTest extends AutomatedTestBase
 		runMatrixVectorMultTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/CompressedSerializationTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/CompressedSerializationTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/CompressedSerializationTest.java
index b0857a1..9afd85e 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/CompressedSerializationTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/CompressedSerializationTest.java
@@ -140,13 +140,7 @@ public class CompressedSerializationTest extends AutomatedTestBase
 		runCompressedSerializationTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runCompressedSerializationTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runCompressedSerializationTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeCompressionTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeCompressionTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeCompressionTest.java
index d90118c..35d07e2 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeCompressionTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeCompressionTest.java
@@ -136,12 +136,7 @@ public class LargeCompressionTest extends AutomatedTestBase
 		runCompressionTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runCompressionTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runCompressionTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeMatrixVectorMultTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeMatrixVectorMultTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeMatrixVectorMultTest.java
index f5a5a4b..990845b 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeMatrixVectorMultTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeMatrixVectorMultTest.java
@@ -140,12 +140,7 @@ public class LargeMatrixVectorMultTest extends AutomatedTestBase
 		runMatrixVectorMultTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeParMatrixVectorMultTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeParMatrixVectorMultTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeParMatrixVectorMultTest.java
index 4b6d033..c5f9560 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeParMatrixVectorMultTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeParMatrixVectorMultTest.java
@@ -141,12 +141,7 @@ public class LargeParMatrixVectorMultTest extends AutomatedTestBase
 		runMatrixVectorMultTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeParUnaryAggregateTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeParUnaryAggregateTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeParUnaryAggregateTest.java
index 6d2585a..a566682 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeParUnaryAggregateTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeParUnaryAggregateTest.java
@@ -1034,12 +1034,8 @@ public class LargeParUnaryAggregateTest extends AutomatedTestBase
 	public void testMinSparseConstDataNoCompression() {
 		runUnaryAggregateTest(SparsityType.SPARSE, ValueType.CONST, AggType.MIN, false);
 	}
-		
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runUnaryAggregateTest(SparsityType sptype, ValueType vtype, AggType aggtype, boolean compress)
+	
+	private static void runUnaryAggregateTest(SparsityType sptype, ValueType vtype, AggType aggtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeVectorMatrixMultTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeVectorMatrixMultTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeVectorMatrixMultTest.java
index 4da0a79..982c0c1 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeVectorMatrixMultTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/LargeVectorMatrixMultTest.java
@@ -140,12 +140,7 @@ public class LargeVectorMatrixMultTest extends AutomatedTestBase
 		runMatrixVectorMultTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParCompressionTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParCompressionTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/ParCompressionTest.java
index a7b42d7..04152cd 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParCompressionTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/ParCompressionTest.java
@@ -138,12 +138,7 @@ public class ParCompressionTest extends AutomatedTestBase
 		runCompressionTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runCompressionTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runCompressionTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParMatrixMultChainTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParMatrixMultChainTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/ParMatrixMultChainTest.java
index 4a9d4f5..993164b 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParMatrixMultChainTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/ParMatrixMultChainTest.java
@@ -216,12 +216,8 @@ public class ParMatrixMultChainTest extends AutomatedTestBase
 	public void testSparseConstDataWeightsNoCompression() {
 		runMatrixMultChainTest(SparsityType.SPARSE, ValueType.CONST, ChainType.XtwXv, false);
 	}
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runMatrixMultChainTest(SparsityType sptype, ValueType vtype, ChainType ctype, boolean compress)
+	
+	private static void runMatrixMultChainTest(SparsityType sptype, ValueType vtype, ChainType ctype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParMatrixVectorMultTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParMatrixVectorMultTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/ParMatrixVectorMultTest.java
index 30e57b4..c34216c 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParMatrixVectorMultTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/ParMatrixVectorMultTest.java
@@ -141,12 +141,7 @@ public class ParMatrixVectorMultTest extends AutomatedTestBase
 		runMatrixVectorMultTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParTransposeSelfLeftMatrixMultTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParTransposeSelfLeftMatrixMultTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/ParTransposeSelfLeftMatrixMultTest.java
index a12588a..44e18c5 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParTransposeSelfLeftMatrixMultTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/ParTransposeSelfLeftMatrixMultTest.java
@@ -137,12 +137,7 @@ public class ParTransposeSelfLeftMatrixMultTest extends AutomatedTestBase
 		runTransposeSelfMatrixMultTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runTransposeSelfMatrixMultTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runTransposeSelfMatrixMultTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParUnaryAggregateTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParUnaryAggregateTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/ParUnaryAggregateTest.java
index ebc1159..b883c21 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParUnaryAggregateTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/ParUnaryAggregateTest.java
@@ -1033,12 +1033,8 @@ public class ParUnaryAggregateTest extends AutomatedTestBase
 	public void testMinSparseConstDataNoCompression() {
 		runUnaryAggregateTest(SparsityType.SPARSE, ValueType.CONST, AggType.MIN, false);
 	}
-		
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runUnaryAggregateTest(SparsityType sptype, ValueType vtype, AggType aggtype, boolean compress)
+	
+	private static void runUnaryAggregateTest(SparsityType sptype, ValueType vtype, AggType aggtype, boolean compress)
 	{
 		try
 		{

http://git-wip-us.apache.org/repos/asf/systemml/blob/e106966a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParVectorMatrixMultTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParVectorMatrixMultTest.java b/src/test/java/org/apache/sysml/test/integration/functions/compress/ParVectorMatrixMultTest.java
index 5281404..1fee256 100644
--- a/src/test/java/org/apache/sysml/test/integration/functions/compress/ParVectorMatrixMultTest.java
+++ b/src/test/java/org/apache/sysml/test/integration/functions/compress/ParVectorMatrixMultTest.java
@@ -140,12 +140,7 @@ public class ParVectorMatrixMultTest extends AutomatedTestBase
 		runMatrixVectorMultTest(SparsityType.SPARSE, ValueType.CONST, false);
 	}
 	
-
-	/**
-	 * 
-	 * @param mb
-	 */
-	private void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
+	private static void runMatrixVectorMultTest(SparsityType sptype, ValueType vtype, boolean compress)
 	{
 		try
 		{