Package org.apache.hadoop.hive.ql.session.SessionState

Examples of org.apache.hadoop.hive.ql.session.SessionState.LogHelper.printError()


      if (console == null) {
        return;
      }

      // This is simply to verify that the hooks were in fact run
      console.printError("Running RunSecond for Pre Driver Run Hook");

      Assert.assertTrue("Driver Run Hooks did not run in the order specified.",
          driverRunPreHookFirstRan);
    }
View Full Code Here


      if (console == null) {
        return;
      }

      // This is simply to verify that the hooks were in fact run
      console.printError("Running RunSecond for Post Driver Run Hook");

      Assert.assertTrue("Driver Run Hooks did not run in the order specified.",
          driverRunPostHookFirstRan);
    }
View Full Code Here

        backupCommonJoin++;
        break;
      }
    }
    LogHelper console = SessionState.getConsole();
    console.printError("[MapJoinCounter PostHook] COMMON_JOIN: " + commonJoin
        + " HINTED_MAPJOIN: " + hintedMapJoin + " HINTED_MAPJOIN_LOCAL: " + hintedMapJoinLocal
        + " CONVERTED_MAPJOIN: " + convertedMapJoin + " CONVERTED_MAPJOIN_LOCAL: " + convertedMapJoinLocal
        + " BACKUP_COMMON_JOIN: " + backupCommonJoin);
  }
}
View Full Code Here

      throws SemanticException {
    LogHelper console = SessionState.getConsole();
    isCreateTable = (ast.getToken().getType() == HiveParser.TOK_CREATETABLE);
    myCount = count++;
    if (isCreateTable) {
      console.printError("DummySemanticAnalyzerHook1 Pre: Count " + myCount);
    }
    return ast;
  }

  public DummySemanticAnalyzerHook1() {
View Full Code Here

    }
    tblProps.put("createdBy", DummyCreateTableHook.class.getName());
    tblProps.put("Message", "Hive rocks!! Count: " + myCount);

    LogHelper console = SessionState.getConsole();
    console.printError("DummySemanticAnalyzerHook1 Post: Hive rocks!! Count: " + myCount);
  }
}
View Full Code Here

      }
      outputOrderedMap.put(tableAccess.getKey().getOperatorId(), perOperatorInfo.toString());
    }

    for (String perOperatorInfo: outputOrderedMap.values()) {
        console.printError(perOperatorInfo);
    }
  }
}
View Full Code Here

  public void run(HookContext hookContext) {
    LogHelper console = SessionState.getConsole();

    for (Entry<String, List<String>> entry : SessionState.get().getLocalMapRedErrors().entrySet()) {
      console.printError("ID: " + entry.getKey());

      for (String line : entry.getValue()) {
        console.printError(line);
      }
    }
View Full Code Here

    for (Entry<String, List<String>> entry : SessionState.get().getLocalMapRedErrors().entrySet()) {
      console.printError("ID: " + entry.getKey());

      for (String line : entry.getValue()) {
        console.printError(line);
      }
    }
  }
}
View Full Code Here

      return;
    }

    for (Entry<String, String> entry : ss.getOverriddenConfigurations().entrySet()) {
      if (keysList.contains(entry.getKey())) {
        console.printError("Key: " + entry.getKey() + ", Value: " + entry.getValue());
      }
    }
  }
}
View Full Code Here

    Log LOG = LogFactory.getLog(ExecDriver.class.getName());
    LogHelper console = new LogHelper(LOG, isSilent);

    if (planFileName == null) {
      console.printError("Must specify Plan File Name");
      printUsage();
    }

    // print out the location of the log file for the user so
    // that it's easy to find reason for local mode execution failures
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.