You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ak...@apache.org on 2015/03/04 10:45:18 UTC

[1/3] incubator-ignite git commit: # IGNITE-344 Fixed cache clear and cache load sizes + minor cleanup of Visor-console code.

Repository: incubator-ignite
Updated Branches:
  refs/heads/sprint-2 656ee473e -> 4dd565e22


# IGNITE-344 Fixed cache clear and cache load sizes + minor cleanup of Visor-console code.


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

Branch: refs/heads/sprint-2
Commit: 4348d9ca8a0e6e95817ec90b43bc4f39847e1d9e
Parents: 47539d8
Author: AKuznetsov <ak...@gridgain.com>
Authored: Fri Feb 27 10:07:51 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Fri Feb 27 10:07:51 2015 +0700

----------------------------------------------------------------------
 .../visor/cache/VisorCacheClearTask.java        |   3 +-
 .../visor/cache/VisorCacheLoadTask.java         |   3 +-
 .../scala/org/apache/ignite/visor/Packet.scala  |  38 ------
 .../ignite/visor/commands/VisorConsole.scala    |   2 -
 .../ignite/visor/commands/ack/Packet.scala      |  55 --------
 .../visor/commands/ack/VisorAckCommand.scala    |   2 +-
 .../ignite/visor/commands/alert/Packet.scala    | 108 ----------------
 .../ignite/visor/commands/cache/Packet.scala    | 127 -------------------
 .../commands/cache/VisorCacheCommand.scala      |   2 +-
 .../ignite/visor/commands/config/Packet.scala   |  55 --------
 .../ignite/visor/commands/deploy/Packet.scala   |  76 -----------
 .../ignite/visor/commands/disco/Packet.scala    |  72 -----------
 .../ignite/visor/commands/events/Packet.scala   |  97 --------------
 .../ignite/visor/commands/gc/Packet.scala       |  61 ---------
 .../ignite/visor/commands/kill/Packet.scala     |  78 ------------
 .../visor/commands/kill/VisorKillCommand.scala  |   2 +-
 .../ignite/visor/commands/node/Packet.scala     |  60 ---------
 .../ignite/visor/commands/ping/Packet.scala     |  50 --------
 .../visor/commands/ping/VisorPingCommand.scala  |   2 +-
 .../ignite/visor/commands/start/Packet.scala    |  90 -------------
 .../ignite/visor/commands/tasks/Packet.scala    | 116 -----------------
 .../commands/tasks/VisorTasksCommand.scala      |  26 +---
 .../ignite/visor/commands/top/Packet.scala      |  87 -------------
 .../ignite/visor/commands/vvm/Packet.scala      |  61 ---------
 24 files changed, 15 insertions(+), 1258 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheClearTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheClearTask.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheClearTask.java
index f425d75..f341a04 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheClearTask.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheClearTask.java
@@ -18,6 +18,7 @@
 package org.apache.ignite.internal.visor.cache;
 
 import org.apache.ignite.*;
+import org.apache.ignite.cache.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.internal.processors.task.*;
 import org.apache.ignite.internal.util.typedef.internal.*;
@@ -147,7 +148,7 @@ public class VisorCacheClearTask extends VisorOneNodeTask<String, IgniteBiTuple<
 
         /** {@inheritDoc} */
         @Override public Integer call() throws Exception {
-            return cache.size();
+            return cache.size(CachePeekMode.PRIMARY);
         }
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheLoadTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheLoadTask.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheLoadTask.java
index 329772c..189a07d 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheLoadTask.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheLoadTask.java
@@ -18,6 +18,7 @@
 package org.apache.ignite.internal.visor.cache;
 
 import org.apache.ignite.*;
+import org.apache.ignite.cache.*;
 import org.apache.ignite.internal.processors.task.*;
 import org.apache.ignite.internal.util.lang.*;
 import org.apache.ignite.internal.util.typedef.internal.*;
@@ -80,7 +81,7 @@ public class VisorCacheLoadTask extends
 
                 cache.loadCache(null, ldrArgs);
 
-                res.put(cacheName, cache.size());
+                res.put(cacheName, cache.size(CachePeekMode.PRIMARY));
             }
 
             return res;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/Packet.scala
