You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@beam.apache.org by Beam Jira Bot <ji...@apache.org> on 2022/01/16 16:58:00 UTC

P1 issues report (65)

This is your daily summary of Beam's current P1 issues, not including flaky tests (https://issues.apache.org/jira/issues/?jql=project%20%3D%20BEAM%20AND%20statusCategory%20!%3D%20Done%20AND%20priority%20%3D%20P1%20AND%20(labels%20is%20EMPTY%20OR%20labels%20!%3D%20flake).

See https://beam.apache.org/contribute/jira-priorities/#p1-critical for the meaning and expectations around P1 issues.

    https://issues.apache.org/jira/browse/BEAM-13668: Java Spanner IO Request Count metrics broke backwards compatibility (created 2022-01-15)
    https://issues.apache.org/jira/browse/BEAM-13665: Spanner IO request metrics requires projectId within the config when it didn't in the past (created 2022-01-14)
    https://issues.apache.org/jira/browse/BEAM-13616: Update protobuf-java to 3.19.2 and other vendored dependencies that use protobuf (created 2022-01-08)
    https://issues.apache.org/jira/browse/BEAM-13615: Bumping up FnApi environment version to 9 in Java, Python SDK (created 2022-01-07)
    https://issues.apache.org/jira/browse/BEAM-13611: CrossLanguageJdbcIOTest.test_xlang_jdbc_write failing in Python PostCommits (created 2022-01-07)
    https://issues.apache.org/jira/browse/BEAM-13606: bigtable io doesn't handle non-ok row mutations (created 2022-01-07)
    https://issues.apache.org/jira/browse/BEAM-13598: Install Java 17 on Jenkins VM (created 2022-01-04)
    https://issues.apache.org/jira/browse/BEAM-13582: Beam website precommit mentions broken links, but passes. (created 2021-12-30)
    https://issues.apache.org/jira/browse/BEAM-13579: Cannot run python_xlang_kafka_taxi_dataflow validation script on 2.35.0 (created 2021-12-29)
    https://issues.apache.org/jira/browse/BEAM-13522: Spark tests failing PerKeyOrderingTest (created 2021-12-22)
    https://issues.apache.org/jira/browse/BEAM-13504: Remove provided/compileOnly deps not intended for external use (created 2021-12-21)
    https://issues.apache.org/jira/browse/BEAM-13503: BulkIO public constructor: Missing required property: throwWriteErrors (created 2021-12-21)
    https://issues.apache.org/jira/browse/BEAM-13487: WriteToBigQuery Dynamic table destinations returns wrong tableId (created 2021-12-17)
    https://issues.apache.org/jira/browse/BEAM-13430: Upgrade Gradle version to 7.3 (created 2021-12-09)
    https://issues.apache.org/jira/browse/BEAM-13393: GroupIntoBatchesTest is failing (created 2021-12-07)
    https://issues.apache.org/jira/browse/BEAM-13237: org.apache.beam.sdk.transforms.CombineTest$WindowingTests.testWindowedCombineGloballyAsSingletonView flaky on Dataflow Runner V2 (created 2021-11-12)
    https://issues.apache.org/jira/browse/BEAM-13213: OnWindowExpiration does not work without other state (created 2021-11-10)
    https://issues.apache.org/jira/browse/BEAM-13203: Potential data loss when using SnsIO.writeAsync (created 2021-11-08)
    https://issues.apache.org/jira/browse/BEAM-13164: Race between member variable being accessed due to leaking uninitialized state via OutboundObserverFactory (created 2021-11-01)
    https://issues.apache.org/jira/browse/BEAM-13132: WriteToBigQuery submits a duplicate BQ load job if a 503 error code is returned from googleapi (created 2021-10-27)
    https://issues.apache.org/jira/browse/BEAM-13087: apache_beam.runners.portability.fn_api_runner.translations_test.TranslationsTest.test_run_packable_combine_globally 'apache_beam.coders.coder_impl._AbstractIterable' object is not reversible (created 2021-10-20)
    https://issues.apache.org/jira/browse/BEAM-13078: Python DirectRunner does not emit data at GC time (created 2021-10-18)
    https://issues.apache.org/jira/browse/BEAM-13076: Python AfterAny, AfterAll do not follow spec (created 2021-10-18)
    https://issues.apache.org/jira/browse/BEAM-13010: Delete orphaned files (created 2021-10-06)
    https://issues.apache.org/jira/browse/BEAM-12995: Consumer group with random prefix (created 2021-10-04)
    https://issues.apache.org/jira/browse/BEAM-12959: Dataflow error in CombinePerKey operation (created 2021-09-26)
    https://issues.apache.org/jira/browse/BEAM-12867: Either Create or DirectRunner fails to produce all elements to the following transform (created 2021-09-09)
    https://issues.apache.org/jira/browse/BEAM-12843: (Broken Pipe induced) Bricked Dataflow Pipeline  (created 2021-09-06)
    https://issues.apache.org/jira/browse/BEAM-12807: Java creates an incorrect pipeline proto when core-construction-java jar is not in the CLASSPATH (created 2021-08-26)
    https://issues.apache.org/jira/browse/BEAM-12799: "Java IO IT Tests" - missing data in grafana (created 2021-08-25)
    https://issues.apache.org/jira/browse/BEAM-12792: Beam worker only installs --extra_package once (created 2021-08-24)
    https://issues.apache.org/jira/browse/BEAM-12632: ElasticsearchIO: Enabling both User/Pass auth and SSL overwrites User/Pass (created 2021-07-16)
    https://issues.apache.org/jira/browse/BEAM-12621: Update Jenkins VMs to modern Ubuntu version (created 2021-07-15)
    https://issues.apache.org/jira/browse/BEAM-12525: SDF BoundedSource seems to execute significantly slower than 'normal' BoundedSource (created 2021-06-22)
    https://issues.apache.org/jira/browse/BEAM-12505: codecov/patch has poor behavior (created 2021-06-17)
    https://issues.apache.org/jira/browse/BEAM-12500: Dataflow SocketException (SSLException) error while trying to send message from Cloud Pub/Sub to BigQuery (created 2021-06-16)
    https://issues.apache.org/jira/browse/BEAM-12484: JdbcIO date conversion is sensitive to OS (created 2021-06-14)
    https://issues.apache.org/jira/browse/BEAM-12467: java.io.InvalidClassException With Flink Kafka (created 2021-06-09)
    https://issues.apache.org/jira/browse/BEAM-12279: Implement destination-dependent sharding in FileIO.writeDynamic (created 2021-05-04)
    https://issues.apache.org/jira/browse/BEAM-12256: PubsubIO.readAvroGenericRecord creates SchemaCoder that fails to decode some Avro logical types (created 2021-04-29)
    https://issues.apache.org/jira/browse/BEAM-11959: Python Beam SDK Harness hangs when installing pip packages (created 2021-03-11)
    https://issues.apache.org/jira/browse/BEAM-11906: No trigger early repeatedly for session windows (created 2021-03-01)
    https://issues.apache.org/jira/browse/BEAM-11875: XmlIO.Read does not handle XML encoding per spec (created 2021-02-26)
    https://issues.apache.org/jira/browse/BEAM-11828: JmsIO is not acknowledging messages correctly (created 2021-02-17)
    https://issues.apache.org/jira/browse/BEAM-11755: Cross-language consistency (RequiresStableInputs) is quietly broken (at least on portable flink runner) (created 2021-02-05)
    https://issues.apache.org/jira/browse/BEAM-11578: `dataflow_metrics` (python) fails with TypeError (when int overflowing?) (created 2021-01-06)
    https://issues.apache.org/jira/browse/BEAM-11148: Kafka commitOffsetsInFinalize OOM on Flink (created 2020-10-28)
    https://issues.apache.org/jira/browse/BEAM-11017: Timer with dataflow runner can be set multiple times (dataflow runner) (created 2020-10-05)
    https://issues.apache.org/jira/browse/BEAM-10670: Make non-portable Splittable DoFn the only option when executing Java "Read" transforms (created 2020-08-10)
    https://issues.apache.org/jira/browse/BEAM-10617: python CombineGlobally().with_fanout() cause duplicate combine results for sliding windows (created 2020-07-31)
    https://issues.apache.org/jira/browse/BEAM-10569: SpannerIO tests don't actually assert anything. (created 2020-07-23)
    https://issues.apache.org/jira/browse/BEAM-10529: Kafka XLang fails for ?empty? key/values (created 2020-07-18)
    https://issues.apache.org/jira/browse/BEAM-10295: FileBasedSink: allow setting temp directory provider per dynamic destination (created 2020-06-22)
    https://issues.apache.org/jira/browse/BEAM-10288: Quickstart documents are out of date (created 2020-06-19)
    https://issues.apache.org/jira/browse/BEAM-10100: FileIO writeDynamic with AvroIO.sink not writing all data (created 2020-05-27)
    https://issues.apache.org/jira/browse/BEAM-9564: Remove insecure ssl options from MongoDBIO (created 2020-03-20)
    https://issues.apache.org/jira/browse/BEAM-9482: beam_PerformanceTests_Kafka_IO failing due to " provided port is already allocated" (created 2020-03-10)
    https://issues.apache.org/jira/browse/BEAM-9455: Environment-sensitive provisioning for Dataflow (created 2020-03-05)
    https://issues.apache.org/jira/browse/BEAM-9293: Python direct runner doesn't emit empty pane when it should (created 2020-02-11)
    https://issues.apache.org/jira/browse/BEAM-8985: SortValues should fail if SecondaryKey coder is not deterministic (created 2019-12-17)
    https://issues.apache.org/jira/browse/BEAM-8407: [SQL] Some Hive tests throw NullPointerException, but get marked as passing (Direct Runner) (created 2019-10-15)
    https://issues.apache.org/jira/browse/BEAM-7996: Add support for remaining data types in python RowCoder  (created 2019-08-16)
    https://issues.apache.org/jira/browse/BEAM-7716: PubsubIO returns empty message bodies for all messages read (created 2019-07-10)
    https://issues.apache.org/jira/browse/BEAM-6839: User reports protobuf ClassChangeError running against 2.6.0 or above (created 2019-03-15)
    https://issues.apache.org/jira/browse/BEAM-6466: KafkaIO doesn't commit offsets while being used as bounded source (created 2019-01-18)