You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by sb...@apache.org on 2016/12/09 11:27:44 UTC

[22/25] ignite git commit: Added benchmark for atomic increments w/ and w/o thread-local batching.

Added benchmark for atomic increments w/ and w/o thread-local batching.


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

Branch: refs/heads/ignite-4371
Commit: b65802b9d32d6c52bcf35b3a52a39b12ea34ec0a
Parents: 065ca4a
Author: devozerov <vo...@gridgain.com>
Authored: Fri Dec 9 13:10:22 2016 +0300
Committer: devozerov <vo...@gridgain.com>
Committed: Fri Dec 9 13:10:22 2016 +0300

----------------------------------------------------------------------
 .../jmh/misc/JmhIncrementBenchmark.java         | 95 ++++++++++++++++++++
 1 file changed, 95 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/b65802b9/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/misc/JmhIncrementBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/misc/JmhIncrementBenchmark.java b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/misc/JmhIncrementBenchmark.java
new file mode 100644
index 0000000..629fdd3
--- /dev/null
+++ b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/misc/JmhIncrementBenchmark.java
@@ -0,0 +1,95 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.internal.benchmarks.jmh.misc;
+
+import org.apache.ignite.internal.benchmarks.jmh.JmhAbstractBenchmark;
+import org.apache.ignite.internal.benchmarks.jmh.runner.JmhIdeBenchmarkRunner;
+import org.openjdk.jmh.annotations.Benchmark;
+import org.openjdk.jmh.annotations.Scope;
+import org.openjdk.jmh.annotations.State;
+
+import java.util.concurrent.atomic.AtomicLong;
+
+/**
+ * Test various increment strategies.
+ */
+@State(Scope.Benchmark)
+public class JmhIncrementBenchmark extends JmhAbstractBenchmark {
+    /** Batch size. */
+    private static final int BATCH_SIZE = 1024;
+
+    /** Thread-local value. */
+    private static final ThreadLocal<Long> VAL = new ThreadLocal<Long>() {
+        @Override protected Long initialValue() {
+            return 0L;
+        }
+    };
+
+    /** Atomic variable. */
+    private final AtomicLong atomic = new AtomicLong();
+
+    /**
+     * Test standard increment.
+     */
+    @Benchmark
+    public long increment() {
+        return atomic.incrementAndGet();
+    }
+
+    /**
+     * Test increment with thread-local batching.
+     */
+    @Benchmark
+    public long threadLocalIncrement() {
+        long val = VAL.get();
+
+        if ((val & (BATCH_SIZE - 1)) == 0)
+            val = atomic.addAndGet(BATCH_SIZE);
+
+        VAL.set(++val);
+
+        return val;
+    }
+
+    /**
+     * Run benchmarks.
+     *
+     * @param args Arguments.
+     * @throws Exception If failed.
+     */
+    public static void main(String[] args) throws Exception {
+        run(8);
+    }
+
+    /**
+     * Run benchmark.
+     *
+     * @param threads Amount of threads.
+     * @throws Exception If failed.
+     */
+    private static void run(int threads) throws Exception {
+        JmhIdeBenchmarkRunner.create()
+            .forks(1)
+            .threads(threads)
+            .warmupIterations(30)
+            .measurementIterations(30)
+            .benchmarks(JmhIncrementBenchmark.class.getSimpleName())
+            .jvmArguments("-Xms4g", "-Xmx4g")
+            .run();
+    }
+}