You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by al...@apache.org on 2020/06/19 14:34:02 UTC

[flink] branch docs_experimental__docs updated (4649ddd -> e090f55)

This is an automated email from the ASF dual-hosted git repository.

aljoscha pushed a change to branch docs_experimental__docs
in repository https://gitbox.apache.org/repos/asf/flink.git.


 discard 4649ddd  [FLINK-16678][docs] Fix typo in HBase SQL connector page
    omit a6872837 [hotfix][docs] do not include build scripts in content generation
    omit 430a096  [FLINK-13793][docs] build each language in a separate subprocess
    omit f42f54d  [hotfix][docs] show usage if wrong option is given
     add 84c96b3  [FLINK-14642] Add support for copying null values to the TupleSerializer and CaseClassSerializer
     add f074d1f  [FLINK-14758] Add Executor-related interfaces + wire their discovery to environments.
     add a9b1266  [FLINK-14472][runtime] Implement back-pressure monitor with non-blocking outputs
     add 60f7aa0  [FLINK-14708][runtime] Introduce RestartAllStrategy for NG scheduler
     add 56c4664  [FLINK-14131][runtime] Introduce FailoverStrategyFactoryLoader to load NG failover strategy factories
     add 6abc6d9  [FLINK-14131][runtime] DefaultSchedulerFactory uses FailoverStrategyFactoryLoader to load failover strategy factory
     add 738cda3  [FLINK-14682][tests] Enable AbstractTaskManagerProcessFailureRecoveryTest to pass with new DefaultScheduler
     add 966c1f27 [FLINK-14680][runtime,tests] Enable KafkaConsumerTestBase#runFailOnNoBrokerTest to pass with DefaultScheduler
     add 77bc669  [FLINK-14728][hive][doc] add reminder for users of potential thread safety issues of hive built-in function
     add f2c4355  [FLINK-14727][hive][doc] update doc of supported Hive versions
     add 10d372e  [FLINK-14687][sql] Add database related ddl support to SQL Parser
     add feca8a7  [FLINK-14710][hive] Decide column nullability according to Hive constraints
     add 94c3faf  [hotfix][doc] update links to table functions
     add c9c8a29  [FLINK-14759][coordination] Remove unused class TaskManagerCliOptions
     add 65ecfab  [FLINK-14784][table] CsvTableSink miss delimiter when row start with null member.
     add 468415b  [FLINK-14382][java] Add MultipleParameterTool to support parsing multiple parameters of args. For example, --multi multiValue1 --multi multiValue2.
     add 304736d  [FLINK-14382][examples] Adding multiple --input support to WordCount
     add 8c217d7  [FLINK-14382][e2e] Add another dummy fs for e2e test. It is same as dummy fs with different schema.
     add 67eaddb  [hotfix] Refactor test_yarn_kerberos_docker.sh by moving common functions to common_yarn_docker.sh.
     add 7499653  [FLINK-14382][e2e] Update e2e tests to support two inputs from two dummy FS.
     add bc4e245  [FLINK-14382][yarn] Fixes the Flink plugin mechanism on yarn cluster by shipping only the plugin directory instead of adding it to the classpath. And add class isolation check in dummy FS.
     add ae553ac  [FLINK-13747] Make Client respect classloading policy
     add a599b00  [hotfix] Simplify tests in ClassLoaderITCase
     add 1f28a24  [FLINK-14808] set correct Classloader in the CLI
     add 749086d  [FLINK-14794][runtime] Fixing KeyedStream#transform to properly relay type information if invoked with factories.
     add 6ae01fb  [hotfix][tests] Introduce PartitionDescriptorBuilder
     add cc02399  [FLINK-14679][shuffle] Store number of partitions in PartitionDescriptor
     add 22b2a88  [FLINK-13850] refactor part file configurations into a single method
     add fdc2555  Revert "[FLINK-13850] refactor part file configurations into a single method"
     add fa8d11b  [FLINK-14699][type] Move ClosureCleaner to flink-core
     add 1f5c5b7  [FLINK-14780][runtime] Register restart metrics only when start scheduling
     add 7114281  [FLINK-14782][table] CoreModule#getFunctionDefinition should return empty optional when function does not exist
     add 3a2efb4  [hotfix][kinesis] Eliminate compliler warnings and apply simple inspection-based automated cleanups
     add 2b0a8ce  [FLINK-14635][e2e tests] Use non-relocated imports for AWS SDK Kinesis classes in tests
     add 0d181e9  [FLINK-14663[tests] Support starting individual Job-/TaskManagers
     add 44538e1  [FLINK-11463][tests] Support job submissions
     add 3f92bd4  [FLINK-11463][tests] Add utilities
     add 04aabae  [FLINK-11463][tests] Always run in a fresh copy of the distribution
     add 4d033ce  [hotfix][tests] Remove optional usage
     add 8fb5f1b  [hotfix][tests] Use TestUtils#copyDirectory
     add 751184d  [FLINK-11465][tests] Add FlinkResource
     add f0be162  [FLINK-11464][tests] Add DownloadCache
     add 5221c26  [FLINK-11466][tests] Add KafkaResource
     add 499fe56  [FLINK-11468][tests] Setup surefire execution
     add 33b5663  [FLINK-11467][kafka][tests] Port Kafka Streaming E2E test
     add 671029d  [FLINK-11463][tests] Modify logging
     add e6fc1c6  [FLINK-14801][sql-parser] Improve the local variable name in SqlCreateTable#unparser()
     add b390e21  [docs-sync] Synchronize the latest documentation changes (commits to fdc2555c) into Chinese documents
     add e0824a0  [hotfix][runtime] Refactor the method of AvailabilityProvider#isAvailable
     add 7374ccc  [hotfix][network] Make ResultPartitionWriter extend AvailabilityProvider to avoid defining duplicate method
     add 2c8b4ef  [FLINK-14553][runtime] Respect non-blocking output in StreamTask#processInput
     add 901438b  [FLINK-13850] refactor part file configurations into a single method Closes #10225
     add 1b7a404  [hotfix][network] Reduce the synchronisation overhead in CreditBasedSequenceNumberingViewReader
     add f6e39aa  [FLINK-14830][docs-zh] Correct the links in stream_checkpointing.zh.md page (#10233)
     add 7f3471c  [hotfix] Add shortcuts for getting jvm heap / direct memory size.
     add 306b83b  [FLINK-14637][core][runtime] Introduce config option for framework off-heap memory.
     add 6c4dfcf  [FLINK-14750][configuration] Migrate duration and memory size ConfigOptions in RestartStrategyOptions
     add d8a5d41  [FLINK-14750][documentation] Regenerated restart strategy documentation
     add ec12ec0  [hotfix] Add String type in config docs for taskmanager.memory.framework.off-heap.size
     add dcc1330  [FLINK-14694] [table-planner-blink] Enabled all tests from package o.a.f.table.planner.functions.aggfunctions
     add 7b64ebf  [FLINK-14789][table-comon] extends max/min type in ColumnStats from Number to Comparable
     add 99551e8  [hotfix] Add general options to cli options in SQL cli LocalExecutor
     add df9b757  [FLINK-14581][python] Let python UDF execution no longer rely on the flink directory structure to support running python UDFs on yarn.
     add 7fc1583  [hotfix][configuration] Add method for creating restart strategy from configuration
     add 5711b2c  [FLINK-14786][configuration] Add configure method to ExecutionConfig
     add 7aafb24  [FLINK-14786][documentation] Regenerated documentation for ExecutionOptions & PipelineOptions
     add 974f4da  [FLINK-14806][table-runtime-blink] Add get and set interface for SqlTimestamp to BaseRow and VectorizedColumnBatch
     add 0a9db1e  [FLINK-14466][runtime] Let YarnJobClusterEntrypoint use user code class loader
     add cb62c5f  [hotfix] Refactor TaskExecutorTest.testTaskSubmission to not use mocking
     add d3ecd3d  [hotfix] Introduce TaskSlotUtils for tests
     add 01d6972  [hotfix] Refactor out slots creation from the TaskSlotTable constructor
     add 9fed0dd  [FLINK-14400] Shrink the scope of MemoryManager from TaskExecutor to slot
     add 4c4652e  [hotfix] Remove unused number of slots in MemoryManager
     add 48986aa  [hotfix] Remove unnecessary comments about memory size calculation before network init
     add ad531f0  [hotfix] Remove redundant timerService in TaskExecutorTest
     add 7201206  [FLINK-14720] Bring down ExecutionVertex#deployToSlot access modifier and mark it with @VisibleForTesting annotation
     add 5311fc0  [hotfix][docs] Fix broken links to table functions
     add 21c6b85  [FLINK-14842][table] add logging for loaded modules and functions
     add 2f0177e  [FLINK-14711][table] add alter and show function ddl
     add 32a3227  [FLINK-14066][python] Support to install pyflink in windows
     add 404dede  [FLINK-13184][yarn] Use NMClientAsync instead of NMClient to avoid starting TaskExecutor blocking call. The start container requests will be executed in a thread pool of NMClientAsync.
     add a90520c  [FLINK-13184][yarn] Use dynamic properties instead of uploading taskmanager-conf.yaml to hdfs. This will reduce the time cost of launching a TaskExecutor so that YarnResourceManager could start a large number of TaskExecutors timely.
     add 0e4e605  [FLINK-14858][table-planner] Wrong "if" statement in SqlToOperationConverter
     add f868d3a  [FLINK-11935][table-planner][table-planner-blink] Remove DateTimeUtils from legacy planner and blink planner
     add 25f87ec  [FLINK-11935][table-planner] Fix cast timestamp/date to string to avoid Gregorian cutover
     add 26a9a4c  [FLINK-11935][table-planner] Fix unixDateCeil in Flink since CALCITE-3199 is not fixed in avatica-1.15.0
     add 827e450  [FLINK-11935][table-planner-blink] Fix cast timestamp to string and vice-versa to avoid Gregorian cutover
     add f1a07cc  [FLINK-11935][table-planner-blink] Fix unixDateCeil in blink planner since CALCITE-3199 is not fixed in avatica-1.15.0
     add f806ac7  [FLINK-14716][table-planner-blink] Refactor FlinkRelOptTable and FlinkTable and cooperate computed column with push down rules
     add dde6b62  [hotfix][FLINK-14716][table-planner-blink] Fix the order of fields projected into TableSource
     add 0bdcec9  [hotfix] Fix confusing error message in TableSourceValidation
     add c29ef97  [FLINK-14104][build] Pin jackson version to 2.10.1
     add 1ce777f  [FLINK-14618][runtime] Provide the required akka framesize in the oversized message exception
     add 9706261  [FLINK-14104][build] User projects use shade-plugin 3.1.1
     add e201712  [hotfix][runtime] Remove unused compareTo from ResourceProfile
     add 675e554  [hotfix][core] Remove ResourceSpec#isValid
     add 4a487ca  [hotfix][core] Strengthen ResourceSpec#lessThanOrEqual param checking
     add aba9fe3  [hotfix][core] Remove ResourceAggregateType
     add 5d6b7d2  [hotfix][core] GPUResource hosts its own name
     add d32e1d0  [FLINK-14594][core] Change Resource to use BigDecimal as its value
     add ab6a8c5  [FLINK-14594][core] Introduce CPUResource
     add 37be8e8  [FLINK-14594][core] Change ResourceSpec to use CPUResource for cpu cores
     add 828ba0f  [FLINK-14594][runtime] Change ResourceProfile to use CPUResource for cpu cores
     add 323ca84  [hotfix][docs] fix 'optional' SQL Client function parameters stated as 'optimal'
     add 4920199  [FLINK-13727][docs] update jekyll to the final version 4.0.0
     add 254663e  [hotfix][docs] whitespace fixes
     add 3a16bd2  [FLINK-14803][metrics][influx] Support consistency level
     add def8ec5  [hotfix][tests] Fix ResourceProfile instantiation
     add 4d28d3f  [hotfix][client] PackagedProgram#userCodeClassLoader is final
     add 948bab8  [FLINK-14861][Client/Job Submission] Fix parallelism.default propagation from flink-conf.yaml
     add a779916  [hotfix] Merge configuration args in CliFrontend.run() into one
     add 051ff03  [FLINK-14871][cep] Add space
     add 040bdb4  [FLINK-14641][docs] Fix description of metric `fullRestarts` (#10128)
     add 33a39a2  [FLINK-14642][metrics] Deprecate metric `fullRestarts`
     add 787f841  [FLINK-14822][runtime] Increase number of restarts in StreamingFileSinkProgram
     add d79a9d5  [FLINK-14826][tests] Increase number of restarts in BucketingSinkTestProgram
     add 1f00c06  [FLINK-14821][tests] Enable E2E test to pass with new DefaultScheduler
     add 53060f8  [FLINK-14433][DataStream] Move generated Jaas conf file from /tmp directory to Job specific directory
     add f87bc82  [FLINK-14362][runtime] Fix DefaultResultPartition to return true result partition state
     add 3261292  [hotfix][runtime] Log errors that happen in DefaultScheduler deployment
     add 71efb87  [hotfix][runtime] Fix code style violations in JobVertex
     add 2353877  [hotfix][runtime] Fix code style violations in SlotSharingGroup and VertexSlotSharingTest
     add 4e916e0  [hotfix][runtime] Remove useless constructor of SlotSharingGroup
     add 48f3488  [FLINK-14734][runtime] Add a ResourceSpec in slot sharing group to describe the resources it needs overall
     add beba9dc  [FLINK-14859][runtime] Avoid leaking unassigned slots when deployment is outdated
     add 679398c  [FLINK-14841][table] add create and drop function ddl in SQL parser
     add 93dfdd0  [FLINK-14735][scheduler] Improve scheduling of all-to-all partitions with ALL input constraint for new scheduler
     add cbe0f14  [FLINK-14862][runtime] Fuse initializeState and open in StreamTask
     add ae539c9  [hotfix][runtime] Check managed memory fraction range when setting it into StreamConfig
     add 66b979e  [FLINK-14062][runtime] Calculate managed memory fraction based on slot sharing groups
     add e7c11ed  [FLINK-14746][web] Handle uncaught exceptions in HistoryServerArchiveFetcher.
     add 3aed29a  [hotfix] Fix parallelism consolidation logic in the (Stream)ExecutionEnvironment.
     add fe2b2d6  [hotfix] Ignore empty yarn DYNAMIC_PROPERTIES when creating configuration
     add aae87a1  [hotfix] Make the DefaultExecutorServiceLoader a singleton
     add 68a7987  [hotfix] Annotate all the Executor-related interfaces as @Internal
     add cac4b74  [hotfix] Annotate all ClusterClientFactories as @Internal
     add 09b3d89  [hotfix] Make ClusterClientFactory.isCompatibleWith case-insensitive
     add 54e44b8  [hotfix] Simplify ContextEnvironment construction to use configuration
     add 3cb5921  [FLINK-14850] Update the Executor interface and introduce minimal JobClient
     add aad1131  [hotfix] Rename configuration param in constructor of (Stream)ExecutionEnv
     add 740de18  [FLINK-14851] Add the Yarn/Standalone Executors and make ContextEnvironments use them
     add 8379bc5  [FLINK-14851] Remove redundant CliFrontend.runProgram() method
     add c1904e0  [FLINK-14851] Re-enabled the -sae flag.
     add 3e8477d  [FLINK-14851] Remove getJobSubmissionResult from JobClient
     add 2c117ad  [hotfix] Remove @nonnull annotatation from all the Executor-related interfaces
     add 5e8d5a8  [hotfix] Rename JobClientImpl to ClusterClientJobClientAdapter
     add 2eab3d8  [hotfix][runtime] Do state check before input check in LAZY_FROM_SOURCES scheduling for better performance
     add 88d9e7f  [FLINK-14811][runtime] Replace Java Streams in input checking with for-loops
     add ca0e7b7  [FLINK-14747][runtime] Reintroducing volatile flag in TaskMailboxImpl to     avoid locks in case of empty mail queue.
     add da7971a  [hotfix][runtime] MockStreamTask gracefully stops mailbox processor. MockStreamTask cannot call close on mailbox processor as we cannot assume that #cleanup is called from mailbox thread. Using a graceful termination allows the stream task and any using test harness to be closed from another thread for failure simulation.
     add 9686c0b  [hotfix][runtime] Smaller cleanup of Mailbox and ensuring state changing operation may only occur through the mailbox thread, such that state checks do not any kind of synchronizations.
     add 1c9475f  [hotfix][runtime] Avoid iteration creation in TaskMailboxImpl#tryTakeFromBatch.
     add cc309c5  [hotfix][runtime] Fixing TaskMailboxImpl #take and #tryTake not honoring requested priority if a batch is open.
     add d190308  [FLINK-14735][scheduler] Improve scheduling of all-to-all partitions with ALL input constraint for legacy scheduler
     add 4606fd6  [hotfix][typo] fix typo in ContaineredTaskManagerParameters
     add 027afb2  Merge pull request #9989 from wangxlong/hotifx-annotation-NonWindowLeftRightJoinWithNonEquiPredicates
     add b290230  [Flink-14126][test]Disable Xpack.ml for elasticsearch 6.0+ on ARM
     add 05a3132  [FLINK-14688][table] add show tables syntax support in parsre
     add e14bd50  [FLINK-14866][doc] fix a few broken doc links
     add d3dbc96  [FLINK-14788][configuration] Add configure method to CheckpointConfig
     add 65a472f  [FLINK-14788][documentation] Generated documentation for ExecutionCheckpointingOptions
     add 23c9b5a  [FLINK-13708][table-planner-blink] Transformations should be cleared after execution in blink planner
     add f01cdd1  [FLINK-13708][table-planner-blink] Revert changes in fb7beb88 which is a temporary fix
     add 6dbb308  [FLINK-14481]Modify the Flink valid socket port check to 0 to 65535. (#10184)
     add 03dc734  [FLINK-14481] Unify port range check in couple of missing places
     add 2c5dd63  [hotfix][configuration] Match enums case insensitively in configuration
     add ccf322c  [hotfix] Fix scaladocs links
     add 3ec3079  [FLINK-14787][configuration] Add configure method to StreamExecutionEnvironment
     add 444e26d  [FLINK-14787][documentation] Generate documentation for ExecutionOptions, PipelineOptions and StreamPipelineOptions
     add c7ae2b8  [FLINK-14722][hadoop] Optimize mapred.HadoopInputSplit to serialize conf only when necessary
     add 793f3b0  [FLINK-14915][runtime] Remove unnecessary parameter JobGraph from SchedulingStrategyFactory#createInstance
     add fb17587  [FLINK-14876]Putting xercesImpl related classes into alwaysParentFirstLoaderPatterns to avoid conflicts
     add ec85f82  [FLINK-14878][table] Add useCatalogOperation and support it both in flink/blink planner
     add c2f3af5  [FLINK-14924][connectorsi] Add treat empty field as null option to CsvTableSource
     add ea721c8  [FLINK-14931][docs] Regenerated documentation
     add 33c4abf  [hotfix][runtime] Adding back the missing blacklisting information when refining SotProfile in allocateCoLocatedMultiTaskSlot
     add 2bbcdab  [hotfix][runtime] Fix code style violations in SlotProfile, SchedulerTestBase, PreviousAllocationSlotSelectionStrategyTest and ScheduleWithCoLocationHintTest
     add 50712da  [hotfix][runtime] Cleanup the SlotProfile constructors
     add bc24186  [FLINK-14314][runtime] Introduce physical slot ResourceProfile in SlotProfile
     add 39a2777  [FLINK-14314][runtime] Remove SharedSlotOversubscribedException handling
     add 3442189  [FLINK-14928][docs] Fix the broken links in documentation (#10292)
     add 320240e  [FLINK-14595][orc] Move flink-orc to flink-formats from flink-connectors (#10277)
     add a6d6778  [FLINK-14873][client] Make PackagedProgram#savepointSettings final
     add 5be1e78  [hotfix] Make parameter of PackagedProgram#<init> final
     add 38750f0  [hotfix] Extract loadJarFile from PackageProgram#<init>
     add 461d5af  [FLINK-14767] Mark TaskManagerOptions#EXIT_ON_FATAL_AKKA_ERROR with @Deprecated annotation
     add a7987d4  [hotfix] Don't set plan name after creation in SQL cli ExecutionContext
     add 6111170  [hotfix] Add debug logging in MiniDispatcher
     add 0a62bc0  [hotfix] Fix checkstyle error in ExecutionContext.java
     add 89634d7  [FLINK-14838] Cleanup the description about container number config option in Scala and python shell doc
     add 75427bf  [FLINK-14874][table-planner-blink] add local aggregation to solve data skew for ROLLUP/CUBE
     add 9abe977  [FLINK-14506][python][build] Improve the release script for Python API release package
     add e08e29e  [FLINK-14885][client] YarnClusterDescriptor should not know about detached option
     add 8f665be  [FLINK-14865][python] fix unstable tests PyFlinkBlinkStreamUserDefinedFunctionTests#test_udf_in_join_condition_2
     add 5984d52  [FLINK-14892][docs] Add documentation for checkpoint directory layout (#10305)
     add 6691894  [hotfix] Correct wrong log level in TaskLocalStateStoreImpl#storeLocalState
     add 20f6976  [FLINK-14846][doc] Correct the default writerbuffer size documentation of RocksDB
     add ffde750  [hotfix][table] Move UnresolvedIdentifier to table-common and update UDT
     add 81b5d17  [FLINK-14903][table] Relax structured types constraints
     add 08f1f42  [FLINK-13995][legal] Properly exclude netty license directory
     add d95e2c1  [FLINK-14904][table] Rename ANY type to RAW type
     add 9505b0e  [hotfix][examples-table] Update registerDataSet to createTemporaryView
     add e6dae01  [hotfix] Add more logging in YARN/docker test scripts
     add e383414  [hotfix][core] Make CoreMatchers.containsCause more flexible
     add edf440a  [FLINK-12996][table-common] Require equals/hashCode for type inference classes
     add dac2cb8  [FLINK-12996][table-common] Offer unified exception for type inference classes
     add 0a9e2bd  [FLINK-12996][table-common] Add required input type validators for FLIP-65
     add 86038cd  [FLINK-12996][table-common] Add required type strategies for FLIP-65
     add 0af4801  [FLINK-12996][table-common] Simplify type validators structure
     add e24681b  [FLINK-14817][doc] Fix misleading documentation using method chaining of Configuration (#10323)
     add 9ffc2a2  [FLINK-14913][table] refactor CatalogFunction to remove properties
     add 672cdb3  [FLINK-14948][client] Implement shutDownCluster for MiniClusterClient
     add 3d94ba0  [FLINK-10932][kubernetes] Initialize flink-kubernetes module
     add 20c983c  [FLINK-11491][e2e] Add TPC-DS queries to end to end tests
     add 4b21753  [minor] Fix error logging in common yarn/docker test scripts
     add 5374cfe  [FLINK-14968] Disable flaky yarn_kerberos_docker (custom fs plugin) test
     add 488c742  [hotfix][runtime] Fix checkstyle violations in runtime classes which use ResourceProfile
     add 3466c22  [FLINK-14733][runtime] Introduce a builder for flexible ResourceProfile building
     add 17e7fe9  [FLINK-14930][fs][oss] Fix shading prefix
     add d79dbec  [FLINK-14930][fs][oss] Document credential providers
     add 77bb81b  [hotfix][coordination] Fix error message
     add 4c85821  [FLINK-11835][tests] Wait until job was recovered before unblocking task
     add 4b1a9e4  [FLINK-14940][travis] Fix error code handling for maven calls
     add 3d657b4  [FLINK-14939][e2e] Set distDir property
     add 9f6b204  [FLINK-14901] Throw Error in MemoryUtils if there is problem with using system classes over reflection
     add 8930f62  [hotfix] Annotate interfaces in JavaGcCleanerWrapper with @FunctionalInterface
     add f381065  [FLINK-14505][tests] Temporarily disable SQL Client end-to-end tests for Kafka
     add 981b054  [FLINK-14969][tests] Refactor CliFrontendRunWithYarnTest reflect to new execution codepath (#10331)
     add e583a1c  [FLINK-14709] Allow outputting elements in user defined close method, executed by chained driver.
     add 09f2847  [FLINK-14709] Remove unused GroupCombineChainedDriver.
     add 2ac0dd0  [FLINK-14709] Dispose resources in ChainedDriver close method instead of closeTask.
     add 2772cd0  [FLINK-14813][metrics] Provide `isBackPressured` Task metric
     add 959cf62  [FLINK-13634] Add compression format for use with StreamingFileSink
     add 2ba4a67  [FLINK-13634] Add CompressWriterFactory to documentation
     add 76d794b  [hotfix][tests] Avoid to add vertices to TestingSchedulingTopology when building edges using ProducerConsumerConnectionBuilder
     add 24b77db  [FLINK-14909][runtime] Respect the scheduled vertex order from scheduling strategies
     add 33d81cc  [FLINK-14909][runtime] Change default scheduling strategies to schedule vertices in topological order
     add 7902947  [FLINK-14909][runtime] Cleanup default scheduling strategies
     add 33f5e33  [FLINK-10377] Support checkpoint overtaking a savepoint in TwoPhaseCommitSink
     add 9c9ac52  Revert "[FLINK-14813][metrics] Provide `isBackPressured` Task metric"
     add 3044753  [FLINK-14859][runtime] Remove wrong checkState
     add 070a9d9  [FLINK-14957][yarn] Remove deprecated -yst option
     add be3242d  [hotfix][docs] Update REST API docs
     add 85905f8  [FLINK-14834][tests] Disable flaky yarn_kerberos_docker (default input) test
     add acae782  [hotfix][tests] Expose full heartbeat payload
     add 60067a8  [FLINK-14503][coordination] Simplify method signature
     add 7df7467  [FLINK-14503][coordination] Capture number of partitions
     add cf4e0f1  [FLINK-14503][coordination] Add partition report to heartbeat
     add c927e17  [FLINK-14762][client] Handle clients close gracefully
     add 1266c88  [FLINK-14762][client] ClusterClient#submitJob returns CompletableFuture of JobID
     add 7741eed  [FLINK-14762][tests] Introduce TestingJobClient
     add 318e406  [FLINK-14762][client] Implement JobClient#cancel
     add 0328fb6  [FLINK-14762][client] Implement JobClient#stopWithSavepoint
     add cf4de13  [FLINK-14762][client] Implement JobClient#triggerSavepoint
     add d8aa9b9  [FLINK-14762][client] Implement JobClient#getAccumulators
     add f3df25d  [FLINK-14762][api] Move JobStatus to flink-core
     add 3898a4b  [FLINK-14762][client] Implement JobClient#getJobStatus
     add 4ba834d  [FLINK-14905][build] Unify Java8/11 packaging process
     add daa2f95  [FLINK-14974][runtime] Calculate managed memory fractions with BigDecimal
     add 07b66b6  [FLINK-14976][cassandra] Release semaphore on all Throwable's in send()
     add d439c38  [hotfix][table-planner-blink] Fix statistics extraction for temporary tables
     add e21b4c8  [hotfix][table-planner-blink] Safe casting FlinkContext using unwrap instead of hard cast
     add 2f5cb8d  [FLINK-12905][table-planner] Support CatalogView in legacy planner
     add 8c6cc45  [FLINK-12905][table-planner-blink] Support CatalogView in blink planner
     add 297530c  [FLINK-14135][table-runtime-blink] Introduce DecimalColumnVector
     add 5066f79  [FLINK-14135][table-planner-blink] Fix source explain in PlanUtil.explainStreamGraph
     add 3c1ecbf  [FLINK-14135][orc] Introduce OrcSplitReader to refactor orc input format
     add ab68932  [FLINK-14135][orc] Introduce OrcColumnarRowSplitReader to orc
     add 1f9cd8a  [FLINK-14135][hive] Introduce HiveVectorizedOrcSplitReader to hive
     add c34de6d  [FLINK-14599][table-planner-blink] Use SqlTimestamp as internal representation of Timestamp type
     add 6256b11  [FLINK-14599][table-planner-blink] Support precision of Timestamp type in blink planner
     add 8698ae2  [FLINK-14021][table-planner][table-planner-blink] Add rules to push down the Python ScalarFunctions contained in the join condition of Correlate node
     add d1926e8  [FLINK-14467][mesos] Implement user code classloading in per-job cluster
     add e070921  [hotfix][docs] Remove trailing whitespaces from mesos.md
     add 5066a00  [hotfix][docs] Fix an error in mesos.zh.md
     add 3defcd8  [FLINK-10190] Allow AWS_REGION to be supplied along with custom Kinesis endpoint URL for region-specific signing
     add 25d78f0  [FLINK-14888][python] Move the Python SqlDialect to module table
     add a43ae47  [FLINK-14967][table] Add a utility for creating data types via reflection
     add b0fc92b  [FLINK-14891][python] Set the default chaining strategy to ALWAYS for Python operators
     add b6f18c4  [FLINK-14721][hive]HiveTableSource implement LimitableTableSource interface
     add b04337f  [FLINK-14914][table] refactor CatalogFunction interface and impls to add language field
     add e62a04a  [FLINK-14651][runtime] Enable DefaultScheduler by default
     add c4acb6f  [FLINK-14672][sql-client] Make Executor stateful in sql client
     add 035a233  [FLINK-14254][table-runtime-blink] Introduce FileSystemOutputFormat for batch
     add 9576a3f  [FLINK-14254][hive] Integrate hive table sink with FileSystemOutputFormat
     add ed96fea  [FLINK-14662][table api][hive] Distinguish unknown CatalogTableStatistics and zero
     add afd5f1f  [FLINK-14800][hive] Introduce parallelism inference for HiveTableSource
     add e2bc967  [FLINK-14962] Fix various inefficient use of keySet iterator instead of entrySet iterator
     add 6c2e3f2  [hotfix][test] Drop mockito usage in CheckpointBarrierAlignerAlignmentLimitTest
     add 874e95b  [FLINK-14516][network] Remove non credit-based flow control code
     add 2dc0e3a  [FLINK-14516][network] Simplify code after removing non credit-based flow control
     add 4239dd1  [hotfix][network] Rename fields in CachedBufferStorage
     add 41176ba  [FLINK-14947] Introduce LocalExecutor and make LocalEnvironment use it
     add ef0f56a  [FLINK-14947] Make LocalStreamEnvironment use LocalExecutor
     add 2d67ee0  [FLINK-14947] Remove unused LocalExecutor that extends PlanExecutor
     add 9e69fcd  [hotfix] remove unused code in RemoteStreamEnvironment.executeRemotely()
     add 146c579  [hotfix] Create JarUtils with common jar file tools
     add 2843bd4  [hotfix] Decouple ScalaShellRemoteEnvironment from RemoteEnvironment
     add 814a9fa  [hotfix] Decouple ScalaShellRemoteStreamEnvironment from RemoteStreamEnvironment
     add 057c036  [FLINK-14972] Implement RemoteExecutor + make RemoteEnvironment use it
     add cfc6f83  [FLINK-15033] Remove unused RemoteStreamEnvironment.executeRemotely() (FLINK-11048)
     add 49af102  [FLINK-14972] Make RemoteStreamEnvironment use RemoteExecutor
     add f257cff  [hotfix] Inverse comparison order in ExecutorFactory.isCompatibleWith to avoiod NPE
     add 63d526d  [FLINK-14854][client] Add executeAsync() method to execution environments
     add faf394d  [FLINK-15014][state-processor-api] Refactor KeyedStateInputFormat to support multiple types of user functions
     add 95ad441  [hotfix][rocksdb] fix exception message upon failure to create directory
     add f985ff3  [FLINK-14033][yarn] upload user artifacts for yarn job cluster
     add 2997cb5  [minor] Change YarnTestCacheJob to verify retrieved property
     add dce025e  [hotfix][task,test] Add missing test coverage for pretty mailbox exceptions
     add e6c1b19  [hotfix][task,runtime] Drop unused MailboxExecutor#asExecutor method
     add 62ce2b7  [hotfix][task,runtime] Make MailboxProcessor implement Closeable
     add c41e087  [FLINK-14935][task,runtime] Use RunnableWithException in the Mailbox
     add de44e09  [FLINK-14943][Connector/Kafka] Expose callback and related fields to subclasses for override
     add 773b680  [FLINK-14978][table-api] Introduce constraint class hierarchy required for primary keys
     add 89bd90d  [FLINK-15042][python] Fix python compatibility by excluding executeAsync
     add 5dca721  [hotfix][runtime] Map deprecated config option 'taskmanager.heap.size' and 'taskmanager.heap.mb' to total process memory.
     add 1bc28ef  [hotfix][dist] Refactor 'TaskManagerHeapSizeCalculationJavaBashTest', abstract 'JavaBashTestBase' for executing testing bash scripts from java classes.
     add 3704a0e  [hotfix][runtime] Remove heading/trailing/duplicated whitespaces from shell command generated by BootstrapTools.
     add 30132a8  [hotfix][mesos] Fix missing junit annotation for MesosTaskManagerParametersTest#testForcePullImageTrue.
     add 7027094  [hotfix][runtime] Fix backwards compatibility of NettyShuffleEnvironmentOptions#NETWORK_NUM_BUFFERS.
     add 96b735d  [hotfix][runtime] If not specified, set Total Flink Memory according to JVM free heap memory for MiniCluster.
     add 82f8f42b [hotfix][runtime] Code style clean-up for TaskExecutorResourceUtilsTest
     add 99bc4fd  [hotfix][runtime] Throw IllegalConfigurationException instead of NumberFormatException for negative memory sizes in TaskExecutorResourceUtils.
     add 6681e11  [hotfix][runtime] Add backwards compatibility for setting task executor memory through environment variable.
     add 4b8ed64  [hotfix][core][config] Change default value of TaskManagerOptions#MEMORY_OFF_HEAP from false to true.
     add 65e9507  [hotfix][core][config] Change default value of managed memory fraction from 0.5 to 0.4.
     add 8090cfd  [hotfix][core][config] Change default framework off-heap memory size from 64m to 128m.
     add 0e6c8fa  [hotfix][core][config] Change default jvm metaspace size from 192m to 128m.
     add 937eed6  [FLINK-13983][runtime] Introduce 'BashJavaUtils' allowing bash scripts to call java codes for generating TM resource dynamic configurations and JVM parameters.
     add 9d1256c  [FLINK-13983][runtime][yarn/mesos][dist] Launch task executor with new memory calculation logics
     add c324f1a  [FLINK-13986][dist] Remove codes for legacy memory calculations in task executor startup scripts.
     add d24c324  [FLINK-13986][core][runtime] Remove java codes for legacy memory calculations.
     add ba1d711  [FLINK-13986][core][config] Remove legacy config option TaskManagerOptions#TASK_MANAGER_HEAP_MEMORY.
     add 96da510  [FLINK-13986][core][config] Remove legacy config option TaskManagerOptions#LEGACY_MANAGED_MEMORY_FRACTION.
     add ffe323e  [FLINK-13986][core][config] Remove legacy config option TaskManagerOptions#LEGACY_MANAGED_MEMORY_SIZE.
     add 65460ec  [FLINK-13986][core][config] Remove unused ConfigConstants#TASK_MANAGER_MEMORY_OFF_HEAP_KEY.
     add 96fe45e  [FLINK-13986][core][config] Remove usage of legacy NETWORK_BUFFERS_MEMORY_(MIN|MAX|FRACTION).
     add 5bdc299  [FLINK-13986][doc] Update docs for managed memory configuration.
     add 5576851  [FLINK-13986][core][config] Remove FLIP-49 feature option.
     add 60b3f2f  [FLINK-14936][runtime] Introduce MemoryManager#computeMemorySize to calculate managed memory size from a fraction
     add 2bd9cec  [FLINK-15016][build] Remove unused dependency
     add 02a8c41  [FLINK-14691][table] Support create/drop/alter/use database in TableEnvironment
     add 6d677fb  [hotfix] Fix the comment about dropping database in in-memory catalog
     add d59c317  [FLINK-13502][table-planner-blink] Move CatalogTableStatisticsConverter & TreeNode to correct package
     add f2378f9  [FLINK-15039] Remove default close() implementation from ClusterClient
     add 86c2324  [FLINK-15041] Remove default close() implementation from JobClient
     add ba2799e  [hotfix][javadocs] Fix typo
     add 8bad45a  [hotfix][table][docs] Fix link
     add 64e2f27  [FLINK-14654][logging] Fix various placeholder issues
     add 7a37209  [FLINK-15025][python][build] Include resource directory in jar
     add e041d51  [FLINK-14997][state-backends] Avoid unnecessary delete() calls in RocksDBState's mergeNamespaces implementation
     add ccef736  [FLINK-15044][e2e tests] Clean up TpcdsResultComparator
     add dda6585  [FLINK-15044][e2e tests] Remove trailing error message from TPC-DS query 46 answer
     add 88c206d  [hotfix][state-backends] Simple cleanups in RocksDBStateBackend
     add 4060acc  [FLINK-15047][runtime] Fix format of setting managed memory size in ActiveResourceManagerFactory.
     add 1f5e56a  [hotfix][runtime] Code clean-up in ResourceProfile.
     add 2142dc7  [FLINK-15023][runtime] Remove on-heap managed memory
     add e505bef  [FLINK-14813][metrics] Provide `isBackPressured` Task metric (#10359)
     add 4b7baf5  [FLINK-14910][datastream] Checking for auto generated uids only for PhysicalStreamTransformations
     add 2cad743  [FLINK-14960][e2e] Fix failed dependency shading test of table modules
     add 9e165a8  [hotfix] wrap root exception when instantiating catalog functions
     add 560726a  [FLINK-15036][yarn] Container startup error should be handled inside of the YarnResourceManager's main thread
     add 19890f6  [hotfix] Correct log statements in YarnResourceManager
     add ea71251  [hotfix] Let YarnResourceManagerTest run asynchronous tasks in main thread
     add c79ca44  [FLINK-14663]Distinguish Unknown CatalogColumnStats and other values
     add 9829b9c  [FLINK-15051][state-backends] Fix typos in RocksDBStateBackend and RocksDBNativeMetricMonitor methods.
     add 1d034ad  [FLINK-13450][table api] Use StrictMath instead of Math for some expressions
     add dd82989  [FLINK-15034][state-backends] Bump FRocksDB version to support better control over used memory
     add 8287509  [FLINK-14019][python] Add client API for Python environment and dependency management.
     add 24b32d1  [FLINK-14019][python] Add PythonDependencyInfo for Python environment and dependency management.
     add 76c63fd  [FLINK-14019][python] Refactor python runners and operators to add PythonEnvironmentManager and ProcessEnvironmentManager for Python environment and dependency management.
     add ac456fb  [FLINK-14019][python] Add necessary changes on shell script and boot.py to support pip installation and changing working directory.
     add 36cb5d4  [FLINK-14019][python] add ITCases for Python environment and dependency management.
     add 1274395  [FLINK-10935][kubernetes] Add config options and cli options for kubernetes.
     add d35a969  [FLINK-10935][kubernetes] Add FlinkKubeClient API and basic kubernetes resources.
     add f49e632  [FLINK-10935][kubernetes] Add fabric8 kubeClient implementation and decorators.
     add 3c9f448  [FLINK-15060][e2e tests] Add aarch64 support for tpcds e2e test (#10424)
     add d52a0e5  [hotfix][yarn] Extract some common codes of TaskManagerRunner to public methods and simplify YarnTaskExecutorRunner
     add 1b15be2  [FLINK-10968][kubernetes] Implement KubernetesTaskExecutorRunner
     add b3ded50  [hotfix][yarn] Rename YarnTaskExecutorRunner#run to #runTaskManagerSecurely
     add a62e1ac  [FLINK-14890] Add broadcast operators test harnesses
     add 10c0cd8  [FLINK-14890] Add utility class for initializing various process function test harnesses
     add ed99909  [FLINK-14890] Add ProcessFunctionTestHarnesses tests
     add 2891a53  [FLINK-14809] Use StreamRecord matchers in ProcessFunctionTestHarnessTest
     add 93110d9  [minor] Move StreamRecordMatchers to util package
     add 23e62e4  [minor] Rename StreamRecordMatchers.isStreamRecord() to streamRecord()
     add 4b95648  [FLINK-14781] [docs-zh] correct the state_backends.zh external link and some other things (#10206)
     add af60be4  [hotfix][build] Remove redundant shaded-jackson version
     add da9268c  [FLINK-14104][build] Upgrade to flink-shaded 9.0
     add b8f3b39  [FLINK-14795][tests] Rework TaskExecutorPartitionLifecycleTest
     add 8c334f9  [FLINK-14573][python] Support TimeType for Python UDF
     add 0d72b2a  [FLINK-14573][python] Support TimestampType for Python UDF
     add d0fbd34  [FLINK-14063][table-planner-blink] Operators use fractions to decide how many managed memory to allocate
     add 61f9f2f  [FLINK-15062][formats] Orc reader should use java.sql.Timestamp to read for respecting time zone
     add e1312c8  [hotifx][runtime/task] Split StreamTask.invoke into several smaller methods
     add 12a9d6d  [hotfix][runtime/task] remove MailboxExecutor#executeFirst and enqueue MailboxProcessor "control" mails directly in it The only use of MailboxExecutor#executeFirst is in MailboxProcessor to send control messages to itself. These control messages don't require any special handling like synchronization with task state changing actions.
     add 8fb0bdb  [FLINK-12484][runtime/task] introduce StreamTaskActionExecutor (no semantic changes)
     add 9b3a0b5  [hotfix][runtime] Allow TaskMailbox to be injected into MailboxProcessor and StreamTask to ease testing
     add b4aa6e5  [FLINK-12484][runtime/task] synchronize all mailbox actions
     add d08beaa  [hotfix] encapsulate Mail.runnable: do not expose Mail#runnable field
     add ff63f6a  [FLINK-14984][web] Remove old WebUI
     add 23ea91b  [FLINK-15059][table-common] Update ASM opcode to 7
     add 9084534  [hotfix][core] Transformation#setResources validates resources params
     add 7536968  [hotfix][runtime] Introduce ZERO ResourceSpec to represent zero amount of resources
     add ab0f6d6  [hotfix][runtime] Fix issue that iteration tail node has UNKNOWN resources when the head node has specified resources
     add 85927e0f [FLINK-14566][core] Enable to get/set managed memory weight in Transformation
     add 17c5cec  [FLINK-14566][runtime] Set Transformation managed memory weight to corresponding StreamNode
     add 28ad851  [FLINK-14566][runtime] Adjust managed memory fraction calculation regarding managed memory weights
     add bed676f  [hotfix] Let StreamGraphGeneratorTest extend TestLogger
     add c7572a6  [FLINK-14590][python] Unify the working directory of Java process and Python process when submitting python jobs via "flink run -py"
     add c20697e  [FLINK-14965] [table-planner-blink] Correct the logic of convertToTableStats method in CatalogTableStatisticsConverter
     add 5973508  [FLINK-15026][sql clientSupport create/drop/alter database in sql client
     add ca1bf97  [FLINK-14692][table] Support rename/alter table in TableEnvironment for both flink/blink planner
     add 0d6b439  [FLINK-14552][table-planner-blink] Enable partition level statistics in blink planner
     add cda7ab3  [FLINK-13943][table-planner-blink] Provide utility method to convert table to Java List
     add a1c2413  [hotfix][task] Refactor StreamTask#disposed field
     add 68bba73  [FLINK-14198][python] Add "type" and "rtype" options to flink python API docstrings of table.py and table_environment.py
     add fa1dadc  [FLINK-15063][metric]fix input group and output group of the task metric are reversed
     add dd2c844  [FLINK-15045][runtime] Only log RestartStrategy in legacy scheduling mode
     add 6c90bd0  [hotfix][runtime] Fix typo in static factory method
     add ff995aa  [FLINK-15045][runtime] Log which RestartBackoffTimeStrategy is used for a job
     add a2bbd32  [hotfix][runtime] Log start scheduling message on info level
     add a4072ef  [FLINK-15091][table-planner-blink] Fix memory overused in SortMergeJoinOperator
     add 8403fd4  [FLINK-14890] Add utility method to extract values from test harnesses and use in ProcessFunctionTestHarnessesTest
     add 4dfb925  [FLINK-14857][runtime] Remove remaining checkpoint lock usages from AsyncWaitOperator
     add 16de600  [FLINK-14857][runtime/task] deprecate StreamTask.getCheckpointLock method (#10252)
     add 923a5f1  [FLINK-15084][runtime] Add shared resources tracking to MemoryManager
     add 7de2e46  [FLINK-14407][yarn] Retry S3 tests on failure
     add af8b3a8  [FLINK-15054][docs] Add FAQ section to IntelliJ setup guide
     add 5545d8a  [FLINK-13450][table api] Use StrictMath instead of Math for exp
     add 111865b  [hotfix][rocksdb] Fix description of DefaultConfigurableOptionsFactory
     add 798b22c  [FLINK-15068][rocksdb] stop writing to RocksDB logs by default
     add 953f1a0  [FLINK-15057][tests] Set JM and TM memory config in flink-conf.yaml
     add 4cfe3dd  [FLINK-14847][hive] Support retrieving Hive PK constraints
     add 0f47614  [FLINK-14949][Runtime/Task] Task cancellation can be stuck against out-of-thread error (#10387)
     add 95dfccc  [hotfix][metrics] Add missing Override annotations
     add 06bfd9b  [FLINK-14983][table-common] Add interfaces for input type inference
     add f4a0458  [hotfix][table-planner-blink] Fix the redundant line break in the plan XML
     add 1f8c5c9  [FLINK-14624][table-blink] Support computed column as rowtime attribute
     add 25c1a46  [FLINK-11524][tests] Print failure cause if job failed
     add a0a35bf  [hotfix][config] Improve error messages
     add 83a9919  [FLINK-15079][tests][config] Run BashJavaUtils after packaging
     add a61f261  [FLINK-13945][build][docs] Fix instructions for building against custom hadoop versions
     add 393a34f  [FLINK-14512][table] Introduce listPartitionsByFilter to Catalog
     add 0d1bfeb  [FLINK-15080][fs][oss] Enable deployment
     add 1b0b289  [FLINK-15085][hs] Simplify dashboard config generation
     add c8d69f4  [FLINK-13862][docs] Update execution plans docs
     add 9da970f  [hotfix][tests] Consolidate the instantiation of the RocksDBKEyesStateBackendBuilder for tests in a utility class.
     add 112e865  [FLINK-14484][state-backend] Control memory usage of RocksDB via Cache and WriteBufferManager
     add 06fb0ec  [FLINK-14484][state-backend] Some refactorings for the RocksDB memory controlling code
     add e9afee7  [FLINK-15113][config] add fs.azure.account.key to list of sensitive configs
     add 747f0af  [FLINK-14912][Table] register, drop, and alter catalog functions from DDL via catalog
     add 40b6efc  [FLINK-15106][hive] Hive 3.x tests leave metastore_db folder under build directory
     add 60357b0  [hotfix][doc] update docs to replace content of external catalog with new catalog api
     add fc2ef35  [FLINK-14959][table-planner-blink] Use SqlTimestamp as internal representation of LocalZonedTimestampType
     add 6fdc0e6  [FLINK-14959][table-planner-blink] Support precision of LocalZonedTimestampType in blink planner
     add efc18e9  [FLINK-14584][python] Support ArrayType
     add 3a1153b  [FLINK-14584][python] Support MapType
     add 87f067d  [FLINK-14584][python] Support DecimalType
     add f208354  [FLINK-14584][python] Fix impletation bug of TinyIntCoder and CharCoder
     add 7af523d  [FLINK-15027][sql client] Support alter table in SQL CLI
     add 26431ec  [FLINK-15114][sql client] Print execute result info for alter/create/drop database in sql-client
     add 7c2620f  [FLINK-14026][python] Manage the resource of Python worker properly
     add 70c2c16  [FLINK-14019][python][cli] Add commandline options for managing Python UDF environment and dependencies.
     add caff2ed  [FLINK-13195][sql client] Add create/drop table support in sql client
     add b2022ba  [FLINK-14845][runtime][table] Move block compression utils from table module to runtime module.
     add 66d4d7d  [FLINK-14845][runtime] Introduce data compression to reduce disk and network IO of shuffle.
     add d585346  [FLINK-15035][table-planner-blink] Use unknown managed memory in blink planner
     add 6b389eb  [FLINK-15107][sql client] Fix sql cli can not execute statement with lower 'inert into'
     add 5696c14  [FLINK-14645][table-common] Support to parse LegacyTypeInformationType
     add 3088c7a  [FLINK-14645][table] Support to keep nullability and precision when converting DataTypes to properties
     add 54b3fcc  [FLINK-14645][csv] Support LocalTimestamp/LocalDate/LocalTime for CSV format
     add 6c0bc5b  [FLINK-14645][json] Support LocalTimestamp/LocalDate/LocalTime for JSON format
     add 8b8a9ea  [FLINK-14645][connectors] Support new schema properties for SQL connectors
     add 2ecf7ca  [FLINK-14645][docs] Update documentation to use "data-type" instead of "type" to declare a data type
     add be967fa  [FLINK-14346] [serialization] faster implementation of StringValue writeString and readString (#10358)
     add 5a24e83  [hotfix][scala-shell] Minor license refactoring
     add 58e0cf8  [hotfix] Uniformize Executor names
     add 8f10e50d [hotfix] Factor out YarnClusterDescriptor.setClusterEntrypointInfoToConfig() method
     add 219903e  [hotfix] FlinkILoop: reset ContextEnvFactories also for StreamEnvironments
     add dea4226  [FLINK-15120] YarnSessionCli.isActive & getApplicationId account conf APPLICATION_ID
     add 585f5d4  [FLINK-15118] Make flink-scala-shell use Executors
     add 4d33f4f  [FLINK-15119] Remove unused Plan/RemoteExecutor
     add 81bd77d  [minor] Refactor getJarFiles() out of ScalaShellEnvironments
     add 9356c99  [hotfix] Remove Mockito from RemoteStreamExecutionEnvironmentTest
     add 1863bb8  [FLINK-14872][runtime] Temporary fix for potential deadlock problem when tasks read from blocking ResultPartitions. (#10472)
     add f5dafd3  [FLINK-11120][table] Fix timestampadd operation not returning correct result.
     add 9320f34  [FLINK-11120][table] Fix timestampadd on non-zero, negative interaval that cross over day boundary, refine documentation.
     add 383beb0  [FLINK-14911] [table] register and drop temp catalog functions from DDL to FunctionCatalog
     add c1d0e99  [FLINK-8949] Add dedicated watermarks metric retrieval endpoint (#10238)
     add 99c1aa3  [FLINK-14840] Add unit tests for exception behaviour of SQL cli executor
     add d480e25  [FLINK-14840] Use Executor interface in SQL cli
     add 9000a9b  [hotfix][yarn] Move getDynamicProperties from yarn utils to BootstrapTools
     add c63f407  [hotfix][yarn] Fix typos in YarnResourceManager
     add 3aa143f  [hotfix][yarn] Add ActiveResourceManager containing some common codes
     add fc37b6d  [FLINK-9495][kubernetes] Implement ResourceManager for Kubernetes
     add 5f5cdeb  [hotfix][runtime] Checkstyle fixes in JobVertex
     add 8caea1a  [FLINK-14454][tests] Re-enable SavepointSerializers.setFailWhenLegacyStateDetected after tests
     add 56cd59f  [FLINK-14907] [filesystems] Add EnvironmentVariableKeyProvider for Azure Blob Storage
     add 3e28aed  [FLINK-14970][table] Remove useless pattern matching case for NaN
     add 0d7c157  [FLINK-15096][python] Pass python configuration to the python operators instead of global job parameters.
     add 190b13a  [FLINK-10933][kubernetes] Add Kubernetes session cluster entry point
     add d4bd2d6  [FLINK-15095][table-planner-blink] Bridge table schema's primary key to metadata handler in blink planner
     add 57bb952  [FLINK-15020][hive] Support timestamp type in hive
     add beb64bd  [hotfix][kubernetes] Let creating Flink master deployment and taskmanager pod respect user defined config
     add ef5314a  [FLINK-9955][kubernetes] Add Kubernetes ClusterDescriptor to support deploying session cluster
     add 4a132c4  [FLINK-14993][metrics] Reorganize reporter-scoped information
     add 7d375cc  [FLINK-14993][metrics] Store delimiter in reporter settings
     add 4ca5cdf  [hotfix][yarn] Add AbstractClusterClientFactory containing some common implementations
     add 9781928  [hotfix][yarn] Move some common methods to AbstractCustomCommandLine
     add 912d256  [FLINK-10936][kubernetes] Implement Kubernetes command line tools to support session cluster
     add 5d99cd6  [FLINK-10937][dist] Add kubernetes-entry.sh and kubernetes-session.sh
     add 5edc973  [hotfix] Fix checkstyle violations in CliFrontend.java
     add a0d441f  [minor] Make RestClient logging less noisy
     add b8153d3  [hotfix] Remove "shutdown if attached" option from "all" YARN options
     add 27488a4  [minor] Add debug statements in Cli frontends
     add 6825f80  [FLINK-15116] Return a ClusterClientProvider from ClusterDescriptor methods
     add 1b99d53  [FLINK-15116] Make JobClient stateless, remove AutoCloseable
     add bd521c1  [FLINK-15116] Move attached shutdown hook to context environment
     add 3005f04  [FLINK-14264][rest] Expose state backend name
     add 533b08e  [FLINK-14264][runtime] Reduce surface area to EG
     add d788a72  [hotfix][e2e] Cleaning logs before executing single tests.
     add 058cad0  [hotfix][e2e] Removing unused s3 methods
     add b0d2ed5  [FLINK-14574][e2e] Replacing s3Util with dockerized aws cli enabling customized endpoints and other features that would needed to be manually implemented.
     add 418e78b  [FLINK-14574][e2e] Providing minio based s3 setup allowing users without AWS secrets to test plugins.
     add 713cbf8  [FLINK-14574][core/e2e] Wrap FileSystem to use plugin context classloader.
     add 42276ba  [hotfix][core] Removing deprecated methods in SafetyNetCloseableRegistry.
     add 5bc914e  [FLINK-14906][table] create and drop temp system functions from DDL to FunctionCatalog
     add 1858ce2  [hotfix][hive] adapt HiveFunctionDefinitionFactory.createFunctionDefinition to latest APPI
     add 20e945d  [FLINK-14898] Enable background cleanup of state with TTL by default
     add dbdaf5b  [hotfix][core] Introduce divide operation to Resource
     add a78a5d4  [hotfix][core] Introduce divide operation to MemorySize
     add 5183be8  [hotfix][core] Introduce TaskExecutorResourceSpecBuilder for building TaskExecutorResourceSpec.
     add d2558f4  [FLINK-14188][runtime][yarn/mesos] Set container cpu cores into TaskExecutorResourceSpec when launching TaskExecutors on Yarn/Mesos.
     add db33a49  [FLINK-14188][runtime] Derive and register TaskExecutor to ResourceManager with default slot resource profile.
     add 66be972  [FLINK-14188][runtime] Use default slot resource profile derived from TaskExecutorResourceSpec on both RM and TM sides.
     add 25f79fb  [hotfix][runtime] Wrap arguments of ResourceManagerGateway#registerTaskExecutor into TaskExecutorRegistration.
     add da071ce  [FLINK-14189][runtime] TaskExecutor register to ResourceManager with total resource profile.
     add 516aee3  [FLINK-14189][runtime] Extend TaskExecutor to support dynamic slot allocation
     add db3dec5  [FLINK-14189][runtime] Do not store dynamic slots by index in TaskSlotTable
     add c00717e  [FLINK-15110][metrics] Support variable exclusion
     add f3ba8b4  [FLINK-14824][table] Make derivation schema as a default option for CSV source and sink
     add 61859a8  [FLINK-14824][csv][json] Make derivation schema as default option for CSV and JSON formats
     add 1710207  [FLINK-14824][docs] Improve schema derivation for formats
     add 59ac518  [FLINK-15109][runtime] Null out restoredTimersSnapshot when it is no longer needed
     add f631df9  [FLINK-15121] Add public constructors for execution environments that take Configuration
     add 47f2939  [FLINK-14513][hive] Implement listPartitionsByFilter to HiveCatalog
     add 0d9058c  [FLINK-14378][state-backends] Cleanup rocksDB lib folder if loading the library fails
     add 1489cb0  [FLINK-15130][core] Deprecate RequiredParameters and Option
     add f90fd6b  [FLINK-15136][docs] Update the Chinese version of Working with State TTL
     add c93205b  [FLINK-14649][kafka][es] Flatten all the connector properties keys to make it easy to configure in DDL (#10468)
     add 2994f0e  [FLINK-13438][hive] Support date type in Hive
     add 4ee5477  [FLINK-15134][client] Delete temporary files created in YarnClusterDescriptor
     add cdfe1d4  [hotfix][configuration] Improve Configuration set method for a more fluent api
     add b0785ba  [FLINK-15067][table] Pass configuration to the underlying ExecutionEnvironment
     add bb6fd82  [FLINK-15067][table-api] Add utility method to TableConfig that adds a new job parameter
     add 4ccac6b  Update version to 1.11-SNAPSHOT
     add 5452bec  [FLINK-15127][table] rename function operations to catalog function operations
     add decacc9  [hotfix] Fix typo in HiveShimV100
     add b5d958d  [FLINK-14953][formats] use table type to build parquet FilterPredicate
     add a435827  [FLINK-15157] Make ScalaShell ensureYarnConfig() and fetchConnectionInfo() public
     add 166e10f  [FLINK-15129] Return JobClient instead of JobClient Future from executeAsync()
     add 06a78c6  [FLINK-14992][client] Add job listener to execution environments
     add f26d654  [FLINK-14992] Extend test coverage of JobListenerITCase
     add 4d693c4  [FLINK-15166][runtime] Fix the bug of wrongly recycling uncompressed buffer
     add c29f659  [hotfix][test] Do not hide original exception in the SourceStreamTaskTest
     add 7e77a66  [FLINK-15076][task] Fix SourceStreamTask cancellation
     add 26c1d36  [hotfix][test] Rename and reformat testCancellationFailsWithBlockingLock
     add 657d4df  [hotfix][task] Do not wrap Errors from SourceFunctionThread
     add 6576245  [hotfix] Fix checkstyle violation in AbstractMetricGroup
     add 9c44413  [FLINK-15093][streaming-java] StreamExecutionEnvironment#getStreamGraph should clear transformations
     add a11893f  [FLINK-15052][sql-client] Test transformation.clear() in sqlClient
     add 01410ca  [hotfix][kubernetes] Remove per-job related config options
     add 0d47a71  [hotfix][kubernetes] Correct some description of cli options
     add 09208f9  [hotfix][kubernetes] Separate creating and retrieving flink cluster logs
     add 4286fca  [FLINK-15153][kubernetes] Service selector needs to contain jobmanager component label
     add 6e2c9a9  [FLINK-14958][table] ProgramTargetDescriptor#jobID can be of type JobID
     add 40c2154  [FLINK-14006][python][docs] Add documentation for how to use Java UDFs with Python API
     add 5c89d12  [hotfix][doc] update Hive functions page with more info
     add 2c11291  [FLINK-14951][tests] Harden the thread safety of State TTL backend tests
     add 886bf6f  [FLINK-15008][build] Bundle javax.activation-api for Java 11
     add eddad991 [FLINK-15008][legal] Update licensing
     add e05618b  [FLINK-14926][state-backend-rocksdb] Ensure that RocksObjects are always closed on backend disposal
     add 6560929  [hotfix][tests] Remove unnecessary temp directory handling
     add 08554b9  [hotfix][tests Use assumptions rather than manual checks in RocksDBStateBackendConfigTest to report skipped tests properly
     add 3820bdd  [hotfix][tests] Ensure RocksDB native library is loaded into temp directory
     add fdc5ed5  [FLINK-15177][state-backend-rocksdb] Migrate RocksDB Configurable Options to new type safe config options
     add 6955ba7  [hotfix][state-backend-rocksdb] Some minor style cleanups in RocksDBResourceContainer
     add 0602ccf  [FLINK-14926][state-backend-rocksdb] (follow-up) Make RocksDBResourceContainer immutable
     add 93deb1a  [FLINK-14926][state-backend-rocksdb] (follow-up) Simplify test to rely on RocksDBResourceContainer for cleanup of native handles
     add 31dd8c3  [FLINK-14926][state-backend-rocksdb] (follow-up) Avoid exposing handles that will not be closed from RocksDBStateBackend
     add 2405111  [FLINK-14926][state-backend-rocksdb] (follow-up) Simplify collecton the option objects to close
     add 07f08fb  [FLINK-14926][state-backend-rocksdb] (follow-up) Replace OptionsFactory for RocksDBOptionsFactory
     add 04ab225  [FLINK-15069][benchmark] Supplement the pipelined shuffle compression case for benchmark
     add 9277e9e  [FLINK-15199][rocksdb] Make RocksDBResourceContainer public for the benchmarks
     add 940613b  [hotfix][doc] update and remove limitations of Hive connector
     add 26de396  [hotfix][doc] update Hive doc
     add e40e158  [FLINK-15203][doc] rephrase Hive's data types doc
     add bdb4de7  [hotfix][doc] update catalog APIs
     add 5b09f19  [FLINK-13577][ml] Add an util class to build result row and generate result schema.
     add ab4c31c  [FLINK-15061][table]create/alter and table/databases properties should be case sensitive stored in catalog
     add 98dd5dc  [FLINK-14007][python][docs] Add documentation for how to use Java user-defined source/sink in Python API
     add 7bf96cf  [FLINK-15073][sql client] Sql client falis to run same query multiple times
     add 6515a79  [hotfix][docs] Add missing endhighlight
     add 3a30e29  [FLINK-15185][hive] Shade flink-hadoop-fs to use hive connectors in standalone mode
     add f80be71  [FLINK-15195][kubernetes] Remove unused KubernetesConfigOptionsInternal.ENTRY_POINT_CLASS_ARGS
     add b8f3e3a  [FLINK-15082] Respect new FLIP-49 taskmanager.memory.total-process.size in Mesos RM
     add 792c674  [FLINK-15082] Deprecate mesos.resourcemanager.tasks.mem in favour of taskmanager.memory.total-process.size
     add f283edb  [FLINK-15139] [table/sql-client] parse dependecy jars in execution config
     add ef0a033  [FLINK-15001] [table-planner-blink] The digest of sub-plan reuse should contain retraction traits for stream physical nodes
     add 3e5a045  [FLINK-15124][table] Fix types with precision defined in DDL can't be executed
     add 9e91664  [hotfix][table-runtime-blink] Fix the watermark assigner operator should emit max watermark in close
     add 7bb9a2c  [FLINK-15161][table-common] Introduce TypeTransformation interface and basic transformations (#10500)
     add 435dbca  [hotfix][build] Fix typo in maven property
     add 213bdf0  [FLINK-15163][build] Set japicmp.referenceVersion to 1.9.1
     add 7bc79a1  [FLINK-15196][Mesos] Using the mesos.resourcemanager.tasks.cpus to determine the cpus of Mesos worker.
     add 2ae4c42  [hotfix][documentation] Generate the respective htmls because of previous configuration changes
     add 7600e8b  [FLINK-14952][network] Solve the issue of exceeding memory limits when using mmap blocking partition
     add 556a88d  [hotfix][streaming] Fix API incompatibility
     add 4150d30  [hotfix][doc] add missing tag in catalogs.zh.md
     add 127ef48  [FLINK-14941][hbase] Fix the same row appear twice if encountered any HBase exception when scanning
     add 5139282  [FLINK-15140][runtime] Fix that data compression doesn't work with BroadcastRecordWriter for pipelined mode
     add 1ee309d  [hotfix][config] Document enhancement: reminding users that shuffle data compression is experimental currently
     add cd4c3dd  [FLINK-15167][sql client] Catalogs should be created and registered with user class loader
     add 332d532  [FLINK-15058][runtime] Log required config options if TaskManager memory configuration is invalid
     add 2bc43d5  [FLINK-15222][state backends] Move state benchmark utils into core repository
     add 3cd0919  [FLINK-15197][kubernetes] And resource dynamic properties into TM start command for kubernetes integration.
     add a67c273  [hotfix] Simplify SlotSharingManagerTest by introducing factory method
     add 632586f  [FLINK-15013] Mark root as resolved before completing MultiTaskSlot
     add 65777f2  [hotfix] Introduce SlotSharingManager#createAndRegisterRootSlot
     add fff9cbc  [hotfix] Refactor LocationPreferenceSlotSelectionStrategyTest to use Hamcrest matchers
     add f455423  [hotfix] Add locality assertions to LocationPreferenceSlotSelectionStrategyTest tests
     add 9493c3d  [FLINK-15013] Fix selection of NON_LOCAL slots in LocationPreferenceSlotSelectionStrategy
     add ae67940  [hotfix] Remove explicit capacity from HashMap creation in SlotSharingManager
     add a1bead9  [hotfix] Set initial bestCandidateScore in LocationPreferenceSlotSelectionStrategy to Double.NEGATIVE_INFINITY
     add bc36896  [hotfix][hive][test] rename util method from createTableEnv to createTableEnvWithBlinkPlannerBatchMode
     add aa56e6d  [hotfix][hive] rename HiveCatalogTestBase to HiveCatalogMetadataTestBase
     add 940bdfc  [FLINK-15234][table][hive] hive table created from flink catalog table cannot have null properties in parameters
     add e4cecef  [FLINK-15240][hive] is_generic key is missing for Flink table stored in HiveCatalog
     add 8c3f034  [hotfix] Leverage autoCloseable to simplify CliFrontend.runClusterAction()
     add 53f9c24  [FLINK-15179] Introduce generic ExecutorCLI
     add 22d3fe6  [FLINK-15179] Remove StandaloneSessionClusterExecutor so ExecutorCLI supports list()/cancel()
     add bc8964c  [FLINK-15179] Make Kubernetes Session CLI use the ExecutorCLI
     add 2ec51f6  [FLINK-15179] Assume Deployment.target=kubernetes-session when in KubernetesSessionCli
     add 31b3abd  [FLINK-15179] Annotate KubernetesSessionCli as internal
     add fdaf692  [FLINK-15260] Uniformize Kubernetes executor name with the rest
     add f6c38ec  [hotfix][doc][hive] rename page from 'Hive' to 'Hive Integration'
     add a5cfc3c  [FLINK-15159][docs] Update the mapping of  JSON schema string type to Flink SQL STRING type (#10582)
     add 36e8244  [hotfix][doc][hive] add doc on what hive dependencies to put in /lib dir
     add 8fa00ef  [hotfix][hive][test] enhance HiveCatalog IT case with 'alter table' and 'drop table' statements
     add 10936d7  [FLINK-15190][doc]add documentation for DDL in FLIP-69
     add c3c290c  [FLINK-15233][kafka] Improve Kafka connector properties to make append update-mode as default
     add 0bd083e  [FLINK-13589] Fixing DelimitedInputFormat for whole file input splits.
     add f6ce8dd  [FLINK-15228][docs] Drop vendor specific deployment documentation
     add 2ba2a91  [FLINK-15257][hive]convert HiveCatalogITCase.testCsvTableViaAPI() to use blink planner
     add 7f8bd71  [FLINK-15128][hive][doc] Document support for Hive timestamp type
     add bd15e36  [FLINK-15263][hive][doc] add dedicated page for HiveCatalog
     add 387c8b6  [hotfix][doc][hive] add Hive connector to SQL's connector page
     add 6a0570d  [FLINK-15254][sql cli][module] modules in SQL CLI yaml should preserve order
     add 393c96e  [FLINK-15271][python][docs] Add documentation about the environment requirements for running Python UDF
     add 6f71ef0  [FLINK-15270][python][docs] Add documentation about how to specify third-party dependencies via API for Python UDFs
     add 5b1df6e  [FLINK-15270][python][docs] Corrects docs for method `set_python_executable` in TableConfig
     add 60098a7  [FLINK-15267][table-planner-blink] Fix NoSuchElementException if rowtime field is remapped in TableSource (#10596)
     add b0783b50 [FLINK-15245][hive] Fix hive table source cannot write data to another hadoop cluster
     add 685c443  [FLINK-15286][state-backend-rocksdb] Read option whether to use managed memory from configuration
     add bd11e05  [FLINK-14834] Re-activate kerberized YARN on Docker tests
     add cb84e69  [FLINK-15251][kubernetes] Use hostname to create end point when ip in load balancer is null
     add 972aac1  [FLINK-15265] Remove "-executor" suffix from executor names
     add 0e3a969  [FLINK-15072][client] Move printing stringified JobExecutionResult to ContextEnv
     add cdc0d44  [FLINK-15072][client] Remove JobExecutionResult container from ClientUtils#executeProgram
     add 8cef3e9  [FLINK-15201][client] Remove verifications in ContextEnv for detached execution
     add 992f26f  [FLINK-15072][client] Hijack executeAsync instead of execute for create pipeline
     add 8c78e1e  [FLINK-14929][tests] Harden ContinuousFileProcessingCheckpointITCase
     add ce214d2  [hotfix][tests] Remove unnecessary try-catch usage
     add c9f7a5a  [hotfix][tests] Remove unnecessary try-catch usage
     add 4259baf  [hotfix][tests] Remove unnecessary override of close() method
     add 864668f  [FLINK-15250][docs] Update "Connect to External Systems" page to list the required formats in connectors definition section
     add c332bf3  [FLINK-15191][table][connectors] Fix connector factories that CREATE TABLE DDL can't work if watermark or computed column is defined
     add 410aa96  [FLINK-15191][kafka] Add Kafka IT cases for Table API & SQL
     add 15f7cda  [FLINK-14899] [table-planner-blink] Fix unexpected plan when PROCTIME() is defined in query
     add 6ed64ab  [FLINK-15169][runtime] Set global failure cause to ExecutionGraph
     add 0186e10  [FLINK-15169][runtime] Hand task failures to ExecutionGraph so that the vertex state and failure cause are properly set
     add c325191  [FLINK-15092][java, table] Remove the restriction that CsvInputFormat expects at least one parser
     add ca02ebc  [FLINK-15105][test] Skipping exception checks for resuming checkpoint tests after terminal failure
     add 5a1ac14  [FLINK-13373][docs] Remove examples section from getting started
     add 7ad543c  [FLINK-13373][docs] Move python tutorial to the walkthrough section
     add 087adc4  [hotfix][docs] Cleanup grammar in python table walkthrough
     add 974627d  [FLINK-13373][docs] Merge bash and windows local setup and move to deployment
     add 4e3b8cc  [FLINK-15256][hive] HiveModuleFactory should take hive-version as required supported property
     add 1384381  [FLINK-15205][hive][document] Update hive partition and orc for read_write_hive
     add fcbbd44  [hotfix][doc] Add single quotes to csv format ddl property
     add d6e3bd9  [FLINK-15049][table-planner-blink] Fix compile error when hash join with timestamp type key (#10415)
     add 781a7c8  [FLINK-15232][table] Improve message of NoMatchingTableFactoryException to tell users which part is not matched (#10563)
     add 6241894  [FLINK-15291][table-common] Rename WatermarkSepc#getWatermarkExpressionString to getWatermarkExpr (#10614)
     add 09bcde2  [hotfix][table] Rename UserFunctionsTypeHelper
     add 91629d6  [FLINK-12283][table] Relax UDF constraints by using the ClosureCleaner
     add 7fb9f9b  [hotfix][table] Update function tests to use testing infrastructure
     add 524b443  [hotfix][table] Use testing infrastacture in tests
     add a607bd9  [FLINK-14170][fs-connector] Support hadoop<2.7 in StreamFileSink when truncate() not used
     add f1c4ddf  [FLINK-14170][fs-connector] Add tests for hadoop<2.7 support in StreamFileSink
     add a7884ab  [FLINK-14944][python] Fix pip install ConnectionResetError
     add 4e4dcf5  [FLINK-13197][table-planner-blink] Fix Hive view row type mismatch when expanding in planner
     add 931f52c  [FLINK-13197][table-planner] Fix Hive view row type mismatch when expanding in planner
     add 3c8a3ac  [FLINK-15244][FileSystems] Avoid following symbolic links in FileUtils#deleteDirectory(File)
     add 023cff2  [hotfix][travis] Made shade.sh standard shell compliant.
     add 510f9ce  [hotfix][e2e] Added "minio" to test descriptions.
     add 0e85f54  [hotfix][filesystems] Also mirroring s3.path-style-access.
     add 5846ee5  [FLINK-11956][travis] Removed S3 shading checks from build script.
     add 9fdedf5  [FLINK-11956][filesystem] Remove relocations from s3 plugins.
     add 4fc55c7  [FLINK-15241] Revert the unexpected change of the configuration for Mesos CPU cores
     add 300e249  [FLINK-15171] [serialization] fix performance regression caused by too many buffer allocations on string serialization
     add e7dab6f  [FLINK-15312][tests] Remove PlanExposingEnvironment
     add bdd432a  [FLINK-13567][e2e] Support retry with cleanup
     add d2f3b27  [FLINK-13567][e2e] Dump kafka logs in shutdown on error
     add feb68d8  [FLINK-13567][e2e] Retry kafka/registry start
     add 3d8fe9c  [FLINK-13567][e2e] Enable schema registry tests
     add 36aff23  [FLINK-15317][runtime] Handle closed input gates more gracefully during cancellation. (#10621)
     add e72a5a7  [FLINK-15149][table-common] Merge InputTypeStrategy and InputTypeValidator
     add a27d73a  [FLINK-14683] Fix RemoteStreamEnvironment's constructor
     add 22020e1  [hotfix][table-common] Add utility method for checking if a type is a composite type
     add 958663b  [hotfix][table-common] Add utility for expanding a composite type to a schema.
     add 21107c7  [hotfix][table-api] Add utility for extracting accessed fields from a given physical type.
     add cbc1005  [hotfix][table-common] Add utility for mapping logical fields to physical indices.
     add 170a822  [hotfix][table] Remove duplicated code for physical to logical mapping
     add 39b7992  [FLINK-15168][table-planner] Fix physical indices computing.
     add cd36331  [hotfix][table-planner-blink, tests] Fix produced data type of TestCollectionTableSource.
     add 1960b27  [FLINK-15168][table-planner-blink] Compute physical indices based on new type hierarchy instead of TypeInformation
     add d49ee21  [hotfix][table-common] Deprecate TableSource#getSchema.
     add 8990e4a  [hotfix][connectors/jdbc, table, tests] Fix types in schema ddl in tests
     add 5249249  [hotfix][connectors/kafka, table, tests] Fix types in schema ddl in tests
     add 6053e7a  [FLINK-15050][table-planner-blink] DataFormatConverters should support any TIMESTAMP WITHOUT TIME ZONE types
     add b692d10  [FLINK-15269][table] Fix INSERT OVERWRITE/PARTITION syntax shouldn't be limited to Hive dialect (#10587)
     add 5f86f2d  [FLINK-15266][table-planner-blink] Fix NPE for code generated CASE WHEN operator in blink planner (#10594)
     add 2416f08  [FLINK-11767] [tests] Introduce ClassRelocator
     add bbfaf57  [FLINK-11767] [tests] Introduce new TypeSerializerUpgradeTestBase
     add 15f175a  [FLINK-11767] [test] Add new PojoSerializer upgrade test based on TypeSerializerUpgradeTestBase
     add 21165ea  [minor] Add more JavaDoc to ClassRelocator
     add 0703cce  [FLINK-11767] Allow multiple migrate versions in PojoSerializerUpgradeTest
     add acd4bed  [FLINK-11767] In PojoSerializerUpgradeTest also check against Flink 1.8
     add 44f8c97  [minor] In TypeSerializerUpgradeTestBase add note about generating test data
     add 96b44e9  [FLINK-13632] In PojoSerializerUpgradeTest also check against Flink 1.9
     add 99ff931  [FLINK-11767] In TypeSerializerUpgradeTestBase move migration version to base class
     add 1247e66  [FLINK-11767] Deprecate TypeSerializerSnapshotMigrationTestBase in favour of TypeSerializerUpgradeTestBase
     add 9362fc9  [hotfix] In ClassRelocator, use correct ASM7 dependency
     add 78eea09  [FLINK-14505][e2e, table] Update expected results after format change introduced in FLINK-11935
     add 92da39d  Revert "[FLINK-14505][tests] Temporarily disable SQL Client end-to-end tests for Kafka"
     add 47f2efe  [FLINK-15332][jepsen] Copy flink-s3-fs-hadoop* into /plugins directory instead of lib
     add 01cb140  [hotfix][yarn] Refactor YarnDistributedCacheITCase to avoid code duplication
     add 65fbb3d  [hotfix][yarn] Fix logs in YARNITCase could not show up
     add e47bbcc  [FLINK-15194] Support registering directory as cache file in Yarn per-job mode
     add 96f4c79  [FLINK-15268][build] Correctly set Multi-Release in manifest.
     add ef7ee76  [FLINK-15065][docs] Correct default value of RocksDB options in documentation
     add 444a544  [FLINK-15311][runtime] Remove the shade of lz4 compression for using efficient native implementation
     add 8525c37  [FLINK-15308][runtime] Remove data compression for pipelined partition
     add c2c38b1  [FLINK-15301] [kinesis] Exception propagation from record emitter to source thread
     add 57be6ed  [FLINK-15287][hive] Pack flink-hadoop-compatibility and flink-orc into flink-hive
     add a0ceb6f  [hotfix][doc][hive] add information of hive connector jar
     add c84f206  [FLINK-15322][hive] Parquet test fails with Hive versions prior to 1.2.0
     add 0468708  [FLINK-14796][hive][doc] Add document about limitations of different Hive versions
     add b719582  [hotfix][e2e] Refactor test_kubernetes_embedded_job.sh by moving common functions to common_kubernetes.sh
     add e1ef44b  [FLINK-10938][e2e] Add e2e test for natively running flink session cluster on kubernetes
     add ed6a3bd  [hotfix] Enable killing mesos job manager in e2e clean up function
     add db814b0  [hotfix] Forcelly remove the useless log in e2e clean up function
     add cf19795  [Flink-15135][e2e][Mesos] Adding Dockerfiles relevant to Mesos setup
     add d1c1764  [Flink-15135][e2e][Mesos] Adding common functions to setup Flink on Mesos cluster
     add aff08e5  [Flink-15135][e2e][Mesos] Adding WordCount e2e test for Flink on Mesos
     add 20c670a4 [hotfix] Enable arg list for nightly.sh
     add 633c795  [Flink-15135][e2e][Mesos] Enable Mesos e2e test in Travis
     add 50b1dcb  [hotfix] Adding Mesos e2e tests to run-nightly-test script
     add cce1cef  [hotfix] Using retry_times when building docker image
     add e30bcfd  [FLINK-15360][e2e] Fix the issue of parameter with whitespace in retry_times shell function
     add 90b0feb  [FLINK-15320][runtime] Increment versions of all vertices when failing/canceling/suspending a job
     add 94edb0c  [FLINK-15320] Simplify DefaultSchedulerTest tests for incrementing vertex versions
     add dcf4869  [FLINK-15272][table-planner-blink] Improve exception message when insert partition with values (#10591)
     add 0f88c39  [FLINK-15361][parquet] ParquetTableSource should pass predicate in projectFields
     add 790a077  [FLINK-15348][hive] Fix orc optimization for version less than 2.3 by introducing orc shim
     add fada682  [FLINK-15193][table][docs] Move DDL to the first tab in table connector page
     add 393b91f  [FLINK-15243][table][docs] Fix documentation about how to set line feed as delimiter for csv format
     add 5ec3fea  [FLINK-15344][documentation] Update limitations in hive udf document
     add fc4927e  [FLINK-15175][sql client] Fix SqlClient not support with..select statement
     add dcb0250  [FLINK-15359][configuration] Remove unused YarnConfigOptions
     add a62641a  [FLINK-13662][core] Add timeLeft variant that throws TimeoutException
     add 20041ca  [FLINK-13662][kinesis] Relax timing requirements
     add 545534e  [FLINK-15248][FileSystems] Allow FileUtils#compressDirectory to process relative directories.
     add e3e4281  [FLINK-11524][tests] Throw descriptive error if job terminates prematurely
     add b115369  [FLINK-11524][tests] Make JobResultUtils#assertIncomplete implementation more comprehensive
     add a026811  [hotfix] Unmounted the data and log directory of Mesos docker
     add 3036dd9  [FLINK-15377] Add ResourceManager connecting error to white list
     add 2039dda  [hotfix] Using docker detach execution mode to start flink cluster
     add e9c8282  [FLINK-15374][core][config] Update jvm overhead config descriptions regarding direct/native memory and jvm parameters.
     add 55760b1  [FLINK-15373][core][config] Update framework off-heap memory config description regarding direct/native memory and jvm parameters.
     add 807bbe8  [FLINK-15373][core][config] Update task off-heap memory config description regarding direct/native memory and jvm parameters.
     add 16b6357  [hotfix] Update task heap/offheap config option descriptions for preciseness.
     add c685ee9  [hotfix][doc] add section for various optimizations of reading Hive tables
     add b3ff6ae  [FLINK-15342][hive] add IT for querying Hive view
     add 82619f2  [FLINK-15372][core][config] Remove 'total-' from total process memory config key.
     add 0ba4a2b4 [FLINK-15372][core][config] Remove 'total-' from total flink memory config key.
     add 1871743  [hotfix][table-common] Add toNullable() and legacyDecimalToDefaultDecimal() TypeTransformations
     add f7ac7b9  [hotfix][table-api] Use new type system for CsvTableSink
     add 32ff63e  [hotfix][hive] Use TableUtils.collectToList(Table) to verify query result
     add fb0cd0e  [FLINK-15313][table-blink] Fix can't insert decimal data into sink using TypeInformation
     add 5cc4ef8  [hotfix][hive] Use TableUtils.collectToList(Table) in TableEnvHiveConnectorTest
     add 89ce45b  [FLINK-15382][docs] Exclude PythonConfig from configuration docs generator
     add d6ba651  [hotfix][yarn] Move yarn Utils#calculateHeapSize to BootstrapTools
     add d3f1f06  [FLINK-15288][kubernetes] Starting jobmanager pod should respect containerized heap-cutoff
     add 2e9a7f3  [FLINK-15391][hive] DATE and TIMESTAMP partition columns don't work
     add 52fdee1  [FLINK-15239][table-planner-blink] Fix CompileUtils:#COMPILED_CACHE leaks class loaders (#10620)
     add 2e0ba5d  [FLINK-15189][hive][doc] Add documentation for hive view
     add 28b6221  [FLINK-14849][hive][doc] Fix documentation about Hive dependencies
     add 450795e  [FLINK-15426][e2e] Fix TPC-DS end-to-end test (Blink planner) fails on travis (#10707)
     add ab96f2c  [FLINK-15125][table-planner-blink] Fix PROCTIME() computed column defined in CREATE TABLE doesn't work
     add 42b09a4  [FLINK-13667][ml] Add the utility class for common Table operations.
     add 959d086  [FLINK-13667][ml] Improve API and extend test coverage on all functions in TableUtils.
     add 539e6a0  [FLINK-15435][python] Fix unstable test for ExecutionConfigTests.test_equals_and_hash
     add 21f769b  [FLINK-15389][jdbc] Improve JDBCUpsertOutputFormat to schedule flusher when flushMaxSize is not one
     add f3108bf  [FLINK-15418][table-planner-blink] Set FlinkRelDistribution in StreamExecMatchRule
     add 4f77546  [FLINK-15425][csv][docs] Improve docs that only old CSV format is supported in filesystem connector (#10718)
     add 5bd12fd  [FLINK-15192][table][docs] Restructure "SQL" page into multiple sub-pages and reorder pages under Table API & SQL
     add ee5409d  [FLINK-14610][table][docs] Add documentation for how to define time attribute in DDL
     add b2d7571  [FLINK-15439][table][docs] Fix incorrect description about unsupported DDL in "Queries" page
     add 9dc2528  [FLINK-15231][table-runtime-blink] Remove useless methods in AbstractHeapVector
     add ba44335  [FLINK-15421][table-planner-blink] Fix cast exception for timestamp MAX/MIN retract aggregate functions
     add fc23c44  [FLINK-15428][e2e] Skip Avro Confluent Schema Registry case when running with JDK11
     add 0c0dc79  [FLINK-15428][e2e] Fix the error command for stopping kafka cluster
     add e1340a0  [FLINK-15409][table-planner-blink] Fix code generation in windowed join function (#10714)
     add f205d75  [FLINK-15290][streaming] Configure user defined function with global configuration
     add 6f3a077  [FLINK-15259][hive] HiveInspector.toInspectors() should convert Flink constant to Hive constant
     add 5023646  [FLINK-15443][jdbc] Fix mismatch between Java float and JDBC float (#10731)
     add e1e040d  [hotfix][table-planner-blink] Fix comparison of timestamp with local time zone
     add eadbd4c  [FLINK-15411][table-planner-blink] Fix prune partition on DATE/TIME/TIMESTAMP columns
     add dc0cf3b  [FLINK-15411][hive] Fix listPartitions in HiveCatalog & Add time prune partition tests
     add 24c970b  [FLINK-15420][table-planner-blink] Fix precision is lost when casting string to timestamp (#10727)
     add 3843e16  [FLINK-15383][table-planner] Use sink schema field name instead of query field name for UpsertStreamTableSink#setKeyFields
     add 898064f  [FLINK-15334][table-api] Fix physical schema mapping in TableFormatFactoryBase to support define orderless computed column (#10693)
     add 6b6dfd0  [FLINK-15381] [table-planner-blink] Fix collation derive logic on RelSubset in RelMdCollation (#10694)
     add 8830ef0  [FLINK-15377][tests] Remove docker-engine install in Mesos docker image
     add cac6b9d  [FLINK-14980][docs] add function ddl docs
     add 9637af3  [FLINK-14613][table-planner-blink] Fix wrong result when lookup join equality condition contains function on lookup key.
     add 382443d  [hotfix][docs] Fix link to latency granularity in "Metrics" page (#10751)
     add 2dfa76e  [hotfix][csv][json] Deprecate schema methods for CSV and JSON formats
     add 6609016  [FLINK-15446][table][docs] Improve "Connect to External Systems" documentation page
     add 671f18b  [hotfix][yarn] Write yarn properties file without YarnClusterDescriptor.
     add d82828d  [hotfix][yarn] Remove unused argument workingDirectory for YarnEntrypointUtils#installSecurityContext.
     add 267f590  [hotfix][yarn] Remove unused argument logger for YarnEntrypointUtils#loadConfiguration.
     add 367765b  [FLINK-15437][yarn] Apply dynamic properties early on client side.
     add 1c5806a  [FLINK-15429][hive] HiveObjectConversion implementations need to handle null values
     add c0e34ac  [hotfix][runtime] Fix formatting in TaskExecutorResourceUtils and NetworkBufferPool
     add 11be93a  [FLINK-15403][task] Allow the CancelTaskException to be thrown from mailbox thread
     add a9839f3  [FLINK-15380][scala-shell] Unable to set number of TM and number of Slot for MiniCluster in Scala shell
     add bec32a3  [hotfix][core][config] Use the new type definition for config options of primitive types in TaskManagerOptions.
     add 702a016  [FLINK-15371][core][config] Use the new type definition for config options of memory types in TaskManagerOptions.
     add 29c718d  [hotfix][core][config] Use the new type definition for config options of duration types in TaskManagerOptions.
     add 552a076  [FLINK-15427][Statebackend][test] Check TTL test in test_stream_state_ttl.sh and skip the exception check
     add 23ecdb1  [FLINK-15279][doc] Document new executeAsync() method and the newly introduced JobClient
     add de512c0  [FLINK-15454][cluster] Remove redundant inherited ClusterEntrypoint#installSecurityContext
     add 4920ac8  [FLINK-15341][client] Reset context classload in PackagedProgramUtils#createJobGraph
     add 897e137  [FLINK-15427][e2e] Harden test_stream_state_ttl.sh verification logic
     add 007253f  [FLINK-9679] Add Schema Registry version as parameter + update version
     add 37a818c  [FLINK-9679] Add (Confluent)(Registry)AvroSerializationSchema
     add b55002b  [minor] Simplify RegistryAvroSerializationSchema.serialize()
     add b1fc6da  [FLINK-9679] In Confluent Schema Registry e2e, also test write path
     add 23c0bb0  [FLINK-15297][yarn] Do not throw exception if YARN Application switched to FINISHED immediately after deployed in YarnClusterDescriptor#startAppMaster
     add 65853b3  [FLINK-15459] Drop vendor specific repos from parent pom.xml
     add f503664  [FLINK-14765][runtime] Remove STATE_UPDATER in Execution
     add a483524  [FLINK-13596][ml] Add DataStream and DataSet to Table transformations.
     add ec8ea8b  [FLINK-13596][ml] Improve fallback conversion and test for Table transformation.
     add df5eb21  [FLINK-13027][fs-connector] SFS bulk-encoded writer supports customized checkpoint policy
     add 6e0088a  [FLINK-14766][coordination] Remove volatile keyword in executiongraph package
     add 99ef937  [hotfix][doc] Remove invalid comment from CheckpointedInputGate
     add 35457ce  [hotfix][doc] Fix typo in asyncio.md
     add 0a2cc58  [FLINK-15468][sql-client] INSERT OVERWRITE not supported from SQL CLI
     add 29a38a4  [FLINK-15453][hive] Remove unneeded HiveShim methods
     add 1d04a8c  [FLINK-15385][table][docs-zh] Translate "SQL" pages of Table API into Chinese
     add aff2b99  [hotfix][runtime] Fix a comment typo in CheckpointBarrierAligner
     add a50d9ff  [hotfix][runtime] Remove unused IOManager parameter while constructing BufferStorage
     add a5ef143  [FLINK-14655][runtime] Change type of field jobStatusListeners from CopyOnWriteArrayList to ArrayList
     add 744ba5d  [FLINK-15430][table-planner-blink] Split generated methods for Calc to prevent compiler exceptions (#10737)
     add 0fd8f39  [FLINK-14572][test] Print the root cause if job fails in BlobsCleanupITCase
     add 58e18c2  [FLINK-15481][python] Add `list[str]` to the type hint of parameter "schema" in `TableEnvironment#from_elements`.
     add 2388d2b  [hotfix][table-api-java] Remove @Experimental from useCatalog/useDatabase
     add 9d0653f  [hotfix][docs] Align the documentation of checkpoint directory to the actual implementation
     add 9f9bf02  [hotfix] Remove default value of legacy 'taskmanager.heap.mb', in case of implicit usages.
     add 48f838f  [hotfix] Add the legacy config option 'taskmanager.heap.size' back.
     add a455ddf  [hotfix] Remove unused ClusterSpecification#fromConfiguration.
     add 3285f7d  [hotfix] Rename AbstractClusterClientFactory to AbstractContainerizedClusterClientFactory.
     add 7fd7698  [FLINK-15367][runtime] Map legacy 'taskmanager.heap.size' to new config options differently for standalone / active setups.
     add 97910b3  [hotfix] Remove unnecessarily setting managed memory size for active resource manager configurations.
     add 229d021  [FLINK-15369][runtime] Set MiniCluster to use fixed managed / shuffle memory size by default.
     add 961ecd7  [hotfix][network] Fix the import format of NettyConfig class
     add 22cf1c5  [hotfix][network] Remove unused method from NettyConfig class
     add 12d0950  [FLINK-15021][network] Remove the setting of netty channel watermark in NettyServer
     add 1121949  [FLINK-14200][table] Fix NPE for Temporal Table Function Join when left side is a query instead of a source (#10763)
     add f0fe365  [FLINK-15478][table-planner-blink] Fix FROM_BASE64 code generation exception because of the wrong result type (#10766)
     add 2ff1de7  [FLINK-15053][runtime] Escape all dynamic property values for taskmanager
     add 61edf26  [FLINK-15398][docs] Fix incorrect code example in "Catalogs" page (#10786)
     add 69ed6fe  [FLINK-15465][FLINK-11964][table-runtime-blink] Fix required memory calculation not accurate and hash collision bugs in hash table (#10756)
     add b195383  [FLINK-15482][table][hive] Fix calling Hive functions with returning decimal type failed (#10775)
     add cb78583  [FLINK-15442] Harden the way to loop in retry_times_with_backoff_and_cleanup
     add 020c4d1  [FLINK-15442] Retry to download the kafka and confluent dist
     add ef78962  [FLINK-15501] Remove the wrong doc of ExecutionVertexSchedulingRequirements#getExecutionVertexId
     add f21f1c7  [FLINK-15406][state-processor-api] RocksDB savepoints with heap timers cannot be restored by non-process functions
     add 9a7cc30  [hotfix][e2e] Normalize the way to get log file name in wait_num_of_occurence_in_logs function
     add a26181b  [FLINK-15214][e2e] Enable waiting for job terminal state for all deployment modes
     add af99f5e  [FLINK-15214][e2e] Make CPU resources for mesos agent configurable per test
     add ec19b7a  [FLINK-15214][e2e] Introduce multiple submissions e2e test for mesos
     add 0b7d496  [FLINK-15370][state backends] Make sure sharedResources takes effect in RocksDBResourceContainer
     add 6ff3928  [FLINK-14926][state-backend-rocksdb] (follow-up) Move additional setup with sharedResources into RocksDBResourceContainer
     add dffa19b  [FLINK-11135][configuration] Reorder Hadoop config loading in HadoopUtils
     add f325c0b  [FLINK-15502][docs-zh] Fix hyperlink mistake in 'Queries' page (#10789)
     add 9df5c80  [FLINK-15499][yarn] Log TM host and resource at INFO level when starting new TMs.
     add 6f7c41c  [hotfix] Refactor memory range fraction parsing to throw IllegalConfigurationException
     add cd240bf  [hotfix] Fix TaskExecutorResourceUtilsTest#validateFail to catch only relevant exception and throw assert error
     add b301b82  [hotfix] Simplify logic which duplicates TaskExecutorResourceUtils#deriveManagedMemoryAbsoluteOrWithFraction and calls it again
     add d22fdc3  [FLINK-15300][Runtime] Allow shuffle memory fraction mismatch if derived from other memory types
     add b8e52e1  [hotfix] Improve derived shuffle memory sanity check test coverage
     add 73bb503  [hotfix] Log if memory fraction is outside of its min/max range and has to be capped
     add 6132f81  [hofix] Improve failure message of shuffle memory sanity check
     add 039955c  [hotfix] [python] Change the text of PyPI Author from `Flink Developers` to `Apache Software Foundation` (#10799)
     add d46b07b  [FLINK-15355][plugins] Added parent first patterns for plugins.
     add 0a1ac45  [FLINK-10939][doc] Add documents for running Flink cluster natively on Kubernetes
     add abe3b49  [FLINK-10939] Adjust spelling and ordering in Flink on Kubernetes doc
     add 26578f0  [hotfix] Fix typos in Flink on Kubernetes doc
     add ba15488  [hotfix][doc] Add missing execution configuration in config.zh.md
     add 07ce59e  [FLINK-15510] Pretty Print StreamGraph JSON Plan
     add efb12fe  [hotfix] Refactor OperatorID compartion in StreamGraph JSONGenerator
     add 7e73e59  [hotfix][yarn] Move yarn/Utils#getEnvironmentVariables to BootstrapTools
     add 9f99d59  [FLINK-15483][kubernetes] Starting jobmanager pod should respect environment config option
     add fd91220  [FLINK-8255] Throw meaningful exception when using string keys on row types
     add bd56224  [FLINK-14825][state-processor-api][docs] Rework state processor api documentation
     add f30dd98  [FLINK-15338][python] Cherry-pick NETTY#8955 to fix the TM Metaspace memory leak problem in shaded netty when submitting PyFlink UDF jobs multiple times.
     add 74dc895  [FLINK-15338][python] Cherry-pick BEAM-9006#10462 to fix the TM Metaspace memory leak problem when submitting PyFlink UDF jobs multiple times.
     add 94398f6  [hotfix][docs] Fix typo
     add d31bd5a  [hotfix][javadocs] Fix class reference
     add 6f2e9ab  [FLINK-15466][table-planner-blink] Fix the wrong plan when use distinct aggregations with filter
     add 5791298  [FLINK-15536][configuration] Revert removal of ConfigConstants.YARN_MAX_FAILED_CONTAINERS (#10808)
     add 3872c0d  [FLINK-15457][yarn] Remove outdated TODO
     add dba5b9e  [FLINK-15518][web] do not hide web frontend side pane automatically (#10803)
     add 169edef  [FLINK-15306][network] Adjust the default netty transport option from nio to auto
     add 6df2e0e  [FLINK-12785][StateBackend] RocksDB savepoint recovery can use a lot of unmanaged memory
     add b59ca9e  [FLINK-15009][table-common] Improve error message for common type mistakes
     add f65c5f2  [FLINK-15009][table-common] Add a utility for creating type inference logic via reflection
     add 9e23814  [hotfix][table-common] Add utility methods to identifiers
     add 21d1c65  [FLINK-15281][table-planner-blink] Map Flink's TypeInference to Calcite's interfaces
     add f7833af  [FLINK-15355][plugins] Fixed parsing of plugin parent-first patterns.
     add 75cded9  [FLINK-15542][legal] Move NOTICE entry for lz4-java
     add 7ec228a  [FLINK-15543][legal] Remove Apache Camel NOTICE entries
     add d9029b4  [FLINK-15319][e2e] Support configurable download retries/timeout
     add 5ea097c  [FLINK-15319][travis] Retry downloads
     add 2339924  [FLINK-15520][prometheus][tests] Use DownloadCache
     add fb12bcf  [FLINK-12004][core] Make Pojo types accept chainable setters
     add f0f9343  [FLINK-15490][kafka][test-stability] Enable idempotence producing in KafkaITCase to avoid intermittent test failure.
     add 4bb4a50  [FLINK-15504] Allow output to stdout/stderr during execution of PackagedProgram
     add 27c29f7  [FLINK-15387][rocksdb][metrics] Expose missing RocksDB properties out via RocksDBNativeMetricOptions
     add 21aff32  [FLINK-15515][hive][doc] Document that Hive connector should be used with blink planner
     add 8fbab0d  [FLINK-15464][hive] Fix HiveTableSourceTest::testPartitionFilterDateTimestamp for 1.x
     add f39ff2b  [FLINK-13465][legal] Update licensing
     add 5c037f2  [FLINK-15523][conf] Revert removal of Public fields
     add 7a6ca9c  [FLINK-15523][conf] Japicmp checks ConfigConstants
     add 346e2e0  [FLINK-15512][state backends] Refactor the mechanism to calculate the cache capacity shared among RocksDB instance(s)
     add 328a428  [FLINK-15485][table-planner] Reopen ignored tests whose related issues have been resolved
     add e155909  [FLINK-15548][table-blink] Use KeyedCoProcessOperator instead of LegacyKeyedCoProcessOperator in blink planner
     add a1a27d0  [FLINK-15522][runtime] JobResult takes ExecutionGraph failure cause as its failure cause only if job is FAILED
     add 1402416  [hotfix][runtime] ExecutionGraph failure cause cannot be null if job is FAILED
     add 0274258  [FLINK-15495][sql-cli] Set default planner to Blink planner for SQL Client (#10787)
     add 2ad4e74  [hotfix][runtime] Fix variable name typos in TaskInformation
     add d76f216  [FLINK-15488][runtime] Obtain JVM and TM params correctly
     add 16eed29  [FLINK-15174][security] Added certificate pinning for SSL mutual auth
     add 69a727d  [FLINK-15174][security] (follow-up) Add a test for exceptions on invalid / malformed fingerprint and refine docs.
     add 97535b3  [FLINK-15529] [docs] Update upgrade compatibility table in operations doc for 1.10.0
     add ff097e0  [FLINK-15292] Rename Executor to PipelineExecutor
     add d82b604  [FLINK-15292] Rename ExecutorFactory to PipelineExecutorFactory
     add 3035a50  [FLINK-15115][kafka] Reduce mocking
     add c8926c1  [FLINK-15115][kafka] Drop Kafka 0.8
     add 6edd673  [FLINK-15115][kafka] Drop Kafka 0.9 SQL jar
     add 96b2f93  [hotfix][kafka][legal] Correct version in NOTICE
     add 0cf5a8d  [FLINK-15115][kafka] Drop Kafka 0.9
     add 6f5f23b  [FLINK-15541] Fix unstable case FlinkKinesisConsumerTest
     add a38d3f7  [FLINK-15565][table-planner-blink] Fix error conversion of TINYINT, SMALLINT literals between Flink and Calcite (#10841)
     add dd05f44  [FLINK-15559][docs] Fix broken links due to missing baseurl (#10844)
     add b2e3967  [FLINK-15567][table][docs] Add documentation for INSERT statements for Flink SQL (#10839)
     add 2abfe43  [hotfix][kubernetes] Remove the unnecessary clean up codes for Kubernetes embedded job
     add cd54369  [hotfix][kubernetes] Use stable api apps/v1 instead of extensions/v1beta1
     add 6cf5940  [FLINK-15354][e2e] Start and stop minikube only in kubernetes related e2e tests
     add 704b7d9  [FLINK-15533] Consolidate parallelism in Environment constructor
     add 6f6fb43  [FLINK-15533] Deprecate text sink facilitation methods in DataStream
     add 8f67d1d  [hotfix] remove isSystemFunction from DropCatalogFunctionOperation as it's never used
     add 9611de4  [FLINK-15576] remove isTemporary property from CatalogFunction API
     add c9f9118  [hotfix][docs] Fix typo in class doc of KafkaTopicPartitionStateWithPunctuatedWatermarks
     add 8d8e708  [FLINK-15431][CEP] Add numLateRecordsDropped metric in CepOperator
     add 4b98956  [FLINK-14091][coordination] Allow updates to connection state when ZKCheckpointIDCounter reconnects to ZK
     add 25b1697  [FLINK-14091][tests] Tests ZooKeeperCheckpointIDCounter can be recoverd from connection loss
     add 7a0fa1e  [FLINK-14091][tests] Refactor ZooKeeperCheckpointIDCounter for a more testable codebase
     add 75ecfae  [hotfix] Fix checkstyle violations in ZooKeeperCheckpointIDCounter
     add 7455a09  [FLINK-14091] Harden ZKCheckpointIDCounterMultiServersTest
     add e1ad65b  [FLINK-15434][tests] Harden JobMasterTest
     add cec75ef  [FLINK-15278] Update the StreamingFileSink docs
     add d7edaaa  [FLINK-15535][doc] Add ProcessFunctionTestHarnesses documentation
     add a9411b7  [FLINK-15554][azure] Bump jetty-util to 3.1.2
     add 4852002  [FLINK-15327][runtime] No warning of InterruptedException during cancel.
     add e17907a  [hotfix][typo] Fix doc typo for the java doc of MultiStateKeyIteratorTest
     add 7513d9b  [FLINK-15517][Runtime][Configuration][Network] Use back 'network' in 'shuffle' memory config option names
     add 6bcb9bf  [FLINK-15589][doc] remove beta tag from catalog and hive doc
     add 2231e1b  [FLINK-15590][doc] add section for current catalog and current database
     add 5984e7e  [FLINK-15307][runtime] Rename Subclasses of FailoverStrategy
     add 948e245  [hotfix][dist][config] Update the comments of TM process memory size in default flink-conf.yaml.
     add 6ec4b56  [FLINK-15145][dist][config] Increase the TM process memory size in default flink-conf.yaml to 1568MB.
     add e3f2cad  [FLINK-15145][core][config] Increase the TM JVM overhead min size default value to 192MB.
     add d5272ec  [FLINK-15145][core][config] Decrease the TM JVM metaspace size default value to 96MB.
     add 4cd4a04  [FLINK-15521][e2e] Follow symbolic link when copying distribution
     add 3619543  [hotfix][tests] Fix typo
     add e6aff96  [FLINK-15152][checkpointing] Restart CheckpointCoordinator if StopWithSavepoint failed (#10824)
     add 9a58ded  [FLINK-14843][e2e] Harden bucketing sink e2e test
     add 26c9082  [FLINK-15220][Table][Kafka] Add startup timestamp in KafkaTableSource
     add 4717c51  [FLINK-15220][Table,Kafka,Python] Add startup timestamp in KafkaTableSource in python API
     add fa1ea5c  [FLINK-14853][core] Implemented Duration formatting
     add dff4837  [FLINK-14853][core] Implemented MemorySize formatting
     add ffa233a  [FLINK-14853][docs] Updated documentation generator to print MemorySize and Duration in a nicer way
     add 1bec3d2  [hotfix][coordination][configuration] Fix docs: container cutoff options are only used for JM after FLIP-49
     add 8712667  [FLINK-15489][web] Avoid caching of JM and TM logs in the web ui
     add f2b6da5   [FLINK-15355][plugins]Classloader restricted to whitelisted system classes.
     add 9b023c2  [hotfix][plugins]Hide classloader pattern options from documentation.
     add fff0952  [FLINK-13595][connector/kafka][test] Close the KafkaAdminClient with a timeout. Print stacktrace if a long closure happens.
     add 46a5748  [FLINK-15558][Connector] Bump Elasticsearch version from 7.3.2 to 7.5.1 for es7 connector
     add e32a016  [FLINK-15597][runtime] Compromise JVM Overhead fraction to Total Flink / Process Memory sizes, wrt JVM Overhead min/max.
     add 1385b79  [hotfix][javadoc] Add a missing param doc for JobExecutionException
     add eeabc86  [hotfix][e2e] Compile walkthroughs for e2e tests
     add bf32fca  [FLINK-15583][walkthrough] Use -nobootcp in maven-scala-plugin
     add 9ac44ba  [FLINK-15583][e2e] Add walkthroughs e2e tests to misc split
     add 56cff88  [hotfix][e2e] Force local archetype catalog
     add 788a943  [FLINK-15605][State][TTL] Remove deprecated in 1.9 StateTtlConfig.TimeCharacteristic
     add f2848fd  [FLINK-15606][State][TTL] Deprecate enable default background cleanup of state with TTL
     add 4a66f10  [FLINK-15506][State][TTL] Enable State TTL Compaction Filter by default and deprecate the option
     add 838120d  [hotfix] Add space after period in TTL_COMPACT_FILTER_ENABLED description
     add e3acccd  [FLINK-15564][yarn][test] Fix that YarnClusterDescriptorTest#testFailIfTaskSlotsHigherThanMaxVcores and #testConfigOverwrite not validating the original intended behaviors.
     add 1db3b55  [FLINK-15564][yarn] Factor max vcores retrieval out of YarnClusterDescriptor
     add 85ff2fe  [hotfix][yarn] Remove yarn app master env keys that are not used.
     add 6d6053a  [hotfix][yarn][client] Remove invalid numberTaskManagers from ClusterSpecification.
     add 7acc0e6  [FLINK-15598][yarn] Remove unnecessary cluster specification validation in YarnClusterDescriptor#deployInternal.
     add 12f7873  [FLINK-15598][yarn] Do not overwrite configuration with cluster specification in YarnClusterDescriptor#startAppMaster.
     add 9575b91  [FLINK-15623][build][python] Exclude code style check of generation code in PyFlink.
     add 9b5232d  [hotfix][javadocs] Correct add() return type
     add 8d74bff  [FLINK-15615][docs] Fix reported file sink consistency guarantees
     add d3781d2  [hotfix][build] Remove unused depMgmt entry
     add 6fa1ea1  [FLINK-14163][runtime] Enforce synchronous registration of produced partitions
     add 5420f29  [FLINK-14703][e2e] Port the Kafka SQL related tests.
     add 4c63ec4  [FLINK-15616][python] Move boot error messages from python-udf-boot.log to taskmanager's log file
     add 1ffa299  [FLINK-15638][release][python] Change version of pyflink to the release version when creating release branch
     add ab6b359  [hotfix][conf][tests] Introduce factory method
     add 7be292c  [FLINK-15458][conf][tests] Separate options discovery and well-definedness check
     add 6825dbd  [FLINK-15458][conf][docs] Introduce SuffixOption annotation
     add eeee9b9  [FLINK-14831][metrics][docs] Generate InfluxDB config docs
     add 7ccc5b3  [FLINK-15479][jdbc] Override explainSource method for JDBCTableSource to fix project pushdown (#10769)
     add ee3101a  [FLINK-15650][python][doc] Improve the udfs documentation of the Python API
     add ac5e288  [FLINK-15537][table-planner-blink] Fix code generation to use BinaryRow instead of GenericRow for distinct keys
     add 48547ba  [FLINK-15630][python][doc] Improve the environment requirement documentation of the Python API. (#10884)
     add 2ef9f47  [FLINK-15657][python][doc] Fix the python table api doc link
     add 24471855 [FLINK-15577][table-planner] Add Window specs to WindowAggregate nodes' digests
     add fdc1014  [FLINK-15577][table-planner-blink] Add different windows tests to blink planner
     add ad96288  [FLINK-15575] [filesystems] fix shading of azure filesystem
     add 360afd9  [FLINK-15675][python][docs] Add exception and documentation that Python UDF is not supported in old Planner under batch mode
     add fd2b8e5  [FLINK-15599][table] SQL client requires both legacy and blink planner to be on the classpath
     add bf09457  [FLINK-15497][table-planner-blink] Reduce outputs when rank number is not required in Retractable TopN (#10823)
     add a22b9d8  [FLINK-15631][table-planner-blink] Fix equals code generation for RAW and TIMESTAMP type
     add a02facb  [FLINK-15637][state backends] Make RocksDB the default store for timers when using RocksDBStateBackend
     add 9eda8c3  [FLINK-15700][python][doc] Improves the Python API Tutorial doc
     add 43a9c44  [FLINK-15700][python][doc] Improves the Python API Tutorial doc
     add e1c9ede  [hotfix] Introduce builder for checkpoint coordinator to deduplicate test codes
     add 9fd0590  [hotfix] Normalize variable name of CheckpointCoordinatorTriggeringTest
     add 7d4b19f  [FLINK-13905][checkpointing] Unify all error handlings of checkpoint failure
     add ee6869a  [FLINK-13905][checkpointing] Redefine the behavior if there are too many pending checkpoints
     add 90e2c2e  [hotfix] Fix broken test utils caused by FLINK-12039
     add 8b5ea9d  [hotfix] Introduce helper method FutureUtils#getWithoutException
     add 0352fa5  [FLINK-13905][checkpointing] Separate checkpoint triggering into several asynchronous stages.
     add 4a31751  [FLINK-15549] Fix Integer overflow in ResettableIterator. (#10903)
     add 1662d5d  [FLINK-15278][docs-zh] Update Chinese version StreamingFileSink doc
     add 86ebb10  [hotfix][tests] Remove legany codes from CheckpointBarrierAlignerTestBase
     add 9f92ddf  [FLINK-15444][runtime] Make the component AbstractInvokable in CheckpointBarrierHandler NonNull
     add 7f2178d  [FLINK-15355][plugins] PluginLoader allows access to JDK9 modules.
     add 9af5056  [FLINK-15355][s3]Plugins now use multi-release mechanism to ship jaxb for Java 9+.
     add c4c2169  [FLINK-15601] Remove unused constant field NUM_STOP_CALL_TRIES in Execution (#10906)
     add 8d85f85  [FLINK-15686][sql-client] Use old type system in CollectStreamTableSink
     add 156cb47  [hotfix] Clean up in TaskExecutorResourceUtilsTest.
     add 441615b  [FLINK-15375][core] Introduce MemorySize#toHumanReadableString.
     add 173f2f8  [FLINK-15375][core][runtime] Print MemorySize with human readable string in logs and error messages.
     add 4f55895  [FLINK-15375][core] Add factory method for creating MemorySize from mebibytes.
     add 8bb83c7  [FLINK-13758][client] Support to register DFS files as distributed cache
     add 9b72299  [hotfix][kubernetes] Only check the expected env vars in Fabric8ClientTest#testCreateFlinkMasterDeployment
     add 003ceb9  [FLINK-15632][kubernetes] Make Flink client always uses Kubernetes service to contact with jobmanager via rest client
     add be4b713  [FLINK-15632][kubernetes] Set JobManagerOptions#ADDRESS to the pod ip address when HA mode enabled
     add cd9836c  [FLINK-15632][kubernetes] Update the cluster id and high-availability jobmanager port when HA enabled
     add 4df4840  [FLINK-15612][table] Refactor DataTypeLookup to DataTypeFactory
     add c16121f  [FLINK-15612][table] Integrate data type factory into catalog manager
     add 11007c0  [FLINK-15612][table-planner-blink] Propagate the data type factory in the planner
     add 9aa24d8  [FLINK-15636][python] Support Python UDF in old planner under batch mode
     add fcd0055  [FLINK-15519][configuration]Preserve logs from BashJavaUtils and make them part of TM logs
     add ddb11ca  [FLINK-15684][docs] Add taskmanager.memory.flink.size to common options
     add 0de3485  [FLINK-15684][docs] Regenerate documentation
     add 349492e  [FLINK-15726] [Blink Planner] [hotfix] Fix error message in StreamExecTableSourceScan & BatchExecTableSourceScan
     add fbc1ef7  [FLINK-15150][tests] Prevent job from reaching terminal state
     add 1b6a074  [hotfix][zookeeper] Log changes to SchedulingState
     add e1660b4  [hotfix] Correct logging statement in TaskExecutorResourceUtils
     add c4b059a  [minor] Remove outdated mention of getPlan() from CliFrontendParser
     add 3a3dad4  [FLINK-15276] Update executor CLI name and help message
     add aa43ff6  [FLINK-15276] Regenerate bin/flink output in docs/ops/cli.md
     add d9532e3  [FLINK-15276] Add method for listing executors to PipelineExecutorServiceLoader
     add 6e63632  [FLINK-15276] List available executors in ExecutorCLI
     add 897e667  [FLINK-15276] Add introduction text about executors in cli.md
     add 5fcf9f6  [FLINK-15276] Bring cli.zh.md in line with recent changes to cli.md
     add 4a9a0a0  [FLINK-15690][core] In environments, call configure() in constructors with passed Configuration
     add dbd0ea0  [FLINK-15690][docs] Updated CACHED_FILES doc
     add b2fda00  [FLINK-15689][table] Configure ExecutionEnvironment from BatchTableEnvironment
     add 338ae70  [FLINK-15552][table] Use thread context classloader to find factories in TableFactoryService
     add 2e62ae7  [FLINK-15487][table-common] Make TypeInference mandatory for function definitions
     add e6ff565  [FLINK-15692][state] Enable limiting RocksDB memory consumption by default
     add c191ecb  [hotfix] Fix checkstyle violation in TestingResourceManagerGateway
     add 8b485eb  [FLINK-14742][test] Harden TaskExecutorTest#testSubmitTaskBeforeAcceptSlot
     add 84e76b0  [FLINK-15602][table-planner-blink] Padding zeros for TIMESTAMP type to respect the precision when casting timestamp to varchar
     add 6128028  [FLINK-15368][e2e] Add end-to-end test for controlling RocksDB memory usage
     add 7a8ac1c  [FLINK-15368][e2e] (follow-up) Minor improvements to the RocksDB Memory Control e2e test
     add 3850577  [hotfix][tests] Setup closable resources in BeforeClass
     add f7a7d89  [FLINK-15691][tests] Remove runInTaskExecutorThreadAndWait()
     add 32b7a9d  [FLINK-15592][hive] Add black list for Hive built-in functions
     add 120eb14  [FLINK-15603][metrics] Add checkpointStartDelayNanos metric
     add a6c7e6a  [FLINK-15275] Deprecate ineffectual sysoutLogging CLI option
     add bd5901f  [FLINK-14701][runtime] Fix MultiTaskSlot to not remove slots which are not its children
     add 05bddfb  [FLINK-15741][docs][TTL] Fix TTL docs after enabling RocksDB compaction filter by default
     add c5b49d9  [hotfix] Remove 'null if not allocated' from TaskSlot comments
     add 2f9769d  [hotfix] Segregate TaskSlotPayload interface from Task for TaskSlot and TaskSlotTable
     add e68c6c5  [FLINK-15247][Runtime] Wait for all slots to be free before task executor services shutdown upon stopping
     add 07a3b56  [FLINK-15751][tests] Ignore exceptions in RocksDB Memory Limiting e2e test
     add 90f638c  [hotfix] Align the parameter pattern of retry_times with retry_times_with_backoff_and_cleanup
     add 6dcaae0  [FLINK-14894][core][mem] Do not explicitly release unsafe memory when managed segment is freed
     add e7e2447  [FLINK-15754][docs] Remove config options table.exec.resource.*memory from docs
     add 53f956f  [FLINK-10819] Replace with the Flink's Deadline implementation
     add 391dd4c  [FLINK-15739] Fix TypeSerializerUpgradeTestBase on Java 12
     add 7c6ecc4  [FLINK-15751][task] Let all exceptions propagate from the StreamTask#runMailboxLoop
     add f54c3f1  [hotfix][minicl] Set default managed memory to 128mb for mini cluster
     add 8ee2260  [hotfix] Rename TaskExecutorResourceSpec to TaskExecutorProcessSpec
     add 03c7274  [FLINK-15763][Runtime] Running TM checks only necessary resource cofig, set to default for local execution
     add b90d1a2  [hotfix] Fix checkstyle violations in TaskExecutorResourceUtilsTest
     add 676b53f  Revert "[FLINK-14894][core][mem] Do not explicitly release unsafe memory when managed segment is freed"
     add d8ff590  [FLINK-15701][Travis] Retries when uploading to transfer.sh fails
     add 8e99240  [FLINK-15681] Remove legacy ExecutionAndAllocationFuture class
     add 95af634  [FLINK-15617] Remove useless JobRetrievalException
     add a5bc859  [FLINK-15274][docs]Added separate plugin page.
     add 83e78db  [hotfix][web] Rename Checkpoint metric fields
     add 8128a88  [hotfix][rest] Introduce MinMaxAvgStatistics.valueOf helper method
     add 06a1624  [hotfix][rest] Remove redundant comments in TaskStateStats
     add f87879c  [hotfix][rest] Remove redundant comments in SubtaskStateStats
     add 4615602  [FLINK-15603][web] Expose checkpointStartDelayNanos metric in the WebUI
     add e7bfa88  [hotfix][tests] Make JarHandlers re-usable
     add 23ff230  [FLINK-15651][tests] Refactor JarHandlerTest
     add fcd2834  [FLINK-15768] Consolidate executor-related classes in flink-client
     add 4aae548  [FLINK-15628][rest] Create webSumissionHandlers List with default capacity
     add 236710c  [hotfix][javadocs] Fix OutputTag example
     add 5619307  [hotfix][runtime] Add missing space to exception message
     add 631722d  [FLINK-15743][docs] Add release notes for Flink 1.10
     add fe284c8  [FLINK-15487][table] Allow registering FLIP-65 functions in TableEnvironment
     add 8699e03  [FLINK-15738][build] Bump powermock to 2.0.4
     add 7e1a0f4  [FLINK-9272][metrics][datadog] Rename counter type to count
     add e8f4f67  [FLINK-15623][checkstyle] Exclude target directory
     add f89a4e6  [hotfix][checkstyle] Remove outdated checkstyle suppressions
     add 79f2f04  [FLINK-13689] [Connectors/ElasticSearch] Fix thread leak in Elasticsearch connector when cluster is down
     add d8164e1  [FLINK-15627][cep] Correct the wrong naming of compareMaps in NFATestUtilities
     add e6eea61  [FLINK-15810] Add more description for FlinkKafkaProducerMigrationOperatorTest
     add 36a0e4c  [FLINK-15837] Add proper NOTICE file to flink-kubernetes
     add 183c8d1  [FLINK-15840][table-planner-blink] Fix ClassCastException when use tEnv.from for temp/catalog table (#10989)
     add 8687f55  [hotfix][k8s] Correct relocation patterns in flink-kubernetes
     add 62ea66f  [FLINK-15806][yarn] Log recommended way how to stop a detached Yarn session cluster
     add d6fa9c6  [FLINK-15806][doc] Update yarn documentation to include proper way of stopping a detached Yarn session
     add aff098b  [FLINK-15797][k8s] Reduce log noise of Fabric8FlinkKubeClient
     add bab25ae  [FLINK-15789][kubernetes] Do not wrap the InterruptedException and throw a different one in ActionWatcher.await
     add 9ec3e1c  [FLINK-15694][docs] Remove HDFS Section of Configuration Page
     add afd88a3  [FLINK-15697][docs] Move python options from general configuration page to table config options page
     add 4c21029  [FLINK-15824][docs] Generalize CommonOption
     add 2ce0409  [hotfix][docs] Clean up deprecation/unused warnings in tests for ConfigOptionsDocGenerator
     add c8ade87  [FLINK-15824][docs] (follow-up) Simple improvements/cleanups on @SectionOption
     add afb11a9a [FLINK-15698][docs] Restructure the Configuration docs
     add d6a7b01  [FLINK-15695][docs] Remove outdated background sections from configuration docs
     add 45f534d  [FLINK-14495][docs] Add documentation for memory control of RocksDB state backend
     add 9afcf31  [FLINK-14495][docs] Reorganize sections of RocksDB documentation
     add 436cd39  [FLINK-14495][docs] Synchronize the Chinese document for state backend with the English version
     add 5036334  [FLINK-15010][network] Add shut down hook to ensure cleanup netty shuffle directories
     add 4ed552c  [hotfix][python] Remove unused variable from class AbstractPythonFunctionRunner
     add 5281212  [FLINK-15494][table-planner-blink] Fix incorrect time field index in LogicalWindowAggregateRuleBase
     add de7440e  [FLINK-15658][table-planner-blink] Fix duplicate field names exception when join on the same key multiple times (#11011)
     add 3d51e6c3d [hotfix] [javadoc] RocksFullSnapshotStrategy remark DESCRIPTION correctly
     add eea3d6f  [FLINK-15864][k8s] Upgrade jackson-databind dependency to 2.10.1
     add 2ae305c  [FLINK-15807][docs] Add Java 11 to supported JDKs
     add d2de15c  [FLINK-15614][docs] Consolidate Hadoop documentation
     add 712207a  [hotfix][docs] Fix missing double quotes in catalog docs
     add 4fcd877  [FLINK-15858][hive] Store generic table schema as properties
     add e0afec8  [FLINK-15706][table-planner-blink] Fix LastValueAggFunctionWithOrderTest compilation error due to incompatible types
     add b3c86a8  [FLINK-15706][table-planner-blink] Reorder and split into sections classes in aggfunctions tests.
     add 0905647  [FLINK-15872][javadoc] Remove unnessary javadocs in InputFormat
     add 73017a8  [FLINK-15335] Replace `add-dependencies-for-IDEA` profile
     add 2b2d6ac  [hotfix][table-common] Fix invalid BYTES data type extraction
     add 035092b  [hotfix][table] Fix various type inference issues
     add 75248b4  [hotfix][table-common] Add 'use argument' type strategy
     add 5e6e851  [FLINK-15487][table] Update code generation for new type inference
     add 7ef6eb4  [FLINK-15863][docs] Fix docs stating that savepoints are relocatable
     add 939889a  [FLINK-15905][runtime] Fix race condition between allocation and release of OpaqueMemoryResource
     add c3a85f7  [FLINK-15916][docs] Remove outdated sections for Asnc Snapshots and Network buffers from Tuning Checkpoints and Large State
     add e51ad13  [FLINK-15868][kinesis] Resolve version conflict between jackson-core and jackson-dataformat-cbor
     add 264ccf6  [FLINK-15868] Pin jackson-dataformat-smile dependency to 2.10.1
     add 3a7edb3  [FLINK-15868] Pin jackson-dataformat-yaml dependency to 2.10.1
     add af30427  [hotfix][es][tests] Remove unused variable
     add ff25837  [hotfix][es][tests] Refactor utils
     add 02c9c09  [FLINK-15868][es] Add tests for different formats
     add 652e979  [FLINK-15868] Bump flink-table-planner jackson dependencies to 2.10.1
     add cf126ff  [FLINK-15868] Pin snakeyaml dependency in flink-connector-elasticsearch5 to 1.25
     add c463358  [FLINK-15921] [python] Add version range of grpcio. (#11024)
     add 34db538  [FLINK-11373] Don't cut of error message in CliFrontend
     add 7d06b11  [FLINK-15811][task] report CancelTaskException on SourceStreamTask cancellation
     add f6f5370  [hotfix][docs] Improve description of 'high-availability.jobmanager.port' config option.
     add d8f0418  [hotfix][runtime] Clean up minor issues in TaskInformation
     add 5727e88  [FLINK-15920][build] Show thread names in logs by default
     add e12512f  [hotfix][runtime] Small improvements in log messages for Task and RocksDB Backend
     add 0817a61  [hotfix][build] Move jaxb copy into execution
     add 031256e  [hotfix][tests] Add "javax.management.*" to PowerMock ignore list
     add 321a317  [hotfix][build] Add depMgmt entry for flink-shaded-hadoop
     add 1a1bcda  [hotfix][build][sql] Remove slf4j/log4j dependencies
     add 7a5373d  [hotfix][build] Remove unnecessary log4j files
     add 06169c7  [FLINK-15181][docs] Fix minor typos and mistakes in table documentation
     add 3808858  [FLINK-15929][python] Update the version limit of grpcio to 1.26.0
     add 0acd349  [FLINK-15937][python] Update the Development Status to 5 - Production/Stable (#11028)
     add 081c4da  [hotfix][travis] Remove outdated activation properties
     add 2b28169  [FLINK-15785][travis][e2e] Rework E2E test activations
     add d2ea1fc  [FLINK-15685][e2e] Kafka SQL test requires Hadoop
     add c0268ea  [hotfix][documentation] Fix wrong time semantics description
     add 5c1d7e4  [FLINK-15897][python] Defer the deserialization of the Python UDF execution results
     add d3f53dd  [FLINK-15919][core][mem] MemoryManager shouldn't allow releasing more memory than reserved
     add 8929577  [hotfix][build][e2e] Invert Java 11 activation condition
     add ac24cee  [hotfix][build][e2e] Remove empty include/exclude property
     add c90fc7b  [hotfix][build][e2e][addendum] Remove empty include/exclude property
     add 3da0748  [hotfix][e2e] Add retry timeout to kafka broker startup
     add deeeee7  [hotfix][build system] Improve logging in maven setup script
     add 369ab8c  [hotfix][travis] Improve Maven dependency download stability
     add 45e0b12  [hotfix][travis] Use echo instead of printf
     add 14603b7  [hotfix][table] Convert FlinkCalciteSqlValidator to Java
     add 4c2857b  [hotfix][table] Simplify FlinkCalciteSqlValidator
     add 3ebfb32  [FLINK-15618][runtime] Remove unused JobTimeoutException
     add aa38468  [FLINK-15935][table] Fix watermark can't work when depending both on flink planner and blink planner in project
     add f08ac8b  [FLINK-15935][example] Add Streaming Window SQL example
     add 8a95253  [FLINK-14270][web] Support to display more metrics at once (#10689)
     add 9911e52  [hotfix][travis] Fix caching of misc job
     add c858d86  [FLINK-15902][python][docs] Improve the Python API documentation adding the version an API was introduced
     add 19689cb  [hotfix][example] Add StreamWindowSQLExample.jar to dist (#11036)
     add 43b4289  [FLINK-15942] Do not log huge/infinite cpu/memory resources in profiles
     add 3b59aca  [hotfix] Let ResourceProfileTest extend TestLogger
     add 89b095f  [FLINK-15942][tests] Simplify ResourceProfileTest tests
     add 274416f  [hotfix][docs]  Fix some typos in state_processor_api docs (#11033)
     add eb00ada  [hotfix][travis] Add missing jdk11 classifier
     add 303b08a  [hotfix][travis] Reduce depth for walkthrough module detection
     add fee187e  [FLINK-15913][python] Add Python TableFunction Runner and Operator in old planner (#11020)
     add c8bdb67  [hotfix][docs] Fix Readme Description for the State Machine Example (#11046)
     add 0b85496  [hotfix][e2e] Reduce e2e-hadoop to exclusion
     add ceefbe7  [FLINK-15417][e2e] Change the access permission of files modified in mesos constainer
     add 6bf9cf2  [FLINK-15741][docs-zh][TTL] Fix TTL docs after enabling RocksDB compaction filter by default
     add 3f5a8c7  [hotfix][runtime,test] refactor ContinuousFileProcessingRescalingTest to prepare for ContinuousFileReaderOperator migration to Mailbox Execution model
     add 2e96ee7  [FLINK-13955][runtime] use mailbox execution model in ContinuousFileReaderOperator.
     add 5f38f91  [hotfix] Remove deadcode in ExecutionGraph#restart
     add aaba4e8  Revert "[hotfix] Remove deadcode in ExecutionGraph#restart"
     add edfbbb7  [hotfix][example] Copy StreamWindowSQLExample.jar to dist/examples/table
     add ba0e2e0  [FLINK-15917][runtime] Fix that the root exception is not shown in Web UI
     add b902ed5  [FLINK-15918][runtime] Fix that 'uptime' metric is not reset after restart
     add 01a9ff9  [FLINK-15143][docs] Add new memory configuration guide for FLIP-49
     add d4aa8fa  [FLINK-15143][docs] Add tuning and troubleshooting guides for memory configuration
     add 0cb8834  [FLINK-15143][docs] Add migration guide from pre-FLIP-49 memory config
     add ef364bb  [FLINK-15875][python] Bump Beam to 2.19.0
     add d1bc10f  [FLINK-15875][python] Remove the ProcessManager which is copied from Beam 2.19
     add 5614f21  [FLINK-15546][table-planner-blink] Fix obscure error message from ScalarOperatorGens::generateCast (#11021)
     add 3766daa  [FLINK-15933][catalog][doc] Update content of how generic table schema is stored in hive via HiveCatalog
     add 57c3396  [FLINK-15561] Unify Kerberos credentials checking
     add 2558c9e  [hotfix][task] Fix the comment typo in TwoInputStreamTask class
     add 2a0555b  [FLINK-15914][checkpointing][metrics] Miss the checkpoint related metrics for the case of two inputs
     add 3ac3728  [FLINK-12484][runtime] remove checkpoint lock *usage* from production code After b4aa6e lock is acquired for every mailbox action if needed.
     add 3e467fd  [FLINK-12484][runtime] remove checkpoint lock tests After a3b6be905f lock is not managed by operators so the test aren't relevant anymore.
     add 6a160d7  [FLINK-12484][runtime] push checkpoint lock from StreamTask to SourceStream
     add e591947  [FLINK-15914][tests] Fix the fragile tests caused by race condition of multiple threads
     add f001021  [FLINK-15743][docs] Extend Flink 1.10 release notes
     add a0a4758  [FLINK-15862][kafka] Remove deprecated KafkaPartitioner
     add 407b5bc  [FLINK-15646][kubernetes] Make kubernetes context configurable
     add 82731bbb [FLINK-15995][table-planner-blink] Change TO_BASE64 operand type checker from ANY to STRING
     add 3cbee0a  [FLINK-15941] [format-avro] Create schema coder only once in RegistryAvroSerializationSchema
     add aedbdc3  [FLINK-15994][table-planner-blink]Support byte array argument for FROM_BASE64 function (#11060)
     add 4ad2c5f  [FLINK-15445][jdbc] Support new type system and check unsupported data types for JDBC table source
     add 0398c30  [FLINK-15990][table][python] Remove register source and sink in ConnectTableDescriptor
     add c615864  [FLINK-15992][kafka][es] Use thread context classloader when finding TableFormatFactory (#11064)
     add 51f4954  [hotfix][docs] Add 1.10 to list of previous docs
     add cb69037  [hotfix][build] Add safeguards against rebranded jaxb-api/javax.activation-api dependencies
     add 73b7232  [FLINK-15949][build] Harden jackson dependency constraints
     add 7a6ec30  [hotfix][javadocs] Add missing asterisk
     add c40b0b2  [FLINK-16026][python] Limit the version of avro-python3
     add 6278fa8  [FLINK-15970][python] Optimize the Python UDF execution to only serialize the value (#11059)
     add f4f6f8d  [FLINK-15982][e2e] Pick the right Flink version to fix the java quickstart test
     add a984b6a  [hotfix][build] Downgrade groovy to 2.5.8
     add eea7db6  [FLINK-16004][build] Use correct parent
     add 114f2b4  [hotfix][docs] show usage if wrong option is given
     add cf27ba2  [FLINK-13793][docs] build each language in a separate subprocess
     add fcb443a  [hotfix][docs] do not include build scripts in content generation
     add 3c7eeed  [FLINK-15993] Move 404 "refresh" redirect into noscript block, add timeout
     add 01094b0  [FLINK-15997] Make documentation 404 page look like a documentation page
     add def0000  [minor][docs] Fix missing "page" text in redirect.html layout
     add 3e6ded1  [FLINK-16037][build] Bump dependency-analyzer to 1.11.1
     add 2afd7e3  [hotfix][build] Remove unused flink-test-utils dependencies
     add 818953a  [hotfix][build] Remove redundant flink-test-utils-junit version/scope
     add 58a8846  [FLINK-15802][table] Bring input/output types of table functions closer
     add 7a490d8  [FLINK-15802][table] Support new type inference for table functions
     add 244d2db  [hotfix][web][build] Cleanup dependencies
     add 06c645e6 [FLINK-15402][csv, table] Expose disable quote character option to CSV format
     add d6a8e8e  [hotfix][runtime][tests] Use javax annotation
     add de443da  [hotfix][core][tests] Mark SerializerTestInstance with @Ignore
     add dd34b05  [hotfix][build] Remove unused shaded-asm7 dependencies
     add fe71457  [hotfix][build] Remove unused akka-testkit dependencies
     add 3cc8e1a  [FLINK-16040][python] Change local import to global import (#11084)
     add d36d97c  [FLINK-15913][python] Add Python TableFunction Runner and Operator in Blink planner
     add 0dc4e76  [hotfix][docs] Add note SSL not enabled by default
     add a44cf4d  [hotfix][tests] Add a TestingSchedulerFactory to help instantiating the scheduler in tests
     add 41b6bfa  [FLINK-15099][runtime] Add Operator Coordinators and Events
     add 74828e7  [FLINK-16046][es] Drop Elasticsearch 2 connector
     add 881a3ca  [FLINK-16053][python] Remove redundant metrics in PyFlink (#11089)
     add 5988281  [FLINK-16059][rest][docs] Order properties alphabetically
     add fc59aa4  [FLINK-16065][core] Unignore FileUtilsTest.testDeleteDirectoryConcurrently()
     add 30b5f61  [hotfix][tests] Adjust FileUtilsTest.testDeleteSymbolicLinkDirectory() to handle unsupported situations in Windows
     add 736ebc0  [hotfix][build] Remove various unused test dependencies
     add 63e9e9d  [FLINK-14802][orc][hive] Multi vectorized read version support for hive orc read
     add 3c696a3  [hotfix][docs][conf] Add query service port to port section
     add 3259270  [hotfix][docs][conf] Add query service port to port section
     add a589467  [hotfix][docs][conf] Setup logging for generator
     add 47a1725  [hotfix][docs][conf] Log included packages / excluded classes
     add 85b34eb  [docs-sync] Synchronize the latest documentation changes into Chinese documents
     add 946d25e  [FLINK-15702][sql-client] Respect CLASSLOADER_RESOLVE_ORDER in sql-client
     add 539ba87  [hotfix][build system] broader search for YARN logs
     add cda368d  [hotfix][e2e] harden elasticsearch test
     add c8756da  [hotfix][e2e] Fix docker invocation in mesos tests
     add 0a24c89  [hotfix] Harden kubernetes test
     add 84fd23d  [FLINK-13978][build system] Add experimental support for building on Azure Pipelines
     add 8887290  [hotfix][docs] Regenerate documentation
     add 85794f7  [FLINK-16109][python] Move the Python scalar operators and table operators to separate package
     add aad2637  [FLINK-16049] Remove outdated "Best Practices" section from Application Development Section
     add 429b596  [FLINK-15708] Add MigrationVersion.v1_10
     add 9bc6f69  [FLINK-16071][python] Introduce FlattenRowCoder to solve the performance issue of __get_item__ in Row
     add 22899a1  [FLINK-16113][table-planner-blink] ExpressionReducer shouldn't escape the reduced string value (#11108)
     add e099310  [FLINK-16118][table-planner-blink] Ignore order for FunctionITCase.testDynamicTableFunction
     add 0064949  [FLINK-16068][table-planner-blink] Fix DDL fails when both computed column and keyword-escaped column exist (#11101)
     add b43701f  [FLINK-15988][json] Make JsonRowSerializationSchema's constructor private (#11080)
     add dddda69  [FLINK-10918][state backends] Change o.a.f.core.fs.Path to java.nio.file.Path in RocksDB incremental checkpoints
     add bd1a838  [hotfix][core] Fix broken JavaDoc link in FileUtils
     add 2da3bc3  [hotfix][runtime] Small docs/comments cleanups in RPC code.
     add 2746e6a  [FLINK-15966][runtime] Capture callstacks for RPC ask() calls to improve exceptions.
     add 5b71c7f  [hotfix][config] Adjust AkkaOptions to new type-safe pattern
     add 82b709f  [FLINK-16057][runtime] chain ContinuousFileReaderOperator by default (HEAD)
     add 91fcd83  [FLINK-15961][table-planner][table-planner-blink] Add physical Python Correlate rules and RelNodes
     add d3cb7ed  [FLINK-16056][runtime][tests] do fail ContinuousFileProcessingITCase on failure
     add 468f90f  [FLINK-16056][runtime][tests] create ContinuousFileReaderOperator using factory only Also drop test constructor and make the class package-private.
     add bc0466b  [FLINK-16056][docs] update StreamExecutionEnvironment javadoc
     add 77fe6b4  [FLINK-16136][yarn][tests] Increase disk space limit for all YARN tests
     add e3da52f  [FLINK-14086][core] Add OperatingArchitecture Enum
     add 4a361e1  [FLINK-14086][core] (follow-up) Clean-up / unify processor and memory architecture enums
     add e3d5820  [FLINK-15473][core] Add ppc64le to the list of known processor architectures.
     add b6ec10f  [FLINK-16055][hive] Avoid catalog functions when listing Hive built-in functions
     add b38a702  [FLINK-15744] Log erroneous Task state changes at warn level
     add abf8010  [FLINK-15835][build][oss] Exclude hadoop-common
     add c4db705  [hotfix][docs] Minor improvements of glossary.
     add 296a8af  [FLINK-14533][flink-table-planner] Fix LOWER/UPPER not being pushed down to TableSource (#10005)
     add d4bcd28  [FLINK-16135][core] Unify the TemporaryClassLoaderContext and AutoContextClassLoader
     add de2e82a  [FLINK-15866] Make ClosureCleaner "work" for classes that have no super class or interfaces
     add 57215c4  [FLINK-16162][build] Bump flink-shaded to 10.0
     add 80f40cf  [FLINK-16033][table-api] Construct expressions through factory methods (#11141)
     add 7cfd898  [FLINK-16164][build] Disable maven-site-plugin
     add 20fa7ed  [FLINK-7727] [REST] Improve error logging in StaticFileServerHandlers
     add b2ad74b  [hotfix][table-common] Remove deprecated DataTypes.ANY(...)
     add ff3aabf  [FLINK-16169][tests] Harden BlobServerRangeTest
     add 7c68a0b  [hotfix][table-api] Fixed ExpressionResolver rules modifiers.
     add cb841fa  [FLINK-16072][python] Optimize the performance of the write/read null mask of FlattenRowCoder
     add fae420e  [FLINK-15833] Fix 'Kerberized YARN on Docker' e2e test on Azure Pipelines
     add 9d91aac  [FLINK-12343][yarn] Add YARN file replication option
     add 110b99d  [hotfix] Refactor YARNFileReplicationITCase to avoid inheritance
     add 7a9580e  [FLINK-15904][connectors/kafka] Use explicit Serializer for KafkaConsumer unionOffsetStates
     add e590316  [FLINK-16000] Move "Project Build Setup" to "Getting Started" in documentation
     add c9ac11e  [FLINK-16000] Add "where to go" to getting-started overview section
     add f75575c  [FLINK-16000] Remove icons from getting-started subsections
     add 964d698  [FLINK-16041] Expand "popular" documentation sections by default
     add 333e374  [FLINK-16182][table-api] Remove check against null types as a result of an input type inference when deriving output type based on surrounding info.
     add e3cbe8b  [FLINK-16191][state backends] Improve error message on Windows when RocksDB is give a too long path.
     add 90dd45b  [hotfix][runtime] Fix checkstyle in org.apache.flink.runtime.checkpoint (main scope)
     add 55272b3  [hotfix][DataStream API] Minor JavaDoc / deprecation cleanup in CheckpointedFunction
     add 8c01397  [FLINK-16139][runtime] Reset colocation constraints when restarting tasks in DefaultScheduler
     add 294a219  [FLINK-15652][kubernetes] Support for imagePullSecrets K8s option
     add 7bc7930  [FLINK-15652][kubernetes] Change imagePullSecrets option to list ConfigOption
     add 0f71ab3  [FLINK-16019][runtime] fix ContinuousFileReaderOperator error handling
     add dddbc2b  [FLINK-16019][runtime][test] Implement test coverage for FLINK-16019 bug
     add 40857d9  [FLINK-11589] Support security module and context discovery via ServiceLoader.
     add 3430d54  [FLINK-11589] Add tests for SecurityContext fallback behaviour
     add 9c9916e  [FLINK-11589] Regenerate security configuration docs
     add fa22ed2  [FLINK-14231][task] Add the quiesce() method to ProcessingTimeService and remove TimerService::awaitPendingAfterQuiesce method
     add ab642cb  [FLINK-14231][runtime] Introduce and use ProcessingTimeServiceAware to pass ProcessingTimeService to operator
     add 56ce696  [FLINK-14231][task] Add StreamOperatorWrapper that handles the close, endInput and other related logic of an operator
     add 5fce538  [FLINK-14231][task] Change StreamTask to close operators with StreamOperatorWrapper to make the endInput semantics on the chain strict
     add fd1ee49  [hotfix][test] Clean up the codes in StreamTaskTestHarness, StreamTaskTimerTest and TestProcessingTimeServiceTest
     add aacf079  [hotfix] Revert "[FLINK-15992][kafka][es] Use thread context classloader when finding TableFormatFactory (#11064)"
     add 692fe55  [FLINK-15999][doc] Add outline of new concepts section
     add 852834b  [FLINK-15999][doc] Move explanation of DAGs/Dataflows from programming-model.md to stream-processing.md
     add c38315d  [FLINK-15999][doc] Clean up DAG/parallel DAG section in concepts doc
     add 019e3b2  [FLINK-15999][doc] Move state introduction from programming-model.md to stateful-stream-processing.md and clean up
     add 2c6fce8  [FLINK-15999][doc] Move checkpointing introduction from programming-model.md to stateful-stream-processing.md
     add 1c1acf7  [FLINK-15999][doc] Move batch-fault-tolerance from programming-model.md to stateful-stream-processing.md
     add e1d09e4  [FLINK-15999][doc] Remove distinction between managed and raw state from state.md
     add 2ed9885  [FLINK-15999][doc] Move keyed state/operator state explanation from api doc to concepts
     add 1714379  [FLINK-15999][doc] Move broadcast state explanation from api doc to concepts
     add ce74513  [FLINK-15999][doc] Move checkpointing doc from internals to concepts
     add ef23c35  [FLINK-15999][doc] Update newly moved checkpointing concepts section
     add 2c4a7c3  [FLINK-15999][doc] Add TODOs to state concepts section
     add 4382399  [FLINK-15999][doc] Rename time concepts section to "Timely Stream Processing"
     add 8d7c0db  [FLINK-15999][doc] Move time and windows section from programming-model.md to timely-stream-processing.md
     add 3ac8430  [FLINK-15999][doc] Fix formatting and links in timely-stream-processing.md
     add e4c74f4  [FLINK-15999][doc] Move relevant sections from event_time.md to timely-stream-processing.md
     add 5d92a82  [FLINK-15999][doc] Add reference to windowing and ProcessFunction doc in event_time.md
     add 36c3247  [FLINK-15999][doc] Remove "Low-level Operations" from ProcessFunction documentation
     add 45de303  [FLINK-15999][doc] Add TODOs in timely-stream-processing.md
     add 4a13e62  [minor] Remove outdated components(.zh).md
     add c5468da  [FLINK-15999][doc] Move state backend and savepoint doc from runtime.md to stateful-stream-processing.md
     add 938b64d  [FLINK-15999][doc] Move flink components doc from runtime.md to flink-architecture.md
     add 3608a6d  [FLINK-15999][doc] Move remaining text from runtime.md to flink-architecture.md
     add d744724  [FLINK-15999][doc] Remove "Asynchronous State Snapshots" section from concepts
     add a681389  [FLINK-15999][doc] Remove "ingestion time" from concepts section
     add ac4e757  [FLINK-15999][doc] Remove "operator state" from concepts section
     add 87e6cc2  [FLINK-15999][doc] Remove programming-model section and incorporate into overview
     add a26b75f  [FLINK-15999][doc] Update/remove outdated information in concepts section
     add a50b666  [FLINK-15977][docs] Update pull request template to include Kubernetes as deployment candidates
     add e396e7c  [FLINK-15672][build] Migrate to log4j2
     add e7db6b2  [FLINK-15672][build] Migrate production log4j configuration to log4j2
     add ee7fb5e  [FLINK-15672][build][tests] Migrate test log4j configurations to log4j2
     add 39ef959  [FLINK-16163][build] Migrate to flink-shaded-zookeeper
     add 409f35f  [hotfix][build system] Do not trigger dependent jobs if predecessor fails
     add 3d1330f  [FLINK-15967][examples] Use universal kafka connector in StateMachineExample
     add 956c9ed  [hotfix][scripts] Fix comment for default GC configuration
     add 326b482  [FLINK-14038][docs] Extend Application Profiling documentation
     add 9511243  [FLINK-16186][es][tests] Reduce connect timeout to 5 seconds
     add f6895da  [FLINK-15912][table] Add Context to TableSourceFactory and TableSinkFactory
     add 306a89a  [FLINK-15912][table] Support create table source/sink by context in sql-cli
     add 69d8816  [FLINK-15912][table-planner-blink] Support create table source/sink by context in blink planner
     add e280ffc  [FLINK-15912][table-planner] Support create table source/sink by context in legacy planner
     add 4e92bdb  [FLINK-15912][table] Support create table source/sink by context in hive connector
     add 052eb77  [FLINK-15912][table] Clean TableFactoryUtil
     add aa048ae  [FLINK-16082][docs-zh][table] Translate "Streaming Concepts Overview" page into Chinese (#11128)
     add 24c9f2b  [hotfix] Stabilize python tests
     add 494f94b  [FLINK-16233][hive][build] Add additional log4j 1 exclusions
     add 7b88951  [FLINK-16081][docs-zh][table] Translate /dev/table/index.zh.md (#11127)
     add 8bb14b8  [FLINK-16243][docs] Update quickstarts to Log4j2
     add 0aa296c  [hotfix][docs] Sync slf4j version
     add 40c0ba3  [FLINK-16188][e2e] AutoClosableProcess constructor now private
     add 091c672  java8 compat
     add 3c58f5a  fix stream issue
     add ae0fb0b  Remove concurrent access to process stdout
     add c11c696  [FLINK-15172][table-blink] Introduce LazyMemorySegmentPool
     add 56acfe9  [FLINK-15172][table-blink] Imporve BinaryExternalSorter to lazy allocate memory
     add f144e13  [FLINK-15172][table-blink] Imporve BytesHashMap to lazy allocate memory
     add adb595c  [FLINK-15172][table-blink] Improve ResettableExternalBuffer to lazy allocate memory
     add a907f29  [FLINK-15172][table-blink] Improve Hash join tables to lazy allocate memory
     add 127fd56  [FLINK-16288][travis] Remove redundant double-quote
     add 9969083  [FLINK-16237][build] Add Log4j2 configuration properties
     add fe9f448  [FLINK-16161][hive] Statistics zero should be unknown in HiveCatalog
     add ca2bc35  [FLINK-16121][python] Introduce ArrowReader and ArrowWriter for reading and writing Arrow format data
     add 4ecd525  [FLINK-16183][table-api] Make identifier parsing in Table API more lenient
     add 108286a  [FLINK-16183][table-api] Update documentation to reflect the more lenient sql identifier parsing.
     add f3415d7  [FLINK-16067][table] Forward Calcite exception when parsing a sql query
     add 0d7b3f9  [FLINK-16033][table-api] Fix loosing function identifier in ExpressionResolver rules
     add 93bd73a  [FLINK-16033][table-api] Parse identifiers in FunctionLookup.
     add 7cee4b1  [FLINK-16033][table-api] Expose catalog lookup function calls in Scala's expression dsl.
     add 3a830be  [FLINK-16242][table-runtime-blink] Duplicate field serializers in BaseRowSerializer (#11194)
     add 4c43be9  [FLINK-16013][core] Make complex type config options could be parsed correctly
     add ceaee9b  [hotfix] Minor clean-up in TaskExecutorProcessUtils.
     add 2836550  [FLINK-16111][k8s] Fix Kubernetes deployment not respecting 'taskmanager.cpu.cores'.
     add 4e96cd5  [hotfix][yarn][test] Add test cases for validating Yarn deployment respecting the cpu configuration fallback order.
     add 42a56f4  [hotfix][mesos][test] Update test cases for validating Mesos deployment respecting the cpu configuration fallback order.
     add 93da5ec  [FLINK-16263][python][tests] Set io.netty.tryReflectionSetAccessible to true for JDK9+
     add 35f967c  [hotfix] Fix minor IDE warnings in MemoryUtils
     add 74fc20a  [FLINK-15094] Use Unsafe to instantiate and construct DirectByteBuffer
     add 3fdd856  [hotfix] fix typo in FlinkKafkaConsumerBase
     add fa3f564  [FLINK-16179][hive] Use configuration from TableFactory in hive connector (#11201)
     add dd288c9  [FLINK-16264][table] Fix ConnectTableDescriptor loose time attribute bug (#11204)
     add 29d52cb  [FLINK-16178][refactor] Avoid costly eager error message construction in OperatorState.
     add 4ae98ff  [FLINK-16178][refactor] Remove SavepointV1 class and move relevant code to test scope
     add ca626cd  [FLINK-16178][refactor] Remove redundant (duplicate) check on version availability.
     add f575a82  [FLINK-16178][refactor] Make the versioned Checkpoint Metadata Serializers only responsible for deserialization.
     add b8277f9  [FLINK-16192][checkpointing] Remove remaining bits of "legacy state" and Savepoint 1.2 compatibility
     add 5fa3edc  [FLINK-16247][checkpoints] Rename 'checkpoints.savepoint.' package and classes to 'checkpoint.metadata.'
     add ff83629  [FLINK-16259][checkpoints] Drop interface/impl separation for checkpoint Metadata and rename MetadataV2 to CheckpointMetadata
     add b92803d  [FLINK-15349] add 'create catalog' DDL to blink planner
     add 7a283be  [FLINK-16265][table][csv] CsvTableSourceFactoryBase should compare LogicalTypes instead of TableSchema (#11214)
     add 1ada299  [FLINK-16251][python] Optimize the cost of function call in ScalarFunctionOpertation
     add ce0366d  [FLINK-16248][python][ml] Add interfaces for MLEnvironment and MLEnvironmentFactory (#11198)
     add 10b33f8  [FLINK-16283][table-planner] Fix potential NullPointerException when invoking close() on generated function (#11217)
     add 8760769  [FLINK-16231][hive][build] Add missing jdk.tools exclusion
     add a6c4bbe  [FLINK-16287][es][build] Remove Log4j2 relocation
     add b4a1f0b  [FLINK-16115][filesystem][oss] Relocate flink-hadoop-fs
     add df54637  [FLINK-15834] Set up nightly builds in Azure
     add c28c491  [FLINK-15834][hotfix][build scripts] Properly set return code before check
     add b394f5b  [FLINK-15834][hotfix] Always run end to end tests
     add 19e1291  [FLINK-15834][hotfix] Fix Kubernetes E2E tests
     add dc81ccb  [FLINK-15834][hotfix] Fix Kerberized YARN e2e test
     add 966dd2c  [FLINK-15834][hotfix] Fix queryable state e2e test
     add 293fd5a  [FLINK-16265][table][csv] CsvTableSinkFactoryBase should compare LogicalTypes instead of TableSchema (#11229)
     add 2ed4cf7  [FLINK-16252][python] Optimize the output emit logic to remove unnecessary overhead
     add 92253f2  [FLINK-14818][benchmark] Fix InputGate setup logic of StreamNetworkBenchmarkEnvironment
     add 39e75eb  [FLINK-16234][tests] Fix unstable cases in StreamingJobGraphGeneratorTest
     add ee0c21e  [FLINK-16196][hive] FlinkStandaloneHiveRunner leaks HMS process (#11169)
     add 68afd04  [FLINK-16275][table-planner-blink] AggsHandlerCodeGenerator can fail with custom module (#11215)
     add 45ec36e  [FLINK-15972][python][table-planner][table-planner-blink] Implement Physical Python Correlate Node
     add 2d0841c  [FLINK-15972][python] Add TableFunctionRowCoder
     add 3de1205  [FLINK-15972][python][table-planner][table-planner-blink] Add Python building blocks to make sure the basic functionality of Python TableFunction could work
     add d23e63c  [hotfix][docs] Remove unnecessary indents and blank lines
     add 244e58f  [FLINK-15562][docs] Add example settings.xml for configuring snapshot repository
     add a8bb211  [FLINK-15198][Config][Mesos] Remove deprecated option 'mesos.resourcemanager.tasks.mem'
     add 6deca76  [FLINK-15847][ml] Include flink-ml-api and flink-ml-lib in opt
     add 556c6d2  [FLINK-16257][network] Remove useless ResultPartitionID from AddCredit message
     add d19d747  [hotfix][network] Cleanup the unused method from SingleInputGate
     add d6f0396  [FLINK-15948][yarn] Enrich the warning log for YARN minimum allocation memory
     add ff0e366  [FLINK-16301][table-api] Improve logging message in ModuleManager (#11244)
     add bd5a235  [FLINK-15688][streaming] Define DataStream API for MultipleInputStreamOperator
     add eac3bd5  [hotfix][test] Rename getStreamEdges to getStreamEdgesOrThrow
     add 3fe3c66  [hotfix][streaming] Deduplicate code in StreamGraph
     add 261dd71  [FLINK-15688][streaming] Add support for MultipleInputStreamOperator in the StreamGraphGenerator
     add e0a857e  [hotfix][test] Deduplicate code in LinkedBufferStorageTest
     add c83a3be  [FLINK-16060][checkpointing] Generalize LinkedBufferStorage to support arbitrary number of linked buffer storages
     add f108d04  [FLINK-16060][metrics] Generalize MinWatermarkGauge to accept an aribtrary number of input gauges
     add 96b1b55  [hotfix][task] Extract InputSelection.NONE_AVAILABLE constant
     add 0958f3d  [FLINK-16060][task] Implement InputSelection#fairSelectNextIndex
     add ad6fc37  [FLINK-16060][task] Generalize InputSelection#isAllMaskOf2 to multiple inputs
     add 10c3bb8  [hotfix][tests] Clean up exception lists of StreamTestSingleInputGate
     add 1438882  [FLINK-16060][test] Provide a test harness for MultipleInputStreamTask
     add 8becccb  [FLINK-16060][task] Implemente working StreamMultipleInputProcessor
     add e5ef38f  [FLINK-16292][AZP] Simplify mechanism for choosing jdk version
     add 4c6fc2a  [FLINK-16292][e2e] Improve debugging of schema registry test
     add f979881  [FLINK-16292][AZP] Add missing nightly tests
     add a6a5195  [FLINK-16271][python] Introduce ArrowPythonScalarFunctionOperator for vectorized Python UDF execution
     add 5a8cb2b  [hotfix] Fix checkstyle violations in ScheduledUnit
     add 8f6fcd2  [hotfix][tests] Mock ExecutionVertex#getID() in ScheduelrTestUtils to avoid NPE issues
     add 9a3eb5b  [FLINK-16180][runtime] Replace the nullable vertexExecution in ScheduledUnit with a non-null executionVertexId
     add 22af97f  [FLINK-16297][docs] Remove unnecessary indents and blank lines
     add 8c063d3  [FLINK-16288] Document how to keep the task managers around longer in Kubernetes
     add 525f164  [FLINK-15329][runtime] Fix incorrect Javadoc in MemoryManager
     add 550ca72  [FLINK-15975][tests] Ignore order in assertion
     add ba295fa  [FLINK-13934][rest] Throw RestHandlerException instead of sending inline response
     add ddbe9f7  [FLINK-13934][rest][tests] Fix and strengthen response assertions
     add f3a26f1  [FLINK-16331][legal] Remove source licenses for old WebUI
     add 2e25b0a  [FLINK-16339][metrics][datadog] Log configuration
     add d50e1c5  [FLINK-16307][e2e] Use start-cluster.sh instead of manually building cluster
     add ca22304  [FLINK-16341][metrics][datadog] Unify DatadogHttpRequest and DSeries
     add 5371fda  [hotfix][tests] Make SchedulerTestingUtils constructor private
     add f40658d  [hotfix][runtime] Remove slotProvider and slotRequestTimeout param from DefaultScheduler constructor
     add bd757cb  [FLINK-16276][tests] Introduce a builder and factory methods to create DefaultScheduler for testing
     add 622bd31  Fixup! [FLINK-16276][tests] Introduce a builder and factory methods to create DefaultScheduler for testing
     add 0abab7e  Revert "Fixup! [FLINK-16276][tests] Introduce a builder and factory methods to create DefaultScheduler for testing"
     add 1cc6c79  Revert "[FLINK-16276][tests] Introduce a builder and factory methods to create DefaultScheduler for testing"
     add 9e0465d  [FLINK-16276][tests] Introduce a builder and factory methods to create DefaultScheduler for testing
     add 8e12742  [FLINK-16342][metrics][datadog] Remove mocking
     add d8a6d11  [FLINK-13417][build] Bundle Zookeeper 3.5 in opt
     add 029d578  [FLINK-16033][table-api] Introduced Java Table API Expression DSL
     add eb13a15  [FLINK-16033][table-api, test] Added test that check scala/java APIs completeness
     add 344477b  [FLINK-16033][table-api] Updated a test to use java expression dsl
     add 50dcae2  [FLINK-16033][table-api] Added test for expression resolution.
     add 569468f  [FLINK-16285][network] Refactor SingleInputGate#setInputChannel to remove IntermediateResultPartitionID argument
     add d4ca6ea  [hotfix][tests] Remove the dead codes of StreamTestSingleInputGate and TestInputChannel
     add da7a688  [FLINK-16352][table-common] Changing HashMap to LinkedHashMap for deterministic iterations in ExpressionTest (#11269)
     add d9b9aad  [FLINK-16360][orc] Flink STRING data type should map to ORC STRING type (#11277)
     add f0bdf31  [FLINK-16007][table-planner][table-planner-blink][python] Add PythonCorrelateSplitRule to push down the Java Calls contained in Python Correlate node
     add 0cfbe1f  [hotfix][hdfs] Fixed error message when using HadoopRecoverableWriter on non hdfs.
     add 91399fe  [FLINK-16015][filesystems]Throw an error when a plugin for a known scheme is missing.
     add 2489d04  [hotfix][runtime] Removed duplicate isChainable.
     add 1034b6a  [hotfix][runtime] Unified variable names in StreamingJobGraphGenerator.
     add ae823c8  [FLINK-16219][runtime] Disallow chaining of legacy source and yielding operator.
     add 3a04e17  [FLINK-16219][runtime] Made AsyncWaitOperator chainable to non-sources.
     add 447deaa  [hotfix][build] Remove redundant javadoc-plugin versions
     add 8cdef52  [FLINK-15633][build] Bump javadoc-plugin to 3.1.1
     add cc75e01  [FLINK-2336][DataStream API] Fix ArrayIndexOufOBoundsException in TypeExtractor for type erased lambdas
     add d62eb7e  [hotfix][docs] Fix the mismatch between java and scala CEP examples
     add 2806215  [hotfix][table] Remove unused import in DataStreamConversions
     add 195b0d0  [FLINK-16380][AZP] Fix jdk11 switch
     add 3e10f0a  [FLINK-16281][jdbc] Parameter 'maxRetryTimes' can not work in AppendOnlyWriter (#11223)
     add 242efcd  [FLINK-12814][sql-client] Support a traditional and scrolling view of result (tableau format)
     add 53079f7  [FLINK-15081][docs-zh] Translate "Concepts & Common API" page of Table
     add dfd79bc  [FLINK-16370][build] Only bundle javax as Java11-exclusive dependency
     add 4a509fc  [FLINK-16359][table-runtime] Introduce WritableVectors for abstract writing (#11275)
     add eb814e8  [FLINK-16190][e2e] Migrate tests to FlinkResource
     add e3307b7  [FLINK-16190][e2e] Move FlinkDistribution into flink package
     add a9d47c7  [FLINK-16348][WebUI] Add commas to numeric accumulators
     add 68b2b56  [hotfix][dataset][javadoc] Fix typo
     add 69bdb72  [hotfix][table][docs] Fix typo
     add 197991a  [hotfix][kinesis][build] Document why guava must not be relocated
     add f179127  [FLINK-10885][e2e] Stabilize confluent schema registry test
     add bc73338  [FLINK-15582][tests] Enable batch scheduling tests for both LegacyScheduler and DefaultScheduler
     add b3f8e33  [FLINK-16140] [docs-zh] Translate Event Processing (CEP) page into Chinese (#11168)
     add 2b13a41  [FLINK-16362][table] Remove deprecated `emitDataStream` method in StreamTableSink
     add 3cf8fe5  [FLINK-11193][State] Fix Rockdb timer service factory configuration option to be settable per job
     add 095da70  [hotfix] Fix chinese doc links to make master documentation build again
     add cfe1f9e  [hotfix][scaladoc] Add missing parameter in DataStreamConversions's scaladoc
     add 78d3da7  [FLINK-16131] [docs] Translate /ops/filesystems/s3.zh.md
     add 9dba72a  [hotfix] [docs] Fix typo in /ops/filesystems/s3.md
     add 8b9af0a  [FLINK-10917][build] Move&rename drowpizard property
     add 4921e3c  [FLINK-10917][metrics] Bump dropwizard to 3.2.6
     add 4580fd6  [FLINK-16280][doc] Fix sample code errors in the documentation about elasticsearch connector.
     add b098ce5  [FLINK-15838] Dangling CountDownLatch.await(timeout)
     add de5f8fa  [FLINK-16393][kinesis] Skip record emitter thread creation w/o source sync
     add 9b065dc  [hotfix] Fix checkstyle violations in ExecutionGraphTestUtils
     add b2bcbd7  [hotfix][tests] Change ExecutionGraphTestUtils#getExecutionVertex(…) to ExecutionGraphTestUtils#getExecutionJobVertex(…)
     add 007b875  [FLINK-16300][tests] Introduce ExecutionGraphTestUtils#getExecutions(…) to replace SchedulerTestUtils#getTestVertex(…)
     add 11fa028  [hotfix] [k8s] Normalize name or package class of the test classes
     add 0743b43  [FLINK-16194][k8s] Remove the existing decorator patterns
     add 20d0990  [FLINK-16194][k8s] Refactor and simplify KubernetesTestBase
     add 8c7a17e  [FLINK-16194][k8s] Remove Flink Configuration out of KubernetesResource
     add 22735e3  [FLINK-16194][k8s] Introduce Kubernetes parameters parsing/verifying/managing tool
     add a50435d  [FLINK-16194][k8s] Introduce the monadic step decorator design and the InitJobManagerDecorator and the TaskManagerDecorator
     add 7f19c9c  [FLINK-16194][k8s] Introduce Java command decorator for the main Container of the JobManager and the TaskManger Pod
     add 4d8281a  [FLINK-16194][k8s] Introduce the internal and the external Service decorator
     add d29628c  [FLINK-16194][k8s] Introduce decorator for mounting configuration files such as flink-conf.yaml, log4j.properties, and logback.xml
     add 10f5329  [FLINK-16194][k8s] Introduce Factories that chain the decorators together to construct all the client/cluster-side Kubernetes resources
     add f6ad968  [FLINK-16194][k8s] Rework FlinkKubeClient to use the new decorator pattern
     add dd8ce6c  [FLINK-16194][k8s] Make FlinkPod a value class
     add 3408ead  [FLINK-15584][table-planner] Give nested data type of ROWs in ValidationException
     add 0362d20  [FLINK-16414][table] Fix sql validation failed when using udaf/udtf has no getResultType (#11302)
     add 59b6584  [FLINK-16133][docs-zh] Translate /ops/filesystems/azure.zh.md
     add 0428b10  [FLINK-16132][docs-zh] Translate /ops/filesystems/oss.zh.md into Chinese
     add 5781c67  [FLINK-16089][docs-zh] Translate "Data Type" page of Table API & SQL into Chinese
     add 059e71d  [FLINK-16084][docs-zh] Translate /dev/table/streaming/time_attributes.zh.md (#11102)
     add b473030  [FLINK-16418][hive] Hide hive version to avoid user confuse (#11304)
     add 0296dfa  [FLINK-16122][AZP] Upload artifacts file
     add 2e4a642  [hotfix][AZP] Shorten cron build job names
     add be0eb54  [FLINK-16400][s3] Fixing YarnFileStageTestS3ITCase for direct Hadoop access.
     add 3e66fcf  [FLINK-16400][filesystem] Deprecating filesystem kind.
     add 377024b  [FLINK-16269][FLINK-16108][table-planner-blink] Fix schema of query and sink do not match when generic or POJO type is requested (#11236)
     add ef8402e  [FLINK-16177][refactor][checkpointing] Remove unnecessary test constructor from PendingCheckpoint.
     add 1961966  [FLINK-16177][refactor][checkpointing] Introduce a new MetadataV3Serializer for the latest version
     add a05f456  [FLINK-16177][refactor][checkpointing] Remove unused fields from Metadata Serializer version 3
     add add0722  [hotfix][checkpointing] Minor code cleanups for 'checkpoint.metadata' test classes
     add 086c0ff  [hotfix][tests] Fix parameter error in CheckpointCoordinatorTestingUtils
     add 963974f  [FLINK-16177][checkpointing] Integrate OperatorCoordinator with checkpoints (triggering and committing)
     add b6f07dd  [FLINK-16410][e2e][build] Add explicit flink-runtime dependency
     add 8587ce8  [FLINK-16172][build] Add baseline set of allowed unused dependencies
     add a762e76  [FLINK-16173][build] Reduce noise for used undeclared dependencies
     add 1924f82   [FLINK-16189][e2e] Remove test logic from FlinkDistribution
     add 2b19918  [FLINK-16417][e2e] Slightly increase offheap memory for ConnectedComponents test
     add bd0d631  [FLINK-16431][AZP] Pass build profile into end to end test script on Azure
     add 1a4fb25  [FLINK-16378][AZP] Disable Docker tests when running with JDK11
     add b7f53c2  [FLINK-16249][python][ml] Add interfaces for Params, ParamInfo and WithParams
     add 1aabab8  [FLINK-11899][parquet] Introduce parquet ColumnarRow split reader
     add 1ec78b7  [FLINK-16129][docs-zh] Translate /ops/filesystems/index.zh.md into Chinese
     add 5adbd70  [FLINK-16130][docs-zh] Translate /opt/filesystems/common.zh.md into Chinese
     add 2a3daf3  [FLINK-16337][python][table-planner-blink] Add support of vectorized Python UDF in blink planner
     add 3ebc162  [FLINK-16337][python][table-planner] Add support of vectorized Python UDF in old planner
     add 37578f7  [FLINK-16435][python] Replace since decorator with versionadd to mark the version an API was introduced
     add d1f1d40  [FLINK-16313] Ignore unstable rocksdb state processing api test
     add ce85bb7  [hotfix] In flink-end-to-end-tests-common-kafka, execute dependency plugin in different phase
     add 809eb2a  [FLINK-16445][build] Set property japicmp.referenceVersion to 1.10.0
     add 560e805  [FLINK-16313][state-processor-api] Properly dispose of native resources when closing input split
     add a68f5fd  [FLINK-16450][hive] Integrate parquet columnar row reader to hive
     add e9fd832  [FLINK-16463][table-planner-blink] Remove the redundant semicolon in the generated code in CodeGenUtils
     add b642005  [FLINK-16199][table] Support IS JSON predication for SQL in blink planner
     add 2d08e10  [FLINK-16500][hive] Hive get primary key should not throw exception when Invalid method name
     add cac40c6  [FLINK-16467][core] Fix MemorySizeTest#testToHumanReadableString failure due to different string formats in different locales.
     add aaf63f0  [FLINK-16427][api] Don't throw ProgramInvocationException in RemoteStreamEnvironment
     add f21fa96  [FLINK-16273][python] Set io.netty.tryReflectionSetAccessible to true by default (#11341)
     add 5a81fa0  [FLINK-15131][connector/source] Add the APIs for Source (FLIP-27).
     add 8f8e358  [FLINK-16167][python][doc] Improve python_shell document
     add 6f19fd2  [FLINK-16483][python] Add Python building blocks to make sure the basic functionality of vectorized Python UDF could work (#11342)
     add 79de2ea  [FLINK-16371][fs-connector] Make CompressWriterFactory serializable
     add 33c6d4b  [FLINK-16371][fs-connector] Add ITCase
     add dae1750  [FLINK-15782][connectors/jdbc] rename package-private JDBC classes Motivation: Future classes for JDBC XA and JDBC DML make uppercase convention inconvenient
     add b41e0d1  [FLINK-15782][connectors/jdbc] introduce parameter objects Motivated partially by future use in public API
     add 11f6967  [FLINK-15782][connectors/jdbc] refactor JDBC connector impl. Motivation: use existing code oriented to Table API in DataStream API Changes: 1. make JDBC writers more general PreparedStatement executors (still operating on Rows) 2. isolate Delete operation specific to Table API 3. generalize JdbcUpsertOutputFormat and rename to JdbcBatchingOutputFormat
     add 427eb55  [FLINK-15782][connectors/jdbc] generalize jdbc statement executors (from Row to <T>) Motivation: use existing code oriented to Table API in DataStream API
     add 62065c8  [FLINK-15782][connectors/jdbc] generalize output formats and sinks (from Row to <T>) Motivation: use existing code oriented to Table API in DataStream API
     add 3d2e47d  [FLINK-15782][connectors/jdbc] rename Batch to Execution Options
     add 3ad2f32  [FLINK-15782][connectors/jdbc] inject connection provider instead of options Motivation: manage connections outside of JDBCOutputFormat. In particular, this is required to manage transactions.
     add 40cab49  [FLINK-15782][connectors/jdbc] refactor JDBC sink tests Changes: 1. extract DbMetadata to allow to use different databases 2. extract test fixture from the base class 3. use inheritance only for @Before/@After behaviour
     add 713bf4c  [FLINK-15782][connectors/jdbc] add JDBC sink DataStream API
     add 5afe1b5  [FLINK-15782][connectors/jdbc][pr-review] use SimpleBatchStatementExecutor for Upsert [pr-review] enforce use of Builder and Optional in JdbcOptions [pr-review] don't expose Row in DataStream API [pr-review] fix typo and remove redirects in docs; add some javadoc [pr-review] rename ExecutorCreator to StatementExecutorCreator and some vars/methods [pr-review] address formatting and some other minor issues
     add bd18b87  [FLINK-16455][hive] Introduce flink-sql-connector-hive modules to provide hive uber jars
     add 87ebe55  [FLINK-15396][json] Support to ignore parse errors for JSON format
     add 1ad361b  [FLINK-16512][task] Unaligned checkpoints: API for persistence
     add 642f096  [FLINK-16525][task] Increment subtask id by 1 to display subtask name
     add ffc8e42  [FLINK-16014][s3] Force usage of SAXParserFactory over XMLReaderFactory
     add 1276fa6  [FLINK-16363][table] Correct the execution behavior of TableEnvironment and StreamTableEnvironment
     add 610c9fb  [FLINK-16519][checkpointing][tests] Remove PowerMock
     add 2a4a2e2  [FLINK-14041][tests] Refactor LeaderRetrievalServiceHostnameResolutionTest
     add 5fa4259  [FLINK-16477][hotfix][test] Add SerialVersionUID to the test Class to get stable functionIdentifier
     add b2c20e9  [FLINK-16516][python] Avoid codegen user-defined function for Python UDF (#11358)
     add 271ab60  [FLINK-16530][docs] Add documentation about "GROUPING SETS" and "CUBE" support in streaming mode
     add 091d1d3  [FLINK-16374][AZP] Disable java e2e tests in misc profile
     add 10e8918  [FLINK-16456][e2e] Increase memory off heap of 'Heavy deployment end-to-end test'
     add bf11952  [FLINK-16417][e2e] Increase offheap memory for high-parallel-iterations test
     add 1b628d4  [FLINK-15337][docs] Add vendor table to documentation
     add 81c48e5  [FLINK-16546][yarn] Fix logging bug in YarnClusterDescriptor#startAppMaster
     add 5132375  [hotfix] Fix some typos in flink-examples-streaming
     add 3ef2c08  [FLINK-16545][build] Remove Eclipse-specific plugins
     add 9c6aa32  [FLINK-11720][connectors] Bump ElasticSearch5 to 5.3.3
     add d723d00  [FLINK-16526][table-planner-blink] Fix exception when computed column expression references a keyword column name
     add 663af45c [FLINK-16493][k8s] Use enum type instead of string type for KubernetesConfigOptions.REST_SERVICE_EXPOSED_TYPE
     add bb8e387  [FLINK-16406] Increase default value for JVM Metaspace to minimise its OutOfMemoryError
     add 42f4948  [FLINK-16304][python] Remove python packages bundled in the flink-python jar. (#11238)
     add ab37867  [FLINK-15727][scripts] Return dynamic configs and JVM parameters in one call
     add 62abfa9  [FLINK-16550][s3] Force namespace parsing in XmlResponsesSaxParser.
     add fac04a7  [FLINK-16343][table-planner-blink] Improve exception message when reading an unbounded source in batch mode
     add 108f528  [FLINK-16350][e2e] Run half of streaming HA tests against ZK 3.5
     add 625da7b  [FLINK-16539][sql-client] Trim the value when calling set command in sql cli
     add 88d7d95  [FLINK-15090][tests] Explicitly depend on flink-clients
     add de4c116  [FLINK-15090][tests] Move streaming env tests to flink-tests
     add 9504252  [FLINK-15090][compiler] Extract JobGraphGenerator#addUserArtifactEntries to a flink-runtime utils
     add 0523ef6  [FLINK-15090][api] Reverse the dependency from flink-streaming-java to flink-clients
     add 222dc571 [FLINK-16330][AZP] Enable tests requiring S3 credentials
     add 6f10a23  [FLINK-16250][python][ml] Add interfaces for PipelineStage and Pipeline (#11344)
     add 7338719  [hotfix][network] Fix the comments error in NettyMessage
     add db5d753  [FLINK-10742][network] Let Netty use Flink's buffers directly on receiver side
     add ae1d1b2  [FLINK-16008][python][table-planner][table-planner-blink] Add rules to transpose the join condition as a Calc on top of the Python Correlate node (#11299)
     add 2424301  [FLINK-16538][python][docs] Restructure Python Table API documentation (#11375)
     add 22915d0  [FLINK-16464][sql-client] Result-mode tableau may shift when content contains Chinese string in SQL CLI (#11334)
     add d6038cc  [FLINK-16524][python] Optimize the Python UDF execution to use generator to eliminate unnecessary function calls (#11374)
     add 6126600  [FLINK-16261][table] Use type compatibility consistently to avoid casting
     add 3b99f7e  [FLINK-16554][task][refactoring] split StreamTask
     add 0920e64  [FLINK-11088] Allow YARN to discover pre-installed keytab files
     add ea8f0e3  [FLINK-11088] Refactor keytab resolution to Utils
     add 7f86f74  [FLINK-11088] Regenerate YARN/kerberos config docs
     add c83bc65  [FLINK-11088] Add unit test for Kerberos parsing in YarnEntrypointUtilsTest
     add 0477368  [FLINK-14121] Update commons-compress because of CVE-2019-12402
     add 5157691  [hotfix][docs] fix mistakes in Modules document
     add 3d11907  [FLINK-16508][k8s] Name the ports exposed by the main Container in Pod
     add 328193d  [FLINK-16541][doc] Fix document of table.exec.shuffle-mode
     add 608e9e7  [FLINK-16336][table] Add new type inference for temporal table functions
     add 4a4baf0  [FLINK-16613] make build trigger on azp more reliable
     add 4da4432  [FLINK-16573] Ensure Kinesis RecordFetcher threads shutdown on cancel
     add f062b95  [FLINK-16096][docs-zh] Translate dev/table/catalog.zh.md into Chinese
     add 4035f03  [FLINK-16454][build] Update the copyright with 2020 year in NOTICE files
     add 1063d56  [FLINK-16413][hive] Reduce hive source parallelism when limit push down
     add 9242daf  [FLINK-16623][sql-client] Add the shorthand 'desc' for describe in sql client
     add 428c778  [FLINK-16607][python] Update flink-fn-execution.proto adding more schema information
     add fac0cf1  [FLINK-16047][table-planner-blink] Fix Blink planner produces wrong aggregate results with state clean up
     add 594a722  [FLINK-16551][WebUI][tests] Improve assertions
     add 6cf07d3  [FLINK-16494][k8s] Switch to enum type for config option KubernetesConfigOptions.CONTAINER_IMAGE_PULL_POLICY
     add 0a8eb8d  [FLINK-16586][network] Build ResultSubpartitionInfo and InputChannelInfo in respective constructors
     add ddec073  [hotfix][task][tests] Remove useless import from TaskTest class
     add 8bddbc2  Fix typo
     add cd51ffc  [FLINK-16433][table-api] TableEnvironmentImpl doesn't clear buffered operations when it fails
     add a7dccf1  [FLINK-16565][python][ml] Make Pipeline Json compitable between Java and Python if all PipelineStages are Java ones (#11420)
     add b83060d  [FLINK-16606][python] Throw exceptions for the data types which are not currently supported
     add cf7cc89  [FLINK-16373] Make JobManagerLeaderListener thread safe
     add 3cd1eab  [hotfix] Minor cleanups in JobLeaderService
     add 9a07945  [hotfix] Add JavaDoc to RegisteredRpcConnection#tryReconnect
     add b4c0f2d  [FLINK-16635] Remove pinned dependency for okio and okhttp from flink-metrics-influxdb
     add 405cf8f  [FLINK-16635] Bump influxdb-java version to 2.17
     add 65037f0  [FLINK-16083][docs-zh] Translate "Dynamic Table" page of "Streaming Concepts" into Chinese
     add 1276507   [FLINK-16646][orc] Flink read orc file throw a NullPointerException after re-open
     add 4f4c682  [hotfix][doc] Fix typos and broken links in memory configuration docs.
     add ba38b03  [FLINK-15991][docs-zh] Translate the index of "Memory Configuration" into Chinese.
     add b133cc1  [FLINK-15991][docs-zh] Translate the "Set up Task Executor Memory" page into Chinese.
     add 1f852b7  [FLINK-15991][docs-zh] Translate the "Detailed Memory Model" page into Chinese.
     add 61d0e0e  [FLINK-15991][docs-zh] Translate the "Memory tuning guide" page into Chinese.
     add 3209719  [FLINK-15991][docs-zh] Translate the "Troubleshooting" page into Chinese.
     add 6c1f94c  [FLINK-15991][docs-zh] Translate the "Migration Guide" page into Chinese.
     add 64abbdd  [FLINK-15953][web] Fix color of RESTARTING status in Web UI
     add e8d98f4  [FLINK-15958][table-common] Introduce unresolved data types in API
     add 5ce71d4  [FLINK-16344][table-planner-blink] Preserve nullability for nested types
     add e30089c  [FLINK-15771][tests] Harden SQLClientKafkaITCase
     add aeffce4  [hotfix][tests] Fix exception in AutoClosableProcess
     add 6aa4a3f  [FLINK-16583][sql-client] Provide classloader during pipeline creation
     add a56738f  [FLINK-16664][stream] fix wrong check for DataStreamSource#setParallelism()
     add 43f455d  [FLINK-16592][docs] The doc of Streaming File Sink has a mistake of grammar
     add 8c3c548  [FLINK-16432][hive] Fix dependencies in Hive Connector build
     add e19bc92  [FLINK-16675][test] Fix TableEnvironmentITCase.testClearOperation failure
     add 8c224fe  [FLINK-16236][yarn][hotfix] fix YARNSessionFIFOSecuredITCase not loading the right security context factory
     add 9b34929  [FLINK-16236][yarn][runtime] Change security context factory initialization
     add b4828d0  [hotfix] Add log4j2 properties file to flink-yarn-tests
     add c0416f2  [FLINK-13000][tests] Remove unused JobID parameters
     add b9943dc  [FLINK-16676][python][test] Fix ValidationPipelineTest.test_pipeline_from_invalid_json failure in Azure
     add 75b240d  [hotfix][docs] Fix broken links
     add b237b00  [FLINK-16293] Document using plugins in Docker and Kubernetes
     add 6ee5dba  [FLINK-15852][cli] Prioritize ExecutorCLI over YarnSessionCLI for active CLI
     add 0b9fac1  [hotfix] Make TestBulkWriterFactory publicly available for other test modules
     add 067c044  [FLINK-16684] Fix StreamingFileSink builder compilation for Scala
     add 5ccb167  [FLINK-16650][python] Support LocalZonedTimestampType for Python UDF in blink planner (#11439)
     add 0619a5b  [FLINK-16220][json] Fix cast exception in JsonRowSerializationSchema when serializing null fields
     add c60d11d  [FLINK-16653][network][tests] Implement MockResultPartitionWriter base for simplifying tests
     add 0bc38ba  [FLINK-15962][network] Reduce the default chunk size to 4M in netty stack
     add b226cbd  [FLINK-16633][AZP] Fix builds without s3 credentials
     add 96dc51f  [FLINK-16011] fix the bug that with will not effect if not in the end of pattern
     add 1be88b1  [FLINK-16011] Distinguish between no time window and 0 length time windwo in NFACompiler
     add 8a27bd9  [FLINK-16691][python][docs] Improve Python UDF documentation to remind users to install PyFlink on the cluster
     add 74b8bde  [FLINK-16471][jdbc] develop JDBCCatalog and PostgresCatalog
     add 75ad29c  [FLINK-16472] support precision of timestamp and time data types
     add 8a1666e  [hotfix][task] Remove unnecessary fields and methods from StreamTask
     add 6937fd8  [hotfix][tests] Remove dead codes from SynchronousCheckpointTest
     add 7dafd1c  [FLINK-16690][tests] Refactor StreamTaskTest to reuse TestTaskBuilder and MockStreamTaskBuilder
     add 54395d9  [FLINK-16345][table-planner-blink] Fix computed column can not refer row time attribute column
     add 044733d  [FLINK-16532][core] Shouldn't trim whitespaces in Path
     add 816bff8  [FLINK-16711][parquet] Parquet columnar row reader read footer from wrong end
     add cdcc25c  [FLINK-16652][orc] BytesColumnVector should init buffer in Hive 3.x
     add f56a075  [FLINK-15667][k8s] Support to mount custom Hadoop Configurations
     add 6049b83  [FLINK-16547][yarn] Respect the config option of FileJobGraphRetriever#JOB_GRAPH_FILE_PATH
     add 50ee655  [FLINK-16718][tests] Fix ByteBuf leak in KvStateServerHandlerTest
     add a2b669f  [hotfix][doc] Document union list metadata gotcha
     add c125c04  [FLINK-16302][rest] Enable retrieval of custom TaskManager log files
     add 505a808  [FLINK-16302][rest] Add tests for (un)marshalling LogListInfo
     add 874310f  [FLINK-14971][checkpointing] Handle ack/declined message of checkpoint in timer thread
     add 1a13862  [FLINK-14971][checkpointing] Introduce main thread executor in CheckpointCoordinator to execute all non-IO operations instead of the timer thread
     add 300263e  [hotfix] Harden ResumeCheckpointManuallyITCase
     add f248e6d  [FLINK-14971][checkpointing] Make CompletedCheckpointStore thread-safe to avoid synchronization outside
     add d8267be  [FLINK-14971][checkpointing] Remove coordinator-wide lock of CheckpointCoordinator
     add 6936713  [FLINK-14971][checkpointing] Remove lock of PendingCheckpoint and introduce IO lock for PendingCheckpoint
     add e08606c  [FLINK-16092][docs-zh] Translate dev/table/functions/index.zh.md into Chinese
     add 9c351b7  [FLINK-16567][table][doc] Update to TableConfig in query_configuration document
     add f0777fe  [FLINK-16608][python] Remove the method which derives the LogicalType from the Arrow ValueVector
     add 09fcfab  [FLINK-16608][python] Support BooleanType in vectorized Python UDF
     add 63ba201  [FLINK-16608][python] Support FloatType in vectorized Python UDF
     add 180c2c9b [FLINK-16608][python] Support DoubleType in vectorized Python UDF
     add cf1d8c6  [FLINK-16608][python] Support VarCharType in vectorized Python UDF
     add 6918ae7  [FLINK-16608][python] Support VarBinaryType in vectorized Python UDF
     add 27d8547  [FLINK-16608][python] Support DecimalType in vectorized Python UDF
     add 9992b37  [FLINK-16608][python] Support DateType in vectorized Python UDF
     add 28bcbd0  [FLINK-16608][python] Support TimeType in vectorized Python UDF
     add 813f590  [FLINK-16225] Improve metaspace out-of-memory error handling thrown in user code
     add 874a4af  [FLINK-16225] Add JVM Metaspace Error assumption test
     add a752184  [FLINK-15989] Improve direct out-of-memory error handling in MemorySegmentFactory
     add f22756c  [FLINK-15989] Add JVM Direct Error assumption test
     add d6a0e4a  [FLINK-16740][orc] Orc logicalTypeToOrcType fails to create decimal type with precision < 10
     add b7a83ff  [FLINK-16732][hive] Failed to call Hive UDF with constant return value
     add c4aa570  [hotfix][runtime] Minor code clean-ups.
     add 61086f4  [hotfix][e2e] Deduplicate codes for building docker image with custom jar.
     add 03b6e76  [FLINK-15911][runtime] Refactor to create AkkaRpsService with builder class, in order to reduce the number of nested creating methods.
     add 8a1dbcc  [FLINK-15911][runtime] Support configure address/port and bind-address/bind-port separately for JM/TM RPC services.
     add 3c99779  [FLINK-15911][runtime] Support configure address/port and bind-address/bind-port separately for netty shuffle service.
     add 9dc7a4a  [FLINK-15911][runtime] Support unresolveable external hostname.
     add 5c35d9d  [FLINK-15911][e2e] Add e2e test for Flink over NAT.
     add 3df0eb7  [FLINK-15647][k8s] Support user-specified annotations for the JM/TM pods
     add f6312b8  [FLINK-15647][k8s] Return an empty Map instead of null when annotations is not set
     add 1827e4d  [FLINK-16170][elasticsearch] Fix SearchTemplateRequest ClassNotFoundException when using flink-sql-connector-elasticsearch7
     add 5642479  [FLINK-15579][table-planner-blink] UpsertStreamTableSink should work on batch mode
     add d38a010  [FLINK-15579][table-planner-blink] Fix UpsertStreamTableSink support and add tests
     add bb4ec22  [FLINK-16712][task] Refactor StreamTask to construct final fields
     add f4b68c4  [FLINK-15640][k8s] Support to set labels for jobmanager and taskmanager pod
     add f80c384  [FLINK-16625][utils] Extract BootstrapTools#getEnvironmentVariables to ConfigurationUtils#getPrefixedKeyValuePairs
     add 1ff2bf0  [FLINK-16604][web] JM config key column has 30% width
     add 811c3be  [FLINK-16629] Ignore Streaming bucketing end-to-end test with Hadoop 2.4.1
     add e5bca02  [FLINK-16663][docs] Interpret versions as strings
     add 5aedb83  [FLINK-16692] Register custom JobListeners throug config.
     add 89ceb2a  [FLINK-16316][task] Remove StreamTask dependency from AbstractStreamOperator#snapshotState
     add c5eb0e5  [FLINK-16316][operators] Remove chaining strategy methods from the StreamOperator interface
     add cb4c32f  [FLINK-16316][operators] Pass StreamTaskStateInitializer to operators from outside
     add 63d6add  [hotfix][test] Fix formatting in AbstractStreamOperatorTest
     add a909af1  [hotfix][test] Remove no-op tests for AbstractStreamOperator
     add 7e7bcc4  [FLINK-16316][operators] Extract state handling code from AbstractStreamOperator
     add 239088e  [FLINK-16316][operators] Cut dependency between StreamingRuntimeContext and AbstractStreamOperator
     add c1398f0  [FLINK-16316][operators] Move inner CountingClass class out from AbstractStreamOperator
     add f84cc1b  [FLINK-16316][operators] Introduce StreamOperatorParameters class
     add 16a0334  [FLINK-16316][operators] Implement new AbstractStreamOperatorV2 as a replacement for AbstractStreamOperator
     add 73d4103  [FLINK-16316][operators] Make StreamOperatorFactory Experimental
     add 66101d8  [FLINK-16166][build] Append additional javadoc options
     add 90a9b3e  [FLINK-16377][table] Support calls to inline functions in the expressions DSL.
     add 1c86b8b  [FLINK-16480][AZP] fix log upload condition
     add b17d01b  [FLINK-16480][e2e] On failure, add e2e logs into artifact
     add 5b3d4eb  [hotfix][tests] Remove dead code
     add 158e447  [FLINK-16317][operators] Provide support for watermarks in  MultipleInputStreamOperator
     add a443b04  [FLINK-16317][operators] Refactor AbstractStreamOperatorTest class
     add 381a01a  [FLINK-16317][operators] Implement AbstractStreamOperatorV2Test
     add 05883b7  [FLINK-16317][operators] Provide support for key selector and latency marker in MultipleInputStreamOperator
     add 1d5f447  [FLINK-16317][operators] return this from (Keyed)MultipleInputTransformation#addInput
     add dee9156  [FLINK-16778][e2e] Make sure all java e2e tests are running
     add 8fcadbf  [hotfix] Remove unused method in TaskExecutorProcessUtils
     add d05d752  [hotfix] add int type to JOB_MANAGER_HEAP_MEMORY_MB option
     add a39630d  [hotfix] change type of JOB_MANAGER_HEAP_MEMORY option from String to MemorySize
     add 3e754ed  [FLINK-16615] Introduce data structures and utilities to calculate Job Manager memory components
     add 69f20e9  [FLINK-15438][metrics][datadog] Report counter deltas and not totals
     add 2db31ff  [FLINK-15438][metrics][datadog] Add DCounterTest
     add e0517e0  [FLINK-16795][AZP] Increase e2e test timeout by 40min
     add 6b78fe0  [FLINK-16790][python][doc] Enables the interpretation of backslash escapes (#11526)
     add cb67adc  [FLINK-16671][python] Support for defining scopes on Python metric group (#11470)
     add cd5e3f4  [FLINK-16805][e2e] Remove pre-commit profile activation
     add 7ce9d7c  [FLINK-16786][hotfix] Fix pyarrow version in setup.py (#11517)
     add ce52f3b  [FLINK-16702] develop JDBCCatalogFactory, descriptor, and validator for service discovery
     add 358e4e7  [hotfix][jdbc] rename PostgresCatalogITCase to PostgresCatalogTest
     add 25f2d62  [FLINK-16498] connect PostgresCatalog to table planner
     add 6a08051  [FLINK-16411][AZP] Use google mvn mirror globally
     add 8cf8d8d  [FLINK-16810][jdbc] add back PostgresCatalogITCase
     add ebb9f59  [hotfix][connector] Correct exception message (#11523)
     add eeb9108  [hotfix][jdbc] add license header to PostgresCatalogITCase
     add 7feba94  [FLINK-16127][docs-zh] Translate "Fault Tolerance Guarantees" page of connectors into Chinese
     add 66c2913  [FLINK-16128][docs-zh] Translate "Google Cloud PubSub" page into Chinese
     add e91bbcf  [hotfix][python] Improve the imports to use full path when importing a PyFlink module (#11525)
     add 530943e  [FLINK-16647][hadoop-compatibility] Refactor HadoopUtils to extract a possible Hadoop conf util method
     add 7984d02  [FLINK-16647][hive] Hive connector should read mapred-site.xml
     add 51b1a4f  [FLINK-16647][table-runtime-blink][hive] Miss file extension when inserting to hive table with compression
     add b752bfb  [FLINK-16821][e2e] Use constant minikube version instead of latest
     add eb489cc  [FLINK-11404][web] Add load more feature to exception page
     add 42dd176  [FLINK-16825][prometheus][tests] Use Path returned by DownloadCache
     add fbfb639  [FLINK-16798][scripts] Properly forward BashJavaUtils logging output
     add 200d346  [FLINK-16826][e2e] Support copying of jars
     add 9dc7731  [FLINK-16828][prometheus][metrics] Support factories
     add d8b4679  [hotfix][coordination] Exit early for empty collection
     add 2b11932  [hotfix][tests] Rename variable
     add 22a3e8a  [FLINK-14792][coordination] Rework partition storage
     add 1ce9fcb  [FLINK-14792][coordination] Implement TE cluster partition release
     add 37d1043  [hotfix][metrics] Do not log reporter config to prevent credentials leak
     add eec8fea  [FLINK-16594][runtime] Fix typo in GlobalAggregateManager Javadoc
     add d91cd98  [FLINK-16831][e2e] Support plugin directory as JarLocation
     add 35f4ae7  [hotfix][metrics][prometheus] Add missing import
     add a0ea5e9  [FLINK-16832][metrics] Refactor ReporterSetup
     add 4308e0c  [FLINK-16222][core] Relax Plugin bounded type parameter constraint
     add 850c709  [FLINK-16222][runtime] Introduce PluginManager to ReporterSetup
     add 1a7acef  [FLINK-16222][metrics] Support loading reporters as plugins
     add e25e521  [FLINK-16222][metrics][prometheus] Add plugin e2e test
     add 4f6efed  [FLINK-15100][connector/common] Add abstract implementation for SourceReader (FLIP-27).
     add ff0d0c9  [FLINK-16262][connectors/kafka] Set the context classloader for parallel stream in FlinkKafkaProducer
     add ae3b0ff  [FLINK-15101][hotfix] Remove the BOUNDEDNESS option from SourceReaderOptions
     add 179d7a6  [FLINK-16070] [table-planner-blink] Stream planner supports remove constant keys from an aggregate
     add f765ad0  [FLINK-16727][table-planner-blink] Fix cast exception when having time point literal as parameters
     add ea1d15c  [FLINK-16672][python] Support Counter, Gauge, Meter, Distribution metric type for Python UDF (#11543)
     add f40cd69  [FLINK-16862][quickstarts] Remove example url
     add ff491bd  [FLINK-13483] Retry delete when checking path existence in AbstractHadoopFileSystemITTest
     add 0dad640  [FLINK-16806][operators] Fix shouldSetAvailableForAnotherInput for MultipleInputStreamOperator
     add f7c3d1b  [FLINK-16806][operators] Add support for InputSelection to MultipleInputStreamOperator
     add 750ef68  [hotfix][operators] Rename InputSelectable inputSelector field to inputSelectable
     add da30827  [FLINK-16741][web] Add TM log list and TM log detail page
     add 919075a  [FLINK-16847][python] Support LocalZonedTimestampType in vectorized Python UDF
     add 851a830  [FLINK-16847][python] Support TimestampType in vectorized Python UDF
     add e931515  [FLINK-14338][flink-table] Update flink table POM and NOTICE file Calcite dependency to 1.22.0
     add 7849985  [FLINK-14338][sql-parser] Bump sql parser Calcite dependency to 1.22.0
     add 07dec98  [FLINK-14338][table-planner][table-planner-blink] Implements new RelMetadataQuery extension
     add ac972cd  [FLINK-14338][table-planner][table-planner-blink] Remove usage of TableScanRule and use new TableScanFactory extension
     add 7dad5c4  [FLINK-14338][table-planner][table-planner-blink] Tweak implementations due to API change
     add 10c8392  [FLINK-14338][table-planner][table-planner-blink] Remove redundant code copy because the bugs are already fixed in Calcite
     add 06489d1  [FLINK-14338][table-planner-blink] Plan verify changes from DIGEST to EXPLAIN
     add c41887d  [FLINK-14338][table-planner-blink] Plan verify changes from DIGEST to EXPLAIN: change plan for expand node
     add d5f45c3  [FLINK-14338][table-planner-blink] Plan verify changes from DIGEST to EXPLAIN: change plan for values node
     add 333885a  [FLINK-14338][table-planner][table-planner-blink] Update files due to builtin TUMBLE operator name changes to $Tumble
     add 8a6877d  [FLINK-14338][table-planner][table-planner-blink] Update files due to CALCITE-3763
     add 5fef3c1  [FLINK-14338][table-planner-blink] Update files due to CALCITE-1824
     add fabff4f  [FLINK-14338][table-planner][table-planner-blink] Update all kinds of left plan changes
     add 52315e7  [FLINK-16796][python] Fix the bug of Python UDTF in SQL query (#11521)
     add ee1e83c  [FLINK-16673][python] Support metric for Python UDTF (#11566)
     add e789bb7  [FLINK-16857][table-planner-blink] Support partition prune by getPartitions of source
     add 1444fd6  [FLINK-16767][hive] Failed to read Hive table with RegexSerDe
     add 979d005  [hotfix][runtime][tests] Rename/move ClassLoaderTest
     add b0dff77a [FLINK-16245][runtime] Decouple user from context classloader
     add 5f2f661  [FLINK-16245][table] Close user classloader
     add a982488  [FLINK-16245][tests] Adjust BatchFineGrainedRecoveryITCase
     add 73958cc  [FLINK-16018] Increase default value of web.timeout to 10 minutes
     add a9d634b  [hotfix][rpc] Add proper error reporting to AkkaRpcActor#handleControlMessage
     add 1e0db64  [FLINK-16703][rpc] Set AkkaRpcActor state to TERMINATING when terminating
     add 7ff9ce1  [FLINK-16836] Clear rpcConnection field in JobManagerLeaderListener when target loses leadership
     add 4519758  [FLINK-16878][e2e][table] Fix dependency shading of table modules test failure after FLINK-14338
     add a857a27  [FLINK-16849] [docs] Comment is not reasonable
     add f728eec  [FLINK-16411][AZP] Cache maven artifacts for tests as well
     add 15d42c8  [hotfix] Fix typo in org.apache.flink.sql.parser.ddl.SqlCreateTable
     add 853fc3c  [FLINK-16858][table] Expose partitioned by grammar
     add bb19563  [FLINK-16888][legal] Add jquery license
     add e0333a4  [FLINK-16807][e2e] Improve reporting for instantiation errors
     add 3bef3a7  [FLINK-16808][e2e] Consolidated logging
     add 7c3b065  [FLINK-16837][build] Disable trimStackTrace in surefire-plugin
     add f97b1b5  [FLINK-16877][table-runtime] SingleDirectoryWriter should not produce file when no input record
     add da734c3  [FLINK-16834] Add flink-clients dependency to all example modules
     add 390704e  [hotfix] Add log4j2 and logback properties file to flink-examples-table
     add 3ce6ecd  [FLINK-16834] Add flink-clients to flink-quickstarts poms
     add da46ab6  [FLINK-16834] Add flink-clients dependency to flink-walkthroughs
     add 41724c7  [FLINK-16674][python][docs] Add documentation about how to use user-defined metrics for Python UDF (#11576)
     add eb12141  [FLINK-14311] Relax restart checker to harden StreamingFileSink e2e test
     add 4412c6e  [minor] Add debug logging if aws cli command fails
     add 612e1e9  [FLINK-16035] Updated Stream/BatchTableEnvironment.java to use Java's Expression DSL
     add fab6c2a  [FLINK-16036][table-api] Deprecate String based Expression DSL in TableEnvironments
     add d39f5b3  [hotfix][table] Fix scalastyle issue
     add 0622ef7  [FLINK-16737][k8s] Remove KubernetesUtils#getContentFromFile
     add 9ffa85a  [FLINK-16535][table] BatchTableSink emitDataSet to consumeDataSet
     add c8a23c7  [FLINK-16860][orc] Distinguish empty filters from no pushed down in expainSource
     add a24734e  [FLINK-16560] Forward Configuration in PackagedProgramUtils#getPipelineFromProgram
     add 356e2b6  [FLINK-14316] Properly manage rpcConnection in JobManagerLeaderListener under leader change
     add 89522f9  [FLINK-16944][tests] Fix compile errors
     add c79c26a  [FLINK-16917][runtime] Revert FLINK-16245
     add 3fa4a7e5 [FLINK-16939][rest] Declare field taskManagerIdParameter final
     add f1c91cc  [FLINK-16940][runtime] Create currentRegion HashSet with default capacity
     add 88cd700  [hotfix][coordination] Add sanity checks to ClusterPartitionReportEntry
     add e63c31b  [FLINK-14791][coordination] ResourceManager tracks ClusterPartitions
     add d6d7158  [FLINK-16916][serialization] Fix the logic of NullableSerializer#copy
     add f93346c  [FLINK-16125][connecotr/kafka] Remove Kafka connector property zookeeper.connect and clear documentation because Kafka 0.8 connector has been removed.
     add 2b94ca6  [FLINK-16885][hive] Remove wilcard excludes that don't work on maven 3.1.X
     add b93c75b  [FLINK-16476] [table-planner-blink] Remove PowerMockito to avoid LinkageError in SelectivityEstimatorTest
     add 00526eb  [FLINK-16476] [table-planner-blink] Remove PowerMockito to avoid LinkageError in AggCallSelectivityEstimatorTest
     add 70a320b  [FLINK-16389][kafka] Bump kafka version to 0.10.2.2
     add 0629d16  [FLINK-16942][es] Allow users to override http/transport type
     add 6a42bf6  Revert "[FLINK-16535][table] BatchTableSink emitDataSet to consumeDataSet"
     add 0c94de1  [FLINK-16772][hive] Move derby dependency to test scope
     add 8d66baa  [FLINK-16921][e2e] Do not start/stop minikube in non-linux environment for k8s e2e tests
     add c3ec5b5  [FLINK-16921][e2e] Print more information for debugging when Kubernetes e2e tests failed
     add 0d20a6d  [FLINK-16921][e2e] Wait for rest endpoint up and then submit Flink job to existing Kubernetes session
     add 13ef823  [FLINK-15305][tests] Make BoundedDataTestBase#testGetSizeMultipleRegions respect system page size to avoid potential failure
     add f87734d  [hotfix][metrics] Extend MetricReporterFactory javadocs
     add db81417  [FLINK-16705] Ensure MiniCluster shutdown does not interfere with JobResult retrieval
     add 7ea3f6f  [hotfix] Add resourceManagerGateway null check to SlotPoolImpl
     add 10aadfc  [FLINK-6258] Deprecate ListCheckpointed interface
     add e25f0d3  [FLINK-16044][doc] Extract libraries documentation to a top-level section
     add c3251f5  [FLINK-16045][doc] Extract connectors documentation to a top-level section
     add dbf0c4c  [FLINK-16710][runtime] Avoid blocking TaskExecutor Main Thread
     add d2d91b6  [FLINK-16921][e2e] Describe all resources and show pods logs before cleanup when failed
     add d859ff3  [FLINK-16980][python] Fix Python UDF to work with protobuf 3.6.1 (#11631)
     add fc1df95  [FLINK-16098][docs-zh] Translate "Overview" page of "Hive Integration" into Chinese
     add bb46756  [FLINK-16913] Migrate StateBackends to use ReadableConfig instead of Configuration
     add 105379f8 [FLINK-16979][hive][build] Exclude jdk.tools
     add dd9f9bf  [hotfix] Make the checkpoint resuming e2e case pass by increasing the retained checkpoints number
     add d6efa75  [hotfix][metrics][javadocs] Fix typo
     add c982598  [FLINK-14126][e2e] Enforce elasticsearch version check
     add bf671fb  [FLINK-16981][tests] Add global PowerMock exclusions
     add 5f2f7d6  [minor] Remove --quiet from aws file fetching to help debugging
     add 1a06dd8  [FLINK-15772] Add retry to test_batch_wordcount file fetching
     add c9121f0  [FLINK-15998] In Glossary, clarify Application/Job cluster description
     add d2be6ae  [FLINK-16921][e2e] Disable K8s tests until instability is resolved
     add 7381304  [FLINK-16655][FLINK-16657] Introduce embedded executor and use it in Web Submission
     add ab123f2  [FLINK-16657] Allow the (Stream)ContenxtEnv to enforce single job execution
     add e6cea4f  [FLINK-16657] Forbid blocking calls in JobClient when in Web Submission
     add 482bff9  [minor] Rename ExecutorUtils to PipelineExecutorUtils
     add d3c149d  [FLINK-16912][parquet] Introduce table row write support for parquet writer
     add d156d09  [FLINK-16830][table-api] Let users use Row/List/Map/Seq directly in Expression DSL
     add b0e334a  [FLINK-16859][filesystem][table-runtime] Introduce file system table factory
     add 04096fc  [FLINK-14266][csv] Introduce RowCsvInputFormat to CSV module
     add 1a751a3  [hotfix][k8s] Remove the outdated comments and unused config option
     add 5b54a25  [FLINK-16749][k8s] Support to set node selector for jobmanager and taskmanager pod
     add e9603f5  [FLINK-16914][table-runtime-blink] Introduce array column vector in blink
     add 72a7ccc  [FLINK-16914][python] Support ArrayType in vectorized Python UDF
     add 2e74f25  [FLINK-16590] flink-oss-fs-hadoop: remove erroneous license references
     add 4555492  [FLINK-17007][docs] Add section 'Handling Application Parameters' in DataStream
     add aad3f7d  [FLINK-16973][tests] Add tooling for collecting jvm crash files
     add 693cb6a  [FLINK-16537][network] Implement ResultPartition state recovery for unaligned checkpoint
     add a9f3e2f  [FLINK-17010] Remove --quiet from s3 get operation
     add 989bc02  [FLINK-16817][core] StringUtils.arrayToString() doesn't convert array of byte array correctly
     add 3fd568a  [FLINK-16811][jdbc] introduce row converter API to JDBCDialect
     add 980e31d  [FLINK-16535][table] rename BatchTableSink#emitDataSet to BatchTableSink#consumeDataSet, and return DataSink
     add dd6d40f  [FLINK-16632][table-planner-blink] Fix SqlDateTimeUtils#toSqlTimestamp(String, String) may yield incorrect result
     add 5303a21  [FLINK-17040][tests] Fix SavepointWriterITCase failure because of UnsupportedOperationException
     add 1878723  [FLINK-16864][metrics] Add IdleTime metric for task
     add 86e9ec0  [FLINK-16856][scripts] Manually calculate lines of logging output
     add 562e771  [FLINK-16602][k8s] Rework the internal & external Service
     add c2c9297  [FLINK-14162][runtime] SchedulerOperations#allocateSlotsAndDeploy always deploys tasks in a bulk
     add 288750a  [FLINK-16945][checkpointing] Execute CheckpointFailureManager.FailJobCallback directly in main thread executor
     add 5e5fddb  [FLINK-9429] run-single-test.sh: fix order of "imports"
     add 7cf0f68  [FLINK-16555] Reject Enum as key type
     add c51b65a  [FLINK-17035][runtime] Add new methods to TestingSchedulingTopology
     add 10af1cc  [FLINK-17035][runtime] Replace FailoverTopology with SchedulingTopology
     add 37f5c24  [FLINK-17035][runtime] Rename method TestingSchedulingExecutionVertex#newVertex()
     add ed992fb  [FLINK-16988][table] Add core table source/sink interfaces
     add 5254920  [FLINK-16513][checkpointing] pre-requisite refactorings to add channel state to snapshot metadata
     add d6982e6  [FLINK-16513][checkpointing] add task channel state for unaligned checkpoints
     add d69d3c0  Revert "[FLINK-16864][metrics] Add IdleTime metric for task"
     add 10a5b90  [hotfix][table-api] Change QueryOperations' factories scope to default
     add 08cee24  [hotfix] Fix logical type generalization for approximate types.
     add 5d4da72  [hotfix][table-api] Add literal conversions between all numeric types.
     add 9646760  [hotfix][tabe, tests] Extract FunctionLookupMock to be reusable.
     add 446dda1  [FLINK-15812][runtime] Archive jobs asynchronously
     add 2795af3  [FLINK-16696][rest] Properly document async responses
     add 4e51682  [FLINK-16696][javadocs] Correct field name for operation result
     add 841205c  [FLINK-17047][runtime] Change SchedulingStrategy#onPartitionConsumable(…) to take IntermediateResultPartitionID instead of ResultPartitionID
     add 0d21f47  [FLINK-17047][runtime] Remove the producerId param from SchedulingStrategy#onPartitionConsumable(…)
     add b29af7d  [FLINK-17036][metrics][datadog] Support EU data center
     add 6f235b0  [FLINK-16666][table][python] Introduce Python dependency config options
     add ef1c7a0  [FLINK-17065][python][doc] Add documentation about the Python versions supported for PyFlink (#11685)
     add 36e5972  [FLINK-17062][python] Fix the conversion from Java row type to Python row type
     add b8f0bf4  [FLINK-16864][metrics] Add IdleTime metric for task This pr adds an IdleTime metric which measures idle time of a task including the time cost for mail processor to wait for new mail and the time cost in record writer to waiting a new buffer.
     add 61cb1fb  [FLINK-17063][table-api] Make null type be a possible result of a type inference.
     add 48ca137  FLINK-16697][metrics][jmx] Disable rebinding
     add 6846522  [FLINK-15817][k8s] Clean up residual resources when failed to deploy a new Cluster
     add 492d8fd  [FLINK-16687][python] Support Python UDF in Java Correlate (#11650)
     add e5d8f3d  [FLINK-16744][task][hotfix] Finalize StreamTask methods used during construction
     add 94ccf00  [FLINK-16744][task][refactor] Extract SubtaskCheckpointCoordinator
     add 97a7a10  [FLINK-16744][task] Split finish() in ChannelStateWriter
     add 53d9f36  [FLINK-16744][task] Implement channel state reading and writing for unaligned checkpoints
     add 83c8d93  [FLINK-16744][task] Send channel state handles to JM
     add dcaa814  [FLINK-16744][task][test][hotfix] Fix formatting
     add 6e296ad  [FLINK-16744][task][hotfix] Refactor SubtaskCheckpointCoordinatorImpl
     add 09e6cb0  [FLINK-9656][scripts] Take also env.java.opts from flink-conf.yaml at the client side
     add 9db0ced  [FLINK-9656][scripts] Add DEFAULT_ENV_JAVA_OPTS_CLI & KEY_ENV_JAVA_OPTS_CLI to read env.java.opts.client from flink-conf.yaml
     add 680db0d  [FLINK-9656][docs] Add env.java.opts.client to docs
     add 2c77192  [FLINK-9656] Add FLINK_CLI_JVM_OPTIONS with key env.java.opts.client
     add a03dd1b  [hotfix] Update CoreOptions JVM options to use stringType
     add c401da3  [FLINK-16668][python] Improve PythonDriver to parse python dependency info from configuration
     add 73fa677  [FLINK-17081][table-planner-blink] Extend batch integration tests with TestLogger
     add 8615625  [FLINK-16761][python] Return JobExecutionResult for Python execute method (#11670)
     add b7c8686  [hotfix][doc] Typo fixups in the concepts part of the website. (#11703)
     add 36f8f6e  [hotfix][docs] Correct english typo in streamfile sinks
     add afb4645  [FLINK-16949][test] Enhance AbstractStreamOperatorTestHarness to use customized TtlTimeProvider
     add a882498  [FLINK-16626][runtime] Prevent REST handler from being closed more than once
     add 5d9e5d4  [FLINK-16803][hive] Need to make sure partition inherit table spec when writing
     add 30311ec  [FLINK-15639][k8s] Support to set tolerations for jobmanager and taskmanger pod
     add b0719f0  [FLINK-17050][runtime] Replace usages of getResultPartition() with getResultPartitionOrThrow()
     add 3e9418c  [FLINK-17050][runtime] Remove methods getVertex() and getResultPartition()
     add 39ebaae  [FLINK-17050][runtime] Rename methods getVertexOrThrow() and getResultPartitionOrThrow()
     add eb4a211  [FLINK-17107][checkpointing] Make CheckpointCoordinatorConfiguration#isExactlyOnce() be consistent with StreamConfig#getCheckpointMode()
     add 531d6bf  [hotfix] Extract common logic of getting CheckpointingMode as StreamingJobGraphGenerator#getCheckpointingMode
     add 53755ec  [FLINK-16303][rest] Enable retrieval of custom JobManager log files
     add 865b276  [FLINK-17098][table] CatalogManager#dropTemporaryTable and dropTemporaryView should use ObjectIdentifier as its argument
     add 7280f98  [FLINK-17067][table] CatalogManager#createTable and createTemporaryTable should provide consistent semantics
     add 8127339  [FLINK-16951][parquet] Integrate parquet to file system connector
     add 3c0d5ff  [FLINK-16771][table-planner-blink] NPE when filtering by decimal column
     add 5cbb50f  [FLINK-16961][es] Bump Netty to 4.1.44
     add 5088021  [FLINK-16961][hbase] Bump Netty to 4.1.44
     add 3830402  [FLINK-16961][cassandra] Bump Netty to 4.1.44
     add 7f2166c  [FLINK-16961][python] Bump Netty to 4.1.44
     add 9ef41a4  [FLINK-16961][hive] Bump Netty to 4.1.44
     add 280f344  [FLINK-15936] Harden TaskExecutorTest#testSlotAcceptance
     add 2735fa7  [hotfix][coordination] Log if TaskExecutor#establishResourceManagerConnection fails
     add b91c059  [hotifx][tests] Remove dead code in TaskExecutorTest
     add 76064f5  [FLINK-17114][python] Set the default value of 'python.executable' to the path of the python interpreter which launches the job when the job is executed by LocalExecutor.
     add 2eec043  [FLINK-14504][rest] Rename AbstractTaskManagerHandler
     add 2ac3492  [FLINK-14504][runtime] List incomplete data sets
     add fbefc4a  [FLINK-14504][runtime] Introduce ClusterPartitionManager interface
     add 5da6ce8  [FLINK-14504][rest] Add Cluster DataSet REST API
     add ec1e863  [FLINK-17124][python] Fix PyFlink Job runs into infinite loop if Python UDF imports job code which is not enclosed in a `if name == 'main'` statement
     add d241773  [FLINK-13691][table] Remove deprecated query config
     add 485ac22  correct logs information in KafkaPartitionDiscoverer
     add 3933b04  [FLINK-16995][table-common] Add new data structure interfaces in table-common
     add 1f28494  [FLINK-16960][runtime] Rename LogicalPipelinedRegion to DefaultLogicalPipelinedRegion
     add b36c44e  [FLINK-16960][runtime] Add PipelinedRegion interface
     add 975149c  [FLINK-16748][python][doc] Add Python UDTF doc (#11531)
     add ae2b82f  [hotfix][doc] Typo fixups in the concepts/runtime part of the website. (#11740)
     add ffb9878  [FLINK-17136][doc] rename toplevel DataSet/DataStream section titles
     add 0fa0830  [FLINK-17080][java,table] Fix possible NPE in Utils#CollectHelper
     add 0f83584  [FLINK-17103][table-planner-blink] Supports dynamic options for Blink planner
     add 936cb65  [FLINK-13880][core] Correct the behavior of JobExecutionResult#getAccumulatorResult to match Javadoc
     add 231bdf3  [hotfix][runtime] Remove unused method ExecutionJobVertex#generateDebugString()
     add 48bf9fb  [FLINK-17093][python][table-planner][table-planner-blink] Fix Python UDF to make it work with inputs from composite field (#11717)
     add 893ae56  [FLINK-16222][metrics][docs] Document plugins support
     add 5d21fbe  [hotfix][rocksdb] Fix exception message
     add 0a4870d  [FLINK-16576][state backends] Fix the problem of wrong mapping between stateId and metaInfo in HeapRestoreOperation
     add 792dbf0  [FLINK-16576][state backends] Do not distribute KeyGroupsStateHandle which contains empty KeyGroupRange
     add dcdbc79  [FLINK-16887][table-planner-blink] Refactor retraction rules to support inferring ChangelogMode
     add 297f0a2  [FLINK-16822][sql-client] `table.xx` property set from CLI should also be set into TableEnvironment's TableConfig
     add 5f14987  [FLINK-15827][runtime][coordination] Deprecate unused taskmanager.registration.* options
     add 96d4dfe  [FLINK-17064][table-planner] Improve literals conversion in ExpressionConverter
     add b3292cb  [hotfix] Use UTC when converting to/from SqlTimestamp and TimestampString
     add 6acd646  [FLINK-17084][table] Implement input type inference and output type strategy for ARRAY/ROW/MAP built-in functions (#11701)
     add 3bfeea1  [FLINK-16813][jdbc] JDBCInputFormat doesn't correctly map Short
     add aa9bcc1  [FLINK-16820][jdbc] support reading timestamp, data, and time in JDBCTableSource
     add 978d7e9  [FLINK-16815][jdbc] add e2e tests for reading primitive data types from postgres with JDBCTableSource and PostgresCatalog
     add 59a71b0  [FLINK-16486][python][docs] Add documentation for vectorized Python UDF (#11724)
     add 135d2e2c [FLINK-16598][k8s] Respect the rest port exposed by Service in Fabric8FlinkKubeClient#getRestEndpoint
     add 177976b  [FLINK-16983][python] Support RowType in vectorized Python UDF (#11656)
     add 4563176  [FLINK-17152][table] Fix FunctionDefinitionUtil generate wrong resultType and acc type for AggregateFunctionDefinition
     add a49f75d  [FLINK-15486][tests] Remove timeout of LocalInputChannelTest#testConcurrentConsumeMultiplePartitions to avoid potential timeout problem on slow machine
     add 56d7f53  [FLINK-16750][e2e] Always copy and show the logs when yarn e2e tests failed
     add ef9bf36  [hotfix][sql] CliTablaeuResultViewTest runnable on Windows
     add b3b4ac5  [hotfix][sql] Add name for exector
     add 546afbe  [FLINK-17082][sql] Remove mocking in SQL client
     add b482695  [FLINK-17131][build] Downgrade javadoc-plugin
     add ee9ea10  [FLINK-16346][tests] Use fixed JobIDs
     add c96cd9c  [FLINK-16968][stats][metrics] Add StatsDReporterFactory
     add 72f9f20  [hotfix][doc] Fix typo of TaskManagerSlot#jobId javadoc
     add 1a5b35b  [FLINK-17118][python] Add Cython support for primitive data types (#11718)
     add f4a062a  [hotfix][javadocs] Fix typo
     add 577abe7  [FLINK-15790][k8s] Make some interfaces in FlinkKubeClient asynchronous which potentially blocks the execution of RpcEndpoint's main thread
     add 2669f5b  [FLINK-17172][tests] Enable DEBUG level logging in Jepsen tests
     add 5eaf2b5  [FLINK-17119][python] Add Cython support for composite types (#11767)
     add c1bc0d4  [FLINK-17128][table] Add isBounded to TableSinkFactory#Context
     add b21ef4b  [hotfix][runtime] Remove declaring of ResourceManagerException from ResourceActions#allocateResource.
     add 9479338  [hotfix][runtime] Code clean-ups in ActiveResourceManagerFactory.
     add 7286c5c  [FLINK-16437][runtime] Introduce WorkerResourceSpec for describing resource specification of a requested worker between ResourceManager and SlotManager.
     add 5b735c0  [FLINK-16437][runtime] Pass SlotManagerConfiguration into SlotManagerImpl.
     add 7089bd6  [FLINK-16437][runtime] Create SlotManagerImpl with default WorkerResourceSpec.
     add 92b30ed  [FLINK-16437][runtime] Create SlotManagerImpl with default numSlotsPerWorker.
     add 9c5a1d1  [FLINK-16437][runtime] Compute pending slot profiles inside SlotManager when allocating resource.
     add 8f43063  [FLINK-16437][runtime] ResourceManager retrieve a collection of pending workers from SlotManager, instead of number of pending slots.
     add d981c94  [FLINK-16437][runtime] Remove numSlotsPerTaskManager from ActiveResourceManager and ContaineredTaskManagerParameters.
     add 6b99a57  [FLINK-16437][runtime] SlotManager allocate resource from ResourceManager with WorkerRequest instead of ResourceProfile.
     add 3fa10a1  [hotfix] Fix PerJobMiniClusterFactory does not properly calculate numSlotsPerTaskManager.
     add 3f6080f  [FLINK-16581][table-planner-blink] Support state ttl for Mini-Batch deduplication using StateTtlConfig
     add c201e1d  Revert "[FLINK-17119][python] Add Cython support for composite types (#11767)"
     add e1ac6c9  [FLINK-17132][metrics] Bump Prometheus to 0.8.1
     add 9bed566  [hotfix][task] Avoid unnecessary actionExecutor for notifyCheckpointComplete.
     add 7327ffd  [hotfix][network] Remove unused InterruptedExceptions.
     add c172e7a  [hotfix][network] Move uncritical code out of lock in RemoteInputChannel#onBuffer.
     add 4319b01  [hotfix][task] Rename CheckpointedInputGate#cleanup to close and implement Closeable.
     add 9649d38  [hotfix][task] Narrowing checkpointing related exceptions to IOException.
     add ef6e2c4  [hotfix][task] Generalizing MailboxExecutor#execute to ThrowingRunnable.
     add b63797c  [FLINK-16587][checkpointing] Make ChannelStateWriterImpl#getWriteResult idempotent.
     add b9b761d  [FLINK-16587][coordinator] Ensuring channel deployment descriptors are lists.
     add 1007232  [FLINK-16587][checkpointing] Introducing IndexedInputGate for abstracting single channel InputGates with a specific index.
     add bde57b2  [FLINK-16587][checkpointing] Switch to positional input channel and subpartitions.
     add aed6c1a  [FLINK-16587][checkpointing] Adding unaligned checkpoint config flag.
     add dbdaa51  [FLINK-16587][checkpointing] Introduce BufferReceivedListener for notifying of received buffers and barriers from network channel.
     add 4538321  [FLINK-16587][checkpointing] Implement CheckpointBarrierUnaligner to trigger checkpoint when receiving the first barrier.
     add 825cb25  [FLINK-16587][task] Moving event creation from OperatorChain to SubtaskCheckpointCoordinatorImpl.
     add 9b0477f  [FLINK-16587][checkpointing] Implement checkpoint barrier overtake in output partitions.
     add d041efe  [FLINK-16587][checkpointing] Provide the method for getting unconsumed buffer from RecordDeserializer.
     add f661d18  [FLINK-16587][checkpointing] Provide the method of getting in-flight buffers from input gate.
     add 5cebfb7  [FLINK-16587][checkpointing] Spill the in-flight input and output buffers during checkpointing.
     add 77dce77  [FLINK-16587][checkpointing] Fix abortion of ChannelStateWriter and add test/IT cases for unaligned checkpoint.
     add d3fa2e5  Revert "[FLINK-16945][checkpointing] Execute CheckpointFailureManager.FailJobCallback directly in main thread executor"
     add cfe5a27  Revert "[hotfix] Make the checkpoint resuming e2e case pass by increasing the retained checkpoints number"
     add 5d5a29b  Revert "[FLINK-14971][checkpointing] Remove lock of PendingCheckpoint and introduce IO lock for PendingCheckpoint"
     add 214896a  Revert "[FLINK-14971][checkpointing] Remove coordinator-wide lock of CheckpointCoordinator"
     add 6adbe94  Revert "[FLINK-14971][checkpointing] Make CompletedCheckpointStore thread-safe to avoid synchronization outside"
     add e217a8c  Revert "[hotfix] Harden ResumeCheckpointManuallyITCase"
     add 2813be7  Revert "[FLINK-14971][checkpointing] Introduce main thread executor in CheckpointCoordinator to execute all non-IO operations instead of the timer thread"
     add ffa4475  Revert "[FLINK-14971][checkpointing] Handle ack/declined message of checkpoint"
     add 4ed8bb8  [FLINK-16308] [docs] Fix Maven download links for SQL connectors.
     add 4799d2e  [minor] Add ES7 to list of sql connector downloads
     add 146b34e  [FLINK-17052] Extract the Plan Generation logic from ExecutionEnvironment
     add 7b3db65  [FLINK-16967][metrics][slf4j] Add Slf4jReporterFactory
     add 5421071  [FLINK-16962][metrics][datadog] Add DatadogHttpReporterFactory
     add 9f113e4  Revert "[FLINK-17118][python] Add Cython support for primitive data types (#11718)"
     add 04337dd  [FLINK-17211] Enable JUnit 4 tests in flink-sql-parser module
     add 69cfc11  [FLINK-16921][e2e] Use kubectl instead of curl to wait for rest endpoint up
     add 9b50470  [FLINK-16921][e2e] Set service exposed type to NodePort explicitly
     add b7f16a4  [FLINK-16921][e2e] Enable K8s tests
     add 0c9ced4  [FLINK-17023][scripts] Improve handling of unexpected input
     add b6956ff  [FLINK-17132][metrics] Update licensing
     add 935313b  [hotfix][runtime] Fix import order in PipelinedRegionComputeUtil
     add cc30a4e  [FLINK-17181][runtime] Drop generic Types in Topology Interface
     add f506f0d  [FLINK-16683][scripts] Remove Windows scripts
     add d6c782f  [FLINK-16895][docs] Remove build_docs.bat
     add f960a2e  [FLINK-17142][orc] Bump ORC dependency version to 1.5.6
     add bdc6693  [FLINK-16411][AZP] Use Maven cache in the same data center
     add a20ed14  [FLINK-8864][sql-client] Add cli command history in sql client and make it avaible after restart
     add 5915277  [FLINK-16823][table-planner-blink] Fix TIMESTAMPDIFF/TIMESTAMPADD yield incorrect results
     add c1a21c6  [FLINK-15400][elasticsearch] Support dynamic index for Elasticsearch sink connector
     add 957c49d  [hotfix] Force not null types for literals with non null value
     add e69328b  [hotfix][table-api] Make ApiExpressionUtils#objectToExpressionConversion convert byte[] to a BINARY literal
     add 6b3e037  [FLINK-16379][table] Introduce fromValues in TableEnvironment.
     add 7a7aaec  [FLINK-16600][k8s] Respect the rest.bind-port config option for the Kubernetes setup
     add cb8ae28  [FLINK-17223][AZP] Clean up disk space on Azure-hosted builders
     add 6e61339  [FLINK-17068][python][tests] Ensure the permission of scripts set correctly before executing the Python tests (#11805)
     add e0d2db7  [FLINK-16366] [table] Introduce executeSql method in TableEnvironment
     add c874700  [FLINK-17118][AZP] Use rmetzger/flink-ci:ubuntu-amd64-bcef226 image which contains gcc used for PyFlink cython tests
     add 3cd8716  [FLINK-17118][python] Add Cython support for primitive data types
     add 5456360  [FLINK-17119][python] Add Cython support for composite types (#11812)
     add b8b0331  [hotfix][docs] Fix overlapping text
     add fabeb9f  Revert "[hotfix][docs] Fix overlapping text"
     add fa816c5  [FLINK-15816][k8s] Limit the value of kubernetes.cluster-id to have no more than 45 characters
     add 691fed1  [FLINK-16992][table-common] Add all ability interfaces for table sourcs and sinks
     add ac44e1e  [FLINK-17156][checkpointing][hotfix] simplify cancellation in CheckpointBarrierUnaligner
     add a7d80fb  [FLINK-17156][checkpointing] ignore cancelled checkpoints by CheckpointBarrierUnaligner
     add fe78c9b  [FLINK-17257][yarn][test] Fix AbstractYarnClusterTest not compiling with hadoop 2.10.
     add 4ed6a0f  [hotfix] Fix the code style in BashJavaUtilsITCase
     add b4618ae  [FLINK-16874] Respect the dynamic options when calculating memory options in taskmanager.sh
     add 7d65fe2  [hotfix] Add RpcUtils#terminateRpcEndpoints
     add eb56ab4  [hotfix] Add RpcUtils#INF_DURATION
     add 03b5115  [hotfix] Add RpcRuntimeException
     add 067b9c0  [hotfix] Add AkkRpcRuntimeException
     add ef0ae0b  [hotfix] Let AkkaUnknownMessageException extend AkkaRpcRuntimeException
     add db375bb  [FLINK-15347] Bump AkkRpcVersion to 2
     add 4c63f21  [FLINK-15347][tests] Add ActorSystemResource
     add f0529de  [FLINK-15347] Add SupervisorActor which monitors the proper termination of AkkaRpcActors
     add 2cf7955  [FLINK-15347] Introduce separate dispatcher for SupervisorActor
     add df30edd  [hotfix] Add FutureUtils.forwardAsync
     add 422aa89  [FLINK-15347] Add dedicated termination future executor to SupervisorActor
     add 43876ff  [FLINK-17263][table-planner-blink] Replace RepeatFamilyOperandTypeChecker with CompositeOperandTypeChecker in planner
     add 34105c7  [FLINK-17135][python][tests] Fix the test testPandasFunctionMixedWithGeneralPythonFunction to make it more stable
     add 6b80935  [FLINK-17120][python] Add Cython support for operations (#11784)
     add bda9b77  [FLINK-17013][python] Support Python UDTF in old planner under batch mode (#11668)
     add 67835fe  [FLINK-17014][runtime] TestingSchedulingTopology implements pipelined region getter interfaces
     add 99cbaa9  [FLINK-17014][runtime] Implement PipelinedRegionSchedulingStrategy
     add 3ae1da0  [FLINK-17264][scripts] Fix broken taskmanager.sh by using -ne to compare num_lines
     add 036197e  [FLINK-17266] Make WorkerResourceSpec serializable
     add 89cc0b9  [FLINK-17197][runtime] switch ContinuousFileReaderOperator state to FAILED on error
     add e806e95  [hotfix][runtime] move ContinuousFileReaderOperator unit test to the appropriate class and module
     add 7269e6c  [hotfix][runtime] rename ContinuousFileReaderOperator.TRANSITIONS to VALID_TRANSITIONS
     add a0f349f  [FLINK-16572] [pubsub,e2e] Only acknowledge list of messages if the list is not empty + small style fixes (removal of uncommented code etc)]
     add c89df66  [FLINK-16656] Introduce the DispatcherBootstrap
     add 7676360  [FLINK-16660] Add stop() to DispatcherBootstrap
     add e600dc4  [FLINK-16660] Separate the code-paths of web submission and application mode
     add 3ff4cee  [FLINK-16660] Introduce the ApplicationDispatcherBootstrap
     add 9d4fdcb  [FLINK-16658] Add ApplicationDispatcherGatewayServiceFactory for Application Mode execution
     add 52bcb21  [FLINK-16658] Add PackagedProgramRetriever
     add 74fc5a7  [FLINK-16658] Wire the ApplicationDispatcherBootstrap to the StandaloneJobClusterEntryPoint
     add e15da89  [minor] Remove unused ClassPathJobGraphRetriever
     add 8af9e21  [FLINK-16658] Make StandaloneJobClusterEntryPoint extend directly ClusterEntrypoint
     add 3ab3b57  [FLINK-16660] Make rpc timeout and retry period configurable for application mode
     add 4f55b88  [FLINK-16658] Refactor ApplicationDispatcherBootstrap and test
     add e191220  [FLINK-17249] Bump universal Kafka connector to Kafka 2.2.2
     add 2b23c4a  [hotfix][table sql planner/table sql legacy planner]fix icu license in NOTICE file
     add 9b35c28  [hotfix][docs] fix broken SVG figure and include license this time
     add 68142e5  [FLINK-16943][python] Support to set the configuration option "pipeline.jars" in PyFlink (#11768)
     add 60bfc14  [FLINK-17206][table] refactor function catalog to support delayed UDF initialization.
     add 38d8c31  [hotfix][table-sql-parser] Don't ExtendedSqlNode when not needed, remove superfluous null checks.
     add a140670  [FLINK-17003][table-sql-parser] Support parsing LIKE clause in a CREATE TABLE statement.
     add db62724  [hotfix][AZP] Re-evalute scheduled builds
     add 838badc  [FLINK-16412][hive] Disallow embedded metastore in HiveCatalog
     add 0650e4b  [FLINK-15669] [sql-client] Fix SQL client can't cancel flink job
     add 3ce6c09  [FLINK-17106][sql-parser] Support to parse TEMPORARY and IF NOT EXISTS in view definition
     add 322d589  [FLINK-17106][table-planner] Support create and drop view in both planners
     add c983ac9  [FLINK-17126][java] Introduce CollectionPipelineExecutor for CollectionEnvironment
     add cbcf2fe  [FLINK-17126][java] set `execution.target` and `execution.attached` for TestEnvironment
     add c565ec3  [FLINK-17126][table-planner] Correct the execution behavior of BatchTableEnvironment
     add 39626e2  [hotfix][typo]Fix typo in RelationalQueryCompilerTest and TpcdsTestProgram
     add a526c20  [FLINK-17121][build system][python] Adds Pipeline of Building Wheel Packages in Azure CI
     add 96c60ff  [hotfix][docs] copy concepts/*stream-processing over to zh docs
     add 889d3b8  [hotfix][docs] change KeySelector in program dataflow figure from String to lambda
     add 2527cac  [FLINK-17236][docs] Add Tutorials section overview
     add 4379b07  [FLINK-17237][docs] Add Intro to DataStream API tutorial
     add e5eb80e  [FLINK-17238][docs] Data Pipelines and ETL tutorial
     add 648750f  [FLINK-17239][docs] Streaming Analytics tutorial
     add 1d59da2  [FLINK-17240][docs] Add tutorial on Event-driven Apps
     add 315a818  [FLINK-17241][docs] Add Fault Tolerance tutorial
     add 19d9cee  [FLINK-16662] Let PackagedProgramUtils create JobGraph under the user classloader
     add 31827ff  [minor] Simplify PlanExecutor.execute() signature
     add c694954  [FLINK-16766][python] Support creating StreamTableEnvironment without passing StreamExecutionEnvironment (#11769)
     add 07667d2  [FLINK-17323][task] Return NO_MORE_DATA from ChannelStateReader for unknown channels
     add 27d1a48  [FLINK-17138][sql-client] Close catalogs when close the session
     add aa48926  [FLINK-17209][table] Allow users to specify dialect in sql-client yaml
     add 889dabb  [FLINK-16779][table] Fix RAW type creation during type inference
     add 5b54df3  [hotfix][sql-parser] Remove unused class SqlTimeUnit
     add 2bb4821  [hotfix][table] Print more details during sink type mismatches
     add ccf77f7  [FLINK-16779][table] Add RAW type support in DDL and functions
     add dcd8113  Revert "[FLINK-14499][metric] MetricRegistry#getMetricQueryServiceGatewayRpcAddress is Nonnull"
     add 1543823  [FLINK-17226][metrics][prometheus] Remove relocations
     add 8066160  [FLINK-17227][metrics][datadog] Remove relocations
     add d1f53ae  [FLINK-16669][python] Introduce PythonFunctionFactory to provide a way to get the meta information of a Python UDF used in Java
     add fa13969  [FLINK-16669][python][table] Support parse and register Python UDF via sql ddl
     add 008e0af  [FLINK-17338] Increase timeouts on LocalExecutorITCase
     add e3faf63  [FLINK-16485][python] Support vectorized Python UDF in batch mode of old planner (#11859)
     add 401290a  [FLINK-17352][docs] Fix doc links using site.baseurl w/ link tag
     add f469d9f  [hotfix] fix broken links in documentation
     add b118186  [hotfix] Add TimeUtils.toDuration
     add ab7bdf0  [hotfix] Simplify AkkaRpcService.connectInternal by relying on Akka APIs
     add 9c86077  [hotfix] Remove unused jobManagerAddress from StandaloneHAServices
     add e3b2504  [hotfix] Remove unused RESOURCE_MANAGER_RPC_ENDPOINT_NAME from StandaloneHaServices
     add 82f20cf  [hotfix] Fix checkstyle violations in StandaloneHaServices
     add 543cd85  [FLINK-17072] Add test case for random actor resolution
     add 04d6bc6  [FLINK-17072] Let ResourceManager use random endpoint id
     add c7ecfbe  [FLINK-17072] Let Dispatcher use random endpoint id
     add bf05c90  [FLINK-16473][doc][jdbc] add documentation for JDBCCatalog and PostgresCatalog
     add 681371b  [FLINK-17188][python] Use pip instead of conda to install flake8 and sphinx (#11836)
     add b917b59  [FLINK-15971][python] Adjust the default value of bundle size and bundle time (#11881)
     add 43cf121  [FLINK-16802][hive] Set schema info in JobConf for Hive readers
     add 6976e50  [FLINK-14543][table] Support partition for temporary table
     add 3a30886  [FLINK-15901][hive] Support partitioned generic table in HiveCatalog
     add ef4daeb  [FLINK-17020][runtime] Introduce GlobalDataExchangeMode for JobGraph generation
     add 26af121  [hotfix][docs] link tags in zh docs require .zh.md links
     add 91f4a3c  [FLINK-17169][core] Add shortString() method to RowKind to get short string representation
     add 7662e0b  [FLINK-17169][table-planner-blink] Rename StreamRecordUtils#record() to insertRecord()
     add 670ef41  [FLINK-17169][table-blink] Fix allowLateness shouldn't affect producing updates of emit strategy
     add bf39d75  [FLINK-17169][table-blink] Refactor BaseRow to use RowKind instead of byte header
     add eeaf08f  [FLINK-16667][python][client] Support the Python dependency configuration options in CliFrontend (#11702)
     add 948a42f  [FLINK-17344][test] Fix unstability on IdleTime metric test.
     add e48fac8  [hotfix] Remove unused docs.rest.NoOpTransientBlobService
     add 5cfa396  [hotfix] Make NoOpTransientBlobService a public testing class
     add bf0cfa6  [FLINK-17308] Pass ScheduledExecutorService to WebMonitorEndpoint
     add 3635b54  [FLINK-17308] Pass in ExecutionGraphCache to WebMonitorEndpoint
     add 08025ec  [FLINK-17308] Extract ExecutionGraphCache interface and rename impl into DefaultExecutionGraphCache
     add 8514200  [FLINK-17308] Add regular cleanup task for ExecutionGraphCache
     add fd13c2c  [hotfix][runtime] Throw exception from TestingSchedulingPipelinedRegion#getVertex() for unknown vertices
     add 23c13bb  [FLINK-17180][runtime] Implement SchedulingPipelinedRegion interface
     add 95b3c95  [FLINK-17180][runtime] Use SchedulingPipelinedRegion in RegionPartitionReleaseStrategy
     add f9c23a0  [FLINK-17180][runtime] Use SchedulingPipelinedRegion in RestartPipelinedRegionFailoverStrategy
     add efd22a7  [hotfix][filesystems] Remove unused StopWatch
     add 90fed72  [FLINK-17345][python][table] Support register and get Python UDF in Catalog (#11884)
     add deb1268  [FLINK-17021][table-planner-blink] Blink batch planner set GlobalDataExchangeMode
     add c4b44e9  [FLINK-13639] Refactor the IntermediateResultPartitionID to consist of IntermediateDataSetID and partitionIndex
     add 6128bd1  [FLINK-17175][core] StringUtils.arrayToString() should consider Object[] lastly
     add 4121292  [FLINK-16812][jdbc] support array types in PostgresRowConverter
     add f6f2fb5  [FLINK-17333][doc] add doc for 'create catalog' ddl
     add 490e2af  [FLINK-16935][table-planner-blink] Enable or delete most of the ignored test cases in blink planner.
     add 5d1c5ac  [hotfix][k8s] Remove duplicated taskManagerMemoryMB from KubernetesTaskManagerParameters.
     add 83b7138  [hotfix][k8s][test] Allowing custom slot manager in KubernetesResourceManagerTest.
     add 78603b3  [FLINK-16439][runtime] Introduce PendingWorkerCounter for counting pending workers per WorkerResourceSpec in ActiveResourceManager.
     add 98e8b0e  [FLINK-16439][k8s] KubernetesResourceManager starts workers with resources requested by SlotManager.
     add 8882b86  [hotfix][runtime][k8s] Renaming methods for better code readability.
     add bdd3978  [hotfix][yarn][test] Avoid using Mockito for Container in YarnResourceManagerTest.
     add 8b2376a  [hotfix][yarn][test] Avoid using Mockito for ContainerStatus in YarnResourceManagerTest.
     add 16a84fd  [hotfix][yarn][test] Avoid using Mockito for AMRMClientAsync in YarnResourceManagerTest.
     add a864a8e  [hotfix][yarn][test] Avoid using Mockito for NMClientAsync in YarnResourceManagerTest.
     add 47025f7  [hotfix][yarn][test] Avoid using Mockito for TaskExecutorGateway in YarnResourceManagerTest.
     add 8380081  [hotfix][yarn] Code clean-ups in RegisterApplicationMasterResponseReflectorTest.
     add a91057f  [FLINK-16438][yarn] Introduce WorkerSpecContainerResourceAdapter for converting between Flink WorkerResourceSpec and Yarn container Resource in YarnResourceManager.
     add f019356  [FLINK-16438][yarn] YarnResourceManager starts workers with resources requested by SlotManager.
     add 03da1cf  [FLINK-16438][runtime] Remove unused TaskExecutorProcessSpec from ActiveResourceManager.
     add 65e43b8  [FLINK-16438][yarn] Decide WorkerSpecContainerResourceAdapter.MatchingStrategy based on RegisterApplicationMasterResponse.
     add f095f26  [FLINK-14258][table][filesystem] Integrate file system connector to streaming sink
     add ba54a8d  [FLINK-15006][table-planner] Add option to shuffle-by-partition when dynamic inserting
     add cbaea29  Partial Revert "[FLINK-15669] [sql-client] Fix SQL client can't cancel flink job"
     add f0a4b09  [FLINK-17339][table-api] Change default planner to blink
     add 04c52f8  [FLINK-17339][table-planner] Update test cases due to default planner change.
     add 2421f94  [FLINK-17339][sql-client] Change default planner to blink.
     add cb523d3  [FLINK-17339][table-planner-blink] Simplify test cases due to default planner changing.
     add aa4e1d6  [FLINK-17339][examples] Update examples due to default planner changing.
     add a9f8a0b  [FLINK-17339][misc] Update tests due to default planner changing.
     add 237a63f  [FLINk-17268][connector/common] Fix the bug of missing records during SplitFetcher wakeup. Added unit test for SplitFetcher.
     add b7b2c43  [hotfix] Remove the unused Boundedness parameter.
     add 90a38e8  [FLINK-17268][connector/common] Fix the shutdown sequence in SplitFetcher to avoid blocking on shutdown. Fix flaky SourceReaderTestBase#testAvailableOnEmptyQueue().
     add 4540a83  [hotfix][checkpointing] Make CheckpointBarrierUnaligner#processEndOfPartition always return false
     add 9069ac4  [hotfix] Add more information to CheckpointCoordinatorConfiguration#toString
     add 2e313f0  [FLINK-16404][runtime] Avoid caching buffers for blocked input channels before barrier alignment
     add c9dfea3  [hotfix] Remove unused TOTAL_FLINK_MEMORY_MB field
     add 7d0b593  [hotfix] Fix checkstyle violations in TaskExecutorPartitionLifecycleTest
     add a98fa3e  [hotfix] Let TaskExecutorOperatorEventHandlingTest extend TestLogger
     add cc59395  [FLINK-17301][tests] Use proper AkkaRpcService for TaskManagerRunnerStartupTest
     add af1d21f  [FLINK-17301][tests] Set BIND_HOST to localhost in TaskManagerRunnerStartupTest
     add 3baa833  [hotfix][runtime] Code clean-ups in BashJavaUtils and its test cases.
     add 38b341b  [FLINK-16742][dist] config.sh does not assume BashJavaUtils always return two lines of results.
     add e7d68f1  [FLINK-16742][runtime] Ignore unknown command line options for BashJavaUtils.
     add 70b0a73  [FLINK-16742][dist] Extend and use BashJavaUtils for JM memory configuration in start-up scripts.
     add a7923fd  [FLINK-16472][dist] Remove unused memory configuration logics from config.sh.
     add 0f5132d  [FLINK-16742][runtime] Refactor BashJavaUtils, move to separated package and extract configuration loading logics.
     add 113f43b  [FLINK-16745][clients] Parse JobManagerProcessSpec from Configuration into ClusterSpecification
     add c3f0ad5  [FLINK-16745][yarn] Start Yarn JM with FLIP-116 JVM memory args
     add 6c6e91d  [FLINK-16745][k8s] Start Kubernetes JM with FLIP-116 JVM memory args
     add 679cd0f  [FLINK-16745][coordination] Remove unused container cutoff
     add 4385fcc  [hotfix] Remove 'TaskManager' from MemoryBackwardsCompatibilityUtils#getLegacyTaskManagerHeapMemoryIfExplicitlyConfigured
     add d4d8f92  [hotfix] Fix ProcessMemoryUtilsTestBase#testExceptionShouldContainRequiredConfigOptions to run also for TM
     add e1516d3  [FLINK-16746] Add default 'jobmanager.memory.process.size: 1600m' to flink-conf.yaml
     add b020aaf  [FLINK-16746][conf] Deprecate jobmanager.heap.size and expose new memory options
     add c3b3e7e  [hotfix][mesos] Deduplicate code in mesos JM start bash scripts
     add 47cf0c5  [FLINK-17048][mesos] Add memory related JVM args to Mesos JM startup scripts
     add 2452321  [FLINK-17359] Fix EntropyInjector to resolve entropy for ClassLoaderFixingFileSystem
     add bd3be00  [hotfix] Set kafka-schema-registry-client to 4.1.0 in NOTICE
     add b7ce611  [FLINK-10911][scala-shell] Enable flink-scala-shell with Scala 2.12
     add aed8c19  [FLINK-17313] Fix type validation error when sink table ddl contains columns with precision of decimal/varchar (#11848)
     add 9665c29  Revert "[FLINK-10911][scala-shell] Enable flink-scala-shell with Scala 2.12"
     add b41f09f   [FLINK-16965][metrics][graphite] Add GraphiteReporterFactory
     add 80715fe  [FLINK-17009] Move Java lambda and Scala Extension doc under streaming section
     add b3aa6eb  [FLINK-17009] Copy What is a Collection and Anatomy from api_concepts.md to datastream_api.md
     add 7f05db3  [FLINK-17009] Copy Lazy Evaluation from api_concepts.md to datastream_api.md
     add cb3ddf1  [FLINK-17009] Add intro to KeyedDataStream in state.md
     add 3308972  [FLINK-17009] Copy Specifying Keys from api_concepts.md to state.md
     add ba9d2c3  [FLINK-17009] Copy Specifying Keys section to DataSet documentation
     add 70e0b6e  [FLINK-17009] Remove tuple/expression keys from state.md
     add f851f41  [FLINK-17009] Copy UDF section from api_concepts.md to toplevel DataStream section
     add 0a747ac  [FLINK-17009] Move Supported Data Type from api_concepts.md to types_serialization.md
     add 1f6ad19  [FLINK-17009] Copy Accumulators & Counters from api_concepts.md to user_defined_functions.md
     add 5354502  [FLINK-17009] Remove api_concepts.md
     add 9bdde27  [FLINK-17395][release][python] Add the sign and shasum logic for PyFlink wheel packages
     add 0a12db0  [FLINK-16971][python][sql-client] Support Python UDF in SQL Client.
     add 58171eb  [hotfix][yarn] Code clean-ups in WorkerSpecContainerResourceAdapter.
     add 537a564  [FLINK-17390][yarn] Fix Hadoop 2.10+ compatibility for WorkerSpecContainerResourceAdapter.
     add b9fe201  [hotfix][runtime] Code clean-ups in ResourceManagerRuntimeServices.
     add 63b13c5  [hotfix][runtime] Code deduplication in ResourceManagerFactory and its implementations.
     add c47ee28  [FLINK-16440][runtime][metrics] Introduce SlotManagerMetricGroup for registering related metrics inside SlotManager.
     add 5330e9b  [FLINK-16440][core] Introduce multiplication for Resource.
     add e7e5e1d  [FLINK-16440][runtime] Introduce multiplication for ResourceProfile.
     add 44fde5d  [FLINK-16440][runtime] Extend ResourceOverview and TaskManager(Details)Info for registered/free resources.
     add c18ba69  [FLINK-17315][tests] Increased timeouts of UnalignedCheckpointITCase.
     add 9a96609  [hotfix][docs] Fix typo
     add c078ccf  [FLINK-17311][python] Change the version of cython to 0.29.16
     add 4fdde55  [FLINK-17311][AZP] Add the logic of compressed in tgz before uploading artifacts
     add 4f106c5  [FLINK-17074] Deprecate java Datastream.keyBy methods that do not use KeySelector
     add ccb7d1e  [FLINK-17074] Deprecate java Datastream.partitionCustom methods that do not use KeySelector
     add f7eb01e  [FLINK-17074] Deprecate scala Datastream.keyBy methods that do not use KeySelector
     add db3c341  [FLINK-17074] Deprecate scala Datastream.partitionCustom methods that do not use KeySelector
     add ddf6a0d  [FLINK-17210][sql-parser][hive] Implement database DDLs for Hive dialect
     add eddd91a  [hotfix] Remove site.baseurl from {% link %} tags
     add ea51116  [FLINK-17111][table] Support SHOW VIEWS in Flink SQL
     add c955eb3  [FLINK-17432][docs-training] Rename Tutorials to Training for better SEO (#11931)
     add 5d9a9b8  [FLINK-10114] Add ORC BulkWriter support for StreamingFileSink
     add e850398  [FLINK-17334][hive] Flink does not support HIVE UDFs with primitive return types
     add 02978da  [FLINK-16645][network] Limit the maximum backlogs in subpartitions
     add 2296487  [FLINK-16996][table-common] Add necessary methods to internal data structures
     add 130967a  [FLINK-16996][table-common] Add binary implementations of internal data structures
     add c69d67c  [FLINK-16996][table-runtime-blink] Implement all the data structures and serializers around RowData
     add 264d685  [FLINK-16996][table-runtime-blink] Remove legacy data formats (BaseRow)
     add 4ff59a7  [FLINK-16996][table] Refactor planner and runtime to use new data structures
     add 1481f3d  [FLINK-16996][python] Refactor pyflink to use new data structures
     add b2c4092  [FLINK-16996][parquet] Refactor parquet connector to use new data structures
     add b8fa6f6  [FLINK-16996][orc] Refactor ORC connector to use new data structures
     add f622530  [FLINK-16996][hive] Refactor Hive connector to use new data structures
     add f4999cd  [FLINK-17414][python][docs] Update the documentation about PyFlink build about Cython support
     add dcc469f  [FLINK-17391][filesystem] sink.rolling-policy.time.interval default value should be bigger
     add cc9b6ea  [FLINK-17455][table][filesystem] Move FileSystemFormatFactory to table common
     add 9cb1ebd  [hotfix][runtime] Add sanity check to SlotManagerConfiguration
     add 026a2b6  [FLINK-16605][core][config] Add slotmanager.max-number-of-slots config option
     add 9e69b27  [FLINK-16605][runtime] Pass the slotmanager.max-number-of-slots to the SlotManagerImpl
     add dcf9cc6  [FLINK-16605][runtime] Make the SlotManager respect the max limitation for slots
     add f87e120  [hotfix][tests] Deduplicate code in SlotManagerImplTest
     add 4a1363f  [hotfix][network] Rename ResultPartitionWriter#initializeState to #readRecoveredState
     add 59ae237  [hotfix][checkpointing] Use practical ChannelStateReader instead of NO_OP
     add 72f528d  [FLINK-17440][network] Resolve potential buffer leak in output unspilling for unaligned checkpoints
     add 1855bf3  [FLINK-16423][e2e] Introduce timeouts for HA tests
     add b973b75  [FLINK-17374][travis] Remove travis-related files
     add 1c67c5f  [FLINK-17374][travis] Remove tools/travis directory
     add c379d1c  [FLINK-17374][travis] Further removals of travis-mentions
     add 2e475477 [FLINK-17254][python][docs] Improve the PyFlink documentation and examples to use SQL DDL for source/sink definition.
     add c54293b  [FLINK-17148][python] Support converting pandas DataFrame to Flink Table (#11832)
     add 55e8d1a  [FLINK-15591][sql-parser] Support parsing TEMPORARY in table definition
     add dca4a77  [FLINK-15591][table] Support create/drop temporary table in both planners
     add 774132a  [hotfix][docs] fix some typos in elasticsearch connector
     add 9bef952  [FLINK-14241][test] Add arm support for docker test
     add 4aa9cf1  [FLINK-17325][orc] Integrate orc to file system connector
     add 39345e0  [FLINK-13390][checkpointing] Clarify the exact meaning of state size when executing incremental checkpoint
     add 6b5d294  [FLINK-17461][formats][json] Support JSON serialization and deseriazation schema for RowData type
     add 4c15a50  [hotfix][javadocs] Fix typo
     add 8651234  [FLINK-17370][table-common] Ensure deterministic type inference extraction
     add 6d19a40  [hotfix][table-common] Reduce number of public extraction classes
     add ac903e7  [FLINK-17471][python] Move the LICENSE and NOTICE file to the package root of the PyFlink source distribution. (#11956)
     add bdf4f71  [FLINK-17436][python] Fix the IllegalAccessError caused by package-private access control when submitting Python job via "flink run". (#11930)
     add 1fe57ab  [FLINK-17373][table] Support the NULL type for function calls
     add 473ce29  [FLINK-14652][checkpointing] Refactor notifyCheckpointComplete to SubtaskCheckpointCoordinator
     add 4b4a550  [minor] Remove empty check in ConfigUtils#encodeCollectionToConfig()
     add 4d9e67a  [FLINK-16661] Allow to set ApplicationStatus when shutting down cluster
     add 93d4c35  [FLINK-16661] Move the ClassPathPackagedProgramRetriever to flink-clients
     add 3c4cd5c  [FLINK-16661][yarn] Add the YarnApplicationClusterEntryPoint
     add 7f49ec9  [FLINK-16661] Consolidating code in ApplicationClusterEntrypoints
     add 5e65d58  [FLINK-16661] Add support for Application Mode to Yarn
     add e2ccf81  [FLINK-16661][cli] Add the 'run-application' command
     add d553c7f  [FLINK-16661][cli] Fix log configuration forwarding for yarn application mode
     add f42c14e  [FLINK-16661] Move the static job id setting to ApplicationDispatcherBootstrap
     add 59f3040  [FLINK-16661] Add YARN application end-to-end test
     add 9e8ad72  [minor] Move getUsrLibDir() to YarnEntrypointUtils
     add ddf9bbb  [FLINK-16661] Report the correct ApplicationStatus when job cancelled
     add 440755d  [minor] Verify cluster shutdown status in ApplicationDispatcherBootstrap
     add fe78fde  [FLINK-17125][python] Add a Usage Notes Page to Answer Common Questions Encountered by PyFlink Users
     add 9740469  [hotfix] Fix formatting on python common questions
     add 1f036d7  [FLINK-17315][tests] Temporary disable UnalignedCheckpointITCase.
     add 8ab08cc4 [hotfix] fix donwload link
     add 7c53d71  [hotfix] Add comments to FileType enum values
     add 42a4dfd  [hotfix] Factor out putTransientBlobStream from requestFileuploadFilePath
     add 0294409  [FLINK-14816] Add thread dump feature for taskmanager
     add 4dc1f7e  [FLINK-14816] Let TaskManagerThreadDumpHandler return JSON response
     add 261e721  [FLINK-16901][legal] Correctly handle the THIRD_PARTY_NOTICES file in kinesis connector bundled dependency
     add 18af2a1  [FLINK-16103][docs-zh] Translate "Configuration" page of "Table API & SQL" into Chinese
     add 28185fc  [FLINK-17423][python] Support Java UDTF and UDAF in Blink planner under batch mode for PyFlink
     add d385f20  [FLINK-17473][tests] Remove unused test utilities
     add 51f373e  [FLINK-16034][table-api, docs] Updat documentation with new Java Expression DSL (#11533)
     add 7d6aa34  [FLINK-17483][legal] Update flink-sql-connector-elasticsearch7 NOTICE file to correctly reflect bundled dependencies
     add d6439c8  [FLINK-17499][state-processor-api] LazyTimerService used to register timers via State Processing API incorectly mixes event time timers with processing time timers
     add 7b2f000  [FLINK-17489][core] Support any kind of array in StringUtils.arrayAwareToString()
     add 2849e39  [FLINK-17515][yarn] Move YARN staging functionality to a separate class
     add a737cdc  [FLINK-17496][kinesis] Upgrade amazon-kinesis-producer to 0.14.0
     add f90740f  [FLINK-17420][table sql / api]Cannot alias Tuple and Row fields when converting DataStream to Table (#11951)11951)
     add 4cb58e7  [FLINK-17244][docs] Update the Getting Started page (#11988)
     add ed40049  [FLINK-15101][connector/common] Add the SourceCoordinator implementation
     add 5aec41d  [hotfix][table-common] Improve terminology around catalog table options
     add 5adbba8  [hotfix][table-common] Enable receiving isBounded in DynamicTableSink
     add fef974d  [FLINK-16997][table-common] Add new factory interfaces and discovery utilities
     add 04ab8d2  [FLINK-17332][k8s] Fix restart policy not equals to Never for native task manager pods
     add b1e436a  [FLINK-17462][format][csv] Support CSV serialization and deseriazation schema for RowData type
     add cbd24c8  [hotfix][tests] Add TestingTaskManagerActions implementation
     add 0ea539d  [FLINK-17514] Let TaskCancelerWatchDog call TaskManagerActions.notifyFatalError with non-null cause
     add 221bbf7  [FLINK-17514] Fail fatally if the TaskCancelerWatchDog encounters exception in run method
     add fdd128a  [FLINK-17514] Harden ExceptionUtils.tryEnrichTaskManagerError, .isMetaspaceOutOfMemoryError and .isDirectOutOfMemoryError to handle null values
     add c2540e4  [FLINK-17501][qs] Improve logging in AbstractServerHandler#channelRead(ChannelHandlerContext, Object)
     add 40b742f  [FLINK-17403][test] Fix invalid classpath in BashJavaUtilsITCase
     add a8cee7b  [FLINK-17255][python] Support HBase connector descriptor in PyFlink. (#11955)
     add d40cf24  [FLINK-17460][orc][parquet] Create sql-jars for parquet and orc
     add a9f72f9  [FLINK-16871][runtime] Make more build time information available at runtime
     add ccb29e9  [FLINK-16804] Deprecate all Table methods that accept expressions as a String
     add d33fb62  [FLINK-17385][jdbc][postgres] Handled problem of numeric with 0 precision
     add 4d16d84  [FLINK-16102][docs-zh] Translate /dev/table/hive/scala_shell_hive.zh.md into Chinese
     add ad46ca3  [FLINK-17416][e2e][k8s][hotfix] Disable failing test
     add c20374b  [FLINK-17306] Added open to DeserializationSchema
     add d97d75a  [FLINK-17306] Add open to KafkaDeserializationSchema
     add 8b128c9  [FLINK-17306] Add open to KinesisDeserializationSchema
     add ff07c3a  [FLINK-17306] Add open to PubSubDeserializationSchema
     add e2973f1  [FLINK-17306] Call open of DeserializationSchema in RMQ
     add cf68178  [FLINK-17306] Add open to SerializationSchema
     add 1849f3a  [FLINK-17306] Add open to KafkaSerializationSchema
     add 6aa50ed  [FLINK-17306] Add open to KinesisSerializationSchema
     add 64f4a43  [FLINK-17306] Call open of SerializationSchema in PubSub sink
     add 22334ff   [FLINK-17306] Call open of SerializationSchema in RMQ sink
     add 7a28dbe  [FLINK-12717][python] Add windows support for PyFlink (#11960)
     add a7b2b5a  [FLINK-16782][state] Avoid unnecessary check on expired entry when ReturnExpiredIfNotCleanedUp
     add fcce072  [FLINK-16029][table] Port CustomConnectorDescriptor to flink-table-common module
     add 5511009  [FLINK-16029][table] Refactor CsvTableSink to support numFiles and writeMode
     add ee9bb64  [FLINK-16029][table-planner-blink] Remove registerTableSource/registerTableSink in test cases of blink planner (use tableEnv.connect() instead).
     add a63de6e  [hotfix] Add QuadConsumer interface
     add 4b22637  [hotfix] Add QuadFunction interface
     add 7898f48  [hotfix][tests] Let TestingResourceManagerGateway accept registerJobManagerFunction
     add a6e479f  [hotfix][tests] Use self gateway in TaskExecutorPartitionLifecycleTest.testJobMasterConnectionTerminationAfterExternalReleaseOrPromotion
     add df9080b  [hotfix] Extract JobLeaderService interface + rename impl into DefaultJobLeaderService
     add ca602af  [hotfix] Fix checkstyle violations in TaskManagerServicesBuilder
     add fdac62e  [hotfix] Extract JobManagerTable interface + rename impl into DefaultJobManagerTable
     add c6e9e94  [hotfix][tests] Remove Mockito from TaskExecutorTest
     add c04be32  [hotfix] Fix checkstyle violations in LibraryCacheManager
     add 4a81322  [hotfix] Fix checkstyle violations in BlobLibraryCacheManager
     add edd8d10  [hotfix] Factor out allocateSlot method from TaskExecutor.requestSlot
     add 592d23c  [hotfix] Establish strict one to one mapping between primary and secondary key in DualKeyLinkedMap
     add 588e6fb  [hotfix] Integrate TaskExecutor.jobManagerConnections into JobManagerTable
     add 24be9cf  [hotfix][tests] Add TestingPartitionProducerStateChecker
     add ff255d0  [hotfix][tests] Make NoOpCheckpointResponder top level class
     add c2ef78d  [hotfix][tests] Add TestingLibraryCacheManager
     add dd9bcc9  [hotfix][tests] Speed up TaskManagerRunnerConfigurationTest#testTaskManagerRpcServiceShouldBindToHostnameAddress
     add deb0d53  [hotfix][tests] Speed up TaskExecutorSubmissionTest.testRequestTaskBackPressure
     add fdaf5fd  [hotfix][tests] Add TestingFatalErrorHandlerResource
     add 154a13b  [FLINK-16408] Introduce JobTable which manages the lifecycle of job services on the TaskExecutor
     add 92ef0ce  [FLINK-16408] Remove JobManagerTable and its implementations
     add 11f5c7f  [FLINK-16408] Bind job blob lifecycle to JobTable.Job
     add 7f503f2  [FLINK-16408] Bind user code class loader to lifetime of Job on TaskExecutor
     add ceca1d2  [FLINK-16408] Let TaskExecutor reuse LibraryCacheManager instances
     add ab7ec38  [hotfix][tests] Replaced some manual TestingFatalErrorHandler usages with TestingFatalErrorHandlerResource
     add 970862a  [FLINK-16408] Introduce JobTable.JobServices which allows combine more job services
     add 91a0c8c  [hotfix] Remove throws exception clause from DefaultJobLeaderService#removeJob
     add f1d6336  [FLINK-17552][network] Do not cache InputChannels in UnionInputGate
     add 552d84c  [hotfix][network] Improve error message in ChannelStateWriterImpl
     add 35aea92  [hotfix][network] Add debug message marking end of output recovery for unaligned checkpoints
     add 6548971  [FLINK-17555][python] Remove duplicate FileSystem object in descriptors (#12023)
     add 0114338  [FLINK-16638][runtime][checkpointing] Flink checkStateMappingCompleteness doesn't include UserDefinedOperatorIDs
     add 967b89c  [FLINK-17092][python] Add retry when pip install dependencies (#12024)
     add 1de54fe  [FLINK-17251] [table] Introduce Table#executeInsert & add insert statement support to TableEnvironment#executeSql
     add 66f1e90  [FLINK-16529][python] Add ignore_parse_errors() method to Json format in python API
     add 485a34d  [FLINK-16104][docs-zh] Translate "Streaming Aggregation" page of "Table API & SQL" into Chinese
     add 0d1738b  [FLINK-17256][python] Support keyword arguments in the PyFlink descriptor API
     add 59ca355  [FLINK-17267] [table-planner] legacy stream planner supports explain insert operation
     add 2fc82ad  [FLINK-17267] [table-planner] legacy batch planner supports explain insert operation
     add 6013a62  [FLINK-17267] [table] TableEnvironment#explainSql supports EXPLAIN statement
     add 1a5fc5f  [FLINK-17267] [table] Introduce TableEnvironment#explainSql api
     add 4959ebf  [FLINK-17267] [table] Introduce Table#explain api
     add 7c5ac35  [hotfix][docs][s3] Clarify wording of S3 Filesystem support
     add 571c089  [FLINK-17570] Fix recursive call in BatchTableEnvironment#fromValues
     add 288a0af  [hotfix][table-common] Make scan and sink RuntimeProvider interfaces public
     add f2d1029  [FLINK-16989][table-planner-blink] Rename current TableSourceScan into LegacyTableSourceScan
     add a38d9f6  [FLINK-16989][table-planner-blink] Support ScanTableSource in blink planner
     add 49956b5  [FLINK-17030][sql-parser] Add primary key syntax for CREATE TABLE
     add 9add89e  [FLINK-17030][sql-parser] Add primary key syntax for ALTER TABLE
     add 3765fe9  [FLINK-17030][table-planner-blink] Add primary key syntax for CREATE TABLE
     add 28ab459  [FLINK-17030][table-planner-blink] Add primary key syntax for ALTER TABLE
     add fb7ae52  [FLINK-16097][docs-zh] Translate "SQL Client" page of "Table API & SQL" into Chinese
     add 890dd8d  [FLINK-17291][docs-zh] Translate training lesson on event-driven applications to chinese
     add b8ff763  [FLINK-17204][connectors/rabbitmq] Make RMQ queue declaration consistent between source and sink
     add e6c042f  [FLINK-17568][checkpointing] Fix the issue that task may consume input data after checkpoint barrier before checkpoint is performed for unaligned checkpoint
     add 880afe8  [hotfix][tests] Remove redundant test case CheckpointBarrierAlignerTestBase#testMultiChannelSkippingCheckpoints
     add ec846ec  [FLINK-17271][docs-zh] Translate new DataStream API training
     add eb33d98  [FLINK-17585][python] PythonProgramOptions should not change the entrypoint when submitting a Java sql job which contains Python UDF. (#12051)
     add 1a734c2  [FLINK-17586][python] BatchTableEnvImpl uses the cached files registered in the ExecutionEnvironment to create the job pipeline. (#12050)
     add 61fe14f  [FLINK-17586][python] Use the real StreamExecutionEnvironment contained in DummyStreamExecutionEnvironment when translating the Python UDF physical nodes to operators. (#12048)
     add 39d70f0  [FLINK-16990][table-planner-blink] Support LookupTableSource in blink planner
     add 5bf121a  [FLINK-17564][checkpointing] Fix buffer disorder issue of RemoteInputChannel for unaligned checkpoint
     add 55d04d5  [FLINK-16367][table] Introduce TableEnvironment#createStatementSet api
     add 25cbce1  [FLINK-17452][hive] Support creating Hive tables with constraints
     add 51c7d61  [FLINK-17601][table-planner-blink] Correct the table scan node name in the explain result of TableEnvironmentITCase#testStatementSet
     add 477f39f  [FLINK-16346][runtime][tests] Use BlockingNoOpInvokable
     add 186724f  [FLINK-17286][table][json] Integrate json to file system connector
     add 1a2eb5e  [FLINK-17289][docs]Translate tutorials/etl.md to Chinese
     add 5f744d3  [FLINK-17454][python] Specify a port number for gateway callback server from python gateway.
     add d90b5e0  [FLINK-17603][table][core] Prepare Hive partitioned streaming source
     add ce6b97e  [FLINK-17567][python][release] Create a dedicated Python directory in release directory to place Python-related source and binary packages
     add cba4845  [FLINK-17369][tests] In RestartPipelinedRegionFailoverStrategyBuildingTest invoke PipelinedRegionComputeUtil directly
     add 56cc76b  [FLINK-17369][tests] Rename RestartPipelinedRegionFailoverStrategyBuildingTest to PipelinedRegionComputeUtilTest
     add fd0ef6e  [FLINK-17369][tests] Reduce visiblity of internal test methods
     add 5846e54  [FLINK-17416][e2e][k8s] Use fixed v1.16.9 because fabric8 kubernetes-client could not work with higher version under jdk 8u252
     add bbf9d95  [FLINK-17416][e2e][k8s] Enable k8s related tests
     add 3561adf  [FLINK-17523] Add call expression with a class of UDF as a parameter
     add 7cfcd33  [FLINK-17608][web] Add TM log and stdout page/tab back
     add 2160c32  [FLINK-17252][table] Add Table#execute api and support SELECT statement in TableEnvironment#executeSql
     add aa1ede9  [FLINK-16845] Adds implmentation of SourceOperator. This patch does the following: 1. Add CoordinatedOperatorFactory interface. 2. Rename SourceReaderOpertor to SourceOperator, add implementation and connect it to OperatorEventGateway. 3. Rename SourceReaderStreamTask to SourceOperatorStreamTask 4. Fix some bugs in StreamTaskMailboxTestHarness.
     add 66308f8  [FLINK-14257][table][filesystem] Integrate CSV to FileSystemTableFactory
     add 412a16f  [hotfix][network] Fix useless backlog value in BufferAndAvailability returned by RemoteInputChannel#getNextBuffer
     add 90e6358  [hotfix][network] Extract a general buffer manager for future reuse by recovered input channel
     add bcf7e28  [hotfix][network] Maintain MemorySegmentProvider from InputChannel to SingleInputGate
     add a267019  [hotfix][tests] Refactor unit tests in RemoteInputChannelTest to avoid mock way
     add d7525ba  [FLINK-16536][network][checkpointing] Implement InputChannel state recovery for unaligned checkpoint
     add 74b850cd [FLINK-17130][web] Enable listing JM logs and displaying logs by filename
     add 89d46fa  [FLINK-17609][python] Execute the script directly when user specified the entry script with "-py" (#12079)
     add 5ff6751  [FLINK-17577][table-common] SinkFormat#createSinkFormat should use DynamicTableSink.Context as parameter
     add 92f28c7  [FLINK-17434][hive] Hive partitioned source support streaming read
     add 26b2e22  [hotfix][parquet] Parquet notice file should be flink-parquet
     add 9888a87  [FLINK-17536][core] Change the config option for slot max limitation to slotmanager.number-of-slots.max
     add de9ad1b  [FLINK-17497][e2e] Properly switch to Scala 2.12 in quickstart test
     add 9f525f3  [hotfix][kafka] Remove unused method AbstractFetcher#emitRecord
     add fb9d864  [FLINK-17307] Add collector to deserialize in KafkaDeserializationSchema
     add 79a7bba  [FLINK-17309][e2e tests]TPC-DS fail to run data generator due to network issues
     add 6def38d  [FLINK-17614][table] Add project it case for partition table in filesystem connector
     add bb8d962  [FLINK-17003] Added WATERMARKS as additional LIKE clause option in parser
     add b83fa2e  [FLINK-17002] Add util for merging "tables" for CREATE TABLE LIKE
     add cbd1ab1  [FLINK-17002] Support CREATE TABLE LIKE DDL in operation converter
     add a7f02b5  [FLINK-17002] Disallow CREATE TABLE ... LIKE in legacy planner
     add c5c6b76  [FLINK-17112][table] Support DESCRIBE statement in Flink SQL
     add 0a34e4a  [FLINK-16521] Remove unused FileUtils#isClassFile
     add b9eee78  [FLINK-15841][core] Clarify that TimeWindow.intersect returns true if there is no gap
     add 099ba98  [FLINK-17342][checkpointing][hotfix] Synchronize access to CheckpointCoordinator.pendingCheckpoints
     add 842aaa6  [FLINK-17342][checkpointing][hotfix] Extract CheckpointRequestDecider Pre-requsite refactoring to change decision logic
     add 355184d  [FLINK-17342][checkpointing] Enqueue savepoint requests in UC mode
     add 486221d  [hotfix][yarn] Remove duplicated adding ship files in yarn-tests
     add c59e894  [FLINK-13938][yarn] Add yarn.provided.lib.dirs for shared libs across apps on YARN
     add 5f81a36  [hotfix] Fix Scala 2.12 build
     add de34fdd  [minor] Use FutureUtils.waitForAll() in AppDispatcherBootstrap.getApplicationResult()
     add 6f72401  [FLINK-17620] Rename StandaloneJobClusterEntryPoint to StandaloneApplicationClusterEntryPoint
     add 84574fb  [FLINK-17640][network] Temporarily disable unstable RecoveredInputChannelTest#testConcurrentReadStateAndProcessAndRelease
     add 755b576  [FLINK-17315][checkpointing] Fix NPE in unaligned checkpoint after EndOfPartition events
     add 8ebba92  [FLINK-17315][checkpointing] Disable priority event listener
     add 1eda834  [FLINK-17315][checkpointing] LocalInputChannel also checkpoints in-flight data.
     add 0d08d23  [FLINK-17315][checkpointing] Fixed SpillingAdaptiveSpanningRecordDeserializer#getUnconsumedBuffer.
     add 1e20d61  [FLINK-17315][checkpointing] Only adding buffers to inflight data of PipelinedSubpartition.
     add 71e85d8  [FLINK-17315][tests] Fix and reenable UnalignedCheckpointITCase.
     add 63f1d40  [FLINK-17307] Add collector to deserialize method of DeserializationSchema
     add 0b699b4  [FLINK-17307] Forward call to DeserializationSchema#collect with a collector in KafkaDeserializationSchemaWrapper
     add de706dd  [FLINK-17307] Add collector to deserialize in RMQ
     add 407ccc8  [FLINK-17307] Check for deserialize method with a Collector in Kinesis consumer
     add 6119c31  [FLINK-17307] Add collector to deserialize in PubSub
     add aa263f8  [FLINK-17628][python] Remove the unnecessary py4j log information. (#12098)
     add 722f844  [FLINK-17612][python][sql-client] Support Python command line options in SQL Client. (#12077)
     add 5324b0c  [FLINK-16364][table] Deprecate the methods in TableEnvironment & Table proposed by FLIP-84
     add 646be5a  [FLINK-17633][table-common] Improve FactoryUtil to align with new format option keys
     add 78b516c  [FLINK-17431][sql-parser-hive][hive] Implement table DDLs for Hive di… (#11935)
     add 3c6df77  [FLINK-16991][table-planner-blink] Rename current LogicalSink into LogicalLegacySink
     add 64c732f  [FLINK-16991][table-planner-blink] Support DynamicTableSink in blink planner
     add 83d82c1  [FLINK-17562][rest] Use correct headers for POST JobPlanHandler
     add 1e228c8  [hotfix][rest][docs] Regenerate REST documentation
     add 8b519ca  [FLINK-15154][runtime] Make blob sever respect 'jobmanager.bind-host'.
     add dbd93e9  [FLINK-15154][runtime] Use local actor system for metrics query service when using single prc service mode in local execution.
     add d22e965  [hotfix][FLINK-17591][table-planner] Fix TableEnvironmentITCase.testExecuteSqlAndToDataStream failed
     add ac54454  [FLINK-17476][tests] test recovery from snapshot created in different UC mode
     add dee9583  [FLINK-17336][CI] Update watchdog to properly kill watched process
     add 80f4afb  [FLINK-17336][CI] Increase watchdog timeout to 10 minutes
     add 09495d1  [FLINK-17648][yarn] Make YarnApplicationClusterEntryPoint use the yarn.application-master.port
     add 6a6a439  [FLINK-17537][jdbc] Refactor flink-jdbc connector structure
     add e1e7d7f  [FLINK-11086] Replace flink-shaded-hadoop-2 dependency by vanilla Hadoop dependency
     add 07330dd  [FLINK-11086][e2e] Properly add Avro JARs in SQLClientKafkaITCase
     add 90fbb94  [FLINK-11086][HBase] Skip some HBase tests in Hadoop 3
     add 082061d  [FLINK-11086][yarn] Use YARN_APPLICATION_CLASSPATH instead of flink-shaded-hadoop fat jar in tests
     add c3648da  [FLINK-11086][e2e] Use HADOOP_CLASSPATH in end to end tests
     add 75c9cf1  [FLINK-11086][AZP] Add Hadoop3 test profile to nightlies
     add 2cc63a6  [FLINK-11086][docs] Make HADOOP_CLASSPATH approach more prominent in docs
     add 47323a4  [FLINK-11086] Clean up profiles and dependency exclusions
     add 66a0dd8  [FLINK-17660][table-common] Check default constructor for structured types
     add 87c9e4d  [hotfix][docs] Fix and improve query configuration docs.
     add 56ea8d1  [FLINK-17616][tests] Temporarily increase akka.ask.timeout in TPC-DS e2e test
     add e020d73  [FLINK-10934][client] Make flink run-application could support local schema
     add c84e48c  [FLINK-10934][k8s] Support application mode for kubernetes
     add 831ca0b  [FLINK-10934][e2e] Add e2e tests for Kubernetes application mode
     add 1d9d0bf  [FLINK-10934][dist] Set log4j for Kubernetes cli
     add c781d17  [FLINK-17636][network][tests] Fix the unstable unit tests in SingleInputGateTest
     add 3771835  [FLINK-17640][network][tests] Fix the unstable unit tests in RecoveredInputChannelTest
     add 360abcc  [FLINK-17538][hbase] Refactor flink-hbase connector structure
     add 654a637  [FLINK-17604][csv] Implement format factory for CSV serialization and deseriazation schema of RowData type
     add 7e23ceb  [FLINK-17663][task][hotfix] Do not hide original exception in case of a secondary failure during task clean up
     add 0ca918d  [FLINK-17663][network] Properly support UnionInputGates with unaligned checkpoints
     add a386962  [hotfix][hive] Should clear StreamTestSink in HiveTableSourceTest
     add d45985d2 [FLINK-17646][python] Reduce the package size of PyFlink. (#12106)
     add 7b5f853  [FLINK-17679][python] Replace strlen with the Python len for cython bytes encoding (#12142)
     add bc369e2  [FLINK-17655] Remove old and long deprecated TimestampExtractor
     add 6889550  [FLINK-17655] Remove assignTimestamps from documentation
     add dcbd665  [FLINK-17654][core] Move Clock classes to flink-core to make them usable outside runtime
     add 1fb819a  [FLINK-17654][core] Minor cleanups in clock classes
     add ab86a3c  [FLINK-17654] Make Clock interfaces in flink-core PublicEvolving
     add d0bffc8  [FLINK-16946] Update user documentation for job manager memory model
     add 3bb18bb  [FLINK-17665][network] Replace isBuffer with BufferType field in BufferResponse
     add e0438f9  [hotfix][test] Disable Google PubSub Emulator e2e test on aarch64
     add f05faee  [hotfix][runtime] Remove useless class ZooKeeperCompletedCheckpointStoreITCase
     add b3cdd23  [hotfix][typo]Fix typo in task_lifecycle docs
     add b51101b  [FLINK-15138][e2e][python] Add PyFlink e2e tests
     add 381131a  [FLINK-17303][python] Support Python TableResult
     add f8fe4a4  [FLINK-17680][docs] Support @ExcludeFromDocumentation when generating REST API documentations
     add 2f0c4d4  [FLINK-16383] Set close = true in monitor/lock scope in KafkaProducer
     add 9d44834  [FLINK-16383] Add debug logging to internal Kafka Producer
     add cdec46e  [FLINK-16383] Enable DEBUG logging for internal Kafka Producer on CI
     add ff861c2  [FLINK-17578] In StreamEdge, use output tag in hashCode and equals
     add 00a3b89  [FLINK-17467][task][hotfix] Remove cast in CheckpointedInputGate
     add 2c34a8c  [FLINK-17467][task][checkpointing] Align channels on savepoint in UC mode
     add d1db7be   [FLINK-17467][task][checkpointing] Code cleanup
     add 69bcacb  [hotfix][test] Fix formatting in StatefulStreamJobUpgradeTestProgram
     add fbec926  [FLINK-17467][task][e2e] Modify existing upgrade test to verify aligned savepoints
     add 96b86fc  [FLINK-17222][table-common] Ensure deterministic field order in FieldsDataType
     add dd5d007  [FLINK-14881][s3] Bump aws-sdk-version to 1.11.754, httpclient to 4.5.9 and add aws-java-sdk-sts dependency to support WebIdentityToken
     add c1ea6fc  [FLINK-14881][kinesis] Bump aws-sdk-version to 1.11.754 to support WebIdentityToken
     add 96a6337  [FLINK-17668][table] Fix shortcomings in new data structures
     add 9fe920f  [FLINK-14807][rest] Introduce REST API for communication between clients and operator coordinators
     add 74b8bb5  [FLINK-17667][table-planner-blink][hive] Support INSERT statement for hive dialect
     add 2f76042  [FLINK-17629][json] Implement format factory for JSON serialization and deserialization schema
     add 2e6acb6  [FLINK-17387][hive] Implement LookupableTableSource for Hive connector
     add d417889  [FLINK-13811][python] Support converting flink Table to pandas DataFrame
     add ed3817b  [FLINK-12717][python] Remove script pyflink-gateway-server.sh which has been replaced with pyflink_gateway_server.py
     add be9779d  [FLINK-17710][python][hotfix] Fix unstable test for StreamSqlTests.test_execute_sql (#12160)
     add 7982281  Revert "[FLINK-17710][python][hotfix] Fix unstable test for StreamSqlTests.test_execute_sql (#12160)"
     add 70346b2  Revert "[FLINK-17303][python] Support Python TableResult"
     add 3af1756  Revert "[FLINK-17467][task][e2e] Modify existing upgrade test to verify aligned savepoints"
     add 91557c8  [FLINK-17606][table] Introduce DataGenerator connector in table
     add 282da0d  [FLINK-17596][python] Move the Python UDF runner script out of the jar of flink-python
     add 81d3e62  [FLINK-17697][jdbc] Fix JdbcFullTest.testEnrichedClassCastException is failed in JDK11
     add de724f5  [hotfix][docs] Fix Kinesis consumer example
     add f47c61a  [FLINK-17693][table] Add createTypeInformation to DynamicTableSink#Context
     add bff623a  [FLINK-17701][build] Exclude transitive jdk:tools dependency from all Hadoop dependencies.
     add 3e820a6  [FLINK-17664][table] Introduce print, blackhole connector in table
     add 3805808  [FLINK-17722][python][build system] Keeps flink-sql-client_*.jar in cache between stages
     add 9b3732d  [FLINK-17652][config] Legacy JM heap options should fallback to new JVM_HEAP_MEMORY in standalone
     add 8e574f6  [hotfix] Rename JobManagerProcessUtils#processSpecFromConfigWithFallbackForLegacyHeap to processSpecFromConfigAndFallbackToNewOptIfLegacyHeapSet
     add 965c101  [FLINK-11395][avro] Support for Avro StreamingFileSink
     add 32bd094  [FLINK-17435][hive] Hive non-partitioned source supports streaming read
     add e69d21b  Revert "[FLINK-17435][hive] Hive non-partitioned source supports streaming read"
     add f9d4428  [FLINK-17643][tests] Fix LaunchCoordinatorTest instability by completing stubbing
     add 0c038b8  [FLINK-17149][json][debezium] Introduce Debezium format to support reading debezium changelogs
     add d2b8ebb  [FLINK-17150][json][canal] Introduce Canal format to support reading canal changelogs
     add 150fa9e  [FLINK-17161][docs][docker] Document the official docker hub image and examples of how to use it
     add 24ff415  [FLINK-17218][checkpointing] Ensuring that ChannelStateWriter aborts previous checkpoints before a new checkpoint is started.
     add 89446fa  [FLINK-17218][checkpointing] Cleaning up ChannelStateWriter state after all data has been written and after sync checkpoint failure.
     add cd1f858  [FLINK-17218][tests] Adding recoverable failures and correctness checks to UnalignedCheckpointITCase.
     add 04bcc25  [FLINK-17632][yarn] Always build the packaged program in the cluster for application mode
     add 681b211  [FLINK-17632][yarn] Support to specify a remote path for job jar
     add 7bea158  [FLINK-17632][yarn] Move some variables as member of YarnApplicationFileUploader to make it more self-contained
     add 8c52ea0  [minor] Refactoring the ClassPathPackagedProgramRetriever creation
     add f3681d2  [hotfix][yarn] Add validation in YarnClusterDescriptor when parsing provided lib directories
     add 6d97318  [FLINK-17729][yarn] Make mandatory to have lib/, plugin/ and dist in yarn.provided.lib.dirs
     add 01abc3f  [FLINK-17724][python] Set working directory before running the Python helper scripts.
     add de5e631  [hotfix][python] Shows only the slowest 20 tests
     add 3f487c9  [FLINK-17590][fs-connector] Support bucket lifecycle listener in streaming file sink buckets
     add bb11993  [FLINK-17435][hive] Hive non-partitioned source supports streaming read
     add da16f9e  [FLINK-16624][k8s] Support user-specified annotations for the rest Service
     add 32b79d1  [FLINK-17748][table] Remove registration of TableSource/TableSink in table env
     add d17a2e0  [hotfix] fix table walkthrough due to removing TableSource & TableSink registration
     add a7559e5  [hotfix] fix e2e test due to removing TableSource & TableSink registration
     add 677867a  [FLINK-17450][sql-parser][hive] Implement function & catalog DDLs for Hive dialect
     add 9207b81  [FLINK-17727][task] don't create output stream with no channel state (unaligned checkpoints)
     add 91932cc  [FLINK-17727][e2e] Re-enable "[FLINK-17467][task][e2e] Modify existing upgrade test to verify aligned savepoints" after a fix
     add 25279ed  [FLINK-17587][runtime] Extract StreamingFileSinkHelper from StreamingFileSink
     add b843480  [FLINK-17587][filesystem] Filesystem streaming sink support commit success file
     add f25bf57  [hotfix] fix the import of archetype resources
     add 7a09b55  [FLINK-17737][task] use UnalignedCheckpointBarrierHandler for some calls to AlternatingCheckpointBarrierHandler
     add 0da0e15  [FLINK-17737][task] Implement close by AlternatingCheckpointBarrierHandler
     add 51c689c  [FLINK-17737][task] Skip out of order barrier in AlternatingCheckpointBarrierHandler
     add 74e3d9f  [FLINK-17350][task][hotfix] Simplify checkpoint exception handling
     add 8ea4581  [FLINK-17350][task] Fail task immediately if synchronous part snapshotState throws an exception
     add 084b4b24 post-rebase fixup! [FLINK-17350][task] Fail task immediately if synchronous part snapshotState throws an exception
     add 909a13d  [hotfix][checkpointing] Fix the invalid argument in constuctor of CheckpointCoordinatorConfiguration
     add 2b42209  [FLINK-17719][task][checkpointing] Provide ChannelStateReader#hasStates for hints of reading channel states
     add 7c6251e  [FLINK-17734][streaming] Add an operator coordinator and sink function to collect sink data.
     add 6bc61db  [FLINK-17526][avro] Support AVRO serialization and deseriazation schema for RowData type
     add 85bfb00  [FLINK-17718][avro] Integrate avro to file system connector
     add d25af46  [hotfix][table-common] Reduce conversion classes of BINARY/VARBINARY
     add 96a02ab  [hotfix][table-common] Make the usage of structured types easier
     add c2e27f0  [hotfix][table-common] Fix structured type field order
     add b02e7c0  [hotfix][table-common] Fix conversion class of element array data types
     add 8bc7442  [FLINK-16999][table-runtime-blink] Add converters for all data types and conversion classes
     add 399519d  [FLINK-16075][docs-zh] Translate "The Broadcast State Pattern" page into Chinese
     add f967bcb  [FLINK-16075][docs-zh] modification based on klion26's review
     add 367c613  [FLINK-17248] Introduce configuration for pool size of io-executor for ClusterEntrypoint and MiniCluster
     add 4c65864  [FLINK-15836][k8s] Throw fatal error in KubernetesResourceManager when the pods watcher is closed with exception
     add 3262f8d  [FLINK-15668][tests] Remove travis test stages for legacy scheduler
     add dc3a498  [FLINK-15668][tests] Remove AlsoRunWithLegacyScheduler
     add 7796f6e  [FLINK-17739][network][tests] Fix unstable ResultPartitionTest#testInitializeMoreStateThanBuffer
     add 38c92ff  [FLINK-15629][runtime] Remove LegacyScheduler class, factory and tests
     add e67b2ba  [FLINK-15629][runtime] Remove SchedulerBase#getExecutionGraph() which is not needed any more
     add 437763b  [FLINK-15629][runtime] Remove the unused param ‘restartStrategyFactory’ from SchedulerNGFactoryFactory#createSchedulerNGFactory(…)
     add 66c7e49  [FLINK-15629][runtime] Remove unused JobManagerSharedServices#restartStrategyFactory
     add 6f64213  [FLINK-15629] Unify DefaultSchedulerBatchSchedulingTest with BatchSchedulingTestBase
     add 182e6af  [FLINK-5763][state backends] Do not create local stream for savepoint of heapstatebackend
     add c5583c7  [FLINK-5763][state backends] Make savepoint selfcontain and relocatable
     add fd0946a  [hotfix][state backends] Minor code-style cleanups
     add 5bd71c3  [FLINK-5763][state backends] (follow-up) Pull scope and relative/absolut path decision out of FsCheckpointStateOutputStream
     add 21f8234  [hotfix][tests] Make FsCheckpointStateOutputStreamTest work on Windows OS
     add d6bc0d5  [FLINK-5763][state backends] (follow-up) Rework MetaData Serializers and externalPointer passing
     add 4ee41be  [hotfix][tests] Add some clarifying comment in MetadataV3SerializerTest
     add 3ba9b38  [FLINK-17694][core] Fix argument check for SimpleVersionedSerialization
     add 1cceb3e  [FLINK-10740][DataStream API] Add a utility SimpleVersionedListState
     add 61d0344  [FLINK-10740][DataStream API] Simplify SourceOperator by using SimpleVersionedListState
     add 1e4880c  [hotfix][DataStream API] Minor formatting/warnings fixes in the SourceOperator and StreamOperator code.
     add 4c723c5  [hotfix][DataStream API] Fix style and warnings for CollectSinkOperatorFactory
     add 1c9ed3d  [FLINK-17696][streaming runtime] Add CoordinatorEventDispatcher to StreamOperatorParameters
     add 939625f  [FLINK-17699][DataStream API] Initalize SourceOperator more eagerly and reduce scope or collaborators.
     add 1670f16  [FLINK-17028][hbase] Introduce a new HBase connector with new property keys
     add e341310  [FLINK-17674][state] Type OperatorCoordinator state in checkpoints strictly to ByteStreamStateHandle
     add e1fc86b  [hotfix][tests] Remove unused temp folder in CheckpointMetadataLoadingTest
     add 90e4708  [FLINK-17670][refactor] Refactor single test in CheckpointMetadataLoadingTest into finer grained tests.
     add 382cf09  [FLINK-17670][checkpointing] Savepoint handling of "non-restored" state also takes OperatorCoordinator state into account.
     add 8ad1ba3  [FLINK-17671][tests][refactor] Simplify ManuallyTriggeredScheduledExecutor for better debugability.
     add 9f30c7f  [FLINK-16177][refactor] Make test setup logic for OperatorCoordinatorSchedulerTest more flexible.
     add 2430dd8  [FLINK-17672][scheduler] OperatorCoordinators receive failure notifications on task failure instead of restarts
     add b3da4e1  [FLINK-10740][scheduler] Add failure reason to OperatorCoordinator.failTask(...)
     add 52f7b9d  [FLINK-16177][checkpointing] Integrate OperatorCoordinator fully with checkpointing.
     add 7ffa87b  [FLINK-16357][checkpointing] Offer different methods for "global restore" and "local restore" in CheckpointCoordinator
     add 8e3e9cc  [FLINK-16357][checkpointing] Only global failure/restores reset the coordinator state.
     add bfef3db  [FLINK-17702][tests][refactor] Refactor test utils to support different failover strategies.
     add 79aa7d1  [FLINK-17702][scheduler] Cancellations during failover also notify the OperatorCoordinator as "failed tasks"
     add cce715b  [FLINK-7267][connectors/rabbitmq] Allow overriding RMQSource connection
     add 6fa85fe  [FLINK-7267][connectors/rabbitmq] Allow overriding RMQSink connection
     add 1f1d756  [hotfix][docs] Fix typos in config option descriptions
     add 080248d  [hotfix][runtime] Remove useless local variable in CompletedCheckpointStoreTest3testAddCheckpointMoreThanMaxRetained
     add b0f985e  [hotfix][docs] Fix some ScalaDocs in ExecutionEnvironment.scala
     add 812d3d1  [FLINK-17582][quickstarts] Update quickstarts to use universal Kafka connector
     add 2bbf8ed  [FLINK-17448][sql-parser-hive] Implement alter DDL for Hive dialect
     add 81c3738  [FLINK-17451][table][hive] Implement view DDLs for Hive dialect
     add 7c71371  [FLINK-17428][table-planner-blink] supports projection push down on the new DynamicTableSource
     add 6a58ce0  [FLINK-17772][python] Fix to_pandas to make it work in JDK 11
     add fab8bf7  [FLINK-16966][metrics][infuxdb] Add InfluxDBReporterFactory
     add d3c3909  [FLINK-17449][sql-parser-hive] Implement ADD/DROP partitions
     add 83ae463  [hotfix][table-common] Add validateExcept() to FactoryUtil
     add 10a65ed  [hotfix][kafka] Make FlinkKafkaConsumerBase#setStartFromTimestamp to be public
     add ca46672  [FLINK-17026][kafka] Introduce a new Kafka connect or with new property keys
     add e2f2fd1  [FLINK-17757][avro] Implement format factory for Avro serialization and deserialization schema of RowData type
     add 8650e40   [FLINK-17735][streaming] Add an iterator to collect sink results through coordination rest api
     add 0ce2af0  [FLINK-17027] Introduce a new Elasticsearch 7 connector with new property keys
     add ccd2d53  [FLINK-17027] Introduce a new Elasticsearch 6 connector with new property keys
     add f631b49  [FLINK-17764][Examples] Update tips about the default planner to blink when the planner parameter value is not recognized
     add 83cd281  [hotfix] Add setupFlinkConfig to KubernetesTestBase to make sure flinkConfig is always setup before used
     add a06b1bb  [hotfix] Fix the access modifiers in WorkerSpecContainerResourceAdapter
     add 6075ed7  [hotfix] Refactor the setup function of KubernetesTestBase
     add 6b5c173  [hotfix] Extract PluginManager interface
     add f0b9808  [FLINK-17407] Introduce ExternalResourceDriver and ExternalResourceInfo interface.
     add e725526  [FLINK-17407] Introduce config options for external resource framework
     add d4d3747  [FLINK-17407] Add utility class for external resource framework
     add 2cff3d2  [FLINK-17407] Forward extended resource request to YARN.
     add 9dd1f6d  [FLINK-17407] Forward extended resource request to Kubernetes.
     add 22112f1  [FLINK-17407] Instatiate and pass ExternalResourceInfoProvider to RuntimeContext
     add 5dededa  [FLINK-17407] Get the information of external resource from FunctionContext
     add cc8bf34  [FLINK-17649][table-planner-blink] Fix hash aggregate NPE
     add 339f5d8  [FLINK-17593][fs-connector] Support arbitrary recovery mechanism for PartFileWriter
     add f850ec7  [FLINK-17594][fs-connector] Support Hadoop path-based part-file writer
     add 547c168  [FLINK-14255][hive] Integrate hive to streaming file sink
     add 95f25b2  [hotfix][tests] Reformat default flink configuration map
     add fa5206a  [hotfix][tests] Add missing space to help text
     add cd491ea  [hotfix][tests] Add option -m PEM to ssh-keygen
     add b606cba  [FLINK-17522][tests] Add details on how to run Jepsen tests
     add 32a1b17  [FLINK-15758][MemManager] Remove KeyedBudgetManager and use AtomicLong
     add 4e304d4  [FLINK-15758][MemManager] Remove MemoryManager#AllocationRequest
     add 10c29b7  [FLINK-15758][MemManager] Release segment and its unsafe memory in GC Cleaner
     add 4667286  [hotfix] remove IntelliJ '//noinspection ...' directives from MemoryManager
     add 770d7c7  Revert "[FLINK-14255][hive] Integrate hive to streaming file sink"
     add aa2f67f  Revert "[FLINK-17594][fs-connector] Support Hadoop path-based part-file writer"
     add c3a4a12  Revert "[FLINK-17593][fs-connector] Support arbitrary recovery mechanism for PartFileWriter"
     add 0341b4a  [FLINK-17593] Turn BucketStateSerializerTest into an upgrade test
     add d106da1  [FLINK-17656][tests] Migrate docker e2e tests to flink-docker
     add fa0b303  [hotfix][docker] Prevent docker-compose caching
     add bdea432  [FLINK-17163][docker] Remove flink-contrib/docker-flink
     add 22f732f  [FLINK-17165][docker] Remove flink-container/docker
     add 1297992  [FLINK-17740][docker] Remove flink-container/kubernetes
     add 29a224d  [FLINK-17408] Introduce GPUDriver and discovery script
     add 7abced6  [FLINK-15102][datastream/api] Add continuousSource() methods to the StreamExecutionEvironment.
     add f33819b  Revert "[FLINK-17593] Turn BucketStateSerializerTest into an upgrade test"
     add 1892bed  [FLINK-17386][Security] fix LinkageError not captured during security context initialization.
     add 1f668dd  [FLINK-14255][hive] Integrate hive with parquet and orc format to streaming file sink
     add adfd45f  [FLINK-16999][table] Enable new data structure converters for connectors
     add c33bab4  [hotfix][table-planner-blink] Planner should pass query's changelog mode to DynamicTableSink#getChangelogMode
     add ce843a2  [FLINK-17029][jdbc] Introduce a new JDBC connector with new property keys
     add 12b984f  [FLINK-17658] Add new TimestampAssigner and WatermarkGenerator interfaces
     add ba79c0c  [FLINK-17658] Don't mention ingestion time in new TimestampAssigner
     add 792e0cc  [FLINK-17658] Rename DefaultTimestampAssigner to RecordTimestampAssigner
     add eaef2d7  [FLINK-17659] Add common watermark strategies and WatermarkStrategies helper
     add d755e1b  [FLINK-17661] Add APIs for using new WatermarkStrategy/WatermarkGenerator
     add a9fc983  [FLINK-17661] Add WatermarkMatchers
     add 62911db  [FLINK-17661] Add test for new TimestampsAndWatermarksOperator
     add 3b309d3  [FLINK-17661] Deprecate old Watermark Assigner API
     add e0b5d51  [FLINK-17659] Rework WatermarkStrategy, add Suppliers for TimestampAssigner/WatermarkGenerator
     add 3d339de  [FLINK-17661] Add Scala API for using new WatermarkStrategy/WatermarkGenerator
     add 8e5685d  [FLINK-17669] Add WatermarkOutputMultiplexer
     add 12197b3  [minor] Fix warnings in AbstractFetcher(Test)
     add 5be27b0  [FLINK-17669] Use new WatermarkGenerator for per-partition watermarking in KafkaConsumer
     add 59714b9  [FLINK-17766] Use checkpoint lock instead of fine-grained locking in Kafka AbstractFetcher
     add a06bb9e  [FLINK-17166][dist] Add file appender for flink-console.sh
     add af06c19  [hotfix][docs] Fix broken link
     add 591aebc  [FLINK-17768][network] Disable UnalignedCheckpointITCase
     add 03f5d54  [FLINK-15670][core] Provide a utility function to flatten a recursive {@link Properties} to a first level property HashTable
     add e929c3c5 [FLINK-15670][connector] Adds the producer for KafkaShuffle.
     add 9fd02fe  [FLINK-15670][connector] Kafka Shuffle Consumer Part
     add ff1695d  [FLINK-15670][connector] Kafka Shuffle API Part
     add 78b7c71  [FLINK-15670] Kafka Shuffle Test Case + add log4j2 file
     add 1b42120  [FLINK-17692] Keep yarn.classpath in target folder to not pollute local builds
     add 0d9c46e  [FLINK-16160][table-planner-blink] Fix proctime()/rowtime() doesn't work for TableEnvironment.connect().createTemporaryTable()
     add c7f9a8c  [hotfix] Show hostname in error message
     add bf58725  Revert [FLINK-15670]
     add cfeaedd  [FLINK-17791][table][streaming] Support collecting query results under all execution and network environments
     add 50232aa  [hotfix] Remove raw class usages in Configuration.
     add 20c28ac  [FLINK-17715][sql-client] Align function DDL support with TableEnvironment in SQL client
     add dc3efe1  [FLINK-17618][dist] Update comment on how to change log level for Flink
     add 98186e7  [FLINK-17602][docs] Corrected method name in dev/stream/broadcast_state document
     add 6de4f4a  [FLINK-17681] Correct type when converting Row, Map, Array to RexNodes
     add a17da14  [FLINK-17617] Fix SQL Client autocomplete
     add fd051c9  [FLINK-17758][runtime] Remove unused AdaptedRestartPipelinedRegionStrategyNG
     add 729ed6e  [FLINK-17759][runtime] Remove unused RestartIndividualStrategy
     add bf5594c  [FLINK-17357][table-planner-blink] add DROP catalog DDL
     add cd89167  Update version to 1.12-SNAPSHOT
     add e72e270  [FLINK-15670][core] Provide a utility function to flatten a recursive Properties to a first level property HashTable
     add 50a3b0f  [FLINK-15670][connector] Adds the producer for KafkaShuffle.
     add 4b866fb  [FLINK-15670][connector] Adds the consumer for KafkaShuffle.
     add 83a8d57  [FLINK-15670][connector] Kafka Shuffle API Part
     add 1cd696d  [FLINK-15670] Kafka Shuffle Test Case + add log4j2 file
     add caabaf8  [FLINK-17543][Azure] Add timestamp to log name to allow multiple uploads per module
     add a4b41cd  [hotfix][Azure] Use 'ubuntu-16.04' for all AZP builds
     add 43c3bfa  [FLINK-17730][CI] Increase 'no output timeout' to 15 minutes
     add 417936d  [FLINK-17792][tests] Catch and log exception if jstack fails
     add 2df6aeb  [minor] Allow relative paths in LocalFileSystem
     add f1e9362  [FLINK-17593][Connectors/FileSystem] Turn BucketStateSerializerTest into an upgrade test
     add 220f7da  [FLINK-17593][Connectors/FileSystem] Support arbitrary recovery mechanism for PartFileWriter
     add 1aee2c6  [FLINK-17593] Update BucketStateSerializerTest for v2
     add 81ffe8a  [FLINK-17777][tests] Set HADOOP_CLASSPATH for Mesos TaskManagers
     add 2f13ba1  [hotfix][client] Make ConfigUtils.decodeListFromConfig return new array list and throw exception
     add b591f90  [FLINK-17796] Respect user specified classpath for application mode
     add be8c02e  [FLINK-17687][tests] Enable listing files recursively by pattern
     add 12d662c  [FLINK-17687][tests] Collect log files before tearing down Mesos
     add ed74173  [FLINK-17687][tests] Simplify collection of Mesos logs
     add a934009  [hotfix][state-processor-api] Remove BoundedStreamConfig
     add a4eb0ef  [FLINK-17506][state-processor-api] SavepointEnvironment should honour 'io.tmp.dirs' property
     add def4cbb  [FLINK-17781][coordination] Use Scheduler and MainThreadExecutor in OperatorCoordinator.Context.
     add a875235  [FLINK-17799][network] Fix performance regression in the benchmarks
     add 7934fc0  [FLINK-17506][state-processor-api] Use proper RocksDB configurations in KeyedStateInputFormat
     add f356799  [FLINK-16998][core] Add a changeflag to Row
     add b425c05  [FLINK-15813][runtime] Set default value of config “jobmanager.execution.failover-strategy” to “region”
     add 3b3ad3d  [FLINK-17594][filesystem] Support Hadoop path-based part-file writer
     add 4ba1d37  [FLINK-14255][hive] Integrate mapred record writer to hive streaming sink
     add 92f2ae1  [FLINK-16094][docs-zh] Translate /dev/table/functions/udfs.zh.md into Chinese
     add 4cfd23a  [FLINK-16076][docs-zh] Translate "Queryable State" page into Chinese
     add ce0f334  [FLINK-17786][sql-client] Fix can not switch dialect in SQL CLI
     add d0fc028  [FLINK-17790][kafka] Fix JDK 11 compile error
     add 4dc3bda  [FLINK-17353][docs] Fix Broken links in Flink docs master
     add d40abbf  [docs-sync] Synchronize the latest documentation changes into Chinese documents
     add a47c611  [FLINK-17027][hotfix] Rename back-off infix to backoff in new Elasticsearch properties
     add 92d6742  [FLINK-17626][fs-connector] Fs connector should use FLIP-122 format options style
     add 1c810e4  [FLINK-17728] [sql-client] sql client supports parser statements via sql parser
     add d2cfc43  [FLINK-17520] [core] Extend CompositeTypeSerializerSnapshot to allow migration based on outer snapshot
     add 6cda904  [FLINK-17520] [test] Simplify CompositeTypeSerializerSnapshotTest
     add 71e3339  [FLINK-17520] [test] Add test case for outer snapshot requiring migration
     add 55a21bc  [FLINK-17520] [core] Rework all implementations of CompositeTypeSerializerSnapshot#resolveOuterSchemaCompatibility
     add 87e92dd  [FLINK-17520] [doc] Use new resolveOuterSchemaCompatibility in custom serialization docs
     add 7d91197  [FLINK-17527][flink-dist] Rename yarn log4j/logback configuration files so that they could be reused
     add ca5c0a4  [FLINK-17527][flink-dist] Make kubernetes-session.sh use session log4j/logback configuration files
     add 69c7b41  [FLINK-17619] Disable commit on checkpoints if no group.id was specified for Kafka table source
     add 11644c5  [hotfix] Disable e2e execution in PRs
     add cbd9ca0  [FLINK-16383][task] Do not relay notifyCheckpointComplete to closed operators.
     add c770f8e  [FLINK-16970][dist] Bundle JMXReporter separately from dist jar
     add 260ef2c  [FLINK-17634][rest] Reject multiple registration for the same endpoint
     add 8548d37  [FLINK-17547][task][hotfix] Improve error handling 1 catch one more invalid input in DataOutputSerializer.write 2 more informative error messages
     add 6e3c5ab  [FLINK-17547][task][hotfix] Extract NonSpanningWrapper from SpillingAdaptiveSpanningRecordDeserializer (static inner class) As it is, no logical changes.
     add d7b29f7  [FLINK-17547][task][hotfix] Extract SpanningWrapper from SpillingAdaptiveSpanningRecordDeserializer (static inner class). As it is, no logical changes.
     add 67d3eae  [FLINK-17547][task][hotfix] Fix compiler warnings in NonSpanningWrapper
     add 824100e  [FLINK-17547][task][hotfix] Extract methods from RecordsDeserializer
     add 37f441a  [FLINK-17547][task] Use iterator for unconsumed buffers. Motivation: support spilled records Changes: 1. change SpillingAdaptiveSpanningRecordDeserializer.getUnconsumedBuffer signature 2. adapt channel state persistence to new types
     add 179de29  [FLINK-17547][task][hotfix] Extract RefCountedFileWithStream from RefCountedFile Motivation: use RefCountedFile for reading as well.
     add 2fcc1fc  [FLINK-17547][task][hotfix] Move RefCountedFile to flink-core to use it in SpanningWrapper
     add 5415574  [FLINK-17547][task] Use RefCountedFile in SpanningWrapper (todo: merge with next?)
     add 2aacb62  [FLINK-17547][task] Implement getUnconsumedSegment for spilled buffers
     add 31ec497  [FLINK-17763][dist] Properly handle log properties and spaces in scala-shell.sh
     add 2f18138  [FLINK-17809][dist] Quote classpath and FLINK_CONF_DIR
     add 7bed30e  [FLINK-17361] Add custom query on JDBC tables
     add 8c15ff1  [FLINK-17361] Refactor JdbcTableSourceITCase to use TableResult instead of StreamITCase
     add 7723774  [FLINK-17810][doc] Add document for K8s application mode
     add 51a0d42  [FLINK-12030][connector/kafka] Check the topic existence after topic creation using KafkaConsumer.
     add 71e6498  [hotfix][table] Improve testing implementation for the new projection push down
     add 57e4748  [FLINK-17797][connector/hbase] Align the behavior between the new and legacy HBase table source
     add 73520ca  [FLINK-17798][connector/jdbc] Align the behavior between the new and legacy JDBC table source
     add 209a975  Revert "[hotfix] Disable e2e execution in PRs"
     add 92d3f8c  [hotfix][table] Reduce friction around logical type roots
     add 567baea  [hotfix][table] Update FLIP-65 functions to new data structure converters
     add c1e3f15  [hotfix][table-planner-blink] Fix exception for invalid function signature
     add 11b5330  [FLINK-17541][table] Support inline structured types
     add f0ed29c  [FLINK-8871][checkpoint] Support to cancel checkpoing via notification on task side
     add fae6a6c  [FLINK-8871][checkpoint] Support to cancel checkpoing via notification on checkpoint coordinator side
     add 1f6b1e6  [FLINK-8871][checkpoint][tests] Add ITcase for NotifiCheckpointAborted mechanism
     add e991de1  [FLINK-17725][tests] Disable OkHttpClient timeouts for FileUploadHandlerTest
     add df16e42  [FLINK-16611][metrics][datadog] Send report in chunks
     add d7fc0d0  [FLINK-17622][connectors/jdbc] Remove useless switch for decimal in PostgresCatalog
     add 5f0183f  [FLINK-15947] Fix table implicit conversions structure
     add 4e56ca1  [FLINK-15947] Update docs with updated package structure.
     add e7f7c5e  [FLINK-17780][checkpointing] Add task name to log statements of ChannelStateWriter.
     add 34671ad  [FLINK-16922][table-common] Fix DecimalData.toUnscaledBytes() should be consistent with BigDecimla.unscaledValue.toByteArray()
     add b37626bd [FLINK-17356][jdbc][postgres] Support PK and Unique constraints
     add 02a09fe  [hotfix][table-planner-blink] Fix code generation error for CAST STRING to BYTES
     add 38ada4a  [FLINK-17356][jdbc][postgres] Add IT cases for inserting group by query into posgres catalog table
     add 400df32  [FLINK-17846][table, e2e] Fix import in flink-walkthrough-table-scala
     add ffc4ae1  [FLINK-17675][docs] Update jquery dependency to 3.5.1
     add be59c26  [hotfix][core] Add constant serialVersionUIDs to all serializable source API classes
     add 7de9d20  [hotfix][core] Add/remove missing/incorrect serialVersionUID fields in Timestamp Assigner classes
     add ae6e9e4  [hotfix][docs] Fix comment about RocksDB timer default
     add 361fbcd  [hotfix] Fix directory creation in TypeSerializerUpgradeTestBase
     add 6e7c660  [FLINK-13632] In TypeSerializerUpgradeTestBase.UpgradeVerifier return matcher instead of data
     add e68a1b5  [FLINK-13632] Port RowSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 968764c  [hotfix][core] Fix warnings in TypeSerializerUpgradeTestBase
     add 336ded4  [hotfix][core] Fix migration version comparision for 1.10
     add c0e3ddd  [hotfix][core] Add open interval in MigrationVersion
     add adbe5fc  [hotfix][core] Fix TypeSerializerUpgradeTestBase for serializer migration
     add 214b837  [FLINK-16998][core] Support backwards compatibility for upgraded RowSerializer
     add f52899a  Revert "[FLINK-17356][jdbc][postgres] Add IT cases for inserting group by query into posgres catalog table"
     add 9f3a711  [FLINK-17645][runtime] Reset SafetyNetCloseableRegistry#REAPER_THREAD if it fails to start
     add 1cf06e1  [FLINK-17817][streaming] Fix type serializer duplication in CollectSinkFunction
     add 4d1a2f5  [FLINK-17474][parquet][hive] Parquet reader should be case insensitive for hive
     add 25c151e  [FLINK-16074][docs-zh] Translate the Overview page for State & Fault Tolerance into Chinese
     add 4dbc18d  [FLINK-17356][jdbc][postgres] Add IT cases for inserting group by query into posgres catalog table
     add 2b2c574  [FLINK-17794][tests] Tear down installed software in reverse order
     add 3ab5d58  [FLINK-17842][network] Fix performance regression in SpanningWrapper#clear
     add 463dc8b  Merge pull request #12244 from pnowojski/f17258
     add 840a4d9  Revert "Merge pull request #12244 from pnowojski/f17258"
     add b3a7851  [FLINK-17258][network][test] Run ClassLoaderITCase#testDisposeSavepointWithCustomKvState without unaligned checkpoints
     add 05aa2d2  [FLINK-17258][sql][test] Fix AggregateITCase.testPruneUselessAggCall missing sorted
     add 303e008  [FLINK-17258][hotfix][network] Unify checkpoint id logging with CheckpointCoordinator
     add 2efa2ed  [FLINK-17805][hotfix][network] Fix/update/rename InputProcessorUtil.createCheckpointedInputGatePair method
     add c9fd502  [FLINK-17805][network] Fix ArrayIndexOutOfBound for rotated input gate indexes
     add 8b14cd8  [FLINK-17771][python][e2e] Fix the OOM of the PyFlink end to end test on JDK11.
     add 0d5b238  [FLINK-17504][docs] Update Chinese translation of Getting Started / Overview
     add 006ab7a  [FLINK-16911] Increase timeout in S3 ITCases
     add 50c9f9d  [FLINK-17866][core][python] Change the implementation of the LocalFileSystem#pathToFile to fix the test case failure of PyFlink when running on Windows.
     add 1e55455  [FLINK-17881][python][docs] Add documentation for PyFlink's Windows support
     add 677f1c4  [FLINK-17773] Update documentation for new WatermarkGenerator/WatermarkStrategies
     add 5680bc1  [FLINK-17876][python][docs] Add documentation on how to use Python UDF in SQL DDL
     add a47d705  [FLINK-17801][tests] Increase timeout of TaskExecutorTest.testHeartbeatTimeoutWithResourceManager
     add d184f73  [hotfix][tests] Make ClientTest extend TestLogger
     add 984aa0b  [hotfix][qs] Fix logging of exception in RequestWriteListener
     add 564e880  [FLINK-13553][qs] Add logging to AbstractServerHandler
     add 0cc7aae  [FLINK-13553][tests] Enable TRACE logging for org.apache.flink.queryablestate
     add 6186069  [FLINK-17303][python] Return TableResult for Python TableEnvironment
     add d2559d1  [FLINK-17854][core] Move InputStatus to flink-core
     add d0f9892  [FLINK-17854][core] Let SourceReader use InputStatus directly
     add 8719e26  [FLINK-17843][table-api] Check the RowKind when converting a Row from object to an expression
     add ab94738  [FLINK-17004] Document the LIKE clause of CREATE TABLE statement.
     add a91db83  [FLINK-17905][docs] Fix JDBC docs to remove the duplicate licence and markup
     add e8767af  [FLINK-16197][hive] Failed to query partitioned table when partition folder is removed
     add e345d99  [FLINK-17878][fs-connector] Transient watermark attribute should be initial at runtime in streaming file operators
     add 9ccdf06   [FLINK-17651][table-planner-blink] DecomposeGroupingSetsRule generates wrong plan
     add edfb7c4  [FLINK-17894][table] RowGenerator in datagen connector should be serializable
     add 50253c6  Merge pull request #12301 from Xeli/FLINK-16572-logs
     add 702a339  [FLINK-17822][MemMan] Use private Reference.tryHandlePending|waitForReferenceProcessing to trigger GC cleaner
     add d88c195  [FLINK-16210] Extend the Flink Architecture section with more information about Flink Master components and application execution
     add 656e8dc  [hotfix][filesystems][test] Fix improper usage of System.nanoTime().
     add e92b2bf1 [FLINK-17721][filesystems][test] Use independent timeout for each file status checking.
     add b19058a  [FLINK-17230] Fix incorrect returned address of Endpoint for external Service of ClusterIP type
     add 42077e9  [FLINK-17565][k8s] Bump fabric8 version from 4.5.2 to 4.9.2
     add ea54a54  [FLINK-17870] Fix ScalaShell executeAsync to ship all dependencies
     add 8f992e8  [FLINK-17395][python] (followups) Don't remove the dist directory during clean
     add f08c830  [FLINK-17189][table-planner] Table with proctime attribute cannot be read from Hive catalog
     add ec0288c  [FLINK-17889][hive] Hive can not work with filesystem connector
     add e215365  [FLINK-17896][hive] HiveCatalog can work with new table factory because of is_generic
     add babefb5  [FLINK-17867][hive][test] Add hdfs dependency to hive-3.1.1 test
     add dc32661  [FLINK-17456][hive][test] Update hive connector tests to execute DDL & DML via TableEnvironment
     add 808c87d  [hotfix] Remove generic row for HiveTableFactory
     add 8b1e747  [FLINK-15620][state][TTL] Remove deprecated enable default background cleanup
     add aa505a4  [FLINK-15621][state][TTL] Remove deprecated option and method to disable TTL compaction filter
     add d1292b5  [FLINK-17917][yarn] Ignore the external resource with a value of 0 in constructing InternalContainerResource
     add 32f0631  [FLINK-17814][chinese-translation]Translate native kubernetes document to Chinese
     add 784bfad  [FLINK-17929][docs] Fix invalid liquid expressions
     add 66f2132  [FLINK-17939][docs-zh] Translate "Python Table API Installation" page into Chinese
     add 6095131  [FLINK-17802][kafka] Set offset commit only if group id is configured  for new Kafka Table source
     add 1cce2c5  [hotfix][table-common] Add logical type root/family argument strategies
     add b2db9ec  [FLINK-17936][table] Introduce new type inference for AS
     add c99bf2a  [FLINK-17375][CI] Rename log4j-travis.properties
     add 2e4a4e0  [FLINK-17375] Move azure_controller into azure-pipelines folder
     add 4b602a7  [FLINK-17375] Delete unused files in tools/
     add 75cfab4  [FLINK-17375] Rename tools/travis_watchdog.sh -> tools/ci/ci_controller.sh
     add a22b130  [FLINK-17375] Refactor travis_watchdog.sh into separate ci/ and azure-pipelines/ scripts.
     add 1d2aa07  [FLINK-17375] Adopt nightly python wheels jobs to refactored ci scripts
     add f40aa77  [hotfix][AZP] execute junit test result upload also when the previous stage failed
     add cfda686  [FLINK-17076][docs] Revamp Kafka Connector Documentation
     add c8b2654  [FLINK-17756][table] Drop table/view shouldn't take effect on each other
     add 8b4fe87  [FLINK-17820][checkpointing] Respect fileSizeThreshold in FsCheckpointStateOutputStream.flush()
     add 2899d27  [hotfix] Correct comment references to flink-yarn-tests
     add 3be812d  [hotfix] Rename org.apache.flink.yarn.util.YarnTestUtils into o.a.f.y.u.TestUtils
     add e1989bf  [FLINK-17938] Move YarnTestBase.findFile and YarnTestBase.RootDirFilenameFilter to o.a.f.y.u.TestUtils
     add 93b81a3  [FLINK-17750][tests] Harden YARNHighavailabilityITCase by increasing ZK session timeout to 20s
     add cdfb030  [FLINK-17934][fs-connector] StreamingFileWriter should set chainingStrategy
     add 5a9fe5d  [FLINK-17934][fs-connector] Add listener to Buckets and remove listener for BucketsBuilder
     add 0e67f18  [FLINK-17751][table-planner-blink] Fix proctime defined in ddl can not work with over window in Table api
     add 03b6d71  [FLINK-17058] Adding ProcessingTimeoutTrigger of nested triggers.
     add 8461066  [hotfix][tests] Remove note that E2E exactly-once is not covered
     add 7e3b2cd  [hotfix][tests] Document flink-jepsen correctness model
     add a3c5455  [FLINK-17925][fs-connector] Fix Filesystem options to default values and types
     add 026cae8  [hotfix][runtime] Fix typo.
     add a97a917  [hotfix] Remove useless FlinkYarnSessionCli#logAndSysout method
     add 79a5614  [hotfix] Fix a comment error in StreamExecLocalGroupAggregate
     add dcf4cd3  [hotfix][tests][e2e] Delete empty plugin directory after moving jar
     add 3623967  [FLINK-17812][dist] Bundle reporters in plugins/ directory
     add b972b46  [FLINK-16694][ci] Limit number of dumped log lines
     add 3ec768a  [FLINK-17351] Increase `continuousFailureCounter` in `CheckpointFailureManager` for CHECKPOINT_EXPIRED
     add 506819f  [hotfix][runtime] Annotate ProcessingTimeCallback as a FunctionalInterface
     add 352c8f7  [hotfix][core] Add a constant for the special value "NO_TIMESTAMP".
     add 95c9466  [hotfix][DataStream API] Minor code cleanups
     add 067d2f0  [FLINK-17898][core] Remove Exceptions from signatures of SourceOutput methods
     add c6b5a7a  [FLINK-17897][core] Classify FLIP-27 source API to @Experimental / @PublicEvolving
     add 8e01f52  [FLINK-17903][core] WatermarkOutputMultiplexer supports String IDs and de-registration of outputs
     add 204536b  [FLINK-17096][core] Simple performance improvements in WatermarkOutputMultiplexer
     add 20713de  [FLINK-17904][runtime] Add scheduleWithFixedDelay to ProcessingTimeService
     add 5070ee9  [FLINK-17899][runtime][refactor] Make ProcessingTimeService always available to operators.
     add 4bec7fb  [FLINK-17899][core][refactor] Add a utility NoWatermarksGenerator
     add 54f1a4c  [FLINK-17899][runtime] Integrate FLIP-126 Watermarks with FLIP-27 Sources
     add 31d669e  [FLINK-17899][runtime] Remove unnecessary implementation of SourceContext in SourceOperatorStreamTask
     add 4fdcbce  [FLINK-17899][runtime] Add WatermarkStrategies to countinuousSource() methods in the DataStream API
     add b992cef  [FLINK-17950][Scala DataStream API] Fix StreamExecutionEnvironment.continuousSource(...) method
     add 0804de5  [hotfix][core] Improve JavaDocs for FLIP-27 sources.
     add 5365e40  [hotfix] Adjust License Headers for FLIP-27 sources to be same as the remaining code base
     add 3a322e0  [FLINK-16021][table-common] Fix DescriptorProperties.putTableSchema does not include PRIMARY KEY
     add b6f92fe  [FLINK-17942][table-planner-blink] Fix WindowOperator not call StateMapView.cleanup when destroying windows
     add b0dd0aa  [FLINK-17284][jdbc][postgres] Fix serial type columns not work in Postgres catalog
     add be7b7ae  [FLINK-16086][docs-zh] Translate "Temporal Tables" page of "Streaming Concepts" into Chinese
     add f47ffc2  [FLINK-17689][kafka][table] Add integration tests for changelog source and formats (#12284)
     add 8bc7695  [FLINK-17657][jdbc] Fix reading BIGINT UNSIGNED type field not work in JDBC
     add 54ea4d3  [FLINK-17861][tests][hotfix] Fix ChannelStateCheckpointWriterTest.testRecordingOffsets 1. Set writer position in NetworkBuffer passed to ChannelStateCheckpointWriter.write 2. Reduce state size to fit in the configured MemoryCheckpointOutputStream
     add 8f0a41c  [FLINK-17861][task][checkpointing] Merge channel state serializer and deserializer Motivation: 1. add a method that deserializes and then serializes data 2. simplify
     add 1b824d5  [FLINK-17861][task][checkpointing] Split channel state handles sent to JM
     add f89c606  [FLINK-17928][checkpointing] Fix ChannelStateHandle size
     add d7834fc  [FLINK-17375][hotfix] Fix print_stacktraces multiline-behavior
     add 1386e0d  [FLINK-17958][core] Fix MathUtils#divideRoundUp bug for handling zero / negative values.
     add f3088e0  [FLINK-17610][state] Align the behavior of result of internal map state to return empty iterator
     add 435bf23  [FLINK-17988][checkpointing] Discard only unique channel state delegates
     add 0179156  [FLINK-17986] Fix check in FsCheckpointStateOutputStream.write
     add 3717948  [hotfix][tests] Remove unused TestingScheduledExecutor
     add 484bba5  [hotfix][tests] Shutdown TaskmanagerServices
     add 90b8455  [FLINK-17558][runtime] Add Executors#newCachedThreadPool
     add 3a49e89  [FLINK-17558][tests] Simplify partition tracker setup
     add 67d89e7  [FLINK-17558][tests] Extract ShuffleEnvironment/PartitionTracker setup
     add 44fba5f  [FLINK-17558][netty] Release partitions asynchronously
     add 7858c94  [FLINK-13632] Remove old PojoSerializerSnapshotMigrationTest
     add c03fb57  [FLINK-17956] Add Flink 1.11 MigrationVersion
     add 51d0078  [FLINK-13632] Update TypeSerializerUpgradeTestBase for Flink 1.11
     add d31a76c  [FLINK-13632] Add Flink 1.11 snapshots for TypeSerializer upgrade tests
     add 4338308  [FLINK-13632] Port AvroSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 41ed8bc  [FLINK-13632] Port TtlSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 389c23c  [FLINK-13632] Port TupleSerializer upgrade test to TypeSerializerUpgradeTestBase
     add e0ebadb  [FLINK-13632] Port BufferEntrySerializer upgrade test to TypeSerializerUpgradeTestBase
     add eb64bb8  [FLINK-13632] Port ValueSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 9f989b2  [FLINK-13632] Port PrimitiveArraySerializer test to TypeSerializerUpgradeTestBase
     add cfda623  [FLINK-13632] Port TimerSerializer test to TypeSerializerUpgradeTestBase
     add b5ca9f9  [FLINK-13632] Port StreamElementSerializer test to TypeSerializerUpgradeTestBase
     add 12d18d3  [FLINK-13632] Port BaseTypeSerializer test to TypeSerializerUpgradeTestBase
     add b3f8c2f  [FLINK-13632] Port VoidNamespaceSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 5947c2f  [FLINK-13632] Port NullableSerializer test to TypeSerializerUpgradeTestBase
     add ce60ede  [FLINK-13632] Port ScalaOptionSerializer test to TypeSerializerUpgradeTestBase
     add a2760a3  [FLINK-13632] Port KryoSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 7747ce6  [FLINK-13632] Port NFASerializer upgrade test to TypeSerializerUpgradeTestBase
     add 83d2291  [FLINK-13632] Port ScalaTrySerializer upgrade test to TypeSerializerUpgradeTestBase
     add 354ead1  [FLINK-13632] Port MapViewSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 37f4845  [FLINK-13632] Port WindowSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 11b2fca  [FLINK-13632] Port UnionSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 2782465  [FLINK-13632] Port TwoPhaseCommitSinkStateSerializer upgrade test to TypeSerializerUpgradeTestBase
     add dc84941  [FLINK-13632] Port KafkaSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 9f04fa9  [FLINK-13632] Port ValueArraySerializer upgrade test to TypeSerializerUpgradeTestBase
     add cdaa59d  [FLINK-13632] Port MapSerializer upgrade test to TypeSerializerUpgradeTestBase
     add c8b7079  [FLINK-13632] Port CompositeSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 4eae106  [FLINK-13632] Port ListSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 719036b  [FLINK-13632] Port ArrayListSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 293b8d0  [FLINK-13632] Port CopyableSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 79a56ad  [FLINK-13632] Port WritableSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 7cf86d8  [FLINK-13632] Port ScalaEitherSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 82273dd  [FLINK-13632] Port LongValueWithProperHashCodeSerializer upgrade test to TypeSerializerUpgradeTestBase
     add c1ee4f8  [FLINK-13632] Port Kafka011Serializer upgrade test to TypeSerializerUpgradeTestBase
     add ff1e41b  [FLINK-13632] Port ListViewSerializer upgrade test to TypeSerializerUpgradeTestBase
     add a5d0eb5  [FLINK-13632] Port JavaSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 9113555  [FLINK-13632] Port LockableTypeSerializer upgrade test to TypeSerializerUpgradeTestBase
     add f02b236  [FLINK-13632] Port EnumSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 554a2e7  [FLINK-13632] Port ScalaCaseClassSerializer upgrade test to TypeSerializerUpgradeTestBase
     add 2161b16  [FLINK-13632] Port EnumValueSerializer upgrade test to TypeSerializerUpgradeTestBase
     add a60f1ee  [FLINK-13632] Port TraversableSerializer upgrade test to TypeSerializerUpgradeTestBase
     add aedb406  [FLINK-13632] Remove TypeSerializerSnapshotMigrationTestBase
     add 14e11c7  [FLINK-17882][table-common] Check for self references in structured types
     add c4a311c  [hotfix][e2e] Increase 'no activity' timeout to 15 minutes
     add 61423e9  [FLINK-17824][e2e] Introduce timeout to 'resume savepoint' test
     add a835f31  [FLINK-17865][checkpoint] Increase default size of 'state.backend.fs.memory-threshold'
     add c22d01d  [FLINK-17463][tests] Avoid concurrent directory creation and deletion
     add c8ab94f  [FLINK-17819][yarn] Fix error msg for yarn deployments when hadoop not in classpath
     add 40a0e71  [FLINK-17880][table] Use new inference for table/scalar function in catalogs
     add 6257c9e  [FLINK-13782] Implement input type inference for logical functions
     add 618b779  [FLINK-13782] Implement output type strategy for logical functions
     add 8e07ca0  [FLINK-13782] Implement type inference for more logical expressions
     add 7dcfd90  [FLINK-17744] Make (Stream)ContextEnvironment#execute call JobListener#onJobExecuted
     add cda25e5  [FLINK-17946][python] Fix the bug that the config option 'pipeline.jars' doesn't work.
     add dcaa5a0  [FLINK-11523] Use OutputTag.typeInfo in harness
     add 5fc54bb  [FLINK-17844][build] Add tooling for updating japicmp configuration
     add 9579325  [FLINK-17990][python] Fix the test of ArrowSourceFunctionTestBase.testParallelProcessing to use synchronized list
     add 13272ce  [FLINK-16144] get client.timeout for the client, with a fallback to the akka.client.timeout.
     add be04912  [FLINK-17952][python] Fix the bug that exception was thrown when creating BatchTableEnvironment via EnvironmentSettings with old planner.
     add 955a683  [FLINK-17842][network] Remove NextRecordResponse to improve deserialisation performance
     add b66d16f  [hotfix][runtime] Fox log message for web.log.file to only pring config key and not deprecated keys
     add 1af33f1  [hotfix][checkpointing] Beautify stack trace by stripping wrapping CompletionExceptions
     add b144f13  [hotfix][checkpointing] Improve exception in case Coordinator State ack fails
     add 1a721d8  [FLINK-16986][coordination] (part 1) Provide exactly-once guarantees around checkpoints and operator event sending.
     add b233aa8  [FLINK-16986][coordination][refactor] Reduce dependencies of OperatorCoordinatorHolder and OperatorCoordinatorCheckpointContext
     add 7ceee23  [FLINK-16986][coordination][refactor] Change executor in OperatorCoordinatorSchedulerTest
     add 37f7db3  [FLINK-16986][coordination] (part 2) Make OperatorCoordinatorHolder driven by main thread executor
     add 5926e07  [FLINK-16986][coordination] (part 3) Change OperatorCoordinator interface to support better exactly-once semantics
     add 4aff693  [hotfix][coordination] Improve JavaDocs for OperatorCoordinator and OperatorCoordinatorHolder
     add d046fea  [hotfix][coordination] Remove unused class ExecutionJobVertexCoordinatorContext
     add d854b5f  [hotfix][coordination] Remove unused (and unimplemented) method 'failTask(...)' from OperatorCoordinator Context
     add 11d588c  [hotfix][table-common] Accept AbstractDataType for fields
     add 2724942  [hotfix][table] Use AbstractDataType in fromValues()
     add 7ea887f  [hotfix][tests] Move containsCause to FlinkMatchers
     add eab5168  [FLINK-18001][table-planner] Add a new test base for evaluating expressions
     add 092a955  [FLINK-18035][runtime] Use fixed thread pool
     add 9572c92  Revert "[FLINK-17558][runtime] Add Executors#newCachedThreadPool"
     add 64de78e  [FLINK-17887][table][connector] Improve interface of ScanFormatFactory and SinkFormatFactory
     add 2075d5b  [FLINK-17967][docs] Fix Chinese documentation build is broken
     add 03b82f9  [FLINK-17968][hbase] Fix Hadoop Configuration is not properly serialized in HBaseRowInputFormat
     add 1c78ab3  [FLINK-17340][docs] Update docs which related to default planner changing.
     add 8c7c726  [FLINK-17823][network] Resolve the race condition while releasing RemoteInputChannel
     add 2a5482a  [FLINK-17581][docs-zh] Update translation of S3 documentation
     add 064ef34  [hotfix] Fix broken link and wrong node version command in runtime-web readme
     add 65878ca  [FLINK-17996][table-planner-blink] Fix NPE in CatalogTableStatisticsConverter.convertToColumnStats method
     add 8048517  [FLINK-18008][runtime] HistoryServer logs environment info
     add 77d9a22  [FLINK-18010][runtime] Expand HistoryServer logging
     add 3bf3f0c  [FLINK-17970] Rename cluster.io-executor.pool-size config option into cluster.io-pool.size
     add b416302  [FLINK-17970] Increase default value of cluster.io-pool.size from #cores to 4 * #cores
     add 4d200ed  [hotfix] Fix checkstyle violation in TaskSlotTableTest
     add b53e133  [hotfix] Rename TaskSlotTableTest into TaskSlotTableImplTest
     add 3181248  [hotfix] Add TaskSlotTableImplTest.testAllocatedSlotTimeout
     add 3dabc69  [FLINK-18012] Deactivate slot timeout when calling TaskSlotTable.tryMarkSlotActive
     add 78b4e3d  [FLINK-16057][hotfix][task] Remove MailboxProcessor.mainMailboxExecutor field
     add 1a69cb9  [FLINK-16057][task] Optimize ContinuousFileReaderOperator
     add 31d661d  [FLINK-16057][task] Optimize TaskMailbox state retrieval
     add 77e5494  [FLINK-17923][python] Allow Python worker to use off-heap memory
     add 371f3de  [FLINK-17992][checkpointing] Exception from RemoteInputChannel#onBuffer should not fail the whole NetworkClientHandler
     add 21cb586  [FLINK-17937][hive] Change some hive connector tests to IT cases
     add c66eac7  [hotfix][docs] Fix the description of bounded-of-orderness in docs/dev/event_timestamps_watermarks.md
     add 773ad7d  [FLINK-18052] Increase timeout for ES Search API in IT Cases
     add 11e21a4  [hotfix][python] Add the version for the APIs introduced in 1.11.0
     add fbdf920  [FLINK-17901][python] Add module interface in PyFlink
     add d35c33a  [hotfix] Add directory flink-python/apache-flink-*.dev0 to gitignore
     add c52e579  [FLINK-17895][table] Default value of rows-per-second in datagen can be limited
     add dedf4dd  [hotfix][hbase] Rename HBase connector option 'zookeeper.znode-parent' to 'zookeeper.znode.parent'
     add ae8e0f5  [FLINK-17995][docs][table] Redesign Table & SQL Connectors pages
     add 42c0837  [FLINK-17830][docs][hbase] Add documentation for the new HBase SQL connector
     add 9dbd658  [FLINK-17774][streaming] Serialize results in CollectSinkFunction to deal with object reuse
     add 127bb48  [FLINK-17774][table] Supports all kinds of changes for select result
     add dc61816  [FLINK-17376] Use JavaSerializer instead of getSerializableListState()
     add 4ff270e  [FLINK-17376] Don't restore from Flink <= 1.2 state in Kafka connector
     add 276332e  [FLINK-17376] Remove deprecated state access methods
     add a3250c6  [FLINK-18032] Remove outdated sections in migration guide
     add bc16d52  [FLINK-18075][kafka] Call open method of SerializationSchema in Kafka producer
     add 75df7ed  [FLINK-13782][table-api] Fix checking comparision of nested distinct/structured/raw types
     add 80b002b  [FLINK-17959][checkstyle] Exclude all beam classes
     add b31b180  [FLINK-17959][python] Port Beam GrpcStateService class to flink-python module
     add 66d1300  [FLINK-17959][python] Fix the 'call already cancelled' exception when executing Python UDF
     add 07133e6  [FLINK-18051][AZP] Fail Maven setup stage on error
     add b2f8866  [hotfix][table-planner-blink] Prepare ExpressionTestBase for new type system
     add 7dc4193  [hotfix][table-common] Align explicit casting with Calcite's SqlTypeCoercionRule
     add 87d8087  [hotfix][table-common] Add constraint argument type strategy
     add 1d4bd2b  [FLINK-18005][table] Implement type inference for CAST
     add 12a895a  [FLINK-18011] Make WatermarkStrategy/WatermarkStrategies more ergonomic
     add 19bbd6d  [FLINK-17945][python] Improve the error message when instantiating non-existing Java class
     add 9add433  [hotfix][checkpointing] Fix the formatting of CheckpointBarrierUnaligner
     add aa882c1  [FLINK-17994][checkpointing] Fix the race condition between CheckpointBarrierUnaligner#processBarrier and #notifyBarrierReceived
     add 44931eb  [FLINK-16451][table-planner-blink] Fix IndexOutOfBoundsException for DISTINCT AGG with constants
     add fabe021  [FLINK-17466][table-planner-blink] Fix toRetractStream doesn't work correctly with Pojo conversion class
     add c537395  [FLINK-18069] [scala, docs] Scaladocs 2.12 fails to recognize inner interfaces
     add 079b38a  [FLINK-18037][javadocs] Remove duplicate word
     add 640a56f  [FLINK-18006] Always overwrite RestClientFactory in ElasticsearchXDynamicSink
     add f92e70e  [FLINK-16975][documentation] Add docs for FileSystem connector
     add 2eb7377  [FLINK-17935] Move set yarn.log-config-file to YarnClusterClientFactory.createClusterDescriptor()
     add ec4e874  Revert "[FLINK-17935] Move set yarn.log-config-file to YarnClusterClientFactory.createClusterDescriptor()"
     add 3f22069  [FLINK-17931] Document fromValues clause in Table API
     add aa40ffd  [FLINK-18055][sql-client] Fix catalog/database does not exist in sql client
     add d56454a  [FLINK-18087][yarn] Fix uploading user artifact for Yarn job cluster
     add 5ab403d  [FLINK-17918][table-blink] Fix AppendOnlyTopNFunction shouldn't mutate list value of MapState
     add 550d4e1  [hotfix][table-planner-blink] Store last watermark in state to emit on recovery for EventTimeProcessOperator
     add 05332b5  [hotfix][python] Improve the error message when converting from Pandas DataFrame in the batch mode of old planner
     add 20abff9  [FLINK-18120] Don't expand documentation sections by default
     add a674b5e  [FLINK-17935] Move set yarn.log-config-file to YarnClusterClientFactory.createClusterDescriptor()
     add 3ee4c1f  [FLINK-17847][table-planner-blink] Fix runtime ArrayIndexOutOfBoundsException when accessing out-of-bounds elements of ARRAY data
     add 9211cb5  [FLINK-17404] Make sure netty 3.10.6 is used in flink-runtime
     add 52861e3  [FLINK-16572] Clean up PubSub connector e2e test
     add 0799b5c  [FLINK-17384][connectors/hbase] Support reading hbase conf dir from flink-conf.yaml
     add 564b652  [FLINK-16577][table-planner-blink] Fix numeric type mismatch error in  column interval relmetadata
     add f5ba41f  [FLINK-17717][sql-parser] Throws for DDL create temporary system func with composite identifier
     add ad828cb  [hotfix] Remove redundant backslash in the log of GPUDriver
     add e27c517  [FLINK-18074][checkpoint] Ensure task could fail when exception thrown out on notified of checkpoint completed/aborted
     add dcd764a  [FLINK-18143][python] Fix Python meter metric incorrect value problem (#12498)
     add 84c2905  [FLINK-15687][runtime][test] Fix accessing TaskSlotTable via TaskSubmissionTestEnvironment not in RPC main thread.
     add e2cffe1  [FLINK-15687][runtime][test] Make TaskManagerActions access task slot table on rpc main thread in TaskSubmissionTestEnvironment.
     add b28cca2  [FLINK-18059][sql-client] Fix create/drop catalog statement can not be executed in sql client
     add d3dbf61  [FLINK-18142][hive] Wrong state names in HiveContinuousMonitoringFunction
     add 46d42e5  [FLINK-18069][CI] Test if Scala/JavaDocs builds are passing in the compile stage
     add c67109e  [FLINK-17553][table] Fix plan error when constant exists in group window key
     add c0673a2  [FLINK-18038][statebackend] Log application-defined state backends after configuration
     add 826a075  [FLINK-18042][build] Bump flink-shaded to 11.0
     add d991b1a  [FLINK-17816][metrics] Schedule latency markers with fixed delay
     add 13bae63  [FLINK-17974][docs] Extend docker documentation
     add b48d330  [hotfix][docs] Remove HADOOP_CONF_DIR
     add b39ef6c  [FLINK-15339][table][docs] Correct the terminology of "Time-windowed Join" to "Interval Join" in Table API & SQL
     add 61e6f70  [FLINK-18076][table sql / client] Use correct classloader when parsing queries
     add 5834373  [FLINK-18048] Fix --host option for standalone application cluster
     add c389ad0  [FLINK-17260] Make number of expected messages explicit in StreamingKafkaITCase
     add 455fb24  [FLINK-17260] Increase timeout for reading Kafka messages in StreamingKafkaITCase
     add ce7b41e  [FLINK-17260] Make topic names unique in StreamingKafkaITCase to prevent clashes
     add f6bbff4  [FLINK-18020] Make topic names unique in SQLClientKafkaITCase to prevent clashes
     add 971e7b2  [FLINK-18020] Increase timeout in SQLClientKafkaITCase
     add d25609d  [FLINK-18139][checkpointing] Fixing unaligned checkpoints checks wrong channels for inflight data.
     add 674817c  [FLINK-18067][yarn] Change default value of yarnMinAllocationMB from zero to DEFAULT_RM_SCHEDULER_MINIMUM_ALLOCATION_MB
     add 8f858f3  [FLINK-18073][avro] Fix AvroRowDataSerializationSchema is not serializable
     add a479aee  [hotfix][avro] Fix AvroRowSerializationSchema doesn't support TIMESTAMP type
     add 88871b2  [FLINK-18029][kafka] Add more ITCases for Kafka with new formats (avro, csv, json)
     add 0a1b0c6  [FLINK-18110][fs-connector] StreamingFileSink notifies for buckets detected to be inactive on restoring
     add c27a7a6  [FLINK-18151][python] Resolve CWE22 problems in pyflink_gateway_server.py (#12503)
     add a4a99ba  [FLINK-18149][k8s] Do not add DeploymentOptionsInternal#CONF_DIR to config map
     add 44af789  [FLINK-16350] Support Zookeeper 3.5 in test_ha_per_job_cluster_datastream.sh
     add ed7b0b1  [FLINK-18050][task][checkpointing] Use CloseableIterator to write ResultSubpartition state
     add f2dd4b8  [FLINK-18050][task][checkpointing] Simplify ChannelStateCheckpointWriter interface
     add 0b7c23e  [FLINK-17776][hive][doc] Add documentation for DDL&DML in hive dialect
     add ca89635  [FLINK-17406][doc] Add documentation about dynamic table options
     add 88e416f  [FLINK-18046][hive] Decimal column stats not supported for Hive table
     add 4a04a71  [FLINK-17287][github] Disable merge commit button
     add b8c3033   [FLINK-17512] Add notification settings to .asf.yaml
     add 3952bfa  [FLINK-17635][docs][table] Add documentation about view support
     add a08061b  [hotfix][pubsub] Use TestLogger
     add 0358292  [FLINK-16572][e2e][pubsub] Acknowledge message in previous test
     add bebe503  [FLINK-18075] Remove deprecation of Kafka producer ctor that take SerializationSchema
     add 74fd291  [FLINK-18075] Wrap the SerializationSchema in KafkaSerializationSchema in Kafka connector
     add 0e8a53b  [FLINK-13782][table-api] Implement type strategies for IF ELSE expression
     add 50b6d9d  [FLINK-17260] Embellish assert output of StreamingKafkaITCase to help debugging
     add 87d6a76  [FLINK-18075][hotfix] Use DeserializationSchema instead of KeyedDeserializationSchema in DynamicTableSink
     add 926523e  [FLINK-17625][table-runtime-blink] Fix ArrayIndexOutOfBoundsException in AppendOnlyTopNFunction
     add dee868d  [FLINK-16101][docs-zh][table] Translate "Hive Functions" page of "Hive Integration" into Chinese
     add 02b915a  [FLINK-17893][sql-client] SQL CLI should print the root cause if the statement is invalid
     add 2be8239  [FLINK-16291][hive] Ban count from HiveModule
     add fd9214e  [FLINK-16559][hive] Add test for avro table
     add 74231f7  [FLINK-17902][python] Support the new interfaces about temporary functions in PyFlink
     add 45f42f8  [FLINK-18056][fs-connector] Hadoop path-based file writer adds UUID to in-progress file to avoid conflicts
     add 603cd83  [FLINK-18130][hive][fs-connector] File name conflict for different jobs in filesystem/hive sink ()
     add 5b7556b  [FLINK-18042][tests] Log path of used distribution
     add e0c6f76  [FLINK-18042][tests] Auto-detect moduleDir
     add f40936c  [FLINK-18042][tests] More helpful error message if jar cannot be found
     add 64f8f65  [FLINK-18042][tests] Auto-detect distDir
     add 6dc624d  [FLINK-18136][checkpointing] Don't start channel state writer for savepoint
     add 4e24a8b  [FLINK-18181][fs-connector] StreamingFileCommitter should not use fs modification time for proc committer
     add 44acd50  [FLINK-18152][Depl] Fail fast in JM scripts if memory configuration failed
     add bb0ebca  [hotfix][checkpointing] Add VisibleForTesting annotation for related methods
     add 0cbd5e3  [FLINK-18063][checkpointing][refactoring] Implement default #isBlocked method in CheckpointBarrierHandler
     add d99e1f8  [FLINK-18063][checkpointing] Fix the invalid implementation of AlternatingCheckpointBarrierHandler#getAlignmentDurationNanos
     add f672ae5  [FLINK-18063][checkpointing] Fix the race condition of aborting checkpoint in CheckpointBarrierUnaligner
     add a80dc5a  [hotfix][tests] Add missing import
     add 892e1c3  [hotfix][tests] Fix the compile issue caused by constructor change of CheckpointBarrierUnaligner
     add 131cf30  [hotfix][testing] Remove the unused import from CheckpointBarrierUnalignerTest
     add 8fb330a  [FLINK-17765] Strip ExecutionException from StreamExecutionEnvironment.executeAsync
     add 0864b15  [FLINK-17765] Remove JobExecutionException from JobManagerRunnerImpl
     add fa46073  [FLINK-17765] Remove uncheckedSupplier from Dispatcher.createJobManagerRunner
     add 8a8d8a9  [FLINK-17753] [table-planner-blink] Fix watermark defined in ddl does not work in Table api
     add d27c888  [FLINK-18061] [table] TableResult#collect method should return a closeable iterator to avoid resource leak
     add 3057927  [FLINK-18195] Remove references to Expressions.interval(Duration) from (java)docs
     add bed750f  [FLINK-18208] Fix flink ES connector typos
     add 545a5ec  [FLINK-17872][doc] Add document for writing Avro files with StreamingFileSink
     add 415b78a  [FLINK-18045] Fix Kerberos credentials checking
     add 8a7093b  [FLINK-18126][python] Correct the exception handling of the Python CompletableFuture
     add d1ed9bf  [FLINK-18207][FLINK-18185][table] Fix datagen connector exactly-once bug and validation message
     add fa70cef  [FLINK-16694] Run test_resume_externalized_checkpoints.sh with 15 min test timeout
     add 3b5a1c9  [FLINK-18176][document] Add supplement for file system connector document
     add 040ce4b  [FLINK-18157][runtime] Jobstore size check compares against offHeapMemory
     add f7df2e8  [FLINK-18018][dist] Bundle GPU plugin in plugins/ directory
     add 9d9ca95  [FLINK-18156] Add 'or default' for min/max to JVM Overhead sanity check's error message
     add 14c4be5  [FLINK-18154][Runtime] Check Total Flink Memory plus JVM metaspace is less than or equal to the configured Total Process Memory
     add d757fc1  [hotfix] Improve JavaDocs comments for FlinkMemory/FlinkMemoryUtis
     add 9a7dbfc  [FLINK-18057][tests] Fix unstable test SingleInputGateTest#testConcurrentReadStateAndProcessAndClose
     add bac55c1  [FLINK-16225] Implement user class loading exception handler
     add 3716f37  [FLINK-10740][docs] Add documentation for FLIP-27 sources
     add 9fc1ac4  [FLINK-10740][docs] Add documentation for FLIP-27 Source API and SplitReader API.
     add c916e36  [hotfix][docs] Add NEWLINE to end of SVG files
     add c4a9a1b  [hotfix][docs] Minor language cleanups for Data Source docs.
     add a160697  [FLINK-18104][python][windows] Fix the test failures on Windows.
     add b1bc266  [hotfix][python] Add version information for the methods defined in CompletableFuture
     add f81b2c1  [hotfix][python] Remove unnecessary methods in JobExecutionResult
     add 0980a28  [hotfix][avro] Fix TINYINT/SMALLINT types not work in Avro format
     add 9171292  [hotfix][docs][table] Minor improvements on Filesystem and HBase connector page
     add 821e786  [FLINK-18133][docs][avro] Add documentation for the new Avro format
     add 6dd38f4  [hotfix][docs-zh] Update corresponding Chinese Avro format pages
     add 7ab4d33  [FLINK-16681][jdbc] Fix JDBC source/sink lost connection after a long time idle
     add 919bd54  [FLINK-18082][jdbc] Fix UnsignedTypeConversionITCase stalls in ch.vorburger.mariadb4j.DB.stop
     add 4db3680  Fix typo in KafkaResource (#12564)
     add 162994f  [hotfix][doc] Some minor languange clean-ups for the Source doc.
     add f819e08  [FLINK-16217][sql-client] Fix exception catching to avoid SQL client crashes
     add 20e82af  [FLINK-16198] Fix FileUtilsTest on macOS
     add 1839fa5  [FLINK-17498][tests] Increase CancelingTestBase rpc timeout to configured Akka ask timeout
     add 7143e6a  [FLINK-17944][sql-client] Wrong output in SQL Client's table mode
     add 1cb9d54  [FLINK-17869][hotfix] Add taskName to ChannelStateWriter log messages
     add 82a13db  [FLINK-17869][hotfix] Don't pass ChannelStateWrite Future to AsyncCheckpointRunnable
     add 73afe2b  [FLINK-17869][task][checkpointing] Revert "[FLINK-17218][checkpointing] Ensuring that ChannelStateWriter aborts previous checkpoints before a new checkpoint is started."
     add 91df1a5  [FLINK-17869][task][checkpointing] Abort channel state write if checkpoint is subsumed
     add 2b51cda  [FLINK-17869][task][checkpointing] Increase ChannelStateWriterImpl.DEFAULT_MAX_CHECKPOINTS
     add 64ff676  [FLINK-17869][task][checkpointing] Ignore out of order checkpoints in SubtaskCheckpointCoordinator
     add 26762bd1 [FLINK-17869][tests] Unignore UnalignedCheckpointITCase
     add b2d1c2d  [FLINK-17869][task][checkpointing] Abort writing of channel state by RPC notification
     add 2606323  [FLINK-18215][conf] Add log level to JavaBashUtils log4j config
     add 40080e0  [FLINK-16213] Move stateful-stream-processing.md introduction to form "What is State" section
     add 52145af  [FLINK-17982] Remove TODOs from stateful-stream-processing
     add 3a36c76  [FLINK-16208] Add introduction to timely stream processing concepts documentation
     add 1a2fdbf  [FLINK-17982] Remove TODOs from timely-stream-processing.md
     add 218e509  [minor] Propagate recent changes to chinese documentation
     add 828dccd  [hotfix] Correct the default path of nvidia-gpu-discovery
     add 70bfb61  [FLINK-18218][python][e2e] Add PyFlink YARN per-job e2e tests
     add 0c9e7b2  [FLINK-17795][example] Add MatrixVectorMul example
     add c67e796  [hotfix][cli] Update the help message of the Generic CLI
     add d98b935  [hotfix] Fix typo in ops/deployment/index
     add bdcaea6  [FLINK-18084] Rename the ExecutorCLI to GenericCLI according to docs
     add 7aa5f33  [FLINK-18084][docs] Document the Application Mode
     add 5473710  [FLINK-17980][docs] Move getting started walkthroughs to Try Flink
     add 5df3837  [FLINK-17980][docs] Rename Hands-on Training to Learn Flink
     add 49b2e4f  [FLINK-17980][docs] Update headings of datastream and table walkthroughs
     add aec7e66  [FLINK-17980][docs] Update broken links
     add f2db6ac  [FLINK-17980][docs] Add training redirects
     add 420c77b  [FLINK-17980][docs] Update broken links
     add 55712a5  [FLINK-17980][docs] Add training redirects
     add 6e4e7ff  [FLINK-17980][docs] Move project setup into DataStream section
     add 4555ad9  [FLINK-18188][Runtime] Derive JM Off-Heap memory from configured Total Flink Memory minus JVM Heap
     add 6ca803f  [hotfix][table-common] Implement first type strategy
     add 0a0b4a4  [hotfix][table-common] Add a common type strategy
     add fcab7b3  [FLINK-13784][table] Implement type inference for math functions
     add 3dedb85  [FLINK-18239][e2e] Pin minikube version to v1.8.2
     add e850760  [FLINK-18034][runtime] Introduce PreferredLocationsRetriever
     add 31282fe  [FLINK-18034][runtime] ExecutionSlotAllocator uses PreferredLocationsRetriever to get preferred locations for tasks
     add 8ef1e7d  [FLINK-18034][runtime] Remove unused preferredLocations from ExecutionVertexSchedulingRequirements
     add 216f65f  [hotfix][runtime] Remove ExecutionSlotAllocator#stop() which is never used in production
     add f59b8b4  [FLINK-18232][hive] Fix Hive streaming source bugs
     add 88cc44a  [hotfix][avro] Link to Hadoop Integration in Avro format documentation
     add 6fed1a1  [FLINK-18224][docs] Add document about sql client's tableau result mode
     add c9488eb  [FLINK-18030][hive] Hive UDF doesn't accept empty string literal parameters
     add 6f06e3d  [FLINK-17965][sql-parser-hive] Hive dialect needs to unescape backslash in string literals
     add aaf6da0  [FLINK-18131][docs] Add documentation for the new JSON format
     add 41e8ad9  [FLINK-17113][sql-cli] Use executeSql to execute view statements and fix nullability loss problem
     add 4c05dac  [hotfix] Fix a code style local variable name issue in JobManagerProcessUtilsTest
     add 1adfd58  [FLINK-18214][Runtime] Remove Job Cache size check against JVM Heap size
     add 465ec2a  [FLINK-18160][scripts] Do not log about HADOOP_CONF_DIR if HADOOP_CLASSPATH is set
     add 600ace2  [FLINK-18132][docs] Add documentation for the new CSV format
     add 28cc602  [hotfix][table-common] Fix TableSchemaUtils#getPhysicalSchema should keep the original constraint name
     add 6c2ff97  [FLINK-16497][jdbc][table] Improve default flush strategy for new JDBC sink for better out-of-box
     add 37ba881  [FLINK-16496][hbase][table] Improve default flush strategy for new HBase sink for better out-of-box
     add 3d764dc  [FLINK-16495][elasticsearch][table] Improve default flush strategy for new Elasticsearch sink for better out-of-box
     add 9b91f2f  [hotfix][docs][hbase] Improve HBase connector documentation about primary key
     add 21067b3  [FLINK-17832][docs][es] Add documentation for the new Elasticsearch connector
     add 4aa6524  [minor][docs] Update chinese version of flink-architecture.md
     add 35e2fca  [FLINK-18237][fs-connector] Exception when reading filesystem partitioned table with stream mode
     add 582d9e4  [FLINK-17733][FLINK-16448][hive][doc] Adjust Hive doc & Add documentation for real-time hive
     add 0028e2e  [FLINK-15849][doc] Update SQL-CLIENT document from type to data-type
     add 0b0a6bc  [FLINK-18247][table-planner-blink] Fix unstable test: TableITCase.testCollectWithClose
     add 6216906  [FLINK-18217][conf] Explicitly check for empty string
     add 6ee7164  [hotfix][dist] Use dash in plugin directories
     add 13c1706  [FLINK-18058][mesos][tests] Increase heartbeat interval/timeout
     add 8cb6ef6  [FLINK-17829][docs][jdbc] Add documentation for the new JDBC connector
     add dca8848  [hotfix] Fix checkstyle violations in AllocatedSlot
     add 9c2e15a  [hotfix][runtime] Set root cause to pending request released exception
     add 7054f97  [FLINK-17017][runtime] Allow to set whether a physical slot payload will occupy the slot indefinitely
     add 636e36c  [FLINK-17017][runtime] Add SingleLogicalSlot#allocateFromPhysicalSlot(…) for physical slot assignment
     add ccc4d8e  [FLINK-17017][runtime] Enable to get whether a physical slot will be occupied indefinitely
     add f6c275e  [FLINK-17017][runtime] Enable to get allocated slots information of a slot pool
     add 541f28f  [FLINK-17017][runtime] Allow to disable batch slot request timeout check
     add 4c16a34  [FLINK-17017][runtime] Allow nullable timeout for streaming slot request in slot pool
     add 044def9  [FLINK-17017][runtime] Introduce BulkSlotProvider which allocates physical slots in bulks
     add 9aee0c0  [FLINK-17017][runtime] SchedulerImpl supports bulk slot allocation
     add b8332b5  [FLINK-17422][doc] Create user document for the external resource framework and the GPU plugin
     add bef5500  [FLINK-17442][docs] Make example URL Flink version dependent
     add 11cabb6  [hotfix] Fix head --lines usage in test scripts
     add da20f22  [FLINK-17831][docs] Add documentation for the new Kafka connector
     add 5b20de1  [hotfix][docs][connectors] Improve SQL connectors documentation
     add 8ee8f29  [hotfix][docs] Fix parts of broken links
     add 6744033  [FLINK-17788][scala-shell] Fix yarn session support in scala shell
     add f88d98d  [FLINK-17182][network][tests] Fix the unstable RemoteInputChannelTest.testConcurrentOnSenderBacklogAndRecycle
     add 2419627  [FLINK-18256][orc] Exclude ORC's Hadoop dependency and pull in provided vanilla hadoop in flink-orc
     add ba7854b  [hotfix] Improve exception message for parsing kryo serializer classes from config
     add 039a74a  [FLINK-18241] Use correct user class loader in OptimizerPlanEnvironment & StreamPlanEnvironment
     add cf2aba7  [hotfix][docs] Fix Liquid Exception in documentation
     add bfcd800  [FLINK-18246][python][e2e] Disable PyFlink e2e tests when running on jdk11
     add dd3717e  [FLINK-18252][checkpointing] Fix savepoint overtaking output data.
     add 27f6654  [FLINK-18253][doc][avro] Add filesystem option documentation for Avro
     add cb2dc73  [FLINK-18141][doc][parquet] Add documentation for Parquet format
     add 1c9f198  [FLINK-18175][conf] Log final memory configuration
     add a81e747  [FLINK-17977][runtime] Log FS safety-net lifecycle on DEBUG
     add 15c140c  [FLINK-17977][runtime] Log initiation of savepoint operations
     add e4c3768  [FLINK-17977][runtime] Log leader grant/revocation to shutdown JobManager on DEBUG
     add e2c75ac  [FLINK-17977][akka] Log target address retrieval on DEBUG
     add 4718907  [FLINK-17977][runtime] Log registration attempts on DEBUG
     add ca33b28  [FLINK-17977][runtime] Log incompatible security context factories on DEBUG
     add 6fe933d  [FLINK-17977][runtime] Log message timeout on DEBUG
     add 8990f6d  [FLINK-17977][runtime] Log outdated TaskExecutor registration on DEBUG
     add 35cb327  [FLINK-17977][core] Silence type extractor warnings for built-in Row
     add b592dd2  [FLINK-12855] Add WindowStagger to TumblingProcessingTimeWindows
     add 38b2755  [FLINK-18137] Handle discarding of triggering checkpoint correctly
     add 0b071a9  [hotfix] Add @Nullable annotation to FutureUtils.getWithoutException
     add c004b11  [hotfix] Make sure that no exceptions are swallowed in CheckpointCoordinator.startTriggeringCheckpoint
     add e026274  [FLINK-18233][tests] Increase test timeout to 20s for TaskExecutorSubmissionTest
     add 4d8f55e  [FLINK-18259][tests] Increase heartbeat timeouts for HeartbeatManagerTest
     add ca9dc71  [FLINK-17322][network] Fixes BroadcastRecordWriter overwriting memory segments on first finished BufferConsumer.
     add 7e7b132  [FLINK-17322][network] Disallowing repeated consumer creation for BufferBuilder.
     add 86b17c2  [FLINK-17315][tests] Ignore unstable UnalignedCheckpointITCase one more time
     add b25f464  [FLINK-17981][docs] rewrite docs home page
     add 1735af8  [FLINK-17981][docs] Link to statefun docs from the home page
     add 308ef58  [FLINK-17981][docs] Improvements to layout and content based on reviews
     add 481c509  [FLINK-17981][docs] Add a section on getting help to the home page
     add 095529d  [hotfix] Update release notes for 1.10
     add a3b51f8  [FLINK-15687][runtime][test] Fix test instability due to concurrent access to JobTable.
     add 74ada6d  [hotfix][yarn] Code clean-up in YarnResourceManager.
     add 4f333e5  [FLINK-18226][runtime] Fix ActiveResourceManager request extra workers on termination of existing workers.
     add da33f94  [FLINK-18277][elasticsearch] Fix the returned value of Elasticsearch6DynamicSink#asSummaryString()
     add c34d7dc  [FLINK-17836][hive][doc] Add document for Hive dim join
     add 777a193  [FLINK-18265][fs-connector] Hidden files should be ignored when the filesystem table searches for partitions
     add 3916da0  [FLINK-18265][fs-connector] temp path in FileSystemOutputFormat should be deleted
     add 79e8882  [FLINK-18140][doc][orc] Add documentation for ORC format
     add e04894c  [FLINK-17686][doc] Add document to dataGen connector
     add f3637ca  [FLINK-17686][doc] Add document to blackhole connector
     add 97fc6b3  [FLINK-17686][doc] Add document to print connector
     add 5e43f01  [hotfix][doc] Fix minor error in hive_streaming.md
     add 2b2b643  [FLINK-18173][build] Bundle flink-csv and flink-json jars in lib
     add 57992c9  [FLINK-17623][elasticsearch] Support user resource cleanup in ElasticsearchSinkFunction
     add bb2affb  [FLINK-18089][network][tests] Config the e2e for netty shuffle memory control into azure pipeline
     add 35f95f5  [FLINK-17960][python][docs] Improve commands in the "Common Questions" document for PyFlink (#12367)
     add 1830010  [FLINK-18197][hive] Add more logs for hive streaming integration
     add fcb76aa5 [hotfix] Relocation hadoop runtime util
     add f1e4211  [FLINK-18223] Fixed AvroSerializer to initialize GenericRecords in the correct way
     add 6045d2e  [FLINK-17977] Improve checkpoint triggering log message
     add e72ca4a  [FLINK-18147] Fix ORC document display problems
     add 6e688e1  [FLINK-13783][table] Implement type inference for string functions
     add 24201cc  [FLINK-18039][connector/common] Introduce a RecreateOnResetOperatorCoordinator class to recreate an OperatorCoordinator instance when resetToCheckpoint() is invoked. Let SourceCoordinator leverage RecreateOnResetOperatorCoordinator to ensure a clean checkpoint reset.
     add e01cab2  [FLINK-18039] Ensure the source events are sent via the coordinator thread.
     add 36edd14  [minor] In FlinkKafkaInternalProducer add Javadoc to internal methods and clarify names
     add 216744a  [minor] In FlinkKafkaInternalProducer add Javadoc to internal enqueueNewPartitions()
     add 711f619  [FLINK-17327] Always use close() with zero timeout in exactly-once Kafka Producer
     add 889705c  [FLINK-15362] Bump Kafka connector to 2.4.1
     add f883f11  [FLINK-18162][connector/common] Serialize the splits in the AddSplitsEvent.
     add 6388336  [FLINK-18261][parquet][orc] flink-orc and flink-parquet have invalid NOTICE file
     add fea20ad  [FLINK-18268][docs] Correct Table API in Temporal table docs
     add f4aaf8c  [FLINK-18282][docs-zh] Retranslate the home page document
     add 9843424  [hotfix] Introduce TaskManagerExceptionUtils
     add 276e8c6  [FLINK-18250] Enrich OOM error messages with more details in ClusterEntrypoint
     add cc1f1a4  [FLINK-17891][yarn] Set execution.target=yarn-session in FlinkYarnSessionCli.run()
     add 24c6076  [hotfix][table-runtime-blink] Allow subclasses of Map as input conversion class
     add da87bf8  [FLINK-18248][docs] Update data type documentation for 1.11
     add 9eec8f1  [FLINK-17976][docs][k8s/docker] Improvements about custom docker images
     add 4517dec  [hotfix] Remove obsolete .gitattributes file
     add c47fb47  [FLINK-18307][scripts] Rename 'slaves' file to 'workers'
     add a6146a5  [hotfix][docs] Remove outdated confusing HDFS reference in cluster setup.
     add 3792f8f  [FLINK-17666][table-planner-blink] Insert into partitioned table can fail with select *
     add 8ca388c  [FLINK-17800][roksdb] Ensure total order seek to avoid user misuse
     add f125062  [FLINK-17800][roksdb] Support customized RocksDB write/read options and use RocksDBResourceContainer to get them
     add 8e2af35  [FLINK-18322][connector/common][tests] Fix unstable ExecutorNotifierTest#testExceptionInHandler (#12676)
     add c534c3e  [FLINK-18065][docs] Document FLIP-65 table and scalar functions
     add 0e80660  [hotfix][table-common] Relax literal casting check in AdaptedCallContext
     add efd4974  [hotfix][e2e] Sync kafka 0.10 versions
     add 4b7d8db  [hotfix][runtime] Move shared static test methods of physical slot into PhysicalSlotTestUtils
     add a1c9a30  [hotfix][runtime] Move shared static test methods of slot allocator into ExecutionSlotAllocatorTestUtils
     add 6d9eb50  [FLINK-17018][runtime] Extract common logics of DefaultExecutionSlotAllocator into AbstractExecutionSlotAllocator
     add 95cf59a  [FLINK-17018][runtime] Introduce OneSlotPerExecutionSlotAllocator which will request one physical slot for each single execution vertex
     add d75f186  [FLINK-17018][runtime] Use OneSlotPerExecutionSlotAllocator on pipelined region scheduling
     add a10f1a47 [hotfix][runtime] Narrow down the access scope of DefaultExecutionSlotAllocator
     add 0aea300  [hotfix][runtime] Narrow down the access scope of SlotExecutionVertexAssignment
     add d7bf722  [FLINK-18298][table] Rename TableResult headers of SHOW statements
     add c2a6b81  [FLINK-18083][hbase] Improve exception message of TIMESTAMP/TIME out of the HBase connector supported precision
     add b665b93  [FLINK-18294][e2e] Log java processes and disk usage
     add ec6740b  [hotfix][metrics][docs] Fix typo
     add 6220cee  [FLINK-18304][metrics][docs] Add example interval configuration to all supporting reporters
     add 8c565db  [FLINK-18304][metrics] Document default reporter interval
     add f647bf1  [FLINK-18209] Replace slave with worker in docker cluster test scripts
     add 6eb01ce  [FLINK-18134][FLINK-18135][docs] Add documentation for Debezium and Canal formats
     add 47566c8  [hotfix][docs] Improve HBase and JDBC connector documentation
     add 2bb1083  [hotfix][FLINK-18314][docs] Fix wrong documentation in Kafka SQL Connector page
     add 634fb0d  [hotfix][docs] Rearrange the order of SQL connectors in sidebar
     add f01cac8  [FLINK-18311] Fix StreamingKafkaITCase on Kafka 2.4.1
     add ab7b8c4  [FLINK-18311] Make StreamingKafkaITCase more resilient
     add 02cdfe8  [hotfix] Code cleanup: remove useless parameter from Environment#enrich method
     add 471a3df  [FLINK-18161][sql-client] Fix state retention config does not work in sql client
     add 94ea5e6  [FLINK-18161][sql-client] Fix configurations from flink-conf.yaml overwrite sql-client's properties
     add 1ff3d45  [FLINK-17976][doc] Synchronize Chinese native Kubernetes document
     add a9d3074  [FLINK-17824][tests] Fix resume_savepoint e2e test by slowing down the Source (#12671)
     add fc6f372  [FLINK-18291][e2e] Introduce timeout into Streaming File Sink s3 test
     add 63e6e58  [hotfix][docs] Fix typo in operations playground
     add 4a775af  [hotfix][docs] Fix broken link
     add 7ce45b5  [FLINK-18086][tests] Support to set standard inputs for AutoClosableProcess
     add 06d96b5  [FLINK-18086][e2e] Migrate SQLClientKafkaITCase to use DDL and new options to create tables
     add ca1f764  [FLINK-18302][sql-cli] Fix SQL client uses wrong class loader when execute INSERT statements
     add e2db1dc  [FLINK-18303][filesystem][hive] Fix Filesystem connector doesn't flush part files after rolling interval
     add 07772bd  [FLINK-18238][checkpoint] Broadcast CancelCheckpointMarker while executing checkpoint aborted by coordinator RPC
     add 204aa6d  [FLINK-18332][state] Add error message to precondition in KeyGroupPartitionedPriorityQueue
     add 03a8ef6  [FLINK-18072][hbase] Fix HBaseLookupFunction can not work with new internal data structure RowData
     add 0c4c461  [hotfix][e2e] Add 'flink' prefix to flink log backup directory
     add acd0de8  [FLINK-18301][e2e] Backup kafka logs on failure
     add 5d7ea5d  [FLINK-17269][docs-zh] Translate new Training Overview to Chinese
     add f9615a4  [FLINK-17005][docs-zh] Translate the CREATE TABLE ... LIKE syntax documentation to Chinese
     add 630728a  [FLINK-18329][legal] Fix typo
     add efc4c0c  [FLINK-18331][legal] Sort NOTICE entries
     add 7a6a82f  [FLINK-18326][legal] Updated kubernetes NOTICE
     add 05f2c40  [FLINK-18328][legal] Updated blink-planner NOTICE
     add 159582a  [FLINK-14511][Deployment / YARN] Checking YARN queues with  root prefix
     add dc84538  [FLINK-18330][python][legal] Update the NOTICE file of flink-python module adding beam-runners-core-java and beam-vendor-bytebuddy
     add 2150533  [FLINK-16795][e2e] Increase e2e execution timeout +20m
     add 5948690  Revert "[FLINK-17800][roksdb] Support customized RocksDB write/read options and use RocksDBResourceContainer to get them"
     add f6f51d8  Revert "[FLINK-17800][roksdb] Ensure total order seek to avoid user misuse"
     add 03beab8  [FLINK-18094][network] Fixed UnionInputGate#getChannel.
     add 485688f  [FLINK-18094][network] Add InputGate#getChannelInfos for easier testing.
     add 49a36f5  [FLINK-18094][network] Simplifying InputProcessorUtil by delegating createCheckpointedInputGate to createCheckpointedMultipleInputGate.
     add 70e3c88  [FLINK-18094][network] Using lists instead of collections of gates while creating checkpoint handlers.
     add 1bacaee  [FLINK-18094][network] Buffers are only addressed through InputChannelInfo.
     add c42a2f9  [FLINK-18299][json] Fix the non SQL standard timestamp format in JSON format
     add 5ed371f  [FLINK-18242][state-backend-rocksdb] Remove the deprecated OptionsFactory and related classes
     add c025407  [hotfix][docs] Fix typo in sql queries
     add 6623ef1  [FLINK-18236] fix es connector test ElasticsearchSinkTestBase.runElasticsearchSink* verify not right.
     add dfe0521  [hotfix][e2e] Fix package name+
     add f85dfbb  [FLINK-18290][checkpointing] Don't System.exit on CheckpointCoordinator failure if it is shut down
     add 025f457  [FLINK-17019][runtime] All pending requests removal goes to SlotPool#removePendingRequest() for centrally management
     add 1b34f18  [FLINK-17019][runtime] Fulfill slot requests in request order
     add 995e686  [hotfix][runtime] Make DualKeyLinkedMap package private
     add b8698c0  [FLINK-17019][runtime] Make clear the iteration order contract of DualKeyLinkedMap
     add b5e3c92  [FLINK-17019][runtime] Enable DualKeyLinkedMap for querying primary/secondary key with a given secondary/primary key
     add 01360fe  [FLINK-17019][runtime] Change primary key re-insertion in DualKeyLinkedMap to not affect the insertion order
     add df9a882  [FLINK-17019][runtime] Remap orphaned slot allocation to pending slot request which just lost its allocation
     add 40621c7  [FLINK-18272][table-runtime-blink] Add retry logic to FileSystemLookupFunction
     add 626dd39  [FLINK-18300][sql-client] SQL Client doesn't support ALTER VIEW
     add ec9f68d  [FLINK-18319][notice] Lack LICENSE.protobuf in flink-sql-orc
     add eb57c49  [FLINK-17383] Do not use CollectionEnvironment in flink-planner tests
     add 2569d1b  Revert "[FLINK-17126][java] Introduce CollectionPipelineExecutor for CollectionEnvironment"
     add b59ba8b  [hotfix][table-api-java] Add missing @PublicEvolving annotations to classes in flink-table-api-java
     add 99fca58  [FLINK-16589][table-planner-blink] Split code for AggsHandlerCodeGenerator
     add afdb7bf  [FLINK-18310][metrics] Properly handle interval parsing errors
     add 476a8ba  [hotfix][metrics] Only parse reporter interval if required
     add 4183aac  [FLINK-18289][Checkpoint] Ensure notifyCheckpointAborted interface work in UDF operator
     add 66192b8  [FLINK-17768] Reenable UnalignedCheckpointITCase.
     add c241667  [hotfix][FLINK-18071] Temporarily ignore CoordinatorEventsExactlyOnceITCase
     add 4558cb0  [FLINK-18358] Fix comparing double in TableEnvironmentITCase
     add 58025ef  [hotfix] Fix import checkstyle violation in TaskManagerRunner
     add 64f469e  [hotfix][build] Adjust the file permission for update_japicmp_configuration.sh
     add c8e9d0d  [FLINK-18368][tests] Cleanup Kerberos settings after test.
     add febe8e3  [FLINK-18343][e2e] Refactor file-line replacement into separate method
     add f8b0bff  [FLINK-18343][e2e] Set Flink rootLogger to DEBUG
     add 42798cd  [FLINK-18377] Rename "Flink Master" back to JobManager in documentation
     add e090f55  [FLINK-18381] Update Jekyll to 4.0.1

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (4649ddd)
            \
             N -- N -- N   refs/heads/docs_experimental__docs (e090f55)

You should already have received notification emails for all of the O
revisions, and so the following emails describe only the N revisions
from the common base, B.

Any revisions marked "omit" are not gone; other references still
refer to them.  Any revisions marked "discard" are gone forever.

No new revisions were added by this update.

Summary of changes:
 .asf.yaml                                          |   10 +
 .gitattributes                                     |    3 -
 .github/PULL_REQUEST_TEMPLATE.md                   |    4 +-
 .gitignore                                         |    3 +
 .travis.yml                                        |  371 --
 NOTICE                                             |   35 +-
 azure-pipelines.yml                                |   57 +-
 docs/404.md                                        |    6 +-
 docs/Gemfile                                       |    6 +-
 docs/Gemfile.lock                                  |   59 +-
 docs/_config.yml                                   |   29 +-
 docs/_config_dev_en.yml                            |    1 -
 docs/_config_dev_zh.yml                            |    1 -
 docs/_includes/generated/akka_configuration.html   |   12 +-
 .../generated/all_jobmanager_section.html          |   60 +
 .../generated/all_taskmanager_network_section.html |  102 +
 .../generated/all_taskmanager_section.html         |   97 +
 .../generated/checkpointing_configuration.html     |    8 +-
 docs/_includes/generated/client_configuration.html |   24 +
 .../_includes/generated/cluster_configuration.html |    6 +
 .../common_high_availability_section.html          |   30 +
 .../common_high_availability_zk_section.html       |   24 +
 .../generated/common_host_port_section.html        |   72 +
 .../_includes/generated/common_memory_section.html |  150 +
 .../generated/common_miscellaneous_section.html    |   30 +
 docs/_includes/generated/common_section.html       |   78 -
 .../generated/common_state_backends_section.html   |   54 +
 docs/_includes/generated/core_configuration.html   |   32 +-
 .../generated/deployment_configuration.html        |    6 +
 .../generated/deprecated_file_sinks_section.html   |   24 +
 .../generated/environment_configuration.html       |   12 +
 .../execution_checkpointing_configuration.html     |   66 +
 .../generated/execution_config_configuration.html  |   34 +-
 .../generated/execution_configuration.html         |   24 +
 .../generated/expert_class_loading_section.html    |   36 +
 .../generated/expert_fault_tolerance_section.html  |   66 +
 .../expert_high_availability_section.html          |   18 +
 .../expert_high_availability_zk_section.html       |   84 +
 docs/_includes/generated/expert_rest_section.html  |   66 +
 .../generated/expert_rocksdb_section.html          |   36 +
 .../generated/expert_scheduling_section.html       |   36 +
 .../generated/expert_security_ssl_section.html     |   42 +
 .../generated/expert_state_backends_section.html   |   30 +
 .../generated/external_resource_configuration.html |   36 +
 ...ailure_rate_restart_strategy_configuration.html |    8 +-
 ...fixed_delay_restart_strategy_configuration.html |    4 +-
 .../generated/high_availability_configuration.html |   86 +-
 .../generated/influxdb_reporter_configuration.html |   66 +
 .../generated/job_manager_configuration.html       |   64 +-
 .../generated/kubernetes_config_configuration.html |  168 +
 .../mesos_task_manager_configuration.html          |   12 -
 docs/_includes/generated/metric_configuration.html |    4 +-
 .../netty_shuffle_environment_configuration.html   |   70 +-
 .../generated/network_netty_configuration.html     |    4 +-
 .../generated/optimizer_configuration.html         |    2 +-
 .../generated/pipeline_configuration.html          |   90 +
 docs/_includes/generated/python_configuration.html |   62 +-
 .../generated/resource_manager_configuration.html  |   24 +-
 docs/_includes/generated/rest_v1_dispatcher.html   | 1530 +++--
 .../rocks_db_configurable_configuration.html       |   38 +-
 .../generated/rocks_db_configuration.html          |   38 +-
 .../rocks_db_native_metric_configuration.html      |   24 +
 ...on.html => security_auth_kerberos_section.html} |    0
 ...guration.html => security_auth_zk_section.html} |    0
 .../generated/security_configuration.html          |   94 +-
 docs/_includes/generated/security_ssl_section.html |  120 +
 .../generated/state_backend_rocksdb_section.html   |   42 +
 .../generated/stream_pipeline_configuration.html   |   18 +
 .../generated/table_config_configuration.html      |   24 +
 .../generated/task_manager_configuration.html      |   46 +-
 .../task_manager_memory_configuration.html         |  106 +-
 docs/_includes/generated/web_configuration.html    |   18 +-
 .../generated/yarn_config_configuration.html       |   50 +-
 docs/_includes/sidenav.html                        |    4 +-
 docs/_layouts/404_base.html                        |   35 +-
 docs/_layouts/plain.html                           |    2 +-
 docs/_layouts/redirect.html                        |    2 +-
 docs/build_docs.bat                                |   57 -
 docs/build_docs.sh                                 |    8 +-
 docs/concepts/flink-architecture.md                |  267 +
 docs/concepts/flink-architecture.zh.md             |  267 +
 docs/concepts/glossary.md                          |   62 +-
 docs/concepts/glossary.zh.md                       |   47 +-
 docs/concepts/index.md                             |   67 +-
 docs/concepts/index.zh.md                          |   31 +-
 docs/concepts/programming-model.md                 |  217 -
 docs/concepts/programming-model.zh.md              |  217 -
 docs/concepts/runtime.md                           |  127 -
 docs/concepts/runtime.zh.md                        |   99 -
 docs/concepts/stateful-stream-processing.md        |  324 +
 docs/concepts/stateful-stream-processing.zh.md     |  324 +
 docs/concepts/timely-stream-processing.md          |  214 +
 docs/concepts/timely-stream-processing.zh.md       |  214 +
 docs/connectors/index.md                           |   28 +
 docs/connectors/index.zh.md                        |   28 +
 docs/dev/api_concepts.md                           |  902 ---
 docs/dev/api_concepts.zh.md                        |  770 ---
 docs/dev/application_parameters.md                 |  140 +
 docs/dev/application_parameters.zh.md              |  140 +
 docs/dev/batch/connectors.md                       |   54 +-
 docs/dev/batch/connectors.zh.md                    |   54 +-
 docs/dev/batch/examples.md                         |    2 +-
 docs/dev/batch/examples.zh.md                      |    2 +-
 docs/dev/batch/hadoop_compatibility.md             |    2 +-
 docs/dev/batch/hadoop_compatibility.zh.md          |    2 +-
 docs/dev/batch/index.md                            |  281 +-
 docs/dev/batch/index.zh.md                         |  281 +-
 docs/dev/best_practices.md                         |  298 -
 docs/dev/best_practices.zh.md                      |  298 -
 docs/dev/cluster_execution.md                      |    2 +-
 docs/dev/cluster_execution.zh.md                   |    2 +-
 docs/dev/connectors/cassandra.md                   |    4 +-
 docs/dev/connectors/cassandra.zh.md                |    4 +-
 docs/dev/connectors/elasticsearch.md               |   29 +-
 docs/dev/connectors/elasticsearch.zh.md            |   29 +-
 docs/dev/connectors/filesystem_sink.md             |    2 +-
 docs/dev/connectors/filesystem_sink.zh.md          |    2 +-
 docs/dev/connectors/guarantees.md                  |    2 +-
 docs/dev/connectors/guarantees.zh.md               |   55 +-
 docs/dev/connectors/index.md                       |    9 +-
 docs/dev/connectors/index.zh.md                    |    9 +-
 docs/dev/connectors/jdbc.md                        |   67 +
 docs/dev/connectors/jdbc.zh.md                     |   67 +
 docs/dev/connectors/kafka.md                       |  524 +-
 docs/dev/connectors/kafka.zh.md                    |   70 +-
 docs/dev/connectors/kinesis.md                     |   42 +-
 docs/dev/connectors/kinesis.zh.md                  |   42 +-
 docs/dev/connectors/nifi.md                        |    2 +-
 docs/dev/connectors/nifi.zh.md                     |    2 +-
 docs/dev/connectors/pubsub.md                      |    6 +-
 docs/dev/connectors/pubsub.zh.md                   |   54 +-
 docs/dev/connectors/rabbitmq.md                    |    2 +-
 docs/dev/connectors/rabbitmq.zh.md                 |    2 +-
 docs/dev/connectors/streamfile_sink.md             |  581 +-
 docs/dev/connectors/streamfile_sink.zh.md          |  553 +-
 docs/dev/connectors/twitter.md                     |    2 +-
 docs/dev/connectors/twitter.zh.md                  |    2 +-
 docs/dev/datastream_api.md                         |  224 +-
 docs/dev/datastream_api.zh.md                      |  224 +-
 docs/dev/event_time.md                             |  224 +-
 docs/dev/event_time.zh.md                          |  145 +-
 docs/dev/event_timestamp_extractors.md             |   98 +-
 docs/dev/event_timestamps_watermarks.md            |  453 +-
 docs/dev/event_timestamps_watermarks.zh.md         |    4 +-
 docs/dev/execution_plans.md                        |   11 +-
 docs/dev/execution_plans.zh.md                     |   13 +-
 docs/dev/java_lambdas.md                           |    9 +-
 docs/dev/java_lambdas.zh.md                        |    8 +-
 docs/dev/libraries.md                              |    5 +-
 docs/dev/libraries.zh.md                           |    5 +-
 docs/dev/libs/cep.md                               |  135 +-
 docs/dev/libs/cep.zh.md                            |  874 ++-
 docs/dev/libs/gelly/index.md                       |    2 +-
 docs/dev/libs/gelly/index.zh.md                    |    2 +-
 docs/dev/libs/state_processor_api.md               |  557 +-
 docs/dev/libs/state_processor_api.zh.md            |  557 +-
 docs/dev/migration.md                              |  456 +-
 docs/dev/migration.zh.md                           |  456 +-
 docs/dev/parallel.md                               |    2 +-
 docs/dev/parallel.zh.md                            |    2 +-
 docs/dev/project-configuration.md                  |  559 ++
 docs/dev/project-configuration.zh.md               |  559 ++
 docs/dev/projectsetup/dependencies.md              |  240 -
 docs/dev/projectsetup/dependencies.zh.md           |  202 -
 docs/dev/projectsetup/index.md                     |   25 -
 docs/dev/projectsetup/index.zh.md                  |   25 -
 docs/dev/projectsetup/java_api_quickstart.md       |  354 --
 docs/dev/projectsetup/java_api_quickstart.zh.md    |  339 -
 docs/dev/projectsetup/scala_api_quickstart.md      |  230 -
 docs/dev/projectsetup/scala_api_quickstart.zh.md   |  221 -
 docs/dev/scala_api_extensions.md                   |    4 +-
 docs/dev/scala_api_extensions.zh.md                |    4 +-
 docs/dev/stream/experimental.md                    |   38 +-
 docs/dev/stream/experimental.zh.md                 |   38 +-
 docs/dev/stream/operators/asyncio.md               |    2 +-
 docs/dev/stream/operators/index.md                 |  241 +-
 docs/dev/stream/operators/index.zh.md              |  241 +-
 docs/dev/stream/operators/process_function.md      |    2 +-
 docs/dev/stream/operators/process_function.zh.md   |    5 +-
 docs/dev/stream/operators/windows.md               |    2 +-
 docs/dev/stream/operators/windows.zh.md            |    2 +-
 docs/dev/stream/sources.md                         |  391 ++
 docs/dev/stream/sources.zh.md                      |  391 ++
 docs/dev/stream/state/broadcast_state.md           |   17 +-
 docs/dev/stream/state/broadcast_state.zh.md        |  183 +-
 docs/dev/stream/state/checkpointing.md             |    4 +-
 docs/dev/stream/state/checkpointing.zh.md          |    6 +-
 docs/dev/stream/state/custom_serialization.md      |    8 +-
 docs/dev/stream/state/custom_serialization.zh.md   |   24 +-
 docs/dev/stream/state/index.md                     |   21 +-
 docs/dev/stream/state/index.zh.md                  |   33 +-
 docs/dev/stream/state/queryable_state.md           |    2 +-
 docs/dev/stream/state/queryable_state.zh.md        |  197 +-
 docs/dev/stream/state/state.md                     |  291 +-
 docs/dev/stream/state/state.zh.md                  |  202 +-
 docs/dev/stream/testing.md                         |   88 +-
 docs/dev/stream/testing.zh.md                      |   88 +-
 docs/dev/table/catalogs.md                         |  258 +-
 docs/dev/table/catalogs.zh.md                      |  304 +-
 docs/dev/table/common.md                           |  230 +-
 docs/dev/table/common.zh.md                        |  504 +-
 docs/dev/table/config.md                           |   41 +-
 docs/dev/table/config.zh.md                        |   73 +-
 docs/dev/table/connect.md                          | 1270 ++--
 docs/dev/table/connect.zh.md                       | 1266 ++--
 docs/dev/table/connectors/blackhole.md             |   92 +
 docs/dev/table/connectors/blackhole.zh.md          |   92 +
 docs/dev/table/connectors/datagen.md               |  152 +
 docs/dev/table/connectors/datagen.zh.md            |  152 +
 docs/dev/table/connectors/elasticsearch.md         |  268 +
 docs/dev/table/connectors/elasticsearch.zh.md      |  268 +
 docs/dev/table/connectors/filesystem.md            |  374 ++
 docs/dev/table/connectors/filesystem.zh.md         |  374 ++
 docs/dev/table/connectors/formats/avro.md          |  218 +
 docs/dev/table/connectors/formats/avro.zh.md       |  218 +
 docs/dev/table/connectors/formats/canal.md         |  191 +
 docs/dev/table/connectors/formats/canal.zh.md      |  191 +
 docs/dev/table/connectors/formats/csv.md           |  253 +
 docs/dev/table/connectors/formats/csv.zh.md        |  253 +
 docs/dev/table/connectors/formats/debezium.md      |  207 +
 docs/dev/table/connectors/formats/debezium.zh.md   |  207 +
 docs/dev/table/connectors/formats/index.md         |   72 +
 docs/dev/table/connectors/formats/index.zh.md      |   72 +
 docs/dev/table/connectors/formats/json.md          |  212 +
 docs/dev/table/connectors/formats/json.zh.md       |  212 +
 docs/dev/table/connectors/formats/orc.md           |  183 +
 docs/dev/table/connectors/formats/orc.zh.md        |  183 +
 docs/dev/table/connectors/formats/parquet.md       |  189 +
 docs/dev/table/connectors/formats/parquet.zh.md    |  189 +
 docs/dev/table/connectors/hbase.md                 |  301 +
 docs/dev/table/connectors/hbase.zh.md              |  301 +
 docs/dev/table/connectors/index.md                 |  268 +
 docs/dev/table/connectors/index.zh.md              |  268 +
 docs/dev/table/connectors/jdbc.md                  |  562 ++
 docs/dev/table/connectors/jdbc.zh.md               |  562 ++
 docs/dev/table/connectors/kafka.md                 |  216 +
 docs/dev/table/connectors/kafka.zh.md              |  216 +
 docs/dev/table/connectors/print.md                 |  143 +
 docs/dev/table/connectors/print.zh.md              |  143 +
 docs/dev/table/functions/index.md                  |   12 +-
 docs/dev/table/functions/index.zh.md               |   90 +-
 docs/dev/table/functions/systemFunctions.md        |  948 +--
 docs/dev/table/functions/systemFunctions.zh.md     |  948 +--
 docs/dev/table/functions/udfs.md                   | 1045 +++-
 docs/dev/table/functions/udfs.zh.md                |  465 +-
 docs/dev/table/hive/hive_catalog.md                |  393 ++
 docs/dev/table/hive/hive_catalog.zh.md             |  393 ++
 docs/dev/table/hive/hive_dialect.md                |  347 ++
 docs/dev/table/hive/hive_dialect.zh.md             |  347 ++
 docs/dev/table/hive/hive_functions.md              |   88 +-
 docs/dev/table/hive/hive_functions.zh.md           |  122 +-
 docs/dev/table/hive/hive_read_write.md             |  228 +
 docs/dev/table/hive/hive_read_write.zh.md          |  228 +
 docs/dev/table/hive/hive_streaming.md              |  200 +
 docs/dev/table/hive/hive_streaming.zh.md           |  200 +
 docs/dev/table/hive/index.md                       |  432 +-
 docs/dev/table/hive/index.zh.md                    |  439 +-
 docs/dev/table/hive/read_write_hive.md             |  131 -
 docs/dev/table/hive/read_write_hive.zh.md          |  131 -
 docs/dev/table/hive/scala_shell_hive.md            |   43 -
 docs/dev/table/hive/scala_shell_hive.zh.md         |   43 -
 docs/dev/table/index.md                            |   14 +-
 docs/dev/table/index.zh.md                         |   75 +-
 docs/dev/table/modules.md                          |    5 +-
 docs/dev/table/modules.zh.md                       |    5 +-
 docs/dev/table/python/common_questions.md          |   99 +
 docs/dev/table/python/common_questions.zh.md       |   99 +
 docs/dev/table/python/conversion_of_pandas.md      |   80 +
 docs/dev/table/python/conversion_of_pandas.zh.md   |   80 +
 docs/dev/table/python/dependency_management.md     |  110 +
 docs/dev/table/python/dependency_management.zh.md  |  110 +
 docs/dev/table/python/index.md                     |   38 +
 docs/dev/table/python/index.zh.md                  |   38 +
 docs/dev/table/python/installation.md              |   46 +
 docs/dev/table/python/installation.zh.md           |   46 +
 docs/dev/table/python/metrics.md                   |  207 +
 docs/dev/table/python/metrics.zh.md                |  207 +
 docs/dev/table/python/python_config.md             |   32 +
 docs/dev/table/python/python_config.zh.md          |   32 +
 docs/dev/table/python/python_udfs.md               |  227 +
 docs/dev/table/python/python_udfs.zh.md            |  227 +
 docs/dev/table/python/vectorized_python_udfs.md    |   65 +
 docs/dev/table/python/vectorized_python_udfs.zh.md |   65 +
 docs/dev/table/sourceSinks.md                      |   82 +-
 docs/dev/table/sourceSinks.zh.md                   |   98 +-
 docs/dev/table/sql.md                              | 1464 -----
 docs/dev/table/sql.zh.md                           | 1464 -----
 docs/dev/table/sql/alter.md                        |  169 +
 docs/dev/table/sql/alter.zh.md                     |  168 +
 docs/dev/table/sql/create.md                       |  401 ++
 docs/dev/table/sql/create.zh.md                    |  404 ++
 docs/dev/table/sql/drop.md                         |  184 +
 docs/dev/table/sql/drop.zh.md                      |  184 +
 docs/dev/table/sql/hints.md                        |   88 +
 docs/dev/table/sql/hints.zh.md                     |   88 +
 docs/dev/table/sql/index.md                        |   65 +
 docs/dev/table/sql/index.zh.md                     |   65 +
 docs/dev/table/sql/insert.md                       |  181 +
 docs/dev/table/sql/insert.zh.md                    |  178 +
 docs/dev/table/sql/queries.md                      | 1314 ++++
 docs/dev/table/sql/queries.zh.md                   | 1309 ++++
 docs/dev/table/sqlClient.md                        |  218 +-
 docs/dev/table/sqlClient.zh.md                     |  472 +-
 docs/dev/table/streaming/dynamic_tables.md         |    6 +-
 docs/dev/table/streaming/dynamic_tables.zh.md      |  122 +-
 docs/dev/table/streaming/index.md                  |    2 +-
 docs/dev/table/streaming/index.zh.md               |   24 +-
 docs/dev/table/streaming/joins.md                  |   12 +-
 docs/dev/table/streaming/joins.zh.md               |   12 +-
 docs/dev/table/streaming/match_recognize.md        |   14 +-
 docs/dev/table/streaming/match_recognize.zh.md     |   14 +-
 docs/dev/table/streaming/query_configuration.md    |   36 +-
 docs/dev/table/streaming/query_configuration.zh.md |   36 +-
 docs/dev/table/streaming/temporal_tables.md        |   59 +-
 docs/dev/table/streaming/temporal_tables.zh.md     |  181 +-
 docs/dev/table/streaming/time_attributes.md        |  137 +-
 docs/dev/table/streaming/time_attributes.zh.md     |  244 +-
 docs/dev/table/tableApi.md                         |  646 +-
 docs/dev/table/tableApi.zh.md                      |  624 +-
 docs/dev/table/tuning/index.md                     |    2 +-
 docs/dev/table/tuning/index.zh.md                  |    2 +-
 .../tuning/streaming_aggregation_optimization.md   |   74 +-
 .../streaming_aggregation_optimization.zh.md       |  139 +-
 docs/dev/table/types.md                            |  360 +-
 docs/dev/table/types.zh.md                         |  687 +--
 docs/dev/types_serialization.md                    |  201 +
 docs/dev/types_serialization.zh.md                 |  200 +
 docs/dev/user_defined_functions.md                 |  241 +
 docs/dev/user_defined_functions.zh.md              |  241 +
 docs/downloads/setup-pyflink-virtual-env.sh        |   54 +
 docs/fig/FlinkOnK8s.svg                            |  200 +
 .../fig/application-my-app-state-processor-api.png |  Bin 0 -> 49938 bytes
 docs/fig/back_pressure_sampling.png                |  Bin 17635 -> 17525 bytes
 docs/fig/bounded-unbounded.png                     |  Bin 0 -> 176524 bytes
 docs/fig/connected-streams.svg                     |   66 +
 docs/fig/database-my-app-state-processor-api.png   |  Bin 0 -> 50174 bytes
 docs/fig/detailed-mem-model.svg                    |   21 +
 docs/fig/distributed-runtime.svg                   |  475 ++
 docs/fig/event_ingestion_processing_time.svg       |  375 --
 docs/fig/event_processing_time.svg                 |   18 +
 docs/fig/flink-application-sources-sinks.png       |  Bin 0 -> 221958 bytes
 docs/fig/keyBy.png                                 |  Bin 0 -> 19707 bytes
 docs/fig/local-state.png                           |  Bin 0 -> 172758 bytes
 docs/fig/parallel-job.png                          |  Bin 0 -> 58071 bytes
 docs/fig/per_split_watermarks.svg                  |   20 +
 docs/fig/plan_visualizer.png                       |  Bin 145778 -> 140792 bytes
 docs/fig/process_mem_model.svg                     |   21 +
 docs/fig/processes.svg                             |    2 +-
 docs/fig/program_dataflow.svg                      | 1048 ++--
 docs/fig/simple_mem_model.svg                      |   21 +
 docs/fig/source_components.svg                     |   20 +
 docs/fig/source_reader.svg                         |   20 +
 docs/fig/times_clocks.svg                          |  368 --
 docs/fig/transformation.svg                        |   58 +
 docs/fig/window-assigners.svg                      |  328 +
 docs/flinkDev/building.md                          |   82 +-
 docs/flinkDev/building.zh.md                       |   82 +-
 docs/flinkDev/ide_setup.md                         |   29 +-
 docs/flinkDev/ide_setup.zh.md                      |   29 +-
 docs/flinkDev/index.md                             |    2 +-
 docs/flinkDev/index.zh.md                          |    2 +-
 .../flink-operations-playground.md                 |  828 ---
 .../flink-operations-playground.zh.md              |  828 ---
 docs/getting-started/docker-playgrounds/index.md   |   25 -
 .../getting-started/docker-playgrounds/index.zh.md |   25 -
 docs/getting-started/examples/index.md             |   50 -
 docs/getting-started/examples/index.zh.md          |   49 -
 docs/getting-started/index.md                      |   58 -
 docs/getting-started/index.zh.md                   |   61 -
 docs/getting-started/tutorials/api_tutorials.md    |   25 -
 docs/getting-started/tutorials/api_tutorials.zh.md |   25 -
 docs/getting-started/tutorials/flink_on_windows.md |   87 -
 .../tutorials/flink_on_windows.zh.md               |   87 -
 docs/getting-started/tutorials/index.md            |   25 -
 docs/getting-started/tutorials/index.zh.md         |   25 -
 docs/getting-started/tutorials/local_setup.md      |  297 -
 docs/getting-started/tutorials/local_setup.zh.md   |  297 -
 .../tutorials/setup_instructions.md                |   25 -
 .../tutorials/setup_instructions.zh.md             |   25 -
 .../getting-started/walkthroughs/datastream_api.md |  925 ---
 .../walkthroughs/datastream_api.zh.md              |  926 ---
 docs/getting-started/walkthroughs/index.md         |   25 -
 docs/getting-started/walkthroughs/index.zh.md      |   25 -
 docs/getting-started/walkthroughs/table_api.md     |  494 --
 docs/getting-started/walkthroughs/table_api.zh.md  |  494 --
 docs/index.md                                      |   83 +-
 docs/index.zh.md                                   |   82 +-
 docs/internals/components.md                       |   60 -
 docs/internals/components.zh.md                    |   60 -
 docs/internals/index.md                            |    2 +-
 docs/internals/index.zh.md                         |    2 +-
 docs/internals/stream_checkpointing.md             |  173 -
 docs/internals/stream_checkpointing.zh.md          |  173 -
 docs/internals/task_lifecycle.md                   |    4 +-
 docs/internals/task_lifecycle.zh.md                |    4 +-
 docs/learn-flink/datastream_api.md                 |  236 +
 docs/learn-flink/datastream_api.zh.md              |  213 +
 docs/learn-flink/etl.md                            |  536 ++
 docs/learn-flink/etl.zh.md                         |  435 ++
 docs/learn-flink/event_driven.md                   |  308 +
 docs/learn-flink/event_driven.zh.md                |  297 +
 docs/learn-flink/fault_tolerance.md                |  208 +
 docs/learn-flink/fault_tolerance.zh.md             |  208 +
 docs/learn-flink/index.md                          |  185 +
 docs/learn-flink/index.zh.md                       |  117 +
 docs/learn-flink/streaming_analytics.md            |  475 ++
 docs/learn-flink/streaming_analytics.zh.md         |  475 ++
 docs/monitoring/application_profiling.md           |   37 +-
 docs/monitoring/application_profiling.zh.md        |   35 +-
 docs/monitoring/back_pressure.md                   |   18 +-
 docs/monitoring/back_pressure.zh.md                |   22 +-
 docs/monitoring/checkpoint_monitoring.md           |    4 +-
 docs/monitoring/checkpoint_monitoring.zh.md        |    4 +-
 docs/monitoring/debugging_classloading.md          |    4 +-
 docs/monitoring/debugging_classloading.zh.md       |    4 +-
 docs/monitoring/index.md                           |    2 +-
 docs/monitoring/index.zh.md                        |    2 +-
 docs/monitoring/logging.md                         |   27 +-
 docs/monitoring/logging.zh.md                      |   27 +-
 docs/monitoring/metrics.md                         |   91 +-
 docs/monitoring/metrics.zh.md                      |   91 +-
 docs/ops/cli.md                                    |  239 +-
 docs/ops/cli.zh.md                                 |  245 +-
 docs/ops/config.md                                 |  441 +-
 docs/ops/config.zh.md                              |  441 +-
 docs/ops/deployment/aws.md                         |   71 -
 docs/ops/deployment/aws.zh.md                      |   71 -
 docs/ops/deployment/cluster_setup.md               |   16 +-
 docs/ops/deployment/cluster_setup.zh.md            |   16 +-
 docs/ops/deployment/docker.md                      |  549 +-
 docs/ops/deployment/docker.zh.md                   |  551 +-
 docs/ops/deployment/gce_setup.md                   |   95 -
 docs/ops/deployment/gce_setup.zh.md                |   95 -
 docs/ops/deployment/hadoop.md                      |   60 +-
 docs/ops/deployment/hadoop.zh.md                   |   60 +-
 docs/ops/deployment/index.md                       |  280 +
 docs/ops/deployment/index.zh.md                    |  280 +
 docs/ops/deployment/kubernetes.md                  |  362 +-
 docs/ops/deployment/kubernetes.zh.md               |  380 +-
 docs/ops/deployment/local.md                       |  169 +
 docs/ops/deployment/local.zh.md                    |  169 +
 docs/ops/deployment/mapr_setup.md                  |  134 -
 docs/ops/deployment/mapr_setup.zh.md               |  134 -
 docs/ops/deployment/mesos.md                       |   26 +-
 docs/ops/deployment/mesos.zh.md                    |   20 +-
 docs/ops/deployment/native_kubernetes.md           |  259 +
 docs/ops/deployment/native_kubernetes.zh.md        |  258 +
 docs/ops/deployment/yarn_setup.md                  |   78 +-
 docs/ops/deployment/yarn_setup.zh.md               |   78 +-
 docs/ops/external_resources.md                     |  360 ++
 docs/ops/external_resources.zh.md                  |  360 ++
 docs/ops/filesystems/azure.md                      |   21 +-
 docs/ops/filesystems/azure.zh.md                   |   41 +-
 docs/ops/filesystems/common.md                     |    2 +-
 docs/ops/filesystems/common.zh.md                  |   41 +-
 docs/ops/filesystems/index.md                      |   13 +-
 docs/ops/filesystems/index.zh.md                   |  101 +-
 docs/ops/filesystems/oss.md                        |   11 +-
 docs/ops/filesystems/oss.zh.md                     |   47 +-
 docs/ops/filesystems/s3.md                         |   19 +-
 docs/ops/filesystems/s3.zh.md                      |   96 +-
 docs/ops/index.md                                  |    2 +-
 docs/ops/index.zh.md                               |    2 +-
 docs/ops/jobmanager_high_availability.md           |    9 +
 docs/ops/jobmanager_high_availability.zh.md        |    9 +
 docs/ops/memory/index.md                           |   24 +
 docs/ops/memory/index.zh.md                        |   24 +
 docs/ops/memory/mem_migration.md                   |  283 +
 docs/ops/memory/mem_migration.zh.md                |  218 +
 docs/ops/memory/mem_setup.md                       |  152 +
 docs/ops/memory/mem_setup.zh.md                    |  152 +
 docs/ops/memory/mem_setup_jobmanager.md            |   96 +
 docs/ops/memory/mem_setup_jobmanager.zh.md         |   96 +
 docs/ops/memory/mem_setup_tm.md                    |  167 +
 docs/ops/memory/mem_setup_tm.zh.md                 |  119 +
 docs/ops/memory/mem_trouble.md                     |   79 +
 docs/ops/memory/mem_trouble.zh.md                  |   69 +
 docs/ops/memory/mem_tuning.md                      |   90 +
 docs/ops/memory/mem_tuning.zh.md                   |   75 +
 docs/ops/plugins.md                                |  122 +
 docs/ops/plugins.zh.md                             |  122 +
 docs/ops/production_ready.md                       |    2 +-
 docs/ops/production_ready.zh.md                    |    2 +-
 docs/ops/python_shell.md                           |   34 +-
 docs/ops/python_shell.zh.md                        |   30 +-
 docs/ops/scala_shell.md                            |   10 +-
 docs/ops/scala_shell.zh.md                         |   10 +-
 docs/ops/security-ssl.md                           |   47 +-
 docs/ops/security-ssl.zh.md                        |   49 +-
 docs/ops/state/checkpoints.md                      |   19 +
 docs/ops/state/checkpoints.zh.md                   |   19 +
 docs/ops/state/large_state_tuning.md               |  137 +-
 docs/ops/state/large_state_tuning.zh.md            |  145 +-
 docs/ops/state/savepoints.md                       |    2 +-
 docs/ops/state/savepoints.zh.md                    |    2 +-
 docs/ops/state/state_backends.md                   |  163 +-
 docs/ops/state/state_backends.zh.md                |  160 +-
 docs/ops/upgrading.md                              |   39 +-
 docs/ops/upgrading.zh.md                           |   39 +-
 docs/page/js/flink.js                              |    2 +-
 docs/page/js/jquery.min.js                         |    6 +-
 docs/redirects/aws.md                              |   24 +
 docs/redirects/basic_api_concepts.md               |    2 +-
 docs/redirects/basic_api_concepts2.md              |   24 +
 docs/redirects/best_practices.md                   |    2 +-
 docs/redirects/concepts.md                         |    2 +-
 docs/redirects/datastream-walkthrough.md           |   24 +
 docs/redirects/dependencies.md                     |    2 +-
 docs/redirects/examples.md                         |   24 +
 docs/redirects/flink-operations-playground.md      |   24 +
 docs/redirects/gce_setup.md                        |   24 +
 docs/redirects/getting-started-dependencies.md     |   24 +
 docs/redirects/getting-started.md                  |   24 +
 docs/redirects/java-quickstart.md                  |   24 +
 docs/redirects/local_setup_tutorial.md             |   24 +
 docs/redirects/mapr.md                             |   24 +
 docs/redirects/projectsetup_dependencies.md        |   24 +
 docs/redirects/projectsetup_dependencies.zh.md     |   24 +
 docs/redirects/projectsetup_java_api_quickstart.md |   24 +
 .../projectsetup_java_api_quickstart.zh.md         |   24 +
 .../redirects/projectsetup_scala_api_quickstart.md |   24 +
 .../projectsetup_scala_api_quickstart.zh.md        |   24 +
 docs/redirects/python_table_tutorial.md            |   24 +
 docs/redirects/python_table_walkthrough.md         |   24 +
 docs/redirects/scala-quickstart.md                 |   24 +
 docs/redirects/scala_quickstart.md                 |    2 +-
 docs/redirects/setup_quickstart.md                 |    2 +-
 docs/redirects/sql.md                              |   24 +
 docs/redirects/table-walkthrough.md                |   24 +
 docs/redirects/training.md                         |   24 +
 docs/redirects/tutorials_datastream_api.md         |   24 -
 docs/redirects/tutorials_overview.md               |   24 +
 docs/redirects/windows_local_setup.md              |   24 +
 docs/release-notes/flink-1.10.md                   |  470 ++
 docs/release-notes/flink-1.10.zh.md                |  470 ++
 docs/release-notes/flink-1.8.md                    |    2 +-
 docs/release-notes/flink-1.8.zh.md                 |    2 +-
 docs/try-flink/datastream_api.md                   |  943 +++
 docs/try-flink/datastream_api.zh.md                |  945 +++
 docs/try-flink/flink-operations-playground.md      |  828 +++
 docs/try-flink/flink-operations-playground.zh.md   |  828 +++
 docs/try-flink/index.md                            |   27 +
 docs/try-flink/index.zh.md                         |   26 +
 docs/try-flink/python_table_api.md                 |  183 +
 docs/try-flink/python_table_api.zh.md              |  186 +
 docs/try-flink/table_api.md                        |  512 ++
 docs/try-flink/table_api.zh.md                     |  514 ++
 docs/tutorials/python_table_api.md                 |  159 -
 docs/tutorials/python_table_api.zh.md              |  146 -
 flink-annotations/pom.xml                          |    2 +-
 .../java/org/apache/flink/annotation/Internal.java |    2 +-
 .../flink/annotation/docs/Documentation.java       |   73 +-
 flink-clients/pom.xml                              |  102 +-
 .../java/org/apache/flink/client/ClientUtils.java  |  108 +-
 .../flink/client/FlinkPipelineTranslationUtil.java |   59 +-
 .../org/apache/flink/client/LocalExecutor.java     |  123 -
 .../org/apache/flink/client/RemoteExecutor.java    |  132 -
 .../apache/flink/client/StreamGraphTranslator.java |   69 +
 .../client/cli/AbstractCustomCommandLine.java      |   41 +-
 .../flink/client/cli/ApplicationDeployer.java      |   43 +
 .../org/apache/flink/client/cli/CliFrontend.java   |  334 +-
 .../apache/flink/client/cli/CliFrontendParser.java |   69 +-
 .../org/apache/flink/client/cli/ClientOptions.java |   45 +
 .../org/apache/flink/client/cli/DefaultCLI.java    |    5 +-
 .../flink/client/cli/ExecutionConfigAccessor.java  |   40 +-
 .../org/apache/flink/client/cli/GenericCLI.java    |  153 +
 .../apache/flink/client/cli/ProgramOptions.java    |  132 +-
 .../flink/client/cli/ProgramOptionsUtils.java      |   96 +
 .../AbstractContainerizedClusterClientFactory.java |   60 +
 .../client/deployment/ClusterClientFactory.java    |    2 +
 .../deployment/ClusterClientJobClientAdapter.java  |  146 +
 .../flink/client/deployment/ClusterDescriptor.java |   26 +-
 .../client/deployment/ClusterSpecification.java    |   36 +-
 .../DefaultClusterClientServiceLoader.java         |   10 +-
 .../client/deployment/StandaloneClientFactory.java |    7 +-
 .../deployment/StandaloneClusterDescriptor.java    |   31 +-
 .../application/ApplicationClusterEntryPoint.java  |   97 +
 .../application/ApplicationConfiguration.java      |   91 +
 .../ApplicationDispatcherBootstrap.java            |  312 +
 ...ApplicationDispatcherGatewayServiceFactory.java |   99 +
 ...ationDispatcherLeaderProcessFactoryFactory.java |   87 +
 .../application/ApplicationExecutionException.java |   41 +
 .../deployment/application/ApplicationRunner.java  |   49 +
 .../ClassPathPackagedProgramRetriever.java         |  280 +
 .../application/DetachedApplicationRunner.java     |   86 +
 .../deployment/application/EmbeddedJobClient.java  |  140 +
 .../deployment/application/JarManifestParser.java  |  145 +
 .../application/JobStatusPollingUtils.java         |  104 +
 .../application/WebSubmissionJobClient.java        |   84 +
 .../cli/ApplicationClusterDeployer.java            |   67 +
 .../application/executors/EmbeddedExecutor.java    |  151 +
 .../executors/EmbeddedExecutorFactory.java         |   87 +
 .../executors/EmbeddedExecutorServiceLoader.java   |   72 +
 .../executors/EmbeddedJobClientCreator.java        |   37 +
 .../executors/WebSubmissionExecutorFactory.java    |   80 +
 .../WebSubmissionExecutorServiceLoader.java        |   66 +
 .../executors/AbstractJobClusterExecutor.java      |   77 +
 .../executors/AbstractSessionClusterExecutor.java  |   73 +
 .../client/deployment/executors/LocalExecutor.java |  100 +
 .../deployment/executors/LocalExecutorFactory.java |   47 +
 .../executors/PipelineExecutorUtils.java           |   67 +
 .../deployment/executors/RemoteExecutor.java       |   37 +
 .../executors/RemoteExecutorFactory.java           |   47 +
 .../apache/flink/client/program/ClusterClient.java |   39 +-
 .../client/program/ClusterClientProvider.java      |   35 +
 .../flink/client/program/ContextEnvironment.java   |  187 +-
 .../client/program/ContextEnvironmentFactory.java  |  100 -
 .../client/program/DetachedJobExecutionResult.java |   81 -
 .../flink/client/program/MiniClusterClient.java    |   63 +-
 .../client/program/OptimizerPlanEnvironment.java   |   92 +-
 .../flink/client/program/PackagedProgram.java      |  137 +-
 .../client/program/PackagedProgramRetriever.java   |   37 +
 .../flink/client/program/PackagedProgramUtils.java |  197 +-
 .../client/program/PerJobMiniClusterFactory.java   |  203 +
 .../client/program/ProgramAbortException.java      |   27 +
 .../client/program/StreamContextEnvironment.java   |  164 +
 .../client/program/StreamPlanEnvironment.java      |   64 +
 .../client/program/rest/RestClusterClient.java     |  145 +-
 ...he.flink.core.execution.PipelineExecutorFactory |   17 +
 ...test-assembly-test-user-classloader-job-jar.xml |   35 +
 ...-assembly-test-user-classloader-job-lib-jar.xml |   35 +
 .../RemoteExecutorHostnameResolutionTest.java      |   99 -
 .../flink/client/cli/CliFrontendInfoTest.java      |    8 +-
 .../flink/client/cli/CliFrontendListTest.java      |    2 +-
 .../client/cli/CliFrontendPackageProgramTest.java  |   19 +-
 .../flink/client/cli/CliFrontendRunTest.java       |   21 +-
 .../flink/client/cli/CliFrontendTestUtils.java     |    2 +-
 .../apache/flink/client/cli/ClientOptionsTest.java |   53 +
 .../apache/flink/client/cli/DefaultCLITest.java    |    2 +-
 .../apache/flink/client/cli/GenericCLITest.java    |  138 +
 .../client/cli/util/DummyClusterDescriptor.java    |   21 +-
 .../deployment/ClusterClientServiceLoaderTest.java |    7 +-
 .../ApplicationDispatcherBootstrapTest.java        |  537 ++
 .../ClassPathPackagedProgramRetrieverTest.java     |  359 ++
 .../application/JarManifestParserTest.java         |  160 +
 .../application/JobStatusPollingUtilsTest.java     |  169 +
 .../apache/flink/client/program/ClientTest.java    |  153 +-
 .../client/program/ExecutionPlanCreationTest.java  |    2 +-
 ...aderRetrievalServiceHostnameResolutionTest.java |  104 -
 .../program/OptimizerPlanEnvironmentTest.java      |   72 +
 .../program/PackagedProgramUtilsPipelineTest.java  |  194 +
 .../client/program/PackagedProgramUtilsTest.java   |   61 +
 .../program/PerJobMiniClusterFactoryTest.java      |  211 +
 .../flink/client/program/TestingClusterClient.java |   24 +-
 .../client/program/rest/RestClusterClientTest.java |  102 +-
 .../flink/client/testjar/MultiExecuteJob.java      |   50 +
 .../org/apache/flink/client/testjar/TestJob.java   |   62 +
 .../apache/flink/client/testjar/TestJobInfo.java   |   33 +
 .../client/testjar/TestUserClassLoaderJob.java     |   41 +
 .../client/testjar/TestUserClassLoaderJobLib.java  |   32 +
 .../org/apache/flink/client/testjar/WordCount.java |  171 -
 .../src/test/resources/log4j-test.properties       |   30 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../src/test/resources/testconfig/flink-conf.yaml  |    1 +
 flink-connectors/flink-connector-base/pom.xml      |   61 +
 .../base/source/event/NoMoreSplitsEvent.java       |   36 +
 .../base/source/reader/RecordEmitter.java          |   48 +
 .../base/source/reader/RecordsBySplits.java        |  116 +
 .../base/source/reader/RecordsWithSplitIds.java    |   50 +
 .../SingleThreadMultiplexSourceReaderBase.java     |   57 +
 .../base/source/reader/SourceReaderBase.java       |  265 +
 .../base/source/reader/SourceReaderOptions.java    |   52 +
 .../base/source/reader/SplitsRecordIterator.java   |   96 +
 .../base/source/reader/fetcher/AddSplitsTask.java  |   72 +
 .../base/source/reader/fetcher/FetchTask.java      |  107 +
 .../reader/fetcher/SingleThreadFetcherManager.java |   55 +
 .../base/source/reader/fetcher/SplitFetcher.java   |  314 +
 .../source/reader/fetcher/SplitFetcherManager.java |  184 +
 .../source/reader/fetcher/SplitFetcherTask.java    |   41 +
 .../source/reader/splitreader/SplitReader.java     |   60 +
 .../source/reader/splitreader/SplitsAddition.java  |   33 +
 .../source/reader/splitreader/SplitsChange.java    |   41 +
 .../FutureCompletingBlockingQueue.java             |   90 +
 .../reader/synchronization/FutureNotifier.java     |   66 +
 .../source/reader/CoordinatedSourceITCase.java     |   91 +
 .../base/source/reader/SourceReaderBaseTest.java   |  143 +
 .../base/source/reader/SourceReaderTestBase.java   |  221 +
 .../source/reader/fetcher/SplitFetcherTest.java    |  114 +
 .../base/source/reader/mocks/MockBaseSource.java   |  138 +
 .../source/reader/mocks/MockRecordEmitter.java     |   37 +
 .../base/source/reader/mocks/MockSourceReader.java |   62 +
 .../source/reader/mocks/MockSplitEnumerator.java   |   90 +
 .../base/source/reader/mocks/MockSplitReader.java  |  107 +
 .../reader/synchronization/FutureNotifierTest.java |  131 +
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-connectors/flink-connector-cassandra/pom.xml |   17 +-
 .../cassandra/CassandraAppendTableSink.java        |    4 -
 .../connectors/cassandra/CassandraSinkBase.java    |    2 +-
 .../src/main/resources/META-INF/NOTICE             |   13 +-
 .../cassandra/CassandraConnectorITCase.java        |   12 +-
 .../cassandra/CassandraSinkBaseTest.java           |   51 +-
 .../src/test/resources/log4j-test.properties       |   28 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../flink-connector-elasticsearch-base/pom.xml     |   21 +-
 .../elasticsearch/ElasticsearchApiCallBridge.java  |   12 +-
 .../elasticsearch/ElasticsearchSinkBase.java       |   28 +-
 .../elasticsearch/ElasticsearchSinkFunction.java   |   10 +
 .../ElasticsearchUpsertTableSinkBase.java          |   50 +-
 .../ElasticsearchUpsertTableSinkFactoryBase.java   |   45 +-
 .../index/AbstractTimeIndexGenerator.java          |   40 +
 .../elasticsearch/index/IndexGenerator.java        |   41 +
 .../elasticsearch/index/IndexGeneratorBase.java    |   51 +
 .../elasticsearch/index/IndexGeneratorFactory.java |  279 +
 .../elasticsearch/index/StaticIndexGenerator.java  |   35 +
 .../table/AbstractTimeIndexGenerator.java          |   43 +
 .../table/ElasticsearchConfiguration.java          |  157 +
 .../elasticsearch/table/ElasticsearchOptions.java  |  134 +
 .../table/ElasticsearchValidationUtils.java        |   93 +
 .../elasticsearch/table/IndexGenerator.java        |   42 +
 .../elasticsearch/table/IndexGeneratorBase.java    |   54 +
 .../elasticsearch/table/IndexGeneratorFactory.java |  276 +
 .../elasticsearch/table/KeyExtractor.java          |  131 +
 .../elasticsearch/table/RequestFactory.java        |   67 +
 .../table/RowElasticsearchSinkFunction.java        |  142 +
 .../elasticsearch/table/StaticIndexGenerator.java  |   37 +
 .../elasticsearch/util/NoOpFailureHandler.java     |    9 +
 .../flink/table/descriptors/Elasticsearch.java     |   19 +-
 .../table/descriptors/ElasticsearchValidator.java  |   65 +-
 .../elasticsearch/ElasticsearchSinkBaseTest.java   |   53 +-
 .../elasticsearch/ElasticsearchSinkTestBase.java   |   84 +-
 ...lasticsearchUpsertTableSinkFactoryTestBase.java |  121 +-
 .../elasticsearch/index/IndexGeneratorTest.java    |  246 +
 .../table/IndexGeneratorFactoryTest.java           |  213 +
 .../elasticsearch/table/KeyExtractorTest.java      |  130 +
 .../elasticsearch/table/TestContext.java           |   79 +
 .../testutils/ElasticsearchResource.java           |   78 +
 .../testutils/SourceSinkDataTestKit.java           |   44 +-
 .../flink/table/descriptors/ElasticsearchTest.java |   43 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../flink-connector-elasticsearch2/pom.xml         |  229 -
 .../Elasticsearch2ApiCallBridge.java               |  129 -
 .../elasticsearch2/ElasticsearchSink.java          |  111 -
 .../elasticsearch2/ElasticsearchSinkFunction.java  |   63 -
 .../OldNewElasticsearchSinkFunctionBridge.java     |   47 -
 .../elasticsearch2/OldNewRequestIndexerBridge.java |   44 -
 .../connectors/elasticsearch2/RequestIndexer.java  |   32 -
 .../src/main/resources/META-INF/NOTICE             |   83 -
 .../resources/META-INF/licenses/LICENSE.base64     |   26 -
 .../META-INF/licenses/LICENSE.hdrhistogram         |  125 -
 .../resources/META-INF/licenses/LICENSE.jsr166e    |  121 -
 .../resources/META-INF/licenses/LICENSE.jsr166y    |   26 -
 .../main/resources/META-INF/licenses/LICENSE.jzlib |   26 -
 .../resources/META-INF/licenses/LICENSE.webbit     |   38 -
 .../EmbeddedElasticsearchNodeEnvironmentImpl.java  |   69 -
 .../elasticsearch2/ElasticsearchSinkITCase.java    |   97 -
 .../src/test/resources/log4j-test.properties       |   27 -
 .../flink-connector-elasticsearch5/pom.xml         |  119 +-
 .../Elasticsearch5ApiCallBridge.java               |   31 +-
 .../src/main/resources/META-INF/NOTICE             |   76 +-
 .../resources/META-INF/log4j-provider.properties   |   23 -
 .../EmbeddedElasticsearchNodeEnvironmentImpl.java  |    2 +-
 .../elasticsearch5/ElasticsearchSinkITCase.java    |   19 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../flink-connector-elasticsearch6/pom.xml         |   51 +-
 .../table/Elasticsearch6Configuration.java         |   80 +
 .../table/Elasticsearch6DynamicSink.java           |  252 +
 .../table/Elasticsearch6DynamicSinkFactory.java    |  158 +
 .../Elasticsearch6ApiCallBridge.java               |   29 +-
 .../elasticsearch6/ElasticsearchSink.java          |   12 -
 .../org.apache.flink.table.factories.Factory       |   16 +
 .../Elasticsearch6DynamicSinkFactoryTest.java      |  207 +
 .../table/Elasticsearch6DynamicSinkITCase.java     |  266 +
 .../table/Elasticsearch6DynamicSinkTest.java       |  224 +
 .../Elasticsearch6UpsertTableSinkFactoryTest.java  |   15 +-
 .../elasticsearch6/ElasticsearchSinkITCase.java    |    9 +-
 .../src/test/resources/log4j-test.properties       |   24 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../flink-connector-elasticsearch7/pom.xml         |   53 +-
 .../table/Elasticsearch7Configuration.java         |   71 +
 .../table/Elasticsearch7DynamicSink.java           |  253 +
 .../table/Elasticsearch7DynamicSinkFactory.java    |  157 +
 .../Elasticsearch7ApiCallBridge.java               |   29 +-
 .../org.apache.flink.table.factories.Factory       |   16 +
 .../Elasticsearch7DynamicSinkFactoryTest.java      |  200 +
 .../table/Elasticsearch7DynamicSinkITCase.java     |  258 +
 .../table/Elasticsearch7DynamicSinkTest.java       |  224 +
 .../Elasticsearch7UpsertTableSinkFactoryTest.java  |   33 +-
 .../elasticsearch7/ElasticsearchSinkITCase.java    |    9 +-
 .../src/test/resources/log4j-test.properties       |   24 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../flink-connector-filesystem/pom.xml             |   39 +-
 .../connectors/fs/bucketing/BucketingSink.java     |   20 +-
 .../src/main/resources/log4j.properties            |   27 -
 .../fs/bucketing/BucketingSinkMigrationTest.java   |    9 +-
 ...bucketing-sink-migration-test-flink1.2-snapshot |  Bin 1623 -> 0 bytes
 .../src/test/resources/log4j-test.properties       |   29 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../flink-connector-gcp-pubsub/pom.xml             |    2 +-
 .../gcp/pubsub/DeserializationSchemaWrapper.java   |   13 +-
 .../connectors/gcp/pubsub/PubSubSink.java          |    2 +
 .../connectors/gcp/pubsub/PubSubSource.java        |   47 +-
 .../gcp/pubsub/common/AcknowledgeOnCheckpoint.java |    4 +
 .../pubsub/common/PubSubDeserializationSchema.java |   31 +
 .../pubsub/DeserializationSchemaWrapperTest.java   |   23 +-
 .../connectors/gcp/pubsub/PubSubConsumingTest.java |  250 +
 .../connectors/gcp/pubsub/PubSubSourceTest.java    |   82 +-
 .../src/test/resources/log4j-test.properties       |   24 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-connectors/flink-connector-hbase/pom.xml     |  397 ++
 .../flink/addons/hbase/TableInputFormat.java       |   38 +
 .../connector/hbase/HBaseDynamicTableFactory.java  |  205 +
 .../flink/connector/hbase/HBaseTableFactory.java   |  212 +
 .../connector/hbase/options/HBaseOptions.java      |  138 +
 .../connector/hbase/options/HBaseWriteOptions.java |  142 +
 .../hbase/sink/HBaseDynamicTableSink.java          |  111 +
 .../hbase/sink/HBaseMutationConverter.java         |   46 +
 .../connector/hbase/sink/HBaseSinkFunction.java    |  242 +
 .../connector/hbase/sink/HBaseUpsertTableSink.java |  133 +
 .../hbase/sink/LegacyMutationConverter.java        |   55 +
 .../hbase/sink/RowDataToMutationConverter.java     |   57 +
 .../hbase/source/AbstractTableInputFormat.java     |  279 +
 .../hbase/source/HBaseDynamicTableSource.java      |  118 +
 .../connector/hbase/source/HBaseInputFormat.java   |  103 +
 .../hbase/source/HBaseLookupFunction.java          |  152 +
 .../hbase/source/HBaseRowDataInputFormat.java      |  100 +
 .../hbase/source/HBaseRowDataLookupFunction.java   |  154 +
 .../hbase/source/HBaseRowInputFormat.java          |  117 +
 .../connector/hbase/source/HBaseTableSource.java   |  198 +
 .../connector/hbase/source/TableInputSplit.java    |   91 +
 .../hbase/util/HBaseConfigurationUtil.java         |  164 +
 .../connector/hbase/util/HBaseReadWriteHelper.java |  226 +
 .../flink/connector/hbase/util/HBaseSerde.java     |  461 ++
 .../connector/hbase/util/HBaseTableSchema.java     |  384 ++
 .../flink/connector/hbase/util/HBaseTypeUtils.java |  231 +
 .../org/apache/flink/table/descriptors/HBase.java  |    0
 .../flink/table/descriptors/HBaseValidator.java    |    0
 .../org.apache.flink.table.factories.Factory       |   16 +
 .../org.apache.flink.table.factories.TableFactory  |   16 +
 .../connector/hbase/HBaseConnectorITCase.java      |  633 ++
 .../flink/connector/hbase/HBaseDescriptorTest.java |  120 +
 .../hbase/HBaseDynamicTableFactoryTest.java        |  349 ++
 .../connector/hbase/HBaseTableFactoryTest.java     |  186 +
 .../flink/connector/hbase/HBaseTablePlanTest.java  |  127 +
 .../hbase/example/HBaseFlinkTestConstants.java     |   30 +
 .../connector/hbase/example/HBaseReadExample.java  |   85 +
 .../connector/hbase/example/HBaseWriteExample.java |  206 +
 .../hbase/example/HBaseWriteStreamExample.java     |  110 +
 .../hbase/util/HBaseConfigLoadingTest.java         |  176 +
 .../flink/connector/hbase/util/HBaseTestBase.java  |  204 +
 .../hbase/util/HBaseTestingClusterAutoStarter.java |  177 +
 .../flink/connector/hbase/util/PlannerType.java    |   27 +
 .../src/test/resources/hbase-site.xml              |   29 +
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../flink/connector/hbase/HBaseTablePlanTest.xml   |   36 +
 flink-connectors/flink-connector-hive/pom.xml      |  427 +-
 .../apache/flink/connectors/hive/ConsumeOrder.java |   63 +
 .../flink/connectors/hive/FlinkHiveException.java  |    4 +
 .../connectors/hive/HadoopFileSystemFactory.java   |   48 +
 .../connectors/hive/HiveDynamicTableFactory.java   |   88 +
 .../apache/flink/connectors/hive/HiveOptions.java  |   55 +
 .../hive/HiveRowDataPartitionComputer.java         |   77 +
 .../connectors/hive/HiveRowPartitionComputer.java  |   68 +
 .../flink/connectors/hive/HiveTableFactory.java    |   64 +-
 .../connectors/hive/HiveTableInputFormat.java      |  277 -
 .../flink/connectors/hive/HiveTableInputSplit.java |   47 -
 .../connectors/hive/HiveTableMetaStoreFactory.java |  139 +
 .../connectors/hive/HiveTableOutputFormat.java     |  486 --
 .../flink/connectors/hive/HiveTablePartition.java  |   47 +-
 .../flink/connectors/hive/HiveTableSink.java       |  262 +-
 .../flink/connectors/hive/HiveTableSource.java     |  480 +-
 .../flink/connectors/hive/JobConfWrapper.java      |   62 +
 .../hive/read/DirectoryMonitorDiscovery.java       |  112 +
 .../read/HiveContinuousMonitoringFunction.java     |  359 ++
 .../hive/read/HiveMapredSplitReader.java           |  186 +
 .../hive/read/HiveTableFileInputFormat.java        |  115 +
 .../connectors/hive/read/HiveTableInputFormat.java |  370 ++
 .../connectors/hive/read/HiveTableInputSplit.java  |   80 +
 .../hive/read/HiveVectorizedOrcSplitReader.java    |  111 +
 .../read/HiveVectorizedParquetSplitReader.java     |   97 +
 .../connectors/hive/read/PartitionDiscovery.java   |   78 +
 .../flink/connectors/hive/read/SplitReader.java    |   62 +
 .../hive/read/TimestampedHiveInputSplit.java       |  237 +
 .../hive/write/HiveBulkWriterFactory.java          |   81 +
 .../hive/write/HiveOutputFormatFactory.java        |   81 +
 .../connectors/hive/write/HiveWriterFactory.java   |  229 +
 .../flink/table/catalog/hive/HiveCatalog.java      |  565 +-
 .../table/catalog/hive/HiveCatalogConfig.java      |    3 -
 .../flink/table/catalog/hive/HiveDatabaseUtil.java |  108 +
 .../hive/client/HiveMetastoreClientWrapper.java    |   47 +-
 .../flink/table/catalog/hive/client/HiveShim.java  |  110 +-
 .../table/catalog/hive/client/HiveShimV100.java    |  306 +-
 .../table/catalog/hive/client/HiveShimV110.java    |   23 +-
 .../table/catalog/hive/client/HiveShimV120.java    |  125 +-
 .../table/catalog/hive/client/HiveShimV200.java    |   16 +
 .../table/catalog/hive/client/HiveShimV210.java    |  124 +
 .../table/catalog/hive/client/HiveShimV230.java    |   16 -
 .../table/catalog/hive/client/HiveShimV310.java    |  261 +-
 .../factories/HiveFunctionDefinitionFactory.java   |    5 +-
 .../catalog/hive/util/HiveReflectionUtils.java     |   23 +-
 .../table/catalog/hive/util/HiveStatsUtil.java     |  194 +-
 .../table/catalog/hive/util/HiveTableUtil.java     |  433 +-
 .../table/catalog/hive/util/HiveTypeUtil.java      |   73 +-
 .../functions/hive/DeferredObjectAdapter.java      |    5 +-
 .../table/functions/hive/HiveGenericUDAF.java      |    8 +-
 .../flink/table/functions/hive/HiveGenericUDF.java |    9 +-
 .../table/functions/hive/HiveGenericUDTF.java      |   10 +-
 .../table/functions/hive/HiveScalarFunction.java   |    4 +-
 .../flink/table/functions/hive/HiveSimpleUDF.java  |   17 +-
 .../functions/hive/conversion/HiveInspectors.java  |  334 +-
 .../hive/conversion/HiveObjectConversion.java      |    8 +-
 .../hive/conversion/IdentityConversion.java        |    2 +
 .../conversion/WritableHiveObjectConversion.java   |   10 +-
 .../apache/flink/table/module/hive/HiveModule.java |   38 +-
 .../table/module/hive/HiveModuleDescriptor.java    |    9 +-
 .../flink/table/module/hive/HiveModuleFactory.java |    4 +-
 .../src/main/resources/META-INF/NOTICE             |   13 +
 .../connectors/hive/FlinkStandaloneHiveRunner.java |   83 +-
 .../hive/FlinkStandaloneHiveServerContext.java     |   82 +-
 .../flink/connectors/hive/HiveDialectITCase.java   |  470 ++
 .../connectors/hive/HiveLookupJoinITCase.java      |  105 +
 .../hive/HiveOutputFormatFactoryTest.java          |   94 +
 .../connectors/hive/HiveTableFactoryTest.java      |   23 +-
 .../flink/connectors/hive/HiveTableSinkITCase.java |  517 ++
 .../flink/connectors/hive/HiveTableSinkTest.java   |  269 -
 .../connectors/hive/HiveTableSourceITCase.java     |  724 +++
 .../flink/connectors/hive/HiveTableSourceTest.java |  227 -
 .../hive/TableEnvHiveConnectorITCase.java          |  724 +++
 .../connectors/hive/TableEnvHiveConnectorTest.java |  320 -
 .../hive/read/DirectoryMonitorDiscoveryTest.java   |   90 +
 .../hive/read/HiveTableFileInputFormatTest.java    |   50 +
 .../apache/flink/table/HiveVersionTestUtil.java    |    2 +
 .../catalog/hive/HiveCatalogDataTypeTest.java      |    6 +-
 .../hive/HiveCatalogGenericMetadataTest.java       |   37 +-
 .../catalog/hive/HiveCatalogHiveMetadataTest.java  |  140 +-
 .../table/catalog/hive/HiveCatalogITCase.java      |  262 +-
 .../catalog/hive/HiveCatalogMetadataTestBase.java  |   76 +
 .../flink/table/catalog/hive/HiveCatalogTest.java  |   83 +
 .../table/catalog/hive/HiveCatalogTestBase.java    |   56 -
 .../catalog/hive/HiveCatalogUseBlinkITCase.java    |   76 +-
 .../flink/table/catalog/hive/HiveTestUtils.java    |   68 +-
 .../hive/factories/HiveCatalogFactoryTest.java     |   48 +-
 .../table/catalog/hive/util/HiveTableUtilTest.java |   69 +
 .../table/functions/hive/HiveGenericUDFTest.java   |   17 +-
 .../table/functions/hive/HiveGenericUDTFTest.java  |    2 +-
 .../table/functions/hive/HiveSimpleUDFTest.java    |   68 +-
 .../module/hive/HiveModuleDescriptorTest.java      |    5 +-
 .../table/module/hive/HiveModuleFactoryTest.java   |   53 +
 .../flink/table/module/hive/HiveModuleTest.java    |  121 +-
 .../src/test/resources/csv/test3.csv               |    5 +
 .../src/test/resources/log4j-test.properties       |   24 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../test-catalog-factory-conf/hive-site.xml        |   48 +
 flink-connectors/flink-connector-jdbc/pom.xml      |  153 +
 .../flink/api/java/io/jdbc/JDBCInputFormat.java    |  202 +
 .../flink/api/java/io/jdbc/JDBCOutputFormat.java   |  226 +
 .../jdbc/split/GenericParameterValuesProvider.java |   43 +
 .../split/NumericBetweenParametersProvider.java    |   65 +
 .../io/jdbc/split/ParameterValuesProvider.java     |   34 +
 .../connector/jdbc/JdbcConnectionOptions.java      |   99 +
 .../flink/connector/jdbc/JdbcExecutionOptions.java |  112 +
 .../flink/connector/jdbc/JdbcInputFormat.java      |  448 ++
 .../flink/connector/jdbc/JdbcOutputFormat.java     |  143 +
 .../org/apache/flink/connector/jdbc/JdbcSink.java  |   77 +
 .../flink/connector/jdbc/JdbcStatementBuilder.java |   36 +
 .../jdbc/catalog/AbstractJdbcCatalog.java          |  325 +
 .../flink/connector/jdbc/catalog/JdbcCatalog.java  |   91 +
 .../connector/jdbc/catalog/JdbcCatalogUtils.java   |   55 +
 .../connector/jdbc/catalog/PostgresCatalog.java    |  383 ++
 .../connector/jdbc/catalog/PostgresTablePath.java  |   99 +
 .../jdbc/catalog/factory/JdbcCatalogFactory.java   |   93 +
 .../connector/jdbc/dialect/AbstractDialect.java    |   97 +
 .../flink/connector/jdbc/dialect/DerbyDialect.java |  113 +
 .../flink/connector/jdbc/dialect/JdbcDialect.java  |  159 +
 .../flink/connector/jdbc/dialect/JdbcDialects.java |   47 +
 .../flink/connector/jdbc/dialect/MySQLDialect.java |  135 +
 .../connector/jdbc/dialect/PostgresDialect.java    |  134 +
 .../jdbc/internal/AbstractJdbcOutputFormat.java    |   94 +
 .../jdbc/internal/GenericJdbcSinkFunction.java     |   71 +
 .../jdbc/internal/JdbcBatchingOutputFormat.java    |  352 ++
 .../jdbc/internal/TableJdbcUpsertOutputFormat.java |  131 +
 .../connection/JdbcConnectionProvider.java         |   32 +
 .../connection/SimpleJdbcConnectionProvider.java   |   76 +
 .../converter/AbstractJdbcRowConverter.java        |  252 +
 .../jdbc/internal/converter/DerbyRowConverter.java |   38 +
 .../jdbc/internal/converter/JdbcRowConverter.java  |   48 +
 .../jdbc/internal/converter/MySQLRowConverter.java |   38 +
 .../internal/converter/PostgresRowConverter.java   |  112 +
 .../executor/InsertOrUpdateJdbcExecutor.java       |  134 +
 .../executor/JdbcBatchStatementExecutor.java       |   59 +
 .../executor/KeyedBatchStatementExecutor.java      |   87 +
 .../executor/SimpleBatchStatementExecutor.java     |   83 +
 .../jdbc/internal/options/JdbcDmlOptions.java      |  151 +
 .../jdbc/internal/options/JdbcInsertOptions.java   |   54 +
 .../jdbc/internal/options/JdbcLookupOptions.java   |  105 +
 .../jdbc/internal/options/JdbcOptions.java         |  156 +
 .../jdbc/internal/options/JdbcReadOptions.java     |  163 +
 .../internal/options/JdbcTypedQueryOptions.java    |   50 +
 .../split/JdbcGenericParameterValuesProvider.java  |   45 +
 .../JdbcNumericBetweenParametersProvider.java      |  115 +
 .../jdbc/split/JdbcParameterValuesProvider.java    |   36 +
 .../jdbc/table/JdbcDynamicTableFactory.java        |  316 +
 .../connector/jdbc/table/JdbcDynamicTableSink.java |  122 +
 .../jdbc/table/JdbcDynamicTableSource.java         |  168 +
 .../connector/jdbc/table/JdbcLookupFunction.java   |  321 +
 .../jdbc/table/JdbcRowDataInputFormat.java         |  403 ++
 .../jdbc/table/JdbcRowDataLookupFunction.java      |  236 +
 .../jdbc/table/JdbcRowDataOutputFormat.java        |  296 +
 .../connector/jdbc/table/JdbcTableSource.java      |  268 +
 .../jdbc/table/JdbcTableSourceSinkFactory.java     |  225 +
 .../connector/jdbc/table/JdbcUpsertTableSink.java  |  223 +
 .../flink/connector/jdbc/utils/JdbcTypeUtil.java   |  133 +
 .../flink/connector/jdbc/utils/JdbcUtils.java      |  242 +
 .../table/descriptors/JdbcCatalogDescriptor.java   |   68 +
 .../table/descriptors/JdbcCatalogValidator.java    |   43 +
 .../flink/table/descriptors/JdbcValidator.java     |  142 +
 .../org.apache.flink.table.factories.Factory       |   16 +
 .../org.apache.flink.table.factories.TableFactory  |   17 +
 .../api/java/io/jdbc/JDBCInputFormatTest.java      |  372 ++
 .../api/java/io/jdbc/JDBCOutputFormatTest.java     |  259 +
 .../apache/flink/connector/jdbc/DbMetadata.java    |   36 +
 .../flink/connector/jdbc/DerbyDbMetadata.java      |   64 +
 .../flink/connector/jdbc/JdbcDataTestBase.java     |   80 +
 .../flink/connector/jdbc/JdbcDataTypeTest.java     |  195 +
 .../apache/flink/connector/jdbc/JdbcITCase.java    |  104 +
 .../flink/connector/jdbc/JdbcInputFormatTest.java  |  371 ++
 .../connector/jdbc/JdbcLookupFunctionTest.java     |  126 +
 .../flink/connector/jdbc/JdbcOutputFormatTest.java |  352 ++
 .../apache/flink/connector/jdbc/JdbcTestBase.java  |   41 +
 .../flink/connector/jdbc/JdbcTestFixture.java      |  191 +
 .../jdbc/catalog/JdbcCatalogUtilsTest.java         |   44 +
 .../jdbc/catalog/PostgresCatalogITCase.java        |  157 +
 .../jdbc/catalog/PostgresCatalogTest.java          |  167 +
 .../jdbc/catalog/PostgresCatalogTestBase.java      |  321 +
 .../jdbc/catalog/PostgresTablePathTest.java        |   33 +
 .../catalog/factory/JdbcCatalogFactoryTest.java    |   88 +
 .../connector/jdbc/internal/JdbcFullTest.java      |  178 +
 .../jdbc/internal/JdbcTableOutputFormatTest.java   |  151 +
 .../NumericBetweenParametersProviderTest.java      |  122 +
 .../jdbc/table/JdbcAppendOnlyWriterTest.java       |  116 +
 .../jdbc/table/JdbcDynamicTableFactoryTest.java    |  310 +
 .../jdbc/table/JdbcDynamicTableSinkITCase.java     |  276 +
 .../jdbc/table/JdbcDynamicTableSourceITCase.java   |  170 +
 .../jdbc/table/JdbcLookupTableITCase.java          |  164 +
 .../connector/jdbc/table/JdbcLookupTestBase.java   |  105 +
 .../jdbc/table/JdbcRowDataInputFormatTest.java     |  326 +
 .../jdbc/table/JdbcRowDataLookupFunctionTest.java  |  129 +
 .../jdbc/table/JdbcRowDataOutputFormatTest.java    |  433 ++
 .../connector/jdbc/table/JdbcTablePlanTest.java    |   54 +
 .../jdbc/table/JdbcTableSourceITCase.java          |  197 +
 .../jdbc/table/JdbcTableSourceSinkFactoryTest.java |  275 +
 .../jdbc/table/JdbcUpsertTableSinkITCase.java      |  263 +
 .../jdbc/table/UnsignedTypeConversionITCase.java   |  184 +
 .../connector/jdbc/utils/JdbcTypeUtilTest.java     |   52 +
 .../descriptors/JdbcCatalogDescriptorTest.java     |   63 +
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../connector/jdbc/table/JdbcTablePlanTest.xml     |   35 +
 .../flink-connector-kafka-0.10/pom.xml             |  103 +-
 .../connectors/kafka/FlinkKafkaConsumer010.java    |  130 +-
 .../connectors/kafka/FlinkKafkaProducer010.java    |   74 +-
 .../connectors/kafka/Kafka010TableSource.java      |    8 +-
 .../kafka/Kafka010TableSourceSinkFactory.java      |    6 +-
 .../connectors/kafka/internal/Handover.java        |    0
 .../connectors/kafka/internal/Kafka010Fetcher.java |  201 +-
 .../internal/Kafka010PartitionDiscoverer.java      |   75 +-
 .../kafka/internal/KafkaConsumerCallBridge010.java |   54 -
 .../kafka/internal/KafkaConsumerThread.java        |  584 ++
 .../kafka/table/Kafka010DynamicSink.java           |   81 +
 .../kafka/table/Kafka010DynamicSource.java         |   98 +
 .../kafka/table/Kafka010DynamicTableFactory.java   |   82 +
 .../org.apache.flink.table.factories.Factory       |   16 +
 .../src/main/resources/log4j.properties            |   28 -
 .../connectors/kafka/FlinkKafkaProducerTest.java   |   72 +
 .../streaming/connectors/kafka/Kafka010ITCase.java |    5 +
 .../connectors/kafka/Kafka010SecuredRunITCase.java |   63 +
 .../kafka/Kafka010TableSourceSinkFactoryTest.java  |    6 +-
 .../connectors/kafka/KafkaTestEnvironmentImpl.java |   63 +-
 .../connectors/kafka/internal/HandoverTest.java    |    0
 .../kafka/internal/Kafka010FetcherTest.java        |    9 +-
 .../kafka/internal/KafkaConsumerThreadTest.java    | 1124 ++++
 .../table/Kafka010DynamicTableFactoryTest.java     |   93 +
 .../kafka/table/Kafka010TableITCase.java           |   37 +
 .../src/test/resources/log4j-test.properties       |   30 -
 .../src/test/resources/log4j2-test.properties      |   38 +
 .../flink-connector-kafka-0.11/pom.xml             |   69 +-
 .../connectors/kafka/FlinkKafkaProducer011.java    |   35 +-
 .../connectors/kafka/Kafka011TableSink.java        |    3 +-
 .../connectors/kafka/Kafka011TableSource.java      |    8 +-
 .../kafka/Kafka011TableSourceSinkFactory.java      |    6 +-
 .../kafka/internal/FlinkKafkaProducer.java         |   20 +-
 .../kafka/table/Kafka011DynamicSink.java           |   81 +
 .../kafka/table/Kafka011DynamicSource.java         |   98 +
 .../kafka/table/Kafka011DynamicTableFactory.java   |   79 +
 .../org.apache.flink.table.factories.Factory       |   16 +
 .../src/main/resources/log4j.properties            |   28 -
 .../connectors/kafka/FlinkKafkaProducerTest.java   |   72 +
 .../streaming/connectors/kafka/Kafka011ITCase.java |    5 +
 .../kafka/Kafka011SerializerUpgradeTest.java       |  162 +
 .../kafka/Kafka011TableSourceSinkFactoryTest.java  |    6 +-
 .../KafkaSerializerSnapshotsMigrationTest.java     |   59 -
 .../connectors/kafka/KafkaTestEnvironmentImpl.java |   79 +-
 .../table/Kafka011DynamicTableFactoryTest.java     |   93 +
 .../kafka/table/Kafka011TableITCase.java           |   37 +
 .../serializer-snapshot                            |  Bin 0 -> 129 bytes
 .../context-state-serializer-1.11/test-data        |  Bin 0 -> 19 bytes
 .../flink-1.6-context-state-serializer-data        |  Bin 270 -> 0 bytes
 .../flink-1.6-context-state-serializer-snapshot    |  Bin 452 -> 0 bytes
 .../flink-1.6-transaction-state-serializer-data    |  Bin 110 -> 0 bytes
 ...flink-1.6-transaction-state-serializer-snapshot |  Bin 460 -> 0 bytes
 .../flink-1.7-context-state-serializer-data        |  Bin 270 -> 0 bytes
 .../flink-1.7-context-state-serializer-snapshot    |  Bin 440 -> 0 bytes
 .../flink-1.7-transaction-state-serializer-data    |  Bin 110 -> 0 bytes
 ...flink-1.7-transaction-state-serializer-snapshot |  Bin 448 -> 0 bytes
 .../src/test/resources/log4j-test.properties       |   29 -
 .../src/test/resources/log4j2-test.properties      |   38 +
 .../serializer-snapshot                            |  Bin 0 -> 137 bytes
 .../transaction-state-serializer-1.11/test-data    |  Bin 0 -> 17 bytes
 flink-connectors/flink-connector-kafka-0.8/pom.xml |  238 -
 .../connectors/kafka/FlinkKafkaConsumer08.java     |  334 -
 .../connectors/kafka/FlinkKafkaConsumer081.java    |   44 -
 .../connectors/kafka/FlinkKafkaConsumer082.java    |   44 -
 .../connectors/kafka/FlinkKafkaProducer.java       |   85 -
 .../connectors/kafka/FlinkKafkaProducer08.java     |  248 -
 .../connectors/kafka/Kafka08TableSink.java         |   62 -
 .../connectors/kafka/Kafka08TableSource.java       |  100 -
 .../kafka/Kafka08TableSourceSinkFactory.java       |   90 -
 .../connectors/kafka/internals/Kafka08Fetcher.java |  512 --
 .../internals/Kafka08PartitionDiscoverer.java      |  294 -
 .../connectors/kafka/internals/KillerWatchDog.java |   65 -
 .../kafka/internals/PartitionInfoFetcher.java      |   76 -
 .../kafka/internals/PeriodicOffsetCommitter.java   |   90 -
 .../kafka/internals/SimpleConsumerThread.java      |  536 --
 .../kafka/internals/ZookeeperOffsetHandler.java    |  153 -
 .../org.apache.flink.table.factories.TableFactory  |   16 -
 .../streaming/connectors/kafka/Kafka08ITCase.java  |  255 -
 .../connectors/kafka/Kafka08ProducerITCase.java    |   45 -
 .../kafka/Kafka08TableSourceSinkFactoryTest.java   |   99 -
 .../connectors/kafka/KafkaConsumer08Test.java      |  209 -
 .../connectors/kafka/KafkaProducerTest.java        |  129 -
 .../kafka/KafkaShortRetention08ITCase.java         |   41 -
 .../connectors/kafka/KafkaTestEnvironmentImpl.java |  445 --
 .../src/test/resources/log4j-test.properties       |   30 -
 flink-connectors/flink-connector-kafka-0.9/pom.xml |  234 -
 .../connectors/kafka/FlinkKafkaConsumer09.java     |  335 -
 .../connectors/kafka/FlinkKafkaProducer09.java     |  239 -
 .../connectors/kafka/Kafka09TableSink.java         |   62 -
 .../connectors/kafka/Kafka09TableSource.java       |  100 -
 .../kafka/Kafka09TableSourceSinkFactory.java       |   90 -
 .../connectors/kafka/internal/Kafka09Fetcher.java  |  247 -
 .../kafka/internal/Kafka09PartitionDiscoverer.java |  111 -
 .../kafka/internal/KafkaConsumerCallBridge09.java  |   53 -
 .../kafka/internal/KafkaConsumerThread.java        |  588 --
 .../org.apache.flink.table.factories.TableFactory  |   16 -
 .../src/main/resources/log4j.properties            |   28 -
 .../streaming/connectors/kafka/Kafka09ITCase.java  |  282 -
 .../connectors/kafka/Kafka09ProducerITCase.java    |   35 -
 .../connectors/kafka/Kafka09SecuredRunITCase.java  |   63 -
 .../kafka/Kafka09TableSourceSinkFactoryTest.java   |   99 -
 .../connectors/kafka/KafkaProducerTest.java        |  126 -
 .../connectors/kafka/KafkaTestEnvironmentImpl.java |  478 --
 .../kafka/internal/Kafka09FetcherTest.java         |  483 --
 .../kafka/internal/KafkaConsumerThreadTest.java    | 1012 ---
 .../src/test/resources/log4j-test.properties       |   32 -
 .../flink-connector-kafka-base/pom.xml             |   44 +-
 .../connectors/kafka/FlinkKafkaConsumerBase.java   |  184 +-
 .../connectors/kafka/FlinkKafkaProducerBase.java   |   12 +-
 .../kafka/KafkaDeserializationSchema.java          |   31 +
 .../connectors/kafka/KafkaSerializationSchema.java |   13 +
 .../connectors/kafka/KafkaTableSinkBase.java       |    8 +-
 .../connectors/kafka/KafkaTableSourceBase.java     |   43 +-
 .../kafka/KafkaTableSourceSinkFactoryBase.java     |  102 +-
 .../kafka/internals/AbstractFetcher.java           |  381 +-
 .../KafkaDeserializationSchemaWrapper.java         |   13 +-
 .../internals/KafkaSerializationSchemaWrapper.java |   95 +
 .../kafka/internals/KafkaTopicPartitionState.java  |   15 +-
 ...aTopicPartitionStateWithPeriodicWatermarks.java |   72 -
 ...opicPartitionStateWithPunctuatedWatermarks.java |   85 -
 ...aTopicPartitionStateWithWatermarkGenerator.java |   96 +
 .../internals/KeyedSerializationSchemaWrapper.java |    4 +
 .../SourceContextWatermarkOutputAdapter.java       |   45 +
 .../partitioner/FlinkKafkaDelegatePartitioner.java |   52 -
 .../kafka/partitioner/KafkaPartitioner.java        |   48 -
 .../kafka/table/KafkaDynamicSinkBase.java          |  133 +
 .../kafka/table/KafkaDynamicSourceBase.java        |  215 +
 .../kafka/table/KafkaDynamicTableFactoryBase.java  |  172 +
 .../connectors/kafka/table/KafkaOptions.java       |  371 ++
 .../org/apache/flink/table/descriptors/Kafka.java  |   54 +-
 .../flink/table/descriptors/KafkaValidator.java    |  127 +-
 .../kafka/FlinkKafkaConsumerBaseMigrationTest.java |   47 +-
 .../kafka/FlinkKafkaConsumerBaseTest.java          |  150 +-
 .../connectors/kafka/KafkaConsumerTestBase.java    |  153 +-
 .../connectors/kafka/KafkaProducerTestBase.java    |   15 +-
 .../kafka/KafkaShortRetentionTestBase.java         |   10 +-
 .../kafka/KafkaTableSourceSinkFactoryTestBase.java |  278 +-
 .../streaming/connectors/kafka/KafkaTestBase.java  |    3 +-
 .../connectors/kafka/KafkaTestEnvironment.java     |   44 +-
 .../kafka/internals/AbstractFetcherTest.java       |  381 +-
 .../internals/AbstractFetcherWatermarksTest.java   |  510 ++
 .../table/KafkaDynamicTableFactoryTestBase.java    |  424 ++
 .../connectors/kafka/table/KafkaTableTestBase.java |  266 +
 .../connectors/kafka/testutils/DataGenerators.java |    9 +-
 .../kafka/testutils/FailingIdentityMapper.java     |    4 +
 .../connectors/kafka/testutils/IntegerSource.java  |    4 +
 .../apache/flink/table/descriptors/KafkaTest.java  |   40 +-
 .../table/descriptors/KafkaValidatorTest.java      |   76 +
 ...er-migration-test-flink1.2-empty-state-snapshot |  Bin 240 -> 0 bytes
 ...kafka-consumer-migration-test-flink1.2-snapshot |  Bin 1022 -> 0 bytes
 ...er-migration-test-flink1.3-empty-state-snapshot |  Bin 473 -> 0 bytes
 ...kafka-consumer-migration-test-flink1.3-snapshot |  Bin 1255 -> 0 bytes
 .../src/test/resources/log4j-test.properties       |   28 -
 .../src/test/resources/log4j2-test.properties      |   38 +
 flink-connectors/flink-connector-kafka/pom.xml     |   52 +-
 .../connectors/kafka/FlinkKafkaConsumer.java       |   20 +-
 .../connectors/kafka/FlinkKafkaProducer.java       |  229 +-
 .../streaming/connectors/kafka/KafkaTableSink.java |    3 +-
 .../connectors/kafka/KafkaTableSource.java         |    6 +-
 .../kafka/KafkaTableSourceSinkFactory.java         |    6 +-
 .../kafka/internal/FlinkKafkaInternalProducer.java |   93 +-
 .../kafka/internal/KafkaConsumerThread.java        |   18 +-
 .../connectors/kafka/internal/KafkaFetcher.java    |  105 +-
 .../kafka/internal/KafkaPartitionDiscoverer.java   |    2 +-
 .../kafka/internal/KafkaShuffleFetcher.java        |  297 +
 .../kafka/shuffle/FlinkKafkaShuffle.java           |  391 ++
 .../kafka/shuffle/FlinkKafkaShuffleConsumer.java   |   94 +
 .../kafka/shuffle/FlinkKafkaShuffleProducer.java   |  213 +
 .../kafka/shuffle/StreamKafkaShuffleSink.java      |   43 +
 .../connectors/kafka/table/KafkaDynamicSink.java   |   80 +
 .../connectors/kafka/table/KafkaDynamicSource.java |   95 +
 .../kafka/table/KafkaDynamicTableFactory.java      |   78 +
 .../org.apache.flink.table.factories.Factory       |   16 +
 .../src/main/resources/log4j.properties            |   28 -
 .../kafka/FlinkKafkaInternalProducerITCase.java    |   35 +-
 .../FlinkKafkaProducerMigrationOperatorTest.java   |   10 +-
 .../connectors/kafka/FlinkKafkaProducerTest.java   |  118 +
 .../streaming/connectors/kafka/KafkaITCase.java    |    5 +
 .../KafkaSerializerSnapshotsMigrationTest.java     |   59 -
 .../kafka/KafkaSerializerUpgradeTest.java          |  162 +
 .../kafka/KafkaTableSourceSinkFactoryTest.java     |    6 +-
 .../connectors/kafka/KafkaTestEnvironmentImpl.java |   43 +-
 .../shuffle/KafkaShuffleExactlyOnceITCase.java     |  205 +
 .../kafka/shuffle/KafkaShuffleITCase.java          |  476 ++
 .../kafka/shuffle/KafkaShuffleTestBase.java        |  269 +
 .../kafka/table/KafkaDynamicTableFactoryTest.java  |   92 +
 .../connectors/kafka/table/KafkaTableITCase.java   |  192 +
 .../serializer-snapshot                            |  Bin 0 -> 126 bytes
 .../context-state-serializer-1.11/test-data        |  Bin 0 -> 19 bytes
 .../resources/debezium-data-schema-exclude.txt     |   16 +
 .../flink-1.7-context-state-serializer-data        |  Bin 270 -> 0 bytes
 .../flink-1.7-context-state-serializer-snapshot    |  Bin 434 -> 0 bytes
 .../flink-1.7-transaction-state-serializer-data    |  Bin 110 -> 0 bytes
 ...flink-1.7-transaction-state-serializer-snapshot |  Bin 442 -> 0 bytes
 .../src/test/resources/log4j-test.properties       |   29 -
 .../src/test/resources/log4j2-test.properties      |   38 +
 .../serializer-snapshot                            |  Bin 0 -> 134 bytes
 .../transaction-state-serializer-1.11/test-data    |  Bin 0 -> 17 bytes
 flink-connectors/flink-connector-kinesis/pom.xml   |   64 +-
 .../connectors/kinesis/FlinkKinesisProducer.java   |   10 +-
 .../kinesis/config/AWSConfigConstants.java         |   16 +-
 .../internals/DynamoDBStreamsDataFetcher.java      |    8 +-
 .../kinesis/internals/KinesisDataFetcher.java      |   87 +-
 .../kinesis/internals/ShardConsumer.java           |    5 +-
 .../connectors/kinesis/proxy/KinesisProxy.java     |   10 +-
 .../KinesisDeserializationSchema.java              |   12 +
 .../KinesisDeserializationSchemaWrapper.java       |   17 +
 .../serialization/KinesisSerializationSchema.java  |   13 +
 .../streaming/connectors/kinesis/util/AWSUtil.java |   15 +-
 .../connectors/kinesis/util/KinesisConfigUtil.java |   10 +-
 .../connectors/kinesis/util/RecordEmitter.java     |   21 +-
 .../src/main/resources/META-INF/NOTICE             |  242 +-
 .../src/main/resources/log4j.properties            |   27 -
 .../kinesis/FlinkKinesisConsumerTest.java          |   54 +-
 .../kinesis/FlinkKinesisProducerTest.java          |   45 +-
 .../connectors/kinesis/KinesisConsumerTest.java    |   72 +
 .../kinesis/internals/ShardConsumerTest.java       |   32 +-
 .../kinesis/manualtests/ManualExactlyOnceTest.java |    3 +-
 .../ManualExactlyOnceWithStreamReshardingTest.java |    3 +-
 .../kinesis/testutils/KinesisPubsubClient.java     |  129 +
 .../kinesis/testutils/TestRuntimeContext.java      |    2 +-
 ...inesisDataFetcherForShardConsumerException.java |    5 -
 .../connectors/kinesis/util/AWSUtilTest.java       |   83 +
 .../kinesis/util/KinesisConfigUtilTest.java        |   33 +-
 flink-connectors/flink-connector-nifi/pom.xml      |    9 +-
 flink-connectors/flink-connector-rabbitmq/pom.xml  |    2 +-
 .../streaming/connectors/rabbitmq/RMQSink.java     |   23 +-
 .../streaming/connectors/rabbitmq/RMQSource.java   |   60 +-
 .../flink/streaming/connectors/rabbitmq/Util.java  |   34 +
 .../streaming/connectors/rabbitmq/RMQSinkTest.java |   41 +-
 .../connectors/rabbitmq/RMQSourceTest.java         |  125 +-
 flink-connectors/flink-connector-twitter/pom.xml   |    2 +-
 .../src/main/resources/META-INF/NOTICE             |    2 +-
 .../flink-hadoop-compatibility/pom.xml             |   13 +-
 .../api/java/hadoop/mapred/utils/HadoopUtils.java  |   53 +-
 .../hadoop/mapred/wrapper/HadoopInputSplit.java    |   56 +-
 .../mapred/wrapper/HadoopInputSplitTest.java       |  211 +
 .../runtime/WritableSerializerMigrationTest.java   |   88 -
 .../runtime/WritableSerializerUpgradeTest.java     |  151 +
 .../resources/flink-1.6-writeable-serializer-data  |  Bin 150 -> 0 bytes
 .../flink-1.6-writeable-serializer-snapshot        |  Bin 506 -> 0 bytes
 .../resources/flink-1.7-writeable-serializer-data  |  Bin 150 -> 0 bytes
 .../flink-1.7-writeable-serializer-snapshot        |  Bin 494 -> 0 bytes
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../writeable-serializer-1.11/serializer-snapshot  |  Bin 0 -> 187 bytes
 .../resources/writeable-serializer-1.11/test-data  |  Bin 0 -> 7 bytes
 flink-connectors/flink-hbase/pom.xml               |  371 --
 .../addons/hbase/AbstractTableInputFormat.java     |  267 -
 .../flink/addons/hbase/HBaseLookupFunction.java    |  150 -
 .../apache/flink/addons/hbase/HBaseOptions.java    |  135 -
 .../flink/addons/hbase/HBaseRowInputFormat.java    |  119 -
 .../flink/addons/hbase/HBaseTableFactory.java      |  168 -
 .../flink/addons/hbase/HBaseTableSchema.java       |  316 -
 .../flink/addons/hbase/HBaseTableSource.java       |  195 -
 .../addons/hbase/HBaseUpsertSinkFunction.java      |  254 -
 .../flink/addons/hbase/HBaseUpsertTableSink.java   |  133 -
 .../flink/addons/hbase/HBaseWriteOptions.java      |  151 -
 .../flink/addons/hbase/TableInputFormat.java       |   94 -
 .../apache/flink/addons/hbase/TableInputSplit.java |   89 -
 .../addons/hbase/util/HBaseConfigurationUtil.java  |  100 -
 .../addons/hbase/util/HBaseReadWriteHelper.java    |  223 -
 .../flink/addons/hbase/util/HBaseTypeUtils.java    |  166 -
 .../org.apache.flink.table.factories.TableFactory  |   16 -
 .../flink/addons/hbase/HBaseConnectorITCase.java   |  614 --
 .../flink/addons/hbase/HBaseDescriptorTest.java    |  120 -
 .../flink/addons/hbase/HBaseTableFactoryTest.java  |  149 -
 .../hbase/example/HBaseFlinkTestConstants.java     |   30 -
 .../addons/hbase/example/HBaseReadExample.java     |   91 -
 .../addons/hbase/example/HBaseWriteExample.java    |  206 -
 .../hbase/example/HBaseWriteStreamExample.java     |  110 -
 .../flink/addons/hbase/util/HBaseTestBase.java     |  166 -
 .../hbase/util/HBaseTestingClusterAutoStarter.java |  247 -
 .../flink/addons/hbase/util/PlannerType.java       |   27 -
 .../src/test/resources/log4j-test.properties       |   26 -
 flink-connectors/flink-hcatalog/pom.xml            |   28 +-
 flink-connectors/flink-jdbc/pom.xml                |   86 -
 .../api/java/io/jdbc/AbstractJDBCOutputFormat.java |   85 -
 .../api/java/io/jdbc/JDBCAppendTableSink.java      |  130 -
 .../java/io/jdbc/JDBCAppendTableSinkBuilder.java   |  140 -
 .../flink/api/java/io/jdbc/JDBCInputFormat.java    |  445 --
 .../flink/api/java/io/jdbc/JDBCLookupFunction.java |  299 -
 .../flink/api/java/io/jdbc/JDBCLookupOptions.java  |  105 -
 .../apache/flink/api/java/io/jdbc/JDBCOptions.java |  174 -
 .../flink/api/java/io/jdbc/JDBCOutputFormat.java   |  212 -
 .../flink/api/java/io/jdbc/JDBCReadOptions.java    |  146 -
 .../flink/api/java/io/jdbc/JDBCSinkFunction.java   |   63 -
 .../flink/api/java/io/jdbc/JDBCTableSource.java    |  243 -
 .../java/io/jdbc/JDBCTableSourceSinkFactory.java   |  192 -
 .../flink/api/java/io/jdbc/JDBCTypeUtil.java       |  103 -
 .../api/java/io/jdbc/JDBCUpsertOutputFormat.java   |  293 -
 .../api/java/io/jdbc/JDBCUpsertSinkFunction.java   |   63 -
 .../api/java/io/jdbc/JDBCUpsertTableSink.java      |  223 -
 .../apache/flink/api/java/io/jdbc/JDBCUtils.java   |  234 -
 .../api/java/io/jdbc/dialect/JDBCDialect.java      |  131 -
 .../api/java/io/jdbc/dialect/JDBCDialects.java     |  137 -
 .../jdbc/split/GenericParameterValuesProvider.java |   43 -
 .../split/NumericBetweenParametersProvider.java    |  113 -
 .../io/jdbc/split/ParameterValuesProvider.java     |   34 -
 .../api/java/io/jdbc/writer/AppendOnlyWriter.java  |   72 -
 .../flink/api/java/io/jdbc/writer/JDBCWriter.java  |   52 -
 .../api/java/io/jdbc/writer/UpsertWriter.java      |  264 -
 .../flink/table/descriptors/JDBCValidator.java     |  133 -
 .../org.apache.flink.table.factories.TableFactory  |   16 -
 .../api/java/io/jdbc/JDBCAppendTableSinkTest.java  |   90 -
 .../flink/api/java/io/jdbc/JDBCFullTest.java       |  130 -
 .../api/java/io/jdbc/JDBCInputFormatTest.java      |  362 --
 .../api/java/io/jdbc/JDBCLookupFunctionITCase.java |  186 -
 .../api/java/io/jdbc/JDBCOutputFormatTest.java     |  258 -
 .../io/jdbc/JDBCTableSourceSinkFactoryTest.java    |  276 -
 .../flink/api/java/io/jdbc/JDBCTestBase.java       |  164 -
 .../flink/api/java/io/jdbc/JDBCTypeUtilTest.java   |   52 -
 .../java/io/jdbc/JDBCUpsertOutputFormatTest.java   |  144 -
 .../java/io/jdbc/JDBCUpsertTableSinkITCase.java    |  186 -
 .../NumericBetweenParametersProviderTest.java      |  122 -
 .../src/test/resources/log4j-test.properties       |   19 -
 flink-connectors/flink-orc/pom.xml                 |  118 -
 .../org/apache/flink/orc/OrcRowInputFormat.java    |  768 ---
 .../java/org/apache/flink/orc/OrcTableSource.java  |  543 --
 .../apache/flink/orc/OrcRowInputFormatTest.java    |  999 ---
 .../org/apache/flink/orc/OrcTableSourceITCase.java |  117 -
 .../org/apache/flink/orc/OrcTableSourceTest.java   |  336 -
 .../src/test/resources/log4j-test.properties       |   27 -
 .../flink-sql-connector-elasticsearch6/pom.xml     |    6 +-
 .../src/main/resources/META-INF/NOTICE             |   12 +-
 .../flink-sql-connector-elasticsearch7/pom.xml     |   18 +-
 .../src/main/resources/META-INF/NOTICE             |   69 +-
 .../flink-sql-connector-hive-1.2.2/pom.xml         |  145 +
 .../src/main/resources/META-INF/NOTICE             |   13 +
 .../flink-sql-connector-hive-2.2.0/pom.xml         |  120 +
 .../src/main/resources/META-INF/NOTICE             |   11 +
 .../flink-sql-connector-hive-2.3.6/pom.xml         |   91 +
 .../src/main/resources/META-INF/NOTICE             |    9 +
 .../flink-sql-connector-hive-3.1.2/pom.xml         |   94 +
 .../src/main/resources/META-INF/NOTICE             |   10 +
 .../flink-sql-connector-kafka-0.10/pom.xml         |    3 +-
 .../src/main/resources/META-INF/NOTICE             |    4 +-
 .../flink-sql-connector-kafka-0.11/pom.xml         |    3 +-
 .../src/main/resources/META-INF/NOTICE             |    4 +-
 .../flink-sql-connector-kafka-0.9/pom.xml          |   89 -
 .../src/main/resources/META-INF/NOTICE             |    9 -
 flink-connectors/flink-sql-connector-kafka/pom.xml |    2 +-
 .../src/main/resources/META-INF/NOTICE             |    4 +-
 flink-connectors/pom.xml                           |   30 +-
 flink-container/docker/Dockerfile                  |   68 -
 flink-container/docker/README.md                   |   84 -
 flink-container/docker/build.sh                    |  187 -
 flink-container/docker/docker-compose.yml          |   39 -
 flink-container/docker/docker-entrypoint.sh        |   43 -
 flink-container/kubernetes/README.md               |   75 -
 .../kubernetes/job-cluster-job.yaml.template       |   44 -
 .../task-manager-deployment.yaml.template          |   34 -
 flink-container/pom.xml                            |   95 +-
 .../entrypoint/ClassPathJobGraphRetriever.java     |  274 -
 .../container/entrypoint/JarManifestParser.java    |  145 -
 .../StandaloneApplicationClusterConfiguration.java |   75 +
 ...plicationClusterConfigurationParserFactory.java |  124 +
 .../StandaloneApplicationClusterEntryPoint.java    |  131 +
 .../StandaloneJobClusterConfiguration.java         |   75 -
 ...daloneJobClusterConfigurationParserFactory.java |  123 -
 .../entrypoint/StandaloneJobClusterEntryPoint.java |  145 -
 .../src/main/resources/log4j.properties            |   26 -
 ...test-assembly-test-user-classloader-job-jar.xml |   35 -
 ...-assembly-test-user-classloader-job-lib-jar.xml |   35 -
 .../src/test/assembly/test-assembly.xml            |   35 -
 .../entrypoint/ClassPathJobGraphRetrieverTest.java |  298 -
 .../entrypoint/JarManifestParserTest.java          |  160 -
 ...ationClusterConfigurationParserFactoryTest.java |  244 +
 ...neJobClusterConfigurationParserFactoryTest.java |  181 -
 .../StandaloneJobClusterEntryPointTest.java        |  134 -
 .../apache/flink/container/entrypoint/TestJob.java |   61 -
 .../container/entrypoint/testjar/TestJobInfo.java  |   33 -
 .../entrypoint/testjar/TestUserClassLoaderJob.java |   41 -
 .../testjar/TestUserClassLoaderJobLib.java         |   32 -
 .../src/test/resources/log4j-test.properties       |   32 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-contrib/docker-flink/Dockerfile              |   48 -
 flink-contrib/docker-flink/README.md               |   93 -
 .../docker-flink/bluemix-docker-compose.sh         |   22 -
 flink-contrib/docker-flink/build.sh                |  154 -
 .../docker-flink/create-docker-swarm-service.sh    |   54 -
 .../docker-flink/docker-compose-bluemix.yml        |   44 -
 flink-contrib/docker-flink/docker-compose.yml      |   44 -
 flink-contrib/docker-flink/docker-entrypoint.sh    |   42 -
 .../docker-flink/remove-docker-swarm-service.sh    |   43 -
 flink-contrib/flink-connector-wikiedits/pom.xml    |    2 +-
 .../wikiedits/WikipediaEditEventIrcStream.java     |    2 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-contrib/pom.xml                              |    2 +-
 flink-core/pom.xml                                 |    9 +-
 .../apache/flink/api/common/ExecutionConfig.java   |  186 +-
 .../flink/api/common/JobExecutionResult.java       |   24 +-
 .../org/apache/flink/api/common/JobStatus.java     |  105 +
 .../org/apache/flink/api/common/PlanExecutor.java  |  145 -
 .../api/common/accumulators/AccumulatorHelper.java |   28 +-
 .../flink/api/common/cache/DistributedCache.java   |   54 +
 .../eventtime/AscendingTimestampsWatermarks.java   |   46 +
 .../eventtime/BoundedOutOfOrdernessWatermarks.java |   71 +
 .../common/eventtime/IngestionTimeAssigner.java    |   41 +
 .../common/eventtime/NoWatermarksGenerator.java    |   34 +
 .../common/eventtime/RecordTimestampAssigner.java  |   34 +
 .../eventtime/SerializableTimestampAssigner.java   |   30 +
 .../api/common/eventtime/TimestampAssigner.java    |   59 +
 .../eventtime/TimestampAssignerSupplier.java       |   86 +
 .../flink/api/common/eventtime/Watermark.java      |  106 +
 .../api/common/eventtime/WatermarkGenerator.java   |   47 +
 .../eventtime/WatermarkGeneratorSupplier.java      |   60 +
 .../api/common/eventtime/WatermarkOutput.java      |   44 +
 .../eventtime/WatermarkOutputMultiplexer.java      |  266 +
 .../api/common/eventtime/WatermarkStrategy.java    |  185 +
 .../eventtime/WatermarkStrategyWithIdleness.java   |   48 +
 .../WatermarkStrategyWithTimestampAssigner.java    |   48 +
 .../common/eventtime/WatermarksWithIdleness.java   |  137 +
 .../externalresource/ExternalResourceDriver.java   |   44 +
 .../ExternalResourceDriverFactory.java             |   42 +
 .../externalresource/ExternalResourceInfo.java     |   46 +
 .../api/common/functions/AggregateFunction.java    |    8 +-
 .../flink/api/common/functions/RuntimeContext.java |   57 +-
 .../functions/util/AbstractRuntimeUDFContext.java  |   10 -
 .../common/functions/util/RuntimeUDFContext.java   |    7 +
 .../flink/api/common/io/DelimitedInputFormat.java  |    8 +-
 .../apache/flink/api/common/io/InputFormat.java    |   24 +-
 .../GuavaFlinkConnectorRateLimiter.java            |    2 +-
 .../flink/api/common/operators/ResourceSpec.java   |  215 +-
 .../operators/util/OperatorValidationUtils.java    |   22 +-
 .../flink/api/common/resources/CPUResource.java    |   47 +
 .../flink/api/common/resources/GPUResource.java    |   15 +-
 .../flink/api/common/resources/Resource.java       |  110 +-
 .../common/restartstrategy/RestartStrategies.java  |   68 +-
 .../serialization/DeserializationSchema.java       |   54 +
 .../common/serialization/SerializationSchema.java  |   35 +
 .../flink/api/common/state/OperatorStateStore.java |   38 -
 .../flink/api/common/state/StateTtlConfig.java     |   60 +-
 .../org/apache/flink/api/common/time/Deadline.java |   14 +
 .../org/apache/flink/api/common/time/Time.java     |   20 +-
 .../apache/flink/api/common/typeinfo/Types.java    |    2 +-
 .../typeutils/CompositeTypeSerializerSnapshot.java |   78 +-
 .../base/GenericArraySerializerSnapshot.java       |    6 +-
 .../flink/api/connector/source/Boundedness.java    |   55 +
 .../flink/api/connector/source/ReaderInfo.java     |   69 +
 .../flink/api/connector/source/ReaderOutput.java   |  117 +
 .../apache/flink/api/connector/source/Source.java  |   94 +
 .../flink/api/connector/source/SourceEvent.java    |   31 +
 .../flink/api/connector/source/SourceOutput.java   |   67 +
 .../flink/api/connector/source/SourceReader.java   |   81 +
 .../api/connector/source/SourceReaderContext.java  |   41 +
 .../flink/api/connector/source/SourceSplit.java    |   34 +
 .../api/connector/source/SplitEnumerator.java      |   79 +
 .../connector/source/SplitEnumeratorContext.java   |  102 +
 .../api/connector/source/SplitsAssignment.java     |   51 +
 .../org/apache/flink/api/dag/Transformation.java   |   39 +
 .../org/apache/flink/api/java/ClosureCleaner.java  |  274 +
 .../flink/api/java/typeutils/RowTypeInfo.java      |   15 +
 .../flink/api/java/typeutils/TypeExtractor.java    |   15 +-
 .../api/java/typeutils/runtime/MaskUtils.java      |  112 +
 .../api/java/typeutils/runtime/NullMaskUtils.java  |  107 -
 .../java/typeutils/runtime/NullableSerializer.java |    8 +-
 .../api/java/typeutils/runtime/RowComparator.java  |   66 +-
 .../api/java/typeutils/runtime/RowSerializer.java  |  201 +-
 .../java/typeutils/runtime/TupleSerializer.java    |    8 +
 .../apache/flink/configuration/AkkaOptions.java    |   41 +-
 .../flink/configuration/CheckpointingOptions.java  |   34 +-
 .../apache/flink/configuration/ClusterOptions.java |   19 +
 .../flink/configuration/ConfigConstants.java       |   71 +-
 .../apache/flink/configuration/ConfigOption.java   |    8 +-
 .../apache/flink/configuration/ConfigOptions.java  |   28 +-
 .../apache/flink/configuration/ConfigUtils.java    |   22 +-
 .../apache/flink/configuration/Configuration.java  |   39 +-
 .../flink/configuration/ConfigurationUtils.java    |  119 +-
 .../apache/flink/configuration/CoreOptions.java    |   99 +-
 .../configuration/DelegatingConfiguration.java     |    2 +-
 .../flink/configuration/DeploymentOptions.java     |   10 +
 .../configuration/DeploymentOptionsInternal.java   |   37 +
 .../flink/configuration/ExecutionOptions.java      |   58 +
 .../configuration/ExternalResourceOptions.java     |  157 +
 .../flink/configuration/GlobalConfiguration.java   |    2 +-
 .../configuration/HeartbeatManagerOptions.java     |    3 +
 .../configuration/HighAvailabilityOptions.java     |   34 +-
 .../flink/configuration/JobManagerOptions.java     |  155 +-
 .../org/apache/flink/configuration/MemorySize.java |  154 +-
 .../apache/flink/configuration/MetricOptions.java  |    9 +-
 .../NettyShuffleEnvironmentOptions.java            |  118 +-
 .../flink/configuration/OptimizerOptions.java      |    2 +-
 .../flink/configuration/PipelineOptions.java       |  205 +-
 .../configuration/PipelineOptionsInternal.java     |   37 +
 .../configuration/ResourceManagerOptions.java      |   32 +-
 .../apache/flink/configuration/RestOptions.java    |   14 +
 .../configuration/RestartStrategyOptions.java      |   18 +-
 .../flink/configuration/SecurityOptions.java       |   96 +-
 .../configuration/StructuredOptionsSplitter.java   |   31 +
 .../flink/configuration/TaskManagerOptions.java    |  417 +-
 .../org/apache/flink/configuration/WebOptions.java |   12 +-
 .../execution/DefaultExecutorServiceLoader.java    |  100 +
 .../core/execution/DetachedJobExecutionResult.java |   86 +
 .../org/apache/flink/core/execution/JobClient.java |   86 +
 .../apache/flink/core/execution/JobListener.java   |   57 +
 .../flink/core/execution/PipelineExecutor.java     |   45 +
 .../core/execution/PipelineExecutorFactory.java    |   47 +
 .../execution/PipelineExecutorServiceLoader.java   |   48 +
 .../org/apache/flink/core/fs/EntropyInjector.java  |   11 +
 .../java/org/apache/flink/core/fs/FileSystem.java  |   63 +-
 .../apache/flink/core/fs/FileSystemSafetyNet.java  |   18 -
 .../main/java/org/apache/flink/core/fs/Path.java   |   16 +-
 .../flink/core/fs/PluginFileSystemFactory.java     |  193 +
 .../apache/flink/core/fs/RecoverableWriter.java    |    6 +-
 .../org/apache/flink/core/fs/RefCountedFile.java   |   89 +
 .../flink/core/fs/SafetyNetCloseableRegistry.java  |   19 +-
 .../flink/core/fs/local/LocalFileSystem.java       |    7 +-
 .../core/fs/local/LocalRecoverableSerializer.java  |    4 +-
 .../core/fs/local/LocalRecoverableWriter.java      |    3 +-
 .../java/org/apache/flink/core/io/InputStatus.java |   58 +
 .../core/io/SimpleVersionedSerialization.java      |    2 +-
 .../flink/core/memory/DataOutputSerializer.java    |    4 +-
 .../flink/core/memory/HybridMemorySegment.java     |   81 +-
 .../flink/core/memory/MemorySegmentFactory.java    |   72 +-
 .../org/apache/flink/core/memory/MemoryType.java   |   38 -
 .../org/apache/flink/core/memory/MemoryUtils.java  |   96 +-
 .../flink/core/plugin/DefaultPluginManager.java    |   84 +
 .../org/apache/flink/core/plugin/PluginConfig.java |    2 +-
 .../org/apache/flink/core/plugin/PluginLoader.java |  114 +-
 .../apache/flink/core/plugin/PluginManager.java    |   53 +-
 .../org/apache/flink/core/plugin/PluginUtils.java  |    4 +-
 .../core/plugin/TemporaryClassLoaderContext.java   |   39 -
 .../src/main/java/org/apache/flink/types/Row.java  |  173 +-
 .../main/java/org/apache/flink/types/RowKind.java  |  118 +
 .../java/org/apache/flink/types/StringValue.java   |   86 +-
 .../apache/flink/util/ChildFirstClassLoader.java   |   21 +-
 .../org/apache/flink/util/CloseableIterator.java   |  109 +-
 .../java/org/apache/flink/util/CollectionUtil.java |   17 +
 .../java/org/apache/flink/util/ExceptionUtils.java |  115 +
 .../main/java/org/apache/flink/util/FileUtils.java |  136 +-
 .../flink/util/FlinkUserCodeClassLoader.java       |   63 +
 .../main/java/org/apache/flink/util/IOUtils.java   |   16 +
 .../main/java/org/apache/flink/util/JarUtils.java  |   78 +
 .../apache/flink/util/JavaGcCleanerWrapper.java    |  410 +-
 .../java/org/apache/flink/util/LambdaUtil.java     |    5 +-
 .../main/java/org/apache/flink/util/MathUtils.java |   14 +
 .../org/apache/flink/util/MemoryArchitecture.java  |   77 -
 .../main/java/org/apache/flink/util/NetUtils.java  |   28 +-
 .../main/java/org/apache/flink/util/OutputTag.java |    2 +-
 .../apache/flink/util/ProcessorArchitecture.java   |  156 +
 .../java/org/apache/flink/util/PropertiesUtil.java |   23 +
 .../java/org/apache/flink/util/RefCounted.java     |   41 +
 .../java/org/apache/flink/util/StringUtils.java    |   67 +-
 .../flink/util/TaskManagerExceptionUtils.java      |   69 +
 .../flink/util/TemporaryClassLoaderContext.java    |   85 +
 .../flink/util/ThrowableCatchingRunnable.java      |   47 +
 .../main/java/org/apache/flink/util/TimeUtils.java |   69 +
 .../java/org/apache/flink/util/clock/Clock.java    |   57 +
 .../org/apache/flink/util/clock/ManualClock.java   |   73 +
 .../org/apache/flink/util/clock/SystemClock.java   |   60 +
 .../apache/flink/util/function/FunctionUtils.java  |   11 +
 .../util/function/LongFunctionWithException.java   |   37 +
 .../apache/flink/util/function/QuadConsumer.java   |   44 +
 .../apache/flink/util/function/QuadFunction.java   |   46 +
 .../ExecutionConfigFromConfigurationTest.java      |  250 +
 .../flink/api/common/ExecutionConfigTest.java      |  198 +
 .../AscendingTimestampsWatermarksTest.java         |   62 +
 .../BoundedOutOfOrdernessWatermarksTest.java       |   85 +
 .../common/eventtime/TestingWatermarkOutput.java   |   48 +
 .../api/common/eventtime/WatermarkMatchers.java    |   49 +
 .../eventtime/WatermarkOutputMultiplexerTest.java  |  399 ++
 .../common/eventtime/WatermarkStrategyTest.java    |  266 +
 .../eventtime/WatermarksWithIdlenessTest.java      |  108 +
 .../api/common/io/DelimitedInputFormatTest.java    |   17 +-
 .../api/common/operators/ResourceSpecTest.java     |   88 +-
 .../flink/api/common/resources/ResourceTest.java   |  160 +
 .../flink/api/common/resources/TestResource.java   |   42 +
 .../flink/api/common/state/StateTtlConfigTest.java |   55 +-
 .../flink/api/common/typeutils/ClassRelocator.java |  196 +
 ...mpositeTypeSerializerSnapshotMigrationTest.java |   63 -
 .../CompositeTypeSerializerSnapshotTest.java       |   85 +-
 .../CompositeTypeSerializerUpgradeTest.java        |  147 +
 .../common/typeutils/SerializerTestInstance.java   |    2 +
 .../common/typeutils/ThreadContextClassLoader.java |   40 +
 .../TypeSerializerSnapshotMigrationTestBase.java   |  526 --
 .../typeutils/TypeSerializerUpgradeTestBase.java   |  563 ++
 .../BaseTypeSerializerSnapshotMigrationTest.java   |   73 -
 .../base/BasicTypeSerializerUpgradeTest.java       |  199 +
 ...sicTypeSerializerUpgradeTestSpecifications.java | 1002 +++
 .../base/EnumSerializerCompatibilityTest.java      |  117 +
 .../base/EnumSerializerSnapshotMigrationTest.java  |   89 -
 .../typeutils/base/EnumSerializerUpgradeTest.java  |  195 +-
 .../base/ListSerializerSnapshotMigrationTest.java  |   55 -
 .../typeutils/base/ListSerializerUpgradeTest.java  |  109 +
 .../base/MapSerializerSnapshotMigrationTest.java   |   56 -
 .../typeutils/base/MapSerializerUpgradeTest.java   |  111 +
 ...mitiveArraySerializerSnapshotMigrationTest.java |   94 -
 .../array/PrimitiveArraySerializerUpgradeTest.java |  102 +
 ...veArraySerializerUpgradeTestSpecifications.java |  431 ++
 .../api/connector/source/mocks/MockSource.java     |   90 +
 .../connector/source/mocks/MockSourceReader.java   |  131 +
 .../connector/source/mocks/MockSourceSplit.java    |  118 +
 .../source/mocks/MockSourceSplitSerializer.java    |   49 +
 .../source/mocks/MockSplitEnumerator.java          |  139 +
 .../MockSplitEnumeratorCheckpointSerializer.java   |   55 +
 .../apache/flink/api/dag/TransformationTest.java   |   81 +
 .../apache/flink/api/java/ClosureCleanerTest.java  |  531 ++
 .../api/java/typeutils/LambdaExtractionTest.java   |    6 +
 .../api/java/typeutils/TypeExtractorTest.java      |   38 +
 .../runtime/CopyableSerializerMigrationTest.java   |  107 -
 .../runtime/CopyableSerializerUpgradeTest.java     |  174 +
 .../typeutils/runtime/LegacyRowSerializerTest.java |  184 +
 .../runtime/NullableSerializerMigrationTest.java   |   83 -
 .../typeutils/runtime/NullableSerializerTest.java  |    2 +-
 .../runtime/NullableSerializerUpgradeTest.java     |  146 +
 .../PojoSerializerSnapshotMigrationTest.java       |  169 -
 .../runtime/PojoSerializerUpgradeTest.java         |  119 +
 .../PojoSerializerUpgradeTestSpecifications.java   |  827 +++
 .../java/typeutils/runtime/RowComparatorTest.java  |   34 +-
 .../runtime/RowSerializerMigrationTest.java        |   64 -
 .../java/typeutils/runtime/RowSerializerTest.java  |   42 +-
 .../runtime/RowSerializerUpgradeTest.java          |  135 +
 .../runtime/TupleSerializerMigrationTest.java      |   59 -
 .../runtime/TupleSerializerUpgradeTest.java        |  115 +
 .../runtime/ValueSerializerMigrationTest.java      |   88 -
 .../runtime/ValueSerializerUpgradeTest.java        |  138 +
 .../runtime/kryo/KryoPojosForMigrationTests.java   |   18 +
 .../runtime/kryo/KryoSerializerUpgradeTest.java    |  272 +
 .../runtime/kryo/KryoSnapshotMigrationTest.java    |  146 -
 .../flink/configuration/ConfigUtilsTest.java       |   16 +-
 .../flink/configuration/ConfigurationTest.java     |   51 +
 .../configuration/ConfigurationUtilsTest.java      |   20 +-
 .../flink/configuration/CoreOptionsTest.java       |   39 +-
 .../configuration/GlobalConfigurationTest.java     |    1 +
 .../MemorySizePrettyPrintingTest.java              |   72 +
 .../apache/flink/configuration/MemorySizeTest.java |   26 +
 .../StructuredOptionsSplitterEscapeTest.java       |   96 +
 .../core/fs/AbstractCloseableRegistryTest.java     |    2 +-
 .../apache/flink/core/fs/EntropyInjectorTest.java  |   56 +
 .../org/apache/flink/core/fs/FileSystemTest.java   |   64 +
 .../apache/flink/core/fs/FileSystemTestUtils.java  |    7 +-
 .../java/org/apache/flink/core/fs/PathTest.java    |   11 -
 .../apache/flink/core/fs/RefCountedFileTest.java   |   97 +
 .../core/fs/SafetyNetCloseableRegistryTest.java    |   28 +
 .../core/io/SimpleVersionedSerializationTest.java  |   49 +-
 .../flink/core/memory/CrossSegmentTypeTest.java    |    2 +-
 .../flink/core/memory/EndiannessAccessChecks.java  |    2 +-
 .../HybridOffHeapUnsafeMemorySegmentTest.java      |    4 +-
 .../flink/core/memory/MemorySegmentChecksTest.java |    4 +-
 .../core/memory/MemorySegmentFactoryTest.java      |   64 +
 .../core/memory/MemorySegmentUndersizedTest.java   |    4 +-
 .../core/memory/OperationsOnFreedSegmentTest.java  |    2 +-
 .../plugin/TemporaryClassLoaderContextTest.java    |   46 -
 .../flink/core/plugin/TestingPluginManager.java    |   42 +
 .../testutils/migration/MigrationVersion.java      |   23 +-
 .../flink/types/StringSerializationTest.java       |  209 +-
 .../apache/flink/util/CloseableIteratorTest.java   |   82 +
 .../java/org/apache/flink/util/CoreMatchers.java   |   70 -
 .../org/apache/flink/util/ExceptionUtilsTest.java  |   16 +
 .../java/org/apache/flink/util/FileUtilsTest.java  |  124 +-
 .../flink/util/FlinkUserCodeClassLoaderTest.java   |   62 +
 .../flink/util/JavaGcCleanerWrapperTest.java       |    2 +-
 .../java/org/apache/flink/util/MathUtilTest.java   |   28 +
 .../apache/flink/util/MemoryArchitectureTest.java  |   36 -
 .../flink/util/ProcessorArchitectureTest.java      |   43 +
 .../org/apache/flink/util/PropertiesUtilTest.java  |   52 +
 .../org/apache/flink/util/StringUtilsTest.java     |   25 +-
 .../util/TemporaryClassLoaderContextTest.java      |   46 +
 .../flink/util/TimeUtilsPrettyPrintingTest.java    |   79 +
 .../java/org/apache/flink/util/TimeUtilsTest.java  |   14 +
 .../big-dec-serializer-1.11/serializer-snapshot    |  Bin 0 -> 94 bytes
 .../resources/big-dec-serializer-1.11/test-data    |  Bin 0 -> 24 bytes
 .../big-int-serializer-1.11/serializer-snapshot    |  Bin 0 -> 94 bytes
 .../resources/big-int-serializer-1.11/test-data    |  Bin 0 -> 19 bytes
 .../serializer-snapshot                            |  Bin 0 -> 130 bytes
 .../test-data                                      |  Bin 0 -> 6 bytes
 .../boolean-serializer-1.11/serializer-snapshot    |  Bin 0 -> 96 bytes
 .../resources/boolean-serializer-1.11/test-data    |    1 +
 .../serializer-snapshot                            |  Bin 0 -> 106 bytes
 .../boolean-value-serializer-1.11/test-data        |    1 +
 .../serializer-snapshot                            |  Bin 0 -> 124 bytes
 .../byte-primitive-array-serializer-1.11/test-data |  Bin 0 -> 14 bytes
 .../byte-serializer-1.11/serializer-snapshot       |  Bin 0 -> 90 bytes
 .../test/resources/byte-serializer-1.11/test-data  |    1 +
 .../byte-value-serializer-1.11/serializer-snapshot |  Bin 0 -> 100 bytes
 .../resources/byte-value-serializer-1.11/test-data |    1 +
 .../serializer-snapshot                            |  Bin 0 -> 124 bytes
 .../char-primitive-array-serializer-1.11/test-data |  Bin 0 -> 24 bytes
 .../char-serializer-1.11/serializer-snapshot       |  Bin 0 -> 90 bytes
 .../test/resources/char-serializer-1.11/test-data  |    1 +
 .../char-value-serializer-1.11/serializer-snapshot |  Bin 0 -> 100 bytes
 .../resources/char-value-serializer-1.11/test-data |  Bin 0 -> 2 bytes
 .../serializer-snapshot                            |  Bin 0 -> 199 bytes
 .../copyable-value-serializer-1.11/test-data       |  Bin 0 -> 8 bytes
 .../date-serializer-1.11/serializer-snapshot       |  Bin 0 -> 90 bytes
 .../test/resources/date-serializer-1.11/test-data  |  Bin 0 -> 8 bytes
 .../serializer-snapshot                            |  Bin 0 -> 128 bytes
 .../test-data                                      |  Bin 0 -> 84 bytes
 .../double-serializer-1.11/serializer-snapshot     |  Bin 0 -> 94 bytes
 .../resources/double-serializer-1.11/test-data     |    1 +
 .../serializer-snapshot                            |  Bin 0 -> 104 bytes
 .../double-value-serializer-1.11/test-data         |    1 +
 .../either-serializer-1.11/serializer-snapshot     |  Bin 0 -> 276 bytes
 .../resources/either-serializer-1.11/test-data     |    1 +
 .../enum-serializer-1.11/serializer-snapshot       |  Bin 0 -> 188 bytes
 .../test/resources/enum-serializer-1.11/test-data  |  Bin 0 -> 4 bytes
 .../serializer-snapshot                            |  Bin 0 -> 163 bytes
 .../enum-serializerreconfig-1.11/test-data         |  Bin 0 -> 4 bytes
 .../resources/flink-1.6-big-dec-serializer-data    |  Bin 300 -> 0 bytes
 .../flink-1.6-big-dec-serializer-snapshot          |  Bin 394 -> 0 bytes
 .../resources/flink-1.6-big-int-serializer-data    |  Bin 64 -> 0 bytes
 .../flink-1.6-big-int-serializer-snapshot          |  Bin 394 -> 0 bytes
 ...ink-1.6-boolean-primitive-array-serializer-data |  Bin 80 -> 0 bytes
 ...1.6-boolean-primitive-array-serializer-snapshot |  Bin 436 -> 0 bytes
 .../resources/flink-1.6-boolean-serializer-data    |    1 -
 .../flink-1.6-boolean-serializer-snapshot          |  Bin 396 -> 0 bytes
 .../flink-1.6-boolean-value-serializer-data        |  Bin 10 -> 0 bytes
 .../flink-1.6-boolean-value-serializer-snapshot    |  Bin 406 -> 0 bytes
 .../flink-1.6-byte-primitive-array-serializer-data |  Bin 80 -> 0 bytes
 ...nk-1.6-byte-primitive-array-serializer-snapshot |  Bin 430 -> 0 bytes
 .../test/resources/flink-1.6-byte-serializer-data  |    1 -
 .../resources/flink-1.6-byte-serializer-snapshot   |  Bin 390 -> 0 bytes
 .../resources/flink-1.6-byte-value-serializer-data |    1 -
 .../flink-1.6-byte-value-serializer-snapshot       |  Bin 400 -> 0 bytes
 .../flink-1.6-char-primitive-array-serializer-data |  Bin 140 -> 0 bytes
 ...nk-1.6-char-primitive-array-serializer-snapshot |  Bin 430 -> 0 bytes
 .../test/resources/flink-1.6-char-serializer-data  |  Bin 20 -> 0 bytes
 .../resources/flink-1.6-char-serializer-snapshot   |  Bin 390 -> 0 bytes
 .../resources/flink-1.6-char-value-serializer-data |  Bin 20 -> 0 bytes
 .../flink-1.6-char-value-serializer-snapshot       |  Bin 400 -> 0 bytes
 .../flink-1.6-copyable-value-serializer-data       |  Bin 80 -> 0 bytes
 .../flink-1.6-copyable-value-serializer-snapshot   |  Bin 534 -> 0 bytes
 .../test/resources/flink-1.6-date-serializer-data  |  Bin 80 -> 0 bytes
 .../resources/flink-1.6-date-serializer-snapshot   |  Bin 390 -> 0 bytes
 ...link-1.6-double-primitive-array-serializer-data |  Bin 440 -> 0 bytes
 ...-1.6-double-primitive-array-serializer-snapshot |  Bin 434 -> 0 bytes
 .../resources/flink-1.6-double-serializer-data     |    1 -
 .../resources/flink-1.6-double-serializer-snapshot |  Bin 394 -> 0 bytes
 .../flink-1.6-double-value-serializer-data         |    1 -
 .../flink-1.6-double-value-serializer-snapshot     |  Bin 404 -> 0 bytes
 .../resources/flink-1.6-either-serializer-data     |  Bin 42 -> 0 bytes
 .../resources/flink-1.6-either-serializer-snapshot |  Bin 1365 -> 0 bytes
 .../test/resources/flink-1.6-enum-serializer-data  |  Bin 40 -> 0 bytes
 .../resources/flink-1.6-enum-serializer-snapshot   |  Bin 949 -> 0 bytes
 ...flink-1.6-float-primitive-array-serializer-data |  Bin 240 -> 0 bytes
 ...k-1.6-float-primitive-array-serializer-snapshot |  Bin 432 -> 0 bytes
 .../test/resources/flink-1.6-float-serializer-data |    1 -
 .../resources/flink-1.6-float-serializer-snapshot  |  Bin 392 -> 0 bytes
 .../flink-1.6-float-value-serializer-data          |    1 -
 .../flink-1.6-float-value-serializer-snapshot      |  Bin 402 -> 0 bytes
 .../flink-1.6-generic-array-serializer-data        |  Bin 90 -> 0 bytes
 .../flink-1.6-generic-array-serializer-snapshot    |  Bin 1007 -> 0 bytes
 .../flink-1.6-int-primitive-array-serializer-data  |  Bin 240 -> 0 bytes
 ...ink-1.6-int-primitive-array-serializer-snapshot |  Bin 428 -> 0 bytes
 .../test/resources/flink-1.6-int-serializer-data   |  Bin 40 -> 0 bytes
 .../resources/flink-1.6-int-serializer-snapshot    |  Bin 388 -> 0 bytes
 .../resources/flink-1.6-int-value-serializer-data  |  Bin 40 -> 0 bytes
 .../flink-1.6-int-value-serializer-snapshot        |  Bin 398 -> 0 bytes
 .../flink-1.6-kryo-type-serializer-custom-data     |    1 -
 .../flink-1.6-kryo-type-serializer-custom-snapshot |  Bin 4808 -> 0 bytes
 .../resources/flink-1.6-kryo-type-serializer-data  |    1 -
 ...link-1.6-kryo-type-serializer-empty-config-data |  Bin 180 -> 0 bytes
 ...-1.6-kryo-type-serializer-empty-config-snapshot |  Bin 2759 -> 0 bytes
 .../flink-1.6-kryo-type-serializer-snapshot        |  Bin 3854 -> 0 bytes
 .../test/resources/flink-1.6-list-serializer-data  |  Bin 240 -> 0 bytes
 .../resources/flink-1.6-list-serializer-snapshot   |  Bin 888 -> 0 bytes
 .../flink-1.6-long-primitive-array-serializer-data |  Bin 440 -> 0 bytes
 ...nk-1.6-long-primitive-array-serializer-snapshot |  Bin 430 -> 0 bytes
 .../test/resources/flink-1.6-long-serializer-data  |  Bin 80 -> 0 bytes
 .../resources/flink-1.6-long-serializer-snapshot   |  Bin 390 -> 0 bytes
 .../resources/flink-1.6-long-value-serializer-data |  Bin 80 -> 0 bytes
 .../flink-1.6-long-value-serializer-snapshot       |  Bin 400 -> 0 bytes
 .../test/resources/flink-1.6-map-serializer-data   |  Bin 440 -> 0 bytes
 .../resources/flink-1.6-map-serializer-snapshot    |  Bin 1356 -> 0 bytes
 .../flink-1.6-null-value-serializer-snapshot       |  Bin 400 -> 0 bytes
 .../flink-1.6-nullable-not-padded-serializer-data  |  Bin 58 -> 0 bytes
 ...ink-1.6-nullable-not-padded-serializer-snapshot |  Bin 944 -> 0 bytes
 .../flink-1.6-nullable-padded-serializer-data      |  Bin 90 -> 0 bytes
 .../flink-1.6-nullable-padded-serializer-snapshot  |  Bin 952 -> 0 bytes
 ...1.6-pojo-new-and-removed-fields-serializer-data |  Bin 320 -> 0 bytes
 ...pojo-new-and-removed-fields-serializer-snapshot |  Bin 4696 -> 0 bytes
 ...nk-1.6-pojo-registered-subclass-serializer-data |  Bin 350 -> 0 bytes
 ....6-pojo-registered-subclass-serializer-snapshot |  Bin 9236 -> 0 bytes
 .../test/resources/flink-1.6-pojo-serializer-data  |  Bin 230 -> 0 bytes
 .../resources/flink-1.6-pojo-serializer-snapshot   |  Bin 4133 -> 0 bytes
 ...-1.6-pojo-unregistered-subclass-serializer-data |  Bin 1320 -> 0 bytes
 ...-pojo-unregistered-subclass-serializer-snapshot |  Bin 8890 -> 0 bytes
 .../test/resources/flink-1.6-row-serializer-data   |  Bin 240 -> 0 bytes
 .../resources/flink-1.6-row-serializer-snapshot    |  Bin 1444 -> 0 bytes
 ...flink-1.6-short-primitive-array-serializer-data |  Bin 140 -> 0 bytes
 ...k-1.6-short-primitive-array-serializer-snapshot |  Bin 432 -> 0 bytes
 .../test/resources/flink-1.6-short-serializer-data |  Bin 20 -> 0 bytes
 .../resources/flink-1.6-short-serializer-snapshot  |  Bin 392 -> 0 bytes
 .../flink-1.6-short-value-serializer-data          |  Bin 20 -> 0 bytes
 .../flink-1.6-short-value-serializer-snapshot      |  Bin 402 -> 0 bytes
 .../resources/flink-1.6-sql-date-serializer-data   |  Bin 80 -> 0 bytes
 .../flink-1.6-sql-date-serializer-snapshot         |  Bin 396 -> 0 bytes
 .../resources/flink-1.6-sql-time-serializer-data   |  Bin 80 -> 0 bytes
 .../flink-1.6-sql-time-serializer-snapshot         |  Bin 396 -> 0 bytes
 .../flink-1.6-sql-timestamp-serializer-data        |  Bin 120 -> 0 bytes
 .../flink-1.6-sql-timestamp-serializer-snapshot    |  Bin 406 -> 0 bytes
 .../resources/flink-1.6-string-serializer-data     |    1 -
 .../resources/flink-1.6-string-serializer-snapshot |  Bin 394 -> 0 bytes
 .../flink-1.6-string-value-serializer-data         |    1 -
 .../flink-1.6-string-value-serializer-snapshot     |  Bin 404 -> 0 bytes
 .../test/resources/flink-1.6-tuple-serializer-data |  Bin 392 -> 0 bytes
 .../resources/flink-1.6-tuple-serializer-snapshot  |  Bin 2256 -> 0 bytes
 .../test/resources/flink-1.6-value-serializer-data |  Bin 150 -> 0 bytes
 .../resources/flink-1.6-value-serializer-snapshot  |  Bin 1310 -> 0 bytes
 .../resources/flink-1.7-big-dec-serializer-data    |  Bin 300 -> 0 bytes
 .../flink-1.7-big-dec-serializer-snapshot          |  Bin 155 -> 0 bytes
 .../resources/flink-1.7-big-int-serializer-data    |  Bin 150 -> 0 bytes
 .../flink-1.7-big-int-serializer-snapshot          |  Bin 155 -> 0 bytes
 ...ink-1.7-boolean-primitive-array-serializer-data |  Bin 90 -> 0 bytes
 ...1.7-boolean-primitive-array-serializer-snapshot |  Bin 212 -> 0 bytes
 .../resources/flink-1.7-boolean-serializer-data    |    1 -
 .../flink-1.7-boolean-serializer-snapshot          |  Bin 158 -> 0 bytes
 .../flink-1.7-boolean-value-serializer-data        |  Bin 10 -> 0 bytes
 .../flink-1.7-boolean-value-serializer-snapshot    |  Bin 173 -> 0 bytes
 .../flink-1.7-byte-primitive-array-serializer-data |  Bin 100 -> 0 bytes
 ...nk-1.7-byte-primitive-array-serializer-snapshot |  Bin 203 -> 0 bytes
 .../test/resources/flink-1.7-byte-serializer-data  |    1 -
 .../resources/flink-1.7-byte-serializer-snapshot   |  Bin 149 -> 0 bytes
 .../resources/flink-1.7-byte-value-serializer-data |    1 -
 .../flink-1.7-byte-value-serializer-snapshot       |  Bin 164 -> 0 bytes
 .../flink-1.7-char-primitive-array-serializer-data |  Bin 240 -> 0 bytes
 ...nk-1.7-char-primitive-array-serializer-snapshot |  Bin 203 -> 0 bytes
 .../test/resources/flink-1.7-char-serializer-data  |  Bin 20 -> 0 bytes
 .../resources/flink-1.7-char-serializer-snapshot   |  Bin 149 -> 0 bytes
 .../resources/flink-1.7-char-value-serializer-data |  Bin 20 -> 0 bytes
 .../flink-1.7-char-value-serializer-snapshot       |  Bin 164 -> 0 bytes
 .../flink-1.7-copyable-value-serializer-data       |  Bin 80 -> 0 bytes
 .../flink-1.7-copyable-value-serializer-snapshot   |  Bin 522 -> 0 bytes
 .../test/resources/flink-1.7-date-serializer-data  |  Bin 80 -> 0 bytes
 .../resources/flink-1.7-date-serializer-snapshot   |  Bin 149 -> 0 bytes
 ...link-1.7-double-primitive-array-serializer-data |  Bin 360 -> 0 bytes
 ...-1.7-double-primitive-array-serializer-snapshot |  Bin 209 -> 0 bytes
 .../resources/flink-1.7-double-serializer-data     |    1 -
 .../resources/flink-1.7-double-serializer-snapshot |  Bin 155 -> 0 bytes
 .../flink-1.7-double-value-serializer-data         |    1 -
 .../flink-1.7-double-value-serializer-snapshot     |  Bin 170 -> 0 bytes
 .../resources/flink-1.7-either-serializer-data     |    1 -
 .../resources/flink-1.7-either-serializer-snapshot |  Bin 383 -> 0 bytes
 .../test/resources/flink-1.7-enum-serializer-data  |  Bin 40 -> 0 bytes
 .../resources/flink-1.7-enum-serializer-snapshot   |  Bin 937 -> 0 bytes
 ...flink-1.7-float-primitive-array-serializer-data |  Bin 160 -> 0 bytes
 ...k-1.7-float-primitive-array-serializer-snapshot |  Bin 206 -> 0 bytes
 .../test/resources/flink-1.7-float-serializer-data |    1 -
 .../resources/flink-1.7-float-serializer-snapshot  |  Bin 152 -> 0 bytes
 .../flink-1.7-float-value-serializer-data          |    1 -
 .../flink-1.7-float-value-serializer-snapshot      |  Bin 167 -> 0 bytes
 .../flink-1.7-generic-array-serializer-data        |  Bin 280 -> 0 bytes
 .../flink-1.7-generic-array-serializer-snapshot    |  Bin 270 -> 0 bytes
 .../flink-1.7-int-primitive-array-serializer-data  |  Bin 160 -> 0 bytes
 ...ink-1.7-int-primitive-array-serializer-snapshot |  Bin 200 -> 0 bytes
 .../test/resources/flink-1.7-int-serializer-data   |  Bin 40 -> 0 bytes
 .../resources/flink-1.7-int-serializer-snapshot    |  Bin 146 -> 0 bytes
 .../resources/flink-1.7-int-value-serializer-data  |  Bin 40 -> 0 bytes
 .../flink-1.7-int-value-serializer-snapshot        |  Bin 161 -> 0 bytes
 .../flink-1.7-kryo-type-serializer-custom-data     |    1 -
 .../flink-1.7-kryo-type-serializer-custom-snapshot |  Bin 4796 -> 0 bytes
 .../resources/flink-1.7-kryo-type-serializer-data  |    1 -
 ...link-1.7-kryo-type-serializer-empty-config-data |  Bin 892 -> 0 bytes
 ...-1.7-kryo-type-serializer-empty-config-snapshot |  Bin 2747 -> 0 bytes
 .../flink-1.7-kryo-type-serializer-snapshot        |  Bin 3842 -> 0 bytes
 .../test/resources/flink-1.7-list-serializer-data  |  Bin 240 -> 0 bytes
 .../resources/flink-1.7-list-serializer-snapshot   |  Bin 238 -> 0 bytes
 .../flink-1.7-long-primitive-array-serializer-data |  Bin 280 -> 0 bytes
 ...nk-1.7-long-primitive-array-serializer-snapshot |  Bin 203 -> 0 bytes
 .../test/resources/flink-1.7-long-serializer-data  |  Bin 80 -> 0 bytes
 .../resources/flink-1.7-long-serializer-snapshot   |  Bin 149 -> 0 bytes
 .../resources/flink-1.7-long-value-serializer-data |  Bin 80 -> 0 bytes
 .../flink-1.7-long-value-serializer-snapshot       |  Bin 164 -> 0 bytes
 .../test/resources/flink-1.7-map-serializer-data   |  Bin 390 -> 0 bytes
 .../resources/flink-1.7-map-serializer-snapshot    |  Bin 379 -> 0 bytes
 .../flink-1.7-null-value-serializer-snapshot       |  Bin 164 -> 0 bytes
 .../flink-1.7-nullable-not-padded-serializer-data  |  Bin 58 -> 0 bytes
 ...ink-1.7-nullable-not-padded-serializer-snapshot |  Bin 941 -> 0 bytes
 .../flink-1.7-nullable-padded-serializer-data      |  Bin 90 -> 0 bytes
 .../flink-1.7-nullable-padded-serializer-snapshot  |  Bin 949 -> 0 bytes
 ...1.7-pojo-new-and-removed-fields-serializer-data |  Bin 320 -> 0 bytes
 ...pojo-new-and-removed-fields-serializer-snapshot |  Bin 4724 -> 0 bytes
 ...nk-1.7-pojo-registered-subclass-serializer-data |  Bin 350 -> 0 bytes
 ....7-pojo-registered-subclass-serializer-snapshot |  Bin 12183 -> 0 bytes
 .../test/resources/flink-1.7-pojo-serializer-data  |  Bin 230 -> 0 bytes
 .../resources/flink-1.7-pojo-serializer-snapshot   |  Bin 4148 -> 0 bytes
 ...-1.7-pojo-unregistered-subclass-serializer-data |  Bin 1320 -> 0 bytes
 ...-pojo-unregistered-subclass-serializer-snapshot |  Bin 11832 -> 0 bytes
 .../test/resources/flink-1.7-row-serializer-data   |  Bin 240 -> 0 bytes
 .../resources/flink-1.7-row-serializer-snapshot    |  Bin 1454 -> 0 bytes
 ...flink-1.7-short-primitive-array-serializer-data |  Bin 120 -> 0 bytes
 ...k-1.7-short-primitive-array-serializer-snapshot |  Bin 206 -> 0 bytes
 .../test/resources/flink-1.7-short-serializer-data |  Bin 20 -> 0 bytes
 .../resources/flink-1.7-short-serializer-snapshot  |  Bin 152 -> 0 bytes
 .../flink-1.7-short-value-serializer-data          |  Bin 20 -> 0 bytes
 .../flink-1.7-short-value-serializer-snapshot      |  Bin 167 -> 0 bytes
 .../resources/flink-1.7-sql-date-serializer-data   |  Bin 80 -> 0 bytes
 .../flink-1.7-sql-date-serializer-snapshot         |  Bin 158 -> 0 bytes
 .../resources/flink-1.7-sql-time-serializer-data   |  Bin 80 -> 0 bytes
 .../flink-1.7-sql-time-serializer-snapshot         |  Bin 158 -> 0 bytes
 .../flink-1.7-sql-timestamp-serializer-data        |  Bin 120 -> 0 bytes
 .../flink-1.7-sql-timestamp-serializer-snapshot    |  Bin 173 -> 0 bytes
 .../resources/flink-1.7-string-serializer-data     |    1 -
 .../resources/flink-1.7-string-serializer-snapshot |  Bin 155 -> 0 bytes
 .../flink-1.7-string-value-serializer-data         |    1 -
 .../flink-1.7-string-value-serializer-snapshot     |  Bin 170 -> 0 bytes
 .../test/resources/flink-1.7-tuple-serializer-data |  Bin 392 -> 0 bytes
 .../resources/flink-1.7-tuple-serializer-snapshot  |  Bin 2277 -> 0 bytes
 .../test/resources/flink-1.7-value-serializer-data |  Bin 150 -> 0 bytes
 .../resources/flink-1.7-value-serializer-snapshot  |  Bin 1298 -> 0 bytes
 .../serializer-snapshot                            |  Bin 0 -> 126 bytes
 .../test-data                                      |  Bin 0 -> 44 bytes
 .../float-serializer-1.11/serializer-snapshot      |  Bin 0 -> 92 bytes
 .../test/resources/float-serializer-1.11/test-data |    1 +
 .../serializer-snapshot                            |  Bin 0 -> 102 bytes
 .../float-value-serializer-1.11/test-data          |    1 +
 .../serializer-snapshot                            |  Bin 0 -> 211 bytes
 .../generic-array-serializer-1.11/test-data        |  Bin 0 -> 19 bytes
 .../serializer-snapshot                            |  Bin 0 -> 122 bytes
 .../int-primitive-array-serializer-1.11/test-data  |  Bin 0 -> 44 bytes
 .../int-serializer-1.11/serializer-snapshot        |  Bin 0 -> 88 bytes
 .../test/resources/int-serializer-1.11/test-data   |  Bin 0 -> 4 bytes
 .../int-value-serializer-1.11/serializer-snapshot  |  Bin 0 -> 98 bytes
 .../resources/int-value-serializer-1.11/test-data  |  Bin 0 -> 4 bytes
 .../serializer-snapshot                            |  Bin 0 -> 1718 bytes
 .../test-data                                      |    1 +
 .../serializer-snapshot                            |  Bin 0 -> 1525 bytes
 .../test-data                                      |    1 +
 .../serializer-snapshot                            |  Bin 0 -> 745 bytes
 .../test-data                                      |  Bin 0 -> 90 bytes
 .../serializer-snapshot                            |  Bin 0 -> 745 bytes
 .../test-data                                      |  Bin 0 -> 90 bytes
 .../list-serializer-1.11/serializer-snapshot       |  Bin 0 -> 185 bytes
 .../test/resources/list-serializer-1.11/test-data  |  Bin 0 -> 17 bytes
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../serializer-snapshot                            |  Bin 0 -> 124 bytes
 .../long-primitive-array-serializer-1.11/test-data |  Bin 0 -> 84 bytes
 .../long-serializer-1.11/serializer-snapshot       |  Bin 0 -> 90 bytes
 .../test/resources/long-serializer-1.11/test-data  |  Bin 0 -> 8 bytes
 .../long-value-serializer-1.11/serializer-snapshot |  Bin 0 -> 100 bytes
 .../resources/long-value-serializer-1.11/test-data |  Bin 0 -> 8 bytes
 .../map-serializer-1.11/serializer-snapshot        |  Bin 0 -> 268 bytes
 .../test/resources/map-serializer-1.11/test-data   |  Bin 0 -> 25 bytes
 .../null-value-serializer-1.11/serializer-snapshot |  Bin 0 -> 100 bytes
 .../test-data}                                     |    0
 .../serializer-snapshot                            |  Bin 0 -> 209 bytes
 .../nullable-not-padded-serializer-1.11/test-data  |    1 +
 .../serializer-snapshot                            |  Bin 0 -> 209 bytes
 .../nullable-padded-serializer-1.11/test-data      |  Bin 0 -> 9 bytes
 .../serializer-snapshot                            |  Bin 0 -> 1214 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 1214 bytes
 .../pojo-serializer-identical-schema-1.7/test-data |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 1214 bytes
 .../pojo-serializer-identical-schema-1.8/test-data |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 1214 bytes
 .../pojo-serializer-identical-schema-1.9/test-data |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 294 bytes
 .../test-data                                      |  Bin 0 -> 6 bytes
 .../serializer-snapshot                            |  Bin 0 -> 294 bytes
 .../test-data                                      |  Bin 0 -> 6 bytes
 .../serializer-snapshot                            |  Bin 0 -> 294 bytes
 .../test-data                                      |  Bin 0 -> 6 bytes
 .../serializer-snapshot                            |  Bin 0 -> 294 bytes
 .../test-data                                      |  Bin 0 -> 6 bytes
 .../serializer-snapshot                            |  Bin 0 -> 2570 bytes
 .../test-data                                      |  Bin 0 -> 24 bytes
 .../serializer-snapshot                            |  Bin 0 -> 2570 bytes
 .../test-data                                      |  Bin 0 -> 24 bytes
 .../serializer-snapshot                            |  Bin 0 -> 2570 bytes
 .../test-data                                      |  Bin 0 -> 24 bytes
 .../serializer-snapshot                            |  Bin 0 -> 2570 bytes
 .../test-data                                      |  Bin 0 -> 24 bytes
 .../serializer-snapshot                            |  Bin 0 -> 4372 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 4372 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 4372 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 4372 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 4372 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 4372 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 4372 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 4372 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 686 bytes
 .../test-data                                      |  Bin 0 -> 28 bytes
 .../serializer-snapshot                            |  Bin 0 -> 686 bytes
 .../test-data                                      |  Bin 0 -> 28 bytes
 .../serializer-snapshot                            |  Bin 0 -> 686 bytes
 .../test-data                                      |  Bin 0 -> 28 bytes
 .../serializer-snapshot                            |  Bin 0 -> 686 bytes
 .../test-data                                      |  Bin 0 -> 28 bytes
 .../serializer-snapshot                            |  Bin 0 -> 1082 bytes
 .../test-data                                      |  Bin 0 -> 27 bytes
 .../serializer-snapshot                            |  Bin 0 -> 1082 bytes
 .../test-data                                      |  Bin 0 -> 27 bytes
 .../serializer-snapshot                            |  Bin 0 -> 1082 bytes
 .../test-data                                      |  Bin 0 -> 27 bytes
 .../serializer-snapshot                            |  Bin 0 -> 1082 bytes
 .../test-data                                      |  Bin 0 -> 27 bytes
 .../serializer-snapshot                            |  Bin 0 -> 4372 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 4372 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 4372 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 4372 bytes
 .../test-data                                      |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 2789 bytes
 .../test-data                                      |  Bin 0 -> 134 bytes
 .../serializer-snapshot                            |  Bin 0 -> 2789 bytes
 .../test-data                                      |  Bin 0 -> 134 bytes
 .../serializer-snapshot                            |  Bin 0 -> 2789 bytes
 .../test-data                                      |  Bin 0 -> 134 bytes
 .../serializer-snapshot                            |  Bin 0 -> 2789 bytes
 .../test-data                                      |  Bin 0 -> 134 bytes
 .../serializer-snapshot                            |  Bin 0 -> 2789 bytes
 .../test-data                                      |  Bin 0 -> 134 bytes
 .../serializer-snapshot                            |  Bin 0 -> 2789 bytes
 .../test-data                                      |  Bin 0 -> 134 bytes
 .../serializer-snapshot                            |  Bin 0 -> 2789 bytes
 .../test-data                                      |  Bin 0 -> 134 bytes
 .../serializer-snapshot                            |  Bin 0 -> 2789 bytes
 .../test-data                                      |  Bin 0 -> 134 bytes
 .../row-serializer-1.10/serializer-snapshot        |  Bin 0 -> 465 bytes
 .../test/resources/row-serializer-1.10/test-data   |  Bin 0 -> 20 bytes
 .../row-serializer-1.11/serializer-snapshot        |  Bin 0 -> 465 bytes
 .../test/resources/row-serializer-1.11/test-data   |  Bin 0 -> 20 bytes
 .../serializer-snapshot                            |  Bin 0 -> 126 bytes
 .../test-data                                      |  Bin 0 -> 24 bytes
 .../short-serializer-1.11/serializer-snapshot      |  Bin 0 -> 92 bytes
 .../test/resources/short-serializer-1.11/test-data |  Bin 0 -> 2 bytes
 .../serializer-snapshot                            |  Bin 0 -> 102 bytes
 .../short-value-serializer-1.11/test-data          |  Bin 0 -> 2 bytes
 .../sql-date-serializer-1.11/serializer-snapshot   |  Bin 0 -> 96 bytes
 .../resources/sql-date-serializer-1.11/test-data   |  Bin 0 -> 8 bytes
 .../sql-time-serializer-1.11/serializer-snapshot   |  Bin 0 -> 96 bytes
 .../resources/sql-time-serializer-1.11/test-data   |  Bin 0 -> 8 bytes
 .../serializer-snapshot                            |  Bin 0 -> 106 bytes
 .../sql-timestamp-serializer-1.11/test-data        |  Bin 0 -> 12 bytes
 .../serializer-snapshot                            |  Bin 0 -> 110 bytes
 .../string-array-serializer-1.11/test-data         |  Bin 0 -> 24 bytes
 .../string-serializer-1.11/serializer-snapshot     |  Bin 0 -> 94 bytes
 .../resources/string-serializer-1.11/test-data     |    1 +
 .../serializer-snapshot                            |  Bin 0 -> 104 bytes
 .../string-value-serializer-1.11/test-data         |    1 +
 .../tuple-serializer-1.11/serializer-snapshot      |  Bin 0 -> 401 bytes
 .../test/resources/tuple-serializer-1.11/test-data |  Bin 0 -> 22 bytes
 .../value-serializer-1.11/serializer-snapshot      |  Bin 0 -> 175 bytes
 .../test/resources/value-serializer-1.11/test-data |  Bin 0 -> 9 bytes
 flink-dist/pom.xml                                 |  324 +-
 flink-dist/src/main/assemblies/bin.xml             |   47 +-
 flink-dist/src/main/assemblies/hadoop.xml          |   41 -
 flink-dist/src/main/assemblies/opt.xml             |   58 +-
 flink-dist/src/main/assemblies/plugins.xml         |  106 +
 flink-dist/src/main/flink-bin/bin/config.sh        |  466 +-
 flink-dist/src/main/flink-bin/bin/flink            |    7 +-
 flink-dist/src/main/flink-bin/bin/flink-console.sh |   39 +-
 flink-dist/src/main/flink-bin/bin/flink-daemon.sh  |    4 +-
 flink-dist/src/main/flink-bin/bin/flink.bat        |   33 -
 flink-dist/src/main/flink-bin/bin/jobmanager.sh    |   18 +-
 .../src/main/flink-bin/bin/standalone-job.sh       |   17 +-
 .../src/main/flink-bin/bin/start-cluster.bat       |   78 -
 flink-dist/src/main/flink-bin/bin/start-cluster.sh |    2 +-
 flink-dist/src/main/flink-bin/bin/stop-cluster.sh  |    2 +-
 flink-dist/src/main/flink-bin/bin/taskmanager.sh   |   45 +-
 .../src/main/flink-bin/conf/log4j-cli.properties   |   47 +-
 .../main/flink-bin/conf/log4j-console.properties   |   43 +-
 .../main/flink-bin/conf/log4j-session.properties   |   37 +
 .../flink-bin/conf/log4j-yarn-session.properties   |   31 -
 .../src/main/flink-bin/conf/log4j.properties       |   32 +-
 .../src/main/flink-bin/conf/logback-console.xml    |   44 +-
 .../conf/{logback-yarn.xml => logback-session.xml} |    0
 .../src/main/flink-bin/conf/{slaves => workers}    |    0
 .../flink-bin/kubernetes-bin/kubernetes-entry.sh   |   35 +
 .../flink-bin/kubernetes-bin/kubernetes-session.sh |   39 +
 .../flink-bin/mesos-bin/mesos-appmaster-job.sh     |   26 +-
 .../main/flink-bin/mesos-bin/mesos-appmaster.sh    |   28 +-
 .../main/flink-bin/mesos-bin/mesos-jobmanager.sh   |   48 +
 .../main/flink-bin/mesos-bin/mesos-taskmanager.sh  |    2 +-
 .../src/main/flink-bin/yarn-bin/yarn-session.sh    |    2 +-
 flink-dist/src/main/resources/META-INF/NOTICE      |   19 +-
 .../META-INF/licenses/LICENSE.javax.activation     |  135 +
 .../main/resources/META-INF/licenses/LICENSE.jaxb  |  135 +
 flink-dist/src/main/resources/flink-conf.yaml      |   22 +-
 .../src/main/resources/log4j-bash-utils.properties |   26 +
 flink-dist/src/test/bin/calcTMHeapSizeMB.sh        |   50 -
 flink-dist/src/test/bin/calcTMNetBufMem.sh         |   41 -
 flink-dist/src/test/bin/runBashJavaUtilsCmd.sh     |   43 +
 .../src/test/bin/runExtractLoggingOutputs.sh       |   38 +
 .../org/apache/flink/dist/BashJavaUtilsITCase.java |  122 +
 .../org/apache/flink/dist/JavaBashTestBase.java    |   53 +
 ...TaskManagerHeapSizeCalculationJavaBashTest.java |  333 -
 .../src/test/resources/log4j-test.properties       |   35 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-docs/pom.xml                                 |   41 +-
 .../configuration/ConfigOptionsDocGenerator.java   |   82 +-
 .../docs/configuration/OptionsClassLocation.java   |    5 +
 .../flink/docs/rest/NoOpTransientBlobService.java  |   77 -
 .../flink/docs/rest/RestAPIDocGenerator.java       |   44 +-
 flink-docs/src/main/resources/log4j.properties     |   24 +
 .../ConfigOptionsDocGeneratorTest.java             |   71 +-
 .../ConfigOptionsDocsCompletenessITCase.java       |  231 +-
 .../docs/configuration/data/TestCommonOptions.java |   11 +-
 .../flink/docs/rest/RestAPIDocGeneratorTest.java   |   90 +
 .../docs/rest/data/TestEmptyMessageHeaders.java    |   94 +
 .../docs/rest/data/TestExcludeMessageHeaders.java  |   96 +
 .../flink-batch-sql-test/pom.xml                   |    2 +-
 .../flink/sql/tests/BatchSQLTestProgram.java       |   13 +-
 .../flink-bucketing-sink-test/pom.xml              |   34 +-
 .../streaming/tests/BucketingSinkTestProgram.java  |   35 +-
 flink-end-to-end-tests/flink-cli-test/pom.xml      |    2 +-
 .../streaming/tests/PeriodicStreamingJob.java      |   30 +-
 .../flink-confluent-schema-registry/pom.xml        |    2 +-
 .../registry/test/TestAvroConsumerConfluent.java   |   17 +-
 .../pom.xml                                        |   20 +-
 .../gcp/pubsub/CheckPubSubEmulatorTest.java        |   31 +-
 .../gcp/pubsub/emulator/GCloudEmulatorManager.java |   18 +-
 .../gcp/pubsub/emulator/GCloudUnitTestBase.java    |    8 +-
 .../gcp/pubsub/emulator/PubsubHelper.java          |   58 +-
 .../src/test/resources/log4j-test.properties       |   24 -
 .../src/test/resources/log4j2-test.properties      |   27 +
 .../flink-dataset-allround-test/pom.xml            |    2 +-
 .../pom.xml                                        |    2 +-
 .../flink-datastream-allround-test/pom.xml         |    2 +-
 .../flink/streaming/tests/FailureMapper.java       |    4 +
 .../flink-distributed-cache-via-blob-test/pom.xml  |    2 +-
 .../flink-e2e-test-utils/pom.xml                   |   80 -
 .../flink/streaming/tests/util/s3/S3QueryUtil.java |   92 -
 .../streaming/tests/util/s3/S3UtilProgram.java     |  225 -
 .../flink-elasticsearch2-test/pom.xml              |   77 -
 .../streaming/tests/Elasticsearch2SinkExample.java |  111 -
 .../flink-elasticsearch5-test/pom.xml              |    2 +-
 .../flink-elasticsearch6-test/pom.xml              |    2 +-
 .../flink-elasticsearch7-test/pom.xml              |    2 +-
 .../flink-end-to-end-tests-common-kafka/pom.xml    |  215 +
 .../flink/tests/util/kafka/KafkaResource.java      |  125 +
 .../tests/util/kafka/KafkaResourceFactory.java     |   37 +
 .../util/kafka/LocalStandaloneKafkaResource.java   |  437 ++
 .../kafka/LocalStandaloneKafkaResourceFactory.java |   46 +
 .../tests/util/kafka/SQLClientKafkaITCase.java     |  247 +
 .../tests/util/kafka/StreamingKafkaITCase.java     |  179 +
 .../src/test/resources/kafka_e2e.sql               |   75 +
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../flink-end-to-end-tests-common/pom.xml          |   73 +-
 .../flink/tests/util/AutoClosableProcess.java      |   83 +-
 .../apache/flink/tests/util/FlinkDistribution.java |  246 -
 .../org/apache/flink/tests/util/TestUtils.java     |  119 +
 .../activation/OperatingSystemRestriction.java     |   62 +
 .../tests/util/cache/AbstractDownloadCache.java    |  168 +
 .../flink/tests/util/cache/DownloadCache.java      |   56 +
 .../tests/util/cache/DownloadCacheFactory.java     |   35 +
 .../apache/flink/tests/util/cache/LolCache.java    |   70 +
 .../flink/tests/util/cache/LolCacheFactory.java    |   36 +
 .../tests/util/cache/PersistingDownloadCache.java  |   81 +
 .../util/cache/PersistingDownloadCacheFactory.java |   47 +
 .../tests/util/cache/TravisDownloadCache.java      |   78 +
 .../util/cache/TravisDownloadCacheFactory.java     |   52 +
 .../apache/flink/tests/util/categories/Dummy.java  |   25 +
 .../flink/tests/util/categories/PreCommit.java     |   25 +
 .../flink/tests/util/categories/TravisGroup1.java  |   25 +
 .../flink/tests/util/categories/TravisGroup2.java  |   25 +
 .../flink/tests/util/categories/TravisGroup3.java  |   25 +
 .../flink/tests/util/categories/TravisGroup4.java  |   25 +
 .../flink/tests/util/categories/TravisGroup5.java  |   25 +
 .../flink/tests/util/categories/TravisGroup6.java  |   25 +
 .../flink/tests/util/flink/ClusterController.java  |   46 +
 .../flink/tests/util/flink/FlinkDistribution.java  |  316 +
 .../flink/tests/util/flink/FlinkResource.java      |   80 +
 .../tests/util/flink/FlinkResourceFactory.java     |   36 +
 .../flink/tests/util/flink/FlinkResourceSetup.java |   87 +
 .../apache/flink/tests/util/flink/JarLocation.java |   27 +
 .../flink/tests/util/flink/JarOperation.java       |   57 +
 .../flink/tests/util/flink/JobController.java      |   25 +
 .../flink/tests/util/flink/JobSubmission.java      |  128 +
 .../util/flink/LocalStandaloneFlinkResource.java   |  217 +
 .../flink/LocalStandaloneFlinkResourceFactory.java |  124 +
 .../flink/tests/util/flink/SQLJobSubmission.java   |  102 +
 .../tests/util/parameters/ParameterProperty.java   |   64 +
 .../apache/flink/tests/util/util/FactoryUtils.java |   89 +
 .../apache/flink/tests/util/util/FileUtils.java    |   58 +
 ...che.flink.tests.util.cache.DownloadCacheFactory |   17 +
 .../org/apache/flink/tests/util/TestUtilsTest.java |   71 +
 .../flink/tests/util/util/FileUtilsTest.java       |   76 +
 .../flink-heavy-deployment-stress-test/pom.xml     |    2 +-
 .../HeavyDeploymentStressTestProgram.java          |    4 +
 .../flink-high-parallelism-iterations-test/pom.xml |    2 +-
 .../pom.xml                                        |    2 +-
 .../StickyAllocationAndLocalRecoveryTestJob.java   |    4 +
 .../src/main/resources/log4j-test.properties       |   27 -
 .../flink-metrics-availability-test/pom.xml        |   37 +-
 .../metrics/tests/MetricsAvailabilityITCase.java   |  168 +
 .../metrics/tests/MetricsAvailabilityITCase.java   |  161 -
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../flink-metrics-reporter-prometheus-test/pom.xml |   37 +-
 .../tests/PrometheusReporterEndToEndITCase.java    |  192 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../pom.xml                                        |   71 +
 .../NettyShuffleMemoryControlTestProgram.java      |  140 +
 .../pom.xml                                        |    2 +-
 .../pom.xml                                        |    2 +-
 .../flink-plugins-test/another-dummy-fs/pom.xml    |   74 +
 .../fs/anotherdummy/AnotherDummyFSFactory.java     |   58 +
 .../fs/anotherdummy/AnotherDummyFSFileStatus.java  |   67 +
 .../fs/anotherdummy/AnotherDummyFSFileSystem.java  |  162 +
 .../fs/anotherdummy/AnotherDummyFSInputStream.java |   51 +
 .../org.apache.flink.core.fs.FileSystemFactory     |   16 +
 .../flink-plugins-test/dummy-fs/pom.xml            |   74 +
 .../org/apache/flink/fs/dummy/DummyFSFactory.java  |   58 +
 .../apache/flink/fs/dummy/DummyFSFileStatus.java   |    0
 .../apache/flink/fs/dummy/DummyFSFileSystem.java   |    0
 .../apache/flink/fs/dummy/DummyFSInputStream.java  |    0
 .../org.apache.flink.core.fs.FileSystemFactory     |   16 +
 flink-end-to-end-tests/flink-plugins-test/pom.xml  |   86 +-
 .../org/apache/flink/fs/dummy/DummyFSFactory.java  |   51 -
 .../org.apache.flink.core.fs.FileSystemFactory     |   16 -
 flink-end-to-end-tests/flink-python-test/pom.xml   |   90 +
 .../flink-python-test/python/add_one.py            |   25 +
 .../flink-python-test/python/python_job.py         |   89 +
 .../python/tests/BlinkBatchPythonUdfSqlJob.java    |   56 +
 .../python/tests/BlinkStreamPythonUdfSqlJob.java   |   58 +
 .../python/tests/FlinkBatchPythonUdfSqlJob.java    |   55 +
 .../python/tests/FlinkStreamPythonUdfSqlJob.java   |   58 +
 .../org/apache/flink/python/tests/util/AddOne.java |   29 +
 .../flink-queryable-state-test/pom.xml             |    2 +-
 .../flink-quickstart-test/pom.xml                  |    2 +-
 .../pom.xml                                        |   79 +
 .../RocksDBStateMemoryControlTestProgram.java      |  184 +
 .../flink-sql-client-test/pom.xml                  |   40 +-
 .../flink-state-evolution-test/pom.xml             |    2 +-
 .../flink-stream-sql-test/pom.xml                  |    2 +-
 .../flink/sql/tests/StreamSQLTestProgram.java      |   56 +-
 .../flink-stream-state-ttl-test/pom.xml            |    2 +-
 .../tests/DataStreamStateTTLTestProgram.java       |    5 -
 .../streaming/tests/MonotonicTTLTimeProvider.java  |   36 +-
 .../streaming/tests/TtlVerifyUpdateFunction.java   |   24 +-
 .../flink-stream-stateful-job-upgrade-test/pom.xml |    2 +-
 .../tests/StatefulStreamJobUpgradeTestProgram.java |  129 +-
 .../flink-streaming-file-sink-test/pom.xml         |    2 +-
 .../src/main/java/StreamingFileSinkProgram.java    |   31 +-
 .../flink-streaming-kafka-test-base/pom.xml        |    2 +-
 .../kafka/test/base/KafkaExampleUtil.java          |    4 +-
 .../flink-streaming-kafka-test/pom.xml             |    8 +-
 .../flink/streaming/kafka/test/KafkaExample.java   |    2 +-
 .../flink-streaming-kafka010-test/pom.xml          |    8 +-
 .../streaming/kafka/test/Kafka010Example.java      |    2 +-
 .../flink-streaming-kafka011-test/pom.xml          |    8 +-
 .../streaming/kafka/test/Kafka011Example.java      |    2 +-
 .../flink-streaming-kinesis-test/pom.xml           |   10 +-
 .../streaming/kinesis/test/KinesisExampleTest.java |   15 +-
 .../kinesis/test/KinesisPubsubClient.java          |  128 -
 flink-end-to-end-tests/flink-tpcds-test/pom.xml    |   83 +
 .../apache/flink/table/tpcds/TpcdsTestProgram.java |  173 +
 .../apache/flink/table/tpcds/schema/Column.java    |   43 +
 .../flink/table/tpcds/schema/TpcdsSchema.java      |   44 +
 .../table/tpcds/schema/TpcdsSchemaProvider.java    |  529 ++
 .../flink/table/tpcds/stats/CatalogTableStats.java |   57 +
 .../table/tpcds/stats/TpcdsStatsProvider.java      |  648 ++
 .../flink/table/tpcds/utils/AnswerFormatter.java   |  187 +
 .../table/tpcds/utils/TpcdsResultComparator.java   |  234 +
 .../flink-tpcds-test/tpcds-tool/README.md          |    0
 .../flink-tpcds-test/tpcds-tool/answer_set/1.ans   |  105 +
 .../flink-tpcds-test/tpcds-tool/answer_set/10.ans  |   10 +
 .../flink-tpcds-test/tpcds-tool/answer_set/11.ans  |   90 +
 .../flink-tpcds-test/tpcds-tool/answer_set/12.ans  |  103 +
 .../flink-tpcds-test/tpcds-tool/answer_set/13.ans  |    6 +
 .../tpcds-tool/answer_set/14a_NULLS_FIRST.ans      |  104 +
 .../tpcds-tool/answer_set/14a_SQL_SERVER.ans       |  101 +
 .../tpcds-tool/answer_set/14b_NULLS_FIRST.ans      |  102 +
 .../tpcds-tool/answer_set/15_NULLS_FIRST.ans       |  102 +
 .../tpcds-tool/answer_set/15_NULLS_LAST.ans        |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/16.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/17.ans  |    5 +
 .../tpcds-tool/answer_set/18_NULLS_FIRST.ans       |  101 +
 .../tpcds-tool/answer_set/18_NULLS_LAST.ans        |  107 +
 .../tpcds-tool/answer_set/18_SQL_SERVER.ans        |  101 +
 .../flink-tpcds-test/tpcds-tool/answer_set/19.ans  |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/2.ans   | 2520 ++++++++
 .../tpcds-tool/answer_set/20_NULLS_FIRST.ans       |  103 +
 .../tpcds-tool/answer_set/20_NULLS_LAST.ans        |  103 +
 .../tpcds-tool/answer_set/21_NULLS_FIRST.ans       |  101 +
 .../tpcds-tool/answer_set/21_NULLS_LAST.ans        |  107 +
 .../tpcds-tool/answer_set/22_NULLS_FIRST.ans       |  102 +
 .../tpcds-tool/answer_set/22_NULLS_LAST.ans        |  107 +
 .../tpcds-tool/answer_set/23_NULLS_LAST.ans        |   12 +
 .../tpcds-tool/answer_set/23a_NULLS_FIRST.ans      |    3 +
 .../tpcds-tool/answer_set/23b_NULLS_FIRST.ans      |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/24a.ans |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/24b.ans |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/25.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/26.ans  |  107 +
 .../tpcds-tool/answer_set/27_NULLS_FIRST.ans       |  102 +
 .../tpcds-tool/answer_set/27_NULLS_LAST.ans        |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/28.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/29.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/3.ans   |   96 +
 .../flink-tpcds-test/tpcds-tool/answer_set/30.ans  |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/31.ans  |   58 +
 .../flink-tpcds-test/tpcds-tool/answer_set/32.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/33.ans  |  107 +
 .../tpcds-tool/answer_set/34_NULLS_FIRST.ans       |  455 ++
 .../tpcds-tool/answer_set/34_NULLS_LAST.ans        |  455 ++
 .../tpcds-tool/answer_set/35_NULLS_FIRST.ans       |  103 +
 .../tpcds-tool/answer_set/35_NULLS_LAST.ans        |  102 +
 .../tpcds-tool/answer_set/36_NULLS_FIRST.ans       |  101 +
 .../tpcds-tool/answer_set/36_NULLS_LAST.ans        |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/37.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/38.ans  |    4 +
 .../flink-tpcds-test/tpcds-tool/answer_set/39a.ans |  244 +
 .../flink-tpcds-test/tpcds-tool/answer_set/39b.ans |   15 +
 .../flink-tpcds-test/tpcds-tool/answer_set/4.ans   |   10 +
 .../flink-tpcds-test/tpcds-tool/answer_set/40.ans  |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/41.ans  |    9 +
 .../flink-tpcds-test/tpcds-tool/answer_set/42.ans  |   17 +
 .../flink-tpcds-test/tpcds-tool/answer_set/43.ans  |    7 +
 .../flink-tpcds-test/tpcds-tool/answer_set/44.ans  |   17 +
 .../flink-tpcds-test/tpcds-tool/answer_set/45.ans  |   25 +
 .../tpcds-tool/answer_set/46_NULLS_FIRST.ans       |  102 +
 .../tpcds-tool/answer_set/46_NULLS_LAST.ans        |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/47.ans  |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/48.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/49.ans  |   39 +
 .../flink-tpcds-test/tpcds-tool/answer_set/50.ans  |   13 +
 .../flink-tpcds-test/tpcds-tool/answer_set/51.ans  |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/52.ans  |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/53.ans  |  102 +
 .../flink-tpcds-test/tpcds-tool/answer_set/54.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/55.ans  |  107 +
 .../tpcds-tool/answer_set/56_NULLS_FIRST.ans       |  102 +
 .../tpcds-tool/answer_set/56_NULLS_LAST.ans        |  102 +
 .../flink-tpcds-test/tpcds-tool/answer_set/57.ans  |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/58.ans  |    5 +
 .../flink-tpcds-test/tpcds-tool/answer_set/59.ans  |  103 +
 .../tpcds-tool/answer_set/5_NULLS_FIRST.ans        |  101 +
 .../tpcds-tool/answer_set/5_NULLS_LAST.ans         |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/60.ans  |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/61.ans  |    3 +
 .../tpcds-tool/answer_set/62_NULLS_FIRST.ans       |  104 +
 .../tpcds-tool/answer_set/62_NULLS_LAST.ans        |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/63.ans  |  101 +
 .../flink-tpcds-test/tpcds-tool/answer_set/64.ans  |   12 +
 .../tpcds-tool/answer_set/65_NULLS_FIRST.ans       |  102 +
 .../tpcds-tool/answer_set/65_NULLS_LAST.ans        |  102 +
 .../tpcds-tool/answer_set/66_NULLS_FIRST.ans       |    6 +
 .../tpcds-tool/answer_set/66_NULLS_LAST.ans        |   10 +
 .../tpcds-tool/answer_set/67_NULLS_FIRST.ans       |  102 +
 .../tpcds-tool/answer_set/67_NULLS_LAST.ans        |  107 +
 .../tpcds-tool/answer_set/68_NULLS_FIRST.ans       |  101 +
 .../tpcds-tool/answer_set/68_NULLS_LAST.ans        |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/69.ans  |  107 +
 .../tpcds-tool/answer_set/6_NULLS_FIRST.ans        |   47 +
 .../tpcds-tool/answer_set/6_NULLS_LAST.ans         |   47 +
 .../flink-tpcds-test/tpcds-tool/answer_set/7.ans   |  102 +
 .../flink-tpcds-test/tpcds-tool/answer_set/70.ans  |    8 +
 .../tpcds-tool/answer_set/70_SQL_SERVER.ans        |    4 +
 .../tpcds-tool/answer_set/71_NULLS_FIRST.ans       | 1022 ++++
 .../tpcds-tool/answer_set/71_NULLS_LAST.ans        | 1019 ++++
 .../tpcds-tool/answer_set/72_NULLS_FIRST.ans       |  103 +
 .../tpcds-tool/answer_set/72_NULLS_LAST.ans        |  102 +
 .../flink-tpcds-test/tpcds-tool/answer_set/73.ans  |    7 +
 .../flink-tpcds-test/tpcds-tool/answer_set/74.ans  |   99 +
 .../flink-tpcds-test/tpcds-tool/answer_set/75.ans  |  102 +
 .../tpcds-tool/answer_set/76_NULLS_FIRST.ans       |  101 +
 .../tpcds-tool/answer_set/76_NULLS_LAST.ans        |  107 +
 .../tpcds-tool/answer_set/77_NULLS_FIRST.ans       |   47 +
 .../tpcds-tool/answer_set/77_NULLS_LAST.ans        |   46 +
 .../tpcds-tool/answer_set/77_SQL_SERVER.ans        |   45 +
 .../flink-tpcds-test/tpcds-tool/answer_set/78.ans  |  103 +
 .../tpcds-tool/answer_set/79_NULLS_FIRST.ans       |  101 +
 .../tpcds-tool/answer_set/79_NULLS_LAST.ans        |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/8.ans   |   10 +
 .../tpcds-tool/answer_set/80_NULLS_FIRST.ans       |  102 +
 .../tpcds-tool/answer_set/80_NULLS_LAST.ans        |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/81.ans  |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/82.ans  |    7 +
 .../flink-tpcds-test/tpcds-tool/answer_set/83.ans  |   28 +
 .../flink-tpcds-test/tpcds-tool/answer_set/84.ans  |   32 +
 .../flink-tpcds-test/tpcds-tool/answer_set/85.ans  |   13 +
 .../tpcds-tool/answer_set/86_NULLS_FIRST.ans       |  101 +
 .../tpcds-tool/answer_set/86_NULLS_LAST.ans        |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/87.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/88.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/89.ans  |  107 +
 .../tpcds-tool/answer_set/8_SQL_SERVER.ans         |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/9.ans   |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/90.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/91.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/92.ans  |    3 +
 .../tpcds-tool/answer_set/93_NULLS_FIRST.ans       |  101 +
 .../tpcds-tool/answer_set/93_NULLS_LAST.ans        |  107 +
 .../flink-tpcds-test/tpcds-tool/answer_set/94.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/95.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/96.ans  |    6 +
 .../flink-tpcds-test/tpcds-tool/answer_set/97.ans  |    2 +
 .../tpcds-tool/answer_set/98_NULLS_FIRST.ans       | 2518 ++++++++
 .../tpcds-tool/answer_set/98_NULLS_LAST.ans        | 2518 ++++++++
 .../tpcds-tool/answer_set/99_NULLS_FIRST.ans       |   91 +
 .../tpcds-tool/answer_set/99_NULLS_LAST.ans        |   97 +
 .../flink-tpcds-test/tpcds-tool/data_generator.sh  |  143 +
 .../flink-tpcds-test/tpcds-tool/query/query1.sql   |   25 +
 .../flink-tpcds-test/tpcds-tool/query/query10.sql  |   59 +
 .../flink-tpcds-test/tpcds-tool/query/query11.sql  |   81 +
 .../flink-tpcds-test/tpcds-tool/query/query12.sql  |   34 +
 .../flink-tpcds-test/tpcds-tool/query/query13.sql  |   52 +
 .../flink-tpcds-test/tpcds-tool/query/query14a.sql |  104 +
 .../flink-tpcds-test/tpcds-tool/query/query14b.sql |  109 +
 .../flink-tpcds-test/tpcds-tool/query/query15.sql  |   20 +
 .../flink-tpcds-test/tpcds-tool/query/query16.sql  |   31 +
 .../flink-tpcds-test/tpcds-tool/query/query17.sql  |   45 +
 .../flink-tpcds-test/tpcds-tool/query/query18.sql  |   33 +
 .../flink-tpcds-test/tpcds-tool/query/query19.sql  |   25 +
 .../flink-tpcds-test/tpcds-tool/query/query2.sql   |   60 +
 .../flink-tpcds-test/tpcds-tool/query/query20.sql  |   30 +
 .../flink-tpcds-test/tpcds-tool/query/query21.sql  |   30 +
 .../flink-tpcds-test/tpcds-tool/query/query22.sql  |   20 +
 .../flink-tpcds-test/tpcds-tool/query/query23a.sql |   52 +
 .../flink-tpcds-test/tpcds-tool/query/query23b.sql |   58 +
 .../flink-tpcds-test/tpcds-tool/query/query24a.sql |   55 +
 .../flink-tpcds-test/tpcds-tool/query/query24b.sql |   55 +
 .../flink-tpcds-test/tpcds-tool/query/query25.sql  |   48 +
 .../flink-tpcds-test/tpcds-tool/query/query26.sql  |   21 +
 .../flink-tpcds-test/tpcds-tool/query/query27.sql  |   23 +
 .../flink-tpcds-test/tpcds-tool/query/query28.sql  |   53 +
 .../flink-tpcds-test/tpcds-tool/query/query29.sql  |   47 +
 .../flink-tpcds-test/tpcds-tool/query/query3.sql   |   21 +
 .../flink-tpcds-test/tpcds-tool/query/query30.sql  |   31 +
 .../flink-tpcds-test/tpcds-tool/query/query31.sql  |   52 +
 .../flink-tpcds-test/tpcds-tool/query/query32.sql  |   28 +
 .../flink-tpcds-test/tpcds-tool/query/query33.sql  |   75 +
 .../flink-tpcds-test/tpcds-tool/query/query34.sql  |   31 +
 .../flink-tpcds-test/tpcds-tool/query/query35.sql  |   58 +
 .../flink-tpcds-test/tpcds-tool/query/query36.sql  |   29 +
 .../flink-tpcds-test/tpcds-tool/query/query37.sql  |   17 +
 .../flink-tpcds-test/tpcds-tool/query/query38.sql  |   23 +
 .../flink-tpcds-test/tpcds-tool/query/query39a.sql |   28 +
 .../flink-tpcds-test/tpcds-tool/query/query39b.sql |   29 +
 .../flink-tpcds-test/tpcds-tool/query/query4.sql   |  116 +
 .../flink-tpcds-test/tpcds-tool/query/query40.sql  |   28 +
 .../flink-tpcds-test/tpcds-tool/query/query41.sql  |   52 +
 .../flink-tpcds-test/tpcds-tool/query/query42.sql  |   22 +
 .../flink-tpcds-test/tpcds-tool/query/query43.sql  |   19 +
 .../flink-tpcds-test/tpcds-tool/query/query44.sql  |   35 +
 .../flink-tpcds-test/tpcds-tool/query/query45.sql  |   20 +
 .../flink-tpcds-test/tpcds-tool/query/query46.sql  |   35 +
 .../flink-tpcds-test/tpcds-tool/query/query47.sql  |   51 +
 .../flink-tpcds-test/tpcds-tool/query/query48.sql  |   67 +
 .../flink-tpcds-test/tpcds-tool/query/query49.sql  |  129 +
 .../flink-tpcds-test/tpcds-tool/query/query5.sql   |  128 +
 .../flink-tpcds-test/tpcds-tool/query/query50.sql  |   59 +
 .../flink-tpcds-test/tpcds-tool/query/query51.sql  |   45 +
 .../flink-tpcds-test/tpcds-tool/query/query52.sql  |   22 +
 .../flink-tpcds-test/tpcds-tool/query/query53.sql  |   28 +
 .../flink-tpcds-test/tpcds-tool/query/query54.sql  |   56 +
 .../flink-tpcds-test/tpcds-tool/query/query55.sql  |   14 +
 .../flink-tpcds-test/tpcds-tool/query/query56.sql  |   69 +
 .../flink-tpcds-test/tpcds-tool/query/query57.sql  |   48 +
 .../flink-tpcds-test/tpcds-tool/query/query58.sql  |   65 +
 .../flink-tpcds-test/tpcds-tool/query/query59.sql  |   44 +
 .../flink-tpcds-test/tpcds-tool/query/query6.sql   |   26 +
 .../flink-tpcds-test/tpcds-tool/query/query60.sql  |   78 +
 .../flink-tpcds-test/tpcds-tool/query/query61.sql  |   44 +
 .../flink-tpcds-test/tpcds-tool/query/query62.sql  |   35 +
 .../flink-tpcds-test/tpcds-tool/query/query63.sql  |   29 +
 .../flink-tpcds-test/tpcds-tool/query/query64.sql  |  121 +
 .../flink-tpcds-test/tpcds-tool/query/query65.sql  |   29 +
 .../flink-tpcds-test/tpcds-tool/query/query66.sql  |  220 +
 .../flink-tpcds-test/tpcds-tool/query/query67.sql  |   44 +
 .../flink-tpcds-test/tpcds-tool/query/query68.sql  |   43 +
 .../flink-tpcds-test/tpcds-tool/query/query69.sql  |   47 +
 .../flink-tpcds-test/tpcds-tool/query/query7.sql   |   21 +
 .../flink-tpcds-test/tpcds-tool/query/query70.sql  |   38 +
 .../flink-tpcds-test/tpcds-tool/query/query71.sql  |   40 +
 .../flink-tpcds-test/tpcds-tool/query/query72.sql  |   29 +
 .../flink-tpcds-test/tpcds-tool/query/query73.sql  |   28 +
 .../flink-tpcds-test/tpcds-tool/query/query74.sql  |   61 +
 .../flink-tpcds-test/tpcds-tool/query/query75.sql  |   70 +
 .../flink-tpcds-test/tpcds-tool/query/query76.sql  |   24 +
 .../flink-tpcds-test/tpcds-tool/query/query77.sql  |  108 +
 .../flink-tpcds-test/tpcds-tool/query/query78.sql  |   58 +
 .../flink-tpcds-test/tpcds-tool/query/query79.sql  |   23 +
 .../flink-tpcds-test/tpcds-tool/query/query8.sql   |  108 +
 .../flink-tpcds-test/tpcds-tool/query/query80.sql  |   96 +
 .../flink-tpcds-test/tpcds-tool/query/query81.sql  |   31 +
 .../flink-tpcds-test/tpcds-tool/query/query82.sql  |   17 +
 .../flink-tpcds-test/tpcds-tool/query/query83.sql  |   67 +
 .../flink-tpcds-test/tpcds-tool/query/query84.sql  |   21 +
 .../flink-tpcds-test/tpcds-tool/query/query85.sql  |   84 +
 .../flink-tpcds-test/tpcds-tool/query/query86.sql  |   26 +
 .../flink-tpcds-test/tpcds-tool/query/query87.sql  |   23 +
 .../flink-tpcds-test/tpcds-tool/query/query88.sql  |   94 +
 .../flink-tpcds-test/tpcds-tool/query/query89.sql  |   28 +
 .../flink-tpcds-test/tpcds-tool/query/query9.sql   |   51 +
 .../flink-tpcds-test/tpcds-tool/query/query90.sql  |   22 +
 .../flink-tpcds-test/tpcds-tool/query/query91.sql  |   31 +
 .../flink-tpcds-test/tpcds-tool/query/query92.sql  |   30 +
 .../flink-tpcds-test/tpcds-tool/query/query93.sql  |   18 +
 .../flink-tpcds-test/tpcds-tool/query/query94.sql  |   29 +
 .../flink-tpcds-test/tpcds-tool/query/query95.sql  |   32 +
 .../flink-tpcds-test/tpcds-tool/query/query96.sql  |   16 +
 .../flink-tpcds-test/tpcds-tool/query/query97.sql  |   25 +
 .../flink-tpcds-test/tpcds-tool/query/query98.sql  |   33 +
 .../flink-tpcds-test/tpcds-tool/query/query99.sql  |   35 +
 flink-end-to-end-tests/flink-tpch-test/pom.xml     |    3 +-
 flink-end-to-end-tests/pom.xml                     |  176 +-
 flink-end-to-end-tests/run-nightly-tests.sh        |  172 +-
 flink-end-to-end-tests/run-pre-commit-tests.sh     |   66 -
 flink-end-to-end-tests/run-single-test.sh          |    3 +
 flink-end-to-end-tests/test-scripts/common.sh      |  143 +-
 .../test-scripts/common_docker.sh                  |   72 +
 .../test-scripts/common_dummy_fs.sh                |    4 +-
 flink-end-to-end-tests/test-scripts/common_ha.sh   |    7 +-
 .../test-scripts/common_kubernetes.sh              |  180 +
 .../test-scripts/common_mesos_docker.sh            |   89 +
 flink-end-to-end-tests/test-scripts/common_s3.sh   |  172 +-
 .../test-scripts/common_s3_minio.sh                |  118 +
 .../test-scripts/common_s3_operations.sh           |  160 +
 flink-end-to-end-tests/test-scripts/common_ssl.sh  |    2 +-
 .../test-scripts/common_utils.sh                   |    2 +
 .../test-scripts/common_yarn_docker.sh             |  212 +
 .../container-scripts/docker-compose.nat.yml       |   93 +
 .../container-scripts/docker-compose.test.yml      |   18 +-
 .../job-cluster-job.yaml.template                  |    9 +-
 .../container-scripts}/job-cluster-service.yaml    |    0
 .../task-manager-deployment.yaml.template          |   17 +-
 .../config/yarn-site.xml                           |    8 +
 .../docker-compose.yml                             |   12 +-
 .../test-scripts/docker-mesos-cluster/Dockerfile   |   29 +
 .../docker-mesos-cluster/docker-compose.yml        |   66 +
 .../test-scripts/elasticsearch-common.sh           |   12 +-
 .../test-scripts/kafka-common.sh                   |   55 +-
 .../test-scripts/kafka_sql_common.sh               |   11 +-
 .../test-scripts/python2_fileserver.py             |   31 +
 .../test-scripts/python3_fileserver.py             |   31 +
 .../test-scripts/queryable_state_base.sh           |    4 +-
 .../test-scripts/test-runner-common.sh             |   25 +-
 .../test-scripts/test_batch_allround.sh            |    4 +-
 .../test-scripts/test_batch_wordcount.sh           |   54 +-
 .../test-scripts/test_confluent_schema_registry.sh |   38 +-
 .../test-scripts/test_datastream_walkthroughs.sh   |    5 +-
 .../test-scripts/test_docker_embedded_job.sh       |   28 +-
 .../test-scripts/test_ha_datastream.sh             |    7 +-
 .../test_ha_per_job_cluster_datastream.sh          |   17 +-
 .../test-scripts/test_heavy_deployment.sh          |   14 +-
 .../test_high_parallelism_iterations.sh            |    3 +
 .../test-scripts/test_kubernetes_application.sh    |   61 +
 .../test-scripts/test_kubernetes_embedded_job.sh   |   47 +-
 .../test-scripts/test_kubernetes_session.sh        |   75 +
 .../test_local_recovery_and_scheduling.sh          |    2 +-
 .../test_mesos_multiple_submissions.sh             |   52 +
 .../test-scripts/test_mesos_wordcount.sh           |   38 +
 flink-end-to-end-tests/test-scripts/test_nat.sh    |   73 +
 .../test_netty_shuffle_memory_control.sh           |   49 +
 .../test-scripts/test_pyflink.sh                   |  210 +
 .../test_queryable_state_restart_tm.sh             |    3 -
 .../test-scripts/test_quickstarts.sh               |   22 +-
 .../test_resume_externalized_checkpoints.sh        |  219 +-
 .../test-scripts/test_resume_savepoint.sh          |  120 +-
 .../test_rocksdb_state_memory_control.sh           |  117 +
 .../test-scripts/test_sql_client.sh                |   87 +-
 .../test-scripts/test_sql_client_kafka.sh          |   22 -
 .../test-scripts/test_sql_client_kafka010.sh       |   22 -
 .../test-scripts/test_sql_client_kafka011.sh       |   22 -
 .../test-scripts/test_sql_client_kafka_common.sh   |  218 -
 .../test-scripts/test_stream_state_ttl.sh          |   10 +-
 .../test-scripts/test_streaming_bucketing.sh       |   16 +-
 .../test-scripts/test_streaming_elasticsearch.sh   |    2 +-
 .../test-scripts/test_streaming_file_sink.sh       |   88 +-
 .../test-scripts/test_streaming_gcp_pubsub.sh      |    4 +-
 .../test-scripts/test_streaming_kafka.sh           |   25 -
 .../test-scripts/test_streaming_kafka010.sh        |   26 -
 .../test-scripts/test_streaming_kafka011.sh        |   24 -
 .../test-scripts/test_streaming_kafka_common.sh    |  103 -
 .../test-scripts/test_table_shaded_dependencies.sh |    6 +
 .../test-scripts/test_table_walkthroughs.sh        |    5 +-
 flink-end-to-end-tests/test-scripts/test_tpcds.sh  |   89 +
 flink-end-to-end-tests/test-scripts/test_tpch.sh   |    1 +
 .../test_yarn_application_kerberos_docker.sh       |  104 +
 .../test-scripts/test_yarn_job_kerberos_docker.sh  |   85 +
 .../test-scripts/test_yarn_kerberos_docker.sh      |  212 -
 flink-examples/flink-examples-batch/pom.xml        |    2 +-
 .../flink/examples/java/wordcount/WordCount.java   |   18 +-
 .../src/main/resources/log4j.properties            |   23 -
 .../src/main/resources/log4j2.properties           |   25 +
 .../flink-examples-streaming-gcp-pubsub/pom.xml    |    2 +-
 .../flink-examples-streaming-state-machine/pom.xml |    2 +-
 .../src/main/resources/META-INF/NOTICE             |    4 +-
 .../flink-examples-streaming-twitter/pom.xml       |    2 +-
 flink-examples/flink-examples-build-helper/pom.xml |    2 +-
 flink-examples/flink-examples-streaming/pom.xml    |  118 +-
 .../streaming/examples/async/AsyncIOExample.java   |   38 +-
 .../streaming/examples/gpu/MatrixVectorMul.java    |  244 +
 .../examples/iteration/IterateExample.java         |    2 +-
 .../flink/streaming/examples/join/WindowJoin.java  |    2 -
 .../examples/sideoutput/SideOutputExample.java     |    2 +-
 .../statemachine/KafkaEventsGeneratorJob.java      |    4 +-
 .../streaming/examples/statemachine/README.md      |    2 +-
 .../examples/statemachine/StateMachineExample.java |    4 +-
 .../generator/EventsGeneratorSource.java           |    2 +-
 .../streaming/examples/wordcount/WordCount.java    |   18 +-
 .../src/main/resources/log4j.properties            |   23 -
 .../src/main/resources/log4j2.properties           |   25 +
 .../src/test/resources/log4j-test.properties       |   23 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-examples/flink-examples-table/pom.xml        |   31 +-
 .../table/examples/java/StreamSQLExample.java      |   26 +-
 .../examples/java/StreamWindowSQLExample.java      |  100 +
 .../flink/table/examples/java/WordCountSQL.java    |    8 +-
 .../flink/table/examples/java/WordCountTable.java  |   10 +-
 .../src/main/resources/log4j2.properties           |   25 +
 .../src/main/resources/logback.xml                 |    0
 .../table/examples/scala/StreamSQLExample.scala    |   22 +-
 .../table/examples/scala/StreamTableExample.scala  |    3 +-
 .../table/examples/scala/TPCHQuery3Table.scala     |    3 +-
 .../flink/table/examples/scala/WordCountSQL.scala  |    7 +-
 .../table/examples/scala/WordCountTable.scala      |    3 +-
 flink-examples/pom.xml                             |   16 +-
 .../flink-external-resource-gpu/pom.xml            |   53 +
 .../flink/externalresource/gpu/GPUDriver.java      |  146 +
 .../externalresource/gpu/GPUDriverFactory.java     |   33 +
 .../apache/flink/externalresource/gpu/GPUInfo.java |   77 +
 ....externalresource.ExternalResourceDriverFactory |   16 +
 .../src/main/resources/gpu-discovery-common.sh     |   92 +
 .../src/main/resources/nvidia-gpu-discovery.sh     |   60 +
 .../gpu/GPUDiscoveryScriptTest.java                |   76 +
 .../flink/externalresource/gpu/GPUDriverTest.java  |  106 +
 .../src/test/resources/test-coordination-mode.sh   |   78 +
 .../src/test/resources/testing-gpu-discovery.sh    |   68 +
 flink-external-resources/pom.xml                   |   40 +
 flink-filesystems/flink-azure-fs-hadoop/pom.xml    |   18 +-
 .../fs/azurefs/EnvironmentVariableKeyProvider.java |   48 +
 .../src/main/resources/META-INF/NOTICE             |   12 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-filesystems/flink-fs-hadoop-shaded/pom.xml   |    2 +-
 .../src/main/resources/META-INF/NOTICE             |    8 +-
 flink-filesystems/flink-hadoop-fs/pom.xml          |   34 +-
 .../hdfs/HadoopRecoverableFsDataOutputStream.java  |   12 +-
 .../runtime/fs/hdfs/HadoopRecoverableWriter.java   |   23 +-
 .../org/apache/flink/runtime/util/HadoopUtils.java |  147 +-
 .../fs/hdfs/AbstractHadoopFileSystemITTest.java    |   38 +-
 .../runtime/fs/hdfs/HadoopConfigLoadingTest.java   |  104 +-
 ...leWriterOldHadoopWithNoTruncateSupportTest.java |  165 +
 .../apache/flink/runtime/fs/hdfs/HdfsKindTest.java |   42 -
 .../apache/flink/runtime/util/HadoopUtilsTest.java |  153 +
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-filesystems/flink-mapr-fs/pom.xml            |   13 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-filesystems/flink-oss-fs-hadoop/pom.xml      |   27 +-
 .../flink/fs/osshadoop/OSSFileSystemFactory.java   |    2 +-
 .../src/main/resources/META-INF/NOTICE             |  121 +-
 .../src/main/resources/licenses/LICENSE.asm        |   31 -
 .../src/main/resources/licenses/LICENSE.cddlv1.0   |  129 -
 .../src/main/resources/licenses/LICENSE.cddlv1.1   |  348 --
 .../src/main/resources/licenses/LICENSE.jzlib      |   26 -
 .../src/main/resources/licenses/LICENSE.paranamer  |   28 -
 .../src/main/resources/licenses/LICENSE.protobuf   |   36 -
 .../fs/osshadoop/HadoopOSSFileSystemITCase.java    |    4 +-
 flink-filesystems/flink-s3-fs-base/pom.xml         |  215 +-
 .../s3/model/transform/XmlResponsesSaxParser.java  | 3769 ++++++++++++
 .../flink/fs/s3/common/FlinkS3FileSystem.java      |    4 +-
 .../flink/fs/s3/common/utils/RefCounted.java       |   41 -
 .../utils/RefCountedBufferingFileStream.java       |   10 +-
 .../s3/common/utils/RefCountedFSOutputStream.java  |    1 +
 .../flink/fs/s3/common/utils/RefCountedFile.java   |  140 -
 .../s3/common/utils/RefCountedFileWithStream.java  |   93 +
 .../s3/common/utils/RefCountedTmpFileCreator.java  |   10 +-
 .../writer/S3RecoverableFsDataOutputStream.java    |   12 +-
 .../S3RecoverableMultipartUploadFactory.java       |    8 +-
 .../fs/s3/common/writer/S3RecoverableWriter.java   |    8 +-
 .../src/main/resources/META-INF/NOTICE             |   24 -
 .../utils/RefCountedBufferingFileStreamTest.java   |    4 +-
 .../fs/s3/common/utils/RefCountedFileTest.java     |  144 -
 .../common/utils/RefCountedFileWithStreamTest.java |  100 +
 .../writer/RecoverableMultiPartUploadImplTest.java |    4 +-
 .../S3RecoverableFsDataOutputStreamTest.java       |   10 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-filesystems/flink-s3-fs-hadoop/pom.xml       |  190 +-
 .../flink/fs/s3hadoop/S3FileSystemFactory.java     |   14 +-
 .../src/main/resources/META-INF/NOTICE             |   50 +
 .../main/resources/META-INF/licenses/LICENSE-re2j} |    0
 .../resources/META-INF/licenses/LICENSE-stax2api}  |    0
 .../META-INF/licenses/LICENSE.javax.activation     |  135 +
 .../main/resources/META-INF/licenses/LICENSE.jaxb  |  135 +
 .../fs/s3hadoop/HadoopS3FileSystemITCase.java      |    2 +-
 .../flink/fs/s3hadoop/HadoopS3FileSystemTest.java  |    2 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-filesystems/flink-s3-fs-presto/pom.xml       |  211 +-
 .../flink/fs/s3presto/S3FileSystemFactory.java     |   14 +-
 .../src/main/resources/META-INF/NOTICE             |   48 +-
 .../main/resources/META-INF/licenses/LICENSE-re2j  |    0
 .../resources/META-INF/licenses/LICENSE-stax2api   |    0
 .../META-INF/licenses/LICENSE.javax.activation     |  135 +
 .../main/resources/META-INF/licenses/LICENSE.jaxb  |  135 +
 .../fs/s3presto/PrestoS3FileSystemITCase.java      |    2 +-
 .../flink/fs/s3presto/PrestoS3FileSystemTest.java  |    2 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-filesystems/flink-swift-fs-hadoop/pom.xml    |   34 +-
 .../src/main/resources/META-INF/NOTICE             |    4 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-filesystems/pom.xml                          |    2 +-
 .../flink-avro-confluent-registry/pom.xml          |    8 +-
 .../ConfluentRegistryAvroSerializationSchema.java  |  116 +
 .../confluent/ConfluentSchemaRegistryCoder.java    |   30 +-
 .../src/main/resources/META-INF/NOTICE             |   12 +-
 flink-formats/flink-avro/pom.xml                   |   74 +-
 .../org/apache/flink/formats/avro/AvroBuilder.java |   38 +
 .../apache/flink/formats/avro/AvroBulkWriter.java  |   58 +
 .../formats/avro/AvroFileSystemFormatFactory.java  |  267 +
 .../flink/formats/avro/AvroFormatFactory.java      |  112 +
 .../avro/AvroRowDataDeserializationSchema.java     |  372 ++
 .../avro/AvroRowDataSerializationSchema.java       |  297 +
 .../formats/avro/AvroRowSerializationSchema.java   |    9 +
 .../formats/avro/AvroSerializationSchema.java      |  165 +
 .../flink/formats/avro/AvroWriterFactory.java      |   90 +
 .../org/apache/flink/formats/avro/AvroWriters.java |  104 +
 .../avro/RegistryAvroSerializationSchema.java      |   98 +
 .../org/apache/flink/formats/avro/SchemaCoder.java |    6 +-
 .../avro/typeutils/AvroSchemaConverter.java        |  143 +-
 .../formats/avro/typeutils/AvroSerializer.java     |    5 +-
 .../org.apache.flink.table.factories.Factory       |   17 +
 .../formats/avro/AvroExternalJarProgramITCase.java |    4 +-
 .../flink/formats/avro/AvroFilesystemITCase.java   |   57 +
 .../formats/avro/AvroFilesystemStreamITCase.java   |   38 +
 .../flink/formats/avro/AvroFormatFactoryTest.java  |  124 +
 .../formats/avro/AvroKryoClassloadingTest.java     |    4 +-
 .../avro/AvroRowDataDeSerializationSchemaTest.java |  200 +
 .../formats/avro/AvroSerializationSchemaTest.java  |   60 +
 .../formats/avro/AvroStreamingFileSinkITCase.java  |  232 +
 .../RegistryAvroDeserializationSchemaTest.java     |   18 +-
 .../avro/typeutils/AvroSchemaConverterTest.java    |   42 +
 .../typeutils/AvroSerializerGenericRecordTest.java |   59 +
 .../typeutils/AvroSerializerMigrationTest.java     |  259 -
 .../avro/typeutils/AvroSerializerUpgradeTest.java  |  185 +
 .../flink/table/runtime/batch/AvroTypesITCase.java |   14 +-
 .../flink-avro/src/test/resources/avro/user.avsc   |   11 +-
 ...6-avro-generic-type-serializer-address-snapshot |  Bin 901 -> 0 bytes
 .../resources/flink-1.6-avro-type-serialized-data  |  Bin 23563 -> 0 bytes
 .../flink-1.6-avro-type-serializer-address-data    |  Bin 240 -> 0 bytes
 ...flink-1.6-avro-type-serializer-address-snapshot |  Bin 710 -> 0 bytes
 .../flink-1.6-avro-type-serializer-snapshot        |  Bin 36411 -> 0 bytes
 .../flink-1.7-avro-type-serializer-address-data    |  Bin 240 -> 0 bytes
 .../src/test/resources/flink_11-kryo_registrations |   86 -
 .../serializer-snapshot}                           |  Bin
 .../generic-avro-serializer-1.11/test-data         |  Bin 0 -> 51 bytes
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../serializer-snapshot}                           |  Bin
 .../specific-avro-serializer-1.11/test-data        |  Bin 0 -> 51 bytes
 flink-formats/flink-compress/pom.xml               |   97 +
 .../formats/compress/CompressWriterFactory.java    |  134 +
 .../flink/formats/compress/CompressWriters.java    |   32 +
 .../compress/extractor/DefaultExtractor.java       |   33 +
 .../formats/compress/extractor/Extractor.java      |   31 +
 .../writers/HadoopCompressionBulkWriter.java       |   60 +
 .../compress/writers/NoCompressionBulkWriter.java  |   60 +
 .../compress/CompressWriterFactoryTest.java        |  205 +
 .../formats/compress/CompressionFactoryITCase.java |  120 +
 .../formats/compress/CustomCompressionCodec.java   |   32 +
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-formats/flink-csv/pom.xml                    |   25 +-
 .../flink/formats/csv/AbstractCsvInputFormat.java  |  130 +
 .../formats/csv/CsvFileSystemFormatFactory.java    |  326 +
 .../apache/flink/formats/csv/CsvFormatFactory.java |  251 +
 .../org/apache/flink/formats/csv/CsvOptions.java   |   95 +
 .../csv/CsvRowDataDeserializationSchema.java       |  455 ++
 .../formats/csv/CsvRowDataSerializationSchema.java |  454 ++
 .../formats/csv/CsvRowDeserializationSchema.java   |   12 +-
 .../flink/formats/csv/CsvRowFormatFactory.java     |    8 +-
 .../flink/formats/csv/CsvRowSchemaConverter.java   |   97 +-
 .../formats/csv/CsvRowSerializationSchema.java     |   24 +
 .../flink/formats/csv/RowCsvInputFormat.java       |  232 +
 .../org/apache/flink/table/descriptors/Csv.java    |   16 +
 .../flink/table/descriptors/CsvValidator.java      |   21 +-
 .../org.apache.flink.table.factories.Factory       |   17 +
 .../formats/csv/CsvFilesystemBatchITCase.java      |  103 +
 .../formats/csv/CsvFilesystemStreamITCase.java     |   37 +
 .../formats/csv/CsvFilesystemStreamSinkITCase.java |   38 +
 .../flink/formats/csv/CsvFormatFactoryTest.java    |  240 +
 .../formats/csv/CsvRowDataSerDeSchemaTest.java     |  355 ++
 .../csv/CsvRowDeSerializationSchemaTest.java       |   18 +
 .../flink/formats/csv/CsvRowFormatFactoryTest.java |   59 +-
 .../formats/csv/RowCsvInputFormatSplitTest.java    |  173 +
 .../flink/formats/csv/RowCsvInputFormatTest.java   |  756 +++
 .../apache/flink/table/descriptors/CsvTest.java    |   14 -
 flink-formats/flink-hadoop-bulk/pom.xml            |  142 +
 .../bulk/DefaultHadoopFileCommitterFactory.java    |   51 +
 .../formats/hadoop/bulk/HadoopFileCommitter.java   |   62 +
 .../hadoop/bulk/HadoopFileCommitterFactory.java    |   57 +
 .../hadoop/bulk/HadoopPathBasedBulkWriter.java     |   71 +
 .../hadoop/bulk/HadoopPathBasedPartFileWriter.java |  297 +
 .../bulk/committer/HadoopRenameFileCommitter.java  |  124 +
 .../HadoopPathBasedBulkFormatBuilder.java          |  134 +
 .../sink/filesystem/SerializableConfiguration.java |   55 +
 .../hadoop/bulk/AbstractFileCommitterTest.java     |  305 +
 .../bulk/HadoopPathBasedPartFileWriterTest.java    |  193 +
 .../committer/HadoopRenameCommitterHDFSTest.java   |   97 +
 .../HadoopRenameCommitterLocalFSTest.java          |   69 +
 .../hadoop/bulk/committer/cluster/HDFSCluster.java |   51 +
 .../filesystem/TestStreamingFileSinkFactory.java   |   32 +
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-formats/flink-json/pom.xml                   |   25 +-
 .../formats/json/JsonFileSystemFormatFactory.java  |  268 +
 .../flink/formats/json/JsonFormatFactory.java      |  157 +
 .../org/apache/flink/formats/json/JsonOptions.java |   84 +
 .../json/JsonRowDataDeserializationSchema.java     |  437 ++
 .../json/JsonRowDataSerializationSchema.java       |  325 +
 .../formats/json/JsonRowDeserializationSchema.java |  218 +-
 .../flink/formats/json/JsonRowFormatFactory.java   |    7 +-
 .../formats/json/JsonRowSerializationSchema.java   |  101 +-
 .../org/apache/flink/formats/json/TimeFormats.java |   18 +-
 .../apache/flink/formats/json/TimestampFormat.java |   35 +
 .../json/canal/CanalJsonDeserializationSchema.java |  191 +
 .../formats/json/canal/CanalJsonFormatFactory.java |  116 +
 .../DebeziumJsonDeserializationSchema.java         |  189 +
 .../json/debezium/DebeziumJsonFormatFactory.java   |  129 +
 .../org/apache/flink/table/descriptors/Json.java   |   29 +
 .../flink/table/descriptors/JsonValidator.java     |   18 +-
 .../org.apache.flink.table.factories.Factory       |   19 +
 .../formats/json/JsonBatchFileSystemITCase.java    |   62 +
 .../flink/formats/json/JsonFormatFactoryTest.java  |  197 +
 .../flink/formats/json/JsonFsStreamSinkITCase.java |   39 +
 .../formats/json/JsonRowDataSerDeSchemaTest.java   |  557 ++
 .../json/JsonRowDeserializationSchemaTest.java     |  207 +-
 .../formats/json/JsonRowFormatFactoryTest.java     |   18 +-
 .../json/JsonRowSerializationSchemaTest.java       |   43 +-
 .../canal/CanalJsonDeserializationSchemaTest.java  |  162 +
 .../json/canal/CanalJsonFormatFactoryTest.java     |  146 +
 .../DebeziumJsonDeserializationSchemaTest.java     |  164 +
 .../debezium/DebeziumJsonFormatFactoryTest.java    |  148 +
 .../apache/flink/table/descriptors/JsonTest.java   |   36 +-
 .../flink-json/src/test/resources/canal-data.txt   |   10 +
 .../resources/debezium-data-schema-exclude.txt     |   16 +
 .../resources/debezium-data-schema-include.txt     |   16 +
 flink-formats/flink-orc-nohive/pom.xml             |  121 +
 .../orc/nohive/OrcNoHiveBulkWriterFactory.java     |  187 +
 .../flink/orc/nohive/OrcNoHiveSplitReaderUtil.java |   93 +
 .../flink/orc/nohive/shim/OrcNoHiveShim.java       |   96 +
 .../orc/nohive/vector/AbstractOrcNoHiveVector.java |  194 +
 .../orc/nohive/vector/OrcNoHiveBatchWrapper.java   |   45 +
 .../orc/nohive/vector/OrcNoHiveBytesVector.java    |   44 +
 .../orc/nohive/vector/OrcNoHiveDecimalVector.java  |   46 +
 .../orc/nohive/vector/OrcNoHiveDoubleVector.java   |   46 +
 .../orc/nohive/vector/OrcNoHiveLongVector.java     |   65 +
 .../nohive/vector/OrcNoHiveTimestampVector.java    |   48 +
 .../OrcColumnarRowSplitReaderNoHiveTest.java       |  121 +
 flink-formats/flink-orc/pom.xml                    |  204 +
 .../java/org/apache/flink/orc/OrcBatchReader.java  |    0
 .../flink/orc/OrcColumnarRowSplitReader.java       |   89 +
 .../flink/orc/OrcFileSystemFormatFactory.java      |  211 +
 .../java/org/apache/flink/orc/OrcInputFormat.java  |  218 +
 .../org/apache/flink/orc/OrcRowInputFormat.java    |  109 +
 .../org/apache/flink/orc/OrcRowSplitReader.java    |   71 +
 .../java/org/apache/flink/orc/OrcSplitReader.java  |  503 ++
 .../org/apache/flink/orc/OrcSplitReaderUtil.java   |  200 +
 .../java/org/apache/flink/orc/OrcTableSource.java  |  545 ++
 .../java/org/apache/flink/orc/shim/OrcShim.java    |   81 +
 .../org/apache/flink/orc/shim/OrcShimV200.java     |  206 +
 .../org/apache/flink/orc/shim/OrcShimV210.java     |   37 +
 .../org/apache/flink/orc/shim/OrcShimV230.java     |   57 +
 .../flink/orc/vector/AbstractOrcColumnVector.java  |  194 +
 .../flink/orc/vector/HiveOrcBatchWrapper.java      |   43 +
 .../flink/orc/vector/OrcBytesColumnVector.java     |   44 +
 .../flink/orc/vector/OrcDecimalColumnVector.java   |   46 +
 .../flink/orc/vector/OrcDoubleColumnVector.java    |   46 +
 .../flink/orc/vector/OrcLongColumnVector.java      |   65 +
 .../flink/orc/vector/OrcTimestampColumnVector.java |   48 +
 .../orc/vector/OrcVectorizedBatchWrapper.java      |   35 +
 .../apache/flink/orc/vector/RowDataVectorizer.java |  144 +
 .../org/apache/flink/orc/vector/Vectorizer.java    |   96 +
 .../org/apache/flink/orc/writer/OrcBulkWriter.java |   77 +
 .../flink/orc/writer/OrcBulkWriterFactory.java     |  126 +
 .../flink/orc/writer/PhysicalWriterImpl.java       |  371 ++
 .../org.apache.flink.table.factories.Factory       |   16 +
 .../org/apache/flink/orc/OrcBatchReaderTest.java   |    0
 .../flink/orc/OrcColumnarRowSplitReaderTest.java   |  457 ++
 .../org/apache/flink/orc/OrcFileSystemITCase.java  |   88 +
 .../apache/flink/orc/OrcFsStreamingSinkITCase.java |   38 +
 .../apache/flink/orc/OrcRowInputFormatTest.java    | 1034 ++++
 .../apache/flink/orc/OrcSplitReaderUtilTest.java   |   68 +
 .../org/apache/flink/orc/OrcTableSourceITCase.java |  118 +
 .../org/apache/flink/orc/OrcTableSourceTest.java   |  354 ++
 .../java/org/apache/flink/orc/data/Record.java     |   59 +
 .../flink/orc/util/OrcBulkWriterTestUtil.java      |   98 +
 .../flink/orc/util/OrcTestFileGenerator.java       |    0
 .../apache/flink/orc/vector/RecordVectorizer.java  |   57 +
 .../flink/orc/writer/OrcBulkWriterITCase.java      |   77 +
 .../apache/flink/orc/writer/OrcBulkWriterTest.java |   83 +
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../resources/test-data-composites-with-nulls.orc  |  Bin
 .../src/test/resources/test-data-decimal.orc       |  Bin
 .../src/test/resources/test-data-flat.orc          |  Bin
 .../src/test/resources/test-data-nested.orc        |  Bin
 .../src/test/resources/test-data-nestedlist.orc    |  Bin
 .../src/test/resources/test-data-repeating.orc     |  Bin
 .../src/test/resources/test-data-timetypes.orc     |  Bin
 flink-formats/flink-parquet/pom.xml                |   46 +-
 .../parquet/ParquetFileSystemFormatFactory.java    |  216 +
 .../formats/parquet/ParquetMapInputFormat.java     |   10 +-
 .../formats/parquet/ParquetPojoInputFormat.java    |    2 +-
 .../flink/formats/parquet/ParquetTableSource.java  |   29 +-
 .../formats/parquet/row/ParquetRowDataBuilder.java |  155 +
 .../formats/parquet/row/ParquetRowDataWriter.java  |  325 +
 .../parquet/utils/ParquetSchemaConverter.java      |   90 +-
 .../parquet/utils/SerializableConfiguration.java   |   55 +
 .../vector/ParquetColumnarRowSplitReader.java      |  367 ++
 .../parquet/vector/ParquetDecimalVector.java       |   65 +
 .../formats/parquet/vector/ParquetDictionary.java  |   66 +
 .../parquet/vector/ParquetSplitReaderUtil.java     |  387 ++
 .../vector/reader/AbstractColumnReader.java        |  318 +
 .../parquet/vector/reader/BooleanColumnReader.java |  115 +
 .../parquet/vector/reader/ByteColumnReader.java    |   99 +
 .../parquet/vector/reader/BytesColumnReader.java   |   98 +
 .../parquet/vector/reader/ColumnReader.java        |   34 +
 .../parquet/vector/reader/DoubleColumnReader.java  |  101 +
 .../vector/reader/FixedLenBytesColumnReader.java   |  144 +
 .../parquet/vector/reader/FloatColumnReader.java   |  101 +
 .../parquet/vector/reader/IntColumnReader.java     |  100 +
 .../parquet/vector/reader/LongColumnReader.java    |  101 +
 .../parquet/vector/reader/RunLengthDecoder.java    |  293 +
 .../parquet/vector/reader/ShortColumnReader.java   |   84 +
 .../vector/reader/TimestampColumnReader.java       |  120 +
 .../org.apache.flink.table.factories.Factory       |   16 +
 .../formats/parquet/ParquetFileSystemITCase.java   |   95 +
 .../parquet/ParquetFsStreamingSinkITCase.java      |   38 +
 .../formats/parquet/ParquetTableSourceITCase.java  |    9 +-
 .../parquet/row/ParquetRowDataWriterTest.java      |  167 +
 .../formats/parquet/utils/ParquetWriterUtil.java   |  166 +
 .../flink/formats/parquet/utils/TestUtil.java      |    3 +-
 .../vector/ParquetColumnarRowSplitReaderTest.java  |  555 ++
 .../src/test/resources/log4j-test.properties       |   23 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-formats/flink-sequence-file/pom.xml          |   12 +-
 .../src/test/resources/log4j-test.properties       |   23 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-formats/flink-sql-orc/pom.xml                |   92 +
 .../src/main/resources/META-INF/NOTICE             |   18 +
 .../resources/META-INF/licenses/LICENSE.protobuf   |    0
 flink-formats/flink-sql-parquet/pom.xml            |   96 +
 .../src/main/resources/META-INF/NOTICE             |   18 +
 flink-formats/pom.xml                              |   27 +-
 flink-fs-tests/pom.xml                             |   43 +-
 .../hdfstests/ContinuousFileProcessingITCase.java  |   76 +-
 .../ContinuousFileProcessingMigrationTest.java     |   24 +-
 .../hdfstests/ContinuousFileProcessingTest.java    |   67 +-
 .../flink/hdfstests/DistributedCacheDfsTest.java   |   36 +-
 .../java/org/apache/flink/hdfstests/Utils.java     |   53 +
 .../src/test/resources/log4j-test.properties       |   31 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 ...-migration-test-1493116191000-flink1.2-snapshot |  Bin 373 -> 0 bytes
 .../reader-migration-test-flink1.2-snapshot        |  Bin 2590 -> 0 bytes
 flink-java/pom.xml                                 |    7 +-
 .../org/apache/flink/api/java/ClosureCleaner.java  |  271 -
 .../java/org/apache/flink/api/java/DataSet.java    |    4 +-
 .../flink/api/java/ExecutionEnvironment.java       |  334 +-
 .../apache/flink/api/java/LocalEnvironment.java    |   31 +-
 .../apache/flink/api/java/RemoteEnvironment.java   |  119 +-
 .../api/java/RemoteEnvironmentConfigUtils.java     |   89 +
 .../main/java/org/apache/flink/api/java/Utils.java |   36 +-
 .../apache/flink/api/java/io/CsvInputFormat.java   |    5 -
 .../flink/api/java/io/RowCsvInputFormat.java       |   11 +-
 .../flink/api/java/operators/UnsortedGrouping.java |    4 +-
 .../api/java/utils/AbstractParameterTool.java      |  308 +
 .../api/java/utils/MultipleParameterTool.java      |  272 +
 .../org/apache/flink/api/java/utils/Option.java    |    7 +-
 .../apache/flink/api/java/utils/OptionType.java    |    7 +-
 .../apache/flink/api/java/utils/ParameterTool.java |  265 +-
 .../apache/flink/api/java/utils/PlanGenerator.java |  191 +
 .../flink/api/java/utils/RequiredParameters.java   |    7 +-
 .../java/utils/RequiredParametersException.java    |    7 +-
 .../java/ExecutorDiscoveryAndJobClientTest.java    |   92 +
 .../apache/flink/api/java/TestingJobClient.java    |   71 +
 .../api/java/functions/ClosureCleanerTest.java     |  523 --
 .../flink/api/java/io/RowCsvInputFormatTest.java   |   26 +
 .../flink/api/java/operator/MaxByOperatorTest.java |   43 +-
 .../flink/api/java/operator/MinByOperatorTest.java |   43 +-
 .../api/java/utils/AbstractParameterToolTest.java  |  547 +-
 .../api/java/utils/MultipleParameterToolTest.java  |   79 +
 .../apache/flink/api/java/utils/OptionsTest.java   |    1 +
 .../flink/api/java/utils/ParameterToolTest.java    |  492 +-
 .../flink/api/java/utils/PlanGeneratorTest.java    |   77 +
 .../api/java/utils/RequiredParametersTest.java     |    1 +
 ...he.flink.core.execution.PipelineExecutorFactory |   16 +
 .../src/test/resources/log4j-test.properties       |   28 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-jepsen/README.md                             |  165 +-
 flink-jepsen/docker/up.sh                          |    2 +-
 flink-jepsen/src/jepsen/flink/db.clj               |   19 +-
 flink-jepsen/src/jepsen/flink/flink.clj            |    6 +-
 flink-jepsen/src/jepsen/flink/mesos.clj            |    5 +-
 flink-jepsen/src/jepsen/flink/utils.clj            |   12 +-
 flink-kubernetes/pom.xml                           |  191 +
 .../kubernetes/KubernetesClusterClientFactory.java |   72 +
 .../kubernetes/KubernetesClusterDescriptor.java    |  261 +
 .../kubernetes/KubernetesResourceManager.java      |  372 ++
 .../flink/kubernetes/KubernetesWorkerNode.java     |   58 +
 .../flink/kubernetes/cli/KubernetesSessionCli.java |  197 +
 .../configuration/KubernetesConfigOptions.java     |  252 +
 .../KubernetesConfigOptionsInternal.java           |   39 +
 .../configuration/KubernetesDeploymentTarget.java  |   87 +
 .../KubernetesResourceManagerConfiguration.java    |   42 +
 .../KubernetesApplicationClusterEntrypoint.java    |  115 +
 .../entrypoint/KubernetesEntrypointUtils.java      |   68 +
 .../KubernetesResourceManagerFactory.java          |   99 +
 .../KubernetesSessionClusterEntrypoint.java        |   55 +
 .../KubernetesWorkerResourceSpecFactory.java       |   48 +
 .../KubernetesSessionClusterExecutor.java          |   38 +
 .../KubernetesSessionClusterExecutorFactory.java   |   50 +
 .../flink/kubernetes/kubeclient/Endpoint.java      |   45 +
 .../kubeclient/Fabric8FlinkKubeClient.java         |  305 +
 .../kubernetes/kubeclient/FlinkKubeClient.java     |  121 +
 .../flink/kubernetes/kubeclient/FlinkPod.java      |   90 +
 .../kubernetes/kubeclient/KubeClientFactory.java   |   80 +
 .../KubernetesJobManagerSpecification.java         |   47 +
 .../AbstractKubernetesStepDecorator.java           |   91 +
 .../decorators/ExternalServiceDecorator.java       |   84 +
 .../decorators/FlinkConfMountDecorator.java        |  189 +
 .../decorators/HadoopConfMountDecorator.java       |  186 +
 .../decorators/InitJobManagerDecorator.java        |  133 +
 .../decorators/InitTaskManagerDecorator.java       |  109 +
 .../decorators/InternalServiceDecorator.java       |  102 +
 .../decorators/JavaCmdJobManagerDecorator.java     |  105 +
 .../decorators/JavaCmdTaskManagerDecorator.java    |  108 +
 .../decorators/KubernetesStepDecorator.java        |   47 +
 .../factory/KubernetesJobManagerFactory.java       |  106 +
 .../factory/KubernetesTaskManagerFactory.java      |   59 +
 .../parameters/AbstractKubernetesParameters.java   |  180 +
 .../parameters/KubernetesJobManagerParameters.java |  140 +
 .../parameters/KubernetesParameters.java           |  113 +
 .../KubernetesTaskManagerParameters.java           |  126 +
 .../kubeclient/resources/KubernetesPod.java        |   46 +
 .../resources/KubernetesPodsWatcher.java           |   75 +
 .../kubeclient/resources/KubernetesResource.java   |   40 +
 .../kubeclient/resources/KubernetesService.java    |   31 +
 .../kubeclient/resources/KubernetesToleration.java |   65 +
 .../kubeclient/resources/KubernetesWatch.java      |   35 +
 .../taskmanager/KubernetesTaskExecutorRunner.java  |   50 +
 .../apache/flink/kubernetes/utils/Constants.java   |   83 +
 .../flink/kubernetes/utils/KubernetesUtils.java    |  234 +
 .../src/main/resources/META-INF/NOTICE             |   26 +
 .../resources/META-INF/licenses/LICENSE.automaton  |   24 +
 ...he.flink.client.deployment.ClusterClientFactory |   16 +
 ...he.flink.core.execution.PipelineExecutorFactory |   16 +
 .../flink/kubernetes/KubernetesClientTestBase.java |  124 +
 .../KubernetesClusterClientFactoryTest.java        |   51 +
 .../KubernetesClusterDescriptorTest.java           |  219 +
 .../kubernetes/KubernetesResourceManagerTest.java  |  724 +++
 .../flink/kubernetes/KubernetesTestBase.java       |  125 +
 .../flink/kubernetes/KubernetesTestUtils.java      |   50 +
 .../flink/kubernetes/KubernetesWorkerNodeTest.java |   49 +
 .../apache/flink/kubernetes/MixedDispatcher.java   |   67 +
 .../flink/kubernetes/MixedKubernetesServer.java    |   70 +
 .../kubernetes/cli/KubernetesSessionCliTest.java   |  282 +
 .../KubernetesDeploymentTargetTest.java            |   75 +
 .../KubernetesWorkerResourceSpecFactoryTest.java   |   66 +
 .../kubeclient/Fabric8FlinkKubeClientTest.java     |  250 +
 .../kubeclient/KubernetesJobManagerTestBase.java   |  100 +
 .../kubeclient/KubernetesTaskManagerTestBase.java  |  101 +
 .../decorators/ExternalServiceDecoratorTest.java   |  107 +
 .../decorators/FlinkConfMountDecoratorTest.java    |  231 +
 .../decorators/HadoopConfMountDecoratorTest.java   |  178 +
 .../decorators/InitJobManagerDecoratorTest.java    |  195 +
 .../decorators/InitTaskManagerDecoratorTest.java   |  217 +
 .../decorators/InternalServiceDecoratorTest.java   |   99 +
 .../decorators/JavaCmdJobManagerDecoratorTest.java |  247 +
 .../JavaCmdTaskManagerDecoratorTest.java           |  245 +
 .../factory/KubernetesJobManagerFactoryTest.java   |  262 +
 .../factory/KubernetesTaskManagerFactoryTest.java  |   84 +
 .../AbstractKubernetesParametersTest.java          |  112 +
 .../KubernetesJobManagerParametersTest.java        |  199 +
 .../KubernetesTaskManagerParametersTest.java       |  153 +
 .../resources/KubernetesPodsWatcherTest.java       |  112 +
 .../kubernetes/utils/KubernetesUtilsTest.java      |   88 +
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-libraries/flink-cep-scala/pom.xml            |    2 +-
 flink-libraries/flink-cep/pom.xml                  |    2 +-
 .../org/apache/flink/cep/nfa/StateTransition.java  |    2 +-
 .../apache/flink/cep/nfa/compiler/NFACompiler.java |   12 +-
 .../flink/cep/nfa/sharedbuffer/Lockable.java       |    2 +-
 .../cep/nfa/sharedbuffer/SharedBufferEdge.java     |   19 +
 .../cep/nfa/sharedbuffer/SharedBufferNode.java     |   18 +
 .../org/apache/flink/cep/operator/CepOperator.java |   19 +
 .../flink/cep/operator/CepRuntimeContext.java      |   14 +-
 .../cep/NFASerializerSnapshotsMigrationTest.java   |   84 -
 .../apache/flink/cep/NFASerializerUpgradeTest.java |  356 ++
 .../apache/flink/cep/nfa/AfterMatchSkipITCase.java |   46 +-
 .../org/apache/flink/cep/nfa/GreedyITCase.java     |   36 +-
 .../java/org/apache/flink/cep/nfa/GroupITCase.java |   34 +-
 .../flink/cep/nfa/IterativeConditionsITCase.java   |   16 +-
 .../java/org/apache/flink/cep/nfa/NFAITCase.java   |  104 +-
 .../nfa/NFAIterativeConditionTimeContextTest.java  |    8 +-
 .../org/apache/flink/cep/nfa/NotPatternITCase.java |   42 +-
 .../apache/flink/cep/nfa/SameElementITCase.java    |   18 +-
 .../apache/flink/cep/nfa/TimesOrMoreITCase.java    |   24 +-
 .../org/apache/flink/cep/nfa/TimesRangeITCase.java |   26 +-
 .../apache/flink/cep/nfa/UntilConditionITCase.java |   26 +-
 .../flink/cep/nfa/compiler/NFACompilerTest.java    |   21 +
 ...ockableTypeSerializerSnapshotMigrationTest.java |   56 -
 .../LockableTypeSerializerUpgradeTest.java         |  102 +
 .../apache/flink/cep/operator/CEPOperatorTest.java |   25 +
 .../flink/cep/operator/CepRuntimeContextTest.java  |   13 -
 .../apache/flink/cep/utils/NFATestUtilities.java   |    2 +-
 .../serializer-snapshot                            |  Bin 0 -> 98 bytes
 .../dewey-number-serializer-1.11/test-data         |  Bin 0 -> 8 bytes
 .../event-id-serializer-1.11/serializer-snapshot   |  Bin 0 -> 99 bytes
 .../resources/event-id-serializer-1.11/test-data   |  Bin 0 -> 12 bytes
 .../flink-1.6-dewey-number-serializer-data         |  Bin 80 -> 0 bytes
 .../flink-1.6-dewey-number-serializer-snapshot     |  Bin 547 -> 0 bytes
 .../resources/flink-1.6-event-id-serializer-data   |  Bin 120 -> 0 bytes
 .../flink-1.6-event-id-serializer-snapshot         |  Bin 402 -> 0 bytes
 .../flink-1.6-lockable-type-serializer-data        |  Bin 160 -> 0 bytes
 .../flink-1.6-lockable-type-serializer-snapshot    |  Bin 561 -> 0 bytes
 .../resources/flink-1.6-nfa-state-serializer-data  |  Bin 1460 -> 0 bytes
 .../flink-1.6-nfa-state-serializer-snapshot        |  Bin 362 -> 0 bytes
 .../resources/flink-1.6-node-id-serializer-data    |  Bin 250 -> 0 bytes
 .../flink-1.6-node-id-serializer-snapshot          |  Bin 398 -> 0 bytes
 .../flink-1.6-shared-buffer-edge-serializer-data   |  Bin 330 -> 0 bytes
 ...link-1.6-shared-buffer-edge-serializer-snapshot |  Bin 438 -> 0 bytes
 .../flink-1.6-shared-buffer-node-serializer-data   |  Bin 370 -> 0 bytes
 ...link-1.6-shared-buffer-node-serializer-snapshot |  Bin 775 -> 0 bytes
 .../flink-1.7-dewey-number-serializer-data         |  Bin 80 -> 0 bytes
 .../flink-1.7-dewey-number-serializer-snapshot     |  Bin 535 -> 0 bytes
 .../resources/flink-1.7-event-id-serializer-data   |  Bin 120 -> 0 bytes
 .../flink-1.7-event-id-serializer-snapshot         |  Bin 390 -> 0 bytes
 .../flink-1.7-lockable-type-serializer-data        |  Bin 160 -> 0 bytes
 .../flink-1.7-lockable-type-serializer-snapshot    |  Bin 241 -> 0 bytes
 .../resources/flink-1.7-nfa-state-serializer-data  |  Bin 1460 -> 0 bytes
 .../flink-1.7-nfa-state-serializer-snapshot        |  Bin 350 -> 0 bytes
 .../resources/flink-1.7-node-id-serializer-data    |  Bin 250 -> 0 bytes
 .../flink-1.7-node-id-serializer-snapshot          |  Bin 386 -> 0 bytes
 .../flink-1.7-shared-buffer-edge-serializer-data   |  Bin 330 -> 0 bytes
 ...link-1.7-shared-buffer-edge-serializer-snapshot |  Bin 426 -> 0 bytes
 .../flink-1.7-shared-buffer-node-serializer-data   |  Bin 370 -> 0 bytes
 ...link-1.7-shared-buffer-node-serializer-snapshot |  Bin 763 -> 0 bytes
 .../serializer-snapshot                            |  Bin 0 -> 188 bytes
 .../lockable-type-serializer-1.11/test-data        |  Bin 0 -> 10 bytes
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../nfa-state-serializer-1.11/serializer-snapshot  |  Bin 0 -> 477 bytes
 .../resources/nfa-state-serializer-1.11/test-data  |  Bin 0 -> 8 bytes
 .../node-id-serializer-1.11/serializer-snapshot    |  Bin 0 -> 211 bytes
 .../resources/node-id-serializer-1.11/test-data    |  Bin 0 -> 18 bytes
 .../serializer-snapshot                            |  Bin 0 -> 447 bytes
 .../shared-buffer-edge-serializer-1.11/test-data   |  Bin 0 -> 26 bytes
 .../serializer-snapshot                            |  Bin 0 -> 680 bytes
 .../shared-buffer-node-serializer-1.11/test-data   |  Bin 0 -> 30 bytes
 flink-libraries/flink-gelly-examples/pom.xml       |   23 +-
 .../src/main/resources/log4j.properties            |   23 -
 .../src/main/resources/log4j2.properties           |   25 +
 ...perHashCodeSerializerSnapshotMigrationTest.java |   55 -
 ...lueWithProperHashCodeSerializerUpgradeTest.java |  101 +
 ...ong-value-with-proper-hash-code-serializer-data |  Bin 80 -> 0 bytes
 ...value-with-proper-hash-code-serializer-snapshot |  Bin 488 -> 0 bytes
 ...ong-value-with-proper-hash-code-serializer-data |  Bin 80 -> 0 bytes
 ...value-with-proper-hash-code-serializer-snapshot |  Bin 476 -> 0 bytes
 .../serializer-snapshot                            |  Bin 0 -> 162 bytes
 .../test-data                                      |  Bin 0 -> 8 bytes
 flink-libraries/flink-gelly-scala/pom.xml          |    2 +-
 flink-libraries/flink-gelly/pom.xml                |    2 +-
 .../flink/graph/library/CommunityDetection.java    |    8 +-
 .../ValueArraySerializerSnapshotMigrationTest.java |   93 -
 .../ValueArraySerializerUpgradeTest.java           |  523 ++
 .../serializer-snapshot                            |  Bin 0 -> 107 bytes
 .../byte-value-array-serializer-1.11/test-data     |  Bin 0 -> 6 bytes
 .../serializer-snapshot                            |  Bin 0 -> 107 bytes
 .../char-value-array-serializer-1.11/test-data     |  Bin 0 -> 10 bytes
 .../serializer-snapshot                            |  Bin 0 -> 111 bytes
 .../double-value-array-serializer-1.11/test-data   |  Bin 0 -> 20 bytes
 .../flink-1.6-byte-value-array-serializer-data     |  Bin 70 -> 0 bytes
 .../flink-1.6-byte-value-array-serializer-snapshot |  Bin 404 -> 0 bytes
 .../flink-1.6-char-value-array-serializer-data     |  Bin 240 -> 0 bytes
 .../flink-1.6-char-value-array-serializer-snapshot |  Bin 404 -> 0 bytes
 .../flink-1.6-double-value-array-serializer-data   |  Bin 280 -> 0 bytes
 ...link-1.6-double-value-array-serializer-snapshot |  Bin 408 -> 0 bytes
 .../flink-1.6-float-value-array-serializer-data    |  Bin 160 -> 0 bytes
 ...flink-1.6-float-value-array-serializer-snapshot |  Bin 406 -> 0 bytes
 .../flink-1.6-int-value-array-serializer-data      |  Bin 160 -> 0 bytes
 .../flink-1.6-int-value-array-serializer-snapshot  |  Bin 402 -> 0 bytes
 .../flink-1.6-long-value-array-serializer-data     |  Bin 280 -> 0 bytes
 .../flink-1.6-long-value-array-serializer-snapshot |  Bin 404 -> 0 bytes
 .../flink-1.6-null-value-array-serializer-data     |  Bin 40 -> 0 bytes
 .../flink-1.6-null-value-array-serializer-snapshot |  Bin 404 -> 0 bytes
 .../flink-1.6-short-value-array-serializer-data    |  Bin 100 -> 0 bytes
 ...flink-1.6-short-value-array-serializer-snapshot |  Bin 406 -> 0 bytes
 .../flink-1.6-string-value-array-serializer-data   |  Bin 280 -> 0 bytes
 ...link-1.6-string-value-array-serializer-snapshot |  Bin 408 -> 0 bytes
 .../flink-1.7-byte-value-array-serializer-data     |  Bin 70 -> 0 bytes
 .../flink-1.7-byte-value-array-serializer-snapshot |  Bin 392 -> 0 bytes
 .../flink-1.7-char-value-array-serializer-data     |  Bin 240 -> 0 bytes
 .../flink-1.7-char-value-array-serializer-snapshot |  Bin 392 -> 0 bytes
 .../flink-1.7-double-value-array-serializer-data   |  Bin 280 -> 0 bytes
 ...link-1.7-double-value-array-serializer-snapshot |  Bin 396 -> 0 bytes
 .../flink-1.7-float-value-array-serializer-data    |  Bin 160 -> 0 bytes
 ...flink-1.7-float-value-array-serializer-snapshot |  Bin 394 -> 0 bytes
 .../flink-1.7-int-value-array-serializer-data      |  Bin 160 -> 0 bytes
 .../flink-1.7-int-value-array-serializer-snapshot  |  Bin 390 -> 0 bytes
 .../flink-1.7-long-value-array-serializer-data     |  Bin 280 -> 0 bytes
 .../flink-1.7-long-value-array-serializer-snapshot |  Bin 392 -> 0 bytes
 .../flink-1.7-null-value-array-serializer-data     |  Bin 40 -> 0 bytes
 .../flink-1.7-null-value-array-serializer-snapshot |  Bin 392 -> 0 bytes
 .../flink-1.7-short-value-array-serializer-data    |  Bin 100 -> 0 bytes
 ...flink-1.7-short-value-array-serializer-snapshot |  Bin 394 -> 0 bytes
 .../flink-1.7-string-value-array-serializer-data   |  Bin 280 -> 0 bytes
 ...link-1.7-string-value-array-serializer-snapshot |  Bin 396 -> 0 bytes
 .../serializer-snapshot                            |  Bin 0 -> 109 bytes
 .../float-value-array-serializer-1.11/test-data    |  Bin 0 -> 12 bytes
 .../serializer-snapshot                            |  Bin 0 -> 105 bytes
 .../int-value-array-serializer-1.11/test-data      |  Bin 0 -> 12 bytes
 .../serializer-snapshot                            |  Bin 0 -> 107 bytes
 .../long-value-array-serializer-1.11/test-data     |  Bin 0 -> 20 bytes
 .../serializer-snapshot                            |  Bin 0 -> 107 bytes
 .../null-value-array-serializer-1.11/test-data     |  Bin 0 -> 4 bytes
 .../serializer-snapshot                            |  Bin 0 -> 109 bytes
 .../short-value-array-serializer-1.11/test-data    |  Bin 0 -> 8 bytes
 .../serializer-snapshot                            |  Bin 0 -> 111 bytes
 .../string-value-array-serializer-1.11/test-data   |  Bin 0 -> 16 bytes
 flink-libraries/flink-state-processing-api/pom.xml |   18 +-
 .../flink/state/api/BootstrapTransformation.java   |   23 +-
 .../apache/flink/state/api/ExistingSavepoint.java  |    8 +-
 .../java/org/apache/flink/state/api/Savepoint.java |    9 +-
 .../state/api/input/KeyedStateInputFormat.java     |  181 +-
 .../state/api/input/MultiStateKeyIterator.java     |   10 +-
 .../state/api/input/OperatorStateInputFormat.java  |   25 +-
 .../input/operator/KeyedStateReaderOperator.java   |  167 +
 .../api/input/operator/StateReaderOperator.java    |  146 +
 .../api/input/splits/KeyGroupRangeInputSplit.java  |    4 +-
 .../flink/state/api/output/BoundedStreamTask.java  |   15 +-
 .../state/api/output/MergeOperatorStates.java      |   15 +-
 .../state/api/output/SavepointOutputFormat.java    |   12 +-
 .../flink/state/api/output/SnapshotUtils.java      |    6 +-
 .../operators/BroadcastStateBootstrapOperator.java |    2 +
 .../operators/KeyedStateBootstrapOperator.java     |    9 +-
 .../api/output/operators/LazyTimerService.java     |   88 +
 .../output/operators/StateBootstrapOperator.java   |    2 +
 .../state/api/runtime/BoundedStreamConfig.java     |   51 -
 .../runtime/NeverFireProcessingTimeService.java    |   13 +-
 .../state/api/runtime/SavepointEnvironment.java    |   47 +-
 .../flink/state/api/runtime/SavepointLoader.java   |    8 +-
 .../state/api/runtime/SavepointRuntimeContext.java |   20 +-
 .../runtime/SavepointTaskManagerRuntimeInfo.java   |    7 +-
 .../api/runtime/SavepointTaskStateManager.java     |   15 +
 .../MemoryStateBackendReaderKeyedStateITCase.java  |   32 +
 .../RocksDBStateBackendReaderKeyedStateITCase.java |   33 +
 .../state/api/SavepointReaderKeyedStateITCase.java |  149 +-
 .../state/api/input/KeyedStateInputFormatTest.java |   20 +-
 .../state/api/input/MultiStateKeyIteratorTest.java |    2 +-
 .../output/KeyedStateBootstrapOperatorTest.java    |  193 +
 .../api/output/SavepointOutputFormatTest.java      |   25 +-
 .../flink/state/api/output/SnapshotUtilsTest.java  |   21 +-
 .../state/api/runtime/OperatorIDGeneratorTest.java |    2 +-
 .../flink/state/api/utils/SavepointTestBase.java   |   91 +
 .../flink/state/api/utils/WaitingSource.java       |  123 +
 flink-libraries/pom.xml                            |    2 +-
 flink-mesos/pom.xml                                |   10 +-
 .../entrypoint/MesosJobClusterEntrypoint.java      |   11 +-
 .../entrypoint/MesosSessionClusterEntrypoint.java  |    5 +-
 .../mesos/entrypoint/MesosTaskExecutorRunner.java  |    7 +-
 .../clusterframework/LaunchableMesosWorker.java    |   14 +-
 .../clusterframework/MesosResourceManager.java     |   33 +-
 .../MesosResourceManagerFactory.java               |   24 +-
 .../MesosTaskManagerParameters.java                |   48 +-
 .../MesosWorkerResourceSpecFactory.java            |   45 +
 .../clusterframework/store/MesosWorkerStore.java   |   40 +-
 .../org/apache/flink/mesos/util/MesosUtils.java    |   14 +-
 flink-mesos/src/main/resources/META-INF/NOTICE     |    8 +-
 flink-mesos/src/main/resources/log4j.properties    |   26 -
 .../LaunchableMesosWorkerTest.java                 |    5 +-
 .../clusterframework/MesosResourceManagerTest.java |   67 +-
 .../MesosTaskManagerParametersTest.java            |   80 +-
 .../store/MesosWorkerStoreTest.java                |   51 +
 .../src/test/resources/log4j-test.properties       |   32 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../mesos/scheduler/LaunchCoordinatorTest.scala    |    3 +
 flink-metrics/flink-metrics-core/pom.xml           |    2 +-
 .../flink/metrics/reporter/MetricReporter.java     |    2 +-
 .../metrics/reporter/MetricReporterFactory.java    |    8 +
 flink-metrics/flink-metrics-datadog/pom.xml        |   25 +-
 .../org/apache/flink/metrics/datadog/Clock.java    |   25 +
 .../org/apache/flink/metrics/datadog/DCounter.java |   21 +-
 .../org/apache/flink/metrics/datadog/DGauge.java   |    4 +-
 .../org/apache/flink/metrics/datadog/DMeter.java   |    4 +-
 .../org/apache/flink/metrics/datadog/DMetric.java  |   10 +-
 .../org/apache/flink/metrics/datadog/DSeries.java  |   18 +-
 .../apache/flink/metrics/datadog/DataCenter.java   |   36 +
 .../flink/metrics/datadog/DatadogHttpClient.java   |   19 +-
 .../flink/metrics/datadog/DatadogHttpReporter.java |   93 +-
 .../datadog/DatadogHttpReporterFactory.java        |   36 +
 .../apache/flink/metrics/datadog/MetricType.java   |    4 +-
 .../src/main/resources/META-INF/NOTICE             |    2 +-
 ...he.flink.metrics.reporter.MetricReporterFactory |   16 +
 .../apache/flink/metrics/datadog/DCounterTest.java |   65 +
 .../metrics/datadog/DatadogHttpClientTest.java     |   45 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-metrics/flink-metrics-dropwizard/pom.xml     |    6 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-metrics/flink-metrics-graphite/pom.xml       |    6 +-
 .../flink/metrics/graphite/GraphiteReporter.java   |    2 +
 .../metrics/graphite/GraphiteReporterFactory.java  |   35 +
 .../src/main/resources/META-INF/NOTICE             |    6 +-
 ...he.flink.metrics.reporter.MetricReporterFactory |   16 +
 flink-metrics/flink-metrics-influxdb/pom.xml       |   57 +-
 .../flink/metrics/influxdb/InfluxdbReporter.java   |   16 +-
 .../metrics/influxdb/InfluxdbReporterFactory.java  |   35 +
 .../metrics/influxdb/InfluxdbReporterOptions.java  |   14 +
 .../src/main/resources/META-INF/NOTICE             |   16 +-
 ...he.flink.metrics.reporter.MetricReporterFactory |   16 +
 .../metrics/influxdb/InfluxdbReporterTest.java     |   14 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-metrics/flink-metrics-jmx/pom.xml            |    4 +-
 .../org/apache/flink/metrics/jmx/JMXReporter.java  |   91 +-
 .../apache/flink/metrics/jmx/JMXReporterTest.java  |   13 +-
 .../jobmanager/JMXJobManagerMetricTest.java        |    3 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-metrics/flink-metrics-prometheus/pom.xml     |   10 +-
 .../prometheus/PrometheusPushGatewayReporter.java  |    2 +
 .../PrometheusPushGatewayReporterFactory.java      |   33 +
 .../PrometheusPushGatewayReporterOptions.java      |    2 +
 .../metrics/prometheus/PrometheusReporter.java     |    2 +
 .../prometheus/PrometheusReporterFactory.java      |   33 +
 .../src/main/resources/META-INF/NOTICE             |   10 +-
 ...he.flink.metrics.reporter.MetricReporterFactory |   17 +
 .../metrics/prometheus/PrometheusReporterTest.java |   17 +-
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-metrics/flink-metrics-slf4j/pom.xml          |    4 +-
 .../apache/flink/metrics/slf4j/Slf4jReporter.java  |    2 +
 .../flink/metrics/slf4j/Slf4jReporterFactory.java  |   35 +
 ...he.flink.metrics.reporter.MetricReporterFactory |   16 +
 .../flink/metrics/slf4j/Slf4jReporterTest.java     |   26 +-
 .../org/apache/flink/metrics/slf4j/TestUtils.java  |   93 -
 .../src/test/resources/log4j-test.properties       |   24 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-metrics/flink-metrics-statsd/pom.xml         |    4 +-
 .../flink/metrics/statsd/StatsDReporter.java       |    2 +
 .../metrics/statsd/StatsDReporterFactory.java      |   35 +
 ...he.flink.metrics.reporter.MetricReporterFactory |   16 +
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-metrics/pom.xml                              |    6 +-
 flink-ml-parent/flink-ml-api/pom.xml               |    5 +-
 flink-ml-parent/flink-ml-lib/pom.xml               |   28 +-
 .../org/apache/flink/ml/common/MLEnvironment.java  |    9 +-
 .../ml/common/utils/DataSetConversionUtil.java     |  168 +
 .../ml/common/utils/DataStreamConversionUtil.java  |  162 +
 .../flink/ml/common/utils/OutputColsHelper.java    |  202 +
 .../apache/flink/ml/common/utils/TableUtil.java    |  439 ++
 .../apache/flink/ml/pipeline/EstimatorBase.java    |    2 +-
 .../apache/flink/ml/pipeline/TransformerBase.java  |    2 +-
 .../src/main/resources/META-INF/NOTICE             |   10 -
 .../apache/flink/ml/common/MLEnvironmentTest.java  |    8 +-
 .../ml/common/utils/DataSetConversionUtilTest.java |  182 +
 .../common/utils/DataStreamConversionUtilTest.java |  181 +
 .../ml/common/utils/OutputColsHelperTest.java      |  263 +
 .../flink/ml/common/utils/TableUtilTest.java       |  176 +
 .../ml/pipeline/UserDefinedPipelineStages.java     |   58 +
 flink-ml-parent/flink-ml-uber/pom.xml              |   76 +
 .../src/main/resources/META-INF/NOTICE             |   10 +
 .../main/resources/META-INF/licenses/LICENSE.core  |    0
 flink-ml-parent/pom.xml                            |    3 +-
 flink-optimizer/pom.xml                            |    2 +-
 .../optimizer/plantranslate/JobGraphGenerator.java |   37 +-
 .../plantranslate/JobGraphGeneratorTest.java       |    3 +-
 .../src/test/resources/log4j-test.properties       |   30 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-python/MANIFEST.in                           |    7 +-
 flink-python/README.md                             |    2 +-
 flink-python/bin/pyflink-gateway-server.sh         |  100 -
 flink-python/bin/pyflink-shell.sh                  |    1 +
 flink-python/bin/pyflink-udf-runner.bat            |   54 +
 flink-python/bin/pyflink-udf-runner.sh             |   68 +-
 flink-python/dev/build-wheels.sh                   |   34 +
 flink-python/dev/dev-requirements.txt              |   18 +
 flink-python/dev/install_command.sh                |   31 +
 flink-python/dev/lint-python.sh                    |  183 +-
 flink-python/dev/pip_test_code.py                  |    4 +-
 flink-python/docs/index.rst                        |    2 +
 flink-python/docs/pyflink.metrics.rst              |   28 +
 flink-python/docs/pyflink.ml.rst                   |   52 +
 .../META-INF/licenses => lib}/LICENSE.cloudpickle  |    0
 {licenses => flink-python/lib}/LICENSE.py4j        |    0
 flink-python/lib/cloudpickle-LICENSE.txt           |   32 -
 flink-python/lib/py4j-LICENSE.txt                  |   26 -
 flink-python/pom.xml                               |  169 +-
 flink-python/pyflink/__init__.py                   |   13 +
 flink-python/pyflink/common/__init__.py            |   12 +-
 flink-python/pyflink/common/completable_future.py  |   95 +
 flink-python/pyflink/common/configuration.py       |    6 +
 flink-python/pyflink/common/execution_mode.py      |    2 +-
 flink-python/pyflink/common/job_client.py          |  135 +
 .../pyflink/common/job_execution_result.py         |   90 +
 flink-python/pyflink/common/job_id.py              |   37 +
 flink-python/pyflink/common/job_status.py          |  173 +
 .../pyflink/common/tests/test_execution_config.py  |    1 +
 .../pyflink/dataset/execution_environment.py       |    6 +-
 .../dataset/tests/test_execution_environment.py    |   23 +-
 .../test_execution_environment_completeness.py     |    4 +-
 flink-python/pyflink/datastream/state_backend.py   |   26 +-
 .../datastream/stream_execution_environment.py     |    6 +-
 .../pyflink/datastream/tests/test_state_backend.py |   44 +-
 .../tests/test_stream_execution_environment.py     |   21 +
 ...st_stream_execution_environment_completeness.py |    3 +-
 flink-python/pyflink/find_flink_home.py            |   11 +-
 flink-python/pyflink/fn_execution/ResettableIO.py  |   72 +
 flink-python/pyflink/fn_execution/boot.py          |  156 +-
 flink-python/pyflink/fn_execution/coder_impl.py    |  387 +-
 flink-python/pyflink/fn_execution/coders.py        |  358 +-
 .../pyflink/fn_execution/fast_coder_impl.pxd       |  217 +
 .../pyflink/fn_execution/fast_coder_impl.pyx       |  799 +++
 .../pyflink/fn_execution/fast_operations.pxd       |   46 +
 .../pyflink/fn_execution/fast_operations.pyx       |  253 +
 .../pyflink/fn_execution/flink_fn_execution_pb2.py |  532 +-
 flink-python/pyflink/fn_execution/operations.py    |  346 +-
 .../pyflink/fn_execution/sdk_worker_main.py        |   15 +-
 .../fn_execution/tests/coders_test_common.py       |   86 -
 .../fn_execution/tests/process_mode_test_data.py   |  114 -
 .../pyflink/fn_execution/tests/test_coders.py      |  159 +
 .../pyflink/fn_execution/tests/test_fast_coders.py |  214 +
 .../fn_execution/tests/test_process_mode_boot.py   |  131 +-
 flink-python/pyflink/gen_protos.py                 |    6 +-
 flink-python/pyflink/java_gateway.py               |   92 +-
 flink-python/pyflink/metrics/__init__.py           |   21 +
 flink-python/pyflink/metrics/metricbase.py         |  258 +
 .../pyflink/{util => metrics/tests}/__init__.py    |    0
 flink-python/pyflink/metrics/tests/test_metric.py  |   97 +
 flink-python/pyflink/{util => ml}/__init__.py      |    0
 flink-python/pyflink/ml/api/__init__.py            |   28 +
 flink-python/pyflink/ml/api/base.py                |  354 ++
 flink-python/pyflink/ml/api/ml_environment.py      |   92 +
 .../pyflink/ml/api/ml_environment_factory.py       |  125 +
 flink-python/pyflink/ml/api/param/__init__.py      |   21 +
 flink-python/pyflink/ml/api/param/base.py          |  350 ++
 flink-python/pyflink/{util => ml/lib}/__init__.py  |    0
 flink-python/pyflink/ml/lib/param/__init__.py      |   21 +
 flink-python/pyflink/ml/lib/param/colname.py       |   78 +
 .../pyflink/{util => ml/tests}/__init__.py         |    0
 .../pyflink/ml/tests/test_ml_environment.py        |   56 +
 .../ml/tests/test_ml_environment_factory.py        |   48 +
 flink-python/pyflink/ml/tests/test_params.py       |  187 +
 flink-python/pyflink/ml/tests/test_pipeline.py     |  172 +
 .../pyflink/ml/tests/test_pipeline_it_case.py      |  202 +
 .../pyflink/ml/tests/test_pipeline_stage.py        |   89 +
 .../pyflink/proto/flink-fn-execution.proto         |   55 +-
 flink-python/pyflink/pyflink_callback_server.py    |   32 +
 flink-python/pyflink/pyflink_gateway_server.py     |  221 +
 flink-python/pyflink/shell.py                      |    8 +-
 flink-python/pyflink/table/__init__.py             |   50 +-
 flink-python/pyflink/table/catalog.py              |   47 +-
 flink-python/pyflink/table/descriptors.py          |  595 +-
 .../pyflink/table/examples/batch/word_count.py     |   22 +-
 flink-python/pyflink/table/explain_detail.py       |   36 +
 flink-python/pyflink/table/module.py               |   51 +
 flink-python/pyflink/table/result_kind.py          |   51 +
 flink-python/pyflink/table/serializers.py          |   79 +
 .../pyflink/{common => table}/sql_dialect.py       |    0
 flink-python/pyflink/table/statement_set.py        |  104 +
 flink-python/pyflink/table/table.py                |  445 +-
 flink-python/pyflink/table/table_config.py         |   56 +-
 flink-python/pyflink/table/table_environment.py    | 1082 +++-
 flink-python/pyflink/table/table_result.py         |  142 +
 flink-python/pyflink/table/tests/test_calc.py      |   26 +-
 flink-python/pyflink/table/tests/test_catalog.py   |    9 +-
 .../table/tests/test_catalog_completeness.py       |    8 +-
 .../pyflink/table/tests/test_dependency.py         |  246 +
 .../pyflink/table/tests/test_descriptor.py         |  340 +-
 .../table/tests/test_environment_completeness.py   |    9 +-
 .../table/tests/test_environment_settings.py       |    4 +-
 flink-python/pyflink/table/tests/test_explain.py   |   40 +
 .../pyflink/table/tests/test_pandas_conversion.py  |  160 +
 .../pyflink/table/tests/test_pandas_udf.py         |  423 ++
 .../pyflink/table/tests/test_shell_example.py      |    4 +-
 flink-python/pyflink/table/tests/test_sql.py       |  151 +
 flink-python/pyflink/table/tests/test_table_api.py |   52 +
 .../pyflink/table/tests/test_table_config.py       |   12 +-
 .../table/tests/test_table_config_completeness.py  |    2 +-
 .../table/tests/test_table_environment_api.py      |  454 +-
 flink-python/pyflink/table/tests/test_types.py     |   36 +-
 flink-python/pyflink/table/tests/test_udf.py       |  176 +-
 flink-python/pyflink/table/tests/test_udtf.py      |  139 +
 flink-python/pyflink/table/types.py                |  350 +-
 flink-python/pyflink/table/udf.py                  |  261 +-
 flink-python/pyflink/table/utils.py                |   69 +
 flink-python/pyflink/testing/source_sink_utils.py  |    2 +-
 flink-python/pyflink/testing/test_case_utils.py    |  102 +-
 flink-python/pyflink/util/exceptions.py            |   29 +
 flink-python/pyflink/util/utils.py                 |   88 +
 flink-python/pyflink/version.py                    |    2 +-
 flink-python/setup.py                              |  182 +-
 .../fnexecution/state/GrpcStateService.java        |  170 +
 .../grpc/v1p21p0/io/netty/buffer/PoolArena.java    |  818 +++
 .../v1p21p0/io/netty/buffer/PoolThreadCache.java   |  508 ++
 .../io/netty/buffer/PooledByteBufAllocator.java    |  640 ++
 .../flink/client/cli/PythonProgramOptions.java     |   97 +
 .../apache/flink/client/python/PythonDriver.java   |   73 +-
 .../flink/client/python/PythonDriverOptions.java   |   38 +-
 .../python/PythonDriverOptionsParserFactory.java   |   67 +-
 .../apache/flink/client/python/PythonEnvUtils.java |  297 +-
 .../flink/client/python/PythonFunctionFactory.java |  182 +
 .../flink/client/python/PythonGatewayServer.java   |   55 +-
 .../flink/client/python/PythonShellParser.java     |   10 -
 .../flink/python/AbstractPythonFunctionRunner.java |  231 +-
 .../java/org/apache/flink/python/PythonConfig.java |  176 +
 .../org/apache/flink/python/PythonOptions.java     |  116 +-
 .../env/ProcessPythonEnvironmentManager.java       |  373 ++
 .../flink/python/env/PythonDependencyInfo.java     |  146 +
 .../flink/python/env/PythonEnvironmentManager.java |   57 +
 .../flink/python/metric/FlinkMetricContainer.java  |  281 +
 .../flink/python/util/PythonDependencyUtils.java   |  270 +
 .../python/util/PythonEnvironmentManagerUtils.java |  215 +
 .../org/apache/flink/python/util/ZipUtils.java     |  113 +
 .../python/AbstractPythonFunctionOperator.java     |  104 +-
 .../python/CustomConnectorDescriptor.java          |   72 -
 .../flink/table/runtime/arrow/ArrowReader.java     |   35 +
 .../flink/table/runtime/arrow/ArrowUtils.java      |  840 +++
 .../flink/table/runtime/arrow/ArrowWriter.java     |   85 +
 .../runtime/arrow/readers/ArrayFieldReader.java    |   83 +
 .../runtime/arrow/readers/ArrowFieldReader.java    |   54 +
 .../runtime/arrow/readers/BigIntFieldReader.java   |   39 +
 .../runtime/arrow/readers/BooleanFieldReader.java  |   39 +
 .../runtime/arrow/readers/DateFieldReader.java     |   46 +
 .../runtime/arrow/readers/DecimalFieldReader.java  |   41 +
 .../runtime/arrow/readers/DoubleFieldReader.java   |   39 +
 .../runtime/arrow/readers/FloatFieldReader.java    |   39 +
 .../runtime/arrow/readers/IntFieldReader.java      |   39 +
 .../runtime/arrow/readers/RowArrowReader.java      |   61 +
 .../runtime/arrow/readers/RowFieldReader.java      |   52 +
 .../runtime/arrow/readers/SmallIntFieldReader.java |   39 +
 .../runtime/arrow/readers/TimeFieldReader.java     |   70 +
 .../arrow/readers/TimestampFieldReader.java        |   65 +
 .../runtime/arrow/readers/TinyIntFieldReader.java  |   39 +
 .../arrow/readers/VarBinaryFieldReader.java        |   39 +
 .../runtime/arrow/readers/VarCharFieldReader.java  |   45 +
 .../arrow/sources/AbstractArrowSourceFunction.java |  220 +
 .../arrow/sources/AbstractArrowTableSource.java    |   55 +
 .../runtime/arrow/sources/ArrowSourceFunction.java |   54 +
 .../runtime/arrow/sources/ArrowTableSource.java    |   40 +
 .../arrow/sources/RowArrowSourceFunction.java      |   54 +
 .../runtime/arrow/sources/RowArrowTableSource.java |   40 +
 .../arrow/vectors/ArrowArrayColumnVector.java      |   59 +
 .../arrow/vectors/ArrowBigIntColumnVector.java     |   51 +
 .../arrow/vectors/ArrowBooleanColumnVector.java    |   51 +
 .../arrow/vectors/ArrowDateColumnVector.java       |   51 +
 .../arrow/vectors/ArrowDecimalColumnVector.java    |   52 +
 .../arrow/vectors/ArrowDoubleColumnVector.java     |   51 +
 .../arrow/vectors/ArrowFloatColumnVector.java      |   51 +
 .../arrow/vectors/ArrowIntColumnVector.java        |   48 +
 .../arrow/vectors/ArrowRowColumnVector.java        |   57 +
 .../arrow/vectors/ArrowSmallIntColumnVector.java   |   48 +
 .../arrow/vectors/ArrowTimeColumnVector.java       |   68 +
 .../arrow/vectors/ArrowTimestampColumnVector.java  |   69 +
 .../arrow/vectors/ArrowTinyIntColumnVector.java    |   48 +
 .../arrow/vectors/ArrowVarBinaryColumnVector.java  |   52 +
 .../arrow/vectors/ArrowVarCharColumnVector.java    |   52 +
 .../runtime/arrow/vectors/RowDataArrowReader.java  |   63 +
 .../table/runtime/arrow/writers/ArrayWriter.java   |  120 +
 .../runtime/arrow/writers/ArrowFieldWriter.java    |   89 +
 .../table/runtime/arrow/writers/BigIntWriter.java  |  101 +
 .../table/runtime/arrow/writers/BooleanWriter.java |  103 +
 .../table/runtime/arrow/writers/DateWriter.java    |  101 +
 .../table/runtime/arrow/writers/DecimalWriter.java |  117 +
 .../table/runtime/arrow/writers/DoubleWriter.java  |  101 +
 .../table/runtime/arrow/writers/FloatWriter.java   |  101 +
 .../table/runtime/arrow/writers/IntWriter.java     |  101 +
 .../runtime/arrow/writers/RowArrayWriter.java      |   63 +
 .../runtime/arrow/writers/RowBigIntWriter.java     |   44 +
 .../runtime/arrow/writers/RowBooleanWriter.java    |   46 +
 .../table/runtime/arrow/writers/RowDateWriter.java |   48 +
 .../runtime/arrow/writers/RowDecimalWriter.java    |   59 +
 .../runtime/arrow/writers/RowDoubleWriter.java     |   44 +
 .../runtime/arrow/writers/RowFloatWriter.java      |   44 +
 .../table/runtime/arrow/writers/RowIntWriter.java  |   44 +
 .../table/runtime/arrow/writers/RowRowWriter.java  |   71 +
 .../runtime/arrow/writers/RowSmallIntWriter.java   |   44 +
 .../table/runtime/arrow/writers/RowTimeWriter.java |   76 +
 .../runtime/arrow/writers/RowTimestampWriter.java  |   66 +
 .../runtime/arrow/writers/RowTinyIntWriter.java    |   44 +
 .../runtime/arrow/writers/RowVarBinaryWriter.java  |   44 +
 .../runtime/arrow/writers/RowVarCharWriter.java    |   46 +
 .../table/runtime/arrow/writers/RowWriter.java     |  129 +
 .../runtime/arrow/writers/SmallIntWriter.java      |  101 +
 .../table/runtime/arrow/writers/TimeWriter.java    |  119 +
 .../runtime/arrow/writers/TimestampWriter.java     |  124 +
 .../table/runtime/arrow/writers/TinyIntWriter.java |  101 +
 .../runtime/arrow/writers/VarBinaryWriter.java     |  101 +
 .../table/runtime/arrow/writers/VarCharWriter.java |  102 +
 .../AbstractPythonScalarFunctionFlatMap.java       |   99 +
 .../AbstractPythonStatelessFunctionFlatMap.java    |  316 +
 .../python/PythonScalarFunctionFlatMap.java        |   82 +
 .../python/PythonTableFunctionFlatMap.java         |  152 +
 .../arrow/ArrowPythonScalarFunctionFlatMap.java    |  128 +
 .../AbstractPythonScalarFunctionOperator.java      |  200 -
 .../python/AbstractStatelessFunctionOperator.java  |  269 +
 .../BaseRowPythonScalarFunctionOperator.java       |  179 -
 .../python/PythonScalarFunctionOperator.java       |  152 -
 .../AbstractPythonScalarFunctionOperator.java      |   96 +
 ...bstractRowDataPythonScalarFunctionOperator.java |  126 +
 .../AbstractRowPythonScalarFunctionOperator.java   |   93 +
 .../scalar/PythonScalarFunctionOperator.java       |   97 +
 .../RowDataPythonScalarFunctionOperator.java       |   96 +
 .../arrow/ArrowPythonScalarFunctionOperator.java   |  129 +
 .../RowDataArrowPythonScalarFunctionOperator.java  |  128 +
 .../table/AbstractPythonTableFunctionOperator.java |   90 +
 .../python/table/PythonTableFunctionOperator.java  |  147 +
 .../table/RowDataPythonTableFunctionOperator.java  |  175 +
 .../python/AbstractPythonScalarFunctionRunner.java |  232 -
 .../AbstractPythonStatelessFunctionRunner.java     |  255 +
 .../python/BaseRowPythonScalarFunctionRunner.java  |   62 -
 .../runners/python/PythonScalarFunctionRunner.java |   62 -
 .../AbstractGeneralPythonScalarFunctionRunner.java |  104 +
 .../scalar/AbstractPythonScalarFunctionRunner.java |   75 +
 .../python/scalar/PythonScalarFunctionRunner.java  |   60 +
 .../scalar/RowDataPythonScalarFunctionRunner.java  |   60 +
 .../AbstractArrowPythonScalarFunctionRunner.java   |  183 +
 .../arrow/ArrowPythonScalarFunctionRunner.java     |   60 +
 .../RowDataArrowPythonScalarFunctionRunner.java    |   60 +
 .../table/AbstractPythonTableFunctionRunner.java   |  121 +
 .../python/table/PythonTableFunctionRunner.java    |   60 +
 .../table/RowDataPythonTableFunctionRunner.java    |   58 +
 .../table/runtime/typeutils/PythonTypeUtils.java   |  315 +-
 .../serializers/python/ArrayDataSerializer.java    |  181 +
 .../serializers/python/BaseRowSerializer.java      |  232 -
 .../serializers/python/BigDecSerializer.java       |  108 +
 .../serializers/python/DateSerializer.java         |   23 +-
 .../serializers/python/DecimalDataSerializer.java  |  189 +
 .../serializers/python/MapDataSerializer.java      |  223 +
 .../serializers/python/RowDataSerializer.java      |  229 +
 .../serializers/python/TimeSerializer.java         |  130 +
 .../serializers/python/TimestampSerializer.java    |  202 +
 flink-python/src/main/resources/META-INF/NOTICE    |   64 +-
 .../flink/client/cli/PythonProgramOptionsTest.java |  107 +
 .../PythonDriverOptionsParserFactoryTest.java      |   34 +-
 .../flink/client/python/PythonDriverTest.java      |   34 +-
 .../flink/client/python/PythonEnvUtilsTest.java    |  185 +-
 .../client/python/PythonFunctionFactoryTest.java   |  150 +
 .../org/apache/flink/python/PythonConfigTest.java  |  161 +
 .../org/apache/flink/python/PythonOptionsTest.java |  120 +
 .../env/ProcessPythonEnvironmentManagerTest.java   |  373 ++
 .../flink/python/env/PythonDependencyInfoTest.java |  138 +
 .../python/metric/FlinkMetricContainerTest.java    |  218 +
 .../python/util/PythonDependencyUtilsTest.java     |  203 +
 .../flink/python/util/TestScalarFunction1.java     |   31 +
 .../flink/python/util/TestScalarFunction2.java     |   31 +
 .../AbstractPythonScalarFunctionRunnerTest.java    |  127 -
 .../BaseRowPythonScalarFunctionRunnerTest.java     |  108 -
 .../python/PythonScalarFunctionRunnerTest.java     |  282 -
 .../functions/python/PythonTypeUtilsTest.java      |   89 -
 .../runtime/arrow/ArrowReaderWriterTestBase.java   |   89 +
 .../flink/table/runtime/arrow/ArrowUtilsTest.java  |  318 +
 .../runtime/arrow/RowArrowReaderWriterTest.java    |  146 +
 .../arrow/RowDataArrowReaderWriterTest.java        |  188 +
 .../arrow/sources/ArrowSourceFunctionTest.java     |  119 +
 .../arrow/sources/ArrowSourceFunctionTestBase.java |  304 +
 .../arrow/sources/RowArrowSourceFunctionTest.java  |   85 +
 .../BaseRowPythonScalarFunctionOperatorTest.java   |  103 -
 .../python/PassThroughPythonFunctionRunner.java    |   75 -
 .../python/PythonScalarFunctionOperatorTest.java   |   81 -
 .../PythonScalarFunctionOperatorTestBase.java      |  223 -
 .../scalar/PythonScalarFunctionOperatorTest.java   |  114 +
 .../PythonScalarFunctionOperatorTestBase.java      |  258 +
 .../RowDataPythonScalarFunctionOperatorTest.java   |  140 +
 .../ArrowPythonScalarFunctionOperatorTest.java     |  113 +
 ...wDataArrowPythonScalarFunctionOperatorTest.java |  137 +
 .../table/PythonTableFunctionOperatorTest.java     |   97 +
 .../table/PythonTableFunctionOperatorTestBase.java |  213 +
 .../RowDataPythonTableFunctionOperatorTest.java    |  118 +
 .../AbstractPythonScalarFunctionRunnerTest.java    |  128 +
 .../scalar/PythonScalarFunctionRunnerTest.java     |  242 +
 .../RowDataPythonScalarFunctionRunnerTest.java     |   91 +
 .../arrow/ArrowPythonScalarFunctionRunnerTest.java |  181 +
 .../AbstractPythonTableFunctionRunnerTest.java     |   45 +
 .../table/PythonTableFunctionRunnerTest.java       |  143 +
 .../RowDataPythonTableFunctionRunnerTest.java      |   76 +
 .../runtime/typeutils/PythonTypeUtilsTest.java     |  101 +
 .../python/ArrayDataSerializerTest.java            |   93 +
 .../serializers/python/BaseRowSerializerTest.java  |  103 -
 .../serializers/python/BigDecSerializerTest.java   |   53 +
 .../python/DecimalDataSerializerTest.java          |   53 +
 .../serializers/python/MapDataSerializerTest.java  |   87 +
 .../serializers/python/RowDataSerializerTest.java  |  103 +
 .../serializers/python/TimeSerializerTest.java     |   49 +
 .../python/TimestampSerializerTest.java            |   68 +
 ...PassThroughArrowPythonScalarFunctionRunner.java |   95 +
 .../PassThroughPythonScalarFunctionRunner.java     |   93 +
 .../PassThroughPythonTableFunctionRunner.java      |   99 +
 .../flink/table/runtime/utils/PythonTestUtils.java |   81 +
 flink-python/tox.ini                               |   15 +-
 .../flink-queryable-state-client-java/pom.xml      |    2 +-
 .../client/QueryableStateClient.java               |    5 +-
 .../queryablestate/network/AbstractServerBase.java |    7 +-
 .../network/AbstractServerHandler.java             |   14 +-
 .../src/test/resources/log4j-test.properties       |   31 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../flink-queryable-state-runtime/pom.xml          |   10 +-
 .../client/proxy/KvStateClientProxyImpl.java       |    5 +-
 .../queryablestate/server/KvStateServerImpl.java   |    5 +-
 .../client/proxy/KvStateClientProxyImplTest.java   |    2 +-
 .../itcases/AbstractQueryableStateTestBase.java    |    6 +-
 .../itcases/HAQueryableStateFsBackendITCase.java   |    3 +-
 .../HAQueryableStateRocksDBBackendITCase.java      |    3 +-
 .../NonHAQueryableStateFsBackendITCase.java        |    3 +-
 .../NonHAQueryableStateRocksDBBackendITCase.java   |    3 +-
 .../queryablestate/network/AbstractServerTest.java |    2 +-
 .../flink/queryablestate/network/ClientTest.java   |    5 +-
 .../KVStateRequestSerializerRocksDBTest.java       |   72 +-
 .../network/KvStateServerHandlerTest.java          |   16 +-
 .../queryablestate/network/KvStateServerTest.java  |    2 +-
 .../src/test/resources/log4j-test.properties       |   31 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-queryable-state/pom.xml                      |    2 +-
 flink-quickstart/flink-quickstart-java/pom.xml     |    2 +-
 .../src/main/resources/archetype-resources/pom.xml |   65 +-
 .../src/main/resources/log4j.properties            |   23 -
 .../src/main/resources/log4j2.properties           |   25 +
 flink-quickstart/flink-quickstart-scala/pom.xml    |    2 +-
 .../src/main/resources/archetype-resources/pom.xml |   69 +-
 .../src/main/resources/log4j.properties            |   23 -
 .../src/main/resources/log4j2.properties           |   25 +
 flink-quickstart/pom.xml                           |    2 +-
 flink-runtime-web/README.md                        |    4 +-
 flink-runtime-web/pom.xml                          |   39 +-
 .../runtime/webmonitor/PipelineErrorHandler.java   |    2 +-
 .../runtime/webmonitor/WebSubmissionExtension.java |    9 +-
 .../webmonitor/handlers/JarListHandler.java        |   11 +-
 .../webmonitor/handlers/JarPlanHandler.java        |    2 +-
 .../runtime/webmonitor/handlers/JarRunHandler.java |   67 +-
 .../webmonitor/handlers/utils/JarHandlerUtils.java |   49 +-
 .../runtime/webmonitor/history/HistoryServer.java  |   24 +-
 .../history/HistoryServerArchiveFetcher.java       |   20 +-
 .../HistoryServerStaticFileServerHandler.java      |   53 +-
 .../src/main/resources/META-INF/NOTICE             |   45 +-
 .../resources/META-INF/licenses/LICENSE.@angular   |   21 -
 .../resources/META-INF/licenses/LICENSE.angular    |   22 -
 .../licenses/LICENSE.angular-drag-and-drop-list    |   22 -
 .../META-INF/licenses/LICENSE.angular-moment       |   21 -
 .../META-INF/licenses/LICENSE.angular-ui-router    |   21 -
 .../META-INF/licenses/LICENSE.ant-design-palettes  |   22 -
 .../resources/META-INF/licenses/LICENSE.bootstrap  |   21 -
 .../resources/META-INF/licenses/LICENSE.core-js    |   21 -
 .../main/resources/META-INF/licenses/LICENSE.d3    |   27 -
 .../main/resources/META-INF/licenses/LICENSE.dagre |   19 -
 .../resources/META-INF/licenses/LICENSE.dagre-d3   |   19 -
 .../resources/META-INF/licenses/LICENSE.ev-emitter |    7 -
 .../META-INF/licenses/LICENSE.font-awesome         |   97 -
 .../resources/META-INF/licenses/LICENSE.graphlib   |   19 -
 .../META-INF/licenses/LICENSE.imagesloaded         |    7 -
 .../resources/META-INF/licenses/LICENSE.jquery     |   20 -
 .../resources/META-INF/licenses/LICENSE.lodash     |   10 -
 .../resources/META-INF/licenses/LICENSE.moment     |   22 -
 .../licenses/LICENSE.moment-duration-format        |   21 -
 .../META-INF/licenses/LICENSE.monaco-editor        |    9 -
 .../META-INF/licenses/LICENSE.ng-zorro-antd        |   22 -
 .../main/resources/META-INF/licenses/LICENSE.qtip2 |   22 -
 .../main/resources/META-INF/licenses/LICENSE.rxjs  |  201 -
 .../main/resources/META-INF/licenses/LICENSE.split |   32 -
 .../resources/META-INF/licenses/LICENSE.tinycolor2 |   21 -
 .../main/resources/META-INF/licenses/LICENSE.tslib |   57 -
 .../main/resources/META-INF/licenses/LICENSE.zone  |   21 -
 .../runtime/webmonitor/WebFrontendITCase.java      |   38 +-
 .../handlers/JarHandlerParameterTest.java          |    3 +-
 .../webmonitor/handlers/JarHandlerTest.java        |   84 +
 .../runtime/webmonitor/handlers/JarHandlers.java   |  157 +
 .../handlers/JarRunHandlerParameterTest.java       |   29 +-
 .../webmonitor/handlers/JarRunHandlerTest.java     |  114 -
 .../webmonitor/handlers/JarSubmissionITCase.java   |  133 +-
 .../handlers/utils/OutputTestProgram.java          |   29 +
 .../webmonitor/handlers/utils/TestProgram.java     |    4 +-
 .../HistoryServerStaticFileServerHandlerTest.java  |   28 +-
 .../webmonitor/history/HistoryServerTest.java      |   37 +-
 .../webmonitor/testutils/ParameterProgram.java     |    4 +-
 .../src/test/resources/log4j-test.properties       |   38 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../src/test/resources/rest_api_v1.snapshot        |  330 +-
 flink-runtime-web/web-dashboard/angular.json       |    5 -
 .../web-dashboard/old-version/css/index.css        |    1 -
 .../web-dashboard/old-version/css/vendor.css       |    4 -
 .../old-version/fonts/FontAwesome.otf              |  Bin 109688 -> 0 bytes
 .../old-version/fonts/fontawesome-webfont.eot      |  Bin 70807 -> 0 bytes
 .../old-version/fonts/fontawesome-webfont.svg      |  655 --
 .../old-version/fonts/fontawesome-webfont.ttf      |  Bin 142072 -> 0 bytes
 .../old-version/fonts/fontawesome-webfont.woff     |  Bin 83588 -> 0 bytes
 .../old-version/fonts/fontawesome-webfont.woff2    |  Bin 66624 -> 0 bytes
 .../old-version/images/android-chrome-192x192.png  |  Bin 45695 -> 0 bytes
 .../old-version/images/android-chrome-512x512.png  |  Bin 163667 -> 0 bytes
 .../old-version/images/apple-touch-icon.png        |  Bin 31358 -> 0 bytes
 .../old-version/images/browserconfig.xml           |   31 -
 .../old-version/images/favicon-16x16.png           |  Bin 1444 -> 0 bytes
 .../old-version/images/favicon-32x32.png           |  Bin 3107 -> 0 bytes
 .../web-dashboard/old-version/images/favicon.ico   |  Bin 15086 -> 0 bytes
 .../old-version/images/flink-logo.png              |  Bin 6096 -> 0 bytes
 .../old-version/images/grips/horizontal.png        |  Bin 2753 -> 0 bytes
 .../old-version/images/grips/vertical.png          |  Bin 91 -> 0 bytes
 .../web-dashboard/old-version/images/manifest.json |   17 -
 .../old-version/images/mstile-144x144.png          |  Bin 30245 -> 0 bytes
 .../old-version/images/mstile-150x150.png          |  Bin 26238 -> 0 bytes
 .../old-version/images/mstile-310x150.png          |  Bin 27184 -> 0 bytes
 .../old-version/images/mstile-310x310.png          |  Bin 73125 -> 0 bytes
 .../old-version/images/mstile-70x70.png            |  Bin 16371 -> 0 bytes
 .../old-version/images/safari-pinned-tab.svg       |  221 -
 .../web-dashboard/old-version/index.html           |   65 -
 .../web-dashboard/old-version/index_hs.html        |   55 -
 .../web-dashboard/old-version/js/hs/index.js       |    2 -
 .../web-dashboard/old-version/js/index.js          |    2 -
 .../web-dashboard/old-version/js/vendor.js         |   30 -
 .../old-version/partials/jobmanager/config.html    |   33 -
 .../old-version/partials/jobmanager/index.html     |   33 -
 .../old-version/partials/jobmanager/log.html       |   39 -
 .../old-version/partials/jobmanager/stdout.html    |   40 -
 .../old-version/partials/jobs/completed-jobs.html  |   53 -
 .../old-version/partials/jobs/job.config.html      |   57 -
 .../old-version/partials/jobs/job.exceptions.html  |   45 -
 .../old-version/partials/jobs/job.html             |   60 -
 .../old-version/partials/jobs/job.plan.html        |   41 -
 .../jobs/job.plan.node-list.accumulators.html      |   40 -
 .../jobs/job.plan.node-list.backpressure.html      |   80 -
 .../jobs/job.plan.node-list.checkpoints.html       |   31 -
 .../partials/jobs/job.plan.node-list.metrics.html  |   49 -
 .../partials/jobs/job.plan.node-list.subtasks.html |   67 -
 .../jobs/job.plan.node-list.watermarks.html        |   45 -
 .../partials/jobs/job.plan.node.accumulators.html  |   68 -
 .../jobs/job.plan.node.checkpoint-history.html     |   57 -
 .../jobs/job.plan.node.checkpoints.config.html     |   59 -
 .../jobs/job.plan.node.checkpoints.counts.html     |   51 -
 .../jobs/job.plan.node.checkpoints.details.html    |  171 -
 .../jobs/job.plan.node.checkpoints.history.html    |   65 -
 .../partials/jobs/job.plan.node.checkpoints.html   |   22 -
 .../jobs/job.plan.node.checkpoints.job.html        |  105 -
 .../jobs/job.plan.node.checkpoints.operator.html   |   61 -
 .../jobs/job.plan.node.checkpoints.overview.html   |   49 -
 .../jobs/job.plan.node.checkpoints.statistics.html |   56 -
 .../jobs/job.plan.node.checkpoints.summary.html    |   53 -
 .../partials/jobs/job.plan.node.subtasks.html      |   52 -
 .../partials/jobs/job.plan.node.taskmanagers.html  |   55 -
 .../partials/jobs/job.plan.node.watermarks.html    |   33 -
 .../old-version/partials/jobs/job.properties.html  |  140 -
 .../old-version/partials/jobs/job.timeline.html    |   23 -
 .../partials/jobs/job.timeline.vertex.html         |   30 -
 .../old-version/partials/jobs/running-jobs.html    |   53 -
 .../old-version/partials/overview.html             |  149 -
 .../web-dashboard/old-version/partials/submit.html |  114 -
 .../old-version/partials/taskmanager/index.html    |   57 -
 .../partials/taskmanager/taskmanager.html          |   35 -
 .../partials/taskmanager/taskmanager.log.html      |   39 -
 .../partials/taskmanager/taskmanager.metrics.html  |  140 -
 .../partials/taskmanager/taskmanager.stdout.html   |   39 -
 .../web-dashboard/src/app/app-routing.module.ts    |    2 +-
 .../web-dashboard/src/app/app.component.html       |    4 -
 .../web-dashboard/src/app/app.component.ts         |   29 +-
 .../web-dashboard/src/app/app.config.ts            |    3 +-
 .../web-dashboard/src/app/app.module.ts            |    2 -
 .../src/app/interfaces/job-checkpoint.ts           |    1 +
 .../src/app/interfaces/task-manager.ts             |   13 +
 .../job-manager-configuration.component.html       |    2 +-
 .../job-manager/job-manager-routing.module.ts      |   16 +
 .../app/pages/job-manager/job-manager.component.ts |    3 +-
 .../app/pages/job-manager/job-manager.module.ts    |    4 +
 .../job-manager-log-detail.component.html          |   36 +
 .../job-manager-log-detail.component.less          |   54 +
 .../log-detail/job-manager-log-detail.component.ts |   78 +
 .../log-list/job-manager-log-list.component.html   |   41 +
 .../log-list/job-manager-log-list.component.ts     |   47 +
 .../logs/job-manager-logs.component.html           |    2 +-
 .../stdout/job-manager-stdout.component.html       |    2 +-
 .../detail/job-checkpoints-detail.component.html   |    2 +-
 .../job/checkpoints/job-checkpoints.component.html |    8 +-
 .../subtask/job-checkpoints-subtask.component.html |   26 +-
 .../job/exceptions/job-exceptions.component.html   |    5 +
 .../job/exceptions/job-exceptions.component.ts     |   26 +-
 ...job-overview-drawer-accumulators.component.html |    2 +-
 .../drawer/job-overview-drawer.component.ts        |   10 +-
 .../pages/job/overview/job-overview.component.ts   |   27 +-
 .../job-overview-drawer-watermarks.component.ts    |    2 +-
 .../task-manager-log-detail.component.html         |   36 +
 .../task-manager-log-detail.component.less         |   60 +
 .../task-manager-log-detail.component.ts           |   83 +
 .../log-list/task-manager-log-list.component.html  |   39 +
 .../log-list/task-manager-log-list.component.ts    |   50 +
 .../logs/task-manager-logs.component.html          |    2 +-
 .../status/task-manager-status.component.ts        |    4 +-
 .../stdout/task-manager-stdout.component.html      |    2 +-
 .../task-manager/task-manager-routing.module.ts    |   24 +
 .../app/pages/task-manager/task-manager.module.ts  |    6 +
 .../task-manager-thread-dump.component.html        |   20 +
 .../task-manager-thread-dump.component.less}       |    0
 .../task-manager-thread-dump.component.ts          |   57 +
 .../src/app/services/job-manager.service.ts        |   39 +-
 .../web-dashboard/src/app/services/job.service.ts  |    7 +-
 .../src/app/services/metrics.service.ts            |   53 +-
 .../src/app/services/task-manager.service.ts       |   61 +-
 .../common/navigation/navigation.component.ts      |   28 +-
 .../app/share/common/resize/resize.component.ts    |    2 +-
 .../customize/job-chart/job-chart.component.html   |    2 +-
 .../customize/job-chart/job-chart.component.less   |    2 +-
 .../customize/job-chart/job-chart.component.ts     |   15 +-
 .../share/customize/job-chart/job-chart.service.ts |   28 +
 .../refresh-download.component.html                |   21 +-
 .../refresh-download.component.less                |    4 +
 .../refresh-download/refresh-download.component.ts |    9 +
 flink-runtime/pom.xml                              |  103 +-
 .../org/apache/flink/runtime/OperatorIDPair.java   |   58 +
 .../runtime/akka/EscalatingSupervisorStrategy.java |   40 +
 ...WithoutLoggingActorKilledExceptionStrategy.java |   53 -
 .../flink/runtime/blob/AbstractBlobCache.java      |    4 +
 .../org/apache/flink/runtime/blob/BlobServer.java  |   10 +-
 .../checkpoint/AbstractCheckpointStats.java        |   10 +-
 .../runtime/checkpoint/CheckpointCoordinator.java  | 1105 ++--
 .../CheckpointCoordinatorDeActivator.java          |    2 +-
 .../checkpoint/CheckpointCoordinatorGateway.java   |    3 +
 .../checkpoint/CheckpointFailureManager.java       |    9 +-
 .../checkpoint/CheckpointFailureReason.java        |   10 +-
 .../runtime/checkpoint/CheckpointIDCounter.java    |    2 +-
 .../runtime/checkpoint/CheckpointMetaData.java     |    4 +-
 .../runtime/checkpoint/CheckpointMetrics.java      |   62 +-
 .../runtime/checkpoint/CheckpointOptions.java      |   57 +-
 .../runtime/checkpoint/CheckpointProperties.java   |   28 +-
 .../checkpoint/CheckpointRequestDecider.java       |  209 +
 .../checkpoint/CheckpointRetentionPolicy.java      |    2 +-
 .../runtime/checkpoint/CheckpointStatsHistory.java |   10 +-
 .../checkpoint/CheckpointStatsSnapshot.java        |    2 +-
 .../runtime/checkpoint/CheckpointStatsTracker.java |   16 -
 .../flink/runtime/checkpoint/Checkpoints.java      |   94 +-
 .../runtime/checkpoint/CompletedCheckpoint.java    |    2 +-
 .../checkpoint/CompletedCheckpointStats.java       |   11 -
 .../CompletedCheckpointStatsSummary.java           |   25 +-
 .../checkpoint/CompletedCheckpointStore.java       |   12 +-
 .../DefaultLastStateConnectionStateListener.java   |   45 +
 .../runtime/checkpoint/FailedCheckpointStats.java  |   12 +-
 .../LastStateConnectionStateListener.java          |   37 +
 .../OperatorCoordinatorCheckpointContext.java      |   41 +
 .../checkpoint/OperatorCoordinatorCheckpoints.java |  147 +
 .../flink/runtime/checkpoint/OperatorState.java    |   50 +-
 .../checkpoint/OperatorStateRepartitioner.java     |    7 +-
 .../runtime/checkpoint/OperatorSubtaskState.java   |   81 +-
 .../runtime/checkpoint/PendingCheckpoint.java      |  117 +-
 .../runtime/checkpoint/PendingCheckpointStats.java |   18 +-
 .../PrioritizedOperatorSubtaskState.java           |   70 +-
 .../RoundRobinOperatorStateRepartitioner.java      |    4 +-
 .../checkpoint/StandaloneCheckpointIDCounter.java  |    2 +-
 .../StandaloneCompletedCheckpointStore.java        |    2 +-
 .../checkpoint/StateAssignmentOperation.java       |  268 +-
 .../runtime/checkpoint/StateObjectCollection.java  |    5 +
 .../flink/runtime/checkpoint/SubtaskState.java     |    4 +-
 .../runtime/checkpoint/SubtaskStateStats.java      |   67 +-
 .../apache/flink/runtime/checkpoint/TaskState.java |   11 +-
 .../flink/runtime/checkpoint/TaskStateStats.java   |   92 +-
 .../checkpoint/ZooKeeperCheckpointIDCounter.java   |   71 +-
 .../ZooKeeperCheckpointRecoveryFactory.java        |    3 +-
 .../ZooKeeperCompletedCheckpointStore.java         |    7 +-
 .../channel/ChannelStateCheckpointWriter.java      |  235 +
 .../checkpoint/channel/ChannelStateReader.java     |   77 +
 .../checkpoint/channel/ChannelStateReaderImpl.java |  124 +
 .../checkpoint/channel/ChannelStateSerializer.java |  212 +
 .../channel/ChannelStateStreamReader.java          |  111 +
 .../channel/ChannelStateWriteRequest.java          |  195 +
 .../ChannelStateWriteRequestDispatcher.java        |   36 +
 .../ChannelStateWriteRequestDispatcherImpl.java    |   99 +
 .../channel/ChannelStateWriteRequestExecutor.java  |   49 +
 .../ChannelStateWriteRequestExecutorImpl.java      |  170 +
 .../checkpoint/channel/ChannelStateWriter.java     |  191 +
 .../checkpoint/channel/ChannelStateWriterImpl.java |  203 +
 .../checkpoint/channel/InputChannelInfo.java       |   71 +
 .../channel/RefCountingFSDataInputStream.java      |  129 +
 .../checkpoint/channel/ResultSubpartitionInfo.java |   72 +
 .../runtime/checkpoint/hooks/MasterHooks.java      |   13 +-
 .../metadata/ChannelStateHandleSerializer.java     |  106 +
 .../checkpoint/metadata/CheckpointMetadata.java    |   74 +
 .../checkpoint/metadata/MetadataSerializer.java    |   44 +
 .../checkpoint/metadata/MetadataSerializers.java   |   63 +
 .../checkpoint/metadata/MetadataV1Serializer.java  |   50 +
 .../checkpoint/metadata/MetadataV2Serializer.java  |  145 +
 .../metadata/MetadataV2V3SerializerBase.java       |  632 ++
 .../checkpoint/metadata/MetadataV3Serializer.java  |  234 +
 .../runtime/checkpoint/savepoint/Savepoint.java    |   78 -
 .../checkpoint/savepoint/SavepointSerializer.java  |   57 -
 .../checkpoint/savepoint/SavepointSerializers.java |   92 -
 .../runtime/checkpoint/savepoint/SavepointV1.java  |   87 -
 .../savepoint/SavepointV1Serializer.java           |  366 --
 .../runtime/checkpoint/savepoint/SavepointV2.java  |  255 -
 .../savepoint/SavepointV2Serializer.java           |  548 --
 .../apache/flink/runtime/client/ClientUtils.java   |    2 +-
 .../runtime/client/JobExecutionException.java      |    3 +-
 .../runtime/client/JobRetrievalException.java      |   42 -
 .../flink/runtime/client/JobStatusMessage.java     |    2 +-
 .../flink/runtime/client/JobTimeoutException.java  |   33 -
 .../clusterframework/ApplicationStatus.java        |    2 +-
 .../runtime/clusterframework/BootstrapTools.java   |  342 +-
 .../ContaineredTaskManagerParameters.java          |  104 +-
 .../clusterframework/TaskExecutorProcessSpec.java  |  158 +
 .../TaskExecutorProcessSpecBuilder.java            |   60 +
 .../clusterframework/TaskExecutorProcessUtils.java |  175 +
 .../clusterframework/TaskExecutorResourceSpec.java |  158 -
 .../TaskExecutorResourceUtils.java                 |  610 --
 .../overlays/FlinkDistributionOverlay.java         |   13 +-
 .../clusterframework/overlays/UserLibOverlay.java  |   72 +
 .../types/ResourceBudgetManager.java               |   76 +
 .../clusterframework/types/ResourceProfile.java    |  418 +-
 .../runtime/clusterframework/types/SlotID.java     |   14 +-
 .../clusterframework/types/SlotProfile.java        |  110 +-
 .../concurrent/FutureTaskWithException.java        |   39 +
 .../flink/runtime/concurrent/FutureUtils.java      |   77 +-
 .../ResultPartitionDeploymentDescriptor.java       |    4 +
 .../deployment/TaskDeploymentDescriptor.java       |   14 +-
 .../dispatcher/AbstractDispatcherBootstrap.java    |   46 +
 .../dispatcher/DefaultDispatcherBootstrap.java     |   53 +
 .../dispatcher/DefaultJobManagerRunnerFactory.java |    4 +-
 .../flink/runtime/dispatcher/Dispatcher.java       |   87 +-
 .../runtime/dispatcher/DispatcherBootstrap.java    |   45 +
 .../runtime/dispatcher/DispatcherFactory.java      |   14 +-
 .../runtime/dispatcher/DispatcherGateway.java      |    5 +
 .../runtime/dispatcher/DispatcherRestEndpoint.java |    7 +-
 .../runtime/dispatcher/DispatcherServices.java     |    7 +-
 .../FileArchivedExecutionGraphStore.java           |    2 +-
 .../runtime/dispatcher/HistoryServerArchivist.java |    5 +-
 .../runtime/dispatcher/JobDispatcherFactory.java   |   12 +-
 .../JsonResponseHistoryServerArchivist.java        |   21 +-
 .../MemoryArchivedExecutionGraphStore.java         |    2 +-
 .../flink/runtime/dispatcher/MiniDispatcher.java   |   27 +-
 .../dispatcher/PartialDispatcherServices.java      |    7 +-
 ...PartialDispatcherServicesWithJobGraphStore.java |    3 +-
 .../dispatcher/SchedulerNGFactoryFactory.java      |   12 +-
 .../dispatcher/SessionDispatcherFactory.java       |    8 +-
 .../runtime/dispatcher/StandaloneDispatcher.java   |    8 +-
 .../runner/AbstractDispatcherLeaderProcess.java    |   20 +-
 .../runner/DefaultDispatcherGatewayService.java    |    7 +-
 .../DefaultDispatcherGatewayServiceFactory.java    |    8 +-
 .../runner/DefaultDispatcherRunnerFactory.java     |    2 +-
 .../DispatcherLeaderProcessFactoryFactory.java     |    2 +
 .../SessionDispatcherLeaderProcessFactory.java     |    6 +-
 .../ClusterConfigurationParserFactory.java         |    8 +-
 .../ClusterEntryPointExceptionUtils.java           |   68 +
 .../runtime/entrypoint/ClusterEntrypoint.java      |   53 +-
 .../StandaloneSessionClusterEntrypoint.java        |    2 +-
 .../AbstractUserClassPathJobGraphRetriever.java    |    2 +
 ...tDispatcherResourceManagerComponentFactory.java |   18 +-
 .../component/FileJobGraphRetriever.java           |   33 +-
 .../flink/runtime/execution/Environment.java       |   20 +-
 .../librarycache/BlobLibraryCacheManager.java      |  428 +-
 .../librarycache/FlinkUserCodeClassLoaders.java    |   42 +-
 .../librarycache/LibraryCacheManager.java          |  120 +-
 .../executiongraph/AccessExecutionGraph.java       |   10 +-
 .../executiongraph/ArchivedExecutionGraph.java     |   18 +-
 .../flink/runtime/executiongraph/Execution.java    |  192 +-
 .../ExecutionAndAllocationFuture.java              |   45 -
 .../runtime/executiongraph/ExecutionGraph.java     |   66 +-
 .../runtime/executiongraph/ExecutionJobVertex.java |  125 +-
 .../runtime/executiongraph/ExecutionVertex.java    |   61 +-
 .../IntermediateResultPartition.java               |    2 +-
 .../runtime/executiongraph/JobStatusListener.java  |    2 +-
 .../runtime/executiongraph/SchedulingUtils.java    |    2 +-
 .../runtime/executiongraph/TaskInformation.java    |   24 +-
 .../AdaptedRestartPipelinedRegionStrategyNG.java   |  320 -
 .../failover/FailoverStrategyLoader.java           |   26 +-
 .../failover/RestartIndividualStrategy.java        |  151 -
 .../failover/flip1/ExecutionFailureHandler.java    |   31 +-
 .../failover/flip1/FailoverRegion.java             |   67 -
 .../failover/flip1/FailoverResultPartition.java    |   30 -
 .../failover/flip1/FailoverStrategy.java           |    3 +-
 .../flip1/FailoverStrategyFactoryLoader.java       |   63 +
 .../failover/flip1/FailoverTopology.java           |   29 -
 .../failover/flip1/FailoverVertex.java             |   30 -
 .../failover/flip1/FailureHandlingResult.java      |   34 +-
 .../FailureRateRestartBackoffTimeStrategy.java     |   28 +-
 .../FixedDelayRestartBackoffTimeStrategy.java      |   12 +-
 .../failover/flip1/PipelinedRegionComputeUtil.java |   28 +-
 .../failover/flip1/RestartAllFailoverStrategy.java |   68 +
 .../RestartBackoffTimeStrategyFactoryLoader.java   |    2 +-
 .../RestartPipelinedRegionFailoverStrategy.java    |  247 +
 .../flip1/RestartPipelinedRegionStrategy.java      |  277 -
 .../NotReleasingPartitionReleaseStrategy.java      |    2 +-
 .../partitionrelease/PartitionReleaseStrategy.java |    2 +-
 .../flip1/partitionrelease/PipelinedRegion.java    |   69 -
 .../PipelinedRegionConsumedBlockingPartitions.java |   51 -
 .../PipelinedRegionExecutionView.java              |   24 +-
 .../RegionPartitionReleaseStrategy.java            |  103 +-
 .../executiongraph/metrics/DownTimeGauge.java      |    4 +-
 .../executiongraph/metrics/RestartTimeGauge.java   |    4 +-
 .../executiongraph/metrics/UpTimeGauge.java        |    4 +-
 .../restart/FailureRateRestartStrategy.java        |   17 +-
 .../restart/FixedDelayRestartStrategy.java         |   14 +-
 .../ExternalResourceInfoProvider.java              |   40 +
 .../externalresource/ExternalResourceUtils.java    |  213 +
 .../StaticExternalResourceInfoProvider.java        |   53 +
 .../apache/flink/runtime/filecache/FileCache.java  |    7 +-
 .../HighAvailabilityServicesUtils.java             |   14 +-
 .../nonha/standalone/StandaloneHaServices.java     |   16 +-
 .../zookeeper/ZooKeeperClientHAServices.java       |    2 +-
 .../zookeeper/ZooKeeperHaServices.java             |    7 +-
 .../zookeeper/ZooKeeperRunningJobsRegistry.java    |   10 +-
 .../flink/runtime/io/AvailabilityProvider.java     |   67 +-
 .../flink/runtime/io/PullingAsyncDataInput.java    |    4 +-
 .../io/compression/BlockCompressionFactory.java    |   87 +
 .../runtime/io/compression/BlockCompressor.java    |   66 +
 .../runtime/io/compression/BlockDecompressor.java  |   64 +
 .../io/compression/DataCorruptionException.java    |   42 +
 .../compression/InsufficientBufferException.java   |   43 +
 .../io/compression/Lz4BlockCompressionFactory.java |   42 +
 .../runtime/io/compression/Lz4BlockCompressor.java |  108 +
 .../io/compression/Lz4BlockDecompressor.java       |  128 +
 .../runtime/io/disk/FileBasedBufferIterator.java   |   90 +
 .../runtime/io/disk/FileChannelManagerImpl.java    |   34 +
 .../io/disk/iomanager/BufferFileChannelReader.java |    5 +-
 .../io/network/NettyShuffleEnvironment.java        |   46 +-
 .../io/network/NettyShuffleServiceFactory.java     |   40 +-
 .../runtime/io/network/NetworkClientHandler.java   |   12 +
 .../io/network/NetworkSequenceViewReader.java      |    7 +-
 .../runtime/io/network/PartitionRequestClient.java |    7 +
 .../runtime/io/network/api/CheckpointBarrier.java  |    4 +
 .../network/api/reader/AbstractRecordReader.java   |   32 +-
 .../network/api/serialization/EventSerializer.java |   26 +-
 .../api/serialization/NonSpanningWrapper.java      |  359 ++
 .../api/serialization/RecordDeserializer.java      |    9 +
 .../network/api/serialization/SpanningWrapper.java |  324 +
 ...SpillingAdaptiveSpanningRecordDeserializer.java |  604 +-
 .../network/api/writer/BroadcastRecordWriter.java  |   10 +-
 .../api/writer/ChannelSelectorRecordWriter.java    |    4 +-
 .../network/api/writer/MultipleRecordWriters.java  |   96 +
 .../io/network/api/writer/NonRecordWriter.java     |   57 +
 .../io/network/api/writer/RecordWriter.java        |   49 +-
 .../network/api/writer/RecordWriterDelegate.java   |   46 +
 .../network/api/writer/ResultPartitionWriter.java  |   52 +-
 .../io/network/api/writer/SingleRecordWriter.java  |   67 +
 .../flink/runtime/io/network/buffer/Buffer.java    |   77 +-
 .../runtime/io/network/buffer/BufferBuilder.java   |   26 +-
 .../io/network/buffer/BufferCompressor.java        |  116 +
 .../runtime/io/network/buffer/BufferConsumer.java  |   24 +-
 .../io/network/buffer/BufferDecompressor.java      |  104 +
 .../runtime/io/network/buffer/BufferPool.java      |    2 +
 .../io/network/buffer/BufferPoolFactory.java       |   13 +-
 .../runtime/io/network/buffer/BufferProvider.java  |   33 +-
 .../io/network/buffer/BufferReceivedListener.java  |   47 +
 .../runtime/io/network/buffer/LocalBufferPool.java |  172 +-
 .../runtime/io/network/buffer/NetworkBuffer.java   |   78 +-
 .../io/network/buffer/NetworkBufferPool.java       |   53 +-
 .../buffer/ReadOnlySlicedNetworkBuffer.java        |   36 +-
 .../network/metrics/InputBufferPoolUsageGauge.java |   52 -
 .../network/metrics/NettyShuffleMetricFactory.java |   28 +-
 .../io/network/netty/BufferResponseDecoder.java    |  119 +
 .../runtime/io/network/netty/ByteBufUtils.java     |   64 +
 .../CreditBasedPartitionRequestClientHandler.java  |  135 +-
 .../CreditBasedSequenceNumberingViewReader.java    |   20 +-
 .../runtime/io/network/netty/NettyBufferPool.java  |   14 +-
 .../runtime/io/network/netty/NettyConfig.java      |   11 +-
 .../io/network/netty/NettyConnectionManager.java   |    5 +-
 .../runtime/io/network/netty/NettyMessage.java     |  221 +-
 .../netty/NettyMessageClientDecoderDelegate.java   |  153 +
 .../io/network/netty/NettyMessageDecoder.java      |   92 +
 .../network/netty/NettyPartitionRequestClient.java |    5 +
 .../runtime/io/network/netty/NettyProtocol.java    |   20 +-
 .../runtime/io/network/netty/NettyServer.java      |   14 -
 .../io/network/netty/NetworkBufferAllocator.java   |   78 +
 .../io/network/netty/NonBufferResponseDecoder.java |   85 +
 .../netty/PartitionRequestClientHandler.java       |  508 --
 .../io/network/netty/PartitionRequestQueue.java    |   13 +-
 .../netty/PartitionRequestServerHandler.java       |   27 +-
 .../network/netty/SequenceNumberingViewReader.java |  149 -
 .../partition/BoundedBlockingSubpartition.java     |   18 +-
 .../BoundedBlockingSubpartitionReader.java         |   14 +-
 .../partition/BufferAvailabilityListener.java      |   13 +
 .../network/partition/BufferReaderWriterUtil.java  |   49 +-
 .../network/partition/ClusterPartitionManager.java |   44 +
 .../io/network/partition/DataSetMetaInfo.java      |   58 +
 .../partition/NoOpResultSubpartitionView.java      |    9 +-
 .../network/partition/PipelinedSubpartition.java   |  147 +-
 .../partition/PipelinedSubpartitionView.java       |   20 +-
 .../ReleaseOnConsumptionResultPartition.java       |   16 +-
 .../partition/ResourceManagerPartitionTracker.java |   67 +
 .../ResourceManagerPartitionTrackerFactory.java    |   26 +
 .../ResourceManagerPartitionTrackerImpl.java       |  246 +
 .../io/network/partition/ResultPartition.java      |   52 +-
 .../network/partition/ResultPartitionFactory.java  |   50 +-
 .../io/network/partition/ResultSubpartition.java   |   72 +-
 .../network/partition/ResultSubpartitionView.java  |   11 +-
 .../TaskExecutorClusterPartitionReleaser.java      |   31 +
 .../partition/TaskExecutorPartitionInfo.java       |   29 +-
 .../partition/TaskExecutorPartitionTracker.java    |   17 +-
 .../TaskExecutorPartitionTrackerImpl.java          |   86 +-
 .../network/partition/consumer/BufferManager.java  |  412 ++
 .../network/partition/consumer/BufferOrEvent.java  |   35 +-
 .../partition/consumer/EndOfChannelStateEvent.java |   66 +
 .../partition/consumer/IndexedInputGate.java       |   28 +
 .../network/partition/consumer/InputChannel.java   |   60 +-
 .../io/network/partition/consumer/InputGate.java   |   46 +-
 .../partition/consumer/LocalInputChannel.java      |   85 +-
 .../consumer/LocalRecoveredInputChannel.java       |   65 +
 .../partition/consumer/RecoveredInputChannel.java  |  218 +
 .../partition/consumer/RemoteInputChannel.java     |  380 +-
 .../consumer/RemoteRecoveredInputChannel.java      |   79 +
 .../partition/consumer/SingleInputGate.java        |  260 +-
 .../partition/consumer/SingleInputGateFactory.java |   72 +-
 .../network/partition/consumer/UnionInputGate.java |  134 +-
 .../partition/consumer/UnknownInputChannel.java    |   38 +-
 .../iterative/task/AbstractIterativeTask.java      |    9 +-
 .../runtime/jobgraph/InputOutputFormatVertex.java  |    7 +-
 .../runtime/jobgraph/IntermediateDataSetID.java    |   17 +
 .../jobgraph/IntermediateResultPartitionID.java    |   54 +-
 .../apache/flink/runtime/jobgraph/JobGraph.java    |    9 +
 .../flink/runtime/jobgraph/JobGraphUtils.java      |   71 +
 .../apache/flink/runtime/jobgraph/JobStatus.java   |  102 -
 .../apache/flink/runtime/jobgraph/JobVertex.java   |  143 +-
 .../runtime/jobgraph/tasks/AbstractInvokable.java  |   59 +-
 .../tasks/CheckpointCoordinatorConfiguration.java  |  121 +
 .../jobgraph/tasks/TaskOperatorEventGateway.java   |   49 +
 .../topology/DefaultLogicalPipelinedRegion.java    |   54 +
 .../jobgraph/topology/DefaultLogicalTopology.java  |    6 +-
 .../jobgraph/topology/LogicalPipelinedRegion.java  |   33 +-
 .../runtime/jobgraph/topology/LogicalTopology.java |    2 +-
 .../runtime/jobmanager/JobManagerProcessSpec.java  |   73 +
 .../runtime/jobmanager/JobManagerProcessUtils.java |   96 +
 .../runtime/jobmanager/ZooKeeperJobGraphStore.java |   13 +-
 .../jobmanager/scheduler/ScheduledUnit.java        |   56 +-
 .../jobmanager/scheduler/SlotSharingGroup.java     |   48 +-
 .../jobmanager/slots/TaskManagerGateway.java       |   52 +-
 .../runtime/jobmaster/JobManagerRunnerImpl.java    |   63 +-
 .../jobmaster/JobManagerSharedServices.java        |   52 +-
 .../apache/flink/runtime/jobmaster/JobMaster.java  |   52 +-
 .../flink/runtime/jobmaster/JobMasterGateway.java  |   30 +-
 .../jobmaster/JobMasterOperatorEventGateway.java   |   52 +
 .../runtime/jobmaster/JobNotFinishedException.java |    2 +-
 .../apache/flink/runtime/jobmaster/JobResult.java  |   10 +-
 .../jobmaster/MiniDispatcherRestEndpoint.java      |    7 +-
 .../runtime/jobmaster/RpcTaskManagerGateway.java   |   33 +-
 .../apache/flink/runtime/jobmaster/SlotInfo.java   |    7 +
 .../runtime/jobmaster/slotpool/AllocatedSlot.java  |   23 +-
 .../jobmaster/slotpool/BulkSlotProvider.java       |   60 +
 .../jobmaster/slotpool/BulkSlotProviderImpl.java   |  213 +
 .../jobmaster/slotpool/DefaultSlotPoolFactory.java |    4 +-
 .../jobmaster/slotpool/DualKeyLinkedMap.java       |   80 +-
 .../LocationPreferenceSlotSelectionStrategy.java   |    4 +-
 .../runtime/jobmaster/slotpool/PhysicalSlot.java   |    9 +-
 .../jobmaster/slotpool/PhysicalSlotRequest.java    |   79 +
 .../slotpool/PhysicalSlotRequestBulk.java          |   79 +
 .../slotpool/PhysicalSlotRequestBulkChecker.java   |  148 +
 .../runtime/jobmaster/slotpool/SchedulerImpl.java  |   77 +-
 .../SharedSlotOversubscribedException.java         |   40 -
 .../jobmaster/slotpool/SingleLogicalSlot.java      |   46 +-
 .../slotpool/SlotInfoWithUtilization.java          |    5 +
 .../flink/runtime/jobmaster/slotpool/SlotPool.java |   18 +-
 .../runtime/jobmaster/slotpool/SlotPoolImpl.java   |  181 +-
 .../runtime/jobmaster/slotpool/SlotProvider.java   |   38 +-
 .../jobmaster/slotpool/SlotSharingManager.java     |  121 +-
 .../jobmaster/slotpool/ThrowingSlotProvider.java   |   47 +
 .../ZooKeeperLeaderElectionService.java            |   25 +-
 .../ZooKeeperLeaderRetrievalService.java           |   15 +-
 .../apache/flink/runtime/memory/MemoryManager.java |  519 +-
 .../flink/runtime/memory/OpaqueMemoryResource.java |   80 +
 .../flink/runtime/memory/SharedResources.java      |  189 +
 .../flink/runtime/memory/UnsafeMemoryBudget.java   |  183 +
 .../runtime/messages/StackTraceSampleResponse.java |   60 -
 .../runtime/messages/TaskBackPressureResponse.java |   59 +
 .../runtime/messages/webmonitor/JobDetails.java    |    2 +-
 .../webmonitor/JobIdsWithStatusOverview.java       |    2 +-
 .../runtime/messages/webmonitor/JobsOverview.java  |    2 +-
 .../apache/flink/runtime/metrics/MetricNames.java  |   16 +
 .../flink/runtime/metrics/MetricRegistry.java      |    8 -
 .../flink/runtime/metrics/MetricRegistryImpl.java  |  112 +-
 .../flink/runtime/metrics/NoOpMetricRegistry.java  |    7 +-
 .../flink/runtime/metrics/ReporterSetup.java       |  124 +-
 .../metrics/groups/AbstractMetricGroup.java        |   48 +-
 .../runtime/metrics/groups/FrontMetricGroup.java   |   21 +-
 .../metrics/groups/ReporterScopedSettings.java     |   53 +
 .../metrics/groups/SlotManagerMetricGroup.java     |   35 +
 .../runtime/metrics/groups/TaskIOMetricGroup.java  |    7 +
 .../metrics/groups/UnregisteredMetricGroups.java   |   17 +-
 .../flink/runtime/metrics/util/MetricUtils.java    |   22 +-
 .../flink/runtime/minicluster/MiniCluster.java     |  169 +-
 .../minicluster/MiniClusterConfiguration.java      |   41 +-
 .../apache/flink/runtime/net/ConnectionUtils.java  |    2 +-
 .../org/apache/flink/runtime/net/SSLUtils.java     |   14 +-
 .../apache/flink/runtime/operators/BatchTask.java  |   13 +-
 .../flink/runtime/operators/DataSinkTask.java      |    2 +-
 .../flink/runtime/operators/DataSourceTask.java    |    8 +-
 .../operators/chaining/ChainedAllReduceDriver.java |    2 +-
 .../runtime/operators/chaining/ChainedDriver.java  |    2 +-
 .../operators/chaining/ChainedMapDriver.java       |    2 +-
 .../chaining/ChainedReduceCombineDriver.java       |   22 +-
 .../chaining/GroupCombineChainedDriver.java        |  241 -
 .../chaining/SynchronousChainedCombineDriver.java  |   27 +-
 .../coordination/CoordinationRequest.java          |   27 +
 .../coordination/CoordinationRequestGateway.java   |   39 +
 .../coordination/CoordinationRequestHandler.java   |   36 +
 .../coordination/CoordinationResponse.java         |   27 +
 .../coordination/OperatorCoordinator.java          |  208 +
 .../coordination/OperatorCoordinatorHolder.java    |  442 ++
 .../operators/coordination/OperatorEvent.java      |   26 +
 .../coordination/OperatorEventDispatcher.java      |   40 +
 .../coordination/OperatorEventGateway.java         |   48 +
 .../coordination/OperatorEventHandler.java         |   32 +
 .../operators/coordination/OperatorEventValve.java |  245 +
 .../operators/coordination/OperatorInfo.java       |   46 +
 .../RecreateOnResetOperatorCoordinator.java        |  195 +
 .../coordination/TaskNotRunningException.java      |   33 +
 .../resettable/SpillingResettableIterator.java     |    4 +-
 .../SpillingResettableMutableObjectIterator.java   |    4 +-
 .../operators/shipping/OutputCollector.java        |    2 +-
 .../util/DistributedRuntimeUDFContext.java         |   16 +-
 .../flink/runtime/query/QueryableStateUtils.java   |    9 +-
 .../registration/RegisteredRpcConnection.java      |    7 +
 .../runtime/registration/RetryingRegistration.java |    4 +-
 .../resourcemanager/ActiveResourceManager.java     |  260 +
 .../ActiveResourceManagerFactory.java              |   40 +-
 .../ArbitraryWorkerResourceSpecFactory.java        |   37 +
 .../runtime/resourcemanager/ResourceManager.java   |  189 +-
 .../resourcemanager/ResourceManagerFactory.java    |   79 +-
 .../resourcemanager/ResourceManagerGateway.java    |   47 +-
 .../ResourceManagerRuntimeServices.java            |   33 +-
 ...esourceManagerRuntimeServicesConfiguration.java |    8 +-
 .../runtime/resourcemanager/ResourceOverview.java  |   20 +-
 .../resourcemanager/StandaloneResourceManager.java |   18 +-
 .../StandaloneResourceManagerFactory.java          |   74 +-
 .../resourcemanager/TaskExecutorRegistration.java  |  103 +
 .../resourcemanager/WorkerResourceSpec.java        |  169 +
 .../resourcemanager/WorkerResourceSpecFactory.java |   40 +
 .../slotmanager/ResourceActions.java               |   14 +-
 .../resourcemanager/slotmanager/SlotManager.java   |   24 +-
 .../slotmanager/SlotManagerConfiguration.java      |   51 +-
 .../slotmanager/SlotManagerImpl.java               |  200 +-
 .../slotmanager/TaskManagerSlot.java               |    2 +-
 .../flink/runtime/rest/JobRestEndpointFactory.java |    5 +-
 .../org/apache/flink/runtime/rest/RestClient.java  |    9 +-
 .../flink/runtime/rest/RestEndpointFactory.java    |   14 +-
 .../flink/runtime/rest/RestServerEndpoint.java     |   40 +-
 .../runtime/rest/SessionRestEndpointFactory.java   |    5 +-
 .../runtime/rest/handler/AbstractHandler.java      |   19 +-
 .../handler/async/AsynchronousOperationResult.java |    2 +-
 .../AsynchronousOperationStatusMessageHeaders.java |    2 +-
 .../cluster/AbstractJobManagerFileHandler.java     |   83 +
 .../cluster/JobManagerCustomLogHandler.java        |   60 +
 .../handler/cluster/JobManagerLogFileHandler.java  |   55 +
 .../handler/cluster/JobManagerLogListHandler.java  |   79 +
 .../dataset/ClusterDataSetDeleteHandlers.java      |  114 +
 .../handler/dataset/ClusterDataSetListHandler.java |   53 +
 .../rest/handler/job/JobDetailsHandler.java        |    2 +-
 .../handler/job/JobExecutionResultHandler.java     |    2 +-
 .../job/checkpoints/CheckpointConfigHandler.java   |    5 +-
 .../CheckpointingStatisticsHandler.java            |   19 +-
 .../TaskCheckpointStatisticDetailsHandler.java     |   26 +-
 .../coordination/ClientCoordinationHandler.java    |   84 +
 .../job/metrics/JobVertexWatermarksHandler.java    |   99 +
 .../job/rescaling/RescalingStatusHeaders.java      |    2 +-
 .../handler/job/savepoints/SavepointHandlers.java  |    2 +-
 .../rest/handler/legacy/ConstantTextHandler.java   |   57 -
 .../handler/legacy/DefaultExecutionGraphCache.java |  157 +
 .../rest/handler/legacy/ExecutionGraphCache.java   |  128 +-
 .../BackPressureRequestCoordinator.java            |  369 ++
 .../legacy/backpressure/BackPressureStats.java     |   87 +
 .../backpressure/BackPressureStatsTracker.java     |    2 +-
 .../backpressure/BackPressureStatsTrackerImpl.java |  233 +-
 .../backpressure/OperatorBackPressureStats.java    |   68 +-
 .../legacy/backpressure/StackTraceSample.java      |  119 -
 .../backpressure/StackTraceSampleCoordinator.java  |  392 --
 .../legacy/files/LogFileHandlerSpecification.java  |   48 -
 .../legacy/files/StaticFileServerHandler.java      |  105 +-
 .../files/StdoutFileHandlerSpecification.java      |   48 -
 .../AbstractResourceManagerHandler.java            |   81 +
 .../AbstractTaskManagerFileHandler.java            |  116 +-
 .../taskmanager/AbstractTaskManagerHandler.java    |   77 -
 .../taskmanager/TaskManagerCustomLogHandler.java   |   67 +
 .../taskmanager/TaskManagerDetailsHandler.java     |    3 +-
 .../taskmanager/TaskManagerLogFileHandler.java     |    5 +-
 .../taskmanager/TaskManagerLogListHandler.java     |   89 +
 .../taskmanager/TaskManagerStdoutFileHandler.java  |    5 +-
 .../taskmanager/TaskManagerThreadDumpHandler.java  |   62 +
 .../handler/taskmanager/TaskManagersHandler.java   |    3 +-
 .../runtime/rest/handler/util/HandlerUtils.java    |   80 +
 .../messages/DashboardConfigurationHeaders.java    |    2 +-
 .../rest/messages/LogFileNamePathParameter.java    |   49 +
 .../flink/runtime/rest/messages/LogInfo.java       |   79 +
 .../flink/runtime/rest/messages/LogListInfo.java   |   72 +
 .../rest/messages/OperatorIDPathParameter.java     |   49 +
 .../runtime/rest/messages/ResourceProfileInfo.java |  159 +
 .../messages/checkpoints/CheckpointConfigInfo.java |   15 +-
 .../messages/checkpoints/CheckpointStatistics.java |   18 +-
 .../checkpoints/CheckpointingStatistics.java       |   10 +-
 .../messages/checkpoints/MinMaxAvgStatistics.java  |    9 +
 .../checkpoints/SubtaskCheckpointStatistics.java   |   34 +-
 .../checkpoints/TaskCheckpointStatistics.java      |   10 +-
 ...TaskCheckpointStatisticsWithSubtaskDetails.java |   29 +-
 .../messages/cluster/FileMessageParameters.java    |   46 +
 .../cluster/JobManagerCustomLogHeaders.java        |   61 +
 .../messages/cluster/JobManagerLogFileHeader.java  |   61 +
 .../messages/cluster/JobManagerLogListHeaders.java |   79 +
 .../cluster/JobManagerStdoutFileHeader.java        |   60 +
 .../dataset/ClusterDataSetDeleteStatusHeaders.java |   76 +
 ...lusterDataSetDeleteStatusMessageParameters.java |   44 +
 .../ClusterDataSetDeleteTriggerHeaders.java        |   69 +
 ...usterDataSetDeleteTriggerMessageParameters.java |   43 +
 .../rest/messages/dataset/ClusterDataSetEntry.java |   62 +
 .../dataset/ClusterDataSetIdPathParameter.java     |   50 +
 .../dataset/ClusterDataSetListHeaders.java         |   73 +
 .../dataset/ClusterDataSetListResponseBody.java    |   62 +
 .../runtime/rest/messages/job/JobDetailsInfo.java  |    2 +-
 .../coordination/ClientCoordinationHeaders.java    |   80 +
 .../ClientCoordinationMessageParameters.java       |   49 +
 .../ClientCoordinationRequestBody.java             |   56 +
 .../ClientCoordinationResponseBody.java            |   56 +
 .../job/metrics/JobVertexWatermarksHeaders.java    |   74 +
 .../savepoints/SavepointDisposalStatusHeaders.java |    2 +-
 .../job/savepoints/SavepointStatusHeaders.java     |    2 +-
 .../taskmanager/TaskManagerCustomLogHeaders.java   |   59 +
 .../taskmanager/TaskManagerDetailsInfo.java        |    7 +
 .../TaskManagerFileMessageParameters.java          |   43 +
 .../rest/messages/taskmanager/TaskManagerInfo.java |   49 +
 .../taskmanager/TaskManagerLogsHeaders.java        |   78 +
 .../taskmanager/TaskManagerMessageParameters.java  |    2 +-
 .../taskmanager/TaskManagerThreadDumpHeaders.java  |   77 +
 .../rest/messages/taskmanager/ThreadDumpInfo.java  |  114 +
 .../org/apache/flink/runtime/rpc/RpcEndpoint.java  |    2 -
 .../org/apache/flink/runtime/rpc/RpcUtils.java     |   37 +-
 .../runtime/rpc/akka/AkkaInvocationHandler.java    |   77 +-
 .../flink/runtime/rpc/akka/AkkaRpcActor.java       |   64 +-
 .../flink/runtime/rpc/akka/AkkaRpcService.java     |  172 +-
 .../rpc/akka/AkkaRpcServiceConfiguration.java      |   19 +-
 .../runtime/rpc/akka/AkkaRpcServiceUtils.java      |  262 +-
 .../rpc/akka/FencedAkkaInvocationHandler.java      |    5 +-
 .../flink/runtime/rpc/akka/SupervisorActor.java    |  366 ++
 .../akka/exceptions/AkkaRpcRuntimeException.java   |   38 +
 .../exceptions/AkkaUnknownMessageException.java    |    2 +-
 .../rpc/exceptions/RpcRuntimeException.java        |   37 +
 .../runtime/rpc/messages/RemoteRpcInvocation.java  |    6 +-
 .../scheduler/AbstractExecutionSlotAllocator.java  |  131 +
 .../scheduler/DefaultExecutionSlotAllocator.java   |  200 +-
 .../DefaultExecutionSlotAllocatorFactory.java      |    8 +-
 .../DefaultExecutionVertexOperations.java          |    5 +
 .../DefaultPreferredLocationsRetriever.java        |  142 +
 .../flink/runtime/scheduler/DefaultScheduler.java  |  172 +-
 .../runtime/scheduler/DefaultSchedulerFactory.java |   45 +-
 .../flink/runtime/scheduler/DeploymentHandle.java  |   14 +
 .../runtime/scheduler/ExecutionSlotAllocator.java  |   12 +-
 .../scheduler/ExecutionSlotAllocatorFactory.java   |    2 +-
 .../scheduler/ExecutionVertexOperations.java       |    2 +
 .../ExecutionVertexSchedulingRequirements.java     |   74 +-
 ...xecutionVertexSchedulingRequirementsMapper.java |   34 +-
 .../scheduler/ExecutionVertexVersioner.java        |   17 +-
 .../flink/runtime/scheduler/LegacyScheduler.java   |  104 -
 .../runtime/scheduler/LegacySchedulerFactory.java  |   88 -
 .../OneSlotPerExecutionSlotAllocator.java          |  217 +
 .../OneSlotPerExecutionSlotAllocatorFactory.java   |   55 +
 .../scheduler/PreferredLocationsRetriever.java     |   44 +
 .../flink/runtime/scheduler/SchedulerBase.java     |  327 +-
 .../flink/runtime/scheduler/SchedulerNG.java       |   42 +-
 .../runtime/scheduler/SchedulerOperations.java     |    8 +-
 .../scheduler/SlotExecutionVertexAssignment.java   |    8 +-
 .../runtime/scheduler/StateLocationRetriever.java  |   39 +
 .../adapter/DefaultExecutionTopology.java          |   94 +-
 .../scheduler/adapter/DefaultExecutionVertex.java  |    6 +-
 .../scheduler/adapter/DefaultResultPartition.java  |   26 +-
 .../adapter/DefaultSchedulingPipelinedRegion.java  |   85 +
 .../strategy/EagerSchedulingStrategy.java          |   41 +-
 .../strategy/InputDependencyConstraintChecker.java |   70 +-
 .../LazyFromSourcesSchedulingStrategy.java         |   87 +-
 .../PipelinedRegionSchedulingStrategy.java         |  162 +
 .../scheduler/strategy/ResultPartitionState.java   |   36 +
 .../strategy/SchedulingExecutionVertex.java        |    4 +-
 .../strategy/SchedulingPipelinedRegion.java        |   30 +
 .../strategy/SchedulingResultPartition.java        |   29 +-
 .../scheduler/strategy/SchedulingStrategy.java     |    5 +-
 .../strategy/SchedulingStrategyFactory.java        |    4 +-
 .../strategy/SchedulingStrategyUtils.java          |   75 +
 .../scheduler/strategy/SchedulingTopology.java     |   32 +-
 .../runtime/security/HadoopSecurityContext.java    |   44 -
 .../security/NoMatchSecurityFactoryException.java  |   59 +
 .../runtime/security/NoOpSecurityContext.java      |   33 -
 .../runtime/security/SecurityConfiguration.java    |   33 +-
 .../flink/runtime/security/SecurityContext.java    |   30 -
 .../SecurityContextInitializeException.java        |   36 +
 .../security/SecurityFactoryServiceLoader.java     |   90 +
 .../flink/runtime/security/SecurityUtils.java      |   87 +-
 .../security/contexts/HadoopSecurityContext.java   |   44 +
 .../contexts/HadoopSecurityContextFactory.java     |   66 +
 .../security/contexts/NoOpSecurityContext.java     |   33 +
 .../contexts/NoOpSecurityContextFactory.java       |   38 +
 .../runtime/security/contexts/SecurityContext.java |   30 +
 .../security/contexts/SecurityContextFactory.java  |   52 +
 .../runtime/security/modules/HadoopModule.java     |   21 +-
 .../flink/runtime/security/modules/JaasModule.java |   25 +-
 .../flink/runtime/shuffle/PartitionDescriptor.java |   11 +
 .../flink/runtime/shuffle/ShuffleEnvironment.java  |   16 +-
 .../runtime/shuffle/ShuffleEnvironmentContext.java |   22 +-
 .../flink/runtime/shuffle/ShuffleMaster.java       |    2 +
 .../runtime/shuffle/ShuffleServiceFactory.java     |    4 +-
 .../source/coordinator/ExecutorNotifier.java       |  156 +
 .../source/coordinator/SourceCoordinator.java      |  278 +
 .../coordinator/SourceCoordinatorContext.java      |  311 +
 .../coordinator/SourceCoordinatorProvider.java     |  110 +
 .../coordinator/SourceCoordinatorSerdeUtils.java   |  179 +
 .../source/coordinator/SplitAssignmentTracker.java |  164 +
 .../flink/runtime/source/event/AddSplitEvent.java  |   59 +
 .../source/event/ReaderRegistrationEvent.java      |   51 +
 .../runtime/source/event/SourceEventWrapper.java   |   48 +
 .../runtime/state/AbstractChannelStateHandle.java  |  135 +
 .../runtime/state/AbstractKeyedStateBackend.java   |    5 +
 .../flink/runtime/state/CheckpointListener.java    |    8 +
 .../runtime/state/ConfigurableStateBackend.java    |    4 +-
 .../runtime/state/DefaultOperatorStateBackend.java |   25 -
 .../flink/runtime/state/DirectoryStateHandle.java  |   31 +-
 .../runtime/state/InputChannelStateHandle.java     |   44 +
 .../apache/flink/runtime/state/JavaSerializer.java |    8 +-
 .../flink/runtime/state/KeyGroupsStateHandle.java  |   13 +-
 .../flink/runtime/state/KeyedStateHandle.java      |    6 +-
 .../runtime/state/NoOpTaskLocalStateStoreImpl.java |    4 +
 .../runtime/state/OperatorStreamStateHandle.java   |    6 +
 .../state/PlaceholderStreamStateHandle.java        |    8 +
 .../state/ResultSubpartitionStateHandle.java       |   44 +
 .../state/RetrievableStreamStateHandle.java        |    6 +
 .../flink/runtime/state/SnapshotDirectory.java     |   42 +-
 .../flink/runtime/state/StateBackendFactory.java   |    4 +-
 .../flink/runtime/state/StateBackendLoader.java    |   21 +-
 .../state/StateSnapshotContextSynchronousImpl.java |    4 +-
 .../org/apache/flink/runtime/state/StateUtil.java  |   11 +-
 .../flink/runtime/state/StreamStateHandle.java     |    6 +
 .../flink/runtime/state/TaskLocalStateStore.java   |    6 +
 .../runtime/state/TaskLocalStateStoreImpl.java     |   11 +-
 .../flink/runtime/state/TaskStateManager.java      |    5 +-
 .../flink/runtime/state/TaskStateManagerImpl.java  |   51 +-
 .../state/filesystem/AbstractFileStateBackend.java |    8 +-
 .../filesystem/AbstractFsCheckpointStorage.java    |    2 +-
 .../runtime/state/filesystem/FileStateHandle.java  |   10 +-
 .../state/filesystem/FsCheckpointStorage.java      |    2 +
 .../filesystem/FsCheckpointStreamFactory.java      |   69 +-
 .../FsCompletedCheckpointStorageLocation.java      |    6 +-
 .../runtime/state/filesystem/FsStateBackend.java   |   57 +-
 .../state/filesystem/FsStateBackendFactory.java    |    6 +-
 .../state/filesystem/RelativeFileStateHandle.java  |   73 +
 .../runtime/state/heap/HeapKeyedStateBackend.java  |    5 +
 .../flink/runtime/state/heap/HeapMapState.java     |    9 +-
 .../runtime/state/heap/HeapRestoreOperation.java   |    8 +-
 .../runtime/state/heap/HeapSnapshotStrategy.java   |    2 +-
 .../heap/KeyGroupPartitionedPriorityQueue.java     |    8 +-
 .../state/memory/ByteStreamStateHandle.java        |    8 +-
 .../runtime/state/memory/MemoryStateBackend.java   |   10 +-
 .../state/memory/MemoryStateBackendFactory.java    |    4 +-
 .../runtime/state/ttl/AbstractTtlDecorator.java    |    2 +-
 .../taskexecutor/BackPressureSampleService.java    |  111 +
 .../taskexecutor/BackPressureSampleableTask.java   |   31 +
 .../taskexecutor/DefaultJobLeaderService.java      |  456 ++
 .../runtime/taskexecutor/DefaultJobTable.java      |  322 +
 .../flink/runtime/taskexecutor/FileType.java       |    9 +-
 .../taskexecutor/GlobalAggregateManager.java       |    2 +-
 .../runtime/taskexecutor/JobLeaderService.java     |  406 +-
 .../runtime/taskexecutor/JobManagerConnection.java |  123 -
 .../runtime/taskexecutor/JobManagerTable.java      |   59 -
 .../flink/runtime/taskexecutor/JobTable.java       |  231 +
 .../flink/runtime/taskexecutor/KvStateService.java |    4 +-
 .../flink/runtime/taskexecutor/SlotReport.java     |    4 +
 .../taskexecutor/StackTraceSampleService.java      |  128 -
 .../taskexecutor/StackTraceSampleableTask.java     |   35 -
 .../flink/runtime/taskexecutor/TaskExecutor.java   |  747 ++-
 .../runtime/taskexecutor/TaskExecutorGateway.java  |   73 +-
 .../taskexecutor/TaskExecutorHeartbeatPayload.java |   11 +-
 .../TaskExecutorOperatorEventGateway.java          |   49 +
 .../taskexecutor/TaskExecutorResourceSpec.java     |   70 +
 .../taskexecutor/TaskExecutorResourceUtils.java    |  179 +
 .../TaskExecutorToResourceManagerConnection.java   |   53 +-
 .../taskexecutor/TaskManagerConfiguration.java     |  132 +-
 .../runtime/taskexecutor/TaskManagerRunner.java    |  140 +-
 .../runtime/taskexecutor/TaskManagerServices.java  |  341 +-
 .../TaskManagerServicesConfiguration.java          |  165 +-
 .../TaskStackTraceSampleableTaskAdapter.java       |   58 -
 .../partition/ClusterPartitionReport.java          |   90 +
 .../rpc/RpcTaskOperatorEventGateway.java           |   65 +
 .../flink/runtime/taskexecutor/slot/SlotOffer.java |    1 -
 .../flink/runtime/taskexecutor/slot/TaskSlot.java  |  173 +-
 .../runtime/taskexecutor/slot/TaskSlotPayload.java |   46 +
 .../runtime/taskexecutor/slot/TaskSlotState.java   |    3 +-
 .../runtime/taskexecutor/slot/TaskSlotTable.java   |  611 +-
 .../taskexecutor/slot/TaskSlotTableImpl.java       |  777 +++
 ...bleNotifyingResultPartitionWriterDecorator.java |   32 +-
 .../runtime/taskmanager/InputGateWithMetrics.java  |   47 +-
 .../NettyShuffleEnvironmentConfiguration.java      |  355 +-
 .../runtime/taskmanager/RuntimeEnvironment.java    |   40 +-
 .../org/apache/flink/runtime/taskmanager/Task.java |  210 +-
 .../runtime/taskmanager/TaskManagerCliOptions.java |   37 -
 .../runtime/taskmanager/TaskManagerLocation.java   |   11 +
 .../taskmanager/TaskManagerRuntimeInfo.java        |   17 +
 .../taskmanager/UnresolvedTaskManagerLocation.java |   60 +
 .../flink/runtime/topology/BaseTopology.java       |   42 +
 .../flink/runtime/topology/PipelinedRegion.java    |   57 +
 .../org/apache/flink/runtime/topology/Result.java  |    2 +-
 .../apache/flink/runtime/topology/ResultID.java    |    2 +-
 .../apache/flink/runtime/topology/Topology.java    |   28 +-
 .../org/apache/flink/runtime/topology/Vertex.java  |    4 +-
 .../flink/runtime/util/ClusterEntrypointUtils.java |   17 +
 .../runtime/util/ConfigurationParserUtils.java     |  104 +-
 .../flink/runtime/util/EnvironmentInformation.java |  182 +-
 .../org/apache/flink/runtime/util/JvmUtils.java    |   48 +
 .../flink/runtime/util/KeyedBudgetManager.java     |  294 -
 .../org/apache/flink/runtime/util/Runnables.java   |   46 +
 .../apache/flink/runtime/util/StandaloneUtils.java |   90 -
 .../apache/flink/runtime/util/ZooKeeperUtils.java  |   20 +-
 .../flink/runtime/util/bash/BashJavaUtils.java     |  155 +
 .../flink/runtime/util/bash/FlinkConfigLoader.java |   68 +
 .../org/apache/flink/runtime/util/clock/Clock.java |   40 -
 .../flink/runtime/util/clock/SystemClock.java      |   57 -
 .../config/memory/CommonProcessMemorySpec.java     |   97 +
 .../runtime/util/config/memory/FlinkMemory.java    |   55 +
 .../util/config/memory/FlinkMemoryUtils.java       |   37 +
 .../config/memory/JvmMetaspaceAndOverhead.java     |   52 +
 .../memory/JvmMetaspaceAndOverheadOptions.java     |   59 +
 .../util/config/memory/LegacyMemoryOptions.java    |   52 +
 .../memory/MemoryBackwardsCompatibilityUtils.java  |   94 +
 .../util/config/memory/ProcessMemoryOptions.java   |   65 +
 .../util/config/memory/ProcessMemorySpec.java      |   40 +
 .../util/config/memory/ProcessMemoryUtils.java     |  298 +
 .../runtime/util/config/memory/RangeFraction.java  |   52 +
 .../memory/jobmanager/JobManagerFlinkMemory.java   |   72 +
 .../jobmanager/JobManagerFlinkMemoryUtils.java     |  128 +
 .../taskmanager/TaskExecutorFlinkMemory.java       |  131 +
 .../taskmanager/TaskExecutorFlinkMemoryUtils.java  |  302 +
 .../flink/runtime/webmonitor/RestfulGateway.java   |   26 +-
 .../runtime/webmonitor/WebMonitorEndpoint.java     |  178 +-
 .../flink/runtime/webmonitor/WebMonitorUtils.java  |   21 +-
 .../zookeeper/FlinkZooKeeperQuorumPeer.java        |   12 +-
 .../runtime/zookeeper/ZooKeeperSharedCount.java    |    3 +-
 .../runtime/zookeeper/ZooKeeperSharedValue.java    |    3 +-
 .../zookeeper/ZooKeeperStateHandleStore.java       |   11 +-
 .../runtime/zookeeper/ZooKeeperUtilityFactory.java |    6 +-
 .../runtime/zookeeper/ZooKeeperVersionedValue.java |    3 +-
 .../.flink-runtime.version.properties              |   22 +
 flink-runtime/src/main/resources/META-INF/NOTICE   |    3 +-
 ...untime.security.contexts.SecurityContextFactory |   17 +
 ....runtime.security.modules.SecurityModuleFactory |   18 +
 flink-runtime/src/main/resources/log4j.properties  |   24 -
 .../org/apache/flink/runtime/akka/AkkaUtils.scala  |   55 +-
 .../runtime/akka/CustomSSLEngineProvider.scala     |   43 +
 .../flink/runtime/blob/BlobServerCleanupTest.java  |   10 +-
 .../flink/runtime/blob/BlobServerRangeTest.java    |   11 +-
 .../runtime/blob/NoOpTransientBlobService.java     |   75 +
 .../ChannelStateNoRescalingPartitionerTest.java    |  131 +
 .../CheckpointCoordinatorFailureTest.java          |   65 +-
 .../CheckpointCoordinatorMasterHooksTest.java      |   22 +-
 .../CheckpointCoordinatorRestoringTest.java        |  252 +-
 .../checkpoint/CheckpointCoordinatorTest.java      | 1091 ++--
 .../CheckpointCoordinatorTestingUtils.java         |  199 +-
 .../CheckpointCoordinatorTriggeringTest.java       |  600 +-
 .../checkpoint/CheckpointFailureManagerTest.java   |    2 +-
 .../checkpoint/CheckpointIDCounterTest.java        |   12 +-
 .../checkpoint/CheckpointMetadataLoadingTest.java  |  199 +-
 .../runtime/checkpoint/CheckpointOptionsTest.java  |   21 +
 .../checkpoint/CheckpointPropertiesTest.java       |    4 +-
 .../checkpoint/CheckpointRequestDeciderTest.java   |  221 +
 .../CheckpointSettingsSerializableTest.java        |    1 +
 .../checkpoint/CheckpointStateRestoreTest.java     |  133 +-
 .../checkpoint/CheckpointStatsSnapshotTest.java    |    9 +-
 .../checkpoint/CheckpointStatsTrackerTest.java     |   47 +-
 .../CompletedCheckpointStatsSummaryTest.java       |   14 +-
 .../checkpoint/CompletedCheckpointStoreTest.java   |    4 +-
 .../checkpoint/CompletedCheckpointTest.java        |    3 +-
 .../ExecutionGraphCheckpointCoordinatorTest.java   |    3 +-
 .../checkpoint/FailedCheckpointStatsTest.java      |    2 -
 .../FailoverStrategyCheckpointCoordinatorTest.java |   16 +-
 .../checkpoint/OperatorSubtaskStateTest.java       |   74 +
 .../checkpoint/PendingCheckpointStatsTest.java     |    7 -
 .../runtime/checkpoint/PendingCheckpointTest.java  |  122 +-
 .../PrioritizedOperatorSubtaskStateTest.java       |  146 +-
 .../StandaloneCompletedCheckpointStoreTest.java    |    4 +-
 .../checkpoint/StateAssignmentOperationTest.java   |  153 +-
 .../runtime/checkpoint/StateHandleDummyUtil.java   |   68 +-
 .../runtime/checkpoint/SubtaskStateStatsTest.java  |   13 +-
 .../runtime/checkpoint/TaskStateSnapshotTest.java  |   30 +
 .../runtime/checkpoint/TaskStateStatsTest.java     |    8 -
 .../ZKCheckpointIDCounterMultiServersTest.java     |  119 +
 .../ZooKeeperCompletedCheckpointStoreITCase.java   |   18 +-
 ...oKeeperCompletedCheckpointStoreMockitoTest.java |   15 +-
 .../ZooKeeperCompletedCheckpointStoreTest.java     |    5 +-
 .../channel/ChannelStateCheckpointWriterTest.java  |  226 +
 .../channel/ChannelStateReaderImplTest.java        |  196 +
 .../channel/ChannelStateSerializerImplTest.java    |  149 +
 ...ChannelStateWriteRequestDispatcherImplTest.java |   69 +
 .../ChannelStateWriteRequestDispatcherTest.java    |  126 +
 .../ChannelStateWriteRequestExecutorImplTest.java  |  216 +
 .../channel/ChannelStateWriterImplTest.java        |  350 ++
 .../channel/CheckpointInProgressRequestTest.java   |   87 +
 .../checkpoint/channel/MockChannelStateWriter.java |  120 +
 .../channel/RecordingChannelStateWriter.java       |   91 +
 .../metadata/CheckpointMetadataTest.java           |   67 +
 .../checkpoint/metadata/CheckpointTestUtils.java   |  249 +
 .../metadata/MetadataV3SerializerTest.java         |  194 +
 .../checkpoint/savepoint/CheckpointTestUtils.java  |  296 -
 .../savepoint/SavepointV1SerializerTest.java       |   64 -
 .../savepoint/SavepointV2SerializerTest.java       |  147 -
 .../checkpoint/savepoint/SavepointV2Test.java      |   68 -
 .../runtime/classloading/ClassLoaderTest.java      |  196 -
 .../clusterframework/BootstrapToolsTest.java       |  224 +-
 .../ContaineredTaskManagerParametersTest.java      |  137 -
 .../TaskExecutorProcessUtilsTest.java              |  642 ++
 .../TaskExecutorResourceUtilsTest.java             |  719 ---
 .../overlays/FlinkDistributionOverlayTest.java     |   34 +
 .../overlays/UserLibOverlayTest.java               |   58 +
 ...ocationPreferenceSlotSelectionStrategyTest.java |  120 +-
 ...reviousAllocationSlotSelectionStrategyTest.java |   38 +-
 .../types/ResourceBudgetManagerTest.java           |   70 +
 .../types/ResourceProfileTest.java                 |  325 +-
 .../types/SlotSelectionStrategyTestBase.java       |    7 +-
 .../flink/runtime/concurrent/FutureUtilsTest.java  |   42 +
 .../ManuallyTriggeredScheduledExecutor.java        |   22 +-
 .../ManuallyTriggeredScheduledExecutorService.java |   98 +
 .../ResultPartitionDeploymentDescriptorTest.java   |    3 +
 .../runtime/deployment/ShuffleDescriptorTest.java  |   12 +-
 .../TaskDeploymentDescriptorBuilder.java           |   10 +-
 .../dispatcher/DispatcherResourceCleanupTest.java  |   38 +-
 .../flink/runtime/dispatcher/DispatcherTest.java   |   38 +-
 .../FileArchivedExecutionGraphStoreTest.java       |    2 +-
 .../runtime/dispatcher/MiniDispatcherTest.java     |   24 +-
 .../dispatcher/SchedulerNGFactoryFactoryTest.java  |   12 +-
 .../runtime/dispatcher/TestingDispatcher.java      |    8 +-
 .../runner/DefaultDispatcherRunnerITCase.java      |   10 +-
 .../ZooKeeperDefaultDispatcherRunnerTest.java      |    3 +-
 .../component/FileJobGraphRetrieverTest.java       |  112 +
 ...tDispatcherResourceManagerComponentFactory.java |   38 -
 .../librarycache/BlobLibraryCacheManagerTest.java  |  357 +-
 .../BlobLibraryCacheRecoveryITCase.java            |   15 +-
 .../ContextClassLoaderLibraryCacheManager.java     |   36 +-
 .../FlinkUserCodeClassLoadersTest.java             |  209 +
 .../librarycache/TestingClassLoaderLease.java      |   76 +
 .../librarycache/TestingLibraryCacheManager.java   |   76 +
 ...egionStrategyNGAbortPendingCheckpointsTest.java |  181 -
 ...inedRegionStrategyNGConcurrentFailoverTest.java |  286 -
 ...startPipelinedRegionStrategyNGFailoverTest.java |  460 --
 .../executiongraph/ArchivedExecutionGraphTest.java |    3 +-
 .../ExecutionGraphCoLocationRestartTest.java       |    4 +-
 .../ExecutionGraphDeploymentTest.java              |    3 +-
 .../executiongraph/ExecutionGraphMetricsTest.java  |    2 +-
 .../ExecutionGraphNotEnoughResourceTest.java       |    2 +-
 .../executiongraph/ExecutionGraphRestartTest.java  |    6 +-
 .../ExecutionGraphSchedulingTest.java              |    2 +-
 .../executiongraph/ExecutionGraphSuspendTest.java  |    8 +-
 .../executiongraph/ExecutionGraphTestUtils.java    |  130 +-
 .../ExecutionGraphVariousFailuesTest.java          |    2 +-
 .../executiongraph/ExecutionJobVertexTest.java     |   26 +-
 .../runtime/executiongraph/ExecutionTest.java      |   72 +-
 .../executiongraph/ExecutionVertexCancelTest.java  |   20 +-
 .../ExecutionVertexDeploymentTest.java             |   16 +-
 .../ExecutionVertexInputConstraintTest.java        |   68 +-
 .../ExecutionVertexSchedulingTest.java             |    8 +-
 .../executiongraph/FinalizeOnMasterTest.java       |   13 +-
 .../executiongraph/GlobalModVersionTest.java       |    4 +-
 .../IntermediateResultPartitionTest.java           |    4 +-
 .../executiongraph/LegacyJobVertexIdTest.java      |   64 -
 .../executiongraph/ProgrammedSlotProvider.java     |    4 +-
 .../RegionPartitionReleaseStrategyTest.java        |   38 +-
 .../executiongraph/TestExecutionVertex.java        |   55 +
 .../executiongraph/VertexSlotSharingTest.java      |   69 +-
 .../flip1/ExecutionFailureHandlerTest.java         |   17 +-
 .../flip1/FailoverStrategyFactoryLoaderTest.java   |   72 +
 .../failover/flip1/FailureHandlingResultTest.java  |    5 +-
 .../FailureRateRestartBackoffTimeStrategyTest.java |    2 +-
 .../flip1/PipelinedRegionComputeUtilTest.java      |  549 ++
 .../flip1/RestartAllFailoverStrategyTest.java      |   55 +
 ...estartBackoffTimeStrategyFactoryLoaderTest.java |   18 +-
 ...RestartPipelinedRegionFailoverStrategyTest.java |  423 ++
 ...RestartPipelinedRegionStrategyBuildingTest.java |  544 --
 .../flip1/RestartPipelinedRegionStrategyTest.java  |  428 --
 .../failover/flip1/TestFailoverTopology.java       |  174 -
 .../PipelinedRegionExecutionViewTest.java          |   21 +-
 .../restart/RestartStrategyFactoryTest.java        |    2 +-
 .../utils/SimpleAckingTaskManagerGateway.java      |   28 +-
 .../executiongraph/utils/SimpleSlotProvider.java   |    9 +-
 .../ExternalResourceUtilsTest.java                 |  246 +
 .../TestingExternalResourceDriver.java             |   43 +
 .../TestingExternalResourceDriverFactory.java      |   34 +
 ...TestingFailedExternalResourceDriverFactory.java |   34 +
 .../filecache/FileCacheDirectoriesTest.java        |   47 +-
 .../runtime/heartbeat/HeartbeatManagerTest.java    |   24 +-
 .../heartbeat/TestingHeartbeatServices.java        |   66 +-
 .../nonha/standalone/StandaloneHaServicesTest.java |    7 +-
 .../zookeeper/ZooKeeperHaServicesTest.java         |    7 +-
 .../flink/runtime/instance/SimpleSlotContext.java  |    5 +
 .../io/compression/BlockCompressionTest.java       |  176 +
 .../io/disk/FileChannelManagerImplTest.java        |  179 +
 .../io/network/NettyShuffleEnvironmentBuilder.java |   54 +-
 .../io/network/NettyShuffleEnvironmentTest.java    |  139 +-
 .../io/network/TestingPartitionRequestClient.java  |    4 +
 .../api/serialization/EventSerializerTest.java     |   60 +-
 .../SpanningRecordSerializationTest.java           |  134 +
 .../api/serialization/SpanningWrapperTest.java     |  115 +
 .../AbstractCollectingResultPartitionWriter.java   |   53 +-
 .../AvailabilityTestResultPartitionWriter.java     |   52 +
 .../api/writer/BroadcastRecordWriterTest.java      |   54 +
 .../api/writer/RecordWriterDelegateTest.java       |  189 +
 .../io/network/api/writer/RecordWriterTest.java    |  314 +-
 .../io/network/buffer/AbstractByteBufTest.java     |    6 +-
 .../buffer/BufferBuilderAndConsumerTest.java       |   49 +-
 .../io/network/buffer/BufferBuilderTestUtils.java  |    8 +-
 .../io/network/buffer/BufferCompressionTest.java   |  217 +
 .../io/network/buffer/LocalBufferPoolTest.java     |   51 +-
 .../io/network/buffer/NetworkBufferPoolTest.java   |   44 +-
 .../io/network/buffer/NetworkBufferTest.java       |    8 +-
 .../runtime/io/network/buffer/NoOpBufferPool.java  |   25 +-
 .../network/buffer/ReadOnlySlicedBufferTest.java   |   10 +-
 .../runtime/io/network/netty/ByteBufUtilsTest.java |  129 +
 .../network/netty/CancelPartitionRequestTest.java  |   11 +-
 .../netty/ClientTransportErrorHandlingTest.java    |    9 +-
 ...editBasedPartitionRequestClientHandlerTest.java |  357 +-
 .../io/network/netty/NettyClientServerSslTest.java |   44 +-
 .../network/netty/NettyConnectionManagerTest.java  |    2 +-
 .../NettyMessageClientDecoderDelegateTest.java     |  353 ++
 .../NettyMessageClientSideSerializationTest.java   |  212 +
 .../netty/NettyMessageSerializationTest.java       |  188 -
 .../NettyMessageServerSideSerializationTest.java   |  123 +
 .../netty/NettyPartitionRequestClientTest.java     |   77 +-
 .../netty/NettyServerLowAndHighWatermarkTest.java  |  208 -
 .../runtime/io/network/netty/NettyTestUtil.java    |   40 +
 .../netty/PartitionRequestClientFactoryTest.java   |    2 +-
 .../netty/PartitionRequestClientHandlerTest.java   |  230 -
 .../network/netty/PartitionRequestQueueTest.java   |   80 +-
 .../netty/PartitionRequestServerHandlerTest.java   |   37 +-
 .../netty/ServerTransportErrorHandlingTest.java    |    2 +-
 .../partition/AbstractPartitionTrackerTest.java    |   14 +-
 .../AwaitableBufferAvailablityListener.java        |   21 +
 ...oundedBlockingSubpartitionAvailabilityTest.java |    8 +-
 .../BoundedBlockingSubpartitionWriteReadTest.java  |   67 +-
 .../io/network/partition/BoundedDataTestBase.java  |   43 +-
 .../partition/FileChannelBoundedDataTest.java      |    2 +-
 .../network/partition/InputChannelTestUtils.java   |   19 +-
 .../network/partition/InputGateFairnessTest.java   |   38 +-
 .../partition/MockResultPartitionWriter.java       |  110 +
 .../partition/NoOpBufferAvailablityListener.java   |    2 +-
 .../NoOpResourceManagerPartitionTracker.java       |   57 +
 .../PartialConsumePipelinedResultTest.java         |    9 +-
 .../io/network/partition/PartitionTestUtils.java   |   26 +-
 .../partition/PipelinedSubpartitionTest.java       |   10 +-
 .../PipelinedSubpartitionWithReadViewTest.java     |  181 +-
 .../ResourceManagerPartitionTrackerImplTest.java   |  205 +
 .../network/partition/ResultPartitionBuilder.java  |   33 +-
 .../partition/ResultPartitionFactoryTest.java      |   21 +-
 .../io/network/partition/ResultPartitionTest.java  |  291 +
 .../TaskExecutorPartitionTrackerImplTest.java      |  225 +
 .../TestingTaskExecutorPartitionTracker.java       |  136 +
 .../consumer/InputBuffersMetricsTest.java          |   16 +-
 .../partition/consumer/InputChannelBuilder.java    |   69 +-
 .../partition/consumer/InputChannelTest.java       |    4 +
 .../partition/consumer/InputGateTestBase.java      |   41 +-
 .../IteratorWrappingTestSingleInputGate.java       |   11 +-
 .../partition/consumer/LocalInputChannelTest.java  |  150 +-
 .../consumer/RecoveredInputChannelTest.java        |  292 +
 .../partition/consumer/RemoteInputChannelTest.java |  435 +-
 .../partition/consumer/SingleInputGateBuilder.java |   61 +-
 .../partition/consumer/SingleInputGateTest.java    |  615 +-
 .../consumer/TestBufferReceivedListener.java       |   43 +
 .../partition/consumer/TestInputChannel.java       |   46 +-
 .../partition/consumer/TestSingleInputGate.java    |   12 +-
 .../partition/consumer/UnionInputGateTest.java     |   57 +-
 .../runtime/io/network/util/TestBufferFactory.java |    2 +-
 .../io/network/util/TestPooledBufferProvider.java  |   21 +-
 .../io/network/util/TestSubpartitionConsumer.java  |    2 +-
 .../flink/runtime/jobgraph/JobGraphTest.java       |    1 +
 .../tasks/JobCheckpointingSettingsTest.java        |    1 +
 .../topology/DefaultLogicalTopologyTest.java       |    2 +-
 .../runtime/jobmanager/BlobsCleanupITCase.java     |   15 +-
 .../jobmanager/JobManagerProcessUtilsTest.java     |  296 +
 .../SlotCountExceedingParallelismTest.java         |    3 -
 .../jobmanager/ZooKeeperJobGraphStoreTest.java     |    5 +-
 .../jobmanager/ZooKeeperJobGraphsStoreITCase.java  |    5 +-
 .../jobmanager/scheduler/DummyScheduledUnit.java   |    1 -
 .../scheduler/ScheduleOrUpdateConsumersTest.java   |    6 +-
 .../scheduler/ScheduleWithCoLocationHintTest.java  |  130 +-
 .../scheduler/SchedulerIsolatedTasksTest.java      |   66 +-
 .../jobmanager/scheduler/SchedulerTestBase.java    |    9 +-
 .../jobmanager/scheduler/SchedulerTestUtils.java   |  162 -
 .../runtime/jobmaster/JobExecutionITCase.java      |    3 -
 .../jobmaster/JobManagerRunnerImplTest.java        |   56 +-
 .../jobmaster/JobMasterPartitionReleaseTest.java   |   10 +-
 .../flink/runtime/jobmaster/JobMasterTest.java     |  132 +-
 .../flink/runtime/jobmaster/JobRecoveryITCase.java |    3 -
 .../flink/runtime/jobmaster/JobResultTest.java     |   15 +-
 .../TestingJobManagerSharedServicesBuilder.java    |   25 +-
 .../slotpool/AllocatedSlotOccupationTest.java      |   50 +
 .../jobmaster/slotpool/AvailableSlotsTest.java     |    5 +-
 .../slotpool/BulkSlotProviderImplTest.java         |  214 +
 .../jobmaster/slotpool/DualKeyLinkedMapTest.java   |   58 +
 .../PhysicalSlotRequestBulkCheckerTest.java        |  193 +
 .../slotpool/PhysicalSlotRequestBulkTest.java      |   61 +
 .../jobmaster/slotpool/PhysicalSlotTestUtils.java  |   58 +
 .../slotpool/SlotPoolBatchSlotRequestTest.java     |    6 +-
 .../jobmaster/slotpool/SlotPoolBuilder.java        |    4 +-
 .../jobmaster/slotpool/SlotPoolCoLocationTest.java |  161 -
 .../jobmaster/slotpool/SlotPoolImplTest.java       |   83 +-
 .../slotpool/SlotPoolInteractionsTest.java         |   12 +-
 .../SlotPoolPendingRequestFailureTest.java         |   40 +
 .../slotpool/SlotPoolRequestCompletionTest.java    |   34 +-
 .../slotpool/SlotPoolSlotSharingTest.java          |   98 +-
 .../jobmaster/slotpool/SlotSharingManagerTest.java |  266 +-
 .../jobmaster/slotpool/TestingSlotPoolImpl.java    |   31 +-
 .../runtime/jobmaster/utils/JobMasterBuilder.java  |   12 +-
 .../runtime/jobmaster/utils/JobResultUtils.java    |   60 +
 .../jobmaster/utils/TestingJobMasterGateway.java   |   39 +-
 .../utils/TestingJobMasterGatewayBuilder.java      |   27 +-
 .../LeaderChangeClusterComponentsTest.java         |   10 +-
 .../runtime/leaderelection/LeaderElectionTest.java |    3 +-
 .../ZooKeeperLeaderElectionTest.java               |   33 +-
 .../ZooKeeperLeaderRetrievalTest.java              |    3 +-
 .../flink/runtime/memory/MemoryManagerBuilder.java |   26 +-
 .../memory/MemoryManagerSharedResourcesTest.java   |  242 +
 .../flink/runtime/memory/MemoryManagerTest.java    |  196 +-
 .../runtime/memory/OpaqueMemoryResourceTest.java   |   52 +
 .../flink/runtime/memory/SharedResourcesTest.java  |  162 +
 .../runtime/memory/UnsafeMemoryBudgetTest.java     |   85 +
 .../runtime/messages/CheckpointMessagesTest.java   |   15 +-
 .../runtime/messages/GenericMessageTester.java     |    6 +-
 .../runtime/messages/WebMonitorMessagesTest.java   |    2 +-
 .../messages/webmonitor/JobDetailsTest.java        |    2 +-
 .../webmonitor/JobIdsWithStatusOverviewTest.java   |    2 +-
 .../webmonitor/MultipleJobsDetailsTest.java        |    2 +-
 .../runtime/metrics/MetricRegistryImplTest.java    |   29 +-
 .../flink/runtime/metrics/ReporterSetupTest.java   |   42 +-
 .../metrics/groups/AbstractMetricGroupTest.java    |   30 +-
 .../metrics/groups/TaskIOMetricGroupTest.java      |    2 +
 .../runtime/metrics/util/MetricUtilsTest.java      |    4 +-
 .../minicluster/MiniClusterConfigurationTest.java  |   77 -
 .../runtime/minicluster/MiniClusterITCase.java     |    5 +-
 .../SessionDispatcherWithUUIDFactory.java          |   53 -
 .../StandaloneResourceManagerWithUUIDFactory.java  |   78 -
 .../runtime/minicluster/TestingMiniCluster.java    |   10 +-
 .../org/apache/flink/runtime/net/SSLUtilsTest.java |   80 +
 .../runtime/operators/DataSourceTaskTest.java      |    2 +-
 .../runtime/operators/chaining/ChainTaskTest.java  |  112 +-
 .../chaining/ChainedOperatorsMetricTest.java       |    2 +-
 .../CoordinatorEventsExactlyOnceITCase.java        |  501 ++
 .../coordination/MockOperatorCoordinator.java      |   65 +
 .../MockOperatorCoordinatorContext.java            |   93 +
 .../coordination/MockOperatorEventGateway.java     |   39 +
 .../OperatorCoordinatorHolderTest.java             |  560 ++
 .../OperatorCoordinatorSchedulerTest.java          |  707 +++
 .../coordination/OperatorEventValveTest.java       |  170 +
 .../RecreateOnResetOperatorCoordinatorTest.java    |  119 +
 .../operators/coordination/TestEventSender.java    |  113 +
 .../operators/coordination/TestOperatorEvent.java  |   59 +
 .../TestingCoordinationRequestHandler.java         |  104 +
 .../coordination/TestingOperatorCoordinator.java   |  167 +
 .../coordination/TestingOperatorInfo.java          |   59 +
 .../testutils/DummyCheckpointInvokable.java        |   42 +
 .../operators/testutils/DummyEnvironment.java      |   19 +-
 .../operators/testutils/DummyInvokable.java        |   27 +-
 .../operators/testutils/ExpectedTestException.java |    4 +-
 .../operators/testutils/MockEnvironment.java       |   99 +-
 .../testutils/MockEnvironmentBuilder.java          |   44 +-
 .../runtime/operators/testutils/TaskTestBase.java  |    2 +-
 .../ActiveResourceManagerFactoryTest.java          |   97 -
 .../resourcemanager/ActiveResourceManagerTest.java |   75 +
 .../resourcemanager/ResourceManagerHATest.java     |   17 +-
 .../ResourceManagerJobMasterTest.java              |    6 +-
 .../ResourceManagerPartitionLifecycleTest.java     |  246 +
 .../ResourceManagerTaskExecutorTest.java           |   36 +-
 .../resourcemanager/ResourceManagerTest.java       |   33 +-
 .../StandaloneResourceManagerFactoryTest.java      |   68 -
 .../StandaloneResourceManagerTest.java             |   10 +-
 .../resourcemanager/TestingResourceManager.java    |   17 +-
 .../resourcemanager/WorkerResourceSpecTest.java    |  173 +
 .../AnyMatchingSlotMatchingStrategyTest.java       |    6 +-
 .../LeastUtilizationSlotMatchingStrategyTest.java  |    4 +-
 .../slotmanager/SlotManagerBuilder.java            |   55 +-
 .../slotmanager/SlotManagerConfigurationTest.java  |    5 +-
 .../SlotManagerFailUnfulfillableTest.java          |   39 +-
 .../slotmanager/SlotManagerImplTest.java           |  320 +-
 .../slotmanager/SlotProtocolTest.java              |   29 +-
 .../TaskManagerReleaseInSlotManagerTest.java       |    3 +-
 .../slotmanager/TestingResourceActions.java        |   14 +-
 .../slotmanager/TestingResourceActionsBuilder.java |   19 +-
 .../slotmanager/TestingSlotManager.java            |   38 +-
 .../slotmanager/TestingSlotManagerBuilder.java     |   13 +-
 .../utils/TestingResourceManagerGateway.java       |  122 +-
 .../flink/runtime/rest/FileUploadHandlerTest.java  |   22 +-
 .../runtime/rest/RestServerEndpointITCase.java     |   49 +-
 .../runtime/rest/RestServerSSLAuthITCase.java      |   88 +-
 .../AbstractAsynchronousOperationHandlersTest.java |    2 +-
 .../cluster/JobManagerLogListHandlerTest.java      |  131 +
 .../rest/handler/job/JobConfigHandlerTest.java     |    4 +-
 .../rest/handler/job/JobExceptionsHandlerTest.java |    4 +-
 .../handler/job/JobExecutionResultHandlerTest.java |    2 +-
 .../SubtaskCurrentAttemptDetailsHandlerTest.java   |    4 +-
 ...askExecutionAttemptAccumulatorsHandlerTest.java |    4 +-
 .../SubtaskExecutionAttemptDetailsHandlerTest.java |    4 +-
 .../metrics/JobVertexWatermarksHandlerTest.java    |  176 +
 .../legacy/DefaultExecutionGraphCacheTest.java     |  316 +
 .../handler/legacy/ExecutionGraphCacheTest.java    |  315 -
 .../BackPressureRequestCoordinatorTest.java        |  343 ++
 .../BackPressureStatsTrackerImplTest.java          |  293 +-
 .../StackTraceSampleCoordinatorTest.java           |  421 --
 .../legacy/utils/ArchivedExecutionBuilder.java     |  157 -
 .../utils/ArchivedExecutionGraphBuilder.java       |    5 +-
 .../utils/ArchivedExecutionJobVertexBuilder.java   |   86 -
 .../utils/ArchivedExecutionVertexBuilder.java      |   73 -
 .../AbstractTaskManagerFileHandlerTest.java        |    8 +-
 .../taskmanager/TaskManagerLogListHandlerTest.java |  116 +
 .../rest/messages/ResourceProfileInfoTest.java     |   55 +
 .../checkpoints/CheckpointConfigInfoTest.java      |    3 +-
 ...CheckpointStatisticsWithSubtaskDetailsTest.java |    6 +-
 .../ClusterDataSetListResponseBodyTest.java        |   85 +
 .../rest/messages/job/JobDetailsInfoTest.java      |    2 +-
 .../rest/messages/taskmanager/LogListInfoTest.java |   45 +
 .../messages/taskmanager/TaskManagerInfoTest.java  |    3 +
 .../messages/taskmanager/ThreadDumpInfoTest.java   |   52 +
 .../util/DocumentingDispatcherRestEndpoint.java    |   58 +-
 .../runtime/rest/util/NoOpExecutionGraphCache.java |   50 +
 .../flink/runtime/rpc/FencedRpcEndpointTest.java   |    4 +-
 .../runtime/rpc/akka/ActorSystemResource.java      |   64 +
 .../runtime/rpc/akka/AkkaActorSystemTest.java      |   89 +
 .../AkkaRpcActorOversizedResponseMessageTest.java  |    6 +-
 .../flink/runtime/rpc/akka/AkkaRpcActorTest.java   |  123 +
 .../runtime/rpc/akka/MessageSerializationTest.java |    4 +-
 .../runtime/rpc/akka/SupervisorActorTest.java      |  249 +
 .../runtime/rpc/akka/TimeoutCallStackTest.java     |  135 +
 .../AbstractExecutionSlotAllocatorTest.java        |  178 +
 ...ecutionSlotAllocatorPreferredLocationsTest.java |  116 -
 .../DefaultExecutionSlotAllocatorTest.java         |  215 +-
 .../DefaultPreferredLocationsRetrieverTest.java    |  190 +
 .../DefaultSchedulerBatchSchedulingTest.java       |  211 +
 .../runtime/scheduler/DefaultSchedulerTest.java    |  366 +-
 .../runtime/scheduler/DeploymentHandleTest.java    |   97 +
 ...GraphToInputsLocationsRetrieverAdapterTest.java |    9 +-
 .../scheduler/ExecutionSlotAllocatorTestUtils.java |   61 +
 .../LegacySchedulerBatchSchedulingTest.java        |  239 -
 .../OneSlotPerExecutionSlotAllocatorTest.java      |  304 +
 .../runtime/scheduler/SchedulerTestingUtils.java   |  517 ++
 .../scheduler/TestExecutionSlotAllocator.java      |   32 +-
 .../TestExecutionSlotAllocatorFactory.java         |   14 +-
 .../TestExecutionVertexOperationsDecorator.java    |    5 +
 .../scheduler/TestingStateLocationRetriever.java   |   43 +
 .../adapter/DefaultExecutionTopologyTest.java      |   52 +-
 .../adapter/DefaultExecutionVertexTest.java        |    6 +-
 .../adapter/DefaultResultPartitionTest.java        |   53 +-
 .../DefaultSchedulingPipelinedRegionTest.java      |  127 +
 .../strategy/EagerSchedulingStrategyTest.java      |   78 +-
 .../InputDependencyConstraintCheckerTest.java      |   17 +-
 .../LazyFromSourcesSchedulingStrategyTest.java     |   99 +-
 .../PipelinedRegionSchedulingStrategyTest.java     |  160 +
 .../scheduler/strategy/StrategyTestUtil.java       |    6 +-
 .../scheduler/strategy/TestSchedulingStrategy.java |   21 +-
 .../strategy/TestingSchedulerOperations.java       |   11 +-
 .../strategy/TestingSchedulingExecutionVertex.java |    3 +-
 .../strategy/TestingSchedulingPipelinedRegion.java |   66 +
 .../strategy/TestingSchedulingResultPartition.java |    9 +-
 .../strategy/TestingSchedulingTopology.java        |  128 +-
 .../flink/runtime/security/SecurityUtilsTest.java  |  178 +-
 ...notherCompatibleTestSecurityContextFactory.java |   52 +
 .../IncompatibleTestSecurityContextFactory.java    |   52 +
 .../LinkageErrorSecurityContextFactory.java        |   38 +
 .../contexts/TestSecurityContextFactory.java       |   51 +
 .../runtime/security/modules/JaasModuleTest.java   |   88 +
 .../modules/TestSecurityModuleFactory.java         |   49 +
 .../shuffle/PartitionDescriptorBuilder.java        |   60 +
 .../runtime/shuffle/ShuffleServiceLoaderTest.java  |    6 +-
 .../source/coordinator/CoordinatorTestUtils.java   |   84 +
 .../source/coordinator/ExecutorNotifierTest.java   |  116 +
 .../coordinator/SourceCoordinatorContextTest.java  |  188 +
 .../coordinator/SourceCoordinatorProviderTest.java |   99 +
 .../source/coordinator/SourceCoordinatorTest.java  |  236 +
 .../coordinator/SourceCoordinatorTestBase.java     |   88 +
 .../coordinator/SplitAssignmentTrackerTest.java    |  173 +
 .../state/ArrayListSerializerMigrationTest.java    |   57 -
 .../state/ArrayListSerializerUpgradeTest.java      |  107 +
 .../runtime/state/ChannelPersistenceITCase.java    |  180 +
 .../IncrementalRemoteKeyedStateHandleTest.java     |    4 +-
 .../state/JavaSerializerSnapshotMigrationTest.java |   57 -
 .../runtime/state/JavaSerializerUpgradeTest.java   |  105 +
 .../runtime/state/KeyGroupsStateHandleTest.java    |   59 +
 .../runtime/state/OperatorStateBackendTest.java    |    4 +-
 .../runtime/state/SharedStateRegistryTest.java     |    6 +
 .../flink/runtime/state/SnapshotDirectoryTest.java |   48 +-
 .../runtime/state/StateBackendLoadingTest.java     |   20 +-
 .../state/StateBackendMigrationTestBase.java       |   25 +-
 .../flink/runtime/state/StateBackendTestBase.java  |  261 +-
 .../state/StateSnapshotTransformerTest.java        |    2 +-
 .../TaskExecutorLocalStateStoresManagerTest.java   |   72 +-
 .../runtime/state/TaskLocalStateStoreImplTest.java |   23 +-
 .../runtime/state/TaskStateManagerImplTest.java    |    6 +-
 .../state/TestCheckpointStorageWorkerView.java     |   52 +
 .../runtime/state/TestTaskLocalStateStore.java     |   19 +
 .../flink/runtime/state/TestTaskStateManager.java  |   28 +-
 .../TestingCheckpointStorageCoordinatorView.java   |  181 +
 .../runtime/state/TestingStreamStateHandle.java    |   50 +
 .../state/VoidNamespaceSerializerUpgradeTest.java  |  102 +
 ...dNamespacieSerializerSnapshotMigrationTest.java |   55 -
 .../FsCheckpointStateOutputStreamTest.java         |   44 +-
 .../state/filesystem/FsCheckpointStorageTest.java  |    8 +-
 .../filesystem/FsCheckpointStreamFactoryTest.java  |  154 +
 .../filesystem/FsStateBackendEntropyTest.java      |    9 +-
 ...HeapKeyedStateBackendSnapshotMigrationTest.java |  135 -
 .../state/testutils/BackendForTestStream.java      |    4 +-
 .../state/testutils/EmptyStreamStateHandle.java    |    6 +
 .../runtime/state/ttl/MockTtlTimeProvider.java     |    4 +
 .../runtime/state/ttl/StateBackendTestContext.java |   10 +-
 .../ttl/TtlMapStateAllEntriesTestContext.java      |    7 +
 .../state/ttl/TtlSerializerStateMigrationTest.java |   60 -
 .../state/ttl/TtlSerializerUpgradeTest.java        |  105 +
 .../flink/runtime/state/ttl/TtlStateTestBase.java  |   10 +-
 .../runtime/state/ttl/TtlStateTestContextBase.java |    6 +
 .../flink/runtime/state/ttl/TtlValueMatchers.java  |   67 +
 .../state/ttl/mock/MockKeyedStateBackend.java      |    5 +
 .../BackPressureSampleServiceTest.java             |  123 +
 .../taskexecutor/DefaultJobLeaderServiceTest.java  |  284 +
 .../runtime/taskexecutor/DefaultJobTableTest.java  |  196 +
 .../NettyShuffleEnvironmentConfigurationTest.java  |  289 +-
 .../taskexecutor/NetworkBufferCalculationTest.java |  115 -
 .../taskexecutor/StackTraceSampleServiceTest.java  |  189 -
 .../runtime/taskexecutor/TaskExecutorITCase.java   |    3 -
 .../TaskExecutorOperatorEventHandlingTest.java     |  216 +
 .../TaskExecutorPartitionLifecycleTest.java        |  397 +-
 .../TaskExecutorResourceUtilsTest.java             |  137 +
 .../taskexecutor/TaskExecutorSlotLifetimeTest.java |  227 +
 .../taskexecutor/TaskExecutorSubmissionTest.java   |  277 +-
 .../runtime/taskexecutor/TaskExecutorTest.java     | 1166 ++--
 ...askExecutorToResourceManagerConnectionTest.java |   27 +-
 .../TaskManagerRunnerConfigurationTest.java        |   29 +-
 .../taskexecutor/TaskManagerRunnerStartupTest.java |   55 +-
 .../taskexecutor/TaskManagerRunnerTest.java        |   14 +-
 .../taskexecutor/TaskManagerServicesBuilder.java   |   74 +-
 .../TaskSubmissionTestEnvironment.java             |  151 +-
 .../taskexecutor/TestTaskManagerActions.java       |    5 +-
 .../taskexecutor/TestingJobLeaderService.java      |  140 +
 .../runtime/taskexecutor/TestingJobServices.java   |   76 +
 .../TestingPartitionProducerStateChecker.java      |   60 +
 .../runtime/taskexecutor/TestingTaskExecutor.java  |   17 +-
 .../taskexecutor/TestingTaskExecutorGateway.java   |   81 +-
 .../TestingTaskExecutorGatewayBuilder.java         |   41 +-
 .../taskexecutor/slot/TaskSlotTableImplTest.java   |  366 ++
 .../taskexecutor/slot/TaskSlotTableTest.java       |  123 -
 .../runtime/taskexecutor/slot/TaskSlotTest.java    |   60 +
 .../runtime/taskexecutor/slot/TaskSlotUtils.java   |   80 +
 .../taskexecutor/slot/TestingTaskSlotPayload.java  |   78 +
 .../taskexecutor/slot/TestingTaskSlotTable.java    |  267 +
 .../taskexecutor/slot/ThreadSafeTaskSlotTable.java |  206 +
 .../LocalUnresolvedTaskManagerLocation.java        |   32 +
 .../taskmanager/NoOpCheckpointResponder.java       |   37 +
 .../taskmanager/NoOpTaskOperatorEventGateway.java  |   34 +
 .../runtime/taskmanager/TaskAsyncCallTest.java     |   23 +-
 .../TaskCancelAsyncProducerConsumerITCase.java     |   10 +-
 .../apache/flink/runtime/taskmanager/TaskTest.java |  157 +-
 .../flink/runtime/taskmanager/TestTaskBuilder.java |   67 +-
 .../taskmanager/TestingTaskManagerActions.java     |   92 +
 .../runtime/testtasks/OutputBlockedInvokable.java  |   47 +
 .../runtime/testutils/CancelableInvokable.java     |   50 +
 .../flink/runtime/testutils/CommonTestUtils.java   |   18 +-
 .../runtime/testutils/MiniClusterResource.java     |    7 +-
 .../RecoverableCompletedCheckpointStore.java       |    2 +-
 .../flink/runtime/testutils/TestJvmProcess.java    |    2 +-
 .../flink/runtime/util/AddressResolutionTest.java  |   90 +
 .../runtime/util/EnvironmentInformationTest.java   |   32 +-
 .../runtime/util/JvmExitOnFatalErrorTest.java      |   51 +-
 .../flink/runtime/util/KeyedBudgetManagerTest.java |  262 -
 .../apache/flink/runtime/util/RunnablesTest.java   |  120 +
 .../flink/runtime/util/SerializableFunction.java   |   31 +
 .../util/TestingFatalErrorHandlerResource.java     |   93 +
 .../runtime/util/TestingScheduledExecutor.java     |   62 -
 .../util/TestingTaskManagerRuntimeInfo.java        |   15 +
 .../flink/runtime/util/bash/BashJavaUtilsTest.java |   49 +
 .../runtime/util/bash/FlinkConfigLoaderTest.java   |   96 +
 .../flink/runtime/util/clock/ManualClock.java      |   49 -
 .../config/memory/ProcessMemoryUtilsTestBase.java  |  384 ++
 .../webmonitor/TestingDispatcherGateway.java       |   37 +-
 .../webmonitor/TestingExecutionGraphCache.java     |  113 +
 .../runtime/webmonitor/TestingRestfulGateway.java  |   55 +-
 .../runtime/webmonitor/WebMonitorEndpointTest.java |   79 +
 .../retriever/impl/RpcGatewayRetrieverTest.java    |    3 +-
 .../flink/runtime/zookeeper/ZooKeeperResource.java |    5 +
 .../zookeeper/ZooKeeperStateHandleStoreTest.java   |    5 +-
 .../zookeeper/ZooKeeperTestEnvironment.java        |   19 +-
 ...untime.security.contexts.SecurityContextFactory |   19 +
 ....runtime.security.modules.SecurityModuleFactory |   16 +
 .../arraylist-serializer-1.11/serializer-snapshot  |  Bin 0 -> 178 bytes
 .../resources/arraylist-serializer-1.11/test-data  |  Bin 0 -> 17 bytes
 .../resources/flink-1.6-arraylist-serializer-data  |  Bin 240 -> 0 bytes
 .../flink-1.6-arraylist-serializer-snapshot        |  Bin 881 -> 0 bytes
 .../test/resources/flink-1.6-java-serializer-data  |  Bin 180 -> 0 bytes
 .../resources/flink-1.6-java-serializer-snapshot   |  Bin 366 -> 0 bytes
 .../test/resources/flink-1.6-ttl-serializer-data   |  Bin 230 -> 0 bytes
 .../resources/flink-1.6-ttl-serializer-snapshot    |  Bin 1753 -> 0 bytes
 .../flink-1.6-void-namespace-serializer-data       |  Bin 10 -> 0 bytes
 .../flink-1.6-void-namespace-serializer-snapshot   |  Bin 384 -> 0 bytes
 .../resources/flink-1.7-arraylist-serializer-data  |  Bin 240 -> 0 bytes
 .../flink-1.7-arraylist-serializer-snapshot        |  Bin 231 -> 0 bytes
 .../test/resources/flink-1.7-java-serializer-data  |  Bin 180 -> 0 bytes
 .../resources/flink-1.7-java-serializer-snapshot   |  Bin 354 -> 0 bytes
 .../test/resources/flink-1.7-ttl-serializer-data   |  Bin 230 -> 0 bytes
 .../resources/flink-1.7-ttl-serializer-snapshot    |  Bin 1763 -> 0 bytes
 .../flink-1.7-void-namespace-serializer-data       |  Bin 10 -> 0 bytes
 .../flink-1.7-void-namespace-serializer-snapshot   |  Bin 372 -> 0 bytes
 .../resources/heap_keyed_statebackend_1_2.snapshot |  Bin 2068 -> 0 bytes
 .../java-serializer-1.11/serializer-snapshot       |  Bin 0 -> 78 bytes
 .../test/resources/java-serializer-1.11/test-data  |  Bin 0 -> 81 bytes
 .../src/test/resources/log4j-test.properties       |   32 -
 .../src/test/resources/log4j2-test.properties      |   32 +
 .../ttl-serializer-1.11/serializer-snapshot        |  Bin 0 -> 278 bytes
 .../test/resources/ttl-serializer-1.11/test-data   |  Bin 0 -> 21 bytes
 .../serializer-snapshot                            |  Bin 0 -> 96 bytes
 .../void-namespace-serializer-1.11/test-data       |  Bin 0 -> 1 bytes
 .../apache/flink/runtime/akka/AkkaUtilsTest.scala  |   37 +-
 flink-scala-shell/pom.xml                          |    2 +-
 .../flink/api/java/ScalaShellEnvironment.java      |  103 +
 .../api/java/ScalaShellRemoteEnvironment.java      |   96 -
 .../java/ScalaShellRemoteStreamEnvironment.java    |  125 -
 .../api/java/ScalaShellStreamEnvironment.java      |  106 +
 .../org/apache/flink/api/scala/FlinkILoop.scala    |   67 +-
 .../org/apache/flink/api/scala/FlinkShell.scala    |  290 +-
 .../org/apache/flink/api/java/FlinkILoopTest.java  |  126 +-
 .../src/test/resources/log4j-test.properties       |   23 -
 .../apache/flink/api/scala/ScalaShellITCase.scala  |   40 +-
 .../start-script/start-scala-shell.sh              |   10 +-
 flink-scala/pom.xml                                |    2 +-
 .../ScalaCaseClassSerializerSnapshot.java          |    6 +-
 .../typeutils/TraversableSerializerSnapshot.java   |    6 +-
 .../Tuple2CaseClassSerializerSnapshot.java         |    6 +-
 .../flink/api/scala/ExecutionEnvironment.scala     |   84 +-
 .../api/scala/typeutils/CaseClassSerializer.scala  |   17 +-
 ...ScalaEitherSerializerSnapshotMigrationTest.java |   59 -
 .../ScalaEitherSerializerUpgradeTest.java          |  107 +
 ...ScalaOptionSerializerSnapshotMigrationTest.java |   58 -
 .../ScalaOptionSerializerUpgradeTest.java          |  104 +
 .../ScalaTrySerializerSnapshotMigrationTest.java   |   59 -
 .../typeutils/ScalaTrySerializerUpgradeTest.java   |  129 +
 .../flink-1.6-scala-case-class-serializer-data     |  Bin 100 -> 0 bytes
 .../flink-1.6-scala-case-class-serializer-snapshot |  Bin 1857 -> 0 bytes
 .../flink-1.6-scala-either-serializer-data         |  Bin 130 -> 0 bytes
 .../flink-1.6-scala-either-serializer-snapshot     |  Bin 1358 -> 0 bytes
 .../resources/flink-1.6-scala-enum-serializer-data |  Bin 40 -> 0 bytes
 .../flink-1.6-scala-enum-serializer-snapshot       |  Bin 1865 -> 0 bytes
 .../flink-1.6-scala-option-serializer-data         |  Bin 31 -> 0 bytes
 .../flink-1.6-scala-option-serializer-snapshot     |  Bin 876 -> 0 bytes
 .../resources/flink-1.6-scala-try-serializer-data  |  Bin 1658 -> 0 bytes
 .../flink-1.6-scala-try-serializer-snapshot        |  Bin 7054 -> 0 bytes
 .../flink-1.6-traversable-serializer-bitset-data   |  Bin 140 -> 0 bytes
 ...link-1.6-traversable-serializer-bitset-snapshot |  Bin 992 -> 0 bytes
 ...link-1.6-traversable-serializer-indexedseq-data |  Bin 130 -> 0 bytes
 ...-1.6-traversable-serializer-indexedseq-snapshot |  Bin 992 -> 0 bytes
 ...flink-1.6-traversable-serializer-linearseq-data |  Bin 130 -> 0 bytes
 ...k-1.6-traversable-serializer-linearseq-snapshot |  Bin 992 -> 0 bytes
 .../flink-1.6-traversable-serializer-map-data      |  Bin 138 -> 0 bytes
 .../flink-1.6-traversable-serializer-map-snapshot  |  Bin 3033 -> 0 bytes
 ...nk-1.6-traversable-serializer-mutable-list-data |  Bin 160 -> 0 bytes
 ....6-traversable-serializer-mutable-list-snapshot |  Bin 993 -> 0 bytes
 .../flink-1.6-traversable-serializer-seq-data      |  Bin 130 -> 0 bytes
 .../flink-1.6-traversable-serializer-seq-snapshot  |  Bin 992 -> 0 bytes
 .../flink-1.6-traversable-serializer-set-data      |  Bin 135 -> 0 bytes
 .../flink-1.6-traversable-serializer-set-snapshot  |  Bin 992 -> 0 bytes
 ...1.6-traversable-serializer-with-case-class-data |  Bin 145 -> 0 bytes
 ...traversable-serializer-with-case-class-snapshot |  Bin 3036 -> 0 bytes
 ...flink-1.6-traversable-serializer-with-pojo-data |  Bin 253 -> 0 bytes
 ...k-1.6-traversable-serializer-with-pojo-snapshot |  Bin 6854 -> 0 bytes
 .../flink-1.7-scala-case-class-serializer-data     |  Bin 100 -> 0 bytes
 .../flink-1.7-scala-case-class-serializer-snapshot |  Bin 1865 -> 0 bytes
 .../flink-1.7-scala-either-serializer-data         |  Bin 130 -> 0 bytes
 .../flink-1.7-scala-either-serializer-snapshot     |  Bin 381 -> 0 bytes
 .../resources/flink-1.7-scala-enum-serializer-data |  Bin 40 -> 0 bytes
 .../flink-1.7-scala-enum-serializer-snapshot       |  Bin 1853 -> 0 bytes
 .../flink-1.7-scala-option-serializer-data         |  Bin 31 -> 0 bytes
 .../flink-1.7-scala-option-serializer-snapshot     |  Bin 877 -> 0 bytes
 .../resources/flink-1.7-scala-try-serializer-data  |  Bin 1658 -> 0 bytes
 .../flink-1.7-scala-try-serializer-snapshot        |  Bin 8932 -> 0 bytes
 .../flink-1.7-traversable-serializer-bitset-data   |  Bin 140 -> 0 bytes
 ...link-1.7-traversable-serializer-bitset-snapshot |  Bin 987 -> 0 bytes
 ...link-1.7-traversable-serializer-indexedseq-data |  Bin 130 -> 0 bytes
 ...-1.7-traversable-serializer-indexedseq-snapshot |  Bin 987 -> 0 bytes
 ...flink-1.7-traversable-serializer-linearseq-data |  Bin 130 -> 0 bytes
 ...k-1.7-traversable-serializer-linearseq-snapshot |  Bin 987 -> 0 bytes
 .../flink-1.7-traversable-serializer-map-data      |  Bin 138 -> 0 bytes
 .../flink-1.7-traversable-serializer-map-snapshot  |  Bin 3905 -> 0 bytes
 ...nk-1.7-traversable-serializer-mutable-list-data |  Bin 160 -> 0 bytes
 ....7-traversable-serializer-mutable-list-snapshot |  Bin 988 -> 0 bytes
 .../flink-1.7-traversable-serializer-seq-data      |  Bin 130 -> 0 bytes
 .../flink-1.7-traversable-serializer-seq-snapshot  |  Bin 987 -> 0 bytes
 .../flink-1.7-traversable-serializer-set-data      |  Bin 135 -> 0 bytes
 .../flink-1.7-traversable-serializer-set-snapshot  |  Bin 987 -> 0 bytes
 ...1.7-traversable-serializer-with-case-class-data |  Bin 145 -> 0 bytes
 ...traversable-serializer-with-case-class-snapshot |  Bin 3909 -> 0 bytes
 ...flink-1.7-traversable-serializer-with-pojo-data |  Bin 253 -> 0 bytes
 ...k-1.7-traversable-serializer-with-pojo-snapshot |  Bin 9607 -> 0 bytes
 .../src/test/resources/log4j-test.properties       |   31 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../serializer-snapshot                            |  Bin 0 -> 323 bytes
 .../scala-case-class-serializer-1.11/test-data     |  Bin 0 -> 10 bytes
 .../serializer-snapshot                            |  Bin 0 -> 270 bytes
 .../scala-either-serializer-1.11/test-data         |  Bin 0 -> 13 bytes
 .../scala-enum-serializer-1.11/serializer-snapshot |  Bin 0 -> 146 bytes
 .../resources/scala-enum-serializer-1.11/test-data |  Bin 0 -> 4 bytes
 .../serializer-snapshot                            |  Bin 0 -> 186 bytes
 .../scala-option-serializer-1.11/test-data         |  Bin 0 -> 1 bytes
 .../scala-try-serializer-1.11/serializer-snapshot  |  Bin 0 -> 672 bytes
 .../resources/scala-try-serializer-1.11/test-data  |  Bin 0 -> 3144 bytes
 .../serializer-snapshot                            |  Bin 0 -> 286 bytes
 .../traversable-serializer-bitset-1.11/test-data   |  Bin 0 -> 19 bytes
 .../serializer-snapshot                            |  Bin 0 -> 270 bytes
 .../test-data                                      |  Bin 0 -> 19 bytes
 .../serializer-snapshot                            |  Bin 0 -> 302 bytes
 .../test-data                                      |  Bin 0 -> 19 bytes
 .../serializer-snapshot                            |  Bin 0 -> 479 bytes
 .../traversable-serializer-map-1.11/test-data      |  Bin 0 -> 27 bytes
 .../serializer-snapshot                            |  Bin 0 -> 322 bytes
 .../test-data                                      |  Bin 0 -> 19 bytes
 .../serializer-snapshot                            |  Bin 0 -> 256 bytes
 .../traversable-serializer-seq-1.11/test-data      |  Bin 0 -> 19 bytes
 .../serializer-snapshot                            |  Bin 0 -> 256 bytes
 .../traversable-serializer-set-1.11/test-data      |  Bin 0 -> 19 bytes
 .../serializer-snapshot                            |  Bin 0 -> 485 bytes
 .../test-data                                      |  Bin 0 -> 27 bytes
 .../serializer-snapshot                            |  Bin 0 -> 977 bytes
 .../test-data                                      |  Bin 0 -> 33 bytes
 .../EnumValueSerializerCompatibilityTest.scala     |  208 +
 .../EnumValueSerializerSnapshotMigrationTest.scala |   61 -
 .../typeutils/EnumValueSerializerUpgradeTest.scala |  231 +-
 ...aCaseClassSerializerSnapshotMigrationTest.scala |   71 -
 .../ScalaCaseClassSerializerUpgradeTest.scala      |   89 +
 ...raversableSerializerSnapshotMigrationTest.scala |  118 -
 .../TraversableSerializerUpgradeTest.scala         |  326 +
 flink-shaded-curator/pom.xml                       |   88 -
 .../src/main/resources/META-INF/NOTICE             |   12 -
 .../flink-statebackend-heap-spillable/pom.xml      |    4 +-
 .../flink-statebackend-rocksdb/pom.xml             |   35 +-
 .../state/ConfigurableOptionsFactory.java          |   39 -
 .../state/ConfigurableRocksDBOptionsFactory.java   |   39 +
 .../state/DefaultConfigurableOptionsFactory.java   |  121 +-
 .../contrib/streaming/state/OptionsFactory.java    |   84 -
 .../contrib/streaming/state/PredefinedOptions.java |   81 +-
 .../streaming/state/RocksDBAggregatingState.java   |    2 +-
 .../state/RocksDBConfigurableOptions.java          |   56 +-
 .../state/RocksDBIncrementalCheckpointUtils.java   |   12 +-
 .../streaming/state/RocksDBKeyedStateBackend.java  |   41 +-
 .../state/RocksDBKeyedStateBackendBuilder.java     |   52 +-
 .../contrib/streaming/state/RocksDBListState.java  |    2 +-
 .../contrib/streaming/state/RocksDBMapState.java   |   13 +-
 .../state/RocksDBMemoryConfiguration.java          |  208 +
 .../state/RocksDBMemoryControllerUtils.java        |   98 +
 .../state/RocksDBNativeMetricMonitor.java          |    4 +-
 .../state/RocksDBNativeMetricOptions.java          |  118 +-
 .../streaming/state/RocksDBOperationUtils.java     |   60 +
 .../contrib/streaming/state/RocksDBOptions.java    |   65 +-
 .../streaming/state/RocksDBOptionsFactory.java     |   93 +
 .../contrib/streaming/state/RocksDBProperty.java   |    6 +-
 .../streaming/state/RocksDBReducingState.java      |    2 +-
 .../streaming/state/RocksDBResourceContainer.java  |  165 +
 .../streaming/state/RocksDBSharedResources.java    |   52 +
 .../streaming/state/RocksDBStateBackend.java       |  273 +-
 .../state/RocksDBStateBackendFactory.java          |    6 +-
 .../streaming/state/RocksDBStateDownloader.java    |   14 +-
 .../streaming/state/RocksDBStateUploader.java      |   14 +-
 .../streaming/state/RocksDBWriteBatchWrapper.java  |   47 +-
 .../state/restore/RocksDBFullRestoreOperation.java |   14 +-
 .../RocksDBIncrementalRestoreOperation.java        |   59 +-
 .../state/snapshot/RocksFullSnapshotStrategy.java  |    7 +-
 .../snapshot/RocksIncrementalSnapshotStrategy.java |   29 +-
 .../state/ttl/RocksDbTtlCompactFiltersManager.java |   13 +-
 .../streaming/state/RocksDBAsyncSnapshotTest.java  |   10 +-
 .../RocksDBIncrementalCheckpointUtilsTest.java     |    3 +-
 .../streaming/state/RocksDBInitResetTest.java      |   32 -
 .../contrib/streaming/state/RocksDBInitTest.java   |   72 +
 .../state/RocksDBMemoryControllerUtilsTest.java    |  100 +
 .../state/RocksDBNativeMetricMonitorTest.java      |    5 -
 .../state/RocksDBOperationsUtilsTest.java          |   88 +
 .../contrib/streaming/state/RocksDBResource.java   |   26 +-
 .../state/RocksDBResourceContainerTest.java        |  249 +
 .../state/RocksDBRocksStateKeysIteratorTest.java   |    7 +-
 .../state/RocksDBStateBackendConfigTest.java       |  309 +-
 .../state/RocksDBStateBackendMigrationTest.java    |    4 +-
 .../streaming/state/RocksDBStateBackendTest.java   |   89 +-
 .../state/RocksDBStateDownloaderTest.java          |   14 +-
 .../streaming/state/RocksDBStateUploaderTest.java  |   13 +-
 .../contrib/streaming/state/RocksDBTestUtils.java  |  101 +
 .../state/RocksDBWriteBatchWrapperTest.java        |   54 +-
 .../state/RocksDbMultiClassLoaderTest.java         |    5 +-
 .../benchmark/StateBackendBenchmarkUtils.java      |  198 +
 .../benchmark/StateBackendBenchmarkUtilsTest.java  |  133 +
 .../state/ttl/RocksDBTtlStateTestBase.java         |    8 +-
 .../src/test/resources/log4j-test.properties       |   30 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 flink-state-backends/pom.xml                       |    2 +-
 flink-streaming-java/pom.xml                       |   11 +-
 .../api/checkpoint/CheckpointedFunction.java       |    6 +-
 .../streaming/api/checkpoint/ListCheckpointed.java |    4 +
 .../streaming/api/datastream/CoGroupedStreams.java |   20 +-
 .../flink/streaming/api/datastream/DataStream.java |  183 +-
 .../streaming/api/datastream/DataStreamSink.java   |    5 -
 .../streaming/api/datastream/DataStreamSource.java |   40 +-
 .../streaming/api/datastream/DataStreamUtils.java  |   85 +-
 .../streaming/api/datastream/KeyedStream.java      |   23 +-
 .../api/datastream/MultipleConnectedStreams.java   |   47 +
 .../api/datastream/SingleOutputStreamOperator.java |    4 +-
 .../api/environment/CheckpointConfig.java          |   79 +-
 .../environment/ExecutionCheckpointingOptions.java |  145 +
 .../api/environment/LocalStreamEnvironment.java    |   38 +-
 .../api/environment/RemoteStreamEnvironment.java   |  250 +-
 .../api/environment/StreamContextEnvironment.java  |   71 -
 .../environment/StreamExecutionEnvironment.java    |  439 +-
 .../api/environment/StreamPipelineOptions.java     |   48 +
 .../api/environment/StreamPlanEnvironment.java     |   65 -
 .../functions/AssignerWithPeriodicWatermarks.java  |    1 +
 .../AssignerWithPunctuatedWatermarks.java          |    1 +
 .../api/functions/IngestionTimeExtractor.java      |    1 +
 .../streaming/api/functions/TimestampAssigner.java |   10 +-
 .../api/functions/TimestampExtractor.java          |   74 -
 .../api/functions/async/RichAsyncFunction.java     |   14 +-
 .../api/functions/sink/SocketClientSink.java       |    3 +-
 .../functions/sink/TwoPhaseCommitSinkFunction.java |    7 +-
 .../sink/filesystem/AbstractPartFileWriter.java    |   58 +
 .../api/functions/sink/filesystem/Bucket.java      |  192 +-
 .../functions/sink/filesystem/BucketFactory.java   |   11 +-
 .../sink/filesystem/BucketLifeCycleListener.java   |   44 +
 .../api/functions/sink/filesystem/BucketState.java |   32 +-
 .../sink/filesystem/BucketStateSerializer.java     |  146 +-
 .../functions/sink/filesystem/BucketWriter.java    |  109 +
 .../api/functions/sink/filesystem/Buckets.java     |   96 +-
 .../sink/filesystem/BulkBucketWriter.java          |   72 +
 .../functions/sink/filesystem/BulkPartWriter.java  |   56 +-
 .../sink/filesystem/DefaultBucketFactoryImpl.java  |   21 +-
 .../sink/filesystem/InProgressFileWriter.java      |   70 +
 .../sink/filesystem/OutputFileConfig.java          |   98 +
 .../OutputStreamBasedPartFileWriter.java           |  296 +
 .../functions/sink/filesystem/PartFileConfig.java  |   53 -
 .../functions/sink/filesystem/PartFileWriter.java  |  141 -
 .../sink/filesystem/RowWiseBucketWriter.java       |   68 +
 .../sink/filesystem/RowWisePartWriter.java         |   50 +-
 .../sink/filesystem/StreamingFileSink.java         |  225 +-
 .../sink/filesystem/StreamingFileSinkHelper.java   |  110 +
 .../sink/filesystem/WriterProperties.java          |   67 +
 .../rollingpolicies/CheckpointRollingPolicy.java   |   51 +
 .../rollingpolicies/OnCheckpointRollingPolicy.java |    9 +-
 .../source/ContinuousFileMonitoringFunction.java   |   15 +-
 .../source/ContinuousFileReaderOperator.java       |  639 +-
 .../ContinuousFileReaderOperatorFactory.java       |   82 +
 .../source/MessageAcknowledgingSourceBase.java     |   12 +-
 .../functions/source/SocketTextStreamFunction.java |    3 +-
 .../source/TimestampedFileInputSplit.java          |   36 +-
 .../functions/source/TimestampedInputSplit.java    |   62 +
 .../functions/source/datagen/DataGenerator.java    |   53 +
 .../source/datagen/DataGeneratorSource.java        |  102 +
 .../functions/source/datagen/RandomGenerator.java  |  119 +
 .../source/datagen/SequenceGenerator.java          |  177 +
 .../timestamps/AscendingTimestampExtractor.java    |    1 +
 .../api/graph/GlobalDataExchangeMode.java          |   48 +
 .../flink/streaming/api/graph/JSONGenerator.java   |   28 +-
 .../flink/streaming/api/graph/StreamConfig.java    |   87 +-
 .../flink/streaming/api/graph/StreamEdge.java      |    7 +-
 .../flink/streaming/api/graph/StreamGraph.java     |  224 +-
 .../streaming/api/graph/StreamGraphGenerator.java  |  107 +-
 .../streaming/api/graph/StreamGraphHasherV2.java   |   20 +-
 .../streaming/api/graph/StreamGraphTranslator.java |   69 -
 .../flink/streaming/api/graph/StreamNode.java      |   82 +-
 .../api/graph/StreamingJobGraphGenerator.java      |  424 +-
 .../streaming/api/operators/AbstractInput.java     |   71 +
 .../api/operators/AbstractStreamOperator.java      |  391 +-
 .../operators/AbstractStreamOperatorFactory.java   |   50 +
 .../api/operators/AbstractStreamOperatorV2.java    |  513 ++
 .../api/operators/AbstractUdfStreamOperator.java   |    9 +
 .../api/operators/CoordinatedOperatorFactory.java  |   45 +
 .../streaming/api/operators/CountingOutput.java    |   65 +
 .../flink/streaming/api/operators/Input.java       |   54 +
 .../streaming/api/operators/InputSelection.java    |   78 +-
 .../api/operators/InternalTimeServiceManager.java  |   64 +
 .../api/operators/InternalTimerServiceImpl.java    |    2 +
 .../streaming/api/operators/MailboxExecutor.java   |   66 +-
 .../api/operators/MultipleInputStreamOperator.java |   31 +
 .../api/operators/OperatorSnapshotFinalizer.java   |   15 +-
 .../api/operators/OperatorSnapshotFutures.java     |  106 +-
 .../api/operators/SetupableStreamOperator.java     |    4 +
 .../api/operators/SimpleOperatorFactory.java       |   29 +-
 .../streaming/api/operators/SourceOperator.java    |  236 +
 .../api/operators/SourceOperatorFactory.java       |  133 +
 .../api/operators/SourceReaderOperator.java        |   34 -
 .../streaming/api/operators/StreamOperator.java    |    6 +-
 .../api/operators/StreamOperatorFactory.java       |    9 +-
 .../api/operators/StreamOperatorFactoryUtil.java   |   45 +-
 .../api/operators/StreamOperatorParameters.java    |   86 +
 .../api/operators/StreamOperatorStateHandler.java  |  316 +
 .../streaming/api/operators/StreamSource.java      |    2 +-
 .../operators/StreamTaskStateInitializerImpl.java  |   15 +-
 .../api/operators/StreamingRuntimeContext.java     |   92 +-
 .../api/operators/TimerHeapInternalTimer.java      |    2 +-
 .../api/operators/YieldingOperatorFactory.java     |    3 +
 .../api/operators/async/AsyncWaitOperator.java     |   33 +-
 .../operators/async/AsyncWaitOperatorFactory.java  |   28 +-
 .../api/operators/co/IntervalJoinOperator.java     |   18 +-
 .../collect/CollectCoordinationRequest.java        |   66 +
 .../collect/CollectCoordinationResponse.java       |   92 +
 .../operators/collect/CollectResultFetcher.java    |  333 +
 .../operators/collect/CollectResultIterator.java   |   95 +
 .../operators/collect/CollectSinkAddressEvent.java |   40 +
 .../api/operators/collect/CollectSinkFunction.java |  498 ++
 .../api/operators/collect/CollectSinkOperator.java |   68 +
 .../collect/CollectSinkOperatorCoordinator.java    |  230 +
 .../collect/CollectSinkOperatorFactory.java        |   74 +
 .../api/operators/collect/CollectStreamSink.java   |   84 +
 .../source/BatchTimestampsAndWatermarks.java       |  126 +
 .../source/SourceOutputWithWatermarks.java         |  179 +
 .../source/StreamingTimestampsAndWatermarks.java   |  247 +
 .../operators/source/TimestampsAndWatermarks.java  |   92 +
 .../source/TimestampsAndWatermarksContext.java     |   46 +
 .../operators/source/WatermarkToDataOutput.java    |   86 +
 .../operators/util/SimpleVersionedListState.java   |  142 +
 .../AbstractMultipleInputTransformation.java       |   85 +
 .../KeyedMultipleInputTransformation.java          |   61 +
 .../LegacySourceTransformation.java                |   90 +
 .../MultipleInputTransformation.java               |   43 +
 .../api/transformations/SourceTransformation.java  |   85 +-
 .../assigners/TumblingProcessingTimeWindows.java   |   37 +-
 .../api/windowing/assigners/WindowStagger.java     |   75 +
 .../triggers/ProcessingTimeoutTrigger.java         |  180 +
 .../api/windowing/windows/TimeWindow.java          |    3 +-
 .../runtime/io/AbstractBufferStorage.java          |  170 -
 .../streaming/runtime/io/AbstractDataOutput.java   |    9 +-
 .../io/AlternatingCheckpointBarrierHandler.java    |  128 +
 .../runtime/io/BufferOrEventSequence.java          |   59 -
 .../flink/streaming/runtime/io/BufferSpiller.java  |  425 --
 .../flink/streaming/runtime/io/BufferStorage.java  |   77 -
 .../streaming/runtime/io/CachedBufferStorage.java  |  161 -
 .../runtime/io/CheckpointBarrierAligner.java       |  139 +-
 .../runtime/io/CheckpointBarrierHandler.java       |  120 +-
 .../runtime/io/CheckpointBarrierTracker.java       |   48 +-
 .../runtime/io/CheckpointBarrierUnaligner.java     |  396 ++
 .../runtime/io/CheckpointedInputGate.java          |  175 +-
 .../streaming/runtime/io/EmptyBufferStorage.java   |   73 -
 .../flink/streaming/runtime/io/InputGateUtil.java  |   20 +-
 .../streaming/runtime/io/InputProcessorUtil.java   |  156 +-
 .../flink/streaming/runtime/io/InputStatus.java    |   47 -
 .../streaming/runtime/io/LinkedBufferStorage.java  |   92 -
 .../runtime/io/MultipleInputSelectionHandler.java  |  158 +
 .../runtime/io/PushingAsyncDataInput.java          |    1 +
 .../streaming/runtime/io/RecordWriterOutput.java   |    4 +-
 .../streaming/runtime/io/StreamInputProcessor.java |    8 +-
 .../runtime/io/StreamMultipleInputProcessor.java   |  322 +
 .../runtime/io/StreamOneInputProcessor.java        |   21 +-
 .../streaming/runtime/io/StreamTaskInput.java      |    8 +
 .../runtime/io/StreamTaskNetworkInput.java         |   69 +-
 .../runtime/io/StreamTaskSourceInput.java          |   21 +-
 .../runtime/io/StreamTwoInputProcessor.java        |  118 +-
 .../runtime/io/TwoInputSelectionHandler.java       |   12 +-
 .../runtime/metrics/MinWatermarkGauge.java         |   21 +-
 .../operators/ExtractTimestampsOperator.java       |   98 -
 .../runtime/operators/GenericWriteAheadSink.java   |   11 +-
 .../TimestampsAndPeriodicWatermarksOperator.java   |  111 -
 .../TimestampsAndPunctuatedWatermarksOperator.java |   75 -
 .../operators/TimestampsAndWatermarksOperator.java |  174 +
 .../AssignerWithPeriodicWatermarksAdapter.java     |   83 +
 .../AssignerWithPunctuatedWatermarksAdapter.java   |   85 +
 .../runtime/tasks/AbstractTwoInputStreamTask.java  |   15 +-
 .../runtime/tasks/AsyncCheckpointRunnable.java     |  264 +
 .../runtime/tasks/MultipleInputStreamTask.java     |  113 +
 .../runtime/tasks/OneInputStreamTask.java          |   49 +-
 .../streaming/runtime/tasks/OperatorChain.java     |  227 +-
 .../runtime/tasks/OperatorEventDispatcherImpl.java |  117 +
 .../runtime/tasks/ProcessingTimeCallback.java      |    1 +
 .../runtime/tasks/ProcessingTimeService.java       |   30 +
 .../runtime/tasks/ProcessingTimeServiceAware.java  |   35 +
 .../tasks/ProcessingTimeServiceFactory.java        |   37 +
 .../runtime/tasks/ProcessingTimeServiceImpl.java   |   84 +-
 .../runtime/tasks/ProcessingTimeServiceUtil.java   |   44 +
 .../runtime/tasks/SourceOperatorStreamTask.java    |   90 +
 .../runtime/tasks/SourceReaderStreamTask.java      |  100 -
 .../streaming/runtime/tasks/SourceStreamTask.java  |   53 +-
 .../runtime/tasks/StreamIterationHead.java         |   14 +-
 .../runtime/tasks/StreamIterationTail.java         |    2 +-
 .../runtime/tasks/StreamOperatorWrapper.java       |  242 +
 .../flink/streaming/runtime/tasks/StreamTask.java  | 1158 ++--
 .../runtime/tasks/StreamTaskActionExecutor.java    |  110 +
 .../tasks/SubtaskCheckpointCoordinator.java        |   88 +
 .../tasks/SubtaskCheckpointCoordinatorImpl.java    |  627 ++
 .../runtime/tasks/SystemProcessingTimeService.java |   63 +-
 .../runtime/tasks/TestProcessingTimeService.java   |   15 +-
 .../streaming/runtime/tasks/TimerService.java      |   17 -
 .../runtime/tasks/TwoInputStreamTask.java          |   34 +-
 .../streaming/runtime/tasks/mailbox/Mail.java      |   29 +-
 .../runtime/tasks/mailbox/MailboxExecutorImpl.java |   53 +-
 .../runtime/tasks/mailbox/MailboxProcessor.java    |  156 +-
 .../runtime/tasks/mailbox/TaskMailbox.java         |   11 +-
 .../runtime/tasks/mailbox/TaskMailboxImpl.java     |   76 +-
 .../util/functions/StreamingFunctionUtils.java     |   20 +-
 .../util/typeutils/FieldAccessorFactory.java       |    2 +-
 .../consumer/StreamTestSingleInputGate.java        |   30 +-
 .../apache/flink/streaming/api/DataStreamTest.java |  233 +-
 .../api/StreamExecutionEnvironmentTest.java        |   41 +-
 .../ReinterpretDataStreamAsKeyedStreamITCase.java  |  327 -
 .../datastream/UnionSerializerMigrationTest.java   |   67 -
 .../api/datastream/UnionSerializerUpgradeTest.java |  154 +
 .../CheckpointConfigFromConfigurationTest.java     |  188 +
 .../environment/LocalStreamEnvironmentITCase.java  |   72 -
 .../RemoteStreamExecutionEnvironmentTest.java      |  115 -
 ...ecutionEnvironmentComplexConfigurationTest.java |  159 +
 ...treamExecutionEnvironmentConfigurationTest.java |  174 +
 .../api/functions/StatefulSequenceSourceTest.java  |   23 +-
 .../api/functions/async/RichAsyncFunctionTest.java |   13 -
 .../sink/TwoPhaseCommitSinkFunctionTest.java       |   85 +-
 ...haseCommitSinkStateSerializerMigrationTest.java |   61 -
 ...oPhaseCommitSinkStateSerializerUpgradeTest.java |  116 +
 .../sink/filesystem/BucketAssignerITCases.java     |    5 +-
 .../sink/filesystem/BucketStateSerializerTest.java |  427 +-
 .../api/functions/sink/filesystem/BucketTest.java  |   70 +-
 .../api/functions/sink/filesystem/BucketsTest.java |  159 +-
 .../functions/sink/filesystem/BulkWriterTest.java  |    5 +-
 .../sink/filesystem/RollingPolicyTest.java         |    5 +-
 .../api/functions/sink/filesystem/TestUtils.java   |   26 +-
 .../filesystem/utils/NoOpRecoverableWriter.java    |    2 +-
 .../source/ContinuousFileReaderOperatorTest.java   |  101 +
 .../source/InputFormatSourceFunctionTest.java      |    2 +-
 .../source/datagen/DataGeneratorSourceTest.java    |  236 +
 .../api/graph/StreamGraphGeneratorTest.java        |  111 +-
 .../api/graph/StreamingJobGraphGeneratorTest.java  |  408 +-
 ...aphGeneratorWithGlobalDataExchangeModeTest.java |  153 +
 .../api/operators/AbstractStreamOperatorTest.java  |  614 +-
 .../operators/AbstractStreamOperatorV2Test.java    |  136 +
 .../AbstractUdfStreamOperatorLifecycleTest.java    |   43 +-
 .../api/operators/GetOperatorUniqueIDTest.java     |   75 -
 .../api/operators/InputSelectionTest.java          |   71 +-
 .../operators/OperatorSnapshotFinalizerTest.java   |  137 +-
 .../api/operators/OperatorSnapshotFuturesTest.java |   44 +-
 .../api/operators/SourceOperatorTest.java          |  168 +
 .../operators/StreamOperatorStateHandlerTest.java  |  202 +
 .../StreamTaskStateInitializerImplTest.java        |   15 +-
 .../api/operators/StreamingRuntimeContextTest.java |  154 +-
 .../TimerSerializerSnapshotMigrationTest.java      |   61 -
 .../api/operators/TimerSerializerUpgradeTest.java  |  107 +
 .../api/operators/async/AsyncWaitOperatorTest.java |   98 +-
 .../api/operators/co/BufferEntryMatchers.java      |   69 +
 .../co/BufferEntrySerializerMigrationTest.java     |   57 -
 .../co/BufferEntrySerializerUpgradeTest.java       |  112 +
 .../collect/CollectResultIteratorTest.java         |  132 +
 .../operators/collect/CollectSinkFunctionTest.java |  687 +++
 .../CollectSinkOperatorCoordinatorTest.java        |  198 +
 .../operators/collect/utils/CollectTestUtils.java  |   48 +
 .../utils/MockFunctionInitializationContext.java   |   48 +
 .../collect/utils/MockFunctionSnapshotContext.java |   42 +
 .../collect/utils/MockOperatorEventGateway.java    |   44 +
 .../collect/utils/MockOperatorStateStore.java      |   98 +
 .../utils/TestCoordinationRequestHandler.java      |  208 +
 .../api/operators/collect/utils/TestJobClient.java |  133 +
 .../api/operators/source/CollectingDataOutput.java |   56 +
 .../source/OnEventTestWatermarkGenerator.java      |   34 +
 .../source/OnPeriodicTestWatermarkGenerator.java   |   43 +
 .../source/SourceOperatorEventTimeTest.java        |  256 +
 .../source/SourceOutputWithWatermarksTest.java     |   85 +
 .../operators/source/TestingSourceOperator.java    |   93 +
 .../source/WatermarkToDataOutputTest.java          |   77 +
 .../ExecutorDiscoveryAndJobClientTest.java         |   92 +
 .../streaming/environment/TestingJobClient.java    |   71 +
 .../StreamingJobGraphGeneratorNodeHashTest.java    |   36 +-
 .../AlternatingCheckpointBarrierHandlerTest.java   |  259 +
 .../streaming/runtime/io/BufferSpillerTest.java    |  108 -
 .../runtime/io/BufferStorageTestBase.java          |  278 -
 .../runtime/io/CachedBufferStorageTest.java        |   53 -
 ...CheckpointBarrierAlignerAlignmentLimitTest.java |  357 --
 .../CheckpointBarrierAlignerMassiveRandomTest.java |   88 +-
 .../io/CheckpointBarrierAlignerTestBase.java       | 1091 ++--
 .../runtime/io/CheckpointBarrierTrackerTest.java   |   39 +-
 ...CheckpointBarrierUnalignerCancellationTest.java |  139 +
 .../runtime/io/CheckpointBarrierUnalignerTest.java |  857 +++
 .../runtime/io/CheckpointSequenceValidator.java    |    2 +-
 .../CreditBasedCheckpointBarrierAlignerTest.java   |   23 +-
 .../runtime/io/InputProcessorUtilTest.java         |   91 +
 .../runtime/io/LinkedBufferStorageTest.java        |  165 -
 .../streaming/runtime/io/MockIndexedInputGate.java |  117 +
 .../flink/streaming/runtime/io/MockInputGate.java  |   49 +-
 .../io/MultipleInputSelectionHandlerTest.java      |   52 +
 .../io/SpilledBufferOrEventSequenceTest.java       |  486 --
 .../io/SpillingCheckpointBarrierAlignerTest.java   |   85 -
 .../runtime/io/StreamTaskNetworkInputTest.java     |  183 +-
 .../benchmark/SingleInputGateBenchmarkFactory.java |  179 +
 .../StreamNetworkBenchmarkEnvironment.java         |   48 +-
 .../StreamNetworkThroughputBenchmarkTest.java      |    2 +-
 .../ContinuousFileProcessingRescalingTest.java     |  365 +-
 .../runtime/operators/MailboxOperatorTest.java     |   82 +-
 .../operators/StreamOperatorChainingTest.java      |   17 +-
 .../StreamSourceOperatorLatencyMetricsTest.java    |    3 +-
 .../StreamSourceOperatorWatermarksTest.java        |   17 +-
 .../operators/StreamTaskOperatorTimerTest.java     |   23 +-
 .../runtime/operators/StreamTaskTimerTest.java     |   38 +-
 .../operators/TestProcessingTimeServiceTest.java   |   20 +-
 ...imestampsAndPeriodicWatermarksOperatorTest.java |  203 -
 ...estampsAndPunctuatedWatermarksOperatorTest.java |  138 -
 .../TimestampsAndWatermarksOperatorTest.java       |  281 +
 .../DynamicEventTimeSessionWindowsTest.java        |    2 +-
 .../DynamicProcessingTimeSessionWindowsTest.java   |    2 +-
 .../windowing/EventTimeSessionWindowsTest.java     |    2 +-
 .../ProcessingTimeSessionWindowsTest.java          |    2 +-
 .../windowing/ProcessingTimeoutTriggerTest.java    |  190 +
 .../windowing/SlidingEventTimeWindowsTest.java     |    2 +-
 .../SlidingProcessingTimeWindowsTest.java          |    2 +-
 .../operators/windowing/StreamRecordMatchers.java  |  177 -
 .../operators/windowing/TimeWindowTest.java        |   21 +
 .../windowing/TumblingEventTimeWindowsTest.java    |    2 +-
 .../TumblingProcessingTimeWindowsTest.java         |   24 +-
 .../windowing/WindowOperatorContractTest.java      |   14 +-
 .../windowing/WindowOperatorMigrationTest.java     |    1 -
 .../WindowSerializerSnapshotsMigrationTest.java    |   60 -
 .../windowing/WindowSerializerUpgradeTest.java     |  144 +
 .../operators/windowing/WindowStaggerTest.java     |   41 +
 .../StreamElementSerializerMigrationTest.java      |   55 -
 .../StreamElementSerializerUpgradeTest.java        |  103 +
 .../runtime/tasks/ExceptionallyDoneFuture.java     |    2 +-
 .../tasks/InterruptSensitiveRestoreTest.java       |   28 +-
 .../runtime/tasks/LocalStateForwardingTest.java    |   46 +-
 .../MockSubtaskCheckpointCoordinatorBuilder.java   |  108 +
 .../runtime/tasks/MultipleInputStreamTaskTest.java |  731 +++
 .../MultipleInputStreamTaskTestHarnessBuilder.java |  108 +
 .../runtime/tasks/OneInputStreamTaskTest.java      |   78 +-
 .../tasks/OneInputStreamTaskTestHarness.java       |   21 +-
 .../streaming/runtime/tasks/OperatorChainTest.java |   31 +-
 .../tasks/ProcessingTimeServiceImplTest.java       |  125 +
 .../runtime/tasks/RestoreStreamTaskTest.java       |    2 +
 .../tasks/SourceOperatorStreamTaskTest.java        |  182 +
 .../runtime/tasks/SourceReaderStreamTaskTest.java  |  209 -
 .../runtime/tasks/SourceStreamTaskTest.java        |  256 +-
 .../runtime/tasks/StreamConfigChainer.java         |   34 +-
 .../runtime/tasks/StreamMockEnvironment.java       |   53 +-
 .../runtime/tasks/StreamOperatorWrapperTest.java   |  301 +
 .../tasks/StreamTaskCancellationBarrierTest.java   |   35 -
 .../tasks/StreamTaskExecutionDecorationTest.java   |  137 +
 .../tasks/StreamTaskMailboxTestHarness.java        |  169 +
 .../tasks/StreamTaskMailboxTestHarnessBuilder.java |  217 +
 ...treamTaskMultipleInputSelectiveReadingTest.java |  376 ++
 .../tasks/StreamTaskSelectiveReadingTest.java      |    2 +-
 .../runtime/tasks/StreamTaskTerminationTest.java   |   21 +-
 .../streaming/runtime/tasks/StreamTaskTest.java    | 1080 ++--
 .../runtime/tasks/StreamTaskTestHarness.java       |  102 +-
 .../tasks/SubtaskCheckpointCoordinatorTest.java    |  530 ++
 .../runtime/tasks/SynchronousCheckpointITCase.java |   27 +-
 .../runtime/tasks/SynchronousCheckpointTest.java   |    6 +-
 .../tasks/SystemProcessingTimeServiceTest.java     |    6 +-
 .../tasks/TaskCheckpointingBehaviourTest.java      |   52 +-
 .../tasks/TestBoundedOneInputStreamOperator.java   |   11 +-
 .../runtime/tasks/TestBoundedTwoInputOperator.java |   67 +
 .../tasks/TestSubtaskCheckpointCoordinator.java    |   89 +
 .../runtime/tasks/TwoInputStreamTaskTest.java      |   90 +-
 .../tasks/TwoInputStreamTaskTestHarness.java       |   26 +-
 .../tasks/mailbox/MailboxExecutorImplTest.java     |   52 +-
 .../tasks/mailbox/SteppingMailboxProcessor.java    |   47 +
 .../runtime/tasks/mailbox/TaskMailboxImplTest.java |   33 +-
 .../tasks/mailbox/TaskMailboxProcessorTest.java    |  112 +-
 ...AbstractBroadcastStreamOperatorTestHarness.java |   81 +
 .../util/AbstractStreamOperatorTestHarness.java    |  101 +-
 .../AbstractStreamOperatorTestHarnessTest.java     |   87 +
 .../util/BroadcastOperatorTestHarness.java         |   48 +
 .../util/KeyedBroadcastOperatorTestHarness.java    |   59 +
 .../KeyedOneInputStreamOperatorTestHarness.java    |   24 +-
 .../flink/streaming/util/LatencyStatsTest.java     |    5 -
 .../streaming/util/MockDeserializationSchema.java  |   67 +
 .../streaming/util/MockSerializationSchema.java    |   54 +
 .../flink/streaming/util/MockStreamConfig.java     |   39 +-
 .../flink/streaming/util/MockStreamTask.java       |   63 +-
 .../streaming/util/MockStreamTaskBuilder.java      |   54 +-
 .../util/MockStreamingRuntimeContext.java          |   25 +-
 .../util/OneInputStreamOperatorTestHarness.java    |   95 +-
 .../flink/streaming/util/OperatorSnapshotUtil.java |   58 +-
 .../util/ProcessFunctionTestHarnesses.java         |  215 +
 .../util/ProcessFunctionTestHarnessesTest.java     |  178 +
 .../flink/streaming/util/SourceFunctionUtil.java   |    2 +-
 .../flink/streaming/util/StreamRecordMatchers.java |  178 +
 .../TestAnyModeMultipleInputStreamOperator.java    |   86 +
 .../util/TestBoundedMultipleInputOperator.java     |   77 +
 .../util/TestBoundedTwoInputOperator.java          |   60 -
 .../TestSequentialMultipleInputStreamOperator.java |   66 +
 .../util/TwoInputStreamOperatorTestHarness.java    |    8 +
 .../flink/streaming/util/WatermarkMatchers.java    |   51 +
 .../util/typeutils/FieldAccessorTest.java          |   20 +
 ...he.flink.core.execution.PipelineExecutorFactory |   16 +
 .../bucket-state-migration-test/empty-v1/snapshot  |  Bin 0 -> 128 bytes
 .../bucket-state-migration-test/empty-v2/snapshot  |  Bin 0 -> 128 bytes
 ...inprogress.a88d5993-77bc-44ce-880b-9f2a43b59ab4 |    2 +
 ...inprogress.7c0f2bd7-3078-48e8-9af2-d8773fb949c5 |    2 +
 ...inprogress.6729a640-0585-4785-a652-89802950c663 |    2 +
 ...inprogress.b4bcb0e9-5c9e-45dd-8963-1b163343544d |    2 +
 ...inprogress.e1e9e48d-0db6-4dd7-8a4d-fb4ebe7ed8ac |    2 +
 .../full-no-in-progress-v1-template/snapshot       |  Bin 0 -> 1537 bytes
 ...inprogress.1e22e72d-0ab2-493b-8b00-9edac4252cec |    2 +
 ...inprogress.3821f491-9fa1-48b2-b66b-655352a3c8ec |    2 +
 ...inprogress.0af18f41-d8f8-4a4e-a92e-de12851be20b |    2 +
 ...inprogress.a3d0f4d2-d6ad-4f83-ba62-ed4b1fa86db2 |    2 +
 ...inprogress.666acf3e-935c-4621-8171-f7c897496524 |    2 +
 .../full-no-in-progress-v2-template/snapshot       |  Bin 0 -> 1597 bytes
 ...inprogress.8fec17e9-5d54-4fa9-aebb-70736fe03c82 |    2 +
 ...inprogress.0035b171-2759-403a-8d6c-4612b28a7a6c |    2 +
 ...inprogress.49da8048-af6b-4665-b4f6-b659cb38dc97 |    2 +
 ...inprogress.d13ec4e0-07b5-4f4e-9be8-9fb457cbcde9 |    2 +
 ...inprogress.123ac2c7-f92a-476a-a848-1369b93d82a7 |    2 +
 ...inprogress.32f5a28f-20e1-48da-9951-10e795133d64 |    1 +
 .../full-v1-template/snapshot                      |  Bin 0 -> 1613 bytes
 ...inprogress.9731063e-2b28-4701-8cc1-e706480b8022 |    2 +
 ...inprogress.1d423406-097a-4deb-bfde-d023d3477cd5 |    2 +
 ...inprogress.6a837aa3-4736-4098-a878-fdeffe227628 |    2 +
 ...inprogress.f121b73d-ac74-4fbd-b70d-f13e51c9132c |    2 +
 ...inprogress.a156884a-f090-4c3f-a271-0b63ab539c45 |    2 +
 ...inprogress.83c527c5-14dc-4d49-9f99-c915f2224f6a |    1 +
 .../full-v2-template/snapshot                      |  Bin 0 -> 1685 bytes
 ...inprogress.a70190d6-d080-43a8-b414-746b09d3a8a0 |    1 +
 .../only-in-progress-v1/snapshot                   |  Bin 0 -> 404 bytes
 ...inprogress.10833090-dd8c-4e36-884d-bb9758a3a8ef |    1 +
 .../only-in-progress-v2/snapshot                   |  Bin 0 -> 416 bytes
 .../serializer-snapshot                            |  Bin 0 -> 214 bytes
 .../buffer-entry-serializer-1.11/test-data         |  Bin 0 -> 7 bytes
 .../flink-1.6-buffer-entry-serializer-data         |  Bin 160 -> 0 bytes
 .../flink-1.6-buffer-entry-serializer-snapshot     |  Bin 935 -> 0 bytes
 .../flink-1.6-global-window-serializer-data        |  Bin 10 -> 0 bytes
 .../flink-1.6-global-window-serializer-snapshot    |  Bin 420 -> 0 bytes
 .../flink-1.6-stream-element-serializer-data       |  Bin 158 -> 0 bytes
 .../flink-1.6-stream-element-serializer-snapshot   |  Bin 931 -> 0 bytes
 .../flink-1.6-time-window-serializer-data          |  Bin 160 -> 0 bytes
 .../flink-1.6-time-window-serializer-snapshot      |  Bin 416 -> 0 bytes
 .../test/resources/flink-1.6-timer-serializer-data |  Bin 240 -> 0 bytes
 .../resources/flink-1.6-timer-serializer-snapshot  |  Bin 1406 -> 0 bytes
 ...1.6-two-phase-commit-sink-state-serializer-data |  Bin 530 -> 0 bytes
 ...two-phase-commit-sink-state-serializer-snapshot |  Bin 1430 -> 0 bytes
 .../test/resources/flink-1.6-union-serializer-data |    1 -
 .../resources/flink-1.6-union-serializer-snapshot  |  Bin 1393 -> 0 bytes
 .../flink-1.7-buffer-entry-serializer-data         |  Bin 160 -> 0 bytes
 .../flink-1.7-buffer-entry-serializer-snapshot     |  Bin 936 -> 0 bytes
 .../flink-1.7-global-window-serializer-data        |  Bin 10 -> 0 bytes
 .../flink-1.7-global-window-serializer-snapshot    |  Bin 408 -> 0 bytes
 .../flink-1.7-stream-element-serializer-data       |  Bin 158 -> 0 bytes
 .../flink-1.7-stream-element-serializer-snapshot   |  Bin 932 -> 0 bytes
 .../flink-1.7-time-window-serializer-data          |  Bin 160 -> 0 bytes
 .../flink-1.7-time-window-serializer-snapshot      |  Bin 404 -> 0 bytes
 .../test/resources/flink-1.7-timer-serializer-data |  Bin 240 -> 0 bytes
 .../resources/flink-1.7-timer-serializer-snapshot  |  Bin 1414 -> 0 bytes
 ...1.7-two-phase-commit-sink-state-serializer-data |  Bin 530 -> 0 bytes
 ...two-phase-commit-sink-state-serializer-snapshot |  Bin 1438 -> 0 bytes
 .../test/resources/flink-1.7-union-serializer-data |    1 -
 .../resources/flink-1.7-union-serializer-snapshot  |  Bin 1403 -> 0 bytes
 .../serializer-snapshot                            |  Bin 0 -> 113 bytes
 .../global-window-serializer-1.11/test-data        |  Bin 0 -> 1 bytes
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../serializer-snapshot                            |  Bin 0 -> 223 bytes
 .../stream-element-serializer-1.11/test-data       |  Bin 0 -> 13 bytes
 .../serializer-snapshot                            |  Bin 0 -> 109 bytes
 .../time-window-serializer-1.11/test-data          |  Bin 0 -> 16 bytes
 .../timer-serializer-1.11/serializer-snapshot      |  Bin 0 -> 268 bytes
 .../test/resources/timer-serializer-1.11/test-data |  Bin 0 -> 16 bytes
 .../serializer-snapshot                            |  Bin 0 -> 300 bytes
 .../test-data                                      |  Bin 0 -> 35 bytes
 .../union-serializer-one-1.11/serializer-snapshot  |  Bin 0 -> 288 bytes
 .../resources/union-serializer-one-1.11/test-data  |    1 +
 .../union-serializer-two-1.11/serializer-snapshot  |  Bin 0 -> 288 bytes
 .../resources/union-serializer-two-1.11/test-data  |  Bin 0 -> 9 bytes
 ...-migration-test-accum-aligned-flink1.2-snapshot |  Bin 222 -> 0 bytes
 ...p-migration-test-aggr-aligned-flink1.2-snapshot |  Bin 187 -> 0 bytes
 ...gration-test-apply-event-time-flink1.2-snapshot |  Bin 2193 -> 0 bytes
 ...on-test-apply-processing-time-flink1.2-snapshot |  Bin 2081 -> 0 bytes
 ...tion-test-kryo-serialized-key-flink1.2-snapshot |  Bin 3686 -> 0 bytes
 ...ration-test-reduce-event-time-flink1.2-snapshot |  Bin 1988 -> 0 bytes
 ...n-test-reduce-processing-time-flink1.2-snapshot |  Bin 1925 -> 0 bytes
 ...session-with-stateful-trigger-flink1.2-snapshot |  Bin 3703 -> 0 bytes
 ...on-with-stateful-trigger-mint-flink1.2-snapshot |  Bin 494 -> 0 bytes
 flink-streaming-scala/pom.xml                      |   11 +-
 .../flink/streaming/api/scala/DataStream.scala     |  112 +-
 .../api/scala/StreamExecutionEnvironment.scala     |  146 +-
 .../src/test/resources/log4j-test.properties       |   38 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../flink/streaming/api/scala/DataStreamTest.scala |  169 +-
 .../streaming/api/scala/SideOutputITCase.scala     |   88 +
 .../api/scala/StreamExecutionEnvironmentTest.scala |   56 +
 .../sink/filesystem/StreamingFileSinkTest.scala    |   53 +
 flink-table/flink-sql-client/bin/sql-client.sh     |   10 +-
 .../flink-sql-client/conf/sql-client-defaults.yaml |    6 +-
 flink-table/flink-sql-client/pom.xml               |   48 +-
 .../org/apache/flink/table/client/SqlClient.java   |   78 +-
 .../table/client/cli/CliChangelogResultView.java   |    6 +-
 .../apache/flink/table/client/cli/CliClient.java   |  229 +-
 .../apache/flink/table/client/cli/CliOptions.java  |   18 +-
 .../flink/table/client/cli/CliOptionsParser.java   |   59 +-
 .../flink/table/client/cli/CliResultView.java      |    2 +-
 .../apache/flink/table/client/cli/CliStrings.java  |   42 +-
 .../flink/table/client/cli/CliTableResultView.java |    5 +-
 .../table/client/cli/CliTableauResultView.java     |  324 +
 .../apache/flink/table/client/cli/CliUtils.java    |   36 +-
 .../flink/table/client/cli/SqlCommandParser.java   |  261 +-
 .../flink/table/client/cli/SqlCompleter.java       |   52 +-
 .../flink/table/client/config/Environment.java     |   26 +-
 .../client/config/entries/DeploymentEntry.java     |    5 +
 .../client/config/entries/ExecutionEntry.java      |   23 +-
 .../flink/table/client/gateway/Executor.java       |   99 +-
 .../client/gateway/ProgramTargetDescriptor.java    |   44 +-
 .../table/client/gateway/ResultDescriptor.java     |   13 +-
 .../flink/table/client/gateway/SessionContext.java |  103 +-
 .../gateway/local/CollectBatchTableSink.java       |    8 +-
 .../gateway/local/CollectStreamTableSink.java      |   27 +-
 .../client/gateway/local/ExecutionContext.java     |  932 ++-
 .../table/client/gateway/local/LocalExecutor.java  |  484 +-
 .../client/gateway/local/ProgramDeployer.java      |  159 +-
 .../table/client/gateway/local/ResultStore.java    |   48 +-
 .../local/result/ChangelogCollectStreamResult.java |   13 +-
 .../gateway/local/result/CollectStreamResult.java  |   77 +-
 .../client/gateway/local/result/DynamicResult.java |   13 +-
 .../result/MaterializedCollectBatchResult.java     |   73 +-
 .../result/MaterializedCollectStreamResult.java    |   22 +-
 .../src/main/resources/META-INF/NOTICE             |    2 +-
 .../flink/table/client/cli/CliClientTest.java      |  316 +-
 .../flink/table/client/cli/CliResultViewTest.java  |   97 +-
 .../table/client/cli/CliTableauResultViewTest.java |  421 ++
 .../flink/table/client/cli/CliUtilsTest.java       |   43 -
 .../table/client/cli/SqlCommandParserTest.java     |  416 +-
 .../flink/table/client/cli/TestingExecutor.java    |  261 +
 .../table/client/cli/TestingExecutorBuilder.java   |  104 +
 .../table/client/cli/utils/SqlParserHelper.java    |   60 +
 .../table/client/cli/utils/TerminalUtils.java      |   11 +-
 .../table/client/gateway/local/DependencyTest.java |   71 +-
 .../client/gateway/local/EnvironmentTest.java      |   29 +
 .../client/gateway/local/ExecutionContextTest.java |  283 +-
 .../client/gateway/local/LocalExecutorITCase.java  | 1178 +++-
 .../MaterializedCollectStreamResultTest.java       |   31 +-
 .../gateway/utils/TestTableSinkFactoryBase.java    |   34 +-
 .../gateway/utils/TestTableSourceFactoryBase.java  |   30 +-
 .../gateway/utils/TestUserClassLoaderJar.java      |   90 +
 .../org.apache.flink.table.factories.TableFactory  |    1 +
 .../src/test/resources/log4j-test.properties       |   27 -
 .../src/test/resources/log4j2-test.properties      |   28 +
 .../src/test/resources/test-data.csv               |   12 +-
 .../test/resources/test-sql-client-catalogs.yaml   |    4 +
 .../test/resources/test-sql-client-defaults.yaml   |   18 +-
 .../test/resources/test-sql-client-dialect.yaml    |   30 +
 .../test/resources/test-sql-client-modules.yaml    |    5 +
 .../test-sql-client-python-functions.yaml          |   32 +
 flink-table/flink-sql-parser-hive/pom.xml          |  217 +
 .../src/main/codegen/config.fmpp                   |    0
 .../src/main/codegen/data/Parser.tdd               |  594 ++
 .../main/codegen/includes/compoundIdentifier.ftl   |    0
 .../src/main/codegen/includes/parserImpls.ftl      | 1447 +++++
 .../flink/sql/parser/hive/ddl/HiveDDLUtils.java    |  393 ++
 .../sql/parser/hive/ddl/SqlAddHivePartitions.java  |   88 +
 .../sql/parser/hive/ddl/SqlAlterHiveDatabase.java  |   60 +
 .../hive/ddl/SqlAlterHiveDatabaseLocation.java     |   59 +
 .../parser/hive/ddl/SqlAlterHiveDatabaseOwner.java |   75 +
 .../parser/hive/ddl/SqlAlterHiveDatabaseProps.java |   57 +
 .../hive/ddl/SqlAlterHivePartitionRename.java      |   72 +
 .../sql/parser/hive/ddl/SqlAlterHiveTable.java     |   64 +
 .../ddl/SqlAlterHiveTableAddReplaceColumn.java     |   81 +
 .../hive/ddl/SqlAlterHiveTableChangeColumn.java    |   78 +
 .../hive/ddl/SqlAlterHiveTableFileFormat.java      |   55 +
 .../parser/hive/ddl/SqlAlterHiveTableLocation.java |   56 +
 .../parser/hive/ddl/SqlAlterHiveTableProps.java    |   59 +
 .../parser/hive/ddl/SqlAlterHiveTableSerDe.java    |   94 +
 .../hive/ddl/SqlAlterHiveViewProperties.java       |   54 +
 .../sql/parser/hive/ddl/SqlCreateHiveDatabase.java |   97 +
 .../sql/parser/hive/ddl/SqlCreateHiveTable.java    |  495 ++
 .../sql/parser/hive/ddl/SqlCreateHiveView.java     |   93 +
 .../sql/parser/hive/ddl/SqlDescribeHiveTable.java  |   51 +
 .../parser/hive/ddl/SqlHiveConstraintEnable.java   |   39 +
 .../sql/parser/hive/ddl/SqlHiveConstraintRely.java |   39 +
 .../parser/hive/ddl/SqlHiveConstraintTrait.java    |   59 +
 .../parser/hive/ddl/SqlHiveConstraintValidate.java |   39 +
 .../sql/parser/hive/dml/RichSqlHiveInsert.java     |  103 +
 .../apache/flink/sql/parser/hive/package-info.java |   39 +
 .../hive/type/ExtendedHiveStructTypeNameSpec.java  |   68 +
 .../parser/hive/FlinkHiveSqlParserImplTest.java    |  421 ++
 flink-table/flink-sql-parser/pom.xml               |   51 +-
 .../src/main/codegen/data/Parser.tdd               |  183 +-
 .../src/main/codegen/includes/parserImpls.ftl      |  826 ++-
 .../calcite/sql/ExtendedSqlRowTypeNameSpec.java    |  150 -
 .../org/apache/calcite/sql/SqlMapTypeNameSpec.java |  103 -
 .../java/org/apache/calcite/sql/package-info.java  |   27 -
 .../apache/flink/sql/parser/SqlPartitionUtils.java |   61 +
 .../flink/sql/parser/ddl/SqlAddPartitions.java     |  100 +
 .../flink/sql/parser/ddl/SqlAddReplaceColumns.java |   97 +
 .../flink/sql/parser/ddl/SqlAlterDatabase.java     |   97 +
 .../flink/sql/parser/ddl/SqlAlterFunction.java     |  132 +
 .../apache/flink/sql/parser/ddl/SqlAlterTable.java |  100 +
 .../sql/parser/ddl/SqlAlterTableAddConstraint.java |   69 +
 .../parser/ddl/SqlAlterTableDropConstraint.java    |   65 +
 .../sql/parser/ddl/SqlAlterTableProperties.java    |   80 +
 .../flink/sql/parser/ddl/SqlAlterTableRename.java  |   58 +
 .../apache/flink/sql/parser/ddl/SqlAlterView.java  |   61 +
 .../flink/sql/parser/ddl/SqlAlterViewAs.java       |   61 +
 .../sql/parser/ddl/SqlAlterViewProperties.java     |   71 +
 .../flink/sql/parser/ddl/SqlAlterViewRename.java   |   59 +
 .../flink/sql/parser/ddl/SqlChangeColumn.java      |  109 +
 .../flink/sql/parser/ddl/SqlCreateCatalog.java     |  101 +
 .../flink/sql/parser/ddl/SqlCreateDatabase.java    |  130 +
 .../flink/sql/parser/ddl/SqlCreateFunction.java    |  127 +
 .../flink/sql/parser/ddl/SqlCreateTable.java       |  239 +-
 .../apache/flink/sql/parser/ddl/SqlCreateView.java |   44 +-
 .../flink/sql/parser/ddl/SqlDropCatalog.java       |   75 +
 .../flink/sql/parser/ddl/SqlDropDatabase.java      |   89 +
 .../flink/sql/parser/ddl/SqlDropFunction.java      |   98 +
 .../flink/sql/parser/ddl/SqlDropPartitions.java    |   87 +
 .../apache/flink/sql/parser/ddl/SqlDropTable.java  |   23 +-
 .../apache/flink/sql/parser/ddl/SqlDropView.java   |   19 +-
 .../flink/sql/parser/ddl/SqlTableColumn.java       |   16 +-
 .../apache/flink/sql/parser/ddl/SqlTableLike.java  |  275 +
 .../apache/flink/sql/parser/ddl/SqlUseCatalog.java |    2 +-
 .../flink/sql/parser/ddl/SqlUseDatabase.java       |   72 +
 .../ddl/constraint/SqlConstraintEnforcement.java   |   47 +
 .../parser/ddl/constraint/SqlTableConstraint.java  |  173 +
 .../sql/parser/ddl/constraint/SqlUniqueSpec.java   |   47 +
 .../apache/flink/sql/parser/dml/RichSqlInsert.java |   32 +-
 .../flink/sql/parser/dql/SqlDescribeDatabase.java  |   81 +
 .../flink/sql/parser/dql/SqlRichDescribeTable.java |   78 +
 .../flink/sql/parser/dql/SqlShowCatalogs.java      |    2 +-
 .../flink/sql/parser/dql/SqlShowDatabases.java     |   60 +
 .../flink/sql/parser/dql/SqlShowFunctions.java     |   71 +
 .../apache/flink/sql/parser/dql/SqlShowTables.java |   60 +
 .../apache/flink/sql/parser/dql/SqlShowViews.java  |   57 +
 .../parser/type/ExtendedSqlBasicTypeNameSpec.java  |   57 -
 .../type/ExtendedSqlCollectionTypeNameSpec.java    |   12 +
 .../parser/type/ExtendedSqlRowTypeNameSpec.java    |  160 +
 .../flink/sql/parser/type/SqlMapTypeNameSpec.java  |  107 +
 .../flink/sql/parser/type/SqlRawTypeNameSpec.java  |   89 +
 .../flink/sql/parser/utils/ParserResource.java     |    6 -
 .../apache/flink/sql/parser/utils/SqlTimeUnit.java |   49 -
 .../sql/parser/validate/FlinkSqlConformance.java   |   22 +-
 .../table/calcite/ExtendedRelTypeFactory.java      |   38 +
 .../ParserResource.properties                      |    2 -
 .../flink/sql/parser/CreateTableLikeTest.java      |  274 +
 .../java/org/apache/flink/sql/parser/Fixture.java  |   14 +-
 .../flink/sql/parser/FlinkDDLDataTypeTest.java     |   47 +-
 .../flink/sql/parser/FlinkSqlParserImplTest.java   |  761 ++-
 .../sql/parser/TableApiIdentifierParsingTest.java  |  124 +
 .../flink/sql/parser/TestRelDataTypeFactory.java   |   64 +
 flink-table/flink-table-api-java-bridge/pom.xml    |   29 +-
 .../api/bridge/java/BatchTableEnvironment.java     |  516 ++
 .../api/bridge/java/StreamTableEnvironment.java    |  659 ++
 .../java/internal/StreamTableEnvironmentImpl.java  |  396 ++
 .../table/api/java/BatchTableEnvironment.java      |  405 --
 .../table/api/java/StreamTableEnvironment.java     |  574 --
 .../java/internal/StreamTableEnvironmentImpl.java  |  431 --
 .../table/connector/sink/SinkFunctionProvider.java |   42 +
 .../connector/source/SourceFunctionProvider.java   |   52 +
 .../PeriodicWatermarkAssignerProvider.java         |   34 +
 .../PunctuatedWatermarkAssignerProvider.java       |   34 +
 .../org/apache/flink/table/descriptors/OldCsv.java |   93 +-
 .../flink/table/descriptors/OldCsvValidator.java   |   15 +-
 .../flink/table/descriptors/SchemaValidator.java   |   65 +-
 .../table/factories/BlackHoleTableSinkFactory.java |   91 +
 .../table/factories/DataGenTableSourceFactory.java |  325 +
 .../table/factories/PrintTableSinkFactory.java     |  166 +
 .../table/factories/StreamTableSinkFactory.java    |   15 +-
 .../table/factories/StreamTableSourceFactory.java  |   15 +-
 .../operations/JavaDataStreamQueryOperation.java   |    5 +-
 .../apache/flink/table/sinks/BatchTableSink.java   |   12 +-
 .../org/apache/flink/table/sinks/CsvTableSink.java |   77 +-
 .../flink/table/sinks/CsvTableSinkFactoryBase.java |   74 +-
 .../flink/table/sinks/OutputFormatTableSink.java   |    5 -
 .../apache/flink/table/sinks/StreamTableSink.java  |   17 +-
 .../apache/flink/table/sources/CsvTableSource.java |  212 +-
 .../table/sources/CsvTableSourceFactoryBase.java   |   55 +-
 .../org.apache.flink.table.factories.Factory       |   18 +
 .../internal/StreamTableEnvironmentImplTest.java   |  120 +
 .../internal/StreamTableEnvironmentImplTest.java   |  119 -
 .../table/factories/BlackHoleSinkFactoryTest.java  |   60 +
 .../table/factories/CsvTableSinkFactoryTest.java   |   19 +-
 .../factories/DataGenTableSourceFactoryTest.java   |  230 +
 .../table/factories/PrintSinkFactoryTest.java      |   63 +
 .../flink/table/sources/CsvTableSourceTest.java    |   41 +
 flink-table/flink-table-api-java/pom.xml           |    3 +-
 .../apache/flink/table/api/AggregatedTable.java    |   24 +-
 .../org/apache/flink/table/api/ApiExpression.java  |   66 +
 .../apache/flink/table/api/BatchQueryConfig.java   |   32 -
 .../flink/table/api/EnvironmentSettings.java       |   18 +-
 .../org/apache/flink/table/api/ExplainDetail.java  |   39 +
 .../org/apache/flink/table/api/Expressions.java    |  573 ++
 .../apache/flink/table/api/FlatAggregateTable.java |   24 +-
 .../org/apache/flink/table/api/GroupWindow.java    |    5 +-
 .../apache/flink/table/api/GroupWindowedTable.java |   14 +-
 .../org/apache/flink/table/api/GroupedTable.java   |   54 +-
 .../main/java/org/apache/flink/table/api/Over.java |    2 +
 .../flink/table/api/OverWindowPartitioned.java     |    2 +
 .../table/api/OverWindowPartitionedOrdered.java    |    4 +-
 .../api/OverWindowPartitionedOrderedPreceding.java |    2 +
 .../apache/flink/table/api/OverWindowedTable.java  |   14 +
 .../org/apache/flink/table/api/QueryConfig.java    |   34 -
 .../org/apache/flink/table/api/ResultKind.java     |   39 +
 .../java/org/apache/flink/table/api/Session.java   |    2 +
 .../org/apache/flink/table/api/SessionWithGap.java |    5 +-
 .../flink/table/api/SessionWithGapOnTime.java      |    5 +-
 .../table/api/SessionWithGapOnTimeWithAlias.java   |    3 +-
 .../java/org/apache/flink/table/api/Slide.java     |    2 +
 .../org/apache/flink/table/api/SlideWithSize.java  |    5 +-
 .../flink/table/api/SlideWithSizeAndSlide.java     |    7 +-
 .../table/api/SlideWithSizeAndSlideOnTime.java     |   13 +-
 .../api/SlideWithSizeAndSlideOnTimeWithAlias.java  |   13 +-
 .../org/apache/flink/table/api/StatementSet.java   |   65 +
 .../apache/flink/table/api/StreamQueryConfig.java  |  101 -
 .../java/org/apache/flink/table/api/Table.java     |  501 +-
 .../org/apache/flink/table/api/TableConfig.java    |   98 +-
 .../apache/flink/table/api/TableEnvironment.java   |  527 +-
 .../org/apache/flink/table/api/TableResult.java    |  144 +
 .../java/org/apache/flink/table/api/Tumble.java    |    2 +
 .../org/apache/flink/table/api/TumbleWithSize.java |    5 +-
 .../flink/table/api/TumbleWithSizeOnTime.java      |    5 +-
 .../table/api/TumbleWithSizeOnTimeWithAlias.java   |    3 +-
 .../apache/flink/table/api/WindowGroupedTable.java |   32 +
 .../table/api/config/ExecutionConfigOptions.java   |  106 +-
 .../table/api/config/OptimizerConfigOptions.java   |    2 +
 .../flink/table/api/config/TableConfigOptions.java |   54 +
 .../flink/table/api/internal/BaseExpressions.java  | 1284 ++++
 .../api/internal/CatalogTableSchemaResolver.java   |  118 +
 .../flink/table/api/internal/Registration.java     |   22 -
 .../table/api/internal/SelectResultProvider.java   |   42 +
 .../flink/table/api/internal/StatementSetImpl.java |  102 +
 .../table/api/internal/TableEnvironmentImpl.java   | 1002 ++-
 .../api/internal/TableEnvironmentInternal.java     |  111 +
 .../apache/flink/table/api/internal/TableImpl.java |  116 +-
 .../flink/table/api/internal/TableResultImpl.java  |  256 +
 .../flink/table/catalog/AbstractCatalogTable.java  |    6 +
 .../flink/table/catalog/CatalogFunctionImpl.java   |   51 +-
 .../apache/flink/table/catalog/CatalogManager.java |  329 +-
 .../flink/table/catalog/CatalogTableBuilder.java   |   10 +
 .../flink/table/catalog/CatalogTableImpl.java      |   45 +
 .../flink/table/catalog/ConnectorCatalogTable.java |   13 +-
 .../flink/table/catalog/DataTypeFactoryImpl.java   |  157 +
 .../flink/table/catalog/FunctionCatalog.java       |  577 +-
 .../apache/flink/table/catalog/FunctionLookup.java |   28 +-
 .../table/catalog/GenericInMemoryCatalog.java      |   30 +-
 .../flink/table/catalog/UnresolvedIdentifier.java  |  127 -
 .../apache/flink/table/delegation/Executor.java    |   31 +-
 .../org/apache/flink/table/delegation/Parser.java  |   12 +
 .../org/apache/flink/table/delegation/Planner.java |    7 +-
 .../table/descriptors/ConnectTableDescriptor.java  |   91 +-
 .../table/expressions/ApiExpressionUtils.java      |  363 ++
 .../expressions/LocalReferenceExpression.java      |    2 +-
 .../table/expressions/LookupCallExpression.java    |    5 +-
 .../expressions/TableReferenceExpression.java      |    2 +-
 .../expressions/UnresolvedCallExpression.java      |   11 +-
 .../expressions/UnresolvedReferenceExpression.java |    2 +-
 .../expressions/resolver/ExpressionResolver.java   |   81 +-
 .../expressions/resolver/LookupCallResolver.java   |   19 +-
 .../resolver/rules/ExpandColumnFunctionsRule.java  |   20 +-
 .../resolver/rules/OverWindowResolverRule.java     |   11 +-
 .../rules/QualifyBuiltInFunctionsRule.java         |    7 +-
 .../resolver/rules/ReferenceResolverRule.java      |   18 +-
 .../resolver/rules/ResolveCallByArgumentsRule.java |  205 +-
 .../expressions/resolver/rules/ResolverRule.java   |   12 +
 .../expressions/resolver/rules/ResolverRules.java  |    6 +
 .../resolver/rules/UnwrapApiExpressionRule.java    |   40 +
 .../expressions/utils/ApiExpressionUtils.java      |  150 -
 .../flink/table/factories/TableFactoryUtil.java    |  100 +-
 .../table/functions/FunctionDefinitionUtil.java    |   64 +-
 .../table/functions/TemporalTableFunctionImpl.java |   15 +-
 .../table/functions/UserFunctionsTypeHelper.java   |  176 -
 .../apache/flink/table/module/ModuleManager.java   |   25 +-
 .../table/operations/CalculatedQueryOperation.java |   46 +-
 .../operations/CatalogSinkModifyOperation.java     |   13 +-
 .../table/operations/DescribeTableOperation.java   |   59 +
 .../flink/table/operations/ExplainOperation.java   |   46 +
 .../table/operations/ModifyOperationVisitor.java   |    2 +
 .../flink/table/operations/OperationUtils.java     |   14 +-
 .../table/operations/QueryOperationVisitor.java    |    4 +-
 .../table/operations/SelectSinkOperation.java      |   69 +
 .../table/operations/ShowCatalogsOperation.java    |   30 +
 .../table/operations/ShowDatabasesOperation.java   |   30 +
 .../table/operations/ShowFunctionsOperation.java   |   30 +
 .../flink/table/operations/ShowOperation.java      |   29 +
 .../table/operations/ShowTablesOperation.java      |   30 +
 .../flink/table/operations/ShowViewsOperation.java |   30 +
 .../table/operations/UseCatalogOperation.java      |   40 +
 .../table/operations/UseDatabaseOperation.java     |   46 +
 .../flink/table/operations/UseOperation.java       |   33 +
 .../table/operations/ValuesQueryOperation.java     |   98 +
 .../operations/ddl/AddPartitionsOperation.java     |   74 +
 .../ddl/AlterCatalogFunctionOperation.java         |   84 +
 .../operations/ddl/AlterDatabaseOperation.java     |   71 +
 .../flink/table/operations/ddl/AlterOperation.java |   32 +
 .../operations/ddl/AlterPartitionOperation.java    |   39 +
 .../ddl/AlterPartitionPropertiesOperation.java     |   49 +
 .../ddl/AlterTableAddConstraintOperation.java      |   73 +
 .../ddl/AlterTableDropConstraintOperation.java     |   43 +
 .../table/operations/ddl/AlterTableOperation.java  |   37 +
 .../ddl/AlterTablePropertiesOperation.java         |   52 +
 .../operations/ddl/AlterTableRenameOperation.java  |   43 +
 .../operations/ddl/AlterTableSchemaOperation.java  |   46 +
 .../table/operations/ddl/AlterViewAsOperation.java |   44 +
 .../table/operations/ddl/AlterViewOperation.java   |   37 +
 .../ddl/AlterViewPropertiesOperation.java          |   50 +
 .../operations/ddl/AlterViewRenameOperation.java   |   44 +
 .../ddl/CreateCatalogFunctionOperation.java        |   84 +
 .../operations/ddl/CreateCatalogOperation.java     |   62 +
 .../operations/ddl/CreateDatabaseOperation.java    |   78 +
 .../table/operations/ddl/CreateTableOperation.java |   10 +-
 .../ddl/CreateTempSystemFunctionOperation.java     |   79 +
 .../table/operations/ddl/CreateViewOperation.java  |   80 +
 .../ddl/DropCatalogFunctionOperation.java          |   75 +
 .../table/operations/ddl/DropCatalogOperation.java |   59 +
 .../operations/ddl/DropDatabaseOperation.java      |   61 +
 .../operations/ddl/DropPartitionsOperation.java    |   60 +
 .../table/operations/ddl/DropTableOperation.java   |   12 +-
 .../ddl/DropTempSystemFunctionOperation.java       |   63 +
 .../table/operations/ddl/DropViewOperation.java    |   69 +
 .../utils/AggregateOperationFactory.java           |  595 ++
 .../operations/utils/AliasOperationUtils.java      |  112 +
 .../operations/utils/CalculatedTableFactory.java   |  166 +
 .../operations/utils/ColumnOperationUtils.java     |  157 +
 .../operations/utils/JoinOperationFactory.java     |  146 +
 .../utils/OperationExpressionsUtils.java           |   14 +-
 .../operations/utils/OperationTreeBuilder.java     |  153 +-
 .../utils/ProjectionOperationFactory.java          |  236 +
 .../utils/QueryOperationDefaultVisitor.java        |    6 +
 .../operations/utils/SetOperationFactory.java      |  108 +
 .../operations/utils/SortOperationFactory.java     |  157 +
 .../operations/utils/ValuesOperationFactory.java   |  369 ++
 .../utils/factories/AggregateOperationFactory.java |  595 --
 .../utils/factories/AliasOperationUtils.java       |  112 -
 .../utils/factories/CalculatedTableFactory.java    |  147 -
 .../utils/factories/ColumnOperationUtils.java      |  157 -
 .../utils/factories/JoinOperationFactory.java      |  146 -
 .../factories/ProjectionOperationFactory.java      |  236 -
 .../utils/factories/SetOperationFactory.java       |  108 -
 .../utils/factories/SortOperationFactory.java      |  157 -
 .../table/sources/tsextractors/ExistingField.java  |    2 +-
 .../tsextractors/StreamRecordTimestamp.java        |    2 +-
 .../flink/table/typeutils/FieldInfoUtils.java      |   19 +-
 .../flink/table/api/TableEnvironmentTest.java      |   54 +-
 .../flink/table/catalog/CatalogTestBase.java       |   18 +-
 .../flink/table/catalog/FunctionCatalogTest.java   |  703 ++-
 .../table/catalog/GenericInMemoryCatalogTest.java  |   23 +-
 .../descriptors/ConnectTableDescriptorTest.java    |   56 +
 .../table/expressions/ObjectToExpressionTest.java  |  125 +
 .../resolver/ExpressionResolverTest.java           |  354 ++
 .../functions/FunctionDefinitionUtilTest.java      |   88 +-
 .../flink/table/functions/TestGenericUDF.java      |   50 +
 .../flink/table/functions/TestSimpleUDF.java       |   50 +
 .../flink/table/operations/QueryOperationTest.java |    2 +-
 .../utils/ValuesOperationTreeBuilderTest.java      |  435 ++
 .../flink/table/typeutils/FieldInfoUtilsTest.java  |  124 +
 .../flink/table/utils/CatalogManagerMocks.java     |   52 +
 .../org/apache/flink/table/utils/ExecutorMock.java |   14 +-
 .../flink/table/utils/FunctionLookupMock.java      |  142 +
 .../org/apache/flink/table/utils/ParserMock.java   |    7 +
 .../org/apache/flink/table/utils/PlannerMock.java  |    3 +-
 .../flink/table/utils/TableEnvironmentMock.java    |   24 +-
 .../flink/table/utils/TableSourceFactoryMock.java  |   26 +-
 .../apache/flink/table/utils/TableSourceMock.java  |    6 +-
 flink-table/flink-table-api-scala-bridge/pom.xml   |    2 +-
 .../operations/ScalaDataStreamQueryOperation.java  |    2 +-
 .../api/bridge/scala/BatchTableEnvironment.scala   |  406 ++
 .../api/bridge/scala/DataSetConversions.scala      |   65 +
 .../api/bridge/scala/DataStreamConversions.scala   |   63 +
 .../api/bridge/scala/StreamTableEnvironment.scala  |  487 ++
 .../table/api/bridge/scala/TableConversions.scala  |  105 +
 .../internal/StreamTableEnvironmentImpl.scala      |  330 +
 .../flink/table/api/bridge/scala/package.scala     |   84 +
 .../table/api/scala/BatchTableEnvironment.scala    |  374 --
 .../flink/table/api/scala/DataSetConversions.scala |   65 -
 .../table/api/scala/DataStreamConversions.scala    |   63 -
 .../table/api/scala/StreamTableEnvironment.scala   |  461 --
 .../flink/table/api/scala/TableConversions.scala   |  176 -
 .../internal/StreamTableEnvironmentImpl.scala      |  362 --
 .../org/apache/flink/table/api/scala/package.scala |   89 -
 .../internal/StreamTableEnvironmentImplTest.scala  |  104 +
 .../internal/StreamTableEnvironmentImplTest.scala  |  106 -
 flink-table/flink-table-api-scala/pom.xml          |   25 +-
 .../table/api/ImplicitExpressionConversions.scala  |  693 +++
 .../table/api/ImplicitExpressionOperations.scala   |  181 +
 .../org/apache/flink/table/api/expressionDsl.scala | 1532 -----
 .../scala/org/apache/flink/table/api/package.scala |    8 +-
 .../api/ExpressionsConsistencyCheckTest.scala      |  296 +
 .../flink/table/api/ImplicitConversionsTest.scala  |   91 +
 .../expressions/ObjectToExpressionScalaTest.scala  |   56 +
... 7449 lines suppressed ...