Examples of TableNotFoundException


Examples of co.cask.cdap.explore.service.TableNotFoundException

                           tableInfo.getSd().getInputFormat(), tableInfo.getSd().getOutputFormat(),
                           tableInfo.getSd().isCompressed(), tableInfo.getSd().getNumBuckets(),
                           tableInfo.getSd().getSerdeInfo().getSerializationLib(),
                           tableInfo.getSd().getSerdeInfo().getParameters(), isDatasetTable);
    } catch (NoSuchObjectException e) {
      throw new TableNotFoundException(e);
    } catch (TException e) {
      throw new ExploreException(e);
    }
  }
View Full Code Here

Examples of com.alibaba.wasp.TableNotFoundException

      if (parentTable == null) {
        parentTable = TableSchemaCacheReader.getService(reader.getConf())
            .getTable(tableName);
      }
      if (parentTable == null) {
        throw new TableNotFoundException("Not found parent table:" + parentName);
      }

      if (!parentTable.getEntityGroupKey().getName()
          .equals(table.getEntityGroupKey().getName())) {
        throw new UnsupportedException("Parent" + parentName
View Full Code Here

Examples of com.alibaba.wasp.TableNotFoundException

    this.assignmentManager = assignmentManager;
    this.tableLockManager = server.getTableLockManager();

    // Check if table exists
    if (!FMetaReader.tableExists(server.getConfiguration(), this.tableNameStr)) {
      throw new TableNotFoundException(tableNameStr);
    }
    if (!this.assignmentManager.getZKTable().isDisabledTable(tableNameStr)) {
      throw new TableNotDisabledException(tableNameStr);
    }
    ftable = FMetaReader.getTable(server.getConfiguration(), tableNameStr);
View Full Code Here

Examples of com.alibaba.wasp.TableNotFoundException

        table = TableSchemaCacheReader.getService(reader.getConf()).getTable(
            tableName);
      }
    }
    if (table == null) {
      throw new TableNotFoundException(tableName + " not exists!");
    }
    return table;
  }
View Full Code Here

Examples of com.facebook.presto.spi.TableNotFoundException

            }

            return new ConnectorPartitionResult(builder.build(), tupleDomain);
        }
        catch (Exception e) {
            throw new TableNotFoundException(kafkaTableHandle.toSchemaTableName(), e);
        }
    }
View Full Code Here

Examples of com.nearinfinity.honeycomb.exceptions.TableNotFoundException

        try {
            final Result result = HBaseOperations.performGet(hTable, get);

            final byte[] tableIdBytes = result.getValue(columnFamily, serializedName);
            if (tableIdBytes == null) {
                throw new TableNotFoundException(tableName);
            }

            return deserializeId(tableIdBytes);
        } finally {
            HBaseOperations.closeTable(hTable);
View Full Code Here

Examples of com.salesforce.phoenix.schema.TableNotFoundException

                    if (didRetry && logger.isDebugEnabled()) {
                        logger.debug("Re-resolved stale table " + fullTableName + " with seqNum " + tableRef.getTable().getSequenceNumber() + " at timestamp " + tableRef.getTable().getTimeStamp() + " with " + tableRef.getTable().getColumns().size() + " columns: " + tableRef.getTable().getColumns());
                    }
                    break;
                } catch (TableNotFoundException e) {
                    sqlE = new TableNotFoundException(e,timeStamp);
                }
                // If we haven't already tried, update our cache and retry
                // Only loop back if the cache was updated or we got a result back and we're allowed to multi-tenant tables
                if (retry && ((result = client.updateCache(schemaName, tableName)).wasUpdated() || (result.getTable() != null && allowMultiTenant))) {
                    timeStamp = result.getMutationTime();
View Full Code Here

Examples of org.apache.accumulo.core.client.TableNotFoundException

  }
 
  private void checkTableExists(Connector connector, String tableName) throws TableNotFoundException {
   
    if (!connector.tableOperations().exists(tableName)) {
      throw new TableNotFoundException(null, tableName, "Not found");
    }
  }
View Full Code Here

Examples of org.apache.accumulo.core.client.TableNotFoundException

  @Deprecated
  @Override
  public void addAggregators(String tableName, List<? extends PerColumnIteratorConfig> aggregators) throws AccumuloSecurityException, TableNotFoundException,
      AccumuloException {
    if (!exists(tableName))
      throw new TableNotFoundException(tableName, tableName, "");
    acu.addAggregators(tableName, aggregators);
  }
View Full Code Here

Examples of org.apache.accumulo.core.client.TableNotFoundException

  }
 
  @Override
  public Collection<Text> getSplits(String tableName) throws TableNotFoundException {
    if (!exists(tableName))
      throw new TableNotFoundException(tableName, tableName, "");
    return Collections.emptyList();
  }
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. 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.