You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tez.apache.org by je...@apache.org on 2021/01/20 22:12:44 UTC

[tez] branch branch-0.9 updated: TEZ-4095: Review of Debug Logging (#87)

This is an automated email from the ASF dual-hosted git repository.

jeagles pushed a commit to branch branch-0.9
in repository https://gitbox.apache.org/repos/asf/tez.git


The following commit(s) were added to refs/heads/branch-0.9 by this push:
     new 961dc07  TEZ-4095: Review of Debug Logging (#87)
961dc07 is described below

commit 961dc0711f95fa28ed0e3665220a993c7d57c99a
Author: belugabehr <12...@users.noreply.github.com>
AuthorDate: Wed Jan 20 15:53:15 2021 -0500

    TEZ-4095: Review of Debug Logging (#87)
    
    (cherry picked from commit c2d48a688e041e2b5689d26908a7de7d135bff3e)
---
 .../java/org/apache/tez/client/TezClientUtils.java | 13 ++----
 .../org/apache/tez/common/JavaOptsChecker.java     | 11 ++----
 .../java/org/apache/tez/common/ProgressHelper.java | 12 ++----
 .../org/apache/tez/dag/api/TezConfiguration.java   |  4 +-
 .../apache/tez/dag/api/client/DAGClientImpl.java   | 16 ++------
 .../tez/dag/api/client/TimelineReaderFactory.java  |  6 +--
 .../tez/dag/api/client/rpc/DAGClientRPCImpl.java   |  8 +---
 .../tez/dag/api/client/DAGClientHandler.java       |  4 +-
 .../java/org/apache/tez/dag/app/DAGAppMaster.java  | 36 ++++++-----------
 .../org/apache/tez/dag/app/RecoveryParser.java     |  7 +---
 .../tez/dag/app/TaskCommunicatorManager.java       | 13 ++----
 .../tez/dag/app/TezLocalTaskCommunicatorImpl.java  |  4 +-
 .../tez/dag/app/TezTaskCommunicatorImpl.java       | 17 ++------
 .../org/apache/tez/dag/app/dag/impl/DAGImpl.java   |  5 +--
 .../tez/dag/app/dag/impl/TaskAttemptImpl.java      | 31 +++++----------
 .../org/apache/tez/dag/app/dag/impl/TaskImpl.java  | 12 ++----
 .../apache/tez/dag/app/dag/impl/VertexImpl.java    | 46 ++++++----------------
 .../dag/speculation/legacy/LegacySpeculator.java   |  4 +-
 .../dag/app/launcher/TezContainerLauncherImpl.java |  4 +-
 .../tez/dag/app/rm/DagAwareYarnTaskScheduler.java  |  2 +-
 .../tez/dag/app/rm/TaskSchedulerManager.java       |  8 +---
 .../tez/dag/app/rm/YarnTaskSchedulerService.java   | 31 +++++----------
 .../dag/app/rm/container/AMContainerHelpers.java   |  4 +-
 .../apache/tez/dag/app/web/AMWebController.java    |  8 +---
 .../org/apache/tez/dag/app/web/WebUIService.java   |  4 +-
 .../tez/dag/history/recovery/RecoveryService.java  | 22 ++++-------
 .../mapred/split/TezGroupedSplitsInputFormat.java  | 12 ++----
 .../split/TezGroupedSplitsInputFormat.java         | 12 ++----
 .../apache/tez/mapreduce/client/YARNRunner.java    |  4 +-
 .../tez/mapreduce/hadoop/MRInputHelpers.java       |  8 +---
 .../org/apache/tez/mapreduce/output/MROutput.java  |  4 +-
 .../org/apache/tez/mapreduce/processor/MRTask.java |  5 +--
 .../org/apache/tez/auxservices/IndexCache.java     | 17 +++-----
 .../org/apache/tez/auxservices/ShuffleHandler.java | 24 +++--------
 .../tez/runtime/LogicalIOProcessorRuntimeTask.java | 24 +++--------
 .../tez/runtime/api/impl/TezInputContextImpl.java  |  4 +-
 .../tez/runtime/api/impl/TezOutputContextImpl.java |  4 +-
 .../runtime/api/impl/TezProcessorContextImpl.java  |  4 +-
 .../runtime/common/resources/ScalingAllocator.java |  9 +----
 .../org/apache/tez/runtime/task/TaskReporter.java  |  8 +---
 .../java/org/apache/tez/runtime/task/TezChild.java |  4 +-
 .../java/org/apache/tez/http/HttpConnection.java   |  8 +---
 .../tez/http/async/netty/AsyncHttpConnection.java  |  4 +-
 .../runtime/library/common/TezRuntimeUtils.java    |  4 +-
 .../library/common/shuffle/ShuffleUtils.java       |  8 +---
 .../shuffle/impl/ShuffleInputEventHandlerImpl.java | 12 ++----
 .../common/shuffle/impl/ShuffleManager.java        | 20 +++-------
 .../orderedgrouped/FetcherOrderedGrouped.java      | 38 +++++-------------
 .../shuffle/orderedgrouped/MergeManager.java       |  8 +---
 .../ShuffleInputEventHandlerOrderedGrouped.java    | 17 +++-----
 .../shuffle/orderedgrouped/ShuffleScheduler.java   | 12 ++----
 .../runtime/library/common/sort/impl/IFile.java    |  4 +-
 .../task/local/output/TezTaskOutputFiles.java      |  6 +--
 .../library/input/OrderedGroupedKVInput.java       |  4 +-
 .../WeightedScalingMemoryDistributor.java          |  4 +-
 .../java/org/apache/tez/tools/TFileLoader.java     |  5 +--
 56 files changed, 167 insertions(+), 462 deletions(-)

diff --git a/tez-api/src/main/java/org/apache/tez/client/TezClientUtils.java b/tez-api/src/main/java/org/apache/tez/client/TezClientUtils.java
index 3fa2f93..5cbff67 100644
--- a/tez-api/src/main/java/org/apache/tez/client/TezClientUtils.java
+++ b/tez-api/src/main/java/org/apache/tez/client/TezClientUtils.java
@@ -480,9 +480,7 @@ public class TezClientUtils {
     capability.setVirtualCores(
         amConfig.getTezConfiguration().getInt(TezConfiguration.TEZ_AM_RESOURCE_CPU_VCORES,
             TezConfiguration.TEZ_AM_RESOURCE_CPU_VCORES_DEFAULT));
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("AppMaster capability = " + capability);
-    }
+    LOG.debug("AppMaster capability = {}", capability);
 
     // Setup required Credentials for the AM launch. DAG specific credentials
     // are handled separately.
@@ -551,10 +549,7 @@ public class TezClientUtils {
     }
     vargsFinal.add(mergedCommand.toString());
 
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Command to launch container for ApplicationMaster is : "
-          + mergedCommand);
-    }
+    LOG.debug("Command to launch container for ApplicationMaster is : {}", mergedCommand);
 
     Map<String, String> environment = new TreeMap<String, String>();
     TezYARNUtils.setupDefaultEnv(environment, conf,
@@ -959,9 +954,7 @@ public class TezClientUtils {
           serviceAddr);
       userUgi.addToken(token);
     }
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Connecting to Tez AM at " + serviceAddr);
-    }
+    LOG.debug("Connecting to Tez AM at {}", serviceAddr);
     DAGClientAMProtocolBlockingPB proxy = null;
     try {
       proxy = userUgi.doAs(new PrivilegedExceptionAction<DAGClientAMProtocolBlockingPB>() {
diff --git a/tez-api/src/main/java/org/apache/tez/common/JavaOptsChecker.java b/tez-api/src/main/java/org/apache/tez/common/JavaOptsChecker.java
index 6de402a..3e93446 100644
--- a/tez-api/src/main/java/org/apache/tez/common/JavaOptsChecker.java
+++ b/tez-api/src/main/java/org/apache/tez/common/JavaOptsChecker.java
@@ -38,9 +38,8 @@ public class JavaOptsChecker {
 
   public void checkOpts(String opts) throws TezException {
     Set<String> gcOpts = new TreeSet<String>();
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Checking JVM GC opts: " + opts);
-    }
+    LOG.debug("Checking JVM GC opts: {}", opts);
+
     Matcher matcher = pattern.matcher(opts);
     while (matcher.find()) {
       if (matcher.groupCount() != 3) {
@@ -74,10 +73,8 @@ public class JavaOptsChecker {
         }
       }
 
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Found clashing GC opts"
-            + ", conflicting GC Values=" + gcOpts);
-      }
+      LOG.debug("Found clashing GC opts, conflicting GC Values={}", gcOpts);
+
       throw new TezException("Invalid/conflicting GC options found,"
           + " cmdOpts=\"" + opts + "\"");
     }
diff --git a/tez-api/src/main/java/org/apache/tez/common/ProgressHelper.java b/tez-api/src/main/java/org/apache/tez/common/ProgressHelper.java
index 1518ccd..289847a 100644
--- a/tez-api/src/main/java/org/apache/tez/common/ProgressHelper.java
+++ b/tez-api/src/main/java/org/apache/tez/common/ProgressHelper.java
@@ -117,10 +117,8 @@ public class ProgressHelper {
           // Report progress as 0.0f when if are errors.
           processorContext.setProgress(progressVal);
         } catch (Throwable th) {
-          if (LOG.isDebugEnabled()) {
-            LOG.debug("progress update: Encountered InterruptedException during"
-                + " Processor={}", processorName, th);
-          }
+          LOG.debug("progress update: Encountered InterruptedException during"
+              + " Processor={}", processorName, th);
           if (th instanceof InterruptedException) {
             // set interrupt flag to true sand exit
             Thread.currentThread().interrupt();
@@ -161,10 +159,8 @@ public class ProgressHelper {
           scheduledExecutorService.shutdownNow();
         }
       } catch (InterruptedException e) {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Interrupted exception while shutting down the "
-              + "executor service for the processor name={}", processorName);
-        }
+        LOG.debug("Interrupted exception while shutting down the "
+            + "executor service for the processor name={}", processorName);
       }
       scheduledExecutorService.shutdownNow();
     }
diff --git a/tez-api/src/main/java/org/apache/tez/dag/api/TezConfiguration.java b/tez-api/src/main/java/org/apache/tez/dag/api/TezConfiguration.java
index cfc3cce..68b567c 100644
--- a/tez-api/src/main/java/org/apache/tez/dag/api/TezConfiguration.java
+++ b/tez-api/src/main/java/org/apache/tez/dag/api/TezConfiguration.java
@@ -1875,9 +1875,7 @@ public class TezConfiguration extends Configuration {
   public static void validateProperty(String property, Scope usedScope) {
     Scope validScope = PropertyScope.get(property);
     if (validScope == null) {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug(property + " is not standard configuration property of tez, can not been validated");
-      }
+      LOG.debug("{} is not standard configuration property of tez, can not been validated", property);
     } else {
       if (usedScope.ordinal() > validScope.ordinal()) {
         throw new IllegalStateException(property + " is set at the scope of " + usedScope
diff --git a/tez-api/src/main/java/org/apache/tez/dag/api/client/DAGClientImpl.java b/tez-api/src/main/java/org/apache/tez/dag/api/client/DAGClientImpl.java
index 52f66e3..162f2c5 100644
--- a/tez-api/src/main/java/org/apache/tez/dag/api/client/DAGClientImpl.java
+++ b/tez-api/src/main/java/org/apache/tez/dag/api/client/DAGClientImpl.java
@@ -247,9 +247,7 @@ public class DAGClientImpl extends DAGClient {
         LOG.info("Failed to fetch DAG data for completed DAG from YARN Timeline"
             + " - Application not found by YARN", e);
       } catch (TezException e) {
-        if (LOG.isDebugEnabled()) {
-          LOG.info("DAGStatus fetch failed." + e.getMessage());
-        }
+        LOG.debug("DAGStatus fetch failed", e);
       }
     }
 
@@ -302,9 +300,7 @@ public class DAGClientImpl extends DAGClient {
             + " - Application not found by YARN", e);
         return null;
       } catch (TezException e) {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("ERROR fetching vertex data from Yarn Timeline. " + e.getMessage());
-        }
+        LOG.debug("ERROR fetching vertex data from Yarn Timeline", e);
       }
     }
 
