You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by se...@apache.org on 2015/02/02 02:54:13 UTC

[45/50] [abbrv] incubator-ignite git commit: gg*{sh, bat} renamed to ignite*{sh, bat}

gg*{sh,bat} renamed to ignite*{sh,bat}


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

Branch: refs/heads/ignite-sql
Commit: 7e8ea4f1d71e6c9a9e329a0f00471878a73d6b54
Parents: 115f597
Author: Anton Vinogradov <av...@gridgain.com>
Authored: Fri Jan 30 22:33:10 2015 +0300
Committer: Anton Vinogradov <av...@gridgain.com>
Committed: Fri Jan 30 22:33:11 2015 +0300

----------------------------------------------------------------------
 assembly/libs/readme.txt                        |   4 +-
 assembly/release-base-fabric.xml                |   4 +-
 assembly/release-base.xml                       |   4 +-
 bin/ggrouter.bat                                |  33 ---
 bin/ggrouter.sh                                 |  50 ----
 bin/ggstart.bat                                 | 228 -------------------
 bin/ggstart.sh                                  | 176 --------------
 bin/ggvisorcmd.bat                              | 144 ------------
 bin/ggvisorcmd.sh                               | 124 ----------
 bin/ignite.bat                                  | 228 +++++++++++++++++++
 bin/ignite.sh                                   | 176 ++++++++++++++
 bin/igniterouter.bat                            |  33 +++
 bin/igniterouter.sh                             |  50 ++++
 bin/ignitevisorcmd.bat                          | 144 ++++++++++++
 bin/ignitevisorcmd.sh                           | 124 ++++++++++
 bin/setup-hadoop.bat                            |   2 +-
 bin/setup-hadoop.sh                             |   2 +-
 config/hadoop/default-config.xml                |   2 +-
 config/router/default-router.xml                |   2 +-
 docs/hadoop_readme.md                           |   6 +-
 docs/ignite_readme.md                           |  12 +-
 examples/config/example-cache.xml               |   2 +-
 examples/config/example-streamer.xml            |   2 +-
 examples/config/filesystem/example-ggfs.xml     |   2 +-
 examples/rest/http-rest-example.php             |   2 +-
 examples/rest/memcache-rest-example.php         |   2 +-
 .../compute/ComputeBroadcastExample.java        |   2 +-
 .../compute/ComputeCallableExample.java         |   2 +-
 .../examples/compute/ComputeClosureExample.java |   2 +-
 .../compute/ComputeContinuousMapperExample.java |   2 +-
 .../compute/ComputeExecutorServiceExample.java  |   2 +-
 .../ComputeFibonacciContinuationExample.java    |   2 +-
 .../compute/ComputeProjectionExample.java       |   2 +-
 .../examples/compute/ComputeReducerExample.java |   2 +-
 .../compute/ComputeRunnableExample.java         |   2 +-
 .../compute/ComputeScheduleExample.java         |   2 +-
 .../examples/compute/ComputeTaskMapExample.java |   2 +-
 .../compute/ComputeTaskSplitExample.java        |   2 +-
 .../compute/montecarlo/CreditRiskExample.java   |   2 +-
 .../examples/datagrid/CacheAffinityExample.java |   2 +-
 .../examples/datagrid/CacheApiExample.java      |   2 +-
 .../datagrid/CacheContinuousQueryExample.java   |   2 +-
 .../datagrid/CacheDataLoaderExample.java        |   2 +-
 .../examples/datagrid/CacheEventsExample.java   |   2 +-
 .../datagrid/CachePopularNumbersExample.java    |   2 +-
 .../examples/datagrid/CachePutGetExample.java   |   2 +-
 .../examples/datagrid/CacheQueryExample.java    |   2 +-
 .../datagrid/CacheTransactionExample.java       |   2 +-
 .../datastructures/CacheAtomicLongExample.java  |   2 +-
 .../CacheAtomicReferenceExample.java            |   2 +-
 .../CacheAtomicSequenceExample.java             |   2 +-
 .../CacheAtomicStampedExample.java              |   2 +-
 .../CacheCountDownLatchExample.java             |   2 +-
 .../datastructures/CacheQueueExample.java       |   2 +-
 .../datastructures/CacheSetExample.java         |   2 +-
 .../starschema/CacheStarSchemaExample.java      |   2 +-
 .../ignite/examples/events/EventsExample.java   |   2 +-
 .../ignite/examples/ggfs/GgfsExample.java       |   2 +-
 .../examples/ggfs/GgfsMapReduceExample.java     |   2 +-
 .../ignite/examples/ggfs/GgfsNodeStartup.java   |   4 +-
 .../examples/messaging/MessagingExample.java    |   2 +-
 .../messaging/MessagingPingPongExample.java     |   2 +-
 .../MessagingPingPongListenActorExample.java    |   2 +-
 .../misc/deployment/DeploymentExample.java      |   2 +-
 .../misc/springbean/SpringBeanExample.java      |   2 +-
 .../examples/services/ServicesExample.java      |   2 +-
 .../streaming/StreamingCheckInExample.java      |   2 +-
 .../StreamingPopularNumbersExample.java         |   2 +-
 .../streaming/StreamingPriceBarsExample.java    |   2 +-
 .../StreamingRunningAverageExample.java         |   2 +-
 .../apache/ignite/examples/ComputeExample.java  |   2 +-
 .../ignite/examples/MessagingExample.java       |   2 +-
 .../examples/ScalarCacheAffinityExample1.scala  |   2 +-
 .../examples/ScalarCacheAffinityExample2.scala  |   2 +-
 .../ScalarCacheAffinitySimpleExample.scala      |   2 +-
 .../scalar/examples/ScalarCacheExample.scala    |   2 +-
 .../ScalarCachePopularNumbersExample.scala      |   2 +-
 .../examples/ScalarCacheQueryExample.scala      |   2 +-
 .../scalar/examples/ScalarClosureExample.scala  |   2 +-
 .../examples/ScalarContinuationExample.scala    |   2 +-
 .../examples/ScalarCreditRiskExample.scala      |   2 +-
 .../examples/ScalarPiCalculationExample.scala   |   2 +-
 .../scalar/examples/ScalarPingPongExample.scala |   2 +-
 .../scalar/examples/ScalarPrimeExample.scala    |   2 +-
 .../scalar/examples/ScalarScheduleExample.scala |   2 +-
 .../examples/ScalarSnowflakeSchemaExample.scala |   2 +-
 .../scalar/examples/ScalarTaskExample.scala     |   2 +-
 .../examples/ScalarWorldShortestMapReduce.scala |   2 +-
 modules/aop/readme.txt                          |   2 +-
 modules/aws/readme.txt                          |   2 +-
 modules/clients/src/test/bin/start-nodes.cmd    |  10 +-
 modules/clients/src/test/bin/start-nodes.sh     |   8 +-
 .../clients/src/test/resources/spring-cache.xml |   2 +-
 .../src/test/resources/spring-router-ssl.xml    |   2 +-
 .../src/test/resources/spring-router.xml        |   2 +-
 .../src/test/resources/spring-server-node.xml   |   2 +-
 .../test/resources/spring-server-ssl-node.xml   |   2 +-
 .../java/org/apache/ignite/IgniteCluster.java   |   4 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |   4 +-
 .../java/org/apache/ignite/IgniteLogger.java    |   2 +-
 .../apache/ignite/IgniteSystemProperties.java   |   4 +-
 .../main/java/org/apache/ignite/Ignition.java   |   4 +-
 .../ignite/client/router/GridRouterFactory.java |   2 +-
 .../configuration/IgniteDeploymentMode.java     |   2 +-
 .../apache/ignite/internal/IgniteKernal.java    |   6 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   2 +-
 .../apache/ignite/lifecycle/LifecycleBean.java  |   2 +-
 .../segmentation/GridSegmentationPolicy.java    |   2 +-
 .../startup/cmdline/CommandLineStartup.java     |  10 +-
 .../startup/cmdline/CommandLineTransformer.java |   6 +-
 .../core/src/test/bin/start-nodes-custom.bat    |   2 +-
 modules/core/src/test/bin/start-nodes-custom.sh |   2 +-
 .../spring-cache-client-benchmark-1.xml         |   2 +-
 .../spring-cache-client-benchmark-2.xml         |   2 +-
 .../spring-cache-client-benchmark-3.xml         |   2 +-
 modules/core/src/test/config/example-cache.xml  |   2 +-
 modules/core/src/test/config/ggfs-loopback.xml  |   2 +-
 modules/core/src/test/config/ggfs-shmem.xml     |   2 +-
 .../core/src/test/config/spring-cache-load.xml  |   2 +-
 .../core/src/test/config/spring-multicache.xml  |   2 +-
 .../average/spring-streamer-average-base.xml    |   2 +-
 .../average/spring-streamer-average-local.xml   |   2 +-
 .../average/spring-streamer-average-random.xml  |   2 +-
 .../config/streamer/spring-streamer-base.xml    |   2 +-
 .../GridCacheMultiNodeDataStructureTest.java    |   4 +-
 .../capacity/spring-capacity-cache.xml          |   2 +-
 .../loadtests/colocation/spring-colocation.xml  |   2 +-
 .../loadtests/mapper/GridNodeStartup.java       |   4 +-
 .../startup/GridRandomCommandLineLoader.java    |   2 +-
 .../ignite/startup/GridVmNodesStarter.java      |   2 +-
 .../core/src/test/webapp/META-INF/gg-config.xml |   2 +-
 modules/email/readme.txt                        |   2 +-
 modules/hadoop/readme.txt                       |   2 +-
 modules/hibernate/readme.txt                    |   2 +-
 modules/indexing/readme.txt                     |   2 +-
 modules/jcl/readme.txt                          |   2 +-
 modules/jta/readme.txt                          |   2 +-
 modules/log4j/readme.txt                        |   2 +-
 modules/rest-http/readme.txt                    |   2 +-
 modules/scalar/readme.txt                       |   2 +-
 modules/schedule/readme.txt                     |   2 +-
 modules/slf4j/readme.txt                        |   2 +-
 modules/spring/readme.txt                       |   2 +-
 .../ignite/cache/spring/SpringCacheManager.java |   2 +-
 modules/ssh/readme.txt                          |   2 +-
 .../util/nodestart/GridNodeCallableImpl.java    |   8 +-
 modules/urideploy/readme.txt                    |   2 +-
 .../scala/org/apache/ignite/visor/Packet.scala  |   2 +-
 .../ignite/visor/commands/start/Packet.scala    |   4 +-
 .../commands/start/VisorStartCommand.scala      |   8 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   2 +-
 modules/web/readme.txt                          |   2 +-
 152 files changed, 934 insertions(+), 934 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/assembly/libs/readme.txt
