https://github.com/apache/flink

sort by:
Revision Author Date Message Commit Date
895c609 Commit for release 1.14.4 25 February 2022, 10:57:14 UTC
a5dc36d [FLINK-26159][doc] add description for MAX_FETCH_RECORD related question Update docs/content/docs/connectors/datastream/pulsar.md Co-authored-by: MartijnVisser <martijn@2symbols.com> Update docs/content/docs/connectors/datastream/pulsar.md Co-authored-by: MartijnVisser <martijn@2symbols.com> add Chinese documentation 24 February 2022, 16:05:16 UTC
3c830d0 [FLINK-26160][pulsar][doc] update the doc of setUnboundedStopCursor() 24 February 2022, 16:03:21 UTC
8a168e1 [FLINK-26304][streaming] Do not forward failed committables With the introduction of retries of failed committables we should not simply forward all committables but check their status. Only committables that have been committed successfully should be forwarded. 23 February 2022, 18:13:58 UTC
fdc6d6c [FLINK-24407][doc-zh] Fix the broken links in Chinese document of Pulsar connector This closes #18849. 23 February 2022, 13:41:43 UTC
0a76d63 [FLINK-24607] Make OperatorCoordinator closure more robust. 22 February 2022, 08:44:08 UTC
6936ce6 [FLINK-24607] Add util methods to shutdown executor services. 22 February 2022, 08:44:07 UTC
89046bc [FLINK-24607] Let Deadline handle duration overflow. 22 February 2022, 08:44:07 UTC
1ff23ac [FLINK-25851][cassandra][tests] Inject dynamic table name into Pojos 22 February 2022, 07:32:25 UTC
d725ba8 [FLINK-25851][build][tests] Bump bytebuddy to 1.8.22 22 February 2022, 07:32:24 UTC
cfc54ca [FLINK-25856][python][BP-1.14] Fix use of UserDefinedType in from_elements This closes #18864. 22 February 2022, 01:55:38 UTC
451c5aa [FLINK-25893][runtime] Do not report error if ResourceManagerServiceImpl#deregisterApplication is called when there's no leading RM. close #18856 21 February 2022, 10:54:48 UTC
ce560c6 [FLINK-25893][runtime] Fix that ResourceManagerServiceImpl may call ResourceManager#deregisterApplication before RM being fully started. 21 February 2022, 10:54:47 UTC
2465c85 [FLINK-23240][runtime] Master process supports living through multiple leader sessions. This is supported on all non-Yarn deployments. The Yarn deployment is not supported because each AM process can only register at Yarn RM for once. close #18839 20 February 2022, 08:56:20 UTC
7cebc6c [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:49:54 UTC
075c65d [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:49:54 UTC
5408bc6 [FLINK-25698][connectors/elasticsearch] Enable logging for Elasticsearch containers 17 February 2022, 10:28:11 UTC
03883eb [FLINK-26187][docs] Chinese docs only redirect for chinese urls 17 February 2022, 08:00:08 UTC
68f0688 [FLINK-20830][k8s] Add type of Headless_Cluster_IP for external rest service This closes #18767. 17 February 2022, 06:25:48 UTC
918b089 [FLINK-21407][docs][formats] Remove MongoDb connector as it is not supported on DataStream API. 14 February 2022, 10:03:41 UTC
77e65db [FLINK-25883][python] Set the default value of DEFAULT_BUNDLE_PROCESSOR_CACHE_SHUTDOWN_THRESHOLD_S to 30 days 14 February 2022, 03:54:56 UTC
4b5e232 [FLINK-25227][table] Boxed numeric type should be considered when generating code for equality checking This closes #18291 14 February 2022, 02:45:58 UTC
3ae076a [FLINK-24880][python] Fix PeriodicThread to handle properly for negative wait timeout value This closes #18640. 14 February 2022, 02:45:25 UTC
30994a1 [FLINK-25466][state] Enable state descriptor to handle StateTtlConfig#DISABLED 14 February 2022, 02:16:10 UTC
e230a7b [FLINK-25785][Connectors][JDBC] Upgrade com.h2database:h2 to 2.1.210 (cherry picked from commit 8488b9e110baec5ed31c3e62d72ff3eceaab721c) Signed-off-by: martijnvisser <martijn@2symbols.com> 11 February 2022, 22:08:44 UTC
83aa7cc [FLINK-18356][tests] Disable fork-reuse for table-planner 11 February 2022, 09:48:55 UTC
c06e3bb [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. 09 February 2022, 14:30:03 UTC
ca9edeb [FLINK-26039][table-runtime] Fix the incorrect value getter in map unnest table function This closes #18679. 09 February 2022, 13:36:42 UTC
e2a17ad [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:50:48 UTC
47e8238 [FLINK-25879][Docs] Track used search terms in Matomo 07 February 2022, 09:28:24 UTC
b9f7a4f [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:01:06 UTC
150f768 [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:01:06 UTC
9365510 [FLINK-25827][task] Fix potential memory leak in SourceOperator when using CompletableFuture.anyOf 04 February 2022, 11:41:33 UTC
9bef4bc [FLINK-25827][task] Move and rename MultipleInputAvailabilityHelper 04 February 2022, 11:41:33 UTC
6a96c10 [hotfix][test] Fix SourceOperatorTest#testSameAvailabilityFuture Previously this test was returning always CompletedFuture, which technically speaking should have been converted to AVAILABLE. And it also wasn't testing the important behaviour, that when being unavailable for long period of time, getAvailableFuture shouldn't be producing new CompletableFuture per each call. 04 February 2022, 11:41:33 UTC
2aec27e [hotfix][test] Extract SourceOperatorTestBase from SourceOperatorTest 04 February 2022, 11:41:33 UTC
fdbf60f [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:29:58 UTC
6a4e8fb [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:33:36 UTC
7904842 [FLINK-25880][docs] Add Matomo tracking code to base layout 02 February 2022, 12:10:11 UTC
f1819dd [FLINK-25880][docs] Remove Google Analytics implementation 02 February 2022, 12:10:11 UTC
498ee85 [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:40:41 UTC
b7a0e02 [FLINK-25771][connectors][Cassandra][test] Raise all read/write/miscellaneous requests timeouts (cherry picked from commit 9d44bc0e973cca6d03ed222158b7b5ce70306ab0) 01 February 2022, 12:40:41 UTC
0a294e3 [FLINK-25147][connectors][Cassandra][test] Use parent test containers version (cherry picked from commit c5483c684e668010a607b5b97618d22be66d1d55) 01 February 2022, 12:40:41 UTC
e074805 [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:53:49 UTC
761a462 [FLINK-25728][task] Simplify MultipleInputAvailabilityHelper 31 January 2022, 16:27:44 UTC
6f4de73 [FLINK-25728][task] Avoid unnessesary CompletableFuture.thenRun calls on idle inputProcessor's avaiableFuture, preventing memory leaks. 31 January 2022, 16:27:41 UTC
0b519c2 [FLINK-25486][Runtime/Coordination] Fix the bug that flink will lost state when zookeeper leader changes This closes #18559. 30 January 2022, 16:22:39 UTC
517436a [FLINK-25767][docs-zh] Totally translate state.md into Chinese This closes #18460. 29 January 2022, 04:28:39 UTC
3f54ec7 [FLINK-25278][ci] Use Maven proxy for confluent repo 25 January 2022, 11:09:26 UTC
bf8d811 Update for 1.14.3 25 January 2022, 09:46:19 UTC
70acbc5 [FLINK-25171][table-planner] Validation of duplicate fields in ddl sql This closes #18017 (cherry picked from commit 34de3989a613cf7124f9e301cb8284080f4df4ac) 25 January 2022, 04:32:46 UTC
891ea2a [hotfix][docs] Fixing multiple internal and external 404 links This closes #18425. 24 January 2022, 12:21:16 UTC
e358ac6 [FLINK-25732][coordination] Pass serializable collection 24 January 2022, 09:51:53 UTC
2cca3a6 [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, 07:34:43 UTC
eff530f [FLINK-24334][k8s] Set FLINK_LOG_DIR environment for JobManager and TaskManager pod if configured via options This closes #18435. 24 January 2022, 02:37:45 UTC
11a406e [FLINK-25678][runtime] Make TaskExecutorStateChangelogStoragesManager.shutdown thread-safe The method is called from the shutdown hook and must be thread-safe. 22 January 2022, 11:17:15 UTC
142a5ee [FLINK-25674][connectors][cassandra][tests] use constants instead of string literals to avoid copy/paste 21 January 2022, 10:03:43 UTC
a033436 [FLINK-25674][connectors][cassandra][tests] Add drop tables to be idempotent in case of retrials and the related test 21 January 2022, 10:03:34 UTC
303e306 [FLINK-20188][Connectors][Docs][FileSystem] Added documentation for File Source Co-authored-by: shihong90 <2572805166@qq.com> Co-authored-by: Alexander Fedulov <1492164+afedulov@users.noreply.github.com> 21 January 2022, 09:32:50 UTC
444641c [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, 07:55:11 UTC
bd1cd34 Update japicmp configuration for 1.14.3 20 January 2022, 00:31:04 UTC
e7102f5 [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 #18389. 19 January 2022, 10:54:47 UTC
43b073e [FLINK-25650][docs] Added "Interplay with long-running record processing" limit in unaligned checkpoint documentation 19 January 2022, 07:31:18 UTC
d3bb555 [FLINK-25611][core] Remove CoordinatorExecutorThreadFactory thread creation guards 18 January 2022, 09:09:04 UTC
f8d00a2 [FLINK-25654][network] Remove the redundant locks in SortMergeResultPartition and PartitionSortedBuffer. After FLINK-2372, the task canceler will never call the close method of ResultPartition, which can reduce some race conditions and simplify the code. This PR aims to remove some redundant locks in SortMergeResultPartition and PartitionSortedBuffer. This closes #18364. 18 January 2022, 03:10:41 UTC
3891eaf [FLINK-24858][release][docs] Recommend users to upgrade to 1.14.3 from 1.13.x to use state serializer fix 17 January 2022, 15:28:58 UTC
97fe172 [FLINK-24444][runtime][tests] Wait until checkpoints stopped triggering 16 January 2022, 11:31:18 UTC
b1efd3b [hotfix] Fix typing errors for SortMergeResultPartitionReadScheduler#createSubpartitionReader This closes #17936. 15 January 2022, 03:48:04 UTC
936f1d7 [FLINK-24954][network] Refresh read buffer request timeout on buffer recycling/requesting for sort-shuffle The implementation of read buffer request timeout for sorting shuffle is a little aggressive. When a running task encounters data skew or the task is slow, a timeout exception may be triggered. To improve this situation, when at least one buffer is recycled or allocated, the buffer request timeout should be refreshed to avoid throwing a timeout exception. This closes #17936. 15 January 2022, 03:48:04 UTC
bfc108f [FLINK-25160][docs] Clarified purpose of execution.checkpointing.tolerable-failed-checkpoints 14 January 2022, 15:07:39 UTC
7784ec7 [FLINK-25407][network] Fix the issues caused by FLINK-24035 This PR tries to fix the issues caused by FLINK-24035. More specifically, there are two issues, the first one is the deadlock caused by acquiring the 'factoryLock' in NetworkBufferPool and the other is the incorrect decreasing of the required segments of NetworkBufferPool. Both issues occur during exception handling of requesting segments. Actually, when reserving memory segments for LocalBufferPool, there is no need to modify the value of required segments. As a result, there is no need to acquire the 'factoryLock'. This PR fixes the issues by removing the required segments decreasing logic together with the 'factoryLock' acquiring during exception handling of requesting segments in NetworkBufferPool. This closes #18173. 13 January 2022, 14:11:45 UTC
1c151e4 [hotfix] Rename some methods of NetworkBufferPool and add more comments for better readability This closes #18173. 13 January 2022, 14:11:45 UTC
e93fb03 [FLINK-25280][connector/kafka] Disable log deletion in KafkaTestEnvironmentImpl to prevent records from being deleted during test run 12 January 2022, 14:30:14 UTC
2f16c53 [FLINK-25576][Connectors][JDBC] Upgrade com.h2database:h2 to 2.0.206 11 January 2022, 08:55:06 UTC
7b24c90 [FLINK-25362][docs] fix maven instructions for "Confluent Avro Format" 11 January 2022, 08:02:57 UTC
eca3aab [FLINK-25362][docs] fix the Avro Format maven dependency It was falsely pointing to the shaded sql artifact. 11 January 2022, 08:02:57 UTC
d8b6f89 [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:02:57 UTC
ae8a4b7 [FLINK-25307][test] Print the curl logs is querying dispatcher startup failed This closes #18298. 08 January 2022, 11:47:25 UTC
c50151b [FLINK-24880][python] Fix PeriodicThread to handle properly for negative wait timeout value This closes #18292. 07 January 2022, 06:03:45 UTC
69dc8ba [FLINK-25513][python] Handle properly for None result in flat_map and map of ConnectedStream This closes #18280. 06 January 2022, 11:29:25 UTC
fee5532 [FLINK-25464][python] Turn on output infos for package installation in tox This closes #18270. 06 January 2022, 02:16:40 UTC
24f1449 [hotfix][doc]Fixed an issue where clicking Window Assigner and Window Function in Windows documents could not jump correctly. 05 January 2022, 14:23:32 UTC
7263d97 [FLINK-25477][docs] Make the directory structure of the State Backends document display correctly 04 January 2022, 03:14:13 UTC
6525971 [FLINK-25294][python] Fix cloudpickle import This closes #18099. 31 December 2021, 06:22:00 UTC
19c3655 [FLINK-25418][python] Install dependencies offline if the cache dir is specified This closes #18186. 31 December 2021, 06:07:28 UTC
09a8d25 [FLINK-25472][core] Update to Log4j 2.17.1 This closes #18230. 30 December 2021, 13:30:51 UTC
a73d1b2 [hotfix][connectors][docs] Use big M letters for month in date format 30 December 2021, 07:59:12 UTC
95777d1 [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:51:37 UTC
e9b6abc [FLINK-25147] add keyspace drop because the docker image is reused and modified by the tests. 29 December 2021, 14:51:36 UTC
f851f58 [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:24:38 UTC
24016b8 [FLINK-25446][state] Avoid improper sanity check on read bytes on DataInputStream#read(byte[]) 28 December 2021, 14:03:30 UTC
457c42f [FLINK-23047] Ignore CassandraConnectorITCase until the flakiness of this test is fixed. This closes #18204. 27 December 2021, 10:27:03 UTC
ebbf772 [FLINK-25132][connector/kafka] Move record deserializing from SplitFetcher to RecordEmitter to support object-reusing deserializer 26 December 2021, 11:39:15 UTC
49971b8 [FLINK-25375] Update log4j2 dependency to 2.17.0 to address (#18167) CVE-2021-45105 Co-authored-by: Bernard Joseph Jean Bruno <brunobernard@busymind101.com> 26 December 2021, 07:41:52 UTC
a9d43ee [FLINK-24481][docs] Translate buffer debloat documenation to chinese This closes #17953 23 December 2021, 07:37:27 UTC
2bf213c [hotfix][docs] Minor fixes in Network Memory Tuning Guide 23 December 2021, 07:37:22 UTC
ae4856a [FLINK-25422][python] Specify requirements in dev-requirements.txt 23 December 2021, 06:24:47 UTC
68148d9 [FLINK-25271][clients] Harden the ApplicationDispatcherBootstrapITCase. 22 December 2021, 10:38:13 UTC
cc78ea5 [FLINK-25147][connectors][test] This test case now works on java 11 This closes #18138. 21 December 2021, 14:20:57 UTC
a80c179 [FLINK-25147][connectors][test] Migrate Cassandra connector tests to testContainers 17 December 2021, 10:52:45 UTC
back to top