Changelog for
kafka-zookeeper-1.0.1-18.1.x86_64.rpm :
Mon Jan 7 13:00:00 2019 ilausuchAATTsuse.com
- Upgrade kafka version to 1.0.1
- Removed patch rotate-gc-log.patch because is already fixed in the current version
* New features:
* [KAFKA-3487] - KIP-146: Support per-connector/per-task classloaders in Connect
* [KAFKA-4208] - Add Record Headers
* [KAFKA-4586] - Add purgeDataBefore() API in AdminClient
* [KAFKA-4720] - Add KStream.peek(ForeachAction)
* [KAFKA-4743] - Add a tool to Reset Consumer Group Offsets
* [KAFKA-4881] - Add internal leave.group.on.close config to consumer
* [KAFKA-4923] - Add Exactly-Once Semantics to Streams
* [KAFKA-5059] - Implement Transactional Coordinator
* [KAFKA-5192] - Range Scan for Windowed State Stores
* Improvements:
* [KAFKA-5987] - Kafka metrics templates used in document generation should maintain order of tags
* [KAFKA-6102] - Consolidate MockTime implementations between connect and clients
* [KAFKA-6157] - Fix repeated words words in JavaDoc and comments.
* [KAFKA-6172] - Cache lastEntry in TimeIndex to avoid unnecessary disk access
* [KAFKA-6175] - AbstractIndex should cache index file to avoid unnecessary disk access during resize()
* [KAFKA-6205] - Have State Stores Restore Before Initializing Toplogy
* [KAFKA-6258] - SSLTransportLayer should keep reading from socket until either the buffer is full or the socket has no more data
* [KAFKA-6274] - Improve KTable Source state store auto-generated names
* [KAFKA-6205] - Have State Stores Restore Before Initializing Toplogy
* [KAFKA-6634] - Delay initiating the txn on producers until initializeTopology with EOS turned on
* [KAFKA-7009] - Mute logger for reflections.org at the warn level in system tests
* [KAFKA-5242] - add max_number _of_retries to exponential backoff strategy
* [KAFKA-5410] - Fix taskClass() method name in Connector and flush() signature in SinkTask
* [KAFKA-5485] - Streams should not suspend tasks twice
* [KAFKA-1449] - Extend wire protocol to allow CRC32C
* [KAFKA-2358] - Cluster collection returning methods should never return null
* [KAFKA-2955] - Add Prompt to kafka-console-producer
* [KAFKA-3714] - Allow users greater access to register custom streams metrics
* [KAFKA-3878] - Exponential backoff for broker reconnect attempts (KIP-144)
* [KAFKA-3989] - Add JMH module for Benchmarks
* [KAFKA-3995] - Split the ProducerBatch and resend when received RecordTooLargeException
* [KAFKA-4144] - Allow per stream/table timestamp extractor
* [KAFKA-4195] - support throttling on request rate
* [KAFKA-4266] - Replication Quota Tests: Ensure ZK updated before tests start
* [KAFKA-4276] - REST configuration not visible in connector properties config files
* [KAFKA-4291] - TopicCommand --describe shows topics marked for deletion as under-replicated and unavailable (KIP-137)
* [KAFKA-4317] - RocksDB checkpoint files lost on kill -9
* [KAFKA-4613] - Treat null-key records the same way for joins and aggreations
* [KAFKA-4636] - Per listener security setting overrides (KIP-103)
* [KAFKA-4684] - Kafka does not offer kafka-configs.bat on Windows box
* [KAFKA-4702] - Parametrize streams benchmarks to run at scale
* [KAFKA-4709] - Error message from Struct.validate() should include the name of the offending field.
* [KAFKA-4722] - Add application.id to StreamThread name
* [KAFKA-4733] - Improve Streams Reset Tool console output
* [KAFKA-4769] - Add Float serializer, deserializer, serde
* [KAFKA-4772] - Exploit #peek to implement #print() and other methods
* [KAFKA-4773] - The Kafka build should run findbugs
* [KAFKA-4774] - Inner classes which don\'t need a reference to the outer class should be static
* [KAFKA-4775] - Fix findbugs warnings in kafka-tools
* [KAFKA-4839] - throw NoOffsetForPartitionException once for all assigned partitions from poll
* [KAFKA-4843] - Stream round-robin scheduler is inneficient
* [KAFKA-4922] - Fix several FindBugs warnings in Clients and Connect
* [KAFKA-4943] - SCRAM secret\'s should be better protected with Zookeeper ACLs
* [KAFKA-4965] - set internal.leave.group.on.close to false in KafkaStreams
* [KAFKA-4982] - Add listener tag to socket-server-metrics.connection-... metrics (KIP-136)
* [KAFKA-5036] - Followups from KIP-101
* [KAFKA-5052] - We shouldn\'t pass the underlying exception to RetriableCommitFailedException when an async offset commit fails.
* [KAFKA-5068] - Optionally print out metrics after running the perf tests
* [KAFKA-5091] - ReassignPartitionsCommand should protect against empty replica list assignment
* [KAFKA-5094] - Censor SCRAM config change logging
* [KAFKA-5104] - DumpLogSegments should not open index files with `rw`
* [KAFKA-5108] - Add support for reading PID snapshot files to DumpLogSegments
* [KAFKA-5111] - Improve internal Task APIs
* [KAFKA-5112] - Trunk compatibility tests should test against 0.10.2
* [KAFKA-5118] - Improve message for Kafka failed startup with non-Kafka data in data.dirs
* [KAFKA-5137] - Controlled shutdown timeout message improvement
* [KAFKA-5161] - reassign-partitions to check if broker of ID exists in cluster
* [KAFKA-5166] - Add option \"dry run\" to Streams application reset tool
* [KAFKA-5176] - AdminClient: add controller and clusterId methods to DescribeClusterResults
* [KAFKA-5194] - KIP-153: Include only client traffic in BytesOutPerSec metric
* [KAFKA-5210] - Application Reset Tool does not need to seek for internal topics
* [KAFKA-5218] - New Short serializer, deserializer, serde
* [KAFKA-5257] - Change Default unclean.leader.election.enabled from True to False
* [KAFKA-5277] - Sticky Assignor should not cache the calculated assignment (KIP-54 follow-up)
* [KAFKA-5311] - Support ExtendedDeserializer in Kafka Streams
* [KAFKA-5333] - Remove Broker ACL resource type
* [KAFKA-5405] - Request log should log throttle time
* [KAFKA-5411] - Generate javadoc for AdminClient and show configs in documentation
* [KAFKA-5446] - Annoying braces showed on log.error using streams
* Bugs
* [KAFKA-4263] - QueryableStateIntegrationTest.concurrentAccess is failing occasionally in jenkins builds
* [KAFKA-4767] - KafkaProducer is not joining its IO thread properly
* [KAFKA-4827] - Kafka connect: error with special characters in connector name
* [KAFKA-6069] - Streams metrics tagged incorrectly
* [KAFKA-6148] - ClassCastException in BigQuery connector
* [KAFKA-6164] - ClientQuotaManager threads prevent shutdown when encountering an error loading logs
* [KAFKA-6166] - Streams configuration requires consumer. and producer. in order to be read
* [KAFKA-6167] - Timestamp on streams directory contains a colon, which is an illegal character
* [KAFKA-6174] - Add methods in Options classes to keep binary compatibility with 0.11
* [KAFKA-6179] - RecordQueue.clear() does not clear MinTimestampTracker\'s maintained list
* [KAFKA-6185] - Selector memory leak with high likelihood of OOM in case of down conversion
* [KAFKA-6190] - GlobalKTable never finishes restoring when consuming transactional messages
* [KAFKA-6210] - IllegalArgumentException if 1.0.0 is used for inter.broker.protocol.version or log.message.format.version
* [KAFKA-6214] - Using standby replicas with an in memory state store causes Streams to crash
* [KAFKA-6238] - Issues with protocol version when applying a rolling upgrade to 1.0.0
* [KAFKA-6252] - A metric named \'XX\' already exists, can\'t register another one.
* [KAFKA-6256] - Flaky Unit test: KStreamKTableJoinIntegrationTest.shouldCountClicksPerRegionWithNonZeroByteCache
* [KAFKA-6260] - AbstractCoordinator not clearly handles NULL Exception
* [KAFKA-6261] - Request logging throws exception if acks=0
* [KAFKA-6269] - KTable state restore fails after rebalance
* [KAFKA-6277] - Make loadClass thread-safe for class loaders of Connect plugins
* [KAFKA-6287] - Inconsistent protocol type for empty consumer groups
* [KAFKA-6288] - Broken symlink interrupts scanning the plugin path
* [KAFKA-6289] - NetworkClient should not return internal failed api version responses from poll
* [KAFKA-6302] - Topic can not be recreated after it is deleted
* [KAFKA-6307] - mBeanName should be removed before returning from JmxReporter#removeAttribute()
* [KAFKA-6308] - Connect: Struct equals/hashCode method should use Arrays#deep
* methods
* [KAFKA-6319] - kafka-acls regression for comma characters (and maybe other characters as well)
* [KAFKA-6323] - punctuate with WALL_CLOCK_TIME triggered immediately
* [KAFKA-6354] - Update KStream JavaDoc with regard to KIP-182
* [KAFKA-6366] - StackOverflowError in kafka-coordinator-heartbeat-thread
* [KAFKA-6367] - Fix StateRestoreListener To Use Correct Batch Ending Offset
* [KAFKA-6378] - NullPointerException on KStream-GlobalKTable leftJoin when KeyValueMapper returns null
* [KAFKA-6398] - Non-aggregation KTable generation operator does not construct value getter correctly
* [KAFKA-6422] - When enable trace level log in mirror maker, it will throw null pointer exception and the mirror maker will shutdown
* [KAFKA-6467] - Enforce layout of dependencies within a Connect plugin to be deterministic
* [KAFKA-6504] - Connect: Some per-task-metrics not working
* [KAFKA-6529] - Broker leaks memory and file descriptors after sudden client disconnects
* [KAFKA-4767] - KafkaProducer is not joining its IO thread properly
* [KAFKA-4827] - Kafka connect: error with special characters in connector name
* [KAFKA-6054] - ERROR \"SubscriptionInfo - unable to decode subscription data: version=2\" when upgrading from 0.10.0.0 to 0.10.2.1
* [KAFKA-6148] - ClassCastException in BigQuery connector
* [KAFKA-6277] - Make loadClass thread-safe for class loaders of Connect plugins
* [KAFKA-6288] - Broken symlink interrupts scanning the plugin path
* [KAFKA-6307] - mBeanName should be removed before returning from JmxReporter#removeAttribute()
* [KAFKA-6360] - RocksDB segments not removed when store is closed causes re-initialization to fail
* [KAFKA-6467] - Enforce layout of dependencies within a Connect plugin to be deterministic
* [KAFKA-6529] - Broker leaks memory and file descriptors after sudden client disconnects
* [KAFKA-6536] - Streams quickstart pom.xml is missing versions for a bunch of plugins
* [KAFKA-6566] - SourceTask#stop() not called after exception raised in poll()
* [KAFKA-6568] - LogCleanerManager.doneDeleting() should check the partition state before deleting the in progress partition
* [KAFKA-6661] - Sink connectors that explicitly \'resume\' topic partitions can resume a paused task
* [KAFKA-6711] - GlobalStateManagerImpl should not write offsets of in-memory stores in checkpoint file
* [KAFKA-6747] - kafka-streams Invalid transition attempted from state READY to state ABORTING_TRANSACTION
* [KAFKA-6782] - GlobalKTable GlobalStateStore never finishes restoring when consuming aborted messages
* [KAFKA-6857] - LeaderEpochFileCache.endOffsetFor() should check for UNDEFINED_EPOCH explicitly
* [KAFKA-6906] - Kafka Streams does not commit transactions if data is produced via wall-clock punctuation
* [KAFKA-6925] - Memory leak in org.apache.kafka.streams.processor.internals.StreamThread$StreamsMetricsThreadImpl
* [KAFKA-7021] - Source KTable checkpoint is not correct
* [KAFKA-7058] - ConnectSchema#equals() broken for array-typed default values
* [KAFKA-5140] - Flaky ResetIntegrationTest
* [KAFKA-5967] - Ineffective check of negative value in CompositeReadOnlyKeyValueStore#approximateNumEntries()
* [KAFKA-5970] - Deadlock due to locking of DelayedProduce and group
* [KAFKA-5986] - Streams State Restoration never completes when logging is disabled
* [KAFKA-6003] - Replication Fetcher thread for a partition with no data fails to start
* [KAFKA-6026] - KafkaFuture timeout fails to fire if a narrow race condition is hit
* [KAFKA-6030] - Integer overflow in log cleaner cleanable ratio computation
* [KAFKA-6042] - Kafka Request Handler deadlocks and brings down the cluster.
* [KAFKA-6087] - Scanning plugin.path needs to support relative symlinks
* [KAFKA-6116] - Major performance issue due to excessive logging during leader election
* [KAFKA-6119] - Silent Data Loss in Kafka011 Transactional Producer
* [KAFKA-6131] - Transaction markers are sometimes discarded if txns complete concurrently
* [KAFKA-6134] - High memory usage on controller during partition reassignment
* [KAFKA-6179] - RecordQueue.clear() does not clear MinTimestampTracker\'s maintained list
* [KAFKA-6190] - GlobalKTable never finishes restoring when consuming transactional messages
* [KAFKA-2105] - NullPointerException in client on MetadataRequest
* [KAFKA-4669] - KafkaProducer.flush hangs when NetworkClient.handleCompletedReceives throws exception
* [KAFKA-4856] - Calling KafkaProducer.close() from multiple threads may cause spurious error
* [KAFKA-5152] - Kafka Streams keeps restoring state after shutdown is initiated during startup
* [KAFKA-5167] - streams task gets stuck after re-balance due to LockException
* [KAFKA-5417] - Clients get inconsistent connection states when SASL/SSL connection is marked CONECTED and DISCONNECTED at the same time
* [KAFKA-5431] - LogCleaner stopped due to org.apache.kafka.common.errors.CorruptRecordException
* [KAFKA-5464] - StreamsKafkaClient should not use StreamsConfig.POLL_MS_CONFIG
* [KAFKA-5484] - Refactor kafkatest docker support
* [KAFKA-5506] - bin/kafka-consumer-groups.sh failing to query offsets
* [KAFKA-5508] - Documentation for altering topics
* [KAFKA-5512] - KafkaConsumer: High memory allocation rate when idle
* [KAFKA-5544] - The LastStableOffsetLag metric should be removed when partition is deleted
* [KAFKA-5556] - KafkaConsumer.commitSync throws IllegalStateException: Attempt to retrieve exception from future which hasn\'t failed
* [KAFKA-5567] - With transformations that mutate the topic-partition committing offsets should to refer to the original topic-partition
* [KAFKA-5584] - Incorrect log size for topics larger than 2 GB
* [KAFKA-5587] - Processor got uncaught exception: NullPointerException
* [KAFKA-5600] - Group loading regression causing stale metadata/offsets cache
* [KAFKA-5603] - Streams should not abort transaction when closing zombie task
* [KAFKA-5608] - System test failure due to timeout starting Jmx tool
* [KAFKA-5610] - KafkaApis.handleWriteTxnMarkerRequest can return UNSUPPORTED_FOR_MESSAGE_FORMAT error on partition emigration
* [KAFKA-5611] - One or more consumers in a consumer-group stop consuming after rebalancing
* [KAFKA-5623] - ducktape kafka service: do not assume Service contains num_nodes
* [KAFKA-5630] - Consumer poll loop over the same record after a CorruptRecordException
* [KAFKA-5634] - Replica fetcher thread crashes due to OffsetOutOfRangeException
* [KAFKA-5643] - Using _DUCKTAPE_OPTIONS has no effect on executing tests
* [KAFKA-5644] - Transient test failure: ResetConsumerGroupOffsetTest.testResetOffsetsToZonedDateTime
* [KAFKA-5658] - Fix AdminClient request timeout handling bug resulting in continual BrokerNotAvailableExceptions
* [KAFKA-5659] - Fix error handling, efficiency issue in AdminClient#describeConfigs
* [KAFKA-5700] - producer missed header information when splitting batches
* [KAFKA-5704] - Auto topic creation causes failure with older clusters
* [KAFKA-5717] -
* [streams] \'null\' values in state stores
* [KAFKA-5731] - Connect WorkerSinkTask out of order offset commit can lead to inconsistent state
* [KAFKA-5737] - KafkaAdminClient thread should be daemon
* [KAFKA-5745] - Partition.makeLeader() should convert HW to OffsetMetadata before becoming the leader
* [KAFKA-5747] - Broker crashes on startup when trying to parse empty snapshot files
* [KAFKA-5752] - Delete topic and re-create topic immediate will delete the new topic\'s timeindex
* [KAFKA-5771] - org.apache.kafka.streams.state.internals.Segments#segments method returns incorrect results when segments were added out of order
* [KAFKA-5787] - StoreChangeLogReader needs to restore partitions that were added post initialization
* [KAFKA-5818] - KafkaStreams state transitions not correct
* [KAFKA-977] - Implement generation/term per leader to reconcile messages correctly
* [KAFKA-1211] - Hold the produce request with ack > 1 in purgatory until replicas\' HW has larger than the produce offset (KIP-101)
* [KAFKA-2000] - Delete consumer offsets from kafka once the topic is deleted
* [KAFKA-2818] - Clean up Controller Object on forced Resignation
* [KAFKA-2857] - ConsumerGroupCommand throws GroupCoordinatorNotAvailableException when describing a non-existent group before the offset topic is created
* [KAFKA-3070] - SASL unit tests dont work with IBM JDK
* [KAFKA-3123] - Follower Broker cannot start if offsets are already out of range
* [KAFKA-3353] - Remove deprecated producer configs.
* [KAFKA-3754] - Kafka default -Xloggc settings should include GC log rotation flags
* [KAFKA-3835] - Streams is creating two ProducerRecords for each send via RecordCollector
* [KAFKA-3919] - Broker faills to start after ungraceful shutdown due to non-monotonically incrementing offsets in logs
* [KAFKA-3940] - Log should check the return value of dir.mkdirs()
* [KAFKA-3959] - KIP-115: __consumer_offsets wrong number of replicas at startup
* [KAFKA-3982] - Issue with processing order of consumer properties in console consumer
* [KAFKA-4039] - Exit Strategy: using exceptions instead of inline invocation of exit/halt
* [KAFKA-4059] - Documentation still refers to AsyncProducer and SyncProducer
* [KAFKA-4343] - KIP-151: Connect REST API should expose whether each connector is a source or sink
* [KAFKA-4408] - KTable doesn\'t work with ProcessorTopologyTestDriver in Kafka 0.10.1.0
* [KAFKA-4459] - rat license check not running in Jenkins
* [KAFKA-4461] - When using ProcessorTopologyTestDriver, the combination of map and .groupByKey does not produce any result
* [KAFKA-4484] - Set more conservative default values on RocksDB for memory usage
* [KAFKA-4494] - Significant startup delays in KStreams app
* [KAFKA-4525] - Kafka should not require SSL trust store password
* [KAFKA-4564] - When the destination brokers are down or misconfigured in config, Streams should fail fast
* [KAFKA-4567] - Connect Producer and Consumer ignore ssl parameters configured for worker
* [KAFKA-4594] - Annotate integration tests and provide gradle build targets to run subsets of tests
* [KAFKA-4595] - Controller send thread can\'t stop when broker change listener event trigger for dead brokers
* [KAFKA-4603] - the argument of shell in doc wrong and command parsed error
* [KAFKA-4607] - Kafka Streams allows you to provide strings with illegal characters for internal topic names
* [KAFKA-4617] - gradle-generated core eclipse project has incorrect source folder structure
* [KAFKA-4631] - Refresh consumer metadata more frequently for unknown subscribed topics
* [KAFKA-4667] - KIP-154: Connect should create internal topics
* [KAFKA-4671] - Fix Streams window retention policy
* [KAFKA-4672] - KIP-100 api changes break Java 8 lambda expressions in some cases
* [KAFKA-4673] - Python VerifiableConsumer service has thread-safety bug for event_handlers
* [KAFKA-4677] - Avoid unnecessary task movement across threads during rebalance
* [KAFKA-4689] - OffsetValidationTest fails validation with \"Current position greater than the total number of consumed records\"
* [KAFKA-4700] - StreamsKafkaClient drops security configs
* [KAFKA-4708] - Fix Transient failure in BrokerApiVersionsCommandTest.checkBrokerApiVersionCommandOutput
* [KAFKA-4714] - Implement remaining KIP-66 SMTs
* [KAFKA-4716] - Fix logic for re-checking if internal topic is ready
* [KAFKA-4717] - connect jars are missing LICENSE/NOTICE files
* [KAFKA-4719] - Timed out waiting for consumption in OffsetValidationTest.test_broker_failure
* [KAFKA-4724] - Clean up of state directories can possibly remove stores that are about to be used by another thread
* [KAFKA-4728] - KafkaConsumer#commitSync should clone its input
* [KAFKA-4735] - Fix deadlock issue during MM shutdown
* [KAFKA-4738] - Remove generic type of class ClientState
* [KAFKA-4741] - Memory leak in RecordAccumulator.append
* [KAFKA-4744] - Streams_bounce test failing occassionally
* [KAFKA-4749] - fix join-time-max and sync-time-max MeasurableStat type
* [KAFKA-4752] - Streams Simple Benchmark MB/sec calculation is not correct for Join operations
* [KAFKA-4755] - SimpleBenchmark test fails for streams
* [KAFKA-4757] - Improve NetworkClient trace logging of request details
* [KAFKA-4758] - Connect WorkerSinkTask is missing checks for NO_TIMESTAMP
* [KAFKA-4765] - org.apache.kafka.clients.producer.KafkaProducerTest#testConstructorFailureCloseResource and Similar Tests are Failing on some Systems (127.0.53.53 Collision Warning)
* [KAFKA-4776] - Implement graceful handling for improperly formed compressed message sets
* [KAFKA-4777] - Kafka client Heartbeat thread use all the cpu.
* [KAFKA-4779] - Failure in kafka/tests/kafkatest/tests/core/security_rolling_upgrade_test.py
* [KAFKA-4783] - KIP-128: Blackbox or pass through converter or ByteArrayConverter for connect
* [KAFKA-4788] - Broker level configuration \'log.segment.bytes\' not used when \'segment.bytes\' not configured per topic.
* [KAFKA-4789] - ProcessorTopologyTestDriver does not forward extracted timestamps to internal topics
* [KAFKA-4790] - Kafka cannot recover after a disk full
* [KAFKA-4791] - Kafka Streams - unable to add state stores when using wildcard topics on the source
* [KAFKA-4796] - Fix some findbugs warnings in Kafka Java client
* [KAFKA-4800] - Streams State transition ASCII diagrams need fixing and polishing
* [KAFKA-4806] - KafkaConsumer: ConsumerConfig gets logged twice.
* [KAFKA-4809] - docker/run_tests.sh should set up /opt/kafka-dev to be the source directory
* [KAFKA-4810] - SchemaBuilder should be more lax about checking that fields are unset if they are being set to the same value
* [KAFKA-4811] - ReplicaFetchThread may fail to create due to existing metric
* [KAFKA-4814] - ZookeeperLeaderElector not respecting zookeeper.set.acl
* [KAFKA-4826] - Fix some findbugs warnings in Kafka Streams
* [KAFKA-4828] - ProcessorTopologyTestDriver does not work when using .through()
* [KAFKA-4837] - Config validation in Connector plugins need to compare against both canonical and simple class names
* [KAFKA-4841] - NetworkClient should only consider a connection to be fail after attempt to connect
* [KAFKA-4848] - Stream thread getting into deadlock state while trying to get rocksdb lock in retryWithBackoff
* [KAFKA-4851] - SessionStore.fetch(key) is a performance bottleneck
* [KAFKA-4855] - Struct SchemaBuilder should not allow duplicate fields.
* [KAFKA-4863] - Querying window store may return unwanted keys
* [KAFKA-4864] - Kafka Secure Migrator tool doesn\'t secure all the nodes
* [KAFKA-4866] - Kafka console consumer property is ignored
* [KAFKA-4878] - Kafka Connect does not log connector configuration errors
* [KAFKA-4885] - processstreamwithcachedstatestore and other streams benchmarks fail occasionally
* [KAFKA-4891] - kafka.request.logger TRACE regression
* [KAFKA-4894] - Fix findbugs \"default character set in use\" warnings
* [KAFKA-4895] - Fix findbugs \"format string should use %n rather than \
\" in tools
* [KAFKA-4899] - Fix findbugs warnings in kafka-core
* [KAFKA-4901] - Make ProduceRequest thread-safe
* [KAFKA-4902] - Utils#delete should correctly handle I/O errors and symlinks
* [KAFKA-4903] - Remove unused code for reading Shell command stdout and add unit test
* [KAFKA-4916] - Add streams tests with brokers failing
* [KAFKA-4919] - Document that stores must not be closed when Processors are closed
* [KAFKA-4924] - Fix findbugs warnings in Kafka-Connect-API
* [KAFKA-4925] - Add a configurable delay to the initial consumer group rebalance
* [KAFKA-4927] - KStreamsTestDriver fails with NPE when KStream.to() sinks are used
* [KAFKA-4929] - Transformation Key/Value type references should be to class name(), not canonicalName()
* [KAFKA-4937] - Batch resetting offsets in Streams\' StoreChangelogReader
* [KAFKA-4942] - Kafka Connect: Offset committing times out before expected
* [KAFKA-4944] - Fix an \"unread field\" findbugs warning in streams examples
* [KAFKA-4945] - Suppress findbugs warnings about machine-generated code in jmh-benchmarks
* [KAFKA-4959] - remove controller concurrent access to non-threadsafe NetworkClient, Selector, and SSLEngine
* [KAFKA-4964] - Delete the kafka to prefix the name of the keystore and truststore file will be more suitable
* [KAFKA-4977] - kafka-connect: fix findbugs issues in connect/runtime
* [KAFKA-4980] - testReprocessingFromScratch unit test failure
* [KAFKA-4993] - Fix findbugs warnings in kafka-clients
* [KAFKA-4995] - Fix remaining findbugs warnings in Kafka Streams
* [KAFKA-5003] - StreamThread should catch InvalidTopicException
* [KAFKA-5005] - JoinIntegrationTest fails occasionally
* [KAFKA-5013] - Fail the build when findbugs fails
* [KAFKA-5014] - SSL Channel not ready but tcp is established and the server is hung will not sending metadata
* [KAFKA-5038] - running multiple kafka streams instances causes one or more instance to get into file contention
* [KAFKA-5040] - Increase number of Streams producer retries from the default of 0
* [KAFKA-5042] - InFlightRequests#isEmpty() always returns false
* [KAFKA-5043] - Add FindCoordinatorRequest RPC stub and update InitPidRequest for KIP-98
* [KAFKA-5047] - NullPointerException while using GlobalKTable in KafkaStreams
* [KAFKA-5049] - Chroot check should be done for each ZkUtils instance
* [KAFKA-5051] - Avoid DNS reverse lookup in security-critical TLS code path
* [KAFKA-5055] - Kafka Streams skipped-records-rate sensor producing nonzero values even when FailOnInvalidTimestamp is used as extractor
* [KAFKA-5073] - Kafka Streams stuck rebalancing after exception thrown in rebalance listener
* [KAFKA-5075] - Defer exception to the next pollOnce() if consumer\'s fetch position has already increased
* [KAFKA-5078] - PartitionRecords.fetchRecords(...) should defer exception to the next call if iterator has already moved across any valid record
* [KAFKA-5081] - two versions of jackson-annotations-xxx.jar in distribution tgz
* [KAFKA-5086] - Update topic expiry time in Metadata every time the topic metadata is requested
* [KAFKA-5088] - some spelling error in code comment
* [KAFKA-5090] - Kafka Streams SessionStore.findSessions javadoc broken
* [KAFKA-5095] - ThreadCacheTest.cacheOverheadsSmallValues fails intermittently
* [KAFKA-5099] - Replica Deletion Regression from KIP-101
* [KAFKA-5100] - ProducerPerformanceService failing due to parsing error
* [KAFKA-5101] - Remove KafkaController\'s incrementControllerEpoch method parameter
* [KAFKA-5119] - Transient test failure SocketServerTest.testMetricCollectionAfterShutdown
* [KAFKA-5135] - Controller Health Metrics (KIP-143)
* [KAFKA-5140] - Flaky ResetIntegrationTest
* [KAFKA-5143] - Windows platform does not offer kafka-broker-api-versions.bat
* [KAFKA-5144] - MinTimestampTracker uses confusing variable names
* [KAFKA-5150] - LZ4 decompression is 4-5x slower than Snappy on small batches / messages
* [KAFKA-5164] - SetSchemaMetadata does not replace the schemas in structs correctly
* [KAFKA-5167] - streams task gets stuck after re-balance due to LockException
* [KAFKA-5169] - KafkaConsumer.close should be idempotent
* [KAFKA-5170] - KafkaAdminClientIntegration test should wait until metadata is propagated to all brokers
* [KAFKA-5172] - CachingSessionStore doesn\'t fetchPrevious correctly.
* [KAFKA-5173] - SASL tests failing with Could not find a \'KafkaServer\' or \'sasl_plaintext.KafkaServer\' entry in the JAAS configuration
* [KAFKA-5174] - RocksDb might stall in environments with 1 core only
* [KAFKA-5198] - RocksDbStore#openIterators should be synchronized, since it is accessed from multiple threads
* [KAFKA-5203] - Percentilles are calculated incorrectly
* [KAFKA-5205] - CachingSessionStore doesn\'t use the default keySerde.
* [KAFKA-5206] - RocksDBSessionStore doesn\'t use default aggSerde.
* [KAFKA-5211] - KafkaConsumer should not skip a corrupted record after throwing an exception.
* [KAFKA-5213] - IllegalStateException in ensureOpenForRecordAppend
* [KAFKA-5215] - Small JavaDoc fix for AdminClient#describeTopics
* [KAFKA-5216] - Cached Session/Window store may return error on iterator.peekNextKey()
* [KAFKA-5226] - NullPointerException (NPE) in SourceNodeRecordDeserializer.deserialize
* [KAFKA-5229] - Reflections logs excessive warnings when scanning classpaths
* [KAFKA-5230] - Recommended values for Connect transformations contain the wrong class name
* [KAFKA-5232] - Kafka broker fails to start if a topic containing dot in its name is marked for delete but hasn\'t been deleted during previous uptime
* [KAFKA-5236] - Regression in on-disk log size when using Snappy compression with 0.8.2 log message format
* [KAFKA-5241] - GlobalKTable does not checkpoint offsets after restoring state
* [KAFKA-5244] - Tests which delete singleton metrics break subsequent metrics tests
* [KAFKA-5250] - handleFetchRequest should do down conversion after throttling
* [KAFKA-5263] - kakfa-clients consume 100% CPU with manual partition assignment when network connection is lost
* [KAFKA-5265] - Move ACLs, Config, NodeVersions classes into org.apache.kafka.common
* [KAFKA-5266] - Follow-up improvements for consumer offset reset tool (KIP-122)
* [KAFKA-5278] - kafka-console-consumer: `--value-deserializer` is not working but `--property value.deserializer` does
* [KAFKA-5289] - One StopReplicaRequest will caused two Responses
* [KAFKA-5293] - Do not apply exponential backoff if users have overridden reconnect.backoff.ms
* [KAFKA-5294] - PlainSaslServerFactory should allow a null Map in getMechanismNames
* [KAFKA-5303] - FetchRequest doesn\'t implement toString
* [KAFKA-5305] - Missing logging information in ReplicaFetcher
* [KAFKA-5309] - Stores not queryable after one thread died
* [KAFKA-5316] - Log cleaning can increase message size and cause cleaner to crash with buffer overflow
* [KAFKA-5321] - MemoryRecords.filterTo can return corrupt data if output buffer is not large enough
* [KAFKA-5324] - AdminClient: add close with timeout, fix some timeout bugs
* [KAFKA-5325] - Connection Lose during Kafka Kerberos Renewal process
* [KAFKA-5329] - Replica list in the metadata cache on the broker may have different order from zookeeper
* [KAFKA-5334] - rocksdb.config.setter must be a class instance, not a class name
* [KAFKA-5336] - ListGroup requires Describe on Cluster, but the command-line AclCommand tool does not allow this to be set
* [KAFKA-5338] - There is a Misspell in ResetIntegrationTest
* [KAFKA-5344] - Change message.timestamp.difference.max.ms back to Long.MaxValue
* [KAFKA-5345] - Some socket connections not closed after restart of Kafka Streams
* [KAFKA-5349] - KafkaConsumer occasionally hits IllegalStateException
* [KAFKA-5350] - Modify Unstable annotations in Streams API
* [KAFKA-5353] - baseTimestamp should always have a create timestamp
* [KAFKA-5354] - MirrorMaker not preserving headers
* [KAFKA-5360] - Down-converted uncompressed batches should respect fetch offset
* [KAFKA-5361] - Add EOS integration tests for Streams API
* [KAFKA-5362] - Add EOS system tests for Streams API
* [KAFKA-5368] - Kafka Streams skipped-records-rate sensor produces nonzero values when the timestamps are valid
* [KAFKA-5373] - ConsoleConsumer prints out object addresses rather than what is expected
* [KAFKA-5374] - AdminClient gets \"server returned information about unknown correlation ID\" when communicating with older brokers
* [KAFKA-5375] - Transactions: Concurrent transactional consumer loses messages when there are broker bounces
* [KAFKA-5380] - Transient test failure: KafkaConsumerTest.testChangingRegexSubscription
* [KAFKA-5382] - Log recovery can fail if topic names contain one of the index suffixes
* [KAFKA-5385] - Transactional Producer allows batches to expire and commits transactions regardless
* [KAFKA-5394] - KafkaAdminClient#timeoutCallsInFlight does not work as expected
* [KAFKA-5395] - Distributed Herder Deadlocks on Shutdown
* [KAFKA-5404] - Add more AdminClient checks to ClientCompatibilityTest
* [KAFKA-5413] - Log cleaner fails due to large offset in segment file
* [KAFKA-5414] - Console consumer offset commit regression
* [KAFKA-5415] - TransactionCoordinator doesn\'t complete transition to PrepareCommit state
* [KAFKA-5416] - TransactionCoordinator doesn\'t complete transition to CompleteCommit
* [KAFKA-5418] - ZkUtils.getAllPartitions() may fail if a topic is marked for deletion
* [KAFKA-5422] - Multiple produce request failures causes invalid state transition in TransactionManager
* [KAFKA-5433] - Transient test failure: SaslPlainSslEndToEndAuthorizationTest.testNoProduceWithDescribeAcl
* [KAFKA-5442] - Streams producer `client.id` are not unique for EOS
* [KAFKA-5448] - TimestampConverter\'s \"type\" config conflicts with the basic Transformation \"type\" config
* [KAFKA-5449] - Flaky test TransactionsTest.testReadCommittedConsumerShouldNotSeeUndecidedData
* [KAFKA-5450] - Scripts to startup Connect in system tests have too short a timeout
* [KAFKA-5455] - Update java docs for consumer and producer to be up to date for EOS
* [KAFKA-5456] - Producer fails with NPE if compressed V0 or V1 record is larger than batch size
* [KAFKA-5457] - MemoryRecordsBuilder.hasRoomfor doesn\'t take into account the headers while computing available space
* [KAFKA-5463] - Controller incorrectly logs rack information when new brokers are added
* [KAFKA-5472] - Connector validate REST endpoint returning duplicate entries in \"groups\"
* [KAFKA-5475] - Connector config validation REST API endpoint not including fields for transformations
* [KAFKA-5477] - TransactionalProducer sleeps unnecessarily long during back to back transactions
* [KAFKA-5486] - org.apache.kafka logging should go to server.log
* [KAFKA-5491] - The ProducerPerformance tool should support transactions
* [KAFKA-5498] - Connect validation API stops returning recommendations for some fields after the right sequence of requests
Tue Aug 7 14:00:00 2018 johannes.grasslerAATTsuse.com
- Remove commented Requires and BuildRequires
- Add pointer to documentation on kafka-kit rebuild
- Refresh lock-down-jmxremote.patch and rotate-gc-log.patch
- Add noreplace directive for /etc/kafka/server.properties
- Update to version 0.10.2.2 (bsc#1102920, CVE-2018-1288)
* Improvements:
* [KAFKA-4965] - set internal.leave.group.on.close to false in
KafkaStreams
* [KAFKA-5118] - Improve message for Kafka failed startup with
non-Kafka data in data.dirs
* [KAFKA-5242] - add max_number _of_retries to exponential
backoff strategy
* [KAFKA-7009] - Mute logger for reflections.org at the warn
level in system tests
* Bugs:
* [KAFKA-4827] - Kafka connect: error with special characters
in connector name
* [KAFKA-5150] - LZ4 decompression is 4-5x slower than Snappy
on small batches / messages
* [KAFKA-5167] - streams task gets stuck after re-balance due
to LockException
* [KAFKA-5205] - CachingSessionStore doesn\'t use the default
keySerde.
* [KAFKA-5206] - RocksDBSessionStore doesn\'t use default
aggSerde.
* [KAFKA-5230] - Recommended values for Connect
transformations contain the wrong class name
* [KAFKA-5232] - Kafka broker fails to start if a topic
containing dot in its name is marked for
delete but hasn\'t been deleted during
previous uptime
* [KAFKA-5241] - GlobalKTable does not checkpoint offsets
after restoring state
* [KAFKA-5316] - Log cleaning can increase message size and
cause cleaner to crash with buffer overflow
* [KAFKA-5345] - Some socket connections not closed after
restart of Kafka Streams
* [KAFKA-5395] - Distributed Herder Deadlocks on Shutdown
* [KAFKA-5413] - Log cleaner fails due to large offset in
segment file
* [KAFKA-5464] - StreamsKafkaClient should not use
StreamsConfig.POLL_MS_CONFIG
* [KAFKA-5484] - Refactor kafkatest docker support
* [KAFKA-5623] - ducktape kafka service: do not assume Service
contains num_nodes
* [KAFKA-5643] - Using _DUCKTAPE_OPTIONS has no effect on
executing tests
* [KAFKA-5731] - Connect WorkerSinkTask out of order offset
commit can lead to inconsistent state
* [KAFKA-6054] - ERROR \"SubscriptionInfo - unable to decode
subscription data: version=2\" when upgrading
from 0.10.0.0 to 0.10.2.1
* [KAFKA-6360] - RocksDB segments not removed when store is
closed causes re-initialization to fail
* [KAFKA-6371] - FetchMetadata creates unneeded Strings on
instantiation
* [KAFKA-6566] - SourceTask#stop() not called after exception
raised in poll()
* [KAFKA-6661] - Sink connectors that explicitly \'resume\'
topic partitions can resume a paused task
* [KAFKA-6711] - GlobalStateManagerImpl should not write
offsets of in-memory stores in checkpoint
file
* [KAFKA-7021] - Source KTable checkpoint is not correct
* [KAFKA-7058] - ConnectSchema#equals() broken for array-typed
default values
Thu Jun 28 14:00:00 2018 johannes.grasslerAATTsuse.com
- Reduce package ownership of tmpfiles.d to bare minium (SLE12 SP2)
Wed Jun 27 14:00:00 2018 johannes.grasslerAATTsuse.com
- Fix SLE and older Leap breakage caused by previous fix
Wed Jun 27 14:00:00 2018 johannes.grasslerAATTsuse.com
- Fix various spec errors affecting Leap 15 and Tumbleweed
Mon Jun 18 14:00:00 2018 jodavisAATTsuse.com
- Set log rotation options (bsc#1094448)
- Disable jmxremote debugging (bsc#1095603)
Wed Mar 28 14:00:00 2018 tbechtoldAATTsuse.com
- Increase open file limits (bsc#1086909)
Tue Apr 25 14:00:00 2017 sjamgadeAATTsuse.com
- Added Environment variables to the service files. (bsc#1048688, FATE#323204)
Fri Feb 10 13:00:00 2017 johannes.grasslerAATTsuse.com
- Limited architecture to amd64
- Cleaned up %files section
- Downgraded to upstream version 0.9.0.1
- Switched from upstream binary tarball to Tetra based build
from source
Thu Jan 5 13:00:00 2017 johannes.grasslerAATTsuse.com
- Initial package.