You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@drill.apache.org by pa...@apache.org on 2016/07/23 04:58:46 UTC

[6/6] drill git commit: DRILL-4499: Remove 16 unused classes

DRILL-4499: Remove 16 unused classes

This closes #426


Project: http://git-wip-us.apache.org/repos/asf/drill/repo
Commit: http://git-wip-us.apache.org/repos/asf/drill/commit/5a7d4c39
Tree: http://git-wip-us.apache.org/repos/asf/drill/tree/5a7d4c39
Diff: http://git-wip-us.apache.org/repos/asf/drill/diff/5a7d4c39

Branch: refs/heads/master
Commit: 5a7d4c3983747a778e6a29d3450dd18871e98f2c
Parents: 81772d3
Author: Sudheesh Katkam <sk...@maprtech.com>
Authored: Thu Jul 21 17:13:59 2016 -0700
Committer: Parth Chandra <pa...@apache.org>
Committed: Fri Jul 22 21:28:10 2016 -0700

----------------------------------------------------------------------
 .../apache/drill/common/DrillCloseables.java    | 55 -------------------
 .../drill/exec/expr/annotations/MethodMap.java  | 35 ------------
 .../apache/drill/exec/expr/fn/FunctionBody.java | 29 ----------
 .../org/apache/drill/exec/ops/Multitimer.java   | 42 ---------------
 .../org/apache/drill/exec/ops/QuerySetup.java   | 26 ---------
 .../exec/rpc/control/AvailabilityListener.java  | 22 --------
 .../drill/exec/rpc/control/ControlCommand.java  | 28 ----------
 .../drill/exec/rpc/control/SendProgress.java    | 22 --------
 .../drill/exec/rpc/data/SendProgress.java       | 22 --------
 .../apache/drill/exec/rpc/user/DrillUser.java   | 36 -------------
 .../apache/drill/exec/store/RecordRecorder.java | 36 -------------
 .../drill/exec/store/schedule/PartialWork.java  | 43 ---------------
 .../org/apache/drill/exec/util/AtomicState.java | 56 --------------------
 .../drill/exec/work/RecordOutputStream.java     | 22 --------
 .../apache/drill/exec/work/ResourceRequest.java | 30 -----------
 .../apache/drill/exec/work/RootNodeDriver.java  | 25 ---------
 16 files changed, 529 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/common/src/main/java/org/apache/drill/common/DrillCloseables.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/drill/common/DrillCloseables.java b/common/src/main/java/org/apache/drill/common/DrillCloseables.java
