Package org.apache.hadoop.hive.ql.history

Examples of org.apache.hadoop.hive.ql.history.HiveHistory


      startSs.getConf()
          .setVar(HiveConf.ConfVars.HIVESESSIONID, makeSessionId());
    }

    if (startSs.hiveHist == null) {
      startSs.hiveHist = new HiveHistory(startSs);
    }

    if (startSs.getTmpOutputFile() == null) {
      // per-session temp file containing results to be sent from HiveServer to HiveClient
      File tmpDir = new File(
View Full Code Here


      startSs.getConf()
          .setVar(HiveConf.ConfVars.HIVESESSIONID, makeSessionId());
    }

    if (startSs.hiveHist == null) {
      startSs.hiveHist = new HiveHistory(startSs);
    }

    if (startSs.getTmpOutputFile() == null) {
      // per-session temp file containing results to be sent from HiveServer to HiveClient
      File tmpDir = new File(
View Full Code Here

      }
      opHandleSet.clear();
      // Cleanup session log directory.
      cleanupSessionLogDir();

      HiveHistory hiveHist = sessionState.getHiveHistory();
      if (null != hiveHist) {
        hiveHist.closeStream();
      }
      sessionState.close();
    } catch (IOException ioe) {
      throw new HiveSQLException("Failure to close", ioe);
    } finally {
View Full Code Here

  public static SessionState start(SessionState startSs) {

    tss.set(startSs);

    if (startSs.hiveHist == null) {
      startSs.hiveHist = new HiveHistory(startSs);
    }

    if (startSs.getTmpOutputFile() == null) {
      // per-session temp file containing results to be sent from HiveServer to HiveClient
      File tmpDir = new File(
View Full Code Here

public class PrintQueryHook implements PreExecute {

  @Override
  public void run(SessionState session, Set<ReadEntity> reads,
      Set<WriteEntity> writes, UserGroupInformation ugi) throws Exception {
    HiveHistory history = session.getHiveHistory();
   
    session.out.println(" PreExecute Query " + session.getCmd());

  }
View Full Code Here

      // Iterate through the opHandles and close their operations
      for (OperationHandle opHandle : opHandleSet) {
        operationManager.closeOperation(opHandle);
      }
      opHandleSet.clear();
      HiveHistory hiveHist = sessionState.getHiveHistory();
      if (null != hiveHist) {
        hiveHist.closeStream();
      }
      sessionState.close();
    } catch (IOException ioe) {
      throw new HiveSQLException("Failure to close", ioe);
    } finally {
View Full Code Here

      // Iterate through the opHandles and close their operations
      for (OperationHandle opHandle : opHandleSet) {
        operationManager.closeOperation(opHandle);
      }
      opHandleSet.clear();
      HiveHistory hiveHist = sessionState.getHiveHistory();
      if (null != hiveHist) {
        hiveHist.closeStream();
      }
      sessionState.close();
      release();
    } catch (IOException ioe) {
      release();
View Full Code Here

   * @throws HiveException
   */
  public static SessionState start(HiveConf conf) throws HiveException {
    SessionState ss = new SessionState(conf);
    ss.getConf().setVar(HiveConf.ConfVars.HIVESESSIONID, makeSessionId());
    ss.hiveHist = new HiveHistory(ss);
    ss.authenticator = HiveUtils.getAuthenticator(conf);
    ss.authorizer = HiveUtils.getAuthorizeProviderManager(
        conf, ss.authenticator);
    ss.createTableGrants = CreateTableAutomaticGrant.create(conf);
    tss.set(ss);
View Full Code Here

      startSs.getConf()
          .setVar(HiveConf.ConfVars.HIVESESSIONID, makeSessionId());
    }

    if (startSs.hiveHist == null) {
      startSs.hiveHist = new HiveHistory(startSs);
    }
   
    try {
      startSs.authenticator = HiveUtils.getAuthenticator(startSs
          .getConf());
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hive.ql.history.HiveHistory

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.