You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@systemml.apache.org by de...@apache.org on 2016/11/09 23:35:44 UTC

[1/2] incubator-systemml git commit: [SYSTEMML-842] Javadoc cleanup in lops package

Repository: incubator-systemml
Updated Branches:
  refs/heads/master 082a743db -> c96ed96af


http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/compile/Dag.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/compile/Dag.java b/src/main/java/org/apache/sysml/lops/compile/Dag.java
index ecf7346..5a15c9f 100644
--- a/src/main/java/org/apache/sysml/lops/compile/Dag.java
+++ b/src/main/java/org/apache/sysml/lops/compile/Dag.java
@@ -182,10 +182,6 @@ public class Dag<N extends Lop>
 		}		
 	}
 	
-	
-	/**
-	 * Constructor
-	 */
 	public Dag() 
 	{
 		//allocate internal data structures
@@ -224,7 +220,7 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to add a node to the DAG.
 	 * 
-	 * @param node
+	 * @param node low-level operator
 	 * @return true if node was not already present, false if not.
 	 */
 
@@ -235,14 +231,6 @@ public class Dag<N extends Lop>
 		return true;
 	}
 	
-	/**
-	 * 
-	 * @param config
-	 * @return
-	 * @throws LopsException
-	 * @throws IOException
-	 * @throws DMLRuntimeException
-	 */
 	public ArrayList<Instruction> getJobs(DMLConfig config)
 			throws LopsException, IOException, DMLRuntimeException 
 	{
@@ -252,11 +240,13 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to compile a dag generically
 	 * 
-	 * @param config
-	 * @throws LopsException
-	 * @throws DMLRuntimeException
+	 * @param sb statement block
+	 * @param config dml configuration
+	 * @return list of instructions
+	 * @throws LopsException if LopsException occurs
+	 * @throws IOException if IOException occurs
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
 	 */
-
 	public ArrayList<Instruction> getJobs(StatementBlock sb, DMLConfig config)
 			throws LopsException, IOException, DMLRuntimeException {
 		
@@ -443,11 +433,11 @@ public class Dag<N extends Lop>
 
 	/**
 	 * Function that determines if the two input nodes can be executed together 
-	 * in at least on job.
+	 * in at least one job.
 	 * 
-	 * @param node1
-	 * @param node2
-	 * @return
+	 * @param node1 low-level operator 1
+	 * @param node2 low-level operator 2
+	 * @return true if nodes can be executed together
 	 */
 	private static boolean isCompatible(Lop node1, Lop node2) {
 		return( (node1.getCompatibleJobs() & node2.getCompatibleJobs()) > 0);
@@ -456,9 +446,9 @@ public class Dag<N extends Lop>
 	/**
 	 * Function that checks if the given node executes in the job specified by jt.
 	 * 
-	 * @param node
-	 * @param jt
-	 * @return
+	 * @param node low-level operator
+	 * @param jt job type
+	 * @return true if node executes in the specified job type
 	 */
 	private static boolean isCompatible(Lop node, JobType jt) {
 		if ( jt == JobType.GMRCELL )
@@ -574,9 +564,10 @@ public class Dag<N extends Lop>
 	 * As some jobs only write one output, all operations in the mapper need to
 	 * be redone and cannot be marked as finished.
 	 * 
-	 * @param execNodes
-	 * @param jobNodes
-	 * @throws LopsException
+	 * @param execNodes list of exec low-level operators
+	 * @param jobNodes list of job low-level operators
+	 * @param finishedNodes list of finished low-level operators
+	 * @throws LopsException if LopsException occurs
 	 */
 	private void handleSingleOutputJobs(ArrayList<Lop> execNodes,
 			ArrayList<ArrayList<Lop>> jobNodes, ArrayList<Lop> finishedNodes)
@@ -634,7 +625,13 @@ public class Dag<N extends Lop>
 		
 	}
 
-	/** Method to check if a lop can be eliminated from checking **/
+	/**
+	 * Method to check if a lop can be eliminated from checking
+	 * 
+	 * @param node low-level operator
+	 * @param execNodes list of exec nodes
+	 * @return true if lop can be eliminated
+	 */
 	private static boolean canEliminateLop(Lop node, ArrayList<Lop> execNodes) {
 		// this function can only eliminate "aligner" lops such a group
 		if (!node.isAligner())
@@ -669,8 +666,10 @@ public class Dag<N extends Lop>
 	 * Transient reads needn't be considered here since the previous program 
 	 * block would already create appropriate entries in the symbol table.
 	 * 
-	 * @param nodes
-	 * @throws LopsException 
+	 * @param nodes_v list of nodes
+	 * @param inst list of instructions
+	 * @throws LopsException if LopsException occurs
+	 * @throws IOException if IOException occurs
 	 */
 	private static void generateInstructionsForInputVariables(ArrayList<Lop> nodes_v, ArrayList<Instruction> inst) throws LopsException, IOException {
 		for(Lop n : nodes_v) {
@@ -701,8 +700,8 @@ public class Dag<N extends Lop>
 	 * 
 	 * 2) if the exectype of write lop itself is marked MR i.e., memory estimate > memory budget.
 	 * 
-	 * @param node
-	 * @return
+	 * @param node low-level operator
+	 * @return true if lop should be sent to MR
 	 */
 	private static boolean sendWriteLopToMR(Lop node) 
 	{
@@ -734,6 +733,9 @@ public class Dag<N extends Lop>
 	 * Computes the memory footprint required to execute <code>node</code> in the mapper.
 	 * It is used only for those nodes that use inputs from distributed cache. The returned 
 	 * value is utilized in limiting the number of instructions piggybacked onto a single GMR mapper.
+	 * 
+	 * @param node low-level operator
+	 * @return memory footprint
 	 */
 	private static double computeFootprintInMapper(Lop node) {
 		// Memory limits must be checked only for nodes that use distributed cache
@@ -783,6 +785,10 @@ public class Dag<N extends Lop>
 	 * If the total estimated footprint (<code>node</code> and previously added nodes in GMR) is less than available memory on 
 	 * the mappers then <code>node</code> can be executed in current round, and <code>true</code> is returned. Otherwise, 
 	 * <code>node</code> must be queued and <code>false</code> is returned. 
+	 * 
+	 * @param node low-level operator
+	 * @param footprintInMapper mapper footprint
+	 * @return true if node can be executed in current round of jobs
 	 */
 	private static boolean checkMemoryLimits(Lop node, double footprintInMapper) {
 		boolean addNode = true;
@@ -802,9 +808,12 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to group a vector of sorted lops.
 	 * 
-	 * @param node_v
-	 * @throws LopsException
-	 * @throws DMLRuntimeException
+	 * @param sb statement block
+	 * @param node_v list of low-level operators
+	 * @return list of instructions
+	 * @throws LopsException if LopsException occurs
+	 * @throws IOException if IOException occurs
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
 	 */
 	private ArrayList<Instruction> doGreedyGrouping(StatementBlock sb, ArrayList<Lop> node_v)
 			throws LopsException, IOException, DMLRuntimeException
@@ -1266,10 +1275,10 @@ public class Dag<N extends Lop>
 	}
 
 	/**
-	 * Exclude rmvar instruction for <varname> from deleteInst, if exists
+	 * Exclude rmvar instruction for varname from deleteInst, if exists
 	 * 
-	 * @param varName
-	 * @param deleteInst
+	 * @param varName variable name
+	 * @param deleteInst list of instructions
 	 */
 	private static void excludeRemoveInstruction(String varName, ArrayList<Instruction> deleteInst) {
 		//for(Instruction inst : deleteInst) {
@@ -1286,9 +1295,10 @@ public class Dag<N extends Lop>
 	/**
 	 * Generate rmvar instructions for the inputs, if their consumer count becomes zero.
 	 * 
-	 * @param node
-	 * @param inst
-	 * @throws DMLRuntimeException
+	 * @param node low-level operator
+	 * @param inst list of instructions
+	 * @param delteInst list of instructions
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
 	 */
 	private void processConsumersForInputs(Lop node, ArrayList<Instruction> inst, ArrayList<Instruction> delteInst) throws DMLRuntimeException {
 		// reduce the consumer count for all input lops
@@ -1328,11 +1338,12 @@ public class Dag<N extends Lop>
 	 * this point, this DAG has no dependencies on the MR dag. ie. none of the
 	 * inputs are outputs of MR jobs
 	 * 
-	 * @param execNodes
-	 * @param inst
-	 * @param deleteInst
-	 * @throws LopsException
-	 * @throws DMLRuntimeException
+	 * @param execNodes list of low-level operators
+	 * @param inst list of instructions
+	 * @param writeInst list of write instructions
+	 * @param deleteInst list of delete instructions
+	 * @throws LopsException if LopsException occurs
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
 	 */
 	private void generateControlProgramJobs(ArrayList<Lop> execNodes,
 			ArrayList<Instruction> inst, ArrayList<Instruction> writeInst, ArrayList<Instruction> deleteInst) throws LopsException, DMLRuntimeException {
@@ -1638,11 +1649,12 @@ public class Dag<N extends Lop>
 	 * Method to remove all child nodes of a queued node that should be executed
 	 * in a following iteration.
 	 * 
-	 * @param node
-	 * @param finishedNodes
-	 * @param execNodes
-	 * @param queuedNodes
-	 * @throws LopsException
+	 * @param node low-level operator
+	 * @param finishedNodes list of finished nodes
+	 * @param execNodes list of exec nodes
+	 * @param queuedNodes list of queued nodes
+	 * @param jobvec list of lists of low-level operators
+	 * @throws LopsException if LopsException occurs
 	 */
 	private void removeNodesForNextIteration(Lop node, ArrayList<Lop> finishedNodes,
 			ArrayList<Lop> execNodes, ArrayList<Lop> queuedNodes,
@@ -1908,11 +1920,11 @@ public class Dag<N extends Lop>
 	 * Reduce: CAN NOT be piggybacked since it must execute before <code>node</code>
 	 * Map or MapOrReduce: CAN be piggybacked ONLY IF it is comatible w/ <code>tmpNode</code> 
 	 * 
-	 * @param tmpNode
-	 * @param node
-	 * @param execNodes
-	 * @param finishedNodes
-	 * @return
+	 * @param tmpNode temporary low-level operator
+	 * @param node low-level operator
+	 * @param execNodes list of exec nodes
+	 * @param queuedNodes list of queued nodes
+	 * @return true if tmpNode can be piggbacked on node
 	 */
 	private boolean branchCanBePiggyBackedMapAndReduce(Lop tmpNode, Lop node,
 			ArrayList<Lop> execNodes, ArrayList<Lop> queuedNodes) {
@@ -1978,10 +1990,10 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to return the job index for a lop.
 	 * 
-	 * @param lops
-	 * @param jobvec
-	 * @return
-	 * @throws LopsException
+	 * @param lops low-level operator
+	 * @param jobvec list of lists of low-level operators
+	 * @return job index for a low-level operator
+	 * @throws LopsException if LopsException occurs
 	 */
 	private static int jobType(Lop lops, ArrayList<ArrayList<Lop>> jobvec) throws LopsException {
 		for ( JobType jt : JobType.values()) {
@@ -1997,10 +2009,10 @@ public class Dag<N extends Lop>
 	 * Method to see if there is a node of type MapAndReduce between tmpNode and node
 	 * in given node collection
 	 * 
-	 * @param tmpNode
-	 * @param nodeList
-	 * @param node
-	 * @return
+	 * @param tmpNode temporary low-level operator
+	 * @param nodeList list of low-level operators
+	 * @param node low-level operator
+	 * @return true if MapAndReduce node between tmpNode and node in nodeList
 	 */
 	private boolean hasOtherMapAndReduceParentNode(Lop tmpNode,
 			ArrayList<Lop> nodeList, Lop node) {
@@ -2023,10 +2035,10 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to check if there is a queued node that is a parent of both tmpNode and node
 	 * 
-	 * @param tmpNode
-	 * @param queuedNodes
-	 * @param node
-	 * @return
+	 * @param tmpNode temporary low-level operator
+	 * @param queuedNodes list of queued nodes
+	 * @param node low-level operator
+	 * @return true if there is a queued node that is a parent of tmpNode and node
 	 */
 	private boolean hasOtherQueuedParentNode(Lop tmpNode, ArrayList<Lop> queuedNodes, Lop node) {
 		if ( queuedNodes.isEmpty() )
@@ -2049,8 +2061,8 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to print the lops grouped by job type
 	 * 
-	 * @param jobNodes
-	 * @throws DMLRuntimeException
+	 * @param jobNodes list of lists of low-level operators
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
 	 */
 	private static void printJobNodes(ArrayList<ArrayList<Lop>> jobNodes)
 		throws DMLRuntimeException 
@@ -2075,9 +2087,9 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to check if there exists any lops with ExecLocation=RecordReader
 	 * 
-	 * @param nodes
-	 * @param loc
-	 * @return
+	 * @param nodes list of low-level operators
+	 * @param loc exec location
+	 * @return true if there is a node with RecordReader exec location
 	 */
 	private static boolean hasANode(ArrayList<Lop> nodes, ExecLocation loc) {
 		for ( Lop n : nodes ) {
@@ -2139,12 +2151,13 @@ public class Dag<N extends Lop>
 	 * sub-types and then invokes the appropriate method to generate
 	 * instructions.
 	 * 
-	 * @param execNodes
-	 * @param inst
-	 * @param deleteinst
-	 * @param jobNodes
-	 * @throws LopsException
-	 * @throws DMLRuntimeException
+	 * @param execNodes list of exec nodes
+	 * @param inst list of instructions
+	 * @param writeinst list of write instructions
+	 * @param deleteinst list of delete instructions
+	 * @param jobNodes list of list of low-level operators
+	 * @throws LopsException if LopsException occurs
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
 	 */
 	private void generateMRJobs(ArrayList<Lop> execNodes,
 			ArrayList<Instruction> inst,
@@ -2224,9 +2237,9 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to add all parents of "node" in exec_n to node_v.
 	 * 
-	 * @param node
-	 * @param node_v
-	 * @param exec_n
+	 * @param node low-level operator
+	 * @param node_v list of nodes
+	 * @param exec_n list of nodes
 	 */
 	private void addParents(Lop node, ArrayList<Lop> node_v, ArrayList<Lop> exec_n) {
 		for (Lop enode : exec_n ) {
@@ -2243,9 +2256,9 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to add all relevant data nodes for set of exec nodes.
 	 * 
-	 * @param node
-	 * @param node_v
-	 * @param exec_n
+	 * @param node low-level operator
+	 * @param node_v list of nodes
+	 * @param exec_n list of nodes
 	 */
 	private static void addChildren(Lop node, ArrayList<Lop> node_v, ArrayList<Lop> exec_n) {
 
@@ -2272,9 +2285,10 @@ public class Dag<N extends Lop>
 	/**
 	 * Method that determines the output format for a given node.
 	 * 
-	 * @param node
-	 * @return
-	 * @throws LopsException 
+	 * @param node low-level operator
+	 * @param cellModeOverride override mode
+	 * @return output info
+	 * @throws LopsException if LopsException occurs
 	 */
 	private static OutputInfo getOutputInfo(Lop node, boolean cellModeOverride) 
 		throws LopsException 
@@ -2363,8 +2377,14 @@ public class Dag<N extends Lop>
 
 	/**
 	 * Method to setup output filenames and outputInfos, and to generate related instructions
-	 * @throws DMLRuntimeException 
-	 * @throws LopsException 
+	 * 
+	 * @param node low-level operator
+	 * @param et exec type
+	 * @param cellModeOverride override mode
+	 * @param copyTWrite ?
+	 * @return node output
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
+	 * @throws LopsException if LopsException occurs
 	 */
 	private NodeOutput setupNodeOutputs(Lop node, ExecType et, boolean cellModeOverride, boolean copyTWrite) 
 	throws DMLRuntimeException, LopsException {
@@ -2817,12 +2837,14 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to generate MapReduce job instructions from a given set of nodes.
 	 * 
-	 * @param execNodes
-	 * @param inst
-	 * @param deleteinst
-	 * @param jobType
-	 * @throws LopsException
-	 * @throws DMLRuntimeException
+	 * @param execNodes list of exec nodes
+	 * @param inst list of instructions
+	 * @param writeinst list of write instructions
+	 * @param deleteinst list of delete instructions
+	 * @param rmvarinst list of rmvar instructions
+	 * @param jt job type
+	 * @throws LopsException if LopsException occurs
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
 	 */
 	private void generateMapReduceInstructions(ArrayList<Lop> execNodes,
 			ArrayList<Instruction> inst, ArrayList<Instruction> writeinst, ArrayList<Instruction> deleteinst, ArrayList<Instruction> rmvarinst, 
@@ -3070,10 +3092,10 @@ public class Dag<N extends Lop>
 	}
 
 	/**
-	 * converts an array list into a comma separated string
+	 * converts an array list into a Lop.INSTRUCTION_DELIMITOR separated string
 	 * 
-	 * @param inputStrings
-	 * @return
+	 * @param inputStrings list of input strings
+	 * @return Lop.INSTRUCTION_DELIMITOR separated string
 	 */
 	private static String getCSVString(ArrayList<String> inputStrings) {
 		StringBuilder sb = new StringBuilder();
@@ -3090,16 +3112,18 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to populate aggregate and other instructions in reducer.
 	 * 
-	 * @param node
-	 * @param execNodes
-	 * @param aggInstructionsReducer
-	 * @param otherInstructionsReducer
-	 * @param nodeIndexMapping
-	 * @param start_index
-	 * @param inputLabels
-	 * @param MRJoblineNumbers
-	 * @return
-	 * @throws LopsException
+	 * @param node low-level operator
+	 * @param execNodes list of exec nodes
+	 * @param shuffleInstructions list of shuffle instructions
+	 * @param aggInstructionsReducer ?
+	 * @param otherInstructionsReducer ?
+	 * @param nodeIndexMapping node index mapping
+	 * @param start_index start index
+	 * @param inputLabels list of input labels
+	 * @param inputLops list of input lops
+	 * @param MRJobLineNumbers MR job line numbers
+	 * @return -1 if problem
+	 * @throws LopsException if LopsException occurs
 	 */
 	private int getAggAndOtherInstructions(Lop node, ArrayList<Lop> execNodes,
 			ArrayList<String> shuffleInstructions,
@@ -3350,16 +3374,17 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to get record reader instructions for a MR job.
 	 * 
-	 * @param node
-	 * @param execNodes
-	 * @param inputStrings
-	 * @param recordReaderInstructions
-	 * @param nodeIndexMapping
-	 * @param start_index
-	 * @param inputLabels
-	 * @param MRJobLineNumbers
-	 * @return
-	 * @throws LopsException
+	 * @param node low-level operator
+	 * @param execNodes list of exec nodes
+	 * @param inputStrings list of input strings
+	 * @param recordReaderInstructions list of record reader instructions
+	 * @param nodeIndexMapping node index mapping
+	 * @param start_index start index
+	 * @param inputLabels list of input labels
+	 * @param inputLops list of input lops
+	 * @param MRJobLineNumbers MR job line numbers
+	 * @return -1 if problem
+	 * @throws LopsException if LopsException occurs
 	 */
 	private static int getRecordReaderInstructions(Lop node, ArrayList<Lop> execNodes,
 			ArrayList<String> inputStrings,
@@ -3451,16 +3476,16 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to get mapper instructions for a MR job.
 	 * 
-	 * @param node
-	 * @param execNodes
-	 * @param inputStrings
-	 * @param instructionsInMapper
-	 * @param nodeIndexMapping
-	 * @param start_index
-	 * @param inputLabels
-	 * @param MRJoblineNumbers
-	 * @return
-	 * @throws LopsException
+	 * @param node low-level operator
+	 * @param execNodes list of exec nodes
+	 * @param inputStrings list of input strings
+	 * @param instructionsInMapper list of instructions in mapper
+	 * @param nodeIndexMapping ?
+	 * @param start_index starting index
+	 * @param inputLabels input labels
+	 * @param MRJoblineNumbers MR job line numbers
+	 * @return -1 if problem
+	 * @throws LopsException if LopsException occurs
 	 */
 	private int getMapperInstructions(Lop node, ArrayList<Lop> execNodes,
 			ArrayList<String> inputStrings,
@@ -3717,8 +3742,9 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to find all terminal nodes.
 	 * 
-	 * @param execNodes
-	 * @param rootNodes
+	 * @param execNodes list of exec nodes
+	 * @param rootNodes list of root nodes
+	 * @param jt job type
 	 */
 	private static void getOutputNodes(ArrayList<Lop> execNodes, ArrayList<Lop> rootNodes, JobType jt) {
 		for ( Lop node : execNodes ) {
@@ -3755,8 +3781,10 @@ public class Dag<N extends Lop>
 	/**
 	 * check to see if a is the child of b (i.e., there is a directed path from a to b)
 	 * 
-	 * @param a
-	 * @param b
+	 * @param a child lop
+	 * @param b parent lop
+	 * @param IDMap id map
+	 * @return true if a child of b
 	 */
 	private static boolean isChild(Lop a, Lop b, HashMap<Long, Integer> IDMap) {
 		int bID = IDMap.get(b.getID());
@@ -3766,7 +3794,7 @@ public class Dag<N extends Lop>
 	/**
 	 * Method to topologically sort lops
 	 * 
-	 * @param v
+	 * @param v list of lops
 	 */
 	@SuppressWarnings({ "unchecked", "rawtypes" })
 	private void doTopologicalSort_strict_order(ArrayList<Lop> v) {
@@ -3835,8 +3863,8 @@ public class Dag<N extends Lop>
 	 * Method to perform depth-first traversal from a given node in the DAG.
 	 * Store the reachability information in marked[] boolean array.
 	 * 
-	 * @param root
-	 * @param marked
+	 * @param root low-level operator
+	 * @param marked reachability results
 	 */
 	private void dagDFS(Lop root, boolean[] marked) {
 		//contains check currently required for globalopt, will be removed when cleaned up

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/compile/LopComparator.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/compile/LopComparator.java b/src/main/java/org/apache/sysml/lops/compile/LopComparator.java
index 74130a7..2ab0edb 100644
--- a/src/main/java/org/apache/sysml/lops/compile/LopComparator.java
+++ b/src/main/java/org/apache/sysml/lops/compile/LopComparator.java
@@ -39,7 +39,7 @@ import org.apache.sysml.lops.Lop;
  * 
  * compare() method is designed to respect the above two requirements.
  *  
- * @param <N>
+ * @param <N> class extending Lop
  */
 public class LopComparator<N extends Lop>
 		implements Comparator<N> 

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/runtime/RunMRJobs.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/runtime/RunMRJobs.java b/src/main/java/org/apache/sysml/lops/runtime/RunMRJobs.java
index 519d5ff..71de7c8 100644
--- a/src/main/java/org/apache/sysml/lops/runtime/RunMRJobs.java
+++ b/src/main/java/org/apache/sysml/lops/runtime/RunMRJobs.java
@@ -84,13 +84,13 @@ public class RunMRJobs
 	 * required. 
 	 * 
 	 * Furthermore, this wrapper also provides a hook for runtime piggybacking to intercept
-	 * concurrent job submissions in order to collect and merge instructions.   
+	 * concurrent job submissions in order to collect and merge instructions.
 	 * 
-	 * @param inst
-	 * @param ec
-	 * @return
+	 * @param inst instruction
+	 * @param ec execution context
+	 * @return job status
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
 	 */
-
 	public static JobReturn prepareAndSubmitJob( MRJobInstruction inst, ExecutionContext ec )
 		throws DMLRuntimeException 
 	{
@@ -155,10 +155,9 @@ public class RunMRJobs
 	/**
 	 * Submits an MR job instruction, without modifying any state of that instruction.
 	 * 
-	 * @param inst
-	 * @param ec
-	 * @return
-	 * @throws DMLRuntimeException
+	 * @param inst instruction
+	 * @return job status
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
 	 */
 	public static JobReturn submitJob(MRJobInstruction inst ) 
 		throws DMLRuntimeException 
@@ -379,13 +378,6 @@ public class RunMRJobs
 		throw new DMLRuntimeException("Unexpected Job Type: " + inst.getJobType());
 	}
 
-	/**
-	 * 
-	 * @param inst
-	 * @param inputMatrices
-	 * @param pb
-	 * @throws DMLRuntimeException
-	 */
 	private static void checkEmptyInputs( MRJobInstruction inst, MatrixObject[] inputMatrices ) 
 		throws DMLRuntimeException
 	{
@@ -409,11 +401,11 @@ public class RunMRJobs
 	 * (e.g., ##mVar2## or ##Var5##). The replacement is a HDFS filename for matrix 
 	 * variables, and is the actual value (stored in symbol table) for scalar variables.
 	 * 
-	 * @param inst
-	 * @param varName
-	 * @param map
-	 * @return
-	 * @throws DMLRuntimeException
+	 * @param inst instruction
+	 * @param varName variable name
+	 * @param map local variable map
+	 * @return string variable name
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
 	 */
 	private static String getVarNameReplacement(String inst, String varName, LocalVariableMap map) throws DMLRuntimeException {
 		Data val = map.get(varName);
@@ -435,10 +427,10 @@ public class RunMRJobs
 	/** 
 	 * Replaces ALL placeholder strings (such as ##mVar2## and ##Var5##) in a single instruction.
 	 *  
-	 * @param inst
-	 * @param map
-	 * @return
-	 * @throws DMLRuntimeException
+	 * @param inst string instruction
+	 * @param map local variable map
+	 * @return string instruction after replacement
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
 	 */
 	private static String updateInstLabels(String inst, LocalVariableMap map) throws DMLRuntimeException {
 		if ( inst.contains(Lop.VARIABLE_NAME_PLACEHOLDER) ) {
@@ -457,10 +449,10 @@ public class RunMRJobs
 	 * Takes a delimited string of instructions, and replaces ALL placeholder labels 
 	 * (such as ##mVar2## and ##Var5##) in ALL instructions.
 	 *  
-	 * @param instList
-	 * @param labelValueMapping
-	 * @return
-	 * @throws DMLRuntimeException
+	 * @param instList instruction list as string
+	 * @param labelValueMapping local variable map
+	 * @return instruction list after replacement
+	 * @throws DMLRuntimeException if DMLRuntimeException occurs
 	 */
 	public static String updateLabels (String instList, LocalVariableMap labelValueMapping) throws DMLRuntimeException {
 
@@ -480,12 +472,6 @@ public class RunMRJobs
 	}
 
 	
-	/**
-	 * 
-	 * @param inputMatrices
-	 * @return
-	 * @throws DMLRuntimeException
-	 */
 	private static long[] getNNZ( MatrixObject[] inputMatrices ) 
 		throws DMLRuntimeException
 	{
@@ -503,15 +489,6 @@ public class RunMRJobs
 		return ret;
 	}
 	
-	/**
-	 * 
-	 * @param inst
-	 * @param shuffleInst
-	 * @param inputMatrices
-	 * @param outputMatrices
-	 * @return
-	 * @throws DMLRuntimeException
-	 */
 	private static JobReturn executeInMemoryReblockOperations( MRJobInstruction inst, String shuffleInst, MatrixObject[] inputMatrices, MatrixObject[] outputMatrices ) 
 		throws DMLRuntimeException
 	{


[2/2] incubator-systemml git commit: [SYSTEMML-842] Javadoc cleanup in lops package

Posted by de...@apache.org.
[SYSTEMML-842] Javadoc cleanup in lops package

Remove blank comments.
Fix broken comments.


Project: http://git-wip-us.apache.org/repos/asf/incubator-systemml/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-systemml/commit/c96ed96a
Tree: http://git-wip-us.apache.org/repos/asf/incubator-systemml/tree/c96ed96a
Diff: http://git-wip-us.apache.org/repos/asf/incubator-systemml/diff/c96ed96a

Branch: refs/heads/master
Commit: c96ed96af568e6ea9a5d800923b6932459325d03
Parents: 082a743
Author: Deron Eriksson <de...@us.ibm.com>
Authored: Wed Nov 9 15:23:08 2016 -0800
Committer: Deron Eriksson <de...@us.ibm.com>
Committed: Wed Nov 9 15:23:08 2016 -0800

----------------------------------------------------------------------
 .../java/org/apache/sysml/lops/Aggregate.java   |  14 +-
 src/main/java/org/apache/sysml/lops/Binary.java |  11 +-
 .../java/org/apache/sysml/lops/BinaryM.java     |  16 +-
 .../org/apache/sysml/lops/BinaryScalar.java     |  21 +-
 .../org/apache/sysml/lops/BinaryUAggChain.java  |  15 +-
 .../org/apache/sysml/lops/CentralMoment.java    |   6 +-
 .../java/org/apache/sysml/lops/Checkpoint.java  |  23 +-
 .../java/org/apache/sysml/lops/CoVariance.java  |  21 +-
 .../org/apache/sysml/lops/CombineBinary.java    |   8 +-
 .../org/apache/sysml/lops/CombineUnary.java     |   9 +-
 .../java/org/apache/sysml/lops/Compression.java |  13 -
 .../apache/sysml/lops/ConvolutionTransform.java |  12 +-
 .../sysml/lops/CumulativeOffsetBinary.java      |  17 --
 .../sysml/lops/CumulativePartialAggregate.java  |  16 -
 .../sysml/lops/CumulativeSplitAggregate.java    |  11 -
 src/main/java/org/apache/sysml/lops/Data.java   |  53 ++--
 .../java/org/apache/sysml/lops/DataGen.java     |  50 ++--
 .../org/apache/sysml/lops/FunctionCallCP.java   |   4 -
 src/main/java/org/apache/sysml/lops/Group.java  |   8 +-
 .../org/apache/sysml/lops/GroupedAggregate.java |  15 +-
 .../apache/sysml/lops/GroupedAggregateM.java    |   7 -
 .../java/org/apache/sysml/lops/LeftIndex.java   |  14 +-
 src/main/java/org/apache/sysml/lops/Lop.java    | 209 ++++++++++---
 src/main/java/org/apache/sysml/lops/MMCJ.java   |  20 +-
 src/main/java/org/apache/sysml/lops/MMRJ.java   |   9 +-
 src/main/java/org/apache/sysml/lops/MMZip.java  |   5 -
 .../java/org/apache/sysml/lops/MapMult.java     |  32 +-
 .../org/apache/sysml/lops/MapMultChain.java     |  30 +-
 src/main/java/org/apache/sysml/lops/PMMJ.java   |  18 +-
 .../java/org/apache/sysml/lops/PMapMult.java    |  12 -
 .../apache/sysml/lops/ParameterizedBuiltin.java |  21 +-
 .../org/apache/sysml/lops/PartialAggregate.java |  19 +-
 .../apache/sysml/lops/RangeBasedReIndex.java    |  11 +-
 .../java/org/apache/sysml/lops/ReBlock.java     |   6 -
 src/main/java/org/apache/sysml/lops/RepMat.java |  12 +-
 .../java/org/apache/sysml/lops/Ternary.java     |  12 +-
 .../org/apache/sysml/lops/TernaryAggregate.java |  12 +-
 .../java/org/apache/sysml/lops/Transform.java   |  11 +-
 .../org/apache/sysml/lops/UAggOuterChain.java   |  15 +-
 src/main/java/org/apache/sysml/lops/Unary.java  |  37 +--
 .../java/org/apache/sysml/lops/UnaryCP.java     |   7 +-
 .../apache/sysml/lops/WeightedCrossEntropy.java |   7 -
 .../sysml/lops/WeightedCrossEntropyR.java       |   8 -
 .../org/apache/sysml/lops/WeightedDivMM.java    |   7 -
 .../org/apache/sysml/lops/WeightedDivMMR.java   |   8 -
 .../org/apache/sysml/lops/WeightedSigmoid.java  |   7 -
 .../org/apache/sysml/lops/WeightedSigmoidR.java |   8 -
 .../apache/sysml/lops/WeightedSquaredLoss.java  |   7 -
 .../apache/sysml/lops/WeightedSquaredLossR.java |   8 -
 .../org/apache/sysml/lops/WeightedUnaryMM.java  |   7 -
 .../org/apache/sysml/lops/WeightedUnaryMMR.java |   8 -
 .../java/org/apache/sysml/lops/compile/Dag.java | 300 ++++++++++---------
 .../sysml/lops/compile/LopComparator.java       |   2 +-
 .../apache/sysml/lops/runtime/RunMRJobs.java    |  65 ++--
 54 files changed, 617 insertions(+), 687 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/Aggregate.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/Aggregate.java b/src/main/java/org/apache/sysml/lops/Aggregate.java
index fc229a0..b1e63cd 100644
--- a/src/main/java/org/apache/sysml/lops/Aggregate.java
+++ b/src/main/java/org/apache/sysml/lops/Aggregate.java
@@ -46,8 +46,10 @@ public class Aggregate extends Lop
 	private CorrectionLocationType correctionLocation = CorrectionLocationType.INVALID;
 
 	/**
-	 * @param input - input lop
-	 * @param op - operation type
+	 * @param input input lop
+	 * @param op operation type
+	 * @param dt data type
+	 * @param vt value type
 	 */
 	public Aggregate(Lop input, Aggregate.OperationTypes op, DataType dt, ValueType vt ) {
 		super(Lop.Type.Aggregate, dt, vt);
@@ -90,10 +92,6 @@ public class Aggregate extends Lop
 		}
 	}
 	
-	/**
-	 * for debugging purposes. 
-	 */
-	
 	public String toString()
 	{
 		return "Operation: " + operation;		
@@ -101,9 +99,9 @@ public class Aggregate extends Lop
 
 	/**
 	 * method to get operation type
-	 * @return
+	 * 
+	 * @return operator type
 	 */
-	 
 	public OperationTypes getOperationType()
 	{
 		return operation;

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/Binary.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/Binary.java b/src/main/java/org/apache/sysml/lops/Binary.java
index bae7dee..89c1f47 100644
--- a/src/main/java/org/apache/sysml/lops/Binary.java
+++ b/src/main/java/org/apache/sysml/lops/Binary.java
@@ -46,8 +46,13 @@ public class Binary extends Lop
 	
 	/**
 	 * Constructor to perform a binary operation.
-	 * @param input
-	 * @param op
+	 * 
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param op operation type
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et exec type
 	 */
 	public Binary(Lop input1, Lop input2, OperationTypes op, DataType dt, ValueType vt, ExecType et) {
 		this(input1, input2, op, dt, vt, et, 1);
@@ -100,7 +105,7 @@ public class Binary extends Lop
 
 	/**
 	 * method to get operation type
-	 * @return
+	 * @return operation type
 	 */
 	 
 	public OperationTypes getOperationType()

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/BinaryM.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/BinaryM.java b/src/main/java/org/apache/sysml/lops/BinaryM.java
index a911e5c..f6a29cb 100644
--- a/src/main/java/org/apache/sysml/lops/BinaryM.java
+++ b/src/main/java/org/apache/sysml/lops/BinaryM.java
@@ -50,11 +50,17 @@ public class BinaryM extends Lop
 	
 	/**
 	 * Constructor to perform a binary operation.
-	 * @param input
-	 * @param op
-	 * @throws DMLRuntimeException 
+	 * 
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param op operation type
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et exec type
+	 * @param partitioned true if partitioned
+	 * @param colVector true if colVector
+	 * @throws LopsException if LopsException occurs
 	 */
-
 	public BinaryM(Lop input1, Lop input2, OperationTypes op, DataType dt, ValueType vt, ExecType et, boolean partitioned, boolean colVector ) throws LopsException {
 		super(Lop.Type.Binary, dt, vt);
 		
@@ -93,7 +99,7 @@ public class BinaryM extends Lop
 
 	/**
 	 * method to get operation type
-	 * @return
+	 * @return operation type
 	 */
 	 
 	public OperationTypes getOperationType()

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/BinaryScalar.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/BinaryScalar.java b/src/main/java/org/apache/sysml/lops/BinaryScalar.java
index f61c145..c6aa86b 100644
--- a/src/main/java/org/apache/sysml/lops/BinaryScalar.java
+++ b/src/main/java/org/apache/sysml/lops/BinaryScalar.java
@@ -47,6 +47,13 @@ public class BinaryScalar extends Lop
 
 	/**
 	 * This overloaded constructor is used for setting exec type in case of spark backend
+	 * 
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param op operation type
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et exec type
 	 */
 	public BinaryScalar(Lop input1, Lop input2, OperationTypes op, DataType dt, ValueType vt, ExecType et) 
 	{
@@ -66,10 +73,13 @@ public class BinaryScalar extends Lop
 	
 	/**
 	 * Constructor to perform a scalar operation
-	 * @param input
-	 * @param op
+	 * 
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param op operation type
+	 * @param dt data type
+	 * @param vt value type
 	 */
-
 	public BinaryScalar(Lop input1, Lop input2, OperationTypes op, DataType dt, ValueType vt) 
 	{
 		super(Lop.Type.BinaryCP, dt, vt);		
@@ -131,11 +141,6 @@ public class BinaryScalar extends Lop
 		}
 	}
 	
-	/**
-	 * 
-	 * @param op
-	 * @return
-	 */
 	public static String getOpcode( OperationTypes op )
 	{
 		switch ( op ) 

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/BinaryUAggChain.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/BinaryUAggChain.java b/src/main/java/org/apache/sysml/lops/BinaryUAggChain.java
index 290d8e4..eebb3b8 100644
--- a/src/main/java/org/apache/sysml/lops/BinaryUAggChain.java
+++ b/src/main/java/org/apache/sysml/lops/BinaryUAggChain.java
@@ -41,11 +41,16 @@ public class BinaryUAggChain extends Lop
 	/**
 	 * Constructor to setup a map mult chain without weights
 	 * 
-	 * @param input
-	 * @param op
-	 * @return 
-	 * @throws LopsException
-	 */	
+	 * 
+	 * @param input1 low-level operator
+	 * @param bop binary operation type
+	 * @param uaop aggregate operation type
+	 * @param uadir partial aggregate direction type
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et execution type
+	 * @throws LopsException if LopsException occurs
+	 */
 	public BinaryUAggChain(Lop input1, Binary.OperationTypes bop, Aggregate.OperationTypes uaop, PartialAggregate.DirectionTypes uadir, DataType dt, ValueType vt, ExecType et) 
 		throws LopsException 
 	{

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/CentralMoment.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/CentralMoment.java b/src/main/java/org/apache/sysml/lops/CentralMoment.java
index ef000e7..881e5dc 100644
--- a/src/main/java/org/apache/sysml/lops/CentralMoment.java
+++ b/src/main/java/org/apache/sysml/lops/CentralMoment.java
@@ -35,8 +35,12 @@ public class CentralMoment extends Lop
 	 * Constructor to perform central moment.
 	 * input1 <- data (weighted or unweighted)
 	 * input2 <- order (integer: 0, 2, 3, or 4)
+	 * 
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param input3 low-level operator 3
+	 * @param et execution type
 	 */
-
 	private void init(Lop input1, Lop input2, Lop input3, ExecType et) {
 		this.addInput(input1);
 		this.addInput(input2);

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/Checkpoint.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/Checkpoint.java b/src/main/java/org/apache/sysml/lops/Checkpoint.java
index dd82b20..aca91b1 100644
--- a/src/main/java/org/apache/sysml/lops/Checkpoint.java
+++ b/src/main/java/org/apache/sysml/lops/Checkpoint.java
@@ -54,12 +54,11 @@ public class Checkpoint extends Lop
 	 * TODO change string parameter storage.level to StorageLevel as soon as we can assume
 	 * that Spark libraries are always available.
 	 * 
-	 * @param input
-	 * @param dt
-	 * @param vt
-	 * @param level
-	 * @param et
-	 * @throws LopsException
+	 * @param input low-level operator
+	 * @param dt data type
+	 * @param vt value type
+	 * @param level storage level
+	 * @throws LopsException if LopsException occurs
 	 */
 	public Checkpoint(Lop input, DataType dt, ValueType vt, String level) 
 		throws LopsException
@@ -121,8 +120,8 @@ public class Checkpoint extends Lop
 	 * This is a utility method because Sparks StorageLevel.toString() is incompatible with its own
 	 * fromString() method.
 	 * 
-	 * @param level
-	 * @return
+	 * @param level RDD storage level
+	 * @return storage level as a string
 	 */
 	public static String getStorageLevelString( StorageLevel level)
 	{
@@ -152,18 +151,10 @@ public class Checkpoint extends Lop
 		return "INVALID";
 	}
 	
-	/**
-	 * 
-	 * @return
-	 */
 	public static String getDefaultStorageLevelString() {
 		return getStorageLevelString( DEFAULT_STORAGE_LEVEL );
 	}
 	
-	/**
-	 * 
-	 * @return
-	 */
 	public static String getSerializeStorageLevelString() {
 		return getStorageLevelString( SER_STORAGE_LEVEL );
 	}

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/CoVariance.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/CoVariance.java b/src/main/java/org/apache/sysml/lops/CoVariance.java
index d992b5e..fe69fae 100644
--- a/src/main/java/org/apache/sysml/lops/CoVariance.java
+++ b/src/main/java/org/apache/sysml/lops/CoVariance.java
@@ -35,11 +35,14 @@ public class CoVariance extends Lop
 	
 	/**
 	 * Constructor to perform covariance.
-	 * input1 <- data 
+	 * input1 &lt;- data 
 	 * (prior to this lop, input vectors need to attached together using CombineBinary or CombineTertiary) 
-	 * @throws LopsException 
+	 * 
+	 * @param input1 low-level operator
+	 * @param dt data type
+	 * @param vt value type
+	 * @throws LopsException if LopsException occurs
 	 */
-
 	public CoVariance(Lop input1, DataType dt, ValueType vt) throws LopsException {
 		this(input1, dt, vt, ExecType.MR);
 	}
@@ -107,8 +110,8 @@ public class CoVariance extends Lop
 	
 	/**
 	 * Function two generate CP instruction to compute unweighted covariance.
-	 * input1 -> input column 1
-	 * input2 -> input column 2
+	 * input1 -&gt; input column 1
+	 * input2 -&gt; input column 2
 	 */
 	@Override
 	public String getInstructions(String input1, String input2, String output) {
@@ -131,9 +134,9 @@ public class CoVariance extends Lop
 
 	/**
 	 * Function two generate CP instruction to compute weighted covariance.
-	 * input1 -> input column 1
-	 * input2 -> input column 2
-	 * input3 -> weights
+	 * input1 -&gt; input column 1
+	 * input2 -&gt; input column 2
+	 * input3 -&gt; weights
 	 */
 	@Override
 	public String getInstructions(String input1, String input2, String input3, String output) {
@@ -159,7 +162,7 @@ public class CoVariance extends Lop
 
 	/**
 	 * Function to generate MR version of covariance instruction.
-	 * input_index -> denote the "combined" input columns and weights, 
+	 * input_index -&gt; denote the "combined" input columns and weights, 
 	 * when applicable.
 	 */
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/CombineBinary.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/CombineBinary.java b/src/main/java/org/apache/sysml/lops/CombineBinary.java
index 2df1bf9..1c98b11 100644
--- a/src/main/java/org/apache/sysml/lops/CombineBinary.java
+++ b/src/main/java/org/apache/sysml/lops/CombineBinary.java
@@ -40,10 +40,12 @@ public class CombineBinary extends Lop
 	OperationTypes operation;
 
 	/**
-	 * @param input - input lop
-	 * @param op - operation type
+	 * @param op operation type
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param dt data type
+	 * @param vt value type
 	 */
-	
 	public CombineBinary(OperationTypes op, Lop input1, Lop input2, DataType dt, ValueType vt) 
 	{
 		super(Lop.Type.CombineBinary, dt, vt);	

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/CombineUnary.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/CombineUnary.java b/src/main/java/org/apache/sysml/lops/CombineUnary.java
index a2a3677..98f0a99 100644
--- a/src/main/java/org/apache/sysml/lops/CombineUnary.java
+++ b/src/main/java/org/apache/sysml/lops/CombineUnary.java
@@ -33,14 +33,11 @@ import org.apache.sysml.parser.Expression.*;
 
 public class CombineUnary extends Lop
 {
-
-	
-
 	/**
-	 * @param input - input lop
-	 * @param op - operation type
+	 * @param input1 low-level operator 1
+	 * @param dt data type
+	 * @param vt value type
 	 */
-	
 	public CombineUnary(Lop input1, DataType dt, ValueType vt) 
 	{
 		super(Lop.Type.CombineUnary, dt, vt);	

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/Compression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/Compression.java b/src/main/java/org/apache/sysml/lops/Compression.java
index 54dc445..75feef4 100644
--- a/src/main/java/org/apache/sysml/lops/Compression.java
+++ b/src/main/java/org/apache/sysml/lops/Compression.java
@@ -25,23 +25,10 @@ import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 
-
-/**
- * 
- */
 public class Compression extends Lop 
 {
 	public static final String OPCODE = "compress"; 
 
-	/**
-	 * 
-	 * @param input
-	 * @param dt
-	 * @param vt
-	 * @param level
-	 * @param et
-	 * @throws LopsException
-	 */
 	public Compression(Lop input, DataType dt, ValueType vt, ExecType et) 
 		throws LopsException
 	{

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/ConvolutionTransform.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/ConvolutionTransform.java b/src/main/java/org/apache/sysml/lops/ConvolutionTransform.java
index 9164d36..e512982 100644
--- a/src/main/java/org/apache/sysml/lops/ConvolutionTransform.java
+++ b/src/main/java/org/apache/sysml/lops/ConvolutionTransform.java
@@ -39,10 +39,14 @@ public class ConvolutionTransform extends Lop
 	
 	/**
 	 * Constructor when we have one input.
-	 * @param input
-	 * @param op
+	 * 
+	 * @param input low-level operator
+	 * @param op convolution transform operation type
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et execution type
+	 * @param k number of threads
 	 */
-
 	public ConvolutionTransform(Lop input, ConvolutionTransform.OperationTypes op, DataType dt, ValueType vt, ExecType et, int k) 
 	{
 		super(Lop.Type.Transform, dt, vt);		
@@ -86,7 +90,7 @@ public class ConvolutionTransform extends Lop
 
 	/**
 	 * method to get operation type
-	 * @return
+	 * @return operation type
 	 */
 	 
 	public OperationTypes getOperationType()

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/CumulativeOffsetBinary.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/CumulativeOffsetBinary.java b/src/main/java/org/apache/sysml/lops/CumulativeOffsetBinary.java
index 0e8b928..9dc93b9 100644
--- a/src/main/java/org/apache/sysml/lops/CumulativeOffsetBinary.java
+++ b/src/main/java/org/apache/sysml/lops/CumulativeOffsetBinary.java
@@ -25,11 +25,6 @@ import org.apache.sysml.lops.LopProperties.ExecType;
 import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.*;
 
-
-/**
- * 
- * 
- */
 public class CumulativeOffsetBinary extends Lop 
 {
 	
@@ -59,13 +54,6 @@ public class CumulativeOffsetBinary extends Lop
 		init(data, offsets, dt, vt, et);
 	}
 	
-	/**
-	 * 
-	 * @param input
-	 * @param dt
-	 * @param vt
-	 * @param et
-	 */
 	private void init(Lop input1, Lop input2, DataType dt, ValueType vt, ExecType et) 
 	{
 		this.addInput(input1);
@@ -99,11 +87,6 @@ public class CumulativeOffsetBinary extends Lop
 		return "CumulativeOffsetBinary";
 	}
 
-	/**
-	 * 
-	 * @param op
-	 * @throws LopsException
-	 */
 	private void checkSupportedOperations(OperationTypes op) 
 		throws LopsException
 	{

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/CumulativePartialAggregate.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/CumulativePartialAggregate.java b/src/main/java/org/apache/sysml/lops/CumulativePartialAggregate.java
index 4f7cbcb..ccd25a9 100644
--- a/src/main/java/org/apache/sysml/lops/CumulativePartialAggregate.java
+++ b/src/main/java/org/apache/sysml/lops/CumulativePartialAggregate.java
@@ -25,11 +25,6 @@ import org.apache.sysml.lops.LopProperties.ExecType;
 import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.*;
 
-
-/**
- * 
- * 
- */
 public class CumulativePartialAggregate extends Lop 
 {
 	
@@ -51,13 +46,6 @@ public class CumulativePartialAggregate extends Lop
 		init(input, dt, vt, et);
 	}
 	
-	/**
-	 * 
-	 * @param input
-	 * @param dt
-	 * @param vt
-	 * @param et
-	 */
 	private void init(Lop input, DataType dt, ValueType vt, ExecType et) 
 	{
 		this.addInput(input);
@@ -90,10 +78,6 @@ public class CumulativePartialAggregate extends Lop
 		return "CumulativePartialAggregate";
 	}
 	
-	/**
-	 * 
-	 * @return
-	 */
 	private String getOpcode() 
 	{
 		switch( _op ) {

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/CumulativeSplitAggregate.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/CumulativeSplitAggregate.java b/src/main/java/org/apache/sysml/lops/CumulativeSplitAggregate.java
index c247f84..252af95 100644
--- a/src/main/java/org/apache/sysml/lops/CumulativeSplitAggregate.java
+++ b/src/main/java/org/apache/sysml/lops/CumulativeSplitAggregate.java
@@ -24,10 +24,6 @@ import org.apache.sysml.lops.LopProperties.ExecType;
 import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.*;
 
-
-/**
- * 
- */
 public class CumulativeSplitAggregate extends Lop 
 {
 
@@ -41,13 +37,6 @@ public class CumulativeSplitAggregate extends Lop
 		init(input, dt, vt, ExecType.MR);
 	}
 	
-	/**
-	 * 
-	 * @param input
-	 * @param dt
-	 * @param vt
-	 * @param et
-	 */
 	private void init(Lop input, DataType dt, ValueType vt, ExecType et) {
 		this.addInput(input);
 		input.addOutput(this);

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/Data.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/Data.java b/src/main/java/org/apache/sysml/lops/Data.java
index f21dd03..2cf125e 100644
--- a/src/main/java/org/apache/sysml/lops/Data.java
+++ b/src/main/java/org/apache/sysml/lops/Data.java
@@ -52,10 +52,10 @@ public class Data extends Lop
 	/**
 	 * Method to create literal LOPs.
 	 * 
-	 * @param vt
-	 * @param literalValue
-	 * @return
-	 * @throws LopsException
+	 * @param vt value type
+	 * @param literalValue literal value
+	 * @return literal low-level operator
+	 * @throws LopsException if LopsException occurs
 	 */
 	public static Data createLiteralLop(ValueType vt, String literalValue) throws LopsException {
 		// All literals have default format type of TEXT
@@ -67,15 +67,16 @@ public class Data extends Lop
 	 * In case of write: <code>input</code> must be provided. This will always be added as the first element in <code>input</code> array.
 	 * For literals: this function is invoked through the static method <code>createLiteralLop</code>.
 	 * 
-	 * @param op
-	 * @param input
-	 * @param inputParametersLops
-	 * @param name
-	 * @param literal
-	 * @param dt
-	 * @param vt
-	 * @param isTransient
-	 * @throws LopsException
+	 * @param op operation type
+	 * @param input low-level operator
+	 * @param inputParametersLops input lops
+	 * @param name string name
+	 * @param literal string literal
+	 * @param dt data type
+	 * @param vt value type
+	 * @param isTransient true if transient
+	 * @param fmt file format
+	 * @throws LopsException if LopsException occurs
 	 */
 	public Data(Data.OperationTypes op, Lop input, HashMap<String, Lop> 
 	inputParametersLops, String name, String literal, DataType dt, ValueType vt, boolean isTransient, FileFormatTypes fmt) throws LopsException 
@@ -178,7 +179,7 @@ public class Data extends Lop
 	 * Data-Lop-specific method to set the execution type for persistent write.
 	 * TODO: split lops into MR/CP lop. 
 	 * 
-	 * @param et
+	 * @param et execution type
 	 */
 	public void setExecType( ExecType et )
 	{
@@ -187,8 +188,8 @@ public class Data extends Lop
 	
 	/**
 	 * Method to set format types for input, output files. 
-	 * @param type
-	 * @throws LopsException 
+	 * @param type file format
+	 * @throws LopsException if LopsException occurs
 	 */
 	public void setFileFormatAndProperties(FileFormatTypes type) throws LopsException 
 	{
@@ -208,7 +209,7 @@ public class Data extends Lop
 
 	/**
 	 * method to get format type for input, output files. 
-	 * @return
+	 * @return file format
 	 */
 	public FileFormatTypes getFileFormatType() 
 	{
@@ -226,7 +227,7 @@ public class Data extends Lop
 
 	/**
 	 * method to get operation type, i.e. read/write.
-	 * @return
+	 * @return operation type
 	 */
 	 
 	public OperationTypes getOperationType()
@@ -236,7 +237,7 @@ public class Data extends Lop
 	
 	/**
 	 * method to get inputParams 
-	 * @return
+	 * @return input parameters
 	 */
 	public HashMap<String, Lop> getInputParams(){
 		return _inputParams;
@@ -256,7 +257,7 @@ public class Data extends Lop
 	
 	/**
 	 * method to check if this data lop represents a literal.
-	 * @return
+	 * @return true if data lop is a literal
 	 */
 	
 	public boolean isLiteral()
@@ -308,17 +309,13 @@ public class Data extends Lop
 	
 	/**
 	 * Method to check if this represents a transient variable.
-	 * @return
+	 * @return true if this data lop is a transient variable
 	 */
 	public boolean isTransient()
 	{
 		return transient_var;
 	}
 	
-	/**
-	 * 
-	 * @return
-	 */
 	public boolean isPersistentWrite()
 	{
 		return operation == OperationTypes.WRITE && !transient_var;
@@ -504,7 +501,7 @@ public class Data extends Lop
 	/**
 	 * Method to generate createvar instruction that updates symbol table with metadata, hdfsfile name, etc.
 	 * 
-	 * @throws LopsException 
+	 * @throws LopsException if LopsException occurs
 	 */
 	public String getInstructions() throws LopsException {
 		return getCreateVarInstructions(getOutputParameters().getFile_name(), getOutputParameters().getLabel());
@@ -584,8 +581,8 @@ public class Data extends Lop
 	 * Helper function that attaches CSV format-specific properties to createvar instruction.
 	 * The set of properties that are attached for a READ operation is different from that for a WRITE operation.
 	 * 
-	 * @return
-	 * @throws LopsException
+	 * @return instruction with csv format properties appended
+	 * @throws LopsException if LopsException occurs
 	 */
 	private String createVarCSVHelper() throws LopsException {
 		StringBuilder sb = new StringBuilder();

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/DataGen.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/DataGen.java b/src/main/java/org/apache/sysml/lops/DataGen.java
index ec8fb9c..2321b19 100644
--- a/src/main/java/org/apache/sysml/lops/DataGen.java
+++ b/src/main/java/org/apache/sysml/lops/DataGen.java
@@ -54,13 +54,15 @@ public class DataGen extends Lop
 	/**
 	 * <p>Creates a new Rand-LOP. The target identifier has to hold the dimensions of the new random object.</p>
 	 * 
+	 * @param mthd data gen method
 	 * @param id target identifier
-	 * @param inputParameterLops Lops of input parameters
+	 * @param inputParametersLops Lops of input parameters
 	 * @param baseDir base dir for runtime
 	 * @param dt Data type
 	 * @param vt Value type
-	 * @param ExecType Execution type
-	 */	
+	 * @param et Execution type
+	 * @throws LopsException if LopsException occurs
+	 */
 	public DataGen(DataGenMethod mthd, DataIdentifier id, HashMap<String, Lop> 
 				inputParametersLops, String baseDir, DataType dt, ValueType vt, ExecType et) throws LopsException 
 	{
@@ -151,9 +153,10 @@ public class DataGen extends Lop
 	
 	/**
 	 * Private method that generates CP Instruction for Rand.
-	 * @param output
-	 * @return
-	 * @throws LopsException
+	 * 
+	 * @param output output operand
+	 * @return cp instruction for rand
+	 * @throws LopsException if LopsException occurs
 	 */
 	private String getCPInstruction_Rand(String output) 
 		throws LopsException 
@@ -236,12 +239,6 @@ public class DataGen extends Lop
 		return sb.toString(); 
 	}
 
-	/**
-	 * 
-	 * @param output
-	 * @return
-	 * @throws LopsException
-	 */
 	private String getCPInstruction_SInit(String output) 
 		throws LopsException 
 	{
@@ -290,12 +287,6 @@ public class DataGen extends Lop
 		return sb.toString();
 	}
 	
-	/**
-	 * 
-	 * @param output
-	 * @return
-	 * @throws LopsException
-	 */
 	private String getCPInstruction_Sample(String output) 
 		throws LopsException
 	{
@@ -342,9 +333,10 @@ public class DataGen extends Lop
 	
 	/**
 	 * Private method that generates CP Instruction for Seq.
-	 * @param output
-	 * @return
-	 * @throws LopsException
+	 * 
+	 * @param output output operand
+	 * @return cp instruction for seq
+	 * @throws LopsException if LopsException occurs
 	 */
 	private String getCPInstruction_Seq(String output) throws LopsException {
 		if ( method != DataGenMethod.SEQ )
@@ -399,10 +391,10 @@ public class DataGen extends Lop
 	/**
 	 * Private method to generate MR instruction for Rand.
 	 * 
-	 * @param input_index
-	 * @param output_index
-	 * @return
-	 * @throws LopsException
+	 * @param inputIndex input index
+	 * @param outputIndex output index
+	 * @return mr instruction for rand
+	 * @throws LopsException if LopsException occurs
 	 */
 	private String getMRInstruction_Rand(int inputIndex, int outputIndex) 
 		throws LopsException 
@@ -478,10 +470,10 @@ public class DataGen extends Lop
 	/**
 	 * Private method to generate MR instruction for Seq.
 	 * 
-	 * @param input_index
-	 * @param output_index
-	 * @return
-	 * @throws LopsException
+	 * @param inputIndex input index
+	 * @param outputIndex output index
+	 * @return mr instruction for seq
+	 * @throws LopsException if LopsException occurs
 	 */
 	private String getMRInstruction_Seq(int inputIndex, int outputIndex) throws LopsException {
 		StringBuilder sb = new StringBuilder();

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/FunctionCallCP.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/FunctionCallCP.java b/src/main/java/org/apache/sysml/lops/FunctionCallCP.java
index cea01af..28d2f14 100644
--- a/src/main/java/org/apache/sysml/lops/FunctionCallCP.java
+++ b/src/main/java/org/apache/sysml/lops/FunctionCallCP.java
@@ -31,10 +31,6 @@ import org.apache.sysml.parser.DMLProgram;
 import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 
-
-/**
- *
- */
 public class FunctionCallCP extends Lop  
 {	
 	private String _fnamespace;

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/Group.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/Group.java b/src/main/java/org/apache/sysml/lops/Group.java
index e1a1bbc..15a470f 100644
--- a/src/main/java/org/apache/sysml/lops/Group.java
+++ b/src/main/java/org/apache/sysml/lops/Group.java
@@ -39,10 +39,12 @@ public class Group extends Lop
 	
 	/**
 	 * Constructor to create a grouping operation.
-	 * @param input
-	 * @param op
+	 * 
+	 * @param input low-level operator
+	 * @param op group operation type
+	 * @param dt data type
+	 * @param vt value type
 	 */
-
 	public Group(Lop input, Group.OperationTypes op, DataType dt, ValueType vt) 
 	{
 		super(Lop.Type.Grouping, dt, vt);		

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/GroupedAggregate.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/GroupedAggregate.java b/src/main/java/org/apache/sysml/lops/GroupedAggregate.java
index 04ea824..b1fd486 100644
--- a/src/main/java/org/apache/sysml/lops/GroupedAggregate.java
+++ b/src/main/java/org/apache/sysml/lops/GroupedAggregate.java
@@ -49,11 +49,15 @@ public class GroupedAggregate extends Lop
 
 	/**
 	 * Constructor to perform grouped aggregate.
-	 * inputParameterLops <- parameters required to compute different aggregates (hashmap)
+	 * inputParameterLops &lt;- parameters required to compute different aggregates (hashmap)
 	 *   "combinedinput" -- actual data
 	 *   "function" -- aggregate function
+	 * 
+	 * @param inputParameterLops map of input parameter lops
+	 * @param weights weights
+	 * @param dt data type
+	 * @param vt value type
 	 */
-	
 	public GroupedAggregate(
 			HashMap<String, Lop> inputParameterLops, boolean weights,
 			DataType dt, ValueType vt) {		
@@ -84,13 +88,6 @@ public class GroupedAggregate extends Lop
 		_numThreads = k;
 	}
 	
-	/**
-	 * 
-	 * @param inputParameterLops
-	 * @param dt
-	 * @param vt
-	 * @param et
-	 */
 	private void init(HashMap<String, Lop> inputParameterLops, 
 			DataType dt, ValueType vt, ExecType et) {
 		if ( et == ExecType.MR ) {

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/GroupedAggregateM.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/GroupedAggregateM.java b/src/main/java/org/apache/sysml/lops/GroupedAggregateM.java
index 2d73abc..a8f9cf2 100644
--- a/src/main/java/org/apache/sysml/lops/GroupedAggregateM.java
+++ b/src/main/java/org/apache/sysml/lops/GroupedAggregateM.java
@@ -53,13 +53,6 @@ public class GroupedAggregateM extends Lop
 		_cacheType = partitioned ? CacheType.RIGHT_PART : CacheType.RIGHT;
 	}
 
-	/**
-	 * 
-	 * @param inputParameterLops
-	 * @param dt
-	 * @param vt
-	 * @param et
-	 */
 	private void init(HashMap<String, Lop> inputParameterLops, 
 			DataType dt, ValueType vt, ExecType et) 
 	{

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/LeftIndex.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/LeftIndex.java b/src/main/java/org/apache/sysml/lops/LeftIndex.java
index 0adf769..71e4882 100644
--- a/src/main/java/org/apache/sysml/lops/LeftIndex.java
+++ b/src/main/java/org/apache/sysml/lops/LeftIndex.java
@@ -32,14 +32,16 @@ public class LeftIndex extends Lop
 	/**
 	 * Constructor to setup a LeftIndexing operation.
 	 * Example: A[i:j, k:l] = B;
-	 *      
 	 * 
-	 * @param input
-	 * @param op
-	 * @return 
-	 * @throws LopsException
+	 * @param lhsMatrix left matrix lop
+	 * @param rhsMatrix right matrix lop
+	 * @param rowL row lower lop
+	 * @param rowU row upper lop
+	 * @param colL column lower lop
+	 * @param colU column upper lop
+	 * @param et execution type
+	 * @throws LopsException if LopsException occurs
 	 */
-	
 	private void init(Lop lhsMatrix, Lop rhsMatrix, Lop rowL, Lop rowU, Lop colL, Lop colU, ExecType et) throws LopsException {
 		/*
 		 * A[i:j, k:l] = B;

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/Lop.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/Lop.java b/src/main/java/org/apache/sysml/lops/Lop.java
index 412e6d4..06ec5e1 100644
--- a/src/main/java/org/apache/sysml/lops/Lop.java
+++ b/src/main/java/org/apache/sysml/lops/Lop.java
@@ -134,9 +134,10 @@ public abstract class Lop
 	/**
 	 * Constructor to be invoked by base class.
 	 * 
-	 * @param t
+	 * @param t lop type
+	 * @param dt data type
+	 * @param vt value type
 	 */
-
 	public Lop(Type t, DataType dt, ValueType vt) {
 		type = t;
 		_dataType = dt; // data type of the output produced from this LOP
@@ -150,7 +151,7 @@ public abstract class Lop
 	/**
 	 * get visit status of node
 	 * 
-	 * @return
+	 * @return visit status
 	 */
 
 	public VisitStatus getVisited() {
@@ -160,7 +161,7 @@ public abstract class Lop
 	/**
 	 * set visit status of node
 	 * 
-	 * @param visited
+	 * @param visited visit status
 	 */
 	public void setVisited(VisitStatus visited) {
 		_visited = visited;
@@ -179,7 +180,7 @@ public abstract class Lop
 	/**
 	 * get data type of the output that is produced by this lop
 	 * 
-	 * @return
+	 * @return data type
 	 */
 
 	public DataType getDataType() {
@@ -189,7 +190,7 @@ public abstract class Lop
 	/**
 	 * set data type of the output that is produced by this lop
 	 * 
-	 * @param dt
+	 * @param dt data type
 	 */
 	public void setDataType(DataType dt) {
 		_dataType = dt;
@@ -198,7 +199,7 @@ public abstract class Lop
 	/**
 	 * get value type of the output that is produced by this lop
 	 * 
-	 * @return
+	 * @return value type
 	 */
 
 	public ValueType getValueType() {
@@ -208,7 +209,7 @@ public abstract class Lop
 	/**
 	 * set value type of the output that is produced by this lop
 	 * 
-	 * @param vt
+	 * @param vt value type
 	 */
 	public void setValueType(ValueType vt) {
 		_valueType = vt;
@@ -218,7 +219,7 @@ public abstract class Lop
 	/**
 	 * Method to get Lop type.
 	 * 
-	 * @return
+	 * @return lop type
 	 */
 
 	public Lop.Type getType() {
@@ -228,7 +229,7 @@ public abstract class Lop
 	/**
 	 * Method to get input of Lops
 	 * 
-	 * @return
+	 * @return list of input lops
 	 */
 	public ArrayList<Lop> getInputs() {
 		return inputs;
@@ -237,7 +238,7 @@ public abstract class Lop
 	/**
 	 * Method to get output of Lops
 	 * 
-	 * @return
+	 * @return list of output lops
 	 */
 
 	public ArrayList<Lop> getOutputs() {
@@ -247,7 +248,7 @@ public abstract class Lop
 	/**
 	 * Method to add input to Lop
 	 * 
-	 * @param op
+	 * @param op input lop
 	 */
 
 	public void addInput(Lop op) {
@@ -257,7 +258,7 @@ public abstract class Lop
 	/**
 	 * Method to add output to Lop
 	 * 
-	 * @param op
+	 * @param op output lop
 	 */
 
 	public void addOutput(Lop op) {
@@ -333,6 +334,8 @@ public abstract class Lop
 
 	/**
 	 * Method to return the ID of LOP
+	 * 
+	 * @return lop ID
 	 */
 	public long getID() {
 		return lps.getID();
@@ -349,7 +352,7 @@ public abstract class Lop
 	/**
 	 * Method to get the location property of LOP
 	 * 
-	 * @return
+	 * @return location
 	 */
  	public ExecLocation getExecLocation() {
 		return lps.getExecLocation();
@@ -358,7 +361,7 @@ public abstract class Lop
 	/**
 	 * Method to get the execution type (CP or MR) of LOP
 	 * 
-	 * @return
+	 * @return execution type
 	 */
  	public ExecType getExecType() {
 		return lps.getExecType();
@@ -366,7 +369,8 @@ public abstract class Lop
  
 	/**
 	 * Method to get the compatible job type for the LOP
-	 * @return
+	 * 
+	 * @return compatible job type
 	 */
 	
 	public int getCompatibleJobs() {
@@ -375,6 +379,8 @@ public abstract class Lop
 	
 	/**
 	 * Method to find if the lop breaks alignment
+	 * 
+	 * @return true if lop breaks alignment
 	 */
 	public boolean getBreaksAlignment() {
 		return lps.getBreaksAlignment();
@@ -397,7 +403,7 @@ public abstract class Lop
 	/**
 	 * Method to recursively add LOPS to a DAG
 	 * 
-	 * @param dag
+	 * @param dag lop DAG
 	 */
 	public final void addToDag(Dag<Lop> dag) 
 	{
@@ -409,29 +415,70 @@ public abstract class Lop
 	/**
 	 * Method to get output parameters
 	 * 
-	 * @return
+	 * @return output parameters
 	 */
 
 	public OutputParameters getOutputParameters() {
 		return outParams;
 	}
 	
-	/** Method should be overridden if needed **/
+	/**
+	 * Method should be overridden if needed
+	 * 
+	 * @param input1 input 1
+	 * @param input2 input 2
+	 * @param input3 input 3
+	 * @param output output
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions(String input1, String input2, String input3, String output) throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
 	
-	/** Method should be overridden if needed **/
+	/**
+	 * Method should be overridden if needed
+	 * 
+	 * @param input1 input 1
+	 * @param input2 input 2
+	 * @param input3 input 3
+	 * @param input4 input 4
+	 * @param output output
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions(String input1, String input2, String input3, String input4, String output) throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
 
-	/** Method should be overridden if needed **/
+	/**
+	 * Method should be overridden if needed
+	 * 
+	 * @param input1 input 1
+	 * @param input2 input 2
+	 * @param input3 input 3
+	 * @param input4 input 4
+	 * @param input5 input 5
+	 * @param output output
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions(String input1, String input2, String input3, String input4, String input5, String output) throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
 
-	/** Method should be overridden if needed **/
+	/** Method should be overridden if needed
+	 * 
+	 * @param input1 input 1
+	 * @param input2 input 2
+	 * @param input3 input 3
+	 * @param input4 input 4
+	 * @param input5 input 5
+	 * @param input6 input 6
+	 * @param output output
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions(String input1, String input2, String input3, String input4, String input5, String input6, String output) throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
@@ -444,52 +491,118 @@ public abstract class Lop
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass. Lop Type: " + this.getType());
 	}
 
-	/** Method should be overridden if needed **/
+	/** Method should be overridden if needed
+	 * 
+	 * @param input_index1 input index 1
+	 * @param input_index2 input index 2
+	 * @param output_index output index
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions(int input_index1, int input_index2, int output_index) throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
 
-	/** Method should be overridden if needed **/
+	/** Method should be overridden if needed
+	 * 
+	 * @param input_index1 input index 1
+	 * @param input_index2 input index 2
+	 * @param input_index3 input index 3
+	 * @param output_index output index
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions(int input_index1, int input_index2, int input_index3, int output_index) throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
 	
-	/** Method should be overridden if needed **/
+	/** Method should be overridden if needed
+	 * 
+	 * @param input_index1 input index 1
+	 * @param input_index2 input index 2
+	 * @param input_index3 input index 3
+	 * @param input_index4 input index 4
+	 * @param output_index output index
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions(int input_index1, int input_index2, int input_index3, int input_index4, int output_index) throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
 
-	/** Method should be overridden if needed **/
+	/** Method should be overridden if needed
+	 * 
+	 * @param input_index1 input index 1
+	 * @param input_index2 input index 2
+	 * @param input_index3 input index 3
+	 * @param input_index4 input index 4
+	 * @param input_index5 input index 5
+	 * @param output_index output index
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions(int input_index1, int input_index2, int input_index3, int input_index4, int input_index5, int output_index) throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
 
-	/** Method should be overridden if needed **/
+	/** Method should be overridden if needed
+	 * 
+	 * @param input1 input 1
+	 * @param input2 input 2
+	 * @param output output
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions(String input1, String input2, String output) throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
 
-	/** Method should be overridden if needed **/
+	/** Method should be overridden if needed
+	 * 
+	 * @param input1 input 1
+	 * @param output output
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions(String input1, String output) throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
 
-	/** Method should be overridden if needed **/
+	/** Method should be overridden if needed
+	 * 
+	 * @param output output
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions(String output) throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
 
-	/** Method should be overridden if needed **/
+	/** Method should be overridden if needed
+	 * 
+	 * @param inputs array of inputs
+	 * @param outputs array of outputs
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions(String[] inputs, String[] outputs) throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
 	
-	/** Method should be overridden if needed **/
+	/** Method should be overridden if needed
+	 * 
+	 * @return instructions as string
+	 * @throws LopsException if LopsException occurs
+	 */
 	public String getInstructions() throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
 
-	/** Method should be overridden if needed **/
+	/** Method should be overridden if needed
+	 * 
+	 * @return simple instruction type
+	 * @throws LopsException if LopsException occurs
+	 */
 	public SimpleInstType getSimpleInstructionType() throws LopsException {
 		throw new LopsException(this.printErrorLocation() + "Should never be invoked in Baseclass");
 	}
@@ -559,7 +672,7 @@ public abstract class Lop
 	/**
 	 * Function that determines if the output of a LOP is defined by a variable or not.
 	 * 
-	 * @return
+	 * @return true if lop output defined by a variable
 	 */
 	public boolean isVariable() {
 		return ( (getExecLocation() == ExecLocation.Data && !((Data)this).isLiteral()) 
@@ -571,10 +684,10 @@ public abstract class Lop
 	/**
 	 * Method to prepare instruction operand with given parameters.
 	 * 
-	 * @param label
-	 * @param dt
-	 * @param vt
-	 * @return
+	 * @param label instruction label
+	 * @param dt data type
+	 * @param vt value type
+	 * @return instruction operand with data type and value type
 	 */
 	public String prepOperand(String label, DataType dt, ValueType vt) {
 		StringBuilder sb = new StringBuilder();
@@ -589,10 +702,11 @@ public abstract class Lop
 	/**
 	 * Method to prepare instruction operand with given parameters.
 	 * 
-	 * @param label
-	 * @param dt
-	 * @param vt
-	 * @return
+	 * @param label instruction label
+	 * @param dt data type
+	 * @param vt value type
+	 * @param literal true if literal
+	 * @return instruction operand with data type, value type, and literal status
 	 */
 	public String prepOperand(String label, DataType dt, ValueType vt, boolean literal) {
 		StringBuilder sb = new StringBuilder();
@@ -610,8 +724,8 @@ public abstract class Lop
 	 * Method to prepare instruction operand with given label. Data type
 	 * and Value type are derived from Lop's properties.
 	 * 
-	 * @param label
-	 * @return
+	 * @param label instruction label
+	 * @return instruction operand with data type and value type
 	 */
 	private String prepOperand(String label) {
 		StringBuilder sb = new StringBuilder("");
@@ -638,7 +752,7 @@ public abstract class Lop
 	 * Function to prepare label for scalar inputs while generating instructions.
 	 * It attaches placeholder suffix and prefixes if the Lop denotes a variable.
 	 * 
-	 * @return
+	 * @return prepared scalar label
 	 */
 	public String prepScalarLabel() {
 		String ret = getOutputParameters().getLabel();
@@ -662,8 +776,9 @@ public abstract class Lop
 	 *     to symbol table and the instruction encodes sufficient information
 	 *     to determine if an operand is a literal or not.
 	 * 
-	 * @param et
-	 * @return
+	 * @param et execution type
+	 * @param label instruction label
+	 * @return prepared scalar operand
 	 */
 	public String prepScalarOperand(ExecType et, String label) {
 		boolean isData = (getExecLocation() == ExecLocation.Data);
@@ -727,6 +842,8 @@ public abstract class Lop
 	 * Method to check if a LOP expects an input from the Distributed Cache.
 	 * The method in parent class always returns <code>false</code> (default).
 	 * It must be overridden by individual LOPs that use the cache.
+	 * 
+	 * @return true if lop expects input from distributed cache. In LOP class, always returns false.
 	 */
 	public boolean usesDistributedCache() {
 		return false;

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/MMCJ.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/MMCJ.java b/src/main/java/org/apache/sysml/lops/MMCJ.java
index 07eec2e..3d3fc8e 100644
--- a/src/main/java/org/apache/sysml/lops/MMCJ.java
+++ b/src/main/java/org/apache/sysml/lops/MMCJ.java
@@ -46,11 +46,14 @@ public class MMCJ extends Lop
 		
 	/**
 	 * Constructor to perform a cross product operation.
-	 * @param et 
-	 * @param input
-	 * @param op
+	 * 
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param dt data type
+	 * @param vt value type
+	 * @param type cross production operation type (aggregate or no aggregate)
+	 * @param et execution type
 	 */
-
 	public MMCJ(Lop input1, Lop input2, DataType dt, ValueType vt, MMCJType type, ExecType et) 
 	{
 		super(Lop.Type.MMCJ, dt, vt);		
@@ -80,15 +83,6 @@ public class MMCJ extends Lop
 		}
 	}
 
-	/**
-	 * 
-	 * @param input1
-	 * @param input2
-	 * @param dt
-	 * @param vt
-	 * @param aggtype
-	 * @param et
-	 */
 	public MMCJ(Lop input1, Lop input2, DataType dt, ValueType vt, SparkAggType aggtype, ExecType et) 
 	{
 		this(input1, input2, dt, vt, MMCJType.NO_AGG, et);

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/MMRJ.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/MMRJ.java b/src/main/java/org/apache/sysml/lops/MMRJ.java
index fee7d34..550960a 100644
--- a/src/main/java/org/apache/sysml/lops/MMRJ.java
+++ b/src/main/java/org/apache/sysml/lops/MMRJ.java
@@ -34,10 +34,13 @@ public class MMRJ extends Lop
 		
 	/**
 	 * Constructor to perform a cross product operation.
-	 * @param input
-	 * @param op
+	 * 
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et execution type
 	 */
-
 	public MMRJ(Lop input1, Lop input2, DataType dt, ValueType vt, ExecType et) 
 	{
 		//handle inputs and outputs

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/MMZip.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/MMZip.java b/src/main/java/org/apache/sysml/lops/MMZip.java
index 6b568e0..40382d2 100644
--- a/src/main/java/org/apache/sysml/lops/MMZip.java
+++ b/src/main/java/org/apache/sysml/lops/MMZip.java
@@ -33,11 +33,6 @@ public class MMZip extends Lop
 {
 	private boolean _tRewrite = true;
 	
-	/**
-	 * 
-	 * @param input
-	 * @param op
-	 */
 	public MMZip(Lop input1, Lop input2, DataType dt, ValueType vt, boolean tRewrite, ExecType et) 
 	{
 		//handle inputs and outputs

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/MapMult.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/MapMult.java b/src/main/java/org/apache/sysml/lops/MapMult.java
index 9c4e4f3..1cb8e46 100644
--- a/src/main/java/org/apache/sysml/lops/MapMult.java
+++ b/src/main/java/org/apache/sysml/lops/MapMult.java
@@ -52,11 +52,15 @@ public class MapMult extends Lop
 	/**
 	 * Constructor to setup a partial Matrix-Vector Multiplication for MR
 	 * 
-	 * @param input
-	 * @param op
-	 * @return 
-	 * @throws LopsException
-	 */	
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param dt data type
+	 * @param vt value type
+	 * @param rightCache true if right cache, false if left cache
+	 * @param partitioned true if partitioned, false if not partitioned
+	 * @param emptyBlocks true if output empty blocks
+	 * @throws LopsException if LopsException occurs
+	 */
 	public MapMult(Lop input1, Lop input2, DataType dt, ValueType vt, boolean rightCache, boolean partitioned, boolean emptyBlocks ) 
 		throws LopsException 
 	{
@@ -85,15 +89,15 @@ public class MapMult extends Lop
 	/**
 	 * Constructor to setup a partial Matrix-Vector Multiplication for Spark
 	 * 
-	 * @param input1
-	 * @param input2
-	 * @param dt
-	 * @param vt
-	 * @param rightCache
-	 * @param emptyBlocks
-	 * @param aggregate
-	 * @param et
-	 * @throws LopsException
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param dt data type
+	 * @param vt value type
+	 * @param rightCache true if right cache, false if left cache
+	 * @param partitioned true if partitioned, false if not partitioned
+	 * @param emptyBlocks true if output empty blocks
+	 * @param aggtype spark aggregation type
+	 * @throws LopsException if LopsException occurs
 	 */
 	public MapMult(Lop input1, Lop input2, DataType dt, ValueType vt, boolean rightCache, boolean partitioned, boolean emptyBlocks, SparkAggType aggtype) 
 		throws LopsException 

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/MapMultChain.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/MapMultChain.java b/src/main/java/org/apache/sysml/lops/MapMultChain.java
index ba424c0..163fa6d 100644
--- a/src/main/java/org/apache/sysml/lops/MapMultChain.java
+++ b/src/main/java/org/apache/sysml/lops/MapMultChain.java
@@ -45,11 +45,13 @@ public class MapMultChain extends Lop
 	/**
 	 * Constructor to setup a map mult chain without weights
 	 * 
-	 * @param input
-	 * @param op
-	 * @return 
-	 * @throws LopsException
-	 */	
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et execution type
+	 * @throws LopsException if LopsException occurs
+	 */
 	public MapMultChain(Lop input1, Lop input2, DataType dt, ValueType vt, ExecType et) 
 		throws LopsException 
 	{
@@ -67,11 +69,15 @@ public class MapMultChain extends Lop
 	/**
 	 * Constructor to setup a map mult chain with weights
 	 * 
-	 * @param input
-	 * @param op
-	 * @return 
-	 * @throws LopsException
-	 */	
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param input3 low-level operator 3
+	 * @param chain chain type
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et execution type
+	 * @throws LopsException if LopsException occurs
+	 */
 	public MapMultChain(Lop input1, Lop input2, Lop input3, ChainType chain, DataType dt, ValueType vt, ExecType et) 
 		throws LopsException 
 	{
@@ -88,10 +94,6 @@ public class MapMultChain extends Lop
 		setupLopProperties(et);
 	}
 
-	/**
-	 * 
-	 * @param et
-	 */
 	private void setupLopProperties( ExecType et )
 	{
 		if( et == ExecType.MR )

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/PMMJ.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/PMMJ.java b/src/main/java/org/apache/sysml/lops/PMMJ.java
index a595576..c371049 100644
--- a/src/main/java/org/apache/sysml/lops/PMMJ.java
+++ b/src/main/java/org/apache/sysml/lops/PMMJ.java
@@ -25,9 +25,6 @@ import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 
-/**
- *
- */
 public class PMMJ extends Lop 
 {
 	
@@ -45,11 +42,16 @@ public class PMMJ extends Lop
 	/**
 	 * Constructor to setup a Permutation Matrix Multiplication
 	 * 
-	 * @param input
-	 * @param op
-	 * @return 
-	 * @throws LopsException
-	 */	
+	 * @param pminput permutation matrix input lop
+	 * @param rightinput right lop
+	 * @param nrow number of rows?
+	 * @param dt data type
+	 * @param vt value type
+	 * @param partitioned true if partitioned
+	 * @param emptyBlocks true if output empty blocks
+	 * @param et execution type
+	 * @throws LopsException if LopsException occurs
+	 */
 	public PMMJ(Lop pminput, Lop rightinput, Lop nrow, DataType dt, ValueType vt, boolean partitioned, boolean emptyBlocks, ExecType et) 
 		throws LopsException 
 	{

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/PMapMult.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/PMapMult.java b/src/main/java/org/apache/sysml/lops/PMapMult.java
index 19c73bc..e5e978d 100644
--- a/src/main/java/org/apache/sysml/lops/PMapMult.java
+++ b/src/main/java/org/apache/sysml/lops/PMapMult.java
@@ -30,18 +30,6 @@ public class PMapMult extends Lop
 {	
 	public static final String OPCODE = "pmapmm";
 
-	/**
-	 * 
-	 * @param input1
-	 * @param input2
-	 * @param dt
-	 * @param vt
-	 * @param rightCache
-	 * @param emptyBlocks
-	 * @param aggregate
-	 * @param et
-	 * @throws LopsException
-	 */
 	public PMapMult(Lop input1, Lop input2, DataType dt, ValueType vt) 
 		throws LopsException 
 	{

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/ParameterizedBuiltin.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/ParameterizedBuiltin.java b/src/main/java/org/apache/sysml/lops/ParameterizedBuiltin.java
index 140adaa..be8d5bd 100644
--- a/src/main/java/org/apache/sysml/lops/ParameterizedBuiltin.java
+++ b/src/main/java/org/apache/sysml/lops/ParameterizedBuiltin.java
@@ -52,18 +52,10 @@ public class ParameterizedBuiltin extends Lop
 	/**
 	 * Creates a new builtin function LOP.
 	 * 
-	 * @param target
-	 *            target identifier
-	 * @param params
-	 *            parameter list
-	 * @param inputParameters
-	 *            list of input LOPs
-	 * @param function
-	 *            builtin function
-	 * @param numRows
-	 *            number of resulting rows
-	 * @param numCols
-	 *            number of resulting columns
+	 * @param paramLops map of parameter lops
+	 * @param op operation type
+	 * @param dt data type
+	 * @param vt value type
 	 */
 	public ParameterizedBuiltin(HashMap<String, Lop> paramLops, OperationTypes op, DataType dt, ValueType vt) 
 	{
@@ -496,11 +488,6 @@ public class ParameterizedBuiltin extends Lop
 		return sb.toString();
 	}
 	
-	/**
-	 * 
-	 * @param params
-	 * @return
-	 */
 	private static String compileGenericParamMap(HashMap<String, Lop> params) {
 		StringBuilder sb = new StringBuilder();		
 		for ( Entry<String, Lop> e : params.entrySet() ) {

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/PartialAggregate.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/PartialAggregate.java b/src/main/java/org/apache/sysml/lops/PartialAggregate.java
index fdcc5b0..cd32f5b 100644
--- a/src/main/java/org/apache/sysml/lops/PartialAggregate.java
+++ b/src/main/java/org/apache/sysml/lops/PartialAggregate.java
@@ -100,10 +100,12 @@ public class PartialAggregate extends Lop
 	/**
 	 * Constructor to setup a partial aggregate operation.
 	 * 
-	 * @param input
-	 * @param op
-	 * @return 
-	 * @throws LopsException
+	 * @param input low-level operator
+	 * @param op aggregate operation type
+	 * @param direct partial aggregate directon type
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et execution type
 	 */
 	private void init(Lop input,
 			Aggregate.OperationTypes op,
@@ -162,6 +164,9 @@ public class PartialAggregate extends Lop
 	 * Computed information is encoded in the PartialAgg instruction so that the
 	 * appropriate aggregate operator is used at runtime (see:
 	 * dml.runtime.matrix.operator.AggregateOperator.java and dml.runtime.matrix)
+	 * 
+	 * @return correct location
+	 * @throws LopsException if LopsException occurs
 	 */
 	public CorrectionLocationType getCorrectionLocation() 
 		throws LopsException 
@@ -335,12 +340,6 @@ public class PartialAggregate extends Lop
 		return sb.toString();
 	}
 
-	/**
-	 * 
-	 * @param op
-	 * @param dir
-	 * @return
-	 */
 	public static String getOpcode(Aggregate.OperationTypes op, DirectionTypes dir) 
 	{
 		switch( op )

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/RangeBasedReIndex.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/RangeBasedReIndex.java b/src/main/java/org/apache/sysml/lops/RangeBasedReIndex.java
index 09296ae..401dfbd 100644
--- a/src/main/java/org/apache/sysml/lops/RangeBasedReIndex.java
+++ b/src/main/java/org/apache/sysml/lops/RangeBasedReIndex.java
@@ -29,16 +29,7 @@ import org.apache.sysml.parser.Expression.ValueType;
 
 public class RangeBasedReIndex extends Lop 
 {
-	
-	/**
-	 * Constructor to setup a RangeBasedReIndex operation.
-	 * 
-	 * @param input
-	 * @param op
-	 * @return 
-	 * @throws LopsException
-	 */
-	
+
 	private boolean forLeftIndexing = false;
 
 	//optional attribute for spark exec type

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/ReBlock.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/ReBlock.java b/src/main/java/org/apache/sysml/lops/ReBlock.java
index 5a62ed7..ec3d647 100644
--- a/src/main/java/org/apache/sysml/lops/ReBlock.java
+++ b/src/main/java/org/apache/sysml/lops/ReBlock.java
@@ -37,12 +37,6 @@ public class ReBlock extends Lop
 	
 	private boolean _outputEmptyBlocks = true;
 	
-	/**
-	 * Constructor to perform a reblock operation. 
-	 * @param input
-	 * @param op
-	 */
-	
 	private Long _rows_per_block;
 	private Long _cols_per_block;
 

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/RepMat.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/RepMat.java b/src/main/java/org/apache/sysml/lops/RepMat.java
index d7ce6b4..42adfac 100644
--- a/src/main/java/org/apache/sysml/lops/RepMat.java
+++ b/src/main/java/org/apache/sysml/lops/RepMat.java
@@ -36,11 +36,13 @@ public class RepMat extends Lop
 	/**
 	 * Constructor to setup a partial Matrix-Vector Multiplication
 	 * 
-	 * @param input
-	 * @param op
-	 * @return 
-	 * @throws LopsException
-	 */	
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param repCols ?
+	 * @param dt data type
+	 * @param vt value type
+	 * @throws LopsException if LopsException occurs
+	 */
 	public RepMat(Lop input1, Lop input2, boolean repCols, DataType dt, ValueType vt) 
 		throws LopsException 
 	{

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/Ternary.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/Ternary.java b/src/main/java/org/apache/sysml/lops/Ternary.java
index e697cc5..7a79088 100644
--- a/src/main/java/org/apache/sysml/lops/Ternary.java
+++ b/src/main/java/org/apache/sysml/lops/Ternary.java
@@ -119,7 +119,7 @@ public class Ternary extends Lop
 
 	/**
 	 * method to get operation type
-	 * @return
+	 * @return operation type
 	 */
 	 
 	public OperationTypes getOperationType()
@@ -332,11 +332,6 @@ public class Ternary extends Lop
 		return sb.toString();
 	}
 
-	/**
-	 * 
-	 * @param type
-	 * @return
-	 */
 	public static String getOpcode(OperationTypes type)
 	{
 		switch( type ) 
@@ -352,11 +347,6 @@ public class Ternary extends Lop
 		}
 	}
 	
-	/**
-	 * 
-	 * @param opcode
-	 * @return
-	 */
 	public static OperationTypes getOperationType(String opcode)
 	{
 		OperationTypes op = null;

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/TernaryAggregate.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/TernaryAggregate.java b/src/main/java/org/apache/sysml/lops/TernaryAggregate.java
index ed2abd1..5f8443f 100644
--- a/src/main/java/org/apache/sysml/lops/TernaryAggregate.java
+++ b/src/main/java/org/apache/sysml/lops/TernaryAggregate.java
@@ -24,11 +24,6 @@ import org.apache.sysml.lops.LopProperties.ExecType;
 import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.*;
 
-
-/**
- * 
- * 
- */
 public class TernaryAggregate extends Lop 
 {
 	
@@ -44,12 +39,7 @@ public class TernaryAggregate extends Lop
 	public TernaryAggregate(Lop input1, Lop input2, Lop input3, Aggregate.OperationTypes aggOp, Binary.OperationTypes binOp, DataType dt, ValueType vt, ExecType et ) {
 		this(input1, input2, input3, aggOp, binOp, dt, vt, et, 1);
 	}
-	
-	/**
-	 * @param et 
-	 * @param input - input lop
-	 * @param op - operation type
-	 */
+
 	public TernaryAggregate(Lop input1, Lop input2, Lop input3, Aggregate.OperationTypes aggOp, Binary.OperationTypes binOp, DataType dt, ValueType vt, ExecType et, int k ) 
 	{
 		super(Lop.Type.TernaryAggregate, dt, vt);

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/Transform.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/Transform.java b/src/main/java/org/apache/sysml/lops/Transform.java
index 6b995f2..e0c2f35 100644
--- a/src/main/java/org/apache/sysml/lops/Transform.java
+++ b/src/main/java/org/apache/sysml/lops/Transform.java
@@ -46,10 +46,13 @@ public class Transform extends Lop
 		
 	/**
 	 * Constructor when we have one input.
-	 * @param input
-	 * @param op
+	 * 
+	 * @param input low-level operator
+	 * @param op transform operation type
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et execution type
 	 */
-
 	public Transform(Lop input, Transform.OperationTypes op, DataType dt, ValueType vt, ExecType et) {
 		this(input, op, dt, vt, et, 1);		
 	}
@@ -116,7 +119,7 @@ public class Transform extends Lop
 
 	/**
 	 * method to get operation type
-	 * @return
+	 * @return operaton type
 	 */
 	 
 	public OperationTypes getOperationType()

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/UAggOuterChain.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/UAggOuterChain.java b/src/main/java/org/apache/sysml/lops/UAggOuterChain.java
index 0c11c2f..db693e2 100644
--- a/src/main/java/org/apache/sysml/lops/UAggOuterChain.java
+++ b/src/main/java/org/apache/sysml/lops/UAggOuterChain.java
@@ -47,11 +47,16 @@ public class UAggOuterChain extends Lop
 	/**
 	 * Constructor to setup a unaryagg outer chain
 	 * 
-	 * @param input
-	 * @param op
-	 * @return 
-	 * @throws LopsException
-	 */	
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param uaop aggregate operation type
+	 * @param uadir partial aggregate direction type
+	 * @param bop binary operation type
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et execution type
+	 * @throws LopsException if LopsException occurs
+	 */
 	public UAggOuterChain(Lop input1, Lop input2, Aggregate.OperationTypes uaop, PartialAggregate.DirectionTypes uadir, Binary.OperationTypes bop, DataType dt, ValueType vt, ExecType et) 
 		throws LopsException 
 	{

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/Unary.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/Unary.java b/src/main/java/org/apache/sysml/lops/Unary.java
index bea7352..c675b4e 100644
--- a/src/main/java/org/apache/sysml/lops/Unary.java
+++ b/src/main/java/org/apache/sysml/lops/Unary.java
@@ -57,10 +57,13 @@ public class Unary extends Lop
 	/**
 	 * Constructor to perform a unary operation with 2 inputs
 	 * 
-	 * @param input
-	 * @param op
+	 * @param input1 low-level operator 1
+	 * @param input2 low-level operator 2
+	 * @param op operation type
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et execution type
 	 */
-
 	public Unary(Lop input1, Lop input2, OperationTypes op, DataType dt, ValueType vt, ExecType et) {
 		super(Lop.Type.UNARY, dt, vt);
 		init(input1, input2, op, dt, vt, et);
@@ -109,9 +112,13 @@ public class Unary extends Lop
 	/**
 	 * Constructor to perform a unary operation with 1 input.
 	 * 
-	 * @param input1
-	 * @param op
-	 * @throws LopsException 
+	 * @param input1 low-level operator 1
+	 * @param op operation type
+	 * @param dt data type
+	 * @param vt value type
+	 * @param et execution type
+	 * @param numThreads number of threads
+	 * @throws LopsException if LopsException occurs
 	 */
 	public Unary(Lop input1, OperationTypes op, DataType dt, ValueType vt, ExecType et, int numThreads) 
 		throws LopsException 
@@ -175,23 +182,12 @@ public class Unary extends Lop
 			return "Operation: " + operation + " " + "Label: N/A";
 	}
 
-	/**
-	 * 
-	 * @return
-	 * @throws LopsException
-	 */
 	private String getOpcode() 
 		throws LopsException 
 	{
 		return getOpcode(operation);
 	}
-	
-	/**
-	 * 
-	 * @param op
-	 * @return
-	 * @throws LopsException
-	 */
+
 	public static String getOpcode(OperationTypes op) 
 		throws LopsException 
 	{
@@ -339,11 +335,6 @@ public class Unary extends Lop
 		}
 	}
 	
-	/**
-	 * 
-	 * @param op
-	 * @return
-	 */
 	public static boolean isCumulativeOp(OperationTypes op) {
 		return op==OperationTypes.CUMSUM
 			|| op==OperationTypes.CUMPROD

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/UnaryCP.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/UnaryCP.java b/src/main/java/org/apache/sysml/lops/UnaryCP.java
index 4fa3cc7..1aec7cc 100644
--- a/src/main/java/org/apache/sysml/lops/UnaryCP.java
+++ b/src/main/java/org/apache/sysml/lops/UnaryCP.java
@@ -53,10 +53,11 @@ public class UnaryCP extends Lop
 	/**
 	 * Constructor to perform a scalar operation
 	 * 
-	 * @param input
-	 * @param op
+	 * @param input low-level operator 1
+	 * @param op operation type
+	 * @param dt data type
+	 * @param vt value type
 	 */
-
 	public UnaryCP(Lop input, OperationTypes op, DataType dt, ValueType vt) {
 		super(Lop.Type.UnaryCP, dt, vt);
 		operation = op;

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/WeightedCrossEntropy.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/WeightedCrossEntropy.java b/src/main/java/org/apache/sysml/lops/WeightedCrossEntropy.java
index 9af14ed..cffacd6 100644
--- a/src/main/java/org/apache/sysml/lops/WeightedCrossEntropy.java
+++ b/src/main/java/org/apache/sysml/lops/WeightedCrossEntropy.java
@@ -25,9 +25,6 @@ import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 
-/**
- * 
- */
 public class WeightedCrossEntropy extends Lop 
 {
 	public static final String OPCODE = "mapwcemm";
@@ -63,10 +60,6 @@ public class WeightedCrossEntropy extends Lop
 		setupLopProperties(et);
 	}
 	
-	/**
-	 * 
-	 * @param et
-	 */
 	private void setupLopProperties( ExecType et )
 	{
 		if( et == ExecType.MR )

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/WeightedCrossEntropyR.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/WeightedCrossEntropyR.java b/src/main/java/org/apache/sysml/lops/WeightedCrossEntropyR.java
index 1e5280f..174236f 100644
--- a/src/main/java/org/apache/sysml/lops/WeightedCrossEntropyR.java
+++ b/src/main/java/org/apache/sysml/lops/WeightedCrossEntropyR.java
@@ -26,9 +26,6 @@ import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 
-/**
- * 
- */
 public class WeightedCrossEntropyR extends Lop 
 {
 
@@ -59,11 +56,6 @@ public class WeightedCrossEntropyR extends Lop
 		setupLopProperties(et);
 	}
 	
-	/**
-	 * 
-	 * @param et
-	 * @throws LopsException 
-	 */
 	private void setupLopProperties( ExecType et ) 
 		throws LopsException
 	{

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/WeightedDivMM.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/WeightedDivMM.java b/src/main/java/org/apache/sysml/lops/WeightedDivMM.java
index 19a167d..5eb1d04 100644
--- a/src/main/java/org/apache/sysml/lops/WeightedDivMM.java
+++ b/src/main/java/org/apache/sysml/lops/WeightedDivMM.java
@@ -26,9 +26,6 @@ import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 import org.apache.sysml.runtime.matrix.MatrixCharacteristics;
 
-/**
- * 
- */
 public class WeightedDivMM extends Lop 
 {
 	public static final String OPCODE = "mapwdivmm";
@@ -102,10 +99,6 @@ public class WeightedDivMM extends Lop
 		setupLopProperties(et);
 	}
 	
-	/**
-	 * 
-	 * @param et
-	 */
 	private void setupLopProperties( ExecType et )
 	{
 		if( et == ExecType.MR )

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/WeightedDivMMR.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/WeightedDivMMR.java b/src/main/java/org/apache/sysml/lops/WeightedDivMMR.java
index cb5bccb..2379b30 100644
--- a/src/main/java/org/apache/sysml/lops/WeightedDivMMR.java
+++ b/src/main/java/org/apache/sysml/lops/WeightedDivMMR.java
@@ -26,9 +26,6 @@ import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 
-/**
- * 
- */
 public class WeightedDivMMR extends Lop 
 {
 	public static final String OPCODE = "redwdivmm";
@@ -56,11 +53,6 @@ public class WeightedDivMMR extends Lop
 		setupLopProperties(et);
 	}
 	
-	/**
-	 * 
-	 * @param et
-	 * @throws LopsException 
-	 */
 	private void setupLopProperties( ExecType et ) 
 		throws LopsException
 	{

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/WeightedSigmoid.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/WeightedSigmoid.java b/src/main/java/org/apache/sysml/lops/WeightedSigmoid.java
index 5f5d532..8b50c74 100644
--- a/src/main/java/org/apache/sysml/lops/WeightedSigmoid.java
+++ b/src/main/java/org/apache/sysml/lops/WeightedSigmoid.java
@@ -25,9 +25,6 @@ import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 
-/**
- * 
- */
 public class WeightedSigmoid extends Lop 
 {
 
@@ -60,10 +57,6 @@ public class WeightedSigmoid extends Lop
 		setupLopProperties(et);
 	}
 	
-	/**
-	 * 
-	 * @param et
-	 */
 	private void setupLopProperties( ExecType et )
 	{
 		if( et == ExecType.MR )

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/WeightedSigmoidR.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/WeightedSigmoidR.java b/src/main/java/org/apache/sysml/lops/WeightedSigmoidR.java
index e563e5c..b46c243 100644
--- a/src/main/java/org/apache/sysml/lops/WeightedSigmoidR.java
+++ b/src/main/java/org/apache/sysml/lops/WeightedSigmoidR.java
@@ -26,9 +26,6 @@ import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 
-/**
- * 
- */
 public class WeightedSigmoidR extends Lop 
 {
 
@@ -57,11 +54,6 @@ public class WeightedSigmoidR extends Lop
 		setupLopProperties(et);
 	}
 	
-	/**
-	 * 
-	 * @param et
-	 * @throws LopsException 
-	 */
 	private void setupLopProperties( ExecType et ) 
 		throws LopsException
 	{

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/WeightedSquaredLoss.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/WeightedSquaredLoss.java b/src/main/java/org/apache/sysml/lops/WeightedSquaredLoss.java
index 12bed1a..b34b3a0 100644
--- a/src/main/java/org/apache/sysml/lops/WeightedSquaredLoss.java
+++ b/src/main/java/org/apache/sysml/lops/WeightedSquaredLoss.java
@@ -25,9 +25,6 @@ import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 
-/**
- * 
- */
 public class WeightedSquaredLoss extends Lop 
 {
 	public static final String OPCODE = "mapwsloss";
@@ -65,10 +62,6 @@ public class WeightedSquaredLoss extends Lop
 		setupLopProperties(et);
 	}
 	
-	/**
-	 * 
-	 * @param et
-	 */
 	private void setupLopProperties( ExecType et )
 	{
 		if( et == ExecType.MR )

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/WeightedSquaredLossR.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/WeightedSquaredLossR.java b/src/main/java/org/apache/sysml/lops/WeightedSquaredLossR.java
index 86c6294..d5d5a28 100644
--- a/src/main/java/org/apache/sysml/lops/WeightedSquaredLossR.java
+++ b/src/main/java/org/apache/sysml/lops/WeightedSquaredLossR.java
@@ -26,9 +26,6 @@ import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 
-/**
- * 
- */
 public class WeightedSquaredLossR extends Lop 
 {
 	public static final String OPCODE = "redwsloss";
@@ -57,11 +54,6 @@ public class WeightedSquaredLossR extends Lop
 		setupLopProperties(et);
 	}
 	
-	/**
-	 * 
-	 * @param et
-	 * @throws LopsException 
-	 */
 	private void setupLopProperties( ExecType et ) 
 		throws LopsException
 	{

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/WeightedUnaryMM.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/WeightedUnaryMM.java b/src/main/java/org/apache/sysml/lops/WeightedUnaryMM.java
index 8530b49..96007da 100644
--- a/src/main/java/org/apache/sysml/lops/WeightedUnaryMM.java
+++ b/src/main/java/org/apache/sysml/lops/WeightedUnaryMM.java
@@ -26,9 +26,6 @@ import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 
-/**
- * 
- */
 public class WeightedUnaryMM extends Lop 
 {
 	public static final String OPCODE = "mapwumm";
@@ -60,10 +57,6 @@ public class WeightedUnaryMM extends Lop
 		setupLopProperties(et);
 	}
 	
-	/**
-	 * 
-	 * @param et
-	 */
 	private void setupLopProperties( ExecType et )
 	{
 		if( et == ExecType.MR )

http://git-wip-us.apache.org/repos/asf/incubator-systemml/blob/c96ed96a/src/main/java/org/apache/sysml/lops/WeightedUnaryMMR.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/sysml/lops/WeightedUnaryMMR.java b/src/main/java/org/apache/sysml/lops/WeightedUnaryMMR.java
index d812e7b..aee0ff5 100644
--- a/src/main/java/org/apache/sysml/lops/WeightedUnaryMMR.java
+++ b/src/main/java/org/apache/sysml/lops/WeightedUnaryMMR.java
@@ -27,9 +27,6 @@ import org.apache.sysml.lops.compile.JobType;
 import org.apache.sysml.parser.Expression.DataType;
 import org.apache.sysml.parser.Expression.ValueType;
 
-/**
- * 
- */
 public class WeightedUnaryMMR extends Lop 
 {
 	public static final String OPCODE = "redwumm";
@@ -58,11 +55,6 @@ public class WeightedUnaryMMR extends Lop
 		setupLopProperties(et);
 	}
 	
-	/**
-	 * 
-	 * @param et
-	 * @throws LopsException 
-	 */
 	private void setupLopProperties( ExecType et ) 
 		throws LopsException
 	{