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 2016/08/08 10:49:44 UTC

[1/5] tinkerpop git commit: added missing feature requirement [Forced Update!]

Repository: tinkerpop
Updated Branches:
  refs/heads/TINKERPOP-1350 57ef449de -> 58d8bade7 (forced update)


added missing feature requirement


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

Branch: refs/heads/TINKERPOP-1350
Commit: 1a4a321406b373167b38d68c67dc52ddf57fad87
Parents: 8ed3c95
Author: sbarzilay <se...@github.com>
Authored: Wed Aug 3 17:08:45 2016 +0300
Committer: sbarzilay <se...@github.com>
Committed: Wed Aug 3 17:08:45 2016 +0300

----------------------------------------------------------------------
 .../tinkerpop/gremlin/process/traversal/step/map/AddVertexTest.java | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/1a4a3214/gremlin-test/src/main/java/org/apache/tinkerpop/gremlin/process/traversal/step/map/AddVertexTest.java
----------------------------------------------------------------------
diff --git a/gremlin-test/src/main/java/org/apache/tinkerpop/gremlin/process/traversal/step/map/AddVertexTest.java b/gremlin-test/src/main/java/org/apache/tinkerpop/gremlin/process/traversal/step/map/AddVertexTest.java
index 5a616f8..d166dcc 100644
--- a/gremlin-test/src/main/java/org/apache/tinkerpop/gremlin/process/traversal/step/map/AddVertexTest.java
+++ b/gremlin-test/src/main/java/org/apache/tinkerpop/gremlin/process/traversal/step/map/AddVertexTest.java
@@ -155,6 +155,7 @@ public abstract class AddVertexTest extends AbstractGremlinTest {
     @FeatureRequirement(featureClass = Graph.Features.VertexFeatures.class, feature = Graph.Features.VertexFeatures.FEATURE_ADD_VERTICES)
     @FeatureRequirement(featureClass = Graph.Features.VertexFeatures.class, feature = Graph.Features.VertexFeatures.FEATURE_ADD_PROPERTY)
     @FeatureRequirement(featureClass = Graph.Features.VertexFeatures.class, feature = Graph.Features.VertexFeatures.FEATURE_MULTI_PROPERTIES)
+    @FeatureRequirement(featureClass = Graph.Features.VertexFeatures.class, feature = Graph.Features.VertexFeatures.FEATURE_META_PROPERTIES)
     public void g_addVXpersonX_propertyXsingle_name_stephenX_propertyXsingle_name_stephenm_since_2010X() {
         final Traversal<Vertex, Vertex> traversal = get_g_addVXpersonX_propertyXsingle_name_stephenX_propertyXsingle_name_stephenm_since_2010X();
         printTraversalForm(traversal);


[4/5] tinkerpop git commit: Doc generation needed an update now that artifacts were renamed on TINKERPOP-1376

Posted by sp...@apache.org.
Doc generation needed an update now that artifacts were renamed on TINKERPOP-1376


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

Branch: refs/heads/TINKERPOP-1350
Commit: 87960e7cebefdcc99fd084f629c0267945535afe
Parents: 8888a8c
Author: Stephen Mallette <sp...@genoprime.com>
Authored: Wed Aug 3 17:04:01 2016 -0400
Committer: Stephen Mallette <sp...@genoprime.com>
Committed: Wed Aug 3 17:04:01 2016 -0400

----------------------------------------------------------------------
 docs/preprocessor/preprocess.sh | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/87960e7c/docs/preprocessor/preprocess.sh
----------------------------------------------------------------------
diff --git a/docs/preprocessor/preprocess.sh b/docs/preprocessor/preprocess.sh
index d225c48..0e9fa73 100755
--- a/docs/preprocessor/preprocess.sh
+++ b/docs/preprocessor/preprocess.sh
@@ -69,7 +69,7 @@ mkdir -p target/postprocess-asciidoc/tmp
 cp -R docs/{static,stylesheets} target/postprocess-asciidoc/
 
 TP_HOME=`pwd`
-CONSOLE_HOME=`directory "${TP_HOME}/gremlin-console/target/apache-gremlin-console-*-standalone"`
+CONSOLE_HOME=`directory "${TP_HOME}/gremlin-console/target/apache-tinkerpop-gremlin-console-*-standalone"`
 PLUGIN_DIR="${CONSOLE_HOME}/ext"
 TP_VERSION=$(cat pom.xml | grep -A1 '<artifactId>tinkerpop</artifactId>' | grep -o 'version>[^<]*' | grep -o '>.*' | cut -d '>' -f2 | head -n1)
 TMP_DIR="/tmp/tp-docs-preprocessor"
@@ -79,7 +79,7 @@ mkdir -p "${TMP_DIR}"
 HISTORY_FILE=".gremlin_groovy_history"
 [ -f ~/${HISTORY_FILE} ] && cp ~/${HISTORY_FILE} ${TMP_DIR}
 
-pushd gremlin-server/target/apache-gremlin-server-*-standalone > /dev/null
+pushd gremlin-server/target/apache-tinkerpop-gremlin-server-*-standalone > /dev/null
 bin/gremlin-server.sh conf/gremlin-server-modern.yaml > /dev/null 2> /dev/null &
 GREMLIN_SERVER_PID=$!
 popd > /dev/null


[5/5] tinkerpop git commit: TINKERPOP-1350 was never quite fixed in 3.1.3.

Posted by sp...@apache.org.
TINKERPOP-1350 was never quite fixed in 3.1.3.

Changed response encoding to not use the session executor when the session has an error condition it is trying to serialize. This should be fine as there is no need to serialized an error condition as part of a transaction and thus no need to have the session thread to do it. That in turn frees up the worker executor to serialize and cancel long run jobs in the session. Removed recommendations for submitting parallel requests on a session from docs.


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

Branch: refs/heads/TINKERPOP-1350
Commit: 58d8bade7425c7a7865382990eaaed2b7d90659c
Parents: 87960e7
Author: Stephen Mallette <sp...@genoprime.com>
Authored: Tue Aug 2 15:59:19 2016 -0400
Committer: Stephen Mallette <sp...@genoprime.com>
Committed: Mon Aug 8 06:49:17 2016 -0400

----------------------------------------------------------------------
 CHANGELOG.asciidoc                              |  1 +
 .../src/reference/gremlin-applications.asciidoc |  6 +-
 .../upgrade/release-3.1.x-incubating.asciidoc   | 22 +++++-
 .../gremlin/groovy/engine/GremlinExecutor.java  |  2 -
 .../handler/GremlinResponseFrameEncoder.java    | 13 +++-
 .../server/GremlinDriverIntegrateTest.java      | 81 +++++++++++---------
 6 files changed, 75 insertions(+), 50 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/58d8bade/CHANGELOG.asciidoc
----------------------------------------------------------------------
diff --git a/CHANGELOG.asciidoc b/CHANGELOG.asciidoc
index 306185c..975f6cf 100644
--- a/CHANGELOG.asciidoc
+++ b/CHANGELOG.asciidoc
@@ -28,6 +28,7 @@ TinkerPop 3.1.4 (NOT OFFICIALLY RELEASED YET)
 
 * Fixed a potential leak of a `ReferenceCounted` resource in Gremlin Server.
 * Renamed distributions to make the prefix "apache-tinkerpop-" as opposed to just "apache-".
+* Fixed a problem (previously thought resolved on 3.1.3) causing Gremlin Server to lock up when parallel requests were submitted on the same session if those parallel requests included a script that blocked indefinitely.
 
 [[release-3-1-3]]
 TinkerPop 3.1.3 (Release Date: July 18, 2016)

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/58d8bade/docs/src/reference/gremlin-applications.asciidoc
----------------------------------------------------------------------
diff --git a/docs/src/reference/gremlin-applications.asciidoc b/docs/src/reference/gremlin-applications.asciidoc
index 9f5121f..cedd98f 100644
--- a/docs/src/reference/gremlin-applications.asciidoc
+++ b/docs/src/reference/gremlin-applications.asciidoc
@@ -1261,7 +1261,7 @@ Tuning
 image:gremlin-handdrawn.png[width=120,float=right] Tuning Gremlin Server for a particular environment may require some simple trial-and-error, but the following represent some basic guidelines that might be useful:
 
 * Gremlin Server defaults to a very modest maximum heap size.  Consider increasing this value for non-trivial uses.  Maximum heap size (`-Xmx`) is defined with the `JAVA_OPTIONS` setting in `gremlin-server.sh`.
-* When configuring the size of `threadPoolWorker` start with the default of `1` and increment by one as needed to a maximum of `2*number of cores`. Note that if using sessions that will accept parallel requests on the same session, then this value should be no less than `2`.
+* When configuring the size of `threadPoolWorker` start with the default of `1` and increment by one as needed to a maximum of `2*number of cores`.
 * The "right" size of the `gremlinPool` setting is somewhat dependent on the type of scripts that will be processed
 by Gremlin Server.  As requests arrive to Gremlin Server they are decoded and queued to be processed by threads in
 this pool.  When this pool is exhausted of threads, Gremlin Server will continue to accept incoming requests, but
@@ -1407,10 +1407,6 @@ request.
 A session is a "heavier" approach to the simple "request/response" approach of sessionless requests, but is sometimes
 necessary for a given use case.
 
-IMPORTANT: If submitting requests in parallel to a single session in Gremlin Server, then the `threadPoolWorker`
-setting can be no less than `2` or else the session may be prone to becoming locked if scripts sent on that session
-tend to block for extended periods of time.
-
 [[considering-transactions]]
 Considering Transactions
 ^^^^^^^^^^^^^^^^^^^^^^^^

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/58d8bade/docs/src/upgrade/release-3.1.x-incubating.asciidoc
----------------------------------------------------------------------
diff --git a/docs/src/upgrade/release-3.1.x-incubating.asciidoc b/docs/src/upgrade/release-3.1.x-incubating.asciidoc
index 11cdb32..b4a1657 100644
--- a/docs/src/upgrade/release-3.1.x-incubating.asciidoc
+++ b/docs/src/upgrade/release-3.1.x-incubating.asciidoc
@@ -22,6 +22,26 @@ image::https://raw.githubusercontent.com/apache/tinkerpop/master/docs/static/ima
 
 *A 187 On The Undercover Gremlinz*
 
+TinkerPop 3.1.4
+---------------
+
+*Release Date: NOT OFFICIALLY RELEASED YET*
+
+Please see the link:https://github.com/apache/tinkerpop/blob/3.1.4/CHANGELOG.asciidoc#tinkerpop-314-release-date-XXXXXXX-XX-2016[changelog] for a complete list of all the modifications that are part of this release.
+
+Upgrading for Users
+~~~~~~~~~~~~~~~~~~~
+
+Gremlin Server Workers
+^^^^^^^^^^^^^^^^^^^^^^
+
+In release 3.1.3, a link:http://tinkerpop.apache.org/docs/3.1.3/upgrade/#_tinkerpop_3_1_3[recommendation] was made to
+ensure that the `threadPoolWorker` setting for Gremlin Server was no less than `2` in cases where Gremlin Server was
+being used with sessions that accept parallel requests. In 3.1.4, that is no longer the case and a size of `1` remains
+acceptable even in that specific case.
+
+See: link:https://issues.apache.org/jira/browse/TINKERPOP-1350[TINKERPOP-1350]
+
 TinkerPop 3.1.3
 ---------------
 
@@ -74,8 +94,6 @@ those that block for an extended period of time) may cause Gremlin Server to loc
 
 See: link:https://issues.apache.org/jira/browse/TINKERPOP-1350[TINKERPOP-1350]
 
-
-
 Upgrading for Providers
 ~~~~~~~~~~~~~~~~~~~~~~~
 

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/58d8bade/gremlin-groovy/src/main/java/org/apache/tinkerpop/gremlin/groovy/engine/GremlinExecutor.java
----------------------------------------------------------------------
diff --git a/gremlin-groovy/src/main/java/org/apache/tinkerpop/gremlin/groovy/engine/GremlinExecutor.java b/gremlin-groovy/src/main/java/org/apache/tinkerpop/gremlin/groovy/engine/GremlinExecutor.java
index d70ff3d..da12e1e 100644
--- a/gremlin-groovy/src/main/java/org/apache/tinkerpop/gremlin/groovy/engine/GremlinExecutor.java
+++ b/gremlin-groovy/src/main/java/org/apache/tinkerpop/gremlin/groovy/engine/GremlinExecutor.java
@@ -232,8 +232,6 @@ public class GremlinExecutor implements AutoCloseable {
         return eval(script, language, boundVars, lifeCycle);
     }
 
-    private static final AtomicInteger ugh = new AtomicInteger(0);
-
     /**
      * Evaluate a script and allow for the submission of alteration to the entire evaluation execution lifecycle.
      *

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/58d8bade/gremlin-server/src/main/java/org/apache/tinkerpop/gremlin/server/handler/GremlinResponseFrameEncoder.java
----------------------------------------------------------------------
diff --git a/gremlin-server/src/main/java/org/apache/tinkerpop/gremlin/server/handler/GremlinResponseFrameEncoder.java b/gremlin-server/src/main/java/org/apache/tinkerpop/gremlin/server/handler/GremlinResponseFrameEncoder.java
index 50c177b..d0f9d76 100644
--- a/gremlin-server/src/main/java/org/apache/tinkerpop/gremlin/server/handler/GremlinResponseFrameEncoder.java
+++ b/gremlin-server/src/main/java/org/apache/tinkerpop/gremlin/server/handler/GremlinResponseFrameEncoder.java
@@ -61,8 +61,12 @@ public class GremlinResponseFrameEncoder extends MessageToMessageEncoder<Respons
             if (useBinary) {
                 final Frame serialized;
 
-                // if the request came in on a session then the serialization must occur in that same thread.
-                if (null == session)
+                // if the request came in on a session then the serialization must occur in that same thread, except
+                // in the case of an error where we can free the session executor from having to do that job. the
+                // problem here is that if the session executor is used in the case of an error and the executor is
+                // blocked by parallel requests then there is no thread available to serialize the result and send
+                // back the response as the workers get all tied up behind the session executor.
+                if (null == session || !o.getStatus().getCode().isSuccess())
                     serialized = new Frame(serializer.serializeResponseAsBinary(o, ctx.alloc()));
                 else
                     serialized = new Frame(session.getExecutor().submit(() -> serializer.serializeResponseAsBinary(o, ctx.alloc())).get());
@@ -75,8 +79,9 @@ public class GremlinResponseFrameEncoder extends MessageToMessageEncoder<Respons
 
                 final Frame serialized;
 
-                // if the request came in on a session then the serialization must occur in that same thread.
-                if (null == session)
+                // if the request came in on a session then the serialization must occur that same thread except
+                // in the case of errors for reasons described above.
+                if (null == session || !o.getStatus().getCode().isSuccess())
                     serialized = new Frame(textSerializer.serializeResponseAsString(o));
                 else
                     serialized = new Frame(session.getExecutor().submit(() -> textSerializer.serializeResponseAsString(o)).get());

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/58d8bade/gremlin-server/src/test/java/org/apache/tinkerpop/gremlin/server/GremlinDriverIntegrateTest.java
----------------------------------------------------------------------
diff --git a/gremlin-server/src/test/java/org/apache/tinkerpop/gremlin/server/GremlinDriverIntegrateTest.java b/gremlin-server/src/test/java/org/apache/tinkerpop/gremlin/server/GremlinDriverIntegrateTest.java
index 7f74e03..7314243 100644
--- a/gremlin-server/src/test/java/org/apache/tinkerpop/gremlin/server/GremlinDriverIntegrateTest.java
+++ b/gremlin-server/src/test/java/org/apache/tinkerpop/gremlin/server/GremlinDriverIntegrateTest.java
@@ -125,8 +125,8 @@ public class GremlinDriverIntegrateTest extends AbstractGremlinServerIntegration
                 settings.graphs.put("graph", "conf/neo4j-empty.properties");
                 break;
             case "shouldProcessSessionRequestsInOrderAfterTimeout":
-                settings.scriptEvaluationTimeout = 1000;
-                settings.threadPoolWorker = 2;
+                settings.scriptEvaluationTimeout = 250;
+                settings.threadPoolWorker = 1;
                 break;
         }
 
@@ -1210,48 +1210,55 @@ public class GremlinDriverIntegrateTest extends AbstractGremlinServerIntegration
         final Cluster cluster = Cluster.open();
         final Client client = cluster.connect(name.getMethodName());
 
-        final ResultSet first = client.submit(
-                "Object mon1 = 'mon1';\n" +
-                        "synchronized (mon1) {\n" +
-                        "    mon1.wait();\n" +
-                        "} ");
-
-        final ResultSet second = client.submit(
-                "Object mon2 = 'mon2';\n" +
-                        "synchronized (mon2) {\n" +
-                        "    mon2.wait();\n" +
-                        "}");
-
-        final CompletableFuture<List<Result>> futureFirst = first.all();
-        final CompletableFuture<List<Result>> futureSecond = second.all();
-
-        final AtomicBoolean hit = new AtomicBoolean(false);
-        while (!futureFirst.isDone()) {
-            // futureSecond can't finish before futureFirst - racy business here?
-            assertThat(futureSecond.isDone(), is(false));
-            hit.set(true);
+        for(int index = 0; index < 50; index++)
+        {
+            final CompletableFuture<ResultSet> first = client.submitAsync(
+                    "Object mon1 = 'mon1';\n" +
+                            "synchronized (mon1) {\n" +
+                            "    mon1.wait();\n" +
+                            "} ");
+
+            final CompletableFuture<ResultSet> second = client.submitAsync(
+                    "Object mon2 = 'mon2';\n" +
+                            "synchronized (mon2) {\n" +
+                            "    mon2.wait();\n" +
+                            "}");
+
+            final CompletableFuture<ResultSet> third = client.submitAsync(
+                    "Object mon3 = 'mon3';\n" +
+                            "synchronized (mon3) {\n" +
+                            "    mon3.wait();\n" +
+                            "}");
+
+            final CompletableFuture<ResultSet> fourth = client.submitAsync(
+                    "Object mon4 = 'mon4';\n" +
+                            "synchronized (mon4) {\n" +
+                            "    mon4.wait();\n" +
+                            "}");
+
+            final CompletableFuture<List<Result>> futureFirst = first.get().all();
+            final CompletableFuture<List<Result>> futureSecond = second.get().all();
+            final CompletableFuture<List<Result>> futureThird = third.get().all();
+            final CompletableFuture<List<Result>> futureFourth = fourth.get().all();
+
+            assertFutureTimeout(futureFirst);
+            assertFutureTimeout(futureSecond);
+            assertFutureTimeout(futureThird);
+            assertFutureTimeout(futureFourth);
         }
+    }
 
-        // should have entered the loop at least once and thus proven that futureSecond didn't return ahead of
-        // futureFirst
-        assertThat(hit.get(), is(true));
-
-        try {
+    private void assertFutureTimeout(final CompletableFuture<List<Result>> futureFirst) {
+        try
+        {
             futureFirst.get();
             fail("Should have timed out");
-        } catch (Exception ex) {
-            final Throwable root = ExceptionUtils.getRootCause(ex);
-            assertThat(root, instanceOf(ResponseException.class));
-            assertThat(root.getMessage(), startsWith("Script evaluation exceeded the configured 'scriptEvaluationTimeout' threshold of 1000 ms for request"));
         }
-
-        try {
-            futureSecond.get();
-            fail("Should have timed out");
-        } catch (Exception ex) {
+        catch (Exception ex)
+        {
             final Throwable root = ExceptionUtils.getRootCause(ex);
             assertThat(root, instanceOf(ResponseException.class));
-            assertThat(root.getMessage(), startsWith("Script evaluation exceeded the configured 'scriptEvaluationTimeout' threshold of 1000 ms for request"));
+            assertThat(root.getMessage(), startsWith("Script evaluation exceeded the configured 'scriptEvaluationTimeout' threshold of 250 ms for request"));
         }
     }
 }


[2/5] tinkerpop git commit: Renamed zip distributions to prefix with "apache-tinkerpop-"

Posted by sp...@apache.org.
Renamed zip distributions to prefix with "apache-tinkerpop-"

It was formerly "apache-". Tested release docs as best I could given that this wasn't an actual release. Couldn't test validate-distribution.sh but that usually requires some tweaks here and there anyway on release day. TINKERPOP-1376 CTR


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

Branch: refs/heads/TINKERPOP-1350
Commit: 6bf0d3b5df3f5bdf7dd5bbce9d2bc8daeffda5a2
Parents: 1a4a321
Author: Stephen Mallette <sp...@genoprime.com>
Authored: Wed Aug 3 11:53:48 2016 -0400
Committer: Stephen Mallette <sp...@genoprime.com>
Committed: Wed Aug 3 11:53:48 2016 -0400

----------------------------------------------------------------------
 CHANGELOG.asciidoc                            |  1 +
 bin/validate-distribution.sh                  |  4 ++--
 docs/src/dev/developer/release.asciidoc       |  2 +-
 gremlin-console/pom.xml                       |  2 +-
 gremlin-console/src/assembly/distribution.xml | 16 ++++++++--------
 gremlin-server/pom.xml                        |  2 +-
 gremlin-server/src/assembly/distribution.xml  | 12 ++++++------
 7 files changed, 20 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/6bf0d3b5/CHANGELOG.asciidoc
----------------------------------------------------------------------
diff --git a/CHANGELOG.asciidoc b/CHANGELOG.asciidoc
index 8735a87..306185c 100644
--- a/CHANGELOG.asciidoc
+++ b/CHANGELOG.asciidoc
@@ -27,6 +27,7 @@ TinkerPop 3.1.4 (NOT OFFICIALLY RELEASED YET)
 ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
 
 * Fixed a potential leak of a `ReferenceCounted` resource in Gremlin Server.
+* Renamed distributions to make the prefix "apache-tinkerpop-" as opposed to just "apache-".
 
 [[release-3-1-3]]
 TinkerPop 3.1.3 (Release Date: July 18, 2016)

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/6bf0d3b5/bin/validate-distribution.sh
----------------------------------------------------------------------
diff --git a/bin/validate-distribution.sh b/bin/validate-distribution.sh
index 30a0345..dcaf8fb 100755
--- a/bin/validate-distribution.sh
+++ b/bin/validate-distribution.sh
@@ -39,8 +39,8 @@ fi
 
 if [ -z ${URL} ]; then
 
-  CONSOLE_URL="https://dist.apache.org/repos/dist/dev/tinkerpop/${VERSION}/apache-gremlin-console-${VERSION}-bin.zip"
-  SERVER_URL="https://dist.apache.org/repos/dist/dev/tinkerpop/${VERSION}/apache-gremlin-server-${VERSION}-bin.zip"
+  CONSOLE_URL="https://dist.apache.org/repos/dist/dev/tinkerpop/${VERSION}/apache-tinkerpop-gremlin-console-${VERSION}-bin.zip"
+  SERVER_URL="https://dist.apache.org/repos/dist/dev/tinkerpop/${VERSION}/apache-tinkerpop-gremlin-server-${VERSION}-bin.zip"
   SOURCE_URL="https://dist.apache.org/repos/dist/dev/tinkerpop/${VERSION}/apache-tinkerpop-${VERSION}-src.zip"
 
   echo -e "\nValidating binary distributions\n"

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/6bf0d3b5/docs/src/dev/developer/release.asciidoc
----------------------------------------------------------------------
diff --git a/docs/src/dev/developer/release.asciidoc b/docs/src/dev/developer/release.asciidoc
index b1586f8..0c21bb6 100644
--- a/docs/src/dev/developer/release.asciidoc
+++ b/docs/src/dev/developer/release.asciidoc
@@ -121,7 +121,7 @@ handled document generation and this step now merely needs to upload what was ge
 .. `cp ~/.m2/repository/org/apache/tinkerpop/gremlin-server/xx.yy.zz/gremlin-server-xx.yy.zz-distribution.zip* dev/xx.yy.zz`
 .. `cp ~/.m2/repository/org/apache/tinkerpop/tinkerpop/xx.yy.zz/tinkerpop-xx.yy.zz-source-release.zip* dev/xx.yy.zz`
 .. `cd dev/xx.yy.zz`
-.. pass:[<code>ls * | xargs -n1 -I {} echo "mv apache-{} {}" | sed -e 's/distribution/bin/' -e 's/source-release/src/' -e s'/^\(.*\) \(.*\) \(.*\)$/\1 \3 \2/' | /bin/bash</code>]
+.. pass:[<code>ls * | xargs -n1 -I {} echo "mv apache-tinkerpop-{} {}" | sed -e 's/distribution/bin/' -e 's/source-release/src/' -e s'/^\(.*\) \(.*\) \(.*\)$/\1 \3 \2/' | /bin/bash</code>]
 .. `cd ..; svn add xx.yy.zz/; svn ci -m "TinkerPop xx.yy.zz release"`
 . Execute `bin/validate-distribution.sh` and any other relevant testing.
 . `git tag -a -m "TinkerPop xx.yy.zz release" xx.yy.zz` and `git push --tags`

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/6bf0d3b5/gremlin-console/pom.xml
----------------------------------------------------------------------
diff --git a/gremlin-console/pom.xml b/gremlin-console/pom.xml
index 54e66f8..817f352 100644
--- a/gremlin-console/pom.xml
+++ b/gremlin-console/pom.xml
@@ -176,7 +176,7 @@ limitations under the License.
                         <descriptor>src/assembly/standalone.xml</descriptor>
                         <descriptor>src/assembly/distribution.xml</descriptor>
                     </descriptors>
-                    <finalName>apache-${project.artifactId}-${project.version}</finalName>
+                    <finalName>apache-tinkerpop-${project.artifactId}-${project.version}</finalName>
                     <outputDirectory>target</outputDirectory>
                     <workDirectory>target/assembly/work</workDirectory>
                     <tarLongFileMode>warn</tarLongFileMode>

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/6bf0d3b5/gremlin-console/src/assembly/distribution.xml
----------------------------------------------------------------------
diff --git a/gremlin-console/src/assembly/distribution.xml b/gremlin-console/src/assembly/distribution.xml
index 69ecc3b..9f13b41 100644
--- a/gremlin-console/src/assembly/distribution.xml
+++ b/gremlin-console/src/assembly/distribution.xml
@@ -22,7 +22,7 @@ limitations under the License.
     <fileSets>
         <fileSet>
             <fileMode>0775</fileMode>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/bin</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/bin</directory>
             <outputDirectory>bin</outputDirectory>
             <includes>
                 <include>*.sh</include>
@@ -31,7 +31,7 @@ limitations under the License.
         </fileSet>
         <fileSet>
             <fileMode>0775</fileMode>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/bin/hadoop</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/bin/hadoop</directory>
             <outputDirectory>bin/hadoop</outputDirectory>
             <includes>
                 <include>*.sh</include>
@@ -43,27 +43,27 @@ limitations under the License.
             <outputDirectory>licenses</outputDirectory>
         </fileSet>
         <fileSet>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/conf</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/conf</directory>
             <outputDirectory>conf</outputDirectory>
         </fileSet>
         <fileSet>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/data</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/data</directory>
             <outputDirectory>data</outputDirectory>
         </fileSet>
         <fileSet>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/docs</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/docs</directory>
             <outputDirectory>docs</outputDirectory>
         </fileSet>
         <fileSet>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/javadocs</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/javadocs</directory>
             <outputDirectory>javadocs</outputDirectory>
         </fileSet>
         <fileSet>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/ext</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/ext</directory>
             <outputDirectory>ext</outputDirectory>
         </fileSet>
         <fileSet>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/lib</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/lib</directory>
             <outputDirectory>lib</outputDirectory>
         </fileSet>
     </fileSets>

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/6bf0d3b5/gremlin-server/pom.xml
----------------------------------------------------------------------
diff --git a/gremlin-server/pom.xml b/gremlin-server/pom.xml
index 0f54cca..bed34eb 100644
--- a/gremlin-server/pom.xml
+++ b/gremlin-server/pom.xml
@@ -124,7 +124,7 @@ limitations under the License.
                         <descriptor>src/assembly/standalone.xml</descriptor>
                         <descriptor>src/assembly/distribution.xml</descriptor>
                     </descriptors>
-                    <finalName>apache-${project.artifactId}-${project.version}</finalName>
+                    <finalName>apache-tinkerpop-${project.artifactId}-${project.version}</finalName>
                     <outputDirectory>target</outputDirectory>
                     <workDirectory>target/assembly/work</workDirectory>
                     <tarLongFileMode>warn</tarLongFileMode>

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/6bf0d3b5/gremlin-server/src/assembly/distribution.xml
----------------------------------------------------------------------
diff --git a/gremlin-server/src/assembly/distribution.xml b/gremlin-server/src/assembly/distribution.xml
index d336fe8..e132a81 100644
--- a/gremlin-server/src/assembly/distribution.xml
+++ b/gremlin-server/src/assembly/distribution.xml
@@ -22,7 +22,7 @@ limitations under the License.
     <fileSets>
         <fileSet>
             <fileMode>0775</fileMode>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/bin</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/bin</directory>
             <outputDirectory>bin</outputDirectory>
             <includes>
                 <include>*.sh</include>
@@ -37,26 +37,26 @@ limitations under the License.
             <outputDirectory>licenses</outputDirectory>
         </fileSet>
         <fileSet>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/data</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/data</directory>
             <outputDirectory>data</outputDirectory>
         </fileSet>
         <fileSet>
             <directory>scripts</directory>
         </fileSet>
         <fileSet>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/ext</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/ext</directory>
             <outputDirectory>ext</outputDirectory>
         </fileSet>
         <fileSet>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/docs</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/docs</directory>
             <outputDirectory>docs</outputDirectory>
         </fileSet>
         <fileSet>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/javadocs</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/javadocs</directory>
             <outputDirectory>javadocs</outputDirectory>
         </fileSet>
         <fileSet>
-            <directory>target/apache-${project.artifactId}-${project.version}-standalone/lib</directory>
+            <directory>target/apache-tinkerpop-${project.artifactId}-${project.version}-standalone/lib</directory>
             <outputDirectory>lib</outputDirectory>
         </fileSet>
     </fileSets>


[3/5] tinkerpop git commit: Modified the message when closing a remote

Posted by sp...@apache.org.
Modified the message when closing a remote

The closing of a remote in yielded a compound message that mentioned the switch to local evaluation first before the close message. That message about the switch didn't seem too useful. Now the switch just happens quietly and user is just informed of the remote closing. TINKERPOP-1377 CTR


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

Branch: refs/heads/TINKERPOP-1350
Commit: 8888a8c3c40e086a324804be088b5ae70eeb0941
Parents: 6bf0d3b
Author: Stephen Mallette <sp...@genoprime.com>
Authored: Wed Aug 3 13:06:03 2016 -0400
Committer: Stephen Mallette <sp...@genoprime.com>
Committed: Wed Aug 3 13:06:03 2016 -0400

----------------------------------------------------------------------
 .../tinkerpop/gremlin/console/commands/RemoteCommand.groovy      | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/8888a8c3/gremlin-console/src/main/groovy/org/apache/tinkerpop/gremlin/console/commands/RemoteCommand.groovy
----------------------------------------------------------------------
diff --git a/gremlin-console/src/main/groovy/org/apache/tinkerpop/gremlin/console/commands/RemoteCommand.groovy b/gremlin-console/src/main/groovy/org/apache/tinkerpop/gremlin/console/commands/RemoteCommand.groovy
index 79e4099..dccebd3 100644
--- a/gremlin-console/src/main/groovy/org/apache/tinkerpop/gremlin/console/commands/RemoteCommand.groovy
+++ b/gremlin-console/src/main/groovy/org/apache/tinkerpop/gremlin/console/commands/RemoteCommand.groovy
@@ -113,11 +113,11 @@ class RemoteCommand extends ComplexCommandSupport {
 
         // the console is in remote evaluation mode.  closing at this point will needs to exit that mode and then
         // kill the remote itself
-        def line = !mediator.localEvaluation ? swapEvaluationMode() : ""
+        if (!mediator.localEvaluation) swapEvaluationMode()
 
         def removed = mediator.removeCurrent()
         removed.close()
-        return line.isEmpty() ? "Removed - $removed" : "$line and removed - $removed"
+        return "Removed - $removed"
     }
 
     def Object do_console = {