carp84 commented on a change in pull request #453:
URL: https://github.com/apache/flink-web/pull/453#discussion_r679675357



##########
File path: _posts/2021-07-01-release-1.13.2.md
##########
@@ -0,0 +1,348 @@
+---
+layout: post
+title:  "Apache Flink 1.13.2 Released"
+date:   2021-07-14 00:00:00
+categories: news
+authors:
+- tangyun:
+  name: "Yun Tang"
+
+---
+
+The Apache Flink community released the second bugfix version of the Apache 
Flink 1.13 series.
+
+This release includes 82 fixes and minor improvements for Flink 1.13.2. The 
list below includes bugfixes and improvements. For a complete list of all 
changes see:
+[JIRA](https://issues.apache.org/jira/secure/ReleaseNote.jspa?version=12350218&styleName=&projectId=12315522).
+
+We highly recommend all users to upgrade to Flink 1.13.2.
+
+Updated Maven dependencies:
+
+```xml
+<dependency>
+  <groupId>org.apache.flink</groupId>
+  <artifactId>flink-java</artifactId>
+  <version>1.13.2</version>
+</dependency>
+<dependency>
+  <groupId>org.apache.flink</groupId>
+  <artifactId>flink-streaming-java_2.11</artifactId>
+  <version>1.13.2</version>
+</dependency>
+<dependency>
+  <groupId>org.apache.flink</groupId>
+  <artifactId>flink-clients_2.11</artifactId>
+  <version>1.13.2</version>
+</dependency>
+```
+
+You can find the binaries on the updated [Downloads page]({{ site.baseurl 
}}/downloads.html).
+
+
+
+        Release Notes - Flink - Version 1.13.2
+    
+<h2>        Sub-task
+</h2>
+<ul>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22726'>FLINK-22726</a>] -     
    Hive GROUPING__ID returns different value in older versions
+</li>
+</ul>
+            
+<h2>        Bug
+</h2>
+<ul>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-15493'>FLINK-15493</a>] -     
    
FlinkKafkaInternalProducerITCase.testProducerWhenCommitEmptyPartitionsToOutdatedTxnCoordinator
 failed on travis
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-20431'>FLINK-20431</a>] -     
    
KafkaSourceReaderTest.testCommitOffsetsWithoutAliveFetchers:133-&gt;lambda$testCommitOffsetsWithoutAliveFetchers$3:134
 expected:&lt;10&gt; but was:&lt;1&gt;
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-20888'>FLINK-20888</a>] -     
    ContinuousFileReaderOperator should not close the output on close()
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-20975'>FLINK-20975</a>] -     
    HiveTableSourceITCase.testPartitionFilter fails on AZP
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-21389'>FLINK-21389</a>] -     
    ParquetInputFormat should not need parquet schema as user input
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-21445'>FLINK-21445</a>] -     
    Application mode does not set the configuration when building 
PackagedProgram
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-21952'>FLINK-21952</a>] -     
    Make all the &quot;Connection reset by peer&quot; exception wrapped as 
RemoteTransportException
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22045'>FLINK-22045</a>] -     
    Set log level for shaded zookeeper logger
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22195'>FLINK-22195</a>] -     
    YARNHighAvailabilityITCase.testClusterClientRetrieval because of 
TestTimedOutException
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22272'>FLINK-22272</a>] -     
    Some scenes can&#39;t drop table by hive catalog
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22312'>FLINK-22312</a>] -     
    
YARNSessionFIFOSecuredITCase&gt;YARNSessionFIFOITCase.checkForProhibitedLogContents
 due to the heartbeat exception with Yarn RM
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22370'>FLINK-22370</a>] -     
    ParquetColumnarRowSplitReader#reachedEnd() returns false after it returns 
true
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22376'>FLINK-22376</a>] -     
    SequentialChannelStateReaderImpl may recycle buffer twice
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22387'>FLINK-22387</a>] -     
    UpsertKafkaTableITCase hangs when setting up kafka
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22443'>FLINK-22443</a>] -     
    can not be execute an extreme long sql under batch mode
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22462'>FLINK-22462</a>] -     
    JdbcExactlyOnceSinkE2eTest.testInsert failed because of too many clients.
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22464'>FLINK-22464</a>] -     
    OperatorEventSendingCheckpointITCase.testOperatorEventLostWithReaderFailure 
hangs with `AdaptiveScheduler`
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22480'>FLINK-22480</a>] -     
    KafkaChangelogTableITCase hangs on Azure
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22492'>FLINK-22492</a>] -     
    KinesisTableApiITCase with wrong results
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22496'>FLINK-22496</a>] -     
    ClusterEntrypointTest.testCloseAsyncShouldBeExecutedInShutdownHook failed
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22545'>FLINK-22545</a>] -     
    JVM crashes when runing 
OperatorEventSendingCheckpointITCase.testOperatorEventAckLost
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22547'>FLINK-22547</a>] -     
    OperatorCoordinatorHolderTest. 
verifyCheckpointEventOrderWhenCheckpointFutureCompletesLate fail
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22613'>FLINK-22613</a>] -     
    FlinkKinesisITCase.testStopWithSavepoint fails
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22621'>FLINK-22621</a>] -     
    HBaseConnectorITCase.testTableSourceSinkWithDDL unstable on azure
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22662'>FLINK-22662</a>] -     
    YARNHighAvailabilityITCase.testKillYarnSessionClusterEntrypoint fail
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22683'>FLINK-22683</a>] -     
    The total Flink/process memory of memoryConfiguration in /taskmanagers can 
be null or incorrect value
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22686'>FLINK-22686</a>] -     
    Incompatible subtask mappings while resuming from unaligned checkpoints
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22689'>FLINK-22689</a>] -     
    Table API Documentation Row-Based Operations Example Fails
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22698'>FLINK-22698</a>] -     
    RabbitMQ source does not stop unless message arrives in queue
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22725'>FLINK-22725</a>] -     
    SlotManagers should unregister metrics at the start of suspend()
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22730'>FLINK-22730</a>] -     
    Lookup join condition with CURRENT_DATE fails to filter records
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22746'>FLINK-22746</a>] -     
    Links to connectors in docs are broken
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22759'>FLINK-22759</a>] -     
    Correct the applicability of RocksDB related options as per operator
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22760'>FLINK-22760</a>] -     
    HiveParser::setCurrentTimestamp fails with hive-3.1.2
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22777'>FLINK-22777</a>] -     
    Restore lost sections in Try Flink DataStream API example
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22779'>FLINK-22779</a>] -     
    KafkaChangelogTableITCase.testKafkaDebeziumChangelogSource fail due to 
ConcurrentModificationException
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22786'>FLINK-22786</a>] -     
    sql-client can not create .flink-sql-history file
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22795'>FLINK-22795</a>] -     
    Throw better exception when executing remote SQL file in SQL Client
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22796'>FLINK-22796</a>] -     
    Update mem_setup_tm documentation
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22814'>FLINK-22814</a>] -     
    New sources are not defining/exposing checkpointStartDelayNanos metric
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22815'>FLINK-22815</a>] -     
    Disable unaligned checkpoints for broadcast partitioning
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22819'>FLINK-22819</a>] -     
    YARNFileReplicationITCase fails with &quot;The YARN application 
unexpectedly switched to state FAILED during deployment&quot;
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22820'>FLINK-22820</a>] -     
    Stopping Yarn session cluster will cause fatal error
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22833'>FLINK-22833</a>] -     
    Source tasks (both old and new) are not reporting checkpointStartDelay via 
CheckpointMetrics
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22856'>FLINK-22856</a>] -     
    Move our Azure pipelines away from Ubuntu 16.04 by September
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22863'>FLINK-22863</a>] -     
    ArrayIndexOutOfBoundsException may happen when building rescale edges
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22884'>FLINK-22884</a>] -     
    Select view columns fail when store metadata with hive
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22886'>FLINK-22886</a>] -     
    Thread leak in RocksDBStateUploader
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22890'>FLINK-22890</a>] -     
    Few tests fail in HiveTableSinkITCase
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22894'>FLINK-22894</a>] -     
    Window Top-N should allow n=1
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22898'>FLINK-22898</a>] -     
    HiveParallelismInference limit return wrong parallelism
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22908'>FLINK-22908</a>] -     
    FileExecutionGraphInfoStoreTest.testPutSuspendedJobOnClusterShutdown should 
wait until job is running
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22927'>FLINK-22927</a>] -     
    Exception on JobClient.get_job_status().result()
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22932'>FLINK-22932</a>] -     
    RocksDBStateBackendWindowITCase fails with savepoint timeout
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22945'>FLINK-22945</a>] -     
    StackOverflowException can happen when a large scale job is 
CANCELING/FAILING
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22946'>FLINK-22946</a>] -     
    Network buffer deadlock introduced by unaligned checkpoint
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22948'>FLINK-22948</a>] -     
    Scala example for toDataStream does not compile
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22952'>FLINK-22952</a>] -     
    docs_404_check fail on azure due to ruby version not available
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22961'>FLINK-22961</a>] -     
    Incorrect calculation of alignment timeout for LocalInputChannel
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22963'>FLINK-22963</a>] -     
    The description of taskmanager.memory.task.heap.size in the official 
document is incorrect
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22964'>FLINK-22964</a>] -     
    Connector-base exposes dependency to flink-core.
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22966'>FLINK-22966</a>] -     
    NPE in StateAssignmentOperation when rescaling
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22980'>FLINK-22980</a>] -     
    FileExecutionGraphInfoStoreTest hangs on azure
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22982'>FLINK-22982</a>] -     
    java.lang.ClassCastException when using Python UDF
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22987'>FLINK-22987</a>] -     
    Scala suffix check isn&#39;t working
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22993'>FLINK-22993</a>] -     
    CompactFileWriter won&#39;t emit EndCheckpoint with Long.MAX_VALUE 
checkpointId
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23001'>FLINK-23001</a>] -     
    flink-avro-glue-schema-registry lacks scala suffix
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23003'>FLINK-23003</a>] -     
    Resource leak in RocksIncrementalSnapshotStrategy
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23010'>FLINK-23010</a>] -     
    HivePartitionFetcherContextBase::getComparablePartitionValueList can return 
partitions that don&#39;t exist
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23018'>FLINK-23018</a>] -     
    State factories should handle extended state descriptors
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23024'>FLINK-23024</a>] -     
    RPC result TaskManagerInfoWithSlots not serializable
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23025'>FLINK-23025</a>] -     
    sink-buffer-max-rows and sink-buffer-flush-interval options produce a lot 
of duplicates
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23030'>FLINK-23030</a>] -     
    PartitionRequestClientFactory#createPartitionRequestClient should throw 
when network failure
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23034'>FLINK-23034</a>] -     
    NPE in JobDetailsDeserializer during the reading old version of 
ExecutionState
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23045'>FLINK-23045</a>] -     
    RunnablesTest.testExecutorService_uncaughtExceptionHandler fails on azure
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23073'>FLINK-23073</a>] -     
    Fix space handling in Row CSV timestamp parser
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23074'>FLINK-23074</a>] -     
    There is a class conflict between flink-connector-hive and flink-parquet
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23092'>FLINK-23092</a>] -     
    Built-in UDAFs could not be mixed use with Python UDAF in group window
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23096'>FLINK-23096</a>] -     
    HiveParser could not attach the sessionstate of hive
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23108'>FLINK-23108</a>] -     
    KafkaITCase.testCancelingEmptyTopic fails on azure
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23119'>FLINK-23119</a>] -     
    Fix the issue that the exception that General Python UDAF is unsupported is 
not thrown in Compile Stage.
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23120'>FLINK-23120</a>] -     
    ByteArrayWrapperSerializer.serialize should use writeInt to serialize the 
length
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23121'>FLINK-23121</a>] -     
    Fix the issue that the InternalRow as arguments in Python UDAF
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23129'>FLINK-23129</a>] -     
    When cancelling any running job of multiple jobs in an application cluster, 
JobManager shuts down
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23133'>FLINK-23133</a>] -     
    The dependencies are not handled properly when mixing use of Python Table 
API and Python DataStream API
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23151'>FLINK-23151</a>] -     
    KinesisTableApiITCase.testTableApiSourceAndSink fails on azure
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23155'>FLINK-23155</a>] -     
    Streaming File Sink s3 end-to-end test fail on azure
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23166'>FLINK-23166</a>] -     
    ZipUtils doesn&#39;t handle properly for softlinks inside the zip file
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23182'>FLINK-23182</a>] -     
    Connection leak in RMQSource 
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23184'>FLINK-23184</a>] -     
    CompileException Assignment conversion not possible from type 
&quot;int&quot; to type &quot;short&quot;
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23188'>FLINK-23188</a>] -     
    Unsupported function definition: IFNULL. Only user defined functions are 
supported as inline functions
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23196'>FLINK-23196</a>] -     
    JobMasterITCase fail on azure due to BindException
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23201'>FLINK-23201</a>] -     
    The check on alignmentDurationNanos seems to be too strict
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23223'>FLINK-23223</a>] -     
    When flushAlways is enabled the subpartition may lose notification of data 
availability
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23233'>FLINK-23233</a>] -     
    OperatorEventSendingCheckpointITCase.testOperatorEventLostWithReaderFailure 
fails on azure
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23235'>FLINK-23235</a>] -     
    SinkITCase.writerAndCommitterAndGlobalCommitterExecuteInStreamingMode fails 
on azure
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23248'>FLINK-23248</a>] -     
    SinkWriter is not closed when failing
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23259'>FLINK-23259</a>] -     
    [DOCS]The &#39;window&#39; link on page 
docs/dev/datastream/operators/overview is failed and 404 is returned
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23260'>FLINK-23260</a>] -     
    [DOCS]The link on page docs/libs/gelly/overview is failed and 404 is 
returned
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23270'>FLINK-23270</a>] -     
    Impove description of Regular Joins section
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23280'>FLINK-23280</a>] -     
    Python ExplainDetails does not have JSON_EXECUTION_PLAN option
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23306'>FLINK-23306</a>] -     
    FlinkRelMdUniqueKeys causes exception when used with new Schema
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23359'>FLINK-23359</a>] -     
    Fix the number of available slots in 
testResourceCanBeAllocatedForDifferentJobAfterFree
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23368'>FLINK-23368</a>] -     
    Fix the wrong mapping of state cache in PyFlink
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23391'>FLINK-23391</a>] -     
    KafkaSourceReaderTest.testKafkaSourceMetrics fails on azure
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23429'>FLINK-23429</a>] -     
    State Processor API failed with FileNotFoundException when working with 
state files on Cloud Storage
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23443'>FLINK-23443</a>] -     
    LaunchCoordinatorTest fails on azure
+</li>
+</ul>
+        
+<h2>        New Feature
+</h2>
+<ul>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22770'>FLINK-22770</a>] -     
    Expose SET/RESET from the parser
+</li>
+</ul>
+        
+<h2>        Improvement
+</h2>
+<ul>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-18182'>FLINK-18182</a>] -     
    Upgrade AWS SDK in flink-connector-kinesis to include new region af-south-1
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-20140'>FLINK-20140</a>] -     
    Add documentation of TableResult.collect for Python Table API
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-21393'>FLINK-21393</a>] -     
    Implement ParquetAvroInputFormat 
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-21411'>FLINK-21411</a>] -     
    The components on which Flink depends may contain vulnerabilities. If yes, 
fix them.
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22358'>FLINK-22358</a>] -     
    Add missing stability annotation to Split Reader API classes
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22527'>FLINK-22527</a>] -     
    Give friendly hint when click FlameGraph without rest.flamegraph.enabled
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22528'>FLINK-22528</a>] -     
    Document latency tracking metrics for state accesses
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22578'>FLINK-22578</a>] -     
    deployment configuration page miss content navigate menu
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22589'>FLINK-22589</a>] -     
    There are quite a few Python classes doesn&#39;t appear in the Python docs
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22638'>FLINK-22638</a>] -     
    Keep channels blocked on alignment timeout
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22655'>FLINK-22655</a>] -     
    When using -i &lt;init.sql&gt; option to initialize SQL Client session It 
should be possible to annotate the script with --
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22722'>FLINK-22722</a>] -     
    Add Documentation for Kafka New Source
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22747'>FLINK-22747</a>] -     
    Update commons-io to 2.8
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22766'>FLINK-22766</a>] -     
    Report metrics of KafkaConsumer in Kafka new source
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22774'>FLINK-22774</a>] -     
    Update Kinesis SQL connector&#39;s Guava to 27.0-jre
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22799'>FLINK-22799</a>] -     
    Missing documentation: State backwards compatibility is not support for 
Flink SQL
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22873'>FLINK-22873</a>] -     
    Add ToC to configuration documentation
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22905'>FLINK-22905</a>] -     
    Fix missing comma in SQL example in &quot;Versioned Table&quot; page
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22939'>FLINK-22939</a>] -     
    Generalize JDK switch in azure setup
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22959'>FLINK-22959</a>] -     
    Keep the job jar files  on JobManager 
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-22996'>FLINK-22996</a>] -     
    The description about coalesce is wrong
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23009'>FLINK-23009</a>] -     
    Bump up Guava in Kinesis Connector
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23052'>FLINK-23052</a>] -     
    cron_snapshot_deployment_maven unstable on maven
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23138'>FLINK-23138</a>] -     
    Raise an exception if types other than PickledBytesTypeInfo are specified 
for state descriptor 
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23156'>FLINK-23156</a>] -     
    Change the reference of &#39;docs/dev/table/sql/queries&#39;
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23157'>FLINK-23157</a>] -     
    Fix missing comma in SQL example in &quot;Versioned View&quot; page
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23162'>FLINK-23162</a>] -     
    Create table uses time_ltz in the column name and it&#39;s expression which 
results in exception 
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23168'>FLINK-23168</a>] -     
    Catalog shouldn&#39;t merge properties for alter DB operation
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23178'>FLINK-23178</a>] -     
    Raise an error for writing stream data into partitioned hive tables without 
a partition committer
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23200'>FLINK-23200</a>] -     
    Correct grammatical mistakes in &#39;Table API&#39; page of &#39;Table API 
&amp; SQL&#39;
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23226'>FLINK-23226</a>] -     
    Flink Chinese doc learn-flink/etl transformation.svg display issue
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23312'>FLINK-23312</a>] -     
    Use -Dfast for building e2e tests on AZP
+</li>
+<li>[<a 
href='https://issues.apache.org/jira/browse/FLINK-23315'>FLINK-23315</a>] -     
    Bump log4j to 2.14.1 for version 1.13.2

Review comment:
       We should remove this line since the JIRA is still not resolved and I've 
updated its fix version to 1.13.3 in JIRA.




-- 
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-unsubscr...@flink.apache.org

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


Reply via email to