You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by uc...@apache.org on 2016/08/08 14:19:59 UTC

[2/2] flink-web git commit: Add 1.1.0 changelog

Add 1.1.0 changelog


Project: http://git-wip-us.apache.org/repos/asf/flink-web/repo
Commit: http://git-wip-us.apache.org/repos/asf/flink-web/commit/e7fe1499
Tree: http://git-wip-us.apache.org/repos/asf/flink-web/tree/e7fe1499
Diff: http://git-wip-us.apache.org/repos/asf/flink-web/diff/e7fe1499

Branch: refs/heads/asf-site
Commit: e7fe1499de4a9750b51ec795d1617189ea494782
Parents: 1f79972
Author: Ufuk Celebi <uc...@apache.org>
Authored: Fri Aug 5 11:03:08 2016 +0200
Committer: Ufuk Celebi <uc...@apache.org>
Committed: Mon Aug 8 16:19:30 2016 +0200

----------------------------------------------------------------------
 blog/release_1.1.0-changelog.md | 488 +++++++++++++++++++++++++++++++++++
 1 file changed, 488 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink-web/blob/e7fe1499/blog/release_1.1.0-changelog.md
----------------------------------------------------------------------
diff --git a/blog/release_1.1.0-changelog.md b/blog/release_1.1.0-changelog.md
new file mode 100644
index 0000000..88e418f
--- /dev/null
+++ b/blog/release_1.1.0-changelog.md
@@ -0,0 +1,488 @@
+---
+title: "Release 1.1.0 \u2013 Changelog"
+---
+
+* toc
+{:toc}
+
+## Changelog
+
+The 1.1.0 release [resolved 457 JIRA issues](https://issues.apache.org/jira/issues/?jql=project+%3D+FLINK+AND+fixVersion+%3D+1.1.0) in total.
+
+### Sub-task
+
+- [FLINK-1502](https://issues.apache.org/jira/browse/FLINK-1502): Expose metrics to graphite, ganglia and JMX.
+- [FLINK-1550](https://issues.apache.org/jira/browse/FLINK-1550): Show JVM Metrics for JobManager
+- [FLINK-3129](https://issues.apache.org/jira/browse/FLINK-3129): Add tooling to ensure interface stability
+- [FLINK-3141](https://issues.apache.org/jira/browse/FLINK-3141): Design of NULL values handling in operation
+- [FLINK-3223](https://issues.apache.org/jira/browse/FLINK-3223): Translate Table API query into logical relational plans for Apache Calcite
+- [FLINK-3225](https://issues.apache.org/jira/browse/FLINK-3225): Optimize logical Table API plans in Calcite
+- [FLINK-3226](https://issues.apache.org/jira/browse/FLINK-3226): Translate optimized logical Table API plans into physical plans representing DataSet programs
+- [FLINK-3229](https://issues.apache.org/jira/browse/FLINK-3229): Kinesis streaming consumer with integration of Flink&#39;s checkpointing mechanics
+- [FLINK-3230](https://issues.apache.org/jira/browse/FLINK-3230): Kinesis streaming producer
+- [FLINK-3231](https://issues.apache.org/jira/browse/FLINK-3231): Handle Kinesis-side resharding in Kinesis streaming consumer
+- [FLINK-3327](https://issues.apache.org/jira/browse/FLINK-3327): Attach the ExecutionConfig to the JobGraph and make it accessible to the AbstractInvocable.
+- [FLINK-3489](https://issues.apache.org/jira/browse/FLINK-3489): Refactor Table API before merging into master
+- [FLINK-3544](https://issues.apache.org/jira/browse/FLINK-3544): ResourceManager runtime components
+- [FLINK-3545](https://issues.apache.org/jira/browse/FLINK-3545): ResourceManager: YARN integration
+- [FLINK-3547](https://issues.apache.org/jira/browse/FLINK-3547): Add support for streaming projection, selection, and union
+- [FLINK-3550](https://issues.apache.org/jira/browse/FLINK-3550): Rework stream join example
+- [FLINK-3552](https://issues.apache.org/jira/browse/FLINK-3552): Change socket WordCount to be properly windowed
+- [FLINK-3573](https://issues.apache.org/jira/browse/FLINK-3573): Implement more String functions for Table API
+- [FLINK-3574](https://issues.apache.org/jira/browse/FLINK-3574): Implement math functions for Table API
+- [FLINK-3586](https://issues.apache.org/jira/browse/FLINK-3586): Risk of data overflow while use sum/count to calculate AVG value
+- [FLINK-3612](https://issues.apache.org/jira/browse/FLINK-3612): Fix/adjust Table API examples
+- [FLINK-3714](https://issues.apache.org/jira/browse/FLINK-3714): Add Support for &quot;Allowed Lateness&quot;
+- [FLINK-3727](https://issues.apache.org/jira/browse/FLINK-3727): Add support for embedded streaming SQL (projection, filter, union)
+- [FLINK-3748](https://issues.apache.org/jira/browse/FLINK-3748): Add CASE function to Table API
+- [FLINK-3756](https://issues.apache.org/jira/browse/FLINK-3756): Introduce state hierarchy in CheckpointCoordinator
+- [FLINK-3837](https://issues.apache.org/jira/browse/FLINK-3837): Create FLOOR/CEIL function
+- [FLINK-3923](https://issues.apache.org/jira/browse/FLINK-3923): Unify configuration conventions of the Kinesis producer to the same as the consumer
+- [FLINK-3949](https://issues.apache.org/jira/browse/FLINK-3949): Collect Metrics in Runtime Operators
+- [FLINK-3951](https://issues.apache.org/jira/browse/FLINK-3951): Add Histogram Metric Type
+- [FLINK-4018](https://issues.apache.org/jira/browse/FLINK-4018): Configurable idle time between getRecords requests to Kinesis shards
+- [FLINK-4019](https://issues.apache.org/jira/browse/FLINK-4019): Expose approximateArrivalTimestamp through the KinesisDeserializationSchema interface
+- [FLINK-4020](https://issues.apache.org/jira/browse/FLINK-4020): Remove shard list querying from Kinesis consumer constructor
+- [FLINK-4033](https://issues.apache.org/jira/browse/FLINK-4033): Missing Scala example snippets for the Kinesis Connector documentation
+- [FLINK-4057](https://issues.apache.org/jira/browse/FLINK-4057): Expose JobManager Metrics
+- [FLINK-4062](https://issues.apache.org/jira/browse/FLINK-4062): Update Windowing Documentation
+- [FLINK-4080](https://issues.apache.org/jira/browse/FLINK-4080): Kinesis consumer not exactly-once if stopped in the middle of processing aggregated records
+- [FLINK-4085](https://issues.apache.org/jira/browse/FLINK-4085): Set Kinesis Consumer Agent to Flink
+- [FLINK-4191](https://issues.apache.org/jira/browse/FLINK-4191): Expose shard information in KinesisDeserializationSchema
+- [FLINK-4239](https://issues.apache.org/jira/browse/FLINK-4239): Set Default Allowed Lateness to Zero and Make Triggers Non-Purging
+
+### Bug
+
+- [FLINK-1159](https://issues.apache.org/jira/browse/FLINK-1159): Case style anonymous functions not supported by Scala API
+- [FLINK-1964](https://issues.apache.org/jira/browse/FLINK-1964): Rework TwitterSource to use a Properties object instead of a file path
+- [FLINK-2392](https://issues.apache.org/jira/browse/FLINK-2392): Instable test in flink-yarn-tests
+- [FLINK-2544](https://issues.apache.org/jira/browse/FLINK-2544): Some test cases using PowerMock fail with Java 8u20
+- [FLINK-2832](https://issues.apache.org/jira/browse/FLINK-2832): Failing test: RandomSamplerTest.testReservoirSamplerWithReplacement
+- [FLINK-2915](https://issues.apache.org/jira/browse/FLINK-2915): JobManagerProcessFailureBatchRecoveryITCase
+- [FLINK-3086](https://issues.apache.org/jira/browse/FLINK-3086): ExpressionParser does not support concatenation of suffix operations
+- [FLINK-3105](https://issues.apache.org/jira/browse/FLINK-3105): Submission in per job YARN cluster mode reuses properties file of long-lived session
+- [FLINK-3126](https://issues.apache.org/jira/browse/FLINK-3126): Remove accumulator type from &quot;value&quot; in web frontend
+- [FLINK-3179](https://issues.apache.org/jira/browse/FLINK-3179): Combiner is not injected if Reduce or GroupReduce input is explicitly partitioned
+- [FLINK-3333](https://issues.apache.org/jira/browse/FLINK-3333): Documentation about object reuse should be improved
+- [FLINK-3380](https://issues.apache.org/jira/browse/FLINK-3380): Unstable Test: JobSubmissionFailsITCase
+- [FLINK-3396](https://issues.apache.org/jira/browse/FLINK-3396): Job submission Savepoint restore logic flawed
+- [FLINK-3411](https://issues.apache.org/jira/browse/FLINK-3411): Failed recovery can lead to removal of HA state
+- [FLINK-3444](https://issues.apache.org/jira/browse/FLINK-3444): env.fromElements relies on the first input element for determining the DataSet/DataStream type
+- [FLINK-3466](https://issues.apache.org/jira/browse/FLINK-3466): Job might get stuck in restoreState() from HDFS due to interrupt
+- [FLINK-3471](https://issues.apache.org/jira/browse/FLINK-3471): JDBCInputFormat cannot handle null fields of certain types
+- [FLINK-3472](https://issues.apache.org/jira/browse/FLINK-3472): JDBCInputFormat.nextRecord(..) has misleading message on NPE
+- [FLINK-3488](https://issues.apache.org/jira/browse/FLINK-3488): Kafka08ITCase.testBigRecordJob fails on Travis
+- [FLINK-3491](https://issues.apache.org/jira/browse/FLINK-3491): HDFSCopyUtilitiesTest fails on Windows
+- [FLINK-3495](https://issues.apache.org/jira/browse/FLINK-3495): RocksDB Tests can&#39;t run on Windows
+- [FLINK-3505](https://issues.apache.org/jira/browse/FLINK-3505): JoinUnionTransposeRule fails to push Join past Union.
+- [FLINK-3519](https://issues.apache.org/jira/browse/FLINK-3519): Subclasses of Tuples don&#39;t work if the declared type of a DataSet is not the descendant
+- [FLINK-3530](https://issues.apache.org/jira/browse/FLINK-3530): Kafka09ITCase.testBigRecordJob fails on Travis
+- [FLINK-3533](https://issues.apache.org/jira/browse/FLINK-3533): Update the Gelly docs wrt examples and cluster execution
+- [FLINK-3534](https://issues.apache.org/jira/browse/FLINK-3534): Cancelling a running job can lead to restart instead of stopping
+- [FLINK-3540](https://issues.apache.org/jira/browse/FLINK-3540): Hadoop 2.6.3 build contains /com/google/common (guava) classes in flink-dist.jar
+- [FLINK-3556](https://issues.apache.org/jira/browse/FLINK-3556): Unneeded check in HA blob store configuration
+- [FLINK-3561](https://issues.apache.org/jira/browse/FLINK-3561): ExecutionConfig&#39;s timestampsEnabled is unused
+- [FLINK-3562](https://issues.apache.org/jira/browse/FLINK-3562): Update docs in the course of EventTimeSourceFunction removal
+- [FLINK-3563](https://issues.apache.org/jira/browse/FLINK-3563): .returns() doesn&#39;t compile when using .map() with a custom MapFunction
+- [FLINK-3565](https://issues.apache.org/jira/browse/FLINK-3565): FlinkKafkaConsumer does not work with Scala 2.11
+- [FLINK-3566](https://issues.apache.org/jira/browse/FLINK-3566): Input type validation often fails on custom TypeInfo implementations
+- [FLINK-3567](https://issues.apache.org/jira/browse/FLINK-3567): Rework selection when grouping in Table API
+- [FLINK-3569](https://issues.apache.org/jira/browse/FLINK-3569): Test cases fail due to Maven Shade plugin
+- [FLINK-3577](https://issues.apache.org/jira/browse/FLINK-3577): Display anchor links when hovering over headers.
+- [FLINK-3578](https://issues.apache.org/jira/browse/FLINK-3578): Scala DataStream API does not support Rich Window Functions
+- [FLINK-3579](https://issues.apache.org/jira/browse/FLINK-3579): Improve String concatenation
+- [FLINK-3583](https://issues.apache.org/jira/browse/FLINK-3583): Configuration not visible in gui when job is running
+- [FLINK-3585](https://issues.apache.org/jira/browse/FLINK-3585): Deploy scripts don&#39;t support spaces in paths
+- [FLINK-3593](https://issues.apache.org/jira/browse/FLINK-3593): DistinctITCase is failing
+- [FLINK-3595](https://issues.apache.org/jira/browse/FLINK-3595): Kafka09 consumer thread does not interrupt when stuck in record emission
+- [FLINK-3601](https://issues.apache.org/jira/browse/FLINK-3601): JobManagerTest times out on StopSignal test
+- [FLINK-3602](https://issues.apache.org/jira/browse/FLINK-3602): Recursive Types are not supported / crash TypeExtractor
+- [FLINK-3608](https://issues.apache.org/jira/browse/FLINK-3608): ImmutableSettings error in ElasticsearchSink
+- [FLINK-3611](https://issues.apache.org/jira/browse/FLINK-3611): Wrong link in CONTRIBUTING.md
+- [FLINK-3619](https://issues.apache.org/jira/browse/FLINK-3619): SavepointCoordinator test failure
+- [FLINK-3621](https://issues.apache.org/jira/browse/FLINK-3621): Misleading documentation of memory configuration parameters
+- [FLINK-3622](https://issues.apache.org/jira/browse/FLINK-3622): Improve error messages for invalid joins
+- [FLINK-3630](https://issues.apache.org/jira/browse/FLINK-3630): Little mistake in documentation
+- [FLINK-3631](https://issues.apache.org/jira/browse/FLINK-3631): CodeGenerator does not check type compatibility for equality expressions
+- [FLINK-3633](https://issues.apache.org/jira/browse/FLINK-3633): Job submission silently fails when using user code types
+- [FLINK-3635](https://issues.apache.org/jira/browse/FLINK-3635): Potential null deference in TwitterExample#SelectEnglishAndTokenizeFlatMap#flatMap
+- [FLINK-3636](https://issues.apache.org/jira/browse/FLINK-3636): NoClassDefFoundError while running WindowJoin example
+- [FLINK-3638](https://issues.apache.org/jira/browse/FLINK-3638): Invalid default ports in documentation
+- [FLINK-3644](https://issues.apache.org/jira/browse/FLINK-3644): WebRuntimMonitor set java.io.tmpdir does not work for change upload dir.
+- [FLINK-3645](https://issues.apache.org/jira/browse/FLINK-3645): HDFSCopyUtilitiesTest fails in a Hadoop cluster
+- [FLINK-3651](https://issues.apache.org/jira/browse/FLINK-3651): Fix faulty RollingSink Restore
+- [FLINK-3653](https://issues.apache.org/jira/browse/FLINK-3653): recovery.zookeeper.storageDir is not documented on the configuration page
+- [FLINK-3663](https://issues.apache.org/jira/browse/FLINK-3663): FlinkKafkaConsumerBase.logPartitionInfo is missing a log marker
+- [FLINK-3669](https://issues.apache.org/jira/browse/FLINK-3669): WindowOperator registers a lot of timers at StreamTask
+- [FLINK-3675](https://issues.apache.org/jira/browse/FLINK-3675): YARN ship folder incosistent behavior
+- [FLINK-3676](https://issues.apache.org/jira/browse/FLINK-3676): WebClient hasn&#39;t been removed from the docs
+- [FLINK-3681](https://issues.apache.org/jira/browse/FLINK-3681): CEP library does not support Java 8 lambdas as select function
+- [FLINK-3682](https://issues.apache.org/jira/browse/FLINK-3682): CEP operator does not set the processing timestamp correctly
+- [FLINK-3684](https://issues.apache.org/jira/browse/FLINK-3684): CEP operator does not forward watermarks properly
+- [FLINK-3689](https://issues.apache.org/jira/browse/FLINK-3689): JobManager blocks cluster shutdown when not connected to ResourceManager
+- [FLINK-3693](https://issues.apache.org/jira/browse/FLINK-3693): JobManagerHAJobGraphRecoveryITCase.testClientNonDetachedListeningBehaviour is unstable
+- [FLINK-3696](https://issues.apache.org/jira/browse/FLINK-3696): Some Union tests fail for TableConfigMode.EFFICIENT
+- [FLINK-3697](https://issues.apache.org/jira/browse/FLINK-3697): keyBy() with nested POJO computes invalid field position indexes
+- [FLINK-3701](https://issues.apache.org/jira/browse/FLINK-3701): Cant call execute after first execution
+- [FLINK-3712](https://issues.apache.org/jira/browse/FLINK-3712): YARN client dynamic properties are not passed correctly to the leader election service on the client
+- [FLINK-3713](https://issues.apache.org/jira/browse/FLINK-3713): DisposeSavepoint message uses system classloader to discard state
+- [FLINK-3716](https://issues.apache.org/jira/browse/FLINK-3716): Kafka08ITCase.testFailOnNoBroker() timing out before it has a chance to pass
+- [FLINK-3718](https://issues.apache.org/jira/browse/FLINK-3718): Add Option For Completely Async Backup in RocksDB State Backend
+- [FLINK-3725](https://issues.apache.org/jira/browse/FLINK-3725): Exception in thread &quot;main&quot; scala.MatchError: ... (of class scala.Tuple4)
+- [FLINK-3728](https://issues.apache.org/jira/browse/FLINK-3728): Throw meaningful exceptions for unsupported SQL features
+- [FLINK-3729](https://issues.apache.org/jira/browse/FLINK-3729): Several SQL tests fail on Windows OS
+- [FLINK-3730](https://issues.apache.org/jira/browse/FLINK-3730): Fix RocksDB Local Directory Initialization
+- [FLINK-3731](https://issues.apache.org/jira/browse/FLINK-3731): Embedded SQL outer joins should fail during translation
+- [FLINK-3732](https://issues.apache.org/jira/browse/FLINK-3732): Potential null deference in ExecutionConfig#equals()
+- [FLINK-3735](https://issues.apache.org/jira/browse/FLINK-3735): Embedded SQL union should fail during translation
+- [FLINK-3737](https://issues.apache.org/jira/browse/FLINK-3737): WikipediaEditsSourceTest.testWikipediaEditsSource() fails locally
+- [FLINK-3745](https://issues.apache.org/jira/browse/FLINK-3745): TimestampITCase testWatermarkPropagationNoFinalWatermarkOnStop failing intermittently
+- [FLINK-3757](https://issues.apache.org/jira/browse/FLINK-3757): addAccumulator does not throw Exception on duplicate accumulator name
+- [FLINK-3759](https://issues.apache.org/jira/browse/FLINK-3759): Table API should throw exception is null value is encountered in non-null mode.
+- [FLINK-3762](https://issues.apache.org/jira/browse/FLINK-3762):  Kryo StackOverflowError due to disabled Kryo Reference tracking
+- [FLINK-3773](https://issues.apache.org/jira/browse/FLINK-3773): Scanners are left unclosed in SqlExplainTest
+- [FLINK-3774](https://issues.apache.org/jira/browse/FLINK-3774): Flink configuration is not correctly forwarded to PlanExecutor in ScalaShellRemoteEnvironment
+- [FLINK-3781](https://issues.apache.org/jira/browse/FLINK-3781): BlobClient may be left unclosed in BlobCache#deleteGlobal()
+- [FLINK-3790](https://issues.apache.org/jira/browse/FLINK-3790): Rolling File sink does not pick up hadoop configuration
+- [FLINK-3792](https://issues.apache.org/jira/browse/FLINK-3792): RowTypeInfo equality should not depend on field names
+- [FLINK-3793](https://issues.apache.org/jira/browse/FLINK-3793): Re-organize the Table API and SQL docs
+- [FLINK-3796](https://issues.apache.org/jira/browse/FLINK-3796): FileSourceFunction doesn&#39;t respect InputFormat&#39;s life cycle methods
+- [FLINK-3803](https://issues.apache.org/jira/browse/FLINK-3803): Checkpoint Stats Tracker Reads from Wrong Configuration
+- [FLINK-3824](https://issues.apache.org/jira/browse/FLINK-3824): ResourceManager may repeatedly connect to outdated JobManager in HA mode
+- [FLINK-3826](https://issues.apache.org/jira/browse/FLINK-3826): Broken test: StreamCheckpointingITCase
+- [FLINK-3835](https://issues.apache.org/jira/browse/FLINK-3835): JSON execution plan not helpful to debug plans with KeySelectors
+- [FLINK-3838](https://issues.apache.org/jira/browse/FLINK-3838): CLI parameter parser is munging application params
+- [FLINK-3840](https://issues.apache.org/jira/browse/FLINK-3840): RocksDB local parent dir is polluted with empty folders with random names
+- [FLINK-3842](https://issues.apache.org/jira/browse/FLINK-3842): Fix handling null record/row in generated code
+- [FLINK-3845](https://issues.apache.org/jira/browse/FLINK-3845): Gelly allows duplicate vertices in Graph.addVertices
+- [FLINK-3846](https://issues.apache.org/jira/browse/FLINK-3846): Graph.removeEdges also removes duplicate edges
+- [FLINK-3860](https://issues.apache.org/jira/browse/FLINK-3860): WikipediaEditsSourceTest.testWikipediaEditsSource times out
+- [FLINK-3863](https://issues.apache.org/jira/browse/FLINK-3863): Yarn Cluster shutdown may fail if leader changed recently
+- [FLINK-3864](https://issues.apache.org/jira/browse/FLINK-3864): Yarn tests don&#39;t check for prohibited strings in log output
+- [FLINK-3877](https://issues.apache.org/jira/browse/FLINK-3877): Create TranslateFunction interface for Graph translators
+- [FLINK-3878](https://issues.apache.org/jira/browse/FLINK-3878): File cache doesn&#39;t support multiple duplicate temp directories
+- [FLINK-3882](https://issues.apache.org/jira/browse/FLINK-3882): Errors in sample Java code for the Elasticsearch 2.x sink
+- [FLINK-3890](https://issues.apache.org/jira/browse/FLINK-3890): Deprecate streaming mode flag from Yarn CLI
+- [FLINK-3892](https://issues.apache.org/jira/browse/FLINK-3892): ConnectionUtils may die with NullPointerException
+- [FLINK-3893](https://issues.apache.org/jira/browse/FLINK-3893): LeaderChangeStateCleanupTest times out
+- [FLINK-3908](https://issues.apache.org/jira/browse/FLINK-3908): FieldParsers error state is not reset correctly to NONE
+- [FLINK-3909](https://issues.apache.org/jira/browse/FLINK-3909): Maven Failsafe plugin may report SUCCESS on failed tests
+- [FLINK-3914](https://issues.apache.org/jira/browse/FLINK-3914): BlobServer.createTemporaryFilename() has concurrency safety problem
+- [FLINK-3922](https://issues.apache.org/jira/browse/FLINK-3922): Infinite recursion on TypeExtractor
+- [FLINK-3926](https://issues.apache.org/jira/browse/FLINK-3926): Incorrect implementation of getFieldIndex in TupleTypeInfo
+- [FLINK-3927](https://issues.apache.org/jira/browse/FLINK-3927): TaskManager registration may fail if Yarn versions don&#39;t match
+- [FLINK-3928](https://issues.apache.org/jira/browse/FLINK-3928): Potential overflow due to 32-bit int arithmetic
+- [FLINK-3933](https://issues.apache.org/jira/browse/FLINK-3933): Add an auto-type-extracting DeserializationSchema
+- [FLINK-3934](https://issues.apache.org/jira/browse/FLINK-3934): Prevent translation of non-equi joins in DataSetJoinRule
+- [FLINK-3935](https://issues.apache.org/jira/browse/FLINK-3935): Invalid check of key and ordering fields in PartitionNode
+- [FLINK-3938](https://issues.apache.org/jira/browse/FLINK-3938): Yarn tests don&#39;t run on the current master
+- [FLINK-3939](https://issues.apache.org/jira/browse/FLINK-3939): Prevent distinct aggregates and grouping sets from being translated
+- [FLINK-3944](https://issues.apache.org/jira/browse/FLINK-3944): Add optimization rules to reorder Cartesian products and joins
+- [FLINK-3948](https://issues.apache.org/jira/browse/FLINK-3948): EventTimeWindowCheckpointingITCase Fails with Core Dump
+- [FLINK-3953](https://issues.apache.org/jira/browse/FLINK-3953): Surefire plugin executes unit tests twice
+- [FLINK-3956](https://issues.apache.org/jira/browse/FLINK-3956): Make FileInputFormats independent from Configuration
+- [FLINK-3960](https://issues.apache.org/jira/browse/FLINK-3960): Disable, fix and re-enable EventTimeWindowCheckpointingITCase
+- [FLINK-3962](https://issues.apache.org/jira/browse/FLINK-3962): JMXReporter doesn&#39;t properly register/deregister metrics
+- [FLINK-3963](https://issues.apache.org/jira/browse/FLINK-3963): AbstractReporter uses shaded dependency
+- [FLINK-3971](https://issues.apache.org/jira/browse/FLINK-3971): Aggregates handle null values incorrectly.
+- [FLINK-3972](https://issues.apache.org/jira/browse/FLINK-3972): Subclasses of ResourceID may not to be serializable
+- [FLINK-3973](https://issues.apache.org/jira/browse/FLINK-3973): Table API documentation is &quot;hidden&quot; in Programming Guide menu list
+- [FLINK-3974](https://issues.apache.org/jira/browse/FLINK-3974): enableObjectReuse fails when an operator chains to multiple downstream operators
+- [FLINK-3975](https://issues.apache.org/jira/browse/FLINK-3975): Override baseurl when serving docs locally
+- [FLINK-3977](https://issues.apache.org/jira/browse/FLINK-3977): Subclasses of InternalWindowFunction must support OutputTypeConfigurable
+- [FLINK-3981](https://issues.apache.org/jira/browse/FLINK-3981): Don&#39;t log duplicate TaskManager registrations as exceptions
+- [FLINK-3982](https://issues.apache.org/jira/browse/FLINK-3982): Multiple ResourceManagers register at JobManager in standalone HA mode
+- [FLINK-3994](https://issues.apache.org/jira/browse/FLINK-3994): Instable KNNITSuite
+- [FLINK-3995](https://issues.apache.org/jira/browse/FLINK-3995): Properly Structure Test Utils and Dependencies
+- [FLINK-4000](https://issues.apache.org/jira/browse/FLINK-4000): Exception: Could not restore checkpointed state to operators and functions;  during Job Restart (Job restart is triggered due to one of the task manager failure)
+- [FLINK-4002](https://issues.apache.org/jira/browse/FLINK-4002): [py] Improve testing infraestructure
+- [FLINK-4009](https://issues.apache.org/jira/browse/FLINK-4009): Scala Shell fails to find library for inclusion in test
+- [FLINK-4011](https://issues.apache.org/jira/browse/FLINK-4011): Unable to access completed job in web frontend
+- [FLINK-4012](https://issues.apache.org/jira/browse/FLINK-4012): Docs: Links to &quot;Iterations&quot; are broken (404)
+- [FLINK-4016](https://issues.apache.org/jira/browse/FLINK-4016): FoldApplyWindowFunction is not properly initialized
+- [FLINK-4024](https://issues.apache.org/jira/browse/FLINK-4024): FileSourceFunction not adjusted to new IF lifecycle
+- [FLINK-4027](https://issues.apache.org/jira/browse/FLINK-4027): FlinkKafkaProducer09 sink can lose messages
+- [FLINK-4028](https://issues.apache.org/jira/browse/FLINK-4028): AbstractAlignedProcessingTimeWindowOperator creates wrong TimeWindow
+- [FLINK-4030](https://issues.apache.org/jira/browse/FLINK-4030): ScalaShellITCase gets stuck
+- [FLINK-4031](https://issues.apache.org/jira/browse/FLINK-4031): Nightly Jenkins job doesn&#39;t deploy sources
+- [FLINK-4038](https://issues.apache.org/jira/browse/FLINK-4038): Impossible to set more than 1 JVM argument in env.java.opts
+- [FLINK-4040](https://issues.apache.org/jira/browse/FLINK-4040): Same env.java.opts is applied for TM , JM and ZK
+- [FLINK-4041](https://issues.apache.org/jira/browse/FLINK-4041): Failure while asking ResourceManager for RegisterResource
+- [FLINK-4046](https://issues.apache.org/jira/browse/FLINK-4046): Failing a restarting job can get stuck in JobStatus.FAILING
+- [FLINK-4052](https://issues.apache.org/jira/browse/FLINK-4052): Unstable test ConnectionUtilsTest
+- [FLINK-4053](https://issues.apache.org/jira/browse/FLINK-4053): Return value from Connection should be checked against null
+- [FLINK-4056](https://issues.apache.org/jira/browse/FLINK-4056): SavepointITCase.testCheckpointHasBeenRemoved failed on Travis
+- [FLINK-4076](https://issues.apache.org/jira/browse/FLINK-4076): BoltWrapper#dispose() should call AbstractStreamOperator#dispose()
+- [FLINK-4077](https://issues.apache.org/jira/browse/FLINK-4077): Register Pojo DataSet/DataStream as Table requires alias expression.
+- [FLINK-4078](https://issues.apache.org/jira/browse/FLINK-4078): Use ClosureCleaner for CoGroup where
+- [FLINK-4079](https://issues.apache.org/jira/browse/FLINK-4079): YARN properties file used for per-job cluster
+- [FLINK-4083](https://issues.apache.org/jira/browse/FLINK-4083): Use ClosureCleaner for Join where and equalTo
+- [FLINK-4089](https://issues.apache.org/jira/browse/FLINK-4089): Ineffective null check in YarnClusterClient#getApplicationStatus()
+- [FLINK-4090](https://issues.apache.org/jira/browse/FLINK-4090): Close of OutputStream should be in finally clause in FlinkYarnSessionCli#writeYarnProperties()
+- [FLINK-4097](https://issues.apache.org/jira/browse/FLINK-4097): Cassandra Sink throws NPE on closing if server is not available
+- [FLINK-4099](https://issues.apache.org/jira/browse/FLINK-4099): CliFrontendYarnAddressConfigurationTest fails
+- [FLINK-4111](https://issues.apache.org/jira/browse/FLINK-4111): Flink Table &amp; SQL doesn&#39;t work in very simple example
+- [FLINK-4113](https://issues.apache.org/jira/browse/FLINK-4113): Always copy first value in ChainedAllReduceDriver
+- [FLINK-4115](https://issues.apache.org/jira/browse/FLINK-4115): FsStateBackend filesystem verification can cause classpath exceptions
+- [FLINK-4122](https://issues.apache.org/jira/browse/FLINK-4122): Cassandra jar contains 2 guava versions
+- [FLINK-4123](https://issues.apache.org/jira/browse/FLINK-4123): CassandraWriteAheadSink can hang on cassandra failure
+- [FLINK-4125](https://issues.apache.org/jira/browse/FLINK-4125): Yarn CLI incorrectly calculates slotsPerTM when parallelism &lt; task manager count
+- [FLINK-4130](https://issues.apache.org/jira/browse/FLINK-4130): CallGenerator could generate illegal code when taking no operands
+- [FLINK-4132](https://issues.apache.org/jira/browse/FLINK-4132): Fix boxed comparison in CommunityDetection algorithm
+- [FLINK-4133](https://issues.apache.org/jira/browse/FLINK-4133): Reflect streaming file source changes in documentation
+- [FLINK-4134](https://issues.apache.org/jira/browse/FLINK-4134): EventTimeSessionWindows trigger for empty windows when dropping late events
+- [FLINK-4139](https://issues.apache.org/jira/browse/FLINK-4139): Yarn: Adjust parallelism and task slots correctly
+- [FLINK-4141](https://issues.apache.org/jira/browse/FLINK-4141): TaskManager failures not always recover when killed during an ApplicationMaster failure in HA mode on Yarn
+- [FLINK-4142](https://issues.apache.org/jira/browse/FLINK-4142): Recovery problem in HA on Hadoop Yarn 2.4.1
+- [FLINK-4144](https://issues.apache.org/jira/browse/FLINK-4144): Yarn properties file: replace hostname/port with Yarn application id
+- [FLINK-4145](https://issues.apache.org/jira/browse/FLINK-4145): JmxReporterTest fails due to port conflicts
+- [FLINK-4146](https://issues.apache.org/jira/browse/FLINK-4146): CliFrontendYarnAddressConfigurationTest picks wrong IP address on Travis
+- [FLINK-4149](https://issues.apache.org/jira/browse/FLINK-4149): Fix Serialization of NFA in AbstractKeyedCEPPatternOperator
+- [FLINK-4150](https://issues.apache.org/jira/browse/FLINK-4150): Problem with Blobstore in Yarn HA setting on recovery after cluster shutdown
+- [FLINK-4152](https://issues.apache.org/jira/browse/FLINK-4152): TaskManager registration exponential backoff doesn&#39;t work
+- [FLINK-4154](https://issues.apache.org/jira/browse/FLINK-4154): Correction of murmur hash breaks backwards compatibility
+- [FLINK-4156](https://issues.apache.org/jira/browse/FLINK-4156): Job with -m yarn-cluster registers TaskManagers to another running Yarn session
+- [FLINK-4157](https://issues.apache.org/jira/browse/FLINK-4157): FlinkKafkaMetrics cause TaskManager shutdown during cancellation
+- [FLINK-4158](https://issues.apache.org/jira/browse/FLINK-4158): Scala QuickStart StreamingJob fails to compile
+- [FLINK-4159](https://issues.apache.org/jira/browse/FLINK-4159): Quickstart poms exclude unused dependencies
+- [FLINK-4160](https://issues.apache.org/jira/browse/FLINK-4160): YARN session doesn&#39;t show input validation errors
+- [FLINK-4166](https://issues.apache.org/jira/browse/FLINK-4166): Generate automatic different namespaces in Zookeeper for Flink applications
+- [FLINK-4167](https://issues.apache.org/jira/browse/FLINK-4167): TaskMetricGroup does not close IOMetricGroup
+- [FLINK-4168](https://issues.apache.org/jira/browse/FLINK-4168): ForkableFlinkMiniCluster not available in Kinesis connector tests
+- [FLINK-4171](https://issues.apache.org/jira/browse/FLINK-4171): StatsD does not accept metrics whose name contains &quot;:&quot;
+- [FLINK-4172](https://issues.apache.org/jira/browse/FLINK-4172): Don&#39;t proxy a ProxiedObject
+- [FLINK-4176](https://issues.apache.org/jira/browse/FLINK-4176): Travis build fails at flink-connector-kinesis for JDK: openjdk7
+- [FLINK-4184](https://issues.apache.org/jira/browse/FLINK-4184): Ganglia and GraphiteReporter report metric names with invalid characters
+- [FLINK-4196](https://issues.apache.org/jira/browse/FLINK-4196): Remove &quot;recoveryTimestamp&quot;
+- [FLINK-4199](https://issues.apache.org/jira/browse/FLINK-4199): Misleading messages by CLI upon job submission
+- [FLINK-4201](https://issues.apache.org/jira/browse/FLINK-4201): Checkpoints for jobs in non-terminal state (e.g. suspended) get deleted
+- [FLINK-4214](https://issues.apache.org/jira/browse/FLINK-4214): JobExceptionsHandler will return all exceptions
+- [FLINK-4216](https://issues.apache.org/jira/browse/FLINK-4216): WordWithCount example with Java has wrong generics type
+- [FLINK-4232](https://issues.apache.org/jira/browse/FLINK-4232): Flink executable does not return correct pid
+- [FLINK-4235](https://issues.apache.org/jira/browse/FLINK-4235): ClassLoaderITCase.testDisposeSavepointWithCustomKvState timed out on Travis
+- [FLINK-4238](https://issues.apache.org/jira/browse/FLINK-4238): Only allow/require query for Tuple Stream in CassandraSink
+- [FLINK-4258](https://issues.apache.org/jira/browse/FLINK-4258): Potential null pointer dereference in SavepointCoordinator#onFullyAcknowledgedCheckpoint
+- [FLINK-4261](https://issues.apache.org/jira/browse/FLINK-4261): Setup atomic deployment of snapshots
+- [FLINK-4277](https://issues.apache.org/jira/browse/FLINK-4277): TaskManagerConfigurationTest fails
+- [FLINK-4284](https://issues.apache.org/jira/browse/FLINK-4284): DataSet/CEP link to non-existant &quot;Linking with Flink&quot; section
+- [FLINK-4296](https://issues.apache.org/jira/browse/FLINK-4296): Scheduler accepts more tasks than it has task slots available
+- [FLINK-4307](https://issues.apache.org/jira/browse/FLINK-4307): Broken user-facing API for ListState
+
+### Improvement
+
+- [FLINK-1827](https://issues.apache.org/jira/browse/FLINK-1827): Move test classes in test folders and fix scope of test dependencies
+- [FLINK-1991](https://issues.apache.org/jira/browse/FLINK-1991): Return Table as DataSet&lt;Tuple&gt;
+- [FLINK-1996](https://issues.apache.org/jira/browse/FLINK-1996): Add output methods to Table API
+- [FLINK-2227](https://issues.apache.org/jira/browse/FLINK-2227): .yarn-properties file is not cleaned up
+- [FLINK-2522](https://issues.apache.org/jira/browse/FLINK-2522): Integrate Streaming Api into Flink-scala-shell
+- [FLINK-2788](https://issues.apache.org/jira/browse/FLINK-2788): Add type hint with TypeExtactor call on Hint Type
+- [FLINK-2829](https://issues.apache.org/jira/browse/FLINK-2829): Confusing error message when Flink cannot create enough task threads
+- [FLINK-2929](https://issues.apache.org/jira/browse/FLINK-2929): Recovery of jobs on cluster restarts
+- [FLINK-2935](https://issues.apache.org/jira/browse/FLINK-2935): Allow scala shell to read yarn properties
+- [FLINK-2985](https://issues.apache.org/jira/browse/FLINK-2985): Allow different field names for unionAll() in Table API
+- [FLINK-3115](https://issues.apache.org/jira/browse/FLINK-3115): Update Elasticsearch connector to 2.X
+- [FLINK-3152](https://issues.apache.org/jira/browse/FLINK-3152): Support all comparisons for Date type
+- [FLINK-3153](https://issues.apache.org/jira/browse/FLINK-3153): Support all comparisons for String type
+- [FLINK-3174](https://issues.apache.org/jira/browse/FLINK-3174): Add merging WindowAssigner
+- [FLINK-3272](https://issues.apache.org/jira/browse/FLINK-3272): Generalize vertex value type in ConnectedComponents
+- [FLINK-3323](https://issues.apache.org/jira/browse/FLINK-3323): Add documentation for NiFi connector
+- [FLINK-3332](https://issues.apache.org/jira/browse/FLINK-3332): Provide an exactly-once Cassandra connector
+- [FLINK-3375](https://issues.apache.org/jira/browse/FLINK-3375): Allow Watermark Generation in the Kafka Source
+- [FLINK-3383](https://issues.apache.org/jira/browse/FLINK-3383): Separate Maven deployment from CI testing
+- [FLINK-3405](https://issues.apache.org/jira/browse/FLINK-3405): Extend NiFiSource with interface StoppableFunction
+- [FLINK-3407](https://issues.apache.org/jira/browse/FLINK-3407): Extend TwitterSource with interface StoppableFunction
+- [FLINK-3428](https://issues.apache.org/jira/browse/FLINK-3428): Add fixed time trailing timestamp/watermark extractor
+- [FLINK-3461](https://issues.apache.org/jira/browse/FLINK-3461): Remove duplicate condition check in ZooKeeperLeaderElectionService
+- [FLINK-3467](https://issues.apache.org/jira/browse/FLINK-3467): Remove superfluous objects from DataSourceTask.invoke
+- [FLINK-3469](https://issues.apache.org/jira/browse/FLINK-3469): Improve documentation for grouping keys
+- [FLINK-3487](https://issues.apache.org/jira/browse/FLINK-3487): FilterAggregateTransposeRule does not transform logical plan as desired.
+- [FLINK-3503](https://issues.apache.org/jira/browse/FLINK-3503): ProjectJoinTransposeRule fails to push down project.
+- [FLINK-3506](https://issues.apache.org/jira/browse/FLINK-3506): ReduceExpressionsRule does not remove duplicate expression in Filter
+- [FLINK-3507](https://issues.apache.org/jira/browse/FLINK-3507): PruneEmptyRules does not prune empty node as expected.
+- [FLINK-3524](https://issues.apache.org/jira/browse/FLINK-3524): Provide a JSONDeserialisationSchema in the kafka connector package
+- [FLINK-3535](https://issues.apache.org/jira/browse/FLINK-3535): Decrease logging verbosity of StackTraceSampleCoordinator
+- [FLINK-3541](https://issues.apache.org/jira/browse/FLINK-3541): Clean up workaround in FlinkKafkaConsumer09
+- [FLINK-3559](https://issues.apache.org/jira/browse/FLINK-3559): Don&#39;t print pid file check if no active PID
+- [FLINK-3560](https://issues.apache.org/jira/browse/FLINK-3560): Examples shouldn&#39;t always print usage statement
+- [FLINK-3570](https://issues.apache.org/jira/browse/FLINK-3570): Replace random NIC selection heuristic by InetAddress.getLocalHost
+- [FLINK-3575](https://issues.apache.org/jira/browse/FLINK-3575): Update Working With State Section in Doc
+- [FLINK-3589](https://issues.apache.org/jira/browse/FLINK-3589): Allow setting Operator parallelism to default value
+- [FLINK-3590](https://issues.apache.org/jira/browse/FLINK-3590): JDBC Format tests don&#39;t hide derby logs
+- [FLINK-3591](https://issues.apache.org/jira/browse/FLINK-3591): Replace Quickstart K-Means Example by Streaming Example
+- [FLINK-3596](https://issues.apache.org/jira/browse/FLINK-3596): DataSet RelNode refactoring
+- [FLINK-3597](https://issues.apache.org/jira/browse/FLINK-3597): Table API operator names should reflect relational expression
+- [FLINK-3603](https://issues.apache.org/jira/browse/FLINK-3603): Re-enable Table API explain
+- [FLINK-3604](https://issues.apache.org/jira/browse/FLINK-3604): Enable ignored Table API tests
+- [FLINK-3607](https://issues.apache.org/jira/browse/FLINK-3607): Decrease default forkCount for tests
+- [FLINK-3614](https://issues.apache.org/jira/browse/FLINK-3614): Remove Non-Keyed Window Operator
+- [FLINK-3618](https://issues.apache.org/jira/browse/FLINK-3618): Rename abstract UDF classes in Scatter-Gather implementation
+- [FLINK-3623](https://issues.apache.org/jira/browse/FLINK-3623): Adjust MurmurHash algorithm
+- [FLINK-3632](https://issues.apache.org/jira/browse/FLINK-3632): Clean up Table API exceptions
+- [FLINK-3634](https://issues.apache.org/jira/browse/FLINK-3634): Fix documentation for DataSetUtils.zipWithUniqueId()
+- [FLINK-3637](https://issues.apache.org/jira/browse/FLINK-3637): Change RollingSink Writer interface to allow wider range of outputs
+- [FLINK-3641](https://issues.apache.org/jira/browse/FLINK-3641): Document registerCachedFile API call
+- [FLINK-3649](https://issues.apache.org/jira/browse/FLINK-3649): Document stable API methods maxBy/minBy
+- [FLINK-3650](https://issues.apache.org/jira/browse/FLINK-3650): Add maxBy/minBy to Scala DataSet API
+- [FLINK-3654](https://issues.apache.org/jira/browse/FLINK-3654): Disable Write-Ahead-Log in RocksDB State
+- [FLINK-3657](https://issues.apache.org/jira/browse/FLINK-3657): Change access of DataSetUtils.countElements() to &#39;public&#39;
+- [FLINK-3658](https://issues.apache.org/jira/browse/FLINK-3658): Allow the FlinkKafkaProducer to send data to multiple topics
+- [FLINK-3664](https://issues.apache.org/jira/browse/FLINK-3664): Create a method to easily Summarize a DataSet
+- [FLINK-3665](https://issues.apache.org/jira/browse/FLINK-3665): Range partitioning lacks support to define sort orders
+- [FLINK-3666](https://issues.apache.org/jira/browse/FLINK-3666): Remove Nephele references
+- [FLINK-3667](https://issues.apache.org/jira/browse/FLINK-3667): Generalize client&lt;-&gt;cluster communication
+- [FLINK-3678](https://issues.apache.org/jira/browse/FLINK-3678): Make Flink logs directory configurable
+- [FLINK-3691](https://issues.apache.org/jira/browse/FLINK-3691): Extend AvroInputFormat to support Avro GenericRecord
+- [FLINK-3700](https://issues.apache.org/jira/browse/FLINK-3700): Replace Guava Preconditions class with Flink Preconditions
+- [FLINK-3736](https://issues.apache.org/jira/browse/FLINK-3736): Move toRexNode and toAggCall logic into Expressions
+- [FLINK-3739](https://issues.apache.org/jira/browse/FLINK-3739): Add a null literal to Table API
+- [FLINK-3747](https://issues.apache.org/jira/browse/FLINK-3747): Consolidate TimestampAssigner Methods in Kafka Consumer
+- [FLINK-3750](https://issues.apache.org/jira/browse/FLINK-3750): Make JDBCInputFormat a parallel source
+- [FLINK-3752](https://issues.apache.org/jira/browse/FLINK-3752): Add Per-Kafka-Partition Watermark Generation to the docs
+- [FLINK-3754](https://issues.apache.org/jira/browse/FLINK-3754): Add a validation phase before construct RelNode using TableAPI
+- [FLINK-3763](https://issues.apache.org/jira/browse/FLINK-3763): RabbitMQ Source/Sink standardize connection parameters
+- [FLINK-3770](https://issues.apache.org/jira/browse/FLINK-3770): Fix TriangleEnumerator performance
+- [FLINK-3776](https://issues.apache.org/jira/browse/FLINK-3776): Flink Scala shell does not allow to set configuration for local execution
+- [FLINK-3794](https://issues.apache.org/jira/browse/FLINK-3794): Add checks for unsupported operations in streaming table API
+- [FLINK-3799](https://issues.apache.org/jira/browse/FLINK-3799): Graph checksum should execute single job
+- [FLINK-3804](https://issues.apache.org/jira/browse/FLINK-3804): Update YARN documentation
+- [FLINK-3806](https://issues.apache.org/jira/browse/FLINK-3806): Revert use of DataSet.count() in Gelly
+- [FLINK-3811](https://issues.apache.org/jira/browse/FLINK-3811): Refactor ExecutionEnvironment in TableEnvironment
+- [FLINK-3815](https://issues.apache.org/jira/browse/FLINK-3815): Replace Guava Preconditions usage in flink-gelly
+- [FLINK-3816](https://issues.apache.org/jira/browse/FLINK-3816): Replace Guava Preconditions usage in flink-clients
+- [FLINK-3817](https://issues.apache.org/jira/browse/FLINK-3817): Remove unused Guava dependency from RocksDB StateBackend
+- [FLINK-3818](https://issues.apache.org/jira/browse/FLINK-3818): Remove Guava dependency from flink-gelly-examples
+- [FLINK-3819](https://issues.apache.org/jira/browse/FLINK-3819): Replace Guava Preconditions usage in flink-gelly-scala
+- [FLINK-3821](https://issues.apache.org/jira/browse/FLINK-3821): Reduce Guava usage in flink-java
+- [FLINK-3853](https://issues.apache.org/jira/browse/FLINK-3853): Reduce object creation in Gelly utility mappers
+- [FLINK-3854](https://issues.apache.org/jira/browse/FLINK-3854): Support Avro key-value rolling sink writer
+- [FLINK-3855](https://issues.apache.org/jira/browse/FLINK-3855): Upgrade Jackson version
+- [FLINK-3868](https://issues.apache.org/jira/browse/FLINK-3868): Specialized CopyableValue serializers and comparators
+- [FLINK-3876](https://issues.apache.org/jira/browse/FLINK-3876): Improve documentation of Scala Shell
+- [FLINK-3880](https://issues.apache.org/jira/browse/FLINK-3880): Improve performance of Accumulator map
+- [FLINK-3886](https://issues.apache.org/jira/browse/FLINK-3886): Give a better error when the application Main class is not public.
+- [FLINK-3887](https://issues.apache.org/jira/browse/FLINK-3887): Improve dependency management for building docs
+- [FLINK-3891](https://issues.apache.org/jira/browse/FLINK-3891): Add a class containing all supported Table API types
+- [FLINK-3900](https://issues.apache.org/jira/browse/FLINK-3900): Set nullCheck=true as default in TableConfig
+- [FLINK-3901](https://issues.apache.org/jira/browse/FLINK-3901): Create a RowCsvInputFormat to use as default CSV IF in Table API
+- [FLINK-3912](https://issues.apache.org/jira/browse/FLINK-3912): Typos in Batch Scala API Documentation
+- [FLINK-3913](https://issues.apache.org/jira/browse/FLINK-3913): Clean up documentation typos
+- [FLINK-3916](https://issues.apache.org/jira/browse/FLINK-3916): Allow generic types passing the Table API
+- [FLINK-3936](https://issues.apache.org/jira/browse/FLINK-3936): Add MIN / MAX aggregations function for BOOLEAN types
+- [FLINK-3937](https://issues.apache.org/jira/browse/FLINK-3937): Make flink cli list, savepoint, cancel and stop work on Flink-on-YARN clusters
+- [FLINK-3945](https://issues.apache.org/jira/browse/FLINK-3945): Degree annotation for directed graphs
+- [FLINK-3955](https://issues.apache.org/jira/browse/FLINK-3955): Change Table.toSink() to Table.writeToSink()
+- [FLINK-3978](https://issues.apache.org/jira/browse/FLINK-3978): Add hasBroadcastVariable method to RuntimeContext
+- [FLINK-3979](https://issues.apache.org/jira/browse/FLINK-3979): [documentation]add missed import classes in run_example_quickstart
+- [FLINK-3980](https://issues.apache.org/jira/browse/FLINK-3980): Remove ExecutionConfig.PARALLELISM_UNKNOWN
+- [FLINK-3993](https://issues.apache.org/jira/browse/FLINK-3993): [py] Add generateSequence() support to Python API
+- [FLINK-4003](https://issues.apache.org/jira/browse/FLINK-4003): Use intrinsics for MathUtils logarithms
+- [FLINK-4017](https://issues.apache.org/jira/browse/FLINK-4017): [py] Add Aggregation support to Python API
+- [FLINK-4025](https://issues.apache.org/jira/browse/FLINK-4025): Add possiblity for the RMQ Streaming Source to customize the queue
+- [FLINK-4026](https://issues.apache.org/jira/browse/FLINK-4026): Fix code, grammar, and link issues in the Streaming documentation
+- [FLINK-4032](https://issues.apache.org/jira/browse/FLINK-4032): Replace all usage of Guava Preconditions
+- [FLINK-4049](https://issues.apache.org/jira/browse/FLINK-4049): Mark RichInputFormat.openInputFormat and closeInputFormat as @PublicEvolving
+- [FLINK-4054](https://issues.apache.org/jira/browse/FLINK-4054): Inconsistent Reporter synchronization within report()
+- [FLINK-4063](https://issues.apache.org/jira/browse/FLINK-4063): Add Metrics Support for Triggers
+- [FLINK-4066](https://issues.apache.org/jira/browse/FLINK-4066): RabbitMQ source, customize queue arguments
+- [FLINK-4067](https://issues.apache.org/jira/browse/FLINK-4067): Add version header to savepoints
+- [FLINK-4070](https://issues.apache.org/jira/browse/FLINK-4070): Support literals on left side of binary expressions
+- [FLINK-4074](https://issues.apache.org/jira/browse/FLINK-4074): Reporter can block TaskManager shutdown
+- [FLINK-4082](https://issues.apache.org/jira/browse/FLINK-4082): Add Setting for LargeRecordHandler
+- [FLINK-4086](https://issues.apache.org/jira/browse/FLINK-4086): Hide internal Expression methods from Table API
+- [FLINK-4087](https://issues.apache.org/jira/browse/FLINK-4087): JMXReporter can&#39;t handle port conflicts
+- [FLINK-4093](https://issues.apache.org/jira/browse/FLINK-4093): Expose metric interfaces
+- [FLINK-4095](https://issues.apache.org/jira/browse/FLINK-4095): Add configDir argument to shell scripts
+- [FLINK-4103](https://issues.apache.org/jira/browse/FLINK-4103): Modify CsvTableSource to implement StreamTableSource
+- [FLINK-4105](https://issues.apache.org/jira/browse/FLINK-4105): Restructure Gelly docs
+- [FLINK-4106](https://issues.apache.org/jira/browse/FLINK-4106): Restructure Gelly docs
+- [FLINK-4107](https://issues.apache.org/jira/browse/FLINK-4107): Restructure Gelly docs
+- [FLINK-4109](https://issues.apache.org/jira/browse/FLINK-4109): Change the name of ternary condition operator  &#39;eval&#39; to  &#39;?&#39;
+- [FLINK-4116](https://issues.apache.org/jira/browse/FLINK-4116): Document metrics
+- [FLINK-4118](https://issues.apache.org/jira/browse/FLINK-4118): The docker-flink image is outdated (1.0.2) and can be slimmed down
+- [FLINK-4119](https://issues.apache.org/jira/browse/FLINK-4119): Null checks in close() for Cassandra Input/Output Formats, checking arguments via Flink Preconditions
+- [FLINK-4121](https://issues.apache.org/jira/browse/FLINK-4121): Add timeunit (ms) to docs for timestamps and watermarks
+- [FLINK-4127](https://issues.apache.org/jira/browse/FLINK-4127): Clean up configuration and check breaking API changes
+- [FLINK-4135](https://issues.apache.org/jira/browse/FLINK-4135): Replace ChecksumHashCode as GraphAnalytic
+- [FLINK-4170](https://issues.apache.org/jira/browse/FLINK-4170): Remove `CONFIG_` prefix from KinesisConfigConstants variables
+- [FLINK-4183](https://issues.apache.org/jira/browse/FLINK-4183): Move checking for StreamTableEnvironment into validation layer
+- [FLINK-4185](https://issues.apache.org/jira/browse/FLINK-4185): Reflecting rename from Tachyon to Alluxio
+- [FLINK-4186](https://issues.apache.org/jira/browse/FLINK-4186): Expose Kafka metrics through Flink metrics
+- [FLINK-4192](https://issues.apache.org/jira/browse/FLINK-4192): Move Metrics API to separate module
+- [FLINK-4197](https://issues.apache.org/jira/browse/FLINK-4197): Allow Kinesis Endpoint to be Overridden via Config
+- [FLINK-4202](https://issues.apache.org/jira/browse/FLINK-4202): Add JM metric which shows the restart duration
+- [FLINK-4206](https://issues.apache.org/jira/browse/FLINK-4206): Metric names should allow special characters
+- [FLINK-4209](https://issues.apache.org/jira/browse/FLINK-4209): Fix issue on docker with multiple NICs and remove supervisord dependency
+- [FLINK-4210](https://issues.apache.org/jira/browse/FLINK-4210): Move close()/isClosed() out of MetricGroup interface
+- [FLINK-4229](https://issues.apache.org/jira/browse/FLINK-4229): Do not start Metrics Reporter by default
+- [FLINK-4244](https://issues.apache.org/jira/browse/FLINK-4244): Field names for union operator do not have to be equal
+- [FLINK-4246](https://issues.apache.org/jira/browse/FLINK-4246): Allow Specifying Multiple Metrics Reporters
+- [FLINK-4269](https://issues.apache.org/jira/browse/FLINK-4269): Decrease log level in RuntimeMonitorHandler
+- [FLINK-4279](https://issues.apache.org/jira/browse/FLINK-4279): [py] Set flink dependencies to provided
+- [FLINK-4299](https://issues.apache.org/jira/browse/FLINK-4299): Show loss of job manager in Client
+
+### New Feature
+
+- [FLINK-1745](https://issues.apache.org/jira/browse/FLINK-1745): Add exact k-nearest-neighbours algorithm to machine learning library
+- [FLINK-2044](https://issues.apache.org/jira/browse/FLINK-2044): Implementation of Gelly HITS Algorithm
+- [FLINK-2099](https://issues.apache.org/jira/browse/FLINK-2099): Add a SQL API
+- [FLINK-2166](https://issues.apache.org/jira/browse/FLINK-2166): Add fromCsvFile() to TableEnvironment
+- [FLINK-2828](https://issues.apache.org/jira/browse/FLINK-2828): Add interfaces for Table API input formats
+- [FLINK-2909](https://issues.apache.org/jira/browse/FLINK-2909): Gelly Graph Generators
+- [FLINK-2946](https://issues.apache.org/jira/browse/FLINK-2946): Add orderBy() to Table API
+- [FLINK-2971](https://issues.apache.org/jira/browse/FLINK-2971): Add outer joins to the Table API
+- [FLINK-2997](https://issues.apache.org/jira/browse/FLINK-2997): Support range partition with user customized data distribution.
+- [FLINK-2998](https://issues.apache.org/jira/browse/FLINK-2998): Support range partition comparison for multi input nodes.
+- [FLINK-3034](https://issues.apache.org/jira/browse/FLINK-3034): Redis SInk Connector
+- [FLINK-3068](https://issues.apache.org/jira/browse/FLINK-3068): Add a Table API configuration to TableEnvironment
+- [FLINK-3207](https://issues.apache.org/jira/browse/FLINK-3207): Add a Pregel iteration abstraction to Gelly
+- [FLINK-3311](https://issues.apache.org/jira/browse/FLINK-3311): Add a connector for streaming data into Cassandra
+- [FLINK-3543](https://issues.apache.org/jira/browse/FLINK-3543): Introduce ResourceManager component
+- [FLINK-3546](https://issues.apache.org/jira/browse/FLINK-3546): Streaming Table API
+- [FLINK-3564](https://issues.apache.org/jira/browse/FLINK-3564): Implement distinct() for Table API
+- [FLINK-3626](https://issues.apache.org/jira/browse/FLINK-3626): zipWithIndex in Python API
+- [FLINK-3639](https://issues.apache.org/jira/browse/FLINK-3639): Add methods and utilities to register DataSets and Tables in the TableEnvironment
+- [FLINK-3640](https://issues.apache.org/jira/browse/FLINK-3640): Add support for SQL queries in DataSet programs
+- [FLINK-3721](https://issues.apache.org/jira/browse/FLINK-3721): Min and max accumulators
+- [FLINK-3768](https://issues.apache.org/jira/browse/FLINK-3768): Clustering Coefficient
+- [FLINK-3771](https://issues.apache.org/jira/browse/FLINK-3771): Methods for translating Graphs
+- [FLINK-3772](https://issues.apache.org/jira/browse/FLINK-3772): Graph algorithms for vertex and edge degree
+- [FLINK-3780](https://issues.apache.org/jira/browse/FLINK-3780): Jaccard Similarity
+- [FLINK-3786](https://issues.apache.org/jira/browse/FLINK-3786): Add BigDecimal and BigInteger as Basic types
+- [FLINK-3856](https://issues.apache.org/jira/browse/FLINK-3856): Create types for java.sql.Date/Time/Timestamp
+- [FLINK-3859](https://issues.apache.org/jira/browse/FLINK-3859): Add BigDecimal/BigInteger support to Table API
+- [FLINK-3872](https://issues.apache.org/jira/browse/FLINK-3872): Add Kafka TableSource with JSON serialization
+- [FLINK-3879](https://issues.apache.org/jira/browse/FLINK-3879): Native implementation of HITS algorithm
+- [FLINK-3898](https://issues.apache.org/jira/browse/FLINK-3898): Adamic-Adar Similarity
+- [FLINK-3906](https://issues.apache.org/jira/browse/FLINK-3906): Global Clustering Coefficient
+- [FLINK-3907](https://issues.apache.org/jira/browse/FLINK-3907): Directed Clustering Coefficient
+- [FLINK-3919](https://issues.apache.org/jira/browse/FLINK-3919): Distributed Linear Algebra: row-based matrix
+- [FLINK-3925](https://issues.apache.org/jira/browse/FLINK-3925): GraphAlgorithm to filter by maximum degree
+- [FLINK-3941](https://issues.apache.org/jira/browse/FLINK-3941): Add support for UNION (with duplicate elimination)
+- [FLINK-3942](https://issues.apache.org/jira/browse/FLINK-3942): Add support for INTERSECT
+- [FLINK-3943](https://issues.apache.org/jira/browse/FLINK-3943): Add support for EXCEPT (set minus)
+- [FLINK-3965](https://issues.apache.org/jira/browse/FLINK-3965): Delegating GraphAlgorithm
+- [FLINK-4013](https://issues.apache.org/jira/browse/FLINK-4013): GraphAlgorithms to simplify directed and undirected graphs
+
+### Task
+
+- [FLINK-3139](https://issues.apache.org/jira/browse/FLINK-3139): NULL values handling in Table API
+- [FLINK-3221](https://issues.apache.org/jira/browse/FLINK-3221): Move Table API on top of Apache Calcite
+- [FLINK-3609](https://issues.apache.org/jira/browse/FLINK-3609): Revisit selection of Calcite rules
+- [FLINK-3738](https://issues.apache.org/jira/browse/FLINK-3738): Refactor TableEnvironment and TranslationContext
+- [FLINK-3743](https://issues.apache.org/jira/browse/FLINK-3743): Upgrade breeze from 0.11.2 to 0.12
+- [FLINK-3847](https://issues.apache.org/jira/browse/FLINK-3847): Reorganize package structure of flink-table
+- [FLINK-3852](https://issues.apache.org/jira/browse/FLINK-3852): Use a StreamExecutionEnvironment in the quickstart job skeleton
+
+### Test
+
+- [FLINK-2100](https://issues.apache.org/jira/browse/FLINK-2100): Add ITCases for all Table API examples
+- [FLINK-2444](https://issues.apache.org/jira/browse/FLINK-2444): Add tests for HadoopInputFormats
+- [FLINK-2445](https://issues.apache.org/jira/browse/FLINK-2445): Add tests for HadoopOutputFormats
+- [FLINK-3517](https://issues.apache.org/jira/browse/FLINK-3517): Number of job and task managers not checked in scripts
+- [FLINK-3782](https://issues.apache.org/jira/browse/FLINK-3782): ByteArrayOutputStream and ObjectOutputStream should close
+- [FLINK-4010](https://issues.apache.org/jira/browse/FLINK-4010): Scala Shell tests may fail because of a locked STDIN
+- [FLINK-4230](https://issues.apache.org/jira/browse/FLINK-4230): Session Windowing IT Case
+
+### Wish
+
+- [FLINK-2673](https://issues.apache.org/jira/browse/FLINK-2673): Scala API does not support Option type as key