You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ag...@apache.org on 2015/09/23 03:36:50 UTC

[21/23] ignite git commit: 1171-debug - Removed debug.

1171-debug - Removed debug.


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/1edd63da
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/1edd63da
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/1edd63da

Branch: refs/heads/ignite-1171
Commit: 1edd63da2f73ccb8dbd51f2f9e1285b7c6b79a99
Parents: 29cd3db
Author: Alexey Goncharuk <al...@gmail.com>
Authored: Tue Sep 22 18:29:56 2015 -0700
Committer: Alexey Goncharuk <al...@gmail.com>
Committed: Tue Sep 22 18:29:56 2015 -0700

----------------------------------------------------------------------
 .../continuous/CacheContinuousQueryManager.java | 15 +-----
 .../ignite/internal/util/IgniteUtils.java       |  3 --
 .../ignite/spi/discovery/tcp/ServerImpl.java    | 52 ++------------------
 3 files changed, 5 insertions(+), 65 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/1edd63da/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryManager.java
index eaa66af..32637b30 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryManager.java
@@ -449,23 +449,12 @@ public class CacheContinuousQueryManager extends GridCacheManagerAdapter {
             taskNameHash,
             skipPrimaryCheck);
 
-        IgniteInternalFuture<UUID> f = cctx.kernalContext().continuous().startRoutine(
+        UUID id = cctx.kernalContext().continuous().startRoutine(
             hnd,
             bufSize,
             timeInterval,
             autoUnsubscribe,
-            grp.predicate());
-
-        while (!f.isDone()) {
-            try {
-                f.get(2000);
-            }
-            catch (Exception e) {
-                U.debug(log, "### Failed to wait for future: " + cctx.gridName() + " " + cctx.nodeId() + " " + f);
-            }
-        }
-
-        UUID id = f.get();
+            grp.predicate()).get();
 
         if (notifyExisting) {
             final Iterator<GridCacheEntryEx> it = cctx.cache().allEntries().iterator();

http://git-wip-us.apache.org/repos/asf/ignite/blob/1edd63da/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java b/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java
index e730edc..e5090cb 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java
@@ -1022,9 +1022,6 @@ public abstract class IgniteUtils {
      */
     @Deprecated
     public static void debug(IgniteLogger log, String msg) {
-        if (true)
-            return;
-
         log.info(msg);
     }
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/1edd63da/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
index 701e31e..0c2c6e6 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
@@ -2086,11 +2086,6 @@ class ServerImpl extends TcpDiscoveryImpl {
             if (log.isDebugEnabled())
                 log.debug("Processing message [cls=" + msg.getClass().getSimpleName() + ", id=" + msg.id() + ']');
 
-            if (!(msg instanceof TcpDiscoveryHeartbeatMessage))
-                U.debug(
-                    log,
-                    "Processing message [locNodeId=" + locNode.id() + ", cls=" + msg.getClass().getSimpleName() + ", id=" + msg.id() + ']');
-
             if (debugMode)
                 debugLog("Processing message [cls=" + msg.getClass().getSimpleName() + ", id=" + msg.id() + ']');
 
@@ -2464,12 +2459,6 @@ class ServerImpl extends TcpDiscoveryImpl {
                                             ", pendingMsgId=" + pendingMsg.id() + ", next=" + next.id() +
                                             ", res=" + res + ']');
 
-                                    U.debug(
-                                        log,
-                                        "Pending message has been sent to next node [msgId=" + msg.id() +
-                                            ", pendingMsgId=" + pendingMsg.id() + ", next=" + next.id() +
-                                            ", res=" + res + ']');
-
                                     if (debugMode)
                                         debugLog("Pending message has been sent to next node [msgId=" + msg.id() +
                                             ", pendingMsgId=" + pendingMsg.id() + ", next=" + next.id() +
@@ -2510,9 +2499,6 @@ class ServerImpl extends TcpDiscoveryImpl {
                                     log.debug("Message has been sent to next node [msg=" + msg +
                                         ", next=" + next.id() +
                                         ", res=" + res + ']');
-                                U.debug(log, "Message has been sent to next node [msg=" + msg +
-                                    ", next=" + next.id() +
-                                    ", res=" + res + ']');
 
                                 if (debugMode)
                                     debugLog("Message has been sent to next node [msg=" + msg +
@@ -3011,8 +2997,6 @@ class ServerImpl extends TcpDiscoveryImpl {
                 TcpDiscoveryNodeAddedMessage nodeAddedMsg = new TcpDiscoveryNodeAddedMessage(locNodeId,
                     node, msg.discoveryData(), spi.gridStartTime);
 
-                U.debug(log, "Create node added msg: " + nodeAddedMsg);
-
                 nodeAddedMsg.client(msg.client());
 
                 processNodeAddedMessage(nodeAddedMsg);
@@ -3235,9 +3219,6 @@ class ServerImpl extends TcpDiscoveryImpl {
 
                 joiningNodes.add(node.id());
 
-                U.debug(log, "Added joining node [joiningNodes=" + joiningNodes + ", node=" + node.id() +
-                        ", msg=" + msg.id() + ']');
-
                 if (!isLocalNodeCoordinator() && spi.nodeAuth != null && spi.nodeAuth.isGlobalNodeAuthentication()) {
                     boolean authFailed = true;
 
@@ -3467,8 +3448,6 @@ class ServerImpl extends TcpDiscoveryImpl {
 
             joiningNodes.remove(nodeId);
 
-            U.debug(log, "Joining nodes remove1: " + joiningNodes + ", node=" + nodeId);
-
             TcpDiscoverySpiState state = spiStateCopy();
 
             if (msg.verified() && !locNodeId.equals(nodeId) && state != CONNECTING && fireEvt) {
@@ -3491,10 +3470,6 @@ class ServerImpl extends TcpDiscoveryImpl {
                     if (log.isDebugEnabled())
                         log.debug("Topology version has been updated: [ring=" + ring + ", msg=" + msg + ']');
 
-                    U.debug(
-                        log,
-                        "Topology version has been updated: [ring=" + ring + ", msg=" + msg + ']');
-
                     lastMsg = msg;
                 }
 
@@ -3655,10 +3630,6 @@ class ServerImpl extends TcpDiscoveryImpl {
                     if (log.isDebugEnabled())
                         log.debug("Topology version has been updated: [ring=" + ring + ", msg=" + msg + ']');
 
-                    U.debug(
-                        log,
-                        "Topology version has been updated: [ring=" + ring + ", msg=" + msg + ']');
-
                     lastMsg = msg;
                 }
 
@@ -3695,8 +3666,6 @@ class ServerImpl extends TcpDiscoveryImpl {
 
                 joiningNodes.remove(leftNode.id());
 
-                U.debug(log, "Joining nodes remove2: " + joiningNodes + ", node=" + leftNode.id());
-
                 spi.stats.onNodeLeft();
 
                 notifyDiscovery(EVT_NODE_LEFT, topVer, leftNode);
@@ -3831,10 +3800,6 @@ class ServerImpl extends TcpDiscoveryImpl {
                     if (log.isDebugEnabled())
                         log.debug("Topology version has been updated: [ring=" + ring + ", msg=" + msg + ']');
 
-                    U.debug(
-                        log,
-                        "Topology version has been updated: [ring=" + ring + ", msg=" + msg + ']');
-
                     lastMsg = msg;
                 }
 
@@ -3859,8 +3824,6 @@ class ServerImpl extends TcpDiscoveryImpl {
 
                 joiningNodes.remove(node.id());
 
-                U.debug(log, "Joining nodes remove3: " + joiningNodes + ", node=" + node.id());
-
                 notifyDiscovery(EVT_NODE_FAILED, topVer, node);
 
                 spi.stats.onNodeFailed();
@@ -4253,8 +4216,6 @@ class ServerImpl extends TcpDiscoveryImpl {
          * @param msg Message.
          */
         private void processCustomMessage(TcpDiscoveryCustomEventMessage msg) {
-            U.debug(log, "Processing custom message [msg=" + msg + ", topVer=" + ring.topologyVersion() + ']');
-
             if (isLocalNodeCoordinator()) {
                 if (!joiningNodes.isEmpty()) {
                     pendingCustomMsgs.add(msg);
@@ -4265,8 +4226,6 @@ class ServerImpl extends TcpDiscoveryImpl {
                 boolean sndNext = !msg.verified();
 
                 if (sndNext) {
-                    U.debug(log, "Joining nodes are empty on coordinator, will proceed with message: " + msg);
-
                     msg.verify(getLocalNodeId());
                     msg.topologyVersion(ring.topologyVersion());
 
@@ -4315,7 +4274,8 @@ class ServerImpl extends TcpDiscoveryImpl {
                 }
 
                 if (msg.verified() && msg.topologyVersion() != ring.topologyVersion()) {
-                    U.debug(log, "Discarding custom message: " + msg + ", topver=" + ring.topologyVersion());
+                    if (log.isDebugEnabled())
+                        log.debug("Discarding custom event message [msg=" + msg + ", ring=" + ring + ']');
 
                     return;
                 }
@@ -4328,11 +4288,8 @@ class ServerImpl extends TcpDiscoveryImpl {
                     notifyDiscoveryListener(msg);
                 }
 
-                if (ring.hasRemoteNodes()) {
-                    U.debug(log, "Will send message to the next node in topology [next=" + next + ", msg=" + msg + ']');
-
+                if (ring.hasRemoteNodes())
                     sendMessageAcrossRing(msg);
-                }
             }
         }
 
@@ -5447,9 +5404,6 @@ class ServerImpl extends TcpDiscoveryImpl {
 
             if (log.isDebugEnabled())
                 log.debug("Message has been added to queue: " + msg);
-
-            if (!(msg instanceof TcpDiscoveryHeartbeatMessage))
-                U.debug(log, "Message has been added to queue: " + msg);
         }
 
         /**