----------------------------------------------------------------------
diff --git a/assembly/libs/readme.txt b/assembly/libs/readme.txt
index 7595da9..78b3604 100644
--- a/assembly/libs/readme.txt
+++ b/assembly/libs/readme.txt
@@ -2,7 +2,7 @@ Apache Ignite Dependencies
 --------------------------
 
 Current folder contains JAR files for all Apache Ignite modules along with their dependencies.
-When node is started using 'ggstart.{sh|bat}' script, all JARs and classes located in
+When node is started using 'ignite.{sh|bat}' script, all JARs and classes located in
 'libs' folder and all its sub-folders except 'optional' are added to classpath of the node.
 
 By default, only Apache Ignite core JAR and a minimum set of modules is enabled, while other
@@ -10,7 +10,7 @@ modules are located in 'optional' folder and therefore disabled.
 
 To enable any of optional Ignite modules when starting a standalone node,
 move corresponding module folder from 'libs/optional' to 'libs' before running
-'ggstart.{sh|bat}' script. The content of the module folder will be added to
+'ignite.{sh|bat}' script. The content of the module folder will be added to
 classpath in this case.
 
 If you need to add your own classes to classpath of the node (e.g., task classes), put them

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/assembly/release-base-fabric.xml
----------------------------------------------------------------------
diff --git a/assembly/release-base-fabric.xml b/assembly/release-base-fabric.xml
index bd70839..f985b6a 100644
--- a/assembly/release-base-fabric.xml
+++ b/assembly/release-base-fabric.xml
@@ -39,7 +39,7 @@
             <directory>bin</directory>
             <outputDirectory>/bin</outputDirectory>
             <includes>
-                <include>ggrouter.bat</include>
+                <include>igniterouter.bat</include>
             </includes>
         </fileSet>
 
@@ -48,7 +48,7 @@
             <outputDirectory>/bin</outputDirectory>
             <fileMode>0755</fileMode>
             <includes>
-                <include>ggrouter.sh</include>
+                <include>igniterouter.sh</include>
             </includes>
         </fileSet>
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/assembly/release-base.xml
----------------------------------------------------------------------
diff --git a/assembly/release-base.xml b/assembly/release-base.xml
index 3995732..5cdeb2a 100644
--- a/assembly/release-base.xml
+++ b/assembly/release-base.xml
@@ -55,7 +55,7 @@
             </includes>
             <excludes>
                 <exclude>**/*hadoop*.bat</exclude>
-                <exclude>ggrouter.bat</exclude>
+                <exclude>igniterouter.bat</exclude>
                 <exclude>**/target-classpath.bat</exclude>
             </excludes>
         </fileSet>
@@ -69,7 +69,7 @@
             </includes>
             <excludes>
                 <exclude>**/*hadoop*.sh</exclude>
-                <exclude>ggrouter.sh</exclude>
+                <exclude>igniterouter.sh</exclude>
                 <exclude>**/target-classpath.sh</exclude>
                 <exclude>**/service.sh</exclude>
             </excludes>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ggrouter.bat