deleted file mode 100644
index bee86ae..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/Packet.scala
+++ /dev/null
@@ -1,38 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite
-
-/**
- * {{{
- * ___    _________________________ ________
- * __ |  / /____  _/__  ___/__  __ \___  __ \
- * __ | / /  __  /  _____ \ _  / / /__  /_/ /
- * __ |/ /  __/ /   ____/ / / /_/ / _  _, _/
- * _____/   /___/   /____/  \____/  /_/ |_|
- *
- * }}}
- *
- * ==Overview==
- * Visor console provides monitoring capabilities for Ignite.
- *
- * ==Usage==
- * Ignite ships with `IGNITE_HOME/bin/ignitevisorcmd.{sh|bat}` script that starts Visor console.
- *
- * Just type:<ex>help</ex> in Visor console to get help and get started.
- */
-package object visor

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/VisorConsole.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/VisorConsole.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/VisorConsole.scala
index 62f590e..f8c5e19 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/VisorConsole.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/VisorConsole.scala
@@ -304,8 +304,6 @@ private[commands] class VisorFileNameCompleter extends Completer {
             if (files.size == 1) {
                 val candidate = files(0)
 
-                if (candidate.isDirectory) separator else " "
-
                 candidates.add(candidate.getName + (if (candidate.isDirectory) separator else " "))
             }
             else

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ack/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ack/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ack/Packet.scala
deleted file mode 100644
index 1529d71..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ack/Packet.scala
+++ /dev/null
@@ -1,55 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Visor 'ack' command implementation.
- *
- * ==Help==
- * {{{
- * +-------------------------------------------+
- * | ack | Acks arguments on all remote nodes. |
- * +-------------------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     ack {"s"}
- *     ack ("s", f)
- * }}}
- *
- * ====Arguments====
- * {{{
- *     s
- *         Optional string to print on each remote node.
- *     f
- *         Optional Scala predicate on 'ScalarRichNodePimp' filtering nodes in the topology.
- * }}}
- *
- * ====Examples====
- * {{{
- *     ack "Howdy!"
- *         Prints 'Howdy!' on all nodes in the topology.
- *     ack("Howdy!", _.id8.startsWith("123"))
- *         Prints 'Howdy!' on all nodes satisfying this predicate.
- *     ack
- *         Prints local node ID on all nodes in the topology.
- * }}}
- */
-package object ack

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ack/VisorAckCommand.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ack/VisorAckCommand.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ack/VisorAckCommand.scala
index 760edde..25d4ad7 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ack/VisorAckCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ack/VisorAckCommand.scala
@@ -157,5 +157,5 @@ object VisorAckCommand {
      *
      * @param vs Visor tagging trait.
      */
-    implicit def fromAck2Visor(vs: VisorTag) = cmd
+    implicit def fromAck2Visor(vs: VisorTag): VisorAckCommand = cmd
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/Packet.scala
deleted file mode 100644
index 8322228..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/Packet.scala
+++ /dev/null
@@ -1,108 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Visor 'alert' command implementation.
- *
- * ==Help==
- * {{{
- * +---------------------------------------------------------------------+
- * | alert | Generates email alerts for user-defined events.             |
- * |       | Node events and grid-wide events are defined via mnemonics. |
- * +---------------------------------------------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     alert
- *     alert "-u {-id=<alert-id>|-a}"
- *     alert "-r {-t=<sec>} -c1=e1<num> -c2=e2<num> ... -ck=ek<num>"
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -u
- *         Unregisters alert(s). Either '-a' flag or '-id' parameter is required.
- *         Note that only one of the '-u' or '-r' is allowed.
- *         If neither '-u' or '-r' provided - all alerts will be printed.
- *     -a
- *         When provided with '-u' - all alerts will be unregistered.
- *     -id=<alert-id>
- *         When provided with '-u' - alert with matching ID will be unregistered.
- *     -r
- *         Register new alert with mnemonic predicate(s).
- *         Note that only one of the '-u' or '-r' is allowed.
- *         If neither '-u' or '-r' provided - all alerts will be printed.
- *     -t
- *         Defines notification frequency in seconds. Default is 15 minutes.
- *         This parameter can only appear with '-r'.
- *     -ck=ek<num>
- *         This defines a mnemonic for the metric that will be measured:
- *         Grid-wide metrics (not node specific):
- *            -cc Total number of available CPUs in the grid.
- *            -nc Total number of nodes in the grid.
- *            -hc Total number of physical hosts in the grid.
- *            -cl Current average CPU load (in %) in the grid.
- *
- *         Per-node current metrics:
- *            -aj Active jobs on the node.
- *            -cj Cancelled jobs on the node.
- *            -tc Thread count on the node.
- *            -it Idle time on the node.
- *                Note: <num> can have 's', 'm', or 'h' suffix indicating
- *                seconds, minutes, and hours. By default (no suffix provided)
- *                value is assumed to be in milliseconds.
- *            -ut Up time on the node.
- *                Note: <num> can have 's', 'm', or 'h' suffix indicating
- *                seconds, minutes, and hours. By default (no suffix provided)
- *                value is assumed to be in milliseconds.
- *            -je Job execute time on the node.
- *            -jw Job wait time on the node.
- *            -wj Waiting jobs count on the node.
- *            -rj Rejected jobs count on the node.
- *            -hu Heap memory used (in MB) on the node.
- *            -cd Current CPU load on the node.
- *            -hm Heap memory maximum (in MB) on the node.
- *
- *         Comparison part of the mnemonic predicate:
- *            =eq<num> Equal '=' to '<num>' number.
- *            =neq<num> Not equal '!=' to '<num>' number.
- *            =gt<num> Greater than '>' to '<num>' number.
- *            =gte<num> Greater than or equal '>=' to '<num>' number.
- *            =lt<num> Less than '<' to 'NN' number.
- *            =lte<num> Less than or equal '<=' to '<num>' number.
- *
- *         NOTE: Email notification will be sent for the alert only when all
- *               provided mnemonic predicates evaluate to 'true'.
- * }}}
- *
- * ====Examples====
- * {{{
- *     alert
- *         Prints all currently registered alerts.
- *     alert "-u -a"
- *         Unregisters all currently registered alerts.
- *     alert "-u -id=12345678"
- *         Unregisters alert with provided ID.
- *     alert "-r -t=900 -cc=gte4 -cl=gt50"
- *         Notify every 15 min if grid has >= 4 CPUs and > 50% CPU load.
- * }}}
- */
-package object alert

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/Packet.scala
deleted file mode 100644
index 443c4ce..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/Packet.scala
+++ /dev/null
@@ -1,127 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Visor 'cache' command implementation.
- *
- * ==Help==
- * {{{
- * +-----------------------------------------------------------------------------------------+
- * | cache          | Prints statistics about caches from specified node on the entire grid. |
- * |                | Output sorting can be specified in arguments.                          |
- * |                |                                                                        |
- * |                | Output abbreviations:                                                  |
- * |                |     #   Number of nodes.                                               |
- * |                |     H/h Number of cache hits.                                          |
- * |                |     M/m Number of cache misses.                                        |
- * |                |     R/r Number of cache reads.                                         |
- * |                |     W/w Number of cache writes.                                        |
- * +-----------------------------------------------------------------------------------------+
- * | cache -compact | Compacts all entries in cache on all nodes.                            |
- * +-----------------------------------------------------------------------------------------+
- * | cache -clear   | Clears all entries from cache on all nodes.                            |
- * +-----------------------------------------------------------------------------------------+
- * | cache -scan    | List all entries in cache with specified name.                         |
- * +-----------------------------------------------------------------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     cache
- *     cache -i
- *     cache {-c=<cache-name>} {-id=<node-id>|id8=<node-id8>} {-s=lr|lw|hi|mi|re|wr} {-a} {-r}
- *     cache -clear {-c=<cache-name>}
- *     cache -compact {-c=<cache-name>}
- *     cache -scan -c=<cache-name> {-id=<node-id>|id8=<node-id8>} {-p=<page size>}
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -id=<node-id>
- *         Full ID of the node to get cache statistics from.
- *         Either '-id8' or '-id' can be specified.
- *         If neither is specified statistics will be gathered from all nodes.
- *     -id8=<node-id>
- *         ID8 of the node to get cache statistics from.
- *         Either '-id8' or '-id' can be specified.
- *         If neither is specified statistics will be gathered from all nodes.
- *     -c=<cache-name>
- *         Name of the cache.
- *     -s=lr|lw|hi|mi|re|wr|cn
- *         Defines sorting type. Sorted by:
- *            lr Last read.
- *            lw Last write.
- *            hi Hits.
- *            mi Misses.
- *            rd Reads.
- *            wr Writes.
- *         If not specified - default sorting is 'lr'.
- *     -i
- *         Interactive mode.
- *         User can interactively select node for cache statistics.
- *     -r
- *         Defines if sorting should be reversed.
- *         Can be specified only with '-s' argument.
- *     -a
- *         Prints details statistics about each cache.
- *         By default only aggregated summary is printed.
- *     -compact
- *          Compacts entries in cache.
- *     -clear
- *          Clears cache.
- *     -scan
- *          Prints list of all entries from cache.
- *     -p=<page size>
- *         Number of object to fetch from cache at once.
- *         Valid range from 1 to 100.
- *         By default page size is 25.
- * }}}
- *
- * ====Examples====
- * {{{
- *     cache
- *         Prints summary statistics about all caches.
- *     cache -id8=12345678 -s=hi -r
- *         Prints summary statistics about caches from node with specified id8
- *         sorted by number of hits in reverse order.
- *     cache -i
- *         Prints cache statistics for interactively selected node.
- *     cache -s=hi -r -a
- *         Prints detailed statistics about all caches sorted by number of hits in reverse order.
- *     cache -compact
- *         Compacts entries in interactively selected cache.
- *     cache -compact -c=cache
- *         Compacts entries in cache with name 'cache'.
- *     cache -clear
- *         Clears interactively selected cache.
- *     cache -clear -c=cache
- *         Clears cache with name 'cache'.
- *     cache -scan
- *         Prints list entries from interactively selected cache.
- *     cache -scan -c=cache
- *         Prints list entries from cache with name 'cache' from all nodes with this cache.
- *     cache -scan -c=@c0 -p=50
- *         Prints list entries from cache with name taken from 'c0' memory variable
- *         with page of 50 items from all nodes with this cache.
- *     cache -scan -c=cache -id8=12345678
- *         Prints list entries from cache with name 'cache' and node '12345678' ID8.
- * }}}
- */
-package object cache

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
index 3c1aa01..dbbdbbc 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
@@ -581,7 +581,7 @@ class VisorCacheCommand {
 
         val sumT = VisorTextTable()
 
-        sumT #= ("#", "Name(@),", "Nodes", "Size")
+        sumT #= ("#", "Name(@)", "Nodes", "Size")
 
         (0 until sortedAggrData.size) foreach (i => {
             val ad = sortedAggrData(i)

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/config/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/config/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/config/Packet.scala
deleted file mode 100644
index c99dd98..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/config/Packet.scala
+++ /dev/null
@@ -1,55 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Visor 'config' command implementation.
- *
- * ==Help==
- * {{{
- * +-------------------------------------+
- * | config | Prints node configuration. |
- * +-------------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     config
- *     config "{-id=<node-id>|id8=<node-id8>}"
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -id=<node-id>
- *         Full node ID. Either '-id8' or '-id' can be specified.
- *         If neither is specified - command starts in interactive mode.
- *     -id8=<node-id8>
- *         Node ID8. Either '-id8' or '-id' can be specified.
- *         If neither is specified - command starts in interactive mode.
- * }}}
- *
- * ====Examples====
- * {{{
- *     config "-id8=12345678"
- *         Prints configuration for node with '12345678' ID8.
- *     config
- *         Starts command in interactive mode.
- * }}}
- */
-package object config

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/deploy/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/deploy/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/deploy/Packet.scala
deleted file mode 100644
index 5e5f285..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/deploy/Packet.scala
+++ /dev/null
@@ -1,76 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Visor 'deploy' command implementation.
- *
- * ==Help==
- * {{{
- * +---------------------------------------------------+
- * | deploy | Copies file or directory to remote host. |
- * |        | Command relies on SFTP protocol.         |
- * +---------------------------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     deploy "-h={<username>{:<password>}@}<host>{:<port>} {-u=<username>}
- *         {-p=<password>} {-k=<path>} -s=<path> {-d<path>}"
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -h={<username>{:<password>}@}<host>{:<port>}
- *         Host specification.
- *
- *         <host> can be a hostname, IP or range of IPs.
- *         Example of range is 192.168.1.100~150,
- *         which means all IPs from 192.168.1.100 to 192.168.1.150 inclusively.
- *
- *         Default port number is 22.
- *
- *         This option can be provided multiple times.
- *     -u=<username>
- *         Default username.
- *         Used if specification doesn't contain username.
- *         If default is not provided as well, current local username will be used.
- *     -p=<password>
- *         Default password.
- *         Used if specification doesn't contain password.
- *         If default is not provided as well, it will be asked interactively.
- *     -k=<path>
- *         Path to private key file.
- *         If provided, it will be used for all specifications that doesn't contain password.
- *     -s=<path>
- *         Source path.
- *     -d=<path>
- *         Destination path (relative to IGNITE_HOME).
- *         If not provided, files will be copied to the root of IGNITE_HOME.
- * }}}
- *
- * ====Examples====
- * {{{
- *     deploy "-h=uname:passwd@host -s=/local/path -d=/remote/path"
- *         Copies file or directory to remote host (password authentication).
- *     deploy "-h=uname@host -k=ssh-key.pem -s=/local/path -d=/remote/path"
- *         Copies file or directory to remote host (private key authentication).
- * }}}
- */
-package object deploy

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/disco/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/disco/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/disco/Packet.scala
deleted file mode 100644
index b6257d7..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/disco/Packet.scala
+++ /dev/null
@@ -1,72 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Visor 'disco' command implementation.
- *
- * ==Help==
- * {{{
- * +---------------------------------------------------------------------------------------+
- * | disco | Prints topology change log as seen from the oldest node.                      |
- * |       | Timeframe for quering events can be specified in arguments.                   |
- * |       |                                                                               |
- * |       | Note that this command depends on Ignite events.                            |
- * |       |                                                                               |
- * |       | Ignite events can be individually enabled and disabled and disabled events  |
- * |       | can affect the results produced by this command. Note also that configuration |
- * |       | of Event Storage SPI that is responsible for temporary storage of generated   |
- * |       | events on each node can also affect the functionality of this command.        |
- * |       |                                                                               |
- * |       | By default - all events are enabled and Ignite stores last 10,000 local     |
- * |       | events on each node. Both of these defaults can be changed in configuration.  |
- * +---------------------------------------------------------------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     disco
- *     disco "{-t=<num>s|m|h|d} {-r} {-c=<n>}"
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -t=<num>s|m|h|d
- *         Defines timeframe for querying events:
- *            =<num>s Events fired during last <num> seconds.
- *            =<num>m Events fired during last <num> minutes.
- *            =<num>h Events fired during last <num> hours.
- *            =<num>d Events fired during last <num> days.
- *     -r
- *         Defines whether sorting should be reversed.
- *     -c=<n>
- *         Defines the maximum events count that can be shown.
- * }}}
- *
- * ====Examples====
- * {{{
- *     disco
- *         Prints all discovery events sorted chronologically (oldest first).
- *     disco "-r"
- *         Prints all discovery events sorted chronologically in reversed order (newest first).
- *     disco "-t=2m"
- *         Prints discovery events fired during last two minutes sorted chronologically.
- * }}}
- */
-package object disco

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/events/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/events/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/events/Packet.scala
deleted file mode 100644
index b4f0546..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/events/Packet.scala
+++ /dev/null
@@ -1,97 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Visor 'events' commands implementation.
- *
- * ==Help==
- * {{{
- * +----------------------------------------------------------------------------------------+
- * | events | Print events from a node.                                                     |
- * |        |                                                                               |
- * |        | Note that this command depends on Ignite events.                            |
- * |        |                                                                               |
- * |        | Ignite events can be individually enabled and disabled and disabled events  |
- * |        | can affect the results produced by this command. Note also that configuration |
- * |        | of Event Storage SPI that is responsible for temporary storage of generated   |
- * |        | events on each node can also affect the functionality of this command.        |
- * |        |                                                                               |
- * |        | By default - all events are enabled and Ignite stores last 10,000 local     |
- * |        | events on each node. Both of these defaults can be changed in configuration.  |
- * +----------------------------------------------------------------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     events
- *     events "{-id=<node-id>|-id8=<node-id8>} {-e=<ch,cp,de,di,jo,ta,cl,ca,sw>}
- *         {-t=<num>s|m|h|d} {-s=e|t} {-r} {-c=<n>}"
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -id=<node-id>
- *         Full node ID.
- *         Either '-id' or '-id8' can be specified.
- *         If called without the arguments - starts in interactive mode.
- *     -id8
- *         Node ID8.
- *         Either '-id' or '-id8' can be specified.
- *         If called without the arguments - starts in interactive mode.
- *     -e=<ch,de,di,jo,ta,cl,ca,sw>
- *         Comma separated list of event types that should be queried:
- *            ch Checkpoint events.
- *            de Deployment events.
- *            di Discovery events.
- *            jo Job execution events.
- *            ta Task execution events.
- *            ca Cache events.
- *            cp Cache pre-loader events.
- *            sw Swapspace events.
- *     -t=<num>s|m|h|d
- *         Defines time frame for querying events:
- *            =<num>s Queries events fired during last <num> seconds.
- *            =<num>m Queries events fired during last <num> minutes.
- *            =<num>h Queries events fired during last <num> hours.
- *            =<num>d Queries events fired during last <num> days.
- *     -s=e|t
- *         Defines sorting of queried events:
- *            =e Sorted by event type.
- *            =t Sorted chronologically.
- *         Only one '=e' or '=t' can be specified.
- *     -r
- *         Defines if sorting should be reversed.
- *         Can be specified only with -s argument.
- *     -c=<n>
- *         Defines the maximum events count that can be shown.
- *         Values in summary tables are calculated over the whole list of events.
- * }}}
- *
- * ====Examples====
- * {{{
- *     events "-id8=12345678"
- *         Queries all events from node with '12345678' ID8.
- *     events "-id8=12345678 -e=di,ca"
- *         Queries discovery and cache events from node with '12345678' ID8.
- *     events
- *         Starts command in interactive mode.
- * }}}
- */
-package object events

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/gc/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/gc/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/gc/Packet.scala
deleted file mode 100644
index 6bcfca8..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/gc/Packet.scala
+++ /dev/null
@@ -1,61 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Contains Visor command `gc` implementation.
- *
- * ==Help==
- * {{{
- * +---------------------------------------------------------------------------+
- * | gc | Runs garbage collector on remote nodes.                              |
- * |    | If specific node is provided, garbage collector is run on that node. |
- * |    | Otherwise, it will be run on all nodes in topology.                  |
- * +---------------------------------------------------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     gc
- *     gc "{-id8=<node-id8>|-id=<node-id>} {-c}"
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -id8=<node-id8>
- *         ID8 of the node.
- *         Note that either '-id8' or '-id' can be specified.
- *     -id=<node-id>
- *         ID of the node.
- *         Note that either '-id8' or '-id' can be specified.
- *     -c
- *         Run DGC procedure on all caches.
- * }}}
- *
- * ====Examples====
- * {{{
- *     gc "-id8=12345678"
- *         Runs garbage collector on specified node.
- *     gc
- *         Runs garbage collector on all nodes in topology.
- *     gc "-id8=12345678 -c"
- *         Runs garbage collector and DGC procedure on all caches.
- * }}}
- */
-package object gc

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/kill/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/kill/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/kill/Packet.scala
deleted file mode 100644
index 7029a4b..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/kill/Packet.scala
+++ /dev/null
@@ -1,78 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Contains Visor command `kill` implementation.
- *
- * ==Help==
- * {{{
- * +--------------------------------+
- * | kill | Kills or restarts node. |
- * +--------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     kill
- *     kill "-in|-ih"
- *     kill "{-r|-k} {-id8=<node-id8>|-id=<node-id>}"
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -in
- *         Run command in interactive mode with ability to
- *         choose a node to kill or restart.
- *         Note that either '-in' or '-ih' can be specified.
- *
- *         This mode is used by default.
- *     -ih
- *         Run command in interactive mode with ability to
- *         choose a host where to kill or restart nodes.
- *         Note that either '-in' or '-ih' can be specified.
- *     -r
- *         Restart node mode.
- *         Note that either '-r' or '-k' can be specified.
- *         If no parameters provided - command starts in interactive mode.
- *     -k
- *         Kill (stop) node mode.
- *         Note that either '-r' or '-k' can be specified.
- *         If no parameters provided - command starts in interactive mode.
- *     -id8=<node-id8>
- *         ID8 of the node to kill or restart.
- *         Note that either '-id8' or '-id' can be specified.
- *         If no parameters provided - command starts in interactive mode.
- *     -id=<node-id>
- *         ID of the node to kill or restart.
- *         Note that either '-id8' or '-id' can be specified.
- *         If no parameters provided - command starts in interactive mode.
- * }}}
- *
- * ====Examples====
- * {{{
- *     kill
- *         Starts command in interactive mode.
- *     kill "-id8=12345678 -r"
- *         Restart node with '12345678' ID8.
- *     kill "-k"
- *         Kill (stop) all nodes.
- * }}}
- */
-package object kill

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/kill/VisorKillCommand.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/kill/VisorKillCommand.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/kill/VisorKillCommand.scala
index 3c9b3d6..a8263e4 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/kill/VisorKillCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/kill/VisorKillCommand.scala
@@ -352,5 +352,5 @@ object VisorKillCommand {
      *
      * @param vs Visor tagging trait.
      */
-    implicit def fromKill2Visor(vs: VisorTag) = cmd
+    implicit def fromKill2Visor(vs: VisorTag): VisorKillCommand = cmd
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/node/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/node/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/node/Packet.scala
deleted file mode 100644
index e070322..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/node/Packet.scala
+++ /dev/null
@@ -1,60 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Contains Visor command `node` implementation.
- *
- * ==Help==
- * {{{
- * +--------------------------------+
- * | node | Prints node statistics. |
- * +--------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     node "{-id8=<node-id8>|-id=<node-id>} {-a}"
- *     node
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -id8=<node-id8>
- *         ID8 of node. Either '-id8' or '-id' can be specified.
- *         If neither specified - command starts in interactive mode.
- *     -id=<node-id>
- *         Full ID of node. Either '-id8' or '-id' can  be specified.
- *         If neither specified - command starts in interactive mode.
- *     -a
- *         Print extended information.
- *         By default - only abbreviated statistics is printed.
- * }}}
- *
- * ====Examples====
- * {{{
- *     node
- *         Starts command in interactive mode.
- *     node "-id8=12345678"
- *         Prints statistics for specified node.
- *     node "-id8=12345678 -a"
- *         Prints full statistics for specified node.
- * }}}
- */
-package object node

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ping/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ping/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ping/Packet.scala
deleted file mode 100644
index eb824e8..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ping/Packet.scala
+++ /dev/null
@@ -1,50 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Command==
- * Visor 'ping' command implementation.
- *
- * ==Help==
- * {{{
- * +--------------------+
- * | ping | Pings node. |
- * +--------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     ping {"id81 id82 ... id8k"}
- * }}}
- *
- * ====Arguments====
- * {{{
- *     id8k
- *         ID8 of the node to ping.
- * }}}
- *
- * ====Examples====
- * {{{
- *     ping "12345678"
- *         Pings node with '12345678' ID8.
- *     ping
- *         Pings all nodes in the topology.
- * }}}
- */
-package object ping

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ping/VisorPingCommand.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ping/VisorPingCommand.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ping/VisorPingCommand.scala
index e19dba2..7027354 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ping/VisorPingCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/ping/VisorPingCommand.scala
@@ -224,5 +224,5 @@ object VisorPingCommand {
      *
      * @param vs Visor tagging trait.
      */
-    implicit def fromPing2Visor(vs: VisorTag) = cmd
+    implicit def fromPing2Visor(vs: VisorTag): VisorPingCommand = cmd
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/Packet.scala
deleted file mode 100644
index 55eb836..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/Packet.scala
+++ /dev/null
@@ -1,90 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Contains Visor command `start` implementation.
- *
- * ==Help==
- * {{{
- * +-----------------------------------------------------+
- * | start | Starts one or more nodes on remote host(s). |
- * |       | Uses SSH protocol to execute commands.      |
- * +-----------------------------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     start "-f=<path> {-m=<num>} {-r}"
- *     start "-h=<hostname> {-p=<num>} {-u=<username>} {-pw=<password>} {-k=<path>}
- *         {-n=<num>} {-g=<path>} {-c=<path>} {-s=<path>} {-m=<num>} {-r}"
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -f=<path>
- *         Path to INI file that contains topology specification.
- *     -h=<hostname>
- *         Hostname where to start nodes.
- *
- *         Can define several hosts if their IPs are sequential.
- *         Example of range is 192.168.1.100~150,
- *         which means all IPs from 192.168.1.100 to 192.168.1.150 inclusively.
- *     -p=<num>
- *         Port number (default is 22).
- *     -u=<username>
- *         Username (if not defined, current local username will be used).
- *     -pw=<password>
- *         Password (if not defined, private key file must be defined).
- *     -k=<path>
- *         Path to private key file. Define if key authentication is used.
- *     -n=<num>
- *         Expected number of nodes on the host.
- *         If some nodes are started already, then only remaining nodes will be started.
- *         If current count of nodes is equal to this number and '-r' flag is not set, then nothing will happen.
- *     -g=<path>
- *         Path to Ignite installation folder.
- *         If not defined, IGNITE_HOME environment variable must be set on remote hosts.
- *     -c=<path>
- *         Path to configuration file (relative to Ignite home).
- *         If not provided, default Ignite configuration is used.
- *     -s=<path>
- *         Path to start script (relative to Ignite home).
- *         Default is "bin/ignite.sh" for Unix or
- *         "bin\ignite.bat" for Windows.
- *     -m=<num>
- *         Defines maximum number of nodes that can be started in parallel on one host.
- *         This actually means number of parallel SSH connections to each SSH server.
- *         Default is 5.
- *     -r
- *         Indicates that existing nodes on the host will be restarted.
- *         By default, if flag is not present, existing nodes will be left as is.
- * }}}
- *
- * ====Examples====
- * {{{
- *     start "-h=10.1.1.10 -u=uname -pw=passwd -n=3"
- *         Starts three nodes with default configuration (password authentication).
- *     start "-h=192.168.1.100~104 -u=uname -k=/home/uname/.ssh/is_rsa -n=5"
- *         Starts 25 nodes on 5 hosts (5 nodes per host) with default configuration (key-based authentication).
- *     start "-f=start-nodes.ini -r"
- *         Starts topology defined in 'start-nodes.ini' file. Existing nodes are stopped.
- * }}}
- */
-package object start

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/tasks/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/tasks/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/tasks/Packet.scala
deleted file mode 100644
index ad35e06..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/tasks/Packet.scala
+++ /dev/null
@@ -1,116 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Visor 'tasks' command implementation.
- *
- * ==Help==
- * {{{
- * +---------------------------------------------------------------------------------------+
- * | tasks | Prints statistics about tasks and executions.                                 |
- * |       |                                                                               |
- * |       | Note that this command depends on Ignite events.                            |
- * |       |                                                                               |
- * |       | Ignite events can be individually enabled and disabled and disabled events  |
- * |       | can affect the results produced by this command. Note also that configuration |
- * |       | of Event Storage SPI that is responsible for temporary storage of generated   |
- * |       | events on each node can also affect the functionality of this command.        |
- * |       |                                                                               |
- * |       | By default - all events are enabled and Ignite stores last 10,000 local     |
- * |       | events on each node. Both of these defaults can be changed in configuration.  |
- * +---------------------------------------------------------------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     tasks
- *     tasks "-l {-t=<num>s|m|h|d} {-r}"
- *     tasks "-s=<substring> {-t=<num>s|m|h|d} {-r}"
- *     tasks "-g {-t=<num>s|m|h|d} {-r}"
- *     tasks "-h {-t=<num>s|m|h|d} {-r}"
- *     tasks "-n=<task-name> {-r}"
- *     tasks "-e=<exec-id>"
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -l
- *         List all tasks and executions for a given time period.
- *         Executions sorted chronologically (see '-r'), and tasks alphabetically
- *         See '-t=<num>s|m|h|d' on how to specify the time limit.
- *         Default time period is one hour, i.e '-t=1h'
- *
- *         This is a default mode when command is called without parameters.
- *     -s=<substring>
- *         List all tasks and executions for a given task name substring.
- *         Executions sorted chronologically (see '-r'), and tasks alphabetically
- *         See '-t=<num>s|m|h|d' on how to specify the time limit.
- *         Default time period is one hour, i.e '-t=1h'
- *     -g
- *         List all tasks grouped by nodes for a given time period.
- *         Tasks sorted alphabetically
- *         See '-t=<num>s|m|h|d' on how to specify the time limit.
- *         Default time period is one hour, i.e '-t=1h'
- *     -h
- *         List all tasks grouped by hosts for a given time period.
- *         Tasks sorted alphabetically
- *         See '-t=<num>s|m|h|d' on how to specify the time limit.
- *         Default time period is one hour, i.e '-t=1h'
- *     -t=<num>s|m|h|d
- *         Defines time frame for '-l' parameter:
- *            =<num>s Last <num> seconds.
- *            =<num>m Last <num> minutes.
- *            =<num>h Last <num> hours.
- *            =<num>d Last <num> days.
- *     -r
- *         Reverse sorting of executions.
- *     -n=<task-name>
- *         Prints aggregated statistic for named task.
- *     -e=<exec-id>
- *         Prints aggregated statistic for given task execution.
- * }}}
- *
- * ====Examples====
- * {{{
- *     tasks "-l"
- *         Prints list of all tasks and executions for the last hour (default).
- *     tasks
- *         Prints list of all tasks and executions for the last hour (default).
- *     tasks "-l -t=5m"
- *         Prints list of tasks and executions that started during last 5 minutes.
- *     tasks "-s=Task"
- *         Prints list of all tasks and executions that have 'Task' in task name.
- *     tasks "-g"
- *         Prints list of tasks grouped by nodes.
- *     tasks "-g -t=5m"
- *         Prints list of tasks that started during last 5 minutes grouped by nodes.
- *     tasks "-h"
- *         Prints list of tasks grouped by hosts.
- *     tasks "-h -t=5m"
- *         Prints list of tasks that started during last 5 minutes grouped by hosts.
- *     tasks "-n=GridTask"
- *         Prints summary for task named 'GridTask'.
- *     tasks "-e=7D5CB773-225C-4165-8162-3BB67337894B"
- *         Traces task execution with ID '7D5CB773-225C-4165-8162-3BB67337894B'.
- *     tasks "-e=@e1"
- *         Traces task execution with ID taken from 'e1' memory variable.
- * }}}
- */
-package object tasks

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/tasks/VisorTasksCommand.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/tasks/VisorTasksCommand.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/tasks/VisorTasksCommand.scala
index 4185d0c..723c135 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/tasks/VisorTasksCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/tasks/VisorTasksCommand.scala
@@ -638,14 +638,10 @@ class VisorTasksCommand {
                     execsT.maxCellWidth = 35
 
                     execsT #=(
-                        (
-                            "ID8(@ID), Start/End,",
-                            "State & Duration"
-                            ),
+                        ("ID8(@ID), Start/End,", "State & Duration"),
                         "Task Name(@)",
                         "Nodes IP, ID8(@)",
-                        "Jobs"
-                        )
+                        "Jobs")
 
                     var sortedExecs = if (!reverse) eLst.sortBy(_.startTs).reverse else eLst.sortBy(_.startTs)
 
@@ -900,14 +896,10 @@ class VisorTasksCommand {
                     execsT.maxCellWidth = 35
 
                     execsT #= (
-                        (
-                            "ID8(@ID), Start/End,",
-                            "State & Duration"
-                            ),
+                        ("ID8(@ID), Start/End,", "State & Duration"),
                         "Task Name(@)",
                         "Nodes IP, ID8(@)",
-                        "Jobs"
-                        )
+                        "Jobs")
 
                     var sorted = if (!reverse) eLst.sortBy(_.startTs).reverse else eLst.sortBy(_.startTs)
 
@@ -1025,14 +1017,10 @@ class VisorTasksCommand {
                 execT.maxCellWidth = 35
 
                 execT #= (
-                    (
-                        "ID8(@ID), Start/End,",
-                        "State & Duration"
-                        ),
+                    ("ID8(@ID), Start/End,", "State & Duration"),
                     "Task Name(@)",
                     "Nodes IP, ID8(@)",
-                    "Jobs"
-                    )
+                    "Jobs")
 
                 val e = eLst.head
 
@@ -1480,5 +1468,5 @@ object VisorTasksCommand {
      *
      * @param vs Visor tagging trait.
      */
-    implicit def fromTrace2Visor(vs: VisorTag) = cmd
+    implicit def fromTrace2Visor(vs: VisorTag): VisorTasksCommand = cmd
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/top/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/top/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/top/Packet.scala
deleted file mode 100644
index b34d4a9..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/top/Packet.scala
+++ /dev/null
@@ -1,87 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Contains Visor command `top` implementation.
- *
- * ==Help==
- * {{{
- * +--------------------------------+
- * | top | Prints current topology. |
- * +--------------------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     top "{-c1=e1<num> -c2=e2<num> ... -ck=ek<num>} {-h=<host1> ... -h=<hostk>} {-a}"
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -ck=ek<num>
- *         This defines a mnemonic for node filter:
- *            -cc Number of available CPUs on the node.
- *            -cl Average CPU load (in %) on the node.
- *            -aj Active jobs on the node.
- *            -cj Cancelled jobs on the node.
- *            -tc Thread count on the node.
- *            -it Idle time on the node.
- *                Note: <num> can have 's', 'm', or 'h' suffix indicating
- *                seconds, minutes, and hours. By default (no suffix provided)
- *                value is assumed to be in milliseconds.
- *            -ut Up time on the node.
- *                Note: <num> can have 's', 'm', or 'h' suffix indicating
- *                seconds, minutes, and hours. By default (no suffix provided)
- *                value is assumed to be in milliseconds.
- *            -je Job execute time on the node.
- *            -jw Job wait time on the node.
- *            -wj Waiting jobs count on the node.
- *            -rj Rejected jobs count on the node.
- *            -hu Heap memory used (in MB) on the node.
- *            -hm Heap memory maximum (in MB) on the node.
- *
- *         Comparison part of the mnemonic predicate:
- *            =eq<num> Equal '=' to '<num>' number.
- *            =neq<num> Not equal '!=' to '<num>' number.
- *            =gt<num> Greater than '>' to '<num>' number.
- *            =gte<num> Greater than or equal '>=' to '<num>' number.
- *            =lt<num> Less than '<' to '<num>' number.
- *            =lte<num> Less than or equal '<=' to '<num>' number.
- *     -h=<host>
- *         This defines a host to show nodes from.
- *         Multiple hosts can be provided.
- *     -a
- *         This defines whether to show a separate table of nodes
- *         with detail per-node information.
- * }}}
- *
- * ====Examples====
- * {{{
- *     top "-cc=eq2"
- *         Prints topology for all nodes with two CPUs.
- *     top "-cc=eq2 -a"
- *         Prints full information for all nodes with two CPUs.
- *     top "-h=10.34.2.122 -h=10.65.3.11"
- *         Prints topology for provided hosts.
- *     top
- *         Prints full topology.
- * }}}
- */
-package object top

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4348d9ca/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/vvm/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/vvm/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/vvm/Packet.scala
deleted file mode 100644
index b01fbcc..0000000
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/vvm/Packet.scala
+++ /dev/null
@@ -1,61 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.visor.commands
-
-/**
- * ==Overview==
- * Contains Visor command `vvm` implementation.
- *
- * ==Help==
- * {{{
- * +-----------------------+
- * | vvm | Opens VisualVM. |
- * +-----------------------+
- * }}}
- *
- * ====Specification====
- * {{{
- *     vvm "{-home=dir} {-id8=<node-id8>} {-id=<node-id>}"
- * }}}
- *
- * ====Arguments====
- * {{{
- *     -home=dir
- *         VisualVM home directory.
- *         If not specified, PATH and JAVA_HOME will be searched
- *     -id8=<node-id8>
- *         ID8 of node.
- *         Either '-id8' or '-id' can be specified.
- *     -id=<node-id>
- *         Full ID of node.
- *         Either '-id8' or '-id' can be specified.
- * }}}
- *
- * ====Examples====
- * {{{
- *     vvm "-id8=12345678"
- *         Opens VisualVM connected to JVM for node with '12345678' ID8.
- *     vvm "-id=5B923966-85ED-4C90-A14C-96068470E94D"
- *         Opens VisualVM connected to JVM for node with given full node ID.
- *     vvm "-home=C:\VisualVM -id8=12345678"
- *         Opens VisualVM installed in 'C:\VisualVM' directory for specified node.
- *     vvm
- *         Opens VisualVM connected to all nodes.
- * }}}
- */
-package object vvm


[3/3] incubator-ignite git commit: Merge branches 'ignite-344' and 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-2

Posted by ak...@apache.org.
Merge branches 'ignite-344' and 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-2


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

Branch: refs/heads/sprint-2
Commit: 4dd565e22911b218234d0bd703495d845b11674c
Parents: 656ee47 5b0d7db
Author: AKuznetsov <ak...@gridgain.com>
Authored: Wed Mar 4 16:34:37 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Wed Mar 4 16:34:37 2015 +0700

----------------------------------------------------------------------
 .../visor/cache/VisorCacheClearTask.java        |   3 +-
 .../visor/cache/VisorCacheLoadTask.java         |   3 +-
 .../scala/org/apache/ignite/visor/Packet.scala  |  38 ------
 .../ignite/visor/commands/VisorConsole.scala    |   2 -
 .../ignite/visor/commands/ack/Packet.scala      |  55 --------
 .../visor/commands/ack/VisorAckCommand.scala    |   2 +-
 .../ignite/visor/commands/alert/Packet.scala    | 108 ----------------
 .../ignite/visor/commands/cache/Packet.scala    | 127 -------------------
 .../commands/cache/VisorCacheCommand.scala      |   2 +-
 .../ignite/visor/commands/config/Packet.scala   |  55 --------
 .../ignite/visor/commands/deploy/Packet.scala   |  76 -----------
 .../ignite/visor/commands/disco/Packet.scala    |  72 -----------
 .../ignite/visor/commands/events/Packet.scala   |  97 --------------
 .../ignite/visor/commands/gc/Packet.scala       |  61 ---------
 .../ignite/visor/commands/kill/Packet.scala     |  78 ------------
 .../visor/commands/kill/VisorKillCommand.scala  |   2 +-
 .../ignite/visor/commands/node/Packet.scala     |  60 ---------
 .../ignite/visor/commands/ping/Packet.scala     |  50 --------
 .../visor/commands/ping/VisorPingCommand.scala  |   2 +-
 .../ignite/visor/commands/start/Packet.scala    |  90 -------------
 .../ignite/visor/commands/tasks/Packet.scala    | 116 -----------------
 .../commands/tasks/VisorTasksCommand.scala      |  26 +---
 .../ignite/visor/commands/top/Packet.scala      |  87 -------------
 .../ignite/visor/commands/vvm/Packet.scala      |  61 ---------
 24 files changed, 15 insertions(+), 1258 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4dd565e2/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/VisorConsole.scala
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4dd565e2/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
----------------------------------------------------------------------


[2/3] incubator-ignite git commit: Merge branches 'ignite-344' and 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-344

Posted by ak...@apache.org.
Merge branches 'ignite-344' and 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-344


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

Branch: refs/heads/sprint-2
Commit: 5b0d7db77cdbca9c2d33b3c64f567f61faec8a8f
Parents: 4348d9c b81c6a2
Author: AKuznetsov <ak...@gridgain.com>
Authored: Tue Mar 3 15:34:35 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Tue Mar 3 15:34:35 2015 +0700

----------------------------------------------------------------------
 config/hadoop/default-config.xml                |   12 +
 config/ignite-log4j.xml                         |    2 +-
 examples/pom-standalone.xml                     |    2 +-
 .../datagrid/CacheContinuousQueryExample.java   |    2 +-
 .../store/CacheNodeWithStoreStartup.java        |    6 +-
 .../store/jdbc/CacheJdbcPersonStore.java        |  115 +-
 ipc/shmem/Makefile.am                           |   15 +
 ipc/shmem/igniteshmem/Makefile.am               |   15 +
 ipc/shmem/include/Makefile.am                   |   15 +
 modules/clients/src/test/keystore/generate.sh   |   15 +-
 .../src/main/java/org/apache/ignite/Ignite.java |    4 +-
 .../java/org/apache/ignite/IgniteCluster.java   |    8 +-
 .../ignite/cache/CacheTypeFieldMetadata.java    |    2 +-
 .../apache/ignite/cache/CacheTypeMetadata.java  |   18 +-
 .../ignite/cache/query/ContinuousQuery.java     |   18 +-
 .../apache/ignite/cache/store/CacheStore.java   |    4 +-
 .../ignite/cache/store/CacheStoreAdapter.java   |    2 +-
 .../ignite/cache/store/CacheStoreSession.java   |   17 +-
 .../apache/ignite/cluster/ClusterMetrics.java   |    2 +-
 .../configuration/IgniteConfiguration.java      |    5 +-
 .../configuration/QueryConfiguration.java       |   37 +-
 .../java/org/apache/ignite/igfs/IgfsMode.java   |    6 +-
 .../ignite/internal/GridKernalContext.java      |   10 +-
 .../ignite/internal/GridKernalContextImpl.java  |   14 +-
 .../apache/ignite/internal/GridProperties.java  |   78 -
 .../ignite/internal/GridUpdateNotifier.java     |    2 +-
 .../apache/ignite/internal/IgniteKernal.java    |   41 +-
 .../ignite/internal/IgniteProperties.java       |   79 +
 .../ignite/internal/IgniteVersionUtils.java     |    8 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |  592 +++----
 .../internal/events/DiscoveryCustomEvent.java   |    3 +
 .../affinity/GridAffinityAssignmentCache.java   |   13 +-
 .../processors/cache/CacheMetricsImpl.java      |    4 +
 .../processors/cache/GridCacheContext.java      |   19 +
 .../processors/cache/GridCacheMapEntry.java     |    9 +
 .../processors/cache/GridCacheProcessor.java    |   15 +
 .../processors/cache/GridCacheStoreManager.java |   18 +-
 .../processors/cache/IgniteCacheProxy.java      |    6 +-
 .../GridDistributedCacheAdapter.java            |    2 +
 .../distributed/dht/GridDhtCacheEntry.java      |    3 +
 .../distributed/dht/GridDhtLocalPartition.java  |    5 +
 .../dht/atomic/GridDhtAtomicCache.java          |    2 +-
 .../dht/colocated/GridDhtColocatedCache.java    |    2 +-
 .../cache/transactions/IgniteTxManager.java     |    7 +-
 .../processors/cluster/ClusterProcessor.java    |   46 +
 .../dataload/IgniteDataLoaderImpl.java          |   29 +-
 .../plugin/IgnitePluginProcessor.java           |   24 +
 .../ignite/internal/util/IgniteUtils.java       |   90 +-
 .../ignite/internal/visor/cache/VisorCache.java |  190 +--
 .../cache/VisorCacheAffinityConfiguration.java  |   53 +-
 .../visor/cache/VisorCacheConfiguration.java    |  484 +-----
 .../cache/VisorCacheDefaultConfiguration.java   |   27 +-
 .../cache/VisorCacheEvictionConfiguration.java  |   81 +-
 .../cache/VisorCacheNearConfiguration.java      |   42 +-
 .../cache/VisorCachePreloadConfiguration.java   |   54 +-
 .../cache/VisorCacheStoreConfiguration.java     |  148 +-
 .../VisorCacheWriteBehindConfiguration.java     |  137 --
 .../visor/node/VisorAtomicConfiguration.java    |   27 +-
 .../visor/node/VisorBasicConfiguration.java     |  197 +--
 .../node/VisorCacheQueryConfiguration.java      |   45 +-
 .../node/VisorExecutorServiceConfiguration.java |   54 +-
 .../visor/node/VisorGridConfiguration.java      |  177 +-
 .../visor/node/VisorIgfsConfiguration.java      |  244 +--
 .../visor/node/VisorLifecycleConfiguration.java |    9 +-
 .../visor/node/VisorMetricsConfiguration.java   |   29 +-
 .../node/VisorPeerToPeerConfiguration.java      |   28 +-
 .../visor/node/VisorQueryConfiguration.java     |   65 +-
 .../visor/node/VisorRestConfiguration.java      |   80 +-
 .../node/VisorSegmentationConfiguration.java    |   45 +-
 .../visor/node/VisorSpisConfiguration.java      |   92 +-
 .../node/VisorTransactionConfiguration.java     |   62 +-
 .../internal/visor/util/VisorTaskUtils.java     |    4 +-
 .../optimized-classnames.previous.properties    |   15 +
 .../optimized/optimized-classnames.properties   | 1565 +-----------------
 .../apache/ignite/plugin/PluginProvider.java    |    5 +
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |  137 +-
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   |  116 ++
 .../TcpDiscoveryCustomEventMessage.java         |    3 +
 .../core/src/main/resources/ignite.properties   |    2 +-
 .../core/src/test/config/store/jdbc/Ignite.xml  |   63 +-
 .../internal/GridUpdateNotifierSelfTest.java    |    2 +-
 .../GridCacheAbstractLocalStoreSelfTest.java    |  440 +++++
 .../cache/GridCacheAbstractMetricsSelfTest.java |   42 +
 ...acheAbstractUsersAffinityMapperSelfTest.java |  207 +++
 ...dCacheAtomicUsersAffinityMapperSelfTest.java |   45 +
 .../GridCachePartitionedLocalStoreSelfTest.java |   51 +
 ...chePartitionedOffHeapLocalStoreSelfTest.java |   56 +
 .../GridCacheReplicatedLocalStoreSelfTest.java  |   51 +
 ...heReplicatedUsersAffinityMapperSelfTest.java |   45 +
 ...ridCacheTxPartitionedLocalStoreSelfTest.java |   51 +
 .../GridCacheTxUsersAffinityMapperSelfTest.java |   45 +
 .../GridCacheQueueCleanupSelfTest.java          |    1 -
 .../IgniteCacheExpiryPolicyAbstractTest.java    |   38 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |    8 +-
 .../config/GridTestProperties.java              |   10 +-
 .../junits/cache/TestCacheSession.java          |    5 +
 .../cache/TestThreadLocalCacheSession.java      |    5 +
 .../ignite/testsuites/IgniteCacheTestSuite.java |    4 +
 modules/extdata/p2p/pom.xml                     |    6 -
 .../client/hadoop/GridHadoopClientProtocol.java |    6 +-
 .../hadoop/IgfsHadoopFileSystemWrapper.java     |  412 +++++
 .../igfs/hadoop/v1/IgfsHadoopFileSystem.java    |    3 +-
 .../igfs/hadoop/v2/IgfsHadoopFileSystem.java    |    3 +-
 .../igfs/hadoop/IgfsHadoopFSProperties.java     |   10 +-
 .../hadoop/IgfsHadoopFileSystemWrapper.java     |  413 -----
 .../internal/igfs/hadoop/IgfsHadoopReader.java  |    2 +-
 .../internal/igfs/hadoop/IgfsHadoopUtils.java   |    4 +-
 .../hadoop/GridHadoopClassLoader.java           |   12 +-
 .../processors/hadoop/GridHadoopSetup.java      |    8 +-
 .../processors/hadoop/GridHadoopUtils.java      |    4 +-
 .../collections/GridHadoopHashMultimapBase.java |    2 +-
 .../GridHadoopExternalCommunication.java        |   14 +-
 .../hadoop/v1/GridHadoopV1MapTask.java          |    6 +-
 .../v2/GridHadoopV2JobResourceManager.java      |    2 +-
 .../GridHadoopClientProtocolSelfTest.java       |    6 +-
 .../apache/ignite/igfs/IgfsEventsTestSuite.java |    2 +-
 .../IgfsHadoop20FileSystemAbstractSelfTest.java |    2 +-
 .../igfs/IgfsHadoopDualAbstractSelfTest.java    |    2 +-
 .../IgfsHadoopFileSystemAbstractSelfTest.java   |    1 +
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |    2 +-
 .../hadoop/GridHadoopGroupingTest.java          |    4 +-
 .../igfs/IgfsPerformanceBenchmark.java          |    9 +-
 modules/hibernate/pom.xml                       |    6 -
 .../HibernateReadWriteAccessStrategy.java       |   81 +-
 modules/indexing/pom.xml                        |    6 -
 modules/jta/pom.xml                             |    6 -
 modules/scalar/pom.xml                          |   12 +-
 .../ignite/schema/generator/PojoGenerator.java  |    3 +-
 .../schema/generator/SnippetGenerator.java      |  138 ++
 .../ignite/schema/generator/XmlGenerator.java   |    8 +-
 .../apache/ignite/schema/model/PojoField.java   |   11 +-
 .../apache/ignite/schema/ui/SchemaLoadApp.java  |    2 +
 .../apache/ignite/schema/load/model/Ignite.xml  |  133 +-
 modules/spring/pom.xml                          |    6 -
 modules/visor-console/pom.xml                   |    7 -
 .../commands/alert/VisorAlertCommand.scala      |    8 +-
 .../commands/cache/VisorCacheCommand.scala      |  116 +-
 .../commands/cache/VisorCacheScanCommand.scala  |    7 +-
 .../config/VisorConfigurationCommand.scala      |  141 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |    2 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    6 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   89 +-
 .../commands/tasks/VisorTasksCommandSpec.scala  |    2 +-
 modules/web/pom.xml                             |    6 -
 modules/winservice/IgniteService.sln            |    2 +-
 .../IgniteService/IgniteService.csproj          |    2 +-
 .../config/benchmark-atomic-win.properties      |   15 +
 .../config/benchmark-atomic.properties          |   15 +
 .../config/benchmark-compute-win.properties     |   15 +
 .../config/benchmark-compute.properties         |   15 +
 .../config/benchmark-multicast.properties       |   15 +
 .../config/benchmark-query-win.properties       |   15 +
 .../yardstick/config/benchmark-query.properties |   15 +
 .../config/benchmark-tx-win.properties          |   15 +
 .../yardstick/config/benchmark-tx.properties    |   15 +
 .../yardstick/config/benchmark-win.properties   |   15 +
 modules/yardstick/config/benchmark.properties   |   15 +
 .../yardstick/config/ignite-store-config.xml    |   15 +-
 pom.xml                                         |  152 +-
 159 files changed, 3884 insertions(+), 5012 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5b0d7db7/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
----------------------------------------------------------------------