You are viewing a plain text version of this content. The canonical link for it is here.
- kafka git commit: KAFKA-4077: Backdate system test certificates to cope with clock skew - posted by ew...@apache.org on 2016/09/01 17:05:43 UTC, 0 replies.
- kafka git commit: KAFKA-4112: Remove alpha quality label from Kafka Streams in docs - posted by gu...@apache.org on 2016/09/01 19:21:58 UTC, 1 replies.
- kafka git commit: KAFKA-4104: Queryable state metadata is sometimes invalid - posted by gu...@apache.org on 2016/09/02 04:21:46 UTC, 0 replies.
- kafka git commit: KAFKA-4099; Fix the potential frequent log rolling - posted by ju...@apache.org on 2016/09/02 19:49:40 UTC, 0 replies.
- kafka git commit: KAFKA-4105: Queryable state tests - posted by gu...@apache.org on 2016/09/05 04:49:52 UTC, 0 replies.
- kafka git commit: KAFKA-4023: Add thread id and task id for logging prefix in Streams - posted by gu...@apache.org on 2016/09/06 18:38:58 UTC, 0 replies.
- [1/2] kafka git commit: MINOR: changes embedded broker time to MockTime - posted by gu...@apache.org on 2016/09/06 22:35:15 UTC, 0 replies.
- [2/2] kafka git commit: MINOR: changes embedded broker time to MockTime - posted by gu...@apache.org on 2016/09/06 22:35:16 UTC, 0 replies.
- kafka git commit: MINOR: Include TopicPartition in warning when log cleaner resets dirty offset - posted by ij...@apache.org on 2016/09/07 00:16:01 UTC, 0 replies.
- kafka git commit: KAFKA-4129; Processor throw exception when getting channel remote address after closing the channel - posted by ij...@apache.org on 2016/09/07 00:17:35 UTC, 0 replies.
- kafka git commit: MINOR: More graceful handling of buffers that are too small in Record's `isValid` and `ensureValid` - posted by gw...@apache.org on 2016/09/07 00:34:49 UTC, 0 replies.
- kafka-site git commit: Add Jason to committers page - posted by jg...@apache.org on 2016/09/07 00:39:28 UTC, 0 replies.
- kafka git commit: MINOR: Reduce the log level when the peer isn't authenticated but is using SSL - posted by ij...@apache.org on 2016/09/07 02:43:56 UTC, 0 replies.
- kafka git commit: KAFKA-4058: Failure in org.apache.kafka.streams.integration.ResetIntegrationTest.testReprocessingFromScratchAfterReset - posted by gu...@apache.org on 2016/09/07 06:02:43 UTC, 0 replies.
- kafka git commit: KAFKA-3129; Console producer issue when request-required-acks=0 - posted by ij...@apache.org on 2016/09/07 16:08:57 UTC, 0 replies.
- kafka git commit: MINOR: Fixes javadoc of Windows, fixes typo in parameter name of KGroupedTable - posted by gu...@apache.org on 2016/09/07 22:28:04 UTC, 0 replies.
- kafka git commit: MINOR: Document that Connect topics should use compaction - posted by jg...@apache.org on 2016/09/08 00:34:40 UTC, 0 replies.
- kafka git commit: KAFKA-4123: Queryable State returning null for key before all stores in instance have been initialized - posted by gu...@apache.org on 2016/09/08 00:42:39 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-3595: window stores use compact, delete config for changelogs - posted by gu...@apache.org on 2016/09/08 01:02:27 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-3595: window stores use compact, delete config for changelogs - posted by gu...@apache.org on 2016/09/08 01:02:28 UTC, 0 replies.
- kafka git commit: KAFKA-4139; Reset findCoordinatorFuture when brokers are unavailable - posted by jg...@apache.org on 2016/09/08 16:42:32 UTC, 0 replies.
- kafka git commit: MINOR: fix transient QueryableStateIntegration test failure - posted by gu...@apache.org on 2016/09/08 17:53:33 UTC, 0 replies.
- kafka git commit: KAFKA-4033; Revise partition assignment semantics on consumer subscription changes (KIP-70) - posted by jg...@apache.org on 2016/09/09 02:57:02 UTC, 0 replies.
- kafka git commit: HOTFIX: Temporarily ignoring this test until fixed - posted by ij...@apache.org on 2016/09/09 14:22:36 UTC, 0 replies.
- kafka git commit: KAFKA-3807; Fix transient test failure caused by race on future completion - posted by ij...@apache.org on 2016/09/09 21:08:38 UTC, 0 replies.
- kafka git commit: KAFKA-4145; Avoid redundant integration testing in ProducerSendTests - posted by ij...@apache.org on 2016/09/10 07:16:39 UTC, 0 replies.
- kafka git commit: KAFKA-4147; Fix transient failure in ConsumerCoordinatorTest.testAutoCommitDynamicAssignment - posted by ij...@apache.org on 2016/09/11 07:46:27 UTC, 0 replies.
- kafka git commit: KAFKA-1981; Make log compaction point configurable - posted by ju...@apache.org on 2016/09/12 01:45:38 UTC, 0 replies.
- kafka git commit: MINOR: catch InvalidStateStoreException in QueryableStateIntegrationTest - posted by gu...@apache.org on 2016/09/12 04:00:35 UTC, 0 replies.
- kafka git commit: KAFKA-2311; Make KafkaConsumer's ensureNotClosed method thread-safe - posted by jg...@apache.org on 2016/09/13 03:31:00 UTC, 0 replies.
- kafka git commit: KAFKA-4158; Reset quota to default value if quota override is deleted - posted by jj...@apache.org on 2016/09/14 00:34:11 UTC, 0 replies.
- kafka git commit: MINOR: Give a name to the coordinator heartbeat thread - posted by jg...@apache.org on 2016/09/14 16:16:39 UTC, 0 replies.
- kafka git commit: KAFKA-4162: Fixed typo "rebalance" - posted by ew...@apache.org on 2016/09/14 17:38:45 UTC, 1 replies.
- kafka git commit: KAFKA-4172; Ensure fetch responses contain the requested partitions - posted by jg...@apache.org on 2016/09/15 01:05:06 UTC, 0 replies.
- kafka git commit: KAFKA-4160: Ensure rebalance listener not called with coordinator lock - posted by gu...@apache.org on 2016/09/15 05:31:56 UTC, 0 replies.
- kafka git commit: HOTFIX: set sourceNodes to null for selectKey - posted by gu...@apache.org on 2016/09/15 15:42:24 UTC, 0 replies.
- kafka git commit: HOTFIX: fix KafkaStreams SmokeTest - posted by gu...@apache.org on 2016/09/15 15:57:51 UTC, 0 replies.
- kafka git commit: KAFKA-4131; Multiple Regex KStream-Consumers cause Null pointer exception - posted by gu...@apache.org on 2016/09/16 00:08:02 UTC, 0 replies.
- [1/3] kafka git commit: KAFKA-1464; Add a throttling option to the Kafka replication - posted by ju...@apache.org on 2016/09/16 05:28:32 UTC, 0 replies.
- [2/3] kafka git commit: KAFKA-1464; Add a throttling option to the Kafka replication - posted by ju...@apache.org on 2016/09/16 05:28:33 UTC, 0 replies.
- [3/3] kafka git commit: KAFKA-1464; Add a throttling option to the Kafka replication - posted by ju...@apache.org on 2016/09/16 05:28:34 UTC, 0 replies.
- [1/6] kafka git commit: KAFKA-3776: Unify store and downstream caching in streams - posted by gu...@apache.org on 2016/09/16 16:58:43 UTC, 0 replies.
- [2/6] kafka git commit: KAFKA-3776: Unify store and downstream caching in streams - posted by gu...@apache.org on 2016/09/16 16:58:44 UTC, 0 replies.
- [3/6] kafka git commit: KAFKA-3776: Unify store and downstream caching in streams - posted by gu...@apache.org on 2016/09/16 16:58:45 UTC, 0 replies.
- [4/6] kafka git commit: KAFKA-3776: Unify store and downstream caching in streams - posted by gu...@apache.org on 2016/09/16 16:58:46 UTC, 0 replies.
- [5/6] kafka git commit: KAFKA-3776: Unify store and downstream caching in streams - posted by gu...@apache.org on 2016/09/16 16:58:47 UTC, 0 replies.
- [6/6] kafka git commit: KAFKA-3776: Unify store and downstream caching in streams - posted by gu...@apache.org on 2016/09/16 16:58:48 UTC, 0 replies.
- kafka git commit: KAFKA-4183; Corrected Kafka Connect's JSON Converter to properly convert from null to logical values - posted by jg...@apache.org on 2016/09/16 21:58:39 UTC, 0 replies.
- kafka git commit: KAFKA-4173; SchemaProjector should successfully project missing Struct field when target field is optional - posted by jg...@apache.org on 2016/09/16 22:54:40 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-4093; Cluster Id (KIP-78) - posted by ij...@apache.org on 2016/09/17 07:13:07 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-4093; Cluster Id (KIP-78) - posted by ij...@apache.org on 2016/09/17 07:13:08 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-3492; Secure quotas for authenticated users - posted by ju...@apache.org on 2016/09/17 17:06:10 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-3492; Secure quotas for authenticated users - posted by ju...@apache.org on 2016/09/17 17:06:11 UTC, 0 replies.
- kafka git commit: HOTFIX: Increase timeout for bounce test - posted by ij...@apache.org on 2016/09/17 21:43:52 UTC, 0 replies.
- kafka git commit: HOTFIX: changed quickstart donwload from 0.10.0.0 to 0.10.0.1 - posted by ij...@apache.org on 2016/09/17 21:45:34 UTC, 1 replies.
- kafka git commit: KAFKA-4157; Transient system test failure in replica_verification_test.test_replica_lags - posted by ij...@apache.org on 2016/09/17 21:48:00 UTC, 1 replies.
- kafka git commit: MINOR: Update the README.md to include a note about GRADLE_USER_HOME - posted by ij...@apache.org on 2016/09/17 22:01:36 UTC, 0 replies.
- [1/3] kafka git commit: KAFKA-2063; Bound fetch response size (KIP-74) - posted by jg...@apache.org on 2016/09/18 16:16:00 UTC, 0 replies.
- [2/3] kafka git commit: KAFKA-2063; Bound fetch response size (KIP-74) - posted by jg...@apache.org on 2016/09/18 16:16:01 UTC, 0 replies.
- [3/3] kafka git commit: KAFKA-2063; Bound fetch response size (KIP-74) - posted by jg...@apache.org on 2016/09/18 16:16:02 UTC, 0 replies.
- kafka git commit: MINOR: Fix reference to argument in `LogSegment.translateOffset` - posted by ij...@apache.org on 2016/09/18 22:01:58 UTC, 0 replies.
- kafka git commit: HOTFIX: logic in QuerybaleStateIntegrationTest.shouldBeAbleToQueryState incorrect - posted by gu...@apache.org on 2016/09/19 17:29:01 UTC, 0 replies.
- kafka git commit: KAFKA-4175: Can't have StandbyTasks in KafkaStreams where NUM_STREAM_THREADS_CONFIG > 1 - posted by gu...@apache.org on 2016/09/19 17:31:02 UTC, 0 replies.
- kafka git commit: KAFKA-4163: NPE in StreamsMetadataState during re-balance operations - posted by gu...@apache.org on 2016/09/19 18:00:57 UTC, 0 replies.
- kafka git commit: KAFKA-4079; Documentation for secure quotas - posted by ju...@apache.org on 2016/09/19 19:16:49 UTC, 0 replies.
- kafka git commit: MINOR: Allow creation of statestore without logging enabled or explicit source topic - posted by gu...@apache.org on 2016/09/19 19:37:25 UTC, 0 replies.
- kafka git commit: KAFKA-4183; Centralize checking for optional and default values in JsonConverter - posted by jg...@apache.org on 2016/09/19 19:49:57 UTC, 0 replies.
- kafka git commit: MINOR: Add KafkaServerStartable constructor overload for compatibility - posted by jg...@apache.org on 2016/09/19 20:08:23 UTC, 0 replies.
- [1/4] kafka git commit: KAFKA-4183; Corrected Kafka Connect's JSON Converter to properly convert from null to logical values - posted by jg...@apache.org on 2016/09/19 21:08:48 UTC, 0 replies.
- [2/4] kafka git commit: KAFKA-4173; SchemaProjector should successfully project missing Struct field when target field is optional - posted by jg...@apache.org on 2016/09/19 21:08:49 UTC, 0 replies.
- [3/4] kafka git commit: KAFKA-4183; Centralize checking for optional and default values in JsonConverter - posted by jg...@apache.org on 2016/09/19 21:08:50 UTC, 0 replies.
- [4/4] kafka git commit: KAFKA-4100: Ensure 'fields' and 'fieldsByName' are not null for Struct schemas - posted by jg...@apache.org on 2016/09/19 21:08:51 UTC, 0 replies.
- kafka git commit: KAFKA-3283; Remove beta from new consumer documentation - posted by jg...@apache.org on 2016/09/19 21:26:34 UTC, 0 replies.
- kafka git commit: KAFKA-4135; Consumer poll with no subscription or assignment should raise an error - posted by jg...@apache.org on 2016/09/19 23:43:09 UTC, 0 replies.
- kafka git commit: KAFKA-4153: Fix incorrect KStream-KStream join behavior with asymmetric time window - posted by gu...@apache.org on 2016/09/20 00:13:50 UTC, 0 replies.
- [1/2] kafka git commit: KAFKA-4148; Support ListOffsetRequest v1 and search offsets by timestamp in consumer (KIP-79) - posted by jg...@apache.org on 2016/09/20 01:38:55 UTC, 0 replies.
- [2/2] kafka git commit: KAFKA-4148; Support ListOffsetRequest v1 and search offsets by timestamp in consumer (KIP-79) - posted by jg...@apache.org on 2016/09/20 01:38:56 UTC, 0 replies.
- [kafka] Git Push Summary - posted by jg...@apache.org on 2016/09/20 02:47:59 UTC, 0 replies.
- kafka git commit: MINOR: Bump to version 0.10.2 - posted by jg...@apache.org on 2016/09/20 04:22:25 UTC, 0 replies.
- kafka git commit: KAFKA-4193; Fix for intermittent failure in FetcherTest - posted by jg...@apache.org on 2016/09/20 06:17:33 UTC, 1 replies.
- kafka git commit: HOTFIX: Added check for metadata unavailable - posted by ij...@apache.org on 2016/09/20 10:39:00 UTC, 1 replies.
- kafka git commit: KAFKA-4184; Intermittent failures in ReplicationQuotasTest.shouldBootstrapTwoBrokersWithFollowerThrottle - posted by ij...@apache.org on 2016/09/20 14:39:08 UTC, 1 replies.
- kafka git commit: KAFKA-4197; Make ReassignPartitionsTest System Test move data - posted by ij...@apache.org on 2016/09/20 14:41:22 UTC, 1 replies.
- kafka git commit: MINOR: add javadoc comment to PersistenKeyValueFactory.enableCaching - posted by gu...@apache.org on 2016/09/21 18:11:16 UTC, 1 replies.
- kafka git commit: MINOR: remove unused code from InternalTopicManager - posted by gu...@apache.org on 2016/09/21 18:13:43 UTC, 1 replies.
- kafka git commit: KAFKA-3782: Ensure heartbeat thread restarted after rebalance woken up - posted by gu...@apache.org on 2016/09/22 17:07:54 UTC, 1 replies.
- kafka git commit: MINOR: Fix comments in KStreamKStreamJoinTest - posted by gu...@apache.org on 2016/09/22 17:33:26 UTC, 1 replies.
- kafka git commit: HOTFIX: Decrease commit interval - posted by gu...@apache.org on 2016/09/22 19:45:46 UTC, 1 replies.
- kafka git commit: MINOR: Increase `zkConnectionTimeout` and timeout in `testReachableServer` - posted by jg...@apache.org on 2016/09/22 21:53:48 UTC, 1 replies.
- kafka git commit: MINOR: Add test cases for delays in consumer rebalance listener - posted by ij...@apache.org on 2016/09/22 22:03:54 UTC, 0 replies.
- kafka git commit: KAFKA-3590; Handle not-enough-replicas errors when writing to offsets topic - posted by jg...@apache.org on 2016/09/23 20:13:39 UTC, 1 replies.
- kafka git commit: KAFKA-3719; Allow underscores in hostname - posted by ij...@apache.org on 2016/09/23 21:22:17 UTC, 1 replies.
- kafka git commit: KAFKA-4151; Update public docs for Cluster Id (KIP-78) - posted by ij...@apache.org on 2016/09/24 09:23:33 UTC, 1 replies.
- kafka git commit: KAFKA-3282; Change tools to use new consumer if zookeeper is not specified - posted by ij...@apache.org on 2016/09/25 08:14:35 UTC, 1 replies.
- kafka git commit: KAFKA-4055; System tests for secure quotas - posted by ju...@apache.org on 2016/09/26 00:01:49 UTC, 1 replies.
- kafka git commit: MINOR: Wakeups propagated from commitOffsets in WorkerSinkTask should be caught - posted by ew...@apache.org on 2016/09/26 21:54:06 UTC, 1 replies.
- kafka git commit: KAFKA-4214; kafka-reassign-partitions fails all the time when brokers are bounced during reassignment - posted by ju...@apache.org on 2016/09/27 00:18:22 UTC, 1 replies.
- kafka git commit: KAFKA-3831; Prepare for updating new-consumer-based Mirror Maker's default partition assignment strategy to round robin - posted by jg...@apache.org on 2016/09/27 02:07:35 UTC, 1 replies.
- kafka git commit: MINOR: Fix Javadoc of @throws AuthorizationException for KafkaConsumer.poll - posted by jg...@apache.org on 2016/09/27 04:15:34 UTC, 1 replies.
- kafka git commit: KAFKA-4200; Fix throttle argument in kafka-reassign-partitions.sh - posted by ij...@apache.org on 2016/09/27 13:33:55 UTC, 1 replies.
- kafka git commit: KAFKA-4177; Remove ThrottledReplicationRateLimit from Server Config - posted by ij...@apache.org on 2016/09/27 19:40:43 UTC, 1 replies.
- kafka git commit: MINOR: Make new consumer default for Mirror Maker - posted by ij...@apache.org on 2016/09/27 21:08:08 UTC, 1 replies.
- kafka git commit: MINOR: Remove no longer required --new-consumer switch in docs - posted by jg...@apache.org on 2016/09/27 23:49:54 UTC, 1 replies.
- kafka git commit: HOTFIX: fix npe in StreamsMetadataState when onChange has not been called - posted by gu...@apache.org on 2016/09/28 00:35:28 UTC, 1 replies.
- kafka git commit: MINOR: fixes a few error logging formats - posted by gu...@apache.org on 2016/09/28 00:37:15 UTC, 1 replies.
- kafka git commit: MINOR: add test to make sure ProcessorStateManager can handle State Stores with logging disabled - posted by gu...@apache.org on 2016/09/28 00:43:40 UTC, 1 replies.
- kafka git commit: HOTFIX: Remove git conflict markers in streams.html - posted by ij...@apache.org on 2016/09/28 01:32:03 UTC, 0 replies.
- kafka git commit: KAFKA-3708: Better exception handling in Kafka Streams - posted by gu...@apache.org on 2016/09/28 18:07:48 UTC, 1 replies.
- kafka git commit: KAFKA-4227; Shutdown AdminManager when KafkaServer is shutdown - posted by ij...@apache.org on 2016/09/28 19:54:58 UTC, 1 replies.
- kafka git commit: MINOR: Improve introduction section in docs to better cover connect and streams. Make uses and ecosystem pages stand alone. - posted by jk...@apache.org on 2016/09/28 23:33:46 UTC, 0 replies.
- kafka git commit: KAFKA-4209; Reduce run time for quota integration tests - posted by ij...@apache.org on 2016/09/29 00:18:46 UTC, 0 replies.
- [1/2] kafka-site git commit: Try to include streams and connect better. Removing messaging centric terminology. Rewrite introduction page. Make a linked doc sections stand alone. - posted by gw...@apache.org on 2016/09/29 00:33:37 UTC, 0 replies.
- [2/2] kafka-site git commit: Try to include streams and connect better. Removing messaging centric terminology. Rewrite introduction page. Make a linked doc sections stand alone. - posted by gw...@apache.org on 2016/09/29 00:33:38 UTC, 0 replies.
- kafka git commit: KAFKA-4194; Follow-up improvements/testing for ListOffsets v1 (KIP-79) - posted by jg...@apache.org on 2016/09/29 01:01:02 UTC, 1 replies.
- kafka-site git commit: Fix typo. - posted by jk...@apache.org on 2016/09/29 01:26:28 UTC, 0 replies.
- kafka git commit: MINOR: Set JVM parameters for the Gradle Test executor processes - posted by jg...@apache.org on 2016/09/29 02:15:12 UTC, 2 replies.
- kafka git commit: HOTFIX: Tools for releases prior to 0.10.1 need --new-consumer flag - posted by ij...@apache.org on 2016/09/29 06:49:36 UTC, 1 replies.
- kafka git commit: KAFKA-4216; Control Leader & Follower Throttled Replicas Separately - posted by ij...@apache.org on 2016/09/29 07:57:33 UTC, 1 replies.
- kafka-site git commit: Fix another typo on the homepage. - posted by jk...@apache.org on 2016/09/29 16:40:56 UTC, 0 replies.
- kafka git commit: MINOR: Allow for asynchronous start of producer consumer in validation test - posted by jg...@apache.org on 2016/09/29 20:52:58 UTC, 1 replies.
- kafka git commit: KAFKA-3965; MirrorMaker should not commit offset when exception is thrown from producer.send - posted by jg...@apache.org on 2016/09/29 23:39:19 UTC, 1 replies.
- kafka git commit: KAFKA-3697; Clean up website documentation of client usage - posted by jg...@apache.org on 2016/09/30 02:37:27 UTC, 1 replies.
- kafka git commit: KAFKA-4223; RocksDBStore should close all open iterators on close - posted by ij...@apache.org on 2016/09/30 08:41:43 UTC, 1 replies.
- kafka git commit: KAFKA-4225; Replication Quotas: Control Leader & Follower Limit Separately - posted by ij...@apache.org on 2016/09/30 10:23:17 UTC, 1 replies.
- kafka git commit: HOTFIX: turn off auto topic creation in embedded kafka cluster - posted by ij...@apache.org on 2016/09/30 11:42:45 UTC, 1 replies.
- kafka git commit: HOTFIX: do not call partitioner if num partitions is non-positive - posted by gu...@apache.org on 2016/09/30 16:36:50 UTC, 1 replies.
- kafka git commit: KAFKA-4235; Fix race condition in Sender.initiateClose that may cause missed callbacks - posted by jg...@apache.org on 2016/09/30 18:50:43 UTC, 1 replies.
- kafka git commit: KAFKA-4233: StateDirectory fails to create directory if any parent directory does not exist - posted by gu...@apache.org on 2016/09/30 18:55:36 UTC, 1 replies.
- kafka git commit: KAFKA-4213; System tests for replication throttling (KIP-73) - posted by ij...@apache.org on 2016/09/30 18:59:03 UTC, 1 replies.
- kafka git commit: KAFKA-4058; improved test condition evaluation - posted by ij...@apache.org on 2016/09/30 19:34:22 UTC, 1 replies.
- kafka git commit: KAFKA-3930; Ensure ipv6 addresses are quoted properly in metrics tags - posted by jg...@apache.org on 2016/09/30 19:40:01 UTC, 1 replies.
- kafka git commit: KAFKA-4234; Revert automatic offset commit behavior in consumer's `unsubscribe()` - posted by jg...@apache.org on 2016/09/30 20:28:48 UTC, 1 replies.