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/06/01 20:58:40 UTC

[1/2] incubator-tinkerpop git commit: Finalize classes in GraphSON.

Repository: incubator-tinkerpop
Updated Branches:
  refs/heads/master 1dd487c20 -> f3e4d54fa


Finalize classes in GraphSON.


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

Branch: refs/heads/master
Commit: 67ad95ec8d06160bfed00e4b1163edf74cc8d007
Parents: 1dd487c
Author: Stephen Mallette <sp...@genoprime.com>
Authored: Mon Jun 1 14:40:24 2015 -0400
Committer: Stephen Mallette <sp...@genoprime.com>
Committed: Mon Jun 1 14:40:24 2015 -0400

----------------------------------------------------------------------
 .../structure/io/graphson/GraphSONIo.java       |  6 +-
 .../structure/io/graphson/GraphSONModule.java   |  2 +-
 .../structure/io/graphson/GraphSONReader.java   |  9 ++-
 .../io/graphson/GraphSONSerializers.java        | 14 ++--
 .../structure/io/graphson/GraphSONVersion.java  |  2 +-
 .../structure/io/graphson/GraphSONWriter.java   |  2 +-
 .../io/graphson/LegacyGraphSONReader.java       | 73 ++++++++++----------
 7 files changed, 55 insertions(+), 53 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/67ad95ec/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONIo.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONIo.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONIo.java
