You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by vi...@apache.org on 2018/07/19 19:55:20 UTC

[21/51] [partial] hive git commit: HIVE-20188 : Split server-specific code outside of standalone metastore-common (Alexander Kolbasov reviewed by Vihang Karajgaonkar)

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPartitionColumnStatistics.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPartitionColumnStatistics.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPartitionColumnStatistics.java
deleted file mode 100644
index 50d9c5b..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPartitionColumnStatistics.java
+++ /dev/null
@@ -1,281 +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.hadoop.hive.metastore.model;
-
-
-
-/**
- *
- * MPartitionColumnStatistics - Represents Hive's partiton level Column Statistics Description.
- * The fields in this class with the exception of partition are persisted in the metastore.
- * In case of partition, part_id is persisted in its place.
- *
- */
-public class MPartitionColumnStatistics {
-
-  private MPartition partition;
-
-  private String catName;
-  private String dbName;
-  private String tableName;
-  private String partitionName;
-  private String colName;
-  private String colType;
-
-  private Long longLowValue;
-  private Long longHighValue;
-  private Double doubleLowValue;
-  private Double doubleHighValue;
-  private String decimalLowValue;
-  private String decimalHighValue;
-  private Long numNulls;
-  private Long numDVs;
-  private byte[] bitVector;
-  private Double avgColLen;
-  private Long maxColLen;
-  private Long numTrues;
-  private Long numFalses;
-  private long lastAnalyzed;
-
-  public MPartitionColumnStatistics() {}
-
-  public String getTableName() {
-    return tableName;
-  }
-
-  public void setTableName(String tableName) {
-    this.tableName = tableName;
-  }
-
-  public String getColName() {
-    return colName;
-  }
-
-  public void setColName(String colName) {
-    this.colName = colName;
-  }
-
-  public Long getNumNulls() {
-    return numNulls;
-  }
-
-  public void setNumNulls(long numNulls) {
-    this.numNulls = numNulls;
-  }
-
-  public Long getNumDVs() {
-    return numDVs;
-  }
-
-  public void setNumDVs(long numDVs) {
-    this.numDVs = numDVs;
-  }
-
-  public Double getAvgColLen() {
-    return avgColLen;
-  }
-
-  public void setAvgColLen(double avgColLen) {
-    this.avgColLen = avgColLen;
-  }
-
-  public Long getMaxColLen() {
-    return maxColLen;
-  }
-
-  public void setMaxColLen(long maxColLen) {
-    this.maxColLen = maxColLen;
-  }
-
-  public Long getNumTrues() {
-    return numTrues;
-  }
-
-  public void setNumTrues(long numTrues) {
-    this.numTrues = numTrues;
-  }
-
-  public Long getNumFalses() {
-    return numFalses;
-  }
-
-  public void setNumFalses(long numFalses) {
-    this.numFalses = numFalses;
-  }
-
-  public long getLastAnalyzed() {
-    return lastAnalyzed;
-  }
-
-  public void setLastAnalyzed(long lastAnalyzed) {
-    this.lastAnalyzed = lastAnalyzed;
-  }
-
-  public String getDbName() {
-    return dbName;
-  }
-
-  public void setDbName(String dbName) {
-    this.dbName = dbName;
-  }
-
-  public String getCatName() {
-    return catName;
-  }
-
-  public void setCatName(String catName) {
-    this.catName = catName;
-  }
-
-  public MPartition getPartition() {
-    return partition;
-  }
-
-  public void setPartition(MPartition partition) {
-    this.partition = partition;
-  }
-
-  public String getPartitionName() {
-    return partitionName;
-  }
-
-  public void setPartitionName(String partitionName) {
-    this.partitionName = partitionName;
-  }
-
-  public String getColType() {
-    return colType;
-  }
-
-  public void setColType(String colType) {
-    this.colType = colType;
-  }
-
-  public void setBooleanStats(Long numTrues, Long numFalses, Long numNulls) {
-    this.numTrues = numTrues;
-    this.numFalses = numFalses;
-    this.numNulls = numNulls;
-  }
-
-  public void setLongStats(Long numNulls, Long numNDVs, byte[] bitVector, Long lowValue, Long highValue) {
-    this.numNulls = numNulls;
-    this.numDVs = numNDVs;
-    this.bitVector = bitVector;
-    this.longLowValue = lowValue;
-    this.longHighValue = highValue;
-  }
-
-  public void setDoubleStats(Long numNulls, Long numNDVs, byte[] bitVector, Double lowValue, Double highValue) {
-    this.numNulls = numNulls;
-    this.numDVs = numNDVs;
-    this.bitVector = bitVector;
-    this.doubleLowValue = lowValue;
-    this.doubleHighValue = highValue;
-  }
-
-  public void setDecimalStats(
-      Long numNulls, Long numNDVs, byte[] bitVector, String lowValue, String highValue) {
-    this.numNulls = numNulls;
-    this.numDVs = numNDVs;
-    this.bitVector = bitVector;
-    this.decimalLowValue = lowValue;
-    this.decimalHighValue = highValue;
-  }
-
-  public void setStringStats(Long numNulls, Long numNDVs, byte[] bitVector, Long maxColLen, Double avgColLen) {
-    this.numNulls = numNulls;
-    this.numDVs = numNDVs;
-    this.bitVector = bitVector;
-    this.maxColLen = maxColLen;
-    this.avgColLen = avgColLen;
-  }
-
-  public void setBinaryStats(Long numNulls, Long maxColLen, Double avgColLen) {
-    this.numNulls = numNulls;
-    this.maxColLen = maxColLen;
-    this.avgColLen = avgColLen;
-  }
-
-  public void setDateStats(Long numNulls, Long numNDVs, byte[] bitVector, Long lowValue, Long highValue) {
-    this.numNulls = numNulls;
-    this.numDVs = numNDVs;
-    this.bitVector = bitVector;
-    this.longLowValue = lowValue;
-    this.longHighValue = highValue;
-  }
-
-  public Long getLongLowValue() {
-    return longLowValue;
-  }
-
-  public void setLongLowValue(Long longLowValue) {
-    this.longLowValue = longLowValue;
-  }
-
-  public Long getLongHighValue() {
-    return longHighValue;
-  }
-
-  public void setLongHighValue(Long longHighValue) {
-    this.longHighValue = longHighValue;
-  }
-
-  public Double getDoubleLowValue() {
-    return doubleLowValue;
-  }
-
-  public void setDoubleLowValue(Double doubleLowValue) {
-    this.doubleLowValue = doubleLowValue;
-  }
-
-  public Double getDoubleHighValue() {
-    return doubleHighValue;
-  }
-
-  public void setDoubleHighValue(Double doubleHighValue) {
-    this.doubleHighValue = doubleHighValue;
-  }
-
-  public String getDecimalLowValue() {
-    return decimalLowValue;
-  }
-
-  public void setDecimalLowValue(String decimalLowValue) {
-    this.decimalLowValue = decimalLowValue;
-  }
-
-  public String getDecimalHighValue() {
-    return decimalHighValue;
-  }
-
-  public void setDecimalHighValue(String decimalHighValue) {
-    this.decimalHighValue = decimalHighValue;
-  }
-
-  public byte[] getBitVector() {
-    return bitVector;
-  }
-
-  public void setBitVector(byte[] bitVector) {
-    this.bitVector = bitVector;
-  }
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPartitionEvent.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPartitionEvent.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPartitionEvent.java
deleted file mode 100644
index d0cc51a..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPartitionEvent.java
+++ /dev/null
@@ -1,97 +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.hadoop.hive.metastore.model;
-
-
-public class MPartitionEvent {
-
-  private String catalogName;
-
-  private String dbName;
-
-  private String tblName;
-
-  private String partName;
-
-  private long eventTime;
-
-  private int eventType;
-
-  public MPartitionEvent(String catName, String dbName, String tblName, String partitionName, int eventType) {
-    super();
-    this.catalogName = catName;
-    this.dbName = dbName;
-    this.tblName = tblName;
-    this.partName = partitionName;
-    this.eventType = eventType;
-    this.eventTime = System.currentTimeMillis();
-  }
-
-  public MPartitionEvent() {}
-
-  public void setCatalogName(String catName) {
-    this.catalogName = catName;
-  }
-
-  /**
-   * @param dbName the dbName to set
-   */
-  public void setDbName(String dbName) {
-    this.dbName = dbName;
-  }
-
-  /**
-   * @param tblName the tblName to set
-   */
-  public void setTblName(String tblName) {
-    this.tblName = tblName;
-  }
-
-  /**
-   * @param partName the partSpec to set
-   */
-  public void setPartName(String partName) {
-    this.partName = partName;
-  }
-
-  /**
-   * @param createTime the eventTime to set
-   */
-  public void setEventTime(long createTime) {
-    this.eventTime = createTime;
-  }
-
-  /**
-   * @param eventType the EventType to set
-   */
-  public void setEventType(int eventType) {
-    this.eventType = eventType;
-  }
-
-  /* (non-Javadoc)
-   * @see java.lang.Object#toString()
-   */
-  @Override
-  public String toString() {
-    return "MPartitionEvent [dbName=" + dbName + ", tblName=" + tblName + ", partName=" + partName
-        + ", eventTime=" + eventTime + ", EventType=" + eventType + "]";
-  }
-
-
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPartitionPrivilege.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPartitionPrivilege.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPartitionPrivilege.java
deleted file mode 100644
index b2ec5e1..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPartitionPrivilege.java
+++ /dev/null
@@ -1,149 +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.hadoop.hive.metastore.model;
-
-public class MPartitionPrivilege {
-
-  private String principalName;
-
-  private String principalType;
-
-  private MPartition partition;
-
-  private String privilege;
-
-  private int createTime;
-
-  private String grantor;
-
-  private String grantorType;
-
-  private boolean grantOption;
-
-  private String authorizer;
-
-  public MPartitionPrivilege() {
-  }
-
-  public MPartitionPrivilege(String principalName, String principalType,
-      MPartition partition, String privilege, int createTime,
-      String grantor, String grantorType, boolean grantOption, String authorizer) {
-    super();
-    this.principalName = principalName;
-    this.principalType = principalType;
-    this.partition = partition;
-    this.privilege = privilege;
-    this.createTime = createTime;
-    this.grantor = grantor;
-    this.grantorType = grantorType;
-    this.grantOption = grantOption;
-    this.authorizer = authorizer;
-  }
-
-  public String getPrincipalName() {
-    return principalName;
-  }
-
-  public void setPrincipalName(String principalName) {
-    this.principalName = principalName;
-  }
-
-
-  /**
-   * @return a set of privileges this user/role/group has
-   */
-  public String getPrivilege() {
-    return privilege;
-  }
-
-  /**
-   * @param dbPrivilege a set of privileges this user/role/group has
-   */
-  public void setPrivilege(String dbPrivilege) {
-    this.privilege = dbPrivilege;
-  }
-
-  /**
-   * @return create time
-   */
-  public int getCreateTime() {
-    return createTime;
-  }
-
-  /**
-   * @param createTime create time
-   */
-  public void setCreateTime(int createTime) {
-    this.createTime = createTime;
-  }
-
-  /**
-   * @return the grantor
-   */
-  public String getGrantor() {
-    return grantor;
-  }
-
-  /**
-   * @param grantor
-   */
-  public void setGrantor(String grantor) {
-    this.grantor = grantor;
-  }
-
-  public String getPrincipalType() {
-    return principalType;
-  }
-
-  public void setPrincipalType(String principalType) {
-    this.principalType = principalType;
-  }
-
-  public MPartition getPartition() {
-    return partition;
-  }
-
-  public void setPartition(MPartition partition) {
-    this.partition = partition;
-  }
-
-  public boolean getGrantOption() {
-    return grantOption;
-  }
-
-  public void setGrantOption(boolean grantOption) {
-    this.grantOption = grantOption;
-  }
-
-  public String getGrantorType() {
-    return grantorType;
-  }
-
-  public void setGrantorType(String grantorType) {
-    this.grantorType = grantorType;
-  }
-
-  public String getAuthorizer() {
-    return authorizer;
-  }
-
-  public void setAuthorizer(String authorizer) {
-    this.authorizer = authorizer;
-  }
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPrincipalDesc.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPrincipalDesc.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPrincipalDesc.java
deleted file mode 100644
index 8e3cf7f..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MPrincipalDesc.java
+++ /dev/null
@@ -1,59 +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.hadoop.hive.metastore.model;
-
-public class MPrincipalDesc {
-
-  private String name;
-  private String type;
-
-  public MPrincipalDesc() {}
-
-  public MPrincipalDesc(String name, String type) {
-    this.name = name;
-    this.type = type;
-  }
-
-  public String getName() {
-    return name;
-  }
-
-  public void setName(String name) {
-    this.name = name;
-  }
-
-  public String getType() {
-    return type;
-  }
-
-  public void setType(String type) {
-    this.type = type;
-  }
-
-  @Override
-  public int hashCode() {
-    return type.hashCode() + name.hashCode();
-  }
-
-  @Override
-  public boolean equals(Object object) {
-    MPrincipalDesc another = (MPrincipalDesc) object;
-    return type.equals(another.type) && name.equals(another.name);
-  }
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MResourceUri.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MResourceUri.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MResourceUri.java
deleted file mode 100644
index 3a7b142..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MResourceUri.java
+++ /dev/null
@@ -1,49 +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.hadoop.hive.metastore.model;
-
-public class MResourceUri {
-  private int resourceType;
-  private String uri;
-
-  public MResourceUri() {
-  }
-
-  public MResourceUri(int resourceType, String uri) {
-    super();
-    this.resourceType = resourceType;
-    this.uri = uri;
-  }
-
-  public int getResourceType() {
-    return resourceType;
-  }
-
-  public void setResourceType(int resourceType) {
-    this.resourceType = resourceType;
-  }
-
-  public String getUri() {
-    return uri;
-  }
-
-  public void setUri(String uri) {
-    this.uri = uri;
-  }
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MRole.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MRole.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MRole.java
deleted file mode 100644
index 54951bd..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MRole.java
+++ /dev/null
@@ -1,80 +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.hadoop.hive.metastore.model;
-
-public class MRole {
-
-  private String roleName;
-
-  private int createTime;
-
-  private String ownerName;
-
-  public MRole() {
-  }
-
-  public MRole(String roleName, int createTime, String ownerName) {
-    super();
-    this.roleName = roleName;
-    this.createTime = createTime;
-    this.ownerName = ownerName;
-  }
-
-  /**
-   * @return role name
-   */
-  public String getRoleName() {
-    return roleName;
-  }
-
-  /**
-   * @param roleName
-   */
-  public void setRoleName(String roleName) {
-    this.roleName = roleName;
-  }
-
-  /**
-   * @return create time
-   */
-  public int getCreateTime() {
-    return createTime;
-  }
-
-  /**
-   * @param createTime
-   *          role create time
-   */
-  public void setCreateTime(int createTime) {
-    this.createTime = createTime;
-  }
-
-  /**
-   * @return the principal name who created this role
-   */
-  public String getOwnerName() {
-    return ownerName;
-  }
-
-  public void setOwnerName(String ownerName) {
-    this.ownerName = ownerName;
-  }
-
-}
-

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MRoleMap.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MRoleMap.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MRoleMap.java
deleted file mode 100644
index 8efcb78..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MRoleMap.java
+++ /dev/null
@@ -1,120 +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.hadoop.hive.metastore.model;
-
-public class MRoleMap {
-  
-  private String principalName;
-  
-  private String principalType;
-  
-  private MRole role;
-  
-  private int addTime;
-  
-  private String grantor;
-  
-  private String grantorType;
-  
-  private boolean grantOption;
-
-  public MRoleMap() {
-  }
-  
-  public MRoleMap(String principalName, String principalType, MRole role,
-      int addTime, String grantor, String grantorType, boolean grantOption) {
-    super();
-    this.principalName = principalName;
-    this.principalType = principalType;
-    this.role = role;
-    this.addTime = addTime;
-    this.grantor = grantor;
-    this.grantorType = grantorType;
-    this.grantOption = grantOption;
-  }
-
-  /**
-   * @return principal name
-   */
-  public String getPrincipalName() {
-    return principalName;
-  }
-
-  /**
-   * @param userName principal name
-   */
-  public void setPrincipalName(String userName) {
-    this.principalName = userName;
-  }
-
-  public String getPrincipalType() {
-    return principalType;
-  }
-
-  public void setPrincipalType(String principalType) {
-    this.principalType = principalType;
-  }
-
-  /**
-   * @return add time
-   */
-  public int getAddTime() {
-    return addTime;
-  }
-
-  /**
-   * @param addTime
-   */
-  public void setAddTime(int addTime) {
-    this.addTime = addTime;
-  }
-
-  public MRole getRole() {
-    return role;
-  }
-
-  public void setRole(MRole role) {
-    this.role = role;
-  }
-  
-  public boolean getGrantOption() {
-    return grantOption;
-  }
-
-  public void setGrantOption(boolean grantOption) {
-    this.grantOption = grantOption;
-  }
-  
-  public String getGrantor() {
-    return grantor;
-  }
-
-  public void setGrantor(String grantor) {
-    this.grantor = grantor;
-  }
-
-  public String getGrantorType() {
-    return grantorType;
-  }
-
-  public void setGrantorType(String grantorType) {
-    this.grantorType = grantorType;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MRuntimeStat.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MRuntimeStat.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MRuntimeStat.java
deleted file mode 100644
index 054ce7c..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MRuntimeStat.java
+++ /dev/null
@@ -1,59 +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.hadoop.hive.metastore.model;
-
-import org.apache.hadoop.hive.metastore.api.RuntimeStat;
-
-/**
- * Represents a runtime stat query entry.
- *
- * As a query may contain a large number of operatorstat entries; they are stored together in a single row in the metastore.
- * The number of operator stat entries this entity has; is shown in the weight column.
- */
-public class MRuntimeStat {
-
-  private int createTime;
-  private int weight;
-  private byte[] payload;
-
-  public static MRuntimeStat fromThrift(RuntimeStat stat) {
-    MRuntimeStat ret = new MRuntimeStat();
-    ret.weight = stat.getWeight();
-    ret.payload = stat.getPayload();
-    ret.createTime = (int) (System.currentTimeMillis() / 1000);
-    return ret;
-  }
-
-  public static RuntimeStat toThrift(MRuntimeStat stat) {
-    RuntimeStat ret = new RuntimeStat();
-    ret.setWeight(stat.weight);
-    ret.setCreateTime(stat.createTime);
-    ret.setPayload(stat.payload);
-    return ret;
-  }
-
-  public int getWeight() {
-    return weight;
-  }
-
-  public int getCreatedTime() {
-    return createTime;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MSchemaVersion.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MSchemaVersion.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MSchemaVersion.java
deleted file mode 100644
index 7c8a6d4..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MSchemaVersion.java
+++ /dev/null
@@ -1,127 +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
- * <p>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p>
- * 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.hadoop.hive.metastore.model;
-
-public class MSchemaVersion {
-  private MISchema iSchema;
-  private int version;
-  private long createdAt;
-  private MColumnDescriptor cols;
-  private int state;
-  private String description;
-  private String schemaText;
-  private String fingerprint;
-  private String name;
-  private MSerDeInfo serDe;
-
-  public MSchemaVersion(MISchema iSchema, int version, long createdAt,
-                        MColumnDescriptor cols, int state, String description,
-                        String schemaText, String fingerprint, String name,
-                        MSerDeInfo serDe) {
-    this.iSchema = iSchema;
-    this.version = version;
-    this.createdAt = createdAt;
-    this.cols = cols;
-    this.state = state;
-    this.description = description;
-    this.schemaText = schemaText;
-    this.fingerprint = fingerprint;
-    this.name = name;
-    this.serDe = serDe;
-  }
-
-  public MISchema getiSchema() {
-    return iSchema;
-  }
-
-  public void setiSchema(MISchema iSchema) {
-    this.iSchema = iSchema;
-  }
-
-  public int getVersion() {
-    return version;
-  }
-
-  public void setVersion(int version) {
-    this.version = version;
-  }
-
-  public long getCreatedAt() {
-    return createdAt;
-  }
-
-  public void setCreatedAt(long createdAt) {
-    this.createdAt = createdAt;
-  }
-
-  public MColumnDescriptor getCols() {
-    return cols;
-  }
-
-  public void setCols(MColumnDescriptor cols) {
-    this.cols = cols;
-  }
-
-  public int getState() {
-    return state;
-  }
-
-  public void setState(int state) {
-    this.state = state;
-  }
-
-  public String getDescription() {
-    return description;
-  }
-
-  public void setDescription(String description) {
-    this.description = description;
-  }
-
-  public String getSchemaText() {
-    return schemaText;
-  }
-
-  public void setSchemaText(String schemaText) {
-    this.schemaText = schemaText;
-  }
-
-  public String getFingerprint() {
-    return fingerprint;
-  }
-
-  public void setFingerprint(String fingerprint) {
-    this.fingerprint = fingerprint;
-  }
-
-  public String getName() {
-    return name;
-  }
-
-  public void setName(String name) {
-    this.name = name;
-  }
-
-  public MSerDeInfo getSerDe() {
-    return serDe;
-  }
-
-  public void setSerDe(MSerDeInfo serDe) {
-    this.serDe = serDe;
-  }
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MSerDeInfo.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MSerDeInfo.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MSerDeInfo.java
deleted file mode 100644
index 68f07e2..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MSerDeInfo.java
+++ /dev/null
@@ -1,127 +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.hadoop.hive.metastore.model;
-
-import java.util.Map;
-
-public class MSerDeInfo {
-  private String name;
-  private String serializationLib;
-  private Map<String, String> parameters;
-  private String description;
-  private String serializerClass;
-  private String deserializerClass;
-  private int serdeType;
-
-  /**
-   *
-   * @param name
-   * @param serializationLib
-   * @param parameters
-   * @param description
-   * @param serializerClass
-   * @param deserializerClass
-   * @param serdeType
-   */
-  public MSerDeInfo(String name, String serializationLib, Map<String, String> parameters,
-                    String description, String serializerClass, String deserializerClass,
-                    int serdeType) {
-    this.name = name;
-    this.serializationLib = serializationLib;
-    this.parameters = parameters;
-    this.description = description;
-    this.serializerClass = serializerClass;
-    this.deserializerClass = deserializerClass;
-    this.serdeType = serdeType;
-  }
-
-  /**
-   * @return the serializationLib
-   */
-  public String getSerializationLib() {
-    return serializationLib;
-  }
-
-  /**
-   * @param serializationLib the serializationLib to set
-   */
-  public void setSerializationLib(String serializationLib) {
-    this.serializationLib = serializationLib;
-  }
-
-  /**
-   * @return the name
-   */
-  public String getName() {
-    return name;
-  }
-
-  /**
-   * @param name the name to set
-   */
-  public void setName(String name) {
-    this.name = name;
-  }
-
-  /**
-   * @return the parameters
-   */
-  public Map<String, String> getParameters() {
-    return parameters;
-  }
-
-  /**
-   * @param parameters the parameters to set
-   */
-  public void setParameters(Map<String, String> parameters) {
-    this.parameters = parameters;
-  }
-
-  public String getDescription() {
-    return description;
-  }
-
-  public void setDescription(String description) {
-    this.description = description;
-  }
-
-  public String getSerializerClass() {
-    return serializerClass;
-  }
-
-  public void setSerializerClass(String serializerClass) {
-    this.serializerClass = serializerClass;
-  }
-
-  public String getDeserializerClass() {
-    return deserializerClass;
-  }
-
-  public void setDeserializerClass(String deserializerClass) {
-    this.deserializerClass = deserializerClass;
-  }
-
-  public int getSerdeType() {
-    return serdeType;
-  }
-
-  public void setSerdeType(int serdeType) {
-    this.serdeType = serdeType;
-  }
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MStorageDescriptor.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MStorageDescriptor.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MStorageDescriptor.java
deleted file mode 100644
index 4c6ce00..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MStorageDescriptor.java
+++ /dev/null
@@ -1,277 +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.hadoop.hive.metastore.model;
-
-import java.util.List;
-import java.util.Map;
-
-public class MStorageDescriptor {
-  private MColumnDescriptor cd;
-  private String location;
-  private String inputFormat;
-  private String outputFormat;
-  private boolean isCompressed = false;
-  private int numBuckets = 1;
-  private MSerDeInfo serDeInfo;
-  private List<String> bucketCols;
-  private List<MOrder> sortCols;
-  private Map<String, String> parameters;
-  private List<String> skewedColNames;
-  private List<MStringList> skewedColValues;
-  private Map<MStringList, String> skewedColValueLocationMaps;
-  private boolean isStoredAsSubDirectories;
-
-  public MStorageDescriptor() {}
-
-
-  /**
-   * @param cd
-   * @param location
-   * @param inputFormat
-   * @param outputFormat
-   * @param isCompressed
-   * @param numBuckets
-   * @param serDeInfo
-   * @param bucketCols
-   * @param sortOrder
-   * @param parameters
-   */
-  public MStorageDescriptor(MColumnDescriptor cd, String location, String inputFormat,
-      String outputFormat, boolean isCompressed, int numBuckets, MSerDeInfo serDeInfo,
-      List<String> bucketCols, List<MOrder> sortOrder, Map<String, String> parameters,
-      List<String> skewedColNames, List<MStringList> skewedColValues,
-      Map<MStringList, String> skewedColValueLocationMaps, boolean storedAsSubDirectories) {
-    this.cd = cd;
-    this.location = location;
-    this.inputFormat = inputFormat;
-    this.outputFormat = outputFormat;
-    this.isCompressed = isCompressed;
-    this.numBuckets = numBuckets;
-    this.serDeInfo = serDeInfo;
-    this.bucketCols = bucketCols;
-    this.sortCols = sortOrder;
-    this.parameters = parameters;
-    this.skewedColNames = skewedColNames;
-    this.skewedColValues = skewedColValues;
-    this.skewedColValueLocationMaps = skewedColValueLocationMaps;
-    this.isStoredAsSubDirectories = storedAsSubDirectories;
-  }
-
-
-  /**
-   * @return the location
-   */
-  public String getLocation() {
-    return location;
-  }
-
-  /**
-   * @param location the location to set
-   */
-  public void setLocation(String location) {
-    this.location = location;
-  }
-
-  /**
-   * @return the isCompressed
-   */
-  public boolean isCompressed() {
-    return isCompressed;
-  }
-
-  /**
-   * @param isCompressed the isCompressed to set
-   */
-  public void setCompressed(boolean isCompressed) {
-    this.isCompressed = isCompressed;
-  }
-
-  /**
-   * @return the numBuckets
-   */
-  public int getNumBuckets() {
-    return numBuckets;
-  }
-
-  /**
-   * @param numBuckets the numBuckets to set
-   */
-  public void setNumBuckets(int numBuckets) {
-    this.numBuckets = numBuckets;
-  }
-
-  /**
-   * @return the bucketCols
-   */
-  public List<String> getBucketCols() {
-    return bucketCols;
-  }
-
-  /**
-   * @param bucketCols the bucketCols to set
-   */
-  public void setBucketCols(List<String> bucketCols) {
-    this.bucketCols = bucketCols;
-  }
-
-  /**
-   * @return the parameters
-   */
-  public Map<String, String> getParameters() {
-    return parameters;
-  }
-
-  /**
-   * @param parameters the parameters to set
-   */
-  public void setParameters(Map<String, String> parameters) {
-    this.parameters = parameters;
-  }
-
-  /**
-   * @return the inputFormat
-   */
-  public String getInputFormat() {
-    return inputFormat;
-  }
-
-  /**
-   * @param inputFormat the inputFormat to set
-   */
-  public void setInputFormat(String inputFormat) {
-    this.inputFormat = inputFormat;
-  }
-
-  /**
-   * @return the outputFormat
-   */
-  public String getOutputFormat() {
-    return outputFormat;
-  }
-
-  /**
-   * @param outputFormat the outputFormat to set
-   */
-  public void setOutputFormat(String outputFormat) {
-    this.outputFormat = outputFormat;
-  }
-
-  /**
-   * @return the column descriptor
-   */
-  public MColumnDescriptor getCD() {
-    return cd;
-  }
-
-  /**
-   * @param cd the Column Descriptor to set
-   */
-  public void setCD(MColumnDescriptor cd) {
-    this.cd = cd;
-  }
-
-  /**
-   * @return the serDe
-   */
-  public MSerDeInfo getSerDeInfo() {
-    return serDeInfo;
-  }
-
-  /**
-   * @param serDe the serDe to set
-   */
-  public void setSerDeInfo(MSerDeInfo serDe) {
-    this.serDeInfo = serDe;
-  }
-
-
-  /**
-   * @param sortOrder the sortOrder to set
-   */
-  public void setSortCols(List<MOrder> sortOrder) {
-    this.sortCols = sortOrder;
-  }
-
-
-  /**
-   * @return the sortOrder
-   */
-  public List<MOrder> getSortCols() {
-    return sortCols;
-  }
-
-  /**
-   * @return the skewedColNames
-   */
-  public List<String> getSkewedColNames() {
-    return skewedColNames;
-  }
-
-  /**
-   * @param skewedColNames the skewedColNames to set
-   */
-  public void setSkewedColNames(List<String> skewedColNames) {
-    this.skewedColNames = skewedColNames;
-  }
-
-  /**
-   * @return the skewedColValues
-   */
-  public List<MStringList> getSkewedColValues() {
-    return skewedColValues;
-  }
-
-  /**
-   * @param skewedColValues the skewedColValues to set
-   */
-  public void setSkewedColValues(List<MStringList> skewedColValues) {
-    this.skewedColValues = skewedColValues;
-  }
-
-  /**
-   * @return the skewedColValueLocationMaps
-   */
-  public Map<MStringList, String> getSkewedColValueLocationMaps() {
-    return skewedColValueLocationMaps;
-  }
-
-  /**
-   * @param listBucketColValuesMapping the skewedColValueLocationMaps to set
-   */
-  public void setSkewedColValueLocationMaps(Map<MStringList, String> listBucketColValuesMapping) {
-    this.skewedColValueLocationMaps = listBucketColValuesMapping;
-  }
-
-
-  /**
-   * @return the storedAsSubDirectories
-   */
-  public boolean isStoredAsSubDirectories() {
-    return isStoredAsSubDirectories;
-  }
-
-
-  /**
-   * @param storedAsSubDirectories the storedAsSubDirectories to set
-   */
-  public void setStoredAsSubDirectories(boolean storedAsSubDirectories) {
-    this.isStoredAsSubDirectories = storedAsSubDirectories;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MStringList.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MStringList.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MStringList.java
deleted file mode 100644
index 66bd5d3..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MStringList.java
+++ /dev/null
@@ -1,62 +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.hadoop.hive.metastore.model;
-
-import java.util.List;
-
-/**
- *
- * It represents data structure of string list.
- *
- * workaround JDO limitation: no support for collection of collection.
- *
- */
-public class MStringList {
-  private List<String> internalList;
-
-  /**
-   *
-   * @param list
-   */
-  public MStringList(List<String> list) {
-    this.internalList = list;
-  }
-
-  /**
-   * @return the internalList
-   */
-  public List<String> getInternalList() {
-    return internalList;
-  }
-
-  /**
-   * @param internalList the internalList to set
-   */
-  public void setInternalList(List<String> internalList) {
-    this.internalList = internalList;
-  }
-
-  /* (non-Javadoc)
-   * @see java.lang.Object#toString()
-   */
-  @Override
-  public String toString() {
-    return  internalList.toString();
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTable.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTable.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTable.java
deleted file mode 100644
index 38ad479..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTable.java
+++ /dev/null
@@ -1,273 +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.hadoop.hive.metastore.model;
-
-import java.util.List;
-import java.util.Map;
-
-public class MTable {
-  
-  private String tableName;
-  private MDatabase database;
-  private MStorageDescriptor sd;
-  private String owner;
-  private String ownerType;
-  private int createTime;
-  private int lastAccessTime;
-  private int retention;
-  private List<MFieldSchema> partitionKeys;
-  private Map<String, String> parameters;
-  private String viewOriginalText;
-  private String viewExpandedText;
-  private boolean rewriteEnabled;
-  private String tableType;
-
-  public MTable() {}
-
-  /**
-   * @param tableName
-   * @param database
-   * @param sd
-   * @param owner
-   * @param ownerType
-   * @param createTime
-   * @param lastAccessTime
-   * @param retention
-   * @param partitionKeys
-   * @param parameters
-   * @param viewOriginalText
-   * @param viewExpandedText
-   * @param tableType
-   */
-  public MTable(String tableName, MDatabase database, MStorageDescriptor sd, String owner, String ownerType,
-      int createTime, int lastAccessTime, int retention, List<MFieldSchema> partitionKeys,
-      Map<String, String> parameters, String viewOriginalText, String viewExpandedText,
-      boolean rewriteEnabled, String tableType) {
-    this.tableName = tableName;
-    this.database = database;
-    this.sd = sd;
-    this.owner = owner;
-    this.ownerType = ownerType;
-    this.createTime = createTime;
-    this.setLastAccessTime(lastAccessTime);
-    this.retention = retention;
-    this.partitionKeys = partitionKeys;
-    this.parameters = parameters;
-    this.viewOriginalText = viewOriginalText;
-    this.viewExpandedText = viewExpandedText;
-    this.rewriteEnabled = rewriteEnabled;
-    this.tableType = tableType;
-  }
-
-  /**
-   * @return the tableName
-   */
-  public String getTableName() {
-    return tableName;
-  }
-
-  /**
-   * @param tableName the tableName to set
-   */
-  public void setTableName(String tableName) {
-    this.tableName = tableName;
-  }
-
-  /**
-   * @return the sd
-   */
-  public MStorageDescriptor getSd() {
-    return sd;
-  }
-
-  /**
-   * @param sd the sd to set
-   */
-  public void setSd(MStorageDescriptor sd) {
-    this.sd = sd;
-  }
-
-  /**
-   * @return the partKeys
-   */
-  public List<MFieldSchema> getPartitionKeys() {
-    return partitionKeys;
-  }
-
-  /**
-   * @param partKeys the partKeys to set
-   */
-  public void setPartitionKeys(List<MFieldSchema> partKeys) {
-    this.partitionKeys = partKeys;
-  }
-
-  /**
-   * @return the parameters
-   */
-  public Map<String, String> getParameters() {
-    return parameters;
-  }
-
-  /**
-   * @param parameters the parameters to set
-   */
-  public void setParameters(Map<String, String> parameters) {
-    this.parameters = parameters;
-  }
-
-  /**
-   * @return the original view text, or null if this table is not a view
-   */
-  public String getViewOriginalText() {
-    return viewOriginalText;
-  }
-
-  /**
-   * @param viewOriginalText the original view text to set
-   */
-  public void setViewOriginalText(String viewOriginalText) {
-    this.viewOriginalText = viewOriginalText;
-  }
-
-  /**
-   * @return the expanded view text, or null if this table is not a view
-   */
-  public String getViewExpandedText() {
-    return viewExpandedText;
-  }
-
-  /**
-   * @param viewExpandedText the expanded view text to set
-   */
-  public void setViewExpandedText(String viewExpandedText) {
-    this.viewExpandedText = viewExpandedText;
-  }
-
-  /**
-   * @return whether the view can be used for rewriting queries
-   */
-  public boolean isRewriteEnabled() {
-    return rewriteEnabled;
-  }
-
-  /**
-   * @param rewriteEnabled whether the view can be used for rewriting queries
-   */
-  public void setRewriteEnabled(boolean rewriteEnabled) {
-    this.rewriteEnabled = rewriteEnabled;
-  }
-
-  /**
-   * @return the owner
-   */
-  public String getOwner() {
-    return owner;
-  }
-
-  /**
-   * @param owner the owner to set
-   */
-  public void setOwner(String owner) {
-    this.owner = owner;
-  }
-
-  /**
-   * @return the owner type
-   */
-  public String getOwnerType() {
-    return ownerType;
-  }
-
-  /**
-   * @param ownerType the owner type to set
-   */
-  public void setOwnerType(String ownerType) {
-    this.ownerType = ownerType;
-  }
-
-  /**
-   * @return the createTime
-   */
-  public int getCreateTime() {
-    return createTime;
-  }
-
-  /**
-   * @param createTime the createTime to set
-   */
-  public void setCreateTime(int createTime) {
-    this.createTime = createTime;
-  }
-
-  /**
-   * @return the database
-   */
-  public MDatabase getDatabase() {
-    return database;
-  }
-
-  /**
-   * @param database the database to set
-   */
-  public void setDatabase(MDatabase database) {
-    this.database = database;
-  }
-
-  /**
-   * @return the retention
-   */
-  public int getRetention() {
-    return retention;
-  }
-
-  /**
-   * @param retention the retention to set
-   */
-  public void setRetention(int retention) {
-    this.retention = retention;
-  }
-
-  /**
-   * @param lastAccessTime the lastAccessTime to set
-   */
-  public void setLastAccessTime(int lastAccessTime) {
-    this.lastAccessTime = lastAccessTime;
-  }
-
-  /**
-   * @return the lastAccessTime
-   */
-  public int getLastAccessTime() {
-    return lastAccessTime;
-  }
-
-  /**
-   * @param tableType the tableType to set
-   */
-  public void setTableType(String tableType) {
-    this.tableType = tableType;
-  }
-
-  /**
-   * @return the tableType
-   */
-  public String getTableType() {
-    return tableType;
-  }
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTableColumnPrivilege.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTableColumnPrivilege.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTableColumnPrivilege.java
deleted file mode 100644
index e2cc0f1..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTableColumnPrivilege.java
+++ /dev/null
@@ -1,170 +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.hadoop.hive.metastore.model;
-
-public class MTableColumnPrivilege {
-
-  private String principalName;
-
-  private String principalType;
-
-  private MTable table;
-
-  private String columnName;
-
-  private String privilege;
-
-  private int createTime;
-
-  private String grantor;
-
-  private String grantorType;
-
-  private boolean grantOption;
-
-  private String authorizer;
-
-  public MTableColumnPrivilege() {
-  }
-
-  /**
-   * @param principalName
-   * @param principalType
-   * @param table
-   * @param columnName
-   * @param privileges
-   * @param createTime
-   * @param grantor
-   * @param grantorType
-   * @param grantOption
-   */
-  public MTableColumnPrivilege(String principalName, String principalType,
-      MTable table, String columnName, String privileges, int createTime,
-      String grantor, String grantorType, boolean grantOption, String authorizer) {
-    super();
-    this.principalName = principalName;
-    this.principalType = principalType;
-    this.table = table;
-    this.columnName = columnName;
-    this.privilege = privileges;
-    this.createTime = createTime;
-    this.grantor = grantor;
-    this.grantorType = grantorType;
-    this.grantOption = grantOption;
-    this.authorizer = authorizer;
-  }
-
-  /**
-   * @return column name
-   */
-  public String getColumnName() {
-    return columnName;
-  }
-
-  /**
-   * @param columnName column name
-   */
-  public void setColumnName(String columnName) {
-    this.columnName = columnName;
-  }
-
-  /**
-   * @return a set of privileges this user/role/group has
-   */
-  public String getPrivilege() {
-    return privilege;
-  }
-
-  /**
-   * @param dbPrivileges a set of privileges this user/role/group has
-   */
-  public void setPrivilege(String dbPrivileges) {
-    this.privilege = dbPrivileges;
-  }
-
-  /**
-   * @return create time
-   */
-  public int getCreateTime() {
-    return createTime;
-  }
-
-  /**
-   * @param createTime create time
-   */
-  public void setCreateTime(int createTime) {
-    this.createTime = createTime;
-  }
-
-  public String getPrincipalName() {
-    return principalName;
-  }
-
-  public void setPrincipalName(String principalName) {
-    this.principalName = principalName;
-  }
-
-  public MTable getTable() {
-    return table;
-  }
-
-  public void setTable(MTable table) {
-    this.table = table;
-  }
-
-  public String getGrantor() {
-    return grantor;
-  }
-
-  public void setGrantor(String grantor) {
-    this.grantor = grantor;
-  }
-
-  public String getGrantorType() {
-    return grantorType;
-  }
-
-  public void setGrantorType(String grantorType) {
-    this.grantorType = grantorType;
-  }
-
-  public boolean getGrantOption() {
-    return grantOption;
-  }
-
-  public void setGrantOption(boolean grantOption) {
-    this.grantOption = grantOption;
-  }
-
-  public String getPrincipalType() {
-    return principalType;
-  }
-
-  public void setPrincipalType(String principalType) {
-    this.principalType = principalType;
-  }
-
-  public String getAuthorizer() {
-    return authorizer;
-  }
-
-  public void setAuthorizer(String authorizer) {
-    this.authorizer = authorizer;
-  }
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTableColumnStatistics.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTableColumnStatistics.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTableColumnStatistics.java
deleted file mode 100644
index 731cd6f..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTableColumnStatistics.java
+++ /dev/null
@@ -1,272 +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.hadoop.hive.metastore.model;
-
-
-
-/**
- *
- * MTableColumnStatistics - Represents Hive's Column Statistics Description. The fields in this
- * class with the exception of table are persisted in the metastore. In case of table, tbl_id is
- * persisted in its place.
- *
- */
-public class MTableColumnStatistics {
-
-  private MTable table;
-  private String catName;
-  private String dbName;
-  private String tableName;
-  private String colName;
-  private String colType;
-
-  private Long longLowValue;
-  private Long longHighValue;
-  private Double doubleLowValue;
-  private Double doubleHighValue;
-  private String decimalLowValue;
-  private String decimalHighValue;
-  private Long numNulls;
-  private Long numDVs;
-  private byte[] bitVector;
-  private Double avgColLen;
-  private Long maxColLen;
-  private Long numTrues;
-  private Long numFalses;
-  private long lastAnalyzed;
-
-  public MTableColumnStatistics() {}
-
-  public MTable getTable() {
-    return table;
-  }
-
-  public void setTable(MTable table) {
-    this.table = table;
-  }
-
-  public String getTableName() {
-    return tableName;
-  }
-
-  public void setTableName(String tableName) {
-    this.tableName = tableName;
-  }
-
-  public String getColName() {
-    return colName;
-  }
-
-  public void setColName(String colName) {
-    this.colName = colName;
-  }
-
-  public String getColType() {
-    return colType;
-  }
-
-  public void setColType(String colType) {
-    this.colType = colType;
-  }
-
-  public Long getNumNulls() {
-    return numNulls;
-  }
-
-  public void setNumNulls(long numNulls) {
-    this.numNulls = numNulls;
-  }
-
-  public Long getNumDVs() {
-    return numDVs;
-  }
-
-  public void setNumDVs(long numDVs) {
-    this.numDVs = numDVs;
-  }
-
-  public Double getAvgColLen() {
-    return avgColLen;
-  }
-
-  public void setAvgColLen(double avgColLen) {
-    this.avgColLen = avgColLen;
-  }
-
-  public Long getMaxColLen() {
-    return maxColLen;
-  }
-
-  public void setMaxColLen(long maxColLen) {
-    this.maxColLen = maxColLen;
-  }
-
-  public Long getNumTrues() {
-    return numTrues;
-  }
-
-  public void setNumTrues(long numTrues) {
-    this.numTrues = numTrues;
-  }
-
-  public Long getNumFalses() {
-    return numFalses;
-  }
-
-  public void setNumFalses(long numFalses) {
-    this.numFalses = numFalses;
-  }
-
-  public long getLastAnalyzed() {
-    return lastAnalyzed;
-  }
-
-  public void setLastAnalyzed(long lastAnalyzed) {
-    this.lastAnalyzed = lastAnalyzed;
-  }
-
-  public String getDbName() {
-    return dbName;
-  }
-
-  public void setDbName(String dbName) {
-    this.dbName = dbName;
-  }
-
-  public String getCatName() {
-    return catName;
-  }
-
-  public void setCatName(String catName) {
-    this.catName = catName;
-  }
-
-  public void setBooleanStats(Long numTrues, Long numFalses, Long numNulls) {
-    this.numTrues = numTrues;
-    this.numFalses = numFalses;
-    this.numNulls = numNulls;
-  }
-
-  public void setLongStats(Long numNulls, Long numNDVs, byte[] bitVector, Long lowValue, Long highValue) {
-    this.numNulls = numNulls;
-    this.numDVs = numNDVs;
-    this.bitVector = bitVector;
-    this.longLowValue = lowValue;
-    this.longHighValue = highValue;
-  }
-
-  public void setDoubleStats(Long numNulls, Long numNDVs, byte[] bitVector, Double lowValue, Double highValue) {
-    this.numNulls = numNulls;
-    this.numDVs = numNDVs;
-    this.bitVector = bitVector;
-    this.doubleLowValue = lowValue;
-    this.doubleHighValue = highValue;
-  }
-
-  public void setDecimalStats(
-      Long numNulls, Long numNDVs, byte[] bitVector, String lowValue, String highValue) {
-    this.numNulls = numNulls;
-    this.numDVs = numNDVs;
-    this.bitVector = bitVector;
-    this.decimalLowValue = lowValue;
-    this.decimalHighValue = highValue;
-  }
-
-  public void setStringStats(Long numNulls, Long numNDVs, byte[] bitVector, Long maxColLen, Double avgColLen) {
-    this.numNulls = numNulls;
-    this.numDVs = numNDVs;
-    this.bitVector = bitVector;
-    this.maxColLen = maxColLen;
-    this.avgColLen = avgColLen;
-  }
-
-  public void setBinaryStats(Long numNulls, Long maxColLen, Double avgColLen) {
-    this.numNulls = numNulls;
-    this.maxColLen = maxColLen;
-    this.avgColLen = avgColLen;
-  }
-
-  public void setDateStats(Long numNulls, Long numNDVs, byte[] bitVector, Long lowValue, Long highValue) {
-    this.numNulls = numNulls;
-    this.numDVs = numNDVs;
-    this.bitVector = bitVector;
-    this.longLowValue = lowValue;
-    this.longHighValue = highValue;
-  }
-
-  public Long getLongLowValue() {
-    return longLowValue;
-  }
-
-  public void setLongLowValue(long longLowValue) {
-    this.longLowValue = longLowValue;
-  }
-
-  public Long getLongHighValue() {
-    return longHighValue;
-  }
-
-  public void setLongHighValue(long longHighValue) {
-    this.longHighValue = longHighValue;
-  }
-
-  public Double getDoubleLowValue() {
-    return doubleLowValue;
-  }
-
-  public void setDoubleLowValue(double doubleLowValue) {
-    this.doubleLowValue = doubleLowValue;
-  }
-
-  public Double getDoubleHighValue() {
-    return doubleHighValue;
-  }
-
-  public void setDoubleHighValue(double doubleHighValue) {
-    this.doubleHighValue = doubleHighValue;
-  }
-
-
-  public String getDecimalLowValue() {
-    return decimalLowValue;
-  }
-
-  public void setDecimalLowValue(String decimalLowValue) {
-    this.decimalLowValue = decimalLowValue;
-  }
-
-  public String getDecimalHighValue() {
-    return decimalHighValue;
-  }
-
-  public void setDecimalHighValue(String decimalHighValue) {
-    this.decimalHighValue = decimalHighValue;
-  }
-
-  public byte[] getBitVector() {
-    return bitVector;
-  }
-
-  public void setBitVector(byte[] bitVector) {
-    this.bitVector = bitVector;
-  }
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTablePrivilege.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTablePrivilege.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTablePrivilege.java
deleted file mode 100644
index f45576c..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTablePrivilege.java
+++ /dev/null
@@ -1,149 +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.hadoop.hive.metastore.model;
-
-public class MTablePrivilege {
-
-  private String principalName;
-
-  private String principalType;
-
-  private MTable table;
-
-  private String privilege;
-
-  private int createTime;
-
-  private String grantor;
-
-  private String grantorType;
-
-  private boolean grantOption;
-
-  private String authorizer;
-
-  public MTablePrivilege() {
-  }
-
-  public MTablePrivilege(String principalName, String principalType,
-      MTable table, String privilege, int createTime,
-      String grantor, String grantorType, boolean grantOption, String authorizer) {
-    super();
-    this.principalName = principalName;
-    this.principalType = principalType;
-    this.table = table;
-    this.privilege = privilege;
-    this.createTime = createTime;
-    this.grantor = grantor;
-    this.grantorType = grantorType;
-    this.grantOption = grantOption;
-    this.authorizer = authorizer;
-  }
-
-  public String getPrincipalName() {
-    return principalName;
-  }
-
-  public void setPrincipalName(String principalName) {
-    this.principalName = principalName;
-  }
-
-
-  /**
-   * @return a set of privileges this user/role/group has
-   */
-  public String getPrivilege() {
-    return privilege;
-  }
-
-  /**
-   * @param dbPrivilege a set of privileges this user/role/group has
-   */
-  public void setPrivilege(String dbPrivilege) {
-    this.privilege = dbPrivilege;
-  }
-
-  /**
-   * @return create time
-   */
-  public int getCreateTime() {
-    return createTime;
-  }
-
-  /**
-   * @param createTime create time
-   */
-  public void setCreateTime(int createTime) {
-    this.createTime = createTime;
-  }
-
-  /**
-   * @return the grantor
-   */
-  public String getGrantor() {
-    return grantor;
-  }
-
-  /**
-   * @param grantor
-   */
-  public void setGrantor(String grantor) {
-    this.grantor = grantor;
-  }
-
-  public String getPrincipalType() {
-    return principalType;
-  }
-
-  public void setPrincipalType(String principalType) {
-    this.principalType = principalType;
-  }
-
-  public MTable getTable() {
-    return table;
-  }
-
-  public void setTable(MTable table) {
-    this.table = table;
-  }
-
-  public boolean getGrantOption() {
-    return grantOption;
-  }
-
-  public void setGrantOption(boolean grantOption) {
-    this.grantOption = grantOption;
-  }
-
-  public String getGrantorType() {
-    return grantorType;
-  }
-
-  public void setGrantorType(String grantorType) {
-    this.grantorType = grantorType;
-  }
-
-  public String getAuthorizer() {
-    return authorizer;
-  }
-
-  public void setAuthorizer(String authorizer) {
-    this.authorizer = authorizer;
-  }
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTxnWriteNotificationLog.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTxnWriteNotificationLog.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTxnWriteNotificationLog.java
deleted file mode 100644
index f5ca386..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MTxnWriteNotificationLog.java
+++ /dev/null
@@ -1,123 +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.hadoop.hive.metastore.model;
-
-/**
- * MTxnWriteNotificationLog
- * DN table for ACID write events.
- */
-public class MTxnWriteNotificationLog {
-  private long txnId;
-  private long writeId;
-  private int eventTime;
-  private String database;
-  private String table;
-  private String partition;
-  private String tableObject;
-  private String partObject;
-  private String files;
-
-  public MTxnWriteNotificationLog() {
-  }
-
-  public MTxnWriteNotificationLog(long txnId, long writeId, int eventTime, String database, String table,
-                               String partition, String tableObject, String partObject, String files) {
-    this.txnId = txnId;
-    this.writeId = writeId;
-    this.eventTime = eventTime;
-    this.database = database;
-    this.table = table;
-    this.partition = partition;
-    this.tableObject = tableObject;
-    this.partObject = partObject;
-    this.files = files;
-  }
-
-  public long getTxnId() {
-    return txnId;
-  }
-
-  public void setTxnId(long txnId) {
-    this.txnId = txnId;
-  }
-
-  public long getWriteId() {
-    return writeId;
-  }
-
-  public void setWriteId(long writeId) {
-    this.writeId = writeId;
-  }
-
-  public int getEventTime() {
-    return eventTime;
-  }
-
-  public void setEventTime(int eventTime) {
-    this.eventTime = eventTime;
-  }
-
-  public String getDatabase() {
-    return database;
-  }
-
-  public void setDatabase(String database) {
-    this.database = database;
-  }
-
-  public String getTable() {
-    return table;
-  }
-
-  public void setTable(String table) {
-    this.table = table;
-  }
-
-  public String getPartition() {
-    return partition;
-  }
-
-  public void setPartition(String partition) {
-    this.partition = partition;
-  }
-
-  public String getTableObject() {
-    return tableObject;
-  }
-
-  public void setTableObject(String tableObject) {
-    this.tableObject = tableObject;
-  }
-
-  public String getPartObject() {
-    return partObject;
-  }
-
-  public void setPartObject(String partObject) {
-    this.partObject = partObject;
-  }
-
-  public String getFiles() {
-    return files;
-  }
-
-  public void setFiles(String files) {
-    this.files = files;
-  }
-}
-

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MType.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MType.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MType.java
deleted file mode 100644
index 97a42a0..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MType.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.apache.hadoop.hive.metastore.model;
-
-import java.util.List;
-
-/**
- * Represents a Hive type
- *
- */
-public class MType {
-  private String name;
-  private String type1;
-  private String type2;
-  private List<MFieldSchema> fields;
-  
-  /**
-   * @param name
-   * @param type1
-   * @param type2
-   * @param fields
-   */
-  public MType(String name, String type1, String type2, List<MFieldSchema> fields) {
-    this.name = name;
-    this.type1 = type1;
-    this.type2 = type2;
-    this.fields = fields;
-  }
-
-  public MType() {}
-  
-  /**
-   * @return the name
-   */
-  public String getName() {
-    return name;
-  }
-  /**
-   * @param name the name to set
-   */
-  public void setName(String name) {
-    this.name = name;
-  }
-  /**
-   * @return the type1
-   */
-  public String getType1() {
-    return type1;
-  }
-
-  /**
-   * @param type1 the type1 to set
-   */
-  public void setType1(String type1) {
-    this.type1 = type1;
-  }
-
-  /**
-   * @return the type2
-   */
-  public String getType2() {
-    return type2;
-  }
-
-  /**
-   * @param type2 the type2 to set
-   */
-  public void setType2(String type2) {
-    this.type2 = type2;
-  }
-
-  /**
-   * @return the fields
-   */
-  public List<MFieldSchema> getFields() {
-    return fields;
-  }
-  /**
-   * @param fields the fields to set
-   */
-  public void setFields(List<MFieldSchema> fields) {
-    this.fields = fields;
-  }
-  
-  
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MVersionTable.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MVersionTable.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MVersionTable.java
deleted file mode 100644
index dd1505d..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MVersionTable.java
+++ /dev/null
@@ -1,57 +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.hadoop.hive.metastore.model;
-
-public class MVersionTable {
-  private String schemaVersion;
-  private String versionComment;
-
-  public MVersionTable() {}
-
-  public MVersionTable(String schemaVersion, String versionComment) {
-    this.schemaVersion = schemaVersion;
-    this.versionComment = versionComment;
-  }
-  /**
-   * @return the versionComment
-   */
-  public String getVersionComment() {
-    return versionComment;
-  }
-  /**
-   * @param versionComment the versionComment to set
-   */
-  public void setVersionComment(String versionComment) {
-    this.versionComment = versionComment;
-  }
-
-  /**
-   * @return the schemaVersion
-   */
-  public String getSchemaVersion() {
-    return schemaVersion;
-  }
-  /**
-   * @param schemaVersion the schemaVersion to set
-   */
-  public void setSchemaVersion(String schemaVersion) {
-    this.schemaVersion = schemaVersion;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MWMMapping.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MWMMapping.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MWMMapping.java
deleted file mode 100644
index a9ae2eb..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MWMMapping.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.apache.hadoop.hive.metastore.model;
-
-public class MWMMapping {
-  private MWMResourcePlan resourcePlan;
-  private EntityType entityType;
-  private String entityName;
-  private MWMPool pool;
-  private Integer ordering;
-
-  public enum EntityType {
-    USER,
-    GROUP,
-    APPLICATION
-  }
-
-  public MWMMapping(MWMResourcePlan resourcePlan, EntityType entityType, String entityName,
-      MWMPool pool, Integer ordering) {
-    this.resourcePlan = resourcePlan;
-    this.entityType = entityType;
-    this.entityName = entityName;
-    this.pool = pool;
-    this.ordering = ordering;
-  }
-
-  public MWMResourcePlan getResourcePlan() {
-    return resourcePlan;
-  }
-
-  public void setResourcePlan(MWMResourcePlan resourcePlan) {
-    this.resourcePlan = resourcePlan;
-  }
-
-  public EntityType getEntityType() {
-    return entityType;
-  }
-
-  public void setEntityType(EntityType entityType) {
-    this.entityType = entityType;
-  }
-
-  public String getEntityName() {
-    return entityName;
-  }
-
-  public void setEntityName(String entityName) {
-    this.entityName = entityName;
-  }
-
-  public MWMPool getPool() {
-    return pool;
-  }
-
-  public void setPool(MWMPool pool) {
-    this.pool = pool;
-  }
-
-  public Integer getOrdering() {
-    return ordering;
-  }
-
-  public void setOrdering(Integer ordering) {
-    this.ordering = ordering;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MWMPool.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MWMPool.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MWMPool.java
deleted file mode 100644
index 58ce277..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MWMPool.java
+++ /dev/null
@@ -1,89 +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.hadoop.hive.metastore.model;
-
-import java.util.Set;
-
-public class MWMPool {
-  private MWMResourcePlan resourcePlan;
-  private String path;
-  private Double allocFraction;
-  private Integer queryParallelism;
-  private String schedulingPolicy;
-  private Set<MWMTrigger> triggers;
-
-  public MWMPool() {}
-
-  public MWMPool(MWMResourcePlan resourcePlan, String path, Double allocFraction,
-      Integer queryParallelism, String schedulingPolicy) {
-    this.resourcePlan = resourcePlan;
-    this.path = path;
-    this.allocFraction = allocFraction;
-    this.queryParallelism = queryParallelism;
-    this.schedulingPolicy = schedulingPolicy;
-  }
-
-  public MWMResourcePlan getResourcePlan() {
-    return resourcePlan;
-  }
-
-  public void setResourcePlan(MWMResourcePlan resourcePlan) {
-    this.resourcePlan = resourcePlan;
-  }
-
-  public String getPath() {
-    return path;
-  }
-
-  public void setPath(String path) {
-    this.path = path;
-  }
-
-  public Double getAllocFraction() {
-    return allocFraction;
-  }
-
-  public void setAllocFraction(Double allocFraction) {
-    this.allocFraction = allocFraction;
-  }
-
-  public Integer getQueryParallelism() {
-    return queryParallelism;
-  }
-
-  public void setQueryParallelism(Integer queryParallelism) {
-    this.queryParallelism = queryParallelism;
-  }
-
-  public String getSchedulingPolicy() {
-    return schedulingPolicy;
-  }
-
-  public void setSchedulingPolicy(String schedulingPolicy) {
-    this.schedulingPolicy = schedulingPolicy;
-  }
-
-  public Set<MWMTrigger> getTriggers() {
-    return triggers;
-  }
-
-  public void setTriggers(Set<MWMTrigger> triggers) {
-    this.triggers = triggers;
-  }
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/081fa368/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MWMResourcePlan.java
----------------------------------------------------------------------
diff --git a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MWMResourcePlan.java b/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MWMResourcePlan.java
deleted file mode 100644
index ac51f2d..0000000
--- a/standalone-metastore/metastore-common/src/main/java/org/apache/hadoop/hive/metastore/model/MWMResourcePlan.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.apache.hadoop.hive.metastore.model;
-
-import java.util.Set;
-
-/**
- * Storage class for ResourcePlan.
- */
-public class MWMResourcePlan {
-  private String name;
-  private Integer queryParallelism;
-  private Status status;
-  private Set<MWMPool> pools;
-  private Set<MWMTrigger> triggers;
-  private Set<MWMMapping> mappings;
-  private MWMPool defaultPool;
-
-
-  public enum Status {
-    ACTIVE,
-    ENABLED,
-    DISABLED
-  }
-
-  public MWMResourcePlan() {}
-
-  public MWMResourcePlan(String name, Integer queryParallelism, Status status) {
-    this.name = name;
-    this.queryParallelism = queryParallelism;
-    this.status = status;
-  }
-
-  public String getName() {
-    return name;
-  }
-
-  public void setName(String name) {
-    this.name = name;
-  }
-
-  public Integer getQueryParallelism() {
-    return queryParallelism;
-  }
-
-  public void setQueryParallelism(Integer queryParallelism) {
-    this.queryParallelism = queryParallelism;
-  }
-
-  public Status getStatus() {
-    return status;
-  }
-
-  public void setStatus(Status status) {
-    this.status = status;
-  }
-
-  public Set<MWMPool> getPools() {
-    return pools;
-  }
-
-  public void setPools(Set<MWMPool> pools) {
-    this.pools = pools;
-  }
-
-  public MWMPool getDefaultPool() {
-    return defaultPool;
-  }
-
-  public void setDefaultPool(MWMPool defaultPool) {
-    this.defaultPool = defaultPool;
-  }
-
-  public Set<MWMTrigger> getTriggers() {
-    return triggers;
-  }
-
-  public void setTriggers(Set<MWMTrigger> triggers) {
-    this.triggers = triggers;
-  }
-
-  public Set<MWMMapping> getMappings() {
-    return mappings;
-  }
-
-  public void setMappings(Set<MWMMapping> mappings) {
-    this.mappings = mappings;
-  }
-}