This is an automated email from the ASF dual-hosted git repository. jarvis pushed a commit to branch 2.3.8-release in repository https://gitbox.apache.org/repos/asf/seatunnel.git
commit d7c2f433347177b3d889e588ef5e9df80721a658 Author: jarvis <jar...@apache.org> AuthorDate: Tue Oct 8 19:54:00 2024 +0800 [Release][2.3.8][release-note] Add release-note --- release-note.md | 378 +++++++++++++++++++++++++------------------------------- 1 file changed, 170 insertions(+), 208 deletions(-) diff --git a/release-note.md b/release-note.md index 6147093eee..8dfdaca62d 100644 --- a/release-note.md +++ b/release-note.md @@ -1,236 +1,198 @@ -# next-release +# 2.3.8 Release Note + ## Bug fix ### Core -- [Core] [API] Fixed generic class loss for lists (#4421) -- [Core] [API] Fix parse nested row data type key changed upper (#4459) -- [Starter][Flink]Support transform-v2 for flink #3396 -- [Flink] Support flink 1.14.x #3963 -- [Core][Translation][Spark] Fix SeaTunnelRowConvertor fail to convert when schema contains row type (#5170) -### Transformer -- [Spark] Support transform-v2 for spark (#3409) -- [ALL]Add FieldMapper Transform #3781 -- [All]Add JsonPath Transform #5633 +- [Hotfix][Core] Fix concurrency exceptions when MultiTableSink#PrepareCommit (#7686) +- [hotfix][zeta] conf property is null, print log bug fix (#7487) +- [Fix][Seatunnel-core]Fix syntax error in the execution script on Windows (#7423) + ### Connectors -- [Elasticsearch] Support https protocol & compatible with opensearch -- [Hbase] Add hbase sink connector #4049 -- [Clickhouse] Fix clickhouse old version compatibility #5326 -- [Easysearch] Support INFINI Easysearch #5933 -- [Web3j] add Web3j source connector #6598 -### Formats -- [Canal]Support read canal format message #3950 -- [Debezium]Support debezium canal format message #3981 +- [Fix][Connecotr-V2] Fix paimon dynamic bucket tale in primary key is not first (#7728) +- [Fix][Connector-V2] Fix iceberg throw java: package sun.security.krb5 does not exist when use jdk 11 (#7734) +- [Fix][Connector-V2] Release resources when task is closed for iceberg sinkwriter (#7729) +- [Fix][Connector-V2] Release resources even the task is crashed for paimon sink (#7726) +- [Fix][Connector-V2] Fix paimon e2e error (#7721) +- [Fix][Connector-V2] Fix known directory create and delete ignore issues (#7700) +- [Fix][Connector-V2] Fixed iceberg sink can not handle uppercase fields (#7660) +- [Hotfix][CDC] Fix ddl duplicate execution error when config multi_table_sink_replica (#7634) +- [Fix][Connector-V2] Fix some throwable error not be caught (#7657) +- [Fix][Connector-V2] Fix jdbc test case failed (#7690) +- [Fix][Connector-v2] Throw Exception in sql query for JdbcCatalog in table or db exists query (#7651) +- [Fix][JDBC] Fix starrocks jdbc dialect catalog conflict with starrocks connector (#7578) +- [bugfix] fix oracle query table length (#7627) +- [Hotfix] Fix iceberg missing column comment when savemode create table (#7608) +- [Hotfix][Seatunnel-common] Fix the CommonError msg for paimon sink (#7591) +- [Hotfix][Connector-v2] Fix the ClassCastException for connector-mongodb (#7586) +- [Hotfix][Connector-v2] Fix the NullPointerException for jdbc oracle which used the table_list (#7544) +- [Bug][e2e][jdbc-gbase] The gbase driver address certificate expired (#7531) +- [Hotfix][Connector-V2] Fixed lost data precision for decimal data types (#7527) +- [Fix][Connector-V2] Fix jdbc query sql can not get table path (#7484) +- [Hotfix][Connector-V2] Fix null not inserted in es (#7493) +- [Fixbug] doris custom sql work (#7464) +- [Fix] Fix oracle sample data from column error (#7340) +- [Hotifx][Jdbc] Fix MySQL unsupport 'ZEROFILL' column type (#7407) +- [Hotfix][CDC] Fix package name spelling mistake (#7415) +- [Hotfix][Zeta] Fix hazelcast client should overwrite cluster address by system env (#7790) -### Connector-V2 +### Zeta(ST-Engine) +- [Core][Zeta] If Zeta not a TCP discovery, it cannot find other members (#7757) +- [Fix][Zeta] Fix resource isolation not working on multi node (#7471) -- [Json-format] [Canal-Json] Fix json deserialize NPE (#4195) -- [Connector-V2] [Jdbc] Field aliases are not supported in the query of jdbc source. (#4210) -- [Connector-V2] [Jdbc] Fix connection failure caused by connection timeout. (#4322) -- [Connector-V2] [Jdbc] Set default value to false of JdbcOption: generate_sink_sql (#4471) -- [Connector-V2] [JDBC] Fix TiDBCatalog without open (#4718) -- [Connector-V2] [Jdbc] Fix XA DataSource crash(Oracle/Dameng/SqlServer) (#4866) -- [Connector-V2] [Pulsar] Fix the bug that can't consume messages all the time. (#4125) -- [Connector-V2] [Eleasticsearch] Document description error (#4390) -- [Connector-V2] [Eleasticsearch] Source deserializer error and inappropriate (#4233) -- [Connector-V2] [Kafka] Fix KafkaProducer resources have never been released. (#4302) -- [Connector-V2] [Kafka] Fix the permission problem caused by client.id. (#4246) -- [Connector-V2] [Kafka] Fix KafkaConsumerThread exit caused by commit offset error. (#4379) -- [Connector-V2] [Mongodb] Mongodb support cdc sink. (#4833) -- [Connector-V2] [kafka] Fix the problem that the partition information can not be obtained when kafka is restored (#4764) -- [Connector-V2] [SFTP] Fix incorrect exception handling logic (#4720) -- [Connector-V2] [File] Fix read temp file (#4876) -- [Connector-V2] [CDC Base] Solving the ConcurrentModificationException caused by snapshotState being modified concurrently. (#4877) -- [Connector-V2] [Doris] update last checkpoint id when doing snapshot (#4881) -- [Connector-v2] [kafka] Fix the short interval of pull data settings and revise the format (#4875) -- [Connector-v2] [RabbitMQ] Fix reduplicate ack msg bug and code style (#4842) -- [Connector-V2] [Jdbc] Fix the error of extracting primary key column in sink (#4815) -- [Connector-V2] [Jdbc] Fix reconnect throw close statement exception (#4801) -- [Connector-V2] [Jdbc] Fix sqlserver system table case sensitivity (#4806) -- [Connector-v2] [File] Fix configuration file format and error comments (#4762) -- [Connector-v2] [Jdbc] Fix oracle sql table identifier (#4754) -- [Connector-v2] [Clickhouse] fix get clickhouse local table name with closing bracket from distributed table engineFull (#4710) -- [Connector-v2] [CDC] Fix jdbc connection leak for mysql (#5037) -- [Connector-v2] [File] Fix WriteStrategy parallel writing thread unsafe issue #5546 -- [Connector-v2] [File] Inject FileSystem to OrcWriteStrategy -- [Connector-v2] [File] Support assign encoding for file source/sink (#5973) -- [Connector-v2] [Mongodb] Support to convert to double from numeric type that mongodb saved it as numeric internally (#6997) -- [Connector-v2] [Redis] Using scan replace keys operation command,support batchWrite in single mode(#7030,#7085) -- [Connector-V2] [Clickhouse] Add a new optional configuration `clickhouse.config` to the source connector of ClickHouse (#7143) -- [Connector-V2] [Redis] Redis scan command supports versions 3, 4, 5, 6, 7 (#7666) +### Transformer +- [Bug][Transforms-V2] Fix LLM transform can not parse boolean value type (#7620) -### Zeta(ST-Engine) +### CI +- [Fix][CI] Fix CI loss document check when raise PR (#7749) +- [Hotfix][ci] Fix github ci License header error (#7738) +- [Fix][CI] Add doc sync to fix ci error (#7720) +- [hotfix] fix FixSlotResourceTest unstable issue (#7577) +- [Fix][e2e] remote loading driver ignores the certificate to avoid certificate address expiration (#7547) +- [Fix] Fix document build error (#7546) +- [Fix][doc] fix dead link (#7508) +- [Fix] update paimon.apache.org deadlink (#7504) +- [Hotfix][Metrics] fix sporadic multi-metrics ci (#7468) +- [Fix] Fix dead link on seatunnel connectors list url (#7453) +- [FIX][E2E]Modify the OceanBase test case to the latest imageChange image (#7452) -- [Zeta] Fix LogicalDagGeneratorTest testcase (#4401) -- [Zeta] Fix MultipleTableJobConfigParser parse only one transform (#4412) -- [Zeta] Fix missing common plugin jars (#4448) -- [Zeta] Fix handleCheckpointError be called while checkpoint already complete (#4442) -- [Zeta] Fix job error message is not right bug (#4463) -- [Zeta] Fix finding TaskGroup deployment node bug (#4449) -- [Zeta] Fix the bug of conf (#4488) -- [Zeta] Fix Connector load logic from zeta (#4510) -- [Zeta] Fix conflict dependency of hadoop-hdfs (#4509) -- [Zeta] Fix TaskExecutionService synchronized lock will not release (#4886) -- [Zeta] Fix TaskExecutionService will return not active ExecutionContext (#4869) -- [Zeta] Fix deploy operation timeout but task already finished bug (#4867) -- [Zeta] Fix restoreComplete Future can't be completed when cancel task (#4863) -- [Zeta] Fix IMap operation timeout bug (#4859) -- [Zeta] fix pipeline state not right bug (#4823) -- [Zeta] Fix the incorrect setting of transform parallelism (#4814) -- [Zeta] Fix master active bug (#4855) -- [Zeta] Fix completePendingCheckpoint concurrent action (#4854) -- [Zeta] Fix engine runtime error (#4850) -- [Zeta] Fix TaskGroupContext always hold classloader so classloader can't recycle (#4849) -- [Zeta] Fix task `notifyTaskStatusToMaster` failed when job not running or failed before run (#4847) -- [Zeta] Fix cpu load problem (#4828) -- [zeta] Fix the deadlock issue with JDBC driver loading (#4878) -- [zeta] dynamically replace the value of the variable at runtime (#4950) -- [Zeta] Add from_unixtime function (#5462) -- [zeta] Fix CDC task restore throw NPE (#5507) -- [Zeta] Fix a checkpoint storage document with OSS (#7507) - -### E2E - -- [E2E] [Kafka] Fix kafka e2e testcase (#4520) -- [Container Version] Fix risk of unreproducible test cases #4591 -- [E2e] [Mysql-cdc] Removing the excess MySqlIncrementalSourceIT e2e reduces the CI time (#4738) -- [E2E] [Common] Update test container version of seatunnel engine (#5323) -- [E2E] [Jdbc] Fix not remove docker image after test finish on jdbc suite (#5586) ## Improve -- [Improve][Connector-V2][Jdbc-Source] Support for Decimal types as splict keys (#4634) - ### Core - -- [Core] [Spark] Push transform operation from Spark Driver to Executors (#4503) -- [Core] [Starter] Optimize code structure & remove redundant code (#4525) -- [Core] [Translation] [Flink] Optimize code structure & remove redundant code (#4527) -- [Core] [Starter] Add check of sink and source config to avoid null pointer exception. (#4734) -- [Core] [Flink] Remove useless stage type related codes. (#5650) - -### Formats - -- [Json] Remove assert key word. (#5919) -- [Formats] Replace CommonErrorCodeDeprecated.JSON_OPERATION_FAILED. (#5948) -- [Formats] Refactor exception catch for `ignoreParseErrors`. (#6065) +- [Improve][Spark] Convert array type to exact type (#7758) +- [Improve][Zeta] Split the classloader of task group (#7580) +- [Improve][Core] Config variables update doc and add test case (#7709) +- [Improve][Zeta] Add log for tryTriggerPendingCheckpoint because the wrong time of server (#7717) +- [Improve][EventService] improve event code and extract event code to EventService (#7153) +- [Chore] Code specification adjustments (#7572) +- [Chore] Update zeta example log4j2.properties (#7563) +- [Improve] Update docker doc and build tag (#7486) +- [Improve][Zeta] Handle user privacy when submitting a task print config logs (#7247) +- [Improve][API] Add IGNORE savemode type (#7443) +- [Improve][API] Move catalog open to SaveModeHandler (#7439) +- [Improve] Skip downloading transitive dependency when install plugins (#7374) +- [Improve] Flink support embedding transform (#7592) ### Connector-V2 - -- [Connector-V2] [CDC] Improve startup.mode/stop.mode options (#4360) -- [Connector-V2] [CDC] Optimize jdbc fetch-size options (#4352) -- [Connector-V2] [CDC] Fix chunk start/end parameter type error (#4777) -- [Connector-V2] [SQLServer] Fix sqlserver catalog (#4441) -- [Connector-V2] [StarRocks] Improve StarRocks Serialize Error Message (#4458) -- [Connector-V2] [Jdbc] add the log for sql and update some style (#4475) -- [Connector-V2] [Jdbc] Fix the table name is not automatically obtained when multiple tables (#4514) -- [Connector-V2] [S3 & Kafka] Delete unavailable S3 & Kafka Catalogs (#4477) -- [Connector-V2] [Pulsar] Support Canal Format -- [Connector-V2] [CDC base] Implement Sample-based Sharding Strategy with Configurable Sampling Rate (#4856) -- [Connector-V2] [SelectDB] Add a jobId to the selectDB label to distinguish between tasks (#4864) -- [Connector-V2] [Doris] Add a jobId to the doris label to distinguish between tasks (#4839) (#4853) -- [Connector-v2] [Mongodb]Refactor mongodb connector (#4620) -- [Connector-v2] [Jdbc] Populate primary key when jdbc sink is created using CatalogTable (#4755) -- [Connector-v2] [Neo4j] Supports neo4j sink batch write mode (#4835) -- [Transform-V2] Optimize SQL Transform package and Fix Spark type conversion bug of transform (#4490) -- [Connector-V2] [Common] Remove assert key word (#5915) -- [Connector-V2] Replace CommonErrorCodeDeprecated.JSON_OPERATION_FAILED. (#5978) +- [Improve][Connector-v2] Remove useless code and add changelog doc for paimon sink (#7748) +- [Improve][Connector-V2] Optimize sqlserver package structure (#7715) +- [Improve][Connector-V2] Optimize milvus code (#7691) +- [Improve][Redis]Redis scan command supports versions 5, 6, 7 (#7666) +- [Improve][Connector-V2] Support read archive compress file (#7633) +- [Improve][Jdbc] Jdbc truncate table should check table not database (#7654) +- [Improve] [Connector-V2] Optimize milvus-connector config code (#7658) +- [Improve][Connector-V2] Time supports default value (#7639) +- [Improve][Iceberg] Add savemode create table primaryKey testcase (#7641) +- [Improve][Kafka] kafka source refactored some reader read logic (#6408) +- [Improve][Connector-V2][MongoDB] A BsonInt32 will be convert to a long type (#7567) +- [Improve][Connector-v2] Improve the exception msg in case-sensitive case for paimon sink (#7549) +- [Improve][Connector-v2] Support mysql 8.1/8.2/8.3 for jdbc (#7530) +- [Improve][Connector-v2] Release resource in closeStatements even exception occurred in executeBatch (#7533) +- [Improve][Connector-V2] Remove hard code iceberg table format version (#7500) +- [Improve][Connector-V2] Fake supports column configuration (#7503) +- [Improve][Connector-V2] update vectorType (#7446) +- [Improve] Improve some connectors prepare check error message (#7465) +- [Improve] Refactor S3FileCatalog and it's factory (#7457) +- [Improve] Added OSSFileCatalog and it's factory (#7458) +- [Improve][Connector-V2] Reuse connection in StarRocksCatalog (#7342) +- [Improve][Connector-V2] Remove system table limit (#7391) +- [Improve][Connector-V2]Support multi-table sink feature for email (#7368) +- [Improve] Update pull request template and github action guide (#7376) +- [Improve][Connector-V2] Close all ResultSet after used (#7389) +- [Improvement] add starrocks jdbc dialect (#7294) + +### Transform +- [Improve][Transform] Improve inner sql query for map field type (#7718) +- [Improve][Transform] Support errorHandleWay on jsonpath transform (#7524) +- [Improve][Transform-v2] Refactor a transformRow from FilterFieldTransform (#7598) +- [Improve][Transform] Add LLM model provider microsoft #7778 ### CI +- [Improve][CI] Move paimon into single task (#7719) +- [Improve][Test][Connector-V2][MongoDB] Add few test cases for BsonToRowDataConverters (#7579) +- [Improve][Test] Remove useless code of S3Utils. (#7515) +- [Improve][E2E] update doris image to official version #7773 -- [CI] Fix error repository name in ci config files (#4795) -- [CI][E2E][Zeta] Increase Zeta checkpoint timeout to avoid connector-file-sftp-e2e failed frequently (#5339) - -### Zeta(ST-Engine) - -- [Zeta] Support run the server through daemon mode (#4161) -- [Zeta] Change ClassLoader To Improve the SDK compatibility of the client (#4447) -- [Zeta] Client Support Async Submit Job (#4456) -- [Zeta] Add more detailed log output. (#4446) -- [Zeta] Improve seatunnel-cluster.sh (#4435) -- [Zeta] Reduce CPU Cost When Task Not Ready (#4479) -- [Zeta] Add parser log (#4485) -- [Zeta] Remove redundant code (#4489) -- [Zeta] Remove redundancy code in validateSQL (#4506) -- [Zeta] Improve JobMetrics fetch performance (#4467) -- [Zeta] Reduce the operation count of imap_running_job_metrics (#4861) -- [Zeta] Speed up listAllJob function (#4852) -- [Zeta] async execute checkpoint trigger and other block method (#4846) -- [Zeta] Reduce the number of IMAPs used by checkpointIdCounter (#4832) -- [Zeta] Cancel pipeline add retry to avoid cancel failed. (#4792) -- [Zeta] Improve Zeta operation max count and ignore NPE (#4787) -- [Zeta] Remove serialize(deserialize) cost when use shuffle action (#4722) -- [zeta] Checkpoint exception status messages exclude state data (#5547) -- [Zeta] Remove assert key words (#5947) ## Feature ### Core - -- [Core] [API] Support convert strings as List<T> option (#4362) -- [Core] [API] Add copy method to Catalog codes (#4414) -- [Core] [API] Add options check before create source and sink and transform in FactoryUtil (#4424) -- [Core] [Shade] Add guava shade module (#4358) -- [Core] [Spark] Support SeaTunnel Time Type (#5188) -- [Core] [Flink] Support Decimal Type with configurable precision and scale (#5419) -- [Core] [API] Support hocon style declare row type in generic type (#6187) +- [Feature][Flink] Support multiple tables read and write (#7713) +- [Feature][Zeta][Core] Support output log file of job (#7712) +- [Feature][REST-API] Add threaddump rest api (#7615) +- [Feature][rest-api] Add whether master node identifier (#7603) +- [Feature][Core] shell batch cancel task (#7612) +- [Feature] Support config variable substitution with default value (#7562) +- [Feature][zeta]Support exposing monitoring metrics by prometheus exporter protocol (#7564) +- [Feature][Zeta] add rest api to update node tags (#7542) +- [Feature][Zeta] Optimized llm doc && add DOUBAO LLM (#7584) +- [Feature][Zeta] Support slf4j mdc tracing job id output into logs (#7491) +- [Feature][Core] Added rest-api for batch start and stop (#7522) +- [Feature][Core] Add event notify for all connector (#7501) +- [Feature] add dockerfile (#7346) +- [Feature][Zeta] Added other metrics info of multi-table (#7338) +- [Feature][Spark] Support multiple tables read and write (#7283) ### Connector-V2 - -- [Connector-V2] [CDC] [SQLServer] Support multi-table read (#4377) -- [Connector-V2] [Kafka] Kafka source supports data deserialization failure skipping (#4364) -- [Connector-V2] [Jdbc] [TiDB] Add TiDB catalog (#4438) -- [Connector-V2] [File] Add file excel sink and source (#4164) -- [Connector-V2] [FILE-OBS] Add Huawei Cloud OBS connector (#4577) -- [Connector-v2] [Snowflake] Add Snowflake Source&Sink connector (#4470) -- [Connector-V2] [Pular] support read format for pulsar (#4111) -- [Connector-V2] [Paimon] Introduce paimon connector (#4178) -- [Connector V2] [Cassandra] Expose configurable options in Cassandra (#3681) -- [Connector V2] [Jdbc] Supports GEOMETRY data type for PostgreSQL (#4673) -- [Connector V2] [Jdbc] Supports Kingbase database (#4803) -- [Transform-V2] Add UDF SPI and an example implement for SQL Transform plugin (#4392) -- [Transform-V2] Support copy field list (#4404) -- [Transform-V2] Add support CatalogTable for FieldMapperTransform (#4423) -- [Transform-V2] Add CatalogTable support for ReplaceTransform (#4411) -- [Transform-V2] Add Catalog support for FilterRowKindTransform (#4420) -- [Transform-V2] Add support CatalogTable for FilterFieldTransform (#4422) -- [Transform-V2] Add catalog support for SQL Transform plugin (#4819) -- [Connector-V2] [Assert] Support check the precision and scale of Decimal type (#6110) -- [Connector-V2] [Assert] Support field type assert and field value equality assert for full data types (#6275) -- [Connector-V2] [Iceberg] Support iceberg sink #6198 -- [Connector-V2] [FILE-OBS] Add Huawei Cloud OBS connector #4578 -- [Connector-V2] [ElasticsSource] Source support multiSource (#6730) - -### Zeta(ST-Engine) - -- [Zeta] Support for mixing Factory and Plugin SPI (#4359) -- [Zeta] Add get running job info by jobId rest api (#4140) -- [Zeta] Add REST API To Get System Monitoring Information (#4315) -- [Transform V2 & Zeta] Make SplitTransform Support CatalogTable And CatalogTable Evolution (#4396) -- [Zeta] Move driver into lib directory and change operation count (#4845) -- [Zeta] Add Metaspace size default value to config file (#4848) -- [Zeta] Reduce the frequency of fetching data from imap (#4851) -- [Zeta] Add OSS support for Imap storage to cluster-mode type (#4683) -- [Zeta] Improve local mode startup request ports (#4660) +- [Feature][Connector-V2] Assert support multi-table check (#7687) +- [Feature][Connector-Paimon] Support dynamic bucket splitting improves Paimon writing efficiency (#7335) +- [Feature][Connector-v2] Support streaming read for paimon (#7681) +- [Feature][Connector-V2] Optimize hudi sink (#7662) +- [Feature][Connector-V2] jdbc saphana source tablepath support view and synonym (#7670) +- [Feature][Connector-V2] Ftp file sink suport multiple table and save mode (#7665) +- [Feature] Support tidb cdc connector source #7199 (#7477) +- [Feature][kafka] Add arg poll.timeout for interval poll messages (#7606) +- [Feature][Connector-V2][Hbase] implement hbase catalog (#7516) +- [Feature][Elastic search] Support multi-table source feature (#7502) +- [Feature][CONNECTORS-V2-Paimon] Paimon Sink supported truncate table (#7560) +- [Feature][Connector-V2] Support Qdrant sink and source connector (#7299) +- [Feature][Connector-V2] Support multi-table sink feature for HBase (#7169) +- [Feature][Connector-V2] Support typesense connector (#7450) +- [Feature][Rabbitmq] Allow configuration of queue durability and deletion policy (#7365) +- [Feature][Connector-V2] Add `decimal_type_narrowing` option in jdbc (#7461) +- [Feature][connector-v2]Add Kafka Protobuf Data Parsing Support (#7361) +- [Feature][Connector-V2][Tablestore] Support Source connector for Tablestore #7448 (#7467) +- [Feature][Connector-V2] Support opengauss-cdc (#7433) +- [Feature][Connector-V2] Suport choose the start page in http paging (#7180) +- [Feature][Connector-V2][OceanBase] Support vector types on OceanBase (#7375) +- [Feature][Connector-V2] Fake Source support produce vector data (#7401) +- [Feature][Connector-V2][Iceberg] Support Iceberg Kerberos (#7246) +- [Feature][Connector-V2] SqlServer support user-defined type (#7706) +- [Feature][Connector-V2] sftp file sink suport multiple table and save mode (#7668) + +### Transform +- [Feature][Transforms-V2] LLM transforms Support custom field name (#7640) +- [Feature][Transforms-V2] LLM transforms Support KimiAI (#7630) +- [Future][Transforms-V2] llm trans support field projection (#7621) +- [Feature][Transform] Add embedding transform (#7534) ## Docs -- [Docs] Optimizes part of the Doris and SelectDB connector documentation (#4365) -- [Docs] Fix docs code style (#4368) -- [Docs] Update jdbc doc and kafka doc (#4380) -- [Docs] Fix max_retries default value is 0. (#4383) -- [Docs] Fix markdown syntax (#4426) -- [Docs] Fix Kafka Doc Error Config Key "kafka." (#4427) -- [Docs] Add Transform to Quick Start v2 (#4436) -- [Docs] Fix Dockerfile and seatunnel-flink.yaml in Set Up with Kubernetes (#4788) -- [Docs] Fix Mysql sink format doc (#4800) -- [Docs] Add the generate sink sql parameter for the jdbc sink document (#4797) -- [Docs] Add the generate sink sql parameter And example (#4769) -- [Docs] Redshift add defaultRowFetchSize (#4616) -- [Docs] Refactor connector-v2 docs using unified format Mysql (#4590) -- [Docs] Add Value types in Java to Schema features (#5087) -- [Docs] Replace username by user in the options of FtpFile (#5421) -- [Docs] Add how to configure logging related parameters of SeaTunnel-E2E Test (#5589) -- [Docs] Remove redundant double quotation mark from an example code (#5845) -- [Docs] Add Hive JDBC reference value (#5882) +- [Docs] Spark use doc update (#7722) +- [Docs] Improve startrocks sink doc (#7744) +- [Docs] Add logging into sidebars.js (#7742) +- [Docs] Add tuning guide for doris sink in streaming mode (#7732) +- [Docs] update Dynamic-compile document (#7730) +- [Docs] Improve engine deployment doc for skip deploy client (#7723) +- [Docs] Add some connector icons (#7710) +- [Docs] Fixed hive sink doc (#7696) +- [Docs] Refactor job env config document (#7631) +- [Docs] Add doc for mysql-cdc schema evolution (#7626) +- [Docs] Additional rest api documentation. (#7645) +- [Docs] Add a usage method for a keyword in sql-config (#7594) +- [Docs] add docker cluster guide (#7532) +- [Docs] Add remind for job config file suffix (#7625) +- [Docs] Fixed telemetry doc (#7623) +- [Docs] Fix document symbol escape error (#7611) +- [Docs] resource isolation add update node tags link (#7607) +- [Docs] Update PostgreSQL-CDC.md (#7601) +- [Docs] Improve quick start and build from source code (#7548) +- [Docs] Update jar download link and formats sidebar (#7569) +- [Docs]add kafka doc (#7553) +- [Docs] Remove a `fs.oss.credentials.provider` option (#7507) +- [Docs] Update the doc structure (#7425) +- [Docs] Update the guide and add example (#7388) +- [ASF] Add new collaborator (#7399) +- [Docs] Improve startrocks source doc #7777