You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by tg...@apache.org on 2017/10/11 03:36:28 UTC

[2/2] beam git commit: Move the Job Server into a Submodule

Move the Job Server into a Submodule

This permits separation of the Job Server and the Java Runner which
submits to it, while both being part of the 'ReferenceRunner'


Project: http://git-wip-us.apache.org/repos/asf/beam/repo
Commit: http://git-wip-us.apache.org/repos/asf/beam/commit/992d805b
Tree: http://git-wip-us.apache.org/repos/asf/beam/tree/992d805b
Diff: http://git-wip-us.apache.org/repos/asf/beam/diff/992d805b

Branch: refs/heads/master
Commit: 992d805bffcf887b65a7f55b63483b1824bba187
Parents: 90f34f2
Author: Thomas Groh <tg...@google.com>
Authored: Mon Oct 9 16:13:28 2017 -0700
Committer: Thomas Groh <tg...@google.com>
Committed: Tue Oct 10 20:36:13 2017 -0700

----------------------------------------------------------------------
 pom.xml                                         |  6 ++
 runners/reference/job-server/pom.xml            | 82 ++++++++++++++++++++
 .../reference/job/ReferenceRunnerJobServer.java | 77 ++++++++++++++++++
 .../job/ReferenceRunnerJobService.java          | 79 +++++++++++++++++++
 .../runners/reference/job/package-info.java     | 23 ++++++
 .../job/ReferenceRunnerJobServiceTest.java      | 34 ++++++++
 runners/reference/pom.xml                       | 47 ++---------
 .../reference/job/ReferenceRunnerJobServer.java | 68 ----------------
 .../job/ReferenceRunnerJobService.java          | 77 ------------------
 .../runners/reference/job/package-info.java     | 23 ------
 .../job/ReferenceRunnerJobServiceTest.java      | 34 --------
 11 files changed, 307 insertions(+), 243 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/beam/blob/992d805b/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index eec82d9..13f0f1b 100644
--- a/pom.xml
+++ b/pom.xml
@@ -621,6 +621,12 @@
 
       <dependency>
         <groupId>org.apache.beam</groupId>
+        <artifactId>beam-runners-reference-job-orchestrator</artifactId>
+        <version>${project.version}</version>
+      </dependency>
+
+      <dependency>
+        <groupId>org.apache.beam</groupId>
         <artifactId>beam-runners-direct-java</artifactId>
         <version>${project.version}</version>
       </dependency>

http://git-wip-us.apache.org/repos/asf/beam/blob/992d805b/runners/reference/job-server/pom.xml
----------------------------------------------------------------------
diff --git a/runners/reference/job-server/pom.xml b/runners/reference/job-server/pom.xml
new file mode 100644
index 0000000..aed03e9
--- /dev/null
+++ b/runners/reference/job-server/pom.xml
@@ -0,0 +1,82 @@
+<?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">
+
+  <modelVersion>4.0.0</modelVersion>
+
+  <parent>
+    <groupId>org.apache.beam</groupId>
+    <artifactId>beam-runners-reference-parent</artifactId>
+    <version>2.3.0-SNAPSHOT</version>
+    <relativePath>../pom.xml</relativePath>
+  </parent>
+
+  <artifactId>beam-runners-reference-job-orchestrator</artifactId>
+
+  <name>Apache Beam :: Runners :: Reference :: Job Orchestrator</name>
+
+  <packaging>jar</packaging>
+
+  <build>
+    <resources>
+      <resource>
+        <directory>src/main/resources</directory>
+        <filtering>true</filtering>
+      </resource>
+    </resources>
+  </build>
+
+  <dependencies>
+    <dependency>
+      <groupId>org.apache.beam</groupId>
+      <artifactId>beam-sdks-common-runner-api</artifactId>
+    </dependency>
+
+    <dependency>
+      <groupId>io.grpc</groupId>
+      <artifactId>grpc-core</artifactId>
+    </dependency>
+
+    <dependency>
+      <groupId>io.grpc</groupId>
+      <artifactId>grpc-stub</artifactId>
+    </dependency>
+
+    <dependency>
+      <groupId>io.grpc</groupId>
+      <artifactId>grpc-netty</artifactId>
+      <scope>runtime</scope>
+    </dependency>
+
+    <dependency>
+      <groupId>org.slf4j</groupId>
+      <artifactId>slf4j-api</artifactId>
+    </dependency>
+
+    <dependency>
+      <groupId>args4j</groupId>
+      <artifactId>args4j</artifactId>
+    </dependency>
+
+    <dependency>
+      <groupId>junit</groupId>
+      <artifactId>junit</artifactId>
+      <scope>test</scope>
+    </dependency>
+  </dependencies>
+</project>