----------------------------------------------------------------------
diff --git a/bin/ggrouter.bat b/bin/ggrouter.bat
deleted file mode 100644
index a364061..0000000
--- a/bin/ggrouter.bat
+++ /dev/null
@@ -1,33 +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.
-
-::
-:: Grid router command line loader.
-::
-
-@echo off
-
-if "%OS%" == "Windows_NT" setlocal
-
-::
-:: Set router service environment.
-::
-set "DEFAULT_CONFIG=config\router\default-router.xml"
-set MAIN_CLASS=org.gridgain.client.router.impl.GridRouterCommandLineStartup
-
-::
-:: Start router service.
-::
-call "%~dp0\ggstart.bat" %*

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ggrouter.sh
----------------------------------------------------------------------
diff --git a/bin/ggrouter.sh b/bin/ggrouter.sh
deleted file mode 100755
index 29ac1d1..0000000
--- a/bin/ggrouter.sh
+++ /dev/null
@@ -1,50 +0,0 @@
-#!/bin/bash
-#  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.
-
-#
-# Router command line loader.
-#
-
-#
-# Import common functions.
-#
-if [ "${IGNITE_HOME}" = "" ];
-    then IGNITE_HOME_TMP="$(dirname "$(cd "$(dirname "$0")"; "pwd")")";IGNITE_HOME_TMP="$(dirname "${IGNITE_HOME_TMP}")" # Will be removed in release.
-    else IGNITE_HOME_TMP=${IGNITE_HOME};
-fi
-
-#
-# Set SCRIPTS_HOME - base path to scripts.
-#
-SCRIPTS_HOME="${IGNITE_HOME_TMP}/bin"
-
-source "${SCRIPTS_HOME}"/include/functions.sh
-
-#
-# Discover IGNITE_HOME environment variable.
-#
-setGridGainHome
-
-#
-# Set router service environment.
-#
-export DEFAULT_CONFIG=config/router/default-router.xml
-export MAIN_CLASS=org.gridgain.client.router.impl.GridRouterCommandLineStartup
-
-#
-# Start router service.
-#
-. "${SCRIPTS_HOME}"/ggstart.sh $@

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ggstart.bat
----------------------------------------------------------------------
diff --git a/bin/ggstart.bat b/bin/ggstart.bat
deleted file mode 100644
index 2db610b..0000000
--- a/bin/ggstart.bat
+++ /dev/null
@@ -1,228 +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.
-
-::
-:: Grid command line loader.
-::
-
-@echo off
-
-if "%OS%" == "Windows_NT"  setlocal
-
-:: Check JAVA_HOME.
-if defined JAVA_HOME  goto checkJdk
-    echo %0, ERROR:
-    echo JAVA_HOME environment variable is not found.
-    echo Please point JAVA_HOME variable to location of JDK 1.7 or JDK 1.8.
-    echo You can also download latest JDK at http://java.com/download.
-goto error_finish
-
-:checkJdk
-:: Check that JDK is where it should be.
-if exist "%JAVA_HOME%\bin\java.exe" goto checkJdkVersion
-    echo %0, ERROR:
-    echo JAVA is not found in JAVA_HOME=%JAVA_HOME%.
-    echo Please point JAVA_HOME variable to installation of JDK 1.7 or JDK 1.8.
-    echo You can also download latest JDK at http://java.com/download.
-goto error_finish
-
-:checkJdkVersion
-"%JAVA_HOME%\bin\java.exe" -version 2>&1 | findstr "1\.[78]\." > nul
-if %ERRORLEVEL% equ 0 goto checkGridGainHome1
-    echo %0, ERROR:
-    echo The version of JAVA installed in %JAVA_HOME% is incorrect.
-    echo Please point JAVA_HOME variable to installation of JDK 1.7 or JDK 1.8.
-    echo You can also download latest JDK at http://java.com/download.
-goto error_finish
-
-:: Check IGNITE_HOME.
-:checkGridGainHome1
-if defined IGNITE_HOME goto checkGridGainHome2
-    pushd "%~dp0"/..
-    set IGNITE_HOME=%CD%
-    popd
-
-:checkGridGainHome2
-:: Strip double quotes from IGNITE_HOME
-set IGNITE_HOME=%IGNITE_HOME:"=%
-
-:: remove all trailing slashes from IGNITE_HOME.
-if %IGNITE_HOME:~-1,1% == \ goto removeTrailingSlash
-if %IGNITE_HOME:~-1,1% == / goto removeTrailingSlash
-goto checkGridGainHome3
-
-:removeTrailingSlash
-set IGNITE_HOME=%IGNITE_HOME:~0,-1%
-goto checkGridGainHome2
-
-:checkGridGainHome3
-if exist "%IGNITE_HOME%\config" goto checkGridGainHome4
-    echo %0, ERROR: GridGain installation folder is not found or IGNITE_HOME environment variable is not valid.
-    echo Please create IGNITE_HOME environment variable pointing to location of
-    echo GridGain installation folder.
-    goto error_finish
-
-:checkGridGainHome4
-
-::
-:: Set SCRIPTS_HOME - base path to scripts.
-::
-set SCRIPTS_HOME=%IGNITE_HOME%\bin
-
-:: Remove trailing spaces
-for /l %%a in (1,1,31) do if /i "%SCRIPTS_HOME:~-1%" == " " set SCRIPTS_HOME=%SCRIPTS_HOME:~0,-1%
-
-if /i "%SCRIPTS_HOME%\" == "%~dp0" goto setProgName
-    echo %0, WARN: IGNITE_HOME environment variable may be pointing to wrong folder: %IGNITE_HOME%
-
-:setProgName
-::
-:: Set program name.
-::
-set PROG_NAME=ggstart.bat
-if "%OS%" == "Windows_NT" set PROG_NAME=%~nx0%
-
-:run
-
-::
-:: Set IGNITE_LIBS
-::
-call "%SCRIPTS_HOME%\include\setenv.bat"
-call "%SCRIPTS_HOME%\include\target-classpath.bat" &:: Will be removed in release.
-set CP=%IGNITE_LIBS%
-
-::
-:: Parse command line parameters.
-::
-if not defined DEFAULT_CONFIG set "DEFAULT_CONFIG=config\default-config.xml"
-call "%SCRIPTS_HOME%\include\parseargs.bat" %*
-if %ERRORLEVEL% neq 0 (
-    echo Arguments parsing failed
-    exit /b %ERRORLEVEL%
-)
-
-::
-:: Process 'restart'.
-::
-set RANDOM_NUMBER_COMMAND="%JAVA_HOME%\bin\java.exe" -cp %CP% org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator
-for /f "usebackq tokens=*" %%i in (`"%RANDOM_NUMBER_COMMAND%"`) do set RANDOM_NUMBER=%%i
-
-set RESTART_SUCCESS_FILE="%IGNITE_HOME%\work\ignite_success_%RANDOM_NUMBER%"
-set RESTART_SUCCESS_OPT=-DIGNITE_SUCCESS_FILE=%RESTART_SUCCESS_FILE%
-
-::
-:: Find available port for JMX
-::
-:: You can specify IGNITE_JMX_PORT environment variable for overriding automatically found JMX port
-::
-for /F "tokens=*" %%A in ('""%JAVA_HOME%\bin\java" -cp %CP% org.gridgain.grid.util.portscanner.GridJmxPortFinder"') do (
-    set JMX_PORT=%%A
-)
-
-::
-:: This variable defines necessary parameters for JMX
-:: monitoring and management.
-::
-:: This enables remote unsecure access to JConsole or VisualVM.
-::
-:: ADD YOUR ADDITIONAL PARAMETERS/OPTIONS HERE
-::
-if "%JMX_PORT%" == "" (
-    echo %0, WARN: Failed to resolve JMX host. JMX will be disabled.
-    set JMX_MON=
-) else (
-    set JMX_MON=-Dcom.sun.management.jmxremote -Dcom.sun.management.jmxremote.port=%JMX_PORT% ^
-    -Dcom.sun.management.jmxremote.authenticate=false -Dcom.sun.management.jmxremote.ssl=false
-)
-
-::
-:: JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
-::
-:: ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
-::
-if "%JVM_OPTS%" == "" set JVM_OPTS=-Xms1g -Xmx1g -server -XX:+AggressiveOpts -XX:MaxPermSize=256m
-
-::
-:: Uncomment the following GC settings if you see spikes in your throughput due to Garbage Collection.
-::
-:: set JVM_OPTS=%JVM_OPTS% -XX:+UseParNewGC -XX:+UseConcMarkSweepGC -XX:+UseTLAB -XX:NewSize=128m -XX:MaxNewSize=128m
-:: set JVM_OPTS=%JVM_OPTS% -XX:MaxTenuringThreshold=0 -XX:SurvivorRatio=1024 -XX:+UseCMSInitiatingOccupancyOnly -XX:CMSInitiatingOccupancyFraction=60
-
-::
-:: Uncomment if you get StackOverflowError.
-:: On 64 bit systems this value can be larger, e.g. -Xss16m
-::
-:: set JVM_OPTS=%JVM_OPTS% -Xss4m
-
-::
-:: Uncomment to set preference to IPv4 stack.
-::
-:: set JVM_OPTS=%JVM_OPTS% -Djava.net.preferIPv4Stack=true
-
-::
-:: Assertions are disabled by default since version 3.5.
-:: If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
-::
-set ENABLE_ASSERTIONS=1
-
-::
-:: Set '-ea' options if assertions are enabled.
-::
-if %ENABLE_ASSERTIONS% == 1 set JVM_OPTS=%JVM_OPTS% -ea
-
-:run_java
-
-::
-:: Set main class to start service (grid node by default).
-::
-
-if "%MAIN_CLASS%" == "" set MAIN_CLASS=org.apache.ignite.startup.cmdline.CommandLineStartup
-
-::
-:: Remote debugging (JPDA).
-:: Uncomment and change if remote debugging is required.
-:: set JVM_OPTS=-Xdebug -Xrunjdwp:transport=dt_socket,address=8787,server=y,suspend=n %JVM_OPTS%
-::
-
-if "%INTERACTIVE%" == "1" (
-    "%JAVA_HOME%\bin\java.exe" %JVM_OPTS% %QUIET% %RESTART_SUCCESS_OPT% %JMX_MON% ^
-    -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="%IGNITE_HOME%" -DIGNITE_PROG_NAME="%PROG_NAME%" %JVM_XOPTS% ^
-    -cp "%CP%" %MAIN_CLASS%
-) else (
-    "%JAVA_HOME%\bin\java.exe" %JVM_OPTS% %QUIET% %RESTART_SUCCESS_OPT% %JMX_MON% ^
-    -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="%IGNITE_HOME%" -DIGNITE_PROG_NAME="%PROG_NAME%" %JVM_XOPTS% ^
-    -cp "%CP%" %MAIN_CLASS% "%CONFIG%"
-)
-
-set JAVA_ERRORLEVEL=%ERRORLEVEL%
-
-:: errorlevel 130 if aborted with Ctrl+c
-if %JAVA_ERRORLEVEL%==130 goto finish
-
-:: Exit if first run unsuccessful (Loader must create file).
-if not exist %RESTART_SUCCESS_FILE% goto error_finish
-del %RESTART_SUCCESS_FILE%
-
-goto run_java
-
-:finish
-if not exist %RESTART_SUCCESS_FILE% goto error_finish
-del %RESTART_SUCCESS_FILE%
-
-:error_finish
-
-if not "%NO_PAUSE%" == "1" pause
-
-goto :eof

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ggstart.sh
----------------------------------------------------------------------
diff --git a/bin/ggstart.sh b/bin/ggstart.sh
deleted file mode 100755
index 4e2f37c..0000000
--- a/bin/ggstart.sh
+++ /dev/null
@@ -1,176 +0,0 @@
-#!/bin/bash
-#  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.
-
-#
-# Grid command line loader.
-#
-
-#
-# Import common functions.
-#
-if [ "${IGNITE_HOME}" = "" ];
-    then IGNITE_HOME_TMP="$(dirname "$(cd "$(dirname "$0")"; "pwd")")";
-    else IGNITE_HOME_TMP=${IGNITE_HOME};
-fi
-
-#
-# Set SCRIPTS_HOME - base path to scripts.
-#
-SCRIPTS_HOME="${IGNITE_HOME_TMP}/bin"
-
-source "${SCRIPTS_HOME}"/include/functions.sh
-
-#
-# Discover path to Java executable and check it's version.
-#
-checkJava
-
-#
-# Discover IGNITE_HOME environment variable.
-#
-setGridGainHome
-
-if [ "${DEFAULT_CONFIG}" == "" ]; then
-    DEFAULT_CONFIG=config/default-config.xml
-fi
-
-#
-# Parse command line parameters.
-#
-. "${SCRIPTS_HOME}"/include/parseargs.sh
-
-#
-# Set IGNITE_LIBS.
-#
-. "${SCRIPTS_HOME}"/include/setenv.sh
-. "${SCRIPTS_HOME}"/include/target-classpath.sh # Will be removed in release.
-CP="${IGNITE_LIBS}"
-
-RANDOM_NUMBER=$("$JAVA" -cp "${CP}" org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator)
-
-RESTART_SUCCESS_FILE="${IGNITE_HOME}/work/ignite_success_${RANDOM_NUMBER}"
-RESTART_SUCCESS_OPT="-DIGNITE_SUCCESS_FILE=${RESTART_SUCCESS_FILE}"
-
-#
-# Find available port for JMX
-#
-# You can specify IGNITE_JMX_PORT environment variable for overriding automatically found JMX port
-#
-findAvailableJmxPort
-
-# Mac OS specific support to display correct name in the dock.
-osname=`uname`
-
-if [ "${DOCK_OPTS}" == "" ]; then
-    DOCK_OPTS="-Xdock:name=GridGain Node"
-fi
-
-#
-# JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
-#
-# ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
-#
-if [ -z "$JVM_OPTS" ] ; then
-    JVM_OPTS="-Xms1g -Xmx1g -server -XX:+AggressiveOpts -XX:MaxPermSize=256m"
-fi
-
-#
-# Uncomment the following GC settings if you see spikes in your throughput due to Garbage Collection.
-#
-# JVM_OPTS="$JVM_OPTS -XX:+UseParNewGC -XX:+UseConcMarkSweepGC -XX:+UseTLAB -XX:NewSize=128m -XX:MaxNewSize=128m"
-# JVM_OPTS="$JVM_OPTS -XX:MaxTenuringThreshold=0 -XX:SurvivorRatio=1024 -XX:+UseCMSInitiatingOccupancyOnly -XX:CMSInitiatingOccupancyFraction=60"
-
-#
-# Uncomment if you get StackOverflowError.
-# On 64 bit systems this value can be larger, e.g. -Xss16m
-#
-# JVM_OPTS="${JVM_OPTS} -Xss4m"
-
-#
-# Uncomment to set preference for IPv4 stack.
-#
-# JVM_OPTS="${JVM_OPTS} -Djava.net.preferIPv4Stack=true"
-
-#
-# Assertions are disabled by default since version 3.5.
-# If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
-#
-ENABLE_ASSERTIONS="1"
-
-#
-# Set '-ea' options if assertions are enabled.
-#
-if [ "${ENABLE_ASSERTIONS}" = "1" ]; then
-    JVM_OPTS="${JVM_OPTS} -ea"
-fi
-
-#
-# Set main class to start service (grid node by default).
-#
-if [ "${MAIN_CLASS}" = "" ]; then
-    MAIN_CLASS=org.apache.ignite.startup.cmdline.CommandLineStartup
-fi
-
-#
-# Remote debugging (JPDA).
-# Uncomment and change if remote debugging is required.
-#
-# JVM_OPTS="-Xdebug -Xrunjdwp:transport=dt_socket,address=8787,server=y,suspend=n ${JVM_OPTS}"
-
-ERRORCODE="-1"
-
-while [ "${ERRORCODE}" -ne "130" ]
-do
-    if [ "${INTERACTIVE}" == "1" ] ; then
-        case $osname in
-            Darwin*)
-                "$JAVA" ${JVM_OPTS} ${QUIET} "${DOCK_OPTS}" "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
-                -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
-                -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS}
-            ;;
-            *)
-                "$JAVA" ${JVM_OPTS} ${QUIET} "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
-                -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
-                -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS}
-            ;;
-        esac
-    else
-        case $osname in
-            Darwin*)
-                "$JAVA" ${JVM_OPTS} ${QUIET} "${DOCK_OPTS}" "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
-                 -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
-                 -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS} "${CONFIG}"
-            ;;
-            *)
-                "$JAVA" ${JVM_OPTS} ${QUIET} "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
-                 -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
-                 -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS} "${CONFIG}"
-            ;;
-        esac
-    fi
-
-    ERRORCODE="$?"
-
-    if [ ! -f "${RESTART_SUCCESS_FILE}" ] ; then
-        break
-    else
-        rm -f "${RESTART_SUCCESS_FILE}"
-    fi
-done
-
-if [ -f "${RESTART_SUCCESS_FILE}" ] ; then
-    rm -f "${RESTART_SUCCESS_FILE}"
-fi

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ggvisorcmd.bat
----------------------------------------------------------------------
diff --git a/bin/ggvisorcmd.bat b/bin/ggvisorcmd.bat
deleted file mode 100644
index c4c64f9..0000000
--- a/bin/ggvisorcmd.bat
+++ /dev/null
@@ -1,144 +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.
-
-::
-:: Starts GridGain Visor Console.
-::
-
-@echo off
-
-if "%OS%" == "Windows_NT"  setlocal
-
-:: Check JAVA_HOME.
-if not "%JAVA_HOME%" == "" goto checkJdk
-    echo %0, ERROR: JAVA_HOME environment variable is not found.
-    echo %0, ERROR: Please create JAVA_HOME variable pointing to location of JDK 1.7 or JDK 1.8.
-    echo %0, ERROR: You can also download latest JDK at: http://java.sun.com/getjava
-goto error_finish
-
-:checkJdk
-:: Check that JDK is where it should be.
-if exist "%JAVA_HOME%\bin\java.exe" goto checkJdkVersion
-    echo %0, ERROR: The JDK is not found in %JAVA_HOME%.
-    echo %0, ERROR: Please modify your script so that JAVA_HOME would point to valid location of JDK.
-goto error_finish
-
-:checkJdkVersion
-"%JAVA_HOME%\bin\java.exe" -version 2>&1 | findstr "1\.[78]\." > nul
-if %ERRORLEVEL% equ 0 goto checkGridGainHome1
-    echo %0, ERROR: The version of JAVA installed in %JAVA_HOME% is incorrect.
-    echo %0, ERROR: Please install JDK 1.7 or 1.8.
-    echo %0, ERROR: You can also download latest JDK at: http://java.sun.com/getjava
-goto error_finish
-
-:: Check IGNITE_HOME.
-:checkGridGainHome1
-if not "%IGNITE_HOME%" == "" goto checkGridGainHome2
-    pushd "%~dp0"/..
-    set IGNITE_HOME=%CD%
-    popd
-
-:checkGridGainHome2
-:: Strip double quotes from IGNITE_HOME
-set IGNITE_HOME=%IGNITE_HOME:"=%
-
-:: remove all trailing slashes from IGNITE_HOME.
-if %IGNITE_HOME:~-1,1% == \ goto removeTrailingSlash
-if %IGNITE_HOME:~-1,1% == / goto removeTrailingSlash
-goto checkGridGainHome3
-
-:removeTrailingSlash
-set IGNITE_HOME=%IGNITE_HOME:~0,-1%
-goto checkGridGainHome2
-
-:checkGridGainHome3
-if exist "%IGNITE_HOME%\config" goto checkGridGainHome4
-    echo %0, ERROR: GridGain installation folder is not found or IGNITE_HOME environment variable is not valid.
-    echo Please create IGNITE_HOME environment variable pointing to location of
-    echo GridGain installation folder.
-    goto error_finish
-
-:checkGridGainHome4
-
-::
-:: Set SCRIPTS_HOME - base path to scripts.
-::
-set SCRIPTS_HOME=%IGNITE_HOME%\bin
-
-:: Remove trailing spaces
-for /l %%a in (1,1,31) do if /i "%SCRIPTS_HOME:~-1%" == " " set SCRIPTS_HOME=%SCRIPTS_HOME:~0,-1%
-
-if /i "%SCRIPTS_HOME%\" == "%~dp0" goto run
-    echo %0, WARN: IGNITE_HOME environment variable may be pointing to wrong folder: %IGNITE_HOME%
-
-:run
-
-::
-:: Set IGNITE_LIBS
-::
-call "%SCRIPTS_HOME%\include\setenv.bat"
-call "%SCRIPTS_HOME%\include\target-classpath.bat" &:: Will be removed in release.
-set CP=%IGNITE_HOME%\bin\include\visor-common\*;%IGNITE_HOME%\bin\include\visorcmd\*;%IGNITE_LIBS%
-
-::
-:: Parse command line parameters.
-::
-call "%SCRIPTS_HOME%\include\parseargs.bat" %*
-if %ERRORLEVEL% neq 0 (
-    echo Arguments parsing failed
-    exit /b %ERRORLEVEL%
-)
-
-::
-:: Set program name.
-::
-set PROG_NAME=gridgain.bat
-if "%OS%" == "Windows_NT" set PROG_NAME=%~nx0%
-
-::
-:: JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
-::
-:: ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
-::
-if "%JVM_OPTS_VISOR%" == "" set JVM_OPTS_VISOR=-Xms1g -Xmx1g -XX:MaxPermSize=128M
-
-::
-:: Uncomment to set preference to IPv4 stack.
-::
-:: set JVM_OPTS_VISOR=%JVM_OPTS_VISOR% -Djava.net.preferIPv4Stack=true
-
-::
-:: Assertions are disabled by default since version 3.5.
-:: If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
-::
-set ENABLE_ASSERTIONS=1
-
-::
-:: Set '-ea' options if assertions are enabled.
-::
-if %ENABLE_ASSERTIONS% == 1 set JVM_OPTS_VISOR=%JVM_OPTS_VISOR% -ea
-
-::
-:: Starts Visor console.
-::
-"%JAVA_HOME%\bin\java.exe" %JVM_OPTS_VISOR% -DIGNITE_PROG_NAME="%PROG_NAME%" ^
--DIGNITE_DEPLOYMENT_MODE_OVERRIDE=ISOLATED %QUIET% %JVM_XOPTS% -cp "%CP%" ^
- org.gridgain.visor.commands.VisorConsole
-
-:error_finish
-
-if not "%NO_PAUSE%" == "1" pause
-
-goto :eof

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ggvisorcmd.sh
----------------------------------------------------------------------
diff --git a/bin/ggvisorcmd.sh b/bin/ggvisorcmd.sh
deleted file mode 100755
index 319d282..0000000
--- a/bin/ggvisorcmd.sh
+++ /dev/null
@@ -1,124 +0,0 @@
-#!/bin/bash
-#  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.
-
-#
-# Import common functions.
-#
-if [ "${IGNITE_HOME}" = "" ];
-    then IGNITE_HOME_TMP="$(dirname "$(cd "$(dirname "$0")"; "pwd")")";IGNITE_HOME_TMP="$(dirname "${IGNITE_HOME_TMP}")" # Will be removed in release.
-    else IGNITE_HOME_TMP=${IGNITE_HOME};
-fi
-
-#
-# Set SCRIPTS_HOME - base path to scripts.
-#
-SCRIPTS_HOME="${IGNITE_HOME_TMP}/bin"
-
-source "${SCRIPTS_HOME}"/include/functions.sh
-
-#
-# Discover path to Java executable and check it's version.
-#
-checkJava
-
-#
-# Discover IGNITE_HOME environment variable.
-#
-setGridGainHome
-
-#
-# Parse command line parameters.
-#
-. "${SCRIPTS_HOME}"/include/parseargs.sh
-
-#
-# Set IGNITE_LIBS.
-#
-. "${SCRIPTS_HOME}"/include/setenv.sh
-. "${SCRIPTS_HOME}"/include/target-classpath.sh # Will be removed in release.
-CP="${IGNITE_HOME}/bin/include/visor-common/*${SEP}${IGNITE_HOME}/bin/include/visorcmd/*${SEP}${IGNITE_LIBS}"
-
-#
-# JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
-#
-# ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
-#
-JVM_OPTS="-Xms1g -Xmx1g -XX:MaxPermSize=128M -server ${JVM_OPTS}"
-
-# Mac OS specific support to display correct name in the dock.
-osname=`uname`
-
-if [ "${DOCK_OPTS}" == "" ]; then
-    DOCK_OPTS="-Xdock:name=Visor - GridGain Shell Console"
-fi
-
-#
-# Uncomment to set preference for IPv4 stack.
-#
-# JVM_OPTS="${JVM_OPTS} -Djava.net.preferIPv4Stack=true"
-
-#
-# Assertions are disabled by default since version 3.5.
-# If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
-#
-ENABLE_ASSERTIONS="1"
-
-#
-# Set '-ea' options if assertions are enabled.
-#
-if [ "${ENABLE_ASSERTIONS}" = "1" ]; then
-    JVM_OPTS="${JVM_OPTS} -ea"
-fi
-
-#
-# Save terminal setting. Used to restore terminal on finish.
-#
-SAVED_STTY=`stty -g 2>/dev/null`
-
-#
-# Restores terminal.
-#
-function restoreSttySettings() {
-    stty ${SAVED_STTY}
-}
-
-#
-# Trap that restores terminal in case script execution is interrupted.
-#
-trap restoreSttySettings INT
-
-#
-# Start Visor console.
-#
-case $osname in
-    Darwin*)
-        "$JAVA" ${JVM_OPTS} ${QUIET} "${DOCK_OPTS}" \
-        -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" -DIGNITE_PROG_NAME="$0" \
-        -DIGNITE_DEPLOYMENT_MODE_OVERRIDE=ISOLATED ${JVM_XOPTS} -cp "${CP}" \
-        org.apache.ignite.visor.commands.VisorConsole
-    ;;
-    *)
-        "$JAVA" ${JVM_OPTS} ${QUIET} -DIGNITE_UPDATE_NOTIFIER=false \
-        -DIGNITE_HOME="${IGNITE_HOME}" -DIGNITE_PROG_NAME="$0" -DIGNITE_DEPLOYMENT_MODE_OVERRIDE=ISOLATED \
-        ${JVM_XOPTS} -cp "${CP}" \
-        org.apache.ignite.visor.commands.VisorConsole
-    ;;
-esac
-
-#
-# Restore terminal.
-#
-restoreSttySettings

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ignite.bat
----------------------------------------------------------------------
diff --git a/bin/ignite.bat b/bin/ignite.bat
new file mode 100644
index 0000000..d11dc1b
--- /dev/null
+++ b/bin/ignite.bat
@@ -0,0 +1,228 @@
+::  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.
+
+::
+:: Grid command line loader.
+::
+
+@echo off
+
+if "%OS%" == "Windows_NT"  setlocal
+
+:: Check JAVA_HOME.
+if defined JAVA_HOME  goto checkJdk
+    echo %0, ERROR:
+    echo JAVA_HOME environment variable is not found.
+    echo Please point JAVA_HOME variable to location of JDK 1.7 or JDK 1.8.
+    echo You can also download latest JDK at http://java.com/download.
+goto error_finish
+
+:checkJdk
+:: Check that JDK is where it should be.
+if exist "%JAVA_HOME%\bin\java.exe" goto checkJdkVersion
+    echo %0, ERROR:
+    echo JAVA is not found in JAVA_HOME=%JAVA_HOME%.
+    echo Please point JAVA_HOME variable to installation of JDK 1.7 or JDK 1.8.
+    echo You can also download latest JDK at http://java.com/download.
+goto error_finish
+
+:checkJdkVersion
+"%JAVA_HOME%\bin\java.exe" -version 2>&1 | findstr "1\.[78]\." > nul
+if %ERRORLEVEL% equ 0 goto checkGridGainHome1
+    echo %0, ERROR:
+    echo The version of JAVA installed in %JAVA_HOME% is incorrect.
+    echo Please point JAVA_HOME variable to installation of JDK 1.7 or JDK 1.8.
+    echo You can also download latest JDK at http://java.com/download.
+goto error_finish
+
+:: Check IGNITE_HOME.
+:checkGridGainHome1
+if defined IGNITE_HOME goto checkGridGainHome2
+    pushd "%~dp0"/..
+    set IGNITE_HOME=%CD%
+    popd
+
+:checkGridGainHome2
+:: Strip double quotes from IGNITE_HOME
+set IGNITE_HOME=%IGNITE_HOME:"=%
+
+:: remove all trailing slashes from IGNITE_HOME.
+if %IGNITE_HOME:~-1,1% == \ goto removeTrailingSlash
+if %IGNITE_HOME:~-1,1% == / goto removeTrailingSlash
+goto checkGridGainHome3
+
+:removeTrailingSlash
+set IGNITE_HOME=%IGNITE_HOME:~0,-1%
+goto checkGridGainHome2
+
+:checkGridGainHome3
+if exist "%IGNITE_HOME%\config" goto checkGridGainHome4
+    echo %0, ERROR: GridGain installation folder is not found or IGNITE_HOME environment variable is not valid.
+    echo Please create IGNITE_HOME environment variable pointing to location of
+    echo GridGain installation folder.
+    goto error_finish
+
+:checkGridGainHome4
+
+::
+:: Set SCRIPTS_HOME - base path to scripts.
+::
+set SCRIPTS_HOME=%IGNITE_HOME%\bin
+
+:: Remove trailing spaces
+for /l %%a in (1,1,31) do if /i "%SCRIPTS_HOME:~-1%" == " " set SCRIPTS_HOME=%SCRIPTS_HOME:~0,-1%
+
+if /i "%SCRIPTS_HOME%\" == "%~dp0" goto setProgName
+    echo %0, WARN: IGNITE_HOME environment variable may be pointing to wrong folder: %IGNITE_HOME%
+
+:setProgName
+::
+:: Set program name.
+::
+set PROG_NAME=ignite.bat
+if "%OS%" == "Windows_NT" set PROG_NAME=%~nx0%
+
+:run
+
+::
+:: Set IGNITE_LIBS
+::
+call "%SCRIPTS_HOME%\include\setenv.bat"
+call "%SCRIPTS_HOME%\include\target-classpath.bat" &:: Will be removed in release.
+set CP=%IGNITE_LIBS%
+
+::
+:: Parse command line parameters.
+::
+if not defined DEFAULT_CONFIG set "DEFAULT_CONFIG=config\default-config.xml"
+call "%SCRIPTS_HOME%\include\parseargs.bat" %*
+if %ERRORLEVEL% neq 0 (
+    echo Arguments parsing failed
+    exit /b %ERRORLEVEL%
+)
+
+::
+:: Process 'restart'.
+::
+set RANDOM_NUMBER_COMMAND="%JAVA_HOME%\bin\java.exe" -cp %CP% org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator
+for /f "usebackq tokens=*" %%i in (`"%RANDOM_NUMBER_COMMAND%"`) do set RANDOM_NUMBER=%%i
+
+set RESTART_SUCCESS_FILE="%IGNITE_HOME%\work\ignite_success_%RANDOM_NUMBER%"
+set RESTART_SUCCESS_OPT=-DIGNITE_SUCCESS_FILE=%RESTART_SUCCESS_FILE%
+
+::
+:: Find available port for JMX
+::
+:: You can specify IGNITE_JMX_PORT environment variable for overriding automatically found JMX port
+::
+for /F "tokens=*" %%A in ('""%JAVA_HOME%\bin\java" -cp %CP% org.gridgain.grid.util.portscanner.GridJmxPortFinder"') do (
+    set JMX_PORT=%%A
+)
+
+::
+:: This variable defines necessary parameters for JMX
+:: monitoring and management.
+::
+:: This enables remote unsecure access to JConsole or VisualVM.
+::
+:: ADD YOUR ADDITIONAL PARAMETERS/OPTIONS HERE
+::
+if "%JMX_PORT%" == "" (
+    echo %0, WARN: Failed to resolve JMX host. JMX will be disabled.
+    set JMX_MON=
+) else (
+    set JMX_MON=-Dcom.sun.management.jmxremote -Dcom.sun.management.jmxremote.port=%JMX_PORT% ^
+    -Dcom.sun.management.jmxremote.authenticate=false -Dcom.sun.management.jmxremote.ssl=false
+)
+
+::
+:: JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
+::
+:: ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
+::
+if "%JVM_OPTS%" == "" set JVM_OPTS=-Xms1g -Xmx1g -server -XX:+AggressiveOpts -XX:MaxPermSize=256m
+
+::
+:: Uncomment the following GC settings if you see spikes in your throughput due to Garbage Collection.
+::
+:: set JVM_OPTS=%JVM_OPTS% -XX:+UseParNewGC -XX:+UseConcMarkSweepGC -XX:+UseTLAB -XX:NewSize=128m -XX:MaxNewSize=128m
+:: set JVM_OPTS=%JVM_OPTS% -XX:MaxTenuringThreshold=0 -XX:SurvivorRatio=1024 -XX:+UseCMSInitiatingOccupancyOnly -XX:CMSInitiatingOccupancyFraction=60
+
+::
+:: Uncomment if you get StackOverflowError.
+:: On 64 bit systems this value can be larger, e.g. -Xss16m
+::
+:: set JVM_OPTS=%JVM_OPTS% -Xss4m
+
+::
+:: Uncomment to set preference to IPv4 stack.
+::
+:: set JVM_OPTS=%JVM_OPTS% -Djava.net.preferIPv4Stack=true
+
+::
+:: Assertions are disabled by default since version 3.5.
+:: If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
+::
+set ENABLE_ASSERTIONS=1
+
+::
+:: Set '-ea' options if assertions are enabled.
+::
+if %ENABLE_ASSERTIONS% == 1 set JVM_OPTS=%JVM_OPTS% -ea
+
+:run_java
+
+::
+:: Set main class to start service (grid node by default).
+::
+
+if "%MAIN_CLASS%" == "" set MAIN_CLASS=org.apache.ignite.startup.cmdline.CommandLineStartup
+
+::
+:: Remote debugging (JPDA).
+:: Uncomment and change if remote debugging is required.
+:: set JVM_OPTS=-Xdebug -Xrunjdwp:transport=dt_socket,address=8787,server=y,suspend=n %JVM_OPTS%
+::
+
+if "%INTERACTIVE%" == "1" (
+    "%JAVA_HOME%\bin\java.exe" %JVM_OPTS% %QUIET% %RESTART_SUCCESS_OPT% %JMX_MON% ^
+    -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="%IGNITE_HOME%" -DIGNITE_PROG_NAME="%PROG_NAME%" %JVM_XOPTS% ^
+    -cp "%CP%" %MAIN_CLASS%
+) else (
+    "%JAVA_HOME%\bin\java.exe" %JVM_OPTS% %QUIET% %RESTART_SUCCESS_OPT% %JMX_MON% ^
+    -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="%IGNITE_HOME%" -DIGNITE_PROG_NAME="%PROG_NAME%" %JVM_XOPTS% ^
+    -cp "%CP%" %MAIN_CLASS% "%CONFIG%"
+)
+
+set JAVA_ERRORLEVEL=%ERRORLEVEL%
+
+:: errorlevel 130 if aborted with Ctrl+c
+if %JAVA_ERRORLEVEL%==130 goto finish
+
+:: Exit if first run unsuccessful (Loader must create file).
+if not exist %RESTART_SUCCESS_FILE% goto error_finish
+del %RESTART_SUCCESS_FILE%
+
+goto run_java
+
+:finish
+if not exist %RESTART_SUCCESS_FILE% goto error_finish
+del %RESTART_SUCCESS_FILE%
+
+:error_finish
+
+if not "%NO_PAUSE%" == "1" pause
+
+goto :eof

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ignite.sh
----------------------------------------------------------------------
diff --git a/bin/ignite.sh b/bin/ignite.sh
new file mode 100644
index 0000000..4e2f37c
--- /dev/null
+++ b/bin/ignite.sh
@@ -0,0 +1,176 @@
+#!/bin/bash
+#  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.
+
+#
+# Grid command line loader.
+#
+
+#
+# Import common functions.
+#
+if [ "${IGNITE_HOME}" = "" ];
+    then IGNITE_HOME_TMP="$(dirname "$(cd "$(dirname "$0")"; "pwd")")";
+    else IGNITE_HOME_TMP=${IGNITE_HOME};
+fi
+
+#
+# Set SCRIPTS_HOME - base path to scripts.
+#
+SCRIPTS_HOME="${IGNITE_HOME_TMP}/bin"
+
+source "${SCRIPTS_HOME}"/include/functions.sh
+
+#
+# Discover path to Java executable and check it's version.
+#
+checkJava
+
+#
+# Discover IGNITE_HOME environment variable.
+#
+setGridGainHome
+
+if [ "${DEFAULT_CONFIG}" == "" ]; then
+    DEFAULT_CONFIG=config/default-config.xml
+fi
+
+#
+# Parse command line parameters.
+#
+. "${SCRIPTS_HOME}"/include/parseargs.sh
+
+#
+# Set IGNITE_LIBS.
+#
+. "${SCRIPTS_HOME}"/include/setenv.sh
+. "${SCRIPTS_HOME}"/include/target-classpath.sh # Will be removed in release.
+CP="${IGNITE_LIBS}"
+
+RANDOM_NUMBER=$("$JAVA" -cp "${CP}" org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator)
+
+RESTART_SUCCESS_FILE="${IGNITE_HOME}/work/ignite_success_${RANDOM_NUMBER}"
+RESTART_SUCCESS_OPT="-DIGNITE_SUCCESS_FILE=${RESTART_SUCCESS_FILE}"
+
+#
+# Find available port for JMX
+#
+# You can specify IGNITE_JMX_PORT environment variable for overriding automatically found JMX port
+#
+findAvailableJmxPort
+
+# Mac OS specific support to display correct name in the dock.
+osname=`uname`
+
+if [ "${DOCK_OPTS}" == "" ]; then
+    DOCK_OPTS="-Xdock:name=GridGain Node"
+fi
+
+#
+# JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
+#
+# ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
+#
+if [ -z "$JVM_OPTS" ] ; then
+    JVM_OPTS="-Xms1g -Xmx1g -server -XX:+AggressiveOpts -XX:MaxPermSize=256m"
+fi
+
+#
+# Uncomment the following GC settings if you see spikes in your throughput due to Garbage Collection.
+#
+# JVM_OPTS="$JVM_OPTS -XX:+UseParNewGC -XX:+UseConcMarkSweepGC -XX:+UseTLAB -XX:NewSize=128m -XX:MaxNewSize=128m"
+# JVM_OPTS="$JVM_OPTS -XX:MaxTenuringThreshold=0 -XX:SurvivorRatio=1024 -XX:+UseCMSInitiatingOccupancyOnly -XX:CMSInitiatingOccupancyFraction=60"
+
+#
+# Uncomment if you get StackOverflowError.
+# On 64 bit systems this value can be larger, e.g. -Xss16m
+#
+# JVM_OPTS="${JVM_OPTS} -Xss4m"
+
+#
+# Uncomment to set preference for IPv4 stack.
+#
+# JVM_OPTS="${JVM_OPTS} -Djava.net.preferIPv4Stack=true"
+
+#
+# Assertions are disabled by default since version 3.5.
+# If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
+#
+ENABLE_ASSERTIONS="1"
+
+#
+# Set '-ea' options if assertions are enabled.
+#
+if [ "${ENABLE_ASSERTIONS}" = "1" ]; then
+    JVM_OPTS="${JVM_OPTS} -ea"
+fi
+
+#
+# Set main class to start service (grid node by default).
+#
+if [ "${MAIN_CLASS}" = "" ]; then
+    MAIN_CLASS=org.apache.ignite.startup.cmdline.CommandLineStartup
+fi
+
+#
+# Remote debugging (JPDA).
+# Uncomment and change if remote debugging is required.
+#
+# JVM_OPTS="-Xdebug -Xrunjdwp:transport=dt_socket,address=8787,server=y,suspend=n ${JVM_OPTS}"
+
+ERRORCODE="-1"
+
+while [ "${ERRORCODE}" -ne "130" ]
+do
+    if [ "${INTERACTIVE}" == "1" ] ; then
+        case $osname in
+            Darwin*)
+                "$JAVA" ${JVM_OPTS} ${QUIET} "${DOCK_OPTS}" "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
+                -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
+                -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS}
+            ;;
+            *)
+                "$JAVA" ${JVM_OPTS} ${QUIET} "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
+                -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
+                -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS}
+            ;;
+        esac
+    else
+        case $osname in
+            Darwin*)
+                "$JAVA" ${JVM_OPTS} ${QUIET} "${DOCK_OPTS}" "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
+                 -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
+                 -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS} "${CONFIG}"
+            ;;
+            *)
+                "$JAVA" ${JVM_OPTS} ${QUIET} "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
+                 -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
+                 -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS} "${CONFIG}"
+            ;;
+        esac
+    fi
+
+    ERRORCODE="$?"
+
+    if [ ! -f "${RESTART_SUCCESS_FILE}" ] ; then
+        break
+    else
+        rm -f "${RESTART_SUCCESS_FILE}"
+    fi
+done
+
+if [ -f "${RESTART_SUCCESS_FILE}" ] ; then
+    rm -f "${RESTART_SUCCESS_FILE}"
+fi

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/igniterouter.bat
----------------------------------------------------------------------
diff --git a/bin/igniterouter.bat b/bin/igniterouter.bat
new file mode 100644
index 0000000..36f1fae
--- /dev/null
+++ b/bin/igniterouter.bat
@@ -0,0 +1,33 @@
+::  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.
+
+::
+:: Grid router command line loader.
+::
+
+@echo off
+
+if "%OS%" == "Windows_NT" setlocal
+
+::
+:: Set router service environment.
+::
+set "DEFAULT_CONFIG=config\router\default-router.xml"
+set MAIN_CLASS=org.gridgain.client.router.impl.GridRouterCommandLineStartup
+
+::
+:: Start router service.
+::
+call "%~dp0\ignite.bat" %*

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/igniterouter.sh
----------------------------------------------------------------------
diff --git a/bin/igniterouter.sh b/bin/igniterouter.sh
new file mode 100644
index 0000000..b75aec3
--- /dev/null
+++ b/bin/igniterouter.sh
@@ -0,0 +1,50 @@
+#!/bin/bash
+#  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.
+
+#
+# Router command line loader.
+#
+
+#
+# Import common functions.
+#
+if [ "${IGNITE_HOME}" = "" ];
+    then IGNITE_HOME_TMP="$(dirname "$(cd "$(dirname "$0")"; "pwd")")";IGNITE_HOME_TMP="$(dirname "${IGNITE_HOME_TMP}")" # Will be removed in release.
+    else IGNITE_HOME_TMP=${IGNITE_HOME};
+fi
+
+#
+# Set SCRIPTS_HOME - base path to scripts.
+#
+SCRIPTS_HOME="${IGNITE_HOME_TMP}/bin"
+
+source "${SCRIPTS_HOME}"/include/functions.sh
+
+#
+# Discover IGNITE_HOME environment variable.
+#
+setGridGainHome
+
+#
+# Set router service environment.
+#
+export DEFAULT_CONFIG=config/router/default-router.xml
+export MAIN_CLASS=org.gridgain.client.router.impl.GridRouterCommandLineStartup
+
+#
+# Start router service.
+#
+. "${SCRIPTS_HOME}"/ignite.sh $@

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ignitevisorcmd.bat
----------------------------------------------------------------------
diff --git a/bin/ignitevisorcmd.bat b/bin/ignitevisorcmd.bat
new file mode 100644
index 0000000..c4c64f9
--- /dev/null
+++ b/bin/ignitevisorcmd.bat
@@ -0,0 +1,144 @@
+::  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.
+
+::
+:: Starts GridGain Visor Console.
+::
+
+@echo off
+
+if "%OS%" == "Windows_NT"  setlocal
+
+:: Check JAVA_HOME.
+if not "%JAVA_HOME%" == "" goto checkJdk
+    echo %0, ERROR: JAVA_HOME environment variable is not found.
+    echo %0, ERROR: Please create JAVA_HOME variable pointing to location of JDK 1.7 or JDK 1.8.
+    echo %0, ERROR: You can also download latest JDK at: http://java.sun.com/getjava
+goto error_finish
+
+:checkJdk
+:: Check that JDK is where it should be.
+if exist "%JAVA_HOME%\bin\java.exe" goto checkJdkVersion
+    echo %0, ERROR: The JDK is not found in %JAVA_HOME%.
+    echo %0, ERROR: Please modify your script so that JAVA_HOME would point to valid location of JDK.
+goto error_finish
+
+:checkJdkVersion
+"%JAVA_HOME%\bin\java.exe" -version 2>&1 | findstr "1\.[78]\." > nul
+if %ERRORLEVEL% equ 0 goto checkGridGainHome1
+    echo %0, ERROR: The version of JAVA installed in %JAVA_HOME% is incorrect.
+    echo %0, ERROR: Please install JDK 1.7 or 1.8.
+    echo %0, ERROR: You can also download latest JDK at: http://java.sun.com/getjava
+goto error_finish
+
+:: Check IGNITE_HOME.
+:checkGridGainHome1
+if not "%IGNITE_HOME%" == "" goto checkGridGainHome2
+    pushd "%~dp0"/..
+    set IGNITE_HOME=%CD%
+    popd
+
+:checkGridGainHome2
+:: Strip double quotes from IGNITE_HOME
+set IGNITE_HOME=%IGNITE_HOME:"=%
+
+:: remove all trailing slashes from IGNITE_HOME.
+if %IGNITE_HOME:~-1,1% == \ goto removeTrailingSlash
+if %IGNITE_HOME:~-1,1% == / goto removeTrailingSlash
+goto checkGridGainHome3
+
+:removeTrailingSlash
+set IGNITE_HOME=%IGNITE_HOME:~0,-1%
+goto checkGridGainHome2
+
+:checkGridGainHome3
+if exist "%IGNITE_HOME%\config" goto checkGridGainHome4
+    echo %0, ERROR: GridGain installation folder is not found or IGNITE_HOME environment variable is not valid.
+    echo Please create IGNITE_HOME environment variable pointing to location of
+    echo GridGain installation folder.
+    goto error_finish
+
+:checkGridGainHome4
+
+::
+:: Set SCRIPTS_HOME - base path to scripts.
+::
+set SCRIPTS_HOME=%IGNITE_HOME%\bin
+
+:: Remove trailing spaces
+for /l %%a in (1,1,31) do if /i "%SCRIPTS_HOME:~-1%" == " " set SCRIPTS_HOME=%SCRIPTS_HOME:~0,-1%
+
+if /i "%SCRIPTS_HOME%\" == "%~dp0" goto run
+    echo %0, WARN: IGNITE_HOME environment variable may be pointing to wrong folder: %IGNITE_HOME%
+
+:run
+
+::
+:: Set IGNITE_LIBS
+::
+call "%SCRIPTS_HOME%\include\setenv.bat"
+call "%SCRIPTS_HOME%\include\target-classpath.bat" &:: Will be removed in release.
+set CP=%IGNITE_HOME%\bin\include\visor-common\*;%IGNITE_HOME%\bin\include\visorcmd\*;%IGNITE_LIBS%
+
+::
+:: Parse command line parameters.
+::
+call "%SCRIPTS_HOME%\include\parseargs.bat" %*
+if %ERRORLEVEL% neq 0 (
+    echo Arguments parsing failed
+    exit /b %ERRORLEVEL%
+)
+
+::
+:: Set program name.
+::
+set PROG_NAME=gridgain.bat
+if "%OS%" == "Windows_NT" set PROG_NAME=%~nx0%
+
+::
+:: JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
+::
+:: ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
+::
+if "%JVM_OPTS_VISOR%" == "" set JVM_OPTS_VISOR=-Xms1g -Xmx1g -XX:MaxPermSize=128M
+
+::
+:: Uncomment to set preference to IPv4 stack.
+::
+:: set JVM_OPTS_VISOR=%JVM_OPTS_VISOR% -Djava.net.preferIPv4Stack=true
+
+::
+:: Assertions are disabled by default since version 3.5.
+:: If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
+::
+set ENABLE_ASSERTIONS=1
+
+::
+:: Set '-ea' options if assertions are enabled.
+::
+if %ENABLE_ASSERTIONS% == 1 set JVM_OPTS_VISOR=%JVM_OPTS_VISOR% -ea
+
+::
+:: Starts Visor console.
+::
+"%JAVA_HOME%\bin\java.exe" %JVM_OPTS_VISOR% -DIGNITE_PROG_NAME="%PROG_NAME%" ^
+-DIGNITE_DEPLOYMENT_MODE_OVERRIDE=ISOLATED %QUIET% %JVM_XOPTS% -cp "%CP%" ^
+ org.gridgain.visor.commands.VisorConsole
+
+:error_finish
+
+if not "%NO_PAUSE%" == "1" pause
+
+goto :eof

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ignitevisorcmd.sh
----------------------------------------------------------------------
diff --git a/bin/ignitevisorcmd.sh b/bin/ignitevisorcmd.sh
new file mode 100644
index 0000000..319d282
--- /dev/null
+++ b/bin/ignitevisorcmd.sh
@@ -0,0 +1,124 @@
+#!/bin/bash
+#  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.
+
+#
+# Import common functions.
+#
+if [ "${IGNITE_HOME}" = "" ];
+    then IGNITE_HOME_TMP="$(dirname "$(cd "$(dirname "$0")"; "pwd")")";IGNITE_HOME_TMP="$(dirname "${IGNITE_HOME_TMP}")" # Will be removed in release.
+    else IGNITE_HOME_TMP=${IGNITE_HOME};
+fi
+
+#
+# Set SCRIPTS_HOME - base path to scripts.
+#
+SCRIPTS_HOME="${IGNITE_HOME_TMP}/bin"
+
+source "${SCRIPTS_HOME}"/include/functions.sh
+
+#
+# Discover path to Java executable and check it's version.
+#
+checkJava
+
+#
+# Discover IGNITE_HOME environment variable.
+#
+setGridGainHome
+
+#
+# Parse command line parameters.
+#
+. "${SCRIPTS_HOME}"/include/parseargs.sh
+
+#
+# Set IGNITE_LIBS.
+#
+. "${SCRIPTS_HOME}"/include/setenv.sh
+. "${SCRIPTS_HOME}"/include/target-classpath.sh # Will be removed in release.
+CP="${IGNITE_HOME}/bin/include/visor-common/*${SEP}${IGNITE_HOME}/bin/include/visorcmd/*${SEP}${IGNITE_LIBS}"
+
+#
+# JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
+#
+# ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
+#
+JVM_OPTS="-Xms1g -Xmx1g -XX:MaxPermSize=128M -server ${JVM_OPTS}"
+
+# Mac OS specific support to display correct name in the dock.
+osname=`uname`
+
+if [ "${DOCK_OPTS}" == "" ]; then
+    DOCK_OPTS="-Xdock:name=Visor - GridGain Shell Console"
+fi
+
+#
+# Uncomment to set preference for IPv4 stack.
+#
+# JVM_OPTS="${JVM_OPTS} -Djava.net.preferIPv4Stack=true"
+
+#
+# Assertions are disabled by default since version 3.5.
+# If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
+#
+ENABLE_ASSERTIONS="1"
+
+#
+# Set '-ea' options if assertions are enabled.
+#
+if [ "${ENABLE_ASSERTIONS}" = "1" ]; then
+    JVM_OPTS="${JVM_OPTS} -ea"
+fi
+
+#
+# Save terminal setting. Used to restore terminal on finish.
+#
+SAVED_STTY=`stty -g 2>/dev/null`
+
+#
+# Restores terminal.
+#
+function restoreSttySettings() {
+    stty ${SAVED_STTY}
+}
+
+#
+# Trap that restores terminal in case script execution is interrupted.
+#
+trap restoreSttySettings INT
+
+#
+# Start Visor console.
+#
+case $osname in
+    Darwin*)
+        "$JAVA" ${JVM_OPTS} ${QUIET} "${DOCK_OPTS}" \
+        -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" -DIGNITE_PROG_NAME="$0" \
+        -DIGNITE_DEPLOYMENT_MODE_OVERRIDE=ISOLATED ${JVM_XOPTS} -cp "${CP}" \
+        org.apache.ignite.visor.commands.VisorConsole
+    ;;
+    *)
+        "$JAVA" ${JVM_OPTS} ${QUIET} -DIGNITE_UPDATE_NOTIFIER=false \
+        -DIGNITE_HOME="${IGNITE_HOME}" -DIGNITE_PROG_NAME="$0" -DIGNITE_DEPLOYMENT_MODE_OVERRIDE=ISOLATED \
+        ${JVM_XOPTS} -cp "${CP}" \
+        org.apache.ignite.visor.commands.VisorConsole
+    ;;
+esac
+
+#
+# Restore terminal.
+#
+restoreSttySettings

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/setup-hadoop.bat
----------------------------------------------------------------------
diff --git a/bin/setup-hadoop.bat b/bin/setup-hadoop.bat
index fa3ba8e..45b3520 100644
--- a/bin/setup-hadoop.bat
+++ b/bin/setup-hadoop.bat
@@ -23,4 +23,4 @@ if "%OS%" == "Windows_NT" setlocal
 
 set MAIN_CLASS=org.gridgain.grid.hadoop.GridHadoopSetup
 
