You are viewing a plain text version of this content. The canonical link for it is here.
- [1/4] flink git commit: [FLINK-7939] [table] Fix Table conversion of DataStream of AtomicType. - posted by fh...@apache.org on 2017/11/01 01:52:10 UTC, 0 replies.
- [2/4] flink git commit: [FLINK-6563] [table] Add builders with time attribute support for KafkaTableSources. - posted by fh...@apache.org on 2017/11/01 01:52:11 UTC, 0 replies.
- [3/4] flink git commit: [FLINK-6563] [table] Add builders with time attribute support for KafkaTableSources. - posted by fh...@apache.org on 2017/11/01 01:52:12 UTC, 0 replies.
- [4/4] flink git commit: [FLINK-6563] [table] Add builders with time attribute support for KafkaTableSources. - posted by fh...@apache.org on 2017/11/01 01:52:13 UTC, 0 replies.
- [1/3] flink git commit: [FLINK-7902] Use TypeSerializer in TwoPhaseCommitSinkFunctions - posted by al...@apache.org on 2017/11/01 09:20:19 UTC, 0 replies.
- [2/3] flink git commit: [hotfix] Make fields transient in TwoPhaseCommitSinkFunction - posted by al...@apache.org on 2017/11/01 09:20:20 UTC, 0 replies.
- [3/3] flink git commit: [hotfix] Make internal KafkaProducer11 details package private - posted by al...@apache.org on 2017/11/01 09:20:21 UTC, 0 replies.
- flink git commit: [FLINK-7939] [table] Fix Table conversion of DataStream of AtomicType. - posted by fh...@apache.org on 2017/11/01 10:55:42 UTC, 0 replies.
- flink git commit: [FLINK-7400][cluster] fix cut-off memory not used for off-heap reserve as intended - posted by tr...@apache.org on 2017/11/01 12:11:59 UTC, 0 replies.
- flink git commit: [FLINK-6225] [cassandra] Add a CassandraAppendTableSink. - posted by fh...@apache.org on 2017/11/01 13:53:01 UTC, 0 replies.
- [1/4] flink git commit: [FLINK-7773] [tests] Fix unfinished stubbing in UtilsTest - posted by tr...@apache.org on 2017/11/01 14:49:47 UTC, 0 replies.
- [2/4] flink git commit: [FLINK-7867] Start MetricQueryService in TaskManagerRunner - posted by tr...@apache.org on 2017/11/01 14:49:48 UTC, 0 replies.
- [3/4] flink git commit: [hotfix] Let flink-yarn-tests UtilsTest extend TestLogger - posted by tr...@apache.org on 2017/11/01 14:49:49 UTC, 0 replies.
- [4/4] flink git commit: [FLINK-7863] Generalize MetricFetcher to work with a RestfulGateway - posted by tr...@apache.org on 2017/11/01 14:49:50 UTC, 0 replies.
- [1/7] flink git commit: [FLINK-7876] Register TaskManagerMetricGroup under ResourceID - posted by tr...@apache.org on 2017/11/01 22:27:41 UTC, 0 replies.
- [2/7] flink git commit: [FLINK-7876] Register TaskManagerMetricGroup under ResourceID - posted by tr...@apache.org on 2017/11/01 22:27:42 UTC, 0 replies.
- [3/7] flink git commit: [FLINK-7876] Register TaskManagerMetricGroup under ResourceID - posted by tr...@apache.org on 2017/11/01 22:27:43 UTC, 0 replies.
- [4/7] flink git commit: [FLINK-7876] Register TaskManagerMetricGroup under ResourceID - posted by tr...@apache.org on 2017/11/01 22:27:44 UTC, 0 replies.
- [5/7] flink git commit: [FLINK-7876] Properly start and shutdown MetricRegistry by ClusterEntrypoint - posted by tr...@apache.org on 2017/11/01 22:27:45 UTC, 0 replies.
- [6/7] flink git commit: [FLINK-7876] Properly start and shutdown MetricRegistry by ClusterEntrypoint - posted by tr...@apache.org on 2017/11/01 22:27:46 UTC, 0 replies.
- [7/7] flink git commit: [FLINK-7876] Merge TaskExecutorMetricsInitializer and MetricUtils - posted by tr...@apache.org on 2017/11/01 22:27:47 UTC, 0 replies.
- [01/11] flink git commit: [FLINK-7784] [kafka011-producer] Make TwoPhaseCommitSinkFunction aware of transaction timeouts. - posted by tz...@apache.org on 2017/11/02 09:59:59 UTC, 0 replies.
- [02/11] flink git commit: [hotfix] [kafka-tests] Clean up FlinkKafkaProducer011Tests - posted by tz...@apache.org on 2017/11/02 10:00:00 UTC, 0 replies.
- [03/11] flink git commit: [FLINK-7732][kafka-consumer] Do not commit to kafka Flink's sentinel offsets - posted by tz...@apache.org on 2017/11/02 10:00:01 UTC, 0 replies.
- [04/11] flink git commit: [hotfix][kafka] Fix FlinkKafkaProducer011 logger - posted by tz...@apache.org on 2017/11/02 10:00:02 UTC, 0 replies.
- [05/11] flink git commit: [FLINK-7838][kafka] Add missing synchronization in FlinkKafkaProducer - posted by tz...@apache.org on 2017/11/02 10:00:03 UTC, 0 replies.
- [06/11] flink git commit: [hotfix][kafka] Bump Kafka 0.11 dependency - posted by tz...@apache.org on 2017/11/02 10:00:04 UTC, 0 replies.
- [07/11] flink git commit: [hotfix][kafka-tests] Fix test names so that they are not ignored by mvn build - posted by tz...@apache.org on 2017/11/02 10:00:05 UTC, 0 replies.
- [08/11] flink git commit: [hotfix][kafka] Remove unsued field in FlinkKafkaProducer011 - posted by tz...@apache.org on 2017/11/02 10:00:06 UTC, 0 replies.
- [09/11] flink git commit: [hotfix][kafka] Move checkpointing enable checking to initializeState - posted by tz...@apache.org on 2017/11/02 10:00:07 UTC, 0 replies.
- [10/11] flink git commit: [hotfix][kafka] Do not return producers to a pool in abort for non EXACTLY_ONCE modes - posted by tz...@apache.org on 2017/11/02 10:00:08 UTC, 0 replies.
- [11/11] flink git commit: [hotfix] [kafka-tests] Rename FlinkKafkaProducerTest to *ITCase - posted by tz...@apache.org on 2017/11/02 10:00:09 UTC, 0 replies.
- [1/3] flink git commit: [hotfix] [docs] Fix typos in types serialization documentation - posted by se...@apache.org on 2017/11/02 13:02:46 UTC, 0 replies.
- [2/3] flink git commit: [hotfix] [javadoc] Fix typo in Javadoc of ManagedSnapshotContext#getCheckpointId() - posted by se...@apache.org on 2017/11/02 13:02:47 UTC, 0 replies.
- [3/3] flink git commit: [hotfix] [docs] Fix broken downloads page url - posted by se...@apache.org on 2017/11/02 13:02:48 UTC, 0 replies.
- [1/2] flink git commit: [FLINK-7960] [tests] Fix race conditions in ExecutionGraphRestartTest#completeCancellingForAllVertices - posted by tr...@apache.org on 2017/11/02 14:08:17 UTC, 0 replies.
- [2/2] flink git commit: [hotfix] Instantiate a HdfsConfiguration in HadoopUtils#getHadoopConfiguration() - posted by tr...@apache.org on 2017/11/02 14:08:18 UTC, 0 replies.
- flink git commit: [FLINK-7764][kafka]FlinkKafkaProducer010 does not accept name, uid, or parallelism - posted by al...@apache.org on 2017/11/02 15:27:35 UTC, 0 replies.
- flink git commit: [FLINK-7764] [kafka] Enable the operator settings for FlinkKafkaProducer010 - posted by al...@apache.org on 2017/11/02 15:31:08 UTC, 0 replies.
- [1/3] flink git commit: [FLINK-7778] [build] Shade ZooKeeper dependency (followups) - posted by se...@apache.org on 2017/11/02 15:51:54 UTC, 0 replies.
- [2/3] flink git commit: [FLINK-7778] [build] Shade ZooKeeper dependency (part 2) - posted by se...@apache.org on 2017/11/02 15:51:55 UTC, 0 replies.
- [3/3] flink git commit: [FLINK-7778] [build] Shade ZooKeeper dependency (part 1) - posted by se...@apache.org on 2017/11/02 15:51:56 UTC, 0 replies.
- [1/4] flink git commit: [FLINK-7153] Re-introduce preferred locations for scheduling - posted by tr...@apache.org on 2017/11/02 17:01:12 UTC, 0 replies.
- [2/4] flink git commit: [FLINK-7153] Introduce LocationPreferenceConstraint for scheduling - posted by tr...@apache.org on 2017/11/02 17:01:13 UTC, 0 replies.
- [3/4] flink git commit: [FLINK-7153] Introduce LocationPreferenceConstraint for scheduling - posted by tr...@apache.org on 2017/11/02 17:01:14 UTC, 0 replies.
- [4/4] flink git commit: [hotfix] Make failover region topological sorted - posted by tr...@apache.org on 2017/11/02 17:01:15 UTC, 0 replies.
- [1/2] flink git commit: [hotfix] [tests] Improve TypeInfoTestCoverageTest - posted by se...@apache.org on 2017/11/02 19:18:14 UTC, 0 replies.
- [2/2] flink git commit: [hotfix] [build] Fix broken project references to 'flink-shaded-curator-recipes'. - posted by se...@apache.org on 2017/11/02 19:18:15 UTC, 0 replies.
- [1/3] flink git commit: [FLINK-7968] [core] Move DataOutputSerializer and DataInputDeserializer to 'flink-core' - posted by se...@apache.org on 2017/11/02 21:22:30 UTC, 0 replies.
- [2/3] flink git commit: [FLINK-7968] [core] Move DataOutputSerializer and DataInputDeserializer to 'flink-core' - posted by se...@apache.org on 2017/11/02 21:22:31 UTC, 0 replies.
- [3/3] flink git commit: [FLINK-7968] [core] Move DataOutputSerializer and DataInputDeserializer to 'flink-core' - posted by se...@apache.org on 2017/11/02 21:22:32 UTC, 0 replies.
- [1/3] flink git commit: [FLINK-6226] [table] Add tests for UDFs with Byte, Short, and Float arguments. - posted by fh...@apache.org on 2017/11/03 08:43:20 UTC, 0 replies.
- [2/3] flink git commit: [FLINK-7421] [table] Fix serializability of AvroRowSerializationSchema + AvroRowDeserializationSchema. - posted by fh...@apache.org on 2017/11/03 08:43:21 UTC, 0 replies.
- [3/3] flink git commit: [FLINK-7338] [table] Fix retrieval of OVER window lower bound. - posted by fh...@apache.org on 2017/11/03 08:43:22 UTC, 0 replies.
- flink git commit: [FLINK-7421] [table] Fix serializability of AvroRowSerializationSchema + AvroRowDeserializationSchema. - posted by fh...@apache.org on 2017/11/03 09:29:47 UTC, 0 replies.
- flink git commit: [FLINK-6226] [table] Add tests for UDFs with Byte, Short, and Float arguments. - posted by fh...@apache.org on 2017/11/03 09:46:19 UTC, 0 replies.
- [01/21] flink git commit: [FLINK-7420] [avro] Abstract all Avro interaction behind AvroUtils - posted by se...@apache.org on 2017/11/03 17:11:24 UTC, 0 replies.
- [02/21] flink git commit: [FLINK-7420] [avro] (follow-up) Do not shade or exclude avro in Hadoop - posted by se...@apache.org on 2017/11/03 17:11:25 UTC, 0 replies.
- [03/21] flink git commit: [hotfix] [tests] Remove console poluting output in tests of flink-streaming-java - posted by se...@apache.org on 2017/11/03 17:11:26 UTC, 0 replies.
- [04/21] flink git commit: [FLINK-7972] [core] Move SerializationSchema to 'flink-core' - posted by se...@apache.org on 2017/11/03 17:11:27 UTC, 0 replies.
- [05/21] flink git commit: [FLINK-7972] [core] Move SerializationSchema to 'flink-core' - posted by se...@apache.org on 2017/11/03 17:11:28 UTC, 0 replies.
- [06/21] flink git commit: [FLINK-7420] [avro] Move all Avro code to flink-avro - posted by se...@apache.org on 2017/11/03 17:11:29 UTC, 0 replies.
- [07/21] flink git commit: [FLINK-7420] [avro] Move all Avro code to flink-avro - posted by se...@apache.org on 2017/11/03 17:11:30 UTC, 0 replies.
- [08/21] flink git commit: [FLINK-7420] [avro] Move all Avro code to flink-avro - posted by se...@apache.org on 2017/11/03 17:11:31 UTC, 0 replies.
- [09/21] flink git commit: [FLINK-7420] [avro] Move all Avro code to flink-avro - posted by se...@apache.org on 2017/11/03 17:11:32 UTC, 0 replies.
- [10/21] flink git commit: [FLINK-7420] [avro] Move all Avro code to flink-avro - posted by se...@apache.org on 2017/11/03 17:11:33 UTC, 0 replies.
- [11/21] flink git commit: [FLINK-7420] [avro] Move all Avro code to flink-avro - posted by se...@apache.org on 2017/11/03 17:11:34 UTC, 0 replies.
- [12/21] flink git commit: [FLINK-7420] [avro] Replace GenericData.Array by dummy when reading TypeSerializers - posted by se...@apache.org on 2017/11/03 17:11:35 UTC, 0 replies.
- [13/21] flink git commit: [FLINK-7420] [avro] Make flink-avro Scala independent - posted by se...@apache.org on 2017/11/03 17:11:36 UTC, 0 replies.
- [14/21] flink git commit: [hotfix] [avro] Improve Avro type hierarchy checks in AvroKryoSerializerUtils - posted by se...@apache.org on 2017/11/03 17:11:37 UTC, 0 replies.
- [15/21] flink git commit: [hotfix] [avro] Remove incorrect serializability from DataOutputEncoder - posted by se...@apache.org on 2017/11/03 17:11:38 UTC, 0 replies.
- [16/21] flink git commit: [FLINK-7847] [avro] Fix typo in jackson shading pattern - posted by se...@apache.org on 2017/11/03 17:11:39 UTC, 0 replies.
- [17/21] flink git commit: [hotfix] [avro] Fix some serializability warnings and problems - posted by se...@apache.org on 2017/11/03 17:11:40 UTC, 0 replies.
- [18/21] flink git commit: [hotfix] [avro] Improve AvroUtils to perform reflection lookups only once. - posted by se...@apache.org on 2017/11/03 17:11:41 UTC, 0 replies.
- [19/21] flink git commit: [hotfix] [avro] Minor XML formatting cleanup - posted by se...@apache.org on 2017/11/03 17:11:42 UTC, 0 replies.
- [20/21] flink git commit: [hotfix] [avro] Simplify the FSDataInputStreamWrapper - posted by se...@apache.org on 2017/11/03 17:11:43 UTC, 0 replies.
- [21/21] flink git commit: [hotfix] [avro] Add test that validates deserialization of Kryo Serializer in the absence of Avro - posted by se...@apache.org on 2017/11/03 17:11:44 UTC, 0 replies.
- flink git commit: [FLINK-7973] [filesystems] Fix shading patterns for META-INF/services entries - posted by se...@apache.org on 2017/11/03 20:10:05 UTC, 0 replies.
- flink git commit: [FLINK-7992][docs] extend the PR template asking for any S3 relation - posted by ch...@apache.org on 2017/11/06 12:15:12 UTC, 0 replies.
- flink git commit: [hotfix][build] Fix typo in parent pom - posted by ch...@apache.org on 2017/11/06 12:47:28 UTC, 0 replies.
- flink git commit: [hotfix][java] Add missing space to error message - posted by ch...@apache.org on 2017/11/06 12:50:06 UTC, 0 replies.
- flink git commit: [FLINK-7843][metrics][docs] Add time unit and metric type to system metrics reference - posted by ch...@apache.org on 2017/11/06 13:42:49 UTC, 0 replies.
- flink git commit: [FLINK-7994][mesos] Remove effectively unused curator dependency - posted by ch...@apache.org on 2017/11/06 14:20:35 UTC, 0 replies.
- flink git commit: [FLINK-7993][kafka] Sync curator shading patterns - posted by ch...@apache.org on 2017/11/06 14:45:08 UTC, 0 replies.
- [1/4] flink git commit: [FLINK-7516][memory] do not allow copies into a read-only ByteBuffer - posted by tr...@apache.org on 2017/11/06 15:19:23 UTC, 0 replies.
- [2/4] flink git commit: [FLINK-7515][network] allow actual 0-length content in NettyMessage#allocateBuffer() - posted by tr...@apache.org on 2017/11/06 15:19:24 UTC, 0 replies.
- [3/4] flink git commit: [FLINK-7745][tests] add tests for ensuring NetworkBufferPool overprovisioning behaviour - posted by tr...@apache.org on 2017/11/06 15:19:25 UTC, 0 replies.
- [4/4] flink git commit: [FLINK-7701][network] really fix watermark configuration order this time - posted by tr...@apache.org on 2017/11/06 15:19:26 UTC, 0 replies.
- [1/3] flink git commit: [FLINK-6022] [avro] Use Avro to serialize Avro in flight and in State - posted by se...@apache.org on 2017/11/06 18:57:51 UTC, 0 replies.
- [2/3] flink git commit: [hotfix] [avro] Define Avro version through variable - posted by se...@apache.org on 2017/11/06 18:57:52 UTC, 0 replies.
- [3/3] flink git commit: [FLINK-7997] [avro] Make Avro part of the user code space - posted by se...@apache.org on 2017/11/06 18:57:53 UTC, 0 replies.
- [flink] Git Push Summary - posted by al...@apache.org on 2017/11/06 19:19:47 UTC, 2 replies.
- flink git commit: Update version to 1.5-SNAPSHOT - posted by al...@apache.org on 2017/11/07 09:19:55 UTC, 0 replies.
- flink git commit: [hotfix][metrics][docs] Add type for numLateRecordsDropped metric - posted by ch...@apache.org on 2017/11/07 10:45:54 UTC, 0 replies.
- flink git commit: [hotfix][docs] Add type for numLateRecordsDropped metric in docs - posted by ch...@apache.org on 2017/11/07 10:46:47 UTC, 0 replies.
- flink git commit: [hotfix][rat] Add missing rat exclusions - posted by ch...@apache.org on 2017/11/07 11:20:47 UTC, 1 replies.
- [1/2] flink git commit: [FLINK-7822][QS][doc] Update Queryable State docs. - posted by kk...@apache.org on 2017/11/07 13:09:48 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-7823][QS] Update Queryable State configuration parameters. - posted by kk...@apache.org on 2017/11/07 13:09:49 UTC, 0 replies.
- [1/2] flink git commit: [FLINK-7823][QS] Update Queryable State configuration parameters. - posted by kk...@apache.org on 2017/11/07 13:14:08 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-7822][QS][doc] Update Queryable State docs. - posted by kk...@apache.org on 2017/11/07 13:14:09 UTC, 0 replies.
- [01/30] flink git commit: [FLINK-7872] Allow to pass in additional HTTP headers - posted by tr...@apache.org on 2017/11/07 14:07:59 UTC, 0 replies.
- [02/30] flink git commit: [hotfix] Speed up JobManagerFailsITCase by decreasing timeout - posted by tr...@apache.org on 2017/11/07 14:08:00 UTC, 0 replies.
- [03/30] flink git commit: [FLINK-7914] Introduce AkkaOptions.RETRY_GATE_CLOSED_FOR - posted by tr...@apache.org on 2017/11/07 14:08:01 UTC, 0 replies.
- [04/30] flink git commit: [FLINK-7862] [flip6] Add TaskManagerDetailsHandler - posted by tr...@apache.org on 2017/11/07 14:08:02 UTC, 0 replies.
- [05/30] flink git commit: [hotfix] Move TaskManagersHandler to rest.handler.taskmanager and messages to rest.messages.taskmanager - posted by tr...@apache.org on 2017/11/07 14:08:03 UTC, 0 replies.
- [06/30] flink git commit: [FLINK-7648] [flip6] Add TaskManagersHandler - posted by tr...@apache.org on 2017/11/07 14:08:04 UTC, 0 replies.
- [07/30] flink git commit: [FLINK-7648] [flip6] Write HardwareDescription in sub object of legacy.TaskManagersHandler - posted by tr...@apache.org on 2017/11/07 14:08:05 UTC, 0 replies.
- [08/30] flink git commit: [FLINK-7648] [flip6] Write HardwareDescription in sub object of legacy.TaskManagersHandler - posted by tr...@apache.org on 2017/11/07 14:08:06 UTC, 0 replies.
- [09/30] flink git commit: [FLINK-7648] [flip6] Write HardwareDescription in sub object of legacy.TaskManagersHandler - posted by tr...@apache.org on 2017/11/07 14:08:07 UTC, 0 replies.
- [10/30] flink git commit: [FLINK-7648] [flip6] Write HardwareDescription in sub object of legacy.TaskManagersHandler - posted by tr...@apache.org on 2017/11/07 14:08:08 UTC, 0 replies.
- [11/30] flink git commit: [FLINK-7862] Change web ui to calculate total memory from heap and non-heap data - posted by tr...@apache.org on 2017/11/07 14:08:09 UTC, 0 replies.
- [12/30] flink git commit: [FLINK-7862] Change web ui to calculate total memory from heap and non-heap data - posted by tr...@apache.org on 2017/11/07 14:08:10 UTC, 0 replies.
- [13/30] flink git commit: [FLINK-7862] Change web ui to calculate total memory from heap and non-heap data - posted by tr...@apache.org on 2017/11/07 14:08:11 UTC, 0 replies.
- [14/30] flink git commit: [FLINK-7862] Change web ui to calculate total memory from heap and non-heap data - posted by tr...@apache.org on 2017/11/07 14:08:12 UTC, 0 replies.
- [15/30] flink git commit: [FLINK-7862] No longer send inidividual TaskManager information in an array - posted by tr...@apache.org on 2017/11/07 14:08:13 UTC, 0 replies.
- [16/30] flink git commit: [FLINK-7862] No longer send inidividual TaskManager information in an array - posted by tr...@apache.org on 2017/11/07 14:08:14 UTC, 0 replies.
- [17/30] flink git commit: [FLINK-7705] Add JobDetailsHandler - posted by tr...@apache.org on 2017/11/07 14:08:15 UTC, 0 replies.
- [18/30] flink git commit: [FLINK-7706] [flip6] Add JobAccumulatorsHandler for new REST endpoint - posted by tr...@apache.org on 2017/11/07 14:08:16 UTC, 0 replies.
- [19/30] flink git commit: [FLINK-7806] [flip6] Register CurrentJobsOverviewHandler under /jobs/overview - posted by tr...@apache.org on 2017/11/07 14:08:17 UTC, 0 replies.
- [20/30] flink git commit: [FLINK-7806] [flip6] Register CurrentJobsOverviewHandler under /jobs/overview - posted by tr...@apache.org on 2017/11/07 14:08:18 UTC, 0 replies.
- [21/30] flink git commit: [FLINK-7806] [flip6] Register CurrentJobsOverviewHandler under /jobs/overview - posted by tr...@apache.org on 2017/11/07 14:08:19 UTC, 0 replies.
- [22/30] flink git commit: [FLINK-7806] [flip6] Register CurrentJobsOverviewHandler under /jobs/overview - posted by tr...@apache.org on 2017/11/07 14:08:20 UTC, 0 replies.
- [23/30] flink git commit: [FLINK-7815] Remove grouping from MultipleJobsDetails - posted by tr...@apache.org on 2017/11/07 14:08:21 UTC, 0 replies.
- [24/30] flink git commit: [FLINK-7815] Remove grouping from MultipleJobsDetails - posted by tr...@apache.org on 2017/11/07 14:08:22 UTC, 0 replies.
- [25/30] flink git commit: [FLINK-7815] Remove grouping from MultipleJobsDetails - posted by tr...@apache.org on 2017/11/07 14:08:23 UTC, 0 replies.
- [26/30] flink git commit: [FLINK-7815] Remove grouping from MultipleJobsDetails - posted by tr...@apache.org on 2017/11/07 14:08:24 UTC, 0 replies.
- [27/30] flink git commit: [FLINK-7941] Store timestamps indexed by ExecutionState in SubtasksTimesInfo - posted by tr...@apache.org on 2017/11/07 14:08:25 UTC, 0 replies.
- [28/30] flink git commit: [FLINK-7941][flip6] Port SubtasksTimesHandler to new REST endpoint - posted by tr...@apache.org on 2017/11/07 14:08:26 UTC, 0 replies.
- [29/30] flink git commit: [FLINK-7870] [runtime] slot pool cancel slot request to resource manager if timeout - posted by tr...@apache.org on 2017/11/07 14:08:27 UTC, 0 replies.
- [30/30] flink git commit: [FLINK-7870] [tests] Add SlotPool test to verify cancellation of failed slot requests - posted by tr...@apache.org on 2017/11/07 14:08:28 UTC, 0 replies.
- flink git commit: [hotfix] Use correct commit id in GenericWriteAheadSink.notifyCheckpoint - posted by al...@apache.org on 2017/11/07 17:29:05 UTC, 1 replies.
- [1/2] flink git commit: [FLINK-7978][kafka] Ensure that transactional ids will never clash - posted by al...@apache.org on 2017/11/07 18:01:09 UTC, 0 replies.
- [2/2] flink git commit: [hotfix][kafka] Extract TransactionalIdsGenerator class from FlinkKafkaProducer011 - posted by al...@apache.org on 2017/11/07 18:01:10 UTC, 0 replies.
- [1/2] flink git commit: [hotfix] [docs] Fix UDTF join description in SQL docs. - posted by fh...@apache.org on 2017/11/07 23:13:53 UTC, 0 replies.
- [2/2] flink git commit: [hotfix] [docs] Improve Supported Types section of Table API & SQL docs. - posted by fh...@apache.org on 2017/11/07 23:13:54 UTC, 0 replies.
- [1/2] flink git commit: [hotfix] [docs] Improve Supported Types section of Table API & SQL docs. - posted by fh...@apache.org on 2017/11/07 23:15:06 UTC, 1 replies.
- [2/2] flink git commit: [hotfix] [docs] Fix UDTF join description in SQL docs. - posted by fh...@apache.org on 2017/11/07 23:15:07 UTC, 1 replies.
- flink git commit: [FLINK-8001] [kafka] Prevent PeriodicWatermarkEmitter from violating IDLE status - posted by tz...@apache.org on 2017/11/08 08:25:42 UTC, 1 replies.
- [1/2] flink git commit: [hotfix][kafka] Extract TransactionalIdsGenerator class from FlinkKafkaProducer011 - posted by al...@apache.org on 2017/11/08 08:48:16 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-7978][kafka] Ensure that transactional ids will never clash - posted by al...@apache.org on 2017/11/08 08:48:17 UTC, 0 replies.
- flink git commit: [FLINK-8004][metrics][docs] Fix usage examples - posted by ch...@apache.org on 2017/11/08 09:16:37 UTC, 1 replies.
- flink git commit: [FLINK-8010][build] Bump remaining flink-shaded versions - posted by ch...@apache.org on 2017/11/08 09:22:12 UTC, 1 replies.
- flink git commit: [FLINK-8009][build][runtime] Remove transitive dependency promotion - posted by ch...@apache.org on 2017/11/08 10:21:49 UTC, 1 replies.
- flink git commit: [FLINK-8001] [kafka] Mark consumer subtask as IDLE if it doesn't have partitions - posted by tz...@apache.org on 2017/11/08 10:50:57 UTC, 0 replies.
- flink git commit: [FLINK-7773] [tests] Move all mocking before testing code in UtilsTest to avoid unfinished stubbing - posted by tr...@apache.org on 2017/11/08 14:33:50 UTC, 0 replies.
- [1/2] flink git commit: [FLINK-7076] [yarn] Implement stopWorker logic for YarnResourceManager - posted by tr...@apache.org on 2017/11/08 14:53:12 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-7076] [tests] Harden YarnResourcemanagerTest#testStopWorker to properly wait for concurrent operations - posted by tr...@apache.org on 2017/11/08 14:53:13 UTC, 0 replies.
- [1/5] flink git commit: [FLINK-8002] [table] Fix join window boundary for LESS_THAN and GREATER_THAN predicates. - posted by fh...@apache.org on 2017/11/08 17:41:58 UTC, 0 replies.
- [2/5] flink git commit: [FLINK-7996] [table] Add support for (left.time = right.time) predicates to window join. - posted by fh...@apache.org on 2017/11/08 17:41:59 UTC, 0 replies.
- [3/5] flink git commit: [FLINK-7971] [table] Fix potential NPE in non-windowed aggregation. - posted by fh...@apache.org on 2017/11/08 17:42:00 UTC, 0 replies.
- [4/5] flink git commit: [FLINK-8012] [table] Fix TableSink config for tables with time attributes. - posted by fh...@apache.org on 2017/11/08 17:42:01 UTC, 1 replies.
- [5/5] flink git commit: [FLINK-7922] [table] Fix FlinkTypeFactory.leastRestrictive for composite types. - posted by fh...@apache.org on 2017/11/08 17:42:02 UTC, 0 replies.
- [1/5] flink git commit: [FLINK-7971] [table] Fix potential NPE in non-windowed aggregation. - posted by fh...@apache.org on 2017/11/08 17:50:52 UTC, 0 replies.
- [2/5] flink git commit: [FLINK-7922] [table] Fix FlinkTypeFactory.leastRestrictive for composite types. - posted by fh...@apache.org on 2017/11/08 17:50:53 UTC, 0 replies.
- [3/5] flink git commit: [FLINK-7996] [table] Add support for (left.time = right.time) predicates to window join. - posted by fh...@apache.org on 2017/11/08 17:50:54 UTC, 0 replies.
- [5/5] flink git commit: [FLINK-8002] [table] Fix join window boundary for LESS_THAN and GREATER_THAN predicates. - posted by fh...@apache.org on 2017/11/08 17:50:56 UTC, 0 replies.
- [1/3] flink git commit: [FLINK-7971] [table] Fix potential NPE in non-windowed aggregation. - posted by fh...@apache.org on 2017/11/08 21:38:34 UTC, 0 replies.
- [2/3] flink git commit: [FLINK-7922] [table] Fix FlinkTypeFactory.leastRestrictive for composite types. - posted by fh...@apache.org on 2017/11/08 21:38:35 UTC, 0 replies.
- [3/3] flink git commit: [FLINK-8012] [table] Fix TableSink config for tables with time attributes. - posted by fh...@apache.org on 2017/11/08 21:38:36 UTC, 0 replies.
- flink git commit: [FLINK-7704] [hotfix] [flip6] Fix JobPlanInfoTest package path - posted by tr...@apache.org on 2017/11/09 09:40:25 UTC, 0 replies.
- [1/4] flink git commit: [FLINK-8000] Sort Rest handler URLS in RestServerEndpoint - posted by tr...@apache.org on 2017/11/09 09:51:13 UTC, 0 replies.
- [2/4] flink git commit: [FLINK-8024] Let ClusterOverviewHandler directly extend from AbstractRestHandler - posted by tr...@apache.org on 2017/11/09 09:51:14 UTC, 0 replies.
- [3/4] flink git commit: [FLINK-8026] Let ClusterConfigHandler directly extend AbstractRestHandler - posted by tr...@apache.org on 2017/11/09 09:51:15 UTC, 0 replies.
- [4/4] flink git commit: [FLINK-8025] Let DashboardConfigHandler directly extend AbstractRestHandler - posted by tr...@apache.org on 2017/11/09 09:51:16 UTC, 0 replies.
- flink git commit: [FLINK-8017] Fix High availability cluster-id key in documentation - posted by al...@apache.org on 2017/11/09 13:08:28 UTC, 1 replies.
- flink git commit: [hotfix] Fix formatting in windowing documentation - posted by al...@apache.org on 2017/11/09 14:35:05 UTC, 1 replies.
- [1/2] flink git commit: [FLINK-7765][build] Enable dependency convergence by default - posted by al...@apache.org on 2017/11/09 14:40:12 UTC, 0 replies.
- [2/2] flink git commit: [hotfix][build] Deduplicate maven-enforcer version - posted by al...@apache.org on 2017/11/09 14:40:13 UTC, 0 replies.
- [1/2] flink git commit: [hotfix][build] Deduplicate maven-enforcer version - posted by al...@apache.org on 2017/11/09 16:10:57 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-7765][build] Enable dependency convergence by default - posted by al...@apache.org on 2017/11/09 16:10:58 UTC, 0 replies.
- flink git commit: [FLINK-8005] Set user-code class loader as context loader before snapshot - posted by al...@apache.org on 2017/11/10 08:26:24 UTC, 1 replies.
- flink git commit: [FLINK-4500] CassandraSinkBase implements CheckpointedFunction - posted by ch...@apache.org on 2017/11/10 10:09:32 UTC, 1 replies.
- [1/3] flink git commit: [FLINK-6434] cancel slot allocation if request timed out in ProviderAndOwner - posted by tr...@apache.org on 2017/11/10 10:24:19 UTC, 0 replies.
- [2/3] flink git commit: [FLINK-6434] [tests] Harden and speed up SlotPoolRpcTest - posted by tr...@apache.org on 2017/11/10 10:24:20 UTC, 0 replies.
- [3/3] flink git commit: [FLINK-6434] [flip6] Introduce SlotRequestID for SlotPool#allocateSlot - posted by tr...@apache.org on 2017/11/10 10:24:21 UTC, 0 replies.
- buildbot failure in on flink-docs-release-1.2 - posted by bu...@apache.org on 2017/11/10 10:45:28 UTC, 0 replies.
- flink git commit: [hotfix][build] Disable dependency convergence in flink-dist - posted by al...@apache.org on 2017/11/10 13:26:31 UTC, 1 replies.
- buildbot success in on flink-docs-release-1.4 - posted by bu...@apache.org on 2017/11/10 14:21:56 UTC, 0 replies.
- flink git commit: [FLINK-6163] Document per-window state in ProcessWindowFunction - posted by al...@apache.org on 2017/11/10 14:57:16 UTC, 1 replies.
- flink git commit: [hotfix][docs] Change mailing list link in quickstart to flink-user - posted by al...@apache.org on 2017/11/10 16:43:37 UTC, 1 replies.
- buildbot success in on flink-docs-release-1.2 - posted by bu...@apache.org on 2017/11/11 04:00:36 UTC, 0 replies.
- [1/2] flink git commit: [FLINK-7702] Remove Javadoc aggregation for Scala code - posted by al...@apache.org on 2017/11/13 11:03:55 UTC, 1 replies.
- [2/2] flink git commit: [FLINK-7702] Add maven-bundle-plugin to root pom - posted by al...@apache.org on 2017/11/13 11:03:56 UTC, 1 replies.
- flink git commit: [FLINK-8040] [tests] Fix test instability in ResourceGuardTest - posted by sr...@apache.org on 2017/11/13 12:44:25 UTC, 0 replies.
- flink git commit: [FLINK-8040] [tests] Fix test instability in ResourceGuardTest (cherry picked from commit ad8ef6d) - posted by sr...@apache.org on 2017/11/13 12:51:31 UTC, 0 replies.
- [1/2] flink git commit: [FLINK-7657] [table] Add all basic types to RexProgramExtractor - posted by tw...@apache.org on 2017/11/13 13:21:11 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-7657] [table] Add time types FilterableTableSource push down - posted by tw...@apache.org on 2017/11/13 13:21:12 UTC, 0 replies.
- [1/2] flink git commit: [FLINK-7657] [table] Add time types FilterableTableSource push down - posted by tw...@apache.org on 2017/11/13 13:27:47 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-7657] [table] Add all basic types to RexProgramExtractor - posted by tw...@apache.org on 2017/11/13 13:27:48 UTC, 0 replies.
- [01/12] flink git commit: [hotfix] let end-to-end tests check for empty .out files again - posted by al...@apache.org on 2017/11/13 15:41:01 UTC, 1 replies.
- [02/12] flink git commit: [hotfix] fix presto end-to-end test not cleaning up - posted by al...@apache.org on 2017/11/13 15:41:02 UTC, 1 replies.
- [03/12] flink git commit: [FLINK-7973] Fix shading and relocating Hadoop for the S3 filesystems - posted by al...@apache.org on 2017/11/13 15:41:03 UTC, 1 replies.
- [04/12] flink git commit: [FLINK-7973] Fix shading and relocating Hadoop for the S3 filesystems - posted by al...@apache.org on 2017/11/13 15:41:04 UTC, 1 replies.
- [05/12] flink git commit: [FLINK-7973] Fix shading and relocating Hadoop for the S3 filesystems - posted by al...@apache.org on 2017/11/13 15:41:05 UTC, 1 replies.
- [06/12] flink git commit: [FLINK-7973] Fix shading and relocating Hadoop for the S3 filesystems - posted by al...@apache.org on 2017/11/13 15:41:06 UTC, 1 replies.
- [07/12] flink git commit: [FLINK-7973] Fix shading and relocating Hadoop for the S3 filesystems - posted by al...@apache.org on 2017/11/13 15:41:07 UTC, 1 replies.
- [08/12] flink git commit: [FLINK-7973] Fix shading and relocating Hadoop for the S3 filesystems - posted by al...@apache.org on 2017/11/13 15:41:08 UTC, 1 replies.
- [09/12] flink git commit: [FLINK-7973] Fix shading and relocating Hadoop for the S3 filesystems - posted by al...@apache.org on 2017/11/13 15:41:09 UTC, 1 replies.
- [10/12] flink git commit: [FLINK-7973] Add shaded S3 FileSystem end-to-end tests - posted by al...@apache.org on 2017/11/13 15:41:10 UTC, 1 replies.
- [11/12] flink git commit: [hotfix] ignore a warning from the error check of the S3 e2e tests - posted by al...@apache.org on 2017/11/13 15:41:11 UTC, 1 replies.
- [12/12] flink git commit: [hotfix] Make end-to-end test scripts more robust - posted by al...@apache.org on 2017/11/13 15:41:12 UTC, 1 replies.
- flink git commit: [FLINK-8053] [checkpoints] Default to asynchronous snapshots for FsStateBackend and MemoryStateBackend. - posted by sr...@apache.org on 2017/11/14 10:53:37 UTC, 1 replies.
- [1/7] flink git commit: [FLINK-4500][docs] Update cassandra documentation regarding data loss - posted by ch...@apache.org on 2017/11/14 14:15:33 UTC, 0 replies.
- [2/7] flink git commit: [hotfix][docs][javadocs] Remove double "of" - posted by ch...@apache.org on 2017/11/14 14:15:34 UTC, 0 replies.
- [3/7] flink git commit: [FLINK-7845][runtime] Make NettyMessage public - posted by ch...@apache.org on 2017/11/14 14:15:35 UTC, 0 replies.
- [4/7] flink git commit: [hotfix][docs] Fix typos in deployment AWS documentation - posted by ch...@apache.org on 2017/11/14 14:15:36 UTC, 0 replies.
- [5/7] flink git commit: [hotfix][docs] Fix broken link to FLINK-7811 - posted by ch...@apache.org on 2017/11/14 14:15:37 UTC, 0 replies.
- [6/7] flink git commit: [FLINK-8011][dist] Set flink-python to provided - posted by ch...@apache.org on 2017/11/14 14:15:38 UTC, 1 replies.
- [7/7] flink git commit: [FLINK-8006] [Startup Shell Scripts] - Fixing $pid - posted by ch...@apache.org on 2017/11/14 14:15:39 UTC, 0 replies.
- [1/7] flink git commit: [FLINK-8006] [Startup Shell Scripts] - Fixing $pid - posted by ch...@apache.org on 2017/11/14 14:16:00 UTC, 0 replies.
- [2/7] flink git commit: [hotfix][docs] Fix broken link to FLINK-7811 - posted by ch...@apache.org on 2017/11/14 14:16:01 UTC, 0 replies.
- [3/7] flink git commit: [hotfix][docs][javadocs] Remove double "of" - posted by ch...@apache.org on 2017/11/14 14:16:02 UTC, 0 replies.
- [4/7] flink git commit: [FLINK-7845][runtime] Make NettyMessage public - posted by ch...@apache.org on 2017/11/14 14:16:03 UTC, 0 replies.
- [5/7] flink git commit: [hotfix][docs] Fix typos in deployment AWS documentation - posted by ch...@apache.org on 2017/11/14 14:16:04 UTC, 0 replies.
- [7/7] flink git commit: [FLINK-4500][docs] Update cassandra documentation regarding data loss - posted by ch...@apache.org on 2017/11/14 14:16:06 UTC, 0 replies.
- flink git commit: [FLINK-8056][dist] Use 'web.port' instead of 'jobmanager.web.port' - posted by ch...@apache.org on 2017/11/14 14:43:42 UTC, 1 replies.
- flink git commit: [FLINK-7998][examples] Fix TPCHQuery3 examples - posted by ch...@apache.org on 2017/11/14 14:57:17 UTC, 1 replies.
- [1/2] flink git commit: [FLINK-8071][build] Bump shade-plugin asm version to 5.1 - posted by ch...@apache.org on 2017/11/14 20:04:32 UTC, 1 replies.
- [2/2] flink git commit: [FLINK-7419][build][avro] Shade jackson dependency in flink-dist - posted by ch...@apache.org on 2017/11/14 20:04:33 UTC, 1 replies.
- flink git commit: [FLINK-7973] disable JNI bridge for relocated hadoop classes in s3-fs-* - posted by al...@apache.org on 2017/11/15 09:46:11 UTC, 1 replies.
- [1/2] flink git commit: [FLINK-7451] [table] Support non-ascii character literals in Table API and SQL - posted by tw...@apache.org on 2017/11/15 13:48:55 UTC, 1 replies.
- [2/2] flink git commit: [FLINK-7451] [table] Disable testing of the charset in TableTestBase - posted by tw...@apache.org on 2017/11/15 13:48:56 UTC, 1 replies.
- flink git commit: [FLINK-8013] [table] Support aggregate functions with generic arrays - posted by tw...@apache.org on 2017/11/15 15:18:31 UTC, 1 replies.
- flink git commit: [FLINK-7678] [table] Support composite inputs for user-defined functions - posted by tw...@apache.org on 2017/11/15 16:33:56 UTC, 1 replies.
- flink git commit: [FLINK-7490] [table] Use correct classloader to compile generated code that calls UDAGGs. - posted by tw...@apache.org on 2017/11/15 16:54:55 UTC, 2 replies.
- flink git commit: [FLINK-7942] [table] Reduce aliasing in RexNodes - posted by tw...@apache.org on 2017/11/15 17:28:46 UTC, 1 replies.
- flink git commit: [FLINK-7962] Add built-in support for min/max aggregation for Timestamp - posted by ja...@apache.org on 2017/11/16 02:53:15 UTC, 0 replies.
- flink git commit: [FLINK-7698] [table] Tests joins with null literals - posted by tw...@apache.org on 2017/11/16 10:04:33 UTC, 1 replies.
- [1/5] flink git commit: [FLINK-7003] [table] Fix 'SELECT *' for tables with nested schema. - posted by fh...@apache.org on 2017/11/16 13:26:10 UTC, 1 replies.
- [2/5] flink git commit: [FLINK-8014] [table] Add Kafka010JsonTableSink. - posted by fh...@apache.org on 2017/11/16 13:26:11 UTC, 0 replies.
- [3/5] flink git commit: [FLINK-8016] [docs] Add documentation for KafkaJsonTableSinks. - posted by fh...@apache.org on 2017/11/16 13:26:12 UTC, 0 replies.
- [4/5] flink git commit: [FLINK-8069] [table] Add preserving WatermarkStrategy. - posted by fh...@apache.org on 2017/11/16 13:26:13 UTC, 0 replies.
- [5/5] flink git commit: [FLINK-7389] [table] Remove Calcite PushProjector - posted by fh...@apache.org on 2017/11/16 13:26:14 UTC, 0 replies.
- [2/5] flink git commit: [FLINK-7389] [table] Remove Calcite PushProjector - posted by fh...@apache.org on 2017/11/16 13:26:55 UTC, 0 replies.
- [3/5] flink git commit: [FLINK-8014] [table] Add Kafka010JsonTableSink. - posted by fh...@apache.org on 2017/11/16 13:26:56 UTC, 0 replies.
- [4/5] flink git commit: [FLINK-8016] [docs] Add documentation for KafkaJsonTableSinks. - posted by fh...@apache.org on 2017/11/16 13:26:57 UTC, 0 replies.
- [5/5] flink git commit: [FLINK-8069] [table] Add preserving WatermarkStrategy. - posted by fh...@apache.org on 2017/11/16 13:26:58 UTC, 0 replies.
- flink git commit: [FLINK-7986] [table] Introduce FilterSetOpTransposeRule - posted by tw...@apache.org on 2017/11/16 15:15:33 UTC, 1 replies.
- flink git commit: [FLINK-8063][QS] QS client does not retry when an UnknownKvStateLocation is thrown. - posted by kk...@apache.org on 2017/11/17 09:34:31 UTC, 0 replies.
- [1/5] flink git commit: [FLINK-8062][QS] Make getKvState() with namespace private. - posted by kk...@apache.org on 2017/11/17 10:06:48 UTC, 0 replies.
- [2/5] flink git commit: [FLINK-8055][QS] Deduplicate logging messages about QS start. - posted by kk...@apache.org on 2017/11/17 10:06:49 UTC, 0 replies.
- [3/5] flink git commit: [FLINK-8065][QS] Improve error message when client already shut down. - posted by kk...@apache.org on 2017/11/17 10:06:50 UTC, 0 replies.
- [4/5] flink git commit: [FLINK-8059][QS] QS client throws FlinkJobNotFoundException for queries with unknown jobIds - posted by kk...@apache.org on 2017/11/17 10:06:51 UTC, 0 replies.
- [5/5] flink git commit: [FLINK-8057][QS] Change error message in KvStateRegistry.registerKvState() - posted by kk...@apache.org on 2017/11/17 10:06:52 UTC, 0 replies.
- [1/6] flink git commit: [FLINK-8063][QS] QS client does not retry when an UnknownKvStateLocation is thrown. - posted by kk...@apache.org on 2017/11/17 11:03:19 UTC, 0 replies.
- [2/6] flink git commit: [FLINK-8062][QS] Make getKvState() with namespace private. - posted by kk...@apache.org on 2017/11/17 11:03:20 UTC, 0 replies.
- [3/6] flink git commit: [FLINK-8065][QS] Improve error message when client already shut down. - posted by kk...@apache.org on 2017/11/17 11:03:21 UTC, 0 replies.
- [4/6] flink git commit: [FLINK-8055][QS] Deduplicate logging messages about QS start. - posted by kk...@apache.org on 2017/11/17 11:03:22 UTC, 0 replies.
- [5/6] flink git commit: [FLINK-8059][QS] QS client throws FlinkJobNotFoundException for queries with unknown jobIds. - posted by kk...@apache.org on 2017/11/17 11:03:23 UTC, 0 replies.
- [6/6] flink git commit: [FLINK-8057][QS] Change error message in KvStateRegistry.registerKvState(). - posted by kk...@apache.org on 2017/11/17 11:03:24 UTC, 0 replies.
- flink git commit: [FLINK-8061][QS] Remove trailing * in QSClient javadocs. - posted by kk...@apache.org on 2017/11/17 14:30:00 UTC, 1 replies.
- [1/2] flink git commit: [FLINK-7266] [core] Prevent attempt for parent directory deletion for object stores - posted by al...@apache.org on 2017/11/17 15:48:51 UTC, 1 replies.
- [2/2] flink git commit: [FLINK-7265] [core] Introduce FileSystemKind to differentiate between FileSystem and ObjectStore - posted by al...@apache.org on 2017/11/17 15:48:52 UTC, 1 replies.
- [1/2] flink git commit: [FLINK-4228][yarn/s3] fix for yarn staging with s3a defaultFs - posted by tr...@apache.org on 2017/11/18 14:34:10 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-7988][s3] fix HadoopS3FileSystemITCase leaving test directories behind in S3 - posted by tr...@apache.org on 2017/11/18 14:34:11 UTC, 0 replies.
- [1/2] flink git commit: [FLINK-7988][s3] fix HadoopS3FileSystemITCase leaving test directories behind in S3 - posted by tr...@apache.org on 2017/11/18 14:34:46 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-4228][yarn/s3] fix for yarn staging with s3a defaultFs - posted by tr...@apache.org on 2017/11/18 14:34:47 UTC, 0 replies.
- flink git commit: [FLINK-8096] [table] Fix time attribute materialization when writing to TableSink - posted by tw...@apache.org on 2017/11/20 11:17:14 UTC, 1 replies.
- flink git commit: [FLINK-8095] [table] Introduce ProjectSetOpTransposeRule - posted by tw...@apache.org on 2017/11/20 11:50:09 UTC, 1 replies.
- flink git commit: [FLINK-4809] [checkpoints] Operators should tolerate checkpoint failures. - posted by sr...@apache.org on 2017/11/20 12:19:16 UTC, 0 replies.
- [1/2] flink git commit: [FLINK-8086][kafka] Ignore ProducerFencedException during recovery - posted by al...@apache.org on 2017/11/20 12:25:20 UTC, 0 replies.
- [2/2] flink git commit: [hotfix][kafka] Improve logging in FlinkKafkaProducer011 - posted by al...@apache.org on 2017/11/20 12:25:21 UTC, 0 replies.
- [1/2] flink git commit: [hotfix][kafka] Improve logging in FlinkKafkaProducer011 - posted by al...@apache.org on 2017/11/20 12:37:23 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-8086][kafka] Ignore ProducerFencedException during recovery - posted by al...@apache.org on 2017/11/20 12:37:24 UTC, 0 replies.
- [flink-shaded] branch master updated: (#28) Bump maven-shade-plugin version to 3.0.0 - posted by ch...@apache.org on 2017/11/20 13:06:42 UTC, 0 replies.
- flink git commit: [FLINK-8099] Reduce default restart delay to 1 second - posted by al...@apache.org on 2017/11/20 13:11:50 UTC, 1 replies.
- [1/3] flink git commit: [FLINK-8109][py] Check for existence of plan/additional files - posted by ch...@apache.org on 2017/11/20 14:43:49 UTC, 0 replies.
- [2/3] flink git commit: [FLINK-8108][py] Fix bounds check - posted by ch...@apache.org on 2017/11/20 14:43:50 UTC, 0 replies.
- [3/3] flink git commit: [FLINK-8114][py] Fix forwarding of arguments - posted by ch...@apache.org on 2017/11/20 14:43:51 UTC, 1 replies.
- [1/3] flink git commit: [FLINK-8108][py] Fix bounds check - posted by ch...@apache.org on 2017/11/20 14:44:25 UTC, 0 replies.
- [2/3] flink git commit: [FLINK-8109][py] Check for existence of plan/additional files - posted by ch...@apache.org on 2017/11/20 14:44:26 UTC, 0 replies.
- flink git commit: [FLINK-8110][dist] Relocate jackson services in flink-dist - posted by ch...@apache.org on 2017/11/20 14:47:57 UTC, 1 replies.
- [1/2] flink git commit: [hotfix][license] Add missing licenses - posted by ch...@apache.org on 2017/11/20 14:50:35 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-7943] Make ParameterTool thread safe - posted by ch...@apache.org on 2017/11/20 14:50:36 UTC, 0 replies.
- [1/2] flink git commit: [FLINK-7943] Make ParameterTool thread safe - posted by ch...@apache.org on 2017/11/20 14:51:16 UTC, 0 replies.
- [2/2] flink git commit: [hotfix][license] Add missing licenses - posted by ch...@apache.org on 2017/11/20 14:51:17 UTC, 0 replies.
- flink git commit: [FLINK-8102][docs] Fixed formatting issues in Mesos documentation. - posted by ch...@apache.org on 2017/11/20 14:57:27 UTC, 1 replies.
- flink git commit: [FLINK-8115] Fix Kafka download link in end-to-end test - posted by al...@apache.org on 2017/11/20 15:09:56 UTC, 1 replies.
- flink git commit: [hotfix] Fix create_release_branch.sh to use correct branch name - posted by al...@apache.org on 2017/11/20 15:32:59 UTC, 1 replies.
- flink git commit: [FLINK-7977][build] Bump version of compatibility check for Flink 1.4 - posted by ch...@apache.org on 2017/11/20 16:30:01 UTC, 0 replies.
- flink git commit: [hotfix] Always explicitly set hadoop.version in create_binary_release - posted by al...@apache.org on 2017/11/20 17:07:08 UTC, 1 replies.
- flink git commit: [hotfix][docs] Fix some typos in the documentation. - posted by ch...@apache.org on 2017/11/21 13:43:50 UTC, 1 replies.
- [1/2] flink git commit: [FLINK-8038] [table] Clear maps and support cardinality - posted by tw...@apache.org on 2017/11/21 16:09:49 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-8038] [table] Support map value constructor, cardinality, and item - posted by tw...@apache.org on 2017/11/21 16:09:50 UTC, 0 replies.
- flink git commit: [FLINK-8097] [table] Add built-in support for min/max aggregation for Date/Time - posted by tw...@apache.org on 2017/11/21 16:36:26 UTC, 0 replies.
- flink git commit: [FLINK-8123][py] Bundle python scripts in jar - posted by ch...@apache.org on 2017/11/21 21:11:46 UTC, 0 replies.
- Build failed in Jenkins: flink-snapshot-deployment #656 - posted by Apache Jenkins Server <je...@builds.apache.org> on 2017/11/22 04:07:14 UTC, 0 replies.
- flink git commit: [FLINK-8117] [runtime] Eliminate modulo operation from round-robin partitioners - posted by se...@apache.org on 2017/11/22 09:02:28 UTC, 0 replies.
- [1/4] flink-web git commit: Allow multiple authors per blog post - posted by al...@apache.org on 2017/11/22 09:57:01 UTC, 0 replies.
- [2/4] flink-web git commit: Add "Release 1.4 and 1.5 Timeline" post - posted by al...@apache.org on 2017/11/22 09:57:02 UTC, 0 replies.
- [3/4] flink-web git commit: Rebuild website - posted by al...@apache.org on 2017/11/22 09:57:03 UTC, 0 replies.
- [4/4] flink-web git commit: Rebuild website - posted by al...@apache.org on 2017/11/22 09:57:04 UTC, 0 replies.
- [1/2] flink git commit: [FLINK-8117] [runtime] Eliminate modulo operation from round-robin partitioners - posted by se...@apache.org on 2017/11/22 10:42:06 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-7841] [docs] Update AWS docs with respect to S3 file system changes - posted by se...@apache.org on 2017/11/22 10:42:07 UTC, 0 replies.
- flink git commit: [FLINK-7841] [docs] Update AWS docs with respect to S3 file system changes - posted by se...@apache.org on 2017/11/22 10:42:44 UTC, 0 replies.
- [1/4] flink git commit: [FLINK-8084][build] Remove unnecessary japicmp pom entries - posted by ch...@apache.org on 2017/11/22 10:53:29 UTC, 0 replies.
- [2/4] flink git commit: [FLINK-8070][yarn][tests] Print errors found in log files - posted by ch...@apache.org on 2017/11/22 10:53:30 UTC, 0 replies.
- [3/4] flink git commit: [FLINK-8113][build] Bump maven-shade-plugin to 3.0.0 - posted by ch...@apache.org on 2017/11/22 10:53:31 UTC, 0 replies.
- [4/4] flink git commit: [FLINK-8126] [build] Fix and update checkstyle - posted by ch...@apache.org on 2017/11/22 10:53:32 UTC, 0 replies.
- flink git commit: [FLINK-8070][yarn][tests] Print errors found in log files - posted by ch...@apache.org on 2017/11/22 10:56:47 UTC, 0 replies.
- flink git commit: [FLINK-8131] Update to Kafka 0.11.0.2 - posted by al...@apache.org on 2017/11/22 13:31:59 UTC, 1 replies.
- flink git commit: [hotfix][docs] Fix typo in Trigger doc - posted by ch...@apache.org on 2017/11/22 14:47:27 UTC, 1 replies.
- flink git commit: [hotfix] Make aws docs version agnostic - posted by al...@apache.org on 2017/11/22 15:22:57 UTC, 1 replies.
- flink git commit: [FLINK-8136] [table] Fix code generation with JodaTime shading - posted by tw...@apache.org on 2017/11/22 17:19:36 UTC, 1 replies.
- [1/9] flink git commit: [FLINK-2170] [connectors] Add OrcRowInputFormat and OrcTableSource. - posted by fh...@apache.org on 2017/11/22 22:10:38 UTC, 1 replies.
- [2/9] flink git commit: [FLINK-2170] [connectors] Add OrcRowInputFormat and OrcTableSource. - posted by fh...@apache.org on 2017/11/22 22:10:39 UTC, 1 replies.
- [3/9] flink git commit: [FLINK-2170] [connectors] Add OrcRowInputFormat and OrcTableSource. - posted by fh...@apache.org on 2017/11/22 22:10:40 UTC, 1 replies.
- [4/9] flink git commit: [FLINK-2170] [connectors] Add OrcRowInputFormat and OrcTableSource. - posted by fh...@apache.org on 2017/11/22 22:10:41 UTC, 1 replies.
- [5/9] flink git commit: [FLINK-2170] [connectors] Add OrcRowInputFormat and OrcTableSource. - posted by fh...@apache.org on 2017/11/22 22:10:42 UTC, 1 replies.
- [6/9] flink git commit: [FLINK-2170] [connectors] Add OrcRowInputFormat and OrcTableSource. - posted by fh...@apache.org on 2017/11/22 22:10:43 UTC, 1 replies.
- [7/9] flink git commit: [FLINK-2170] [connectors] Add OrcRowInputFormat and OrcTableSource. - posted by fh...@apache.org on 2017/11/22 22:10:44 UTC, 1 replies.
- [8/9] flink git commit: [FLINK-2170] [connectors] Add OrcRowInputFormat and OrcTableSource. - posted by fh...@apache.org on 2017/11/22 22:10:45 UTC, 1 replies.
- [9/9] flink git commit: [FLINK-2170] [connectors] Add OrcRowInputFormat and OrcTableSource. - posted by fh...@apache.org on 2017/11/22 22:10:46 UTC, 1 replies.
- Build failed in Jenkins: flink-snapshot-deployment #657 - posted by Apache Jenkins Server <je...@builds.apache.org> on 2017/11/23 04:05:09 UTC, 0 replies.
- [1/2] flink-web git commit: Fix small issues in 1.4 to 1.5 blog post - posted by al...@apache.org on 2017/11/23 11:08:36 UTC, 0 replies.
- [2/2] flink-web git commit: Rebuild website - posted by al...@apache.org on 2017/11/23 11:08:37 UTC, 0 replies.
- flink git commit: [FLIN-6505] Proactively cleanup local FS for RocksDBKeyedStateBackend on startup - posted by sr...@apache.org on 2017/11/23 11:40:15 UTC, 0 replies.
- flink git commit: [FLINK-6505] Proactively cleanup local FS for RocksDBKeyedStateBackend on startup - posted by sr...@apache.org on 2017/11/23 12:52:51 UTC, 0 replies.
- [1/3] flink git commit: [hotfix][kafka] Remove unused method in kafka tests - posted by al...@apache.org on 2017/11/23 13:44:40 UTC, 0 replies.
- [2/3] flink git commit: [FLINK-8132][kafka] Re-initialize transactional KafkaProducer on each checkpoint - posted by al...@apache.org on 2017/11/23 13:44:41 UTC, 1 replies.
- [3/3] flink git commit: [hotfix][kafka] Throw FlinkKafkaProducer011Exception with error codes instead of generic Exception - posted by al...@apache.org on 2017/11/23 13:44:42 UTC, 0 replies.
- [1/3] flink git commit: [hotfix][kafka] Throw FlinkKafkaProducer011Exception with error codes instead of generic Exception - posted by al...@apache.org on 2017/11/23 13:45:41 UTC, 0 replies.
- [3/3] flink git commit: [hotfix][kafka] Remove unused method in kafka tests - posted by al...@apache.org on 2017/11/23 13:45:43 UTC, 0 replies.
- [1/2] flink git commit: [FLINK-8118] [table] Fix documentation mistakes - posted by tw...@apache.org on 2017/11/23 13:49:43 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-8118] [table] Allow to specify the offsets of KafkaTableSources - posted by tw...@apache.org on 2017/11/23 13:49:44 UTC, 1 replies.
- flink git commit: [hotfix][docs] Improve Kafka exactly-once docs - posted by al...@apache.org on 2017/11/23 14:02:42 UTC, 1 replies.
- flink git commit: [FLINK-5465] [streaming] Wait for pending timer threads to finish or to exceed a time limit in exceptional stream task shutdown. - posted by sr...@apache.org on 2017/11/23 14:24:20 UTC, 1 replies.
- [1/2] flink git commit: [FLINK-8118] [table] Improve KafkaTableSource documentation - posted by fh...@apache.org on 2017/11/23 14:33:30 UTC, 0 replies.
- flink git commit: [hotfix] Exclude python-source.zip from checkstyle - posted by al...@apache.org on 2017/11/23 16:58:47 UTC, 0 replies.
- Jenkins build is back to normal : flink-snapshot-deployment #658 - posted by Apache Jenkins Server <je...@builds.apache.org> on 2017/11/23 19:09:52 UTC, 0 replies.
- flink git commit: [FLINK-7316][network] Always use off-heap network buffers. - posted by sr...@apache.org on 2017/11/24 09:49:22 UTC, 0 replies.
- [1/3] flink git commit: [hotfix] [core] Fix lots of checkstyle errors in core.fs - posted by se...@apache.org on 2017/11/24 12:02:51 UTC, 0 replies.
- [2/3] flink git commit: [FLINK-8125] [core] Introduce limiting of outgoing file system connections - posted by se...@apache.org on 2017/11/24 12:02:52 UTC, 1 replies.
- [3/3] flink git commit: [FLINK-8125] [core] Introduce limiting of outgoing file system connections - posted by se...@apache.org on 2017/11/24 12:02:53 UTC, 0 replies.
- [1/3] flink git commit: [FLINK-8125] [core] Introduce limiting of outgoing file system connections - posted by se...@apache.org on 2017/11/24 12:27:27 UTC, 0 replies.
- [3/3] flink git commit: [hotfix] [core] Fix lots of checkstyle errors in core.fs - posted by se...@apache.org on 2017/11/24 12:27:29 UTC, 0 replies.
- flink git commit: [FLINK-6294] Fix potential NPE in BucketingSink.close() - posted by al...@apache.org on 2017/11/24 14:00:27 UTC, 2 replies.
- flink git commit: [FLINK-7718] [flip6] Add JobVertexMetricsHandler to DispatcherRestEndpoint - posted by tr...@apache.org on 2017/11/26 19:13:21 UTC, 0 replies.
- flink git commit: [FLINK-8022][kafka] Bump at-least-once timeout in tests - posted by al...@apache.org on 2017/11/27 11:59:08 UTC, 1 replies.
- flink git commit: [FLINK-8081][metrics] Annotate 'MetricRegistry#getReporters' with '@VisibleForTesting' - posted by ch...@apache.org on 2017/11/27 12:00:05 UTC, 1 replies.
- flink git commit: [hotfix][docs] Fix missing period package declaration - posted by ch...@apache.org on 2017/11/27 12:52:34 UTC, 1 replies.
- flink git commit: [hotfix] Ensure pristine release in tools/releasing/create_source_release.sh - posted by al...@apache.org on 2017/11/27 15:29:00 UTC, 1 replies.
- flink git commit: [hotfix] Remove "Java 7" from README.md - posted by al...@apache.org on 2017/11/27 15:38:20 UTC, 1 replies.
- flink git commit: [hotfix] [docs] Update checkstyle version in documentation - posted by gr...@apache.org on 2017/11/27 19:26:13 UTC, 0 replies.
- [1/2] flink git commit: [FLINK-8126] [build] Fix and update checkstyle - posted by gr...@apache.org on 2017/11/27 20:38:54 UTC, 0 replies.
- [2/2] flink git commit: [hotfix] [docs] Update checkstyle version in documentation - posted by gr...@apache.org on 2017/11/27 20:38:55 UTC, 0 replies.
- [1/4] flink git commit: [FLINK-8142] [config] Cleanup references to deprecated constants in ConfigConstants - posted by gr...@apache.org on 2017/11/28 03:32:02 UTC, 0 replies.
- [2/4] flink git commit: [FLINK-8105] Remove "unnecessary 'null' check before 'instanceof' expression" - posted by gr...@apache.org on 2017/11/28 03:32:03 UTC, 0 replies.
- [3/4] flink git commit: [FLINK-7967] [config] Deprecate Hadoop specific Flink configuration options - posted by gr...@apache.org on 2017/11/28 03:32:04 UTC, 0 replies.
- [4/4] flink git commit: [hotfix] [tests] Use G1GC for tests - posted by gr...@apache.org on 2017/11/28 03:32:05 UTC, 0 replies.
- flink git commit: [FLINK-8161] [tests] Harden YARNSessionCapacitySchedulerITCase - posted by tr...@apache.org on 2017/11/28 10:11:46 UTC, 0 replies.
- [1/2] flink git commit: [hotfix] [optimizer] Normalize job plan operator formatting - posted by gr...@apache.org on 2017/11/28 21:52:29 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-6864] [core] Fix confusing "invalid POJO type" messages from TypeExtractor - posted by gr...@apache.org on 2017/11/28 21:52:30 UTC, 0 replies.
- flink git commit: [hotfix] Fail unacknowledged checkpoints before trying to restart the failed tasks - posted by tr...@apache.org on 2017/11/29 09:15:08 UTC, 0 replies.
- flink git commit: [FLINK-7300] Ignore more exceptions in end-to-end tests - posted by al...@apache.org on 2017/11/29 11:09:51 UTC, 1 replies.
- flink git commit: [FLINK-8166] Create hadoop-free binary in release scripts - posted by al...@apache.org on 2017/11/29 11:35:22 UTC, 1 replies.
- flink git commit: [FLINK-7679][build] Upgrade maven enforcer plugin to 3.0.0-M1 - posted by ch...@apache.org on 2017/11/29 12:25:12 UTC, 0 replies.
- [1/9] flink git commit: [FLINK-7717][flip6] Migrate TaskManagerMetricsHandler to new RestServerEndpoint - posted by tr...@apache.org on 2017/11/29 13:56:10 UTC, 0 replies.
- [2/9] flink git commit: [FLINK-8150] [flip6] Add TaskManagerIdPathParameterTest - posted by tr...@apache.org on 2017/11/29 13:56:11 UTC, 0 replies.
- [3/9] flink git commit: [FLINK-8150] [flip6] Expose TaskExecutor's ResourceID as TaskExecutor id - posted by tr...@apache.org on 2017/11/29 13:56:12 UTC, 0 replies.
- [4/9] flink git commit: [FLINK-8143][flip6] Migrate SubtaskMetricsHandler to new RestServerEndpoint - posted by tr...@apache.org on 2017/11/29 13:56:13 UTC, 0 replies.
- [5/9] flink git commit: [FLIP-7716][flip6] Migrate JobManagerMetricsHandler to new RestServerEndpoint - posted by tr...@apache.org on 2017/11/29 13:56:14 UTC, 0 replies.
- [6/9] flink git commit: [hotfix][Javadoc] Fix typo in ConversionException - posted by tr...@apache.org on 2017/11/29 13:56:15 UTC, 0 replies.
- [7/9] flink git commit: [hotfix][Javadoc] Remove wrong Javadoc from SubtaskMetricsHandler - posted by tr...@apache.org on 2017/11/29 13:56:16 UTC, 0 replies.
- [8/9] flink git commit: [hotfix][flip6] Add unit tests JobVertexMetricsHeadersTest - posted by tr...@apache.org on 2017/11/29 13:56:17 UTC, 0 replies.
- [9/9] flink git commit: [FLINK-7694][flip6] Migrate JobMetricsHandler to new RestServerEndpoint - posted by tr...@apache.org on 2017/11/29 13:56:18 UTC, 0 replies.
- flink git commit: [FLINK-7989][yarn] Do not upload the flink-dist jar twice - posted by ch...@apache.org on 2017/11/29 14:43:13 UTC, 1 replies.
- flink git commit: [FLINK-8165] ParameterTool serialization fix - posted by al...@apache.org on 2017/11/29 14:47:21 UTC, 1 replies.
- [1/2] flink git commit: [FLINK-7652] [flip6] Introduce JobIdWithStatus type for JobIdsWithStatusOverview - posted by tr...@apache.org on 2017/11/29 17:04:03 UTC, 0 replies.
- [2/2] flink git commit: [FLINK-7652] [flip6] Port CurrentJobIdsHandler to new REST endpoint - posted by tr...@apache.org on 2017/11/29 17:04:04 UTC, 0 replies.
- [1/3] flink git commit: [FLINK-8076] [kinesis] Upgrade KinesisProducer to 0.10.6 to set properties approperiately - posted by tz...@apache.org on 2017/11/30 08:23:39 UTC, 0 replies.
- [2/3] flink git commit: [hotfix] [docs] Fix typos in State Backends doc - posted by tz...@apache.org on 2017/11/30 08:23:40 UTC, 0 replies.
- [3/3] flink git commit: [FLINK-8149] [kinesis] Replace usages of deprecated SerializationSchema - posted by tz...@apache.org on 2017/11/30 08:23:41 UTC, 0 replies.
- flink git commit: [FLINK-7595] [Savepoints] Allow removing stateless operators - posted by al...@apache.org on 2017/11/30 13:05:17 UTC, 0 replies.
- [1/3] flink git commit: [FLINK-8027] Generalize existing rest handlers to work with an arbitrary RestfulGateway - posted by tr...@apache.org on 2017/11/30 16:58:38 UTC, 0 replies.
- [2/3] flink git commit: [hotfix] Rename RestfulGateway#requestJobDetails into requestMultipleJobDetails to avoid name conflicts with JobMasterGateway - posted by tr...@apache.org on 2017/11/30 16:58:39 UTC, 0 replies.
- [3/3] flink git commit: [hotfix] Pass in Rest address to Dispatcher as nullable String - posted by tr...@apache.org on 2017/11/30 16:58:40 UTC, 0 replies.