Exemplo n.º 1
0
 def LinkAgainstSimpleBuiltins(self, ast):
     ast = ast.Visit(visitors.NamedTypeToClassType())
     ast = visitors.AdjustTypeParameters(ast)
     ast.Visit(visitors.FillInModuleClasses({"": ast}))
     ast = ast.Visit(visitors.LookupFullNames([self.mini_builtins]))
     ast.Visit(visitors.VerifyLookup())
     return ast
Exemplo n.º 2
0
 def _finish_ast(self, ast):
     module_map = {
         name: module.ast
         for name, module in self._modules.items()
     }
     module_map[""] = ast  # The module itself (local lookup)
     ast.Visit(visitors.FillInModuleClasses(module_map))
     ast.Visit(visitors.VerifyLookup())
Exemplo n.º 3
0
def GetBuiltinsAndTyping(python_version):
    """Get __builtin__.pytd and typing.pytd."""
    assert python_version
    global _cached_builtins_pytd
    if _cached_builtins_pytd.cache:
        assert _cached_builtins_pytd.version == python_version
    else:
        t = parser.parse_string(_FindBuiltinFile("typing", python_version),
                                name="typing",
                                python_version=python_version)
        b = parser.parse_string(_FindBuiltinFile("__builtin__",
                                                 python_version),
                                name="__builtin__",
                                python_version=python_version)
        b = b.Visit(
            visitors.LookupExternalTypes({"typing": t},
                                         full_names=True,
                                         self_name="__builtin__"))
        t = t.Visit(visitors.LookupBuiltins(b))
        b = b.Visit(visitors.NamedTypeToClassType())
        t = t.Visit(visitors.NamedTypeToClassType())
        b = b.Visit(visitors.AdjustTypeParameters())
        t = t.Visit(visitors.AdjustTypeParameters())
        b = b.Visit(visitors.CanonicalOrderingVisitor())
        t = t.Visit(visitors.CanonicalOrderingVisitor())
        b.Visit(
            visitors.FillInLocalPointers({
                "": b,
                "typing": t,
                "__builtin__": b
            }))
        t.Visit(
            visitors.FillInLocalPointers({
                "": t,
                "typing": t,
                "__builtin__": b
            }))
        b.Visit(visitors.VerifyLookup())
        t.Visit(visitors.VerifyLookup())
        b.Visit(visitors.VerifyContainers())
        t.Visit(visitors.VerifyContainers())
        _cached_builtins_pytd = Cache(python_version, (b, t))
    return _cached_builtins_pytd.cache
Exemplo n.º 4
0
def solve(ast, builtins_pytd):
    """Solve the unknowns in a pytd AST using the standard Python builtins.

  Args:
    ast: A pytd.TypeDeclUnit, containing classes named ~unknownXX.
    builtins_pytd: A pytd for builtins.

  Returns:
    A tuple of (1) a dictionary (str->str) mapping unknown class names to known
    class names and (2) a pytd.TypeDeclUnit of the complete classes in ast.
  """
    builtins_pytd = transforms.RemoveMutableParameters(builtins_pytd)
    builtins_pytd = builtins_pytd.Visit(visitors.NamedTypeToClassType())
    builtins_pytd = builtins_pytd.Visit(
        visitors.LookupFullNames([builtins_pytd]))
    builtins_pytd.Visit(visitors.VerifyLookup())
    ast = ast.Visit(visitors.NamedTypeToClassType())
    ast = ast.Visit(visitors.LookupFullNames([builtins_pytd, ast]))
    ast.Visit(visitors.VerifyLookup())
    return TypeSolver(ast, builtins_pytd).solve(), extract_local(ast)
Exemplo n.º 5
0
 def testPackageRelativeImport(self):
     with utils.Tempdir() as d:
         d.create_file("pkg/foo.pyi", "class X: ...")
         d.create_file(
             "pkg/bar.pyi", """
       from .foo import X
       y = ...  # type: X""")
         foo = _Module(module_name="pkg.foo", file_name="pkg/foo.pyi")
         bar = _Module(module_name="pkg.bar", file_name="pkg/bar.pyi")
         self._LoadAst(d, module=bar)
         self._PickleModules(d, foo, bar)
         loaded_ast = self._LoadPickledModule(d, bar)
         loaded_ast.Visit(visitors.VerifyLookup())
