You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by vo...@apache.org on 2016/01/29 11:11:18 UTC

[1/6] ignite git commit: Fixed GridServicePackagePrivateSelfTest - nodes were not properly stopped

Repository: ignite
Updated Branches:
  refs/heads/ignite-2498 14a5f93bf -> 9103b201c


Fixed GridServicePackagePrivateSelfTest - nodes were not properly stopped


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

Branch: refs/heads/ignite-2498
Commit: 7a11154201322fb44e8e0d3061f4cf19151f15fd
Parents: f9868d4
Author: Valentin Kulichenko <va...@gmail.com>
Authored: Thu Jan 28 16:09:20 2016 -0800
Committer: Valentin Kulichenko <va...@gmail.com>
Committed: Thu Jan 28 16:09:20 2016 -0800

----------------------------------------------------------------------
 .../service/GridServicePackagePrivateSelfTest.java | 17 +++++++++++------
 1 file changed, 11 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/7a111542/modules/core/src/test/java/org/apache/ignite/internal/processors/service/GridServicePackagePrivateSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/service/GridServicePackagePrivateSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/service/GridServicePackagePrivateSelfTest.java
index 430d366..c085192 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/service/GridServicePackagePrivateSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/service/GridServicePackagePrivateSelfTest.java
@@ -31,16 +31,21 @@ public class GridServicePackagePrivateSelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testPackagePrivateService() throws Exception {
-        Ignite server = startGrid("server");
+        try {
+            Ignite server = startGrid("server");
 
-        server.services().deployClusterSingleton("my-service", MyServiceFactory.create());
+            server.services().deployClusterSingleton("my-service", MyServiceFactory.create());
 
-        Ignition.setClientMode(true);
+            Ignition.setClientMode(true);
 
-        Ignite client = startGrid("client");
+            Ignite client = startGrid("client");
 
-        MyService svc = client.services().serviceProxy("my-service", MyService.class, true);
+            MyService svc = client.services().serviceProxy("my-service", MyService.class, true);
 
-        assertEquals(42, svc.hello());
+            assertEquals(42, svc.hello());
+        }
+        finally {
+            stopAllGrids();
+        }
     }
 }


[5/6] ignite git commit: Merge remote-tracking branch 'origin/master'

Posted by vo...@apache.org.
Merge remote-tracking branch 'origin/master'


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

Branch: refs/heads/ignite-2498
Commit: c081e3d50f2352502997b92511c50a1e92be122f
Parents: fb206c5 132b1ae
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Fri Jan 29 12:33:59 2016 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Fri Jan 29 12:33:59 2016 +0300

----------------------------------------------------------------------
 .../GridServicePackagePrivateSelfTest.java      | 17 ++++---
 modules/docker/1.5.0.final/Dockerfile           | 40 ++++++++++++++++
 modules/docker/1.5.0.final/run.sh               | 50 ++++++++++++++++++++
 modules/docker/Dockerfile                       |  6 +--
 4 files changed, 104 insertions(+), 9 deletions(-)
----------------------------------------------------------------------



[3/6] ignite git commit: Added docker file for version 1.5.0.final.

Posted by vo...@apache.org.
Added docker file for version 1.5.0.final.


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

Branch: refs/heads/ignite-2498
Commit: 132b1ae7c88382e45a12e91bd6f4b0be94b7d77c
Parents: 8823e46
Author: Tikhonov Nikolay <ti...@gmail.com>
Authored: Fri Jan 29 10:36:03 2016 +0300
Committer: Tikhonov Nikolay <ti...@gmail.com>
Committed: Fri Jan 29 10:36:03 2016 +0300

----------------------------------------------------------------------
 modules/docker/1.5.0.final/Dockerfile | 40 ++++++++++++++++++++++++
 modules/docker/1.5.0.final/run.sh     | 50 ++++++++++++++++++++++++++++++
 modules/docker/Dockerfile             |  6 ++--
 3 files changed, 93 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/132b1ae7/modules/docker/1.5.0.final/Dockerfile