index 57cfc62..29d14cf 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONIo.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONIo.java
@@ -34,11 +34,11 @@ import java.io.OutputStream;
  *
  * @author Stephen Mallette (http://stephen.genoprime.com)
  */
-public class GraphSONIo implements Io<GraphSONReader.Builder, GraphSONWriter.Builder, GraphSONMapper.Builder> {
+public final class GraphSONIo implements Io<GraphSONReader.Builder, GraphSONWriter.Builder, GraphSONMapper.Builder> {
     private final IoRegistry registry;
     private final Graph graph;
 
-    public GraphSONIo(final IoRegistry registry, final Graph graph) {
+    private GraphSONIo(final IoRegistry registry, final Graph graph) {
         this.registry = registry;
         this.graph = graph;
     }
@@ -91,7 +91,7 @@ public class GraphSONIo implements Io<GraphSONReader.Builder, GraphSONWriter.Bui
         return new Builder();
     }
 
-    public static class Builder implements Io.Builder<GraphSONIo> {
+    public final static class Builder implements Io.Builder<GraphSONIo> {
 
         private IoRegistry registry = null;
         private Graph graph;

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/67ad95ec/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONModule.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONModule.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONModule.java
index 4161faf..b53427b 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONModule.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONModule.java
@@ -51,7 +51,7 @@ abstract class GraphSONModule extends SimpleModule {
         /**
          * Constructs a new object.
          */
-        GraphSONModuleV1d0(final boolean normalize) {
+        protected GraphSONModuleV1d0(final boolean normalize) {
             super("graphson-1.0");
             addSerializer(Edge.class, new GraphSONSerializers.EdgeJacksonSerializer(normalize));
             addSerializer(Vertex.class, new GraphSONSerializers.VertexJacksonSerializer(normalize));

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/67ad95ec/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONReader.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONReader.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONReader.java
index 76594ab..311463f 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONReader.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONReader.java
@@ -63,14 +63,14 @@ import java.util.function.Function;
  *
  * @author Stephen Mallette (http://stephen.genoprime.com)
  */
-public class GraphSONReader implements GraphReader {
+public final class GraphSONReader implements GraphReader {
     private final ObjectMapper mapper;
     private final long batchSize;
 
     final TypeReference<Map<String, Object>> mapTypeReference = new TypeReference<Map<String, Object>>() {
     };
 
-    public GraphSONReader(final GraphSONMapper mapper, final long batchSize) {
+    private GraphSONReader(final GraphSONMapper mapper, final long batchSize) {
         this.mapper = mapper.createMapper();
         this.batchSize = batchSize;
     }
@@ -248,13 +248,12 @@ public class GraphSONReader implements GraphReader {
         return new Builder();
     }
 
-    public static class Builder implements ReaderBuilder<GraphSONReader> {
+    public final static class Builder implements ReaderBuilder<GraphSONReader> {
         private long batchSize = 10000;
 
         private GraphSONMapper mapper = GraphSONMapper.build().create();
 
-        private Builder() {
-        }
+        private Builder() {}
 
         /**
          * Number of mutations to perform before a commit is executed when using

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/67ad95ec/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONSerializers.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONSerializers.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONSerializers.java
index 9d637b2..bd43417 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONSerializers.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONSerializers.java
@@ -56,7 +56,7 @@ final class GraphSONSerializers {
 
     private GraphSONSerializers() {}
 
-    static class VertexPropertyJacksonSerializer extends StdSerializer<VertexProperty> {
+    final static class VertexPropertyJacksonSerializer extends StdSerializer<VertexProperty> {
 
         private final boolean normalize;
 
@@ -78,7 +78,7 @@ final class GraphSONSerializers {
         }
     }
 
-    static class PropertyJacksonSerializer extends StdSerializer<Property> {
+    final static class PropertyJacksonSerializer extends StdSerializer<Property> {
 
         public PropertyJacksonSerializer() {
             super(Property.class);
@@ -105,7 +105,7 @@ final class GraphSONSerializers {
         }
     }
 
-    static class EdgeJacksonSerializer extends StdSerializer<Edge> {
+    final static class EdgeJacksonSerializer extends StdSerializer<Edge> {
 
         private final boolean normalize;
 
@@ -160,7 +160,7 @@ final class GraphSONSerializers {
 
     }
 
-    static class VertexJacksonSerializer extends StdSerializer<Vertex> {
+    final static class VertexJacksonSerializer extends StdSerializer<Vertex> {
 
         private final boolean normalize;
 
@@ -226,7 +226,7 @@ final class GraphSONSerializers {
 
     }
 
-    static class PathJacksonSerializer extends StdSerializer<Path> {
+    final static class PathJacksonSerializer extends StdSerializer<Path> {
 
         public PathJacksonSerializer() {
             super(Path.class);
@@ -257,7 +257,7 @@ final class GraphSONSerializers {
     /**
      * Maps in the JVM can have {@link Object} as a key, but in JSON they must be a {@link String}.
      */
-    static class GraphSONKeySerializer extends StdKeySerializer {
+    final static class GraphSONKeySerializer extends StdKeySerializer {
 
         @Override
         public void serialize(final Object o, final JsonGenerator jsonGenerator, final SerializerProvider serializerProvider) throws IOException {
@@ -278,7 +278,7 @@ final class GraphSONSerializers {
         }
     }
 
-    static class TraversalMetricsJacksonSerializer extends StdSerializer<TraversalMetrics> {
+    final static class TraversalMetricsJacksonSerializer extends StdSerializer<TraversalMetrics> {
         public TraversalMetricsJacksonSerializer() {
             super(TraversalMetrics.class);
         }

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/67ad95ec/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONVersion.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONVersion.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONVersion.java
index fef6df6..628ea22 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONVersion.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONVersion.java
@@ -29,7 +29,7 @@ public enum GraphSONVersion {
     private final GraphSONModule.GraphSONModuleBuilder builder;
     private final String versionNumber;
 
-    private GraphSONVersion(final GraphSONModule.GraphSONModuleBuilder builder, final String versionNumber) {
+    GraphSONVersion(final GraphSONModule.GraphSONModuleBuilder builder, final String versionNumber) {
         this.builder = builder;
         this.versionNumber = versionNumber;
     }

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/67ad95ec/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONWriter.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONWriter.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONWriter.java
index bbbfb3b..a531012 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONWriter.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/GraphSONWriter.java
@@ -42,7 +42,7 @@ import java.util.Iterator;
  *
  * @author Stephen Mallette (http://stephen.genoprime.com)
  */
-public class GraphSONWriter implements GraphWriter {
+public final class GraphSONWriter implements GraphWriter {
     private final ObjectMapper mapper;
 
     private GraphSONWriter(final GraphSONMapper mapper) {

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/67ad95ec/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/LegacyGraphSONReader.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/LegacyGraphSONReader.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/LegacyGraphSONReader.java
index a8d1929..ba8255a 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/LegacyGraphSONReader.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/graphson/LegacyGraphSONReader.java
@@ -53,11 +53,11 @@ import java.util.function.Function;
  *
  * @author Stephen Mallette (http://stephen.genoprime.com)
  */
-public class LegacyGraphSONReader implements GraphReader {
+public final class LegacyGraphSONReader implements GraphReader {
     private final ObjectMapper mapper;
     private final long batchSize;
 
-    public LegacyGraphSONReader(final ObjectMapper mapper, final long batchSize) {
+    private LegacyGraphSONReader(final ObjectMapper mapper, final long batchSize) {
         this.mapper = mapper;
         this.batchSize = batchSize;
     }
@@ -80,13 +80,13 @@ public class LegacyGraphSONReader implements GraphReader {
             while (parser.nextToken() != JsonToken.END_OBJECT) {
                 final String fieldName = parser.getCurrentName() == null ? "" : parser.getCurrentName();
                 switch (fieldName) {
-                    case GraphSONTokens.MODE:
+                    case GraphSONTokensTP2.MODE:
                         parser.nextToken();
                         final String mode = parser.getText();
                         if (!mode.equals("EXTENDED"))
                             throw new IllegalStateException("The legacy GraphSON must be generated with GraphSONMode.EXTENDED");
                         break;
-                    case GraphSONTokens.VERTICES:
+                    case GraphSONTokensTP2.VERTICES:
                         parser.nextToken();
                         while (parser.nextToken() != JsonToken.END_ARRAY) {
                             final JsonNode node = parser.readValueAsTree();
@@ -96,12 +96,12 @@ public class LegacyGraphSONReader implements GraphReader {
                                 graphToWriteTo.tx().commit();
                         }
                         break;
-                    case GraphSONTokens.EDGES:
+                    case GraphSONTokensTP2.EDGES:
                         parser.nextToken();
                         while (parser.nextToken() != JsonToken.END_ARRAY) {
                             final JsonNode node = parser.readValueAsTree();
-                            final Vertex inV = cache.get(LegacyGraphSONUtility.getTypedValueFromJsonNode(node.get(GraphSONTokens._IN_V)));
-                            final Vertex outV = cache.get(LegacyGraphSONUtility.getTypedValueFromJsonNode(node.get(GraphSONTokens._OUT_V)));
+                            final Vertex inV = cache.get(LegacyGraphSONUtility.getTypedValueFromJsonNode(node.get(GraphSONTokensTP2._IN_V)));
+                            final Vertex outV = cache.get(LegacyGraphSONUtility.getTypedValueFromJsonNode(node.get(GraphSONTokensTP2._OUT_V)));
                             graphson.edgeFromJson(node, outV, inV);
 
                             if (supportsTx && counter.incrementAndGet() % batchSize == 0)
@@ -201,7 +201,7 @@ public class LegacyGraphSONReader implements GraphReader {
         return new Builder();
     }
 
-    public static class Builder {
+    public final static class Builder {
         private boolean loadCustomModules = false;
         private List<SimpleModule> customModules = new ArrayList<>();
         private long batchSize = 10000;
@@ -263,7 +263,7 @@ public class LegacyGraphSONReader implements GraphReader {
         public Vertex vertexFromJson(final JsonNode json) throws IOException {
             final Map<String, Object> props = readProperties(json);
 
-            final Object vertexId = getTypedValueFromJsonNode(json.get(GraphSONTokens._ID));
+            final Object vertexId = getTypedValueFromJsonNode(json.get(GraphSONTokensTP2._ID));
             final Vertex v = vertexFeatures.willAllowId(vertexId) ? g.addVertex(T.id, vertexId) : g.addVertex();
             cache.put(vertexId, v);
 
@@ -277,8 +277,8 @@ public class LegacyGraphSONReader implements GraphReader {
         public Edge edgeFromJson(final JsonNode json, final Vertex out, final Vertex in) throws IOException {
             final Map<String, Object> props = LegacyGraphSONUtility.readProperties(json);
 
-            final Object edgeId = getTypedValueFromJsonNode(json.get(GraphSONTokens._ID));
-            final JsonNode nodeLabel = json.get(GraphSONTokens._LABEL);
+            final Object edgeId = getTypedValueFromJsonNode(json.get(GraphSONTokensTP2._ID));
+            final JsonNode nodeLabel = json.get(GraphSONTokensTP2._LABEL);
             final String label = nodeLabel == null ? EMPTY_STRING : nodeLabel.textValue();
 
             final Edge e = edgeFeatures.willAllowId(edgeId) ? out.addEdge(label, in, T.id, edgeId) : out.addEdge(label, in) ;
@@ -310,35 +310,35 @@ public class LegacyGraphSONReader implements GraphReader {
         }
 
         private static boolean isReservedKey(final String key) {
-            return key.equals(GraphSONTokens._ID) || key.equals(GraphSONTokens._TYPE) || key.equals(GraphSONTokens._LABEL)
-                    || key.equals(GraphSONTokens._OUT_V) || key.equals(GraphSONTokens._IN_V);
+            return key.equals(GraphSONTokensTP2._ID) || key.equals(GraphSONTokensTP2._TYPE) || key.equals(GraphSONTokensTP2._LABEL)
+                    || key.equals(GraphSONTokensTP2._OUT_V) || key.equals(GraphSONTokensTP2._IN_V);
         }
 
         private static Object readProperty(final JsonNode node) {
             final Object propertyValue;
 
-            if (node.get(GraphSONTokens.TYPE).textValue().equals(GraphSONTokens.TYPE_UNKNOWN)) {
+            if (node.get(GraphSONTokensTP2.TYPE).textValue().equals(GraphSONTokensTP2.TYPE_UNKNOWN)) {
                 propertyValue = null;
-            } else if (node.get(GraphSONTokens.TYPE).textValue().equals(GraphSONTokens.TYPE_BOOLEAN)) {
-                propertyValue = node.get(GraphSONTokens.VALUE).booleanValue();
-            } else if (node.get(GraphSONTokens.TYPE).textValue().equals(GraphSONTokens.TYPE_FLOAT)) {
-                propertyValue = Float.parseFloat(node.get(GraphSONTokens.VALUE).asText());
-            } else if (node.get(GraphSONTokens.TYPE).textValue().equals(GraphSONTokens.TYPE_BYTE)) {
-                propertyValue = Byte.parseByte(node.get(GraphSONTokens.VALUE).asText());
-            } else if (node.get(GraphSONTokens.TYPE).textValue().equals(GraphSONTokens.TYPE_SHORT)) {
-                propertyValue = Short.parseShort(node.get(GraphSONTokens.VALUE).asText());
-            } else if (node.get(GraphSONTokens.TYPE).textValue().equals(GraphSONTokens.TYPE_DOUBLE)) {
-                propertyValue = node.get(GraphSONTokens.VALUE).doubleValue();
-            } else if (node.get(GraphSONTokens.TYPE).textValue().equals(GraphSONTokens.TYPE_INTEGER)) {
-                propertyValue = node.get(GraphSONTokens.VALUE).intValue();
-            } else if (node.get(GraphSONTokens.TYPE).textValue().equals(GraphSONTokens.TYPE_LONG)) {
-                propertyValue = node.get(GraphSONTokens.VALUE).longValue();
-            } else if (node.get(GraphSONTokens.TYPE).textValue().equals(GraphSONTokens.TYPE_STRING)) {
-                propertyValue = node.get(GraphSONTokens.VALUE).textValue();
-            } else if (node.get(GraphSONTokens.TYPE).textValue().equals(GraphSONTokens.TYPE_LIST)) {
-                propertyValue = readProperties(node.get(GraphSONTokens.VALUE).elements());
-            } else if (node.get(GraphSONTokens.TYPE).textValue().equals(GraphSONTokens.TYPE_MAP)) {
-                propertyValue = readProperties(node.get(GraphSONTokens.VALUE));
+            } else if (node.get(GraphSONTokensTP2.TYPE).textValue().equals(GraphSONTokensTP2.TYPE_BOOLEAN)) {
+                propertyValue = node.get(GraphSONTokensTP2.VALUE).booleanValue();
+            } else if (node.get(GraphSONTokensTP2.TYPE).textValue().equals(GraphSONTokensTP2.TYPE_FLOAT)) {
+                propertyValue = Float.parseFloat(node.get(GraphSONTokensTP2.VALUE).asText());
+            } else if (node.get(GraphSONTokensTP2.TYPE).textValue().equals(GraphSONTokensTP2.TYPE_BYTE)) {
+                propertyValue = Byte.parseByte(node.get(GraphSONTokensTP2.VALUE).asText());
+            } else if (node.get(GraphSONTokensTP2.TYPE).textValue().equals(GraphSONTokensTP2.TYPE_SHORT)) {
+                propertyValue = Short.parseShort(node.get(GraphSONTokensTP2.VALUE).asText());
+            } else if (node.get(GraphSONTokensTP2.TYPE).textValue().equals(GraphSONTokensTP2.TYPE_DOUBLE)) {
+                propertyValue = node.get(GraphSONTokensTP2.VALUE).doubleValue();
+            } else if (node.get(GraphSONTokensTP2.TYPE).textValue().equals(GraphSONTokensTP2.TYPE_INTEGER)) {
+                propertyValue = node.get(GraphSONTokensTP2.VALUE).intValue();
+            } else if (node.get(GraphSONTokensTP2.TYPE).textValue().equals(GraphSONTokensTP2.TYPE_LONG)) {
+                propertyValue = node.get(GraphSONTokensTP2.VALUE).longValue();
+            } else if (node.get(GraphSONTokensTP2.TYPE).textValue().equals(GraphSONTokensTP2.TYPE_STRING)) {
+                propertyValue = node.get(GraphSONTokensTP2.VALUE).textValue();
+            } else if (node.get(GraphSONTokensTP2.TYPE).textValue().equals(GraphSONTokensTP2.TYPE_LIST)) {
+                propertyValue = readProperties(node.get(GraphSONTokensTP2.VALUE).elements());
+            } else if (node.get(GraphSONTokensTP2.TYPE).textValue().equals(GraphSONTokensTP2.TYPE_MAP)) {
+                propertyValue = readProperties(node.get(GraphSONTokensTP2.VALUE));
             } else {
                 propertyValue = node.textValue();
             }
@@ -389,7 +389,10 @@ public class LegacyGraphSONReader implements GraphReader {
         }
     }
 
-    public static class GraphSONTokens {
+    public final static class GraphSONTokensTP2 {
+
+        private GraphSONTokensTP2() {}
+
         public static final String _ID = "_id";
         public static final String _LABEL = "_label";
         public static final String _TYPE = "_type";


[2/2] incubator-tinkerpop git commit: Finalize some classes in gryo.

Posted by sp...@apache.org.
Finalize some classes in gryo.


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

Branch: refs/heads/master
Commit: f3e4d54fa37cf3d18f3023eacd9ce5fadfbb2815
Parents: 67ad95e
Author: Stephen Mallette <sp...@genoprime.com>
Authored: Mon Jun 1 14:58:25 2015 -0400
Committer: Stephen Mallette <sp...@genoprime.com>
Committed: Mon Jun 1 14:58:25 2015 -0400

----------------------------------------------------------------------
 .../gremlin/structure/io/gryo/EntrySerializer.java      |  2 +-
 .../tinkerpop/gremlin/structure/io/gryo/GryoIo.java     |  6 +++---
 .../tinkerpop/gremlin/structure/io/gryo/GryoMapper.java |  2 +-
 .../tinkerpop/gremlin/structure/io/gryo/GryoPool.java   |  2 +-
 .../tinkerpop/gremlin/structure/io/gryo/GryoReader.java |  4 ++--
 .../gremlin/structure/io/gryo/GryoSerializers.java      | 12 ++++++------
 .../tinkerpop/gremlin/structure/io/gryo/GryoWriter.java |  4 ++--
 .../gremlin/structure/io/gryo/URISerializer.java        |  2 +-
 .../gremlin/structure/io/gryo/UUIDSerializer.java       |  2 +-
 .../structure/io/gryo/VertexByteArrayInputStream.java   |  2 +-
 .../gremlin/structure/io/gryo/VertexTerminator.java     |  2 +-
 11 files changed, 20 insertions(+), 20 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/f3e4d54f/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/EntrySerializer.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/EntrySerializer.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/EntrySerializer.java
index 41d4fd5..00215e0 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/EntrySerializer.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/EntrySerializer.java
@@ -29,7 +29,7 @@ import java.util.Map;
 /**
  * @author Stephen Mallette (http://stephen.genoprime.com)
  */
-class EntrySerializer extends Serializer<Map.Entry> {
+final class EntrySerializer extends Serializer<Map.Entry> {
     @Override
     public void write(final Kryo kryo, final Output output, final Map.Entry entry) {
         kryo.writeClassAndObject(output, entry.getKey());

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/f3e4d54f/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoIo.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoIo.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoIo.java
index 01ba531..bc4b6aa 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoIo.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoIo.java
@@ -34,12 +34,12 @@ import java.io.OutputStream;
  *
  * @author Stephen Mallette (http://stephen.genoprime.com)
  */
-public class GryoIo implements Io<GryoReader.Builder, GryoWriter.Builder, GryoMapper.Builder> {
+public final class GryoIo implements Io<GryoReader.Builder, GryoWriter.Builder, GryoMapper.Builder> {
 
     private final IoRegistry registry;
     private final Graph graph;
 
-    public GryoIo(final IoRegistry registry, final Graph graph) {
+    private GryoIo(final IoRegistry registry, final Graph graph) {
         this.registry = registry;
         this.graph = graph;
     }
@@ -91,7 +91,7 @@ public class GryoIo implements Io<GryoReader.Builder, GryoWriter.Builder, GryoMa
         return new Builder();
     }
 
-    public static class Builder implements Io.Builder<GryoIo> {
+    public final static class Builder implements Io.Builder<GryoIo> {
 
         private IoRegistry registry = null;
         private Graph graph;

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/f3e4d54f/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoMapper.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoMapper.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoMapper.java
index bb36fbb..8d88f93 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoMapper.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoMapper.java
@@ -152,7 +152,7 @@ public final class GryoMapper implements Mapper<Kryo> {
     /**
      * A builder to construct a {@link GryoMapper} instance.
      */
-    public static class Builder implements Mapper.Builder<Builder> {
+    public final static class Builder implements Mapper.Builder<Builder> {
 
         /**
          * Map with one entry that is used so that it is possible to get the class of LinkedHashMap.Entry.

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/f3e4d54f/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoPool.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoPool.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoPool.java
index bb38ca9..2641e56 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoPool.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoPool.java
@@ -35,7 +35,7 @@ import java.util.function.Function;
  * @author Marko A. Rodriguez (http://markorodriguez.com)
  * @author Stephen Mallette (http://stephen.genoprime.com)
  */
-public class GryoPool {
+public final class GryoPool {
     public static final String CONFIG_IO_REGISTRY = "gremlin.io.registry";
     public static final String CONFIG_IO_GRYO_POOL_SIZE = "gremlin.io.gryo.poolSize";
 

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/f3e4d54f/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoReader.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoReader.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoReader.java
index a208e2f..234a04e 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoReader.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoReader.java
@@ -58,7 +58,7 @@ import java.util.function.Function;
  * @author Stephen Mallette (http://stephen.genoprime.com)
  * @author Marko A. Rodriguez (http://markorodriguez.com)
  */
-public class GryoReader implements GraphReader {
+public final class GryoReader implements GraphReader {
     private final Kryo kryo;
 
     private final long batchSize;
@@ -246,7 +246,7 @@ public class GryoReader implements GraphReader {
         return new Builder();
     }
 
-    public static class Builder implements ReaderBuilder<GryoReader> {
+    public final static class Builder implements ReaderBuilder<GryoReader> {
 
         private long batchSize = 10000;
         /**

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/f3e4d54f/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoSerializers.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoSerializers.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoSerializers.java
index fd63426..42ab74b 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoSerializers.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoSerializers.java
@@ -42,12 +42,12 @@ import org.apache.tinkerpop.shaded.kryo.io.Output;
  * @author Stephen Mallette (http://stephen.genoprime.com)
  * @author Marko A. Rodriguez (http://markorodriguez.com)
  */
-class GryoSerializers {
+final class GryoSerializers {
 
     /**
      * Serializes any {@link Edge} implementation encountered to a {@link DetachedEdge}.
      */
-    static class EdgeSerializer extends Serializer<Edge> {
+    final static class EdgeSerializer extends Serializer<Edge> {
         @Override
         public void write(final Kryo kryo, final Output output, final Edge edge) {
             kryo.writeClassAndObject(output, DetachedFactory.detach(edge, true));
@@ -63,7 +63,7 @@ class GryoSerializers {
     /**
      * Serializes any {@link Vertex} implementation encountered to an {@link DetachedVertex}.
      */
-    static class VertexSerializer extends Serializer<Vertex> {
+    final static class VertexSerializer extends Serializer<Vertex> {
         public VertexSerializer() {
         }
 
@@ -81,7 +81,7 @@ class GryoSerializers {
     /**
      * Serializes any {@link Property} implementation encountered to an {@link DetachedProperty}.
      */
-    static class PropertySerializer extends Serializer<Property> {
+    final static class PropertySerializer extends Serializer<Property> {
         public PropertySerializer() {
         }
 
@@ -99,7 +99,7 @@ class GryoSerializers {
     /**
      * Serializes any {@link VertexProperty} implementation encountered to an {@link DetachedVertexProperty}.
      */
-    static class VertexPropertySerializer extends Serializer<VertexProperty> {
+    final static class VertexPropertySerializer extends Serializer<VertexProperty> {
         public VertexPropertySerializer() {
         }
 
@@ -117,7 +117,7 @@ class GryoSerializers {
     /**
      * Serializes any {@link Path} implementation encountered to an {@link DetachedPath}.
      */
-    static class PathSerializer extends Serializer<Path> {
+    final static class PathSerializer extends Serializer<Path> {
         public PathSerializer() {
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/f3e4d54f/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoWriter.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoWriter.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoWriter.java
index 3435718..d98b8c2 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoWriter.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/GryoWriter.java
@@ -44,7 +44,7 @@ import java.util.Iterator;
  *
  * @author Stephen Mallette (http://stephen.genoprime.com)
  */
-public class GryoWriter implements GraphWriter {
+public final class GryoWriter implements GraphWriter {
     private Kryo kryo;
 
     private GryoWriter(final GryoMapper gryoMapper) {
@@ -158,7 +158,7 @@ public class GryoWriter implements GraphWriter {
         return new Builder();
     }
 
-    public static class Builder implements WriterBuilder<GryoWriter> {
+    public final static class Builder implements WriterBuilder<GryoWriter> {
         /**
          * Always creates the most current version available.
          */

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/f3e4d54f/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/URISerializer.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/URISerializer.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/URISerializer.java
index a19857d..7b6cfec 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/URISerializer.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/URISerializer.java
@@ -28,7 +28,7 @@ import java.net.URI;
 /**
  * @author Stephen Mallette (http://stephen.genoprime.com)
  */
-class URISerializer extends Serializer<URI> {
+final class URISerializer extends Serializer<URI> {
 
     public URISerializer() {
         setImmutable(true);

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/f3e4d54f/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/UUIDSerializer.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/UUIDSerializer.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/UUIDSerializer.java
index 0be904b..e694e38 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/UUIDSerializer.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/UUIDSerializer.java
@@ -28,7 +28,7 @@ import java.util.UUID;
 /**
  * @author Stephen Mallette (http://stephen.genoprime.com)
  */
-class UUIDSerializer extends Serializer<UUID> {
+final class UUIDSerializer extends Serializer<UUID> {
     public UUIDSerializer() {
         setImmutable(true);
     }

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/f3e4d54f/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/VertexByteArrayInputStream.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/VertexByteArrayInputStream.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/VertexByteArrayInputStream.java
index b6ba796..fa34e33 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/VertexByteArrayInputStream.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/VertexByteArrayInputStream.java
@@ -34,7 +34,7 @@ import java.util.List;
  *
  * @author Stephen Mallette (http://stephen.genoprime.com)
  */
-public class VertexByteArrayInputStream extends FilterInputStream {
+public final class VertexByteArrayInputStream extends FilterInputStream {
 
     private static final byte[] vertexTerminatorClass = new byte[]{15, 1, 1, 9};
     private static final byte[] pattern = ByteBuffer.allocate(vertexTerminatorClass.length + 8).put(vertexTerminatorClass).putLong(4185403236219066774L).array();

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/f3e4d54f/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/VertexTerminator.java
----------------------------------------------------------------------
diff --git a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/VertexTerminator.java b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/VertexTerminator.java
index 64c96d7..2028459 100644
--- a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/VertexTerminator.java
+++ b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/structure/io/gryo/VertexTerminator.java
@@ -26,7 +26,7 @@ import java.util.Arrays;
  *
  * @author Stephen Mallette (http://stephen.genoprime.com)
  */
-public class VertexTerminator {
+public final class VertexTerminator {
     public static final VertexTerminator INSTANCE = new VertexTerminator();
 
     public final byte[] terminal;