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 2018/10/25 12:32:03 UTC

ignite git commit: IGNITE-9655: Yardstick: cleanup in DML benchmarks. This closes #4821.

Repository: ignite
Updated Branches:
  refs/heads/master 18c02b5fe -> 610b96ddd


IGNITE-9655: Yardstick: cleanup in DML benchmarks. This closes #4821.


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

Branch: refs/heads/master
Commit: 610b96ddd1352ad645306b2bfae50107e8ee8ab1
Parents: 18c02b5
Author: Pavel Kuznetsov <pa...@gmail.com>
Authored: Thu Oct 25 15:31:57 2018 +0300
Committer: devozerov <vo...@gridgain.com>
Committed: Thu Oct 25 15:31:57 2018 +0300

----------------------------------------------------------------------
 .../config/benchmark-multicast.properties       |   4 -
 .../config/jdbc/benchmark-sql-dml.properties    | 146 +++++++++++++++++++
 .../cache/dml/IgniteSqlDeleteBenchmark.java     |  83 -----------
 .../IgniteSqlInsertIndexedValue1Benchmark.java  |  48 ------
 .../IgniteSqlInsertIndexedValue2Benchmark.java  |  48 ------
 .../IgniteSqlInsertIndexedValue8Benchmark.java  |  48 ------
 .../dml/IgniteSqlUpdateFilteredBenchmark.java   |  89 -----------
 7 files changed, 146 insertions(+), 320 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/610b96dd/modules/yardstick/config/benchmark-multicast.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-multicast.properties b/modules/yardstick/config/benchmark-multicast.properties
index cc07921..4506b28 100644
--- a/modules/yardstick/config/benchmark-multicast.properties
+++ b/modules/yardstick/config/benchmark-multicast.properties
@@ -112,10 +112,6 @@ CONFIGS="\
 -cfg ${SCRIPT_DIR}/../config/ignite-multicast-config.xml -nn ${nodesNum} -b ${b} -w ${w} -d ${d} -t ${t} -sm ${sm} -dn IgniteSqlMergeIndexedValue1Benchmark -sn IgniteNode -ds ${ver}sql-merge-indexed1-${b}-backup,\
 -cfg ${SCRIPT_DIR}/../config/ignite-multicast-config.xml -nn ${nodesNum} -b ${b} -w ${w} -d ${d} -t ${t} -sm ${sm} -dn IgniteSqlMergeIndexedValue2Benchmark -sn IgniteNode -ds ${ver}sql-merge-indexed2-${b}-backup,\
 -cfg ${SCRIPT_DIR}/../config/ignite-multicast-config.xml -nn ${nodesNum} -b ${b} -w ${w} -d ${d} -t ${t} -sm ${sm} -dn IgniteSqlMergeIndexedValue8Benchmark -sn IgniteNode -ds ${ver}sql-merge-indexed8-${b}-backup,\
--cfg ${SCRIPT_DIR}/../config/ignite-multicast-config.xml -nn ${nodesNum} -b ${b} -w ${w} -d ${d} -t ${t} -sm ${sm} -dn IgniteSqlInsertIndexedValue1Benchmark -sn IgniteNode -ds ${ver}sql-insert-indexed1-${b}-backup,\
--cfg ${SCRIPT_DIR}/../config/ignite-multicast-config.xml -nn ${nodesNum} -b ${b} -w ${w} -d ${d} -t ${t} -sm ${sm} -dn IgniteSqlInsertIndexedValue2Benchmark -sn IgniteNode -ds ${ver}sql-insert-indexed2-${b}-backup,\
--cfg ${SCRIPT_DIR}/../config/ignite-multicast-config.xml -nn ${nodesNum} -b ${b} -w ${w} -d ${d} -t ${t} -sm ${sm} -dn IgniteSqlInsertIndexedValue8Benchmark -sn IgniteNode -ds ${ver}sql-insert-indexed8-${b}-backup,\
--cfg ${SCRIPT_DIR}/../config/ignite-multicast-config.xml -nn ${nodesNum} -b ${b} -w ${w} -d ${d} -t ${t} -sm ${sm} -r 300000 -dn IgniteSqlDeleteBenchmark -sn IgniteNode -ds ${ver}sql-delete-${b}-backup,\
 -cfg ${SCRIPT_DIR}/../config/ignite-multicast-config.xml -nn ${nodesNum} -b ${b} -w ${w} -d ${d} -t ${t} -sm ${sm} -dn IgniteSqlDeleteFilteredBenchmark -sn IgniteNode -ds ${ver}sql-delete-filtered-${b}-backup,\
 -cfg ${SCRIPT_DIR}/../config/ignite-multicast-config.xml -nn ${nodesNum} -b ${b} -w ${w} -d ${d} -t ${t} -sm ${sm} -dn IgniteSqlUpdateBenchmark -sn IgniteNode -ds ${ver}sql-update-${b}-backup,\
 -cfg ${SCRIPT_DIR}/../config/ignite-multicast-config.xml -nn ${nodesNum} -b ${b} -w ${w} -d ${d} -t ${t} -sm ${sm} -dn IgniteSqlUpdateFilteredBenchmark -sn IgniteNode -ds ${ver}sql-update-filtered-${b}-backup,\

