http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphMemory.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphMemory.java
 
b/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphMemory.java
deleted file mode 100644
index 56428f3..0000000
--- 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphMemory.java
+++ /dev/null
@@ -1,198 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph.process.computer;
-
-import org.apache.commons.configuration.Configuration;
-import org.apache.giraph.master.MasterCompute;
-import org.apache.hadoop.fs.FileSystem;
-import org.apache.hadoop.fs.Path;
-import org.apache.hadoop.io.SequenceFile;
-import org.apache.tinkerpop.gremlin.hadoop.Constants;
-import org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph;
-import org.apache.tinkerpop.gremlin.hadoop.structure.io.ObjectWritable;
-import org.apache.tinkerpop.gremlin.hadoop.structure.util.ConfUtil;
-import org.apache.tinkerpop.gremlin.process.computer.GraphComputer;
-import org.apache.tinkerpop.gremlin.process.computer.Memory;
-import org.apache.tinkerpop.gremlin.process.computer.MemoryComputeKey;
-import org.apache.tinkerpop.gremlin.process.computer.VertexProgram;
-import org.apache.tinkerpop.gremlin.process.computer.util.MemoryHelper;
-import org.apache.tinkerpop.gremlin.structure.util.StringFactory;
-import org.javatuples.Pair;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.HashMap;
-import java.util.Map;
-import java.util.Set;
-import java.util.function.BinaryOperator;
-import java.util.stream.Collectors;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public final class GiraphMemory extends MasterCompute implements Memory {
-
-    private VertexProgram<?> vertexProgram;
-    private GiraphWorkerContext worker;
-    private Map<String, MemoryComputeKey> memoryComputeKeys;
-    private boolean inExecute = false;
-    private long startTime = System.currentTimeMillis();
-
-    public GiraphMemory() {
-        // Giraph ReflectionUtils requires this to be public at minimum
-    }
-
-    public GiraphMemory(final GiraphWorkerContext worker, final 
VertexProgram<?> vertexProgram) {
-        this.worker = worker;
-        this.vertexProgram = vertexProgram;
-        this.memoryComputeKeys = new HashMap<>();
-        this.vertexProgram.getMemoryComputeKeys().forEach(key -> 
this.memoryComputeKeys.put(key.getKey(), key));
-        this.inExecute = true;
-    }
-
-
-    @Override
-    public void initialize() {
-        // do not initialize aggregators here because the getConf() 
configuration is not available at this point
-        // use compute() initial iteration instead
-    }
-
-    @Override
-    public void compute() {
-        this.inExecute = false;
-        if (0 == this.getSuperstep()) { // setup
-            final Configuration apacheConfiguration = 
ConfUtil.makeApacheConfiguration(this.getConf());
-            this.vertexProgram = 
VertexProgram.createVertexProgram(HadoopGraph.open(apacheConfiguration), 
apacheConfiguration);
-            this.memoryComputeKeys = new HashMap<>();
-            this.vertexProgram.getMemoryComputeKeys().forEach(key -> 
this.memoryComputeKeys.put(key.getKey(), key));
-            try {
-                for (final MemoryComputeKey key : 
this.memoryComputeKeys.values()) {
-                    this.registerPersistentAggregator(key.getKey(), 
MemoryAggregator.class);
-                }
-            } catch (final Exception e) {
-                throw new IllegalStateException(e.getMessage(), e);
-            }
-            this.vertexProgram.setup(this);
-        } else {
-            // a hack to get the last iteration memory values to stick
-            final PassThroughMemory memory = new PassThroughMemory(this);
-            if (this.vertexProgram.terminate(memory)) { // terminate
-                final String outputLocation = 
this.getConf().get(Constants.GREMLIN_HADOOP_OUTPUT_LOCATION, null);
-                if (null != outputLocation) {
-                    try {
-                        for (final String key : this.keys()) {
-                            if 
(!this.memoryComputeKeys.get(key).isTransient()) { // do not write transient 
memory keys to disk
-                                final SequenceFile.Writer writer = 
SequenceFile.createWriter(FileSystem.get(this.getConf()), this.getConf(), new 
Path(outputLocation + "/" + key), ObjectWritable.class, ObjectWritable.class);
-                                
writer.append(ObjectWritable.getNullObjectWritable(), new 
ObjectWritable<>(memory.get(key)));
-                                writer.close();
-                            }
-                        }
-                        // written for GiraphGraphComputer to read and then is 
deleted by GiraphGraphComputer
-                        final SequenceFile.Writer writer = 
SequenceFile.createWriter(FileSystem.get(this.getConf()), this.getConf(), new 
Path(outputLocation + "/" + Constants.HIDDEN_ITERATION), ObjectWritable.class, 
ObjectWritable.class);
-                        writer.append(ObjectWritable.getNullObjectWritable(), 
new ObjectWritable<>(memory.getIteration()));
-                        writer.close();
-                    } catch (final Exception e) {
-                        throw new IllegalStateException(e.getMessage(), e);
-                    }
-                }
-                this.haltComputation();
-            }
-        }
-    }
-
-    @Override
-    public int getIteration() {
-        if (this.inExecute) {
-            return (int) this.worker.getSuperstep();
-        } else {
-            final int temp = (int) this.getSuperstep();
-            return temp == 0 ? temp : temp - 1;
-        }
-    }
-
-    @Override
-    public long getRuntime() {
-        return System.currentTimeMillis() - this.startTime;
-    }
-
-    @Override
-    public Set<String> keys() {
-        return this.memoryComputeKeys.values().stream().filter(key -> 
this.exists(key.getKey())).map(MemoryComputeKey::getKey).collect(Collectors.toSet());
-    }
-
-    @Override
-    public boolean exists(final String key) {
-        if (this.inExecute && this.memoryComputeKeys.containsKey(key) && 
!this.memoryComputeKeys.get(key).isBroadcast())
-            return false;
-        final ObjectWritable value = this.inExecute ? 
this.worker.getAggregatedValue(key) : this.getAggregatedValue(key);
-        return null != value && !value.isEmpty();
-    }
-
-    @Override
-    public <R> R get(final String key) throws IllegalArgumentException {
-        if (!this.memoryComputeKeys.containsKey(key))
-            throw Memory.Exceptions.memoryDoesNotExist(key);
-        if (this.inExecute && !this.memoryComputeKeys.get(key).isBroadcast())
-            throw Memory.Exceptions.memoryDoesNotExist(key);
-        final ObjectWritable<Pair<BinaryOperator, Object>> value = 
this.inExecute ?
-                this.worker.<ObjectWritable<Pair<BinaryOperator, 
Object>>>getAggregatedValue(key) :
-                this.<ObjectWritable<Pair<BinaryOperator, 
Object>>>getAggregatedValue(key);
-        if (null == value || value.isEmpty())
-            throw Memory.Exceptions.memoryDoesNotExist(key);
-        else
-            return (R) value.get().getValue1();
-    }
-
-    @Override
-    public void set(final String key, final Object value) {
-        this.checkKeyValue(key, value);
-        if (this.inExecute)
-            throw 
Memory.Exceptions.memorySetOnlyDuringVertexProgramSetUpAndTerminate(key);
-        this.setAggregatedValue(key, new ObjectWritable<>(new 
Pair<>(this.memoryComputeKeys.get(key).getReducer(), value)));
-    }
-
-    @Override
-    public void add(final String key, final Object value) {
-        this.checkKeyValue(key, value);
-        if (!this.inExecute)
-            throw 
Memory.Exceptions.memoryAddOnlyDuringVertexProgramExecute(key);
-        this.worker.aggregate(key, new ObjectWritable<>(new 
Pair<>(this.memoryComputeKeys.get(key).getReducer(), value)));
-    }
-
-    @Override
-    public void write(final DataOutput output) {
-        // all aggregator data is propagated through writables
-    }
-
-    @Override
-    public void readFields(final DataInput input) {
-        // all aggregator data is propagated through writables
-    }
-
-    @Override
-    public String toString() {
-        return StringFactory.memoryString(this);
-    }
-
-    private void checkKeyValue(final String key, final Object value) {
-        if (!this.memoryComputeKeys.containsKey(key))
-            throw 
GraphComputer.Exceptions.providedKeyIsNotAMemoryComputeKey(key);
-        MemoryHelper.validateValue(value);
-    }
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphMessageCombiner.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphMessageCombiner.java
 
b/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphMessageCombiner.java
deleted file mode 100644
index 4d725b2..0000000
--- 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphMessageCombiner.java
+++ /dev/null
@@ -1,61 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph.process.computer;
-
-import org.apache.commons.configuration.Configuration;
-import org.apache.giraph.conf.ImmutableClassesGiraphConfigurable;
-import org.apache.giraph.conf.ImmutableClassesGiraphConfiguration;
-import org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph;
-import org.apache.tinkerpop.gremlin.hadoop.structure.io.ObjectWritable;
-import org.apache.tinkerpop.gremlin.hadoop.structure.util.ConfUtil;
-import org.apache.tinkerpop.gremlin.process.computer.MessageCombiner;
-import org.apache.tinkerpop.gremlin.process.computer.VertexProgram;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public final class GiraphMessageCombiner extends 
org.apache.giraph.combiner.MessageCombiner<ObjectWritable, ObjectWritable> 
implements ImmutableClassesGiraphConfigurable {
-
-    private MessageCombiner messageCombiner;
-    private ImmutableClassesGiraphConfiguration configuration;
-
-    @Override
-    public void combine(final ObjectWritable vertexIndex, final ObjectWritable 
originalMessage, final ObjectWritable messageToCombine) {
-        originalMessage.set(originalMessage.isEmpty() ?
-                messageToCombine.get() :
-                this.messageCombiner.combine(originalMessage.get(), 
messageToCombine.get()));
-    }
-
-    @Override
-    public ObjectWritable createInitialMessage() {
-        return ObjectWritable.empty();
-    }
-
-    @Override
-    public void setConf(final ImmutableClassesGiraphConfiguration 
configuration) {
-        this.configuration = configuration;
-        final Configuration apacheConfiguration = 
ConfUtil.makeApacheConfiguration(configuration);
-        this.messageCombiner = (MessageCombiner) 
VertexProgram.createVertexProgram(HadoopGraph.open(apacheConfiguration), 
apacheConfiguration).getMessageCombiner().get();
-    }
-
-    @Override
-    public ImmutableClassesGiraphConfiguration getConf() {
-        return this.configuration;
-    }
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphMessenger.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphMessenger.java
 
b/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphMessenger.java
deleted file mode 100644
index 36e641e..0000000
--- 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphMessenger.java
+++ /dev/null
@@ -1,90 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph.process.computer;
-
-import org.apache.tinkerpop.gremlin.hadoop.structure.io.ObjectWritable;
-import org.apache.tinkerpop.gremlin.process.computer.MessageScope;
-import org.apache.tinkerpop.gremlin.process.computer.Messenger;
-import org.apache.tinkerpop.gremlin.process.traversal.Traversal;
-import org.apache.tinkerpop.gremlin.process.traversal.step.map.VertexStep;
-import org.apache.tinkerpop.gremlin.process.traversal.util.TraversalHelper;
-import org.apache.tinkerpop.gremlin.structure.Direction;
-import org.apache.tinkerpop.gremlin.structure.Edge;
-import org.apache.tinkerpop.gremlin.structure.Vertex;
-import org.apache.tinkerpop.gremlin.structure.util.star.StarGraph;
-import org.apache.tinkerpop.gremlin.util.iterator.IteratorUtils;
-
-import java.util.Iterator;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public final class GiraphMessenger<M> implements Messenger<M> {
-
-    private GiraphVertex giraphVertex;
-    private GiraphComputation giraphComputation;
-    private Iterator<ObjectWritable<M>> messages;
-
-    public GiraphMessenger(final GiraphVertex giraphVertex, final 
GiraphComputation giraphComputation, final Iterator<ObjectWritable<M>> 
messages) {
-        this.giraphVertex = giraphVertex;
-        this.giraphComputation = giraphComputation;
-        this.messages = messages;
-    }
-
-    @Override
-    public Iterator<M> receiveMessages() {
-        return IteratorUtils.map(this.messages, ObjectWritable::get);
-    }
-
-    @Override
-    public void sendMessage(final MessageScope messageScope, final M message) {
-        if (messageScope instanceof MessageScope.Local) {
-            final MessageScope.Local<M> localMessageScope = 
(MessageScope.Local) messageScope;
-            final Traversal.Admin<Vertex, Edge> incidentTraversal = 
GiraphMessenger.setVertexStart(localMessageScope.getIncidentTraversal().get().asAdmin(),
 this.giraphVertex.getValue().get());
-            final Direction direction = 
GiraphMessenger.getOppositeDirection(incidentTraversal);
-
-            // handle processing for BOTH given TINKERPOP-1862 where the 
target of the message is the one opposite
-            // the current vertex
-            incidentTraversal.forEachRemaining(edge -> {
-                if (direction.equals(Direction.IN) || 
direction.equals(Direction.OUT))
-                    this.giraphComputation.sendMessage(
-                            new 
ObjectWritable<>(edge.vertices(direction).next().id()),
-                            new 
ObjectWritable<>(localMessageScope.getEdgeFunction().apply(message, edge)));
-                else
-                    this.giraphComputation.sendMessage(
-                            new ObjectWritable<>(edge instanceof 
StarGraph.StarOutEdge ? edge.inVertex().id() : edge.outVertex().id()),
-                            new 
ObjectWritable<>(localMessageScope.getEdgeFunction().apply(message, edge)));
-            });
-        } else {
-            final MessageScope.Global globalMessageScope = 
(MessageScope.Global) messageScope;
-            globalMessageScope.vertices().forEach(vertex ->
-                    this.giraphComputation.sendMessage(new 
ObjectWritable<>(vertex.id()), new ObjectWritable<>(message)));
-        }
-    }
-
-    private static <T extends Traversal.Admin<Vertex, Edge>> T 
setVertexStart(final Traversal.Admin<Vertex, Edge> incidentTraversal, final 
Vertex vertex) {
-        
incidentTraversal.asAdmin().addStart(incidentTraversal.getTraverserGenerator().generate(vertex,
 incidentTraversal.getStartStep(), 1l));
-        return (T) incidentTraversal;
-    }
-
-    private static Direction getOppositeDirection(final 
Traversal.Admin<Vertex, Edge> incidentTraversal) {
-        final VertexStep step = 
TraversalHelper.getLastStepOfAssignableClass(VertexStep.class, 
incidentTraversal).get();
-        return step.getDirection().opposite();
-    }
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphVertex.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphVertex.java
 
b/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphVertex.java
deleted file mode 100644
index 3a95fae..0000000
--- 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphVertex.java
+++ /dev/null
@@ -1,39 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph.process.computer;
-
-import org.apache.giraph.graph.DefaultVertex;
-import org.apache.hadoop.io.NullWritable;
-import org.apache.tinkerpop.gremlin.hadoop.structure.io.ObjectWritable;
-import org.apache.tinkerpop.gremlin.hadoop.structure.io.VertexWritable;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public final class GiraphVertex extends DefaultVertex<ObjectWritable, 
VertexWritable, NullWritable> {
-
-    public GiraphVertex() {
-    }
-
-    public GiraphVertex(final VertexWritable vertexWritable) {
-        final VertexWritable newWritable = new VertexWritable();
-        newWritable.set(vertexWritable.get());
-        this.initialize(new ObjectWritable<>(newWritable.get().id()), 
newWritable, EmptyOutEdges.instance());
-    }
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphWorkerContext.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphWorkerContext.java
 
b/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphWorkerContext.java
deleted file mode 100644
index 0122ab4..0000000
--- 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphWorkerContext.java
+++ /dev/null
@@ -1,78 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph.process.computer;
-
-import org.apache.commons.configuration.Configuration;
-import org.apache.giraph.conf.GiraphConstants;
-import org.apache.giraph.worker.WorkerContext;
-import org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph;
-import org.apache.tinkerpop.gremlin.hadoop.structure.io.HadoopPools;
-import org.apache.tinkerpop.gremlin.hadoop.structure.io.ObjectWritable;
-import org.apache.tinkerpop.gremlin.hadoop.structure.util.ConfUtil;
-import org.apache.tinkerpop.gremlin.process.computer.VertexProgram;
-import org.apache.tinkerpop.gremlin.process.computer.util.ImmutableMemory;
-import org.apache.tinkerpop.gremlin.process.computer.util.VertexProgramPool;
-import 
org.apache.tinkerpop.gremlin.structure.io.gryo.kryoshim.KryoShimServiceLoader;
-
-import java.util.Iterator;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public final class GiraphWorkerContext extends WorkerContext {
-
-    private VertexProgramPool vertexProgramPool;
-    private GiraphMemory memory;
-
-    public GiraphWorkerContext() {
-        // Giraph ReflectionUtils requires this to be public at minimum
-    }
-
-    public void preApplication() throws InstantiationException, 
IllegalAccessException {
-        final Configuration apacheConfiguration = 
ConfUtil.makeApacheConfiguration(this.getContext().getConfiguration());
-        KryoShimServiceLoader.applyConfiguration(apacheConfiguration);
-        final VertexProgram vertexProgram = 
VertexProgram.createVertexProgram(HadoopGraph.open(apacheConfiguration), 
apacheConfiguration);
-        this.vertexProgramPool = new VertexProgramPool(vertexProgram, 
this.getContext().getConfiguration().getInt(GiraphConstants.NUM_COMPUTE_THREADS.getKey(),
 1));
-        this.memory = new GiraphMemory(this, vertexProgram);
-    }
-
-    public void postApplication() {
-
-    }
-
-    public void preSuperstep() {
-        this.vertexProgramPool.workerIterationStart(new 
ImmutableMemory(this.memory));
-    }
-
-    public void postSuperstep() {
-        this.vertexProgramPool.workerIterationEnd(new 
ImmutableMemory(this.memory));
-    }
-
-    public VertexProgramPool getVertexProgramPool() {
-        return this.vertexProgramPool;
-    }
-
-    public GiraphMemory getMemory() {
-        return this.memory;
-    }
-
-    public GiraphMessenger getMessenger(final GiraphVertex giraphVertex, final 
GiraphComputation giraphComputation, final Iterator<ObjectWritable> messages) {
-        return new GiraphMessenger(giraphVertex, giraphComputation, messages);
-    }
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/MemoryAggregator.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/MemoryAggregator.java
 
b/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/MemoryAggregator.java
deleted file mode 100644
index 4929546..0000000
--- 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/MemoryAggregator.java
+++ /dev/null
@@ -1,68 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph.process.computer;
-
-import org.apache.giraph.aggregators.Aggregator;
-import org.apache.tinkerpop.gremlin.hadoop.structure.io.ObjectWritable;
-import org.javatuples.Pair;
-
-import java.util.function.BinaryOperator;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public final class MemoryAggregator implements 
Aggregator<ObjectWritable<Pair<BinaryOperator, Object>>> {
-
-    private ObjectWritable<Pair<BinaryOperator, Object>> currentObject = 
ObjectWritable.<Pair<BinaryOperator, Object>>empty();
-
-    public MemoryAggregator() { // for Giraph serialization
-
-    }
-
-    @Override
-    public ObjectWritable<Pair<BinaryOperator, Object>> getAggregatedValue() {
-        return this.currentObject;
-    }
-
-    @Override
-    public void setAggregatedValue(final ObjectWritable<Pair<BinaryOperator, 
Object>> object) {
-        if (null != object)
-            this.currentObject = object;
-    }
-
-    @Override
-    public void aggregate(final ObjectWritable<Pair<BinaryOperator, Object>> 
object) {
-        if (null == object)
-            return;
-        else if (this.currentObject.isEmpty())
-            this.currentObject = object;
-        else if (!object.isEmpty())
-            this.currentObject.set(new Pair<>(object.get().getValue0(), 
object.get().getValue0().apply(this.currentObject.get().getValue1(), 
object.get().getValue1())));
-    }
-
-    @Override
-    public void reset() {
-        this.currentObject = ObjectWritable.<Pair<BinaryOperator, 
Object>>empty();
-    }
-
-    @Override
-    public ObjectWritable<Pair<BinaryOperator, Object>> createInitialValue() {
-        return ObjectWritable.<Pair<BinaryOperator, Object>>empty();
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/PassThroughMemory.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/PassThroughMemory.java
 
b/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/PassThroughMemory.java
deleted file mode 100644
index dc40e7b..0000000
--- 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/process/computer/PassThroughMemory.java
+++ /dev/null
@@ -1,99 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.tinkerpop.gremlin.giraph.process.computer;
-
-import org.apache.tinkerpop.gremlin.process.computer.Memory;
-import org.apache.tinkerpop.gremlin.structure.util.StringFactory;
-
-import java.util.HashMap;
-import java.util.Map;
-import java.util.Set;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public final class PassThroughMemory implements Memory.Admin {
-
-    private final GiraphMemory giraphMemory;
-    private long runtime = 0l;
-    private int iteration = -1;
-    private final Map<String, Object> memoryMap = new HashMap<>();
-
-    public PassThroughMemory(final GiraphMemory giraphMemory) {
-        this.giraphMemory = giraphMemory;
-        giraphMemory.keys().forEach(key -> this.memoryMap.put(key, 
giraphMemory.get(key)));
-        this.iteration = giraphMemory.getIteration();
-    }
-
-    @Override
-    public Set<String> keys() {
-        return this.memoryMap.keySet();
-    }
-
-    @Override
-    public <R> R get(final String key) throws IllegalArgumentException {
-        final R r = (R) this.memoryMap.get(key);
-        if (null == r)
-            throw Memory.Exceptions.memoryDoesNotExist(key);
-        else
-            return r;
-    }
-
-    @Override
-    public void set(final String key, Object value) {
-        this.memoryMap.put(key, value);
-        this.giraphMemory.set(key, value);
-    }
-
-    @Override
-    public int getIteration() {
-        return this.iteration;
-    }
-
-    @Override
-    public long getRuntime() {
-        return this.runtime;
-    }
-
-    @Override
-    public void add(final String key, final Object value) {
-        this.giraphMemory.add(key, value);
-    }
-
-    @Override
-    public String toString() {
-        return StringFactory.memoryString(this);
-    }
-
-    @Override
-    public void incrIteration() {
-        this.iteration = this.iteration + 1;
-    }
-
-    @Override
-    public void setIteration(final int iteration) {
-        this.iteration = iteration;
-    }
-
-    @Override
-    public void setRuntime(long runtime) {
-        this.runtime = runtime;
-    }
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexInputFormat.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexInputFormat.java
 
b/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexInputFormat.java
deleted file mode 100644
index 5900663..0000000
--- 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexInputFormat.java
+++ /dev/null
@@ -1,58 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph.structure.io;
-
-import org.apache.giraph.io.VertexInputFormat;
-import org.apache.giraph.io.VertexReader;
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.mapreduce.InputSplit;
-import org.apache.hadoop.mapreduce.JobContext;
-import org.apache.hadoop.mapreduce.TaskAttemptContext;
-import 
org.apache.tinkerpop.gremlin.hadoop.process.computer.GraphFilterInputFormat;
-
-import java.io.IOException;
-import java.util.List;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public final class GiraphVertexInputFormat extends VertexInputFormat {
-
-    @Override
-    public void checkInputSpecs(final Configuration configuration) {
-
-    }
-
-    @Override
-    public List<InputSplit> getSplits(final JobContext context, final int 
minSplitCountHint) throws IOException, InterruptedException {
-        return new GraphFilterInputFormat().getSplits(context);
-    }
-
-    @Override
-    public VertexReader createVertexReader(final InputSplit split, final 
TaskAttemptContext context) throws IOException {
-        try {
-            final GiraphVertexReader reader = new GiraphVertexReader();
-            reader.initialize(split, context);
-            return reader;
-        } catch (final InterruptedException e) {
-            throw new IOException(e.getMessage(), e);
-        }
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexOutputFormat.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexOutputFormat.java
 
b/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexOutputFormat.java
deleted file mode 100644
index 9881c77..0000000
--- 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexOutputFormat.java
+++ /dev/null
@@ -1,55 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph.structure.io;
-
-import org.apache.giraph.io.VertexOutputFormat;
-import org.apache.giraph.io.VertexWriter;
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.mapreduce.JobContext;
-import org.apache.hadoop.mapreduce.OutputCommitter;
-import org.apache.hadoop.mapreduce.OutputFormat;
-import org.apache.hadoop.mapreduce.TaskAttemptContext;
-import org.apache.hadoop.util.ReflectionUtils;
-import org.apache.tinkerpop.gremlin.hadoop.Constants;
-
-import java.io.IOException;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public final class GiraphVertexOutputFormat extends VertexOutputFormat {
-
-    @Override
-    public VertexWriter createVertexWriter(final TaskAttemptContext context) 
throws IOException, InterruptedException {
-        return new GiraphVertexWriter();
-    }
-
-    @Override
-    public void checkOutputSpecs(final JobContext context) throws IOException, 
InterruptedException {
-        final Configuration configuration = context.getConfiguration();
-        
ReflectionUtils.newInstance(configuration.getClass(Constants.GREMLIN_HADOOP_GRAPH_WRITER,
 OutputFormat.class, OutputFormat.class), 
configuration).checkOutputSpecs(context);
-    }
-
-    @Override
-    public OutputCommitter getOutputCommitter(final TaskAttemptContext 
context) throws IOException, InterruptedException {
-        final Configuration configuration = context.getConfiguration();
-        return 
ReflectionUtils.newInstance(configuration.getClass(Constants.GREMLIN_HADOOP_GRAPH_WRITER,
 OutputFormat.class, OutputFormat.class), 
configuration).getOutputCommitter(context);
-    }
-
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexReader.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexReader.java
 
b/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexReader.java
deleted file mode 100644
index 5335980..0000000
--- 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexReader.java
+++ /dev/null
@@ -1,68 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph.structure.io;
-
-import org.apache.giraph.graph.Vertex;
-import org.apache.giraph.io.VertexReader;
-import org.apache.hadoop.io.NullWritable;
-import org.apache.hadoop.mapreduce.InputSplit;
-import org.apache.hadoop.mapreduce.RecordReader;
-import org.apache.hadoop.mapreduce.TaskAttemptContext;
-import org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphVertex;
-import 
org.apache.tinkerpop.gremlin.hadoop.process.computer.GraphFilterRecordReader;
-import org.apache.tinkerpop.gremlin.hadoop.structure.io.VertexWritable;
-
-import java.io.IOException;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public final class GiraphVertexReader extends VertexReader {
-
-    private RecordReader<NullWritable, VertexWritable> recordReader;
-
-    public GiraphVertexReader() {
-        this.recordReader = new GraphFilterRecordReader();
-    }
-
-    @Override
-    public void initialize(final InputSplit inputSplit, final 
TaskAttemptContext context) throws IOException, InterruptedException {
-        this.recordReader.initialize(inputSplit, context);
-    }
-
-    @Override
-    public boolean nextVertex() throws IOException, InterruptedException {
-        return this.recordReader.nextKeyValue();
-    }
-
-    @Override
-    public Vertex getCurrentVertex() throws IOException, InterruptedException {
-        return new GiraphVertex(this.recordReader.getCurrentValue());
-    }
-
-    @Override
-    public void close() throws IOException {
-        this.recordReader.close();
-    }
-
-    @Override
-    public float getProgress() throws IOException, InterruptedException {
-        return this.recordReader.getProgress();
-    }
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexWriter.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexWriter.java
 
b/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexWriter.java
deleted file mode 100644
index 3c94137..0000000
--- 
a/giraph-gremlin/src/main/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphVertexWriter.java
+++ /dev/null
@@ -1,71 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph.structure.io;
-
-import org.apache.giraph.graph.Vertex;
-import org.apache.giraph.io.VertexWriter;
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.io.NullWritable;
-import org.apache.hadoop.mapreduce.OutputFormat;
-import org.apache.hadoop.mapreduce.RecordWriter;
-import org.apache.hadoop.mapreduce.TaskAttemptContext;
-import org.apache.hadoop.util.ReflectionUtils;
-import org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphVertex;
-import org.apache.tinkerpop.gremlin.hadoop.Constants;
-import org.apache.tinkerpop.gremlin.hadoop.structure.io.VertexWritable;
-import org.apache.tinkerpop.gremlin.hadoop.structure.util.ConfUtil;
-import org.apache.tinkerpop.gremlin.process.computer.VertexComputeKey;
-import org.apache.tinkerpop.gremlin.process.computer.VertexProgram;
-import org.apache.tinkerpop.gremlin.process.computer.util.VertexProgramHelper;
-import org.apache.tinkerpop.gremlin.structure.util.empty.EmptyGraph;
-
-import java.io.IOException;
-import java.util.stream.Collectors;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public final class GiraphVertexWriter extends VertexWriter {
-    private RecordWriter<NullWritable, VertexWritable> recordWriter;
-    private String[] transientComputeKeys;
-
-    public GiraphVertexWriter() {
-
-    }
-
-    @Override
-    public void initialize(final TaskAttemptContext context) throws 
IOException, InterruptedException {
-        final Configuration configuration = context.getConfiguration();
-        this.recordWriter = 
ReflectionUtils.newInstance(configuration.getClass(Constants.GREMLIN_HADOOP_GRAPH_WRITER,
 OutputFormat.class, OutputFormat.class), 
configuration).getRecordWriter(context);
-        this.transientComputeKeys = 
VertexProgramHelper.vertexComputeKeysAsArray(((VertexProgram<?>) 
VertexProgram.createVertexProgram(EmptyGraph.instance(), 
ConfUtil.makeApacheConfiguration(configuration))).getVertexComputeKeys().stream().
-                filter(VertexComputeKey::isTransient).
-                collect(Collectors.toSet()));
-    }
-
-    @Override
-    public void close(final TaskAttemptContext context) throws IOException, 
InterruptedException {
-        this.recordWriter.close(context);
-    }
-
-    @Override
-    public void writeVertex(final Vertex vertex) throws IOException, 
InterruptedException {
-        ((GiraphVertex) 
vertex).getValue().get().dropVertexProperties(this.transientComputeKeys); // 
remove all transient compute keys before writing to OutputFormat
-        this.recordWriter.write(NullWritable.get(), ((GiraphVertex) 
vertex).getValue());
-    }
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/main/resources/META-INF/services/org.apache.tinkerpop.gremlin.jsr223.GremlinPlugin
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/main/resources/META-INF/services/org.apache.tinkerpop.gremlin.jsr223.GremlinPlugin
 
b/giraph-gremlin/src/main/resources/META-INF/services/org.apache.tinkerpop.gremlin.jsr223.GremlinPlugin
deleted file mode 100644
index 9a92905..0000000
--- 
a/giraph-gremlin/src/main/resources/META-INF/services/org.apache.tinkerpop.gremlin.jsr223.GremlinPlugin
+++ /dev/null
@@ -1 +0,0 @@
-org.apache.tinkerpop.gremlin.giraph.jsr223.GiraphGremlinPlugin
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/GiraphGremlinIntegrateTest.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/GiraphGremlinIntegrateTest.java
 
b/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/GiraphGremlinIntegrateTest.java
deleted file mode 100644
index 955649c..0000000
--- 
a/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/GiraphGremlinIntegrateTest.java
+++ /dev/null
@@ -1,33 +0,0 @@
-/*
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
- *
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-
-package org.apache.tinkerpop.gremlin.giraph;
-
-import org.apache.tinkerpop.gremlin.GraphProviderClass;
-import 
org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphHadoopGraphProvider;
-import org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph;
-import org.junit.runner.RunWith;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-@RunWith(GiraphGremlinSuite.class)
-@GraphProviderClass(provider = GiraphHadoopGraphProvider.class, graph = 
HadoopGraph.class)
-public class GiraphGremlinIntegrateTest {
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/GiraphGremlinSuite.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/GiraphGremlinSuite.java
 
b/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/GiraphGremlinSuite.java
deleted file mode 100644
index 2fe0e4f..0000000
--- 
a/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/GiraphGremlinSuite.java
+++ /dev/null
@@ -1,35 +0,0 @@
-/*
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
- *
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-
-package org.apache.tinkerpop.gremlin.giraph;
-
-import org.apache.tinkerpop.gremlin.AbstractGremlinSuite;
-import org.apache.tinkerpop.gremlin.giraph.structure.io.GiraphIoRegistryCheck;
-import org.apache.tinkerpop.gremlin.process.traversal.TraversalEngine;
-import org.junit.runners.model.InitializationError;
-import org.junit.runners.model.RunnerBuilder;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public final class GiraphGremlinSuite extends AbstractGremlinSuite {
-    public GiraphGremlinSuite(final Class<?> klass, final RunnerBuilder 
builder) throws InitializationError {
-        super(klass, builder, new Class<?>[]{GiraphIoRegistryCheck.class}, new 
Class<?>[]{GiraphIoRegistryCheck.class}, true, TraversalEngine.Type.COMPUTER);
-    }
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/GiraphHadoopGremlinIntegrateTest.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/GiraphHadoopGremlinIntegrateTest.java
 
b/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/GiraphHadoopGremlinIntegrateTest.java
deleted file mode 100644
index ba9e12d..0000000
--- 
a/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/GiraphHadoopGremlinIntegrateTest.java
+++ /dev/null
@@ -1,33 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph;
-
-import org.apache.tinkerpop.gremlin.GraphProviderClass;
-import 
org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphHadoopGraphProvider;
-import org.apache.tinkerpop.gremlin.hadoop.HadoopGremlinSuite;
-import org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph;
-import org.junit.runner.RunWith;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-@RunWith(HadoopGremlinSuite.class)
-@GraphProviderClass(provider = GiraphHadoopGraphProvider.class, graph = 
HadoopGraph.class)
-public class GiraphHadoopGremlinIntegrateTest {
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphGraphComputerProcessIntegrateTest.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphGraphComputerProcessIntegrateTest.java
 
b/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphGraphComputerProcessIntegrateTest.java
deleted file mode 100644
index b6da750..0000000
--- 
a/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphGraphComputerProcessIntegrateTest.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph.process.computer;
-
-import org.apache.tinkerpop.gremlin.GraphProviderClass;
-import org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph;
-import org.apache.tinkerpop.gremlin.process.ProcessComputerSuite;
-import org.junit.runner.RunWith;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-@RunWith(ProcessComputerSuite.class)
-@GraphProviderClass(provider = GiraphHadoopGraphProvider.class, graph = 
HadoopGraph.class)
-public class GiraphGraphComputerProcessIntegrateTest {
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphHadoopGraphProvider.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphHadoopGraphProvider.java
 
b/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphHadoopGraphProvider.java
deleted file mode 100644
index 8eae4f1..0000000
--- 
a/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/process/computer/GiraphHadoopGraphProvider.java
+++ /dev/null
@@ -1,68 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.tinkerpop.gremlin.giraph.process.computer;
-
-import org.apache.giraph.conf.GiraphConstants;
-import org.apache.tinkerpop.gremlin.GraphProvider;
-import org.apache.tinkerpop.gremlin.LoadGraphWith;
-import org.apache.tinkerpop.gremlin.hadoop.HadoopGraphProvider;
-import org.apache.tinkerpop.gremlin.process.computer.GraphComputer;
-import 
org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource;
-import org.apache.tinkerpop.gremlin.structure.Graph;
-
-import java.util.Map;
-import java.util.concurrent.TimeUnit;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-@GraphProvider.Descriptor(computer = GiraphGraphComputer.class)
-public final class GiraphHadoopGraphProvider extends HadoopGraphProvider {
-
-    @Override
-    public Map<String, Object> getBaseConfiguration(final String graphName, 
final Class<?> test, final String testMethodName, final LoadGraphWith.GraphData 
loadGraphWith) {
-        final Map<String, Object> config = 
super.getBaseConfiguration(graphName, test, testMethodName, loadGraphWith);
-        config.put("mapreduce.job.reduces", 2);
-        /// giraph configuration
-        config.put(GiraphConstants.LOCAL_TEST_MODE.getKey(), true); // local 
testing can only spawn one worker
-        config.put(GiraphConstants.MIN_WORKERS, 1);
-        config.put(GiraphConstants.MAX_WORKERS, 1);
-        config.put(GiraphConstants.SPLIT_MASTER_WORKER.getKey(), false);
-        config.put(GiraphConstants.ZOOKEEPER_IS_EXTERNAL.getKey(), false);
-        
config.put(GiraphConstants.NETTY_SERVER_USE_EXECUTION_HANDLER.getKey(), false); 
// this prevents so many integration tests running out of threads
-        
config.put(GiraphConstants.NETTY_CLIENT_USE_EXECUTION_HANDLER.getKey(), false); 
// this prevents so many integration tests running out of threads
-        config.put(GiraphConstants.NETTY_USE_DIRECT_MEMORY.getKey(), true);
-        config.put(GiraphConstants.NUM_INPUT_THREADS.getKey(), 2);
-        config.put(GiraphConstants.NUM_COMPUTE_THREADS.getKey(), 2);
-        config.put(GiraphConstants.MAX_MASTER_SUPERSTEP_WAIT_MSECS.getKey(), 
TimeUnit.MINUTES.toMillis(60L));
-        config.put(GiraphConstants.VERTEX_OUTPUT_FORMAT_THREAD_SAFE.getKey(), 
false);
-        config.put(GiraphConstants.NUM_OUTPUT_THREADS.getKey(), 1);
-        return config;
-    }
-
-    @Override
-    public GraphTraversalSource traversal(final Graph graph) {
-        return graph.traversal().withComputer(GiraphGraphComputer.class);
-    }
-
-    @Override
-    public GraphComputer getGraphComputer(final Graph graph) {
-        return graph.compute(GiraphGraphComputer.class);
-    }
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphIoRegistryCheck.java
----------------------------------------------------------------------
diff --git 
a/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphIoRegistryCheck.java
 
b/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphIoRegistryCheck.java
deleted file mode 100644
index 0a9dc81..0000000
--- 
a/giraph-gremlin/src/test/java/org/apache/tinkerpop/gremlin/giraph/structure/io/GiraphIoRegistryCheck.java
+++ /dev/null
@@ -1,64 +0,0 @@
-/*
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
- *
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-
-package org.apache.tinkerpop.gremlin.giraph.structure.io;
-
-import 
org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphGraphComputer;
-import org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph;
-import 
org.apache.tinkerpop.gremlin.hadoop.structure.io.AbstractIoRegistryCheck;
-import org.apache.tinkerpop.gremlin.hadoop.structure.io.HadoopPools;
-import 
org.apache.tinkerpop.gremlin.structure.io.gryo.kryoshim.KryoShimServiceLoader;
-import org.junit.After;
-import org.junit.Before;
-import org.junit.Test;
-
-/**
- * @author Marko A. Rodriguez (http://markorodriguez.com)
- */
-public class GiraphIoRegistryCheck extends AbstractIoRegistryCheck {
-
-    @Before
-    public void setup() throws Exception {
-        super.setup();
-        KryoShimServiceLoader.close();
-        HadoopPools.close();
-    }
-
-    @After
-    public void tearDown() throws Exception {
-        super.tearDown();
-        KryoShimServiceLoader.close();
-        HadoopPools.close();
-    }
-
-    @Test
-    public void shouldSupportGryoV1d0IoRegistry() throws Exception {
-        super.checkGryoV1d0IoRegistryCompliance((HadoopGraph) graph, 
GiraphGraphComputer.class);
-    }
-
-    @Test
-    public void shouldSupportGryoV3d0IoRegistry() throws Exception {
-        super.checkGryoV3d0IoRegistryCompliance((HadoopGraph) graph, 
GiraphGraphComputer.class);
-    }
-
-    @Test
-    public void shouldSupportGraphSONIoRegistry() throws Exception {
-        super.checkGraphSONIoRegistryCompliance((HadoopGraph) graph, 
GiraphGraphComputer.class);
-    }
-}

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/test/resources/giraph-site.xml
----------------------------------------------------------------------
diff --git a/giraph-gremlin/src/test/resources/giraph-site.xml 
b/giraph-gremlin/src/test/resources/giraph-site.xml
deleted file mode 100644
index 9862296..0000000
--- a/giraph-gremlin/src/test/resources/giraph-site.xml
+++ /dev/null
@@ -1,12 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-<configuration>
-    <property>
-        <name>giraph.zkServerlistPollMsecs</name>
-        <value>500</value>
-    </property>
-    <property>
-        <name>giraph.logLevel</name>
-        <value>info</value>
-    </property>
-</configuration>

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/test/resources/log4j-silent.properties
----------------------------------------------------------------------
diff --git a/giraph-gremlin/src/test/resources/log4j-silent.properties 
b/giraph-gremlin/src/test/resources/log4j-silent.properties
deleted file mode 100644
index 1825bb0..0000000
--- a/giraph-gremlin/src/test/resources/log4j-silent.properties
+++ /dev/null
@@ -1,23 +0,0 @@
-# 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 file should always have logging set to OFF.  it seems, however, that an 
appender of some sort is
-# required or else some logs throw error and use other log4j.properties files 
on the path.
-log4j.rootLogger=OFF, stdout
-log4j.appender.stdout=org.apache.log4j.ConsoleAppender
-log4j.appender.stdout.layout=org.apache.log4j.PatternLayout
-log4j.appender.stdout.layout.ConversionPattern=[%p] %C - %m%n
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/giraph-gremlin/src/test/resources/log4j-test.properties
----------------------------------------------------------------------
diff --git a/giraph-gremlin/src/test/resources/log4j-test.properties 
b/giraph-gremlin/src/test/resources/log4j-test.properties
deleted file mode 100644
index a3e679c..0000000
--- a/giraph-gremlin/src/test/resources/log4j-test.properties
+++ /dev/null
@@ -1,23 +0,0 @@
-# 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.
-
-log4j.rootLogger=WARN, stdout
-log4j.appender.stdout=org.apache.log4j.ConsoleAppender
-log4j.appender.stdout.layout=org.apache.log4j.PatternLayout
-log4j.appender.stdout.layout.ConversionPattern=[%p] %C - %m%n
-
-log4j.logger.org.apache.hadoop=ERROR
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/jsr223/GremlinPlugin.java
----------------------------------------------------------------------
diff --git 
a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/jsr223/GremlinPlugin.java
 
b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/jsr223/GremlinPlugin.java
index 99e6bd9..8f0ce9d 100644
--- 
a/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/jsr223/GremlinPlugin.java
+++ 
b/gremlin-core/src/main/java/org/apache/tinkerpop/gremlin/jsr223/GremlinPlugin.java
@@ -30,8 +30,8 @@ public interface GremlinPlugin {
     /**
      * The name of the module.  This name should be unique (use a namespaced 
approach) as naming clashes will
      * prevent proper module operations. Modules developed by TinkerPop will 
be prefixed with "tinkerpop."
-     * For example, TinkerPop's implementation of Giraph would be named 
"tinkerpop.giraph".  If Facebook were
-     * to do their own implementation the implementation might be called 
"facebook.giraph".
+     * For example, TinkerPop's implementation of Spark would be named 
"tinkerpop.spark".  If Facebook were
+     * to do their own implementation the implementation might be called 
"facebook.spark".
      */
     public String getName();
 

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/hadoop-gremlin/conf/hadoop-graphson.properties
----------------------------------------------------------------------
diff --git a/hadoop-gremlin/conf/hadoop-graphson.properties 
b/hadoop-gremlin/conf/hadoop-graphson.properties
index c37cf28..c2f660b 100644
--- a/hadoop-gremlin/conf/hadoop-graphson.properties
+++ b/hadoop-gremlin/conf/hadoop-graphson.properties
@@ -33,12 +33,6 @@ spark.master=local[4]
 spark.serializer=org.apache.spark.serializer.KryoSerializer
 
spark.kryo.registrator=org.apache.tinkerpop.gremlin.spark.structure.io.gryo.GryoRegistrator
 
-#####################################
-# GiraphGraphComputer Configuration #
-#####################################
-giraph.minWorkers=2
-giraph.maxWorkers=2
-
 
 
 

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/hadoop-gremlin/conf/hadoop-grateful-gryo.properties
----------------------------------------------------------------------
diff --git a/hadoop-gremlin/conf/hadoop-grateful-gryo.properties 
b/hadoop-gremlin/conf/hadoop-grateful-gryo.properties
index 92ed942..f28ce9d 100644
--- a/hadoop-gremlin/conf/hadoop-grateful-gryo.properties
+++ b/hadoop-gremlin/conf/hadoop-grateful-gryo.properties
@@ -30,15 +30,3 @@ spark.executor.memory=1g
 spark.serializer=org.apache.spark.serializer.KryoSerializer
 
spark.kryo.registrator=org.apache.tinkerpop.gremlin.spark.structure.io.gryo.GryoRegistrator
 
-#####################################
-# GiraphGraphComputer Configuration #
-#####################################
-giraph.minWorkers=1
-giraph.maxWorkers=1
-giraph.useOutOfCoreGraph=true
-giraph.useOutOfCoreMessages=true
-mapred.map.child.java.opts=-Xmx1024m
-mapred.reduce.child.java.opts=-Xmx1024m
-giraph.numInputThreads=4
-giraph.numComputeThreads=4
-giraph.maxMessagesInMemory=100000

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/hadoop-gremlin/conf/hadoop-gryo.properties
----------------------------------------------------------------------
diff --git a/hadoop-gremlin/conf/hadoop-gryo.properties 
b/hadoop-gremlin/conf/hadoop-gryo.properties
index c156a98..31286d8 100644
--- a/hadoop-gremlin/conf/hadoop-gryo.properties
+++ b/hadoop-gremlin/conf/hadoop-gryo.properties
@@ -42,21 +42,5 @@ 
spark.kryo.registrator=org.apache.tinkerpop.gremlin.spark.structure.io.gryo.Gryo
 # spark.eventLog.dir=/tmp/spark-event-logs
 # spark.ui.killEnabled=true
 
-#####################################
-# GiraphGraphComputer Configuration #
-#####################################
-giraph.minWorkers=2
-giraph.maxWorkers=2
-giraph.useOutOfCoreGraph=true
-giraph.useOutOfCoreMessages=true
-mapreduce.map.java.opts=-Xmx1024m
-mapreduce.reduce.java.opts=-Xmx1024m
-giraph.numInputThreads=2
-giraph.numComputeThreads=2
-# giraph.maxPartitionsInMemory=1
-# giraph.userPartitionCount=2
-## MapReduce of GiraphGraphComputer ##
-# mapreduce.job.maps=2
-# mapreduce.job.reduces=1
 
 

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/hadoop-gremlin/conf/hadoop-script.properties
----------------------------------------------------------------------
diff --git a/hadoop-gremlin/conf/hadoop-script.properties 
b/hadoop-gremlin/conf/hadoop-script.properties
index 88bf6d9..24d847b 100644
--- a/hadoop-gremlin/conf/hadoop-script.properties
+++ b/hadoop-gremlin/conf/hadoop-script.properties
@@ -38,21 +38,5 @@ 
spark.kryo.registrator=org.apache.tinkerpop.gremlin.spark.structure.io.gryo.Gryo
 # spark.eventLog.dir=/tmp/spark-event-logs
 # spark.ui.killEnabled=true
 
-#####################################
-# GiraphGraphComputer Configuration #
-#####################################
-giraph.minWorkers=2
-giraph.maxWorkers=2
-giraph.useOutOfCoreGraph=true
-giraph.useOutOfCoreMessages=true
-mapreduce.map.java.opts=-Xmx1024m
-mapreduce.reduce.java.opts=-Xmx1024m
-giraph.numInputThreads=2
-giraph.numComputeThreads=2
-# giraph.maxPartitionsInMemory=1
-# giraph.userPartitionCount=2
-## MapReduce of GiraphGraphComputer ##
-# mapreduce.job.maps=2
-# mapreduce.job.reduces=1
 
 

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/hadoop-gremlin/src/main/java/org/apache/tinkerpop/gremlin/hadoop/Constants.java
----------------------------------------------------------------------
diff --git 
a/hadoop-gremlin/src/main/java/org/apache/tinkerpop/gremlin/hadoop/Constants.java
 
b/hadoop-gremlin/src/main/java/org/apache/tinkerpop/gremlin/hadoop/Constants.java
index 2fc5a66..53477b8 100644
--- 
a/hadoop-gremlin/src/main/java/org/apache/tinkerpop/gremlin/hadoop/Constants.java
+++ 
b/hadoop-gremlin/src/main/java/org/apache/tinkerpop/gremlin/hadoop/Constants.java
@@ -45,7 +45,6 @@ public final class Constants {
     public static final String GREMLIN_HADOOP_JARS_IN_DISTRIBUTED_CACHE = 
"gremlin.hadoop.jarsInDistributedCache";
     public static final String HIDDEN_G = Graph.Hidden.hide("g");
     public static final String GREMLIN_HADOOP_JOB_PREFIX = "HadoopGremlin: ";
-    public static final String GREMLIN_HADOOP_GIRAPH_JOB_PREFIX = 
"HadoopGremlin(Giraph): ";
     // public static final String GREMLIN_HADOOP_MAP_REDUCE_JOB_PREFIX = 
"HadoopGremlin(MapReduce): ";
     public static final String GREMLIN_HADOOP_SPARK_JOB_PREFIX = 
"HadoopGremlin(Spark): ";
     public static final String HADOOP_GREMLIN_LIBS = "HADOOP_GREMLIN_LIBS";

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/hadoop-gremlin/src/main/java/org/apache/tinkerpop/gremlin/hadoop/structure/HadoopGraph.java
----------------------------------------------------------------------
diff --git 
a/hadoop-gremlin/src/main/java/org/apache/tinkerpop/gremlin/hadoop/structure/HadoopGraph.java
 
b/hadoop-gremlin/src/main/java/org/apache/tinkerpop/gremlin/hadoop/structure/HadoopGraph.java
index 72eee73..ea8334b 100644
--- 
a/hadoop-gremlin/src/main/java/org/apache/tinkerpop/gremlin/hadoop/structure/HadoopGraph.java
+++ 
b/hadoop-gremlin/src/main/java/org/apache/tinkerpop/gremlin/hadoop/structure/HadoopGraph.java
@@ -69,21 +69,6 @@ import java.util.stream.Stream;
         reason = "Hadoop-Gremlin is OLAP-oriented and for OLTP operations, 
linear-scan joins are required. This particular tests takes many minutes to 
execute.",
         computers = {"ALL"})
 @Graph.OptOut(
-        test = 
"org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchTest$Traversals",
-        method = "g_V_matchXa_knows_b__c_knows_bX",
-        reason = "Giraph does a hard kill on failure and stops threads which 
stops test cases. Exception handling semantics are correct though.",
-        computers = 
{"org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphGraphComputer"})
-@Graph.OptOut(
-        test = 
"org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchTest$Traversals",
-        method = "g_V_matchXa_created_b__c_created_bX_selectXa_b_cX_byXnameX",
-        reason = "Giraph does a hard kill on failure and stops threads which 
stops test cases. Exception handling semantics are correct though.",
-        computers = 
{"org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphGraphComputer"})
-@Graph.OptOut(
-        test = 
"org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchTest$Traversals",
-        method = "g_V_out_asXcX_matchXb_knows_a__c_created_eX_selectXcX",
-        reason = "Giraph does a hard kill on failure and stops threads which 
stops test cases. Exception handling semantics are correct though.",
-        computers = 
{"org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphGraphComputer"})
-@Graph.OptOut(
         test = 
"org.apache.tinkerpop.gremlin.process.traversal.step.map.CountTest$Traversals",
         method = "g_V_both_both_count",
         reason = "Hadoop-Gremlin is OLAP-oriented and for OLTP operations, 
linear-scan joins are required. This particular tests takes many minutes to 
execute.",
@@ -144,7 +129,7 @@ import java.util.stream.Stream;
         test = 
"org.apache.tinkerpop.gremlin.process.traversal.TraversalInterruptionComputerTest",
         method = "*",
         reason = "This test makes use of a sideEffect to enforce when a thread 
interruption is triggered and thus isn't applicable to HadoopGraph",
-        computers = 
{"org.apache.tinkerpop.gremlin.spark.process.computer.SparkGraphComputer", 
"org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphGraphComputer"})
+        computers = 
{"org.apache.tinkerpop.gremlin.spark.process.computer.SparkGraphComputer"})
 @Graph.OptOut(
         test = 
"org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchTest$CountMatchTraversals",
         method = 
"g_V_matchXa_followedBy_count_isXgtX10XX_b__a_0followedBy_count_isXgtX10XX_bX_count",

http://git-wip-us.apache.org/repos/asf/tinkerpop/blob/33bfe547/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index a1abade..ddd9167 100644
--- a/pom.xml
+++ b/pom.xml
@@ -123,7 +123,6 @@ limitations under the License.
         <module>gremlin-dotnet</module>
         <module>hadoop-gremlin</module>
         <module>spark-gremlin</module>
-        <module>giraph-gremlin</module>
         <module>neo4j-gremlin</module>
         <module>gremlin-driver</module>
         <module>gremlin-console</module>
@@ -583,15 +582,6 @@ limitations under the License.
                         <groupId>commons-logging</groupId>
                         <artifactId>commons-logging</artifactId>
                     </exclusion>
-                    <!-- conflicts with giraph-core (which appears to have 
more consistent dependencies) -->
-                    <exclusion>
-                        <groupId>org.codehaus.jackson</groupId>
-                        <artifactId>jackson-core-asl</artifactId>
-                    </exclusion>
-                    <exclusion>
-                        <groupId>org.codehaus.jackson</groupId>
-                        <artifactId>jackson-mapper-asl</artifactId>
-                    </exclusion>
                     <!-- conflict with TinkerPop tests -->
                     <exclusion>
                         <groupId>junit</groupId>
@@ -1147,7 +1137,7 @@ limitations under the License.
                                     
<overview>${basedir}/docs/javadoc/overview.html</overview>
                                     <quiet>true</quiet>
                                     <sourcepath>
-                                        
giraph-gremlin/src/main/java:gremlin-core/src/main/java:gremlin-driver/src/main/java:gremlin-groovy/src/main/java:gremlin-python/src/main/java:gremlin-server/src/main/java:gremlin-test/src/main/java:hadoop-gremlin/src/main/java:neo4j-gremlin/src/main/java:spark-gremlin/src/main/java:tinkergraph-gremlin/src/main/java
+                                        
gremlin-core/src/main/java:gremlin-driver/src/main/java:gremlin-groovy/src/main/java:gremlin-python/src/main/java:gremlin-server/src/main/java:gremlin-test/src/main/java:hadoop-gremlin/src/main/java:neo4j-gremlin/src/main/java:spark-gremlin/src/main/java:tinkergraph-gremlin/src/main/java
                                     </sourcepath>
                                 </configuration>
                             </execution>

Reply via email to