You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by GitBox <gi...@apache.org> on 2022/06/07 06:23:24 UTC

[GitHub] [flink] xuanyu66 opened a new pull request, #19891: [FLINK-27683][table-planner][realease-1.14] Fix SQL hints can't work with targetColumns

xuanyu66 opened a new pull request, #19891:
URL: https://github.com/apache/flink/pull/19891

   - Update for 1.14.0
   - [FLINK-24036][ci] Fix SSL download link
   - [hotfix][tests] Disabling flaky source testing + PulsarSourceITCase cases.
   - [FLINK-23055][docs][table] Add documentation for window tvf offset. (#17015)
   - [FLINK-23899][docs-zh] Translate the "Elastic Scaling" page into Chinese (#16928)
   - [FLINK-23917][table-planner] Project metadata before push-down even if projection push-down is not supported
   - [FLINK-24026][misc] Fix FLIP link can't be recognized correctly by IDEA (#17021)
   - [hotfix] Replace deprecated Assert.assertThat
   - [FLINK-23833][coordination] Add ConsumedPartitionGroup#getIntermediateDataSetID
   - [FLINK-23833][coordination] Make PartitionReleaseStrategy#vertexFinished return a list of releasable ConsumedPartitionGroups
   - [FLINK-23833][coordination] Rename PartitionReleaseStrategy to PartitionGroupReleaseStrategy
   - [FLINK-23833][coordination] Individually clean up the cache for ShuffleDescriptors
   - [FLINK-23833][coordination] Rename IntermediateResult#notifyPartitionChanged to IntermediateResult#clearCacheForConsumedPartitionGroup
   - [FLINK-9925][tests] Harden ClientTest by making handler shareable
   - [FLINK-9925] Rework Client to encapsulate concurrency of single connection
   - [hotfix] Print the test parameters for UnalignedCheckpointTestBase to help debugging when the case is stuck
   - [FLINK-23466][network] Fix the bug that buffer listeners may not be notified when recycling buffers
   - [hotfix][refactor] Remove BufferListener#NotificationResult to simplify the code
   - [FLINK-24027][filesystems] Remove excessive dependencies from NOTICE files
   - Revert "[FLINK-23954][e2e] Add debug logging to KvStateSerializer"
   - [FLINK-23954][tests] Fix e2e test test_queryable_state_restart_tm.sh
   - [FLINK-23947] Improve logging of granting/revoking leadership in DefaultDispatcherRunner
   - [FLINK-23962][table-planner] Fix updateKind trait propagating problem in changelog inference for DAG optimizing
   - [FLINK-23897][hive][doc] Fix obsolete doc about creating hive table with flink dialect
   - [FLINK-24033][table-planner] Propagate unique keys for fromChangelogStream
   - [FLINK-24010][connector/common] HybridSourceReader/Enumerator delegate checkpoint notifications
   - [FLINK-24049][python] Handle properly for field types need conversion in TupleTypeInfo
   - [FLINK-23287][docs][table] Add documentation for Window Join in SQL (#16997)
   -  [FLINK-13636][docs-zh] Translate the "Flink DataStream API Programming Guide" page into Chinese (#16852)
   - [FLINK-23857][table-runtime][hive] Insert overwrite should clear existing data when source is empty
   - [FLINK-24035][network] Guarantee that the LocalBufferPool is initialized with one buffer
   - [FLINK-24003][python] Fix lookback mode doesn't work when mixing use of Python Table API and Python DataStream API
   - [FLINK-23924][python][examples] Add PyFlink examples
   - [FLINK-24004][table-planner] Introduce TableFactoryHarness
   - [FLINK-23663][table-planner] Push primary key filters through ChangelogNormalize
   - [hotfix][table-planner] Migrate PushProjectIntoTableSourceScanRuleTest to test harness
   - [hotfix][table-common] Improve source and sink provider docs
   - [FLINK-23895][table] Upsert materializer is not inserted for all sink providers
   - [FLINK-24055][connectors/kafka] Deprecate FlinkKafkaConsumer
   - [FLINK-24084][docs] Correct the examples in SQL JOIN docs
   - [FLINK-24051][connectors/kafka] Make groupId optional when constructing a KafkaSource
   - [hotfix][docs] Add missing comma
   - [FLINK-23664][connectors/kafka] Mark KafkaSink as PublicEvolving
   - [FLINK-23664][connectors/kafka] Make kafka producer properties optional for building a KafkaSink
   - [FLINK-23664][connectors/kafka] Not register Kafka metrics of KafkaSink if register.producer.metrics is false
   - [FLINK-23664][docs] Add docs for KafkaSink
   - [FLINK-24081][table-planner] Fix StreamExecOverAggregate and StreamExecTemporalSort operator didn't support TIMESTAMP_LTZ rowtime (#17083)
   - [FLINK-24062][python] Fix the serialization of timer to avoid serializing timer data partially
   - [FLINK-23351][tests] Harden FileReadingWatermarkITCase by counting watermarks after source operator finishes
   - [FLINK-23854][datastream] Expose the restored checkpoint id in ManagedInitializationContext.
   - [FLINK-23854][datastream] Pass checkpoint id to SinkWriter#snapshotState and restoredCheckpointId to Sink#InitContext.
   - [FLINK-23896][streaming] Implement retrying for failed committables for Sinks.
   - [hotfix][connectors/kafka] Add TestLogger to Kafka tests.
   - [FLINK-23678][tests] Re-enable KafkaSinkITCase and optimize it.
   - [FLINK-23854][connectors/kafka] Abort transactions on close in KafkaWriter.
   - [FLINK-23854][connectors/kafka] Transfer KafkaProducer from writer to committer.
   - [FLINK-23896][connectors/kafka] Retry committing KafkaCommittables on transient failures.
   - [FLINK-23854][connectors/kafka] Add FlinkKafkaInternalProducer#setTransactionalId.
   - [FLINK-23854][connectors/kafka] Reliably abort lingering transactions in Kafka.
   - [FLINK-23854][kafka/connectors] Adding pooling
   - [FLINK-24085][docs] Add page title for "Versioned Tables" and "Time Zone" pages
   - [FLINK-23750][docs][table] Add documentation for Window Top-N after Windowing TVF (#16983)
   - [FLINK-24029][docs] Fix "dept_id" typo in SQL "Getting Started" page
   - [hotfix][docs] Soft-deprecating Streaming File Sink
   - [FLINK-23817][docs] Add metric description to Kafka source.
   - [hotfix][docs] Remove general operator task/operator metrics in Kafka Sink docs.
   - [FLINK-23971][tests] fix connector testing framework error when compare records in different splits
   - [FLINK-24087][connector-kafka] Avoid importing Table API classes for DataStream API programs
   - [FLINK-23797][tests] Wait for all task running before savepoint for all tests in SavepointITCase
   - [FLINK-24035][network][refactor] Move the blocking allocation of one floating buffer logic from the constructor of LocalBufferPool to SingleInputGate#setupChannels()
   - [FLINK-24097][python] Remove is_streaming_mode checks in StreamTableEnvironment
   - [FLINK-24083][python] Fix Python UDTF to handle properly when the result is str
   - [FLINK-24106][docs] Remove notice that pyflink does not support state TTL
   - [FLINK-24047][tests] Retry if leader election is in progress
   - [FLINK-24054][table-runtime] Let SinkUpsertMaterializer produce +U's when possible
   - [FLINK-24099][docs] Refer to nightlies.apache.org
   - [FLINK-22002][tests] Let taskmanager.slot.timeout fall back to akka.ask.timeout
   - [FLINK-22227][clients] Log submitted job name, id and receiving jobmanager
   - [FLINK-24005][coordination] Only return fulfilled requirements for reserved slots
   - [FLINK-24130][python] Fix RowDataSerializerTest after FLINK-24054
   - [hotfix] Let PartitionRequestClientFactoryTest extend TestLogger
   - [FLINK-24121][flink-python] There are spelling mistakes in the notes.
   - [hotfix][python] Add missing space to error message
   - [FLINK-24105][python] Fix the state ttl does not take effect in PyFlink
   - [FLINK-23242][docs-zh] Translate the page of "Handling Application Parameters" into Chinese (#16949)
   - Revert "[FLINK-23544][table-planner] Window TVF Supports session window in plan"
   - [FLINK-23111][runtime-web] Fix monaco editor async setup
   - [FLINK-20427] Remove configuration option to prefer checkpoints over newer savepoints
   - [FLINK-20427] Remove mention of prefer-checkpoints setting from the docs
   - [hotfix] Remove ZooKeeperCompletedCheckpointStoreMockitoTest.java (made redundant by DefaultCompletedCheckpointStoreUtilsTest.java)
   - [FLINK-24120] Add docs for using environment variable MALLOC_ARENA_MAX to avoid unlimited memory increasing
   - [hotfix] Remove CompletionException from failure cause in Execution.deploy
   - [FLINK-24091][tests] Harden TaskManagerProcessFailureBatchRecoveryITCase
   - [FLINK-23654][runtime] Splitting IO and future threadpools and adding advanced configurations
   - [FLINK-21090] Add tests for stop-with-savepoint and FLIP-147
   - [FLINK-21090] Minor code improvements
   - [FLINK-24056][ha] Remove unused ZooKeeperUtilityFactory
   - [FLINK-24060][Tests]Move ZooKeeperUtilTest to right class
   - [FLINK-24021][HA]Handle curator framework start error by register UnhandledErrorListener before start zk client
   - [FLINK-23916][python] Add python API to set tolerable checkpoint failure number
   - [FLINK-23916][docs] Update the documentation how to set tolerable checkpoint failure number
   - [FLINK-24134][python][docs] Update the documentation about how to install PyFlink in docker
   - Revert "[FLINK-23759][runtime][checkpoint] Ignore the restored checkpoints when reporting latest completed id with abortion message"
   - [FLINK-24096][checkpoint] Skip the complete notification for checkpoints before task startup
   - [FLINK-24090][docs] Added Troubleshooting section with ignoring in-flight data explanation into unaligned checkpoints page
   - [refactor][streaming] Improved description of the calculation of the processing time delay
   - [refactor][streaming] Busy waiting in checkScheduledTimestamps replaced by CompletableFuture
   - [FLINK-23960][streaming] checkScheduledTimestamps changed according to semantic of the calculation processing time delay
   - [FLINK-23839][kafka] Improve warnings on InvalidTxnState-/ProducerFencedException
   - [FLINK-24020][web] Aggregate HTTP requests before custom netty handers are getting the data
   - [FLINK-23912][coordination] Ignore repeated empty requirements declarations
   - [FLINK-24064][connector/common] HybridSource restore from savepoint
   - [FLINK-23983][tests] Ensure to close and dispose created keyed-statebackend in StateBackendTestBase
   - [FLINK-24069][tests] Fail IgnoreInFlightData test when there is not enough data for it for all checkpoints not only the first one
   - [FLINK-24069][tests] Added exponentially increasing checkpoint interval for every next attempt of testIgnoreInFlightDataDuringRecovery
   - [FLINK-23832][docs] Update DataStream API Integration page
   - [FLINK-22971][tests] Bump testcontainers to 1.16.0
   - [hotfix][docs] Update Window TopN SQL example
   - [FLINK-24131][tests] Harden leak check in KafkaSinkITCase.
   - [FLINK-24131][datastream] Ensure that SinkWriter#prepareCommit is not called twice for final commit.
   - [FLINK-24131][datastream] Recommit recovered transactions as quickly as possible.
   - [FLINK-24131][datastream] Ensure writer and committer are closed correctly even with Interruptions.
   - [FLINK-24131][connectors/kafka] Ensure kafka writer and producer closed correctly even with Interruptions.
   - [FLINK-24131][runtime] Introduce CheckpointIDCounter#INITIAL_CHECKPOINT_ID.
   - [FLINK-24131][connectors/kafka] Improve debuggability of KafkaWriter.
   - [FLINK-24131][connectors/kafka] Improve handling of committer errors in KafkaCommitter.
   - [FLINK-24131][connectors/kafka] Improve threading model of KafkaWriter.
   - [FLINK-24131][connectors/kafka] Fix KafkaWriter currentSendTime metric.
   - [FLINK-24151][connectors/kafka] Add concurrent checkpoint test to KafkaSinkITCase.
   - [hotfix][tests] Parameterize PartiallyFinishedSourcesITCase with failover strategy
   - [FLINK-24162][tests] Check MAX_WATERMARK per attempt in FLIP-147 tests
   - [hotfix][yarn-tests] Fixes path definition for local YARN-test working directory artifact collection
   - [hotfix][yarn-tests] Replaces runtime by timestamp
   - [FLINK-23611][yarn-tests] Disables INFO log messages coming from YARN's ResourceLocalizationService
   - [FLINK-24137][python] Add more logs during starting up Python worker
   - [FLINK-24137][python][tests] Upload logs for PyFlink tests
   - [FLINK-24115][docs] Fix outdated SQL Temporal Join example (#17122)
   - [FLINK-24163][test] Increase the checkpoint timeout for PartiallyFinishedSourcesITCase
   - [FLINK-23949][checkpoint] Fix first incremental checkpoint after a savepoint degenerate into a full checkpoint
   - [FLINK-24183][legal] Add aws-java-sdk-s3 to source NOTICE
   - [FLINK-24170][build] Use maven-directory-plugin:directory-of goal
   - [FLINK-23961][kubernetes] Hint user about missing 'kubernetes.cluster-id' config option
   - [FLINK-24126][connector/kafka] Use increment of bytes consumed/produced for updating numBytesIn/Out in Kafka connector
   - [FLINK-23807][connector/testing-framework] Use RestClient to detect TaskManager failure in test environments
   - [FLINK-24034] Upgrade commons-compress to 1.21
   - [FLINK-24068][checkpoint] Also check for alignment start when received EndOfPartition from pending channels
   - [FLINK-24160][tests] Use FS checkpoint storage in PartiallyFinishedSourcesITCase
   - [FLINK-24031] Extend vcs.xml
   - [hotfix] Add .eslintcache to .gitignore
   - [FLINK-23462] [docs-zh] Translate the abfs documentation to chinese
   - [FLINK-22889][tests] Increase timeouts in JdbcExactlyOnceSinkE2eTest
   - [FLINK-24137][python] Fix the cases that Python boot process exits before Python SDK harness connects to the Java Operator in lookback mode
   - [FLINK-24137][python] Fix the issue that tests planned to run in process mode was actually executed in loopback mode
   - [FLINK-24213][qs] Introduce factory for established connection
   - [FLINK-24213][qs] Use single lock in ServerConnection
   - [FLINK-22357][core] Upgrades API stability of unified source API to @Public (= stable).
   - [hotfix][core] Improve/fix JavaDocs in SplitEnumeratorContext class.
   - [FLINK-22358][connector base] Add stability annotations to connector base and iterator sources.
   - [hotfix][connectors] Deduplicate config default in FutureCompletingBlockingQueue.
   - [hotfix] Remove outdated JavaDocs in SourceFunction about deprecated TimeCharacteristic
   - [hotfix] Deduplicate JavaDocs in SourceFunction
   - [hotfix][core] Make the example for checkpointed SourceFunction a bit less strange.
   - [FLINK-23527][core] Clarify semantics of SourceFunction.cancel() with respect to thread interruptions.
   - [FLINK-23345][python] Limits the version requests to 2.26.0 or above
   - [FLINK-23848][connector/pulsar] Fix the consumer not found.
   - [FLINK-23848][connector/pulsar] Make sure the topic would only be sought once.
   - [FLINK-23944][connector/pulsar] Enable PulsarSourceITCase.testTaskManagerFailure after test framework was fixed.
   - [FLINK-24123][python] Optimize the python operator instances of the same job to share one python environment resources in the same jvm
   - [FLINK-24161] Fix interplay of stop-with-savepoint w/o drain with final checkpoints
   - [FLINK-23864][docs] Add flink-connector-pulsar module to flink-docs, auto generate the config document.
   - [FLINK-23864][connector/pulsar] Release Pulsar Message if user enable poolMessage option.
   - [FLINK-23864][connector/pulsar] Remove PULSAR_AUTO_UPDATE_PARTITIONS option.
   - [FLINK-23864][docs] Add pulsar connector document (Chinese & English).
   - [hotfix] Improve language for error message when checkpoint is declined due to some tasks being finished already.
   - [FLINK-24065][connector] Upgrade the state of TwoPhaseCommitSink to support empty transaction after finished
   - [FLINK-18880][python] Respect configurations defined in flink-conf.yaml and environment variables when executing in local mode
   - [FLINK-24244][python] Logging whether it's executed in loopback mode
   - [FLINK-24184][task] Introduce lock to guard against race conditions around shouldInterruptOnCancel
   - [FLINK-24245][python] Fix the problem caused by multiple jobs sharing the loopback mode address stored in the environment variable in PyFlink
   - [FLINK-23458][docs] Added the network buffer  documentation along with the buffer debloat doc
   - [FLINK-24243][python] Cleanup code to use latest API to avoid warnings
   - [FLINK-24098] Document FLIP-147 capabiliites and limitations
   - [hotfix][docs] Adding new sources on overview pages
   - [FLINK-24206][connector/pulsar] Close the pulsar client properly.
   - [FLINK-24212][k8s]fix the problem that kerberos krb5.conf file is mounted as empty directory, not the expected file
   - [FLINK-24155][documentation] Sync Chinese version of documentation to configure CheckpointFailureManager (#17173) (#17252)
   - [hotfix][connector/common] Expose splitFinishedHook in SplitFetcher for fine-grained testing
   - [FLINK-23773][connector/kafka] Mark empty splits as finished to cleanup states in SplitFetcher
   - [FLINK-24267][python][docs] Update the example tutorial to use latest API
   - [FLINK-24276][python] Avoid confusing output when executing in loopback mode
   - [hotfix][connector] Use null to replace empty pending transaction in 2pc sink
   - [FLINK-24266][checkpoint] Log improvement for aborting checkpoint due to tasks are finishing
   - [hotfix][docs] Fix output of test job
   - [FLINK-23607][state/changelog] Make Changelog Backend a transitive dependency
   - [FLINK-23607][state/changelog] Cleanup dependencies of DSTL DFS
   - [FLINK-23607][state/changelog] Document checkpointing.changelog in pom.xml
   - [FLINK-24282][connectors/kafka] Make topic selector for KafkaSink serializable
   - [FLINK-24283][connector/pulsar] Use stick key consumer in Key_Shared subscription. This would make sure Pulsar won't treat the flink reader as a shared consumer.
   - [FLINK-21589][docs] Document table pipeline upgrades
   - [hotfix][docs] Add glossary entry for 'Table program'
   - [FLINK-24059][Connectors/Common][test] Allow SourceReaderTestBase.NUM_SPLITS to be overridden (#17064)
   - [FLINK-24305][python] Limit the protobuf version<3.18
   - [FLINK-24133][core] Network failure test replaced by comment in the code due to high expense of stabilizing such low important test
   - [hotfix] Fix a typo in 'estimatedTimeToConsume(r)BuffersMs'
   - [hotfix] Update frontend-maven-plugin
   - [FLINK-24317][python][tests] Optimize the implementation of Top2 in test_flat_aggregate
   - [hotfix][connectors/kafka] Remove unused code from KafkaDynamicSink
   - [FLINK-24281][connectors/kafka] Only allow KafkaSinkBuilder creation with KafkaSink.builder()
   - [FLINK-24281][connectors/kafka] Migrate all format tests from FlinkKafkaProducer to KafkaSink
   - [FLINK-24292][connectors/kafka] Use KafkaSink in examples instead of FlinkKafkaProducer
   - [hotfix][connectors/kafka] Rename EventDeSerializer to EventDeSerializationSchema in examples
   - [FLINK-23969][connector/pulsar] Create e2e tests for pulsar connector.
   - [FLINK-24129][connectors-pulsar] Harden TopicRangeTest.rangeCreationHaveALimitedScope.
   - [FLINK-24233][runtime] Ignore message about new buffer size if the reader doesn't ready yet
   - [FLINK-24300] SourceOperator#getAvailableFuture reuses future
   - [FLINK-24277][connector/kafka] Add configuration for committing offset on checkpoint and disable it if group ID is not specified
   - [FLINK-24277][connector/kafka] Remove auto-generated group id in Kafka table source
   - [FLINK-24277][connector/kafka] Add OffsetsInitializerValidator interface for validating offset initializer in KafkaSourceBuilder
   - [hotfix][docs] fix link from upsert-kafka to kafka Table(!) connector
   - [hotfix][test] Derive expected files from getFilesToUpload
   - [FLINK-24197] Guard against CLRF being split across chunks
   - [release] Create 1.14 release-notes
   - [FLINK-24303][coordination] Failure when creating a source enumerator lead to full failover, not JobManager failure.
   - [FLINK-24340] Only print exception on job failure/suspension
   - [FLINK-24347][connectors/kafka] Keep idle source readers if parallelism is higher than partitions in KafkaSource
   - [FLINK-24159][docs][Runtime/Checkpointing] document of entropy injection may mislead users
   - [FLINK-24329][pulsar][tests] Fix port conflict
   - [FLINK-23827][table-planner] Fix ModifiedMonotonicity inference for some nodes
   - [FLINK-24353][scripts] Respect dynamic configurations when calculating memory sizes.
   - [FLINK-24344][runtime] testTriggerCheckpointAfterIoException throws exception from initializeLocationForCheckpoint rather than from getAndIncrement
   - [FLINK-24344][runtime] Calling the CheckpointFailureManager even if the exception happens during the checkpoint initialization
   - [FLINK-24315][k8s] Add retry logic when watching pods
   - [FLINK-24336][python] Fix the issue that jar url list may contain empty string.
   - [hotfix][docs] Remove flink-connector-base as required dependency from the kafka connector
   - [hotfix][docs] Remove the explicit requirement of flink-connector-base, and add missing StartCursor in pulsar connector document.
   - [FLINK-24373][docs] Remove BETA Tag from FLIP-27 Source Docs
   - [hotfix][runtime][test] Use builder for creating TestingResourceManager.
   - [FLINK-24377][runtime] Actively release TM resource after heartbeat timeout.
   - [hotfix][test] Reduce visibility of test classes in SinkWriterOperatorTest
   - [FLINK-24371][datastream] Call preCommit on SinkWriter although no committer is available
   - [FLINK-24380][k8s] Terminate the pod if it failed
   - Update japicmp configuration for 1.14.0
   - [FLINK-23313][docs] Reintroduce temporal table function documentation
   - [hotfix][docs] Move out the time zone page from streaming concepts section
   - [hotfix][python][docs] Update the README of PyFlink
   - [release][docs] Clean up 1.14 release notes
   - [FLINK-24058][coordination] Extract TimerService interface
   - [FLINK-24058][coordination] Use ExecutorUtils#gracefulShutdown
   - [FLINK-24058][coordination][tests] Add TestingTimerService
   - [FLINK-24058][coordination][tests] Harden TaskSlotTableImplTest
   - [FLINK-24058][tests] Cleanup DefaultTimerServiceTest
   - [FLINK-24058][coordination][tests] Add test for TimerService#isValid
   - [hotfix][docs] Fix typo in sources doc
   - [FLINK-23519][metrics] Expose state name as varibale if enable state latency tracking
   - [FLINK-24148][state] Add bloom filter option in RocksDBConfiguredOptions
   - [FLINK-21853][e2e] Harden common_ha.sh#ha_tm_watchdog
   - [FLINK-21853][e2e] Reduce the number JM kills in test_ha_per_job_cluster_datastream.sh and test_ha_datastream.sh
   - [FLINK-24117][HA]Remove unHandledErrorListener in ZooKeeperLeaderElectionDriver and ZooKeeperLeaderRetrievalDriver
   - [FLINK-24367] RpcSystem#loader evaluates all service entries
   - [FLINK-24367][tests] Streamline instructions
   - [FLINK-24367][tests] Add FallbackAkkaRpcSystemLoader
   - [FLINK-24269][Runtime / Checkpointing] Rename methods around final checkpoints
   - [hotfix] Fix incorrect state.backend.local-recovery description
   - [FLINK-24445][build] Copy rpc-akka jar in package phase
   - [hotfix][FileSource] Internal refactoring to remove duplicated code without API change. Rename method argument names from "reader" to ***Format to improve the code readability.
   - [hotfix] Fix typo,'Kafka' corrected to 'Kafka'
   - [hotfix] Fix typo multiple word mistakes
   - [FLINK-24382][metrics] Do not compute recordsOut metric in SinkOperator to allow sinks emitting a flexible number of records
   - [FLINK-24405][tests] Introduce util to reliably drain all messages from a kafka topic
   - [FLINK-24405][tests] Harden kafka tests based on KafkaTestBase
   - [hotfix][datastream] Add missing Internal annotations for OperatorCoordinator class
   - [FLINK-24442][table][docs] Fix markup to show back ticks in "Queries" page (#17408)
   - [FLINK-24357][tests] Harden ZooKeeperLeaderElectionConnectionHandlingTest
   - [FLINK-24437][HA]Remove unhandled exception handler from CuratorFramework before closing it
   - [FLINK-23458][docs] Added the network buffer  documentation along with the buffer debloat doc to chinese part of the documentation
   - [FLINK-21345][table-planner] Fix bug of union all join temporal table
   - [FLINK-22954][table-planner] Rewrite Join on constant TableFunctionScan to Correlate
   - [FLINK-24291][table-planner] Decimal precision is lost when deserializing records from testcsv
   - [FLINK-24417] Update MigrationVersion with 1.14
   - [FLINK-24417] Regenerate files for migration tests
   - [FLINK-24431][kinesis][efo] Stop consumer deregistration when EAGER EFO configured. (#17417)
   - [FLINK-24376][runtime] Use operator name for constructing OperatorCoordinatorProvider instead of chained name
   - [refactor][streaming] Types corrections for BufferDebloaterTest
   - [refactor][streaming] Builder for parameters of  BufferDebloaterTest
   - [FLINK-24467][streaming] Announce the min and max buffer size despite last diff less than threshold
   - [FLINK-24513][tests] Make AkkaRpcSystemLoaderTest an ITCase
   - [FLINK-24460][rocksdb] Error handling improvement for RocksIteratorWrapper
   - Fix flaky test by retrying notifyCheckpointComplete until either commit success or timeout
   - [FLINK-24480][table-planner] Do not discard exception in test
   - [FLINK-24432][rocksdb] RocksIteratorWrapper.seekToLast() logic typo
   - [FLINK-23704][task] Extract LatencyMarkerEmitter class
   - [FLINK-23704][test] Introduce SourceOperatorTestHarnes
   - [FLINK-23704][task] FLIP-27 sources are not generating LatencyMarkers
   - [FLINK-23704][task] Apply review suggestsion for generating LatencyMarkers in FLIP-27 sources
   - [FLINK-23704][test] Remove unused CollectorDataOutput class
   - [FLINK-17914][hs] Keep archives if listStatus fails
   - [hotfix] Refactor JobArchiveFetcherTask#run
   - [FLINK-17914] Restructure HistoryServer
   - [FLINK-17914][tests] Increase chances of concurrent deletions
   - [FLINK-24540] Fix file stream resource leaks
   - [FLINK-24559][build] Fix flink-rpc-akka packaging
   - [FLINK-24469][runtime] Allow to have zero number of buffers in use for channels
   - [FLINK-24156][network] Guard against erroneous SocketTimeoutExceptions
   - [FLINK-24465] Fix disabling buffer timeout for pipelined exchanges
   - [hotfix][docs] Add additional sentence for minio users
   - [hotfix][docs] Specify that json format works for append only streams
   - [hotfix][docs] Specify that there is no defined ingestion order for the files in a directory when using the filesystem connector
   - [FLINK-24480][table-planner] Reduce number of fields in test
   - [FLINK-24355][runtime] Expose the flag for enabling checkpoints after tasks finish in the Web UI
   - [hotfix] Sync zh release notes 1.14
   - [hotfix] Update release notes with changes to StreamStatus
   - [FLINK-24318][table-planner] Casting a number to boolean has different results between 'select' fields and 'where' condition
   - [FLINK-24600][ui] Remove duplicate 99th percentile
   - [FLINK-24468][runtime] Moved the methods for sending messages from NetworkClientHandler to NettyPartitioonRequestClient since it is not responsibility of handler to send them
   - [FLINK-24468][runtime] Replaced submit by execute for submitting buffer size calculation to mailbox
   - [refactor][tests] Expanded toString for TestEventSource
   - [FLINK-24331][tests] Forbid to finish the TestEventSource if it has not sent at least one value
   - [FLINK-24613][doc] Documentation on orc supported data types is outdated
   - [FLINK-24647][runtime/coordination] Log thrown exception if UncaughtExceptionHandleMode.LOG is set
   - [FLINK-24662][python][tests] Set the version of Docutils to 0.17.1
   - [FLINK-23391][connector/kafka] Fix flaky Kafka source metric test by retrying notifyCheckpointComplete until success or timeout
   - [FLINK-24381][table] Hiden sensitive config values
   - [hotfix][test] Move CompletedCheckpointStore#storeFor to a test class
   - [FLINK-23647][checkpointing] Wait for CheckpointsCleaner to complete before closing cluster
   - [FLINK-24488][connectors/kafka] Fix KafkaRecordSerializationSchemaBuilder does not forward timestamp
   - [FLINK-24676][table-planner] Fix schema mismatch exception if explain insert with partial column
   - [FLINK-23614][table-planner] The resulting scale of TRUNCATE(DECIMAL) is not correct
   - [FLINK-15987][table-planner] Fix SELECT 1.0e0 / 0.0e0 throws NumberFormatException
   - [FLINK-24678][runtime/metrics] Correct the metric name of map state contains latency
   - [hotfix][connector/testing-framework] Let ExternalContext#generateTestData returns List to preserve order
   - [FLINK-23914][connector/testing-framework] Improve descriptions in test data matchers to reveal more info on failure
   - [FLINK-23914][connector/testing-framework] Add INFO log to track running stage of connector testing framework
   - [FLINK-24670][docs] Restructure unaligned checkpoints docs to checkpointing under backpressure
   - [FLINK-24695][docs] Update how to configure unaligned checkpoints
   - [hotfix][docs] Fix typo in network_mem_tuning.md
   - [FLINK-24612][connectors/kafka] Configure Kafka test container log levels accordingly to test logger
   - [FLINK-24563][table-planner] Fix NullPointerException when comparing timestamp_ltz with random string
   - [FLINK-24408][table-planner] Enable code splitting for large number of VALUES clause
   - [FLINK-24492][table-planner] Fix incorrect implicit type conversion between numeric and (var)char
   - [FLINK-23919][table-planner] Fix field name conflict bug in WindowUtil
   - [FLINK-24671][runtime] Return 0 buffers in use until subpartition view initialization in order to avoid NPE
   - [FLINK-15550][runtime] Don't ignore the interruption for testCancelTaskExceptionAfterTaskMarkedFailed
   - [FLINK-24728][table-runtime] Close output stream in batch SQL file sink
   - [FLINK-20443][API/DataStream] ContinuousProcessingTimeTrigger doesn't fire at the end of the window
   - [FLINK-20443][API/DataStream] ContinuousEventTimeTrigger  optimization
   - [FLINK-24746][ci] Use local Nexus cache
   - [FLINK-24597][state] Avoid KeyedStateBackend#getKeysAndNamespaces to return duplicate data
   - [FLINK-24551][runtime] Read BUFFER_DEBLOAT_SAMPLES from task manager configuration instead of task configuration
   - [FLINK-24706][tests] Increase restart delay to 5 seconds
   - [FLINK-24706][coordination] Strip completion exception in HeartbeatManager
   - [FLINK-24706][rpc] Forward deserialization errors to returned future
   - [FLINK-24609][akka][build] Use same Scala properties as root pom
   - [FLINK-24550][rpc] Use ContextClassLoader for message deserialization
   - [FLINK-24796][ci] Reduce size of compile build artifact
   - [FLINK-24401][runtime] Fix the bug of TM cannot exit after Metaspace OOM
   - [FLINK-24806][connectors/rabbitmq] Fix container startup in RMQSourceITCase
   - [FLINK-24761][table] Fix PartitionPruner code gen compile fail
   - [hotfix][table-common][tests] Add tests for LogicalTypeMerging decimal rules
   - [hotfix][table-common] Add java docs to LogicalTypeMerging
   - [FLINK-24691][table-planner] Fix decimal precision for SUM
   - [FLINK-24654][table] Fix NPE on RetractableTopNFunction when some records were cleared by state ttl
   - [FLINK-24704][table-runtime] Fix exception when the input record loses monotonicity on the sort key field of UpdatableTopNFunction
   - [FLINK-21289][deployment] FIX missing load pipeline.classpaths in application mode, for both k8s and yarn
   - [FLINK-24738][runtime] Ignoring buffer size announcement if the channel is released already
   - [FLINK-24667][runtime] Fix error handling in ChannelStateCheckpointWriter
   - [FLINK-23696][connectors/rabbitmq] Fix RMQSourceTest.testRedeliveredSessionIDsAck test
   - [FLINK-24733][connector/pulsar] Data loss in pulsar source when using shared mode
   - [FLINK-24455][tests]FallbackAkkaRpcSystemLoader checks maven exit code
   - [FLINK-24874][web] Add missing imports for dropdown menu
   - [FLINK-24800][runtime] Changed the assert condition for checking buffer timeout disabling test
   - [FLINK-24773][kafka] Fail job if unhandled exception occurs during committing
   - [FLINK-24552][tests] Moved randomization of buffer debloat from StreamEnvironment to MiniClusterResource
   - [hotfix] Fix spotless issues in MiniClusterResource
   - [FLINK-24690][runtime] Changed the calculation of reaching buffer debloat threshold into more expected way
   - [FLINK-24839][fs-connector] Increase Timeout of FsStreamingSinkITCaseBase to 240
   - [hotfix][tests] Make RpcEndpointTest more informative
   - [FLINK-22419] Wait unlimited in RpcEndpointTest.testCallAsyncTimeout
   - [FLINK-24409][kafka] Fix collection of KafkaSourceReaderMetrics for topics containing periods
   - [FLINK-24409][kafka] Log PendingRecords metrics name if record lag collection fails
   - [FLINK-24631][k8s] Use a stable subset of labels to select jobManager and taskManager pods
   - [FLINK-24366][runtime] Don't log error for failed task restore if the task is already canceled.
   - [FLINK-24255][tests] Test environments respect configuration when being instantiated.
   - [FLINK-23842][coordination] Add logging statements in SourceCoordinators for reader registration and split requests.
   - [FLINK-24835][table-planner] Fix bug in `RelTimeIndicatorConverter` when materialize time attribute fields of regular join's inputs
   - [FLINK-24608][table-planner][table-runtime] Insert rowtime into StreamRecord for SinkProviders
   - [FLINK-24708][table-planner] Fix wrong results of the IN operator
   - [FLINK-24937][e2e] Return correct exit code in build_image
   - [FLINK-24739][docs] Add backreference from the deployment mode of a resource provider to the high-level deployment mode overview.
   - [FLINK-24739][docs] Highlight the fact that the Application Mode excpects user jars to be bundled with the Flink distribution.
   - [FLINK-24958][docs] Fix the link and typo in SQL "Joins" page (#17835)
   - [FLINK-24858][core] Prevent version mismatches in TypeSerializers
   - [FLINK-24922][docs]Fix spelling errors in the word parallism (#17816)
   - [FLINK-25067][doc] Correct the description of RocksDB's background threads for flush and compaction
   - [FLINK-24971][tests] Adding retry function for failures in Bash e2e tests
   - [FLINK-21214][kafka/IT] Add retry rule for the ITCase. The issue has been solved after bumping Kafka to 2.8.1.
   - [FLINK-24543][runtime] Avoid possible inconsistencies of ZookeeperStateHandleStore in case of unstable connection.
   - [FLINK-24789][runtime] Close CheckpointCleaner after checkpoint services in `DefaultScheduler#closeAsync()` and `AdaptiveScheduler#closeAsync()`.'
   - [FLINK-23798][state] Avoid using reflection to get filter when partition filter is enabled
   - [FLINK-24310][doc]Use >= instead of == to cover the downscaling scenario
   - [FLINK-24596][table] Allow using unified Sinks with the DataStreamSinkProvider
   - [FLINK-24596][core] Introduce SerializableFunction and unify usages
   - [FLINK-24596][kafka] Make passed lambdas of UpsertKafka serializable
   - [FLINK-25112][tests] Remove cache-ttl for Java e2e tests
   - [FLINK-21467] Clarify javadocs of Bounded(One/Multi)Input interfaces
   - [FLINK-25092][tests][elasticsearch] Refactor test to use artifact cacher
   - [FLINK-24348][FLINK-24740][testinfrastructure][kafka] Update testcontainers dependency to v1.16.2
   - [FLINK-15493][test] Inherit retry rule annotations to sub classes
   - [FLINK-15493][test] Add retry rule for all tests based on KafkaTestBase
   - [FLINK-25134][test] Remove unused RetryRule from KafkaConsumerTestBase
   - [hotfix][ci] Enable cron build
   - [FLINK-24919][runtime] Getting vertex only under synchronization
   - [FLINK-21407][doc][formats] Add formats to DataStream connectors doc
   - [FLINK-21407][doc][formats] Move haddop input and output formats to hadoop.md formats page
   - [FLINK-21407][doc][formats] Update hadoop doc
   - [FLINK-21407][doc][formats] Drop old formats
   - [FLINK-21407] bump microsoft-hadoop-azure version
   - [FLINK-21407][doc][formats] Split DataSet connectors page into different formats and create a formats sub-folder like in table api doc
   - [FLINK-24813][table-planner] Improve ImplicitTypeConversionITCase
   - [hotfix] Make IncrementalLocalKeyedStateHandle serializable by copying sharedStateHandleIDs
   - [hotfix][tests] Remove Mocking from TaskLocalStateStoreImplTest
   - [FLINK-24506][config] Adds checkpoint directory to CheckpointConfig
   - [FLINK-24777][docs] Correct description of 'Processed (persisted) in-flight data'
   - [FLINK-24859][doc][formats] Make new formats name coherent
   - [FLINK-24859][doc][formats] document text file reading
   - [FLINK-24859][doc][formats] document parquet file reading
   - [FLINK-23493][python] Remove the calling of child process in the beam_boot.py
   - [FLINK-25022][rest] Run jars in separate threads
   - [FLINK-22113][table-planner] Implement column uniqueness checking for TableSourceTable
   - [FLINK-20370][table] part1: Fix wrong results when sink primary key is not the same with query result's changelog upsert key
   - Revert "[FLINK-24859][doc][formats] Make new formats name coherent"
   - [hotfix][runtime] Refactor testing methods out from SlotProfile into SlotProfileTestingUtils
   - [hotfix][runtime] Rename `previousExecutionGraphAllocations` in SlotProfile to `reservedAllocations` to avoid confusion
   - [hotfix][tests] Factor PerJobMiniClusterFactoryTest#MyCancellableInvokable out to be a standalone test class in flink-runtime
   - [FLINK-19142][runtime] Use LocationPreferenceSlotSelectionStrategy for batch jobs even if local recovery is enabled
   - [FLINK-19142][runtime] Fix slot hijacking after task failover
   - [FLINK-25091][docs] Change ORC compression attribute reference error in FileSink doc
   - [FLINK-25096] Fixes empty exception history for JobInitializationException (#18035)
   - [FLINK-23946][clients] Dispatcher in application mode should be able to recover after losing and regaining leadership.
   - [FLINK-23946][FLINK-24038][tests] Harden ZooKeeperLeaderElectionITCase.
   - [FLINK-23946][clients] Code review based fixes.
   - [FLINK-23946] Flink 1.14 compatibility + disable a flaky test `ZooKeeperLeaderElectionITCase#testJobExecutionOnClusterWithLeaderChange` (FLINK-25235)
   - [FLINK-25126][kafka] Reset internal transaction state of FlinkKafkaInternalProducer if transaction finalization fails
   - [FLINK-24077][HBase/IT] Add check of row count after insert and wait explicitly for job to finish.
   - [FLINK-24077][HBase/IT] use MiniClusterWithClientResource as @ClassRule.
   - [FLINK-25240][build] Upgrade Log4j2 to 2.15.0
   - [hotfix][docs] Update Log4j version in Gradle template
   - [FLINK-20195][coordination] Deduplicate jobs for overview
   - [FLINK-22096][tests] Fix port conflict for ServerTransportErrorHandlingTest#testRemoteClose
   - [hotfix][docs] Fix Scala example for MiniCluster test
   - [FLINK-24987][streaming-java] Add explicit enum value NO_EXTERNAL_CHECKPOINTS as default for externalized-checkpoint-retention
   - [FLINK-24987][docs] Improve ExternalizedCheckpointCleanup documentation
   - [FLINK-22775][cassandra][tests] Lower write consistency level to ANY
   - [FLINK-25295][build] Update log4j2 dependency to 2.16.0
   - [FLINK-24846][streaming] Ignoring completing async operator record if mailbox is closed already
   - [FLINK-25222][tests] Remove NetworkFailureProxy used in Kafka tests
   - [hotfix][tests] Close Kafka AdminClients to prevent resource leaks
   - [hotfix][tests] Await broker shutdown during KafkaTestEnvironmentImpl#shutdown
   - [FLINK-24846][streaming] Guava import fix in AsyncWaitOperatorTest
   - Update for 1.14.2
   - [FLINK-25326][connectors/kafka] Fix application of log levels in KafaUtils.createKafkacontainer
   - [FLINK-24232][coordination] Skip history server archiving for suspended jobs
   - [FLINK-24728][tests] Add tests to ensure SQL file sink closes all created files
   - [FLINK-25147][connectors][test] Migrate Cassandra connector tests to testContainers
   - [FLINK-25147][connectors][test] This test case now works on java 11
   - [FLINK-25271][clients] Harden the ApplicationDispatcherBootstrapITCase.
   - [FLINK-25422][python] Specify requirements in dev-requirements.txt
   - [hotfix][docs] Minor fixes in Network Memory Tuning Guide
   - [FLINK-24481][docs] Translate buffer debloat documenation to chinese
   - [FLINK-25375] Update log4j2 dependency to 2.17.0 to address (#18167)
   - [FLINK-25132][connector/kafka] Move record deserializing from SplitFetcher to RecordEmitter to support object-reusing deserializer
   - [FLINK-23047] Ignore CassandraConnectorITCase until the flakiness of this test is fixed.
   - [FLINK-25446][state] Avoid improper sanity check on read bytes on DataInputStream#read(byte[])
   - [FLINK-25468] Copy SST files if they cannot be hard linked in RocksDBHandle.restoreInstanceDirectoryFromPath
   - [FLINK-25147] add keyspace drop because the docker image is reused and modified by the tests.
   - [FLINK-25415] Add retries to CasandraConnectorITCase
   - [hotfix][connectors][docs] Use big M letters for month in date format
   - [FLINK-25472][core] Update to Log4j 2.17.1
   - [FLINK-25418][python] Install dependencies offline if the cache dir is specified
   - [FLINK-25294][python] Fix cloudpickle import
   - [FLINK-25477][docs] Make the directory structure of the State Backends document display correctly
   - [hotfix][doc]Fixed an issue where clicking Window Assigner and Window Function in Windows documents could not jump correctly.
   - [FLINK-25464][python] Turn on output infos for package installation in tox
   - [FLINK-25513][python] Handle properly for None result in flat_map and map of ConnectedStream
   - [FLINK-24880][python] Fix PeriodicThread to handle properly for negative wait timeout value
   - [FLINK-25307][test] Print the curl logs is querying dispatcher startup failed
   - [FLINK-25362][docs] allow SQL maven artifact list
   - [FLINK-25362][docs] fix the Avro Format maven dependency
   - [FLINK-25362][docs] fix maven instructions for "Confluent Avro Format"
   - [FLINK-25576][Connectors][JDBC] Upgrade com.h2database:h2 to 2.0.206
   - [FLINK-25280][connector/kafka] Disable log deletion in KafkaTestEnvironmentImpl to prevent records from being deleted during test run
   - [hotfix] Rename some methods of NetworkBufferPool and add more comments for better readability
   - [FLINK-25407][network] Fix the issues caused by FLINK-24035
   - [FLINK-25160][docs] Clarified purpose of execution.checkpointing.tolerable-failed-checkpoints
   - [FLINK-24954][network] Refresh read buffer request timeout on buffer recycling/requesting for sort-shuffle
   - [hotfix] Fix typing errors for SortMergeResultPartitionReadScheduler#createSubpartitionReader
   - [FLINK-24444][runtime][tests] Wait until checkpoints stopped triggering
   - [FLINK-24858][release][docs] Recommend users to upgrade to 1.14.3 from 1.13.x to use state serializer fix
   - [FLINK-25654][network] Remove the redundant locks in SortMergeResultPartition and PartitionSortedBuffer.
   - [FLINK-25611][core] Remove CoordinatorExecutorThreadFactory thread creation guards
   - [FLINK-25650][docs] Added "Interplay with long-running record processing" limit in unaligned checkpoint documentation
   - [FLINK-25633] Set locale to en-US to avoid ambiguous decimal formattings
   - Update japicmp configuration for 1.14.3
   - [FLINK-25199][network] Make sure StreamEdges are unique
   - [FLINK-20188][Connectors][Docs][FileSystem] Added documentation for File Source
   - [FLINK-25674][connectors][cassandra][tests] Add drop tables to be idempotent in case of retrials and the related test
   - [FLINK-25674][connectors][cassandra][tests] use constants instead of string literals to avoid copy/paste
   - [FLINK-25678][runtime] Make TaskExecutorStateChangelogStoragesManager.shutdown thread-safe
   - [FLINK-24334][k8s] Set FLINK_LOG_DIR environment for JobManager and TaskManager pod if configured via options
   - [FLINK-25683][table] Pass MAX_WATERMARK in InputConversionOperator
   - [FLINK-25732][coordination] Pass serializable collection
   - [hotfix][docs] Fixing multiple internal and external 404 links
   - [FLINK-25171][table-planner] Validation of duplicate fields in ddl sql
   - Update for 1.14.3
   - [FLINK-25278][ci] Use Maven proxy for confluent repo
   - [FLINK-25767][docs-zh] Totally translate state.md into Chinese
   - [FLINK-25486][Runtime/Coordination] Fix the bug that flink will lost state when zookeeper leader changes
   - [FLINK-25728][task] Avoid unnessesary CompletableFuture.thenRun calls on idle inputProcessor's avaiableFuture, preventing memory leaks.
   - [FLINK-25728][task] Simplify MultipleInputAvailabilityHelper
   - [FLINK-25818][Docs][Kafka] Add explanation how Kafka Source deals with idleness when parallelism is higher then the number of partitions
   - [FLINK-25147][connectors][Cassandra][test] Use parent test containers version
   - [FLINK-25771][connectors][Cassandra][test] Raise all read/write/miscellaneous requests timeouts
   - [FLINK-25771][connectors][Cassandra][test] Add a test that raiseCassandraRequestsTimeouts indeed changes the configuration inside the container.
   - [FLINK-25880][docs] Remove Google Analytics implementation
   - [FLINK-25880][docs] Add Matomo tracking code to base layout
   - [FLINK-21788][network] Throw PartitionNotFoundException if the partition file has been lost for blocking shuffle
   - [FLINK-25653][network] Move buffer recycle in SortMergeSubpartitionReader out of lock to avoid deadlock
   - [hotfix][test] Extract SourceOperatorTestBase from SourceOperatorTest
   - [hotfix][test] Fix SourceOperatorTest#testSameAvailabilityFuture
   - [FLINK-25827][task] Move and rename MultipleInputAvailabilityHelper
   - [FLINK-25827][task] Fix potential memory leak in SourceOperator when using CompletableFuture.anyOf
   - [FLINK-21752] NullPointerException on restore in PojoSerializer
   - [FLINK-21752] Add a call to TypeSerializer#duplicate in migration tests
   - [FLINK-25879][Docs] Track used search terms in Matomo
   - [FLINK-25952] Savepoints on S3 are not relocatable even if entropy injection is not enabled
   - [FLINK-26039][table-runtime] Fix the incorrect value getter in map unnest table function
   - [FLINK-25041][e2e] Improve error handling for missing environment variables in E2E tests
   - [FLINK-18356][tests] Disable fork-reuse for table-planner
   - [FLINK-25785][Connectors][JDBC] Upgrade com.h2database:h2 to 2.1.210
   - [FLINK-25466][state] Enable state descriptor to handle StateTtlConfig#DISABLED
   - [FLINK-24880][python] Fix PeriodicThread to handle properly for negative wait timeout value
   - [FLINK-25227][table] Boxed numeric type should be considered when generating code for equality checking
   - [FLINK-25883][python] Set the default value of DEFAULT_BUNDLE_PROCESSOR_CACHE_SHUTDOWN_THRESHOLD_S to 30 days
   - [FLINK-21407][docs][formats] Remove MongoDb connector as it is not supported on DataStream API.
   - [FLINK-20830][k8s] Add type of Headless_Cluster_IP for external rest service
   - [FLINK-26187][docs] Chinese docs only redirect for chinese urls
   - [FLINK-25698][connectors/elasticsearch] Enable logging for Elasticsearch containers
   - [FLINK-26105][e2e] Removes printing of logs to stdout for pyflink_test
   - [FLINK-26105][e2e] Fixes log file extension
   - [FLINK-23240][runtime] Master process supports living through multiple leader sessions.
   - [FLINK-25893][runtime] Fix that ResourceManagerServiceImpl may call ResourceManager#deregisterApplication before RM being fully started.
   - [FLINK-25893][runtime] Do not report error if ResourceManagerServiceImpl#deregisterApplication is called when there's no leading RM.
   - [FLINK-25856][python][BP-1.14] Fix use of UserDefinedType in from_elements
   - [FLINK-25851][build][tests] Bump bytebuddy to 1.8.22
   - [FLINK-25851][cassandra][tests] Inject dynamic table name into Pojos
   - [FLINK-24607] Let Deadline handle duration overflow.
   - [FLINK-24607] Add util methods to shutdown executor services.
   - [FLINK-24607] Make OperatorCoordinator closure more robust.
   - [FLINK-24407][doc-zh] Fix the broken links in Chinese document of Pulsar connector
   - [FLINK-26304][streaming] Do not forward failed committables
   - [FLINK-26160][pulsar][doc] update the doc of setUnboundedStopCursor()
   - [FLINK-26159][doc] add description for MAX_FETCH_RECORD related question
   - [FLINK-26285] Fixes an inconsistency which was introduced by c3a6b51 as part of changes done for FLINK-19543
   - [FLINK-25819][runtime] Reordered requesting and recycling buffers in order to avoid race condition in testIsAvailableOrNotAfterRequestAndRecycleMultiSegments
   - [FLINK-25819][runtime] Added new test for 'Insufficient number of network buffers' scenario into NetworkBufferPoolTest
   - [hotfix][runtime] CodeStyle correction for NetworkBufferPoolTest
   - [Hotfix][doc] Fix typo in java code demo of ES stream connector page for release-1.14 (#18934)
   - [FLINK-25026] UnalignedCheckpointRescaleITCase.shouldRescaleUnalignedCheckpoint fails on AZP
   - [hotfix][docs][table] Fix docs for SHA1
   - [hotfix][Pattern Recognition][docs] Fixed an issue that the example of “Time constraint” omits a comma.
   - [FLINK-26223] Updates log4j configuration
   - [FLINK-26407][end-to-end-tests] Increase timeouts for MetricsAvailabilityITCase.
   - [FLINK-26049][checkpoint] initialize CheckpointLocation after create PendingCheckpoint
   - [FLINK-26049][checkpoint] Moving checkpoint failure log and report failed checkpoint to CheckpointFailureManager
   - [FLINK-26049][checkpoint] Adding CheckpointStatsTracker logic without pending checkpoint
   - [FLINK-20633][python] Add retry times to download avro
   - [FLINK-26504][python] Fix the incorrect type error in unbounded Python UDAF
   - [FLINK-26543][python] Fix the issue that exceptions generated during startup are lost in Python loopback mode
   - [FLINK-23843][runtime] Properly fail the job when SplitEnumeratorContext.runInCoordinatorThread() throws an exception.
   - [FLINK-25771][cassandra][tests] Raise client timeouts
   - [FLINK-26352][runtime-web] Add missing license headers to WebUI source files
   - [FLINK-15550][runtime] Debug logging for TaskTest
   - [FLINK-26550][checkpoint] Correct the information of checkpoint failure
   - [FLINK-24538][runtime][tests] Fix race condition when offering information to leader event queue in TestingRetrievalBase
   - [FLINK-26501][e2e-tests] Added new exception to white list since the failed checkpoint exception is always logging on the task manager site now
   - [FLINK-24274][Documentation] Wrong parameter order in documentation of State Processor API
   - [FLINK-26500][runtime][test] Increases the deadline to wait for parallelism
   - [FLINK-26121][runtime] Adds clearUnhandledEvents() method We experienced some ZK connection issue which resulted in a SUSPEND and a RECONNECT event which were not handled and, therefore, stayed in the queue blocking a thread for the second event (because the capacity of the internally used ArrayBlockingQueue is set to 1). Shutting down the driver initiates a shutdown of the ExecutorService which is used for the listeners internally (see ZooKeeperLeaderRetrievalDriver.close()). The blocking thread will cause a fatal error through an InterruptedException. The test will fail due to the fatal error in the end.
   - [BP-1.14][docs] Update wrong links in the datastream/execution_mode.md page.
   - [FLINK-25771][cassandra][tests] Remove keyspace drop
   - [hotfix] set Flink version to 1.14.4 in docs
   - [FLINK-26650][checkpoint] Avoid to print stack trace for checkpoint trigger failure if not all tasks are started
   - [FLINK-26596][runtime][test] Adds leadership loss handling
   - [FLINK-26658][docs] Migrate documentation build to Github Actions
   - [FLINK-26607][python] Correct the MAX_LONG_VALUE/MIN_LONG_VALUE in several places
   - [hotfix][ci] Try to fix the e2e ci pipeline upgrading the libssl version
   - [hotfix][python][docs] Improve the documentation about how to specify jar files on Windows
   - [FLINK-26723][runtime]fix the error message thrown by SourceCoordinatorContext
   - [FLINK-26618][sql-client] Fix 'remove jar' statement is not aligned with pipeline jars
   - [FLINK-26016][hive] Fix FileSystemLookupFunction does not produce correct results when hive table uses columnar storage
   - [FLINK-5151][docs] Add descriptions about object mutations of state backends
   - [FLINK-26381][docs] Wrong document order of Chinese version
   - [hotfix][docs] Fix the broken link for late events/lateness
   - [hotfix][docs] Fix doc for interval of years
   - [FLINK-26334][datastream] for 1.14.0 . Modified getWindowStartWithOffset method in org.apache.flink.table.runtime.operators.window.TimeWindow and org.apache.flink.streaming.api.windowing.windows.TimeWindow . Added test cases in unit test TimeWindowTest.
   - [FLINK-25904][metrics] Lazily initialize Percentile
   - [FLINK-26775][python] WindowOperator#process_element registers wrong cleanup timer
   - [FLINK-26536][python] Fix RemoteKeyedStateBackend#merge_namespaces to handle properly for the timerservice
   - [hotfix][python][docs] Fix the example in intro_to_datastream_api
   - [FLINK-26846][python] Fix the gauge metric
   - [FLINK-26855][python] Fix Sphinx check failure caused by Jinja2 dependency (#19238)
   - [hotfix][WebUI] Add .angular to .gitignore
   - [FLINK-26708] TimestampsAndWatermarksOperator should not propagate WatermarkStatus
   - [hotfix][connector/common] Fix typo of variable in SourceOperator
   - [FLINK-26018][connector/common] Create per-split output on split addition in SourceOperator
   - [FLINK-26134][docs] Added documentation page with Checkpoint/Savepoint guarantees
   -  [FLINK-26629][runtime] fix bug in code comment of SubtaskStateMapper.RANGE
   - [FLINK-26395][docs] Correct the wrong description of SQL function: RAND_INTEGER. This fixes #19258
   - [FLINK-26575][checkpoint] Improve the info message when restoring keyed state backend
   - [FLINK-26460][table-planner] Fix Unsupported type when convertTypeToSpec: MAP
   - [FLINK-25440][doc][pulsar] Stop and Start cursor now all uses publishTime instead of eventTime; doc changed to reflect this change
   - [FLINK-26798][runtime] Hardens test against unexpected heartbeat
   - [FLINK-26920][python] Handles the dependencies properly in create_temporary_view
   - [FLINK-26797][runtime] Makes the test less strict
   - [hotfix][runtime] Adds debug logs for FinalRequestProcessor to CI run
   - [FLINK-26738][state] Mark StateDescriptor#defaultValue as deprecated with clear docs
   - [FLINK-26961][BP-1.14][connectors][filesystems][formats] Update Jackson Databi… (#19340)
   - [FLINK-25238][table-runtime] Fix ArrayDataSerializer#copy for customized types
   - [FLINK-27108][python] Fix the state cache clean up logic
   - [FLINK-27088][Documentation] Fix the example of using StringDeserializer for deserializing Kafka message value as string
   - [FLINK-27223][python] Fix the state access problem when python.state.cache-size is set to 0
   - [FLINK-25694][Filesystem][S3] Upgrade Presto to resolve GSON/Alluxio Vulnerability. This closes #19478
   - [FLINK-27315][docs] Fix the demo of MemoryStateBackendMigration
   - [hotfix][docs] Misprint in types.md
   - [FLINK-22984][python] Don't pushdown Calc containing Python UDFs into table source
   - [FLINK-27409][runtime] Cleanup stale slot allocation record when the resource requirement of a job is empty
   - [hotfix][tests] Allow retrieval of termination future for running jobs
   - [hotfix][tests] Wait for JobManagerRunner termination
   - [FLINK-24491][runtime] Make the job termination wait until the archiving of ExecutionGraphInfo finishes
   - [FLINK-27420] Recreate metric groups for each new RM to avoid metric loss
   - Revert "[FLINK-27420] Recreate metric groups for each new RM to avoid metric loss"
   - [FLINK-27442][Formats][Avro Confluent] Add Confluent repo to module flink-sql-avro-confluent-registry
   - [release] Show outdated warning for 1.14 docs
   - [FLINK-27545][python][examples] Update the example in PyFlink shell
   - [hotfix][docs] Update Chinese version of datastream.md to include section about NoClassDef found when "Running in an IDE"
   - [FLINK-27480][kafka] Explain possible metrics InstanceAlreadyExistsException in docs
   - [hotfix][docs] Mention changes of "RuntimeContext#getMetricGroup" in 1.14 release notes.
   - [FLINK-26645][Connector/pulsar] Support subscribe only one topic partition.
   - [hotfix][ci] Update libssl download link
   - [FLINK-27255] [flink-avro] flink-avro does not support ser/de of large avro schema (#19705)
   - [FLINK-24433][Tests][Buildsystem] Turn off debug logging for all end-to-end tests to avoid flooding the disk space
   - [FLINK-24433][Tests][Buildsystem] Remove additional pre-installed packages to clean up more diskspace before starting the E2E tests. Also removing the line that removes `^ghc-8.*` since that doesn't exist anymore on the machines.
   - [FLINK-27676][python] Fix on_timer output behind triggering watermark
   - [FLINK-26788][core] Add cause when AbstractDeserializationSchema throw exception
   - [FLINK-27733][python] Rework on_timer output behind watermark bug fix
   - [FLINK-27751][build] Disable jboss repository
   - [FLINK-27174][connector/kafka] Fix checking of bootstrapServers when already provided in producer Properties
   - [FLINK-27760][python] Fix the issue that NPE is thrown when executing PyFlink Table API jobs in batch mode
   - [FLINK-27776][python] Throw meaningful exceptions when UDAF doesn't override method 'merge' is used in cases where 'merge' is used
   - [hotfix][doc] fix typo and enlarge image
   - [FLINK-27683][table-planner][realease-1.14] Fix SQL hints can't work with targetColumns
   
   <!--
   *Thank you very much for contributing to Apache Flink - we are happy that you want to help us improve Flink. To help the community review your contribution in the best possible way, please go through the checklist below, which will get the contribution into a shape in which it can be best reviewed.*
   
   *Please understand that we do not do this to make contributions to Flink a hassle. In order to uphold a high standard of quality for code contributions, while at the same time managing a large number of contributions, we need contributors to prepare the contributions well, and give reviewers enough contextual information for the review. Please also understand that contributions that do not follow this guide will take longer to review and thus typically be picked up with lower priority by the community.*
   
   ## Contribution Checklist
   
     - Make sure that the pull request corresponds to a [JIRA issue](https://issues.apache.org/jira/projects/FLINK/issues). Exceptions are made for typos in JavaDoc or documentation files, which need no JIRA issue.
     
     - Name the pull request in the form "[FLINK-XXXX] [component] Title of the pull request", where *FLINK-XXXX* should be replaced by the actual issue number. Skip *component* if you are unsure about which is the best component.
     Typo fixes that have no associated JIRA issue should be named following this pattern: `[hotfix] [docs] Fix typo in event time introduction` or `[hotfix] [javadocs] Expand JavaDoc for PuncuatedWatermarkGenerator`.
   
     - Fill out the template below to describe the changes contributed by the pull request. That will give reviewers the context they need to do the review.
     
     - Make sure that the change passes the automated tests, i.e., `mvn clean verify` passes. You can set up Azure Pipelines CI to do that following [this guide](https://cwiki.apache.org/confluence/display/FLINK/Azure+Pipelines#AzurePipelines-Tutorial:SettingupAzurePipelinesforaforkoftheFlinkrepository).
   
     - Each pull request should address only one issue, not mix up code from multiple issues.
     
     - Each commit in the pull request has a meaningful commit message (including the JIRA id)
   
     - Once all items of the checklist are addressed, remove the above text and this checklist, leaving only the filled out template below.
   
   
   **(The sections below can be removed for hotfixes of typos)**
   -->
   
   ## What is the purpose of the change
   
   *(For example: This pull request makes task deployment go through the blob server, rather than through RPC. That way we avoid re-transferring them on each deployment (during recovery).)*
   
   
   ## Brief change log
   
   *(for example:)*
     - *The TaskInfo is stored in the blob store on job creation time as a persistent artifact*
     - *Deployments RPC transmits only the blob storage reference*
     - *TaskManagers retrieve the TaskInfo from the blob cache*
   
   
   ## Verifying this change
   
   Please make sure both new and modified tests in this PR follows the conventions defined in our code quality guide: https://flink.apache.org/contributing/code-style-and-quality-common.html#testing
   
   *(Please pick either of the following options)*
   
   This change is a trivial rework / code cleanup without any test coverage.
   
   *(or)*
   
   This change is already covered by existing tests, such as *(please describe tests)*.
   
   *(or)*
   
   This change added tests and can be verified as follows:
   
   *(example:)*
     - *Added integration tests for end-to-end deployment with large payloads (100MB)*
     - *Extended integration test for recovery after master (JobManager) failure*
     - *Added test that validates that TaskInfo is transferred only once across recoveries*
     - *Manually verified the change by running a 4 node cluster with 2 JobManagers and 4 TaskManagers, a stateful streaming program, and killing one JobManager and two TaskManagers during the execution, verifying that recovery happens correctly.*
   
   ## Does this pull request potentially affect one of the following parts:
   
     - Dependencies (does it add or upgrade a dependency): (yes / no)
     - The public API, i.e., is any changed class annotated with `@Public(Evolving)`: (yes / no)
     - The serializers: (yes / no / don't know)
     - The runtime per-record code paths (performance sensitive): (yes / no / don't know)
     - Anything that affects deployment or recovery: JobManager (and its components), Checkpointing, Kubernetes/Yarn, ZooKeeper: (yes / no / don't know)
     - The S3 file system connector: (yes / no / don't know)
   
   ## Documentation
   
     - Does this pull request introduce a new feature? (yes / no)
     - If yes, how is the feature documented? (not applicable / docs / JavaDocs / not documented)
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [flink] xuanyu66 closed pull request #19891: [FLINK-27683][table-planner][realease-1.14] Fix SQL hints can't work with targetColumns

Posted by GitBox <gi...@apache.org>.
xuanyu66 closed pull request #19891:  [FLINK-27683][table-planner][realease-1.14] Fix SQL hints can't work with targetColumns
URL: https://github.com/apache/flink/pull/19891


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org