http://git-wip-us.apache.org/repos/asf/beam/blob/992d805b/runners/reference/job-server/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServer.java
----------------------------------------------------------------------
diff --git a/runners/reference/job-server/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServer.java b/runners/reference/job-server/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServer.java
new file mode 100644
index 0000000..298f532
--- /dev/null
+++ b/runners/reference/job-server/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServer.java
@@ -0,0 +1,77 @@
+/*
+ * 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.beam.runners.reference.job;
+
+import io.grpc.Server;
+import io.grpc.ServerBuilder;
+import java.io.IOException;
+import org.kohsuke.args4j.CmdLineException;
+import org.kohsuke.args4j.CmdLineParser;
+import org.kohsuke.args4j.Option;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/** A program that runs a {@link ReferenceRunnerJobService}. */
+public class ReferenceRunnerJobServer {
+  private static final Logger LOG = LoggerFactory.getLogger(ReferenceRunnerJobService.class);
+
+  public static void main(String[] args) throws IOException, InterruptedException {
+    ServerConfiguration configuration = new ServerConfiguration();
+    CmdLineParser parser = new CmdLineParser(configuration);
+    try {
+      parser.parseArgument(args);
+    } catch (CmdLineException e) {
+      System.err.println(e);
+      printUsage(parser);
+      return;
+    }
+    runServer(configuration);
+  }
+
+  private static void printUsage(CmdLineParser parser) {
+    System.err.println(
+        String.format(
+            "Usage: java %s arguments...", ReferenceRunnerJobService.class.getSimpleName()));
+    parser.printUsage(System.err);
+    System.err.println();
+  }
+
+  private static void runServer(ServerConfiguration configuration)
+      throws IOException, InterruptedException {
+    ReferenceRunnerJobService service = ReferenceRunnerJobService.create();
+    Server server = ServerBuilder.forPort(configuration.port).addService(service).build();
+    server.start();
+    System.out.println(
+        String.format(
+            "Started %s on port %s",
+            ReferenceRunnerJobService.class.getSimpleName(), configuration.port));
+    server.awaitTermination();
+    System.out.println("Server shut down, exiting");
+  }
+
+  private static class ServerConfiguration {
+    @Option(
+      name = "-p",
+      aliases = {"--port"},
+      required = true,
+      usage = "The local port to expose the server on"
+    )
+    private int port = -1;
+  }
+}

