You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by nn...@apache.org on 2019/02/08 01:50:32 UTC

[geode-benchmarks] branch develop updated: GEODE-6332: Add function execution benchmarks (#51)

This is an automated email from the ASF dual-hosted git repository.

nnag pushed a commit to branch develop
in repository https://gitbox.apache.org/repos/asf/geode-benchmarks.git


The following commit(s) were added to refs/heads/develop by this push:
     new 8d181bb  GEODE-6332: Add function execution benchmarks (#51)
8d181bb is described below

commit 8d181bbb3c4264c22a6b6aac43c97585cc10c618
Author: Nabarun Nag <na...@users.noreply.github.com>
AuthorDate: Thu Feb 7 17:50:26 2019 -0800

    GEODE-6332: Add function execution benchmarks (#51)
---
 .../benchmark/geode/data/BenchmarkFunction.java    | 59 ++++++++++++++
 .../geode/data/FunctionWithArguments.java          | 61 +++++++++++++++
 .../benchmark/geode/data/FunctionWithFilter.java   | 56 +++++++++++++
 .../benchmark/parameters/GeodeProperties.java      |  2 +
 .../benchmark/tasks/ExecuteFilteredFunction.java   | 91 ++++++++++++++++++++++
 .../geode/benchmark/tasks/ExecuteFunction.java     | 75 ++++++++++++++++++
 .../tasks/ExecuteParameterizedFunction.java        | 86 ++++++++++++++++++++
 .../apache/geode/benchmark/tasks/StartServer.java  |  1 -
 .../PartitionedFunctionExecutionBenchmark.java     | 60 ++++++++++++++
 ...nedFunctionExecutionWithArgumentsBenchmark.java | 62 +++++++++++++++
 ...ionedFunctionExecutionWithFiltersBenchmark.java | 60 ++++++++++++++
 .../ReplicatedFunctionExecutionBenchmark.java      | 60 ++++++++++++++
 ...tedFunctionExecutionWithArgumentsBenchmark.java | 60 ++++++++++++++
 ...catedFunctionExecutionWithFiltersBenchmark.java | 60 ++++++++++++++
 .../PartitionedFunctionExecutionBenchmarkTest.java | 42 ++++++++++
 ...unctionExecutionWithArgumentsBenchmarkTest.java | 45 +++++++++++
 ...dFunctionExecutionWithFiltersBenchmarkTest.java | 42 ++++++++++
 .../ReplicatedFunctionExecutionBenchmarkTest.java  | 44 +++++++++++
 ...unctionExecutionWithArgumentsBenchmarkTest.java | 44 +++++++++++
 ...dFunctionExecutionWithFiltersBenchmarkTest.java | 44 +++++++++++
 20 files changed, 1053 insertions(+), 1 deletion(-)

diff --git a/geode-benchmarks/src/main/java/benchmark/geode/data/BenchmarkFunction.java b/geode-benchmarks/src/main/java/benchmark/geode/data/BenchmarkFunction.java
new file mode 100644
index 0000000..b5157cd
--- /dev/null
+++ b/geode-benchmarks/src/main/java/benchmark/geode/data/BenchmarkFunction.java
@@ -0,0 +1,59 @@
+/*
+ * 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 benchmark.geode.data;
+
+import java.util.ArrayList;
+import java.util.List;
+
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.RegionFunctionContext;
+
+public class BenchmarkFunction implements Function {
+  private long maxKey;
+  private long minKey;
+
+  public BenchmarkFunction(long minKey, long maxKey) {
+    this.maxKey = maxKey;
+    this.minKey = minKey;
+  }
+
+  @Override
+  public void execute(FunctionContext context) {
+    RegionFunctionContext regionFunctionContext = (RegionFunctionContext) context;
+    Region region = regionFunctionContext.getDataSet();
+    List<Long> results = new ArrayList<>();
+
+    for (long i = minKey; i <= maxKey; i++) {
+      Portfolio portfolio = (Portfolio) region.get(i);
+      if (portfolio != null) {
+        results.add(portfolio.getID());
+      }
+    }
+
+    context.getResultSender().lastResult(results);
+  }
+
+  @Override
+  public String getId() {
+    return "BenchmarkFunction";
+  }
+
+  @Override
+  public boolean isHA() {
+    return false;
+  }
+}
diff --git a/geode-benchmarks/src/main/java/benchmark/geode/data/FunctionWithArguments.java b/geode-benchmarks/src/main/java/benchmark/geode/data/FunctionWithArguments.java
new file mode 100644
index 0000000..2d53ab6
--- /dev/null
+++ b/geode-benchmarks/src/main/java/benchmark/geode/data/FunctionWithArguments.java
@@ -0,0 +1,61 @@
+/*
+ * 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 benchmark.geode.data;
+
+import java.util.ArrayList;
+import java.util.HashMap;
+import java.util.List;
+
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.RegionFunctionContext;
+
+public class FunctionWithArguments implements Function {
+  private long maxKey;
+  private long minKey;
+
+  public FunctionWithArguments() {}
+
+  @Override
+  public void execute(FunctionContext context) {
+    RegionFunctionContext regionFunctionContext = (RegionFunctionContext) context;
+    Region region = regionFunctionContext.getDataSet();
+    HashMap<String, Long> argumentsMap =
+        (HashMap<String, Long>) regionFunctionContext.getArguments();
+    maxKey = argumentsMap.get("maxID");
+    minKey = argumentsMap.get("minID");
+    List<Long> results = new ArrayList<>();
+
+    for (long i = minKey; i <= maxKey; i++) {
+      Portfolio portfolio = (Portfolio) region.get(i);
+      if (portfolio != null) {
+        results.add(portfolio.getID());
+      }
+    }
+
+    context.getResultSender().lastResult(results);
+  }
+
+  @Override
+  public String getId() {
+    return "FunctionWithArguments";
+  }
+
+  @Override
+  public boolean isHA() {
+    return true;
+  }
+}
diff --git a/geode-benchmarks/src/main/java/benchmark/geode/data/FunctionWithFilter.java b/geode-benchmarks/src/main/java/benchmark/geode/data/FunctionWithFilter.java
new file mode 100644
index 0000000..4b0ff5e
--- /dev/null
+++ b/geode-benchmarks/src/main/java/benchmark/geode/data/FunctionWithFilter.java
@@ -0,0 +1,56 @@
+/*
+ * 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 benchmark.geode.data;
+
+import java.util.ArrayList;
+import java.util.List;
+import java.util.Set;
+
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.RegionFunctionContext;
+
+public class FunctionWithFilter implements Function {
+
+  public FunctionWithFilter() {}
+
+  @Override
+  public void execute(FunctionContext context) {
+    RegionFunctionContext regionFunctionContext = (RegionFunctionContext) context;
+    Region region = regionFunctionContext.getDataSet();
+    Set filterKeys = regionFunctionContext.getFilter();
+    List<Long> results = new ArrayList<>();
+
+    filterKeys.stream().forEach(key -> {
+      Portfolio portfolio = (Portfolio) region.get(key);
+      if (portfolio != null) {
+        results.add(portfolio.getID());
+      }
+    });
+
+    context.getResultSender().lastResult(results);
+  }
+
+  @Override
+  public String getId() {
+    return "FunctionWithFilter";
+  }
+
+  @Override
+  public boolean isHA() {
+    return true;
+  }
+}
diff --git a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/parameters/GeodeProperties.java b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/parameters/GeodeProperties.java
index 32178ba..77b4eb8 100644
--- a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/parameters/GeodeProperties.java
+++ b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/parameters/GeodeProperties.java
@@ -36,6 +36,8 @@ public class GeodeProperties {
     properties.setProperty(ConfigurationProperties.DISTRIBUTED_SYSTEM_ID, "0");
     properties.setProperty(ConfigurationProperties.ENABLE_CLUSTER_CONFIGURATION, "false");
     properties.setProperty(ConfigurationProperties.USE_CLUSTER_CONFIGURATION, "false");
+    properties.setProperty(ConfigurationProperties.SERIALIZABLE_OBJECT_FILTER,
+        "benchmark.geode.data.**");
     return properties;
   }
 
diff --git a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/ExecuteFilteredFunction.java b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/ExecuteFilteredFunction.java
new file mode 100644
index 0000000..2bb7b17
--- /dev/null
+++ b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/ExecuteFilteredFunction.java
@@ -0,0 +1,91 @@
+/*
+ * 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.geode.benchmark.tasks;
+
+import java.io.Serializable;
+import java.rmi.UnexpectedException;
+import java.util.ArrayList;
+import java.util.HashSet;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
+import java.util.concurrent.ThreadLocalRandom;
+
+import benchmark.geode.data.FunctionWithFilter;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+import org.yardstickframework.BenchmarkConfiguration;
+import org.yardstickframework.BenchmarkDriverAdapter;
+
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientCacheFactory;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.perftest.jvms.RemoteJVMFactory;
+
+public class ExecuteFilteredFunction extends BenchmarkDriverAdapter implements Serializable {
+  private Region region;
+  long keyRange;
+  long filterRange;
+  private Function function;
+  private static final Logger logger = LoggerFactory.getLogger(RemoteJVMFactory.class);
+
+  public ExecuteFilteredFunction(long keyRange, long filterRange) {
+    this.keyRange = keyRange;
+    this.filterRange = filterRange;
+    this.function = new FunctionWithFilter();
+  }
+
+  @Override
+  public void setUp(BenchmarkConfiguration cfg) throws Exception {
+    super.setUp(cfg);
+    ClientCache cache = ClientCacheFactory.getAnyInstance();
+    region = cache.getRegion("region");
+    FunctionService.registerFunction(function);
+  }
+
+  @Override
+  public boolean test(Map<Object, Object> ctx) throws Exception {
+    long minId = ThreadLocalRandom.current().nextLong(0, this.keyRange - filterRange);
+    long maxId = minId + filterRange;
+    Set<Long> filterSet = new HashSet<>();
+    for (long i = minId; i <= maxId; i++) {
+      filterSet.add(i);
+    }
+    ResultCollector resultCollector = FunctionService
+        .onRegion(region)
+        .withFilter(filterSet)
+        .execute(function);
+    List results = (List) resultCollector.getResult();
+    validateResults(results, minId, maxId);
+    return true;
+
+  }
+
+  private void validateResults(List results, long minId, long maxId)
+      throws UnexpectedException {
+    for (Object result : results) {
+      ArrayList<Long> IDs = (ArrayList<Long>) result;
+      for (Long id : IDs) {
+        if (id < minId || id > maxId) {
+          throw new UnexpectedException("Invalid ID value received [minID = " + minId + " maxID = "
+              + maxId + " ] Portfolio ID received = " + id);
+        }
+      }
+    }
+  }
+}
diff --git a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/ExecuteFunction.java b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/ExecuteFunction.java
new file mode 100644
index 0000000..3106758
--- /dev/null
+++ b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/ExecuteFunction.java
@@ -0,0 +1,75 @@
+/*
+ * 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.geode.benchmark.tasks;
+
+import java.io.Serializable;
+import java.rmi.UnexpectedException;
+import java.util.ArrayList;
+import java.util.List;
+import java.util.Map;
+import java.util.concurrent.ThreadLocalRandom;
+
+import benchmark.geode.data.BenchmarkFunction;
+import org.yardstickframework.BenchmarkConfiguration;
+import org.yardstickframework.BenchmarkDriverAdapter;
+
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientCacheFactory;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
+
+public class ExecuteFunction extends BenchmarkDriverAdapter implements Serializable {
+  private Region region;
+  long keyRange;
+  long functionIDRange;
+
+  public ExecuteFunction(long keyRange, long functionIDRange) {
+    this.keyRange = keyRange;
+    this.functionIDRange = functionIDRange;
+  }
+
+  @Override
+  public void setUp(BenchmarkConfiguration cfg) throws Exception {
+    super.setUp(cfg);
+    ClientCache cache = ClientCacheFactory.getAnyInstance();
+    region = cache.getRegion("region");
+  }
+
+  @Override
+  public boolean test(Map<Object, Object> ctx) throws Exception {
+    long minId = ThreadLocalRandom.current().nextLong(0, this.keyRange - functionIDRange);
+    long maxId = minId + functionIDRange;
+    Function function = new BenchmarkFunction(minId, maxId);
+    FunctionService.registerFunction(function);
+    ResultCollector resultCollector = FunctionService.onRegion(region).execute(function);
+    List results = (List) resultCollector.getResult();
+    validateResults(results, minId, maxId);
+    return true;
+  }
+
+  private void validateResults(List results, long minId, long maxId) throws UnexpectedException {
+    for (Object result : results) {
+      ArrayList<Long> IDs = (ArrayList<Long>) result;
+      for (Long id : IDs) {
+        if (id < minId || id > maxId) {
+          throw new UnexpectedException("Invalid ID values received [min ID=" + minId + ",max ID="
+              + maxId + "] Portfolio ID received=" + id);
+        }
+      }
+    }
+  }
+}
diff --git a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/ExecuteParameterizedFunction.java b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/ExecuteParameterizedFunction.java
new file mode 100644
index 0000000..a965eab
--- /dev/null
+++ b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/ExecuteParameterizedFunction.java
@@ -0,0 +1,86 @@
+/*
+ * 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.geode.benchmark.tasks;
+
+import java.io.Serializable;
+import java.rmi.UnexpectedException;
+import java.util.ArrayList;
+import java.util.HashMap;
+import java.util.List;
+import java.util.Map;
+import java.util.concurrent.ThreadLocalRandom;
+
+import benchmark.geode.data.FunctionWithArguments;
+import org.yardstickframework.BenchmarkConfiguration;
+import org.yardstickframework.BenchmarkDriverAdapter;
+
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientCacheFactory;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
+
+public class ExecuteParameterizedFunction extends BenchmarkDriverAdapter implements Serializable {
+
+  private Region region;
+  long keyRange;
+  long functionIDRange;
+  private Function function;
+
+  public ExecuteParameterizedFunction(long keyRange, long functionIDRange) {
+    this.keyRange = keyRange;
+    this.functionIDRange = functionIDRange;
+    this.function = new FunctionWithArguments();
+  }
+
+  @Override
+  public void setUp(BenchmarkConfiguration cfg) throws Exception {
+    super.setUp(cfg);
+    ClientCache cache = ClientCacheFactory.getAnyInstance();
+    region = cache.getRegion("region");
+    FunctionService.registerFunction(function);
+  }
+
+  @Override
+  public boolean test(Map<Object, Object> ctx) throws Exception {
+    long minId = ThreadLocalRandom.current().nextLong(0, this.keyRange - functionIDRange);
+    long maxId = minId + functionIDRange;
+    Map<String, Long> argumentMap = new HashMap<>();
+    argumentMap.put("maxID", maxId);
+    argumentMap.put("minID", minId);
+    ResultCollector resultCollector = FunctionService
+        .onRegion(region)
+        .setArguments(argumentMap)
+        .execute(function);
+    List results = (List) resultCollector.getResult();
+    validateResults(results, minId, maxId);
+    return true;
+
+  }
+
+  private void validateResults(List results, long minId, long maxId)
+      throws UnexpectedException {
+    for (Object result : results) {
+      ArrayList<Long> IDs = (ArrayList<Long>) result;
+      for (Long id : IDs) {
+        if (id < minId || id > maxId) {
+          throw new UnexpectedException("Invalid ID value received [minID= " + minId
+              + " maxID= " + maxId + " ] Portfolio ID received = " + id);
+        }
+      }
+    }
+  }
+}
diff --git a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/StartServer.java b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/StartServer.java
index 7c18db6..70437ff 100644
--- a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/StartServer.java
+++ b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tasks/StartServer.java
@@ -52,7 +52,6 @@ public class StartServer implements Task {
             "server-" + context.getJvmID() + "-" + InetAddress.getLocalHost())
         .set(ConfigurationProperties.STATISTIC_ARCHIVE_FILE, statsFile)
         .create();
-
     CacheServer cacheServer = cache.addCacheServer();
     cacheServer.setPort(0);
     cacheServer.start();
diff --git a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionBenchmark.java b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionBenchmark.java
new file mode 100644
index 0000000..04832e7
--- /dev/null
+++ b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionBenchmark.java
@@ -0,0 +1,60 @@
+/*
+ * 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.geode.benchmark.tests;
+
+import static org.apache.geode.benchmark.topology.ClientServerTopology.Roles.CLIENT;
+import static org.apache.geode.benchmark.topology.ClientServerTopology.Roles.SERVER;
+
+import org.junit.jupiter.api.Test;
+
+import org.apache.geode.benchmark.tasks.CreateClientProxyRegion;
+import org.apache.geode.benchmark.tasks.CreatePartitionedRegion;
+import org.apache.geode.benchmark.tasks.ExecuteFunction;
+import org.apache.geode.benchmark.tasks.PrePopulateRegion;
+import org.apache.geode.benchmark.topology.ClientServerTopology;
+import org.apache.geode.perftest.PerformanceTest;
+import org.apache.geode.perftest.TestConfig;
+import org.apache.geode.perftest.TestRunners;
+
+public class PartitionedFunctionExecutionBenchmark implements PerformanceTest {
+  private long keyRange = 1000000;
+  private long functionIDRange = 1000;
+
+  public PartitionedFunctionExecutionBenchmark() {}
+
+  public void setKeyRange(long keyRange) {
+    this.keyRange = keyRange;
+  }
+
+  public void setFunctionIDRange(long functionIDRange) {
+    this.functionIDRange = functionIDRange;
+  }
+
+  @Test
+  public void run() throws Exception {
+    TestRunners.defaultRunner().runTest(this);
+  }
+
+  @Override
+  public TestConfig configure() {
+    TestConfig config = GeodeBenchmark.createConfig();
+    ClientServerTopology.configure(config);
+    config.before(new CreatePartitionedRegion(), SERVER);
+    config.before(new CreateClientProxyRegion(), CLIENT);
+    config.before(new PrePopulateRegion(keyRange), SERVER);
+    config.workload(new ExecuteFunction(keyRange, functionIDRange), CLIENT);
+    return config;
+  }
+}
diff --git a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionWithArgumentsBenchmark.java b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionWithArgumentsBenchmark.java
new file mode 100644
index 0000000..52e8965
--- /dev/null
+++ b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionWithArgumentsBenchmark.java
@@ -0,0 +1,62 @@
+/*
+ * 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.geode.benchmark.tests;
+
+import static org.apache.geode.benchmark.topology.ClientServerTopology.Roles.CLIENT;
+import static org.apache.geode.benchmark.topology.ClientServerTopology.Roles.SERVER;
+
+import org.junit.jupiter.api.Test;
+
+import org.apache.geode.benchmark.tasks.CreateClientProxyRegion;
+import org.apache.geode.benchmark.tasks.CreatePartitionedRegion;
+import org.apache.geode.benchmark.tasks.ExecuteParameterizedFunction;
+import org.apache.geode.benchmark.tasks.PrePopulateRegion;
+import org.apache.geode.benchmark.topology.ClientServerTopology;
+import org.apache.geode.perftest.PerformanceTest;
+import org.apache.geode.perftest.TestConfig;
+import org.apache.geode.perftest.TestRunners;
+
+public class PartitionedFunctionExecutionWithArgumentsBenchmark implements PerformanceTest {
+  private long keyRange = 1000000;
+  private long functionIDRange = 1000;
+
+  public PartitionedFunctionExecutionWithArgumentsBenchmark() {}
+
+  public void setKeyRange(long keyRange) {
+    this.keyRange = keyRange;
+  }
+
+  public void setFunctionIDRange(long functionIDRange) {
+    this.functionIDRange = functionIDRange;
+  }
+
+  @Test
+  public void run() throws Exception {
+    TestRunners.defaultRunner().runTest(this);
+  }
+
+
+  @Override
+  public TestConfig configure() {
+    TestConfig config = GeodeBenchmark.createConfig();
+    ClientServerTopology.configure(config);
+    config.before(new CreatePartitionedRegion(), SERVER);
+    config.before(new CreateClientProxyRegion(), CLIENT);
+    config.before(new PrePopulateRegion(keyRange), SERVER);
+    config.workload(new ExecuteParameterizedFunction(keyRange, functionIDRange), CLIENT);
+    return config;
+
+  }
+}
diff --git a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionWithFiltersBenchmark.java b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionWithFiltersBenchmark.java
new file mode 100644
index 0000000..ba2fd76
--- /dev/null
+++ b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionWithFiltersBenchmark.java
@@ -0,0 +1,60 @@
+/*
+ * 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.geode.benchmark.tests;
+
+import static org.apache.geode.benchmark.topology.ClientServerTopology.Roles.CLIENT;
+import static org.apache.geode.benchmark.topology.ClientServerTopology.Roles.SERVER;
+
+import org.junit.jupiter.api.Test;
+
+import org.apache.geode.benchmark.tasks.CreateClientProxyRegion;
+import org.apache.geode.benchmark.tasks.CreatePartitionedRegion;
+import org.apache.geode.benchmark.tasks.ExecuteFilteredFunction;
+import org.apache.geode.benchmark.tasks.PrePopulateRegion;
+import org.apache.geode.benchmark.topology.ClientServerTopology;
+import org.apache.geode.perftest.PerformanceTest;
+import org.apache.geode.perftest.TestConfig;
+import org.apache.geode.perftest.TestRunners;
+
+public class PartitionedFunctionExecutionWithFiltersBenchmark implements PerformanceTest {
+  private long keyRange = 1000000;
+  private long filterKeyRange = 1000;
+
+  public PartitionedFunctionExecutionWithFiltersBenchmark() {}
+
+  public void setKeyRange(long keyRange) {
+    this.keyRange = keyRange;
+  }
+
+  public void setFilterKeyRange(long filterKeyRange) {
+    this.filterKeyRange = filterKeyRange;
+  }
+
+  @Test
+  public void run() throws Exception {
+    TestRunners.defaultRunner().runTest(this);
+  }
+
+  @Override
+  public TestConfig configure() {
+    TestConfig config = GeodeBenchmark.createConfig();
+    ClientServerTopology.configure(config);
+    config.before(new CreatePartitionedRegion(), SERVER);
+    config.before(new CreateClientProxyRegion(), CLIENT);
+    config.before(new PrePopulateRegion(keyRange), SERVER);
+    config.workload(new ExecuteFilteredFunction(keyRange, filterKeyRange), CLIENT);
+    return config;
+  }
+}
diff --git a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionBenchmark.java b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionBenchmark.java
new file mode 100644
index 0000000..53f4790
--- /dev/null
+++ b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionBenchmark.java
@@ -0,0 +1,60 @@
+/*
+ * 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.geode.benchmark.tests;
+
+import static org.apache.geode.benchmark.topology.ClientServerTopology.Roles.CLIENT;
+import static org.apache.geode.benchmark.topology.ClientServerTopology.Roles.SERVER;
+
+import org.junit.jupiter.api.Test;
+
+import org.apache.geode.benchmark.tasks.CreateClientProxyRegion;
+import org.apache.geode.benchmark.tasks.CreateReplicatedRegion;
+import org.apache.geode.benchmark.tasks.ExecuteFunction;
+import org.apache.geode.benchmark.tasks.PrePopulateRegion;
+import org.apache.geode.benchmark.topology.ClientServerTopology;
+import org.apache.geode.perftest.PerformanceTest;
+import org.apache.geode.perftest.TestConfig;
+import org.apache.geode.perftest.TestRunners;
+
+public class ReplicatedFunctionExecutionBenchmark implements PerformanceTest {
+  private long keyRange = 1000000;
+  private long functionIDRange = 1000;
+
+  public ReplicatedFunctionExecutionBenchmark() {}
+
+  public void setKeyRange(long keyRange) {
+    this.keyRange = keyRange;
+  }
+
+  public void setFunctionIDRange(long functionIDRange) {
+    this.functionIDRange = functionIDRange;
+  }
+
+  @Test
+  public void run() throws Exception {
+    TestRunners.defaultRunner().runTest(this);
+  }
+
+  @Override
+  public TestConfig configure() {
+    TestConfig config = GeodeBenchmark.createConfig();
+    ClientServerTopology.configure(config);
+    config.before(new CreateReplicatedRegion(), SERVER);
+    config.before(new CreateClientProxyRegion(), CLIENT);
+    config.before(new PrePopulateRegion(keyRange), SERVER);
+    config.workload(new ExecuteFunction(keyRange, functionIDRange), CLIENT);
+    return config;
+  }
+}
diff --git a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionWithArgumentsBenchmark.java b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionWithArgumentsBenchmark.java
new file mode 100644
index 0000000..99ce9b7
--- /dev/null
+++ b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionWithArgumentsBenchmark.java
@@ -0,0 +1,60 @@
+/*
+ * 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.geode.benchmark.tests;
+
+import static org.apache.geode.benchmark.topology.ClientServerTopology.Roles.CLIENT;
+import static org.apache.geode.benchmark.topology.ClientServerTopology.Roles.SERVER;
+
+import org.junit.jupiter.api.Test;
+
+import org.apache.geode.benchmark.tasks.CreateClientProxyRegion;
+import org.apache.geode.benchmark.tasks.CreateReplicatedRegion;
+import org.apache.geode.benchmark.tasks.ExecuteParameterizedFunction;
+import org.apache.geode.benchmark.tasks.PrePopulateRegion;
+import org.apache.geode.benchmark.topology.ClientServerTopology;
+import org.apache.geode.perftest.PerformanceTest;
+import org.apache.geode.perftest.TestConfig;
+import org.apache.geode.perftest.TestRunners;
+
+public class ReplicatedFunctionExecutionWithArgumentsBenchmark implements PerformanceTest {
+  private long keyRange = 1000000;
+  private long functionIDRange = 1000;
+
+  public ReplicatedFunctionExecutionWithArgumentsBenchmark() {}
+
+  public void setKeyRange(long keyRange) {
+    this.keyRange = keyRange;
+  }
+
+  public void setFunctionIDRange(long functionIDRange) {
+    this.functionIDRange = functionIDRange;
+  }
+
+  @Test
+  public void run() throws Exception {
+    TestRunners.defaultRunner().runTest(this);
+  }
+
+  @Override
+  public TestConfig configure() {
+    TestConfig config = GeodeBenchmark.createConfig();
+    ClientServerTopology.configure(config);
+    config.before(new CreateReplicatedRegion(), SERVER);
+    config.before(new CreateClientProxyRegion(), CLIENT);
+    config.before(new PrePopulateRegion(keyRange), SERVER);
+    config.workload(new ExecuteParameterizedFunction(keyRange, functionIDRange), CLIENT);
+    return config;
+  }
+}
diff --git a/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionWithFiltersBenchmark.java b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionWithFiltersBenchmark.java
new file mode 100644
index 0000000..ecfc147
--- /dev/null
+++ b/geode-benchmarks/src/main/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionWithFiltersBenchmark.java
@@ -0,0 +1,60 @@
+/*
+ * 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.geode.benchmark.tests;
+
+import static org.apache.geode.benchmark.topology.ClientServerTopology.Roles.CLIENT;
+import static org.apache.geode.benchmark.topology.ClientServerTopology.Roles.SERVER;
+
+import org.junit.jupiter.api.Test;
+
+import org.apache.geode.benchmark.tasks.CreateClientProxyRegion;
+import org.apache.geode.benchmark.tasks.CreateReplicatedRegion;
+import org.apache.geode.benchmark.tasks.ExecuteFilteredFunction;
+import org.apache.geode.benchmark.tasks.PrePopulateRegion;
+import org.apache.geode.benchmark.topology.ClientServerTopology;
+import org.apache.geode.perftest.PerformanceTest;
+import org.apache.geode.perftest.TestConfig;
+import org.apache.geode.perftest.TestRunners;
+
+public class ReplicatedFunctionExecutionWithFiltersBenchmark implements PerformanceTest {
+  private long keyRange = 1000000;
+  private long filterKeyRange = 1000;
+
+  public ReplicatedFunctionExecutionWithFiltersBenchmark() {}
+
+  public void setKeyRange(long keyRange) {
+    this.keyRange = keyRange;
+  }
+
+  public void setFilterKeyRange(long filterKeyRange) {
+    this.filterKeyRange = filterKeyRange;
+  }
+
+  @Test
+  public void run() throws Exception {
+    TestRunners.defaultRunner().runTest(this);
+  }
+
+  @Override
+  public TestConfig configure() {
+    TestConfig config = GeodeBenchmark.createConfig();
+    ClientServerTopology.configure(config);
+    config.before(new CreateReplicatedRegion(), SERVER);
+    config.before(new CreateClientProxyRegion(), CLIENT);
+    config.before(new PrePopulateRegion(keyRange), SERVER);
+    config.workload(new ExecuteFilteredFunction(keyRange, filterKeyRange), CLIENT);
+    return config;
+  }
+}
diff --git a/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionBenchmarkTest.java b/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionBenchmarkTest.java
new file mode 100644
index 0000000..ad30de3
--- /dev/null
+++ b/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionBenchmarkTest.java
@@ -0,0 +1,42 @@
+/*
+ * 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.geode.benchmark.tests;
+
+import java.io.File;
+import java.nio.file.Path;
+
+import org.junit.jupiter.api.BeforeEach;
+import org.junit.jupiter.api.extension.ExtendWith;
+import org.junitpioneer.jupiter.TempDirectory;
+
+import org.apache.geode.perftest.TestRunners;
+
+@ExtendWith(TempDirectory.class)
+public class PartitionedFunctionExecutionBenchmarkTest {
+
+  private File folder;
+
+  @BeforeEach
+  void createTemporaryFolder(@TempDirectory.TempDir Path tempFolder) {
+    folder = tempFolder.toFile();
+  }
+
+  public void benchmarkRunsSuccessfully() throws Exception {
+    PartitionedFunctionExecutionBenchmark test = new PartitionedFunctionExecutionBenchmark();
+    test.setKeyRange(100);
+    test.setFunctionIDRange(5);
+    TestRunners.minimalRunner(folder).runTest(test);
+  }
+}
diff --git a/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionWithArgumentsBenchmarkTest.java b/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionWithArgumentsBenchmarkTest.java
new file mode 100644
index 0000000..58a4490
--- /dev/null
+++ b/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionWithArgumentsBenchmarkTest.java
@@ -0,0 +1,45 @@
+/*
+ * 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.geode.benchmark.tests;
+
+import java.io.File;
+import java.nio.file.Path;
+
+import org.junit.jupiter.api.BeforeEach;
+import org.junit.jupiter.api.Test;
+import org.junit.jupiter.api.extension.ExtendWith;
+import org.junitpioneer.jupiter.TempDirectory;
+
+import org.apache.geode.perftest.TestRunners;
+
+@ExtendWith(TempDirectory.class)
+public class PartitionedFunctionExecutionWithArgumentsBenchmarkTest {
+
+  private File folder;
+
+  @BeforeEach
+  void createTemporaryFolder(@TempDirectory.TempDir Path tempFolder) {
+    folder = tempFolder.toFile();
+  }
+
+  @Test
+  public void benchmarkRunsSuccessfully() throws Exception {
+    PartitionedFunctionExecutionWithArgumentsBenchmark test =
+        new PartitionedFunctionExecutionWithArgumentsBenchmark();
+    test.setKeyRange(100);
+    test.setFunctionIDRange(5);
+    TestRunners.minimalRunner(folder).runTest(test);
+  }
+}
diff --git a/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionWithFiltersBenchmarkTest.java b/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionWithFiltersBenchmarkTest.java
new file mode 100644
index 0000000..7a9f446
--- /dev/null
+++ b/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/PartitionedFunctionExecutionWithFiltersBenchmarkTest.java
@@ -0,0 +1,42 @@
+/*
+ * 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.geode.benchmark.tests;
+
+import java.io.File;
+import java.nio.file.Path;
+
+import org.junit.jupiter.api.BeforeEach;
+import org.junit.jupiter.api.Test;
+import org.junit.jupiter.api.extension.ExtendWith;
+import org.junitpioneer.jupiter.TempDirectory;
+
+@ExtendWith(TempDirectory.class)
+public class PartitionedFunctionExecutionWithFiltersBenchmarkTest {
+
+  private File folder;
+
+  @BeforeEach
+  void createTemporaryFolder(@TempDirectory.TempDir Path tempFolder) {
+    folder = tempFolder.toFile();
+  }
+
+  @Test
+  public void benchmarkRunsSuccessfully() throws Exception {
+    PartitionedFunctionExecutionWithFiltersBenchmark test =
+        new PartitionedFunctionExecutionWithFiltersBenchmark();
+    test.setKeyRange(100);
+    test.setFilterKeyRange(5);
+  }
+}
diff --git a/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionBenchmarkTest.java b/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionBenchmarkTest.java
new file mode 100644
index 0000000..56d210f
--- /dev/null
+++ b/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionBenchmarkTest.java
@@ -0,0 +1,44 @@
+/*
+ * 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.geode.benchmark.tests;
+
+import java.io.File;
+import java.nio.file.Path;
+
+import org.junit.jupiter.api.BeforeEach;
+import org.junit.jupiter.api.Test;
+import org.junit.jupiter.api.extension.ExtendWith;
+import org.junitpioneer.jupiter.TempDirectory;
+
+import org.apache.geode.perftest.TestRunners;
+
+@ExtendWith(TempDirectory.class)
+public class ReplicatedFunctionExecutionBenchmarkTest {
+
+  private File folder;
+
+  @BeforeEach
+  void createTemporaryFolder(@TempDirectory.TempDir Path tempFolder) {
+    folder = tempFolder.toFile();
+  }
+
+  @Test
+  void benchmarkRunsSuccessfully() throws Exception {
+    ReplicatedFunctionExecutionBenchmark test = new ReplicatedFunctionExecutionBenchmark();
+    test.setKeyRange(100);
+    test.setFunctionIDRange(5);
+    TestRunners.minimalRunner(folder).runTest(test);
+  }
+}
diff --git a/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionWithArgumentsBenchmarkTest.java b/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionWithArgumentsBenchmarkTest.java
new file mode 100644
index 0000000..d4df73c
--- /dev/null
+++ b/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionWithArgumentsBenchmarkTest.java
@@ -0,0 +1,44 @@
+/*
+ * 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.geode.benchmark.tests;
+
+import java.io.File;
+import java.nio.file.Path;
+
+import org.junit.jupiter.api.BeforeEach;
+import org.junit.jupiter.api.Test;
+import org.junit.jupiter.api.extension.ExtendWith;
+import org.junitpioneer.jupiter.TempDirectory;
+
+import org.apache.geode.perftest.TestRunners;
+
+@ExtendWith(TempDirectory.class)
+public class ReplicatedFunctionExecutionWithArgumentsBenchmarkTest {
+  private File folder;
+
+  @BeforeEach
+  void createTemporaryFolder(@TempDirectory.TempDir Path tempFolder) {
+    folder = tempFolder.toFile();
+  }
+
+  @Test
+  public void benchmarkRunsSuccessfully() throws Exception {
+    ReplicatedFunctionExecutionWithArgumentsBenchmark test =
+        new ReplicatedFunctionExecutionWithArgumentsBenchmark();
+    test.setKeyRange(100);
+    test.setFunctionIDRange(5);
+    TestRunners.minimalRunner(folder).runTest(test);
+  }
+}
diff --git a/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionWithFiltersBenchmarkTest.java b/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionWithFiltersBenchmarkTest.java
new file mode 100644
index 0000000..283a849
--- /dev/null
+++ b/geode-benchmarks/src/test/java/org/apache/geode/benchmark/tests/ReplicatedFunctionExecutionWithFiltersBenchmarkTest.java
@@ -0,0 +1,44 @@
+/*
+ * 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.geode.benchmark.tests;
+
+import java.io.File;
+import java.nio.file.Path;
+
+import org.junit.jupiter.api.BeforeEach;
+import org.junit.jupiter.api.Test;
+import org.junit.jupiter.api.extension.ExtendWith;
+import org.junitpioneer.jupiter.TempDirectory;
+
+import org.apache.geode.perftest.TestRunners;
+
+@ExtendWith(TempDirectory.class)
+public class ReplicatedFunctionExecutionWithFiltersBenchmarkTest {
+  private File folder;
+
+  @BeforeEach
+  void createTemporaryFolder(@TempDirectory.TempDir Path tempFolder) {
+    folder = tempFolder.toFile();
+  }
+
+  @Test
+  public void benchmarkRunsSuccessfully() throws Exception {
+    ReplicatedFunctionExecutionWithFiltersBenchmark test =
+        new ReplicatedFunctionExecutionWithFiltersBenchmark();
+    test.setKeyRange(100);
+    test.setFilterKeyRange(5);
+    TestRunners.minimalRunner(folder).runTest(test);
+  }
+}