-call "%~dp0\ggstart.bat" %*
+call "%~dp0\ignite.bat" %*

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/setup-hadoop.sh
----------------------------------------------------------------------
diff --git a/bin/setup-hadoop.sh b/bin/setup-hadoop.sh
index 342916f..f36e4fa 100755
--- a/bin/setup-hadoop.sh
+++ b/bin/setup-hadoop.sh
@@ -57,4 +57,4 @@ export MAIN_CLASS=org.gridgain.grid.hadoop.GridHadoopSetup
 #
 # Start utility.
 #
-. "${SCRIPTS_HOME}/ggstart.sh" $@
+. "${SCRIPTS_HOME}/ignite.sh" $@

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/config/hadoop/default-config.xml
----------------------------------------------------------------------
diff --git a/config/hadoop/default-config.xml b/config/hadoop/default-config.xml
index 03b45fa..1b27ee0 100644
--- a/config/hadoop/default-config.xml
+++ b/config/hadoop/default-config.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/default-config.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/default-config.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/default-config.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/config/router/default-router.xml
----------------------------------------------------------------------
diff --git a/config/router/default-router.xml b/config/router/default-router.xml
index 6a8f831..e40a31f 100644
--- a/config/router/default-router.xml
+++ b/config/router/default-router.xml
@@ -21,7 +21,7 @@
     Default rest router configuration.
 
     This file is automatically scanned by