Exemplo n.º 6
0
  def testStarImport(self):
    with utils.Tempdir() as d:
      d.create_file("foo.pyi", "class A(object): ...")
      d.create_file("bar.pyi", "from foo import *")
      foo = _Module(module_name="foo", file_name="foo.pyi")
      bar = _Module(module_name="bar", file_name="bar.pyi")
      self._LoadAst(d, module=bar)
      self._PickleModules(d, foo, bar)
      loaded_ast = self._LoadPickledModule(d, bar)
      loaded_ast.Visit(visitors.VerifyLookup())
      self.assertMultiLineEqual(pytd.Print(loaded_ast), textwrap.dedent("""\
        import foo

        bar.A = foo.A"""))
Exemplo n.º 7
0
def GetBuiltinsAndTyping():
    """Get __builtin__.pytd and typing.pytd."""
    global _cached_builtins_pytd
    if not _cached_builtins_pytd:
        t = parser.TypeDeclParser().Parse(_FindBuiltinFile("typing"),
                                          name="typing")
        t = t.Visit(visitors.AddNamePrefix())
        b = parser.TypeDeclParser().Parse(_FindBuiltinFile("__builtin__"),
                                          name="__builtin__")
        b = b.Visit(visitors.AddNamePrefix())
        b = b.Visit(visitors.NamedTypeToClassType())
        b = b.Visit(
            visitors.LookupExternalTypes({"typing": t},
                                         full_names=True,
                                         self_name="__builtin__"))
        t = t.Visit(visitors.LookupBuiltins(b))
        t = t.Visit(visitors.NamedTypeToClassType())
        b = visitors.AdjustTypeParameters(b)
        t = visitors.AdjustTypeParameters(t)
        b.Visit(
            visitors.FillInModuleClasses({
                "": b,
                "typing": t,
                "__builtin__": b
            }))
        t.Visit(
            visitors.FillInModuleClasses({
                "": t,
                "typing": t,
                "__builtin__": b
            }))
        b.Visit(visitors.VerifyLookup())
        t.Visit(visitors.VerifyLookup())
        b.Visit(visitors.VerifyContainers())
        t.Visit(visitors.VerifyContainers())
        _cached_builtins_pytd = b, t
    return _cached_builtins_pytd
Exemplo n.º 8
0
def GetBuiltinsAndTyping():
    """Get __builtin__.pytd and typing.pytd."""
    global _cached_builtins_pytd
    if not _cached_builtins_pytd:
        t = parser.parse_string(_FindBuiltinFile("typing"), name="typing")
        b = parser.parse_string(_FindBuiltinFile("__builtin__"),
                                name="__builtin__")
        b = b.Visit(
            visitors.LookupExternalTypes({"typing": t},
                                         full_names=True,
                                         self_name="__builtin__"))
        t = t.Visit(visitors.LookupBuiltins(b))
        b = b.Visit(visitors.NamedTypeToClassType())
        t = t.Visit(visitors.NamedTypeToClassType())
        b = b.Visit(visitors.AdjustTypeParameters())
        t = t.Visit(visitors.AdjustTypeParameters())
        b = b.Visit(visitors.CanonicalOrderingVisitor())
        t = t.Visit(visitors.CanonicalOrderingVisitor())
        b.Visit(
            visitors.FillInLocalPointers({
                "": b,
                "typing": t,
                "__builtin__": b
            }))
        t.Visit(
            visitors.FillInLocalPointers({
                "": t,
                "typing": t,
                "__builtin__": b
            }))
        b.Visit(visitors.VerifyLookup())
        t.Visit(visitors.VerifyLookup())
        b.Visit(visitors.VerifyContainers())
        t.Visit(visitors.VerifyContainers())
        _cached_builtins_pytd = b, t
    return _cached_builtins_pytd
