https://github.com/apache/flink

sort by:
Revision Author Date Message Commit Date
760eea8 Commit for release 1.3.0 26 May 2017, 14:06:53 UTC
869554d [FLINK-6658] [cep] Use scala Collections in scala CEP API. 26 May 2017, 13:04:42 UTC
97c41f6 [FLINK-6702] put the CEP tests' harness.close() calls into a finally block 26 May 2017, 09:36:12 UTC
4123ce6 [FLINK-6702] fix SIGABRT during GC in the CEP unit tests 26 May 2017, 09:36:12 UTC
7fe4df3 [FLINK-6653] [kinesis] Improvements to removal of AWS's Shard class in checkpoints This closes #3994. 26 May 2017, 08:33:50 UTC
64ca1aa [FLINK-6653] Avoid directly serializing AWS's Shard class in Kinesis consumer's checkpoints 26 May 2017, 08:33:42 UTC
4ae040c [FLINK-6704][yarn] Fix user-jars not being possible to exclude from system class path This closes #3979. 26 May 2017, 08:33:29 UTC
2e138f1 [FLINK-6708] [yarn] Minor improvements to YARN session HA fixes This closes #3981. This closes #3982. 26 May 2017, 08:33:20 UTC
9bc34bf [FLINK-6708] [yarn] Harden FlinkYarnSessionCli to handle GetClusterStatusResponse exceptions This PR hardens the FlinkYarnSessionCli by handling exceptions which occur when retrieving the GetClusterStatusResponse. If no such response is retrieved and instead an exception is thrown, the Cli won't fail but retry it the next time. 26 May 2017, 08:33:13 UTC
99e15dd [FLINK-6646] [yarn] Let YarnJobManager delete Yarn application files Before the YarnClusterClient decided when to delete the Yarn application files. This is problematic because the client does not know whether a Yarn application is being restarted or terminated. Due to this the files where always deleted. This prevents Yarn from restarting a failed ApplicationMaster, effectively thwarting Flink's HA capabilities. The PR changes the behaviour such that the YarnJobManager deletes the Yarn files if it receives a StopCluster message. That way, we can be sure that the yarn files are deleted only iff the cluster is intended to be shut down. 26 May 2017, 08:32:48 UTC
e045423 [FLINK-6714] [runtime] Use user classloader for operator state copying on snapshots This closes #3987. 26 May 2017, 08:31:19 UTC
401e997 [FLINK-6669] set inputEncoding to UTF-8 in scalastyle-maven-plugin 24 May 2017, 14:52:02 UTC
d1ae1cd [FLINK-6320] fix unit test failing sometimes when deleting a temp directory This closes #3966. 24 May 2017, 14:52:02 UTC
4767f84 [FLINK-6659] fix SavepointITCase leaving temporary data behind -> use a JUnit '@Rule' that does the cleanup This closes #3962. 24 May 2017, 14:52:02 UTC
0824333 [FLINK-6659] fix RocksDBMergeIteratorTest leaving temporary data behind -> use a JUnit '@Rule' that does the cleanup 24 May 2017, 14:52:02 UTC
0f86dee [FLINK-6650] [table] Improve the error message for toAppendStream This closes #3958. 24 May 2017, 14:05:04 UTC
353d600 [FLINK-6690] Fix meta-data restore in RocksDBKeyedStateBackend under rescaling 24 May 2017, 12:54:20 UTC
f1e059b [FLINK-6685] Prevent that SafetyNetCloseableRegistry is closed prematurely in Task::triggerCheckpointBarrier 24 May 2017, 12:54:12 UTC
d552b34 [FLINK-6662] [errMsg] Improve error message if recovery from RetrievableStateHandles fails When recovering state from a ZooKeeperStateHandleStore it can happen that the deserialization fails, because one tries to recover state from an old Flink version which is not compatible. In this case we should output a better error message such that the user can easily spot the problem. This closes #3972. 23 May 2017, 18:25:18 UTC
ce685db [FLINK-6660] [docs] Expand the connectors overview page This closes #3964. 23 May 2017, 14:27:10 UTC
0ae98d3 [FLINK-6492] Fix unclosed DataOutputViewStream usage This closes #3898. 23 May 2017, 14:26:52 UTC
f112b56 [FLINK-6671] [tests] Make RocksDBStateBackendTest.testCancelRunningSnapshot stable Let first the snapshotting thread completely finish before checking the test condition. This prevents race conditions between the checkpointing thread and the verification. 23 May 2017, 11:40:41 UTC
39114e2 [FLINK-6328] [chkPts] Don't add savepoints to CompletedCheckpointStore The lifecycle of savepoints is not managed by the CheckpointCoordinator and fully in the hand of the user. Therefore, the CheckpointCoordinator cannot rely on them when trying to recover from failures. E.g. a user moving a savepoint shortly before a failure could completely break Flink's recovery mechanism because Flink cannot skip failed checkpoints when recovering. Therefore, until Flink is able to skip failed checkpoints when recovering, we should not add savepoints to the CompletedCheckpointStore which is used to retrieve checkpoint for recovery. The distinction of a savepoint is done on the basis of the CheckpointProperties (CheckpointProperties.STANDARD_SAVEPOINT). 23 May 2017, 08:27:22 UTC
2bd082f [FLINK-6656] [cep] Change element PriorityQueue to MapState. This is to leverage the fact that RocksDB already returns the keys sorted. So now elements, instead of being stores in a PQ and all of them being deserialized and serialized at each incoming element, the are stored in a MapState with the key being the timestamp and the value, a List of elements that refer to the same timestamp. 23 May 2017, 08:23:41 UTC
30fba2b Rebuild webUI 22 May 2017, 17:24:19 UTC
f4f5cf1 [FLINK-6448][web] Rename "Free Memory" field to "JVM Heap Size" 22 May 2017, 17:24:19 UTC
7a9030f [FLINK-6451][web] Rename "Metrics" tab to "Task Metrics" 22 May 2017, 17:24:19 UTC
4df9b5a [FLINK-6450][web] Rename "TaskManagers" tab to "Subtasks by Taskmanager" 22 May 2017, 17:24:19 UTC
f72b873 [FLINK-6610][web] Allow uploadDir to be null in WebFrontendBootstrap 22 May 2017, 17:24:19 UTC
95fce15 [FLINK-6632] [table] Improved the method BoolLiteral of ExpressionParser for case insensitive. This closes #3944. 22 May 2017, 17:01:49 UTC
09cc3f7 [FLINK-6482] [core] Add nested serializers to config snapshots of composite serializers This commit adds also the nested serializers themselves to the configuration snapshots of composite serializers. This opens up the oppurtunity to use the previous nested serializer as the convert deserializer in the case that a nested serializer in the new serializer determines that state migration is required. This commit also consolidate all TypeSerializer-related serialization proxies into a single utility class. This closes #3937. 22 May 2017, 15:30:27 UTC
0d9087d [hotfix] [docs] Remove invalid REST path 22 May 2017, 10:32:03 UTC
f783e52 [FLINK-6629] Use HAServices to find connecting address for ClusterClient's ActorSystem The ClusterClient starts its ActorSystem lazily. In order to find out the address to which to bind, the ClusterClient tries to connect to the JobManager. In order to find out the JobManager's address it is important to use the HighAvailabilityServices instead of retrieving the address information from the configuration, because otherwise it conflicts with HA mode. This closes #3949. 22 May 2017, 09:21:20 UTC
77c02fe [FLINK-6635] [test] Fix ClientConnectionTest The ClientConnectionTest passed even though it was failing the test because we were expecting an exception and checking a special word to contained in the exception's message. Unfortunately, we generated an AssertionError with the same word if the actual logic we wanted to test failed. That cause the test to pass. 22 May 2017, 09:21:20 UTC
6e40223 [FLINK-6651] Add synchronization to SharedStateRegistry::clear (cherry picked from commit 392bc71) 22 May 2017, 08:31:44 UTC
fcf8466 [FLINK-6644] Don't register HUP signal handler on Windows This closes #3955. 20 May 2017, 14:05:40 UTC
1bd7599 [FLINK-6628] Fix start scripts on Windows This closes #3954. 20 May 2017, 14:05:40 UTC
c35a177 [FLINK-6551] Reject empty OutputTag names This closes #3953. 20 May 2017, 14:05:40 UTC
058e0f0 [FLINK-6640] Ensure registration of shared state happens before externalizing a checkpoint (cherry picked from commit 0403563) 20 May 2017, 13:46:52 UTC
c15f373 [FLINK-6641] [ha] Don't let the ClusterClient clean up HA services data when being shut down The ClusterClient should not call HighAvailabilityServices#closeAndCleanupAllData when being shut down. The reason is that this call will delete all HA data needed for a future recovery. Only the JobManager should be allowed to decide when to discard HA data or not. 20 May 2017, 12:56:19 UTC
5fde739 [FLINK-6439] Fix close OutputStream && InputStream in OperatorSnapshotUtil 19 May 2017, 19:09:08 UTC
c3ab5c8 [FLINK-6586] InputGateMetrics return 0 as min for local channels 19 May 2017, 19:09:08 UTC
5d1cda5 [FLINK-6639][docs] fix code tabs in CEP docs 19 May 2017, 19:09:08 UTC
54b88d7 [FLINK-5636][metrics] Measure numRecordsIn in StreamTwoInputProcessor 19 May 2017, 19:09:08 UTC
17a4bb1 [hotfix][rat] Add exclusion for all test snapshots/savepoints This closes #3854. 19 May 2017, 19:09:08 UTC
c62553c [FLINK-6634] [cep] NFASerializer serializes ComputationState counter. 19 May 2017, 14:28:56 UTC
f6a596f [FLINK-6606] Hide WrapperMasterHook by making it private 19 May 2017, 13:21:24 UTC
3dba48e [FLINK-6606] Set UserCodeClassLoader as TCCL for MasterTriggerRestoreHook - wrap calls to MasterTriggerRestoreHook (and its factory) such that the user classloader is applied This closes #3933. 19 May 2017, 13:21:23 UTC
6d178a9 [FLINK-6574] [table] Support nested catalogs in ExternalCatalog. 19 May 2017, 12:23:11 UTC
d1cff3a [FLINK-6582] [docs] Project from maven archetype is not buildable by default The pom.xml for flink-quickstart-java and flink-quickstart-scala must specify scala.version and scala.binary.version. This closes #3910 19 May 2017, 09:45:09 UTC
f620040 [FLINK-6633] Register shared state before adding to CompletedCheckpointStore 19 May 2017, 09:01:12 UTC
f58fec7 [FLINK-6612] Allow ZooKeeperStateHandleStore to lock created ZNodes In order to guard against deletions of ZooKeeper nodes which are still being used by a different ZooKeeperStateHandleStore, we have to introduce a locking mechanism. Only after all ZooKeeperStateHandleStores have released their lock, the ZNode is allowed to be deleted. THe locking mechanism is implemented via ephemeral child nodes of the respective ZooKeeper node. Whenever a ZooKeeperStateHandleStore wants to lock a ZNode, thus, protecting it from being deleted, it creates an ephemeral child node. The node's name is unique to the ZooKeeperStateHandleStore instance. The delete operations will then only delete the node if it does not have any children associated. In order to guard against oprhaned lock nodes, they are created as ephemeral nodes. This means that they will be deleted by ZooKeeper once the connection of the ZooKeeper client which created the node timed out. 19 May 2017, 09:00:07 UTC
0963718 [hotfix] [kafka] Remove unused operator state store field in FlinkKafkaProducerBase 19 May 2017, 06:42:12 UTC
d3b5870 [FLINK-6288] [kafka] Cleanup and improvements to FlinkKafkaPartitioner custom partitioning This commit wraps up some general improvements to the new Kafka sink custom partitioning API, most notably: 1. remove deprecated constructors from base classes, as they are not user-facing. 2. modify producer IT test to test custom partitioning for dynamic topics. 3. improve documentation and Javadocs of the new interfaces. This closes #3901. 19 May 2017, 06:42:04 UTC
58c4eed [FLINK-6288] [kafka] New custom partitioner API that correctly handles multiple Kafka sink topics 19 May 2017, 06:41:54 UTC
1a43bad [FLINK-6608] [security, config] Relax Kerberos login contexts parsing This closes #3928. 19 May 2017, 06:41:48 UTC
94111f9 [hotfix] Correct equals & hashCode implementation of KryoSerializer 18 May 2017, 21:16:27 UTC
fe5b92f [hotfix] Remove unnecessary job id from RocksDBKeyedStateBackend 18 May 2017, 21:16:27 UTC
6c57354 [hotfix] Remove some raw type usage in RocksDBKeyedStateBackend Introduce more generic parameters 18 May 2017, 21:16:27 UTC
cfb6a69 [hotfix] Restore KeySerializer only once 18 May 2017, 21:16:27 UTC
51fb7ed [FLINK-6614] [table] Fix translation of group auxiliary functions (e.g., TUMBLE_END). 18 May 2017, 20:06:00 UTC
0246ce5 [FLINK-6543] [table] Deprecate toDataStream and add toAppendStream. 18 May 2017, 20:06:00 UTC
c794d6e [FLINK-6585] [table] Fix execution of Table examples in IDE. 18 May 2017, 20:06:00 UTC
6583fb4 [FLINK-6618] [table] Fix translation of WindowProperties in Table API. 18 May 2017, 20:06:00 UTC
45923ff [FLINK-6616] [docs] Clarify provenance of official Docker images Note that the official Docker images for Flink are community supported and not an official release of the Apache Flink PMC. This closes #3932 18 May 2017, 20:01:17 UTC
5420687 [hotfix] [docs] Fix link to docker-compose.yml This closes #3887 18 May 2017, 20:01:17 UTC
979228b [FLINK-6416] Fix divide-by-zero in InputGateMetrics 18 May 2017, 15:43:08 UTC
5569c4f [FLINK-6440][metrics] Downgrade fetching failure logging to DEBUG 18 May 2017, 15:42:55 UTC
44be162 [FLINK-6596][travis] Disable javadoc generation for jdk 7 18 May 2017, 15:42:42 UTC
ca3e403 [FLINK-6031][yarn] Add config parameter for user-jar inclusion in classpath This closes #3931 18 May 2017, 12:03:17 UTC
5605feb [FLINK-6624] [cep] Fix SharedBuffer#hashCode(). 18 May 2017, 09:35:34 UTC
a30a8be [FLINK-6570] QueryableStateClient docs with matching constructor signature This closes #3926. 18 May 2017, 07:55:45 UTC
8b5ba67 [FLINK-6600] Add key serializer config snapshot to keyed backend checkpoints This commit adds the config snapshot of the key serializer of keyed backends to its checkpoints. This allows the oppurtunity to upgrade key serializers, as well as state migration in the future in the case of incompatible old and new key serializers. This closes #3925. 17 May 2017, 14:52:54 UTC
98f4fad [FLINK-6589] [core] Deserialize ArrayList with capacity of size+1 to prevent growth. 17 May 2017, 13:29:46 UTC
36cac0f [FLINK-6583] [table] Add state cleanup for counting GroupWindows. 17 May 2017, 13:29:43 UTC
056d955 [FLINK-6598] [table] Remove unused parameter from DataStreamGroupAggregate. 17 May 2017, 13:29:40 UTC
7a045f2 [hotfix] Add configuration notice to HistryServer overview 17 May 2017, 13:11:44 UTC
849dd9d [FLINK-6609] [cep] Fix wrong version assignment with multiple TAKEs. 17 May 2017, 12:40:28 UTC
d80af81 [FLINK-6604] [cep] Remove java serialization from the library. 17 May 2017, 12:40:27 UTC
34a6020 [hotfix] [cep] Remove unused keySelector in operator. 17 May 2017, 12:40:26 UTC
36df901 [FLINK-6578] [cep] Fix self-loop handling in SharedBuffer. 17 May 2017, 12:40:26 UTC
4560d56 [FLINK-6255] [cep] Remove PatternStream.getSideOutput(). 17 May 2017, 12:40:25 UTC
4f14e53 [FLINK-6536] [cep] Improve error message in SharedBuffer::put(). 17 May 2017, 12:40:24 UTC
fa64a60 [FLINK-6371] [cep] NFA return matched patterns as Map<String, List<T>>. 17 May 2017, 12:40:23 UTC
fe1316b [FLINK-6587] [table] Simplification and bug fixing of the ExpressionParser This closes #3923. 17 May 2017, 12:21:12 UTC
954a100 [FLINK-6601] [table] Use time indicators in DataStreamLogicalWindowAggregateRule This closes #3924. 17 May 2017, 09:54:46 UTC
60873b0 [FLINK-6020] Introduce BlobServer#readWriteLock to synchronize file creation and deletion This commit introduces a BlobServer#readWriteLock in order to synchronize file creation and deletion operations in BlobServerConnection and BlobServer. This will prevent that multiple put and get operations interfere with each other and with get operations. The get operations are synchronized using the read lock in order to guarantee some kind of parallelism. Add Get and Delete operation tests This closes #3888. 17 May 2017, 06:17:02 UTC
e3ea89a [FLINK-6519] Integrate BlobStore in lifecycle management of HighAvailabilityServices The HighAvailabilityService creates a single BlobStoreService instance which is shared by all BlobServer and BlobCache instances. The BlobStoreService's lifecycle is exclusively managed by the HighAvailabilityServices. This means that the BlobStore's content is only cleaned up if the HighAvailabilityService's HA data is cleaned up. Having this single point of control, makes it easier to decide when to discard HA data (e.g. in case of a successful job execution) and when to retain the data (e.g. for recovery). Close and cleanup all data of BlobStore in HighAvailabilityServices Use HighAvailabilityServices to create BlobStore Introduce BlobStoreService interface to hide close and closeAndCleanupAllData methods This closes #3864. 17 May 2017, 06:16:59 UTC
827d74e [FLINK-6284] Correct sorting of completed checkpoints in ZooKeeperStateHandleStore In order to store completed checkpoints in an increasing order in ZooKeeper, the paths for the completed checkpoint is no generated by String.format("/%019d", checkpointId) instead of String.format("/%s", checkpointId). This makes sure that the converted long will always have the same length with leading 0s. Fix failing ZooKeeperCompletedCheckpointStoreITCase This closes #3884. 17 May 2017, 06:16:54 UTC
9c6c965 [FLINK-6555] [futures] Generalize ConjunctFuture to return results The ConjunctFuture now returns the set of future values once it is completed. Introduce WaitingConjunctFuture; Fix thread safety issue with ResultConjunctFuture The WaitingConjunctFuture waits for the completion of its futures. The future values are discarded making it more efficient than the ResultConjunctFuture which returns the futures' values. The WaitingConjunctFuture is instantiated via FutureUtils.waitForAll(Collection<Future>). This closes #3873. 17 May 2017, 06:16:50 UTC
4104409 [FLINK-6581] [cli] Correct dynamic property parsing for YARN cli The YARN cli will now split the dynamic propertie at the first occurrence of the = sign instead of splitting it at every = sign. That way we support dynamic properties of the form -yDenv.java.opts="-DappName=foobar". Address PR comments 16 May 2017, 22:39:21 UTC
629d363 [FLINK-6462] [table] Add requiresOver method to AggregateFunction. This closes #3851. 16 May 2017, 19:36:27 UTC
fc20127 [FLINK-6593] [table] Fix Bug in ProctimeAttribute or RowtimeAttribute with CodeGenerator This closes #3918. 16 May 2017, 12:45:15 UTC
a827c54 [hotfix] Further clarify side-output error message for same id and type 16 May 2017, 11:53:45 UTC
4e7598d [FLINK-6175] Harden HistoryServerTest#testFullArchiveLifecycle This closes #3655. 16 May 2017, 06:48:17 UTC
446d651 [FLINK-6552] Allow differing types for side outputs 15 May 2017, 16:54:00 UTC
89e90f3 [FLINK-6580] Sync default heap sizes from code with config file This closes #3900 15 May 2017, 14:03:36 UTC
30c476e [hotfix] Disable broken test in TableEnvironmentITCase 15 May 2017, 13:39:55 UTC
0c2d0da [FLINK-6579] [table] Add proper support for BasicArrayTypeInfo This closes #3902. 15 May 2017, 11:50:51 UTC
e23328e [FLINK-6517] [table] Support multiple consecutive windows This closes #3897. 15 May 2017, 10:16:36 UTC
back to top