Package org.apache.hadoop.hbase.hbql.client

Examples of org.apache.hadoop.hbase.hbql.client.HBqlException


            throw new HBqlException("Family " + familyName + " not defined for table " + tableName);
    }

    public void validateIndexExistsForTable(final String indexName, final String tableName) throws HBqlException {
        if (!this.indexExistsForTable(indexName, tableName))
            throw new HBqlException("Index " + indexName + " not defined for table " + tableName);
    }
View Full Code Here


            throw new HBqlException("Index " + indexName + " not defined for table " + tableName);
    }

    public void validateQueryExecutorPoolNameExists(final String poolName) throws HBqlException {
        if (!QueryExecutorPoolManager.queryExecutorPoolExists(poolName))
            throw new HBqlException("QueryExecutorPool " + poolName + " does not exist.");
    }
View Full Code Here

            throw new HBqlException("QueryExecutorPool " + poolName + " does not exist.");
    }

    public void validateAsyncExecutorNameExists(final String name) throws HBqlException {
        if (!AsyncExecutorManager.asyncExecutorExists(name))
            throw new HBqlException("AsyncExecutor " + name + " does not exist.");
    }
View Full Code Here

            case LT:
                return val0.compareTo(val1) < 0;
            case LTEQ:
                return val0.compareTo(val1) <= 0;
            default:
                throw new HBqlException("Invalid operator: " + this.getOperator());
        }
    }
View Full Code Here

    }

    private ExecutorProperty validateProperty(final ExecutorProperty assignee,
                                              final ExecutorProperty value) throws HBqlException {
        if (assignee != null)
            throw new HBqlException("Multiple " + value.getPropertyType().getDescription()
                                    + " values for " + this.getName() + " not allowed");
        return value;
    }
View Full Code Here

    }

    private ExecutorProperty validateProperty(final ExecutorProperty assignee,
                                              final ExecutorProperty value) throws HBqlException {
        if (assignee != null)
            throw new HBqlException("Multiple " + value.getPropertyType().getDescription()
                                    + " values for " + this.getPoolName() + " not allowed");
        return value;
    }
View Full Code Here

        try {
            return getExpressionTree(sql, mappingContext);
        }
        catch (RecognitionException e) {
            e.printStackTrace();
            throw new HBqlException("Error parsing: " + sql);
        }
    }
View Full Code Here

            case LT:
                return val0 < val1;
            case LTEQ:
                return val0 <= val1;
            default:
                throw new HBqlException("Invalid operator: " + this.getOperator());
        }
    }
View Full Code Here

            case LTEQ:
                return val0 <= val1;
            case NOTEQ:
                return val0 != val1;
            default:
                throw new HBqlException("Invalid operator: " + this.getOperator());
        }
    }
View Full Code Here

                                                   final String tableName,
                                                   final KeyInfo keyInfo,
                                                   final List<FamilyMapping> familyMappingList) throws HBqlException {

        if (!mappingName.equals(SYSTEM_MAPPINGS) && this.mappingExists(mappingName))
            throw new HBqlException("Mapping already defined: " + mappingName);

        final TableMapping tableMapping = new TableMapping(this.getConnection(),
                                                           isTemp,
                                                           isSystem,
                                                           mappingName,
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.hbql.client.HBqlException

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.