@@ -425,9 +421,7 @@ public class DAGClientImpl extends DAGClient {
    */
   @VisibleForTesting
   protected DAGStatus getDAGStatusViaRM() throws TezException, IOException {
-    if(LOG.isDebugEnabled()) {
-      LOG.debug("GetDAGStatus via AM for app: " + appId + " dag:" + dagId);
-    }
+    LOG.debug("GetDAGStatus via AM for app: {} dag:{}", appId, dagId);
     ApplicationReport appReport;
     try {
       appReport = frameworkClient.getApplicationReport(appId);
@@ -638,9 +632,7 @@ public class DAGClientImpl extends DAGClient {
     realClient.close();
     realClient = new DAGClientTimelineImpl(appId, dagId, conf, frameworkClient,
         (int) (2 * PRINT_STATUS_INTERVAL_MILLIS));
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("dag completed switching to DAGClientTimelineImpl");
-    }
+    LOG.debug("dag completed switching to DAGClientTimelineImpl");
   }
 
   @VisibleForTesting
diff --git a/tez-api/src/main/java/org/apache/tez/dag/api/client/TimelineReaderFactory.java b/tez-api/src/main/java/org/apache/tez/dag/api/client/TimelineReaderFactory.java
index 40340cc..fc1595f 100644
--- a/tez-api/src/main/java/org/apache/tez/dag/api/client/TimelineReaderFactory.java
+++ b/tez-api/src/main/java/org/apache/tez/dag/api/client/TimelineReaderFactory.java
@@ -313,10 +313,8 @@ public class TimelineReaderFactory {
       try {
         connectionConf = getNewSSLConnectionConf(conf, connTimeout, sslFactory);
       } catch (IOException e) {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Cannot load customized ssl related configuration."
-              + " Falling back to system-generic settings.", e);
-        }
+        LOG.debug("Cannot load customized ssl related configuration."
+            + " Falling back to system-generic settings.", e);
       }
     }
 
