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

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


    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()
                               + ", MIN_THREAD_COUNT: " + executorPool.getMinThreadCount()
                               + ", MAX_THREAD_COUNT: " + executorPool.getMaxThreadCount()
                               + ", KEEP_ALIVE_SECS: " + executorPool.getKeepAliveSecs()
                               + ", THREADS_READ_RESULTS: " + executorPool.getThreadsReadResults()
                               + ", COMPLETION_QUEUE_SIZE: " + executorPool.getCompletionQueueSize()
                               + ")");
        }
        retval.out.flush();
        return retval;
    }
View Full Code Here


        if (!Utils.isValidString(this.getQueryExecutorPoolName()))
            throw new HBqlException("Connection not assigned a QueryExecutorPool name");

        this.validateQueryExecutorPoolNameExists(this.getQueryExecutorPoolName());

        final QueryExecutorPool pool = QueryExecutorPoolManager.getQueryExecutorPool(this.getQueryExecutorPoolName());
        final CompletionQueueExecutor executorQueue = ((QueryExecutorPoolImpl)pool).take();

        // Reset it prior to handing it out
        executorQueue.resetElement();
        return executorQueue;
View Full Code Here

TOP

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

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.