You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@reef.apache.org by we...@apache.org on 2014/10/23 02:04:16 UTC

[45/51] [abbrv] [partial] Initial merge of Wake, Tang and REEF into one repository and project

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/client/package-info.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/client/package-info.java b/reef-common/src/main/java/com/microsoft/reef/client/package-info.java
deleted file mode 100644
index 3041ecb..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/client/package-info.java
+++ /dev/null
@@ -1,20 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed 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.
- */
-/**
- * Client APIs for REEF. A Client in REEF is the program that submits a Driver to a resource manager.
- * This submission is done via the REEF.submit() method which accepts a Driver Configuration.
- */
-package com.microsoft.reef.client;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobCompletedHandler.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobCompletedHandler.java b/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobCompletedHandler.java
deleted file mode 100644
index 5c1ac21..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobCompletedHandler.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.client.parameters;
-
-import com.microsoft.reef.client.CompletedJob;
-import com.microsoft.reef.runtime.common.client.defaults.DefaultCompletedJobHandler;
-import com.microsoft.tang.annotations.Name;
-import com.microsoft.tang.annotations.NamedParameter;
-import com.microsoft.wake.EventHandler;
-
-/**
- * Event handler for CompletedJob
- */
-@NamedParameter(doc = "Event handler for CompletedJob",
-    default_classes = DefaultCompletedJobHandler.class)
-public final class JobCompletedHandler implements Name<EventHandler<CompletedJob>> {
-  private JobCompletedHandler() {
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobFailedHandler.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobFailedHandler.java b/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobFailedHandler.java
deleted file mode 100644
index 1a2c3bf..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobFailedHandler.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.client.parameters;
-
-import com.microsoft.reef.client.FailedJob;
-import com.microsoft.reef.runtime.common.client.defaults.DefaultFailedJobHandler;
-import com.microsoft.tang.annotations.Name;
-import com.microsoft.tang.annotations.NamedParameter;
-import com.microsoft.wake.EventHandler;
-
-/**
- * Client EventHandler triggered on remote job failure.
- */
-@NamedParameter(doc = "Client EventHandler triggered on remote job failure.",
-    default_classes = DefaultFailedJobHandler.class)
-public final class JobFailedHandler implements Name<EventHandler<FailedJob>> {
-  private JobFailedHandler() {
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobMessageHandler.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobMessageHandler.java b/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobMessageHandler.java
deleted file mode 100644
index 18b4962..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobMessageHandler.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.client.parameters;
-
-import com.microsoft.reef.client.JobMessage;
-import com.microsoft.reef.runtime.common.client.defaults.DefaultJobMessageHandler;
-import com.microsoft.tang.annotations.Name;
-import com.microsoft.tang.annotations.NamedParameter;
-import com.microsoft.wake.EventHandler;
-
-/**
- * Client EventHandler that gets messages from the Driver.
- */
-@NamedParameter(doc = "Client EventHandler that gets messages from the Driver.",
-    default_classes = DefaultJobMessageHandler.class)
-public final class JobMessageHandler implements Name<EventHandler<JobMessage>> {
-  private JobMessageHandler() {
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobRunningHandler.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobRunningHandler.java b/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobRunningHandler.java
deleted file mode 100644
index d331947..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/client/parameters/JobRunningHandler.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.client.parameters;
-
-import com.microsoft.reef.client.RunningJob;
-import com.microsoft.reef.runtime.common.client.defaults.DefaultRunningJobHandler;
-import com.microsoft.tang.annotations.Name;
-import com.microsoft.tang.annotations.NamedParameter;
-import com.microsoft.wake.EventHandler;
-
-/**
- * Client EventHandler triggered when the REEF job is running.
- */
-@NamedParameter(doc = "Client EventHandler triggered when the REEF job is running.",
-    default_classes = DefaultRunningJobHandler.class)
-public final class JobRunningHandler implements Name<EventHandler<RunningJob>> {
-  private JobRunningHandler() {
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/client/parameters/ResourceManagerErrorHandler.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/client/parameters/ResourceManagerErrorHandler.java b/reef-common/src/main/java/com/microsoft/reef/client/parameters/ResourceManagerErrorHandler.java
deleted file mode 100644
index d72795c..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/client/parameters/ResourceManagerErrorHandler.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.client.parameters;
-
-import com.microsoft.reef.client.FailedRuntime;
-import com.microsoft.reef.runtime.common.client.defaults.DefaultRuntimeErrorHandler;
-import com.microsoft.tang.annotations.Name;
-import com.microsoft.tang.annotations.NamedParameter;
-import com.microsoft.wake.EventHandler;
-
-/**
- * Client EventHandler triggered on resource manager error.
- */
-@NamedParameter(doc = "Client EventHandler triggered on resource manager error.",
-    default_classes = DefaultRuntimeErrorHandler.class)
-public final class ResourceManagerErrorHandler implements Name<EventHandler<FailedRuntime>> {
-  private ResourceManagerErrorHandler() {
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/client/parameters/package-info.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/client/parameters/package-info.java b/reef-common/src/main/java/com/microsoft/reef/client/parameters/package-info.java
deleted file mode 100644
index 39d9111..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/client/parameters/package-info.java
+++ /dev/null
@@ -1,19 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed 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.
- */
-/**
- * Named parameters for the REEF client API.
- */
-package com.microsoft.reef.client.parameters;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/common/AbstractFailure.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/common/AbstractFailure.java b/reef-common/src/main/java/com/microsoft/reef/common/AbstractFailure.java
deleted file mode 100644
index 1cae0e1..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/common/AbstractFailure.java
+++ /dev/null
@@ -1,148 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.common;
-
-import com.microsoft.reef.util.Optional;
-
-import java.io.PrintWriter;
-import java.io.StringWriter;
-
-/**
- * Common data and functionality for all error messages in REEF.
- */
-public abstract class AbstractFailure implements Failure {
-
-  /**
-   * Identifier of the entity that produced the error. Cannot be null.
-   */
-  protected final String id;
-
-  /**
-   * One-line error message. For wrapped exceptions, this equals
-   * to the Exception.getMessage() result. Cannot be null.
-   */
-  protected final String message;
-
-  /**
-   * Optional error description (long).
-   * For exceptions it is by default populates with the stack trace.
-   */
-  protected final Optional<String> description;
-
-  /**
-   * Optional Java exception that caused the error.
-   */
-  protected final Optional<Throwable> cause;
-
-  /**
-   * Optional byte array that contains serialized version of the exception.
-   */
-  protected final Optional<byte[]> data;
-
-  /**
-   * @param id          Identifier of the entity that produced the error. Cannot be null.
-   * @param message     One-line error message. Cannot be null.
-   * @param description Long error description. Can be null.
-   * @param cause       Java Exception that caused the error. Can be null.
-   * @param data        byte array that contains serialized version of the error. Can be null.
-   */
-  protected AbstractFailure(final String id,
-                            final String message,
-                            final Optional<String> description,
-                            final Optional<Throwable> cause,
-                            final Optional<byte[]> data) {
-    this.id = id;
-    this.message = message;
-    this.description = description;
-    this.cause = cause;
-    this.data = data;
-  }
-
-
-  /**
-   * Helper function: produce the string that contains the given exception's stack trace.
-   * Returns null if the argument is null.
-   *
-   * @param cause Java Exception or null.
-   * @return A string that contains the exception stack trace, or null.
-   */
-  protected static String getStackTrace(final Throwable cause) {
-    if (cause == null) {
-      return null;
-    } else {
-      final StringWriter writer = new StringWriter();
-      cause.printStackTrace(new PrintWriter(writer));
-      return writer.toString();
-    }
-  }
-
-  /**
-   * @return Identifier of the entity that produced the error. Never null.
-   */
-  @Override
-  public String getId() {
-    return this.id;
-  }
-
-  /**
-   * @return One-line error message. Never null.
-   */
-  @Override
-  public String getMessage() {
-    return this.message;
-  }
-
-  /**
-   * @return Optional long error description. For Java Exceptions, can contain stack trace.
-   */
-  @Override
-  public Optional<String> getDescription() {
-    return this.description;
-  }
-
-  @Override
-  public Optional<Throwable> getReason() {
-    return this.cause;
-  }
-
-  /**
-   * @return Optional serialized version of the error message.
-   */
-  @Override
-  public Optional<byte[]> getData() {
-    return this.data;
-  }
-
-  /**
-   * Return the original Java Exception, or generate a new one if it does not exists.
-   * ALWAYS returns an exception.
-   * FIXME: Replace RuntimeException with a better class.
-   *
-   * @return A java exception. Never null.
-   */
-  @Override
-  public Throwable asError() {
-    return this.cause.isPresent() ? this.cause.get() : new RuntimeException(this.toString());
-  }
-
-  /**
-   * @return Human-readable string representation of an error message.
-   */
-  @Override
-  public String toString() {
-    return this.getClass().getName() + " id=" + this.getId() + " failed: " + this.getMessage();
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/common/Failure.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/common/Failure.java b/reef-common/src/main/java/com/microsoft/reef/common/Failure.java
deleted file mode 100644
index c31ec2a..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/common/Failure.java
+++ /dev/null
@@ -1,55 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.common;
-
-import com.microsoft.reef.io.naming.Identifiable;
-import com.microsoft.reef.util.Optional;
-
-/**
- * Common interface for all error messages in REEF.
- * Most of its functionality is generic and implemented in the AbstractFailure class.
- */
-public interface Failure extends Identifiable {
-
-  /**
-   * @return One-line error message. Should never be null.
-   */
-  String getMessage();
-
-  /**
-   * @return Optional long error description.
-   */
-  Optional<String> getDescription();
-
-  /**
-   * @return Java Exception that caused the error, if any.
-   */
-  Optional<Throwable> getReason();
-
-
-  /**
-   * @return Optional serialized version of the error message.
-   */
-  Optional<byte[]> getData();
-
-  /**
-   * Return the original Java Exception, or generate a new one if it does not exists.
-   * ALWAYS returns an exception.
-   *
-   * @return A java exception. Never null.
-   */
-  Throwable asError();
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/ContextAndTaskSubmittable.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/ContextAndTaskSubmittable.java b/reef-common/src/main/java/com/microsoft/reef/driver/ContextAndTaskSubmittable.java
deleted file mode 100644
index 1012f82..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/ContextAndTaskSubmittable.java
+++ /dev/null
@@ -1,61 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.tang.Configuration;
-
-/**
- * Base interface for classes that support the simultaneous submission of both Context and Task configurations.
- */
-@DriverSide
-@Provided
-@Public
-public interface ContextAndTaskSubmittable {
-  /**
-   * Submit a Context and a Task.
-   * <p/>
-   * The semantics of this call are the same as first submitting the context and then, on the fired ActiveContext event
-   * to submit the Task. The performance of this will be better, though as it potentially saves some roundtrips on
-   * the network.
-   * <p/>
-   * REEF will not fire an ActiveContext as a result of this. Instead, it will fire a TaskRunning event.
-   *
-   * @param contextConfiguration  the Configuration of the EvaluatorContext. See ContextConfiguration for details.
-   * @param taskConfiguration the Configuration of the Task. See TaskConfiguration for details.
-   */
-  public void submitContextAndTask(final Configuration contextConfiguration, final Configuration taskConfiguration);
-
-  /**
-   * Subkit a Context with Services and a Task.
-   * <p/>
-   * The semantics of this call are the same as first submitting the context and services and then, on the fired
-   * ActiveContext event to submit the Task. The performance of this will be better, though as it potentially saves
-   * some roundtrips on the network.
-   * <p/>
-   * REEF will not fire an ActiveContext as a result of this. Instead, it will fire a TaskRunning event.
-   *
-   * @param contextConfiguration
-   * @param serviceConfiguration
-   * @param taskConfiguration
-   */
-  public void submitContextAndServiceAndTask(final Configuration contextConfiguration,
-                                             final Configuration serviceConfiguration,
-                                             final Configuration taskConfiguration);
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/ContextSubmittable.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/ContextSubmittable.java b/reef-common/src/main/java/com/microsoft/reef/driver/ContextSubmittable.java
deleted file mode 100644
index 961f3cb..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/ContextSubmittable.java
+++ /dev/null
@@ -1,46 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.tang.Configuration;
-
-/**
- * Base interface for classes that support Context submission.
- */
-@DriverSide
-@Provided
-@Public
-public interface ContextSubmittable {
-
-  /**
-   * Submit a Context.
-   *
-   * @param contextConfiguration the Configuration of the EvaluatorContext. See ContextConfiguration for details.
-   */
-  public void submitContext(final Configuration contextConfiguration);
-
-  /**
-   * Submit a Context and a Service Configuration.
-   *
-   * @param contextConfiguration the Configuration of the EvaluatorContext. See ContextConfiguration for details.
-   * @param serviceConfiguration the Configuration for the Services. See ServiceConfiguration for details.
-   */
-  public void submitContextAndService(final Configuration contextConfiguration, final Configuration serviceConfiguration);
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/FlexiblePreemptionEvent.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/FlexiblePreemptionEvent.java b/reef-common/src/main/java/com/microsoft/reef/driver/FlexiblePreemptionEvent.java
deleted file mode 100644
index fc992d0..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/FlexiblePreemptionEvent.java
+++ /dev/null
@@ -1,44 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.Unstable;
-import com.microsoft.reef.annotations.audience.Private;
-import com.microsoft.reef.driver.evaluator.EvaluatorRequest;
-
-import java.util.Set;
-
-/**
- * Represents a flexible preemption request: It contains:
- * <p/>
- * <ol>
- * <li>a set of EvaluatorRequests that the resource manager wants to have satisfied and also</li>
- * <li>a set of Evaluators it will choose to kill if the request isn't satisfied otherwise.</li>
- * </ol>
- * <p/>
- * NOTE: This currently not implemented. Consider it a preview of the API.
- */
-@Private
-@Provided
-@Unstable
-public interface FlexiblePreemptionEvent extends PreemptionEvent {
-
-  /**
-   * @return the set of EvaluatorRequests that the underlying resource manager seeks to satisfy.
-   */
-  public Set<EvaluatorRequest> getEvaluatorRequest();
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/PreemptionEvent.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/PreemptionEvent.java b/reef-common/src/main/java/com/microsoft/reef/driver/PreemptionEvent.java
deleted file mode 100644
index c1f1c6c..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/PreemptionEvent.java
+++ /dev/null
@@ -1,44 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.Unstable;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-
-/**
- * Represents Preemption requests issued by the underlying resource manager.
- * <p/>
- * REEF exposes two kinds of preemption requests: Strict ones merely inform the Driver about machines that are about to
- * be preempted. Flexible ones provide that list, but also expose the resource request that the underlying resource
- * manager wants to satisfy, thereby giving the Driver a chance to satisfy it in another way.
- * <p/>
- * NOTE: This currently not implemented. Consider it a preview of the API.
- */
-@DriverSide
-@Public
-@Provided
-@Unstable
-public interface PreemptionEvent {
-
-  /**
-   * @return the Set of RunningEvaluators that the underlying resource manager is about to take away from the Driver.
-   */
-  // TODO: We need to have a set of things to present to the user as preempted. Probably a Set<String> with the Evaluator IDs.
-  // public Set<RunningEvaluator> getToBePreemptedEvaluators();
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/PreemptionHandler.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/PreemptionHandler.java b/reef-common/src/main/java/com/microsoft/reef/driver/PreemptionHandler.java
deleted file mode 100644
index 716a1a5..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/PreemptionHandler.java
+++ /dev/null
@@ -1,33 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver;
-
-import com.microsoft.reef.annotations.Optional;
-import com.microsoft.reef.annotations.Unstable;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.wake.EventHandler;
-
-/**
- * This EventHandler will receive preemption events from the underlying resourcemanager.
- * NOTE: This currently not implemented. Consider it a preview of the API.
- */
-@DriverSide
-@Public
-@Optional
-@Unstable
-public interface PreemptionHandler extends EventHandler<PreemptionEvent> {
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/StrictPreemptionEvent.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/StrictPreemptionEvent.java b/reef-common/src/main/java/com/microsoft/reef/driver/StrictPreemptionEvent.java
deleted file mode 100644
index c243faf..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/StrictPreemptionEvent.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.Unstable;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-
-/**
- * Represents a strict preemption event: It contains the set of Evaluators that the underlying resource manager will
- * take away from the Driver.
- * <p/>
- * NOTE: This currently not implemented. Consider it a preview of the API.
- */
-@Unstable
-@DriverSide
-@Public
-@Provided
-public interface StrictPreemptionEvent extends PreemptionEvent {
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/TaskSubmittable.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/TaskSubmittable.java b/reef-common/src/main/java/com/microsoft/reef/driver/TaskSubmittable.java
deleted file mode 100644
index 5677fa0..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/TaskSubmittable.java
+++ /dev/null
@@ -1,37 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.tang.Configuration;
-
-/**
- * Base interface for classes that support Task submission.
- */
-@DriverSide
-@Provided
-@Public
-public interface TaskSubmittable {
-
-  /**
-   * Submits a Task (encoded in the Configuration) for execution.
-   *
-   * @param taskConf the Configuration. See TaskConfiguration for details
-   */
-  public void submitTask(final Configuration taskConf);
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/catalog/NodeDescriptor.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/catalog/NodeDescriptor.java b/reef-common/src/main/java/com/microsoft/reef/driver/catalog/NodeDescriptor.java
deleted file mode 100644
index be64eba..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/catalog/NodeDescriptor.java
+++ /dev/null
@@ -1,39 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.catalog;
-
-import com.microsoft.reef.annotations.Unstable;
-import com.microsoft.reef.io.naming.Identifiable;
-
-import java.net.InetSocketAddress;
-
-/**
- * Descriptor of the physical setup of an Evaluator.
- */
-@Unstable
-public interface NodeDescriptor extends ResourceCatalog.Descriptor, Identifiable {
-  /**
-   * Access the inet address of the Evaluator.
-   *
-   * @return the inet address of the Evaluator.
-   */
-  public InetSocketAddress getInetSocketAddress();
-
-  /**
-   * @return the rack descriptor that contains this node
-   */
-  public RackDescriptor getRackDescriptor();
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/catalog/RackDescriptor.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/catalog/RackDescriptor.java b/reef-common/src/main/java/com/microsoft/reef/driver/catalog/RackDescriptor.java
deleted file mode 100644
index accb529..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/catalog/RackDescriptor.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.catalog;
-
-import com.microsoft.reef.annotations.Unstable;
-
-import java.util.List;
-
-/**
- * A rack in the cluster.
- */
-@Unstable
-public interface RackDescriptor extends ResourceCatalog.Descriptor {
-
-  /**
-   * @return the list of nodes in this rack.
-   */
-  public List<NodeDescriptor> getNodes();
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/catalog/ResourceCatalog.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/catalog/ResourceCatalog.java b/reef-common/src/main/java/com/microsoft/reef/driver/catalog/ResourceCatalog.java
deleted file mode 100644
index 052e45b..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/catalog/ResourceCatalog.java
+++ /dev/null
@@ -1,62 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.catalog;
-
-import com.microsoft.reef.annotations.Unstable;
-
-import java.util.Collection;
-
-/**
- * A catalog of the resources available to a REEF instance.
- * <p/>
- * This catalog contains static information about the resources and does not
- * reflect that dynamic availability of resources. In other words: Its entries
- * are an upper bound to what is available to a REEF {@link Driver} at any given
- * moment in time.
- */
-@Unstable
-public interface ResourceCatalog {
-
-  public interface Descriptor {
-
-    public String getName();
-
-  }
-
-  /**
-   * The global list of resources.
-   *
-   * @return a list of all the static resources available. This is an upper
-   * bound.
-   */
-  public Collection<NodeDescriptor> getNodes();
-
-  /**
-   * The global list of racks
-   *
-   * @return list of all rack descriptors
-   */
-  public Collection<RackDescriptor> getRacks();
-
-  /**
-   * Get the node descriptor with the given identifier.
-   *
-   * @param id of the node.
-   * @return the node descriptor assigned to the identifier.
-   */
-  public NodeDescriptor getNode(String nodeId);
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/client/JobMessageObserver.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/client/JobMessageObserver.java b/reef-common/src/main/java/com/microsoft/reef/driver/client/JobMessageObserver.java
deleted file mode 100644
index fc31680..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/client/JobMessageObserver.java
+++ /dev/null
@@ -1,41 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.client;
-
-import com.microsoft.reef.annotations.Optional;
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-
-/**
- * The driver uses this interface to communicate with the job client.
- * <p/>
- * Note that as of REEF 0.4, the presence of a client is no longer guaranteed, depending on the deployment environment.
- */
-@Public
-@DriverSide
-@Provided
-@Optional
-public interface JobMessageObserver {
-
-  /**
-   * Send a message to the client.
-   *
-   * @param message a message to be sent to the client
-   */
-  public void sendMessageToClient(final byte[] message);
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/client/package-info.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/client/package-info.java b/reef-common/src/main/java/com/microsoft/reef/driver/client/package-info.java
deleted file mode 100644
index 538210c..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/client/package-info.java
+++ /dev/null
@@ -1,22 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed 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.
- */
-/**
- * Representations of the Client (i.e. the job submitter) to a Driver.
- * Note that as of REEF 0.3, the client is optional and may not be available to a driver.
- */
-@DriverSide package com.microsoft.reef.driver.client;
-
-import com.microsoft.reef.annotations.audience.DriverSide;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/context/ActiveContext.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/context/ActiveContext.java b/reef-common/src/main/java/com/microsoft/reef/driver/context/ActiveContext.java
deleted file mode 100644
index a9be44f..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/context/ActiveContext.java
+++ /dev/null
@@ -1,67 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.context;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.reef.driver.TaskSubmittable;
-import com.microsoft.reef.driver.ContextSubmittable;
-import com.microsoft.reef.io.naming.Identifiable;
-import com.microsoft.tang.Configuration;
-
-/**
- * Represents an active context on an Evaluator.
- * <p/>
- * A context consists of twp configurations:
- * <ol>
- * <li>ContextConfiguration: Its visibility is limited to the context itself and tasks spawned from it.</li>
- * <li>ServiceConfiguration: This is "inherited" by child context spawned.</li>
- * </ol>
- * <p/>
- * Contexts have identifiers. A context is instantiated on a single Evaluator. Contexts are either created on an
- * AllocatedEvaluator (for what is called the "root Context") or by forming sub-Contexts.
- * <p/>
- * Contexts form a stack. Only the topmost context is active. Child Contexts or Tasks can be submitted to the
- * active Context. Contexts can be closed, in which case their parent becomes active.
- * In the case of the root context, closing is equivalent to releasing the Evaluator. A child context "sees" all
- * Configuration in its parent Contexts.
- */
-@Public
-@DriverSide
-@Provided
-public interface ActiveContext extends Identifiable, AutoCloseable, ContextBase, TaskSubmittable, ContextSubmittable {
-
-  @Override
-  public void close();
-
-  @Override
-  public void submitTask(final Configuration taskConf);
-
-  @Override
-  public void submitContext(final Configuration contextConfiguration);
-
-  @Override
-  public void submitContextAndService(final Configuration contextConfiguration, final Configuration serviceConfiguration);
-
-  /**
-   * Send the active context the message, which will be delivered to all registered
-   * {@link com.microsoft.reef.evaluator.context.ContextMessageHandler}, for this context.
-   * @param message
-   */
-  public void sendMessage(final byte[] message);
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/context/ClosedContext.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/context/ClosedContext.java b/reef-common/src/main/java/com/microsoft/reef/driver/context/ClosedContext.java
deleted file mode 100644
index f4b6a64..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/context/ClosedContext.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.context;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-
-/**
- * Represents a Context that has been closed succesfully.
- */
-@Public
-@DriverSide
-@Provided
-public interface ClosedContext extends ContextBase {
-
-  /**
-   * @return the new top of the stack of context.
-   */
-  public ActiveContext getParentContext();
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/context/ContextBase.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/context/ContextBase.java b/reef-common/src/main/java/com/microsoft/reef/driver/context/ContextBase.java
deleted file mode 100644
index 32ec637..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/context/ContextBase.java
+++ /dev/null
@@ -1,53 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.context;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.reef.driver.evaluator.EvaluatorDescriptor;
-import com.microsoft.reef.io.naming.Identifiable;
-import com.microsoft.reef.util.Optional;
-
-/**
- * A common base interface for all Driver-side representations of Contexts.
- */
-@Public
-@DriverSide
-@Provided
-public interface ContextBase extends Identifiable {
-
-  /**
-   * @return the ID of the Context.
-   */
-  @Override
-  String getId();
-
-  /**
-   * @return the identifier of the Evaluator this Context is instantiated on.
-   */
-  String getEvaluatorId();
-
-  /**
-   * @return the ID of the parent context, if there is one.
-   */
-  Optional<String> getParentId();
-
-  /**
-   * @return the descriptor of the Evaluator this Context is on.
-   */
-  EvaluatorDescriptor getEvaluatorDescriptor();
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/context/ContextConfiguration.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/context/ContextConfiguration.java b/reef-common/src/main/java/com/microsoft/reef/driver/context/ContextConfiguration.java
deleted file mode 100644
index 7397fa6..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/context/ContextConfiguration.java
+++ /dev/null
@@ -1,103 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.context;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.reef.driver.task.TaskConfigurationOptions;
-import com.microsoft.reef.evaluator.context.ContextMessageHandler;
-import com.microsoft.reef.evaluator.context.ContextMessageSource;
-import com.microsoft.reef.evaluator.context.events.ContextStart;
-import com.microsoft.reef.evaluator.context.events.ContextStop;
-import com.microsoft.tang.formats.*;
-import com.microsoft.reef.evaluator.context.parameters.*;
-import com.microsoft.reef.runtime.common.evaluator.DefaultDriverConnection;
-import com.microsoft.reef.runtime.common.evaluator.DriverConnection;
-import com.microsoft.reef.task.events.TaskStart;
-import com.microsoft.reef.task.events.TaskStop;
-import com.microsoft.tang.annotations.Name;
-import com.microsoft.tang.annotations.NamedParameter;
-import com.microsoft.wake.EventHandler;
-
-/**
- * A ConfigurationModule for Context Configuration.
- */
-@Public
-@DriverSide
-@Provided
-public class ContextConfiguration extends ConfigurationModuleBuilder {
-
-  /**
-   * The identifier of the Context.
-   */
-  public static final RequiredParameter<String> IDENTIFIER = new RequiredParameter<>();
-
-  /**
-   * Event handler for context start. Defaults to logging if not bound.
-   */
-  public static final OptionalImpl<EventHandler<ContextStart>> ON_CONTEXT_STARTED = new OptionalImpl<>();
-
-  /**
-   * Event handler for context stop. Defaults to logging if not bound.
-   */
-  public static final OptionalImpl<EventHandler<ContextStop>> ON_CONTEXT_STOP = new OptionalImpl<>();
-
-  /**
-   * Event handlers to be informed right before a Task enters its call() method.
-   */
-  public static final OptionalImpl<EventHandler<TaskStart>> ON_TASK_STARTED = new OptionalImpl<>();
-
-  /**
-   * Event handlers to be informed right after a Task exits its call() method.
-   */
-  public static final OptionalImpl<EventHandler<TaskStop>> ON_TASK_STOP = new OptionalImpl<>();
-
-  /**
-   * Source of messages to be called whenever the evaluator is about to make a heartbeat.
-   */
-  public static final OptionalImpl<ContextMessageSource> ON_SEND_MESSAGE = new OptionalImpl<>();
-
-  /**
-   * Driver has sent the context a message, and this parameter is used to register a handler
-   * on the context for processing that message.
-   */
-  public static final OptionalImpl<ContextMessageHandler> ON_MESSAGE = new OptionalImpl<>();
-
-  /**
-   * Implementation for reconnecting to driver after driver restart
-   */
-  public static final OptionalImpl<DriverConnection> ON_DRIVER_RECONNECT = new OptionalImpl<>();
-
-  /**
-   * A ConfigurationModule for context.
-   */
-  public static final ConfigurationModule CONF = new ContextConfiguration()
-      .bindNamedParameter(ContextIdentifier.class, IDENTIFIER)
-      .bindNamedParameter(DriverReconnect.class, ON_DRIVER_RECONNECT)
-      .bindSetEntry(ContextStartHandlers.class, ON_CONTEXT_STARTED)
-      .bindSetEntry(ContextStopHandlers.class, ON_CONTEXT_STOP)
-      .bindSetEntry(ContextMessageSources.class, ON_SEND_MESSAGE)
-      .bindSetEntry(ContextMessageHandlers.class, ON_MESSAGE)
-      .bindSetEntry(TaskConfigurationOptions.StartHandlers.class, ON_TASK_STARTED)
-      .bindSetEntry(TaskConfigurationOptions.StopHandlers.class, ON_TASK_STOP)
-      .build();
-
-  @NamedParameter(doc = "House the implementation for re-connecting to driver after driver restart",
-          default_classes = DefaultDriverConnection.class)
-  public static final class DriverReconnect implements Name<DriverConnection> {
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/context/ContextMessage.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/context/ContextMessage.java b/reef-common/src/main/java/com/microsoft/reef/driver/context/ContextMessage.java
deleted file mode 100644
index 0c9b45c..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/context/ContextMessage.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.context;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.reef.io.Message;
-import com.microsoft.reef.io.naming.Identifiable;
-
-/**
- * Driver-side representation of a message sent by a Context to the Driver.
- */
-@Public
-@DriverSide
-@Provided
-public interface ContextMessage extends Message, Identifiable {
-
-  /**
-   * @return the message sent by the Context.
-   */
-  @Override
-  public byte[] get();
-
-  /**
-   * @return the ID of the sending Context.
-   */
-  @Override
-  public String getId();
-
-  /**
-   * @return the ID of the ContextMessageSource that sent the message on the Context.
-   */
-  public String getMessageSourceID();
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/context/FailedContext.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/context/FailedContext.java b/reef-common/src/main/java/com/microsoft/reef/driver/context/FailedContext.java
deleted file mode 100644
index 9ae6dbc..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/context/FailedContext.java
+++ /dev/null
@@ -1,41 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.context;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.reef.common.Failure;
-import com.microsoft.reef.util.Optional;
-
-/**
- * Represents Context that failed.
- * A typical case would be that its ContextStartHandler threw an exception.
- * <p/>
- * The underlying Evaluator is still accessible and a new context can be established. Note that REEF can't guarantee
- * consistency of the Evaluator for all applications. It is up to the application to decide whether it is safe to keep
- * using the Evaluator.
- */
-@Public
-@Provided
-@DriverSide
-public interface FailedContext extends Failure, ContextBase {
-
-  /**
-   * @return the new top of the stack of context if there is one.
-   */
-  Optional<ActiveContext> getParentContext();
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/context/ServiceConfiguration.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/context/ServiceConfiguration.java b/reef-common/src/main/java/com/microsoft/reef/driver/context/ServiceConfiguration.java
deleted file mode 100644
index 4a930a8..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/context/ServiceConfiguration.java
+++ /dev/null
@@ -1,76 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.context;
-
-import com.microsoft.reef.evaluator.context.parameters.ContextStartHandlers;
-import com.microsoft.reef.evaluator.context.parameters.ContextStopHandlers;
-import com.microsoft.reef.evaluator.context.parameters.Services;
-import com.microsoft.reef.task.events.TaskStart;
-import com.microsoft.reef.task.events.TaskStop;
-import com.microsoft.reef.driver.task.TaskConfigurationOptions;
-import com.microsoft.reef.evaluator.context.events.ContextStart;
-import com.microsoft.reef.evaluator.context.events.ContextStop;
-import com.microsoft.tang.formats.ConfigurationModule;
-import com.microsoft.tang.formats.ConfigurationModuleBuilder;
-import com.microsoft.tang.formats.OptionalImpl;
-import com.microsoft.tang.formats.OptionalParameter;
-import com.microsoft.wake.EventHandler;
-
-/**
- * Configuration module for services. The configuration created here can be passed alongside a ContextConfiguration
- * to form a context. Different from bindings made in the ContextConfiguration, those made here will be passed along
- * to child context.
- */
-public class ServiceConfiguration extends ConfigurationModuleBuilder {
-
-  /**
-   * A set of services to instantiate. All classes given here will be instantiated in the context, and their references
-   * will be made available to child context and tasks.
-   */
-  public static final OptionalParameter<Object> SERVICES = new OptionalParameter<>();
-
-  /**
-   * Event handler for context start. Defaults to logging if not bound.
-   */
-  public static final OptionalImpl<EventHandler<ContextStart>> ON_CONTEXT_STARTED = new OptionalImpl<>();
-
-  /**
-   * Event handler for context stop. Defaults to logging if not bound.
-   */
-  public static final OptionalImpl<EventHandler<ContextStop>> ON_CONTEXT_STOP = new OptionalImpl<>();
-
-  /**
-   * Event handlers to be informed right before a Task enters its call() method.
-   */
-  public static final OptionalImpl<EventHandler<TaskStart>> ON_TASK_STARTED = new OptionalImpl<>();
-
-  /**
-   * Event handlers to be informed right after a Task exits its call() method.
-   */
-  public static final OptionalImpl<EventHandler<TaskStop>> ON_TASK_STOP = new OptionalImpl<>();
-
-  /**
-   * ConfigurationModule for services.
-   */
-  public static final ConfigurationModule CONF = new ServiceConfiguration()
-      .bindSetEntry(Services.class, SERVICES)
-      .bindSetEntry(ContextStartHandlers.class, ON_CONTEXT_STARTED)
-      .bindSetEntry(ContextStopHandlers.class, ON_CONTEXT_STOP)
-      .bindSetEntry(TaskConfigurationOptions.StartHandlers.class, ON_TASK_STARTED)
-      .bindSetEntry(TaskConfigurationOptions.StopHandlers.class, ON_TASK_STOP)
-      .build();
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/AllocatedEvaluator.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/AllocatedEvaluator.java b/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/AllocatedEvaluator.java
deleted file mode 100644
index 68f7821..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/AllocatedEvaluator.java
+++ /dev/null
@@ -1,98 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.evaluator;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.reef.driver.ContextAndTaskSubmittable;
-import com.microsoft.reef.driver.ContextSubmittable;
-import com.microsoft.reef.driver.TaskSubmittable;
-import com.microsoft.reef.io.naming.Identifiable;
-import com.microsoft.tang.Configuration;
-
-import java.io.File;
-import java.io.IOException;
-
-/**
- * Represents an Evaluator that is allocated, but is not running yet.
- */
-@Public
-@DriverSide
-@Provided
-public interface AllocatedEvaluator
-    extends AutoCloseable, Identifiable, ContextSubmittable, ContextAndTaskSubmittable, TaskSubmittable {
-
-  /**
-   * Puts the given file into the working directory of the Evaluator.
-   *
-   * @param file the file to be copied
-   * @throws IOException if the copy fails.
-   */
-  void addFile(final File file);
-
-  /**
-   * Puts the given file into the working directory of the Evaluator and adds it to its classpath.
-   *
-   * @param file the file to be copied
-   * @throws IOException if the copy fails.
-   */
-  void addLibrary(final File file);
-
-  /**
-   * @return the evaluator descriptor of this evaluator.
-   */
-  EvaluatorDescriptor getEvaluatorDescriptor();
-
-  /**
-   * Set the type of Evaluator to be instantiated. Defaults to EvaluatorType.JVM.
-   *
-   * @param type
-   */
-  void setType(final EvaluatorType type);
-
-  /**
-   * Releases the allocated evaluator back to the resource manager.
-   */
-  @Override
-  void close();
-
-  /**
-   * Submits the given Task for execution.
-   * <p/>
-   * This generates a ContextConfiguration for the root context with a generated ID derived from the EvaluatorId.
-   *
-   * @param taskConfiguration the Configuration. See TaskConfiguration for details.
-   */
-  @Override
-  void submitTask(final Configuration taskConfiguration);
-
-  @Override
-  void submitContext(final Configuration contextConfiguration);
-
-  @Override
-  void submitContextAndService(final Configuration contextConfiguration,
-                               final Configuration serviceConfiguration);
-
-  @Override
-  void submitContextAndTask(final Configuration contextConfiguration,
-                            final Configuration taskConfiguration);
-
-  @Override
-  void submitContextAndServiceAndTask(final Configuration contextConfiguration,
-                                      final Configuration serviceConfiguration,
-                                      final Configuration taskConfiguration);
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/CompletedEvaluator.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/CompletedEvaluator.java b/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/CompletedEvaluator.java
deleted file mode 100644
index a2156fa..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/CompletedEvaluator.java
+++ /dev/null
@@ -1,30 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.evaluator;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.reef.io.naming.Identifiable;
-
-/**
- * Represents a successfully closed Evaluator.
- */
-@DriverSide
-@Public
-@Provided
-public interface CompletedEvaluator extends Identifiable {
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorDescriptor.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorDescriptor.java b/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorDescriptor.java
deleted file mode 100644
index ae48041..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorDescriptor.java
+++ /dev/null
@@ -1,44 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.evaluator;
-
-import com.microsoft.reef.driver.catalog.NodeDescriptor;
-
-/**
- * Metadata about an Evaluator.
- */
-public interface EvaluatorDescriptor {
-
-  /**
-   * @return the NodeDescriptor of the node where this Evaluator is running.
-   */
-  public NodeDescriptor getNodeDescriptor();
-
-  /**
-   * @return the type of Evaluator.
-   */
-  public EvaluatorType getType();
-
-  /**
-   * @return the amount of memory allocated to this Evaluator.
-   */
-  public int getMemory();
-
-  /**
-   * @return the number of virtual core allocated to this Evaluator.
-   */
-  public int getNumberOfCores();
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorRequest.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorRequest.java b/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorRequest.java
deleted file mode 100644
index f80d217..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorRequest.java
+++ /dev/null
@@ -1,167 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.evaluator;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.reef.driver.catalog.NodeDescriptor;
-import com.microsoft.reef.driver.catalog.ResourceCatalog;
-
-/**
- * A request for one ore more Evaluators.
- */
-@Public
-@DriverSide
-@Provided
-public final class EvaluatorRequest {
-
-  private final int megaBytes;
-  private final int number;
-  private final int cores;
-  private final ResourceCatalog.Descriptor descriptor;
-
-  EvaluatorRequest(final int number,
-                   final int megaBytes,
-                   final int cores,
-                   final ResourceCatalog.Descriptor descriptor) {
-    this.number = number;
-    this.megaBytes = megaBytes;
-    this.cores = cores;
-    this.descriptor = descriptor;
-  }
-
-  /**
-   * Access the number of Evaluators requested.
-   *
-   * @return the number of Evaluators requested.
-   */
-  public int getNumber() {
-    return this.number;
-  }
-
-  /**
-   * Access the number of core of Evaluators requested.
-   *
-   * @return the number of cores requested.
-   */
-  public int getNumberOfCores() {
-    return this.cores;
-  }
-
-  /**
-   * Access the {@link NodeDescriptor} used as the template for this
-   * {@link EvaluatorRequest}.
-   *
-   * @return the {@link NodeDescriptor} used as the template for this
-   * {@link EvaluatorRequest}.
-   */
-  public final ResourceCatalog.Descriptor getDescriptor() {
-    return this.descriptor;
-  }
-
-  /**
-   * @return the minimum size of Evaluator requested.
-   */
-  public int getMegaBytes() {
-    return megaBytes;
-  }
-
-  /**
-   * @return a new EvaluatorRequest Builder.
-   */
-  public static Builder newBuilder() {
-    return new Builder();
-  }
-
-  /**
-   * @return a new EvaluatorRequest Builder with settings initialized
-   * from an existing request.
-   */
-  public static Builder newBuilder(final EvaluatorRequest request) {
-    return new Builder(request);
-  }
-
-  /**
-   * {@link EvaluatorRequest}s are build using this Builder.
-   */
-  public static class Builder implements com.microsoft.reef.util.Builder<EvaluatorRequest> {
-
-    private int n = 1;
-    private ResourceCatalog.Descriptor descriptor = null;
-    private int megaBytes = -1;
-    private int cores = 1; //if not set, default to 1
-
-    private Builder() {
-    }
-
-    private Builder(final EvaluatorRequest request) {
-      setNumber(request.getNumber());
-      fromDescriptor(request.getDescriptor());
-    }
-
-    /**
-     * @param megaBytes the amount of megabytes to request for the Evaluator.
-     * @return this builder
-     */
-    public Builder setMemory(final int megaBytes) {
-      this.megaBytes = megaBytes;
-      return this;
-    }
-
-    /**
-     * set number of cores
-     * @param cores the number of cores
-     * @return
-     */
-    public Builder setNumberOfCores(final int cores) {
-      this.cores = cores;
-      return this;
-    }
-
-    /**
-     * Set the number of Evaluators requested.
-     *
-     * @param n
-     * @return this Builder.
-     */
-    public Builder setNumber(final int n) {
-      this.n = n;
-      return this;
-    }
-
-    /**
-     * Builds the {@link EvaluatorRequest}.
-     */
-    @Override
-    public EvaluatorRequest build() {
-      return new EvaluatorRequest(this.n, this.megaBytes, this.cores, this.descriptor);
-    }
-
-    /**
-     * Pre-fill this {@link EvaluatorRequest} from the given
-     * {@link NodeDescriptor}. Any value not changed in subsequent calls to
-     * this Builder will be taken from the given descriptor.
-     *
-     * @param rd the descriptor used to pre-fill this request.
-     * @return this
-     */
-    public Builder fromDescriptor(final ResourceCatalog.Descriptor rd) {
-      this.descriptor = rd;
-      return this;
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorRequestor.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorRequestor.java b/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorRequestor.java
deleted file mode 100644
index 7a98ac9..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorRequestor.java
+++ /dev/null
@@ -1,35 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.evaluator;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-
-/**
- * Interface through which Evaluators can be requested.
- */
-@Public
-@DriverSide
-@Provided
-public interface EvaluatorRequestor {
-
-  /**
-   * Submit the request for new evaluator.
-   * The response will surface in the AllocatedEvaluator message handler.
-   */
-  public void submit(final EvaluatorRequest req);
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorType.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorType.java b/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorType.java
deleted file mode 100644
index d5475b8..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/EvaluatorType.java
+++ /dev/null
@@ -1,35 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.evaluator;
-
-/**
- * Enumeration of all Evaluator types supported by REEF.
- */
-public enum EvaluatorType {
-  /**
-   * Indicates an Evaluator that runs on the JVM
-   */
-  JVM,
-  /**
-   * Indicates an Evaluator that runs on the CLR
-   */
-  CLR,
-  /**
-   * Indicates an Evaluator whose type hasn't been decided yet. This is common e.g. between Evaluator allocation
-   * and launch.
-   */
-  UNDECIDED
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/FailedEvaluator.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/FailedEvaluator.java b/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/FailedEvaluator.java
deleted file mode 100644
index cf2478a..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/evaluator/FailedEvaluator.java
+++ /dev/null
@@ -1,52 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.evaluator;
-
-import com.microsoft.reef.annotations.Provided;
-import com.microsoft.reef.annotations.audience.DriverSide;
-import com.microsoft.reef.annotations.audience.Public;
-import com.microsoft.reef.driver.task.FailedTask;
-import com.microsoft.reef.driver.context.FailedContext;
-import com.microsoft.reef.exception.EvaluatorException;
-import com.microsoft.reef.io.naming.Identifiable;
-import com.microsoft.reef.util.Optional;
-
-import java.util.List;
-
-/**
- * Represents an Evaluator that became unavailable.
- */
-@DriverSide
-@Public
-@Provided
-public interface FailedEvaluator extends Identifiable {
-
-  /**
-   * @return the reason for the failure.
-   */
-  public EvaluatorException getEvaluatorException();
-
-  /**
-   * @return the list of all context that failed due to the evaluator failure.
-   */
-  public List<FailedContext> getFailedContextList();
-
-  /**
-   * @return the failed task, if there was one running at the time of the evaluator failure.
-   */
-  public Optional<FailedTask> getFailedTask();
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/package-info.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/package-info.java b/reef-common/src/main/java/com/microsoft/reef/driver/package-info.java
deleted file mode 100644
index 3d24ae1..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/package-info.java
+++ /dev/null
@@ -1,19 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed 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.
- */
-/**
- * Driver APIs for REEF in terms of Rx.
- */
-package com.microsoft.reef.driver;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/parameters/ClientCloseHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/parameters/ClientCloseHandlers.java b/reef-common/src/main/java/com/microsoft/reef/driver/parameters/ClientCloseHandlers.java
deleted file mode 100644
index 31b6154..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/parameters/ClientCloseHandlers.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.parameters;
-
-import com.microsoft.reef.runtime.common.driver.defaults.DefaultClientCloseHandler;
-import com.microsoft.tang.annotations.Name;
-import com.microsoft.tang.annotations.NamedParameter;
-import com.microsoft.wake.EventHandler;
-
-import java.util.Set;
-
-/**
- * Handles close requests from the client.
- */
-@NamedParameter(doc = "Handles close requests from the client.", default_classes = DefaultClientCloseHandler.class)
-public final class ClientCloseHandlers implements Name<Set<EventHandler<Void>>> {
-  private ClientCloseHandlers() {
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/parameters/ClientCloseWithMessageHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/parameters/ClientCloseWithMessageHandlers.java b/reef-common/src/main/java/com/microsoft/reef/driver/parameters/ClientCloseWithMessageHandlers.java
deleted file mode 100644
index dfdf3d4..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/parameters/ClientCloseWithMessageHandlers.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.parameters;
-
-import com.microsoft.reef.runtime.common.driver.defaults.DefaultClientCloseWithMessageHandler;
-import com.microsoft.tang.annotations.Name;
-import com.microsoft.tang.annotations.NamedParameter;
-import com.microsoft.wake.EventHandler;
-
-import java.util.Set;
-
-/**
- * Handles client close requests
- */
-@NamedParameter(doc = "Handles client close requests", default_classes = DefaultClientCloseWithMessageHandler.class)
-public final class ClientCloseWithMessageHandlers implements Name<Set<EventHandler<byte[]>>> {
-  private ClientCloseWithMessageHandlers() {
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/50444bba/reef-common/src/main/java/com/microsoft/reef/driver/parameters/ClientMessageHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/com/microsoft/reef/driver/parameters/ClientMessageHandlers.java b/reef-common/src/main/java/com/microsoft/reef/driver/parameters/ClientMessageHandlers.java
deleted file mode 100644
index f750028..0000000
--- a/reef-common/src/main/java/com/microsoft/reef/driver/parameters/ClientMessageHandlers.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.microsoft.reef.driver.parameters;
-
-import com.microsoft.reef.runtime.common.driver.defaults.DefaultClientMessageHandler;
-import com.microsoft.tang.annotations.Name;
-import com.microsoft.tang.annotations.NamedParameter;
-import com.microsoft.wake.EventHandler;
-
-import java.util.Set;
-
-/**
- * Handles message from the Client.
- */
-@NamedParameter(doc = "Handles message from the Client.", default_classes = DefaultClientMessageHandler.class)
-public final class ClientMessageHandlers implements Name<Set<EventHandler<byte[]>>> {
-  private ClientMessageHandlers() {
-  }
-}