diff --git a/tez-api/src/main/java/org/apache/tez/dag/api/client/rpc/DAGClientRPCImpl.java b/tez-api/src/main/java/org/apache/tez/dag/api/client/rpc/DAGClientRPCImpl.java
index 02935df..1297cbe 100644
--- a/tez-api/src/main/java/org/apache/tez/dag/api/client/rpc/DAGClientRPCImpl.java
+++ b/tez-api/src/main/java/org/apache/tez/dag/api/client/rpc/DAGClientRPCImpl.java
@@ -142,9 +142,7 @@ public class DAGClientRPCImpl extends DAGClientInternal {
 
   @Override
   public void tryKillDAG() throws TezException, IOException {
-    if(LOG.isDebugEnabled()) {
-      LOG.debug("TryKill for app: " + appId + " dag:" + dagId);
-    }
+    LOG.debug("TryKill for app: {} dag:{}", appId, dagId);
     try {
       if (createAMProxyIfNeeded()) {
         TryKillDAGRequestProto requestProto =
@@ -182,9 +180,7 @@ public class DAGClientRPCImpl extends DAGClientInternal {
 
   DAGStatus getDAGStatusViaAM(Set<StatusGetOpts> statusOptions, long timeout)
       throws IOException, TezException {
-    if(LOG.isDebugEnabled()) {
-      LOG.debug("GetDAGStatus via AM for app: " + appId + " dag:" + dagId);
-    }
+    LOG.debug("GetDAGStatus via AM for app: {} dag:{}", appId, dagId);
     GetDAGStatusRequestProto.Builder requestProtoBuilder =
         GetDAGStatusRequestProto.newBuilder()
           .setDagId(dagId).setTimeout(timeout);
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/api/client/DAGClientHandler.java b/tez-dag/src/main/java/org/apache/tez/dag/api/client/DAGClientHandler.java
index 618676d..4cdd1ec 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/api/client/DAGClientHandler.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/api/client/DAGClientHandler.java
@@ -100,9 +100,7 @@ public class DAGClientHandler {
     final String currentDAGIdStr = currentDAG.getID().toString();
     if (!currentDAGIdStr.equals(dagIdStr)) {
       if (getAllDagIDs().contains(dagIdStr)) {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Looking for finished dagId " + dagIdStr + " current dag is " + currentDAGIdStr);
-        }
+        LOG.debug("Looking for finished dagId {} current dag is {}", dagIdStr, currentDAGIdStr);
         throw new DAGNotRunningException("DAG " + dagIdStr + " Not running, current dag is " +
             currentDAGIdStr);
       } else {
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/DAGAppMaster.java b/tez-dag/src/main/java/org/apache/tez/dag/app/DAGAppMaster.java
index d70573a..2760be6 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/DAGAppMaster.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/DAGAppMaster.java
@@ -580,9 +580,7 @@ public class DAGAppMaster extends AbstractService {
       this.webUIService = new WebUIService(context);
       addIfService(webUIService, false);
     } else {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Web UI Service is not enabled.");
-      }
+      LOG.debug("Web UI Service is not enabled.");
     }
 
     this.taskSchedulerManager = createTaskSchedulerManager(taskSchedulerDescriptors);
@@ -1401,9 +1399,8 @@ public class DAGAppMaster extends AbstractService {
       // the job user's UGI context
       LOG.info("Starting DAG submitted via RPC: " + dagPlan.getName());
 
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Invoked with additional local resources: " + additionalResources);
-      }
+      LOG.debug("Invoked with additional local resources: {}", additionalResources);
+
       if (!dagPlan.getName().startsWith(TezConstants.TEZ_PREWARM_DAG_NAME_PREFIX)) {
         submittedDAGs.incrementAndGet();
       }
@@ -1921,9 +1918,8 @@ public class DAGAppMaster extends AbstractService {
     try {
       Throwable firstError = null;
       List<ServiceThread> threads = new ArrayList<ServiceThread>();
-      if(LOG.isDebugEnabled()) {
-        LOG.debug("Begin parallel start");
-      }
+      LOG.debug("Begin parallel start");
+
       for(ServiceWithDependency sd : services.values()) {
         // start the service. If this fails that service
         // will be stopped and an exception raised
@@ -1947,9 +1943,7 @@ public class DAGAppMaster extends AbstractService {
       if(firstError != null) {
         throw ServiceStateException.convert(firstError);
       }
-      if(LOG.isDebugEnabled()) {
-        LOG.debug("End parallel start");
-      }
+      LOG.debug("End parallel start");
     } catch (InterruptedException e) {
       e.printStackTrace();
     }
@@ -1957,9 +1951,7 @@ public class DAGAppMaster extends AbstractService {
 
   void initServices(Configuration conf) {
     for (ServiceWithDependency sd : services.values()) {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Initing service : " + sd.service);
-      }
+      LOG.debug("Initing service : {}", sd.service);
       sd.service.init(conf);
     }
   }
@@ -1977,9 +1969,7 @@ public class DAGAppMaster extends AbstractService {
 
     for (int i = services.size() - 1; i >= 0; i--) {
       Service service = serviceList.get(i);
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Stopping service : " + service);
-      }
+      LOG.debug("Stopping service : {}", service);
       Exception ex = ServiceOperations.stopQuietly(service);
       if (ex != null && firstException == null) {
         LOG.warn("Failed to stop service, name=" + service.getName(), ex);
@@ -2209,10 +2199,8 @@ public class DAGAppMaster extends AbstractService {
       boolean deleteTezScratchData = this.amConf.getBoolean(
           TezConfiguration.TEZ_AM_STAGING_SCRATCH_DATA_AUTO_DELETE,
           TezConfiguration.TEZ_AM_STAGING_SCRATCH_DATA_AUTO_DELETE_DEFAULT);
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Checking whether tez scratch data dir should be deleted, deleteTezScratchData="
-            + deleteTezScratchData);
-      }
+      LOG.debug("Checking whether tez scratch data dir should be deleted, deleteTezScratchData={}",
+        deleteTezScratchData);
       if (deleteTezScratchData && this.taskSchedulerManager != null
           && this.taskSchedulerManager.hasUnregistered()) {
         // Delete tez scratch data dir
@@ -2490,9 +2478,7 @@ public class DAGAppMaster extends AbstractService {
     public void run() {
       LOG.info("DAGAppMasterShutdownHook invoked");
       if(appMaster.getServiceState() == STATE.STOPPED) {
-        if(LOG.isDebugEnabled()) {
-          LOG.debug("DAGAppMaster already stopped. Ignoring signal");
-        }
+        LOG.debug("DAGAppMaster already stopped. Ignoring signal");
         synchronized (appMaster.shutdownHandlerRunning) {
           try {
             if (appMaster.shutdownHandlerRunning.get()) {
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/RecoveryParser.java b/tez-dag/src/main/java/org/apache/tez/dag/app/RecoveryParser.java
index dfb7f61..19c24f3 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/RecoveryParser.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/RecoveryParser.java
@@ -346,11 +346,8 @@ public class RecoveryParser {
     } catch (EOFException eof) {
       return null;
     }
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Parsed event from input stream"
-          + ", eventType=" + eventType
-          + ", event=" + event.toString());
-    }
+      LOG.debug("Parsed event from input stream, eventType={}, event={}",
+        eventType, event);
     return event;
   }
 
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/TaskCommunicatorManager.java b/tez-dag/src/main/java/org/apache/tez/dag/app/TaskCommunicatorManager.java
index 55b2d1b..3a99456 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/TaskCommunicatorManager.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/TaskCommunicatorManager.java
@@ -220,10 +220,7 @@ public class TaskCommunicatorManager extends AbstractService implements
       throws IOException, TezException {
     ContainerId containerId = ConverterUtils.toContainerId(request
         .getContainerIdentifier());
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Received heartbeat from container"
-          + ", request=" + request);
-    }
+    LOG.debug("Received heartbeat from container, request={}", request);
 
     if (!registeredContainers.containsKey(containerId)) {
       LOG.warn("Received task heartbeat from unknown container with id: " + containerId +
@@ -488,9 +485,7 @@ public class TaskCommunicatorManager extends AbstractService implements
 
   @Override
   public void registerRunningContainer(ContainerId containerId, int taskCommId) {
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("ContainerId: " + containerId + " registered with TaskAttemptListener");
-    }
+    LOG.debug("ContainerId: {} registered with TaskAttemptListener", containerId);
     ContainerInfo oldInfo = registeredContainers.put(containerId, NULL_CONTAINER_INFO);
     if (oldInfo != null) {
       throw new TezUncheckedException(
@@ -515,9 +510,7 @@ public class TaskCommunicatorManager extends AbstractService implements
 
   @Override
   public void unregisterRunningContainer(ContainerId containerId, int taskCommId, ContainerEndReason endReason, String diagnostics) {
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Unregistering Container from TaskAttemptListener: " + containerId);
-    }
+    LOG.debug("Unregistering Container from TaskAttemptListener: {}", containerId);
     ContainerInfo containerInfo = registeredContainers.remove(containerId);
     if (containerInfo.taskAttemptId != null) {
       registeredAttempts.remove(containerInfo.taskAttemptId);
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/TezLocalTaskCommunicatorImpl.java b/tez-dag/src/main/java/org/apache/tez/dag/app/TezLocalTaskCommunicatorImpl.java
index 15d90d3..b574959 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/TezLocalTaskCommunicatorImpl.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/TezLocalTaskCommunicatorImpl.java
@@ -39,8 +39,6 @@ public class TezLocalTaskCommunicatorImpl extends TezTaskCommunicatorImpl {
     } catch (UnknownHostException e) {
       throw new TezUncheckedException(e);
     }
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Not starting TaskAttemptListener RPC in LocalMode");
-    }
+    LOG.debug("Not starting TaskAttemptListener RPC in LocalMode");
   }
 }
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/TezTaskCommunicatorImpl.java b/tez-dag/src/main/java/org/apache/tez/dag/app/TezTaskCommunicatorImpl.java
index 9c8fb6c..6d69d36 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/TezTaskCommunicatorImpl.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/TezTaskCommunicatorImpl.java
@@ -310,18 +310,14 @@ public class TezTaskCommunicatorImpl extends TaskCommunicator {
       } else {
         ContainerId containerId = ConverterUtils.toContainerId(containerContext
             .getContainerIdentifier());
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Container with id: " + containerId + " asked for a task");
-        }
+        LOG.debug("Container with id: {} asked for a task", containerId);
         task = getContainerTask(containerId);
         if (task != null && !task.shouldDie()) {
           getContext().taskSubmitted(task.getTaskSpec().getTaskAttemptID(), containerId);
           getContext().taskStartedRemotely(task.getTaskSpec().getTaskAttemptID());
         }
       }
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("getTask returning task: " + task);
-      }
+      LOG.debug("getTask returning task: {}", task);
       return task;
     }
 
@@ -335,10 +331,7 @@ public class TezTaskCommunicatorImpl extends TaskCommunicator {
         TezException {
       ContainerId containerId = ConverterUtils.toContainerId(request.getContainerIdentifier());
       long requestId = request.getRequestId();
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Received heartbeat from container"
-            + ", request=" + request);
-      }
+      LOG.debug("Received heartbeat from container, request={}", request);
 
       ContainerInfo containerInfo = registeredContainers.get(containerId);
       if (containerInfo == null) {
@@ -436,9 +429,7 @@ public class TezTaskCommunicatorImpl extends TaskCommunicator {
           }
         } else {
           task = null;
-          if (LOG.isDebugEnabled()) {
-            LOG.debug("No task assigned yet for running container: " + containerId);
-          }
+          LOG.debug("No task assigned yet for running container: {}", containerId);
         }
       }
     }
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/DAGImpl.java b/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/DAGImpl.java
index a5723cb..c5e39d2 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/DAGImpl.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/DAGImpl.java
@@ -1649,10 +1649,7 @@ public class DAGImpl implements org.apache.tez.dag.app.dag.DAG,
       if (!groupInfo.outputs.isEmpty()) {
         // shared outputs
         for (String vertexName : groupInfo.groupMembers) {
-          if (LOG.isDebugEnabled()) {
-            LOG.debug("Setting shared outputs for group: " + groupName +
-                " on vertex: " + vertexName);
-          }
+          LOG.debug("Setting shared outputs for group: {} on vertex: {}", groupName, vertexName);
           Vertex v = getVertex(vertexName);
           v.addSharedOutputs(groupInfo.outputs);
         }
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/TaskAttemptImpl.java b/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/TaskAttemptImpl.java
index 92597d5..36ea33e 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/TaskAttemptImpl.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/TaskAttemptImpl.java
@@ -1226,10 +1226,8 @@ public class TaskAttemptImpl implements TaskAttempt,
           TaskAttemptFinishedEvent taFinishedEvent =
               ta.recoveryData.getTaskAttemptFinishedEvent();
           if (taFinishedEvent == null) {
-            if (LOG.isDebugEnabled()) {
-              LOG.debug("Only TaskAttemptStartedEvent but no TaskAttemptFinishedEvent, "
-                  + "send out TaskAttemptEventAttemptKilled to move it to KILLED");
-            }
+            LOG.debug("Only TaskAttemptStartedEvent but no TaskAttemptFinishedEvent, "
+                + "send out TaskAttemptEventAttemptKilled to move it to KILLED");
             ta.sendEvent(new TaskAttemptEventAttemptKilled(ta.getID(), 
                 "Task Attempt killed in recovery due to can't recover the running task attempt",
                 TaskAttemptTerminationCause.TERMINATED_AT_RECOVERY, true));
@@ -1244,30 +1242,21 @@ public class TaskAttemptImpl implements TaskAttempt,
             + "taskAttemptId=" + ta.getID());
         switch (taFinishedEvent.getState()) {
           case FAILED:
-            if (LOG.isDebugEnabled()) {
-              LOG.debug("TaskAttemptFinishedEvent is seen with state of FAILED"
-                  + ", send TA_FAILED to itself"
-                  + ", attemptId=" + ta.attemptId);
-            }
+            LOG.debug("TaskAttemptFinishedEvent is seen with state of FAILED, "
+                + "send TA_FAILED to itself, attemptId={}", ta.attemptId);
             ta.sendEvent(new TaskAttemptEventAttemptFailed(ta.getID(), TaskAttemptEventType.TA_FAILED,
                 taFinishedEvent.getTaskFailureType(),
                 taFinishedEvent.getDiagnostics(), taFinishedEvent.getTaskAttemptError(), true));
             break;
           case KILLED:
-            if (LOG.isDebugEnabled()) {
-              LOG.debug("TaskAttemptFinishedEvent is seen with state of KILLED"
-                  + ", send TA_KILLED to itself"
-                  + ", attemptId=" + ta.attemptId);
-            }
+            LOG.debug("TaskAttemptFinishedEvent is seen with state of KILLED, "
+                + "send TA_KILLED to itself, attemptId={}", ta.attemptId);
             ta.sendEvent(new TaskAttemptEventAttemptKilled(ta.getID(),
                 taFinishedEvent.getDiagnostics(), taFinishedEvent.getTaskAttemptError(), true));
             break;
           case SUCCEEDED:
-            if (LOG.isDebugEnabled()) {
-              LOG.debug("TaskAttemptFinishedEvent is seen with state of SUCCEEDED"
-                  + ", send TA_DONE to itself"
-                  + ", attemptId=" + ta.attemptId);
-            }
+              LOG.debug("TaskAttemptFinishedEvent is seen with state of SUCCEEDED, "
+                  + "send TA_DONE to itself, attemptId={}", ta.attemptId);
             ta.sendEvent(new TaskAttemptEvent(ta.getID(), TaskAttemptEventType.TA_DONE));
             break;
           default:
@@ -1629,9 +1618,7 @@ public class TaskAttemptImpl implements TaskAttempt,
       if (ta.recoveryData != null && ta.recoveryData.isTaskAttemptSucceeded()) {
         TaskAttemptFinishedEvent taFinishedEvent = ta.recoveryData
             .getTaskAttemptFinishedEvent();
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("TaskAttempt is recovered to SUCCEEDED, attemptId=" + ta.attemptId);
-        }
+        LOG.debug("TaskAttempt is recovered to SUCCEEDED, attemptId={}", ta.attemptId);
         ta.reportedStatus.counters = taFinishedEvent.getCounters();
         List<TezEvent> tezEvents = taFinishedEvent.getTAGeneratedEvents();
         if (tezEvents != null && !tezEvents.isEmpty()) {
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/TaskImpl.java b/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/TaskImpl.java
index 0b4b116..cb8545f 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/TaskImpl.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/TaskImpl.java
@@ -690,9 +690,7 @@ public class TaskImpl implements Task, EventHandler<TaskEvent> {
   public boolean canCommit(TezTaskAttemptID taskAttemptID) {
     writeLock.lock();
     try {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Commit go/no-go request from " + taskAttemptID);
-      }
+      LOG.debug("Commit go/no-go request from {}", taskAttemptID);
       TaskState state = getState();
       if (state == TaskState.SCHEDULED) {
         // the actual running task ran and is done and asking for commit. we are still stuck 
@@ -730,9 +728,7 @@ public class TaskImpl implements Task, EventHandler<TaskEvent> {
         }
       } else {
         if (commitAttempt.equals(taskAttemptID)) {
-          if (LOG.isDebugEnabled()) {
-            LOG.debug(taskAttemptID + " already given a go for committing the task output.");
-          }
+          LOG.debug("{} already given a go for committing the task output.", taskAttemptID);
           return true;
         }
         // Don't think this can be a pluggable decision, so simply raise an
@@ -740,9 +736,7 @@ public class TaskImpl implements Task, EventHandler<TaskEvent> {
         // Wait for commit attempt to succeed. Dont kill this. If commit
         // attempt fails then choose a different committer. When commit attempt
         // succeeds then this and others will be killed
-        if (LOG.isDebugEnabled()) {
-          LOG.debug(commitAttempt + " is current committer. Commit waiting for:  " + taskAttemptID);
-        }
+        LOG.debug("{} is current committer. Commit waiting for: {}", commitAttempt, taskAttemptID);
         return false;
       }
 
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/VertexImpl.java b/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/VertexImpl.java
index 1e8b1c1..47a0caf 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/VertexImpl.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/dag/impl/VertexImpl.java
@@ -879,10 +879,8 @@ public class VertexImpl implements org.apache.tez.dag.app.dag.Vertex, EventHandl
   @Override
   public void initServices() {
     if (servicesInited.get()) {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Skipping Initing services for vertex because already"
-            + " Initialized, name=" + this.vertexName);
-      }
+      LOG.debug("Skipping Initing services for vertex because already"
+          + " Initialized, name={}", this.vertexName);
       return;
     }
     writeLock.lock();
@@ -890,10 +888,7 @@ public class VertexImpl implements org.apache.tez.dag.app.dag.Vertex, EventHandl
       List<AbstractService> servicesToAdd = new ArrayList<>();
       if (isSpeculationEnabled()) {
         // Initialize the speculator
-        if (LOG.isDebugEnabled()) {
-          LOG.debug(
-              "Initing service vertex speculator, name=" + this.vertexName);
-        }
+        LOG.debug("Initing service vertex speculator, name={}", this.vertexName);
         speculator = new LegacySpeculator(vertexConf, getAppContext(), this);
         speculator.init(vertexConf);
         servicesToAdd.add(speculator);
@@ -903,9 +898,7 @@ public class VertexImpl implements org.apache.tez.dag.app.dag.Vertex, EventHandl
     } finally {
       writeLock.unlock();
     }
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Initing service vertex, name=" + this.vertexName);
-    }
+    LOG.debug("Initing service vertex, name={}", this.vertexName);
   }
 
   @Override
@@ -935,9 +928,7 @@ public class VertexImpl implements org.apache.tez.dag.app.dag.Vertex, EventHandl
     try {
       if (servicesInited.get()) {
         for (AbstractService srvc : services) {
-          if (LOG.isDebugEnabled()) {
-            LOG.debug("Stopping service : " + srvc);
-          }
+          LOG.debug("Stopping service : {}", srvc);
           Exception ex = ServiceOperations.stopQuietly(srvc);
           if (ex != null && firstException == null) {
             LOG.warn(String.format(
@@ -1590,7 +1581,7 @@ public class VertexImpl implements org.apache.tez.dag.app.dag.Vertex, EventHandl
       if (LOG.isDebugEnabled()) {
         if (!ProgressHelper.isProgressWithinRange(taskProg)) {
           LOG.debug("progress update: vertex={}, task={} incorrect; range={}",
-              getName(), task.getTaskId().toString(), taskProg);
+              getName(), task.getTaskId(), taskProg);
         }
       }
       accProg += ProgressHelper.processProgress(taskProg);
@@ -2522,11 +2513,8 @@ public class VertexImpl implements org.apache.tez.dag.app.dag.Vertex, EventHandl
         final RootInputLeafOutput<OutputDescriptor, OutputCommitterDescriptor> od = entry.getValue();
         if (od.getControllerDescriptor() == null
             || od.getControllerDescriptor().getClassName() == null) {
-          if (LOG.isDebugEnabled()) {
-            LOG.debug("Ignoring committer as none specified for output="
-                + outputName
-                + ", vertexId=" + logIdentifier);
-          }
+          LOG.debug("Ignoring committer as none specified for output={}, vertexId={}",
+              outputName, logIdentifier);
           continue;
         }
         LOG.info("Instantiating committer for output=" + outputName
@@ -2547,19 +2535,13 @@ public class VertexImpl implements org.apache.tez.dag.app.dag.Vertex, EventHandl
                 .createClazzInstance(od.getControllerDescriptor().getClassName(),
                     new Class[]{OutputCommitterContext.class},
                     new Object[]{outputCommitterContext});
-            if (LOG.isDebugEnabled()) {
-              LOG.debug("Invoking committer init for output=" + outputName
-                  + ", vertex=" + logIdentifier);
-            }
+            LOG.debug("Invoking committer init for output={}, vertex={}", outputName, logIdentifier);
 
             try {
               TezUtilsInternal.setHadoopCallerContext(appContext.getHadoopShim(), vertexId);
               outputCommitter.initialize();
               outputCommitters.put(outputName, outputCommitter);
-              if (LOG.isDebugEnabled()) {
-                LOG.debug("Invoking committer setup for output=" + outputName
-                    + ", vertex=" + logIdentifier);
-              }
+              LOG.debug("Invoking committer setup for output={}, vertex={}", outputName, logIdentifier);
               outputCommitter.setupOutput();
             } finally {
               appContext.getHadoopShim().clearHadoopCallerContext();
@@ -4744,9 +4726,7 @@ public class VertexImpl implements org.apache.tez.dag.app.dag.Vertex, EventHandl
 
     @Override
     public void initialize() throws Exception {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("initialize NoOpVertexManager");
-      }
+      LOG.debug("initialize NoOpVertexManager");
       configurationDoneEvent = new VertexConfigurationDoneEvent();
       configurationDoneEvent.fromProtoStream(CodedInputStream.newInstance(getContext().getUserPayload().deepCopyAsArray()));
       String vertexName = getContext().getVertexName();
@@ -4772,9 +4752,7 @@ public class VertexImpl implements org.apache.tez.dag.app.dag.Vertex, EventHandl
       }
       getContext().doneReconfiguringVertex();
       int numTasks = getContext().getVertexNumTasks(getContext().getVertexName());
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Schedule all the tasks, numTask=" + numTasks);
-      }
+      LOG.debug("Schedule all the tasks, numTask={}", numTasks);
       List<ScheduleTaskRequest> tasks = new ArrayList<ScheduleTaskRequest>();
       for (int i=0;i<numTasks;++i) {
         tasks.add(ScheduleTaskRequest.create(i, null));
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/dag/speculation/legacy/LegacySpeculator.java b/tez-dag/src/main/java/org/apache/tez/dag/app/dag/speculation/legacy/LegacySpeculator.java
index 6bf02df..7aad8f6 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/dag/speculation/legacy/LegacySpeculator.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/dag/speculation/legacy/LegacySpeculator.java
@@ -243,9 +243,7 @@ public class LegacySpeculator extends AbstractService {
               LOG.info("We launched " + speculations
                   + " speculations.  Waiting " + wait + " milliseconds before next evaluation.");
             } else {
-              if (LOG.isDebugEnabled()) {
-                LOG.debug("Waiting {} milliseconds before next evaluation.", wait);
-              }
+              LOG.debug("Waiting {} milliseconds before next evaluation.", wait);
             }
             Thread.sleep(wait);
           } catch (InterruptedException ie) {
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/launcher/TezContainerLauncherImpl.java b/tez-dag/src/main/java/org/apache/tez/dag/app/launcher/TezContainerLauncherImpl.java
index 67fc4ed..f5be746 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/launcher/TezContainerLauncherImpl.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/launcher/TezContainerLauncherImpl.java
@@ -385,9 +385,7 @@ public class TezContainerLauncherImpl extends DagContainerLauncher {
       // Load ContainerManager tokens before creating a connection.
       // TODO: Do it only once per NodeManager.
       ContainerId containerID = event.getBaseOperation().getContainerId();
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Processing ContainerOperation {}", event);
-      }
+      LOG.debug("Processing ContainerOperation {}", event);
 
       Container c = getContainer(event);
       switch(event.getOpType()) {
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/rm/DagAwareYarnTaskScheduler.java b/tez-dag/src/main/java/org/apache/tez/dag/app/rm/DagAwareYarnTaskScheduler.java
index 31a7142..d8b3397 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/rm/DagAwareYarnTaskScheduler.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/rm/DagAwareYarnTaskScheduler.java
@@ -743,7 +743,7 @@ public class DagAwareYarnTaskScheduler extends TaskScheduler
 
       ++numHeartbeats;
       if (LOG.isDebugEnabled() || numHeartbeats % 50 == 1) {
-        LOG.info(constructPeriodicLog(freeResources));
+        LOG.debug(constructPeriodicLog(freeResources));
       }
 
       preemptedContainers = maybePreempt(freeResources);
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/rm/TaskSchedulerManager.java b/tez-dag/src/main/java/org/apache/tez/dag/app/rm/TaskSchedulerManager.java
index 57eba01..cc2e163 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/rm/TaskSchedulerManager.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/rm/TaskSchedulerManager.java
@@ -265,9 +265,7 @@ public class TaskSchedulerManager extends AbstractService implements
   }
 
   public synchronized void handleEvent(AMSchedulerEvent sEvent) {
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Processing the event " + sEvent.toString());
-    }
+    LOG.debug("Processing the event {}", sEvent);
     switch (sEvent.getType()) {
     case S_TA_LAUNCH_REQUEST:
       handleTaLaunchRequest((AMSchedulerEventTALaunchRequest) sEvent);
@@ -861,9 +859,7 @@ public class TaskSchedulerManager extends AbstractService implements
         }
       }
     }
-    if(LOG.isDebugEnabled()) {
-      LOG.debug("Setting job diagnostics to " + sb.toString());
-    }
+    LOG.debug("Setting job diagnostics to {}", sb);
 
     // if history url is set use the same, if historyUrl is set to "" then rm ui disables the
     // history url
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/rm/YarnTaskSchedulerService.java b/tez-dag/src/main/java/org/apache/tez/dag/app/rm/YarnTaskSchedulerService.java
index c9102e9..b4aa561 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/rm/YarnTaskSchedulerService.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/rm/YarnTaskSchedulerService.java
@@ -449,10 +449,8 @@ public class YarnTaskSchedulerService extends TaskScheduler
           // being released
           // completion of a container we had released earlier
           // an allocated container completed. notify app
-          if (LOG.isDebugEnabled()) {
-            LOG.debug("Released container completed:" + completedId +
-                " last allocated to task: " + task);
-          }
+          LOG.debug("Released container completed:{} last allocated to task: {}",
+            completedId, task);
           appContainerStatus.put(task, containerStatus);
           continue;
         }
@@ -1216,12 +1214,9 @@ public class YarnTaskSchedulerService extends TaskScheduler
 
       if(!preemptionWaitDeadlineCrossed && 
           fitsIn(highestPriRequest.getCapability(), freeResources)) {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug(highestPriRequest + " fits in free resources");
-        } else {
-          if (numHeartbeats % 50 == 1) {
-            LOG.info(highestPriRequest + " fits in free resources");
-          }
+        LOG.debug("{} fits in free resources", highestPriRequest);
+        if (numHeartbeats % 50 == 1) {
+          LOG.info(highestPriRequest + " fits in free resources");
         }
         return true;
       }
@@ -1509,10 +1504,8 @@ public class YarnTaskSchedulerService extends TaskScheduler
               if (container.getId().equals(
                   cookieContainerRequest.getAffinitizedContainer())) {
                 // container level match
-                if (LOG.isDebugEnabled()) {
-                  LOG.debug("Matching with affinity for request: "
-                      + cookieContainerRequest + " container: " + affCId);
-                }
+                  LOG.debug("Matching with affinity for request: {} container: {}",
+                    cookieContainerRequest, affCId);
                 return cookieContainerRequest;
               }
               if (LOG.isDebugEnabled()) {
@@ -2025,10 +2018,7 @@ public class YarnTaskSchedulerService extends TaskScheduler
         if (delayedContainer == null) {
           continue;
         }
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Considering HeldContainer: "
-              + delayedContainer + " for assignment");
-        }
+        LOG.debug("Considering HeldContainer: {} for assignment", delayedContainer);
         long currentTs = System.currentTimeMillis();
         long nextScheduleTs = delayedContainer.getNextScheduleTime();
         if (currentTs >= nextScheduleTs) {
@@ -2091,10 +2081,7 @@ public class YarnTaskSchedulerService extends TaskScheduler
         // honor reuse-locality flags (container not timed out yet), Don't queue
         // (already in queue), don't release (release happens when containers
         // time-out)
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Trying to assign all delayed containers to newly received"
-            + " tasks");
-        }
+        LOG.debug("Trying to assign all delayed containers to newly received tasks");
         Iterator<HeldContainer> iter = delayedContainers.iterator();
         while(iter.hasNext()) {
           HeldContainer delayedContainer = iter.next();
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/rm/container/AMContainerHelpers.java b/tez-dag/src/main/java/org/apache/tez/dag/app/rm/container/AMContainerHelpers.java
index ee32265..19cf5b7 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/rm/container/AMContainerHelpers.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/rm/container/AMContainerHelpers.java
@@ -126,9 +126,7 @@ public class AMContainerHelpers {
           containerTokens_dob.getLength());
 
       // Add shuffle token
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Putting shuffle token in serviceData in common CLC");
-      }
+      LOG.debug("Putting shuffle token in serviceData in common CLC");
       serviceData.put(auxiliaryService,
           TezCommonUtils.serializeServiceData(TokenCache.getSessionToken(containerCredentials)));
     } catch (IOException e) {
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/web/AMWebController.java b/tez-dag/src/main/java/org/apache/tez/dag/app/web/AMWebController.java
index 2115dac..08d754d 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/web/AMWebController.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/web/AMWebController.java
@@ -144,9 +144,7 @@ public class AMWebController extends Controller {
         URL url = new URL(historyUrlBase);
         origin = url.getProtocol() + "://" + url.getAuthority();
       } catch (MalformedURLException e) {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Invalid url set for tez history url base: " + historyUrlBase, e);
-        }
+        LOG.debug("Invalid url set for tez history url base: {}", historyUrlBase, e);
       }
     }
 
@@ -161,9 +159,7 @@ public class AMWebController extends Controller {
   }
 
   void sendErrorResponse(int sc, String msg, Exception e) {
-    if (LOG.isDebugEnabled()) {
-      LOG.debug(msg, e);
-    }
+    LOG.debug(msg, e);
 
     try {
       response().sendError(sc, msg);
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/app/web/WebUIService.java b/tez-dag/src/main/java/org/apache/tez/dag/app/web/WebUIService.java
index b1560a5..1670370 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/app/web/WebUIService.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/app/web/WebUIService.java
@@ -119,9 +119,7 @@ public class WebUIService extends AbstractService {
   @Override
   protected void serviceStop() throws Exception {
     if (this.webApp != null) {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Stopping WebApp");
-      }
+      LOG.debug("Stopping WebApp");
       this.webApp.stop();
     }
     super.serviceStop();
diff --git a/tez-dag/src/main/java/org/apache/tez/dag/history/recovery/RecoveryService.java b/tez-dag/src/main/java/org/apache/tez/dag/history/recovery/RecoveryService.java
index a0a152c..45e7d2f 100644
--- a/tez-dag/src/main/java/org/apache/tez/dag/history/recovery/RecoveryService.java
+++ b/tez-dag/src/main/java/org/apache/tez/dag/history/recovery/RecoveryService.java
@@ -405,11 +405,8 @@ public class RecoveryService extends AbstractService {
   protected void handleSummaryEvent(TezDAGID dagID,
       HistoryEventType eventType,
       SummaryEvent summaryEvent) throws IOException {
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Handling summary event"
-          + ", dagID=" + dagID
-          + ", eventType=" + eventType);
-    }
+      LOG.debug("Handling summary event, dagID={}, eventType={}", dagID, eventType);
+
     if (summaryStream == null) {
       Path summaryPath = TezCommonUtils.getSummaryRecoveryPath(recoveryPath);
       if (LOG.isDebugEnabled()) {
@@ -470,11 +467,8 @@ public class RecoveryService extends AbstractService {
     }
 
 
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Writing recovery event to output stream"
-          + ", dagId=" + dagID
-          + ", eventType=" + eventType);
-    }
+    LOG.debug("Writing recovery event to output stream, dagId={}, eventType={}",
+      dagID, eventType);
     ++unflushedEventsCount;
     recoveryStream.codedOutputStream.writeFixed32NoTag(event.getHistoryEvent().getEventType().ordinal());
     event.getHistoryEvent().toProtoStream(recoveryStream.codedOutputStream);
@@ -489,11 +483,9 @@ public class RecoveryService extends AbstractService {
     boolean doFlush = false;
     if (maxUnflushedEvents >=0
         && unflushedEventsCount >= maxUnflushedEvents) {
-      if  (LOG.isDebugEnabled()) {
-        LOG.debug("Max unflushed events count reached. Flushing recovery data"
-            + ", unflushedEventsCount=" + unflushedEventsCount
-            + ", maxUnflushedEvents=" + maxUnflushedEvents);
-      }
+        LOG.debug("Max unflushed events count reached. Flushing recovery data, "
+            + "unflushedEventsCount={}, maxUnflushedEvents={}", unflushedEventsCount,
+            maxUnflushedEvents);
       doFlush = true;
     } else if (flushInterval >= 0
         && ((currentTime - lastFlushTime) >= (flushInterval*1000))) {
diff --git a/tez-mapreduce/src/main/java/org/apache/hadoop/mapred/split/TezGroupedSplitsInputFormat.java b/tez-mapreduce/src/main/java/org/apache/hadoop/mapred/split/TezGroupedSplitsInputFormat.java
index bce16ee..61e1f6c 100644
--- a/tez-mapreduce/src/main/java/org/apache/hadoop/mapred/split/TezGroupedSplitsInputFormat.java
+++ b/tez-mapreduce/src/main/java/org/apache/hadoop/mapred/split/TezGroupedSplitsInputFormat.java
@@ -68,25 +68,19 @@ public class TezGroupedSplitsInputFormat<K, V>
   public void setSplitSizeEstimator(SplitSizeEstimator estimator) {
     Preconditions.checkArgument(estimator != null);
     this.estimator = estimator;
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Split size estimator : " + estimator);
-    }
+    LOG.debug("Split size estimator : {}", estimator);
   }
 
   public void setSplitLocationProvider(SplitLocationProvider locationProvider) {
     Preconditions.checkArgument(locationProvider != null);
     this.locationProvider = locationProvider;
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Split size location provider: " + locationProvider);
-    }
+    LOG.debug("Split size location provider: {}", locationProvider);
   }
   
   public void setDesiredNumberOfSplits(int num) {
     Preconditions.checkArgument(num >= 0);
     this.desiredNumSplits = num;
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("desiredNumSplits: " + desiredNumSplits);
-    }
+    LOG.debug("desiredNumSplits: {}", desiredNumSplits);
   }
   
   @Override
diff --git a/tez-mapreduce/src/main/java/org/apache/hadoop/mapreduce/split/TezGroupedSplitsInputFormat.java b/tez-mapreduce/src/main/java/org/apache/hadoop/mapreduce/split/TezGroupedSplitsInputFormat.java
index 226425c..863f9aa 100644
--- a/tez-mapreduce/src/main/java/org/apache/hadoop/mapreduce/split/TezGroupedSplitsInputFormat.java
+++ b/tez-mapreduce/src/main/java/org/apache/hadoop/mapreduce/split/TezGroupedSplitsInputFormat.java
@@ -70,25 +70,19 @@ public class TezGroupedSplitsInputFormat<K, V> extends InputFormat<K, V>
   public void setDesiredNumberOfSplits(int num) {
     Preconditions.checkArgument(num >= 0);
     this.desiredNumSplits = num;
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("desiredNumSplits: " + desiredNumSplits);
-    }
+    LOG.debug("desiredNumSplits: {}", desiredNumSplits);
   }
 
   public void setSplitSizeEstimator(SplitSizeEstimator estimator) {
     Preconditions.checkArgument(estimator != null);
     this.estimator = estimator;
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Split size estimator : " + estimator);
-    }
+    LOG.debug("Split size estimator : {}", estimator);
   }
 
   public void setSplitLocationProvider(SplitLocationProvider locationProvider) {
     Preconditions.checkArgument(locationProvider != null);
     this.locationProvider = locationProvider;
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Split location provider : " + locationProvider);
-    }
+    LOG.debug("Split location provider : {}", locationProvider);
   }
 
   @Override
diff --git a/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/client/YARNRunner.java b/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/client/YARNRunner.java
index 00a68cd..127a629 100644
--- a/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/client/YARNRunner.java
+++ b/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/client/YARNRunner.java
@@ -616,9 +616,7 @@ public class YARNRunner implements ClientProtocol {
     dagAMConf.set(TezConfiguration.TEZ_AM_LAUNCH_CMD_OPTS, javaOpts.toString());
     if (envStr.length() > 0) {
       dagAMConf.set(TezConfiguration.TEZ_AM_LAUNCH_ENV, envStr);
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Setting MR AM env to : " + envStr);
-      }
+      LOG.debug("Setting MR AM env to : {}", envStr);
     }
 
     // Submit to ResourceManager
diff --git a/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/hadoop/MRInputHelpers.java b/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/hadoop/MRInputHelpers.java
index 19d64a5..a8e85a3 100644
--- a/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/hadoop/MRInputHelpers.java
+++ b/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/hadoop/MRInputHelpers.java
@@ -322,18 +322,14 @@ public class MRInputHelpers {
     InputSplitInfoMem splitInfoMem = null;
     JobConf jobConf = new JobConf(conf);
     if (jobConf.getUseNewMapper()) {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Generating mapreduce api input splits");
-      }
+      LOG.debug("Generating mapreduce api input splits");
       Job job = Job.getInstance(conf);
       org.apache.hadoop.mapreduce.InputSplit[] splits =
           generateNewSplits(job, groupSplits, sortSplits, targetTasks);
       splitInfoMem = new InputSplitInfoMem(splits, createTaskLocationHintsFromSplits(splits),
           splits.length, job.getCredentials(), job.getConfiguration());
     } else {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Generating mapred api input splits");
-      }
+      LOG.debug("Generating mapred api input splits");
       org.apache.hadoop.mapred.InputSplit[] splits =
           generateOldSplits(jobConf, groupSplits, sortSplits, targetTasks);
       splitInfoMem = new InputSplitInfoMem(splits, createTaskLocationHintsFromSplits(splits),
diff --git a/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/output/MROutput.java b/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/output/MROutput.java
index 18047eb..d5c0517 100644
--- a/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/output/MROutput.java
+++ b/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/output/MROutput.java
@@ -486,9 +486,7 @@ public class MROutput extends AbstractLogicalOutput {
       throws IOException, InterruptedException {
 
     if (useNewApi) {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("using new api for output committer");
-      }
+      LOG.debug("using new api for output committer");
 
       this.committer = newOutputFormat.getOutputCommitter(
           newApiTaskAttemptContext);
diff --git a/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/processor/MRTask.java b/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/processor/MRTask.java
index b79f19c..1a13168 100644
--- a/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/processor/MRTask.java
+++ b/tez-mapreduce/src/main/java/org/apache/tez/mapreduce/processor/MRTask.java
@@ -509,10 +509,7 @@ public abstract class MRTask extends AbstractLogicalIOProcessor {
           comparator,
           keyClass,
           valueClass);
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Using key class: " + keyClass
-          + ", valueClass: " + valueClass);
-    }
+    LOG.debug("Using key class: {}, valueClass: {}", keyClass, valueClass);
 
     org.apache.hadoop.mapreduce.Reducer<INKEY,INVALUE,OUTKEY,OUTVALUE>.Context
         reducerContext =
diff --git a/tez-plugins/tez-aux-services/src/main/java/org/apache/tez/auxservices/IndexCache.java b/tez-plugins/tez-aux-services/src/main/java/org/apache/tez/auxservices/IndexCache.java
index 625f7ab..54db975 100644
--- a/tez-plugins/tez-aux-services/src/main/java/org/apache/tez/auxservices/IndexCache.java
+++ b/tez-plugins/tez-aux-services/src/main/java/org/apache/tez/auxservices/IndexCache.java
@@ -84,9 +84,7 @@ class IndexCache {
           }
         }
       }
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("IndexCache HIT: MapId " + mapId + " found");
-      }
+      LOG.debug("IndexCache HIT: MapId {} found", mapId);
     }
 
     if (info.mapSpillRecord.size() == 0) {
@@ -125,9 +123,7 @@ class IndexCache {
           }
         }
       }
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("IndexCache HIT: MapId " + mapId + " found");
-      }
+      LOG.debug("IndexCache HIT: MapId {} found", mapId);
     }
 
     if (info.mapSpillRecord.size() == 0 ||
@@ -161,14 +157,11 @@ class IndexCache {
           }
         }
       }
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("IndexCache HIT: MapId " + mapId + " found");
-      }
+      LOG.debug("IndexCache HIT: MapId {} found", mapId);
       return info;
     }
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("IndexCache MISS: MapId " + mapId + " not found");
-    }
+    LOG.debug("IndexCache MISS: MapId {} not found", mapId);
+
     TezSpillRecord tmp = null;
     try {
       tmp = new TezSpillRecord(indexFileName, fs, expectedIndexOwner);
diff --git a/tez-plugins/tez-aux-services/src/main/java/org/apache/tez/auxservices/ShuffleHandler.java b/tez-plugins/tez-aux-services/src/main/java/org/apache/tez/auxservices/ShuffleHandler.java
index 3ce294d..c4c2970 100644
--- a/tez-plugins/tez-aux-services/src/main/java/org/apache/tez/auxservices/ShuffleHandler.java
+++ b/tez-plugins/tez-aux-services/src/main/java/org/apache/tez/auxservices/ShuffleHandler.java
@@ -926,9 +926,7 @@ public class ShuffleHandler extends AuxiliaryService {
           Path mapOutputFileName = lDirAlloc.getLocalPathToRead(
               attemptBase + Path.SEPARATOR + DATA_FILE_NAME, conf);
 
-          if (LOG.isDebugEnabled()) {
-            LOG.debug("Loaded : " + key + " via loader");
-          }
+          LOG.debug("Loaded : {} via loader", key);
           return new AttemptPathInfo(indexFileName, mapOutputFileName);
         }
       });
@@ -1004,10 +1002,7 @@ public class ShuffleHandler extends AuxiliaryService {
       boolean keepAliveParam = false;
       if (keepAliveList != null && keepAliveList.size() == 1) {
         keepAliveParam = Boolean.parseBoolean(keepAliveList.get(0));
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("KeepAliveParam : " + keepAliveList
-            + " : " + keepAliveParam);
-        }
+        LOG.debug("KeepAliveParam : {} : {}", keepAliveList, keepAliveParam);
       }
       final List<String> mapIds = splitMaps(q.get("map"));
       final Range reduceRange = splitReduces(q.get("reduce"));
@@ -1211,11 +1206,8 @@ public class ShuffleHandler extends AuxiliaryService {
         AttemptPathIdentifier identifier = new AttemptPathIdentifier(
             jobId, dagId, user, mapId);
         pathInfo = pathCache.get(identifier);
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Retrieved pathInfo for " + identifier +
-              " check for corresponding loaded messages to determine whether" +
-              " it was loaded or cached");
-        }
+        LOG.debug("Retrieved pathInfo for {} check for corresponding loaded " +
+            "messages to determine whether it was loaded or cached", identifier);
       } catch (ExecutionException e) {
         if (e.getCause() instanceof IOException) {
           throw (IOException) e.getCause();
@@ -1288,13 +1280,9 @@ public class ShuffleHandler extends AuxiliaryService {
         response.setHeader(HttpHeaders.Names.CONTENT_LENGTH, String.valueOf(contentLength));
         response.setHeader(HttpHeaders.Names.CONNECTION, HttpHeaders.Values.KEEP_ALIVE);
         response.setHeader(HttpHeaders.Values.KEEP_ALIVE, "timeout=" + connectionKeepAliveTimeOut);
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Content Length in shuffle : " + contentLength);
-        }
+        LOG.debug("Content Length in shuffle : {}", contentLength);
       } else {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Setting connection close header...");
-        }
+        LOG.debug("Setting connection close header...");
         response.setHeader(HttpHeaders.Names.CONNECTION, CONNECTION_CLOSE);
       }
     }