Exemplo n.º 9
0
  def testLookupClasses(self):
    src = textwrap.dedent("""
        class object(object):
            pass

        class A(object):
            def a(self, a: A, b: B) -> A or B raises A, B

        class B(object):
            def b(self, a: A, b: B) -> A or B raises A, B
    """)
    tree = self.Parse(src)
    new_tree = visitors.LookupClasses(tree)
    self.AssertSourceEquals(new_tree, src)
    new_tree.Visit(visitors.VerifyLookup())
Exemplo n.º 10
0
 def testModuleAliases(self):
     with utils.Tempdir() as d:
         d.create_file("pkg/foo.pyi", "class X: ...")
         d.create_file(
             "pkg/bar.pyi", """
       import pkg.foo as baz
       y = ...  # type: baz.X""")
         foo = _Module(module_name="pkg.foo", file_name="pkg/foo.pyi")
         bar = _Module(module_name="pkg.bar", file_name="pkg/bar.pyi")
         loader, _ = self._LoadAst(d, module=bar)
         self._PickleModules(loader, d, foo, bar)
         loaded_ast = self._LoadPickledModule(d, bar)
         loaded_ast.Visit(visitors.VerifyLookup())
         f = loaded_ast.Lookup("pkg.bar.y")
         self.assertEqual("pkg.foo.X", f.type.name)
Exemplo n.º 11
0
    def testLoadTopLevel(self):
        """Tests that a pickled file can be read."""
        with utils.Tempdir() as d:
            module_name = "module1"
            pickled_ast_filename = os.path.join(d.path, "module1.pyi.pickled")
            module_map = self._StoreAst(d, module_name, pickled_ast_filename)
            original_ast = module_map[module_name]
            del module_map[module_name]
            loaded_ast = serialize_ast.ProcessAst(
                pytd_utils.LoadPickle(pickled_ast_filename), module_map)

            self.assertTrue(loaded_ast)
            self.assertTrue(loaded_ast is not original_ast)
            self.assertEqual(loaded_ast.name, module_name)
            self.assertTrue(original_ast.ASTeq(loaded_ast))
            loaded_ast.Visit(visitors.VerifyLookup())
Exemplo n.º 12
0
  def testLoadWithSameModuleName(self):
    with utils.Tempdir() as d:
      self._CreateFiles(tempdir=d)
      module1 = _Module(module_name="foo.bar.module1", file_name="module1.pyi")
      module2 = _Module(module_name="module2", file_name="module2.pyi")
      ast = self._LoadAst(tempdir=d, module=module1)
      self._PickleModules(d, module1, module2)
      pickled_ast_filename = self._GetPath(d, module1.file_name + ".pickled")
      result = serialize_ast.StoreAst(ast, pickled_ast_filename)
      self.assertTrue(result)

      loaded_ast = self._LoadPickledModule(d, module1)
      self.assertTrue(loaded_ast)
      self.assertTrue(loaded_ast is not ast)
      self.assertTrue(ast.ASTeq(loaded_ast))
      loaded_ast.Visit(visitors.VerifyLookup())
Exemplo n.º 13
0
  def testLoadWithDifferentModuleName(self):
    with utils.Tempdir() as d:
      original_module_name = "module1"
      pickled_ast_filename = os.path.join(d.path, "module1.pyi.pickled")
      module_map = self._StoreAst(d, original_module_name, pickled_ast_filename)
      original_ast = module_map[original_module_name]
      del module_map[original_module_name]

      new_module_name = "wurstbrot.module2"
      serializable_ast = pytd_utils.LoadPickle(pickled_ast_filename)
      serializable_ast = serialize_ast.EnsureAstName(
          serializable_ast, new_module_name)
      loaded_ast = serialize_ast.ProcessAst(serializable_ast, module_map)

      self.assertTrue(loaded_ast)
      self.assertTrue(loaded_ast is not original_ast)
      self.assertEqual(loaded_ast.name, new_module_name)
      loaded_ast.Visit(visitors.VerifyLookup())
      self.assertFalse(original_ast.ASTeq(loaded_ast))
      ast_new_module, _ = self._GetAst(temp_dir=d, module_name=new_module_name)
      self.assertTrue(ast_new_module.ASTeq(loaded_ast))