http://git-wip-us.apache.org/repos/asf/beam/blob/992d805b/runners/reference/job-server/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobService.java
----------------------------------------------------------------------
diff --git a/runners/reference/job-server/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobService.java b/runners/reference/job-server/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobService.java
new file mode 100644
index 0000000..fc884ad
--- /dev/null
+++ b/runners/reference/job-server/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobService.java
@@ -0,0 +1,79 @@
+/*
+ * 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.beam.runners.reference.job;
+
+import io.grpc.Status;
+import io.grpc.stub.StreamObserver;
+import org.apache.beam.sdk.common.runner.v1.JobApi;
+import org.apache.beam.sdk.common.runner.v1.JobApi.CancelJobRequest;
+import org.apache.beam.sdk.common.runner.v1.JobApi.CancelJobResponse;
+import org.apache.beam.sdk.common.runner.v1.JobApi.GetJobStateRequest;
+import org.apache.beam.sdk.common.runner.v1.JobApi.GetJobStateResponse;
+import org.apache.beam.sdk.common.runner.v1.JobApi.PrepareJobResponse;
+import org.apache.beam.sdk.common.runner.v1.JobApi.RunJobRequest;
+import org.apache.beam.sdk.common.runner.v1.JobServiceGrpc.JobServiceImplBase;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/** The ReferenceRunner uses the portability framework to execute a Pipeline on a single machine. */
+public class ReferenceRunnerJobService extends JobServiceImplBase {
+  private static final Logger LOG = LoggerFactory.getLogger(ReferenceRunnerJobService.class);
+
+  public static ReferenceRunnerJobService create() {
+    return new ReferenceRunnerJobService();
+  }
+
+  private ReferenceRunnerJobService() {}
+
+  @Override
+  public void prepare(
+      JobApi.PrepareJobRequest request,
+      StreamObserver<JobApi.PrepareJobResponse> responseObserver) {
+    LOG.trace("{} {}", PrepareJobResponse.class.getSimpleName(), request);
+    System.err.println("Preparation Job Blah");
+    responseObserver.onError(Status.UNIMPLEMENTED.asException());
+  }
+
+  @Override
+  public void run(
+      JobApi.RunJobRequest request, StreamObserver<JobApi.RunJobResponse> responseObserver) {
+    LOG.trace("{} {}", RunJobRequest.class.getSimpleName(), request);
+    System.err.println("Run Job Blah");
+    responseObserver.onError(Status.UNIMPLEMENTED.asException());
+  }
+
+  @Override
+  public void getState(
+      GetJobStateRequest request, StreamObserver<GetJobStateResponse> responseObserver) {
+    LOG.trace("{} {}", GetJobStateRequest.class.getSimpleName(), request);
+    responseObserver.onError(
+        Status.NOT_FOUND
+            .withDescription(String.format("Unknown Job ID %s", request.getJobId()))
+            .asException());
+  }
+
+  @Override
+  public void cancel(CancelJobRequest request, StreamObserver<CancelJobResponse> responseObserver) {
+    LOG.trace("{} {}", CancelJobRequest.class.getSimpleName(), request);
+    responseObserver.onError(
+        Status.NOT_FOUND
+            .withDescription(String.format("Unknown Job ID %s", request.getJobId()))
+            .asException());
+  }
+}

http://git-wip-us.apache.org/repos/asf/beam/blob/992d805b/runners/reference/job-server/src/main/java/org/apache/beam/runners/reference/job/package-info.java
----------------------------------------------------------------------
diff --git a/runners/reference/job-server/src/main/java/org/apache/beam/runners/reference/job/package-info.java b/runners/reference/job-server/src/main/java/org/apache/beam/runners/reference/job/package-info.java
new file mode 100644
index 0000000..b6022d9
--- /dev/null
+++ b/runners/reference/job-server/src/main/java/org/apache/beam/runners/reference/job/package-info.java
@@ -0,0 +1,23 @@
+/*
+ * 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.
+ */
+
+/**
+ * An execution engine for Beam Pipelines that uses the Java Runner harness and the Fn API to
+ * execute.
+ */
+package org.apache.beam.runners.reference.job;

http://git-wip-us.apache.org/repos/asf/beam/blob/992d805b/runners/reference/job-server/src/test/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServiceTest.java
----------------------------------------------------------------------
diff --git a/runners/reference/job-server/src/test/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServiceTest.java b/runners/reference/job-server/src/test/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServiceTest.java
new file mode 100644
index 0000000..16cde11
--- /dev/null
+++ b/runners/reference/job-server/src/test/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServiceTest.java
@@ -0,0 +1,34 @@
+/*
+ * 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.beam.runners.reference.job;
+
+import org.junit.Test;
+import org.junit.runner.RunWith;
+import org.junit.runners.JUnit4;
+
+/**
+ * Tests for {@link ReferenceRunnerJobService}.
+ */
+@RunWith(JUnit4.class)
+public class ReferenceRunnerJobServiceTest {
+  @Test
+  public void testPrepareJob() {
+    // TODO: Implement when PrepareJob is implemented.
+  }
+}

http://git-wip-us.apache.org/repos/asf/beam/blob/992d805b/runners/reference/pom.xml
----------------------------------------------------------------------
diff --git a/runners/reference/pom.xml b/runners/reference/pom.xml
index 39659bb..d5f1993 100644
--- a/runners/reference/pom.xml
+++ b/runners/reference/pom.xml
@@ -26,50 +26,15 @@
     <relativePath>../pom.xml</relativePath>
   </parent>
 