diff --git a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/LogicalIOProcessorRuntimeTask.java b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/LogicalIOProcessorRuntimeTask.java
index 44cd320..224d8b3 100644
--- a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/LogicalIOProcessorRuntimeTask.java
+++ b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/LogicalIOProcessorRuntimeTask.java
@@ -460,9 +460,7 @@ public class LogicalIOProcessorRuntimeTask extends RuntimeTask {
     }
 
     protected Void _callInternal() throws Exception {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Initializing Input using InputSpec: " + inputSpec);
-      }
+      LOG.debug("Initializing Input using InputSpec: {}", inputSpec);
       String edgeName = inputSpec.getSourceVertexName();
       InputContext inputContext = createInputContext(inputsMap, inputSpec, inputIndex);
       LogicalInput input = createInput(inputSpec, inputContext);
@@ -476,9 +474,7 @@ public class LogicalIOProcessorRuntimeTask extends RuntimeTask {
           inputContext.getTaskVertexName(), inputContext.getSourceVertexName(),
           taskSpec.getTaskAttemptID());
       initializedInputs.put(edgeName, input);
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Initialized Input with src edge: " + edgeName);
-      }
+      LOG.debug("Initialized Input with src edge: {}", edgeName);
       initializedInputs.put(edgeName, input);
       return null;
     }