http://git-wip-us.apache.org/repos/asf/ignite/blob/610b96dd/modules/yardstick/config/jdbc/benchmark-sql-dml.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/jdbc/benchmark-sql-dml.properties b/modules/yardstick/config/jdbc/benchmark-sql-dml.properties
new file mode 100644
index 0000000..4906bd9
--- /dev/null
+++ b/modules/yardstick/config/jdbc/benchmark-sql-dml.properties
@@ -0,0 +1,146 @@
+#
+# 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.
+#
+
+#
+# Benchmarks for update and insert+delete operations. Operations are measured via JDBC thin, JDBC Thick and native sql.
+#
+
+now0=`date +'%H%M%S'`
+
+# JVM options.
+JVM_OPTS=${JVM_OPTS}" -DIGNITE_QUIET=false"
+
+# Uncomment to enable concurrent garbage collection (GC) if you encounter long GC pauses.
+JVM_OPTS=${JVM_OPTS}" \
+-Xms8g \
+-Xmx8g \
+-Xloggc:./gc${now0}.log \
+-XX:+PrintGCDetails \
+-verbose:gc \
+-XX:+UseParNewGC \
+-XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
+"
+
+#Ignite version
+ver="RELEASE-"
+
+# List of default probes.
+# Add DStatProbe or VmStatProbe if your OS supports it (e.g. if running on Linux).
+BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe,DStatProbe
+
+# Packages where the specified benchmark is searched by reflection mechanism.
+BENCHMARK_PACKAGES=org.yardstickframework,org.apache.ignite.yardstick
+
+# Flag which indicates to restart the servers before every benchmark execution.
+RESTART_SERVERS=true
+
+# Probe point writer class name.
+# BENCHMARK_WRITER=
+
+# The benchmark is applicable only for 2 servers (the second server is started in client mode) and 1 driver.
+SERVER_HOSTS=localhost,localhost
+DRIVER_HOSTS=localhost
+
+# Remote username.
+# REMOTE_USER=
+
+# Number of nodes, used to wait for the specified number of nodes to start.
+nodesNum=$((`echo ${SERVER_HOSTS} | tr ',' '\n' | wc -l` + `echo ${DRIVER_HOSTS} | tr ',' '\n' | wc -l`))
+
+# Backups count.
+b=1
+
+# Warmup.
+w=30
+
+# Duration.
+d=300
+
+# Threads count.
+t=4
+
+# Sync mode.
+sm=PRIMARY_SYNC
+
+# Jobs.
+j=10
+
+
+# Note: don't forget to update --clientNodesAfterId value if benchmark is run on more than 2 hosts.
+commonProps="\
+  -cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml \
+  -nn ${nodesNum} -b ${b} -w ${w} -d ${d} -t ${t} \
+  -sm ${sm} -sn IgniteNode \
+  --clientNodesAfterId 0 \
+  "
+
+# Run configuration which contains all benchmarks.
+# Note that each benchmark is set to run for 300 seconds (5 min) with warm-up set to 60 seconds (1 minute).
+CONFIGS="\
+${commonProps} \
+  -dn NativeSqlInsertDeleteBenchmark \
+  -ds ${ver}sql-insert-delete-native-r1-${b}-backup \
+  --sqlRange 1 \
+  -cl,\
+${commonProps} -jdbc jdbc:ignite:thin://auto.find/\
+  -dn JdbcSqlInsertDeleteBenchmark \
+  -ds ${ver}sql-insert-delete-jdbc-thin-r1-${b}-backup \
+  --sqlRange 1 \
+  -cl,\
+${commonProps} -jdbc jdbc:ignite:cfg://cache=query@config/ignite-jdbc-config.xml \
+  -dn JdbcSqlInsertDeleteBenchmark \
+  -ds ${ver}sql-insert-delete-jdbc2-r1-${b}-backup \
+  --sqlRange 1 \
+  -cl,\
+  \
+${commonProps} \
+  -dn NativeSqlUpdateRangeBenchmark \
+  -ds ${ver}sql-update-native-r1-${b}-backup \
+  --sqlRange 1 \
+  -cl, \
+${commonProps} -jdbc jdbc:ignite:thin://auto.find/\
+  -dn JdbcSqlUpdateBenchmark \
+  -ds ${ver}sql-update-jdbc-thin-r1-${b}-backup \
+  --sqlRange 1 \
+  -cl, \
+${commonProps} -jdbc jdbc:ignite:cfg://cache=query@config/ignite-jdbc-config.xml\
+  -dn JdbcSqlUpdateBenchmark \
+  -ds ${ver}sql-update-jdbc2-r1-${b}-backup \
+  --sqlRange 1 \
+  -cl, \
+  \
+${commonProps} \
+  -dn NativeSqlUpdateRangeBenchmark \
+  -ds ${ver}sql-update-native-r1000-${b}-backup \
+  --sqlRange 1000 \
+  -cl, \
+${commonProps} -jdbc jdbc:ignite:thin://auto.find/\
+  -dn JdbcSqlUpdateBenchmark \
+  -ds ${ver}sql-update-jdbc-thin-r1000-${b}-backup \
+  --sqlRange 1000 \
+  -cl, \
+${commonProps} -jdbc jdbc:ignite:cfg://cache=query@config/ignite-jdbc-config.xml\
+  -dn JdbcSqlUpdateBenchmark \
+  -ds ${ver}sql-update-jdbc2-r1000-${b}-backup \
+  --sqlRange 1000 \
+  -cl, \
+  \
+${commonProps} \
+  -dn IgniteSqlUpdateBenchmark \
+  -ds ${ver}sql-update-${b}-backup \
+"
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/610b96dd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlDeleteBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlDeleteBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlDeleteBenchmark.java
deleted file mode 100644
index 864211c..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlDeleteBenchmark.java
+++ /dev/null
@@ -1,83 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.yardstick.cache.dml;
-
-import java.util.ArrayList;
-import java.util.Collection;
-import java.util.Map;
-import java.util.concurrent.ConcurrentLinkedQueue;
-import java.util.concurrent.atomic.AtomicInteger;
-import org.apache.ignite.IgniteCache;
-import org.apache.ignite.cache.query.SqlFieldsQuery;
-import org.apache.ignite.yardstick.cache.IgniteCacheAbstractBenchmark;
-import org.apache.ignite.yardstick.cache.model.Person1;
-import org.yardstickframework.BenchmarkConfiguration;
-import org.yardstickframework.BenchmarkUtils;
-
-/**
- * Ignite benchmark that performs SQL DELETE operations.
- */
-public class IgniteSqlDeleteBenchmark extends IgniteCacheAbstractBenchmark<Integer, Object> {
-    /** */
-    private final ConcurrentLinkedQueue<Integer> keys = new ConcurrentLinkedQueue<>();
-
-    /** {@inheritDoc} */
-    @Override public void setUp(final BenchmarkConfiguration cfg) throws Exception {
-        super.setUp(cfg);
-
-        final AtomicInteger i = new AtomicInteger();
-
-        Collection<Thread> setupThreads = new ArrayList<>(cfg.threads());
-
-        for (int j = 0; j < cfg.threads(); j++) {
-            Thread t = new Thread() {
-                /** {@inheritDoc} */
-                @Override public void run() {
-                    int k;
-
-                    while ((k = i.getAndIncrement()) < args.range()) {
-                        cache().put(k, new Person1(k));
-                        keys.add(k);
-                        if (k % 100000 == 0)
-                            BenchmarkUtils.println(cfg, "DELETE setUp: have successfully put " + k + " items");
-                    }
-                }
-            };
-
-            setupThreads.add(t);
-
-            t.start();
-        }
-
-        for (Thread t : setupThreads)
-            t.join();
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        cache.query(new SqlFieldsQuery("delete from Person1 where _key = ?").setArgs(keys.remove()));
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return ignite().cache("atomic-index");
-    }
-}
-

