Package org.apache.hadoop.hive.ql.exec

Examples of org.apache.hadoop.hive.ql.exec.FunctionInfo


      if (expressionTree.getChild(0).getType() == HiveParser.Identifier) {
        String functionName = unescapeIdentifier(expressionTree.getChild(0)
            .getText());
        if (FunctionRegistry.getGenericUDAFResolver(functionName) != null) {
          aggregations.put(expressionTree.toStringTree(), expressionTree);
          FunctionInfo fi = FunctionRegistry.getFunctionInfo(functionName);
          if (!fi.isNative()) {
            unparseTranslator.addIdentifierTranslation((ASTNode) expressionTree
                .getChild(0));
          }
          return;
        }
View Full Code Here


    int udtfExprType = udtfExpr.getType();
    if (udtfExprType == HiveParser.TOK_FUNCTION
        || udtfExprType == HiveParser.TOK_FUNCTIONSTAR) {
      String funcName = TypeCheckProcFactory.DefaultExprProcessor
          .getFunctionText(udtfExpr, true);
      FunctionInfo fi = FunctionRegistry.getFunctionInfo(funcName);
      if (fi != null) {
        genericUDTF = fi.getGenericUDTF();
      }
      isUDTF = (genericUDTF != null);
      if (isUDTF) {
        globalLimitCtx.setHasTransformOrUDTF(true);
      }
      if (isUDTF && !fi.isNative()) {
        unparseTranslator.addIdentifierTranslation((ASTNode) udtfExpr
            .getChild(0));
      }
    }
View Full Code Here

     * @throws UDFArgumentException
     */
    public static ExprNodeDesc getFuncExprNodeDesc(String udfName, ExprNodeDesc... children) throws UDFArgumentException
    {

      FunctionInfo fi = FunctionRegistry.getFunctionInfo(udfName);
      if (fi == null)
      {
        throw new UDFArgumentException(udfName + " not found.");
      }

      GenericUDF genericUDF = fi.getGenericUDF();
      if (genericUDF == null)
      {
        throw new UDFArgumentException(udfName
            + " is an aggregation function or a table function.");
      }
View Full Code Here

        }
      }
      else
      {
        // other operators or functions
        FunctionInfo fi = FunctionRegistry.getFunctionInfo(funcText);

        if (fi == null)
        {
          if (isFunction)
          {
            throw new SemanticException(
                ErrorMsg.INVALID_FUNCTION.getMsg((ASTNode) expr
                    .getChild(0)));
          }
          else
          {
            throw new SemanticException(
                ErrorMsg.INVALID_FUNCTION.getMsg(expr));
          }
        }

        if (!fi.isNative())
        {
          // TODO revisit: will we ever hit this case for Windowing?
//          ctx.getUnparseTranslator().addIdentifierTranslation((ASTNode) expr.getChild(0));
        }

        // Detect UDTF's in nested SELECT, GROUP BY, etc as they aren't
        // supported
        if (fi.getGenericUDTF() != null)
        {
          throw new SemanticException(
              ErrorMsg.UDTF_INVALID_LOCATION.getMsg());
        }
        // UDAF in filter condition, group-by caluse, param of funtion,
        // etc.
        if (fi.getGenericUDAFResolver() != null)
        {
          if (isFunction)
          {
            // TODO: using UDTF_INVALID_LOC instead of UDAF_INVALID_LOC
//            throw new SemanticException(ErrorMsg.UDAF_INVALID_LOCATION.getMsg((ASTNode) expr.getChild(0)));
            throw new SemanticException(ErrorMsg.UDTF_INVALID_LOCATION.getMsg((ASTNode) expr.getChild(0)));
          }
          else
          {
            // TODO: using UDTF_INVALID_LOC instead of UDAF_INVALID_LOC
//            throw new SemanticException(ErrorMsg.UDAF_INVALID_LOCATION.getMsg(expr));
            throw new SemanticException(ErrorMsg.UDTF_INVALID_LOCATION.getMsg(expr));
          }
        }
        if (!ctx.getAllowStatefulFunctions()
            && (fi.getGenericUDF() != null))
        {
          if (FunctionRegistry.isStateful(fi.getGenericUDF()))
          {
            throw new SemanticException(
                ErrorMsg.UDF_STATEFUL_INVALID_LOCATION.getMsg());
          }
        }

        // Try to infer the type of the constant only if there are two
        // nodes, one of them is column and the other is numeric const
        if (fi.getGenericUDF() instanceof GenericUDFBaseCompare
            && children.size() == 2
            && ((children.get(0) instanceof ExprNodeConstantDesc && children
                .get(1) instanceof ExprNodeColumnDesc) || (children
                .get(0) instanceof ExprNodeColumnDesc && children
                .get(1) instanceof ExprNodeConstantDesc)))
        {
          int constIdx = children.get(0) instanceof ExprNodeConstantDesc ? 0
              : 1;

          Set<String> inferTypes = new HashSet<String>(Arrays.asList(
              Constants.TINYINT_TYPE_NAME.toLowerCase(),
              Constants.SMALLINT_TYPE_NAME.toLowerCase(),
              Constants.INT_TYPE_NAME.toLowerCase(),
              Constants.BIGINT_TYPE_NAME.toLowerCase(),
              Constants.FLOAT_TYPE_NAME.toLowerCase(),
              Constants.DOUBLE_TYPE_NAME.toLowerCase(),
              Constants.STRING_TYPE_NAME.toLowerCase()));

          String constType = children.get(constIdx).getTypeString()
              .toLowerCase();
          String columnType = children.get(1 - constIdx)
              .getTypeString().toLowerCase();

          if (inferTypes.contains(constType)
              && inferTypes.contains(columnType)
              && !columnType.equalsIgnoreCase(constType))
          {
            String constValue = ((ExprNodeConstantDesc) children
                .get(constIdx)).getValue().toString();
            boolean triedDouble = false;

            Number value = null;
            try
            {
              if (columnType
                  .equalsIgnoreCase(Constants.TINYINT_TYPE_NAME))
              {
                value = new Byte(constValue);
              }
              else if (columnType
                  .equalsIgnoreCase(Constants.SMALLINT_TYPE_NAME))
              {
                value = new Short(constValue);
              }
              else if (columnType
                  .equalsIgnoreCase(Constants.INT_TYPE_NAME))
              {
                value = new Integer(constValue);
              }
              else if (columnType
                  .equalsIgnoreCase(Constants.BIGINT_TYPE_NAME))
              {
                value = new Long(constValue);
              }
              else if (columnType
                  .equalsIgnoreCase(Constants.FLOAT_TYPE_NAME))
              {
                value = new Float(constValue);
              }
              else if (columnType
                  .equalsIgnoreCase(Constants.DOUBLE_TYPE_NAME)
                  || (columnType
                      .equalsIgnoreCase(Constants.STRING_TYPE_NAME) && !constType
                      .equalsIgnoreCase(Constants.BIGINT_TYPE_NAME)))
              {
                // no smart inference for queries like
                // "str_col = bigint_const"
                triedDouble = true;
                value = new Double(constValue);
              }
            }
            catch (NumberFormatException nfe)
            {
              // this exception suggests the precise type
              // inference did not succeed
              // we'll try again to convert it to double
              // however, if we already tried this, or the column
              // is NUMBER type and
              // the operator is EQUAL, return false due to the
              // type mismatch
              if (triedDouble
                  || (fi.getGenericUDF() instanceof GenericUDFOPEqual && !columnType
                      .equals(Constants.STRING_TYPE_NAME)))
              {
                return new ExprNodeConstantDesc(false);
              }

              try
              {
                value = new Double(constValue);
              }
              catch (NumberFormatException ex)
              {
                return new ExprNodeConstantDesc(false);
              }
            }

            if (value != null)
            {
              children.set(constIdx, new ExprNodeConstantDesc(
                  value));
            }
          }
        }

        desc = ExprNodeGenericFuncDesc.newInstance(fi.getGenericUDF(), children);
      }
      // UDFOPPositive is a no-op.
      // However, we still create it, and then remove it here, to make
      // sure we
      // only allow
