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/02/09 21:48:50 UTC

[18/19] incubator-tinkerpop git commit: Added ASL headers

Added ASL headers


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

Branch: refs/heads/master
Commit: 8dd1b91aaca3ea64cb0932a91f5084cae17191ac
Parents: db98c2d
Author: paliwalashish <pa...@gmail.com>
Authored: Mon Feb 9 17:20:03 2015 +0530
Committer: paliwalashish <pa...@gmail.com>
Committed: Mon Feb 9 17:20:03 2015 +0530

----------------------------------------------------------------------
 bin/bump.sh                                     | 19 +++++++++++++++++++
 bin/clean-grapes.sh                             | 19 +++++++++++++++++++
 bin/gremlin-server.sh                           | 19 +++++++++++++++++++
 bin/gremlin.sh                                  | 19 +++++++++++++++++++
 bin/publish-docs.sh                             | 19 +++++++++++++++++++
 gremlin-algorithm/pom.xml                       | 17 ++++++++++++++++-
 .../algorithm/generator/AbstractGenerator.java  | 18 ++++++++++++++++++
 .../algorithm/generator/CommunityGenerator.java | 18 ++++++++++++++++++
 .../algorithm/generator/CopyDistribution.java   | 18 ++++++++++++++++++
 .../algorithm/generator/Distribution.java       | 18 ++++++++++++++++++
 .../generator/DistributionGenerator.java        | 18 ++++++++++++++++++
 .../gremlin/algorithm/generator/Generator.java  | 18 ++++++++++++++++++
 .../algorithm/generator/NormalDistribution.java | 18 ++++++++++++++++++
 .../generator/PowerLawDistribution.java         | 18 ++++++++++++++++++
 .../algorithm/generator/SizableIterable.java    | 18 ++++++++++++++++++
 gremlin-console/pom.xml                         | 17 ++++++++++++++++-
 gremlin-console/src/assembly/distribution.xml   | 16 ++++++++++++++++
 gremlin-console/src/assembly/standalone.xml     | 16 ++++++++++++++++
 gremlin-console/src/main/bin/gremlin.sh         | 19 +++++++++++++++++++
 .../tinkerpop/gremlin/console/Console.groovy    | 18 ++++++++++++++++++
 .../ConsoleImportCustomizerProvider.groovy      | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/console/Mediator.groovy   | 18 ++++++++++++++++++
 .../console/commands/InstallCommand.groovy      | 18 ++++++++++++++++++
 .../console/commands/PluginCommand.groovy       | 18 ++++++++++++++++++
 .../console/commands/RemoteCommand.groovy       | 18 ++++++++++++++++++
 .../console/commands/SubmitCommand.groovy       | 18 ++++++++++++++++++
 .../console/commands/UninstallCommand.groovy    | 18 ++++++++++++++++++
 .../console/plugin/ConsolePluginAcceptor.groovy | 18 ++++++++++++++++++
 .../console/plugin/GephiRemoteAcceptor.groovy   | 18 ++++++++++++++++++
 .../gremlin/console/plugin/PluggedIn.groovy     | 18 ++++++++++++++++++
 .../gremlin/console/util/ArrayIterator.groovy   | 18 ++++++++++++++++++
 .../groovy/plugin/DriverGremlinPlugin.java      | 18 ++++++++++++++++++
 .../groovy/plugin/DriverRemoteAcceptor.java     | 18 ++++++++++++++++++
 .../groovy/plugin/GephiGremlinPlugin.java       | 18 ++++++++++++++++++
 .../groovy/plugin/UtilitiesGremlinPlugin.java   | 18 ++++++++++++++++++
 .../console/commands/InstallCommand.properties  | 17 +++++++++++++++++
 .../console/commands/PluginCommand.properties   | 16 ++++++++++++++++
 .../console/commands/RemoteCommand.properties   | 16 ++++++++++++++++
 .../console/commands/SubmitCommand.properties   | 16 ++++++++++++++++
 .../commands/UninstallCommand.properties        | 16 ++++++++++++++++
 .../plugin/UtilitiesGremlinPluginScript.groovy  | 19 +++++++++++++++++++
 .../AbstractGremlinServerIntegrationTest.java   | 18 ++++++++++++++++++
 .../groovy/plugin/DriverGremlinPluginTest.java  | 18 ++++++++++++++++++
 .../DriverRemoteAcceptorIntegrateTest.java      | 18 ++++++++++++++++++
 .../groovy/plugin/DriverRemoteAcceptorTest.java | 18 ++++++++++++++++++
 .../groovy/plugin/SpyPluginAcceptor.java        | 18 ++++++++++++++++++
 .../groovy/plugin/SugarGremlinPluginTest.java   | 18 ++++++++++++++++++
 .../plugin/UtilitiesGremlinPluginTest.java      | 18 ++++++++++++++++++
 .../groovy/plugin/tinkergraph-empty.properties  | 17 +++++++++++++++++
 gremlin-core/pom.xml                            | 17 ++++++++++++++++-
 .../process/FastNoSuchElementException.java     | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/process/Path.java     | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/process/Scope.java    | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/process/Step.java     | 18 ++++++++++++++++++
 .../java/com/tinkerpop/gremlin/process/T.java   | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/process/Traversal.java    | 18 ++++++++++++++++++
 .../gremlin/process/TraversalEngine.java        | 18 ++++++++++++++++++
 .../gremlin/process/TraversalSideEffects.java   | 18 ++++++++++++++++++
 .../gremlin/process/TraversalStrategies.java    | 18 ++++++++++++++++++
 .../gremlin/process/TraversalStrategy.java      | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/process/Traverser.java    | 18 ++++++++++++++++++
 .../gremlin/process/TraverserGenerator.java     | 18 ++++++++++++++++++
 .../process/computer/ComputerResult.java        | 18 ++++++++++++++++++
 .../gremlin/process/computer/GraphComputer.java | 18 ++++++++++++++++++
 .../gremlin/process/computer/KeyValue.java      | 18 ++++++++++++++++++
 .../gremlin/process/computer/MapReduce.java     | 18 ++++++++++++++++++
 .../gremlin/process/computer/Memory.java        | 18 ++++++++++++++++++
 .../process/computer/MessageCombiner.java       | 18 ++++++++++++++++++
 .../gremlin/process/computer/MessageScope.java  | 18 ++++++++++++++++++
 .../gremlin/process/computer/Messenger.java     | 18 ++++++++++++++++++
 .../gremlin/process/computer/VertexProgram.java | 19 +++++++++++++++++++
 .../peerpressure/ClusterCountMapReduce.java     | 18 ++++++++++++++++++
 .../ClusterPopulationMapReduce.java             | 18 ++++++++++++++++++
 .../peerpressure/PeerPressureVertexProgram.java | 18 ++++++++++++++++++
 .../computer/lambda/LambdaMapReduce.java        | 18 ++++++++++++++++++
 .../computer/lambda/LambdaVertexProgram.java    | 18 ++++++++++++++++++
 .../ranking/pagerank/PageRankMapReduce.java     | 18 ++++++++++++++++++
 .../pagerank/PageRankMessageCombiner.java       | 18 ++++++++++++++++++
 .../ranking/pagerank/PageRankVertexProgram.java | 18 ++++++++++++++++++
 .../computer/traversal/TraversalScript.java     | 18 ++++++++++++++++++
 .../traversal/TraversalVertexProgram.java       | 18 ++++++++++++++++++
 .../TraversalVertexProgramMessageCombiner.java  | 18 ++++++++++++++++++
 .../computer/traversal/TraverserExecutor.java   | 18 ++++++++++++++++++
 .../traversal/VertexTraversalSideEffects.java   | 18 ++++++++++++++++++
 .../traversal/step/map/ComputerResultStep.java  | 18 ++++++++++++++++++
 .../mapreduce/TraverserMapReduce.java           | 18 ++++++++++++++++++
 .../util/AbstractVertexProgramBuilder.java      | 18 ++++++++++++++++++
 .../computer/util/ComputerDataStrategy.java     | 18 ++++++++++++++++++
 .../computer/util/GraphComputerHelper.java      | 18 ++++++++++++++++++
 .../process/computer/util/ImmutableMemory.java  | 18 ++++++++++++++++++
 .../process/computer/util/LambdaHolder.java     | 18 ++++++++++++++++++
 .../process/computer/util/MapMemory.java        | 18 ++++++++++++++++++
 .../process/computer/util/MemoryHelper.java     | 18 ++++++++++++++++++
 .../computer/util/ScriptEngineCache.java        | 18 ++++++++++++++++++
 .../computer/util/ScriptEngineLambda.java       | 18 ++++++++++++++++++
 .../process/computer/util/StaticMapReduce.java  | 18 ++++++++++++++++++
 .../computer/util/StaticVertexProgram.java      | 18 ++++++++++++++++++
 .../computer/util/VertexProgramHelper.java      | 18 ++++++++++++++++++
 .../graph/traversal/DefaultGraphTraversal.java  | 18 ++++++++++++++++++
 .../process/graph/traversal/EdgeTraversal.java  | 18 ++++++++++++++++++
 .../graph/traversal/ElementTraversal.java       | 18 ++++++++++++++++++
 .../process/graph/traversal/GraphTraversal.java | 18 ++++++++++++++++++
 .../traversal/VertexPropertyTraversal.java      | 18 ++++++++++++++++++
 .../graph/traversal/VertexTraversal.java        | 18 ++++++++++++++++++
 .../gremlin/process/graph/traversal/__.java     | 18 ++++++++++++++++++
 .../graph/traversal/lambda/LoopTraversal.java   | 18 ++++++++++++++++++
 .../graph/traversal/step/ComparatorHolder.java  | 18 ++++++++++++++++++
 .../traversal/step/HasContainerHolder.java      | 18 ++++++++++++++++++
 .../process/graph/traversal/step/Ranging.java   | 18 ++++++++++++++++++
 .../graph/traversal/step/SideEffectCapable.java | 18 ++++++++++++++++++
 .../traversal/step/TraversalOptionParent.java   | 18 ++++++++++++++++++
 .../graph/traversal/step/branch/BranchStep.java | 18 ++++++++++++++++++
 .../graph/traversal/step/branch/ChooseStep.java | 18 ++++++++++++++++++
 .../graph/traversal/step/branch/LocalStep.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/branch/RepeatStep.java | 18 ++++++++++++++++++
 .../graph/traversal/step/branch/UnionStep.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/AndStep.java    | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/CoinStep.java   | 18 ++++++++++++++++++
 .../traversal/step/filter/ConjunctionStep.java  | 18 ++++++++++++++++++
 .../traversal/step/filter/CyclicPathStep.java   | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/DedupStep.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/ExceptStep.java | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/FilterStep.java | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/HasStep.java    | 18 ++++++++++++++++++
 .../traversal/step/filter/HasTraversalStep.java | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/IsStep.java     | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/OrStep.java     | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/RangeStep.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/RetainStep.java | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/SampleStep.java | 18 ++++++++++++++++++
 .../traversal/step/filter/SimplePathStep.java   | 18 ++++++++++++++++++
 .../traversal/step/filter/TimeLimitStep.java    | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/WhereStep.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/map/BackStep.java      | 18 ++++++++++++++++++
 .../graph/traversal/step/map/CoalesceStep.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/map/CountStep.java     | 18 ++++++++++++++++++
 .../traversal/step/map/EdgeOtherVertexStep.java | 18 ++++++++++++++++++
 .../traversal/step/map/EdgeVertexStep.java      | 18 ++++++++++++++++++
 .../graph/traversal/step/map/FlatMapStep.java   | 18 ++++++++++++++++++
 .../graph/traversal/step/map/FoldStep.java      | 18 ++++++++++++++++++
 .../graph/traversal/step/map/IdStep.java        | 18 ++++++++++++++++++
 .../graph/traversal/step/map/KeyStep.java       | 18 ++++++++++++++++++
 .../graph/traversal/step/map/LabelStep.java     | 18 ++++++++++++++++++
 .../graph/traversal/step/map/MapStep.java       | 18 ++++++++++++++++++
 .../graph/traversal/step/map/MaxStep.java       | 18 ++++++++++++++++++
 .../graph/traversal/step/map/MeanStep.java      | 18 ++++++++++++++++++
 .../graph/traversal/step/map/MinStep.java       | 18 ++++++++++++++++++
 .../traversal/step/map/OrderGlobalStep.java     | 18 ++++++++++++++++++
 .../traversal/step/map/OrderLocalStep.java      | 18 ++++++++++++++++++
 .../graph/traversal/step/map/PathStep.java      | 18 ++++++++++++++++++
 .../traversal/step/map/PropertiesStep.java      | 18 ++++++++++++++++++
 .../traversal/step/map/PropertyElementStep.java | 18 ++++++++++++++++++
 .../traversal/step/map/PropertyMapStep.java     | 18 ++++++++++++++++++
 .../traversal/step/map/PropertyValueStep.java   | 18 ++++++++++++++++++
 .../graph/traversal/step/map/SackStep.java      | 18 ++++++++++++++++++
 .../graph/traversal/step/map/SelectOneStep.java | 18 ++++++++++++++++++
 .../graph/traversal/step/map/SelectStep.java    | 18 ++++++++++++++++++
 .../graph/traversal/step/map/SumStep.java       | 18 ++++++++++++++++++
 .../graph/traversal/step/map/UnfoldStep.java    | 18 ++++++++++++++++++
 .../graph/traversal/step/map/VertexStep.java    | 18 ++++++++++++++++++
 .../traversal/step/map/match/Bindings.java      | 18 ++++++++++++++++++
 .../step/map/match/CrossJoinEnumerator.java     | 18 ++++++++++++++++++
 .../traversal/step/map/match/Enumerator.java    | 18 ++++++++++++++++++
 .../step/map/match/InnerJoinEnumerator.java     | 18 ++++++++++++++++++
 .../step/map/match/IteratorEnumerator.java      | 18 ++++++++++++++++++
 .../traversal/step/map/match/MatchStep.java     | 18 ++++++++++++++++++
 .../step/map/match/SerialEnumerator.java        | 18 ++++++++++++++++++
 .../step/map/match/SimpleEnumerator.java        | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/AddEdgeStep.java  | 18 ++++++++++++++++++
 .../step/sideEffect/AggregateStep.java          | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/GraphStep.java    | 18 ++++++++++++++++++
 .../step/sideEffect/GroupCountStep.java         | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/GroupStep.java    | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/IdentityStep.java | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/InjectStep.java   | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/ProfileStep.java  | 18 ++++++++++++++++++
 .../step/sideEffect/SackElementValueStep.java   | 18 ++++++++++++++++++
 .../step/sideEffect/SackObjectStep.java         | 18 ++++++++++++++++++
 .../step/sideEffect/SideEffectCapStep.java      | 18 ++++++++++++++++++
 .../step/sideEffect/SideEffectStep.java         | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/StartStep.java    | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/StoreStep.java    | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/SubgraphStep.java | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/TreeStep.java     | 18 ++++++++++++++++++
 .../mapreduce/AggregateMapReduce.java           | 18 ++++++++++++++++++
 .../mapreduce/GroupCountMapReduce.java          | 18 ++++++++++++++++++
 .../sideEffect/mapreduce/GroupMapReduce.java    | 18 ++++++++++++++++++
 .../sideEffect/mapreduce/ProfileMapReduce.java  | 18 ++++++++++++++++++
 .../sideEffect/mapreduce/StoreMapReduce.java    | 18 ++++++++++++++++++
 .../sideEffect/mapreduce/TreeMapReduce.java     | 18 ++++++++++++++++++
 .../step/util/CollectingBarrierStep.java        | 18 ++++++++++++++++++
 .../traversal/step/util/ComputerAwareStep.java  | 18 ++++++++++++++++++
 .../traversal/step/util/MarkerIdentityStep.java | 18 ++++++++++++++++++
 .../traversal/step/util/PathIdentityStep.java   | 18 ++++++++++++++++++
 .../step/util/ReducingBarrierStep.java          | 18 ++++++++++++++++++
 .../step/util/SupplyingBarrierStep.java         | 18 ++++++++++++++++++
 .../strategy/AbstractTraversalStrategy.java     | 18 ++++++++++++++++++
 .../ComparatorHolderRemovalStrategy.java        | 18 ++++++++++++++++++
 .../traversal/strategy/ConjunctionStrategy.java | 18 ++++++++++++++++++
 .../strategy/DedupOptimizerStrategy.java        | 18 ++++++++++++++++++
 .../strategy/EngineDependentStrategy.java       | 18 ++++++++++++++++++
 .../strategy/IdentityRemovalStrategy.java       | 18 ++++++++++++++++++
 .../strategy/LabeledEndStepStrategy.java        | 18 ++++++++++++++++++
 .../traversal/strategy/MatchWhereStrategy.java  | 18 ++++++++++++++++++
 .../traversal/strategy/ProfileStrategy.java     | 18 ++++++++++++++++++
 .../traversal/strategy/ReducingStrategy.java    | 18 ++++++++++++++++++
 .../strategy/SideEffectCapStrategy.java         | 18 ++++++++++++++++++
 .../SideEffectRegistrationStrategy.java         | 18 ++++++++++++++++++
 .../strategy/TraversalVerificationStrategy.java | 18 ++++++++++++++++++
 .../traversal/util/EmptyGraphTraversal.java     | 18 ++++++++++++++++++
 .../process/graph/util/HasContainer.java        | 18 ++++++++++++++++++
 .../gremlin/process/graph/util/Tree.java        | 18 ++++++++++++++++++
 .../process/traversal/DefaultTraversal.java     | 18 ++++++++++++++++++
 .../traversal/DefaultTraversalSideEffects.java  | 18 ++++++++++++++++++
 .../traversal/DefaultTraversalStrategies.java   | 18 ++++++++++++++++++
 .../gremlin/process/traversal/StepPosition.java | 18 ++++++++++++++++++
 .../process/traversal/TraversalMatrix.java      | 18 ++++++++++++++++++
 .../lambda/AbstractLambdaTraversal.java         | 18 ++++++++++++++++++
 .../traversal/lambda/ElementValueTraversal.java | 18 ++++++++++++++++++
 .../traversal/lambda/FilterTraversal.java       | 18 ++++++++++++++++++
 .../lambda/FilterTraverserTraversal.java        | 18 ++++++++++++++++++
 .../traversal/lambda/HasNextTraversal.java      | 18 ++++++++++++++++++
 .../traversal/lambda/IdentityTraversal.java     | 18 ++++++++++++++++++
 .../process/traversal/lambda/MapTraversal.java  | 18 ++++++++++++++++++
 .../traversal/lambda/MapTraverserTraversal.java | 18 ++++++++++++++++++
 .../process/traversal/lambda/OneTraversal.java  | 18 ++++++++++++++++++
 .../process/traversal/lambda/TrueTraversal.java | 18 ++++++++++++++++++
 .../process/traversal/step/AbstractStep.java    | 18 ++++++++++++++++++
 .../step/ElementFunctionComparator.java         | 18 ++++++++++++++++++
 .../traversal/step/ElementValueComparator.java  | 18 ++++++++++++++++++
 .../process/traversal/step/EmptyStep.java       | 18 ++++++++++++++++++
 .../process/traversal/step/EngineDependent.java | 18 ++++++++++++++++++
 .../traversal/step/ExpandableStepIterator.java  | 18 ++++++++++++++++++
 .../process/traversal/step/MapReducer.java      | 18 ++++++++++++++++++
 .../process/traversal/step/Reducing.java        | 18 ++++++++++++++++++
 .../process/traversal/step/Reversible.java      | 18 ++++++++++++++++++
 .../traversal/step/SideEffectRegistrar.java     | 18 ++++++++++++++++++
 .../process/traversal/step/TraversalParent.java | 18 ++++++++++++++++++
 .../process/traversal/util/EmptyTraversal.java  | 18 ++++++++++++++++++
 .../util/EmptyTraversalSideEffects.java         | 18 ++++++++++++++++++
 .../util/EmptyTraversalStrategies.java          | 18 ++++++++++++++++++
 .../traversal/util/SideEffectHelper.java        | 18 ++++++++++++++++++
 .../process/traversal/util/TraversalHelper.java | 18 ++++++++++++++++++
 .../process/traversal/util/TraversalRing.java   | 18 ++++++++++++++++++
 .../process/traversal/util/TraversalUtil.java   | 18 ++++++++++++++++++
 .../traverser/B_O_PA_S_SE_SL_Traverser.java     | 18 ++++++++++++++++++
 .../B_O_PA_S_SE_SL_TraverserGenerator.java      | 18 ++++++++++++++++++
 .../traverser/B_O_P_PA_S_SE_SL_Traverser.java   | 18 ++++++++++++++++++
 .../B_O_P_PA_S_SE_SL_TraverserGenerator.java    | 18 ++++++++++++++++++
 .../process/traverser/B_O_Traverser.java        | 18 ++++++++++++++++++
 .../traverser/B_O_TraverserGenerator.java       | 18 ++++++++++++++++++
 .../gremlin/process/traverser/O_Traverser.java  | 18 ++++++++++++++++++
 .../process/traverser/O_TraverserGenerator.java | 18 ++++++++++++++++++
 .../traverser/TraverserGeneratorFactory.java    | 18 ++++++++++++++++++
 .../process/traverser/TraverserRequirement.java | 18 ++++++++++++++++++
 .../traverser/util/AbstractPathTraverser.java   | 18 ++++++++++++++++++
 .../traverser/util/AbstractTraverser.java       | 18 ++++++++++++++++++
 .../util/DefaultTraverserGeneratorFactory.java  | 18 ++++++++++++++++++
 .../process/traverser/util/EmptyTraverser.java  | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/process/util/BulkSet.java | 18 ++++++++++++++++++
 .../gremlin/process/util/MapHelper.java         | 18 ++++++++++++++++++
 .../gremlin/process/util/TraverserSet.java      | 18 ++++++++++++++++++
 .../process/util/metric/ImmutableMetrics.java   | 18 ++++++++++++++++++
 .../gremlin/process/util/metric/Metrics.java    | 18 ++++++++++++++++++
 .../process/util/metric/MutableMetrics.java     | 18 ++++++++++++++++++
 .../util/metric/StandardTraversalMetrics.java   | 18 ++++++++++++++++++
 .../process/util/metric/TraversalMetrics.java   | 18 ++++++++++++++++++
 .../gremlin/process/util/path/EmptyPath.java    | 18 ++++++++++++++++++
 .../process/util/path/ImmutablePath.java        | 18 ++++++++++++++++++
 .../gremlin/process/util/path/MutablePath.java  | 18 ++++++++++++++++++
 .../gremlin/process/util/path/SparsePath.java   | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/structure/Compare.java    | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/structure/Contains.java   | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/structure/Direction.java  | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/structure/Edge.java   | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/structure/Element.java    | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/structure/Graph.java  | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/structure/Operator.java   | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/structure/Order.java  | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/structure/Property.java   | 18 ++++++++++++++++++
 .../gremlin/structure/PropertyType.java         | 18 ++++++++++++++++++
 .../gremlin/structure/Transaction.java          | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/structure/Vertex.java | 18 ++++++++++++++++++
 .../gremlin/structure/VertexProperty.java       | 18 ++++++++++++++++++
 .../gremlin/structure/io/DefaultIo.java         | 18 ++++++++++++++++++
 .../gremlin/structure/io/GraphMigrator.java     | 18 ++++++++++++++++++
 .../gremlin/structure/io/GraphReader.java       | 18 ++++++++++++++++++
 .../gremlin/structure/io/GraphWriter.java       | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/structure/io/Mapper.java  | 18 ++++++++++++++++++
 .../structure/io/graphml/GraphMLReader.java     | 18 ++++++++++++++++++
 .../structure/io/graphml/GraphMLTokens.java     | 18 ++++++++++++++++++
 .../structure/io/graphml/GraphMLWriter.java     | 18 ++++++++++++++++++
 .../io/graphml/GraphMLWriterHelper.java         | 18 ++++++++++++++++++
 .../structure/io/graphson/GraphSONGraph.java    | 18 ++++++++++++++++++
 .../structure/io/graphson/GraphSONMapper.java   | 18 ++++++++++++++++++
 .../structure/io/graphson/GraphSONModule.java   | 18 ++++++++++++++++++
 .../structure/io/graphson/GraphSONReader.java   | 18 ++++++++++++++++++
 .../io/graphson/GraphSONSerializerProvider.java | 18 ++++++++++++++++++
 .../structure/io/graphson/GraphSONTokens.java   | 18 ++++++++++++++++++
 .../structure/io/graphson/GraphSONVertex.java   | 18 ++++++++++++++++++
 .../io/graphson/GraphSONVertexProperty.java     | 18 ++++++++++++++++++
 .../structure/io/graphson/GraphSONWriter.java   | 18 ++++++++++++++++++
 .../io/graphson/LegacyGraphSONReader.java       | 18 ++++++++++++++++++
 .../structure/io/kryo/EdgeTerminator.java       | 18 ++++++++++++++++++
 .../structure/io/kryo/EntrySerializer.java      | 18 ++++++++++++++++++
 .../structure/io/kryo/GraphSerializer.java      | 18 ++++++++++++++++++
 .../structure/io/kryo/GremlinClassResolver.java | 18 ++++++++++++++++++
 .../gremlin/structure/io/kryo/KryoMapper.java   | 18 ++++++++++++++++++
 .../gremlin/structure/io/kryo/KryoReader.java   | 18 ++++++++++++++++++
 .../gremlin/structure/io/kryo/KryoWriter.java   | 18 ++++++++++++++++++
 .../structure/io/kryo/URISerializer.java        | 18 ++++++++++++++++++
 .../structure/io/kryo/UUIDSerializer.java       | 18 ++++++++++++++++++
 .../io/kryo/VertexByteArrayInputStream.java     | 18 ++++++++++++++++++
 .../structure/io/kryo/VertexTerminator.java     | 18 ++++++++++++++++++
 .../gremlin/structure/server/ClusterAware.java  | 18 ++++++++++++++++++
 .../structure/server/IntervalVertexRange.java   | 18 ++++++++++++++++++
 .../gremlin/structure/server/Partition.java     | 18 ++++++++++++++++++
 .../gremlin/structure/server/VertexRange.java   | 18 ++++++++++++++++++
 .../structure/strategy/GraphStrategy.java       | 18 ++++++++++++++++++
 .../gremlin/structure/strategy/IdStrategy.java  | 18 ++++++++++++++++++
 .../structure/strategy/IdentityStrategy.java    | 18 ++++++++++++++++++
 .../structure/strategy/PartitionStrategy.java   | 18 ++++++++++++++++++
 .../structure/strategy/ReadOnlyStrategy.java    | 18 ++++++++++++++++++
 .../structure/strategy/SequenceStrategy.java    | 18 ++++++++++++++++++
 .../structure/strategy/StrategyContext.java     | 18 ++++++++++++++++++
 .../structure/strategy/StrategyEdge.java        | 18 ++++++++++++++++++
 .../structure/strategy/StrategyElement.java     | 18 ++++++++++++++++++
 .../structure/strategy/StrategyGraph.java       | 18 ++++++++++++++++++
 .../structure/strategy/StrategyProperty.java    | 18 ++++++++++++++++++
 .../structure/strategy/StrategyVariables.java   | 18 ++++++++++++++++++
 .../structure/strategy/StrategyVertex.java      | 18 ++++++++++++++++++
 .../strategy/StrategyVertexProperty.java        | 18 ++++++++++++++++++
 .../structure/strategy/StrategyWrapped.java     | 18 ++++++++++++++++++
 .../structure/strategy/SubgraphStrategy.java    | 18 ++++++++++++++++++
 .../step/sideEffect/StrategyGraphStep.java      | 18 ++++++++++++++++++
 .../gremlin/structure/util/Comparators.java     | 18 ++++++++++++++++++
 .../gremlin/structure/util/ElementHelper.java   | 18 ++++++++++++++++++
 .../structure/util/FeatureDescriptor.java       | 18 ++++++++++++++++++
 .../gremlin/structure/util/GraphFactory.java    | 18 ++++++++++++++++++
 .../structure/util/GraphVariableHelper.java     | 18 ++++++++++++++++++
 .../gremlin/structure/util/StringFactory.java   | 18 ++++++++++++++++++
 .../structure/util/batch/BatchFeatures.java     | 18 ++++++++++++++++++
 .../structure/util/batch/BatchGraph.java        | 18 ++++++++++++++++++
 .../gremlin/structure/util/batch/Exists.java    | 18 ++++++++++++++++++
 .../structure/util/batch/VertexIdType.java      | 18 ++++++++++++++++++
 .../util/batch/cache/AbstractIDVertexCache.java | 18 ++++++++++++++++++
 .../util/batch/cache/LongIDVertexCache.java     | 18 ++++++++++++++++++
 .../util/batch/cache/ObjectIDVertexCache.java   | 18 ++++++++++++++++++
 .../util/batch/cache/StringCompression.java     | 18 ++++++++++++++++++
 .../util/batch/cache/StringIDVertexCache.java   | 18 ++++++++++++++++++
 .../util/batch/cache/URLCompression.java        | 18 ++++++++++++++++++
 .../structure/util/batch/cache/VertexCache.java | 18 ++++++++++++++++++
 .../structure/util/detached/Attachable.java     | 18 ++++++++++++++++++
 .../structure/util/detached/DetachedEdge.java   | 18 ++++++++++++++++++
 .../util/detached/DetachedElement.java          | 18 ++++++++++++++++++
 .../util/detached/DetachedFactory.java          | 18 ++++++++++++++++++
 .../structure/util/detached/DetachedPath.java   | 18 ++++++++++++++++++
 .../util/detached/DetachedProperty.java         | 18 ++++++++++++++++++
 .../structure/util/detached/DetachedVertex.java | 18 ++++++++++++++++++
 .../util/detached/DetachedVertexProperty.java   | 18 ++++++++++++++++++
 .../structure/util/empty/EmptyGraph.java        | 18 ++++++++++++++++++
 .../structure/util/empty/EmptyProperty.java     | 18 ++++++++++++++++++
 .../util/empty/EmptyVertexProperty.java         | 18 ++++++++++++++++++
 .../structure/util/wrapped/WrappedEdge.java     | 18 ++++++++++++++++++
 .../structure/util/wrapped/WrappedElement.java  | 18 ++++++++++++++++++
 .../structure/util/wrapped/WrappedGraph.java    | 18 ++++++++++++++++++
 .../structure/util/wrapped/WrappedProperty.java | 18 ++++++++++++++++++
 .../util/wrapped/WrappedVariables.java          | 18 ++++++++++++++++++
 .../structure/util/wrapped/WrappedVertex.java   | 18 ++++++++++++++++++
 .../util/wrapped/WrappedVertexProperty.java     | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/util/Gremlin.java     | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/util/Serializer.java  | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/util/StreamFactory.java   | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/util/TimeUtil.java    | 18 ++++++++++++++++++
 .../gremlin/util/config/YamlConfiguration.java  | 18 ++++++++++++++++++
 .../gremlin/util/function/FunctionUtils.java    | 18 ++++++++++++++++++
 .../util/function/ThrowingBiConsumer.java       | 18 ++++++++++++++++++
 .../gremlin/util/function/ThrowingConsumer.java | 18 ++++++++++++++++++
 .../gremlin/util/function/ThrowingFunction.java | 18 ++++++++++++++++++
 .../gremlin/util/function/ThrowingSupplier.java | 18 ++++++++++++++++++
 .../util/function/TraversableLambda.java        | 18 ++++++++++++++++++
 .../gremlin/util/function/TriConsumer.java      | 18 ++++++++++++++++++
 .../gremlin/util/function/TriFunction.java      | 18 ++++++++++++++++++
 .../gremlin/util/iterator/ArrayIterator.java    | 18 ++++++++++++++++++
 .../gremlin/util/iterator/DoubleIterator.java   | 18 ++++++++++++++++++
 .../gremlin/util/iterator/IteratorUtils.java    | 18 ++++++++++++++++++
 .../gremlin/util/iterator/MultiIterator.java    | 18 ++++++++++++++++++
 .../gremlin/util/iterator/SingleIterator.java   | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/util/tools/MultiMap.java  | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/util/tools/TimeUtils.java | 18 ++++++++++++++++++
 gremlin-driver/pom.xml                          | 17 ++++++++++++++++-
 .../tinkerpop/gremlin/driver/Channelizer.java   | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/driver/Client.java    | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/driver/Cluster.java   | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/driver/ClusterInfo.java   | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/driver/Connection.java    | 18 ++++++++++++++++++
 .../gremlin/driver/ConnectionPool.java          | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/driver/Handler.java   | 18 ++++++++++++++++++
 .../java/com/tinkerpop/gremlin/driver/Host.java | 18 ++++++++++++++++++
 .../gremlin/driver/LoadBalancingStrategy.java   | 18 ++++++++++++++++++
 .../gremlin/driver/MessageSerializer.java       | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/driver/ResponseQueue.java | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/driver/Result.java    | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/driver/ResultSet.java | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/driver/Settings.java  | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/driver/Tokens.java    | 18 ++++++++++++++++++
 .../driver/exception/ConnectionException.java   | 18 ++++++++++++++++++
 .../driver/exception/ResponseException.java     | 18 ++++++++++++++++++
 .../handler/NioGremlinRequestEncoder.java       | 18 ++++++++++++++++++
 .../handler/NioGremlinResponseDecoder.java      | 18 ++++++++++++++++++
 .../driver/handler/WebSocketClientHandler.java  | 18 ++++++++++++++++++
 .../handler/WebSocketGremlinRequestEncoder.java | 18 ++++++++++++++++++
 .../WebSocketGremlinResponseDecoder.java        | 18 ++++++++++++++++++
 .../gremlin/driver/message/RequestMessage.java  | 18 ++++++++++++++++++
 .../gremlin/driver/message/ResponseMessage.java | 18 ++++++++++++++++++
 .../gremlin/driver/message/ResponseResult.java  | 18 ++++++++++++++++++
 .../gremlin/driver/message/ResponseStatus.java  | 18 ++++++++++++++++++
 .../driver/message/ResponseStatusCode.java      | 18 ++++++++++++++++++
 .../ser/AbstractJsonMessageSerializerV1d0.java  | 18 ++++++++++++++++++
 .../driver/ser/JsonBuilderKryoSerializer.java   | 18 ++++++++++++++++++
 .../ser/JsonMessageSerializerGremlinV1d0.java   | 18 ++++++++++++++++++
 .../driver/ser/JsonMessageSerializerV1d0.java   | 18 ++++++++++++++++++
 .../driver/ser/KryoMessageSerializerV1d0.java   | 18 ++++++++++++++++++
 .../driver/ser/MessageTextSerializer.java       | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/driver/ser/SerTokens.java | 18 ++++++++++++++++++
 .../driver/ser/SerializationException.java      | 18 ++++++++++++++++++
 .../gremlin/driver/ser/Serializers.java         | 18 ++++++++++++++++++
 .../gremlin/driver/simple/NioClient.java        | 18 ++++++++++++++++++
 .../gremlin/driver/simple/SimpleClient.java     | 18 ++++++++++++++++++
 .../gremlin/driver/simple/WebSocketClient.java  | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/driver/HostTest.java  | 18 ++++++++++++++++++
 .../gremlin/driver/RequestMessageTest.java      | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/driver/ResultTest.java    | 18 ++++++++++++++++++
 .../driver/benchmark/ProfilingApplication.java  | 18 ++++++++++++++++++
 .../JsonMessageSerializerGremlinV1d0Test.java   | 18 ++++++++++++++++++
 .../ser/JsonMessageSerializerV1d0Test.java      | 18 ++++++++++++++++++
 .../ser/KryoMessageSerializerV1d0Test.java      | 18 ++++++++++++++++++
 gremlin-groovy-test/pom.xml                     | 17 ++++++++++++++++-
 .../groovy/loaders/GremlinLoaderTest.groovy     | 18 ++++++++++++++++++
 .../groovy/loaders/SugarLoaderTest.groovy       | 18 ++++++++++++++++++
 .../gremlin/groovy/util/SugarTestHelper.groovy  | 18 ++++++++++++++++++
 .../gremlin/process/ComputerTestHelper.groovy   | 18 ++++++++++++++++++
 .../computer/GroovyGraphComputerTest.groovy     | 18 ++++++++++++++++++
 .../step/branch/GroovyBranchTest.groovy         | 18 ++++++++++++++++++
 .../step/branch/GroovyChooseTest.groovy         | 18 ++++++++++++++++++
 .../step/branch/GroovyLocalTest.groovy          | 18 ++++++++++++++++++
 .../step/branch/GroovyRepeatTest.groovy         | 18 ++++++++++++++++++
 .../step/branch/GroovyUnionTest.groovy          | 18 ++++++++++++++++++
 .../traversal/step/filter/GroovyAndTest.groovy  | 18 ++++++++++++++++++
 .../traversal/step/filter/GroovyCoinTest.groovy | 18 ++++++++++++++++++
 .../step/filter/GroovyCyclicPathTest.groovy     | 18 ++++++++++++++++++
 .../step/filter/GroovyDedupTest.groovy          | 18 ++++++++++++++++++
 .../step/filter/GroovyExceptTest.groovy         | 18 ++++++++++++++++++
 .../step/filter/GroovyFilterTest.groovy         | 18 ++++++++++++++++++
 .../step/filter/GroovyHasNotTest.groovy         | 18 ++++++++++++++++++
 .../traversal/step/filter/GroovyHasTest.groovy  | 18 ++++++++++++++++++
 .../traversal/step/filter/GroovyIsTest.groovy   | 18 ++++++++++++++++++
 .../traversal/step/filter/GroovyOrTest.groovy   | 18 ++++++++++++++++++
 .../step/filter/GroovyRangeTest.groovy          | 18 ++++++++++++++++++
 .../step/filter/GroovyRetainTest.groovy         | 18 ++++++++++++++++++
 .../step/filter/GroovySampleTest.groovy         | 18 ++++++++++++++++++
 .../step/filter/GroovySimplePathTest.groovy     | 18 ++++++++++++++++++
 .../step/filter/GroovyWhereTest.groovy          | 18 ++++++++++++++++++
 .../traversal/step/map/GroovyBackTest.groovy    | 18 ++++++++++++++++++
 .../step/map/GroovyCoalesceTest.groovy          | 18 ++++++++++++++++++
 .../traversal/step/map/GroovyCountTest.groovy   | 18 ++++++++++++++++++
 .../traversal/step/map/GroovyFoldTest.groovy    | 18 ++++++++++++++++++
 .../traversal/step/map/GroovyMapTest.groovy     | 18 ++++++++++++++++++
 .../traversal/step/map/GroovyMatchTest.groovy   | 18 ++++++++++++++++++
 .../traversal/step/map/GroovyMaxTest.groovy     | 18 ++++++++++++++++++
 .../traversal/step/map/GroovyMeanTest.groovy    | 18 ++++++++++++++++++
 .../traversal/step/map/GroovyMinTest.groovy     | 18 ++++++++++++++++++
 .../traversal/step/map/GroovyOrderTest.groovy   | 18 ++++++++++++++++++
 .../traversal/step/map/GroovyPathTest.groovy    | 18 ++++++++++++++++++
 .../step/map/GroovyPropertiesTest.groovy        | 18 ++++++++++++++++++
 .../traversal/step/map/GroovySelectTest.groovy  | 18 ++++++++++++++++++
 .../traversal/step/map/GroovyUnfoldTest.groovy  | 18 ++++++++++++++++++
 .../step/map/GroovyValueMapTest.groovy          | 18 ++++++++++++++++++
 .../traversal/step/map/GroovyVertexTest.groovy  | 18 ++++++++++++++++++
 .../step/sideEffect/GroovyAddEdgeTest.groovy    | 18 ++++++++++++++++++
 .../step/sideEffect/GroovyAggregateTest.groovy  | 18 ++++++++++++++++++
 .../step/sideEffect/GroovyGroupCountTest.groovy | 18 ++++++++++++++++++
 .../step/sideEffect/GroovyGroupTest.groovy      | 18 ++++++++++++++++++
 .../step/sideEffect/GroovyInjectTest.groovy     | 18 ++++++++++++++++++
 .../step/sideEffect/GroovyProfileTest.groovy    | 18 ++++++++++++++++++
 .../step/sideEffect/GroovySackTest.groovy       | 18 ++++++++++++++++++
 .../sideEffect/GroovySideEffectCapTest.groovy   | 18 ++++++++++++++++++
 .../step/sideEffect/GroovySideEffectTest.groovy | 18 ++++++++++++++++++
 .../step/sideEffect/GroovyStoreTest.groovy      | 18 ++++++++++++++++++
 .../step/sideEffect/GroovySubgraphTest.groovy   | 18 ++++++++++++++++++
 .../step/sideEffect/GroovyTreeTest.groovy       | 18 ++++++++++++++++++
 .../groovy/GroovyEnvironmentIntegrateSuite.java | 18 ++++++++++++++++++
 .../gremlin/groovy/GroovyEnvironmentSuite.java  | 18 ++++++++++++++++++
 .../groovy/engine/GremlinExecutorTest.java      | 18 ++++++++++++++++++
 .../engine/GroovyTraversalScriptTest.java       | 18 ++++++++++++++++++
 .../GremlinGroovyScriptEngineIntegrateTest.java | 18 ++++++++++++++++++
 .../jsr223/GremlinGroovyScriptEngineTest.java   | 18 ++++++++++++++++++
 .../process/GroovyProcessComputerSuite.java     | 18 ++++++++++++++++++
 .../process/GroovyProcessStandardSuite.java     | 18 ++++++++++++++++++
 .../groovy/engine/GremlinExecutorInit.groovy    | 18 ++++++++++++++++++
 .../DefaultImportCustomizerProviderTest.java    | 18 ++++++++++++++++++
 gremlin-groovy/pom.xml                          | 17 ++++++++++++++++-
 .../gremlin/groovy/loaders/GremlinLoader.groovy | 18 ++++++++++++++++++
 .../gremlin/groovy/loaders/ObjectLoader.groovy  | 18 ++++++++++++++++++
 .../gremlin/groovy/loaders/StepLoader.groovy    | 18 ++++++++++++++++++
 .../gremlin/groovy/loaders/SugarLoader.groovy   | 18 ++++++++++++++++++
 .../groovy/util/DependencyGrabber.groovy        | 18 ++++++++++++++++++
 .../gremlin/groovy/util/MetaRegistryUtil.groovy | 18 ++++++++++++++++++
 .../AbstractImportCustomizerProvider.java       | 18 ++++++++++++++++++
 .../groovy/CompilerCustomizerProvider.java      | 18 ++++++++++++++++++
 .../groovy/DefaultImportCustomizerProvider.java | 18 ++++++++++++++++++
 .../groovy/EmptyImportCustomizerProvider.java   | 18 ++++++++++++++++++
 .../groovy/ImportCustomizerProvider.java        | 18 ++++++++++++++++++
 .../groovy/NoImportCustomizerProvider.java      | 18 ++++++++++++++++++
 .../groovy/SecurityCustomizerProvider.java      | 18 ++++++++++++++++++
 .../gremlin/groovy/engine/GremlinExecutor.java  | 18 ++++++++++++++++++
 .../groovy/engine/GroovyTraversalScript.java    | 18 ++++++++++++++++++
 .../gremlin/groovy/engine/ScriptEngines.java    | 18 ++++++++++++++++++
 .../gremlin/groovy/function/GComparator.java    | 18 ++++++++++++++++++
 .../gremlin/groovy/function/GFunction.java      | 18 ++++++++++++++++++
 .../groovy/jsr223/DependencyManager.java        | 18 ++++++++++++++++++
 .../groovy/jsr223/GremlinGroovyClassLoader.java | 18 ++++++++++++++++++
 .../jsr223/GremlinGroovyScriptEngine.java       | 18 ++++++++++++++++++
 .../GremlinGroovyScriptEngineFactory.java       | 18 ++++++++++++++++++
 .../jsr223/ManagedConcurrentValueMap.java       | 18 ++++++++++++++++++
 .../jsr223/ScriptEnginePluginAcceptor.java      | 18 ++++++++++++++++++
 .../gremlin/groovy/jsr223/ScriptExecutor.java   | 18 ++++++++++++++++++
 .../groovy/plugin/AbstractGremlinPlugin.java    | 18 ++++++++++++++++++
 .../gremlin/groovy/plugin/Artifact.java         | 18 ++++++++++++++++++
 .../gremlin/groovy/plugin/GremlinPlugin.java    | 18 ++++++++++++++++++
 .../groovy/plugin/GremlinPluginException.java   | 18 ++++++++++++++++++
 .../plugin/IllegalEnvironmentException.java     | 18 ++++++++++++++++++
 .../gremlin/groovy/plugin/PluginAcceptor.java   | 18 ++++++++++++++++++
 .../plugin/PluginInitializationException.java   | 18 ++++++++++++++++++
 .../gremlin/groovy/plugin/RemoteAcceptor.java   | 18 ++++++++++++++++++
 .../gremlin/groovy/plugin/RemoteException.java  | 18 ++++++++++++++++++
 .../groovy/plugin/SugarGremlinPlugin.java       | 18 ++++++++++++++++++
 gremlin-server/bin/gremlin-server.sh            | 20 +++++++++++++++++++-
 gremlin-server/conf/log4j-server.properties     | 16 ++++++++++++++++
 gremlin-server/conf/neo4j-empty.properties      | 16 ++++++++++++++++
 .../conf/tinkergraph-empty.properties           | 16 ++++++++++++++++
 gremlin-server/pom.xml                          | 17 ++++++++++++++++-
 gremlin-server/scripts/generate-classic.groovy  | 18 ++++++++++++++++++
 gremlin-server/scripts/generate-modern.groovy   | 18 ++++++++++++++++++
 gremlin-server/scripts/generate-sample.groovy   | 18 ++++++++++++++++++
 gremlin-server/scripts/sample.groovy            | 18 ++++++++++++++++++
 gremlin-server/src/assembly/distribution.xml    | 16 ++++++++++++++++
 gremlin-server/src/assembly/standalone.xml      | 16 ++++++++++++++++
 gremlin-server/src/main/bin/gremlin-server.sh   | 20 +++++++++++++++++++-
 .../gremlin/server/AbstractChannelizer.java     | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/server/Channelizer.java   | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/server/Context.java   | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/server/Graphs.java    | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/server/GremlinServer.java | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/server/OpProcessor.java   | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/server/Settings.java  | 18 ++++++++++++++++++
 .../gremlin/server/channel/HttpChannelizer.java | 18 ++++++++++++++++++
 .../gremlin/server/channel/NioChannelizer.java  | 18 ++++++++++++++++++
 .../server/channel/WebSocketChannelizer.java    | 18 ++++++++++++++++++
 .../handler/HttpGremlinEndpointHandler.java     | 18 ++++++++++++++++++
 .../gremlin/server/handler/IteratorHandler.java | 18 ++++++++++++++++++
 .../handler/NioGremlinBinaryRequestDecoder.java | 18 ++++++++++++++++++
 .../handler/NioGremlinResponseEncoder.java      | 18 ++++++++++++++++++
 .../server/handler/OpExecutorHandler.java       | 18 ++++++++++++++++++
 .../server/handler/OpSelectorHandler.java       | 18 ++++++++++++++++++
 .../gremlin/server/handler/StateKey.java        | 18 ++++++++++++++++++
 .../handler/WsGremlinBinaryRequestDecoder.java  | 18 ++++++++++++++++++
 .../handler/WsGremlinResponseEncoder.java       | 18 ++++++++++++++++++
 .../handler/WsGremlinTextRequestDecoder.java    | 18 ++++++++++++++++++
 .../server/op/AbstractEvalOpProcessor.java      | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/server/op/OpLoader.java   | 18 ++++++++++++++++++
 .../gremlin/server/op/OpProcessorException.java | 18 ++++++++++++++++++
 .../server/op/control/ControlOpProcessor.java   | 18 ++++++++++++++++++
 .../gremlin/server/op/control/ControlOps.java   | 18 ++++++++++++++++++
 .../gremlin/server/op/session/Session.java      | 18 ++++++++++++++++++
 .../server/op/session/SessionOpProcessor.java   | 18 ++++++++++++++++++
 .../gremlin/server/op/session/SessionOps.java   | 18 ++++++++++++++++++
 .../server/op/standard/StandardOpProcessor.java | 18 ++++++++++++++++++
 .../gremlin/server/op/standard/StandardOps.java | 18 ++++++++++++++++++
 .../server/util/GremlinServerInstall.java       | 18 ++++++++++++++++++
 .../gremlin/server/util/MetricManager.java      | 18 ++++++++++++++++++
 .../AbstractGremlinServerIntegrationTest.java   | 18 ++++++++++++++++++
 .../AbstractGremlinServerPerformanceTest.java   | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/server/GraphsTest.java    | 18 ++++++++++++++++++
 .../server/GremlinAdditionPerformanceTest.java  | 18 ++++++++++++++++++
 .../server/GremlinDriverIntegrateTest.java      | 18 ++++++++++++++++++
 .../server/GremlinServerHttpIntegrateTest.java  | 18 ++++++++++++++++++
 .../server/GremlinServerIntegrateTest.java      | 18 ++++++++++++++++++
 .../server/GremlinTraversalPerformanceTest.java | 18 ++++++++++++++++++
 .../src/test/resources/application.conf         | 17 +++++++++++++++++
 gremlin-server/src/test/resources/gatling.conf  | 17 +++++++++++++++++
 .../src/test/resources/logback-test.xml         | 17 ++++++++++++++++-
 .../GremlinServerAdditionSimulation.scala       | 18 ++++++++++++++++++
 gremlin-test/pom.xml                            | 17 ++++++++++++++++-
 .../gremlin/AbstractGraphProvider.java          | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/AbstractGremlinSuite.java | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/AbstractGremlinTest.java  | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/ExceptionCoverage.java    | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/ExceptionCoverageSet.java | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/FeatureRequirement.java   | 18 ++++++++++++++++++
 .../gremlin/FeatureRequirementSet.java          | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/FeatureRequirements.java  | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/GraphManager.java     | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/GraphProvider.java    | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/LoadGraphWith.java    | 18 ++++++++++++++++++
 .../java/com/tinkerpop/gremlin/TestHelper.java  | 18 ++++++++++++++++++
 .../generator/AbstractGeneratorTest.java        | 18 ++++++++++++++++++
 .../generator/CommunityGeneratorTest.java       | 18 ++++++++++++++++++
 .../generator/DistributionGeneratorTest.java    | 18 ++++++++++++++++++
 .../process/AbstractGremlinProcessTest.java     | 18 ++++++++++++++++++
 .../gremlin/process/ProcessComputerSuite.java   | 18 ++++++++++++++++++
 .../process/ProcessPerformanceSuite.java        | 18 ++++++++++++++++++
 .../gremlin/process/ProcessStandardSuite.java   | 18 ++++++++++++++++++
 .../process/TraversalPerformanceTest.java       | 18 ++++++++++++++++++
 .../process/computer/GraphComputerTest.java     | 18 ++++++++++++++++++
 .../ranking/PageRankVertexProgramTest.java      | 18 ++++++++++++++++++
 .../computer/util/ComputerDataStrategyTest.java | 18 ++++++++++++++++++
 .../graph/traversal/step/branch/BranchTest.java | 18 ++++++++++++++++++
 .../graph/traversal/step/branch/ChooseTest.java | 18 ++++++++++++++++++
 .../graph/traversal/step/branch/LocalTest.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/branch/RepeatTest.java | 18 ++++++++++++++++++
 .../graph/traversal/step/branch/UnionTest.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/AndTest.java    | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/CoinTest.java   | 18 ++++++++++++++++++
 .../traversal/step/filter/CyclicPathTest.java   | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/DedupTest.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/ExceptTest.java | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/FilterTest.java | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/HasNotTest.java | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/HasTest.java    | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/IsTest.java     | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/OrTest.java     | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/RangeTest.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/RetainTest.java | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/SampleTest.java | 18 ++++++++++++++++++
 .../traversal/step/filter/SimplePathTest.java   | 18 ++++++++++++++++++
 .../graph/traversal/step/filter/WhereTest.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/map/BackTest.java      | 18 ++++++++++++++++++
 .../graph/traversal/step/map/CoalesceTest.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/map/CountTest.java     | 18 ++++++++++++++++++
 .../graph/traversal/step/map/FoldTest.java      | 18 ++++++++++++++++++
 .../graph/traversal/step/map/MapTest.java       | 18 ++++++++++++++++++
 .../graph/traversal/step/map/MatchTest.java     | 18 ++++++++++++++++++
 .../graph/traversal/step/map/MaxTest.java       | 18 ++++++++++++++++++
 .../graph/traversal/step/map/MeanTest.java      | 18 ++++++++++++++++++
 .../graph/traversal/step/map/MinTest.java       | 18 ++++++++++++++++++
 .../graph/traversal/step/map/OrderTest.java     | 18 ++++++++++++++++++
 .../graph/traversal/step/map/PathTest.java      | 18 ++++++++++++++++++
 .../traversal/step/map/PropertiesTest.java      | 18 ++++++++++++++++++
 .../graph/traversal/step/map/SelectTest.java    | 18 ++++++++++++++++++
 .../graph/traversal/step/map/UnfoldTest.java    | 18 ++++++++++++++++++
 .../graph/traversal/step/map/ValueMapTest.java  | 18 ++++++++++++++++++
 .../graph/traversal/step/map/VertexTest.java    | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/AddEdgeTest.java  | 18 ++++++++++++++++++
 .../step/sideEffect/AggregateTest.java          | 18 ++++++++++++++++++
 .../step/sideEffect/GroupCountTest.java         | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/GroupTest.java    | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/InjectTest.java   | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/ProfileTest.java  | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/SackTest.java     | 18 ++++++++++++++++++
 .../step/sideEffect/SideEffectCapTest.java      | 18 ++++++++++++++++++
 .../step/sideEffect/SideEffectTest.java         | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/StoreTest.java    | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/SubgraphTest.java | 18 ++++++++++++++++++
 .../traversal/step/sideEffect/TreeTest.java     | 18 ++++++++++++++++++
 .../step/util/TraversalSideEffectsTest.java     | 18 ++++++++++++++++++
 .../TraversalVerificationStrategyTest.java      | 18 ++++++++++++++++++
 .../process/traversal/CoreTraversalTest.java    | 18 ++++++++++++++++++
 .../process/traversal/DefaultTraversalTest.java | 18 ++++++++++++++++++
 .../gremlin/process/util/PathTest.java          | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/structure/BatchTest.java  | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/structure/EdgeTest.java   | 18 ++++++++++++++++++
 .../gremlin/structure/FeatureSupportTest.java   | 18 ++++++++++++++++++
 .../structure/GraphConstructionTest.java        | 18 ++++++++++++++++++
 .../structure/GraphReadPerformanceTest.java     | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/structure/GraphTest.java  | 18 ++++++++++++++++++
 .../structure/GraphWritePerformanceTest.java    | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/structure/IoTest.java | 18 ++++++++++++++++++
 .../gremlin/structure/MockSerializable.java     | 18 ++++++++++++++++++
 .../gremlin/structure/PropertyTest.java         | 18 ++++++++++++++++++
 .../gremlin/structure/SerializationTest.java    | 18 ++++++++++++++++++
 .../structure/StructurePerformanceSuite.java    | 18 ++++++++++++++++++
 .../structure/StructureStandardSuite.java       | 18 ++++++++++++++++++
 .../gremlin/structure/TransactionTest.java      | 18 ++++++++++++++++++
 .../gremlin/structure/VariablesTest.java        | 18 ++++++++++++++++++
 .../gremlin/structure/VertexPropertyTest.java   | 18 ++++++++++++++++++
 .../tinkerpop/gremlin/structure/VertexTest.java | 18 ++++++++++++++++++
 .../io/graphml/GraphMLResourceAccess.java       | 18 ++++++++++++++++++
 .../io/graphson/GraphSONResourceAccess.java     | 18 ++++++++++++++++++
 .../structure/io/kryo/KryoResourceAccess.java   | 18 ++++++++++++++++++
 .../io/script/ScriptResourceAccess.java         | 18 ++++++++++++++++++
 .../structure/strategy/IdStrategyTest.java      | 18 ++++++++++++++++++
 .../strategy/PartitionStrategyTest.java         | 18 ++++++++++++++++++
 .../strategy/ReadOnlyStrategyTest.java          | 18 ++++++++++++++++++
 .../strategy/SequenceStrategyTest.java          | 18 ++++++++++++++++++
 .../structure/strategy/StrategyGraphTest.java   | 18 ++++++++++++++++++
 .../strategy/SubgraphStrategyTest.java          | 18 ++++++++++++++++++
 .../util/detached/DetachedEdgeTest.java         | 18 ++++++++++++++++++
 .../util/detached/DetachedPropertyTest.java     | 18 ++++++++++++++++++
 .../detached/DetachedVertexPropertyTest.java    | 18 ++++++++++++++++++
 .../util/detached/DetachedVertexTest.java       | 18 ++++++++++++++++++
 .../structure/io/graphml/graph-types.xml        | 17 ++++++++++++++++-
 .../structure/io/graphml/graphml-1.1.xsd        | 17 ++++++++++++++++-
 .../structure/io/graphml/grateful-dead.xml      | 18 +++++++++++++++++-
 .../structure/io/graphml/tinkerpop-classic.xml  | 18 +++++++++++++++++-
 .../structure/io/graphml/tinkerpop-modern.xml   | 18 +++++++++++++++++-
 .../structure/io/script/script-input.groovy     | 18 ++++++++++++++++++
 .../structure/io/script/script-output.groovy    | 18 ++++++++++++++++++
 .../process/TraversalStrategiesTest.java        | 18 ++++++++++++++++++
 .../process/graph/step/util/TreeTest.java       | 18 ++++++++++++++++++
 .../traversal/GraphTraversalMethodsTest.java    | 18 ++++++++++++++++++
 .../gremlin/process/util/BulkSetTest.java       | 18 ++++++++++++++++++
 .../process/util/TraversalHelperTest.java       | 18 ++++++++++++++++++
 .../gremlin/structure/CompareTest.java          | 18 ++++++++++++++++++
 .../structure/ExceptionCoverageTest.java        | 18 ++++++++++++++++++
 .../structure/FeaturesConventionTest.java       | 18 ++++++++++++++++++
 .../gremlin/structure/GraphHiddenTest.java      | 18 ++++++++++++++++++
 .../structure/io/kryo/KryoMapperTest.java       | 18 ++++++++++++++++++
 .../structure/util/ElementHelperTest.java       | 18 ++++++++++++++++++
 .../util/config/YamlConfigurationTest.java      | 18 ++++++++++++++++++
 .../gremlin/util/function/TriConsumerTest.java  | 18 ++++++++++++++++++
 .../gremlin/util/function/TriFunctionTest.java  | 18 ++++++++++++++++++
 hadoop-gremlin/conf/hadoop-graphson.properties  | 17 +++++++++++++++++
 hadoop-gremlin/conf/hadoop-kryo.properties      | 16 ++++++++++++++++
 hadoop-gremlin/pom.xml                          | 17 ++++++++++++++++-
 hadoop-gremlin/src/assembly/hadoop-job.xml      | 16 ++++++++++++++++
 hadoop-gremlin/src/assembly/standalone.xml      | 16 ++++++++++++++++
 .../hadoop/groovy/plugin/HadoopLoader.groovy    | 18 ++++++++++++++++++
 .../com/tinkerpop/gremlin/hadoop/Constants.java | 18 ++++++++++++++++++
 .../groovy/plugin/HadoopGremlinPlugin.java      | 18 ++++++++++++++++++
 .../groovy/plugin/HadoopRemoteAcceptor.java     | 18 ++++++++++++++++++
 .../hadoop/process/computer/HadoopCombine.java  | 18 ++++++++++++++++++
 .../hadoop/process/computer/HadoopMap.java      | 18 ++++++++++++++++++
 .../hadoop/process/computer/HadoopReduce.java   | 18 ++++++++++++++++++
 .../computer/example/TraversalSupplier1.java    | 18 ++++++++++++++++++
 .../computer/example/TraversalSupplier2.java    | 18 ++++++++++++++++++
 .../computer/example/TraversalSupplier3.java    | 18 ++++++++++++++++++
 .../process/computer/giraph/EmptyOutEdges.java  | 18 ++++++++++++++++++
 .../computer/giraph/GiraphComputeVertex.java    | 18 ++++++++++++++++++
 .../computer/giraph/GiraphGraphComputer.java    | 18 ++++++++++++++++++
 .../process/computer/giraph/GiraphMemory.java   | 18 ++++++++++++++++++
 .../computer/giraph/GiraphMessageCombiner.java  | 18 ++++++++++++++++++
 .../computer/giraph/GiraphMessenger.java        | 18 ++++++++++++++++++
 .../computer/giraph/GiraphWorkerContext.java    | 18 ++++++++++++++++++
 .../computer/giraph/MemoryAggregator.java       | 18 ++++++++++++++++++
 .../process/computer/giraph/RuleWritable.java   | 18 ++++++++++++++++++
 .../giraph/io/GiraphVertexInputFormat.java      | 18 ++++++++++++++++++
 .../giraph/io/GiraphVertexOutputFormat.java     | 18 ++++++++++++++++++
 .../computer/giraph/io/GiraphVertexReader.java  | 18 ++++++++++++++++++
 .../computer/giraph/io/GiraphVertexWriter.java  | 18 ++++++++++++++++++
 .../mapreduce/MapReduceGraphComputer.java       | 18 ++++++++++++++++++
 .../process/computer/util/MapReduceHelper.java  | 18 ++++++++++++++++++
 .../process/computer/util/MemoryMapReduce.java  | 18 ++++++++++++++++++
 .../strategy/HadoopElementStepStrategy.java     | 18 ++++++++++++++++++
 .../hadoop/structure/HadoopConfiguration.java   | 18 ++++++++++++++++++
 .../gremlin/hadoop/structure/HadoopEdge.java    | 18 ++++++++++++++++++
 .../gremlin/hadoop/structure/HadoopElement.java | 18 ++++++++++++++++++
 .../gremlin/hadoop/structure/HadoopGraph.java   | 18 ++++++++++++++++++
 .../hadoop/structure/HadoopGraphVariables.java  | 18 ++++++++++++++++++
 .../hadoop/structure/HadoopProperty.java        | 18 ++++++++++++++++++
 .../gremlin/hadoop/structure/HadoopVertex.java  | 18 ++++++++++++++++++
 .../hadoop/structure/HadoopVertexProperty.java  | 18 ++++++++++++++++++
 .../hadoop/structure/hdfs/HDFSTools.java        | 18 ++++++++++++++++++
 .../structure/hdfs/HadoopEdgeIterator.java      | 18 ++++++++++++++++++
 .../structure/hdfs/HadoopElementIterator.java   | 18 ++++++++++++++++++
 .../structure/hdfs/HadoopVertexIterator.java    | 18 ++++++++++++++++++
 .../hadoop/structure/hdfs/HiddenFileFilter.java | 18 ++++++++++++++++++
 .../hadoop/structure/hdfs/TextIterator.java     | 18 ++++++++++++++++++
 .../structure/io/CommonFileOutputFormat.java    | 18 ++++++++++++++++++
 .../hadoop/structure/io/ObjectWritable.java     | 18 ++++++++++++++++++
 .../structure/io/ObjectWritableComparator.java  | 18 ++++++++++++++++++
 .../structure/io/ObjectWritableIterator.java    | 18 ++++++++++++++++++
 .../hadoop/structure/io/VertexWritable.java     | 18 ++++++++++++++++++
 .../io/graphson/GraphSONInputFormat.java        | 18 ++++++++++++++++++
 .../io/graphson/GraphSONOutputFormat.java       | 18 ++++++++++++++++++
 .../io/graphson/GraphSONRecordReader.java       | 18 ++++++++++++++++++
 .../io/graphson/GraphSONRecordWriter.java       | 18 ++++++++++++++++++
 .../structure/io/kryo/KryoInputFormat.java      | 18 ++++++++++++++++++
 .../structure/io/kryo/KryoOutputFormat.java     | 18 ++++++++++++++++++
 .../structure/io/kryo/KryoRecordReader.java     | 18 ++++++++++++++++++
 .../structure/io/kryo/KryoRecordWriter.java     | 18 ++++++++++++++++++
 .../structure/io/kryo/VertexStreamIterator.java | 18 ++++++++++++++++++
 .../structure/io/script/ScriptInputFormat.java  | 18 ++++++++++++++++++
 .../structure/io/script/ScriptOutputFormat.java | 18 ++++++++++++++++++
 .../structure/io/script/ScriptRecordReader.java | 18 ++++++++++++++++++
 .../structure/io/script/ScriptRecordWriter.java | 18 ++++++++++++++++++
 .../gremlin/hadoop/structure/util/ConfUtil.java | 18 ++++++++++++++++++
 .../hadoop/structure/util/HadoopHelper.java     | 18 ++++++++++++++++++
 .../gremlin/hadoop/HadoopGraphProvider.java     | 18 ++++++++++++++++++
 .../process/HadoopGraphProcessStandardTest.java | 18 ++++++++++++++++++
 ...GraphGroovyProcessComputerIntegrateTest.java | 18 ++++++++++++++++++
 .../HadoopGraphGroovyProcessStandardTest.java   | 18 ++++++++++++++++++
 .../io/HadoopGraphStructureStandardTest.java    | 18 ++++++++++++++++++
 .../GraphSONRecordReaderWriterTest.java         | 18 ++++++++++++++++++
 .../io/graphson/VertexStreamIteratorTest.java   | 18 ++++++++++++++++++
 .../io/kryo/KryoRecordReaderWriterTest.java     | 18 ++++++++++++++++++
 .../io/script/ScriptRecordReaderWriterTest.java | 18 ++++++++++++++++++
 neo4j-gremlin/pom.xml                           | 17 ++++++++++++++++-
 .../neo4j/groovy/plugin/Neo4jGremlinPlugin.java | 18 ++++++++++++++++++
 .../step/sideEffect/Neo4jGraphStep.java         | 18 ++++++++++++++++++
 .../step/util/Neo4jCypherIterator.java          | 18 ++++++++++++++++++
 .../strategy/Neo4jGraphStepStrategy.java        | 18 ++++++++++++++++++
 .../gremlin/neo4j/structure/Neo4jEdge.java      | 18 ++++++++++++++++++
 .../gremlin/neo4j/structure/Neo4jElement.java   | 18 ++++++++++++++++++
 .../gremlin/neo4j/structure/Neo4jGraph.java     | 18 ++++++++++++++++++
 .../neo4j/structure/Neo4jGraphVariables.java    | 18 ++++++++++++++++++
 .../gremlin/neo4j/structure/Neo4jHelper.java    | 18 ++++++++++++++++++
 .../gremlin/neo4j/structure/Neo4jProperty.java  | 18 ++++++++++++++++++
 .../gremlin/neo4j/structure/Neo4jVertex.java    | 18 ++++++++++++++++++
 .../neo4j/structure/Neo4jVertexProperty.java    | 18 ++++++++++++++++++
 .../neo4j/AbstractNeo4jGraphProvider.java       | 18 ++++++++++++++++++
 .../gremlin/neo4j/BaseNeo4jGraphTest.java       | 18 ++++++++++++++++++
 .../neo4j/DefaultNeo4jGraphProvider.java        | 18 ++++++++++++++++++
 .../NoMetaMultiPropertyNeo4jGraphProvider.java  | 18 ++++++++++++++++++
 .../neo4j/process/Neo4jCypherStartTest.java     | 18 ++++++++++++++++++
 .../process/Neo4jGraphProcessStandardTest.java  | 18 ++++++++++++++++++
 .../Neo4jGraphGroovyProcessStandardTest.java    | 18 ++++++++++++++++++
 .../Neo4jGraphStructureStandardTest.java        | 18 ++++++++++++++++++
 .../gremlin/neo4j/structure/Neo4jGraphTest.java | 18 ++++++++++++++++++
 ...eo4jGraphStructureStandardIntegrateTest.java | 18 ++++++++++++++++++
 pom.xml                                         | 17 ++++++++++++++++-
 tinkergraph-gremlin/pom.xml                     | 17 ++++++++++++++++-
 .../groovy/plugin/TinkerGraphGremlinPlugin.java | 18 ++++++++++++++++++
 .../process/computer/TinkerGraphComputer.java   | 18 ++++++++++++++++++
 .../process/computer/TinkerGraphView.java       | 18 ++++++++++++++++++
 .../process/computer/TinkerMapEmitter.java      | 18 ++++++++++++++++++
 .../process/computer/TinkerMemory.java          | 18 ++++++++++++++++++
 .../process/computer/TinkerMessageBoard.java    | 18 ++++++++++++++++++
 .../process/computer/TinkerMessenger.java       | 18 ++++++++++++++++++
 .../process/computer/TinkerReduceEmitter.java   | 18 ++++++++++++++++++
 .../process/computer/TinkerWorkerPool.java      | 18 ++++++++++++++++++
 .../traversal/sideEffect/TinkerGraphStep.java   | 18 ++++++++++++++++++
 .../strategy/TinkerElementStepStrategy.java     | 18 ++++++++++++++++++
 .../strategy/TinkerGraphStepStrategy.java       | 18 ++++++++++++++++++
 .../tinkergraph/structure/TinkerEdge.java       | 18 ++++++++++++++++++
 .../tinkergraph/structure/TinkerElement.java    | 18 ++++++++++++++++++
 .../tinkergraph/structure/TinkerFactory.java    | 18 ++++++++++++++++++
 .../tinkergraph/structure/TinkerGraph.java      | 18 ++++++++++++++++++
 .../structure/TinkerGraphVariables.java         | 18 ++++++++++++++++++
 .../tinkergraph/structure/TinkerHelper.java     | 18 ++++++++++++++++++
 .../tinkergraph/structure/TinkerIndex.java      | 18 ++++++++++++++++++
 .../tinkergraph/structure/TinkerProperty.java   | 18 ++++++++++++++++++
 .../tinkergraph/structure/TinkerVertex.java     | 18 ++++++++++++++++++
 .../structure/TinkerVertexProperty.java         | 18 ++++++++++++++++++
 .../structure/GroovyTinkerGraphTest.groovy      | 18 ++++++++++++++++++
 .../tinkergraph/TinkerGraphGraphProvider.java   | 18 ++++++++++++++++++
 .../process/TinkerGraphProcessComputerTest.java | 18 ++++++++++++++++++
 .../TinkerGraphProcessPerformanceTest.java      | 18 ++++++++++++++++++
 .../process/TinkerGraphProcessStandardTest.java | 18 ++++++++++++++++++
 .../TinkerGraphGroovyProcessComputerTest.java   | 18 ++++++++++++++++++
 .../TinkerGraphGroovyProcessStandardTest.java   | 18 ++++++++++++++++++
 .../TinkerGraphStructurePerformanceTest.java    | 18 ++++++++++++++++++
 .../TinkerGraphStructureStandardTest.java       | 18 ++++++++++++++++++
 .../tinkergraph/structure/TinkerGraphTest.java  | 18 ++++++++++++++++++
 ...nkerGraphGroovyEnvironmentIntegrateTest.java | 18 ++++++++++++++++++
 .../TinkerGraphGroovyEnvironmentTest.java       | 18 ++++++++++++++++++
 856 files changed, 15352 insertions(+), 20 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/bin/bump.sh
