https://github.com/apache/flink

sort by:
Revision Author Date Message Commit Date
84c1bd4 [FLINK-27760][python] Fix the issue that NPE is thrown when executing PyFlink Table API jobs in batch mode This closes #19816. 26 May 2022, 01:07:44 UTC
be969dd [hotfix][docs] Fix StringDeserializer typo 11 May 2022, 12:25:20 UTC
79a86f3 [FLINK-22984][python] Don't pushdown Calc containing Python UDFs into table source This closes #19551. 22 April 2022, 14:38:15 UTC
66d8960 [FLINK-27108][python] Fix the state cache clean up logic This closes #19386. 07 April 2022, 11:03:56 UTC
f3a8af5 [FLINK-26460][table-planner] Fix Unsupported type when convertTypeToSpec: MAP (cherry picked from commit 33e7c84fb0f6aadf9d228c41c0ba6808634a7e36) This closes #18967 31 March 2022, 09:48:01 UTC
c9b98fd Revert "[FLINK-26708] TimestampsAndWatermarksOperator should not propagate WatermarkStatus" This reverts commit 1e723c568a76d6b37b08404575878a320f5c7f82. 29 March 2022, 11:01:54 UTC
1e723c5 [FLINK-26708] TimestampsAndWatermarksOperator should not propagate WatermarkStatus 28 March 2022, 08:19:24 UTC
b71eb20 [hotfix][WebUI] Add .angular to .gitignore Ease backports by excluding a large directory that exists in later versions. 25 March 2022, 08:37:49 UTC
88ccdf1 [FLINK-26855][python] Fix Sphinx check failure caused by Jinja2 dependency (#19238) 25 March 2022, 04:13:06 UTC
aa8057e [FLINK-26846][python] Fix the gauge metric This closes #19226. 25 March 2022, 01:26:00 UTC
ee17a23 [hotfix][python][docs] Fix the example in intro_to_datastream_api 24 March 2022, 09:05:25 UTC
9abd874 [FLINK-26536][python] Fix RemoteKeyedStateBackend#merge_namespaces to handle properly for the timerservice This closes #19173. (cherry picked from commit a54c11040dd0103ffce5146a09a2ab6103134906) 22 March 2022, 12:04:50 UTC
0a89a59 [FLINK-26775][python] WindowOperator#process_element registers wrong cleanup timer This closes #19186. 22 March 2022, 07:17:11 UTC
c87417e [hotfix][python][docs] Improve the documentation about how to specify jar files on Windows 17 March 2022, 12:56:45 UTC
7c50872 [FLINK-26658][docs] Remove workflow file 16 March 2022, 22:28:39 UTC
1145341 [FLINK-26658][docs] Migrate documentation build to Github Actions 16 March 2022, 20:47:21 UTC
7315265 [hotfix] [docs] set Flink version to 1.13.6 in docs 15 March 2022, 11:50:41 UTC
2a15802 [FLINK-25771][cassandra][tests] Remove keyspace drop Since each test uses a separate table we no longer need to re-create the keyspace for each run, reducing the load on the cluster. 15 March 2022, 10:07:20 UTC
98c20ce [FLINK-15550][runtime] Debug logging for TaskTest (cherry picked from commit 16e9b7325881b45741f3591f73a7b7bcfd39322b) 10 March 2022, 10:03:51 UTC
66f3c90 [FLINK-26352][runtime-web] Add missing license headers to WebUI source files 09 March 2022, 15:34:21 UTC
7a0f5ea [FLINK-25771][cassandra][tests] Raise client timeouts 09 March 2022, 11:28:05 UTC
c4cafa3 [FLINK-23843][runtime] Properly fail the job when SplitEnumeratorContext.runInCoordinatorThread() throws an exception. Now that coordinatorExecutor is a ScheduledExecutorService, UncaughtExceptionHandler is useful only for exception raised by the threadPool as the JVM now uses a ScheduledFutureTask that catches exceptions in its run method. Manually catch the exceptions and call the exception handler. 09 March 2022, 09:44:18 UTC
812e674 [FLINK-26504][python] Fix the incorrect type error in unbounded Python UDAF 07 March 2022, 12:36:19 UTC
f754870 [FLINK-20633][python] Add retry times to download avro This closes #18954. 07 March 2022, 02:56:47 UTC
0bfb320 [FLINK-26407][end-to-end-tests] Increase timeouts for MetricsAvailabilityITCase. 03 March 2022, 12:29:30 UTC
f344cc5 [FLINK-26223] Updates log4j configuration This change moves ZK-related log output into a dedicated file and enables INFO logging for ZK again to determine instabilities. 02 March 2022, 15:28:05 UTC
167f71d [hotfix][docs][table] Fix docs for SHA1 01 March 2022, 15:27:40 UTC
ef75b87 [FLINK-26285] Fixes an inconsistency which was introduced by c3a6b51 as part of changes done for FLINK-19543 This issue never appeared because of the following reasons: - getAllAndLock is only called by the CompletedCheckpoint recovery which happens during the recovery of a job (i.e. after failover) - the removal happens through releaseAndTryRemove which can be called in the following places: - through DefaultCompletedCheckpointStore.addCheckpointAndSubsumeOldestOne That happens after a job is already recovered and running - through DefaultCompletedCheckpointStore.shutdown ...where it's only called if the job reached a globally-terminal state (i.e. it's not subject to job recovery) - through DefaultJobGraphStore.globalCleanupAsync ...which is also only called on jobs that reached a globally-terminal state (i.e. it's not subject to job recovery) - ZooKeeperStateHandleStore.releaseAndTryRemoveAll ...which seems to be legacy code which is not used anywhere in production, anymore. I'm leaving it here because it might make sense to remove ZooKeeper completely, anyway. 28 February 2022, 07:40:34 UTC
6fb7807 [FLINK-24607] Make OperatorCoordinator closure more robust. 23 February 2022, 02:33:18 UTC
0774fed [FLINK-24607] Add util methods to shutdown executor services. 23 February 2022, 02:33:18 UTC
e2a8990 [FLINK-24607] Let Deadline handle duration overflow. 23 February 2022, 02:33:18 UTC
965774c [FLINK-25851][cassandra][tests] Inject dynamic table name into Pojos 21 February 2022, 17:39:05 UTC
42db40c [FLINK-25851][build][tests] Bump bytebuddy to 1.8.22 21 February 2022, 17:38:18 UTC
b0d0a00 [FLINK-25227][table] Boxed numeric type should be considered when generating code for equality checking This closes #18743 21 February 2022, 02:33:49 UTC
3d22d95 Update japicmp configuration for 1.13.6 18 February 2022, 13:17:19 UTC
b3e520d [FLINK-26105][e2e] Fixes log file extension Rolling log file naming strategy is enabled by default which might cause test instabilities do to the relevant substring not being present in the *.log file. This change expands the grep and find calls to also consider *.log.[0-9]+ files. 18 February 2022, 08:50:17 UTC
f445136 [FLINK-26105][e2e] Removes printing of logs to stdout for pyflink_test I removed the test_pyflink.sh to align it with how errors are handled in other e2e tests. The logs are accessible through the build artifacts and shouldn't spill into stdout. The rolling filenames in flink might lead to a strange ordering anyway. 18 February 2022, 08:50:17 UTC
f71cbb9 [FLINK-25883][python] Set the default value of DEFAULT_BUNDLE_PROCESSOR_CACHE_SHUTDOWN_THRESHOLD_S to 30 days 14 February 2022, 03:54:27 UTC
ab86ffa [FLINK-25466][state] Enable state descriptor to handle StateTtlConfig#DISABLED 14 February 2022, 02:17:19 UTC
91a1811 [FLINK-25785][Connectors][JDBC] Upgrade com.h2database:h2 to 2.1.210 (cherry picked from commit 8488b9e110baec5ed31c3e62d72ff3eceaab721c) Signed-off-by: martijnvisser <martijn@2symbols.com> 12 February 2022, 07:51:26 UTC
cff3939 [FLINK-25041][e2e] Improve error handling for missing environment variables in E2E tests There are several points where the E2E tests check that an environment variable is nonempty before proceeding with the tests, such as the E2E_TARBALL_CACHE. Usually, this results in a friendly error message stating "You have to export the E2E Tarball Cache as E2E_TARBALL_CACHE". However, if running the scripts with nounset during development, this results in an `E2E_TARBALL_CACHE: unbound variable` error, which is less friendly to the user. This PR changes these instances to use parameter expansion for these variables, so that even with nounset, the user recieves the friendly error message for a missing environment variable. (cherry picked from commit 8bd978683f76b691d7edbf4f5eba5f7a9f690672) 09 February 2022, 14:30:01 UTC
ace49aa [FLINK-26039][table-runtime] Fix the incorrect value getter in map unnest table function This closes #18679. 09 February 2022, 13:39:52 UTC
e12ad75 [FLINK-25952] Savepoints on S3 are not relocatable even if entropy injection is not enabled We treat all filesystems that extend from EntropyInjectingFileSystem as if they always inject entropy. However, we support returning null from EntropyInjectingFileSystem#getEntropyInjectionKey which translates to disabled entropy injections. In such cases we should support savepoints relocation by creating relative paths for exclusive files. 07 February 2022, 11:53:24 UTC
ab70e9b [FLINK-25879][Docs] Track used search terms in Matomo 07 February 2022, 09:28:27 UTC
695372c [FLINK-21752] Add a call to TypeSerializer#duplicate in migration tests We should verify that a TypeSerializer even after migration can be safely duplicated. In order to do that we can duplicate a new serializer in the TypeSerializerUpgradeTestBase before we try to use for deserialization. 04 February 2022, 12:02:22 UTC
3d2329e [FLINK-21752] NullPointerException on restore in PojoSerializer In order to support Pojo schema migration, we added a new ctor to the PojoSerializer, which uses data extracted from a snapshot. However the duplicate method still used the old ctor which tries to recreate parts of the data from the current context. We should use the same ctor as we use for schema migration in the duplicate methods. We must make sure though all serializers are properly duplicated. 04 February 2022, 12:02:22 UTC
7012130 [FLINK-25653][network] Move buffer recycle in SortMergeSubpartitionReader out of lock to avoid deadlock For the current sort-shuffle implementation, the different lock orders in SortMergeSubpartitionReader and SortMergeResultPartitionReadScheduler may cause deadlock. To solve the problem, this change moves buffer recycle in SortMergeSubpartitionReader out of the lock. This closes #18551. 04 February 2022, 05:39:51 UTC
ca8dbcd [FLINK-21788][network] Throw PartitionNotFoundException if the partition file has been lost for blocking shuffle Currently, if the partition file has been lost for blocking shuffle, FileNotFoundException will be thrown and the partition data will not be regenerated. This change makes it throw PartitionNotFoundException instead. This closes #18515. 04 February 2022, 02:49:56 UTC
1ba923c [FLINK-18356][tests] Disable fork-reuse for table-planner 03 February 2022, 09:44:17 UTC
8ed9524 [FLINK-25880][docs] Add Matomo tracking code to base layout 02 February 2022, 12:10:16 UTC
0191401 [FLINK-25880][docs] Remove Google Analytics implementation 02 February 2022, 12:10:16 UTC
10a30f6 [FLINK-25771][connectors][Cassandra][test] Add a test that raiseCassandraRequestsTimeouts indeed changes the configuration inside the container. (cherry picked from commit 3144fae0dc8f3ef4b2ed6a8da4cdff920bcc4128) 01 February 2022, 12:41:30 UTC
1288b75 [FLINK-25771][connectors][Cassandra][test] Raise all read/write/miscellaneous requests timeouts 01 February 2022, 12:41:30 UTC
58b70f9 [FLINK-25147][connectors][Cassandra][test] Use parent test containers version (cherry picked from commit c5483c684e668010a607b5b97618d22be66d1d55) 01 February 2022, 12:41:30 UTC
91e3acf [FLINK-25818][Docs][Kafka] Add explanation how Kafka Source deals with idleness when parallelism is higher then the number of partitions 01 February 2022, 08:54:37 UTC
9653999 [FLINK-25728][task] Simplify MultipleInputAvailabilityHelper 31 January 2022, 16:31:49 UTC
41dec90 [FLINK-25728][task] Avoid unnessesary CompletableFuture.thenRun calls on idle inputProcessor's avaiableFuture, preventing memory leaks. 31 January 2022, 16:31:03 UTC
fe5a171 [FLINK-25486][Runtime/Coordination] Fix the bug that flink will lost state when zookeeper leader changes This closes #18560. 30 January 2022, 16:21:32 UTC
5c0af53 [FLINK-25278][ci] Use Maven proxy for confluent repo 25 January 2022, 11:09:54 UTC
16feba6 [FLINK-25683][table] Pass MAX_WATERMARK in InputConversionOperator MAX_WATERMARK emitted automatically has a special handling e.g. in BATCH runtime mode. It flushes remaining records at the end of processing. Therefore we should not discard those when converting to a Table pipeline. This closes #18405 24 January 2022, 16:02:10 UTC
1152293 [FLINK-25732][coordination] Pass serializable collection 24 January 2022, 09:52:30 UTC
e778992 [FLINK-24334][k8s] Set FLINK_LOG_DIR environment for JobManager and TaskManager pod if configured via options This closes #18436. 24 January 2022, 02:37:26 UTC
69075ed [FLINK-25674][connectors][cassandra][tests] use constants instead of string literals to avoid copy/paste 21 January 2022, 11:35:41 UTC
26fb7a2 [FLINK-25674][connectors][cassandra][tests] Add drop tables to be idempotent in case of retrials and the related test 21 January 2022, 11:35:40 UTC
ee93467 [hotfix] Fix spotless violation 21 January 2022, 11:35:09 UTC
9c1bf6c [FLINK-25199][network] Make sure StreamEdges are unique Previously, if there was a node that was self-unioned with itself, it was creating a situation with two identical StreamEdges. Both with the same partitioning, from the same source node to the same target node. This was causing issues when constructing output collectors and picking the correct RecordWriters, as StreamTask was not able to uniquely identify given StreamEdge and was assigning the same RecordWriter to both of the edges. As a result all stream elements were sent twice through the same RecordWriter. It was actually pretty harmless apart of calculating the combined watermark downstream, since all watermarks were always comming just from one single edge/inputgate, and the unused edges were always stuck with min watermark. As a solution we are making sure that StreamEdges are unique by introducing a uniqueId field, incremented for every pair of StreamEdges connecting the same node. 21 January 2022, 09:17:30 UTC
5e15418 [FLINK-25633] Set locale to en-US to avoid ambiguous decimal formattings This commit sets the locale to en-US in order to avoid ambiguous decimal formattings that can cause the CPUResourceTest to fail. This closes #18390. 19 January 2022, 10:55:36 UTC
f0df0e5 [FLINK-25611][core] Remove CoordinatorExecutorThreadFactory thread creation guards 18 January 2022, 09:09:35 UTC
90b48cb [FLINK-25160][docs] Clarified purpose of execution.checkpointing.tolerable-failed-checkpoints 14 January 2022, 15:08:53 UTC
98275f9 [FLINK-25280][connector/kafka] Disable log deletion in KafkaTestEnvironmentImpl to prevent records from being deleted during test run 12 January 2022, 14:30:18 UTC
74a4351 [FLINK-25576][Connectors][JDBC] Upgrade com.h2database:h2 to 2.0.206 11 January 2022, 08:54:46 UTC
e3d06b8 [FLINK-25362][docs] fix maven instructions for "Confluent Avro Format" 11 January 2022, 08:05:39 UTC
06ab1ec [FLINK-25362][docs] fix the Avro Format maven dependency It was falsely pointing to the shaded sql artifact. 11 January 2022, 08:05:39 UTC
327113d [FLINK-25362][docs] allow SQL maven artifact list If a connector needs more than one maven dependency, these can instead be defined as a list/array now. The old syntax with a single string is also still possible. 11 January 2022, 08:05:39 UTC
86a6e2b [FLINK-25307][test] Print the curl logs is querying dispatcher startup failed This closes #18298. 08 January 2022, 12:23:43 UTC
1dc9faf [FLINK-25513][python] Handle properly for None result in flat_map and map of ConnectedStream This closes #18280. 06 January 2022, 11:34:34 UTC
02c433c [FLINK-25464][python] Turn on output infos for package installation in tox This closes #18270. 06 January 2022, 02:21:17 UTC
f324992 [FLINK-25472][core] Update to Log4j 2.17.1 This closes #18232. 30 December 2021, 13:34:29 UTC
ac08b44 [FLINK-25415] Add retries to CasandraConnectorITCase Add 3 retrials to all tests and to startAndInitializeCassandra() methods in CassandraConnectorITCase upon NoHostAvailableException which happens under load when cluster.connect() is called. 29 December 2021, 14:54:39 UTC
8c7df6c [FLINK-25147] add keyspace drop because the docker image is reused and modified by the tests. 29 December 2021, 14:52:52 UTC
eace77b [FLINK-25468] Copy SST files if they cannot be hard linked in RocksDBHandle.restoreInstanceDirectoryFromPath The RocksDBHandle.restoreInstanceDirectoryFromPath hard links SST files. If this operation does not work because the source directory is on a different file system then it will now copy the file over. This closes #18222. 29 December 2021, 08:27:46 UTC
4f81fc6 [FLINK-23047] Ignore CassandraConnectorITCase until the flakiness of this test is fixed. This closes #18204. 27 December 2021, 10:28:51 UTC
d903739 [FLINK-25375] Update log4j2 dependency to 2.17.0 to address (#18168) CVE-2021-45105 Co-authored-by: Bernard Joseph Jean Bruno <brunobernard@busymind101.com> 26 December 2021, 07:41:14 UTC
5afe88a [FLINK-25437][python] Correct grpcio dependency version in dev-requirenment.txt This closes #18197. 24 December 2021, 10:58:39 UTC
365715d [FLINK-25422][python] Specify requirements in dev-requirements.txt 23 December 2021, 06:29:55 UTC
0b30780 [FLINK-25147][connectors][test] This test case now works on java 11 This closes #18140. 21 December 2021, 14:45:57 UTC
96c3b94 [FLINK-25147][connectors][test] Migrate Cassandra connector tests to testContainers 17 December 2021, 12:03:37 UTC
3200e8e [FLINK-24728][table-runtime-blink] Close output stream in batch SQL file sink This closes #18074 17 December 2021, 05:37:47 UTC
ca3798c [FLINK-24232][coordination] Skip history server archiving for suspended jobs Do not create an archive for suspended jobs, as this would eventually lead to multiple archive attempts which we currently do not support. 16 December 2021, 20:41:22 UTC
d11dbf8 Update for 1.13.5 16 December 2021, 13:22:26 UTC
2bdc194 [FLINK-24846][streaming] Ignoring completing async operator record if mailbox is closed already 16 December 2021, 08:07:47 UTC
809b059 [FLINK-25295][build] Update log4j2 dependency to 2.16.0 14 December 2021, 22:13:04 UTC
b749e4f [FLINK-22775][cassandra][tests] Lower write consistency level to ANY This consistency level is only available on write, so we need to create one builder for reading and one for writing. Some sinks are used for both reading and writing, in that case, reading builder is used. (cherry picked from commit c40bbf1e87cc62880905cd567dca05a4e15aff35) 14 December 2021, 15:02:56 UTC
cf9f90e [FLINK-24987][streaming-java] Add explicit enum value NO_EXTERNAL_CHECKPOINTS as default for externalized-checkpoint-retention (cherry picked from commit f4db43a3a8d7147f3ebd1279addcb35fb2c5e38b) 14 December 2021, 07:16:16 UTC
f394abd [FLINK-22096][tests] Fix port conflict for ServerTransportErrorHandlingTest#testRemoteClose 14 December 2021, 06:48:09 UTC
de8ee32 [FLINK-24813][table-planner-blink] Improve ImplicitTypeConversionITCase This closes #18049 13 December 2021, 01:57:38 UTC
11ac7c2 [FLINK-20195][coordination] Deduplicate jobs for overview 12 December 2021, 11:24:37 UTC
0c2fd40 [FLINK-25240][build] Upgrade Log4j2 to 2.15.0 12 December 2021, 10:48:45 UTC
9d9842f [FLINK-24077][HBase/IT] use MiniClusterWithClientResource as @ClassRule. while using TableEnvironment in the ITCase, a Flink MiniCluster will be started/stopped automatically in the background. Since the shutdown of the MiniCluster will be called asynchronously, CollectResultFetcher will get data lost sometimes based on race conditions and the unchecked RuntimeException java.lang.IllegalStateException will be thrown that we were not aware of. The solution is to control the lifecycle of the MiniCluster manually in this test. The MiniClusterWithClientResource could be a good fit in this case. (cherry picked from commit fca04c3aaf6346d61cf9fe022a7ac77ab4d66c91) 11 December 2021, 16:07:43 UTC
2efb0df [FLINK-24077][HBase/IT] Add check of row count after insert and wait explicitly for job to finish. (cherry picked from commit 7976be0f8675a8753a5bb7e7a44dda6b4a347247) 11 December 2021, 16:07:43 UTC
back to top