You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@drill.apache.org by td...@apache.org on 2012/12/02 00:47:45 UTC

[1/7] git commit: Removed early distractions

Updated Branches:
  refs/heads/DRILL-3 [created] 4fedb7a5b


Removed early distractions


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

Branch: refs/heads/DRILL-3
Commit: 4fedb7a5b24a9ce62c370da374d0d79e3077347e
Parents: af71b12
Author: Jacques Nadeau <ja...@gmail.com>
Authored: Thu Nov 29 19:11:49 2012 -0800
Committer: Jacques Nadeau <ja...@gmail.com>
Committed: Thu Nov 29 19:11:49 2012 -0800

----------------------------------------------------------------------
 .../common/expression/visitors/BasicEvaluator.java |   22 -------
 .../common/expression/visitors/GetIdentifiers.java |   28 ---------
 .../apache/drill/common/physical/Partitioner.java  |   23 -------
 .../drill/common/physical/PhysicalOperator.java    |   42 -------------
 .../apache/drill/common/physical/PhysicalPlan.java |   22 -------
 .../common/physical/RowBatchReceiverSource.java    |   23 -------
 .../drill/common/physical/RowBatchSenderSink.java  |   22 -------
 .../apache/drill/common/physical/StreamSink.java   |   22 -------
 .../apache/drill/common/physical/StreamSource.java |   22 -------
 .../drill/common/physical/operators/Dump.java      |   22 -------
 .../common/physical/operators/HashAggregate.java   |   22 -------
 .../drill/common/physical/operators/HashJoin.java  |   22 -------
 .../drill/common/physical/operators/Limit.java     |   22 -------
 .../drill/common/physical/operators/MergeJoin.java |   22 -------
 .../drill/common/physical/operators/RowRotate.java |   29 ---------
 .../drill/common/physical/operators/Scan.java      |   22 -------
 .../drill/common/physical/operators/Sort.java      |   22 -------
 .../drill/common/physical/operators/Store.java     |   22 -------
 .../physical/operators/StreamingAggregate.java     |   22 -------
 .../common/physical/operators/StreamingSort.java   |   22 -------
 .../drill/common/physical/operators/Union.java     |   22 -------
 .../apache/drill/common/storage/FieldSchema.java   |   47 ---------------
 .../drill/common/storage/ReaderCapabilities.java   |   23 -------
 .../apache/drill/common/storage/StorageEngine.java |   23 -------
 .../apache/drill/common/storage/StorageReader.java |   42 -------------
 .../apache/drill/common/storage/TreeHolder.java    |   29 ---------
 .../apache/drill/common/storage/ValueCapturer.java |   42 -------------
 .../apache/drill/common/storage/ValueHolder.java   |   34 -----------
 .../apache/drill/common/storage/ValueModifier.java |   23 -------
 29 files changed, 0 insertions(+), 760 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/expression/visitors/BasicEvaluator.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/expression/visitors/BasicEvaluator.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/expression/visitors/BasicEvaluator.java