@@ -505,9 +501,7 @@ public class LogicalIOProcessorRuntimeTask extends RuntimeTask {
     }
 
     protected Void _callInternal() throws Exception {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Starting Input with src edge: " + srcVertexName);
-      }
+      LOG.debug("Starting Input with src edge: {}", srcVertexName);
 
       input.start();
       LOG.info("Started Input with src edge: " + srcVertexName);
@@ -537,9 +531,7 @@ public class LogicalIOProcessorRuntimeTask extends RuntimeTask {
     }
 
     protected Void _callInternal() throws Exception {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Initializing Output using OutputSpec: " + outputSpec);
-      }
+      LOG.debug("Initializing Output using OutputSpec: {}", outputSpec);
       String edgeName = outputSpec.getDestinationVertexName();
       OutputContext outputContext = createOutputContext(outputSpec, outputIndex);
       LogicalOutput output = createOutput(outputSpec, outputContext);
@@ -552,9 +544,7 @@ public class LogicalIOProcessorRuntimeTask extends RuntimeTask {
           outputContext.getTaskVertexName(),
           outputContext.getDestinationVertexName(), taskSpec.getTaskAttemptID());
       initializedOutputs.put(edgeName, output);
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Initialized Output with dest edge: " + edgeName);
-      }
+      LOG.debug("Initialized Output with dest edge: {}", edgeName);
       initializedOutputs.put(edgeName, output);
       return null;
     }