Exemplo n.º 14
0
    def testNodeIndexVisitorUsage(self):
        """Confirms that the node index is used.

    This removes the first node from the class_type_nodes list and checks that
    that node is not updated by ProcessAst.
    """
        with utils.Tempdir() as d:
            module_name = "module1"
            pickled_ast_filename = os.path.join(d.path, "module1.pyi.pickled")
            module_map = self._StoreAst(d, module_name, pickled_ast_filename)
            del module_map[module_name]
            serialized_ast = pytd_utils.LoadPickle(pickled_ast_filename)

            # The sorted makes the testcase more deterministic.
            serialized_ast = serialized_ast.Replace(
                class_type_nodes=sorted(serialized_ast.class_type_nodes)[1:])
            loaded_ast = serialize_ast.ProcessAst(serialized_ast, module_map)

            with self.assertRaisesRegexp(
                    ValueError, "Unresolved class: '__builtin__.NoneType'"):
                loaded_ast.Visit(visitors.VerifyLookup())
Exemplo n.º 15
0
    def testLoadWithSameModuleName(self):
        """Explicitly set the module name and reload with the same name.

    The difference to testLoadTopLevel is that the module name does not match
    the filelocation.
    """
        with utils.Tempdir() as d:
            module_name = "foo.bar.module1"
            pickled_ast_filename = os.path.join(d.path, "module1.pyi.pickled")
            module_map = self._StoreAst(d, module_name, pickled_ast_filename)
            original_ast = module_map[module_name]
            del module_map[module_name]

            loaded_ast = serialize_ast.ProcessAst(
                pytd_utils.LoadPickle(pickled_ast_filename), module_map)

            self.assertTrue(loaded_ast)
            self.assertTrue(loaded_ast is not original_ast)
            self.assertEqual(loaded_ast.name, "foo.bar.module1")
            self.assertTrue(original_ast.ASTeq(loaded_ast))
            loaded_ast.Visit(visitors.VerifyLookup())
Exemplo n.º 16
0
    def testUnrestorableChild(self):
        # Assume .cls in a ClassType X in module1 was referencing something for
        # which, Visitors.LookupExternalTypes returned AnythingType.
        # Now if something in module1 is referencing X external types need to be
        # resolved before local types, so that we can resolve local types to the
        # correct ClassType, as the ClassType instance changes, if .cls can not be
        # filled and instead AnythingType is used.

        class RenameVisitor(visitors.Visitor):
            def __init__(self, *args, **kwargs):
                super(RenameVisitor, self).__init__(*args, **kwargs)
                self._init = False

            def EnterFunction(self, func):
                if func.name == "__init__":
                    self._init = True
                    return None
                return False

            def LeaveFunction(self, func):
                self._init = False

            def VisitClassType(self, cls_type):
                if self._init:
                    cls_type = cls_type.Replace(
                        name="other_module.unknown_Reference")
                    # Needs to be copied manually as it is not part of the NamedTuple.
                    cls_type.cls = None
                return cls_type

        with utils.Tempdir() as d:
            src = ("""
        import other_module
        x = other_module.UnusedReferenceNeededToKeepTheImport

        class SomeClass(object):
          def __init__(will_be_replaced_with_visitor) -> None:
            pass

        def func(a:SomeClass) -> None:
          pass
      """)
            d.create_file(
                "other_module.pyi", """
          from typing import Any
          def __getattr__(self, name) -> Any: ...""")
            ast, loader = self._GetAst(temp_dir=d,
                                       module_name="module1",
                                       src=src)

            ast = ast.Visit(RenameVisitor())

            pickled_ast_filename = os.path.join(d.path, "module1.pyi.pickled")
            module_map = self._StoreAst(d,
                                        "module1",
                                        pickled_ast_filename,
                                        ast=ast,
                                        loader=loader)
            del module_map["module1"]

            serialized_ast = pytd_utils.LoadPickle(pickled_ast_filename)
            loaded_ast = serialize_ast.ProcessAst(serialized_ast, module_map)
            # Look up the "SomeClass" in "def func(a: SomeClass), then run
            # VerifyLookup on it. We can't run VerifyLookup on the root node, since
            # visitors don't descend into the "cls" attribute of ClassType.
            cls = loaded_ast.functions[0].signatures[0].params[0].type.cls
            cls.Visit(visitors.VerifyLookup())