http://git-wip-us.apache.org/repos/asf/ignite/blob/610b96dd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlInsertIndexedValue1Benchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlInsertIndexedValue1Benchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlInsertIndexedValue1Benchmark.java
deleted file mode 100644
index 63a585d..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlInsertIndexedValue1Benchmark.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.yardstick.cache.dml;
-
-import java.util.Map;
-import java.util.concurrent.atomic.AtomicInteger;
-import org.apache.ignite.IgniteCache;
-import org.apache.ignite.cache.query.SqlFieldsQuery;
-import org.apache.ignite.yardstick.cache.IgniteCacheAbstractBenchmark;
-import org.apache.ignite.yardstick.cache.model.Person1;
-
-/**
- * Ignite benchmark that performs SQL INSERT operations for entity with 1 indexed field.
- */
-public class IgniteSqlInsertIndexedValue1Benchmark extends IgniteCacheAbstractBenchmark<Integer, Object> {
-    /** */
-    private final AtomicInteger insCnt = new AtomicInteger();
-
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        int key = insCnt.getAndIncrement();
-
-        cache.query(new SqlFieldsQuery("insert into Person1(_key, _val) values (?, ?)")
-            .setArgs(key, new Person1(key)));
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return ignite().cache("atomic-index-with-eviction");
-    }
-}