-    $IGNITE_HOME/bin/ggrouter.sh and $IGNITE_HOME/bin/ggrouter.bat
+    $IGNITE_HOME/bin/igniterouter.sh and $IGNITE_HOME/bin/igniterouter.bat
     for org.gridgain.client.router.GridTcpRestRouterConfiguration  bean definition.
     First found is used to start router instance.
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/docs/hadoop_readme.md
----------------------------------------------------------------------
diff --git a/docs/hadoop_readme.md b/docs/hadoop_readme.md
index 1fda55d..22d52a0 100644
--- a/docs/hadoop_readme.md
+++ b/docs/hadoop_readme.md
@@ -40,7 +40,7 @@ Installation requirements:
 After setup script successfully completed, you can execute the Ignite startup script.
 The following command will startup Ignite node with default configuration using multicast node discovery.
 
-    bin/ggstart.{sh|bat}
+    bin/ignite.{sh|bat}
 
 If Ignite was installed successfully, the output from above commands should produce no exceptions or errors.
 Note that you may see some other warnings during startup, but this is OK as they are meant to inform that certain
@@ -53,7 +53,7 @@ Here is an example of log printout when 2 nodes join topology:
 
 You can also start Ignite Management Console, called Visor, and observe started nodes. To startup Visor, you should execute the following script:
 
