Skip to content

Conversation

@victor09091
Copy link
Contributor

What is the purpose of the change

(We could make CI fail earlier when download fails.)

Brief change log

  • backports 1.17,modify common_kubernetes.sh

Does this pull request potentially affect one of the following parts:

  • Dependencies (does it add or upgrade a dependency): (no)
  • The public API, i.e., is any changed class annotated with @Public(Evolving): (no)
  • The serializers: (no)
  • The runtime per-record code paths (performance sensitive): (no)
  • Anything that affects deployment or recovery: JobManager (and its components), Checkpointing, Kubernetes/Yarn, ZooKeeper: (no)
  • The S3 file system connector: (no)

Documentation

  • Does this pull request introduce a new feature? no)
  • If yes, how is the feature documented? (not applicable)

Myasuka and others added 30 commits March 6, 2023 18:12
…ger constructor and mark it as deprecated

This closes apache#22094.
…sk manager in FineGrainedSlotManagerTest.

We use TaskManagerTracker.addPendingTaskManager to allocate task manager
in FineGrainedSlotManagerTest. This make the resource requirements
different between FineGrainedSlotManager and TaskManagerTracker. And the
FineGrainedSlotManager may trigger resource recycling after the requirementCheckDelay.

So we use processResourceRequirements to allocate task manager. And set
the requirementCheckDelay to 0 to stabilize this test.

(cherry picked from commit bec6a45)
…ns in column list of a partial-insert statement

This closes apache#22109
…leUp timing out.

We're starting TMs with two slots, and in case both slots don't arrive simultaneously, we might have an additional restart of the job. Unfortunately calling OnceBlockingNoOpInvokable#cancel would effectively unblock all future #invoke calls by setting the running flag to true. We address the issue by tracking this flag for each execution attempt separately.
… causes issues with Hugo version 0.111.0 and higher. This closes apache#22113

(cherry picked from commit 3ea83ba)
…eadSchedulerTest#testRequestTimeoutIsRefreshedAndSuccess.

(cherry picked from commit a306831)
…f numRequestedBuffers is greater than 0.

This will cause deadlock as read buffer was occupied by a reader with low consumption priority.

This closes apache#22122

(cherry picked from commit 5ad2ae2)
…tLocalHostThrows swallows IllegalArgumentException
…rtitionGroup if it has too many consumers

This closes apache#22098.
…huffle

Currently, the SortMergeResultPartition may allocate more network buffers than the guaranteed size of the LocalBufferPool. As a result, some result partitions may need to wait other result partitions to release the over-allocated network buffers to continue. However, the result partitions which have allocated more than guaranteed buffers relies on the processing of input data to trigger data spilling and buffer recycling. The input data further relies on batch reading buffers used by the SortMergeResultPartitionReadScheduler which may already taken by those blocked result partitions that are waiting for buffers. Then deadlock occurs. This patch fixes the deadlock issue by reserving the guaranteed buffers on initializing.

This closes apache#22148.
…" from table header of operator IDs

This closes apache#22164.

Co-authored-by: jingge <gejing@gmail.com>
…wnload links on the the FileSystem documentation. This closes apache#22039

Remove Scala suffix for ORC and Parquet format download links on the the FileSystem documentation

(cherry picked from commit a8848f8)
…artitionReadSchedulerTest.testRequestBufferTimeout

This closes apache#22172.
…t#testShutDown.

testShutDown using two gateways contains a timeout gateway but expected all request futures not done before shutdown. If the timeout reached, this future will be failed, result in request future to be done.
…ngly pushed down and get wrong join results

This closes apache#22049

(cherry picked from commit 8990822)
…P function for different argument formats

This closes apache#22187.
…that by default everything is included.

This resolves the accidental exclusion of Guava, causing Avro Confluent Schema Registry to fail.
…ryIntervalMs error condition check cause bounded source can not quit
mimaomao and others added 25 commits August 25, 2023 08:35
Signed-off-by: Maomao Min <mimaomao@amazon.com>
…e checks

The version and offset check is not really necessary for the server-side processing because it's
verifying test code (the ServerThread handles the forwarding of the version and the setting of the
offset). Therefore, we can also remove those checks.
…improve its testability

Additionally, a few new test scenarios were added to CollectSinkOperatorCoordinatorTest and SocketConnection was introduced
…oint together for NotifyCheckpointAbortedITCase#testNotifyCheckpointAborted (apache#23333)

(cherry picked from commit 66cc21d)
…tExecutorExtension instead of using a ThreadFactory
…ecutorExtension instead of using a ThreadFactory
…torExtension instead of using a ThreadFactory
The instability is caused by the timeout. The fatal error hides the actual cause (i.e. the TimeoutException). It can be reproduced by setting the timeout of the test to 0ms. The actual cause is revealed when disabling the fatal error handling or not throwing a AssertionError in case of the fatal error.
… establish ssl connection to github on AZP
@flinkbot
Copy link
Collaborator

flinkbot commented Nov 1, 2023

CI report:

Bot commands The @flinkbot bot supports the following commands:
  • @flinkbot run azure re-run the last Azure build

Sign up for free to join this conversation on GitHub. Already have an account? Sign in to comment

Projects

None yet

Development

Successfully merging this pull request may close these issues.