-  <artifactId>beam-runners-reference</artifactId>
+  <artifactId>beam-runners-reference-parent</artifactId>
+
   <name>Apache Beam :: Runners :: Reference</name>
   <description>A Pipeline Runner which executes on the local machine using the
   Beam portability framework to execute an arbitrary Pipeline.</description>
 
-  <packaging>jar</packaging>
-
-  <dependencies>
-    <dependency>
-      <groupId>org.apache.beam</groupId>
-      <artifactId>beam-sdks-common-runner-api</artifactId>
-    </dependency>
-
-    <dependency>
-      <groupId>io.grpc</groupId>
-      <artifactId>grpc-core</artifactId>
-    </dependency>
-
-    <dependency>
-      <groupId>io.grpc</groupId>
-      <artifactId>grpc-stub</artifactId>
-    </dependency>
-
-    <dependency>
-      <groupId>args4j</groupId>
-      <artifactId>args4j</artifactId>
-    </dependency>
-
-    <dependency>
-      <groupId>org.slf4j</groupId>
-      <artifactId>slf4j-api</artifactId>
-    </dependency>
-
-    <!-- test dependencies -->
-    <dependency>
-      <groupId>junit</groupId>
-      <artifactId>junit</artifactId>
-      <scope>test</scope>
-    </dependency>
+  <packaging>pom</packaging>
 
-    <dependency>
-      <groupId>org.slf4j</groupId>
-      <artifactId>slf4j-jdk14</artifactId>
-      <scope>test</scope>
-    </dependency>
-  </dependencies>
+  <modules>
+    <module>job-server</module>
+  </modules>
 </project>

http://git-wip-us.apache.org/repos/asf/beam/blob/992d805b/runners/reference/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServer.java
----------------------------------------------------------------------
diff --git a/runners/reference/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServer.java b/runners/reference/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServer.java
deleted file mode 100644
index 3262036..0000000
--- a/runners/reference/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServer.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.beam.runners.reference.job;
-
-import io.grpc.Server;
-import io.grpc.ServerBuilder;
-import java.io.IOException;
-import org.kohsuke.args4j.CmdLineException;
-import org.kohsuke.args4j.CmdLineParser;
-import org.kohsuke.args4j.Option;
-
-/** A program that runs a {@link ReferenceRunnerJobService}. */
-public class ReferenceRunnerJobServer {
-  public static void main(String[] args) throws IOException, InterruptedException {
-    ServerConfiguration configuration = new ServerConfiguration();
-    CmdLineParser parser = new CmdLineParser(configuration);
-    try {
-      parser.parseArgument(args);
-    } catch (CmdLineException e) {
-      System.err.println(e);
-      printUsage(parser);
-      return;
-    }
-    runServer(configuration);
-  }
-
-  private static void printUsage(CmdLineParser parser) {
-    System.err.println(
-        String.format(
-            "Usage: java %s arguments...", ReferenceRunnerJobService.class.getSimpleName()));
-    parser.printUsage(System.err);
-    System.err.println();
-  }
-
-  private static void runServer(ServerConfiguration configuration)
-      throws IOException, InterruptedException {
-    ReferenceRunnerJobService service = ReferenceRunnerJobService.create();
-    Server server = ServerBuilder.forPort(configuration.port).addService(service).build();
-    server.start();
-    server.awaitTermination();
-  }
-
-  private static class ServerConfiguration {
-    @Option(
-      name = "p",
-      aliases = {"port"},
-      required = true,
-      usage = "The local port to expose the server on"
-    )
-    private int port = -1;
-  }
-}