@@ -572,9 +562,7 @@ public class LogicalIOProcessorRuntimeTask extends RuntimeTask {
     if (groupInputSpecs != null && !groupInputSpecs.isEmpty()) {
      groupInputsMap = new ConcurrentHashMap<String, MergedLogicalInput>(groupInputSpecs.size());
      for (GroupInputSpec groupInputSpec : groupInputSpecs) {
-       if (LOG.isDebugEnabled()) {
-         LOG.debug("Initializing GroupInput using GroupInputSpec: " + groupInputSpec);
-       }
+       LOG.debug("Initializing GroupInput using GroupInputSpec: {}", groupInputSpec);
        MergedInputContext mergedInputContext =
            new TezMergedInputContextImpl(groupInputSpec.getMergedInputDescriptor().getUserPayload(),
                groupInputSpec.getGroupName(), groupInputsMap, inputReadyTracker, localDirs, this);
diff --git a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/api/impl/TezInputContextImpl.java b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/api/impl/TezInputContextImpl.java
index 9ff284d..f28573a 100644
--- a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/api/impl/TezInputContextImpl.java
+++ b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/api/impl/TezInputContextImpl.java
@@ -187,8 +187,6 @@ public class TezInputContextImpl extends TezTaskContextImpl
     super.close();
     this.userPayload = null;
     this.inputReadyTracker = null;
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Cleared TezInputContextImpl related information");
-    }
+    LOG.debug("Cleared TezInputContextImpl related information");
   }
 }
diff --git a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/api/impl/TezOutputContextImpl.java b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/api/impl/TezOutputContextImpl.java
index db32122..ec8280a 100644
--- a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/api/impl/TezOutputContextImpl.java
+++ b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/api/impl/TezOutputContextImpl.java
@@ -167,8 +167,6 @@ public class TezOutputContextImpl extends TezTaskContextImpl
   public void close() throws IOException {
     super.close();
     this.userPayload = null;
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Cleared TezOutputContextImpl related information");
-    }
+    LOG.debug("Cleared TezOutputContextImpl related information");
   }
 }
diff --git a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/api/impl/TezProcessorContextImpl.java b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/api/impl/TezProcessorContextImpl.java
index 71ed077..e09aa83 100644
--- a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/api/impl/TezProcessorContextImpl.java
+++ b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/api/impl/TezProcessorContextImpl.java
@@ -143,9 +143,7 @@ public class TezProcessorContextImpl extends TezTaskContextImpl implements Proce
     super.close();
     this.userPayload = null;
     this.inputReadyTracker = null;
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Cleared TezProcessorContextImpl related information");
-    }
+    LOG.debug("Cleared TezProcessorContextImpl related information");
   }
 
 }
diff --git a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/common/resources/ScalingAllocator.java b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/common/resources/ScalingAllocator.java
index 872632e..e045abd 100644
--- a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/common/resources/ScalingAllocator.java
+++ b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/common/resources/ScalingAllocator.java
@@ -80,16 +80,11 @@ public class ScalingAllocator implements InitialMemoryAllocator {
       long requestedSize = request.getRequestedSize();
       if (requestedSize == 0) {
         allocations.add(0l);
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Scaling requested: 0 to allocated: 0");
-        }
+        LOG.debug("Scaling requested: 0 to allocated: 0");
       } else {
         long allocated = (long) ((requestedSize / (double) totalRequested) * availableForAllocation);
         allocations.add(allocated);
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Scaling requested: " + requestedSize + " to allocated: " + allocated);  
-        }
-
+        LOG.debug("Scaling requested: {} to allocated: {}", requestedSize, allocated);  
       }
     }
     return allocations;
