You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tinkerpop.apache.org by sp...@apache.org on 2015/05/08 20:14:13 UTC

[1/3] incubator-tinkerpop git commit: Use an executorservice in the profiling app to submit requests.

Repository: incubator-tinkerpop
Updated Branches:
  refs/heads/master 48c15ee28 -> 8f798f5cd


Use an executorservice in the profiling app to submit requests.


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

Branch: refs/heads/master
Commit: aa398ee1cccc847b5dd45a0bb79fc00c8977a7c9
Parents: 083afee
Author: Stephen Mallette <sp...@genoprime.com>
Authored: Fri May 8 14:12:56 2015 -0400
Committer: Stephen Mallette <sp...@genoprime.com>
Committed: Fri May 8 14:12:56 2015 -0400

----------------------------------------------------------------------
 .../tinkerpop/gremlin/driver/util/ProfilingApplication.java    | 6 +++++-
 1 file changed, 5 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/aa398ee1/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/util/ProfilingApplication.java
----------------------------------------------------------------------
diff --git a/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/util/ProfilingApplication.java b/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/util/ProfilingApplication.java
index d4d75be..fc2c6ef 100644
--- a/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/util/ProfilingApplication.java
+++ b/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/util/ProfilingApplication.java
@@ -31,6 +31,8 @@ import java.util.Map;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.CountDownLatch;
 import java.util.concurrent.CyclicBarrier;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.Executors;
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.TimeoutException;
 import java.util.concurrent.atomic.AtomicBoolean;
@@ -48,6 +50,8 @@ public class ProfilingApplication {
     private final int clients;
     private final String executionName;
 
+    private static final ExecutorService executor = Executors.newFixedThreadPool(8);
+
     public ProfilingApplication(final String executionName, final Cluster cluster, final int clients, final int requests) {
         this.executionName = executionName;
         this.cluster = cluster;
@@ -83,7 +87,7 @@ public class ProfilingApplication {
                         } finally {
                             latch.countDown();
                         }
-                    })
+                    }, executor)
                 );
 
                 // finish once all requests are accounted for


[2/3] incubator-tinkerpop git commit: Make sure that the cluster executor handles all async ops.

Posted by sp...@apache.org.
Make sure that the cluster executor handles all async ops.

Should be resorting to fork/join pool anywhere.


Project: http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/commit/186494d4
Tree: http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/tree/186494d4
Diff: http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/diff/186494d4

Branch: refs/heads/master
Commit: 186494d41e8153dbe332f6cbfc8ea7796ad839c6
Parents: aa398ee
Author: Stephen Mallette <sp...@genoprime.com>
Authored: Fri May 8 14:13:14 2015 -0400
Committer: Stephen Mallette <sp...@genoprime.com>
Committed: Fri May 8 14:13:14 2015 -0400

----------------------------------------------------------------------
 .../src/main/java/org/apache/tinkerpop/gremlin/driver/Cluster.java | 2 +-
 .../main/java/org/apache/tinkerpop/gremlin/driver/Connection.java  | 2 +-
 .../java/org/apache/tinkerpop/gremlin/driver/ConnectionPool.java   | 2 +-
 3 files changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/186494d4/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/Cluster.java