http://git-wip-us.apache.org/repos/asf/ignite/blob/610b96dd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlInsertIndexedValue2Benchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlInsertIndexedValue2Benchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlInsertIndexedValue2Benchmark.java
deleted file mode 100644
index b099951..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlInsertIndexedValue2Benchmark.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.yardstick.cache.dml;
-
-import java.util.Map;
-import java.util.concurrent.atomic.AtomicInteger;
-import org.apache.ignite.IgniteCache;
-import org.apache.ignite.cache.query.SqlFieldsQuery;
-import org.apache.ignite.yardstick.cache.IgniteCacheAbstractBenchmark;
-import org.apache.ignite.yardstick.cache.model.Person2;
-
-/**
- * Ignite benchmark that performs SQL INSERT operations for entity with 2 indexed fields.
- */
-public class IgniteSqlInsertIndexedValue2Benchmark extends IgniteCacheAbstractBenchmark<Integer, Object> {
-    /** */
-    private final AtomicInteger insCnt = new AtomicInteger();
-
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        int key = insCnt.getAndIncrement();
-
-        cache.query(new SqlFieldsQuery("insert into Person2(_key, _val) values (?, ?)")
-            .setArgs(key, new Person2(key)));
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return ignite().cache("atomic-index-with-eviction");
-    }
-}