-    /bin/ggvisorcmd.{sh|bat} 
+    /bin/ignitevisorcmd.{sh|bat}
 
 ## 3. Configuration
 
@@ -112,6 +112,6 @@ Ignite comes with CLI (command) based DevOps Managements Console, called Visor,
 
 To start Visor in console mode you should execute the following command:
 
-    `bin/ggvisorcmd.sh`
+    `bin/ignitevisorcmd.sh`
 
 On Windows, run the same commands with `.bat` extension.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/docs/ignite_readme.md
----------------------------------------------------------------------
diff --git a/docs/ignite_readme.md b/docs/ignite_readme.md
index 297b8b3..a238109 100644
--- a/docs/ignite_readme.md
+++ b/docs/ignite_readme.md
@@ -37,11 +37,11 @@ To verify Ignite installation, you can execute the Ignite startup script.
 
 The following command will startup Ignite with default configuration using Multicast node discovery.
 
-    bin/ggstart.{sh|bat}
+    bin/ignite.{sh|bat}
 
 The following command will startup Ignite with example configuration.
 
-    bin/ggstart.{sh|bat} examples/config/example-compute.xml
+    bin/ignite.{sh|bat} examples/config/example-compute.xml
 
 If Ignite was installed successfully, the output from above commands should produce no exceptions or errors.
 Note that you may see some warnings during startup, but this is OK as they are meant to inform that certain functionality is turned on or off by default.