deleted file mode 100644
index 289066b..0000000
--- a/common/src/main/java/org/apache/drill/common/DrillCloseables.java
+++ /dev/null
@@ -1,55 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.drill.common;
-
-import java.io.Closeable;
-import java.io.IOException;
-
-/**
- * Provides additional functionality to Guava's Closeables.
- */
-public class DrillCloseables {
-  /**
-   * Constructor. Prevents construction for class of static utilities.
-   */
-  private DrillCloseables() {
-  }
-
-  /**
-   * Close() a {@see java.io.Closeable} without throwing a (checked)
-   * {@see java.io.IOException}. This wraps the close() call with a
-   * try-catch that will rethrow an IOException wrapped with a
-   * {@see java.lang.RuntimeException}, providing a way to call close()
-   * without having to do the try-catch everywhere or propagate the IOException.
-   *
-   * <p>Guava has deprecated {@see com.google.common.io.Closeables.closeQuietly()}
-   * as described in
-   * {@link https://code.google.com/p/guava-libraries/issues/detail?id=1118}.
-   *
-   * @param closeable the Closeable to close
-   * @throws RuntimeException if an IOException occurs; the IOException is
-   *   wrapped by the RuntimeException
-   */
-  public static void closeNoChecked(final Closeable closeable) {
-    try {
-      closeable.close();
-    } catch(final IOException e) {
-      throw new RuntimeException("IOException while closing", e);
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/expr/annotations/MethodMap.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/expr/annotations/MethodMap.java b/exec/java-exec/src/main/java/org/apache/drill/exec/expr/annotations/MethodMap.java
deleted file mode 100644
index 775f6a3..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/expr/annotations/MethodMap.java
+++ /dev/null
@@ -1,35 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.drill.exec.expr.annotations;
-
-import java.lang.annotation.ElementType;
-import java.lang.annotation.Retention;
-import java.lang.annotation.RetentionPolicy;
-import java.lang.annotation.Target;
-
-/**
- * Marker annotation to determine which fields should be included as parameters for the function.
- */
-@Retention(RetentionPolicy.RUNTIME)
-@Target({ElementType.METHOD})
-public @interface MethodMap {
-
-
-  String parentMethod();
-
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/expr/fn/FunctionBody.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/expr/fn/FunctionBody.java b/exec/java-exec/src/main/java/org/apache/drill/exec/expr/fn/FunctionBody.java
deleted file mode 100644
index df110ed..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/expr/fn/FunctionBody.java
+++ /dev/null
@@ -1,29 +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.drill.exec.expr.fn;
-
-public class FunctionBody {
-  static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(FunctionBody.class);
-
-
-  public static enum BodyType{
-    SETUP, EVAL_INNER, EVAL_OUTER,
-  }
-
-
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/ops/Multitimer.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/ops/Multitimer.java b/exec/java-exec/src/main/java/org/apache/drill/exec/ops/Multitimer.java
deleted file mode 100644
index 7e6ae8e..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/ops/Multitimer.java
+++ /dev/null
@@ -1,42 +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.drill.exec.ops;
-
-import org.slf4j.Logger;
-
-public class Multitimer<T extends Enum<T>> {
-  static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(Multitimer.class);
-
-  private final long start;
-  private final long[] times;
-  private final Class<T> clazz;
-
-  public Multitimer(Class<T> clazz){
-    this.times = new long[clazz.getEnumConstants().length];
-    this.start = System.nanoTime();
-    this.clazz = clazz;
-  }
-
-  public void mark(T timer){
-    times[timer.ordinal()] = System.nanoTime();
-  }
-
-  public void log(Logger logger){
-
-  }
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/ops/QuerySetup.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/ops/QuerySetup.java b/exec/java-exec/src/main/java/org/apache/drill/exec/ops/QuerySetup.java
deleted file mode 100644
index ef73867..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/ops/QuerySetup.java
+++ /dev/null
@@ -1,26 +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.drill.exec.ops;
-
-public enum QuerySetup {
-  START_SQL_PARSING,
-  START_SQL_VALIDATION,
-  START_SQL_TO_REL,
-  START_OPTIQ_REL_TO_DRILL_LOGICAL,
-  START_DRILL_LOGICAL_TO_PHYSICAL;
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/control/AvailabilityListener.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/control/AvailabilityListener.java b/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/control/AvailabilityListener.java
deleted file mode 100644
index 4f817c6..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/control/AvailabilityListener.java
+++ /dev/null
@@ -1,22 +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.drill.exec.rpc.control;
-
-public interface AvailabilityListener {
-  public void isAvailable(ControlConnection connection);
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/control/ControlCommand.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/control/ControlCommand.java b/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/control/ControlCommand.java
deleted file mode 100644
index 52d4289..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/control/ControlCommand.java
+++ /dev/null
@@ -1,28 +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.drill.exec.rpc.control;
-
-import org.apache.drill.exec.rpc.RpcConnectionHandler;
-
-import com.google.protobuf.MessageLite;
-
-public interface ControlCommand<T extends MessageLite> extends RpcConnectionHandler<ControlConnection>{
-
-  public abstract void connectionAvailable(ControlConnection connection);
-
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/control/SendProgress.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/control/SendProgress.java b/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/control/SendProgress.java
deleted file mode 100644
index f270eee..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/control/SendProgress.java
+++ /dev/null
@@ -1,22 +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.drill.exec.rpc.control;
-
-public class SendProgress {
-  static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(SendProgress.class);
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/data/SendProgress.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/data/SendProgress.java b/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/data/SendProgress.java
deleted file mode 100644
index 490013f..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/data/SendProgress.java
+++ /dev/null
@@ -1,22 +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.drill.exec.rpc.data;
-
-public class SendProgress {
-  static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(SendProgress.class);
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/user/DrillUser.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/user/DrillUser.java b/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/user/DrillUser.java
deleted file mode 100644
index c344ce1..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/rpc/user/DrillUser.java
+++ /dev/null
@@ -1,36 +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.drill.exec.rpc.user;
-
-import java.io.IOException;
-
-import org.apache.hadoop.security.UserGroupInformation;
-
-public class DrillUser {
-  static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(DrillUser.class);
-
-  private UserGroupInformation hadoopUser;
-
-  public DrillUser(String userName) throws IOException {
-    this.hadoopUser = UserGroupInformation.createProxyUser(userName, UserGroupInformation.getCurrentUser());
-  }
-
-  public UserGroupInformation getHadoopUser(){
-    return hadoopUser;
-  }
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/store/RecordRecorder.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/store/RecordRecorder.java b/exec/java-exec/src/main/java/org/apache/drill/exec/store/RecordRecorder.java
deleted file mode 100644
index ffaff8f..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/store/RecordRecorder.java
+++ /dev/null
@@ -1,36 +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.drill.exec.store;
-
-import java.io.IOException;
-
-import org.apache.drill.exec.record.RecordBatch;
-
-public interface RecordRecorder {
-  static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(RecordRecorder.class);
-
-  public void setup() throws IOException;
-
-  /**
-   *
-   * @param batch
-   * @return
-   */
-  public boolean record(RecordBatch batch);
-
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/store/schedule/PartialWork.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/store/schedule/PartialWork.java b/exec/java-exec/src/main/java/org/apache/drill/exec/store/schedule/PartialWork.java
deleted file mode 100644
index 8080747..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/store/schedule/PartialWork.java
+++ /dev/null
@@ -1,43 +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.drill.exec.store.schedule;
-
-import org.apache.drill.exec.proto.CoordinationProtos.DrillbitEndpoint;
-
-public class PartialWork {
-  static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(PartialWork.class);
-
-  private final long length;
-  private final DrillbitEndpoint[] locations;
-
-  public PartialWork(long length, DrillbitEndpoint[] locations) {
-    super();
-    this.length = length;
-    this.locations = locations;
-  }
-
-  public long getLength() {
-    return length;
-  }
-  public DrillbitEndpoint[] getLocations() {
-    return locations;
-  }
-
-
-
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/util/AtomicState.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/util/AtomicState.java b/exec/java-exec/src/main/java/org/apache/drill/exec/util/AtomicState.java
deleted file mode 100644
index ec498d4..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/util/AtomicState.java
+++ /dev/null
@@ -1,56 +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.drill.exec.util;
-
-import java.util.concurrent.atomic.AtomicInteger;
-
-import com.google.protobuf.Internal.EnumLite;
-
-/**
- * Simple wrapper class around AtomicInteger which allows management of a State value extending EnumLite.
- * @param <T> The type of EnumLite to use for state.
- */
-public abstract class AtomicState<T extends EnumLite> {
-  static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(AtomicState.class);
-
-  private final AtomicInteger state = new AtomicInteger();
-
-  /**
-   * Constructor that defines initial T state.
-   * @param initial
-   */
-  public AtomicState(T initial){
-    state.set(initial.getNumber());
-  }
-
-  protected abstract T getStateFromNumber(int i);
-
-  /**
-   * Does an atomic conditional update from one state to another.
-   * @param oldState The expected current state.
-   * @param newState The desired new state.
-   * @return Whether or not the update was successful.
-   */
-  public boolean updateState(T oldState, T newState){
-    return state.compareAndSet(oldState.getNumber(), newState.getNumber());
-  }
-
-  public T getState(){
-    return getStateFromNumber(state.get());
-  }
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/work/RecordOutputStream.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/work/RecordOutputStream.java b/exec/java-exec/src/main/java/org/apache/drill/exec/work/RecordOutputStream.java
deleted file mode 100644
index 25d1786..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/work/RecordOutputStream.java
+++ /dev/null
@@ -1,22 +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.drill.exec.work;
-
-public class RecordOutputStream {
-  static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(RecordOutputStream.class);
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/work/ResourceRequest.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/work/ResourceRequest.java b/exec/java-exec/src/main/java/org/apache/drill/exec/work/ResourceRequest.java
deleted file mode 100644
index 5b7b623..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/work/ResourceRequest.java
+++ /dev/null
@@ -1,30 +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.drill.exec.work;
-
-public class ResourceRequest {
-  static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(ResourceRequest.class);
-
-  public long memoryMin;
-  public long memoryDesired;
-
-
-  public static class ResourceAllocation {
-    public long memory;
-  }
-}

http://git-wip-us.apache.org/repos/asf/drill/blob/5a7d4c39/exec/java-exec/src/main/java/org/apache/drill/exec/work/RootNodeDriver.java
----------------------------------------------------------------------
diff --git a/exec/java-exec/src/main/java/org/apache/drill/exec/work/RootNodeDriver.java b/exec/java-exec/src/main/java/org/apache/drill/exec/work/RootNodeDriver.java
deleted file mode 100644
index b56477b..0000000
--- a/exec/java-exec/src/main/java/org/apache/drill/exec/work/RootNodeDriver.java
+++ /dev/null
@@ -1,25 +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.drill.exec.work;
-
-public interface RootNodeDriver {
-  static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(RootNodeDriver.class);
-
-  public boolean doNext();
-
-}