View Full Code Here

  static void registerHiveUDAFsAsWindowFunctions()
  {
    Set<String> fNames = HiveFR.getFunctionNames();
    for(String fName : fNames)
    {
      FunctionInfo fInfo = HiveFR.getFunctionInfo(fName);
      if ( fInfo.isGenericUDAF())
      {
        WindowFunctionInfo wInfo = new WindowFunctionInfo(fInfo);
        windowFunctions.put(fName, wInfo);
      }
    }
View Full Code Here

  }
 
  public static void registerWindowFunction(String name, GenericUDAFResolver wFn)
  {
    HiveFR.registerGenericUDAF(true, name, wFn);
    FunctionInfo fInfo = HiveFR.getFunctionInfo(name);
    WindowFunctionInfo wInfo = new WindowFunctionInfo(fInfo);
    windowFunctions.put(name.toLowerCase(), wInfo);
  }
View Full Code Here

  public static boolean isCustomUDF(ExprNodeGenericFuncDesc expr) {
    String udfName = expr.getFuncText();
    if (udfName == null) {
      return false;
    }
    FunctionInfo funcInfo = FunctionRegistry.getFunctionInfo(udfName);
    if (funcInfo == null) {
      return false;
    }
    boolean isNativeFunc = funcInfo.isNative();
    return !isNativeFunc;
  }