----------------------------------------------------------------------
diff --git a/modules/docker/1.5.0.final/Dockerfile b/modules/docker/1.5.0.final/Dockerfile
new file mode 100644
index 0000000..bdc7baf
--- /dev/null
+++ b/modules/docker/1.5.0.final/Dockerfile
@@ -0,0 +1,40 @@
+#
+# 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.
+#
+
+# Start from a Java image.
+FROM java:7
+
+# Ignite version
+ENV IGNITE_VERSION 1.5.0.final
+
+WORKDIR /opt/ignite
+
+ADD http://www.us.apache.org/dist/ignite/1.5.0.final/apache-ignite-fabric-1.5.0.final-bin.zip /opt/ignite/ignite.zip
+
+# Ignite home
+ENV IGNITE_HOME /opt/ignite/apache-ignite-fabric-1.5.0.final-bin
+
+RUN unzip ignite.zip
+
+RUN rm ignite.zip
+
+# Copy sh files and set permission
+ADD ./run.sh $IGNITE_HOME/
+
+RUN chmod +x $IGNITE_HOME/run.sh
+
+CMD $IGNITE_HOME/run.sh
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/132b1ae7/modules/docker/1.5.0.final/run.sh
----------------------------------------------------------------------
diff --git a/modules/docker/1.5.0.final/run.sh b/modules/docker/1.5.0.final/run.sh
new file mode 100644
index 0000000..dbf2871
--- /dev/null
+++ b/modules/docker/1.5.0.final/run.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.
+#
+
+if [ ! -z "$OPTION_LIBS" ]; then
+  IFS=, LIBS_LIST=("$OPTION_LIBS")
+
+  for lib in ${LIBS_LIST[@]}; do
+    cp -r $IGNITE_HOME/libs/optional/"$lib"/* \
+        $IGNITE_HOME/libs/
+  done
+fi
+
+if [ ! -z "$EXTERNAL_LIBS" ]; then
+  IFS=, LIBS_LIST=("$EXTERNAL_LIBS")
+
+  for lib in ${LIBS_LIST[@]}; do
+    echo $lib >> temp
+  done
+
+  wget -i temp -P $IGNITE_HOME/libs
+
+  rm temp
+fi
+
+QUIET=""
+
+if [ "$IGNITE_QUIET" = "false" ]; then
+  QUIET="-v"
+fi
+
+if [ -z $CONFIG_URI ]; then
+  $IGNITE_HOME/bin/ignite.sh $QUIET
+else
+  $IGNITE_HOME/bin/ignite.sh $QUIET $CONFIG_URI
+fi

http://git-wip-us.apache.org/repos/asf/ignite/blob/132b1ae7/modules/docker/Dockerfile
----------------------------------------------------------------------
diff --git a/modules/docker/Dockerfile b/modules/docker/Dockerfile
index 11be2b4..bdc7baf 100644
--- a/modules/docker/Dockerfile
+++ b/modules/docker/Dockerfile
@@ -19,14 +19,14 @@
 FROM java:7
 
 # Ignite version
-ENV IGNITE_VERSION 1.5.0-b1
+ENV IGNITE_VERSION 1.5.0.final
 
 WORKDIR /opt/ignite
 
-ADD http://www.us.apache.org/dist/ignite/1.5.0-b1/apache-ignite-fabric-1.5.0-b1-bin.zip /opt/ignite/ignite.zip
+ADD http://www.us.apache.org/dist/ignite/1.5.0.final/apache-ignite-fabric-1.5.0.final-bin.zip /opt/ignite/ignite.zip
 
 # Ignite home
-ENV IGNITE_HOME /opt/ignite/apache-ignite-fabric-1.5.0-b1-bin
+ENV IGNITE_HOME /opt/ignite/apache-ignite-fabric-1.5.0.final-bin
 
 RUN unzip ignite.zip
 


[2/6] ignite git commit: Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/ignite

Posted by vo...@apache.org.
Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/ignite


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

Branch: refs/heads/ignite-2498
Commit: 8823e46860c520abfc9b9c718df5c2d92f0c820f
Parents: 7a11154 79db260
Author: Valentin Kulichenko <va...@gmail.com>
Authored: Thu Jan 28 16:09:36 2016 -0800
Committer: Valentin Kulichenko <va...@gmail.com>
Committed: Thu Jan 28 16:09:36 2016 -0800

----------------------------------------------------------------------
 .../examples/datagrid/CacheAffinityExample.java |   8 +-
 .../java8/datagrid/CacheAffinityExample.java    |   6 +-
 modules/benchmarks/pom.xml                      |  30 --
 .../benchmarks/jmh/JmhAbstractBenchmark.java    | 150 ++++++++
 .../jmh/cache/JmhCacheAbstractBenchmark.java    | 181 ++++++++++
 .../jmh/cache/JmhCachePutBenchmark.java         | 122 +++++++
 .../benchmarks/jmh/cache/PutBenchmark.java      | 170 ---------
 .../jmh/runner/JmhIdeBenchmarkRunner.java       | 214 +++++++++++
 .../internal/client/ClientGetAffinityTask.java  |   4 +-
 .../java/org/apache/ignite/IgniteCluster.java   |   7 +-
 .../apache/ignite/cache/affinity/Affinity.java  |  24 +-
 .../affinity/GridAffinityProcessor.java         |  60 ++--
 .../cache/GridCacheAffinityManager.java         |  47 ++-
 .../cache/affinity/GridCacheAffinityImpl.java   |  48 ++-
 .../near/GridNearTxFinishFuture.java            |  96 ++---
 .../ignite/internal/GridAffinityMappedTest.java |   8 +-
 .../internal/GridAffinityNoCacheSelfTest.java   | 290 +++++++++++++++
 .../internal/GridAffinityP2PSelfTest.java       |   8 +-
 .../ignite/internal/GridAffinitySelfTest.java   |   8 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |   4 +-
 .../cache/GridCacheAffinityRoutingSelfTest.java |  10 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |   4 +-
 .../GridCacheDaemonNodeAbstractSelfTest.java    |  17 +-
 .../cache/GridCacheDeploymentSelfTest.java      |   8 +-
 .../cache/GridCacheEntryMemorySizeSelfTest.java |   6 +-
 ...hePartitionedProjectionAffinitySelfTest.java |   8 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |   4 +-
 .../dht/GridCacheDhtMultiBackupTest.java        |   4 +-
 .../near/GridCacheNearOnlyTopologySelfTest.java |   4 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |   4 +-
 ...titionedExplicitLockNodeFailureSelfTest.java |   6 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |  10 +-
 .../processors/igfs/IgfsStreamsSelfTest.java    |   4 +-
 .../ignite/loadtests/dsi/GridDsiClient.java     |   4 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |   4 +-
 .../testsuites/IgniteComputeGridTestSuite.java  |   4 +-
 .../cpp/common/project/vs/common.vcxproj        |   2 +-
 .../Apache.Ignite.Benchmarks.csproj             |   4 +-
 .../Apache.Ignite.Core.Tests.TestDll.csproj     |   4 +-
 .../Apache.Ignite.Core.Tests.csproj             |   2 +-
 .../Apache.Ignite.Core.csproj                   |   8 +-
 .../Apache.Ignite.Core.ruleset                  |  26 ++
 .../Binary/BinaryConfiguration.cs               |   3 +
 .../Binary/BinaryTypeConfiguration.cs           |   5 +
 .../Binary/BinaryTypeNames.cs                   |  64 ++--
 .../Cache/CachePartialUpdateException.cs        |   3 +
 .../Apache.Ignite.Core/Cache/CacheResult.cs     |  41 ++-
 .../Cache/Event/ICacheEntryEventFilter.cs       |   1 +
 .../Cache/Event/ICacheEntryEventListener.cs     |   1 +
 .../Cache/Query/Continuous/ContinuousQuery.cs   |   2 +-
 .../Apache.Ignite.Core/Cache/Query/QueryBase.cs |   2 +-
 .../Cache/Query/SqlFieldsQuery.cs               |   2 +-
 .../Apache.Ignite.Core/Cache/Query/SqlQuery.cs  |   6 +-
 .../Apache.Ignite.Core/Cache/Query/TextQuery.cs |   7 +-
 .../Cache/Store/CacheStoreAdapter.cs            |   4 +
 .../Compute/ComputeJobAdapter.cs                |   2 +-
 .../Compute/ComputeJobResultPolicy.cs           |   2 -
 .../Compute/ComputeTaskAdapter.cs               |   3 +
 .../Compute/ComputeTaskSplitAdapter.cs          |  18 +-
 .../Datastream/StreamTransformer.cs             |   2 +
 .../Datastream/StreamVisitor.cs                 |   2 +
 .../Apache.Ignite.Core/Events/CacheEvent.cs     |   8 +-
 .../Events/CacheQueryExecutedEvent.cs           |   4 +-
 .../Events/CacheQueryReadEvent.cs               |   6 +-
 .../Events/CacheRebalancingEvent.cs             |   4 +-
 .../Events/CheckpointEvent.cs                   |   4 +-
 .../Apache.Ignite.Core/Events/DiscoveryEvent.cs |   4 +-
 .../Apache.Ignite.Core/Events/EventBase.cs      |  70 +++-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |   3 +-
 .../Apache.Ignite.Core/Impl/Binary/Binary.cs    |  47 +--
 .../Impl/Binary/BinaryFullTypeDescriptor.cs     |   2 +-
 .../Impl/Binary/BinaryObject.cs                 |  44 ++-
 .../Impl/Binary/BinaryObjectBuilder.cs          |  75 ++--
 .../Impl/Binary/BinaryReader.cs                 |   1 +
 .../Impl/Binary/BinaryReflectiveSerializer.cs   |   2 +-
 .../Impl/Binary/BinarySystemHandlers.cs         |   9 +-
 .../Impl/Binary/BinaryUtils.cs                  |   7 +-
 .../Impl/Binary/BinaryWriter.cs                 |   3 +
 .../Impl/Binary/Io/BinaryHeapStream.cs          |   9 +
 .../Impl/Binary/Marshaller.cs                   |  19 +-
 .../Impl/Binary/Metadata/BinaryType.cs          |   2 +
 .../Impl/Binary/SerializableObjectHolder.cs     |  13 +-
 .../Impl/Binary/Structure/BinaryStructure.cs    |   3 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |  42 ++-
 .../Impl/Cache/Query/AbstractQueryCursor.cs     |   4 +-
 .../Continuous/ContinuousQueryFilterHolder.cs   |   2 +-
 .../Continuous/ContinuousQueryHandleImpl.cs     |   4 +-
 .../Impl/Cache/Query/FieldsQueryCursor.cs       |   2 +
 .../Impl/Cache/Query/QueryCursor.cs             |   2 +
 .../Impl/Common/CancelledTask.cs                |   3 +
 .../Common/CopyOnWriteConcurrentDictionary.cs   |   1 +
 .../Impl/Common/DelegateConverter.cs            |  11 +-
 .../Apache.Ignite.Core/Impl/Common/Future.cs    |   2 +
 .../Impl/Common/LoadedAssembliesResolver.cs     |   1 +
 .../Closure/ComputeAbstractClosureTask.cs       |   3 +
 .../Compute/Closure/ComputeMultiClosureTask.cs  |   2 +
 .../Closure/ComputeReducingClosureTask.cs       |   2 +
 .../Compute/Closure/ComputeSingleClosureTask.cs |   2 +
 .../Impl/Datastream/DataStreamerBatch.cs        |   1 +
 .../Impl/Datastream/DataStreamerImpl.cs         |   5 +-
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |  56 +--
 .../Impl/Handle/HandleRegistry.cs               |   1 +
 .../Apache.Ignite.Core/Impl/IgniteUtils.cs      |  11 +-
 .../Impl/InteropExceptionHolder.cs              |  11 +-
 .../Memory/PlatformBigEndianMemoryStream.cs     |   8 +
 .../Impl/Memory/PlatformMemory.cs               |   2 +
 .../Impl/Memory/PlatformMemoryManager.cs        |   2 +
 .../Impl/Memory/PlatformMemoryStream.cs         |   2 +
 .../Impl/Memory/PlatformRawMemory.cs            |   2 +
 .../Apache.Ignite.Core/Impl/PlatformTarget.cs   |   3 +-
 .../Impl/Resource/ResourceProcessor.cs          |   2 +-
 .../Impl/Resource/ResourceTypeDescriptor.cs     |   2 +-
 .../Impl/Services/ServiceProxy.cs               |   2 +
 .../Impl/Services/ServiceProxyInvoker.cs        |   1 +
 .../Impl/Transactions/TransactionsImpl.cs       |   2 +
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |   5 +-
 .../Services/ServiceInvocationException.cs      |   2 +
 modules/platforms/dotnet/Apache.Ignite.FxCop    | 354 +++----------------
 modules/platforms/dotnet/Apache.Ignite.sln      |   4 +-
 .../Apache.Ignite.sln.TeamCity.DotSettings      |  30 ++
 .../dotnet/Apache.Ignite/Apache.Ignite.csproj   |   5 +-
 .../Apache.Ignite.Examples.csproj               |   4 +-
 .../Apache.Ignite.ExamplesDll.csproj            |   4 +-
 parent/pom.xml                                  |   3 +-
 124 files changed, 1816 insertions(+), 932 deletions(-)
----------------------------------------------------------------------



[4/6] ignite git commit: WIP on local benchmarks: added profiler option.

Posted by vo...@apache.org.
WIP on local benchmarks: added profiler option.


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

Branch: refs/heads/ignite-2498
Commit: fb206c5bc0c8059cbcc8e503391cf0d8b8962c7d
Parents: 79db260
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Fri Jan 29 12:33:35 2016 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Fri Jan 29 12:33:35 2016 +0300

----------------------------------------------------------------------
 modules/benchmarks/pom.xml                        |  2 +-
 .../jmh/cache/JmhCachePutBenchmark.java           |  2 ++
 .../jmh/runner/JmhIdeBenchmarkRunner.java         | 18 ++++++++++++++++++
 3 files changed, 21 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/fb206c5b/modules/benchmarks/pom.xml
----------------------------------------------------------------------
diff --git a/modules/benchmarks/pom.xml b/modules/benchmarks/pom.xml
index e735491..7dbc66f 100644
--- a/modules/benchmarks/pom.xml
+++ b/modules/benchmarks/pom.xml
@@ -36,7 +36,7 @@
 
     <properties>
         <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
-        <jmh.version>1.11.1</jmh.version>
+        <jmh.version>1.11.3</jmh.version>
         <javac.target>1.6</javac.target>
         <uberjar.name>benchmarks</uberjar.name>
     </properties>

http://git-wip-us.apache.org/repos/asf/ignite/blob/fb206c5b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCachePutBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCachePutBenchmark.java b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCachePutBenchmark.java
index 1bc24af..848e7ce 100644
--- a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCachePutBenchmark.java
+++ b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCachePutBenchmark.java
@@ -23,6 +23,7 @@ import org.apache.ignite.cache.CacheWriteSynchronizationMode;
 import org.apache.ignite.internal.benchmarks.jmh.runner.JmhIdeBenchmarkRunner;
 import org.apache.ignite.internal.benchmarks.model.IntValue;
 import org.openjdk.jmh.annotations.Benchmark;
+import org.openjdk.jmh.profile.GCProfiler;
 
 import java.util.concurrent.ThreadLocalRandom;
 
@@ -107,6 +108,7 @@ public class JmhCachePutBenchmark extends JmhCacheAbstractBenchmark {
             .measurementIterations(60)
             .classes(JmhCachePutBenchmark.class)
             .output(output + ".jmh.log")
+            .profilers(GCProfiler.class)
             .jvmArguments(
                 "-Xms4g",
                 "-Xmx4g",

http://git-wip-us.apache.org/repos/asf/ignite/blob/fb206c5b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/runner/JmhIdeBenchmarkRunner.java
----------------------------------------------------------------------
diff --git a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/runner/JmhIdeBenchmarkRunner.java b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/runner/JmhIdeBenchmarkRunner.java
index d92a879..af84862 100644
--- a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/runner/JmhIdeBenchmarkRunner.java
+++ b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/runner/JmhIdeBenchmarkRunner.java
@@ -54,6 +54,9 @@ public class JmhIdeBenchmarkRunner {
     /** Amount of threads. */
     private int threads;
 