----------------------------------------------------------------------
diff --git a/bin/bump.sh b/bin/bump.sh
index 9dde49c..a5dea43 100755
--- a/bin/bump.sh
+++ b/bin/bump.sh
@@ -1,4 +1,23 @@
 #!/bin/bash
+#
+#
+# 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.
+#
 
 # This script bumps version in the various files that reference the current TinkerPop version files (e.g. pom.xml)
 # in preparation for release. Usage:

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/bin/clean-grapes.sh
----------------------------------------------------------------------
diff --git a/bin/clean-grapes.sh b/bin/clean-grapes.sh
index 2ad0a1e..3467db2 100755
--- a/bin/clean-grapes.sh
+++ b/bin/clean-grapes.sh
@@ -1,4 +1,23 @@
 #!/bin/bash
+#
+#
+# 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.
+#
 
 # This script removes the com.tinkerpop directory from the "grapes" directory. This
 # script assumes that an environment variable of GROOVY_GRAPES is set with the location

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/bin/gremlin-server.sh
----------------------------------------------------------------------
diff --git a/bin/gremlin-server.sh b/bin/gremlin-server.sh
index 738033e..ad24926 100755
--- a/bin/gremlin-server.sh
+++ b/bin/gremlin-server.sh
@@ -1,3 +1,22 @@
 #!/bin/bash