----------------------------------------------------------------------
diff --git a/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/Cluster.java b/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/Cluster.java
index c42014a..0e5617e 100644
--- a/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/Cluster.java
+++ b/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/Cluster.java
@@ -466,7 +466,7 @@ public class Cluster {
             return CompletableFuture.supplyAsync(() -> {
                 this.factory.shutdown();
                 return null;
-            });
+            }, executor());
         }
 
         @Override

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/186494d4/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/Connection.java
----------------------------------------------------------------------
diff --git a/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/Connection.java b/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/Connection.java
index 6c4b4a4..00e87c3 100644
--- a/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/Connection.java
+++ b/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/Connection.java
@@ -174,7 +174,7 @@ class Connection {
                             thisConnection.returnToPool();
                             if (isClosed() && pending.isEmpty())
                                 shutdown(closeFuture.get());
-                        });
+                        }, cluster.executor());
                         final ResultQueue handler = new ResultQueue(resultLinkedBlockingQueue, readCompleted);
                         pending.put(requestMessage.getRequestId(), handler);
                         final ResultSet resultSet = new ResultSet(handler, cluster.executor(), channel,

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/186494d4/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/ConnectionPool.java
----------------------------------------------------------------------
diff --git a/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/ConnectionPool.java b/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/ConnectionPool.java
index 839978f..9ea3db6 100644
--- a/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/ConnectionPool.java
+++ b/gremlin-driver/src/main/java/org/apache/tinkerpop/gremlin/driver/ConnectionPool.java
@@ -226,7 +226,7 @@ class ConnectionPool {
         final List<CompletableFuture<Void>> futures = new ArrayList<>(connections.size());
         for (Connection connection : connections) {
             final CompletableFuture<Void> future = connection.closeAsync();
-            future.thenRunAsync(open::decrementAndGet);
+            future.thenRunAsync(open::decrementAndGet, cluster.executor());
             futures.add(future);
         }
         return futures.toArray(new CompletableFuture[futures.size()]);


[3/3] incubator-tinkerpop git commit: Merge remote-tracking branch 'origin/master'

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


Project: http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/commit/8f798f5c
Tree: http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/tree/8f798f5c
Diff: http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/diff/8f798f5c

Branch: refs/heads/master
Commit: 8f798f5cdae22da52befc722602facf95d673e8d
Parents: 186494d 48c15ee
Author: Stephen Mallette <sp...@genoprime.com>
Authored: Fri May 8 14:14:06 2015 -0400
Committer: Stephen Mallette <sp...@genoprime.com>
Committed: Fri May 8 14:14:06 2015 -0400

----------------------------------------------------------------------
 CHANGELOG.asciidoc                              |  1 +
 .../gremlin/process/computer/MapReduce.java     |  9 ++++---
 .../gremlin/process/computer/VertexProgram.java | 15 ++++++------
 .../peerpressure/ClusterCountMapReduce.java     |  3 ++-
 .../ClusterPopulationMapReduce.java             |  3 ++-
 .../peerpressure/PeerPressureVertexProgram.java |  3 ++-
 .../ranking/pagerank/PageRankMapReduce.java     |  3 ++-
 .../ranking/pagerank/PageRankVertexProgram.java |  3 ++-
 .../traversal/TraversalVertexProgram.java       | 12 ++++++----
 .../traversal/step/map/ComputerResultStep.java  |  2 +-
 .../mapreduce/TraverserMapReduce.java           |  5 ++--
 .../util/AbstractVertexProgramBuilder.java      |  5 ++--
 .../process/traversal/step/map/GroupStep.java   | 25 +++++++++-----------
 .../step/sideEffect/AggregateStep.java          |  5 ++--
 .../sideEffect/GroupCountSideEffectStep.java    |  5 ++--
 .../step/sideEffect/GroupSideEffectStep.java    |  7 +++---
 .../traversal/step/sideEffect/StoreStep.java    |  5 ++--
 .../step/sideEffect/TreeSideEffectStep.java     |  3 ++-
 .../ranking/PageRankVertexProgramTest.java      |  2 +-
 .../groovy/plugin/HadoopRemoteAcceptor.java     |  2 +-
 .../hadoop/process/computer/HadoopCombine.java  |  5 +++-
 .../hadoop/process/computer/HadoopMap.java      |  5 +++-
 .../hadoop/process/computer/HadoopReduce.java   |  6 +++--
 .../computer/giraph/GiraphGraphComputer.java    |  2 +-
 .../process/computer/giraph/GiraphMemory.java   |  6 ++++-
 .../computer/giraph/GiraphMessageCombiner.java  |  5 +++-
 .../computer/giraph/GiraphWorkerContext.java    |  5 +++-
 .../process/computer/spark/SparkExecutor.java   |  9 +++----
 .../computer/spark/SparkGraphComputer.java      |  2 +-
 .../process/computer/util/MemoryMapReduce.java  |  3 ++-
 .../structure/io/ObjectWritableComparator.java  |  7 ++++--
 31 files changed, 105 insertions(+), 68 deletions(-)
----------------------------------------------------------------------