View Full Code Here

     * @throws UDFArgumentException
     */
    static ExprNodeDesc getFuncExprNodeDescWithUdfData(String udfName, TypeInfo typeInfo,
        ExprNodeDesc... children) throws UDFArgumentException {

      FunctionInfo fi = FunctionRegistry.getFunctionInfo(udfName);
      if (fi == null) {
        throw new UDFArgumentException(udfName + " not found.");
      }

      GenericUDF genericUDF = fi.getGenericUDF();
      if (genericUDF == null) {
        throw new UDFArgumentException(udfName
            + " is an aggregation function or a table function.");
      }

View Full Code Here

          throw new SemanticException(ErrorMsg.NON_COLLECTION_TYPE.getMsg(expr,
              myt.getTypeName()));
        }
      } else {
        // other operators or functions
        FunctionInfo fi = FunctionRegistry.getFunctionInfo(funcText);

        if (fi == null) {
          if (isFunction) {
            throw new SemanticException(ErrorMsg.INVALID_FUNCTION
                .getMsg((ASTNode) expr.getChild(0)));
          } else {
            throw new SemanticException(ErrorMsg.INVALID_FUNCTION.getMsg(expr));
          }
        }

        // getGenericUDF() actually clones the UDF. Just call it once and reuse.
        GenericUDF genericUDF = fi.getGenericUDF();

        if (!fi.isNative()) {
          ctx.getUnparseTranslator().addIdentifierTranslation(
              (ASTNode) expr.getChild(0));
        }

        // Handle type casts that may contain type parameters
        if (isFunction) {
          ASTNode funcNameNode = (ASTNode)expr.getChild(0);
          switch (funcNameNode.getType()) {
            case HiveParser.TOK_CHAR:
              // Add type params
              CharTypeInfo charTypeInfo = ParseUtils.getCharTypeInfo(funcNameNode);
              if (genericUDF != null) {
                ((SettableUDF)genericUDF).setTypeInfo(charTypeInfo);
              }
              break;
            case HiveParser.TOK_VARCHAR:
              VarcharTypeInfo varcharTypeInfo = ParseUtils.getVarcharTypeInfo(funcNameNode);
              if (genericUDF != null) {
                ((SettableUDF)genericUDF).setTypeInfo(varcharTypeInfo);
              }
              break;
            case HiveParser.TOK_DECIMAL:
              DecimalTypeInfo decTypeInfo = ParseUtils.getDecimalTypeTypeInfo(funcNameNode);
              if (genericUDF != null) {
                ((SettableUDF)genericUDF).setTypeInfo(decTypeInfo);
              }
              break;
            default:
              // Do nothing
              break;
          }
        }

        // Detect UDTF's in nested SELECT, GROUP BY, etc as they aren't
        // supported
        if (fi.getGenericUDTF() != null) {
          throw new SemanticException(ErrorMsg.UDTF_INVALID_LOCATION.getMsg());
        }
        // UDAF in filter condition, group-by caluse, param of funtion, etc.
        if (fi.getGenericUDAFResolver() != null) {
          if (isFunction) {
            throw new SemanticException(ErrorMsg.UDAF_INVALID_LOCATION.
                getMsg((ASTNode) expr.getChild(0)));
          } else {
            throw new SemanticException(ErrorMsg.UDAF_INVALID_LOCATION.getMsg(expr));
View Full Code Here

        if (FunctionRegistry.getGenericUDAFResolver(functionName) != null) {
          if(containsLeadLagUDF(expressionTree)) {
            throw new SemanticException(ErrorMsg.MISSING_OVER_CLAUSE.getMsg(functionName));
          }
          aggregations.put(expressionTree.toStringTree(), expressionTree);
          FunctionInfo fi = FunctionRegistry.getFunctionInfo(functionName);
          if (!fi.isNative()) {
            unparseTranslator.addIdentifierTranslation((ASTNode) expressionTree
                .getChild(0));
          }
          return;
        }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hive.ql.exec.FunctionInfo

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.