Package org.apache.hadoop.hive.metastore.api

Examples of org.apache.hadoop.hive.metastore.api.MetaException


      // of the names. that match.

      try {
         parts = get_partitions(db_name, tbl_name, (short) -1);
      } catch (NoSuchObjectException e) {
        throw new MetaException(e.getMessage());
      }

      for (Partition p : parts) {
        if (MetaStoreUtils.pvalMatches(part_vals, p.getValues())) {
          matchingParts.add(p);
View Full Code Here


      logStartPartitionFunction("get_partitions_names_ps", db_name, tbl_name, part_vals);
      Table t;
      try {
        t = get_table(db_name, tbl_name);
      } catch (NoSuchObjectException e) {
        throw new MetaException(e.getMessage());
      }

     List<String> partNames = get_partition_names(db_name, tbl_name, max_parts);
     List<String> filteredPartNames = new ArrayList<String>();
View Full Code Here

        String idxTblName = index.getIndexTableName();
        if (idxTblName != null) {
          Table tbl = null;
          tbl = this.get_table(dbName, idxTblName);
          if (tbl.getSd() == null) {
            throw new MetaException("Table metadata is corrupted");
          }

          if (tbl.getSd().getLocation() != null) {
            tblPath = new Path(tbl.getSd().getLocation());
          }
          if (!ms.dropTable(dbName, idxTblName)) {
            throw new MetaException("Unable to drop underlying data table "
                + idxTblName + " for index " + idxTblName);
          }
        }
        success = ms.commitTransaction();
      } finally {
View Full Code Here

          Table table = get_table(hiveObject.getDbName(), hiveObject
              .getObjectName());
          partName = Warehouse
              .makePartName(table.getPartitionKeys(), partValue);
        } catch (NoSuchObjectException e) {
          throw new MetaException(e.getMessage());
        }
      }
      return partName;
    }
View Full Code Here

      incrementCounter("cancel_delegation_token");
      logStartFunction("cancel_delegation_token");
      try {
        HiveMetaStore.cancelDelegationToken(token_str_form);
      } catch(IOException e) {
        throw new MetaException(e.getMessage());
      }

    }
View Full Code Here

      try {
        return
        HiveMetaStore.getDelegationToken(renewer_kerberos_principal_name,
            token_signature);
      } catch(IOException e) {
        throw new MetaException(e.getMessage());
      }
    }
View Full Code Here

      incrementCounter("renew_delegation_token");
      logStartFunction("renew_delegation_token");
      try {
        return HiveMetaStore.renewDelegationToken(token_str_form);
      } catch(IOException e) {
        throw new MetaException(e.getMessage());
      }
    }
View Full Code Here

      logStartFunction("get_delegation_token_with_signature");
      try {
        return
        HiveMetaStore.getDelegationToken(renewer_kerberos_principal_name);
      } catch(IOException e) {
        throw new MetaException(e.getMessage());
      }
    }
View Full Code Here

    }
    return keys;
  }
 
  private SerDeInfo converToSerDeInfo(MSerDeInfo ms) throws MetaException {
   if(ms == null) throw new MetaException("Invalid SerDeInfo object");
   return new SerDeInfo(ms.getName(),
       ms.getSerializationLib(),
       ms.getParameters());
  }
View Full Code Here

       ms.getSerializationLib(),
       ms.getParameters());
  }
 
  private MSerDeInfo converToMSerDeInfo(SerDeInfo ms) throws MetaException {
    if(ms == null) throw new MetaException("Invalid SerDeInfo object");
    return new MSerDeInfo(ms.getName(),
        ms.getSerializationLib(),
        ms.getParameters());
   }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hive.metastore.api.MetaException

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.