You are viewing a plain text version of this content. The canonical link for it is here.
- kafka git commit: MINOR: removed obsolete class - posted by gu...@apache.org on 2016/02/01 22:51:59 UTC, 0 replies.
- kafka git commit: KAFKA-1860: Fix issue that file system errors are not detected unless Kafka tries to write. - posted by gu...@apache.org on 2016/02/01 23:41:25 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-3060: Refactor MeteredStore and RockDBStore Impl - posted by ew...@apache.org on 2016/02/02 01:11:27 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-3060: Refactor MeteredStore and RockDBStore Impl - posted by ew...@apache.org on 2016/02/02 01:11:28 UTC, 0 replies.
- kafka git commit: MINOR: Reorder StreamThread shutdown sequence - posted by ew...@apache.org on 2016/02/02 02:32:52 UTC, 0 replies.
- kafka git commit: KAFKA-3068: Remove retry with nodesEverSeen - posted by ew...@apache.org on 2016/02/02 18:36:35 UTC, 1 replies.
- kafka git commit: KAFKA-3170; Set default fetch_min_bytes in new consumer to 1 - posted by gu...@apache.org on 2016/02/02 18:38:54 UTC, 0 replies.
- kafka git commit: Cherry-pick c97a75d985e42a9d1b1be0352240c45e0b0d2978 - posted by gu...@apache.org on 2016/02/02 18:51:20 UTC, 0 replies.
- kafka git commit: revert one upgrade.html change from trunk - posted by gu...@apache.org on 2016/02/02 18:52:22 UTC, 0 replies.
- kafka git commit: MINOR: fix the logic of RocksDBWindowStore using RocksDBStore Segments - posted by gu...@apache.org on 2016/02/02 19:14:17 UTC, 0 replies.
- kafka git commit: MINOR: some javadocs for kstream public api - posted by gu...@apache.org on 2016/02/02 19:52:46 UTC, 0 replies.
- kafka git commit: KAFKA-3121: Refactor KStream Aggregate to be Lambda-able. - posted by ew...@apache.org on 2016/02/02 21:01:59 UTC, 0 replies.
- kafka git commit: MINOR: Increment ducktape dependency - posted by ew...@apache.org on 2016/02/03 02:58:19 UTC, 0 replies.
- kafka git commit: KAFKA-3195; Transient test failure in OffsetCheckpointTest.testReadWrite - posted by ew...@apache.org on 2016/02/03 03:29:38 UTC, 0 replies.
- kafka git commit: KAFKA-3092: Replace SinkTask onPartitionsAssigned/onPartitionsRevoked with open/close - posted by ew...@apache.org on 2016/02/03 20:29:14 UTC, 0 replies.
- kafka git commit: MINOR: Some more Kafka Streams Javadocs - posted by ew...@apache.org on 2016/02/03 20:35:08 UTC, 0 replies.
- kafka git commit: KAFKA-3194: Validate security.inter.broker.protocol against the adver… - posted by gw...@apache.org on 2016/02/04 00:42:27 UTC, 1 replies.
- kafka git commit: MINOR: Fix restoring for source KTable - posted by gu...@apache.org on 2016/02/04 05:42:48 UTC, 0 replies.
- kafka git commit: MINOR: Pin to system tests to ducktape 0.3.10 - posted by ew...@apache.org on 2016/02/04 07:33:52 UTC, 0 replies.
- kafka git commit: KAFKA-3198: Ticket Renewal Thread exits prematurely due to inverted c… - posted by gw...@apache.org on 2016/02/04 08:48:21 UTC, 1 replies.
- kafka git commit: HOTFIX: temp fix for ktable look up - posted by gu...@apache.org on 2016/02/04 19:16:05 UTC, 0 replies.
- kafka git commit: HOTFIX: fix broken WorkerSourceTask test - posted by ew...@apache.org on 2016/02/04 20:11:53 UTC, 0 replies.
- kafka git commit: MINOR: Removed unnecessary Vagrantfile hack - posted by ew...@apache.org on 2016/02/04 22:49:15 UTC, 1 replies.
- kafka git commit: HOTFIX: fix partition ordering in assignment - posted by gu...@apache.org on 2016/02/04 23:14:13 UTC, 0 replies.
- kafka git commit: MINOR: log connect reconfiguration error only if there was an error - posted by ew...@apache.org on 2016/02/04 23:34:35 UTC, 1 replies.
- kafka git commit: KAFKA-3207: Fix StateChangeLogger to use the right topic name - posted by gu...@apache.org on 2016/02/04 23:51:14 UTC, 0 replies.
- kafka git commit: KAFKA-3179; Fix seek on compressed messages - posted by jj...@apache.org on 2016/02/05 01:08:42 UTC, 1 replies.
- kafka git commit: KAFKA-3211: Handle WorkerTask stop before start correctly - posted by ew...@apache.org on 2016/02/05 03:00:52 UTC, 0 replies.
- kafka git commit: KAFKA-3003: Update the replica.highWatermark correctly - posted by gu...@apache.org on 2016/02/05 18:06:51 UTC, 1 replies.
- kafka git commit: KAFKA-3157: Mirror maker doesn't commit offset with low traffic - posted by gu...@apache.org on 2016/02/05 18:11:26 UTC, 1 replies.
- kafka git commit: KAFKA-3165: Fix ignored parameters in the gradle "All" tasks - posted by ew...@apache.org on 2016/02/05 19:41:18 UTC, 0 replies.
- kafka git commit: MINOR: Add more info to RecordCollector error message - posted by ew...@apache.org on 2016/02/05 21:58:40 UTC, 0 replies.
- kafka git commit: KAFKA-3037: Test number of alive brokers known after single node cluster startup - posted by ew...@apache.org on 2016/02/05 22:16:14 UTC, 0 replies.
- kafka git commit: KAFKA-2589: The default value for the "rebalance.backoff.ms" property is not specified correctly - posted by ew...@apache.org on 2016/02/05 22:25:31 UTC, 1 replies.
- kafka git commit: MINOR: Updated kafkatest version to match version specified in gradle.properties - posted by ew...@apache.org on 2016/02/05 22:45:10 UTC, 0 replies.
- kafka git commit: MINOR: Improve error message for inconsistent broker ids - posted by ew...@apache.org on 2016/02/05 23:59:03 UTC, 0 replies.
- kafka git commit: HOTFIX: fix streams issues - posted by gu...@apache.org on 2016/02/08 21:46:34 UTC, 0 replies.
- kafka git commit: MINOR: fix RocksDBStore range search - posted by gu...@apache.org on 2016/02/08 22:00:55 UTC, 0 replies.
- kafka git commit: HOTFIX: RecordCollector should send a record to the specified partition - posted by ew...@apache.org on 2016/02/09 01:35:10 UTC, 0 replies.
- kafka git commit: HOTFIX: open window segments on init - posted by ew...@apache.org on 2016/02/09 01:48:56 UTC, 0 replies.
- kafka git commit: KAFKA-3191: Improve offset committing JavaDoc in KafkaConsumer - posted by ew...@apache.org on 2016/02/09 01:57:12 UTC, 1 replies.
- kafka git commit: MINOR: Use explicit type in AclCommand - posted by ew...@apache.org on 2016/02/09 18:25:34 UTC, 1 replies.
- kafka git commit: KAFKA-3217: Close producers in unit tests - posted by ew...@apache.org on 2016/02/09 18:49:43 UTC, 0 replies.
- kafka git commit: HOTFIX: Fix NPE after standby task reassignment - posted by ew...@apache.org on 2016/02/09 19:02:25 UTC, 0 replies.
- kafka git commit: KAFKA-3189: Kafka server returns UnknownServerException for inherited exceptions - posted by ew...@apache.org on 2016/02/09 19:17:12 UTC, 0 replies.
- kafka git commit: KAFKA-3216: "Modifying topics" section incorrectly says you can't change replication factor. - posted by gw...@apache.org on 2016/02/09 19:33:43 UTC, 1 replies.
- kafka git commit: MINOR: Stabilize transient replication test failures in 0.9.0 - posted by gw...@apache.org on 2016/02/09 19:36:19 UTC, 0 replies.
- kafka git commit: HOTFIX: open window segments in order, add segment id check in getSegment - posted by ew...@apache.org on 2016/02/09 22:22:54 UTC, 0 replies.
- kafka git commit: KAFKA-3159; stale high watermark segment offset causes early fetch return - posted by ju...@apache.org on 2016/02/09 23:57:58 UTC, 1 replies.
- kafka git commit: KAFKA-3141: Add checks to catch invalid authorizer porperties - posted by gw...@apache.org on 2016/02/10 05:49:02 UTC, 1 replies.
- kafka git commit: KAFKA-3162: Added producer and consumer interceptors - posted by gw...@apache.org on 2016/02/10 06:10:11 UTC, 0 replies.
- kafka git commit: MINOR: Remove multi-byte charactor in docs - posted by gw...@apache.org on 2016/02/10 20:51:03 UTC, 1 replies.
- kafka git commit: HOTFIX: poll even when all partitions are paused. handle concurrent cleanup - posted by gw...@apache.org on 2016/02/10 23:02:32 UTC, 0 replies.
- kafka git commit: MINOR: Connect hangs on startup failure - posted by ew...@apache.org on 2016/02/11 02:08:39 UTC, 0 replies.
- kafka git commit: MINOR: add setUncaughtExceptionHandler to KafkaStreams - posted by ew...@apache.org on 2016/02/11 07:02:19 UTC, 0 replies.
- kafka git commit: KAFKA-3229 ensure that root statestore is registered with ProcessorStateManager - posted by gw...@apache.org on 2016/02/11 19:36:11 UTC, 0 replies.
- kafka git commit: change release version to 0.9.0.1 - posted by ju...@apache.org on 2016/02/12 01:34:03 UTC, 0 replies.
- [kafka] Git Push Summary - posted by ju...@apache.org on 2016/02/12 01:39:38 UTC, 0 replies.
- kafka git commit: MINOR: catch an exception in rebalance and stop the stream thread - posted by gu...@apache.org on 2016/02/12 10:11:27 UTC, 0 replies.
- kafka git commit: KAFKA-3147; Memory records is not writable in MirrorMaker - posted by gu...@apache.org on 2016/02/12 10:15:52 UTC, 0 replies.
- kafka git commit: KAFKA-3088; Make client-id a nullable string and fix handling of invalid requests." - posted by jj...@apache.org on 2016/02/13 03:49:30 UTC, 0 replies.
- kafka git commit: KAFKA-3227; Conservative update of Kafka dependencies - posted by ew...@apache.org on 2016/02/16 16:19:19 UTC, 0 replies.
- kafka git commit: KAFKA-3088; Make client-id a nullable string and fix handling of invalid requests. - posted by jj...@apache.org on 2016/02/16 20:29:32 UTC, 0 replies.
- kafka git commit: MINOR: Reconcile differences in .bat & .sh start scripts - posted by ew...@apache.org on 2016/02/16 21:23:55 UTC, 0 replies.
- kafka git commit: KAFKA-2508; Replace UpdateMetadata{Request,Response} with o.a.k.c.req… - posted by sr...@apache.org on 2016/02/17 03:25:22 UTC, 0 replies.
- kafka git commit: KAFKA-2547; Make DynamicConfigManager to use the ZkNodeChangeNotifica… - posted by sr...@apache.org on 2016/02/17 05:35:16 UTC, 0 replies.
- svn commit: r12425 - in /release/kafka/0.9.0.1: ./ javadoc/ javadoc/org/ javadoc/org/apache/ javadoc/org/apache/kafka/ javadoc/org/apache/kafka/clients/ javadoc/org/apache/kafka/clients/consumer/ javadoc/org/apache/kafka/clients/producer/ javadoc/org/a... - posted by ju...@apache.org on 2016/02/17 08:05:20 UTC, 0 replies.
- kafka git commit: KAFKA-2757; Consolidate BrokerEndPoint and EndPoint - posted by gu...@apache.org on 2016/02/17 11:48:13 UTC, 0 replies.
- kafka git commit: KAFKA-3225: Method commit() of class SourceTask never invoked - posted by ew...@apache.org on 2016/02/17 17:13:07 UTC, 0 replies.
- kafka git commit: MINOR: remove streams config params from producer/consumer configs - posted by gu...@apache.org on 2016/02/18 02:39:44 UTC, 0 replies.
- [1/5] kafka git commit: KAFKA-3025; Added timetamp to Message and use relative offset. - posted by ju...@apache.org on 2016/02/19 16:56:48 UTC, 0 replies.
- [2/5] kafka git commit: KAFKA-3025; Added timetamp to Message and use relative offset. - posted by ju...@apache.org on 2016/02/19 16:56:49 UTC, 0 replies.
- [3/5] kafka git commit: KAFKA-3025; Added timetamp to Message and use relative offset. - posted by ju...@apache.org on 2016/02/19 16:56:50 UTC, 0 replies.
- [4/5] kafka git commit: KAFKA-3025; Added timetamp to Message and use relative offset. - posted by ju...@apache.org on 2016/02/19 16:56:51 UTC, 0 replies.
- [5/5] kafka git commit: KAFKA-3025; Added timetamp to Message and use relative offset. - posted by ju...@apache.org on 2016/02/19 16:56:52 UTC, 0 replies.
- [1/3] kafka-site git commit: updating docs for 0.9.0.1 release - posted by ju...@apache.org on 2016/02/19 18:27:06 UTC, 0 replies.
- [2/3] kafka-site git commit: updating docs for 0.9.0.1 release - posted by ju...@apache.org on 2016/02/19 18:27:07 UTC, 0 replies.
- [3/3] kafka-site git commit: updating docs for 0.9.0.1 release - posted by ju...@apache.org on 2016/02/19 18:27:08 UTC, 0 replies.
- kafka git commit: trivial fix to authorization CLI table - posted by ju...@apache.org on 2016/02/19 18:41:50 UTC, 1 replies.
- kafka-site git commit: trivial fix to authorization CLI table - posted by ju...@apache.org on 2016/02/19 18:50:13 UTC, 0 replies.
- kafka git commit: trivial change to make release version 0.9.0.2-SNAPSHOT - posted by ju...@apache.org on 2016/02/19 18:59:15 UTC, 0 replies.
- kafka git commit: inor: Added few variable and their descriptions to vagrant readme - posted by gw...@apache.org on 2016/02/22 07:53:00 UTC, 0 replies.
- kafka git commit: KAFKA-3235: Unclosed stream in AppInfoParser static block - posted by gw...@apache.org on 2016/02/22 07:54:44 UTC, 0 replies.
- kafka git commit: KAFKA-3255: Added unit tests for NetworkClient.connectionDelay(Node node, long now) - posted by ew...@apache.org on 2016/02/22 19:13:28 UTC, 0 replies.
- kafka git commit: MINOR: Example style improvements - posted by gw...@apache.org on 2016/02/22 20:40:41 UTC, 0 replies.
- kafka git commit: MINOR: Update streams RocksDb to 4.1.0 - posted by gu...@apache.org on 2016/02/22 22:03:24 UTC, 0 replies.
- kafka git commit: HOTFIX: make sure to go through all shutdown steps - posted by gu...@apache.org on 2016/02/22 22:16:05 UTC, 0 replies.
- kafka git commit: KAFKA-3256; Add print.timestamp option to console consumer. - posted by ju...@apache.org on 2016/02/23 00:58:00 UTC, 0 replies.
- kafka git commit: MINOR - remove unused imports in package kafka.utils - posted by jj...@apache.org on 2016/02/23 03:14:28 UTC, 0 replies.
- kafka git commit: HOTFIX: check offset limits in streamtask when recovering KTable store - posted by gu...@apache.org on 2016/02/23 06:37:31 UTC, 0 replies.
- kafka git commit: MINOR: catch a commit failure due to rebalance in StreamThread - posted by gu...@apache.org on 2016/02/23 06:39:29 UTC, 0 replies.
- kafka git commit: KAFKA-2802: kafka streams system tests - posted by ew...@apache.org on 2016/02/23 21:14:41 UTC, 0 replies.
- kafka git commit: KAFKA-3242: minor rename / logging change to Controller - posted by gw...@apache.org on 2016/02/23 21:52:10 UTC, 0 replies.
- kafka git commit: KAFKA-3245: config for changelog replication factor - posted by gu...@apache.org on 2016/02/23 23:54:10 UTC, 0 replies.
- kafka git commit: HOTFIX: fix consumer config for streams - posted by gu...@apache.org on 2016/02/23 23:55:11 UTC, 0 replies.
- kafka git commit: KAFKA-3046: Add ByteBuffer Serializer and Deserializer - posted by gu...@apache.org on 2016/02/24 00:04:10 UTC, 0 replies.
- kafka git commit: MINOR: KTable.count() to only take a selector for key - posted by gw...@apache.org on 2016/02/24 00:11:05 UTC, 0 replies.
- kafka git commit: HOTFIX: Add missing file for KeyValue unit test - posted by gw...@apache.org on 2016/02/24 00:33:35 UTC, 0 replies.
- kafka git commit: KAFKA-3007: implement max.poll.records (KIP-41) - posted by ew...@apache.org on 2016/02/24 00:46:50 UTC, 0 replies.
- kafka git commit: KAFKA-3272: Add debugging options to kafka-run-class.sh so we can easily run remote debugging - posted by gw...@apache.org on 2016/02/24 00:55:14 UTC, 0 replies.
- [1/3] kafka git commit: KAFKA-3093: Add Connect status tracking API - posted by ew...@apache.org on 2016/02/24 07:47:48 UTC, 0 replies.
- [2/3] kafka git commit: KAFKA-3093: Add Connect status tracking API - posted by ew...@apache.org on 2016/02/24 07:47:49 UTC, 0 replies.
- [3/3] kafka git commit: KAFKA-3093: Add Connect status tracking API - posted by ew...@apache.org on 2016/02/24 07:47:50 UTC, 0 replies.
- kafka git commit: KAFKA-3277; Update trunk version to be 0.10.0.0-SNAPSHOT - posted by ew...@apache.org on 2016/02/24 18:21:54 UTC, 0 replies.
- kafka git commit: MINOR: Add note about which files need to be edited when updating the version number - posted by gw...@apache.org on 2016/02/24 19:12:54 UTC, 0 replies.
- kafka git commit: MINOR: add useful debug log messages to KConnect source task execution - posted by ew...@apache.org on 2016/02/24 20:08:06 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-3259 KAFKA-3253; KIP-31/KIP-32 Follow-up - posted by ju...@apache.org on 2016/02/24 20:28:59 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-3259 KAFKA-3253; KIP-31/KIP-32 Follow-up - posted by ju...@apache.org on 2016/02/24 20:29:00 UTC, 0 replies.
- kafka git commit: MINOR: add retry to state dir locking - posted by gu...@apache.org on 2016/02/24 22:41:49 UTC, 0 replies.
- kafka git commit: MINOR: enhance streams system test - posted by gu...@apache.org on 2016/02/25 03:11:40 UTC, 0 replies.
- kafka git commit: KAFKA-2698: Add paused() method to o.a.k.c.c.Consumer - posted by gu...@apache.org on 2016/02/25 04:42:00 UTC, 0 replies.
- kafka git commit: MINOR: Connect status tracking API followup - posted by gw...@apache.org on 2016/02/25 22:59:21 UTC, 0 replies.
- kafka git commit: KAFKA-3292; ClientQuotaManager.getOrCreateQuotaSensors() may return a null ClientSensors.throttleTimeSensor - posted by ju...@apache.org on 2016/02/26 02:53:24 UTC, 0 replies.
- kafka git commit: MINOR: Validate inner message compression attribute - posted by ju...@apache.org on 2016/02/26 03:08:28 UTC, 0 replies.
- kafka git commit: KAFKA-3280: KafkaConsumer Javadoc contains misleading description of heartbeat behavior and correct use - posted by gw...@apache.org on 2016/02/26 03:24:57 UTC, 0 replies.
- kafka git commit: KAFKA-3243: Fix Kafka basic ops documentation for Mirror maker, blacklist is not supported for new consumers - posted by ew...@apache.org on 2016/02/26 19:38:01 UTC, 0 replies.
- kafka git commit: KAFKA-3214: Added system tests for compressed topics - posted by gw...@apache.org on 2016/02/26 22:40:46 UTC, 0 replies.
- kafka git commit: KAFKA-3278: concatenate thread name to clientId when producer and consumers config is created - posted by gu...@apache.org on 2016/02/27 00:00:45 UTC, 0 replies.
- kafka git commit: KAFKA-3291; DumpLogSegment tool should also provide an option to only… - posted by sr...@apache.org on 2016/02/29 18:14:58 UTC, 0 replies.
- kafka git commit: KAFKA-3133: Add putIfAbsent function to KeyValueStore - posted by gu...@apache.org on 2016/02/29 21:46:07 UTC, 0 replies.
- kafka git commit: HOTFIX: Missing streams jar in release - posted by gu...@apache.org on 2016/02/29 21:50:27 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-3192: Add unwindowed aggregations for KStream; and make all example code executable - posted by gu...@apache.org on 2016/02/29 23:03:36 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-3192: Add unwindowed aggregations for KStream; and make all example code executable - posted by gu...@apache.org on 2016/02/29 23:03:37 UTC, 0 replies.