+#
+#
+# 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.
+#
 
 (cd `dirname $0`/../gremlin-server/ && bin/gremlin-server.sh $@)

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/bin/gremlin.sh
----------------------------------------------------------------------
diff --git a/bin/gremlin.sh b/bin/gremlin.sh
index efb690e..512f71f 100755
--- a/bin/gremlin.sh
+++ b/bin/gremlin.sh
@@ -1,3 +1,22 @@
 #!/bin/bash
+#
+#
+# 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.
+#
 
 `dirname $0`/../gremlin-console/bin/gremlin.sh $@

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/bin/publish-docs.sh
----------------------------------------------------------------------
diff --git a/bin/publish-docs.sh b/bin/publish-docs.sh
index 5a2b5cb..cc36644 100755
--- a/bin/publish-docs.sh
+++ b/bin/publish-docs.sh
@@ -1,4 +1,23 @@
 #!/bin/bash
+#
+#
+# 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.
+#
 
 git checkout publish-docs
 git fetch origin

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-algorithm/pom.xml
----------------------------------------------------------------------
diff --git a/gremlin-algorithm/pom.xml b/gremlin-algorithm/pom.xml
index dcccd4e..2a096d7 100644
--- a/gremlin-algorithm/pom.xml
+++ b/gremlin-algorithm/pom.xml
@@ -1,4 +1,19 @@
-<?xml version="1.0" encoding="UTF-8"?>
+<!--
+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.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0"
          xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
          xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/AbstractGenerator.java