http://git-wip-us.apache.org/repos/asf/ignite/blob/610b96dd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlInsertIndexedValue8Benchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlInsertIndexedValue8Benchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlInsertIndexedValue8Benchmark.java
deleted file mode 100644
index 3193f38..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlInsertIndexedValue8Benchmark.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.yardstick.cache.dml;
-
-import java.util.Map;
-import java.util.concurrent.atomic.AtomicInteger;
-import org.apache.ignite.IgniteCache;
-import org.apache.ignite.cache.query.SqlFieldsQuery;
-import org.apache.ignite.yardstick.cache.IgniteCacheAbstractBenchmark;
-import org.apache.ignite.yardstick.cache.model.Person8;
-
-/**
- * Ignite benchmark that performs SQL INSERT operations for entity with 8 indexed fields.
- */
-public class IgniteSqlInsertIndexedValue8Benchmark extends IgniteCacheAbstractBenchmark<Integer, Object> {
-    /** */
-    private final AtomicInteger insCnt = new AtomicInteger();
-
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        int key = insCnt.incrementAndGet();
-
-        cache.query(new SqlFieldsQuery("insert into Person8(_key, _val) values (?, ?)")
-            .setArgs(key, new Person8(key)));
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return ignite().cache("atomic-index-with-eviction");
-    }
-}

http://git-wip-us.apache.org/repos/asf/ignite/blob/610b96dd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlUpdateFilteredBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlUpdateFilteredBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlUpdateFilteredBenchmark.java
deleted file mode 100644
index c66f335..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/dml/IgniteSqlUpdateFilteredBenchmark.java
+++ /dev/null
@@ -1,89 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.yardstick.cache.dml;
-
-import java.util.Map;
-import java.util.concurrent.ThreadLocalRandom;
-import java.util.concurrent.atomic.AtomicInteger;
-import java.util.concurrent.atomic.AtomicLong;
-import org.apache.ignite.IgniteCache;
-import org.apache.ignite.cache.query.SqlFieldsQuery;
-import org.apache.ignite.yardstick.cache.IgniteCacheAbstractBenchmark;
-import org.apache.ignite.yardstick.cache.model.Person;
-import org.yardstickframework.BenchmarkConfiguration;
-
-import static org.yardstickframework.BenchmarkUtils.println;
-
-/**
- * Ignite benchmark that performs put and SQL UPDATE operations.
- */
-public class IgniteSqlUpdateFilteredBenchmark extends IgniteCacheAbstractBenchmark<Integer, Object> {
-    /** */
-    private AtomicInteger putCnt = new AtomicInteger();
-
-    /** */
-    private AtomicInteger updCnt = new AtomicInteger();
-
-    /** */
-    private AtomicLong updItemsCnt = new AtomicLong();
-
-    /** {@inheritDoc} */
-    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
-        super.setUp(cfg);
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        ThreadLocalRandom rnd = ThreadLocalRandom.current();
-
-        if (rnd.nextBoolean()) {
-            double salary = rnd.nextDouble() * args.range() * 1000;
-
-            double maxSalary = salary + 1000;
-
-            Long res = (Long)cache().query(new SqlFieldsQuery("update Person set salary = (salary - ?1 + ?2) / 2 " +
-                "where salary >= ?1 and salary <= ?2").setArgs(salary, maxSalary)).getAll().get(0).get(0);
-
-            updItemsCnt.getAndAdd(res);
-
-            updCnt.getAndIncrement();
-        }
-        else {
-            int i = rnd.nextInt(args.range());
-
-            cache.put(i, new Person(i, "firstName" + i, "lastName" + i, i * 1000));
-
-            putCnt.getAndIncrement();
-        }
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return ignite().cache("query");
-    }
-
-    /** {@inheritDoc} */
-    @Override public void tearDown() throws Exception {
-        println(cfg, "Finished SQL UPDATE query benchmark [putCnt=" + putCnt.get() + ", updCnt=" + updCnt.get() +
-            ", updItemsCnt=" + updItemsCnt.get() + ']');
-
-        super.tearDown();
-    }
-}