You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@carbondata.apache.org by ch...@apache.org on 2016/08/15 07:09:05 UTC

[20/52] [partial] incubator-carbondata git commit: Renamed packages to org.apache.carbondata and fixed errors

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/datachunk/DataChunk.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/datachunk/DataChunk.java b/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/datachunk/DataChunk.java
deleted file mode 100644
index dbbed6d..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/datachunk/DataChunk.java
+++ /dev/null
@@ -1,327 +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.carbondata.core.carbon.metadata.blocklet.datachunk;
-
-import java.io.Serializable;
-import java.util.List;
-
-import org.carbondata.core.carbon.metadata.blocklet.compressor.ChunkCompressorMeta;
-import org.carbondata.core.carbon.metadata.blocklet.sort.SortState;
-import org.carbondata.core.carbon.metadata.encoder.Encoding;
-import org.carbondata.core.metadata.ValueEncoderMeta;
-
-/**
- * Class holds the information about the data chunk metadata
- */
-public class DataChunk implements Serializable {
-
-  /**
-   * serialization version
-   */
-  private static final long serialVersionUID = 1L;
-
-  /**
-   * the compression meta data of a chunk
-   */
-  private ChunkCompressorMeta chunkCompressionMeta;
-
-  /**
-   * whether this chunk is a row chunk or column chunk
-   */
-  private boolean isRowMajor;
-
-  /**
-   * the column IDs in this chunk, will have atleast
-   * one column ID for columnar format, many column ID for
-   * row major format
-   */
-  private List<Integer> columnUniqueIdList;
-
-  /**
-   * Offset of data page
-   */
-  private long dataPageOffset;
-
-  /**
-   * length of data page
-   */
-  private int dataPageLength;
-
-  /**
-   * information about presence of values in each row of this column chunk
-   */
-  private transient PresenceMeta nullValueIndexForColumn;
-
-  /**
-   * offset of row id page, only if encoded using inverted index
-   */
-  private long rowIdPageOffset;
-
-  /**
-   * length of row id page, only if encoded using inverted index
-   */
-  private int rowIdPageLength;
-
-  /**
-   * offset of rle page, only if RLE coded.
-   */
-  private long rlePageOffset;
-
-  /**
-   * length of rle page, only if RLE coded.
-   */
-  private int rlePageLength;
-
-  /**
-   * is rle is applied in the data chunk
-   */
-  private boolean isRleApplied;
-
-  /**
-   * is dictionary is applied in the column, only if it is a dimension column
-   */
-  private boolean isNoDictonaryColumn;
-
-  /**
-   * sorting type selected for chunk;
-   */
-  private SortState sortState;
-
-  /**
-   * The List of encoders overriden at node level
-   */
-  private List<Encoding> encodingList;
-
-  /**
-   * value encoder meta which will holds the information
-   * about max, min, decimal length, type
-   */
-  private List<ValueEncoderMeta> valueEncoderMetaList;
-
-  /**
-   * @return the chunkCompressionMeta
-   */
-  public ChunkCompressorMeta getChunkCompressionMeta() {
-    return chunkCompressionMeta;
-  }
-
-  /**
-   * @param chunkCompressionMeta the chunkCompressionMeta to set
-   */
-  public void setChunkCompressionMeta(ChunkCompressorMeta chunkCompressionMeta) {
-    this.chunkCompressionMeta = chunkCompressionMeta;
-  }
-
-  /**
-   * @return the isRowMajor
-   */
-  public boolean isRowMajor() {
-    return isRowMajor;
-  }
-
-  /**
-   * @param isRowMajor the isRowMajor to set
-   */
-  public void setRowMajor(boolean isRowMajor) {
-    this.isRowMajor = isRowMajor;
-  }
-
-  /**
-   * @return the columnUniqueIdList
-   */
-  public List<Integer> getColumnUniqueIdList() {
-    return columnUniqueIdList;
-  }
-
-  /**
-   * @param columnUniqueIdList the columnUniqueIdList to set
-   */
-  public void setColumnUniqueIdList(List<Integer> columnUniqueIdList) {
-    this.columnUniqueIdList = columnUniqueIdList;
-  }
-
-  /**
-   * @return the dataPageOffset
-   */
-  public long getDataPageOffset() {
-    return dataPageOffset;
-  }
-
-  /**
-   * @param dataPageOffset the dataPageOffset to set
-   */
-  public void setDataPageOffset(long dataPageOffset) {
-    this.dataPageOffset = dataPageOffset;
-  }
-
-  /**
-   * @return the dataPageLength
-   */
-  public int getDataPageLength() {
-    return dataPageLength;
-  }
-
-  /**
-   * @param dataPageLength the dataPageLength to set
-   */
-  public void setDataPageLength(int dataPageLength) {
-    this.dataPageLength = dataPageLength;
-  }
-
-  /**
-   * @return the nullValueIndexForColumn
-   */
-  public PresenceMeta getNullValueIndexForColumn() {
-    return nullValueIndexForColumn;
-  }
-
-  /**
-   * @param nullValueIndexForColumn the nullValueIndexForColumn to set
-   */
-  public void setNullValueIndexForColumn(PresenceMeta nullValueIndexForColumn) {
-    this.nullValueIndexForColumn = nullValueIndexForColumn;
-  }
-
-  /**
-   * @return the rowIdPageOffset
-   */
-  public long getRowIdPageOffset() {
-    return rowIdPageOffset;
-  }
-
-  /**
-   * @param rowIdPageOffset the rowIdPageOffset to set
-   */
-  public void setRowIdPageOffset(long rowIdPageOffset) {
-    this.rowIdPageOffset = rowIdPageOffset;
-  }
-
-  /**
-   * @return the rowIdPageLength
-   */
-  public int getRowIdPageLength() {
-    return rowIdPageLength;
-  }
-
-  /**
-   * @param rowIdPageLength the rowIdPageLength to set
-   */
-  public void setRowIdPageLength(int rowIdPageLength) {
-    this.rowIdPageLength = rowIdPageLength;
-  }
-
-  /**
-   * @return the rlePageOffset
-   */
-  public long getRlePageOffset() {
-    return rlePageOffset;
-  }
-
-  /**
-   * @param rlePageOffset the rlePageOffset to set
-   */
-  public void setRlePageOffset(long rlePageOffset) {
-    this.rlePageOffset = rlePageOffset;
-  }
-
-  /**
-   * @return the rlePageLength
-   */
-  public int getRlePageLength() {
-    return rlePageLength;
-  }
-
-  /**
-   * @param rlePageLength the rlePageLength to set
-   */
-  public void setRlePageLength(int rlePageLength) {
-    this.rlePageLength = rlePageLength;
-  }
-
-  /**
-   * @return the isRleApplied
-   */
-  public boolean isRleApplied() {
-    return isRleApplied;
-  }
-
-  /**
-   * @param isRleApplied the isRleApplied to set
-   */
-  public void setRleApplied(boolean isRleApplied) {
-    this.isRleApplied = isRleApplied;
-  }
-
-  /**
-   * @return the isNoDictonaryColumn
-   */
-  public boolean isNoDictonaryColumn() {
-    return isNoDictonaryColumn;
-  }
-
-  /**
-   * @param isNoDictonaryColumn the isNoDictonaryColumn to set
-   */
-  public void setNoDictonaryColumn(boolean isNoDictonaryColumn) {
-    this.isNoDictonaryColumn = isNoDictonaryColumn;
-  }
-
-  /**
-   * @return the sortState
-   */
-  public SortState getSortState() {
-    return sortState;
-  }
-
-  /**
-   * @param sortState the sortState to set
-   */
-  public void setSortState(SortState sortState) {
-    this.sortState = sortState;
-  }
-
-  /**
-   * @return the encoderList
-   */
-  public List<Encoding> getEncodingList() {
-    return encodingList;
-  }
-
-  /**
-   * @param encoderList the encoderList to set
-   */
-  public void setEncoderList(List<Encoding> encodingList) {
-    this.encodingList = encodingList;
-  }
-
-  /**
-   * @return the valueEncoderMeta
-   */
-  public List<ValueEncoderMeta> getValueEncoderMeta() {
-    return valueEncoderMetaList;
-  }
-
-  /**
-   * @param valueEncoderMeta the valueEncoderMeta to set
-   */
-  public void setValueEncoderMeta(List<ValueEncoderMeta> valueEncoderMetaList) {
-    this.valueEncoderMetaList = valueEncoderMetaList;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/datachunk/PresenceMeta.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/datachunk/PresenceMeta.java b/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/datachunk/PresenceMeta.java
deleted file mode 100644
index 0726c1e..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/datachunk/PresenceMeta.java
+++ /dev/null
@@ -1,66 +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.carbondata.core.carbon.metadata.blocklet.datachunk;
-
-import java.util.BitSet;
-
-/**
- * information about presence of values in each row of the column chunk
- */
-public class PresenceMeta {
-
-  /**
-   * if true, ones in the bit stream reprents presence. otherwise represents absence
-   */
-  private boolean representNullValues;
-
-  /**
-   * Compressed bit stream representing the presence of null values
-   */
-  private BitSet bitSet;
-
-  /**
-   * @return the representNullValues
-   */
-  public boolean isRepresentNullValues() {
-    return representNullValues;
-  }
-
-  /**
-   * @param representNullValues the representNullValues to set
-   */
-  public void setRepresentNullValues(boolean representNullValues) {
-    this.representNullValues = representNullValues;
-  }
-
-  /**
-   * @return the bitSet
-   */
-  public BitSet getBitSet() {
-    return bitSet;
-  }
-
-  /**
-   * @param bitSet the bitSet to set
-   */
-  public void setBitSet(BitSet bitSet) {
-    this.bitSet = bitSet;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/index/BlockletBTreeIndex.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/index/BlockletBTreeIndex.java b/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/index/BlockletBTreeIndex.java
deleted file mode 100644
index ed0826e..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/index/BlockletBTreeIndex.java
+++ /dev/null
@@ -1,76 +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.carbondata.core.carbon.metadata.blocklet.index;
-
-import java.io.Serializable;
-
-/**
- * Class hold the information about start and end key of one blocklet
- */
-public class BlockletBTreeIndex implements Serializable {
-
-  /**
-   * serialization version
-   */
-  private static final long serialVersionUID = 6116185464700853045L;
-
-  /**
-   * Bit-packed start key of one blocklet
-   */
-  private byte[] startKey;
-
-  /**
-   * Bit-packed start key of one blocklet
-   */
-  private byte[] endKey;
-
-  public BlockletBTreeIndex() {
-  }
-
-  public BlockletBTreeIndex(byte[] startKey, byte[] endKey) {
-    this.startKey = startKey;
-    this.endKey = endKey;
-  }
-
-  /**
-   * @return the startKey
-   */
-  public byte[] getStartKey() {
-    return startKey;
-  }
-
-  /**
-   * @param startKey the startKey to set
-   */
-  public void setStartKey(byte[] startKey) {
-    this.startKey = startKey;
-  }
-
-  /**
-   * @return the endKey
-   */
-  public byte[] getEndKey() {
-    return endKey;
-  }
-
-  /**
-   * @param endKey the endKey to set
-   */
-  public void setEndKey(byte[] endKey) {
-    this.endKey = endKey;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/index/BlockletIndex.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/index/BlockletIndex.java b/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/index/BlockletIndex.java
deleted file mode 100644
index a396795..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/index/BlockletIndex.java
+++ /dev/null
@@ -1,77 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * http://www.apache.org/licenses/LICENSE-2.0
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.carbondata.core.carbon.metadata.blocklet.index;
-
-import java.io.Serializable;
-
-/**
- * Persist Index of all blocklets in one file
- */
-public class BlockletIndex implements Serializable {
-
-  /**
-   * serialization version
-   */
-  private static final long serialVersionUID = 1L;
-
-  /**
-   * list of btree index for all the leaf
-   */
-  private BlockletBTreeIndex btreeIndex;
-
-  /**
-   * list of max and min key of all leaf
-   */
-  private BlockletMinMaxIndex minMaxIndex;
-
-  public BlockletIndex() {
-  }
-
-  public BlockletIndex(BlockletBTreeIndex btree, BlockletMinMaxIndex minmax) {
-    this.btreeIndex = btree;
-    this.minMaxIndex = minmax;
-  }
-
-  /**
-   * @return the btreeIndex
-   */
-  public BlockletBTreeIndex getBtreeIndex() {
-    return btreeIndex;
-  }
-
-  /**
-   * @param btreeIndex the btreeIndex to set
-   */
-  public void setBtreeIndex(BlockletBTreeIndex btreeIndex) {
-    this.btreeIndex = btreeIndex;
-  }
-
-  /**
-   * @return the minMaxIndex
-   */
-  public BlockletMinMaxIndex getMinMaxIndex() {
-    return minMaxIndex;
-  }
-
-  /**
-   * @param minMaxIndex the minMaxIndex to set
-   */
-  public void setMinMaxIndex(BlockletMinMaxIndex minMaxIndex) {
-    this.minMaxIndex = minMaxIndex;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/index/BlockletMinMaxIndex.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/index/BlockletMinMaxIndex.java b/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/index/BlockletMinMaxIndex.java
deleted file mode 100644
index 822cd5b..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/index/BlockletMinMaxIndex.java
+++ /dev/null
@@ -1,83 +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.carbondata.core.carbon.metadata.blocklet.index;
-
-import java.io.Serializable;
-import java.nio.ByteBuffer;
-import java.util.List;
-
-/**
- * Below class holds the information of max and min value of all the columns in a blocklet
- */
-public class BlockletMinMaxIndex implements Serializable {
-
-  /**
-   * serialization version
-   */
-  private static final long serialVersionUID = -4311405145501302895L;
-
-  /**
-   * Min value of all columns of one blocklet Bit-Packed
-   */
-  private byte[][] minValues;
-
-  /**
-   * Max value of all columns of one blocklet Bit-Packed
-   */
-  private byte[][] maxValues;
-
-  public BlockletMinMaxIndex() {
-  }
-
-  public BlockletMinMaxIndex(List<ByteBuffer> minValues, List<ByteBuffer> maxValues) {
-    this.minValues = new byte[minValues.size()][];
-    this.maxValues = new byte[maxValues.size()][];
-    for (int i = 0; i < minValues.size(); i++) {
-      this.minValues[i] = minValues.get(i).array();
-      this.maxValues[i] = maxValues.get(i).array();
-    }
-  }
-
-  /**
-   * @return the minValues
-   */
-  public byte[][] getMinValues() {
-    return minValues;
-  }
-
-  /**
-   * @param minValues the minValues to set
-   */
-  public void setMinValues(byte[][] minValues) {
-    this.minValues = minValues;
-  }
-
-  /**
-   * @return the maxValues
-   */
-  public byte[][] getMaxValues() {
-    return maxValues;
-  }
-
-  /**
-   * @param maxValues the maxValues to set
-   */
-  public void setMaxValues(byte[][] maxValues) {
-    this.maxValues = maxValues;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/sort/SortState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/sort/SortState.java b/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/sort/SortState.java
deleted file mode 100644
index 6e6d683..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/blocklet/sort/SortState.java
+++ /dev/null
@@ -1,38 +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.carbondata.core.carbon.metadata.blocklet.sort;
-
-/**
- * Enum for sort type information
- */
-public enum SortState {
-
-  /**
-   * column is not sorted
-   */
-  SORT_NONE,
-
-  /**
-   * data from source was already in sorted order
-   */
-  SORT_NATIVE,
-
-  /**
-   * data from source was not sorted,so data is explicitly sorted
-   */
-  SORT_EXPLICT;
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/converter/SchemaConverter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/converter/SchemaConverter.java b/core/src/main/java/org/carbondata/core/carbon/metadata/converter/SchemaConverter.java
deleted file mode 100644
index bb10258..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/converter/SchemaConverter.java
+++ /dev/null
@@ -1,105 +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.carbondata.core.carbon.metadata.converter;
-
-import org.carbondata.core.carbon.metadata.schema.SchemaEvolution;
-import org.carbondata.core.carbon.metadata.schema.SchemaEvolutionEntry;
-import org.carbondata.core.carbon.metadata.schema.table.TableInfo;
-import org.carbondata.core.carbon.metadata.schema.table.TableSchema;
-import org.carbondata.core.carbon.metadata.schema.table.column.ColumnSchema;
-
-/**
- * Converter interface which will be implemented for external to carbon schema
- */
-public interface SchemaConverter {
-  /**
-   * @param wrapperSchemaEvolutionEntry
-   * @return
-   */
-  org.carbondata.format.SchemaEvolutionEntry fromWrapperToExternalSchemaEvolutionEntry(
-      SchemaEvolutionEntry wrapperSchemaEvolutionEntry);
-
-  /**
-   * @param wrapperSchemaEvolution
-   * @return
-   */
-  org.carbondata.format.SchemaEvolution fromWrapperToExternalSchemaEvolution(
-      SchemaEvolution wrapperSchemaEvolution);
-
-  /**
-   * @param wrapperColumnSchema
-   * @return
-   */
-  org.carbondata.format.ColumnSchema fromWrapperToExternalColumnSchema(
-      ColumnSchema wrapperColumnSchema);
-
-  /**
-   * @param wrapperTableSchema
-   * @return
-   */
-  org.carbondata.format.TableSchema fromWrapperToExternalTableSchema(
-      TableSchema wrapperTableSchema);
-
-  /**
-   * @param wrapperTableInfo
-   * @param dbName
-   * @param tableName
-   * @return
-   */
-  org.carbondata.format.TableInfo fromWrapperToExternalTableInfo(TableInfo wrapperTableInfo,
-      String dbName, String tableName);
-
-  /**
-   * @param externalSchemaEvolutionEntry
-   * @return
-   */
-  SchemaEvolutionEntry fromExternalToWrapperSchemaEvolutionEntry(
-      org.carbondata.format.SchemaEvolutionEntry externalSchemaEvolutionEntry);
-
-  /**
-   * @param externalSchemaEvolution
-   * @return
-   */
-  SchemaEvolution fromExternalToWrapperSchemaEvolution(
-      org.carbondata.format.SchemaEvolution externalSchemaEvolution);
-
-  /**
-   * @param externalColumnSchema
-   * @return
-   */
-  ColumnSchema fromExternalToWrapperColumnSchema(
-      org.carbondata.format.ColumnSchema externalColumnSchema);
-
-  /**
-   * @param externalTableSchema
-   * @param tableNam
-   * @return
-   */
-  TableSchema fromExternalToWrapperTableSchema(
-      org.carbondata.format.TableSchema externalTableSchema, String tableNam);
-
-  /**
-   * @param externalTableInfo
-   * @param dbName
-   * @param tableName
-   * @return
-   */
-  TableInfo fromExternalToWrapperTableInfo(org.carbondata.format.TableInfo externalTableInfo,
-      String dbName, String tableName, String storePath);
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/converter/ThriftWrapperSchemaConverterImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/converter/ThriftWrapperSchemaConverterImpl.java b/core/src/main/java/org/carbondata/core/carbon/metadata/converter/ThriftWrapperSchemaConverterImpl.java
deleted file mode 100644
index c33c008..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/converter/ThriftWrapperSchemaConverterImpl.java
+++ /dev/null
@@ -1,382 +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.carbondata.core.carbon.metadata.converter;
-
-import java.util.ArrayList;
-import java.util.List;
-
-import org.carbondata.core.carbon.metadata.datatype.DataType;
-import org.carbondata.core.carbon.metadata.encoder.Encoding;
-import org.carbondata.core.carbon.metadata.schema.SchemaEvolution;
-import org.carbondata.core.carbon.metadata.schema.SchemaEvolutionEntry;
-import org.carbondata.core.carbon.metadata.schema.table.TableInfo;
-import org.carbondata.core.carbon.metadata.schema.table.TableSchema;
-import org.carbondata.core.carbon.metadata.schema.table.column.ColumnSchema;
-
-/**
- * Thrift schema to carbon schema converter and vice versa
- */
-public class ThriftWrapperSchemaConverterImpl implements SchemaConverter {
-
-  /* (non-Javadoc)
-   * Converts  from wrapper to thrift schema evolution entry
-   */
-  @Override
-  public org.carbondata.format.SchemaEvolutionEntry fromWrapperToExternalSchemaEvolutionEntry(
-      SchemaEvolutionEntry wrapperSchemaEvolutionEntry) {
-    org.carbondata.format.SchemaEvolutionEntry thriftSchemaEvolutionEntry =
-        new org.carbondata.format.SchemaEvolutionEntry(wrapperSchemaEvolutionEntry.getTimeStamp());
-
-    List<org.carbondata.format.ColumnSchema> thriftAddedColumns =
-        new ArrayList<org.carbondata.format.ColumnSchema>();
-    for (ColumnSchema wrapperColumnSchema : wrapperSchemaEvolutionEntry.getAdded()) {
-      thriftAddedColumns.add(fromWrapperToExternalColumnSchema(wrapperColumnSchema));
-    }
-
-    List<org.carbondata.format.ColumnSchema> thriftRemovedColumns =
-        new ArrayList<org.carbondata.format.ColumnSchema>();
-    for (ColumnSchema wrapperColumnSchema : wrapperSchemaEvolutionEntry.getRemoved()) {
-      thriftRemovedColumns.add(fromWrapperToExternalColumnSchema(wrapperColumnSchema));
-    }
-
-    thriftSchemaEvolutionEntry.setAdded(thriftAddedColumns);
-    thriftSchemaEvolutionEntry.setRemoved(thriftRemovedColumns);
-    return thriftSchemaEvolutionEntry;
-  }
-
-  /* (non-Javadoc)
-   * converts from wrapper to thrift schema evolution
-   */
-  @Override public org.carbondata.format.SchemaEvolution fromWrapperToExternalSchemaEvolution(
-      SchemaEvolution wrapperSchemaEvolution) {
-
-    List<org.carbondata.format.SchemaEvolutionEntry> thriftSchemaEvolEntryList =
-        new ArrayList<org.carbondata.format.SchemaEvolutionEntry>();
-    for (SchemaEvolutionEntry schemaEvolutionEntry : wrapperSchemaEvolution
-        .getSchemaEvolutionEntryList()) {
-      thriftSchemaEvolEntryList
-          .add(fromWrapperToExternalSchemaEvolutionEntry(schemaEvolutionEntry));
-    }
-    return new org.carbondata.format.SchemaEvolution(thriftSchemaEvolEntryList);
-  }
-
-
-  /**
-   * converts from wrapper to external encoding
-   *
-   * @param encoder
-   * @return
-   */
-  private org.carbondata.format.Encoding fromWrapperToExternalEncoding(Encoding encoder) {
-
-    if (null == encoder) {
-      return null;
-    }
-
-    switch (encoder) {
-      case DICTIONARY:
-        return org.carbondata.format.Encoding.DICTIONARY;
-      case DELTA:
-        return org.carbondata.format.Encoding.DELTA;
-      case RLE:
-        return org.carbondata.format.Encoding.RLE;
-      case INVERTED_INDEX:
-        return org.carbondata.format.Encoding.INVERTED_INDEX;
-      case BIT_PACKED:
-        return org.carbondata.format.Encoding.BIT_PACKED;
-      case DIRECT_DICTIONARY:
-        return org.carbondata.format.Encoding.DIRECT_DICTIONARY;
-      default:
-        return org.carbondata.format.Encoding.DICTIONARY;
-    }
-  }
-
-  /**
-   * convert from wrapper to external data type
-   *
-   * @param dataType
-   * @return
-   */
-  private org.carbondata.format.DataType fromWrapperToExternalDataType(DataType dataType) {
-
-    if (null == dataType) {
-      return null;
-    }
-    switch (dataType) {
-      case STRING:
-        return org.carbondata.format.DataType.STRING;
-      case INT:
-        return org.carbondata.format.DataType.INT;
-      case SHORT:
-        return org.carbondata.format.DataType.SHORT;
-      case LONG:
-        return org.carbondata.format.DataType.LONG;
-      case DOUBLE:
-        return org.carbondata.format.DataType.DOUBLE;
-      case DECIMAL:
-        return org.carbondata.format.DataType.DECIMAL;
-      case TIMESTAMP:
-        return org.carbondata.format.DataType.TIMESTAMP;
-      case ARRAY:
-        return org.carbondata.format.DataType.ARRAY;
-      case STRUCT:
-        return org.carbondata.format.DataType.STRUCT;
-      default:
-        return org.carbondata.format.DataType.STRING;
-    }
-  }
-
-  /* (non-Javadoc)
-   * convert from wrapper to external column schema
-   */
-  @Override public org.carbondata.format.ColumnSchema fromWrapperToExternalColumnSchema(
-      ColumnSchema wrapperColumnSchema) {
-
-    List<org.carbondata.format.Encoding> encoders = new ArrayList<org.carbondata.format.Encoding>();
-    for (Encoding encoder : wrapperColumnSchema.getEncodingList()) {
-      encoders.add(fromWrapperToExternalEncoding(encoder));
-    }
-    org.carbondata.format.ColumnSchema thriftColumnSchema = new org.carbondata.format.ColumnSchema(
-        fromWrapperToExternalDataType(wrapperColumnSchema.getDataType()),
-        wrapperColumnSchema.getColumnName(), wrapperColumnSchema.getColumnUniqueId(),
-        wrapperColumnSchema.isColumnar(), encoders, wrapperColumnSchema.isDimensionColumn());
-    thriftColumnSchema.setColumn_group_id(wrapperColumnSchema.getColumnGroupId());
-    thriftColumnSchema.setScale(wrapperColumnSchema.getScale());
-    thriftColumnSchema.setPrecision(wrapperColumnSchema.getPrecision());
-    thriftColumnSchema.setNum_child(wrapperColumnSchema.getNumberOfChild());
-    thriftColumnSchema.setDefault_value(wrapperColumnSchema.getDefaultValue());
-    thriftColumnSchema.setColumnProperties(wrapperColumnSchema.getColumnProperties());
-    thriftColumnSchema.setInvisible(wrapperColumnSchema.isInvisible());
-    thriftColumnSchema.setColumnReferenceId(wrapperColumnSchema.getColumnReferenceId());
-    return thriftColumnSchema;
-  }
-
-  /* (non-Javadoc)
-   * convert from wrapper to external tableschema
-   */
-  @Override public org.carbondata.format.TableSchema fromWrapperToExternalTableSchema(
-      TableSchema wrapperTableSchema) {
-
-    List<org.carbondata.format.ColumnSchema> thriftColumnSchema =
-        new ArrayList<org.carbondata.format.ColumnSchema>();
-    for (ColumnSchema wrapperColumnSchema : wrapperTableSchema.getListOfColumns()) {
-      thriftColumnSchema.add(fromWrapperToExternalColumnSchema(wrapperColumnSchema));
-    }
-    org.carbondata.format.SchemaEvolution schemaEvolution =
-        fromWrapperToExternalSchemaEvolution(wrapperTableSchema.getSchemaEvalution());
-    return new org.carbondata.format.TableSchema(wrapperTableSchema.getTableId(),
-        thriftColumnSchema, schemaEvolution);
-  }
-
-  /* (non-Javadoc)
-   * convert from wrapper to external tableinfo
-   */
-  @Override public org.carbondata.format.TableInfo fromWrapperToExternalTableInfo(
-      TableInfo wrapperTableInfo, String dbName, String tableName) {
-
-    org.carbondata.format.TableSchema thriftFactTable =
-        fromWrapperToExternalTableSchema(wrapperTableInfo.getFactTable());
-    List<org.carbondata.format.TableSchema> thriftAggTables =
-        new ArrayList<org.carbondata.format.TableSchema>();
-    for (TableSchema wrapperAggTableSchema : wrapperTableInfo.getAggregateTableList()) {
-      thriftAggTables.add(fromWrapperToExternalTableSchema(wrapperAggTableSchema));
-    }
-    return new org.carbondata.format.TableInfo(thriftFactTable, thriftAggTables);
-  }
-
-  /* (non-Javadoc)
-   * convert from external to wrapper schema evolution entry
-   */
-  @Override public SchemaEvolutionEntry fromExternalToWrapperSchemaEvolutionEntry(
-      org.carbondata.format.SchemaEvolutionEntry externalSchemaEvolutionEntry) {
-
-    SchemaEvolutionEntry wrapperSchemaEvolutionEntry = new SchemaEvolutionEntry();
-    wrapperSchemaEvolutionEntry.setTimeStamp(externalSchemaEvolutionEntry.getTime_stamp());
-
-    List<ColumnSchema> wrapperAddedColumns = new ArrayList<ColumnSchema>();
-    if (null != externalSchemaEvolutionEntry.getAdded()) {
-      for (org.carbondata.format.ColumnSchema externalColumnSchema : externalSchemaEvolutionEntry
-          .getAdded()) {
-        wrapperAddedColumns.add(fromExternalToWrapperColumnSchema(externalColumnSchema));
-      }
-    }
-    List<ColumnSchema> wrapperRemovedColumns = new ArrayList<ColumnSchema>();
-    if (null != externalSchemaEvolutionEntry.getRemoved()) {
-      for (org.carbondata.format.ColumnSchema externalColumnSchema : externalSchemaEvolutionEntry
-          .getRemoved()) {
-        wrapperRemovedColumns.add(fromExternalToWrapperColumnSchema(externalColumnSchema));
-      }
-    }
-
-    wrapperSchemaEvolutionEntry.setAdded(wrapperAddedColumns);
-    wrapperSchemaEvolutionEntry.setRemoved(wrapperRemovedColumns);
-    return wrapperSchemaEvolutionEntry;
-
-  }
-
-  /* (non-Javadoc)
-   * convert from external to wrapper schema evolution
-   */
-  @Override public SchemaEvolution fromExternalToWrapperSchemaEvolution(
-      org.carbondata.format.SchemaEvolution externalSchemaEvolution) {
-    List<SchemaEvolutionEntry> wrapperSchemaEvolEntryList = new ArrayList<SchemaEvolutionEntry>();
-    for (org.carbondata.format.SchemaEvolutionEntry schemaEvolutionEntry : externalSchemaEvolution
-        .getSchema_evolution_history()) {
-      wrapperSchemaEvolEntryList
-          .add(fromExternalToWrapperSchemaEvolutionEntry(schemaEvolutionEntry));
-    }
-    SchemaEvolution wrapperSchemaEvolution = new SchemaEvolution();
-    wrapperSchemaEvolution.setSchemaEvolutionEntryList(wrapperSchemaEvolEntryList);
-    return wrapperSchemaEvolution;
-  }
-
-  /**
-   * convert from external to wrapper encoding
-   *
-   * @param encoder
-   * @return
-   */
-  private Encoding fromExternalToWrapperEncoding(org.carbondata.format.Encoding encoder) {
-    if (null == encoder) {
-      return null;
-    }
-    switch (encoder) {
-      case DICTIONARY:
-        return Encoding.DICTIONARY;
-      case DELTA:
-        return Encoding.DELTA;
-      case RLE:
-        return Encoding.RLE;
-      case INVERTED_INDEX:
-        return Encoding.INVERTED_INDEX;
-      case BIT_PACKED:
-        return Encoding.BIT_PACKED;
-      case DIRECT_DICTIONARY:
-        return Encoding.DIRECT_DICTIONARY;
-      default:
-        return Encoding.DICTIONARY;
-    }
-  }
-
-  /**
-   * convert from external to wrapper data type
-   *
-   * @param dataType
-   * @return
-   */
-  private DataType fromExternalToWrapperDataType(org.carbondata.format.DataType dataType) {
-    if (null == dataType) {
-      return null;
-    }
-    switch (dataType) {
-      case STRING:
-        return DataType.STRING;
-      case INT:
-        return DataType.INT;
-      case SHORT:
-        return DataType.SHORT;
-      case LONG:
-        return DataType.LONG;
-      case DOUBLE:
-        return DataType.DOUBLE;
-      case DECIMAL:
-        return DataType.DECIMAL;
-      case TIMESTAMP:
-        return DataType.TIMESTAMP;
-      case ARRAY:
-        return DataType.ARRAY;
-      case STRUCT:
-        return DataType.STRUCT;
-      default:
-        return DataType.STRING;
-    }
-  }
-
-  /* (non-Javadoc)
-   * convert from external to wrapper columnschema
-   */
-  @Override public ColumnSchema fromExternalToWrapperColumnSchema(
-      org.carbondata.format.ColumnSchema externalColumnSchema) {
-    ColumnSchema wrapperColumnSchema = new ColumnSchema();
-    wrapperColumnSchema.setColumnUniqueId(externalColumnSchema.getColumn_id());
-    wrapperColumnSchema.setColumnName(externalColumnSchema.getColumn_name());
-    wrapperColumnSchema.setColumnar(externalColumnSchema.isColumnar());
-    wrapperColumnSchema.setDataType(fromExternalToWrapperDataType(externalColumnSchema.data_type));
-    wrapperColumnSchema.setDimensionColumn(externalColumnSchema.isDimension());
-    List<Encoding> encoders = new ArrayList<Encoding>();
-    for (org.carbondata.format.Encoding encoder : externalColumnSchema.getEncoders()) {
-      encoders.add(fromExternalToWrapperEncoding(encoder));
-    }
-    wrapperColumnSchema.setEncodingList(encoders);
-    wrapperColumnSchema.setNumberOfChild(externalColumnSchema.getNum_child());
-    wrapperColumnSchema.setPrecision(externalColumnSchema.getPrecision());
-    wrapperColumnSchema.setColumnGroup(externalColumnSchema.getColumn_group_id());
-    wrapperColumnSchema.setScale(externalColumnSchema.getScale());
-    wrapperColumnSchema.setDefaultValue(externalColumnSchema.getDefault_value());
-    wrapperColumnSchema.setAggregateFunction(externalColumnSchema.getAggregate_function());
-    wrapperColumnSchema.setColumnProperties(externalColumnSchema.getColumnProperties());
-    wrapperColumnSchema.setInvisible(externalColumnSchema.isInvisible());
-    wrapperColumnSchema.setColumnReferenceId(externalColumnSchema.getColumnReferenceId());
-    return wrapperColumnSchema;
-  }
-
-  /* (non-Javadoc)
-   * convert from external to wrapper tableschema
-   */
-  @Override public TableSchema fromExternalToWrapperTableSchema(
-      org.carbondata.format.TableSchema externalTableSchema, String tableName) {
-    TableSchema wrapperTableSchema = new TableSchema();
-    wrapperTableSchema.setTableId(externalTableSchema.getTable_id());
-    wrapperTableSchema.setTableName(tableName);
-    List<ColumnSchema> listOfColumns = new ArrayList<ColumnSchema>();
-    for (org.carbondata.format.ColumnSchema externalColumnSchema : externalTableSchema
-        .getTable_columns()) {
-      listOfColumns.add(fromExternalToWrapperColumnSchema(externalColumnSchema));
-    }
-    wrapperTableSchema.setListOfColumns(listOfColumns);
-    wrapperTableSchema.setSchemaEvalution(
-        fromExternalToWrapperSchemaEvolution(externalTableSchema.getSchema_evolution()));
-    return wrapperTableSchema;
-  }
-
-  /* (non-Javadoc)
-   * convert from external to wrapper tableinfo
-   */
-  @Override public TableInfo fromExternalToWrapperTableInfo(
-      org.carbondata.format.TableInfo externalTableInfo, String dbName, String tableName,
-      String storePath) {
-    TableInfo wrapperTableInfo = new TableInfo();
-    wrapperTableInfo.setLastUpdatedTime(
-        externalTableInfo.getFact_table().getSchema_evolution().getSchema_evolution_history().get(0)
-            .getTime_stamp());
-    wrapperTableInfo.setDatabaseName(dbName);
-    wrapperTableInfo.setTableUniqueName(dbName + "_" + tableName);
-    wrapperTableInfo.setStorePath(storePath);
-    wrapperTableInfo.setFactTable(
-        fromExternalToWrapperTableSchema(externalTableInfo.getFact_table(), tableName));
-    List<TableSchema> aggTablesList = new ArrayList<TableSchema>();
-    int index = 0;
-    for (org.carbondata.format.TableSchema aggTable : externalTableInfo.getAggregate_table_list()) {
-      aggTablesList.add(fromExternalToWrapperTableSchema(aggTable, "agg_table_" + index));
-      index++;
-    }
-    return wrapperTableInfo;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/datatype/ConvertedType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/datatype/ConvertedType.java b/core/src/main/java/org/carbondata/core/carbon/metadata/datatype/ConvertedType.java
deleted file mode 100644
index bbf71bc..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/datatype/ConvertedType.java
+++ /dev/null
@@ -1,122 +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.carbondata.core.carbon.metadata.datatype;
-
-public enum ConvertedType {
-
-  /**
-   * a BYTE_ARRAY actually contains UTF8 encoded chars
-   */
-  UTF8,
-  /**
-   * a map is converted as an optional field containing a repeated key/value pair
-   */
-  MAP,
-  /**
-   * a key/value pair is converted into a group of two fields
-   */
-  MAP_KEY_VALUE,
-  /**
-   * a list is converted into an optional field containing a repeated field for its
-   * values
-   */
-  LIST,
-  /**
-   * an enum is converted into a binary field
-   */
-  ENUM,
-  /**
-   * A decimal value.
-   * This may be used to annotate binary or fixed primitive types. The
-   * underlying byte array stores the unscaled value encoded as two's
-   * complement using big-endian byte order (the most significant byte is the
-   * zeroth element). The value of the decimal is the value * 10^{-scale}.
-   * This must be accompanied by a (maximum) precision and a scale in the
-   * SchemaElement. The precision specifies the number of digits in the decimal
-   * and the scale stores the location of the decimal point. For example 1.23
-   * would have precision 3 (3 total digits) and scale 2 (the decimal point is
-   * 2 digits over).
-   */
-  DECIMAL,
-  /**
-   * A Date
-   * Stored as days since Unix epoch, encoded as the INT32 physical type.
-   */
-  DATE,
-  /**
-   * A time
-   * The total number of milliseconds since midnight.  The value is stored
-   * as an INT32 physical type.
-   */
-  TIME_MILLIS,
-  /**
-   * A date/time combination
-   * Date and time recorded as milliseconds since the Unix epoch.  Recorded as
-   * a physical type of INT64.
-   */
-  TIMESTAMP_MILLIS,
-
-  RESERVED,
-  /**
-   * An unsigned integer value.
-   * The number describes the maximum number of meainful data bits in
-   * the stored value. 8, 16 and 32 bit values are stored using the
-   * INT32 physical type.  64 bit values are stored using the INT64
-   * physical type.
-   */
-  UINT_8,
-  UINT_16,
-  UINT_32,
-  UINT_64,
-  /**
-   * A signed integer value.
-   * The number describes the maximum number of meainful data bits in
-   * the stored value. 8, 16 and 32 bit values are stored using the
-   * INT32 physical type.  64 bit values are stored using the INT64
-   * physical type.
-   */
-  INT_8,
-  INT_16,
-  INT_32,
-  INT_64,
-  /**
-   * An embedded JSON document
-   * A JSON document embedded within a single UTF8 column.
-   */
-  JSON,
-
-  /**
-   * An embedded BSON document
-   * A BSON document embedded within a single BINARY column.
-   */
-  BSON,
-
-  /**
-   * An interval of time
-   * This type annotates data stored as a FIXED_LEN_BYTE_ARRAY of length 12
-   * This data is composed of three separate little endian unsigned
-   * integers.  Each stores a component of a duration of time.  The first
-   * integer identifies the number of months associated with the duration,
-   * the second identifies the number of days associated with the duration
-   * and the third identifies the number of milliseconds associated with
-   * the provided duration.  This duration of time is independent of any
-   * particular timezone or date.
-   */
-  INTERVAL;
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/datatype/DataType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/datatype/DataType.java b/core/src/main/java/org/carbondata/core/carbon/metadata/datatype/DataType.java
deleted file mode 100644
index 5fbe9cb..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/datatype/DataType.java
+++ /dev/null
@@ -1,48 +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.carbondata.core.carbon.metadata.datatype;
-
-public enum DataType {
-
-  STRING(0),
-  DATE(1),
-  TIMESTAMP(2),
-  BOOLEAN(1),
-  SHORT(2),
-  INT(3),
-  FLOAT(4),
-  LONG(5),
-  DOUBLE(6),
-  NULL(7),
-  DECIMAL(8),
-  ARRAY(9),
-  STRUCT(10),
-  MAP(11);
-
-  private int presedenceOrder;
-
-  DataType(int value) {
-    this.presedenceOrder = value;
-  }
-
-  public int getPresedenceOrder() {
-    return presedenceOrder;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/encoder/Encoding.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/encoder/Encoding.java b/core/src/main/java/org/carbondata/core/carbon/metadata/encoder/Encoding.java
deleted file mode 100644
index bc1ecaa..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/encoder/Encoding.java
+++ /dev/null
@@ -1,31 +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.carbondata.core.carbon.metadata.encoder;
-
-/**
- * Encoding type supported in carbon
- */
-public enum Encoding {
-  DICTIONARY,
-  DELTA,
-  RLE,
-  INVERTED_INDEX,
-  BIT_PACKED,
-  DIRECT_DICTIONARY;
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/index/BlockIndexInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/index/BlockIndexInfo.java b/core/src/main/java/org/carbondata/core/carbon/metadata/index/BlockIndexInfo.java
deleted file mode 100644
index bfed3dd..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/index/BlockIndexInfo.java
+++ /dev/null
@@ -1,92 +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.carbondata.core.carbon.metadata.index;
-
-import org.carbondata.core.carbon.metadata.blocklet.index.BlockletIndex;
-
-/**
- * Below class will be used hold the information
- * about block index
- */
-public class BlockIndexInfo {
-
-  /**
-   * total number of rows present in the file
-   */
-  private long numberOfRows;
-
-  /**
-   * file name
-   */
-  private String fileName;
-
-  /**
-   * offset of metadata in data file
-   */
-  private long offset;
-
-  /**
-   * to store min max and start and end key
-   */
-  private BlockletIndex blockletIndex;
-
-  /**
-   * Constructor
-   *
-   * @param numberOfRows  number of rows
-   * @param fileName      full qualified name
-   * @param offset        offset of the metadata in data file
-   * @param blockletIndex block let index
-   */
-  public BlockIndexInfo(long numberOfRows, String fileName, long offset,
-      BlockletIndex blockletIndex) {
-    this.numberOfRows = numberOfRows;
-    this.fileName = fileName;
-    this.offset = offset;
-    this.blockletIndex = blockletIndex;
-  }
-
-  /**
-   * @return the numberOfRows
-   */
-  public long getNumberOfRows() {
-    return numberOfRows;
-  }
-
-  /**
-   * @return the fileName
-   */
-  public String getFileName() {
-    return fileName;
-  }
-
-  /**
-   * @return the offset
-   */
-  public long getOffset() {
-    return offset;
-  }
-
-  /**
-   * @return the blockletIndex
-   */
-  public BlockletIndex getBlockletIndex() {
-    return blockletIndex;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/schema/SchemaEvolution.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/schema/SchemaEvolution.java b/core/src/main/java/org/carbondata/core/carbon/metadata/schema/SchemaEvolution.java
deleted file mode 100644
index 6ce7f5e..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/schema/SchemaEvolution.java
+++ /dev/null
@@ -1,52 +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.carbondata.core.carbon.metadata.schema;
-
-import java.io.Serializable;
-import java.util.List;
-
-/**
- * Persisting schema restructuring information;
- */
-public class SchemaEvolution implements Serializable {
-
-  /**
-   * serialization version
-   */
-  private static final long serialVersionUID = 8186224567517679868L;
-
-  /**
-   * list of schema evolution entry
-   */
-  private List<SchemaEvolutionEntry> schemaEvolutionEntryList;
-
-  /**
-   * @return the schemaEvolutionEntryList
-   */
-  public List<SchemaEvolutionEntry> getSchemaEvolutionEntryList() {
-    return schemaEvolutionEntryList;
-  }
-
-  /**
-   * @param schemaEvolutionEntryList the schemaEvolutionEntryList to set
-   */
-  public void setSchemaEvolutionEntryList(List<SchemaEvolutionEntry> schemaEvolutionEntryList) {
-    this.schemaEvolutionEntryList = schemaEvolutionEntryList;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/schema/SchemaEvolutionEntry.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/schema/SchemaEvolutionEntry.java b/core/src/main/java/org/carbondata/core/carbon/metadata/schema/SchemaEvolutionEntry.java
deleted file mode 100644
index ef06963..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/schema/SchemaEvolutionEntry.java
+++ /dev/null
@@ -1,93 +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.carbondata.core.carbon.metadata.schema;
-
-import java.io.Serializable;
-import java.util.List;
-
-import org.carbondata.core.carbon.metadata.schema.table.column.ColumnSchema;
-
-/**
- * Store the infomation about the schema evolution
- */
-public class SchemaEvolutionEntry implements Serializable {
-
-  /**
-   * serilization version
-   */
-  private static final long serialVersionUID = -7619477063676325276L;
-
-  /**
-   * time stamp of restructuring
-   */
-  private long timeStamp;
-
-  /**
-   * new column added in restructuring
-   */
-  private List<ColumnSchema> added;
-
-  /**
-   * column removed in restructuring
-   */
-  private List<ColumnSchema> removed;
-
-  /**
-   * @return the timeStamp
-   */
-  public long getTimeStamp() {
-    return timeStamp;
-  }
-
-  /**
-   * @param timeStamp the timeStamp to set
-   */
-  public void setTimeStamp(long timeStamp) {
-    this.timeStamp = timeStamp;
-  }
-
-  /**
-   * @return the added
-   */
-  public List<ColumnSchema> getAdded() {
-    return added;
-  }
-
-  /**
-   * @param added the added to set
-   */
-  public void setAdded(List<ColumnSchema> added) {
-    this.added = added;
-  }
-
-  /**
-   * @return the removed
-   */
-  public List<ColumnSchema> getRemoved() {
-    return removed;
-  }
-
-  /**
-   * @param removed the removed to set
-   */
-  public void setRemoved(List<ColumnSchema> removed) {
-    this.removed = removed;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/CarbonTable.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/CarbonTable.java b/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/CarbonTable.java
deleted file mode 100644
index 4d16659..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/CarbonTable.java
+++ /dev/null
@@ -1,399 +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.carbondata.core.carbon.metadata.schema.table;
-
-import java.io.Serializable;
-import java.util.ArrayList;
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-
-import org.carbondata.core.carbon.AbsoluteTableIdentifier;
-import org.carbondata.core.carbon.CarbonTableIdentifier;
-import org.carbondata.core.carbon.metadata.encoder.Encoding;
-import org.carbondata.core.carbon.metadata.schema.table.column.CarbonDimension;
-import org.carbondata.core.carbon.metadata.schema.table.column.CarbonMeasure;
-import org.carbondata.core.carbon.metadata.schema.table.column.ColumnSchema;
-
-/**
- * Mapping class for Carbon actual table
- */
-public class CarbonTable implements Serializable {
-
-  /**
-   * serialization id
-   */
-  private static final long serialVersionUID = 8696507171227156445L;
-
-  /**
-   * Absolute table identifier
-   */
-  private AbsoluteTableIdentifier absoluteTableIdentifier;
-
-  /**
-   * TableName, Dimensions list
-   */
-  private Map<String, List<CarbonDimension>> tableDimensionsMap;
-
-  /**
-   * table measures list.
-   */
-  private Map<String, List<CarbonMeasure>> tableMeasuresMap;
-
-  /**
-   * tableUniqueName
-   */
-  private String tableUniqueName;
-
-  /**
-   * Aggregate tables name
-   */
-  private List<String> aggregateTablesName;
-
-  /**
-   * metadata file path (check if it is really required )
-   */
-  private String metaDataFilepath;
-
-  /**
-   * last updated time
-   */
-  private long tableLastUpdatedTime;
-
-  public CarbonTable() {
-    this.tableDimensionsMap = new HashMap<String, List<CarbonDimension>>();
-    this.tableMeasuresMap = new HashMap<String, List<CarbonMeasure>>();
-    this.aggregateTablesName = new ArrayList<String>();
-  }
-
-  /**
-   * @param tableInfo
-   */
-  public void loadCarbonTable(TableInfo tableInfo) {
-    this.tableLastUpdatedTime = tableInfo.getLastUpdatedTime();
-    this.tableUniqueName = tableInfo.getTableUniqueName();
-    this.metaDataFilepath = tableInfo.getMetaDataFilepath();
-    //setting unique table identifier
-    CarbonTableIdentifier carbontableIdentifier =
-        new CarbonTableIdentifier(tableInfo.getDatabaseName(),
-            tableInfo.getFactTable().getTableName(), tableInfo.getFactTable().getTableId());
-    this.absoluteTableIdentifier =
-        new AbsoluteTableIdentifier(tableInfo.getStorePath(), carbontableIdentifier);
-
-    fillDimensionsAndMeasuresForTables(tableInfo.getFactTable());
-    List<TableSchema> aggregateTableList = tableInfo.getAggregateTableList();
-    for (TableSchema aggTable : aggregateTableList) {
-      this.aggregateTablesName.add(aggTable.getTableName());
-      fillDimensionsAndMeasuresForTables(aggTable);
-    }
-  }
-
-  /**
-   * Fill dimensions and measures for carbon table
-   *
-   * @param tableSchema
-   */
-  private void fillDimensionsAndMeasuresForTables(TableSchema tableSchema) {
-    List<CarbonDimension> dimensions = new ArrayList<CarbonDimension>();
-    List<CarbonMeasure> measures = new ArrayList<CarbonMeasure>();
-    this.tableDimensionsMap.put(tableSchema.getTableName(), dimensions);
-    this.tableMeasuresMap.put(tableSchema.getTableName(), measures);
-    int dimensionOrdinal = 0;
-    int measureOrdinal = 0;
-    int keyOrdinal = 0;
-    int columnGroupOrdinal = -1;
-    int previousColumnGroupId = -1;
-    List<ColumnSchema> listOfColumns = tableSchema.getListOfColumns();
-    int complexTypeOrdinal = -1;
-    for (int i = 0; i < listOfColumns.size(); i++) {
-      ColumnSchema columnSchema = listOfColumns.get(i);
-      if (columnSchema.isDimensionColumn()) {
-        if (columnSchema.getNumberOfChild() > 0) {
-          CarbonDimension complexDimension =
-              new CarbonDimension(columnSchema, dimensionOrdinal++, -1, -1, ++complexTypeOrdinal);
-          complexDimension.initializeChildDimensionsList(columnSchema.getNumberOfChild());
-          dimensions.add(complexDimension);
-          dimensionOrdinal =
-              readAllComplexTypeChildrens(dimensionOrdinal, columnSchema.getNumberOfChild(),
-                  listOfColumns, complexDimension);
-          i = dimensionOrdinal - 1;
-          complexTypeOrdinal = assignComplexOrdinal(complexDimension, complexTypeOrdinal);
-        } else {
-          if (!columnSchema.getEncodingList().contains(Encoding.DICTIONARY)) {
-            dimensions.add(new CarbonDimension(columnSchema, dimensionOrdinal++, -1, -1, -1));
-          } else if (columnSchema.getEncodingList().contains(Encoding.DICTIONARY)
-              && columnSchema.getColumnGroupId() == -1) {
-            dimensions
-                .add(new CarbonDimension(columnSchema, dimensionOrdinal++, keyOrdinal++, -1, -1));
-          } else {
-            columnGroupOrdinal =
-                previousColumnGroupId == columnSchema.getColumnGroupId() ? ++columnGroupOrdinal : 0;
-            previousColumnGroupId = columnSchema.getColumnGroupId();
-            dimensions.add(new CarbonDimension(columnSchema, dimensionOrdinal++, keyOrdinal++,
-                columnGroupOrdinal, -1));
-
-          }
-        }
-      } else {
-        measures.add(new CarbonMeasure(columnSchema, measureOrdinal++));
-      }
-    }
-  }
-
-  /**
-   * Read all primitive/complex children and set it as list of child carbon dimension to parent
-   * dimension
-   *
-   * @param dimensionOrdinal
-   * @param childCount
-   * @param listOfColumns
-   * @param parentDimension
-   * @return
-   */
-  private int readAllComplexTypeChildrens(int dimensionOrdinal, int childCount,
-      List<ColumnSchema> listOfColumns, CarbonDimension parentDimension) {
-    for (int i = 0; i < childCount; i++) {
-      ColumnSchema columnSchema = listOfColumns.get(dimensionOrdinal);
-      if (columnSchema.isDimensionColumn()) {
-        if (columnSchema.getNumberOfChild() > 0) {
-          CarbonDimension complexDimension =
-              new CarbonDimension(columnSchema, dimensionOrdinal++, -1, -1, -1);
-          complexDimension.initializeChildDimensionsList(columnSchema.getNumberOfChild());
-          parentDimension.getListOfChildDimensions().add(complexDimension);
-          dimensionOrdinal =
-              readAllComplexTypeChildrens(dimensionOrdinal, columnSchema.getNumberOfChild(),
-                  listOfColumns, complexDimension);
-        } else {
-          parentDimension.getListOfChildDimensions()
-              .add(new CarbonDimension(columnSchema, dimensionOrdinal++, -1, -1, -1));
-        }
-      }
-    }
-    return dimensionOrdinal;
-  }
-
-  /**
-   * Read all primitive/complex children and set it as list of child carbon dimension to parent
-   * dimension
-   *
-   * @param dimensionOrdinal
-   * @param childCount
-   * @param listOfColumns
-   * @param parentDimension
-   * @return
-   */
-  private int assignComplexOrdinal(CarbonDimension parentDimension, int complexDimensionOrdianl) {
-    for (int i = 0; i < parentDimension.getNumberOfChild(); i++) {
-      CarbonDimension dimension = parentDimension.getListOfChildDimensions().get(i);
-      if (dimension.getNumberOfChild() > 0) {
-        dimension.setComplexTypeOridnal(++complexDimensionOrdianl);
-        complexDimensionOrdianl = assignComplexOrdinal(dimension, complexDimensionOrdianl);
-      } else {
-        parentDimension.getListOfChildDimensions().get(i)
-            .setComplexTypeOridnal(++complexDimensionOrdianl);
-      }
-    }
-    return complexDimensionOrdianl;
-  }
-
-  /**
-   * @return the databaseName
-   */
-  public String getDatabaseName() {
-    return absoluteTableIdentifier.getCarbonTableIdentifier().getDatabaseName();
-  }
-
-  /**
-   * @return the tabelName
-   */
-  public String getFactTableName() {
-    return absoluteTableIdentifier.getCarbonTableIdentifier().getTableName();
-  }
-
-  /**
-   * @return the tableUniqueName
-   */
-  public String getTableUniqueName() {
-    return tableUniqueName;
-  }
-
-  /**
-   * @return the metaDataFilepath
-   */
-  public String getMetaDataFilepath() {
-    return metaDataFilepath;
-  }
-
-  /**
-   * @return storepath
-   */
-  public String getStorePath() {
-    return absoluteTableIdentifier.getStorePath();
-  }
-
-  /**
-   * @return list of aggregate TablesName
-   */
-  public List<String> getAggregateTablesName() {
-    return aggregateTablesName;
-  }
-
-  /**
-   * @return the tableLastUpdatedTime
-   */
-  public long getTableLastUpdatedTime() {
-    return tableLastUpdatedTime;
-  }
-
-  /**
-   * to get the number of dimension present in the table
-   *
-   * @param tableName
-   * @return number of dimension present the table
-   */
-  public int getNumberOfDimensions(String tableName) {
-    return tableDimensionsMap.get(tableName).size();
-  }
-
-  /**
-   * to get the number of measures present in the table
-   *
-   * @param tableName
-   * @return number of measures present the table
-   */
-  public int getNumberOfMeasures(String tableName) {
-    return tableMeasuresMap.get(tableName).size();
-  }
-
-  /**
-   * to get the all dimension of a table
-   *
-   * @param tableName
-   * @return all dimension of a table
-   */
-  public List<CarbonDimension> getDimensionByTableName(String tableName) {
-    return tableDimensionsMap.get(tableName);
-  }
-
-  /**
-   * to get the all measure of a table
-   *
-   * @param tableName
-   * @return all measure of a table
-   */
-  public List<CarbonMeasure> getMeasureByTableName(String tableName) {
-    return tableMeasuresMap.get(tableName);
-  }
-
-  /**
-   * to get particular measure from a table
-   *
-   * @param tableName
-   * @param columnName
-   * @return
-   */
-  public CarbonMeasure getMeasureByName(String tableName, String columnName) {
-    List<CarbonMeasure> measureList = tableMeasuresMap.get(tableName);
-    for (CarbonMeasure measure : measureList) {
-      if (measure.getColName().equalsIgnoreCase(columnName)) {
-        return measure;
-      }
-    }
-    return null;
-  }
-
-  /**
-   * to get particular dimension from a table
-   *
-   * @param tableName
-   * @param columnName
-   * @return
-   */
-  public CarbonDimension getDimensionByName(String tableName, String columnName) {
-    List<CarbonDimension> dimList = tableDimensionsMap.get(tableName);
-    for (CarbonDimension dim : dimList) {
-      if (dim.getColName().equalsIgnoreCase(columnName)) {
-        return dim;
-      }
-    }
-    return null;
-  }
-
-  /**
-   * gets all children dimension for complex type
-   *
-   * @param dimName
-   * @return list of child dimensions
-   */
-  public List<CarbonDimension> getChildren(String dimName) {
-    for (List<CarbonDimension> list : tableDimensionsMap.values()) {
-      List<CarbonDimension> childDims = getChildren(dimName, list);
-      if (childDims != null) {
-        return childDims;
-      }
-    }
-    return null;
-  }
-
-  /**
-   * returns level 2 or more child dimensions
-   *
-   * @param dimName
-   * @param dimensions
-   * @return list of child dimensions
-   */
-  public List<CarbonDimension> getChildren(String dimName, List<CarbonDimension> dimensions) {
-    for (CarbonDimension carbonDimension : dimensions) {
-      if (carbonDimension.getColName().equals(dimName)) {
-        return carbonDimension.getListOfChildDimensions();
-      } else if (null != carbonDimension.getListOfChildDimensions()
-          && carbonDimension.getListOfChildDimensions().size() > 0) {
-        List<CarbonDimension> childDims =
-            getChildren(dimName, carbonDimension.getListOfChildDimensions());
-        if (childDims != null) {
-          return childDims;
-        }
-      }
-    }
-    return null;
-  }
-
-  /**
-   * @return absolute table identifier
-   */
-  public AbsoluteTableIdentifier getAbsoluteTableIdentifier() {
-    return absoluteTableIdentifier;
-  }
-
-  /**
-   * @return carbon table identifier
-   */
-  public CarbonTableIdentifier getCarbonTableIdentifier() {
-    return absoluteTableIdentifier.getCarbonTableIdentifier();
-  }
-
-  /**
-   * gets partition count for this table
-   * TODO: to be implemented while supporting partitioning
-   */
-  public int getPartitionCount() {
-    return 1;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/TableInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/TableInfo.java b/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/TableInfo.java
deleted file mode 100644
index 0a9cfca..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/TableInfo.java
+++ /dev/null
@@ -1,239 +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.carbondata.core.carbon.metadata.schema.table;
-
-import java.io.Serializable;
-import java.util.ArrayList;
-import java.util.List;
-
-import org.carbondata.core.constants.CarbonCommonConstants;
-
-/**
- * Store the information about the table.
- * it stores the fact table as well as aggregate table present in the schema
- */
-public class TableInfo implements Serializable {
-
-  /**
-   * serialization version
-   */
-  private static final long serialVersionUID = -5034287968314105193L;
-
-  /**
-   * name of the database;
-   */
-  private String databaseName;
-
-  /**
-   * table name to group fact table and aggregate table
-   */
-  private String tableUniqueName;
-
-  /**
-   * fact table information
-   */
-  private TableSchema factTable;
-
-  /**
-   * list of aggregate table
-   */
-  private List<TableSchema> aggregateTableList;
-
-  /**
-   * last updated time to update the table if any changes
-   */
-  private long lastUpdatedTime;
-
-  /**
-   * metadata file path (check if it is really required )
-   */
-  private String metaDataFilepath;
-
-  /**
-   * store location
-   */
-  private String storePath;
-
-  public TableInfo() {
-    aggregateTableList = new ArrayList<TableSchema>(CarbonCommonConstants.DEFAULT_COLLECTION_SIZE);
-  }
-
-  /**
-   * @return the factTable
-   */
-  public TableSchema getFactTable() {
-    return factTable;
-  }
-
-  /**
-   * @param factTable the factTable to set
-   */
-  public void setFactTable(TableSchema factTable) {
-    this.factTable = factTable;
-  }
-
-  /**
-   * @return the aggregateTableList
-   */
-  public List<TableSchema> getAggregateTableList() {
-    return aggregateTableList;
-  }
-
-  /**
-   * @param aggregateTableList the aggregateTableList to set
-   */
-  public void setAggregateTableList(List<TableSchema> aggregateTableList) {
-    this.aggregateTableList = aggregateTableList;
-  }
-
-  /**
-   * @return the databaseName
-   */
-  public String getDatabaseName() {
-    return databaseName;
-  }
-
-  /**
-   * @param databaseName the databaseName to set
-   */
-  public void setDatabaseName(String databaseName) {
-    this.databaseName = databaseName;
-  }
-
-  public TableSchema getTableSchemaByName(String tableName) {
-    if (factTable.getTableName().equalsIgnoreCase(tableName)) {
-      return factTable;
-    }
-    for (TableSchema aggregatTableSchema : aggregateTableList) {
-      if (aggregatTableSchema.getTableName().equals(tableName)) {
-        return aggregatTableSchema;
-      }
-    }
-    return null;
-  }
-
-  public TableSchema getTableSchemaByTableId(String tableId) {
-    if (factTable.getTableId().equals(tableId)) {
-      return factTable;
-    }
-    for (TableSchema aggregatTableSchema : aggregateTableList) {
-      if (aggregatTableSchema.getTableId().equals(tableId)) {
-        return aggregatTableSchema;
-      }
-    }
-    return null;
-  }
-
-  public int getNumberOfAggregateTables() {
-    return aggregateTableList.size();
-  }
-
-  /**
-   * @return the tableUniqueName
-   */
-  public String getTableUniqueName() {
-    return tableUniqueName;
-  }
-
-  /**
-   * @param tableUniqueName the tableUniqueName to set
-   */
-  public void setTableUniqueName(String tableUniqueName) {
-    this.tableUniqueName = tableUniqueName;
-  }
-
-  /**
-   * @return the lastUpdatedTime
-   */
-  public long getLastUpdatedTime() {
-    return lastUpdatedTime;
-  }
-
-  /**
-   * @param lastUpdatedTime the lastUpdatedTime to set
-   */
-  public void setLastUpdatedTime(long lastUpdatedTime) {
-    this.lastUpdatedTime = lastUpdatedTime;
-  }
-
-  /**
-   * @return
-   */
-  public String getMetaDataFilepath() {
-    return metaDataFilepath;
-  }
-
-  /**
-   * @param metaDataFilepath
-   */
-  public void setMetaDataFilepath(String metaDataFilepath) {
-    this.metaDataFilepath = metaDataFilepath;
-  }
-
-  public String getStorePath() {
-    return storePath;
-  }
-
-  public void setStorePath(String storePath) {
-    this.storePath = storePath;
-  }
-
-  /**
-   * to generate the hash code
-   */
-  @Override public int hashCode() {
-    final int prime = 31;
-    int result = 1;
-    result = prime * result + ((databaseName == null) ? 0 : databaseName.hashCode());
-    result = prime * result + ((tableUniqueName == null) ? 0 : tableUniqueName.hashCode());
-    return result;
-  }
-
-  /**
-   * Overridden equals method
-   */
-  @Override public boolean equals(Object obj) {
-    if (this == obj) {
-      return true;
-    }
-    if (obj == null) {
-      return false;
-    }
-    if (!(obj instanceof TableInfo)) {
-      return false;
-    }
-    TableInfo other = (TableInfo) obj;
-    if (databaseName == null) {
-      if (other.databaseName != null) {
-        return false;
-      }
-    } else if (!tableUniqueName.equals(other.tableUniqueName)) {
-      return false;
-    }
-
-    if (tableUniqueName == null) {
-      if (other.tableUniqueName != null) {
-        return false;
-      }
-    } else if (!tableUniqueName.equals(other.tableUniqueName)) {
-      return false;
-    }
-    return true;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/TableSchema.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/TableSchema.java b/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/TableSchema.java
deleted file mode 100644
index 06e9cf5..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/TableSchema.java
+++ /dev/null
@@ -1,185 +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.carbondata.core.carbon.metadata.schema.table;
-
-import java.io.Serializable;
-import java.util.ArrayList;
-import java.util.List;
-
-import org.carbondata.core.carbon.metadata.schema.SchemaEvolution;
-import org.carbondata.core.carbon.metadata.schema.table.column.ColumnSchema;
-import org.carbondata.core.constants.CarbonCommonConstants;
-
-/**
- * Persisting the table information
- */
-public class TableSchema implements Serializable {
-
-  /**
-   * serialization version
-   */
-  private static final long serialVersionUID = -1928614587722507026L;
-
-  /**
-   * table id
-   */
-  private String tableId;
-
-  /**
-   * table Name
-   */
-  private String tableName;
-
-  /**
-   * Columns in the table
-   */
-  private List<ColumnSchema> listOfColumns;
-
-  /**
-   * History of schema evolution of this table
-   */
-  private SchemaEvolution schemaEvalution;
-
-  public TableSchema() {
-    this.listOfColumns = new ArrayList<ColumnSchema>(CarbonCommonConstants.DEFAULT_COLLECTION_SIZE);
-  }
-
-  /**
-   * @return the tableId
-   */
-  public String getTableId() {
-    return tableId;
-  }
-
-  /**
-   * @param tableId the tableId to set
-   */
-  public void setTableId(String tableId) {
-    this.tableId = tableId;
-  }
-
-  /**
-   * @return the listOfColumns
-   */
-  public List<ColumnSchema> getListOfColumns() {
-    return listOfColumns;
-  }
-
-  /**
-   * @param listOfColumns the listOfColumns to set
-   */
-  public void setListOfColumns(List<ColumnSchema> listOfColumns) {
-    this.listOfColumns = listOfColumns;
-  }
-
-  /**
-   * @return the schemaEvalution
-   */
-  public SchemaEvolution getSchemaEvalution() {
-    return schemaEvalution;
-  }
-
-  /**
-   * @param schemaEvalution the schemaEvalution to set
-   */
-  public void setSchemaEvalution(SchemaEvolution schemaEvalution) {
-    this.schemaEvalution = schemaEvalution;
-  }
-
-  /**
-   * @return the tableName
-   */
-  public String getTableName() {
-    return tableName;
-  }
-
-  /**
-   * @param tableName the tableName to set
-   */
-  public void setTableName(String tableName) {
-    this.tableName = tableName;
-  }
-
-  /**
-   * to get the column schema present in the table by name
-   *
-   * @param columnName
-   * @return column schema if matches the name
-   */
-  public ColumnSchema getColumnSchemaByName(String columnName) {
-    for (ColumnSchema tableColumn : listOfColumns) {
-      if (tableColumn.getColumnName().equals(columnName)) {
-        return tableColumn;
-      }
-    }
-    return null;
-  }
-
-  /**
-   * to get the column schema present in the table by unique id
-   *
-   * @param columnUniqueId
-   * @return column schema if matches the id
-   */
-  public ColumnSchema getColumnSchemaById(String columnUniqueId) {
-    for (ColumnSchema tableColumn : listOfColumns) {
-      if (tableColumn.getColumnUniqueId().equalsIgnoreCase(columnUniqueId)) {
-        return tableColumn;
-      }
-    }
-    return null;
-  }
-
-  @Override public int hashCode() {
-    final int prime = 31;
-    int result = 1;
-    result = prime * result + ((tableId == null) ? 0 : tableId.hashCode());
-    result = prime * result + ((tableName == null) ? 0 : tableName.hashCode());
-    return result;
-  }
-
-  @Override public boolean equals(Object obj) {
-    if (this == obj) {
-      return true;
-    }
-    if (obj == null) {
-      return false;
-    }
-    if (getClass() != obj.getClass()) {
-      return false;
-    }
-    TableSchema other = (TableSchema) obj;
-    if (tableId == null) {
-      if (other.tableId != null) {
-        return false;
-      }
-    } else if (!tableId.equals(other.tableId)) {
-      return false;
-    }
-    if (tableName == null) {
-      if (other.tableName != null) {
-        return false;
-      }
-    } else if (!tableName.equals(other.tableName)) {
-      return false;
-    }
-    return true;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/cd6a4ff3/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/column/CarbonColumn.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/column/CarbonColumn.java b/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/column/CarbonColumn.java
deleted file mode 100644
index 90d1869..0000000
--- a/core/src/main/java/org/carbondata/core/carbon/metadata/schema/table/column/CarbonColumn.java
+++ /dev/null
@@ -1,174 +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.carbondata.core.carbon.metadata.schema.table.column;
-
-import java.io.Serializable;
-import java.util.List;
-import java.util.Map;
-
-import org.carbondata.core.carbon.ColumnIdentifier;
-import org.carbondata.core.carbon.metadata.datatype.DataType;
-import org.carbondata.core.carbon.metadata.encoder.Encoding;
-
-public class CarbonColumn implements Serializable {
-
-  /**
-   * serialization version
-   */
-  private static final long serialVersionUID = 3648269871256322681L;
-
-  /**
-   * column schema
-   */
-  protected ColumnSchema columnSchema;
-
-  /**
-   * table ordinal
-   */
-  protected int ordinal;
-
-  /**
-   * default value for in case of restructuring will be used when older
-   * segment does not have particular column
-   */
-  protected byte[] defaultValue;
-
-  /**
-   * Column identifier
-   */
-  protected ColumnIdentifier columnIdentifier;
-
-  public CarbonColumn(ColumnSchema columnSchema, int ordinal) {
-    this.columnSchema = columnSchema;
-    this.ordinal = ordinal;
-    this.columnIdentifier =
-        new ColumnIdentifier(getColumnId(), getColumnProperties(), getDataType());
-  }
-
-  /**
-   * @return columnar or row based
-   */
-  public boolean isColumnar() {
-    return columnSchema.isColumnar();
-  }
-
-  /**
-   * @return column unique id
-   */
-  public String getColumnId() {
-    return columnSchema.getColumnUniqueId();
-  }
-
-  /**
-   * @return the dataType
-   */
-  public DataType getDataType() {
-    return columnSchema.getDataType();
-  }
-
-  /**
-   * @return the colName
-   */
-  public String getColName() {
-    return columnSchema.getColumnName();
-  }
-
-  /**
-   * @return the ordinal
-   */
-  public int getOrdinal() {
-    return ordinal;
-  }
-
-  /**
-   * @return the list of encoder used in dimension
-   */
-  public List<Encoding> getEncoder() {
-    return columnSchema.getEncodingList();
-  }
-
-  /**
-   * @return row group id if it is row based
-   */
-  public int columnGroupId() {
-    return columnSchema.getColumnGroupId();
-  }
-
-  /**
-   * @return the defaultValue
-   */
-  public byte[] getDefaultValue() {
-    return defaultValue;
-  }
-
-  /**
-   * @param defaultValue the defaultValue to set
-   */
-  public void setDefaultValue(byte[] defaultValue) {
-    this.defaultValue = defaultValue;
-  }
-
-  /**
-   * @param encoding
-   * @return true if contains the passing encoding
-   */
-  public boolean hasEncoding(Encoding encoding) {
-    return columnSchema.hasEncoding(encoding);
-  }
-
-  /**
-   * @return if DataType is ARRAY or STRUCT, this method return true, else
-   * false.
-   */
-  public Boolean isComplex() {
-    return columnSchema.isComplex();
-  }
-
-  /**
-   * @return if column is dimension return true, else false.
-   */
-  public Boolean isDimesion() {
-    return columnSchema.isDimensionColumn();
-  }
-
-  /**
-   * @return if column use inverted index return true, else false.
-   */
-  public Boolean isUseInvertedIndnex() {
-    return columnSchema.isUseInvertedIndex();
-  }
-  public ColumnSchema getColumnSchema() {
-    return this.columnSchema;
-  }
-
-  /**
-   * @return columnproperty
-   */
-  public Map<String, String> getColumnProperties() {
-    return this.columnSchema.getColumnProperties();
-  }
-
-  /**
-   * @return columnIdentifier
-   */
-  public ColumnIdentifier getColumnIdentifier() {
-    return this.columnIdentifier;
-  }
-}