Exemplo n.º 17
0
 def testGetBuiltinsPyTD(self):
     self.assertIsNotNone(self.builtins)
     # Will throw an error for unresolved identifiers:
     self.builtins.Visit(visitors.VerifyLookup())
Exemplo n.º 18
0
  def call(self, node, _, args):
    """Creates a namedtuple class definition.

    Performs the same argument checking as collections.namedtuple, e.g. making
    sure field names don't start with _ or digits, making sure no keywords are
    used for the typename or field names, and so on. Because the methods of the
    class have to be changed to match the number and names of the fields, we
    construct pytd.Function and pytd.Constant instances for each member of the
    class. Finally, the pytd.Class is wrapped in an abstract.PyTDClass.

    If incorrect arguments are passed, a subclass of abstract.FailedFunctionCall
    will be raised. Other cases may raise abstract.ConversionError exceptions,
    such as when the arguments are in unicode or any of the arguments have
    multiple bindings, but these are caught and return Any. This also occurs if
    an argument to namedtuple is invalid, e.g. a keyword is used as a field name
    and rename is False.

    Arguments:
      node: the current CFG node
      _: the func binding, ignored.
      args: an abstract.FunctionArgs instance

    Returns:
      a tuple of the given CFG node and an abstract.PyTDClass instance (wrapped
      in a Variable) representing the constructed namedtuple class.
      If a abstract.ConversionError occurs or if field names are invalid, this
      function returns Unsolvable (in a Variable) instead of a PyTDClass.

    Raises:
      abstract.FailedFunctionCall: Raised by _getargs if any of the arguments
        do not match the function signature.
    """
    # If we can't extract the arguments, we take the easy way out and return Any
    try:
      name_var, field_names, rename = self._getargs(node, args)
    except abstract.ConversionError:
      return node, self.vm.convert.unsolvable.to_variable(node)

    # We need the bare name for a few things, so pull that out now.
    # The same unicode issue can strike here, so again return Any.
    try:
      name = abstract.get_atomic_python_constant(name_var)
    except abstract.ConversionError:
      return node, self.vm.convert.unsolvable.to_variable(node)

    # namedtuple does some checking and optionally renaming of field names,
    # so we do too.
    try:
      field_names = self._validate_and_rename_args(name, field_names, rename)
    except ValueError as e:
      self.vm.errorlog.invalid_namedtuple_arg(self.vm.frames, e.message)
      return node, self.vm.convert.unsolvable.to_variable(node)

    name = namedtuple_name(name, field_names)
    ast = namedtuple_ast(name, field_names,
                         python_version=self.vm.python_version)
    mapping = self._get_known_types_mapping()

    # A truly well-formed pyi for the namedtuple will have references to the new
    # namedtuple class itself for all `self` params and as the return type for
    # methods like __new__, _replace and _make. In order to do that, we need a
    # ClassType.
    cls_type = pytd.ClassType(name)
    mapping[name] = cls_type

    cls = ast.Lookup(name).Visit(visitors.ReplaceTypes(mapping))
    cls_type.cls = cls

    # Make sure all NamedType nodes have been replaced by ClassType nodes with
    # filled cls pointers.
    cls.Visit(visitors.VerifyLookup())

    # We can't build the PyTDClass directly, and instead must run it through
    # convert.constant_to_value first, for caching.
    instance = self.vm.convert.constant_to_value(cls, {}, self.vm.root_cfg_node)
    self.vm.trace_namedtuple(instance)
    return node, instance.to_variable(node)
Exemplo n.º 19
0
 def _verify_ast(self, ast):
     try:
         ast.Visit(visitors.VerifyLookup())
     except ValueError as e:
         raise BadDependencyError(e.message)
     ast.Visit(visitors.VerifyContainers())