You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by gu...@apache.org on 2014/02/28 22:34:57 UTC

svn commit: r1573086 - in /hive/branches/tez/ql/src/java/org/apache/hadoop/hive/ql/parse: FileSinkProcessor.java GenTezUtils.java

Author: gunther
Date: Fri Feb 28 21:34:57 2014
New Revision: 1573086

URL: http://svn.apache.org/r1573086
Log:
HIVE-6525: Fix some whitespace issues in GenTezUtils (Gunther Hagleitner)

Modified:
    hive/branches/tez/ql/src/java/org/apache/hadoop/hive/ql/parse/FileSinkProcessor.java
    hive/branches/tez/ql/src/java/org/apache/hadoop/hive/ql/parse/GenTezUtils.java

Modified: hive/branches/tez/ql/src/java/org/apache/hadoop/hive/ql/parse/FileSinkProcessor.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/ql/src/java/org/apache/hadoop/hive/ql/parse/FileSinkProcessor.java?rev=1573086&r1=1573085&r2=1573086&view=diff
==============================================================================
--- hive/branches/tez/ql/src/java/org/apache/hadoop/hive/ql/parse/FileSinkProcessor.java (original)
+++ hive/branches/tez/ql/src/java/org/apache/hadoop/hive/ql/parse/FileSinkProcessor.java Fri Feb 28 21:34:57 2014
@@ -51,7 +51,7 @@ public class FileSinkProcessor implement
 
     GenTezProcContext context = (GenTezProcContext) procCtx;
     FileSinkOperator fileSink = (FileSinkOperator) nd;
-    
+
     // just remember it for later processing
     context.fileSinkSet.add(fileSink);
     return true;

Modified: hive/branches/tez/ql/src/java/org/apache/hadoop/hive/ql/parse/GenTezUtils.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/ql/src/java/org/apache/hadoop/hive/ql/parse/GenTezUtils.java?rev=1573086&r1=1573085&r2=1573086&view=diff
==============================================================================
--- hive/branches/tez/ql/src/java/org/apache/hadoop/hive/ql/parse/GenTezUtils.java (original)
+++ hive/branches/tez/ql/src/java/org/apache/hadoop/hive/ql/parse/GenTezUtils.java Fri Feb 28 21:34:57 2014
@@ -146,8 +146,8 @@ public class GenTezUtils {
   }
 
   // this method's main use is to help unit testing this class
-  protected void setupMapWork(MapWork mapWork, GenTezProcContext context, 
-      PrunedPartitionList partitions, Operator<? extends OperatorDesc> root, 
+  protected void setupMapWork(MapWork mapWork, GenTezProcContext context,
+      PrunedPartitionList partitions, Operator<? extends OperatorDesc> root,
       String alias) throws SemanticException {
     // All the setup is done in GenMapRedUtils
     GenMapRedUtils.setMapWork(mapWork, context.parseContext,
@@ -155,12 +155,12 @@ public class GenTezUtils {
   }
 
   // removes any union operator and clones the plan
-  public void removeUnionOperators(Configuration conf, GenTezProcContext context, 
-      BaseWork work) 
+  public void removeUnionOperators(Configuration conf, GenTezProcContext context,
+      BaseWork work)
     throws SemanticException {
 
     Set<Operator<?>> roots = work.getAllRootOperators();
-    
+
     // need to clone the plan.
     Set<Operator<?>> newRoots = Utilities.cloneOperatorTree(conf, roots);
 
@@ -185,14 +185,14 @@ public class GenTezUtils {
 
       if (current instanceof FileSinkOperator) {
         FileSinkOperator fileSink = (FileSinkOperator)current;
-        
+
         // remember it for additional processing later
         context.fileSinkSet.add(fileSink);
 
         FileSinkDesc desc = fileSink.getConf();
         Path path = desc.getDirName();
         List<FileSinkDesc> linked;
-        
+
         if (!context.linkedFileSinks.containsKey(path)) {
           linked = new ArrayList<FileSinkDesc>();
           context.linkedFileSinks.put(path, linked);
@@ -203,7 +203,7 @@ public class GenTezUtils {
         desc.setDirName(new Path(path, ""+linked.size()));
         desc.setLinkedFileSinkDesc(linked);
       }
-      
+
       if (current instanceof UnionOperator) {
         Operator<?> parent = null;
         int count = 0;
@@ -214,7 +214,7 @@ public class GenTezUtils {
             parent = op;
           }
         }
-        
+
         // we should have been able to reach the union from only one side.
         assert count <= 1;
 
@@ -232,7 +232,7 @@ public class GenTezUtils {
       } else {
         operators.addAll(current.getChildOperators());
       }
-    }   
+    }
     work.replaceRoots(replacementMap);
   }
 
@@ -240,11 +240,11 @@ public class GenTezUtils {
       throws SemanticException {
 
     ParseContext parseContext = context.parseContext;
-    
+
     boolean isInsertTable = // is INSERT OVERWRITE TABLE
         GenMapRedUtils.isInsertInto(parseContext, fileSink);
     HiveConf hconf = parseContext.getConf();
-    
+
     boolean chDir = GenMapRedUtils.isMergeRequired(context.moveTask,
         hconf, fileSink, context.currentTask, isInsertTable);