+    /** Profilers. */
+    private Class[] profilers;
+
     /**
      * Create new runner.
      *
@@ -160,6 +163,16 @@ public class JmhIdeBenchmarkRunner {
     }
 
     /**
+     * @param profilers Profilers.
+     * @return This instance.
+     */
+    public JmhIdeBenchmarkRunner profilers(Class... profilers) {
+        this.profilers = profilers;
+
+        return this;
+    }
+
+    /**
      * Get prepared options builder.
      *
      * @return Options builder.
@@ -189,6 +202,11 @@ public class JmhIdeBenchmarkRunner {
         if (output != null)
             builder.output(output);
 
+        if (profilers != null) {
+            for (Class profiler : profilers)
+                builder.addProfiler(profiler);
+        }
+
         return builder;
     }
 


[6/6] ignite git commit: Merge branch 'master' into ignite-2498

Posted by vo...@apache.org.
Merge branch 'master' into ignite-2498


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

Branch: refs/heads/ignite-2498
Commit: 9103b201c4edf68b0fa75f05f5936e5ca637a0ac
Parents: 14a5f93 c081e3d
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Fri Jan 29 13:10:59 2016 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Fri Jan 29 13:10:59 2016 +0300

----------------------------------------------------------------------
 modules/benchmarks/pom.xml                      |  2 +-
 .../jmh/cache/JmhCachePutBenchmark.java         |  2 +
 .../jmh/runner/JmhIdeBenchmarkRunner.java       | 18 +++++++
 .../GridServicePackagePrivateSelfTest.java      | 17 ++++---
 modules/docker/1.5.0.final/Dockerfile           | 40 ++++++++++++++++
 modules/docker/1.5.0.final/run.sh               | 50 ++++++++++++++++++++
 modules/docker/Dockerfile                       |  6 +--
 7 files changed, 125 insertions(+), 10 deletions(-)
----------------------------------------------------------------------