----------------------------------------------------------------------
diff --git a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/AbstractGenerator.java b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/AbstractGenerator.java
index 0e109b4..9dd3684 100644
--- a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/AbstractGenerator.java
+++ b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/AbstractGenerator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 com.tinkerpop.gremlin.algorithm.generator;
 
 import com.tinkerpop.gremlin.structure.Edge;

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/CommunityGenerator.java
----------------------------------------------------------------------
diff --git a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/CommunityGenerator.java b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/CommunityGenerator.java
index c952244..cd3f8f9 100644
--- a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/CommunityGenerator.java
+++ b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/CommunityGenerator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 com.tinkerpop.gremlin.algorithm.generator;
 
 import com.tinkerpop.gremlin.structure.Edge;

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/CopyDistribution.java
----------------------------------------------------------------------
diff --git a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/CopyDistribution.java b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/CopyDistribution.java
index 560b75f..8a3cdec 100644
--- a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/CopyDistribution.java
+++ b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/CopyDistribution.java
@@ -1,3 +1,21 @@
+/*
+ * 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 com.tinkerpop.gremlin.algorithm.generator;
 
 import java.util.Random;

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/Distribution.java
----------------------------------------------------------------------
diff --git a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/Distribution.java b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/Distribution.java
index 329623c..46bae25 100644
--- a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/Distribution.java
+++ b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/Distribution.java
@@ -1,3 +1,21 @@
+/*
+ * 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 com.tinkerpop.gremlin.algorithm.generator;
 
 import java.util.Random;

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/DistributionGenerator.java
----------------------------------------------------------------------
diff --git a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/DistributionGenerator.java b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/DistributionGenerator.java
index b132bfd..35ae0da 100644
--- a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/DistributionGenerator.java
+++ b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/DistributionGenerator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 com.tinkerpop.gremlin.algorithm.generator;
 
 import com.tinkerpop.gremlin.structure.Edge;

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/Generator.java
----------------------------------------------------------------------
diff --git a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/Generator.java b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/Generator.java
index 657aa4c..fc2ac41 100644
--- a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/Generator.java
+++ b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/Generator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 com.tinkerpop.gremlin.algorithm.generator;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/NormalDistribution.java
----------------------------------------------------------------------
diff --git a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/NormalDistribution.java b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/NormalDistribution.java
index d96e3f5..3a9f391 100644
--- a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/NormalDistribution.java
+++ b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/NormalDistribution.java
@@ -1,3 +1,21 @@
+/*
+ * 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 com.tinkerpop.gremlin.algorithm.generator;
 
 import java.util.Random;

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/PowerLawDistribution.java
----------------------------------------------------------------------
diff --git a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/PowerLawDistribution.java b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/PowerLawDistribution.java
index 85d4e89..d197561 100644
--- a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/PowerLawDistribution.java
+++ b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/PowerLawDistribution.java
@@ -1,3 +1,21 @@
+/*
+ * 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 com.tinkerpop.gremlin.algorithm.generator;
 
 import java.util.Random;

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/SizableIterable.java
----------------------------------------------------------------------
diff --git a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/SizableIterable.java b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/SizableIterable.java
index 263ac26..4fed416 100644
--- a/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/SizableIterable.java
+++ b/gremlin-algorithm/src/main/java/com/tinkerpop/gremlin/algorithm/generator/SizableIterable.java
@@ -1,3 +1,21 @@
+/*
+ * 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 com.tinkerpop.gremlin.algorithm.generator;
 
 import java.util.Collection;

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-console/pom.xml
----------------------------------------------------------------------
diff --git a/gremlin-console/pom.xml b/gremlin-console/pom.xml
index cfc6e7f..d0711ba 100644
--- a/gremlin-console/pom.xml
+++ b/gremlin-console/pom.xml
@@ -1,4 +1,19 @@
-<?xml version="1.0" encoding="UTF-8"?>
+<!--
+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.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0"
          xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
          xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-console/src/assembly/distribution.xml
----------------------------------------------------------------------
diff --git a/gremlin-console/src/assembly/distribution.xml b/gremlin-console/src/assembly/distribution.xml
index fab040b..a155705 100644
--- a/gremlin-console/src/assembly/distribution.xml
+++ b/gremlin-console/src/assembly/distribution.xml
@@ -1,3 +1,19 @@
+<!--
+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.
+-->
 <assembly>
     <id>distribution</id>
     <formats>

http://git-wip-us.apache.org/repos/asf/incubator-tinkerpop/blob/8dd1b91a/gremlin-console/src/assembly/standalone.xml
----------------------------------------------------------------------
diff --git a/gremlin-console/src/assembly/standalone.xml b/gremlin-console/src/assembly/standalone.xml
index 8ca6823..96c519a 100644
--- a/gremlin-console/src/assembly/standalone.xml
+++ b/gremlin-console/src/assembly/standalone.xml
@@ -1,3 +1,19 @@
+<!--
+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.
+-->
 <assembly>
     <id>standalone</id>
     <formats>