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

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


        super(null);
    }

    protected ExecutionResults execute(final HConnectionImpl conn) throws HBqlException {

        final ExecutionResults retval = new ExecutionResults();
        retval.out.println("Query Executor Pools: ");
        for (final String name : QueryExecutorPoolManager.getQueryExecutorPoolNames()) {
            final QueryExecutorPool executorPool = QueryExecutorPoolManager.getQueryExecutorPool(name);
            retval.out.println("\t" + executorPool.getName() + "(" +
                               "MAX_EXECUTOR_POOL_SIZE: " + executorPool.getMaxPoolSize()
View Full Code Here


        return filename;
    }

    public ExecutionResults execute(final HConnectionImpl conn) {

        final ExecutionResults results = new ExecutionResults();

        boolean success;
        try {
            success = processInput(new PrintWriter(results.out), conn, readFile(this.getFilename()));
        }
        catch (IOException e) {
            success = false;
            results.out.println(e.getMessage());
        }
        results.setSuccess(success);

        return results;
    }
View Full Code Here

        return this.indexName;
    }

    protected ExecutionResults execute(final HConnectionImpl conn) throws HBqlException {
        conn.dropIndexForTable(this.getTableName(), this.getIndexName());
        return new ExecutionResults("Index " + this.getIndexName() + " dropped for table " + this.getTableName());
    }
View Full Code Here

        return this.genericValue;
    }

    public ExecutionResults execute(HConnectionImpl connection) throws HBqlException {

        final ExecutionResults retval = new ExecutionResults("Parsed successfully");

        if (this.getGenericValue() != null) {
            final SimpleExpressionContext expr = new SimpleExpressionContext(this.getGenericValue());
            expr.validate();
            final Object val = expr.getValue(connection);
View Full Code Here

        return this.stmt;
    }

    public ExecutionResults execute(HConnectionImpl connection) throws HBqlException {

        final ExecutionResults retval = new ExecutionResults("Parsed successfully");

        retval.out.println(this.getStmt().getClass().getSimpleName());

        return retval;
    }
View Full Code Here

                                                             this.getTableName(),
                                                             this.getKeyInfo(),
                                                             this.getFamilyMappingList());
        this.getMappingContext().setMapping(tableMapping);
        tableMapping.validate(tableMapping.getMappingName());
        return new ExecutionResults("Mapping " + tableMapping.getMappingName() + " defined.");
    }
View Full Code Here

            batch.apply();
            cnt++;
        }

        final ExecutionResults results = new ExecutionResults(cnt + " record" + ((cnt > 1) ? "s" : "") + " inserted");
        results.setCount(cnt);
        return results;
    }
View Full Code Here

            throw new HBqlException(e);
        }
        catch (InterruptedException e) {
            throw new HBqlException(e);
        }
        return new ExecutionResults("Table " + this.getTableName() + " flushed.");
    }
View Full Code Here

    }

    protected ExecutionResults execute(final HBqlStatement statement) throws HBqlException {
        if (Utils.isSelectStatement(statement)) {
            this.executeQuery(statement, null);
            return new ExecutionResults("Query executed");
        }
        else {
            return this.executeUpdate(statement);
        }
    }
View Full Code Here

TOP

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

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.