diff --git a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/task/TaskReporter.java b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/task/TaskReporter.java
index fb066fd..978942d 100644
--- a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/task/TaskReporter.java
+++ b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/task/TaskReporter.java
@@ -264,16 +264,12 @@ public class TaskReporter implements TaskReporterInterface {
       int maxEvents = Math.min(maxEventsToGet, task.getMaxEventsToHandle());
       TezHeartbeatRequest request = new TezHeartbeatRequest(requestId, events, fromPreRoutedEventId,
           containerIdStr, task.getTaskAttemptID(), fromEventId, maxEvents);
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Sending heartbeat to AM, request=" + request);
-      }
+      LOG.debug("Sending heartbeat to AM, request={}", request);
 
       maybeLogCounters();
 
       TezHeartbeatResponse response = umbilical.heartbeat(request);
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Received heartbeat response from AM, response=" + response);
-      }
+      LOG.debug("Received heartbeat response from AM, response={}", response);
 
       if (response.shouldDie()) {
         LOG.info("Received should die response from AM");
diff --git a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/task/TezChild.java b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/task/TezChild.java
index 4bba139..f11a034 100644
--- a/tez-runtime-internals/src/main/java/org/apache/tez/runtime/task/TezChild.java
+++ b/tez-runtime-internals/src/main/java/org/apache/tez/runtime/task/TezChild.java
@@ -334,9 +334,7 @@ public class TezChild {
       UserGroupInformation ugi) throws IOException, TezException {
 
     final Map<String, TezLocalResource> additionalResources = containerTask.getAdditionalResources();
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Additional Resources added to container: " + additionalResources);
-    }
+    LOG.debug("Additional Resources added to container: {}", additionalResources);
 
     if (additionalResources != null && !additionalResources.isEmpty()) {
       LOG.info("Localizing additional local resources for Task : " + additionalResources);
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/http/HttpConnection.java b/tez-runtime-library/src/main/java/org/apache/tez/http/HttpConnection.java
index 3b45cdd..e12331c 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/http/HttpConnection.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/http/HttpConnection.java
@@ -77,9 +77,7 @@ public class HttpConnection extends BaseHttpConnection {
     this.url = url;
     this.stopWatch = new StopWatch();
     this.urlLogCount = new AtomicLong();
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("MapOutput URL :" + url.toString());
-    }
+    LOG.debug("MapOutput URL :{}", url);
   }
 
   @VisibleForTesting
@@ -278,9 +276,7 @@ public class HttpConnection extends BaseHttpConnection {
     stopWatch.reset().start();
     try {
       if (input != null) {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Closing input on " + logIdentifier);
-        }
+        LOG.debug("Closing input on {}", logIdentifier);
         input.close();
         input = null;
       }
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/http/async/netty/AsyncHttpConnection.java b/tez-runtime-library/src/main/java/org/apache/tez/http/async/netty/AsyncHttpConnection.java
index 1bf0b2c..feae8ab 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/http/async/netty/AsyncHttpConnection.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/http/async/netty/AsyncHttpConnection.java
@@ -114,9 +114,7 @@ public class AsyncHttpConnection extends BaseHttpConnection {
     this.httpConnParams = connParams;
     this.url = url;
     this.stopWatch = new StopWatch();
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("MapOutput URL :" + url.toString());
-    }
+    LOG.debug("MapOutput URL :{}", url);
 
     initClient(httpConnParams);
     pos = new PipedOutputStream();
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/TezRuntimeUtils.java b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/TezRuntimeUtils.java
index c9ddb6c..b33b4cd 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/TezRuntimeUtils.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/TezRuntimeUtils.java
@@ -80,9 +80,7 @@ public class TezRuntimeUtils {
     if (className == null) {
       return null;
     }
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Using Combiner class: " + className);
-    }
+    LOG.debug("Using Combiner class: {}", className);
     try {
       clazz = (Class<? extends Combiner>) conf.getClassByName(className);
     } catch (ClassNotFoundException e) {
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/ShuffleUtils.java b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/ShuffleUtils.java
index 1b93c91..c088a25 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/ShuffleUtils.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/ShuffleUtils.java
@@ -121,10 +121,7 @@ public class ShuffleUtils {
       IFile.Reader.readToMemory(shuffleData, input, compressedLength, codec,
           ifileReadAhead, ifileReadAheadLength);
       // metrics.inputBytes(shuffleData.length);
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Read " + shuffleData.length + " bytes from input for "
-            + identifier);
-      }
+      LOG.debug("Read {} bytes from input for {}", shuffleData.length, identifier);
     } catch (InternalError | Exception e) {
       // Close the streams
       LOG.info("Failed to read data to memory for " + identifier + ". len=" + compressedLength +
@@ -200,8 +197,7 @@ public class ShuffleUtils {
       try {
         c.close();
       } catch (IOException e) {
-        if (LOG.isDebugEnabled())
-          LOG.debug("Exception in closing " + c, e);
+        LOG.debug("Exception in closing {}", c, e);
       }
     }
   }
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/impl/ShuffleInputEventHandlerImpl.java b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/impl/ShuffleInputEventHandlerImpl.java
index 542ec34..ca01a76 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/impl/ShuffleInputEventHandlerImpl.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/impl/ShuffleInputEventHandlerImpl.java
@@ -176,10 +176,8 @@ public class ShuffleInputEventHandlerImpl implements ShuffleEventHandler {
       if (emptyPartitionsBitSet.get(srcIndex)) {
         CompositeInputAttemptIdentifier srcAttemptIdentifier =
             constructInputAttemptIdentifier(dme.getTargetIndex(), 1, dme.getVersion(), shufflePayload, false);
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Source partition: " + srcIndex + " did not generate any data. SrcAttempt: ["
-              + srcAttemptIdentifier + "]. Not fetching.");
-        }
+        LOG.debug("Source partition: {} did not generate any data. SrcAttempt: [{}]. Not fetching.",
+          srcIndex, srcAttemptIdentifier);
         numDmeEventsNoData.getAndIncrement();
         shuffleManager.addCompletedInputWithNoData(srcAttemptIdentifier.expand(0));
         return;
@@ -210,10 +208,8 @@ public class ShuffleInputEventHandlerImpl implements ShuffleEventHandler {
         allPartitionsEmpty &= emptyPartitionsBitSet.get(srcPartitionId);
         if (emptyPartitionsBitSet.get(srcPartitionId)) {
           InputAttemptIdentifier srcAttemptIdentifier = compositeInputAttemptIdentifier.expand(i);
-          if (LOG.isDebugEnabled()) {
-            LOG.debug("Source partition: " + srcPartitionId + " did not generate any data. SrcAttempt: ["
-                + srcAttemptIdentifier + "]. Not fetching.");
-          }
+          LOG.debug("Source partition: {} did not generate any data. SrcAttempt: [{}]. Not fetching.",
+            srcPartitionId, srcAttemptIdentifier);
           numDmeEventsNoData.getAndIncrement();
           shuffleManager.addCompletedInputWithNoData(srcAttemptIdentifier);
         }
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/impl/ShuffleManager.java b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/impl/ShuffleManager.java
index 0905f9d..9b65103 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/impl/ShuffleManager.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/impl/ShuffleManager.java
@@ -341,9 +341,7 @@ public class ShuffleManager implements FetcherCallback {
           break;
         }
 
-        if (LOG.isDebugEnabled()) {
-          LOG.debug(srcNameTrimmed + ": " + "NumCompletedInputs: " + numCompletedInputs);
-        }
+        LOG.debug("{}: NumCompletedInputs: {}", srcNameTrimmed, numCompletedInputs);
         if (numCompletedInputs.get() < numInputs && !isShutdown.get()) {
           lock.lock();
           try {
@@ -561,9 +559,7 @@ public class ShuffleManager implements FetcherCallback {
   public void addCompletedInputWithNoData(
       InputAttemptIdentifier srcAttemptIdentifier) {
     int inputIdentifier = srcAttemptIdentifier.getInputIdentifier();
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("No input data exists for SrcTask: " + inputIdentifier + ". Marking as complete.");
-    }
+    LOG.debug("No input data exists for SrcTask: {}. Marking as complete.", inputIdentifier);
     lock.lock();
     try {
       if (!completedInputSet.get(inputIdentifier)) {
@@ -980,9 +976,7 @@ public class ShuffleManager implements FetcherCallback {
     @Override
     public void onFailure(Throwable t) {
       if (isShutdown.get()) {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug(srcNameTrimmed + ": " + "Already shutdown. Ignoring error: " + t);
-        }
+        LOG.debug("{}: Already shutdown. Ignoring error.", srcNameTrimmed, t);
       } else {
         LOG.error(srcNameTrimmed + ": " + "Scheduler failed with error: ", t);
         inputContext.reportFailure(TaskFailureType.NON_FATAL, t, "Shuffle Scheduler Failed");
@@ -1013,9 +1007,7 @@ public class ShuffleManager implements FetcherCallback {
     public void onSuccess(FetchResult result) {
       fetcher.shutdown();
       if (isShutdown.get()) {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug(srcNameTrimmed + ": " + "Already shutdown. Ignoring event from fetcher");
-        }
+        LOG.debug("{}: Already shutdown. Ignoring event from fetcher", srcNameTrimmed);
       } else {
         Iterable<InputAttemptIdentifier> pendingInputs = result.getPendingInputs();
         if (pendingInputs != null && pendingInputs.iterator().hasNext()) {
@@ -1038,9 +1030,7 @@ public class ShuffleManager implements FetcherCallback {
       // Unsuccessful - the fetcher may not have shutdown correctly. Try shutting it down.
       fetcher.shutdown();
       if (isShutdown.get()) {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug(srcNameTrimmed + ": " + "Already shutdown. Ignoring error from fetcher: " + t);
-        }
+        LOG.debug("{}: Already shutdown. Ignoring error from fetcher.", srcNameTrimmed, t);
       } else {
         LOG.error(srcNameTrimmed + ": " + "Fetcher failed with error: ", t);
         shuffleError = t;
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/FetcherOrderedGrouped.java b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/FetcherOrderedGrouped.java
index 6b8ccb0..1fcd621 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/FetcherOrderedGrouped.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/FetcherOrderedGrouped.java
@@ -208,9 +208,7 @@ class FetcherOrderedGrouped extends CallableWithNdc<Void> {
 
   public void shutDown() {
     if (!stopped) {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Fetcher stopped for host " + mapHost);
-      }
+      LOG.debug("Fetcher stopped for host {}", mapHost);
       stopped = true;
       // An interrupt will come in while shutting down the thread.
       cleanupCurrentConnection(false);
@@ -287,19 +285,14 @@ class FetcherOrderedGrouped extends CallableWithNdc<Void> {
           // Setup connection again if disconnected
           cleanupCurrentConnection(true);
           if (stopped) {
-            if (LOG.isDebugEnabled()) {
-              LOG.debug("Not re-establishing connection since Fetcher has been stopped");
-            }
+            LOG.debug("Not re-establishing connection since Fetcher has been stopped");
             return;
           }
           // Connect with retry
           if (!setupConnection(host, remaining.values())) {
             if (stopped) {
               cleanupCurrentConnection(true);
-              if (LOG.isDebugEnabled()) {
-                LOG.debug(
-                    "Not reporting connection re-establishment failure since fetcher is stopped");
-              }
+              LOG.debug("Not reporting connection re-establishment failure since fetcher is stopped");
               return;
             }
             failedTasks = new InputAttemptIdentifier[] {getNextRemainingAttempt()};
@@ -347,9 +340,7 @@ class FetcherOrderedGrouped extends CallableWithNdc<Void> {
       connectSucceeded = httpConnection.connect();
 
       if (stopped) {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Detected fetcher has been shutdown after connection establishment. Returning");
-        }
+        LOG.debug("Detected fetcher has been shutdown after connection establishment. Returning");
         return false;
       }
       input = httpConnection.getInputStream();
@@ -360,9 +351,7 @@ class FetcherOrderedGrouped extends CallableWithNdc<Void> {
         Thread.currentThread().interrupt(); //reset status
       }
       if (stopped) {
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Not reporting fetch failure, since an Exception was caught after shutdown");
-        }
+        LOG.debug("Not reporting fetch failure, since an Exception was caught after shutdown");
         return false;
       }
       ioErrs.increment(1);
@@ -454,9 +443,7 @@ class FetcherOrderedGrouped extends CallableWithNdc<Void> {
                   InputAttemptIdentifier.PATH_PREFIX + ", partition: " + header.forReduce);
               return new InputAttemptIdentifier[]{getNextRemainingAttempt()};
             } else {
-              if (LOG.isDebugEnabled()) {
-                LOG.debug("Already shutdown. Ignoring invalid map id error");
-              }
+              LOG.debug("Already shutdown. Ignoring invalid map id error");
               return EMPTY_ATTEMPT_ID_ARRAY;
             }
           }
@@ -499,9 +486,7 @@ class FetcherOrderedGrouped extends CallableWithNdc<Void> {
             assert (srcAttemptId != null);
             return new InputAttemptIdentifier[]{srcAttemptId};
           } else {
-            if (LOG.isDebugEnabled()) {
-              LOG.debug("Already stopped. Ignoring verification failure.");
-            }
+            LOG.debug("Already stopped. Ignoring verification failure.");
             return EMPTY_ATTEMPT_ID_ARRAY;
           }
         }
@@ -525,9 +510,7 @@ class FetcherOrderedGrouped extends CallableWithNdc<Void> {
             ioErrs.increment(1);
             scheduler.reportLocalError(e);
           } else {
-            if (LOG.isDebugEnabled()) {
-              LOG.debug("Already stopped. Ignoring error from merger.reserve");
-            }
+            LOG.debug("Already stopped. Ignoring error from merger.reserve");
           }
           return EMPTY_ATTEMPT_ID_ARRAY;
         }
@@ -738,10 +721,7 @@ class FetcherOrderedGrouped extends CallableWithNdc<Void> {
               LOG.warn("Failed to read local disk output of " + srcAttemptId + " from " +
                   host.getHostIdentifier(), e);
             } else {
-              if (LOG.isDebugEnabled()) {
-                LOG.debug(
-                    "Ignoring fetch error during local disk copy since fetcher has already been stopped");
-              }
+              LOG.debug("Ignoring fetch error during local disk copy since fetcher has already been stopped");
               return;
             }
 
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/MergeManager.java b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/MergeManager.java
index 78ce3e8..4a6e94f 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/MergeManager.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/MergeManager.java
@@ -378,9 +378,7 @@ public class MergeManager implements FetchedInputAllocatorOrderedGrouped {
     }
     if (triggerAdditionalMerge) {
       inMemoryMerger.waitForMerge();
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Additional in-memory merge triggered");
-      }
+      LOG.debug("Additional in-memory merge triggered");
     }
   }
 
@@ -690,9 +688,7 @@ public class MergeManager implements FetchedInputAllocatorOrderedGrouped {
     }
 
     try {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Deleting " + path);
-      }
+      LOG.debug("Deleting {}", path);
       fs.delete(path, true);
     } catch (IOException e) {
       LOG.info("Error in deleting " + path);
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/ShuffleInputEventHandlerOrderedGrouped.java b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/ShuffleInputEventHandlerOrderedGrouped.java
index 116098f..0c55a3a 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/ShuffleInputEventHandlerOrderedGrouped.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/ShuffleInputEventHandlerOrderedGrouped.java
@@ -156,11 +156,8 @@ public class ShuffleInputEventHandlerOrderedGrouped implements ShuffleEventHandl
     if (shufflePayload.hasEmptyPartitions()) {
       try {
         if (emptyPartitionsBitSet.get(partitionId)) {
-          if (LOG.isDebugEnabled()) {
-            LOG.debug(
-                "Source partition: " + partitionId + " did not generate any data. SrcAttempt: ["
-                    + srcAttemptIdentifier + "]. Not fetching.");
-          }
+          LOG.debug("Source partition: {} did not generate any data. SrcAttempt: [{}]. Not fetching.",
+               partitionId, srcAttemptIdentifier);
           numDmeEventsNoData.getAndIncrement();
           scheduler.copySucceeded(srcAttemptIdentifier.expand(0), null, 0, 0, 0, null, true);
           return;
@@ -191,10 +188,8 @@ public class ShuffleInputEventHandlerOrderedGrouped implements ShuffleEventHandl
         allPartitionsEmpty &= emptyPartitionsBitSet.get(srcPartitionId);
         if (emptyPartitionsBitSet.get(srcPartitionId)) {
           InputAttemptIdentifier srcInputAttemptIdentifier = compositeInputAttemptIdentifier.expand(i);
-          if (LOG.isDebugEnabled()) {
-            LOG.debug("Source partition: " + srcPartitionId + " did not generate any data. SrcAttempt: ["
-                + srcInputAttemptIdentifier + "]. Not fetching.");
-          }
+          LOG.debug("Source partition: {} did not generate any data. SrcAttempt: [{}]. Not fetching.",
+              srcPartitionId, srcInputAttemptIdentifier);
           numDmeEventsNoData.getAndIncrement();
           scheduler.copySucceeded(srcInputAttemptIdentifier, null, 0, 0, 0, null, true);
         }
@@ -212,9 +207,7 @@ public class ShuffleInputEventHandlerOrderedGrouped implements ShuffleEventHandl
   private void processTaskFailedEvent(InputFailedEvent ifEvent) {
     InputAttemptIdentifier taIdentifier = new InputAttemptIdentifier(ifEvent.getTargetIndex(), ifEvent.getVersion());
     scheduler.obsoleteInput(taIdentifier);
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("Obsoleting output of src-task: " + taIdentifier);
-    }
+    LOG.debug("Obsoleting output of src-task: {}", taIdentifier);
   }
 
   /**
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/ShuffleScheduler.java b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/ShuffleScheduler.java
index 8f59a4e..a2ea037 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/ShuffleScheduler.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/shuffle/orderedgrouped/ShuffleScheduler.java
@@ -1102,9 +1102,7 @@ class ShuffleScheduler {
       if (eventInfo.eventsProcessed.isEmpty() && !eventInfo.scheduledForDownload) {
         // obsoleted anyways; no point tracking if nothing is started
         pipelinedShuffleInfoEventsMap.remove(srcAttempt.getInputIdentifier());
-        if (LOG.isDebugEnabled()) {
-          LOG.debug("Removing " + eventInfo + " from tracking");
-        }
+        LOG.debug("Removing {} from tracking", eventInfo);
         return;
       }
       IOException exception = new IOException(srcAttempt + " is marked as obsoleteInput, but it "
@@ -1126,9 +1124,7 @@ class ShuffleScheduler {
 
   public synchronized MapHost getHost() throws InterruptedException {
     while (pendingHosts.isEmpty() && remainingMaps.get() > 0) {
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("PendingHosts=" + pendingHosts);
-      }
+      LOG.debug("PendingHosts={}", pendingHosts);
       waitAndNotifyProgress();
     }
 
@@ -1434,9 +1430,7 @@ class ShuffleScheduler {
               if (mapHost == null) {
                 break; // Check for the exit condition.
               }
-              if (LOG.isDebugEnabled()) {
-                LOG.debug(srcNameTrimmed + ": " + "Processing pending host: " + mapHost.toString());
-              }
+              LOG.debug("{}: Processing pending host: {}", srcNameTrimmed, mapHost);
               if (!isShutdown.get()) {
                 count++;
                 if (LOG.isDebugEnabled()) {
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/sort/impl/IFile.java b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/sort/impl/IFile.java
index 07fbd0c..f424ff0 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/sort/impl/IFile.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/sort/impl/IFile.java
@@ -644,9 +644,7 @@ public class IFile {
           try {
             in.close();
           } catch(IOException e) {
-            if(LOG.isDebugEnabled()) {
-              LOG.debug("Exception in closing " + in, e);
-            }
+            LOG.debug("Exception in closing {}", in, e);
           }
         }
         throw ioe;
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/task/local/output/TezTaskOutputFiles.java b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/task/local/output/TezTaskOutputFiles.java
index 88474f9..3fb9086 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/task/local/output/TezTaskOutputFiles.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/common/task/local/output/TezTaskOutputFiles.java
@@ -65,11 +65,7 @@ public class TezTaskOutputFiles extends TezTaskOutput {
    * if service_id = tez_shuffle  then "${appDir}/dagId/output/${uniqueId}"
    */
   private Path getAttemptOutputDir() {
-    if (LOG.isDebugEnabled()) {
-      LOG.debug("getAttemptOutputDir: "
-          + Constants.TEZ_RUNTIME_TASK_OUTPUT_DIR + "/"
-          + uniqueId);
-    }
+    LOG.debug("getAttemptOutputDir: {}/{}", Constants.TEZ_RUNTIME_TASK_OUTPUT_DIR, uniqueId);
     String dagPath = getDagOutputDir(Constants.TEZ_RUNTIME_TASK_OUTPUT_DIR);
     return new Path(dagPath, uniqueId);
   }
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/input/OrderedGroupedKVInput.java b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/input/OrderedGroupedKVInput.java
index c1879bc..eafc488 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/input/OrderedGroupedKVInput.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/input/OrderedGroupedKVInput.java
@@ -130,9 +130,7 @@ public class OrderedGroupedKVInput extends AbstractLogicalInput {
       // Start the shuffle - copy and merge
       shuffle = createShuffle();
       shuffle.run();
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Initialized the handlers in shuffle..Safe to start processing..");
-      }
+      LOG.debug("Initialized the handlers in shuffle..Safe to start processing..");
       List<Event> pending = new LinkedList<Event>();
       pendingEvents.drainTo(pending);
       if (pending.size() > 0) {
diff --git a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/resources/WeightedScalingMemoryDistributor.java b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/resources/WeightedScalingMemoryDistributor.java
index b82e6d3..52f3d44 100644
--- a/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/resources/WeightedScalingMemoryDistributor.java
+++ b/tez-runtime-library/src/main/java/org/apache/tez/runtime/library/resources/WeightedScalingMemoryDistributor.java
@@ -244,9 +244,7 @@ public class WeightedScalingMemoryDistributor implements InitialMemoryAllocator
       requestType = RequestType.PARTITIONED_UNSORTED_OUTPUT;
     } else {
       requestType = RequestType.OTHER;
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("Falling back to RequestType.OTHER for class: " + className);
-      }
+      LOG.debug("Falling back to RequestType.OTHER for class: {}", className);
     }
     return requestType;
   }
diff --git a/tez-tools/tez-tfile-parser/src/main/java/org/apache/tez/tools/TFileLoader.java b/tez-tools/tez-tfile-parser/src/main/java/org/apache/tez/tools/TFileLoader.java
index 18e9940..320428b 100644
--- a/tez-tools/tez-tfile-parser/src/main/java/org/apache/tez/tools/TFileLoader.java
+++ b/tez-tools/tez-tfile-parser/src/main/java/org/apache/tez/tools/TFileLoader.java
@@ -66,10 +66,7 @@ public class TFileLoader extends FileInputLoadFunc implements LoadMetadata {
 
       currentKey = recReader.getCurrentKey();
       String line = recReader.getCurrentValue().toString();
-      if (LOG.isDebugEnabled()) {
-        LOG.debug("currentKey: " + currentKey
-                + ", line=" + line);
-      }
+      LOG.debug("currentKey: {}, line={}", currentKey, line);
       //Tuple would be of format: machine, key, line
       Tuple tuple = tupleFactory.newTuple(3);
       if (currentKey != null) {