github.com/apache/beam/sdks/v2@v2.48.2/python/mypy.ini (about)

     1  #
     2  # Licensed to the Apache Software Foundation (ASF) under one or more
     3  # contributor license agreements.  See the NOTICE file distributed with
     4  # this work for additional information regarding copyright ownership.
     5  # The ASF licenses this file to You under the Apache License, Version 2.0
     6  # (the "License"); you may not use this file except in compliance with
     7  # the License.  You may obtain a copy of the License at
     8  #
     9  #    http://www.apache.org/licenses/LICENSE-2.0
    10  #
    11  # Unless required by applicable law or agreed to in writing, software
    12  # distributed under the License is distributed on an "AS IS" BASIS,
    13  # WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    14  # See the License for the specific language governing permissions and
    15  # limitations under the License.
    16  #
    17  
    18  [mypy]
    19  python_version = 3.7
    20  ignore_missing_imports = true
    21  follow_imports = normal
    22  warn_no_return = true
    23  no_implicit_optional = true
    24  warn_redundant_casts = true
    25  warn_unused_ignores = true
    26  show_error_codes = true
    27  files = apache_beam
    28  color_output = true
    29  # uncomment this to see how close we are to being complete
    30  # check_untyped_defs = true
    31  
    32  [mypy-apache_beam.coders.proto2_coder_test_messages_pb2]
    33  ignore_errors = true
    34  
    35  [mypy-apache_beam.examples.*]
    36  ignore_errors = true
    37  
    38  [mypy-apache_beam.io.gcp.gcsfilesystem_test]
    39  # error: Cannot infer type of lambda  [misc]
    40  ignore_errors = true
    41  
    42  [mypy-apache_beam.io.gcp.internal.clients.storage.storage_v1_client]
    43  ignore_errors = true
    44  
    45  [mypy-apache_beam.io.gcp.internal.clients.bigquery.bigquery_v2_client]
    46  ignore_errors = true
    47  
    48  [mypy-apache_beam.portability.api.*]
    49  ignore_errors = true
    50  
    51  [mypy-apache_beam.runners.dataflow.internal.clients.dataflow.dataflow_v1b3_client]
    52  ignore_errors = true
    53  
    54  [mypy-apache_beam.typehints.typed_pipeline_test_py3]
    55  # error: Signature of "process" incompatible with supertype "DoFn"  [override]
    56  ignore_errors = true
    57  
    58  [mypy-apache_beam.typehints.typehints_test_py3]
    59  # error: Signature of "process" incompatible with supertype "DoFn"  [override]
    60  ignore_errors = true
    61  
    62  
    63  # TODO(https://github.com/apache/beam/issues/19737): Remove the lines below.
    64  
    65  [mypy-apache_beam.io.*]
    66  ignore_errors = true
    67  
    68  [mypy-apache_beam.io.filesystem]
    69  ignore_errors = false
    70  
    71  [mypy-apache_beam.io.iobase]
    72  ignore_errors = false
    73  
    74  [mypy-apache_beam.ml.gcp.*]
    75  ignore_errors = true
    76  
    77  [mypy-apache_beam.pipeline]
    78  ignore_errors = true
    79  
    80  [mypy-apache_beam.pvalue]
    81  ignore_errors = true
    82  
    83  [mypy-apache_beam.runners.common]
    84  ignore_errors = true
    85  
    86  [mypy-apache_beam.runners.dataflow.dataflow_runner]
    87  ignore_errors = true
    88  
    89  [mypy-apache_beam.runners.direct.*]
    90  ignore_errors = true
    91  
    92  [mypy-apache_beam.runners.dask.*]
    93  ignore_errors = true
    94  
    95  [mypy-apache_beam.runners.interactive.*]
    96  ignore_errors = true
    97  
    98  [mypy-apache_beam.testing.synthetic_pipeline]
    99  ignore_errors = true
   100  
   101  [mypy-apache_beam.testing.test_stream]
   102  ignore_errors = true
   103  
   104  
   105  [mypy-apache_beam.typehints.*]
   106  ignore_errors = true