deleted file mode 100644
index a7a0056..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/expression/visitors/BasicEvaluator.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.common.expression.visitors;
-
-public class BasicEvaluator extends FunctionVisitor{
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/expression/visitors/GetIdentifiers.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/expression/visitors/GetIdentifiers.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/expression/visitors/GetIdentifiers.java
deleted file mode 100644
index df2c2bf..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/expression/visitors/GetIdentifiers.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.common.expression.visitors;
-
-import java.util.HashSet;
-
-import org.apache.drill.common.expression.ValueExpressions;
-
-public class GetIdentifiers extends FunctionVisitor{
-	private HashSet<ValueExpressions.Identifier> identifiers = new HashSet<ValueExpressions.Identifier>();
-	
-	
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/Partitioner.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/Partitioner.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/Partitioner.java
deleted file mode 100644
index 20a2049..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/Partitioner.java
+++ /dev/null
@@ -1,23 +0,0 @@
-/*******************************************************************************
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- ******************************************************************************/
-package org.apache.drill.common.physical;
-
-public interface Partitioner {
-	public int getPartition();
-	public int getPartitionCount();
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/PhysicalOperator.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/PhysicalOperator.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/PhysicalOperator.java
deleted file mode 100644
index ede1653..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/PhysicalOperator.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.common.physical;
-
-
-public class PhysicalOperator {
-	
-	public static enum IteratorOutcome{
-		OK, NONE, CANCEL;
-	}
-	
-	private StreamSource[] sources;
-	private StreamSink[] sinks;
-	private Partitioner partitioner;
-	
-	public void setup(){
-		
-	}
-	
-	public IteratorOutcome getNext(){
-		return IteratorOutcome.CANCEL;
-	}
-	
-	public void teardown(){
-		
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/PhysicalPlan.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/PhysicalPlan.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/PhysicalPlan.java
deleted file mode 100644
index 6c831a2..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/PhysicalPlan.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.common.physical;
-
-public class PhysicalPlan {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/RowBatchReceiverSource.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/RowBatchReceiverSource.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/RowBatchReceiverSource.java
deleted file mode 100644
index a8727dd..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/RowBatchReceiverSource.java
+++ /dev/null
@@ -1,23 +0,0 @@
-/*******************************************************************************
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- ******************************************************************************/
-package org.apache.drill.common.physical;
-
-
-public class RowBatchReceiverSource implements StreamSource {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/RowBatchSenderSink.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/RowBatchSenderSink.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/RowBatchSenderSink.java
deleted file mode 100644
index 0f5de94..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/RowBatchSenderSink.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.common.physical;
-
-public class RowBatchSenderSink {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/StreamSink.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/StreamSink.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/StreamSink.java
deleted file mode 100644
index bbe64c7..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/StreamSink.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.common.physical;
-
-public interface StreamSink {
-	
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/StreamSource.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/StreamSource.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/StreamSource.java
deleted file mode 100644
index 78692f3..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/StreamSource.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.common.physical;
-
-public interface StreamSource {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Dump.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Dump.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Dump.java
deleted file mode 100644
index 7f5ebfc..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Dump.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.common.physical.operators;
-
-public class Dump {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/HashAggregate.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/HashAggregate.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/HashAggregate.java
deleted file mode 100644
index 6426015..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/HashAggregate.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.common.physical.operators;
-
-public class HashAggregate {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/HashJoin.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/HashJoin.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/HashJoin.java
deleted file mode 100644
index 96cdd6a..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/HashJoin.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.common.physical.operators;
-
-public class HashJoin {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Limit.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Limit.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Limit.java
deleted file mode 100644
index 2c9033f..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Limit.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.common.physical.operators;
-
-public class Limit {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/MergeJoin.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/MergeJoin.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/MergeJoin.java
deleted file mode 100644
index 9acc22e..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/MergeJoin.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.common.physical.operators;
-
-public class MergeJoin {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/RowRotate.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/RowRotate.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/RowRotate.java
deleted file mode 100644
index 483a95c..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/RowRotate.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.common.physical.operators;
-
-/**
- * This operator is responsible for rotating a set of values from columns to a
- * collection of rows. This allows etremely wide rows to be into multipe rows.
- * 
- * @author jnadeau
- * 
- */
-public class RowRotate {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Scan.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Scan.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Scan.java
deleted file mode 100644
index 2e24b6b..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Scan.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.common.physical.operators;
-
-public class Scan {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Sort.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Sort.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Sort.java
deleted file mode 100644
index 0a4ed14..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Sort.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.common.physical.operators;
-
-public class Sort {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Store.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Store.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Store.java
deleted file mode 100644
index fbd6bff..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Store.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.common.physical.operators;
-
-public class Store {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/StreamingAggregate.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/StreamingAggregate.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/StreamingAggregate.java
deleted file mode 100644
index 557ec83..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/StreamingAggregate.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.common.physical.operators;
-
-public class StreamingAggregate {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/StreamingSort.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/StreamingSort.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/StreamingSort.java
deleted file mode 100644
index 2a5ae49..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/StreamingSort.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.common.physical.operators;
-
-public class StreamingSort {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Union.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Union.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Union.java
deleted file mode 100644
index 36b313e..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/physical/operators/Union.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.common.physical.operators;
-
-public class Union {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/FieldSchema.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/FieldSchema.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/FieldSchema.java
deleted file mode 100644
index 00cd645..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/FieldSchema.java
+++ /dev/null
@@ -1,47 +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.storage;
-
-import java.nio.ByteBuffer;
-
-/**
- * Holds the schema of the incoming data.  Each row batch carries a particular schema.  In the case of a mid row batch schema change, the provided schema is a union of the found schemas.  As the schema changes between row batches, the schema id increments.  New schemas should be provided the first time their schema is changed.  Each scanner is provided with a unique schema shift.  When multiple scanner data is merged, so are the schemas.
- * @author jnadeau
- *
- */
-public class FieldSchema {
-
-	/**
-	 * Stores the set of provided schemas.  Is in a protobuf binary format.  Each object is:
-	 *   parentField: int32
-	 *   format: value type
-	 *   name: string 
-	 *   
-	 */
-	private ByteBuffer schemaHolder;
-	private int currentSchemaPosition;
-	private long currentSchemaId;
-	
-	public void mergeSchema(FieldSchema schema){
-		
-	}
-	
-	public static FieldSchema generateMerged(FieldSchema...schemas){
-		return null;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ReaderCapabilities.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ReaderCapabilities.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ReaderCapabilities.java
deleted file mode 100644
index 713a4c9..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ReaderCapabilities.java
+++ /dev/null
@@ -1,23 +0,0 @@
-/*******************************************************************************
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- ******************************************************************************/
-package org.apache.drill.common.storage;
-
-public class ReaderCapabilities {
-	public boolean supportsIndexBasedFieldReading;
-	public boolean supportsNestedData;
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/StorageEngine.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/StorageEngine.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/StorageEngine.java
deleted file mode 100644
index d9c3219..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/StorageEngine.java
+++ /dev/null
@@ -1,23 +0,0 @@
-/*******************************************************************************
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- ******************************************************************************/
-package org.apache.drill.common.storage;
-
-public interface StorageEngine {
-	public ReaderCapabilities getReaderCapabilities();
-	
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/StorageReader.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/StorageReader.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/StorageReader.java
deleted file mode 100644
index 6282bda..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/StorageReader.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.common.storage;
-
-import java.nio.ByteBuffer;
-import java.nio.IntBuffer;
-
-public interface StorageReader {
-
-		public static enum Outcome {
-			NO_MORE_DATA, AT_TREE_BOUNDARY, WITHIN_TREE, FATAL_ERROR
-		}
-		
-		
-		
-		
-		/**
-		 * 
-		 * @param dataBuffer
-		 * @param positionBuffer
-		 * @return
-		 */
-		public abstract Outcome getMoreData(ByteBuffer dataBuffer, IntBuffer positionBuffer);
-		
-		
-		public abstract void registerByFieldOrdinal(int ordinal, Object fieldHandler);		
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/TreeHolder.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/TreeHolder.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/TreeHolder.java
deleted file mode 100644
index 253ad82..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/TreeHolder.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.common.storage;
-
-/**
- * Holds all 
- * @author jnadeau
- *
- */
-public class TreeHolder {
-	private boolean isComplete;
-	
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ValueCapturer.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ValueCapturer.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ValueCapturer.java
deleted file mode 100644
index bec6b60..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ValueCapturer.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.common.storage;
-
-public class ValueCapturer {
-	
-	
-	/** 
-	 * Capture the value of a field.  This is used when the fieldId is already known.
-	 * @param fieldId
-	 * @param value
-	 */
-	public void capture(int fieldId, ValueHolder value){
-		
-	}
-	
-	/**
-	 * Capture the value of a previously unknown field.  This is used when
-	 * @param fieldParent
-	 * @param fieldName
-	 * @param value
-	 * @return
-	 */
-	public int capture(int fieldParent, String fieldName, ValueHolder value){
-		return -1;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ValueHolder.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ValueHolder.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ValueHolder.java
deleted file mode 100644
index 54c97ef..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ValueHolder.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/*******************************************************************************
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- ******************************************************************************/
-package org.apache.drill.common.storage;
-
-import java.nio.ByteBuffer;
-
-
-public class ValueHolder {
-	private int fieldId;
-	private int valueLength;
-	private int startIndex;
-	private ByteBuffer buffer;
-
-	public void setValue(int fieldId, ByteBuffer buffer, int startIndex, int valueLength){
-		this.fieldId = fieldId;
-		this.valueLength = valueLength;
-		this.startIndex = startIndex;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-drill/blob/4fedb7a5/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ValueModifier.java
----------------------------------------------------------------------
diff --git a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ValueModifier.java b/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ValueModifier.java
deleted file mode 100644
index 5b916f2..0000000
--- a/sandbox/prototype/common/src/main/java/org/apache/drill/common/storage/ValueModifier.java
+++ /dev/null
@@ -1,23 +0,0 @@
-/*******************************************************************************
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- ******************************************************************************/
-package org.apache.drill.common.storage;
-
-
-public interface ValueModifier {
-    public boolean modifyValue(ValueHolder value);
-}