Return-Path: X-Original-To: apmail-accumulo-commits-archive@www.apache.org Delivered-To: apmail-accumulo-commits-archive@www.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id 84FD3102A0 for ; Tue, 16 Dec 2014 23:51:47 +0000 (UTC) Received: (qmail 51414 invoked by uid 500); 16 Dec 2014 23:51:47 -0000 Delivered-To: apmail-accumulo-commits-archive@accumulo.apache.org Received: (qmail 51308 invoked by uid 500); 16 Dec 2014 23:51:47 -0000 Mailing-List: contact commits-help@accumulo.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@accumulo.apache.org Delivered-To: mailing list commits@accumulo.apache.org Received: (qmail 51282 invoked by uid 99); 16 Dec 2014 23:51:47 -0000 Received: from tyr.zones.apache.org (HELO tyr.zones.apache.org) (140.211.11.114) by apache.org (qpsmtpd/0.29) with ESMTP; Tue, 16 Dec 2014 23:51:47 +0000 Received: by tyr.zones.apache.org (Postfix, from userid 65534) id 13E99A2E004; Tue, 16 Dec 2014 23:51:47 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: elserj@apache.org To: commits@accumulo.apache.org Date: Tue, 16 Dec 2014 23:51:48 -0000 Message-Id: In-Reply-To: References: X-Mailer: ASF-Git Admin Mailer Subject: [2/3] accumulo git commit: ACCUMULO-3425 Use slfj4 logger variable substitution. ACCUMULO-3425 Use slfj4 logger variable substitution. Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/0433e037 Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/0433e037 Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/0433e037 Branch: refs/heads/master Commit: 0433e0374a179ba64b94cbdb544ac1f803f620d8 Parents: dfb66c3 Author: Josh Elser Authored: Tue Dec 16 16:56:16 2014 -0500 Committer: Josh Elser Committed: Tue Dec 16 16:56:16 2014 -0500 ---------------------------------------------------------------------- .../core/client/impl/ThriftTransportPool.java | 39 ++++++++------------ .../accumulo/server/rpc/TServerUtils.java | 8 ++-- 2 files changed, 20 insertions(+), 27 deletions(-) ---------------------------------------------------------------------- http://git-wip-us.apache.org/repos/asf/accumulo/blob/0433e037/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftTransportPool.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftTransportPool.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftTransportPool.java index c159e8b..7a6e6ab 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftTransportPool.java +++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ThriftTransportPool.java @@ -34,9 +34,10 @@ import java.util.concurrent.atomic.AtomicBoolean; import org.apache.accumulo.core.rpc.ThriftUtil; import org.apache.accumulo.core.util.Daemon; import org.apache.accumulo.core.util.Pair; -import org.apache.log4j.Logger; import org.apache.thrift.transport.TTransport; import org.apache.thrift.transport.TTransportException; +import org.slf4j.Logger; +import org.slf4j.LoggerFactory; import com.google.common.net.HostAndPort; @@ -53,7 +54,7 @@ public class ThriftTransportPool { private CountDownLatch closerExitLatch; - private static final Logger log = Logger.getLogger(ThriftTransportPool.class); + private static final Logger log = LoggerFactory.getLogger(ThriftTransportPool.class); private static final Long ERROR_THRESHOLD = 20l; private static final int STUCK_THRESHOLD = 2 * 60 * 1000; @@ -175,9 +176,8 @@ public class ThriftTransportPool { lastIoCount = -1; } else { if ((ioCount & 1) == 1) { - // connection unreserved, but it seems io may still be - // happening - log.warn("Connection returned to thrift connection pool that may still be in use " + ioThreadName + " " + Thread.currentThread().getName(), + // connection unreserved, but it seems io may still be happening + log.warn("Connection returned to thrift connection pool that may still be in use {} {}", ioThreadName, Thread.currentThread().getName(), new Exception()); } @@ -204,7 +204,7 @@ public class ThriftTransportPool { long delta = System.currentTimeMillis() - ioStartTime; if (delta >= threshold && stuckThreadName == null) { stuckThreadName = ioThreadName; - log.warn("Thread \"" + ioThreadName + "\" stuck on IO to " + cacheKey + " for at least " + delta + " ms"); + log.warn("Thread \"{}\" stuck on IO to {} for at least {} ms", ioThreadName, cacheKey, delta); } } else { // remember this ioCount and the time we saw it, need to see @@ -214,7 +214,7 @@ public class ThriftTransportPool { if (stuckThreadName != null) { // doing I/O, but ioCount changed so no longer stuck - log.info("Thread \"" + stuckThreadName + "\" no longer stuck on IO to " + cacheKey + " sawError = " + sawError); + log.info("Thread \"{}\" no longer stuck on IO to {} sawError = {}", stuckThreadName, cacheKey, sawError); stuckThreadName = null; } } @@ -222,7 +222,7 @@ public class ThriftTransportPool { // I/O is not currently happening if (stuckThreadName != null) { // no longer stuck, and was stuck in the past - log.info("Thread \"" + stuckThreadName + "\" no longer stuck on IO to " + cacheKey + " sawError = " + sawError); + log.info("Thread \"{}\" no longer stuck on IO to {} sawError = {}", stuckThreadName, cacheKey, sawError); stuckThreadName = null; } } @@ -406,8 +406,7 @@ public class ThriftTransportPool { for (CachedConnection cachedConnection : ccl) { if (!cachedConnection.isReserved()) { cachedConnection.setReserved(true); - if (log.isTraceEnabled()) - log.trace("Using existing connection to " + cacheKey.getLocation() + ":" + cacheKey.getPort()); + log.trace("Using existing connection to {}:{}", cacheKey.getLocation(), cacheKey.getPort()); return cachedConnection.transport; } } @@ -436,8 +435,7 @@ public class ThriftTransportPool { for (CachedConnection cachedConnection : getCache().get(ttk)) { if (!cachedConnection.isReserved()) { cachedConnection.setReserved(true); - if (log.isTraceEnabled()) - log.trace("Using existing connection to " + ttk.getLocation() + ":" + ttk.getPort()); + log.trace("Using existing connection to {}:{}", ttk.getLocation(), ttk.getPort()); return new Pair(ttk.getLocation() + ":" + ttk.getPort(), cachedConnection.transport); } } @@ -458,8 +456,7 @@ public class ThriftTransportPool { for (CachedConnection cachedConnection : cachedConnList) { if (!cachedConnection.isReserved()) { cachedConnection.setReserved(true); - if (log.isTraceEnabled()) - log.trace("Using existing connection to " + ttk.getLocation() + ":" + ttk.getPort() + " timeout " + ttk.getTimeout()); + log.trace("Using existing connection to {}:{} timeout {}", ttk.getLocation(), ttk.getPort(), ttk.getTimeout()); return new Pair(ttk.getLocation() + ":" + ttk.getPort(), cachedConnection.transport); } } @@ -483,8 +480,7 @@ public class ThriftTransportPool { TTransport transport = ThriftUtil.createClientTransport(HostAndPort.fromParts(cacheKey.getLocation(), cacheKey.getPort()), (int) cacheKey.getTimeout(), cacheKey.getSslParams()); - if (log.isTraceEnabled()) - log.trace("Creating new connection to connection to " + cacheKey.getLocation() + ":" + cacheKey.getPort()); + log.trace("Creating new connection to connection to {}:{}", cacheKey.getLocation(), cacheKey.getPort()); CachedTTransport tsc = new CachedTTransport(transport, cacheKey); @@ -528,8 +524,7 @@ public class ThriftTransportPool { closeList.add(cachedConnection); iterator.remove(); - if (log.isTraceEnabled()) - log.trace("Returned connection had error " + ctsc.getCacheKey()); + log.trace("Returned connection had error {}", ctsc.getCacheKey()); Long ecount = errorCount.get(ctsc.getCacheKey()); if (ecount == null) @@ -543,16 +538,14 @@ public class ThriftTransportPool { } if (ecount >= ERROR_THRESHOLD && !serversWarnedAbout.contains(ctsc.getCacheKey())) { - log.warn("Server " + ctsc.getCacheKey() + " had " + ecount + " failures in a short time period, will not complain anymore "); + log.warn("Server {} had {} failures in a short time period, will not complain anymore", ctsc.getCacheKey(), ecount); serversWarnedAbout.add(ctsc.getCacheKey()); } cachedConnection.setReserved(false); } else { - - if (log.isTraceEnabled()) - log.trace("Returned connection " + ctsc.getCacheKey() + " ioCount : " + cachedConnection.transport.ioCount); + log.trace("Returned connection {} ioCount: {}", ctsc.getCacheKey(), cachedConnection.transport.ioCount); cachedConnection.lastReturnTime = System.currentTimeMillis(); cachedConnection.setReserved(false); @@ -595,7 +588,7 @@ public class ThriftTransportPool { */ public synchronized void setIdleTime(long time) { this.killTime = time; - log.debug("Set thrift transport pool idle time to " + time); + log.debug("Set thrift transport pool idle time to {}", time); } private static ThriftTransportPool instance = new ThriftTransportPool(); http://git-wip-us.apache.org/repos/asf/accumulo/blob/0433e037/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java ---------------------------------------------------------------------- diff --git a/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java b/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java index 9a74357..d972b9a 100644 --- a/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java +++ b/server/base/src/main/java/org/apache/accumulo/server/rpc/TServerUtils.java @@ -110,7 +110,7 @@ public class TServerUtils { // Note: with a TNonblockingServerSocket a "port taken" exception is a cause-less // TTransportException, and with a TSocket created by TSSLTransportFactory, it // comes through as caused by a BindException. - log.info("Unable to use port " + port + ", retrying. (Thread Name = " + threadName + ")"); + log.info("Unable to use port {}, retrying. (Thread Name = {})", port, threadName); UtilWaitThread.sleep(250); } else { // thrift is passing up a nested exception that isn't a BindException, @@ -145,7 +145,7 @@ public class TServerUtils { public void run() { if (pool.getCorePoolSize() <= pool.getActiveCount()) { int larger = pool.getCorePoolSize() + Math.min(pool.getQueue().size(), 2); - log.info("Increasing server thread pool size on " + serverName + " to " + larger); + log.info("Increasing server thread pool size on {} to {}", serverName, larger); pool.setMaximumPoolSize(larger); pool.setCorePoolSize(larger); } else { @@ -156,7 +156,7 @@ public class TServerUtils { // we decrease the core pool size... so the active count could end up higher than // the core pool size, in which case everything will be queued... the increase case // should handle this and prevent deadlock - log.info("Decreasing server thread pool size on " + serverName + " to " + smaller); + log.info("Decreasing server thread pool size on {} to {}", serverName, smaller); pool.setCorePoolSize(smaller); } } @@ -251,7 +251,7 @@ public class TServerUtils { ExecutorService es = (ExecutorService) f.get(s); es.shutdownNow(); } catch (Exception e) { - TServerUtils.log.error("Unable to call shutdownNow", e); + log.error("Unable to call shutdownNow", e); } } }