You are viewing a plain text version of this content. The canonical link for it is here.
- kafka git commit: MINOR: Add jenkins.sh to 0.10.2 branch - posted by ij...@apache.org on 2017/04/01 13:32:14 UTC, 0 replies.
- [1/4] kafka git commit: KAFKA-4817; Add idempotent producer semantics - posted by ju...@apache.org on 2017/04/03 02:41:47 UTC, 0 replies.
- [2/4] kafka git commit: KAFKA-4817; Add idempotent producer semantics - posted by ju...@apache.org on 2017/04/03 02:41:48 UTC, 0 replies.
- [3/4] kafka git commit: KAFKA-4817; Add idempotent producer semantics - posted by ju...@apache.org on 2017/04/03 02:41:49 UTC, 0 replies.
- [4/4] kafka git commit: KAFKA-4817; Add idempotent producer semantics - posted by ju...@apache.org on 2017/04/03 02:41:50 UTC, 0 replies.
- kafka git commit: MINOR: Fix deadlock between StreamThread and KafkaStreams - posted by ij...@apache.org on 2017/04/03 11:55:06 UTC, 0 replies.
- kafka git commit: MINOR: Fix potential deadlock in consumer close test - posted by ij...@apache.org on 2017/04/03 11:58:21 UTC, 0 replies.
- kafka git commit: HOTFIX: Set `baseOffset` correctly in `RecordAccumulator` - posted by ju...@apache.org on 2017/04/03 16:40:41 UTC, 0 replies.
- kafka git commit: MINOR: fix cleanup phase for KStreamWindowAggregateTest - posted by ju...@apache.org on 2017/04/03 16:54:32 UTC, 0 replies.
- kafka git commit: KAFKA-4878: Improved Invalid Connect Config Error Message - posted by gw...@apache.org on 2017/04/03 20:09:31 UTC, 1 replies.
- kafka git commit: MINOR: Close the producer batch append stream when the batch gets full to free up resources - posted by ij...@apache.org on 2017/04/03 23:14:54 UTC, 0 replies.
- kafka git commit: MINOR: Suppress ProducerConfig warning in MirrorMaker - posted by ij...@apache.org on 2017/04/03 23:18:02 UTC, 0 replies.
- kafka git commit: KAFKA-4977: Fix findbugs issues in connect/runtime - posted by ew...@apache.org on 2017/04/04 00:57:18 UTC, 0 replies.
- kafka git commit: KAFKA-4855: Struct SchemaBuilder should not allow duplicate fields - posted by ew...@apache.org on 2017/04/04 03:09:59 UTC, 0 replies.
- kafka git commit: KAFKA-4810: Make Kafka Connect SchemaBuilder more lax about checking that fields are unset - posted by ew...@apache.org on 2017/04/04 21:58:52 UTC, 0 replies.
- kafka git commit: KAFKA-4837: Fix class name comparison in connector-plugins REST endpoint - posted by ew...@apache.org on 2017/04/04 22:07:38 UTC, 1 replies.
- kafka git commit: MINOR: don't throw CommitFailedException during suspendTasksAndState - posted by ew...@apache.org on 2017/04/04 22:12:38 UTC, 0 replies.
- kafka git commit: MINOR: improve MinTimestampTrackerTest and fix NPE when null element - posted by ew...@apache.org on 2017/04/04 23:27:56 UTC, 0 replies.
- kafka git commit: KAFKA-4916: test streams with brokers failing - posted by ew...@apache.org on 2017/04/05 01:40:59 UTC, 1 replies.
- kafka git commit: HOTFIX: WindowedStreamPartitioner does not provide topic name to serializer - posted by ij...@apache.org on 2017/04/05 09:31:18 UTC, 1 replies.
- kafka git commit: MINOR: Fix flaky StateDirectoryTest - posted by ij...@apache.org on 2017/04/05 09:42:12 UTC, 0 replies.
- kafka git commit: HOTFIX: Fix checkstyle indentation error in ConnectorPluginsResource - posted by ij...@apache.org on 2017/04/05 09:54:05 UTC, 0 replies.
- kafka git commit: MINOR: Make ConfigDef safer by not using empty string for NO_DEFAULT_VALUE. - posted by ij...@apache.org on 2017/04/05 10:37:43 UTC, 0 replies.
- kafka git commit: MINOR: Fix multiple KafkaStreams.StreamStateListener being instantiated - posted by ij...@apache.org on 2017/04/05 10:39:44 UTC, 0 replies.
- kafka git commit: KAFKA-4993; Fix findbugs warnings in kafka-clients - posted by ij...@apache.org on 2017/04/05 21:17:37 UTC, 0 replies.
- kafka git commit: KAFKA-5003; StreamThread should catch InvalidTopicException - posted by ij...@apache.org on 2017/04/06 11:02:48 UTC, 1 replies.
- kafka git commit: MINOR: Improve log4j on stream thread and stream process - posted by ij...@apache.org on 2017/04/06 11:28:45 UTC, 0 replies.
- kafka git commit: MINOR: Improve topic management instructions for Kafka Streams examples - posted by ij...@apache.org on 2017/04/06 11:34:23 UTC, 1 replies.
- kafka git commit: MINOR: Clarify ReadOnlyWindowStore's time range behaviour - posted by ij...@apache.org on 2017/04/06 13:45:04 UTC, 1 replies.
- kafka git commit: KAFKA-4929: Transformation Key/Value type references should be to class name(), not canonicalName() - posted by gw...@apache.org on 2017/04/06 18:33:57 UTC, 0 replies.
- kafka git commit: KAFKA-4901; Make ProduceRequest thread-safe - posted by ij...@apache.org on 2017/04/06 20:58:31 UTC, 0 replies.
- [1/3] kafka git commit: KIP-101: Alter Replication Protocol to use Leader Epoch rather than High Watermark for Truncation - posted by ju...@apache.org on 2017/04/06 21:51:29 UTC, 0 replies.
- [2/3] kafka git commit: KIP-101: Alter Replication Protocol to use Leader Epoch rather than High Watermark for Truncation - posted by ju...@apache.org on 2017/04/06 21:51:30 UTC, 0 replies.
- [3/3] kafka git commit: KIP-101: Alter Replication Protocol to use Leader Epoch rather than High Watermark for Truncation - posted by ju...@apache.org on 2017/04/06 21:51:31 UTC, 0 replies.
- kafka-site git commit: SMT example, correct classnames in the generated transformations list and more Connect in TOC - posted by gw...@apache.org on 2017/04/06 22:45:26 UTC, 0 replies.
- kafka git commit: HOTFIX: Remove duplicate entry from ApiVersion - posted by ju...@apache.org on 2017/04/06 22:57:25 UTC, 0 replies.
- kafka git commit: KAFKA-4995; Fix remaining findbugs warnings in Kafka Streams - posted by ij...@apache.org on 2017/04/06 22:59:23 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-4990; Request/response classes for transactions (KIP-98) - posted by ij...@apache.org on 2017/04/07 11:08:45 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-4990; Request/response classes for transactions (KIP-98) - posted by ij...@apache.org on 2017/04/07 11:08:46 UTC, 0 replies.
- kafka git commit: MINOR: CollectionUtils.groupDataByTopic in OffsetsForLeaderEpochRequest/Response - posted by ij...@apache.org on 2017/04/07 11:24:17 UTC, 0 replies.
- kafka git commit: KAFKA-4899; Fix findbugs warnings in kafka-core - posted by ij...@apache.org on 2017/04/07 11:40:38 UTC, 0 replies.
- kafka git commit: KAFKA-4899; Fix findbugs warnings in kafka-core [Forced Update!] - posted by ij...@apache.org on 2017/04/07 11:41:46 UTC, 0 replies.
- kafka git commit: KAFKA-5040; Increase number of retries from the default of 0 - posted by ij...@apache.org on 2017/04/07 12:39:47 UTC, 1 replies.
- kafka git commit: KAFKA-5042: InFlightRequests#isEmpty() always returns false - posted by gw...@apache.org on 2017/04/07 17:14:16 UTC, 0 replies.
- [1/2] kafka git commit: MINOR: Log append validation improvements - posted by ij...@apache.org on 2017/04/07 17:30:10 UTC, 0 replies.
- [2/2] kafka git commit: MINOR: Log append validation improvements - posted by ij...@apache.org on 2017/04/07 17:30:11 UTC, 0 replies.
- kafka git commit: KAFKA-4943: Make /config/users with SCRAM credentials not world-readable - posted by gw...@apache.org on 2017/04/07 18:07:14 UTC, 1 replies.
- [kafka] Git Push Summary - posted by gw...@apache.org on 2017/04/07 22:52:00 UTC, 4 replies.
- [1/6] kafka-site git commit: Add 0.10.2 docs from 0.10.2.1 RC0 - posted by gw...@apache.org on 2017/04/07 23:57:51 UTC, 0 replies.
- [2/6] kafka-site git commit: Add 0.10.2 docs from 0.10.2.1 RC0 - posted by gw...@apache.org on 2017/04/07 23:57:52 UTC, 0 replies.
- [3/6] kafka-site git commit: Add 0.10.2 docs from 0.10.2.1 RC0 - posted by gw...@apache.org on 2017/04/07 23:57:53 UTC, 0 replies.
- [4/6] kafka-site git commit: Add 0.10.2 docs from 0.10.2.1 RC0 - posted by gw...@apache.org on 2017/04/07 23:57:54 UTC, 0 replies.
- [5/6] kafka-site git commit: Add 0.10.2 docs from 0.10.2.1 RC0 - posted by gw...@apache.org on 2017/04/07 23:57:55 UTC, 0 replies.
- [6/6] kafka-site git commit: Add 0.10.2 docs from 0.10.2.1 RC0 - posted by gw...@apache.org on 2017/04/07 23:57:56 UTC, 0 replies.
- kafka git commit: MINOR: Fix incorrect pattern matching on `version` in `CheckpointFile` - posted by ij...@apache.org on 2017/04/08 00:04:04 UTC, 0 replies.
- kafka git commit: HOTFIX: Use a true sentinel for `UseDefaultAcls` - posted by gw...@apache.org on 2017/04/10 16:16:56 UTC, 1 replies.
- kafka git commit: KAFKA-5052; Don't pass underlying internal exception to RetriableCommitFailedException - posted by ij...@apache.org on 2017/04/11 00:21:20 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-5043; Rename GroupCoordinator to FindCoordinator (KIP-98) - posted by ij...@apache.org on 2017/04/11 08:31:11 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-5043; Rename GroupCoordinator to FindCoordinator (KIP-98) - posted by ij...@apache.org on 2017/04/11 08:31:12 UTC, 0 replies.
- kafka git commit: MINOR: Document ordering contract of iterator for window stores and session stores - posted by ij...@apache.org on 2017/04/11 08:50:13 UTC, 1 replies.
- kafka git commit: MINOR: Fix typo in consumer ACL example - posted by ij...@apache.org on 2017/04/11 10:29:29 UTC, 0 replies.
- kafka git commit: KAFKA-4866; Console consumer `print.value` property is ignored - posted by ij...@apache.org on 2017/04/11 11:39:53 UTC, 0 replies.
- kafka git commit: KAFKA-5013; Fail the build when findbugs fails - posted by ij...@apache.org on 2017/04/11 23:47:56 UTC, 0 replies.
- kafka git commit: MINOR: Make LeaderAndIsr immutable case class - posted by ij...@apache.org on 2017/04/12 00:03:10 UTC, 0 replies.
- kafka git commit: MINOR: Added changes in 0.10.2.1 - posted by gw...@apache.org on 2017/04/12 00:07:57 UTC, 1 replies.
- kafka-site git commit: upgrade notes for 0.10.2.1 - posted by gw...@apache.org on 2017/04/12 00:41:32 UTC, 0 replies.
- kafka-site git commit: MINOR: fixing broken tag - posted by gw...@apache.org on 2017/04/12 00:56:09 UTC, 0 replies.
- kafka git commit: HOTFIX: HTML formatting error in upgrade docs - posted by ij...@apache.org on 2017/04/12 10:09:10 UTC, 1 replies.
- kafka git commit: KAFKA-4965; set internal.leave.group.on.close to false in StreamsConfig - posted by ij...@apache.org on 2017/04/12 12:05:04 UTC, 0 replies.
- kafka git commit: KAFKA-5038; Throw correct exception of locking of state directory fails - posted by ij...@apache.org on 2017/04/12 14:27:17 UTC, 1 replies.
- kafka git commit: KAFKA-4986; Producer per StreamTask support (KIP-129) - posted by ij...@apache.org on 2017/04/14 14:21:22 UTC, 0 replies.
- kafka git commit: KAFKA-5075; Defer exception to the next pollOnce() if consumer's fetch position has already increased - posted by jq...@apache.org on 2017/04/17 06:23:31 UTC, 1 replies.
- [1/2] kafka git commit: KAFKA-5036; Second part: Points 2 -> 5): Refactor caching of Latest Epoch - posted by ju...@apache.org on 2017/04/18 00:24:50 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-5036; Second part: Points 2 -> 5): Refactor caching of Latest Epoch - posted by ju...@apache.org on 2017/04/18 00:24:51 UTC, 0 replies.
- kafka git commit: KAFKA-5069; add controller integration tests - posted by ju...@apache.org on 2017/04/18 23:39:51 UTC, 0 replies.
- kafka git commit: KAFKA-5049; Chroot check should be done for each ZkUtils instance - posted by ij...@apache.org on 2017/04/19 10:36:49 UTC, 0 replies.
- kafka git commit: MINOR: Fix some re-raising of exceptions in system tests - posted by ij...@apache.org on 2017/04/19 15:17:58 UTC, 0 replies.
- kafka git commit: KAFKA-5068; Optionally print out metrics after running the perf tests - posted by ju...@apache.org on 2017/04/19 16:53:16 UTC, 0 replies.
- kafka git commit: MINOR: Update dependencies for 0.11 - posted by ij...@apache.org on 2017/04/20 07:55:55 UTC, 0 replies.
- kafka git commit: KAFKA-4814; Enable ZK ACLs only when zookeeper.set.acl is set - posted by ij...@apache.org on 2017/04/20 09:24:15 UTC, 0 replies.
- kafka git commit: MINOR: Fix open file leak in log cleaner integration tests - posted by ij...@apache.org on 2017/04/20 12:19:44 UTC, 0 replies.
- kafka git commit: MINOR: Improvements to PID snapshot management - posted by ju...@apache.org on 2017/04/20 20:01:50 UTC, 0 replies.
- kafka git commit: KAFKA-4937: Batch offset fetches in the Consumer - posted by gu...@apache.org on 2017/04/20 20:36:55 UTC, 0 replies.
- kafka git commit: KAFKA-5097; Fix regression in consumer caused by unsafe access to potentially unassigned partitions - posted by jg...@apache.org on 2017/04/20 20:43:08 UTC, 0 replies.
- kafka git commit: MINOR: improve test stability for Streams broker-compatibility test - posted by gu...@apache.org on 2017/04/20 20:49:10 UTC, 0 replies.
- kafka git commit: KAFKA-5014; NetworkClient.leastLoadedNode should check if channel is ready - posted by jg...@apache.org on 2017/04/20 21:09:37 UTC, 0 replies.
- kafka git commit: MINOR: reduce commit interval and cache size for integration test - posted by gu...@apache.org on 2017/04/20 21:11:53 UTC, 1 replies.
- kafka git commit: KAFKA-5047: NullPointerException while using GlobalKTable in KafkaStreams - posted by gu...@apache.org on 2017/04/20 21:24:50 UTC, 0 replies.
- kafka git commit: KAFKA-5073: Kafka Streams stuck rebalancing after exception thrown in rebalance listener - posted by gu...@apache.org on 2017/04/20 21:34:48 UTC, 0 replies.
- kafka git commit: KAFKA-5095: Adjust accepted overhead for ThreadCacheTest - posted by gu...@apache.org on 2017/04/20 21:55:47 UTC, 1 replies.
- kafka git commit: KAFKA-4980: testReprocessingFromScratch unit test failure - posted by gu...@apache.org on 2017/04/20 23:05:51 UTC, 0 replies.
- kafka git commit: KAFKA-5088: some spelling error in code comment - posted by gu...@apache.org on 2017/04/21 04:43:11 UTC, 0 replies.
- kafka git commit: KAFKA-5094; Replace SCRAM credentials in broker logs with tag hidden - posted by ij...@apache.org on 2017/04/21 09:47:51 UTC, 0 replies.
- kafka git commit: MINOR: findbugs should generate XML reports in Jenkins - posted by ij...@apache.org on 2017/04/21 10:39:20 UTC, 0 replies.
- kafka git commit: MINOR: Fix logging in ControlRecordType - posted by ij...@apache.org on 2017/04/21 13:05:17 UTC, 0 replies.
- kafka git commit: MINOR: Remove redundant CRC validation for non-compressed records in older message formats - posted by jg...@apache.org on 2017/04/21 17:35:54 UTC, 0 replies.
- kafka git commit: MINOR: fix record collector to stick with streams partitioner behavior if it is specified - posted by gu...@apache.org on 2017/04/21 17:47:31 UTC, 0 replies.
- kafka git commit: KAFKA-4564: Add system test for pre-0.10 brokers - posted by gu...@apache.org on 2017/04/21 17:53:32 UTC, 0 replies.
- kafka git commit: KAFKA-5100; ProducerPerformanceService failing due to parsing error - posted by ju...@apache.org on 2017/04/21 19:52:44 UTC, 0 replies.
- kafka git commit: MINOR: improve test cleanup for Streams - posted by gu...@apache.org on 2017/04/21 20:10:08 UTC, 0 replies.
- kafka git commit: KAFKA-5090: Fix Kafka Streams SessionStore.findSessions javadoc broken - posted by gu...@apache.org on 2017/04/21 20:25:16 UTC, 0 replies.
- kafka git commit: MINOR: fix javadoc comment of Transformer - posted by gu...@apache.org on 2017/04/21 20:27:14 UTC, 0 replies.
- kafka git commit: MINOR: Move `Os` class to utils package and rename it to OperatingSystem - posted by jg...@apache.org on 2017/04/22 21:15:33 UTC, 0 replies.
- kafka git commit: KAFKA-4564; Follow-up to fix test_timeout_on_pre_010_brokers system test failure - posted by ij...@apache.org on 2017/04/23 15:23:46 UTC, 0 replies.
- kafka git commit: MINOR: ProducerPerformance should work with older client jars - posted by ij...@apache.org on 2017/04/23 15:29:52 UTC, 0 replies.
- kafka git commit: MINOR: Replication system tests should cover compressed path - posted by ij...@apache.org on 2017/04/24 09:17:18 UTC, 0 replies.
- kafka git commit: KAFKA-4755: Cherry-pick streams tests fixes from trunk - posted by gu...@apache.org on 2017/04/24 16:50:18 UTC, 0 replies.
- kafka git commit: KAFKA-4840; BufferPool errors can cause buffer pool to go into a bad state - posted by jq...@apache.org on 2017/04/25 17:31:23 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-5111: Improve internal Task APIs of Streams - posted by gu...@apache.org on 2017/04/26 01:10:52 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-5111: Improve internal Task APIs of Streams - posted by gu...@apache.org on 2017/04/26 01:10:53 UTC, 0 replies.
- [1/3] kafka git commit: Bump version to 0.10.2.1 - posted by gw...@apache.org on 2017/04/26 19:25:14 UTC, 0 replies.
- [2/3] kafka git commit: Merge tag '0.10.2.1-rc3' into 0.10.2 - posted by gw...@apache.org on 2017/04/26 19:25:15 UTC, 0 replies.
- [3/3] kafka git commit: Post 0.10.2.1 release version bumping - posted by gw...@apache.org on 2017/04/26 19:25:16 UTC, 0 replies.
- kafka git commit: KAFKA-5124: autocommit reset earliest fixes race condition - posted by gu...@apache.org on 2017/04/26 19:27:28 UTC, 0 replies.
- svn commit: r19281 - in /release/kafka/0.10.2.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/... - posted by gu...@apache.org on 2017/04/26 19:59:14 UTC, 0 replies.
- kafka git commit: KAFKA-5108; Add support for reading PID snapshot files to DumpLogSegments - posted by jg...@apache.org on 2017/04/26 20:46:41 UTC, 0 replies.
- [01/10] kafka git commit: KAFKA-5059: Implement Transactional Coordinator - posted by gu...@apache.org on 2017/04/26 21:11:04 UTC, 0 replies.
- [02/10] kafka git commit: KAFKA-5059: Implement Transactional Coordinator - posted by gu...@apache.org on 2017/04/26 21:11:05 UTC, 0 replies.
- [03/10] kafka git commit: KAFKA-5059: Implement Transactional Coordinator - posted by gu...@apache.org on 2017/04/26 21:11:06 UTC, 0 replies.
- [04/10] kafka git commit: KAFKA-5059: Implement Transactional Coordinator - posted by gu...@apache.org on 2017/04/26 21:11:07 UTC, 0 replies.
- [05/10] kafka git commit: KAFKA-5059: Implement Transactional Coordinator - posted by gu...@apache.org on 2017/04/26 21:11:08 UTC, 0 replies.
- [06/10] kafka git commit: KAFKA-5059: Implement Transactional Coordinator - posted by gu...@apache.org on 2017/04/26 21:11:09 UTC, 0 replies.
- [07/10] kafka git commit: KAFKA-5059: Implement Transactional Coordinator - posted by gu...@apache.org on 2017/04/26 21:11:10 UTC, 0 replies.
- [08/10] kafka git commit: KAFKA-5059: Implement Transactional Coordinator - posted by gu...@apache.org on 2017/04/26 21:11:11 UTC, 0 replies.
- [09/10] kafka git commit: KAFKA-5059: Implement Transactional Coordinator - posted by gu...@apache.org on 2017/04/26 21:11:12 UTC, 0 replies.
- [10/10] kafka git commit: KAFKA-5059: Implement Transactional Coordinator - posted by gu...@apache.org on 2017/04/26 21:11:13 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-5028; convert kafka controller to a single-threaded event queue model - posted by ju...@apache.org on 2017/04/27 15:51:28 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-5028; convert kafka controller to a single-threaded event queue model - posted by ju...@apache.org on 2017/04/27 15:51:29 UTC, 0 replies.
- kafka-site git commit: adding release 0.10.2.1 to downloads - posted by gw...@apache.org on 2017/04/27 18:39:52 UTC, 0 replies.
- kafka-site git commit: Add Rajini to committers page - posted by rs...@apache.org on 2017/04/27 20:27:29 UTC, 0 replies.
- [1/3] kafka git commit: KAFKA-4818; Exactly once transactional clients - posted by jg...@apache.org on 2017/04/27 21:29:33 UTC, 0 replies.
- [2/3] kafka git commit: KAFKA-4818; Exactly once transactional clients - posted by jg...@apache.org on 2017/04/27 21:29:34 UTC, 0 replies.
- [3/3] kafka git commit: KAFKA-4818; Exactly once transactional clients - posted by jg...@apache.org on 2017/04/27 21:29:35 UTC, 0 replies.
- kafka git commit: KAFKA-5086: Update topic expiry time in Metadata every time the topic metadata is requested - posted by rs...@apache.org on 2017/04/27 22:01:39 UTC, 0 replies.
- kafka git commit: KAFKA-5119; Ensure global metrics are empty before running testMetricCollectionAfterShutdown - posted by ij...@apache.org on 2017/04/27 23:01:56 UTC, 0 replies.
- kafka git commit: KAFKA-5101; Remove unused zkClient parameter in incrementControllerEpoch - posted by ij...@apache.org on 2017/04/27 23:08:23 UTC, 0 replies.
- kafka git commit: KAFKA-5005: IntegrationTestUtils to override consumer configs and reuse consumer - posted by gu...@apache.org on 2017/04/27 23:38:31 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-5111: Code cleanup and improved log4j on StreamThread and Task - posted by gu...@apache.org on 2017/04/28 00:11:51 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-5111: Code cleanup and improved log4j on StreamThread and Task - posted by gu...@apache.org on 2017/04/28 00:11:52 UTC, 0 replies.
- kafka git commit: KAFKA-4379; Follow-up to avoid sending to changelog while restoring InMemoryLRUCache - posted by jg...@apache.org on 2017/04/28 00:29:18 UTC, 0 replies.
- kafka git commit: MINOR: adding global store must ensure unique names - posted by gu...@apache.org on 2017/04/28 00:41:24 UTC, 0 replies.
- kafka git commit: Use zkUtils instead of zkClient in AdminUtils - posted by ij...@apache.org on 2017/04/28 01:18:23 UTC, 0 replies.
- kafka git commit: KAFKA-4986 Follow-up: cleanup unit tests and further comments addressed - posted by gu...@apache.org on 2017/04/28 06:28:53 UTC, 0 replies.
- kafka git commit: KAFKA-5097; Add testFetchAfterPartitionWithFetchedRecordsIsUnassigned - posted by jg...@apache.org on 2017/04/28 06:41:52 UTC, 0 replies.
- kafka git commit: MINOR: Make assignment expectation explicit in testConsumptionWithBrokerFailures - posted by ij...@apache.org on 2017/04/28 10:06:01 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-4208; Add Record Headers - posted by jg...@apache.org on 2017/04/29 02:40:44 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-4208; Add Record Headers - posted by jg...@apache.org on 2017/04/29 02:40:45 UTC, 0 replies.