@@ -53,7 +53,7 @@ Here is an example of log printout when 2 nodes join topology:
 
 You can also start Ignite Management Console, called Visor, and observe started nodes. To startup Visor, you should execute the following script:
 
-    /bin/ggvisorcmd.{sh|bat} 
+    /bin/ignitevisorcmd.{sh|bat}
 
 ### 2.2 Running Ignite Examples
 
@@ -78,18 +78,18 @@ You can use maven to add Ignite artifacts to your project. Ignite has one main a
 
 
 ## 4. Starting Ignite Nodes
-Ignite nodes can be started by executing `bin/ggstart.{sh|bat}` script and passing a relative path to Ignite configuration file. If no file is passed, then grid nodes are started with default configuration using Multicast discovery protocol.
+Ignite nodes can be started by executing `bin/ignite.{sh|bat}` script and passing a relative path to Ignite configuration file. If no file is passed, then grid nodes are started with default configuration using Multicast discovery protocol.
 
 Here is an example of how to start Ignite node with non-default configuration:
 
-    `bin/ggstart.sh examples/config/example-cache.xml`
+    `bin/ignite.sh examples/config/example-cache.xml`
 
 ## 5. Management & Monitoring with Visor
 Ignite comes with CLI (command) based DevOps Managements Console, called Visor, delivering advance set of management and monitoring capabilities. 
 
 To start Visor in console mode you should execute the following command:
 
