You are viewing a plain text version of this content. The canonical link for it is here.
- kafka git commit: KAFKA-4677 Follow Up: add optimization to StickyTaskAssignor for rolling rebounce - posted by gu...@apache.org on 2017/03/01 19:21:44 UTC, 0 replies.
- kafka git commit: MINOR: improve MinTimestampTrackerTest and fix NPE when null element removed - posted by gu...@apache.org on 2017/03/01 20:07:48 UTC, 0 replies.
- kafka git commit: MINOR: Minor reduce unnecessary calls to time.millisecond (part 2) - posted by gu...@apache.org on 2017/03/01 22:36:11 UTC, 0 replies.
- kafka git commit: KAFKA4811; ReplicaFetchThread may fail to create due to existing metric - posted by ju...@apache.org on 2017/03/02 17:55:04 UTC, 0 replies.
- kafka git commit: KAFKA-2358: Cluster collection returning methods never return null - posted by gu...@apache.org on 2017/03/02 21:13:03 UTC, 0 replies.
- kafka git commit: KAFKA-4652: Added tests for KStreamBuilder - posted by gu...@apache.org on 2017/03/02 21:19:13 UTC, 0 replies.
- kafka git commit: MINOR: Fix typo in GlobalKTable javadocs - posted by gu...@apache.org on 2017/03/02 21:23:59 UTC, 0 replies.
- kafka git commit: KAFKA-4800: Streams State transition ASCII diagrams need fixing and polishing - posted by gu...@apache.org on 2017/03/02 21:26:34 UTC, 1 replies.
- kafka git commit: KAFKA-4631; Request metadata in consumer if topic/partitions unavailable - posted by jg...@apache.org on 2017/03/03 01:54:53 UTC, 1 replies.
- kafka git commit: KAFKA-2857; Retry querying the consumer group while initializing - posted by jg...@apache.org on 2017/03/03 20:04:02 UTC, 0 replies.
- kafka git commit: MINOR: Bump version to 0.11.0.0-SNAPSHOT - posted by ij...@apache.org on 2017/03/03 22:23:39 UTC, 0 replies.
- kafka git commit: MINOR: Fix tests/docker/Dockerfile - posted by ew...@apache.org on 2017/03/04 00:40:32 UTC, 1 replies.
- kafka git commit: KAFKA-2857; MINOR: Follow up to MINOR: Fix ResetIntegrationTest test failures - posted by ij...@apache.org on 2017/03/04 00:50:02 UTC, 0 replies.
- kafka git commit: KAFKA-4796; Fix some findbugs warnings in Kafka Java client - posted by ij...@apache.org on 2017/03/04 00:52:38 UTC, 0 replies.
- kafka git commit: KAFKA-3182; Fix testSocketsCloseOnShutdown transient failures - posted by ij...@apache.org on 2017/03/04 15:28:46 UTC, 0 replies.
- kafka git commit: KAFKA-4820; ConsumerNetworkClient.send() should not require global lock - posted by jq...@apache.org on 2017/03/04 19:39:11 UTC, 0 replies.
- kafka git commit: MINOR: Standardised benchmark params for consumer and streams - posted by gu...@apache.org on 2017/03/05 04:55:19 UTC, 0 replies.
- kafka git commit: KAFKA-4826: Fix some findbugs warnings in Kafka Streams - posted by gu...@apache.org on 2017/03/05 18:01:34 UTC, 0 replies.
- kafka git commit: KAFKA-4276: Add REST configuration in connector properties - posted by gw...@apache.org on 2017/03/05 18:21:14 UTC, 0 replies.
- kafka git commit: KAFKA-4567 - Connect Producer and Consumer ignore ssl parameters… - posted by gw...@apache.org on 2017/03/05 18:28:53 UTC, 0 replies.
- kafka git commit: KAFKA-4828: ProcessorTopologyTestDriver does not work when using through - posted by gu...@apache.org on 2017/03/06 06:42:46 UTC, 0 replies.
- kafka git commit: MINOR: additional refactoring around the use of Errors - posted by ij...@apache.org on 2017/03/06 10:46:06 UTC, 0 replies.
- kafka git commit: KAFKA-3989; Initial support for adding a JMH benchmarking module - posted by ij...@apache.org on 2017/03/06 11:56:30 UTC, 0 replies.
- kafka git commit: KAFKA-4266; ReassignPartitionsClusterTest: ensure ZK publication is completed before start - posted by ij...@apache.org on 2017/03/06 13:32:51 UTC, 0 replies.
- kafka git commit: HOTFIX: fix broken link for wordcount demo example - posted by gu...@apache.org on 2017/03/06 17:52:20 UTC, 1 replies.
- kafka git commit: KAFKA-3155; Avoid long overflow in RecordBatch#maybeExpire - posted by ij...@apache.org on 2017/03/06 21:20:21 UTC, 0 replies.
- kafka git commit: KAFKA-4251: fix test driver not launching in Vagrant 1.8.6 - posted by ij...@apache.org on 2017/03/07 00:03:21 UTC, 1 replies.
- kafka git commit: MINOR: Rename RecordBatch to ProducerBatch to free the name for KIP-98 - posted by ij...@apache.org on 2017/03/07 01:31:05 UTC, 0 replies.
- kafka git commit: KAFKA-4851: only search available segments during Segments.segments(from, to) - posted by gu...@apache.org on 2017/03/07 23:31:25 UTC, 1 replies.
- kafka git commit: KAFKA-4841; NetworkClient should only consider a connection to have failed after attempt to connect - posted by ij...@apache.org on 2017/03/08 01:11:46 UTC, 0 replies.
- kafka git commit: KAFKA-4722: Add application.id to StreamThread name - posted by gu...@apache.org on 2017/03/08 19:40:43 UTC, 0 replies.
- kafka git commit: MINOR: Add varint serde utilities for new message format - posted by ij...@apache.org on 2017/03/08 22:26:28 UTC, 0 replies.
- kafka git commit: MINOR: Use ConcurrentMap for ConsumerNetworkClient UnsentRequests - posted by ij...@apache.org on 2017/03/08 23:17:04 UTC, 0 replies.
- kafka git commit: KAFKA-4745; Remove unnecessary flush in KafkaLZ4BlockOutputStream.close() - posted by ij...@apache.org on 2017/03/09 01:02:09 UTC, 0 replies.
- kafka git commit: KAFKA-4864; added correct zookeeper nodes for security migrator - posted by ju...@apache.org on 2017/03/09 05:41:41 UTC, 1 replies.
- kafka git commit: MINOR: Introduce NetworkClient.hasInFlightRequests - posted by jg...@apache.org on 2017/03/09 17:46:08 UTC, 0 replies.
- kafka git commit: KAFKA-4467: Run tests on travis-ci using docker - posted by ew...@apache.org on 2017/03/10 00:24:46 UTC, 0 replies.
- kafka git commit: KAFKA-4861; GroupMetadataManager record is rejected if broker configured with LogAppendTime - posted by jg...@apache.org on 2017/03/10 01:40:06 UTC, 1 replies.
- kafka git commit: MINOR: KStream: fix typo in javadoc - posted by gu...@apache.org on 2017/03/10 15:51:46 UTC, 0 replies.
- kafka git commit: KAFKA-4738: Remove generic type of class ClientState - posted by gu...@apache.org on 2017/03/10 19:28:09 UTC, 0 replies.
- kafka git commit: MINOR: increase RocksDb parallelism - posted by gu...@apache.org on 2017/03/10 21:43:07 UTC, 1 replies.
- kafka git commit: MINOR: incorrect javadoc formatting - posted by gu...@apache.org on 2017/03/11 00:48:53 UTC, 1 replies.
- kafka git commit: KAFKA-4769: Add Float serializer, deserializer, serde - posted by gu...@apache.org on 2017/03/13 18:49:52 UTC, 0 replies.
- kafka git commit: KAFKA-4657: Improve test coverage of CompositeReadOnlyWindowStore - posted by gu...@apache.org on 2017/03/13 19:05:51 UTC, 0 replies.
- kafka git commit: KAFKA-4891; kafka.request.logger TRACE regression - posted by jq...@apache.org on 2017/03/13 20:01:04 UTC, 0 replies.
- kafka git commit: HOTFIX: Fix apache headers in float serde class files - posted by jg...@apache.org on 2017/03/13 20:48:05 UTC, 0 replies.
- kafka git commit: KAFKA-4863; Querying window store may return unwanted keys - posted by gu...@apache.org on 2017/03/14 21:21:08 UTC, 0 replies.
- kafka git commit: KAFKA-4783: Add ByteArrayConverter (KIP-128) - posted by ew...@apache.org on 2017/03/15 00:20:33 UTC, 0 replies.
- kafka git commit: HOTFIX: Fix header in ByteArrayConverter - posted by ij...@apache.org on 2017/03/15 14:47:00 UTC, 0 replies.
- kafka git commit: MINOR: Improve log4j on stream thread and stream process - posted by jg...@apache.org on 2017/03/15 17:47:00 UTC, 0 replies.
- kafka git commit: MINOR: Fix a documentation typo - posted by sr...@apache.org on 2017/03/15 18:51:02 UTC, 0 replies.
- kafka git commit: KAFKA-4901; Make ProduceRequest thread-safe - posted by ju...@apache.org on 2017/03/16 16:14:03 UTC, 0 replies.
- kafka git commit: KAFKA-4885: Add client.close as exception handler in streams system tests - posted by gu...@apache.org on 2017/03/17 05:33:53 UTC, 0 replies.
- kafka git commit: KAFKA-4859: Set shorter commit interval for integration tests with caching - posted by gu...@apache.org on 2017/03/17 05:36:09 UTC, 0 replies.
- kafka git commit: MINOR: Log error if offsets topic creation fails - posted by ij...@apache.org on 2017/03/17 10:26:46 UTC, 0 replies.
- kafka git commit: MINOR: Increase Throttle lower bound assertion in throttling_test - posted by ij...@apache.org on 2017/03/17 12:40:15 UTC, 1 replies.
- kafka git commit: MINOR: Fix non-null check in the constructor of ListenerName - posted by ij...@apache.org on 2017/03/17 13:49:25 UTC, 0 replies.
- kafka git commit: KAFKA-4895; Fix findbugs "format string should use %n rather than \n" in tools - posted by ij...@apache.org on 2017/03/17 13:59:56 UTC, 0 replies.
- kafka git commit: KAFKA-4607: Validate the names of auto-generated internal topics - posted by gu...@apache.org on 2017/03/17 19:03:05 UTC, 0 replies.
- kafka git commit: MINOR: Guard against NPE when throwing StreamsException on serializer mismatch - posted by gu...@apache.org on 2017/03/17 22:18:09 UTC, 0 replies.
- kafka git commit: KAFKA-4894; Fix findbugs "default character set in use" warnings - posted by ju...@apache.org on 2017/03/20 20:52:39 UTC, 0 replies.
- kafka git commit: KAFKA-4848: Fix retryWithBackoff deadlock issue - posted by gu...@apache.org on 2017/03/21 04:56:19 UTC, 0 replies.
- kafka git commit: MINOR: Fix zookeeper-security-migration documentation example - posted by ij...@apache.org on 2017/03/21 09:52:24 UTC, 1 replies.
- kafka git commit: KAFKA-4594; Annotate integration tests and provide gradle build targets to run subsets of tests - posted by ij...@apache.org on 2017/03/21 10:13:49 UTC, 0 replies.
- kafka git commit: KAFKA-4863 Follow-up: Querying window store may return unwanted keys - posted by gu...@apache.org on 2017/03/21 23:12:03 UTC, 0 replies.
- kafka git commit: KAFKA-4863: Querying window store may return unwanted keys. Backport to 0.10.2 - posted by gu...@apache.org on 2017/03/21 23:14:15 UTC, 0 replies.
- kafka git commit: MINOR: remove unused log field from KStreamTransformValuesProcessor - posted by gu...@apache.org on 2017/03/21 23:17:20 UTC, 1 replies.
- kafka git commit: MINOR: updated incorrect JavaDocs for joins - posted by gu...@apache.org on 2017/03/21 23:21:30 UTC, 1 replies.
- kafka git commit: KAFKA-4924: Fix Kafka Connect API findbugs warnings - posted by ew...@apache.org on 2017/03/21 23:48:03 UTC, 0 replies.
- kafka git commit: MINOR: log start and end offsets for state store restoration - posted by gu...@apache.org on 2017/03/22 02:14:07 UTC, 0 replies.
- kafka git commit: MINOR: improve hanging ResetIntegrationTest - posted by gu...@apache.org on 2017/03/22 02:18:44 UTC, 1 replies.
- kafka git commit: MINOR: Pluggable verifiable clients - posted by ew...@apache.org on 2017/03/22 05:23:31 UTC, 0 replies.
- kafka git commit: MINOR: MyProcessor doc example should implement, not extend `Processor` - posted by gu...@apache.org on 2017/03/22 19:23:10 UTC, 1 replies.
- kafka git commit: MINOR: log state store restore offsets - posted by gu...@apache.org on 2017/03/22 19:24:36 UTC, 0 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/03/22 21:02:17 UTC, 0 replies.
- kafka git commit: MINOR: Improvements on Streams log4j - posted by gu...@apache.org on 2017/03/22 21:33:37 UTC, 0 replies.
- kafka git commit: MINOR: Adding example to SMT documentation - posted by ew...@apache.org on 2017/03/23 06:05:36 UTC, 1 replies.
- kafka git commit: KAFKA-4919: Document that stores must not be closed when Processors are closed - posted by gu...@apache.org on 2017/03/23 16:47:50 UTC, 1 replies.
- kafka git commit: MINOR: only log first exception in RecordCollectorImpl producer callback - posted by gu...@apache.org on 2017/03/23 17:05:05 UTC, 1 replies.
- [01/11] kafka git commit: KAFKA-4816; Message format changes for idempotent/transactional producer (KIP-98) - posted by ij...@apache.org on 2017/03/24 19:43:54 UTC, 0 replies.
- [02/11] kafka git commit: KAFKA-4816; Message format changes for idempotent/transactional producer (KIP-98) - posted by ij...@apache.org on 2017/03/24 19:43:55 UTC, 0 replies.
- [03/11] kafka git commit: KAFKA-4816; Message format changes for idempotent/transactional producer (KIP-98) - posted by ij...@apache.org on 2017/03/24 19:43:56 UTC, 0 replies.
- [04/11] kafka git commit: KAFKA-4816; Message format changes for idempotent/transactional producer (KIP-98) - posted by ij...@apache.org on 2017/03/24 19:43:57 UTC, 0 replies.
- [05/11] kafka git commit: KAFKA-4816; Message format changes for idempotent/transactional producer (KIP-98) - posted by ij...@apache.org on 2017/03/24 19:43:58 UTC, 0 replies.
- [06/11] kafka git commit: KAFKA-4816; Message format changes for idempotent/transactional producer (KIP-98) - posted by ij...@apache.org on 2017/03/24 19:43:59 UTC, 0 replies.
- [07/11] kafka git commit: KAFKA-4816; Message format changes for idempotent/transactional producer (KIP-98) - posted by ij...@apache.org on 2017/03/24 19:44:00 UTC, 0 replies.
- [08/11] kafka git commit: KAFKA-4816; Message format changes for idempotent/transactional producer (KIP-98) - posted by ij...@apache.org on 2017/03/24 19:44:01 UTC, 0 replies.
- [09/11] kafka git commit: KAFKA-4816; Message format changes for idempotent/transactional producer (KIP-98) - posted by ij...@apache.org on 2017/03/24 19:44:02 UTC, 0 replies.
- [10/11] kafka git commit: KAFKA-4816; Message format changes for idempotent/transactional producer (KIP-98) - posted by ij...@apache.org on 2017/03/24 19:44:03 UTC, 0 replies.
- [11/11] kafka git commit: KAFKA-4816; Message format changes for idempotent/transactional producer (KIP-98) - posted by ij...@apache.org on 2017/03/24 19:44:04 UTC, 0 replies.
- kafka git commit: HOTFIX: Fix unsafe dependence on class name in VerifiableClientJava - posted by ew...@apache.org on 2017/03/25 02:41:56 UTC, 0 replies.
- kafka git commit: MINOR: Fix deserialization of abortedTransactions and lastStableOffset in FetchResponse - posted by jg...@apache.org on 2017/03/25 21:08:02 UTC, 0 replies.
- kafka git commit: MINOR: Use method handles instead of reflection for creating Snappy and LZ4 streams - posted by jg...@apache.org on 2017/03/27 16:33:31 UTC, 0 replies.
- kafka git commit: KAFKA-4881: add internal leave.group.on.close config to consumer - posted by gu...@apache.org on 2017/03/27 17:30:45 UTC, 0 replies.
- kafka git commit: KAFKA-4569; Check for wakeup on every call to KafkaConsumer.poll - posted by jg...@apache.org on 2017/03/27 23:05:28 UTC, 0 replies.
- kafka git commit: KAFKA-4575: ensure topic created before starting sink for ConnectDistributedTest.test_pause_resume_sink - posted by ew...@apache.org on 2017/03/28 00:46:16 UTC, 1 replies.
- [1/3] kafka git commit: KAFKA-4586; Add purgeDataBefore() API (KIP-107) - posted by jq...@apache.org on 2017/03/28 16:59:49 UTC, 0 replies.
- [2/3] kafka git commit: KAFKA-4586; Add purgeDataBefore() API (KIP-107) - posted by jq...@apache.org on 2017/03/28 16:59:50 UTC, 0 replies.
- [3/3] kafka git commit: KAFKA-4586; Add purgeDataBefore() API (KIP-107) - posted by jq...@apache.org on 2017/03/28 16:59:51 UTC, 0 replies.
- kafka git commit: Minor: Remove the accidentally checked in file which broke checkStyle. - posted by jq...@apache.org on 2017/03/28 19:19:50 UTC, 0 replies.
- kafka git commit: KAFKA-4959; Remove controller concurrent access to non-threadsafe NetworkClient, Selector, and SSLEngine - posted by ij...@apache.org on 2017/03/28 22:53:56 UTC, 1 replies.
- kafka git commit: MINOR: Support streaming decompression of fetched records for new format - posted by jg...@apache.org on 2017/03/29 01:20:04 UTC, 0 replies.
- kafka git commit: KAFKA-4574; Ignore test_zk_security_upgrade until KIP-101 lands - posted by ij...@apache.org on 2017/03/29 01:30:36 UTC, 0 replies.
- kafka git commit: KAFKA-4903; Remove dead code in Shell - posted by ij...@apache.org on 2017/03/29 15:11:06 UTC, 0 replies.
- kafka git commit: KAFKA-4945; Suppress findbugs warnings about machine-generated code in jmh-benchmarks - posted by ij...@apache.org on 2017/03/29 15:23:06 UTC, 0 replies.
- kafka git commit: KAFKA-4944; Fix an "unread field" findbugs warning in streams examples - posted by ij...@apache.org on 2017/03/29 15:33:28 UTC, 0 replies.
- kafka git commit: KAFKA-1449; Use CRC32C for checksum of V2 message format - posted by jg...@apache.org on 2017/03/29 18:24:04 UTC, 0 replies.
- kafka git commit: KAFKA-4843: More efficient round-robin scheduler - posted by gu...@apache.org on 2017/03/29 22:00:29 UTC, 0 replies.
- kafka git commit: MINOR: FetchRequest.Builder maxBytes for version <3 - posted by ij...@apache.org on 2017/03/30 11:36:19 UTC, 0 replies.
- kafka git commit: MINOR: Map `mkString` format updated to default java format - posted by ij...@apache.org on 2017/03/30 12:27:41 UTC, 0 replies.
- kafka git commit: KAFKA-4902; Utils#delete should correctly handle I/O errors and symlinks - posted by ij...@apache.org on 2017/03/30 12:42:22 UTC, 0 replies.
- kafka git commit: MINOR: Doc change related to ZK sasl configs - posted by ij...@apache.org on 2017/03/30 12:50:51 UTC, 0 replies.
- kafka git commit: MINOR: Fix typos in javadoc and code comments - posted by ij...@apache.org on 2017/03/30 12:52:26 UTC, 0 replies.
- kafka git commit: KAFKA-4973; Fix transient failure of AdminClientTest.testDeleteRecordsWithException - posted by jq...@apache.org on 2017/03/30 17:50:45 UTC, 0 replies.
- kafka git commit: MINOR: Update possible errors in OffsetFetchResponse - posted by jg...@apache.org on 2017/03/30 18:25:03 UTC, 0 replies.
- kafka git commit: KAFKA-4980: testReprocessingFromScratch unit test failure - posted by gu...@apache.org on 2017/03/30 20:30:13 UTC, 0 replies.
- kafka git commit: MINOR: reduce amount of verbose printing - posted by gu...@apache.org on 2017/03/30 20:47:16 UTC, 0 replies.
- kafka git commit: MINOR: Ensure streaming iterator is closed by Fetcher - posted by ij...@apache.org on 2017/03/30 21:39:32 UTC, 0 replies.
- kafka git commit: MINOR: Vagrant provisioning fixes - posted by jg...@apache.org on 2017/03/30 21:41:40 UTC, 0 replies.
- kafka git commit: KAFKA-4791: unable to add state store with regex matched topics - posted by gu...@apache.org on 2017/03/30 22:44:59 UTC, 1 replies.
- kafka git commit: KAFKA-4689; Disable system tests for consumer hard failures - posted by ij...@apache.org on 2017/03/30 22:52:12 UTC, 1 replies.
- kafka git commit: MINOR: Increase max.poll time for streams consumers - posted by gu...@apache.org on 2017/03/30 22:58:27 UTC, 1 replies.
- kafka git commit: KAFKA-4964; Use correct keystore/trustore name in documentation - posted by ij...@apache.org on 2017/03/31 10:10:56 UTC, 0 replies.