https://github.com/apache/flink

sort by:
Revision Author Date Message Commit Date
b1e7b89 [FLINK-25883][python] Set the default value of DEFAULT_BUNDLE_PROCESSOR_CACHE_SHUTDOWN_THRESHOLD_S to 30 days 14 February 2022, 03:53:56 UTC
ef26166 [hotfix][docs] Fix links 02 February 2022, 12:43:05 UTC
75eb2de [FLINK-25880][docs] Add Matomo tracking code to base layout 02 February 2022, 12:41:40 UTC
59ba66e [FLINK-25880][docs] Remove Google Analytics implementation 02 February 2022, 12:41:40 UTC
9be6974 [FLINK-25472][core] Update to Log4j 2.17.1 This closes #18233. 30 December 2021, 13:40:18 UTC
1561f0f [FLINK-25375] Update log4j2 dependency to 2.17.0 to address (#18166) CVE-2021-45105 Co-authored-by: Bernard Joseph Jean Bruno <brunobernard@busymind101.com> 26 December 2021, 07:41:50 UTC
bd2b763 [FLINK-25437][python] Correct grpcio dependency version in dev-requirenment.txt This closes #18198. 24 December 2021, 10:59:34 UTC
97513b2 [FLINK-25422][python] Specify requirements in dev-requirements.txt 23 December 2021, 06:36:05 UTC
9664c17 Update for 1.12.7 16 December 2021, 13:21:32 UTC
fdd52a7 [FLINK-25022][rest] Run jars in separate threads Use a dedicated thread to run each jar, so that pooled threads can't keep references to user-code (e.g., in a ThreadLocal). 16 December 2021, 13:21:32 UTC
b6ae903 [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:08:14 UTC
8e3b291 [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:08:14 UTC
85c39b4 [FLINK-25091][docs] Change ORC compression attribute reference error in FileSink doc 09 December 2021, 07:39:39 UTC
b30e5b4 [FLINK-23493][python] Remove the calling of child process in the beam_boot.py 07 December 2021, 02:13:38 UTC
5972c7f [FLINK-24971][tests] Adding retry function for failures in Bash e2e tests 26 November 2021, 14:16:54 UTC
c1f8e73 [FLINK-22419] Wait unlimited in RpcEndpointTest.testCallAsyncTimeout 12 November 2021, 21:14:32 UTC
9025168 [hotfix][tests] Make RpcEndpointTest more informative 12 November 2021, 21:14:32 UTC
7b2ae80 [FLINK-24860][python] Fix the wrong position mappings in the Python UDTF This closes #17752. 11 November 2021, 02:03:43 UTC
ccf6f1a [FLINK-24812][ci] Upgrade to ubuntu-20.04 09 November 2021, 09:36:06 UTC
b18dd7b [FLINK-24796][ci] Reduce size of compile build artifact 08 November 2021, 10:19:41 UTC
baa524b [FLINK-24746][ci] Use local Nexus cache Each machine now has their own Nexus instance. 05 November 2021, 08:43:41 UTC
3d1f06e [FLINK-15550][runtime] Don't ignore the interruption for testCancelTaskExceptionAfterTaskMarkedFailed 01 November 2021, 11:23:36 UTC
9233b9b [FLINK-24662][python][tests] Set the version of Docutils to 0.17.1 27 October 2021, 03:19:48 UTC
ef9f717 [FLINK-24480][table-planner] Reduce number of fields in test This closes #17499. 18 October 2021, 15:56:46 UTC
534afd6 [FLINK-23704][task] Apply review suggestsion for generating LatencyMarkers in FLIP-27 sources 15 October 2021, 08:27:55 UTC
2ed9278 [FLINK-23704][task] FLIP-27 sources are not generating LatencyMarkers 15 October 2021, 08:27:55 UTC
7ac7629 [FLINK-23704][test] Introduce SourceOperatorTestHarnes 15 October 2021, 08:27:54 UTC
4a8987c [FLINK-23704][task] Extract LatencyMarkerEmitter class 15 October 2021, 08:27:54 UTC
2dabdd9 [FLINK-24480][table-planner] Do not discard exception in test This closes #17469 14 October 2021, 11:18:13 UTC
0f73817 [FLINK-24431][kinesis][efo] Stop consumer deregistration when EAGER EFO configured. (#17417) * FLINK-24431 Stop consumer deregistration when EAGER EFO configured. * FLINK-24431 Verify criteria for stream deregistration in unit tests. * FLINK-24431 Update documentation to reflect new EAGER EFO strategy changes. * FLINK-24431 Remove Java 11 language feature usage in consumer unit test. * FLINK-24431 Untranslated zh documentation updated to match kinesis documentation changes. 11 October 2021, 14:24:32 UTC
d9d4d3c [FLINK-24390][python] Limit the grpcio version <= 1.40.0 for Python 3.5 in dev/requirements.txt (#17445) 11 October 2021, 09:46:18 UTC
5dd50ef [FLINK-24390][python] Limit the grpcio version <= 1.40.0 for Python 3.5 (#17433) 09 October 2021, 06:49:30 UTC
1a9d782 [FLINK-24200][streaming] Calculating maximum alignment time rather than using the constant value (#17354) 01 October 2021, 02:38:40 UTC
f1886ef [FLINK-24336][python] Fix the issue that jar url list may contain empty string. This closes #17322. 24 September 2021, 01:42:38 UTC
44e629e [hotfix][docs] fix link from upsert-kafka to kafka Table(!) connector 20 September 2021, 08:06:48 UTC
7249e0d [FLINK-24277][connector/kafka] Add OffsetsInitializerValidator interface for validating offset initializer in KafkaSourceBuilder (cherry picked from commit 2da73edba95685537040305f30ee9d6dfd8d6c02) 18 September 2021, 13:46:26 UTC
bf3df16 [FLINK-24277][connector/kafka] Add configuration for committing offset on checkpoint and disable it if group ID is not specified 18 September 2021, 13:46:26 UTC
b842230 [FLINK-23949][runtime][checkpoint] fix first incremental checkpoint after a savepoint will degenerate into a full checkpoint 18 September 2021, 10:31:10 UTC
bdb75a8 [FLINK-24133][core] Network failure test replaced by comment in the code due to high expense of stabilizing such low important test 16 September 2021, 08:13:04 UTC
66ddb98 [FLINK-24305][python] Limit the protobuf version<3.18 16 September 2021, 07:43:31 UTC
4adfa04 [hotfix] Fix links in gcs docs 15 September 2021, 10:41:38 UTC
3612991 [FLINK-21589][docs] Document table pipeline upgrades This closes #17285 15 September 2021, 10:41:22 UTC
16c2bcc [FLINK-24260][python] Limit requests to 2.26.0 or above only for python 3.6+ This closes #17248. 13 September 2021, 05:58:04 UTC
d249094 [FLINK-16346][tests] Remove timeout 10 September 2021, 11:11:37 UTC
2fd67cd [FLINK-22971][tests] Bump testcontainers to 1.16.0 10 September 2021, 07:21:20 UTC
de69c3e [FLINK-24213][qs] Use single lock in ServerConnection 10 September 2021, 05:29:36 UTC
fa2ab61 [FLINK-24213][qs] Introduce factory for established connection 10 September 2021, 05:29:32 UTC
07a3f66 [FLINK-23345][python] Limits the version requests to 2.26.0 or above This closes #17219. 10 September 2021, 02:16:50 UTC
afcba03 Revert "[FLINK-23949][checkpoint] Fix first incremental checkpoint after a savepoint degenerate into a full checkpoint" This reverts commit 5f12f4ce88a4e83473e778eb30742ab88d92bdb0. 08 September 2021, 08:21:48 UTC
b682eed [FLINK-24183][legal] Add aws-java-sdk-s3 to source NOTICE 08 September 2021, 08:18:10 UTC
5f12f4c [FLINK-23949][checkpoint] Fix first incremental checkpoint after a savepoint degenerate into a full checkpoint this fix #16969. Co-authored-by: wangfeifan <zoltar9264@163.com> Co-authored-by: jinghaihang <jinghaihang_hrbeu@163.com> 08 September 2021, 07:20:32 UTC
c1844b1 [FLINK-23611][yarn-tests] Disables INFO log messages coming from YARN's ResourceLocalizationService We observed regular INFO log messages being produced by ResourceLocalizationService after the test ran into a timeout: ``` 22:51:31,785 [AsyncDispatcher event handler] INFO org.apache.hadoop.yarn.server.nodemanager.containermanager.localizer.ResourceLocalizationService [] - Cache Size Before Clean: 0, Total Deleted: 0, Public Deleted: 0, Private Deleted: 0 22:51:32,398 [AsyncDispatcher event handler] INFO org.apache.hadoop.yarn.server.nodemanager.containermanager.localizer.ResourceLocalizationService [] - Cache Size Before Clean: 0, Total Deleted: 0, Public Deleted: 0, Private Deleted: 0 ``` These log messages appeared every 10 minutes which prevented the ci/tools/test_controller.sh's watchdog mechanism to kick in. The watchdog mechanism relies on no output being produced for a given amount of time. This way, the test_controller script was unable to archive the YARN Flink log. 07 September 2021, 14:09:36 UTC
1a6146a [hotfix][yarn-tests] Replaces runtime by timestamp The intend is to improve local debugging matching log events in different log files (YARN, Flink) via the timestamp. 07 September 2021, 14:09:36 UTC
6af08c5 [hotfix][yarn-tests] Fixes path definition for local YARN-test working directory artifact collection 07 September 2021, 14:09:36 UTC
b9dc04e [FLINK-22198][connector/kafka] Disable log deletion on Kafka broker in Kafka table connector tests (#17158) 07 September 2021, 10:23:51 UTC
d802693 [FLINK-24134][python][docs] Update the documentation about how to install PyFlink in docker This closes #17154. 06 September 2021, 05:51:39 UTC
87ce3ac [FLINK-22367][streaming] Reset syncSavepointId only if it is equal to checkpoint id from event This closes #17104 03 September 2021, 14:58:59 UTC
39d834f [FLINK-24051][connectors/kafka] Make groupId optional when constructing a KafkaSource Setting a groupdId for the KafkaSource is often not necessary and complicates the setup for users that do not rely on specific semantics which are implied by the groupId. 01 September 2021, 06:46:14 UTC
6f9cfe1 [FLINK-24049][python] Handle properly for field types need conversion in TupleTypeInfo This closes #17046. 31 August 2021, 12:23:29 UTC
af1cac9 [FLINK-23947] Improve logging of granting/revoking leadership in DefaultDispatcherRunner This commit logs on info level when the DefaultDispatcherRunner was granted or revoked its leadership. This closes #17035. 30 August 2021, 10:46:31 UTC
ec42349 [FLINK-23954][tests] Fix e2e test test_queryable_state_restart_tm.sh The problem was that we output the number of state entries at the time when the checkpoint is confirmed. However, at this point in time we might have already added more elements to the map. Hence, we risk reporting more elements than are actually contained in the checkpoint. The solution is to remember what the element count was when creating the checkpoint. This closes #17029. 30 August 2021, 10:31:04 UTC
58039ee [FLINK-9925] Rework Client to encapsulate concurrency of single connection This commit replaces the Client.pendingConnections and .establishedConnections with a single data structure connections of type ServerConnection. The logic of a pending and established conneciton is moved into this class. This allows to get rid of concurrent access to the Client data structures. This closes #16915. 30 August 2021, 09:19:03 UTC
68316d8 [FLINK-9925][tests] Harden ClientTest by making handler shareable This commit makes the handler that is used for the testConcurrentQueries shareable so that Netty won't fail if another pipeline is created. 30 August 2021, 09:13:41 UTC
a54aa85 [FLINK-24036][ci] Fix SSL download link 28 August 2021, 09:06:43 UTC
6e4f119 [FLINK-23945][docs] Correct S3 URI in K8s ha documentation This closes #17018. 27 August 2021, 16:50:01 UTC
adcd545 [FLINK-23984][python][tests] Update test_kubernetes_pyflink_application to use conda to install Python This closes #17014. 27 August 2021, 14:46:22 UTC
7e61fa4 Revert "[FLINK-23984][python][tests] Temporary disable the PyFlink end to end tests due to Python 3.7 was removed from debian" This reverts commit a5ec7a7222273368824ad6fa06e9dc51ec3af7c4 27 August 2021, 14:46:14 UTC
cfe9519 [FLINK-23994][python] Handle properly for null values in ArrayDataSerializer and MapDataSerializer This closes #16998. 27 August 2021, 02:14:02 UTC
a5ec7a7 [FLINK-23984][python][tests] Temporary disable the PyFlink end to end tests due to Python 3.7 was removed from debian 26 August 2021, 06:03:13 UTC
c22c3da [FLINK-22545][tests] Fix delayed split assignment in OperatorEventSendingCheckpointITCase 25 August 2021, 11:57:40 UTC
70a5657 [FLINK-23908][runtime] Hint user about possibly non-deterministic shuffle key, when attemting to access out-of-the-bounds state key group. This closes #16943. 25 August 2021, 07:34:39 UTC
f00ce56 [FLINK-20461][tests] Check replication factor before asking for JobResult This commit hardens the YARNFileReplicationITCase by checking the replication factor before asking for the JobResult. If done in the reverse order, then it can happen that the Flink application has already terminated before doing the file replication check because the per-job mode has already delivered the JobResult. This closes #16917. 24 August 2021, 15:28:25 UTC
acea21c [FLINK-23936][python] Disable cleanup the Python UDFs which are inactive for a few minutes This would avoid reinitializing the Python UDFs which usually is a heavy operation in scenarios such as machine learning, e.g., loading a big ML model This closes #16958. 24 August 2021, 11:31:24 UTC
fc9da62 [FLINK-22932][tests] Harden RocksDBStateBackendWindowITCase by using RpcUtils.INF_TIMEOUT for MiniCluster RPC timeout This commit sets the default rpc timeout for the MiniCluster to RpcUtils.INF_TIMEOUT. This should be ok since in a local execution the communication between the different components should be reliable. This closes #16914. 24 August 2021, 10:25:28 UTC
ee91395 [FLINK-23906][tests] Increase the default akka.ask.timeout for the MiniCluster to 5 minutes This commit sets the akka.ask.timeout, if not explicitly configured, to 5 minutes when using the MiniCluster. The idea behind this change is to harden all our tests that rely on the MiniCluster and run into TimeoutExceptions on our slow CI infrastructure. This closes #16923. 24 August 2021, 10:16:34 UTC
8a83d8b [FLINK-23579][table-runtime] Fix compile exception in hash functions with varbinary arguments This closes #16903 24 August 2021, 08:05:57 UTC
0385419 [FLINK-22333][tests] Harden Elasticsearch7DynamicSinkITCase.testWritingDocuments by setting parallelism to 4 This commit hardens the Elasticsearch7DynamicSinkITCase.testWritingDocuments tests by settings its parallelism to 4. Otherwise the test is run with as many CPUs are available on the machine. This can slow down the test on our CI infrastructure. This closes #16926. 23 August 2021, 10:02:07 UTC
748543c [hotfix] Let Elasticsearch7DynamicSink* test cases extend from TestLogger 23 August 2021, 10:02:06 UTC
f2c5259 [FLINK-21538][tests] Set default parallelism to 4 for Elasticsearch6DynamicSinkITCase.testWritingDocuments This commit sets the default parallelism of Elasticsearch6DynamicSinkITCase.testWritingDocuments to 4 in order to reduce the load for our CI infrastructure. This closes #16920. 23 August 2021, 09:49:36 UTC
ba81fa6 [hotfix][tests] Let ElasticSearch6DynamicSink tests extend TestLogger 23 August 2021, 09:49:33 UTC
86aa3ae [FLINK-23097][tests] Harden test_queryable_state_restart_tm.sh This commit hardens the test_queryable_state_restart_tm.sh e2e test by only writing the count value of state entries on notifyCheckpointComplete. Before we have written out uncommitted information out that led to test failures. This closes #16910. 23 August 2021, 08:59:57 UTC
49fedc1 [FLINK-23841][doc]Modify incorrect English statements for page "execution_configuration" This closes #16866. 20 August 2021, 08:43:09 UTC
4380185 [FLINK-23765][python] Fix the NPE in Python UDTF This closes #16890. 19 August 2021, 12:06:31 UTC
5e83f3e [FLINK-23806][runtime] Avoid StackOverflowException when a large scale job failed to acquire enough slots in time 18 August 2021, 11:22:27 UTC
097c77f [FLINK-23362][tests] Remove timeouts 17 August 2021, 18:05:06 UTC
b477faf [FLINK-22211][datastream] Only log exceptions if job has been initialized 17 August 2021, 11:34:29 UTC
bbae6a1 [FLINK-23802][kinesis][efo] Request next record from the Flink source thread rather than the AWS SDK response thread. Increase Read Timeout to 6m, higher than the maximum Shard subscription duration (5m) and enable TCP keep alive. 17 August 2021, 08:23:50 UTC
e84c1b4 [FLINK-23692][ui] Clarify text on 'Cancel Job' confirmation button 11 August 2021, 12:20:36 UTC
a43db75 [FLINK-22312][yarn][test] Fix log whitelist for AMRMClient heartbeat interruption. This closes #16733 09 August 2021, 02:08:45 UTC
adf2f29 [FLINK-23509][connectors/kafka] Create new ProducerIdAndEpoch when resuming Kafka transaction Before this change we did not create a new ProducerIdAndEpoch and rather mutated the already created one. This can overwrite the internally used static ProducerIdAndEpoch#None which is used to describe a non initialized state. Once the static object is mutated it breaks the recovery of transactions. 06 August 2021, 12:02:24 UTC
6e6739b Update japicmp configuration for 1.12.5 06 August 2021, 06:28:56 UTC
e8e6d06 [FLINK-21116][tests] Harden DefaultDispatcherRunnerITCase#leaderChange_withBlockingJobManagerTermination_doesNotAffectNewLeader. This closes #16695. 05 August 2021, 10:05:30 UTC
d79db15 [FLINK-22382][tests] Harden ProcessFailureCancelingITCase.testCancelingOnProcessFailure This commit hardens the ProcessFailureCancelingITCase.testCancelingOnProcessFailure by increasing the accepted heartbeat timeout. 05 August 2021, 09:23:51 UTC
d3cf911 [FLINK-23628][metrics][influxdb] Fix test setup 04 August 2021, 15:31:34 UTC
080e028 [FLINK-23619][metrics][influxdb] Fix compile issue 04 August 2021, 10:08:44 UTC
7e17c1d [FLINK-23183][connectors/rabbitmq] Fix ACKs for redelivered messages in RMQSource and add integration tests Changes: - channel.basicReject in RMQSource is called in case of already processed (and checkpointed) but redelivered messages (e.g. after the job failover) - add integration test that verifies that the source actually consumes the messages - add integration test reproducing the message redelivery issue in case of ack failure 04 August 2021, 08:19:29 UTC
14bdf8a [FLINK-23539][metrics][influxdb] Filter '\n' in tags 04 August 2021, 07:02:50 UTC
33ad098 [FLINK-23450][avro-confluent-registry] Set properties map for DebeziumAvroFormat 03 August 2021, 08:01:19 UTC
c8f4d80 [FLINK-21207][csv] Fix 'csv.disable-quote-character' = 'true' can not take effect in source table This closes #16614 03 August 2021, 03:16:17 UTC
e621c70 [FLINK-21569][dependency] Upgrade flink-shaded-jackson version to 2.12.1-13.0 This closes #16642 03 August 2021, 02:04:42 UTC
back to top