-    `bin/ggvisorcmd.sh`
+    `bin/ignitevisorcmd.sh`
 
 On Windows, run the same commands with `.bat` extension.
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/config/example-cache.xml
----------------------------------------------------------------------
diff --git a/examples/config/example-cache.xml b/examples/config/example-cache.xml
index 682a8a3..9ec2ef2 100644
--- a/examples/config/example-cache.xml
+++ b/examples/config/example-cache.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file to GridGain:
     GridGain.start("examples/config/example-cache.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/config/example-streamer.xml
----------------------------------------------------------------------
diff --git a/examples/config/example-streamer.xml b/examples/config/example-streamer.xml
index 6674b24..c13b90d 100644
--- a/examples/config/example-streamer.xml
+++ b/examples/config/example-streamer.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid with streamers.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/example-streamer.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/example-streamer.xml
     When starting nodes this way JAR file containing the examples code
     should be placed to {IGNITE_HOME}/libs folder. You can build
     gridgain-examples.jar by running "mvn package" in {IGNITE_HOME}/examples folder.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/config/filesystem/example-ggfs.xml
----------------------------------------------------------------------
diff --git a/examples/config/filesystem/example-ggfs.xml b/examples/config/filesystem/example-ggfs.xml
index 08ac4cd..fb64227 100644
--- a/examples/config/filesystem/example-ggfs.xml
+++ b/examples/config/filesystem/example-ggfs.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/filesystem/example-ggfs.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/filesystem/example-ggfs.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("examples/config/filesystem/example-ggfs.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/rest/http-rest-example.php
----------------------------------------------------------------------
diff --git a/examples/rest/http-rest-example.php b/examples/rest/http-rest-example.php
index 9c02a16..26bb394 100644
--- a/examples/rest/http-rest-example.php
+++ b/examples/rest/http-rest-example.php
@@ -22,7 +22,7 @@
  * To execute this script simply start up an instance of GridGain with cache enabled.
  * You can use any cache configuration from examples/config folder as follows:
  * ----
- * ${IGNITE_HOME}/bin/ggstart.sh examples/config/example-cache.xml
+ * ${IGNITE_HOME}/bin/ignite.sh examples/config/example-cache.xml
  * ----
  *
  * Make sure you have correctly specified $CACHE_NAME script global variable

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/rest/memcache-rest-example.php
----------------------------------------------------------------------
diff --git a/examples/rest/memcache-rest-example.php b/examples/rest/memcache-rest-example.php
index 9507e19..b8509cf 100644
--- a/examples/rest/memcache-rest-example.php
+++ b/examples/rest/memcache-rest-example.php
@@ -27,7 +27,7 @@
  * You can use default cache configuration from examples/config folder to
  * start up an instance of GridGain with cache enabled as follows:
  * ----
- * ${IGNITE_HOME}/bin/ggstart.sh examples/config/example-cache-default.xml
+ * ${IGNITE_HOME}/bin/ignite.sh examples/config/example-cache-default.xml
  * ----
  */
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeBroadcastExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeBroadcastExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeBroadcastExample.java
index cf8e487..a12b6ac 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeBroadcastExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeBroadcastExample.java
@@ -28,7 +28,7 @@ import java.util.*;
  * Demonstrates broadcasting computations within grid projection.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeCallableExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeCallableExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeCallableExample.java
index 6c70c70..880ed10 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeCallableExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeCallableExample.java
@@ -31,7 +31,7 @@ import java.util.*;
  * word.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeClosureExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeClosureExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeClosureExample.java
index 0365fb5..d0b2538 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeClosureExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeClosureExample.java
@@ -30,7 +30,7 @@ import java.util.*;
  * nodes and then computes total amount of non-whitespaces characters in the phrase.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeContinuousMapperExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeContinuousMapperExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeContinuousMapperExample.java
index cea5ee0..cfbbc94 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeContinuousMapperExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeContinuousMapperExample.java
@@ -40,7 +40,7 @@ import java.util.concurrent.atomic.*;
  * previous word has been received.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeExecutorServiceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeExecutorServiceExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeExecutorServiceExample.java
index 46f6bfa..38f277f 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeExecutorServiceExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeExecutorServiceExample.java
@@ -27,7 +27,7 @@ import java.util.concurrent.*;
  * Simple example to demonstrate usage of grid-enabled executor service provided by GridGain.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeFibonacciContinuationExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeFibonacciContinuationExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeFibonacciContinuationExample.java
index 9301686..6f2ced7 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeFibonacciContinuationExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeFibonacciContinuationExample.java
@@ -37,7 +37,7 @@ import java.util.*;
  * {@link org.apache.ignite.compute.ComputeJobContext#callcc()} method calls in {@link FibonacciClosure} class.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeProjectionExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeProjectionExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeProjectionExample.java
index 258b5cd..0131003 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeProjectionExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeProjectionExample.java
@@ -26,7 +26,7 @@ import org.apache.ignite.lang.*;
  * Demonstrates new functional APIs.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeReducerExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeReducerExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeReducerExample.java
index 779add0..4942875 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeReducerExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeReducerExample.java
@@ -31,7 +31,7 @@ import java.util.concurrent.atomic.*;
  * calculated. Then total phrase length is calculated using reducer.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeRunnableExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeRunnableExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeRunnableExample.java
index a7dfad0..e062335 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeRunnableExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeRunnableExample.java
@@ -28,7 +28,7 @@ import java.util.*;
  * Demonstrates a simple use of {@link org.apache.ignite.lang.IgniteRunnable}.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeScheduleExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeScheduleExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeScheduleExample.java
index 07f2fa6..7802f75 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeScheduleExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeScheduleExample.java
@@ -30,7 +30,7 @@ import java.util.concurrent.*;
  * three times with initial scheduling delay equal to five seconds.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskMapExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskMapExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskMapExample.java
index eece6f2..bd3fc67 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskMapExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskMapExample.java
@@ -34,7 +34,7 @@ import java.util.*;
  * calculated on reduce stage.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskSplitExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskSplitExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskSplitExample.java
index 8bb9191..d6c7d4c 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskSplitExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskSplitExample.java
@@ -32,7 +32,7 @@ import java.util.*;
  * is calculated on reduce stage.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.