http://git-wip-us.apache.org/repos/asf/beam/blob/992d805b/runners/reference/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobService.java
----------------------------------------------------------------------
diff --git a/runners/reference/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobService.java b/runners/reference/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobService.java
deleted file mode 100644
index 9084bdf..0000000
--- a/runners/reference/src/main/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobService.java
+++ /dev/null
@@ -1,77 +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.beam.runners.reference.job;
-
-import io.grpc.Status;
-import io.grpc.stub.StreamObserver;
-import org.apache.beam.sdk.common.runner.v1.JobApi;
-import org.apache.beam.sdk.common.runner.v1.JobApi.CancelJobRequest;
-import org.apache.beam.sdk.common.runner.v1.JobApi.CancelJobResponse;
-import org.apache.beam.sdk.common.runner.v1.JobApi.GetJobStateRequest;
-import org.apache.beam.sdk.common.runner.v1.JobApi.GetJobStateResponse;
-import org.apache.beam.sdk.common.runner.v1.JobApi.PrepareJobResponse;
-import org.apache.beam.sdk.common.runner.v1.JobApi.RunJobRequest;
-import org.apache.beam.sdk.common.runner.v1.JobServiceGrpc.JobServiceImplBase;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/** The ReferenceRunner uses the portability framework to execute a Pipeline on a single machine. */
-public class ReferenceRunnerJobService extends JobServiceImplBase {
-  private static final Logger LOG = LoggerFactory.getLogger(ReferenceRunnerJobService.class);
-
-  public static ReferenceRunnerJobService create() {
-    return new ReferenceRunnerJobService();
-  }
-
-  private ReferenceRunnerJobService() {}
-
-  @Override
-  public void prepare(
-      JobApi.PrepareJobRequest request,
-      StreamObserver<JobApi.PrepareJobResponse> responseObserver) {
-    LOG.trace("{} {}", PrepareJobResponse.class.getSimpleName(), request);
-    responseObserver.onError(Status.UNIMPLEMENTED.asException());
-  }
-
-  @Override
-  public void run(
-      JobApi.RunJobRequest request, StreamObserver<JobApi.RunJobResponse> responseObserver) {
-    LOG.trace("{} {}", RunJobRequest.class.getSimpleName(), request);
-    responseObserver.onError(Status.UNIMPLEMENTED.asException());
-  }
-
-  @Override
-  public void getState(
-      GetJobStateRequest request, StreamObserver<GetJobStateResponse> responseObserver) {
-    LOG.trace("{} {}", GetJobStateRequest.class.getSimpleName(), request);
-    responseObserver.onError(
-        Status.NOT_FOUND
-            .withDescription(String.format("Unknown Job ID %s", request.getJobId()))
-            .asException());
-  }
-
-  @Override
-  public void cancel(CancelJobRequest request, StreamObserver<CancelJobResponse> responseObserver) {
-    LOG.trace("{} {}", CancelJobRequest.class.getSimpleName(), request);
-    responseObserver.onError(
-        Status.NOT_FOUND
-            .withDescription(String.format("Unknown Job ID %s", request.getJobId()))
-            .asException());
-  }
-}

http://git-wip-us.apache.org/repos/asf/beam/blob/992d805b/runners/reference/src/main/java/org/apache/beam/runners/reference/job/package-info.java
----------------------------------------------------------------------
diff --git a/runners/reference/src/main/java/org/apache/beam/runners/reference/job/package-info.java b/runners/reference/src/main/java/org/apache/beam/runners/reference/job/package-info.java
deleted file mode 100644
index b6022d9..0000000
--- a/runners/reference/src/main/java/org/apache/beam/runners/reference/job/package-info.java
+++ /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.
- */
-
-/**
- * An execution engine for Beam Pipelines that uses the Java Runner harness and the Fn API to
- * execute.
- */
-package org.apache.beam.runners.reference.job;

http://git-wip-us.apache.org/repos/asf/beam/blob/992d805b/runners/reference/src/test/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServiceTest.java
----------------------------------------------------------------------
diff --git a/runners/reference/src/test/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServiceTest.java b/runners/reference/src/test/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServiceTest.java
deleted file mode 100644
index 16cde11..0000000
--- a/runners/reference/src/test/java/org/apache/beam/runners/reference/job/ReferenceRunnerJobServiceTest.java
+++ /dev/null
@@ -1,34 +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.beam.runners.reference.job;
-
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.junit.runners.JUnit4;
-
-/**
- * Tests for {@link ReferenceRunnerJobService}.
- */
-@RunWith(JUnit4.class)
-public class ReferenceRunnerJobServiceTest {
-  @Test
-  public void testPrepareJob() {
-    // TODO: Implement when PrepareJob is implemented.
-  }
-}