Use 0.10.2.0 release version of javadocs.
Project: http://git-wip-us.apache.org/repos/asf/kafka-site/repo Commit: http://git-wip-us.apache.org/repos/asf/kafka-site/commit/836bb442 Tree: http://git-wip-us.apache.org/repos/asf/kafka-site/tree/836bb442 Diff: http://git-wip-us.apache.org/repos/asf/kafka-site/diff/836bb442 Branch: refs/heads/asf-site Commit: 836bb4426ca9ddc6927669a21c744902d354b3d3 Parents: 29d98a8 Author: Ewen Cheslack-Postava <[email protected]> Authored: Fri Feb 24 16:40:34 2017 -0800 Committer: Ewen Cheslack-Postava <[email protected]> Committed: Fri Feb 24 16:40:34 2017 -0800 ---------------------------------------------------------------------- 0102/javadoc/allclasses-frame.html | 143 +- 0102/javadoc/allclasses-noframe.html | 143 +- 0102/javadoc/constant-values.html | 67 +- 0102/javadoc/deprecated-list.html | 91 +- 0102/javadoc/help-doc.html | 41 +- 0102/javadoc/index-all.html | 4283 +++++++++--------- 0102/javadoc/index.html | 4 +- 0102/javadoc/org/apache/index.html | 8 + .../clients/consumer/CommitFailedException.html | 88 +- .../apache/kafka/clients/consumer/Consumer.html | 425 +- .../kafka/clients/consumer/ConsumerConfig.html | 391 +- .../clients/consumer/ConsumerInterceptor.html | 112 +- .../consumer/ConsumerRebalanceListener.html | 116 +- .../kafka/clients/consumer/ConsumerRecord.html | 255 +- .../kafka/clients/consumer/ConsumerRecords.html | 174 +- .../consumer/InvalidOffsetException.html | 110 +- .../kafka/clients/consumer/KafkaConsumer.html | 868 ++-- .../kafka/clients/consumer/MockConsumer.html | 598 ++- .../consumer/NoOffsetForPartitionException.html | 118 +- .../clients/consumer/OffsetAndMetadata.html | 157 +- .../clients/consumer/OffsetAndTimestamp.html | 137 +- .../clients/consumer/OffsetCommitCallback.html | 95 +- .../consumer/OffsetOutOfRangeException.html | 118 +- .../clients/consumer/OffsetResetStrategy.html | 128 +- .../kafka/clients/consumer/RangeAssignor.html | 115 +- .../RetriableCommitFailedException.html | 100 +- .../clients/consumer/RoundRobinAssignor.html | 123 +- .../kafka/clients/consumer/package-frame.html | 15 +- .../kafka/clients/consumer/package-summary.html | 57 +- .../kafka/clients/consumer/package-tree.html | 105 +- .../javadoc/org/apache/kafka/clients/index.html | 9 + .../producer/BufferExhaustedException.html | 86 +- .../apache/kafka/clients/producer/Callback.html | 89 +- .../kafka/clients/producer/KafkaProducer.html | 290 +- .../kafka/clients/producer/MockProducer.html | 285 +- .../kafka/clients/producer/Partitioner.html | 115 +- .../apache/kafka/clients/producer/Producer.html | 140 +- .../kafka/clients/producer/ProducerConfig.html | 360 +- .../clients/producer/ProducerInterceptor.html | 119 +- .../kafka/clients/producer/ProducerRecord.html | 248 +- .../kafka/clients/producer/RecordMetadata.html | 190 +- .../kafka/clients/producer/package-frame.html | 15 +- .../kafka/clients/producer/package-summary.html | 53 +- .../kafka/clients/producer/package-tree.html | 81 +- .../org/apache/kafka/common/Cluster.html | 307 +- .../apache/kafka/common/ClusterResource.html | 114 +- .../kafka/common/ClusterResourceListener.html | 104 +- .../org/apache/kafka/common/Configurable.html | 77 +- .../org/apache/kafka/common/KafkaException.html | 100 +- .../javadoc/org/apache/kafka/common/Metric.html | 83 +- .../org/apache/kafka/common/MetricName.html | 264 +- 0102/javadoc/org/apache/kafka/common/Node.html | 190 +- .../org/apache/kafka/common/PartitionInfo.html | 141 +- .../org/apache/kafka/common/TopicPartition.html | 142 +- .../kafka/common/config/AbstractConfig.html | 300 +- .../org/apache/kafka/common/config/Config.html | 99 +- .../common/config/ConfigDef.ConfigKey.html | 185 +- .../common/config/ConfigDef.Importance.html | 128 +- .../kafka/common/config/ConfigDef.Range.html | 123 +- .../common/config/ConfigDef.Recommender.html | 109 +- .../kafka/common/config/ConfigDef.Type.html | 140 +- .../common/config/ConfigDef.ValidList.html | 110 +- .../common/config/ConfigDef.ValidString.html | 110 +- .../common/config/ConfigDef.Validator.html | 85 +- .../kafka/common/config/ConfigDef.Width.html | 130 +- .../apache/kafka/common/config/ConfigDef.html | 882 ++-- .../kafka/common/config/ConfigException.html | 100 +- .../apache/kafka/common/config/ConfigValue.html | 187 +- .../apache/kafka/common/config/SaslConfigs.html | 285 +- .../apache/kafka/common/config/SslConfigs.html | 390 +- .../kafka/common/config/package-frame.html | 11 +- .../kafka/common/config/package-summary.html | 57 +- .../kafka/common/config/package-tree.html | 87 +- .../kafka/common/errors/ApiException.html | 126 +- .../common/errors/AuthenticationException.html | 96 +- .../common/errors/AuthorizationException.html | 96 +- .../errors/BrokerNotAvailableException.html | 96 +- .../errors/ClusterAuthorizationException.html | 96 +- .../common/errors/ControllerMovedException.html | 96 +- .../common/errors/CorruptRecordException.html | 104 +- .../common/errors/DisconnectException.html | 120 +- .../errors/GroupAuthorizationException.html | 112 +- .../GroupCoordinatorNotAvailableException.html | 120 +- .../errors/GroupLoadInProgressException.html | 104 +- .../errors/IllegalGenerationException.html | 104 +- .../errors/IllegalSaslStateException.html | 96 +- .../InconsistentGroupProtocolException.html | 96 +- .../kafka/common/errors/InterruptException.html | 96 +- .../InvalidCommitOffsetSizeException.html | 96 +- .../errors/InvalidConfigurationException.html | 96 +- .../errors/InvalidFetchSizeException.html | 96 +- .../common/errors/InvalidGroupIdException.html | 96 +- .../common/errors/InvalidMetadataException.html | 104 +- .../common/errors/InvalidOffsetException.html | 98 +- .../errors/InvalidPartitionsException.html | 96 +- .../InvalidReplicaAssignmentException.html | 96 +- .../InvalidReplicationFactorException.html | 96 +- .../common/errors/InvalidRequestException.html | 96 +- .../errors/InvalidRequiredAcksException.html | 90 +- .../errors/InvalidSessionTimeoutException.html | 96 +- .../errors/InvalidTimestampException.html | 96 +- .../common/errors/InvalidTopicException.html | 104 +- .../errors/LeaderNotAvailableException.html | 96 +- .../kafka/common/errors/NetworkException.html | 104 +- .../common/errors/NotControllerException.html | 96 +- .../errors/NotCoordinatorForGroupException.html | 104 +- .../NotEnoughReplicasAfterAppendException.html | 90 +- .../errors/NotEnoughReplicasException.html | 104 +- .../errors/NotLeaderForPartitionException.html | 104 +- .../common/errors/OffsetMetadataTooLarge.html | 104 +- .../errors/OffsetOutOfRangeException.html | 96 +- .../common/errors/PolicyViolationException.html | 96 +- .../errors/RebalanceInProgressException.html | 104 +- .../errors/RecordBatchTooLargeException.html | 104 +- .../common/errors/RecordTooLargeException.html | 132 +- .../errors/ReplicaNotAvailableException.html | 100 +- .../kafka/common/errors/RetriableException.html | 104 +- .../common/errors/SerializationException.html | 126 +- .../kafka/common/errors/TimeoutException.html | 104 +- .../errors/TopicAuthorizationException.html | 116 +- .../common/errors/TopicExistsException.html | 96 +- .../common/errors/UnknownMemberIdException.html | 104 +- .../common/errors/UnknownServerException.html | 104 +- .../UnknownTopicOrPartitionException.html | 104 +- .../UnsupportedForMessageFormatException.html | 96 +- .../UnsupportedSaslMechanismException.html | 96 +- .../errors/UnsupportedVersionException.html | 96 +- .../kafka/common/errors/WakeupException.html | 90 +- .../kafka/common/errors/package-frame.html | 7 +- .../kafka/common/errors/package-summary.html | 49 +- .../kafka/common/errors/package-tree.html | 161 +- 0102/javadoc/org/apache/kafka/common/index.html | 23 + .../org/apache/kafka/common/package-frame.html | 13 +- .../apache/kafka/common/package-summary.html | 53 +- .../org/apache/kafka/common/package-tree.html | 69 +- .../serialization/ByteArrayDeserializer.html | 152 +- .../serialization/ByteArraySerializer.html | 152 +- .../serialization/ByteBufferDeserializer.html | 152 +- .../serialization/ByteBufferSerializer.html | 152 +- .../common/serialization/BytesDeserializer.html | 152 +- .../common/serialization/BytesSerializer.html | 152 +- .../common/serialization/Deserializer.html | 123 +- .../serialization/DoubleDeserializer.html | 152 +- .../common/serialization/DoubleSerializer.html | 152 +- .../serialization/IntegerDeserializer.html | 152 +- .../common/serialization/IntegerSerializer.html | 152 +- .../common/serialization/LongDeserializer.html | 152 +- .../common/serialization/LongSerializer.html | 152 +- .../kafka/common/serialization/Serde.html | 118 +- .../serialization/Serdes.ByteArraySerde.html | 85 +- .../serialization/Serdes.ByteBufferSerde.html | 85 +- .../common/serialization/Serdes.BytesSerde.html | 85 +- .../serialization/Serdes.DoubleSerde.html | 85 +- .../serialization/Serdes.IntegerSerde.html | 85 +- .../common/serialization/Serdes.LongSerde.html | 85 +- .../serialization/Serdes.StringSerde.html | 85 +- .../serialization/Serdes.WrapperSerde.html | 160 +- .../kafka/common/serialization/Serdes.html | 179 +- .../kafka/common/serialization/Serializer.html | 125 +- .../serialization/StringDeserializer.html | 152 +- .../common/serialization/StringSerializer.html | 152 +- .../common/serialization/package-frame.html | 13 +- .../common/serialization/package-summary.html | 51 +- .../common/serialization/package-tree.html | 99 +- .../kafka/connect/connector/ConnectRecord.html | 195 +- .../kafka/connect/connector/Connector.html | 226 +- .../connect/connector/ConnectorContext.html | 88 +- .../apache/kafka/connect/connector/Task.html | 99 +- .../kafka/connect/connector/package-frame.html | 11 +- .../connect/connector/package-summary.html | 51 +- .../kafka/connect/connector/package-tree.html | 51 +- .../kafka/connect/data/ConnectSchema.html | 391 +- .../org/apache/kafka/connect/data/Date.html | 151 +- .../org/apache/kafka/connect/data/Decimal.html | 165 +- .../org/apache/kafka/connect/data/Field.html | 150 +- .../apache/kafka/connect/data/Schema.Type.html | 158 +- .../org/apache/kafka/connect/data/Schema.html | 266 +- .../kafka/connect/data/SchemaAndValue.html | 153 +- .../kafka/connect/data/SchemaBuilder.html | 558 +-- .../kafka/connect/data/SchemaProjector.html | 117 +- .../org/apache/kafka/connect/data/Struct.html | 343 +- .../org/apache/kafka/connect/data/Time.html | 151 +- .../apache/kafka/connect/data/Timestamp.html | 151 +- .../kafka/connect/data/package-frame.html | 9 +- .../kafka/connect/data/package-summary.html | 53 +- .../apache/kafka/connect/data/package-tree.html | 71 +- .../connect/errors/AlreadyExistsException.html | 96 +- .../kafka/connect/errors/ConnectException.html | 96 +- .../kafka/connect/errors/DataException.html | 96 +- .../errors/IllegalWorkerStateException.html | 96 +- .../kafka/connect/errors/NotFoundException.html | 96 +- .../connect/errors/RetriableException.html | 96 +- .../connect/errors/SchemaBuilderException.html | 96 +- .../errors/SchemaProjectorException.html | 96 +- .../kafka/connect/errors/package-frame.html | 7 +- .../kafka/connect/errors/package-summary.html | 49 +- .../kafka/connect/errors/package-tree.html | 67 +- .../javadoc/org/apache/kafka/connect/index.html | 15 + .../kafka/connect/sink/SinkConnector.html | 104 +- .../apache/kafka/connect/sink/SinkRecord.html | 195 +- .../org/apache/kafka/connect/sink/SinkTask.html | 277 +- .../kafka/connect/sink/SinkTaskContext.html | 146 +- .../kafka/connect/sink/package-frame.html | 9 +- .../kafka/connect/sink/package-summary.html | 51 +- .../apache/kafka/connect/sink/package-tree.html | 55 +- .../kafka/connect/source/SourceConnector.html | 89 +- .../kafka/connect/source/SourceRecord.html | 239 +- .../apache/kafka/connect/source/SourceTask.html | 197 +- .../kafka/connect/source/SourceTaskContext.html | 77 +- .../kafka/connect/source/package-frame.html | 9 +- .../kafka/connect/source/package-summary.html | 51 +- .../kafka/connect/source/package-tree.html | 55 +- .../apache/kafka/connect/storage/Converter.html | 122 +- .../connect/storage/OffsetStorageReader.html | 101 +- .../kafka/connect/storage/StringConverter.html | 161 +- .../kafka/connect/storage/package-frame.html | 11 +- .../kafka/connect/storage/package-summary.html | 51 +- .../kafka/connect/storage/package-tree.html | 49 +- .../connect/transforms/Transformation.html | 103 +- .../kafka/connect/transforms/package-frame.html | 9 +- .../connect/transforms/package-summary.html | 49 +- .../kafka/connect/transforms/package-tree.html | 51 +- .../kafka/connect/util/ConnectorUtils.html | 107 +- .../kafka/connect/util/package-frame.html | 7 +- .../kafka/connect/util/package-summary.html | 49 +- .../apache/kafka/connect/util/package-tree.html | 45 +- 0102/javadoc/org/apache/kafka/index.html | 11 + .../kafka/streams/KafkaClientSupplier.html | 118 +- .../kafka/streams/KafkaStreams.State.html | 150 +- .../streams/KafkaStreams.StateListener.html | 85 +- .../org/apache/kafka/streams/KafkaStreams.html | 391 +- .../org/apache/kafka/streams/KeyValue.html | 179 +- .../streams/StreamsConfig.InternalConfig.html | 102 +- .../org/apache/kafka/streams/StreamsConfig.html | 524 +-- .../apache/kafka/streams/StreamsMetrics.html | 224 +- .../errors/InvalidStateStoreException.html | 96 +- .../kafka/streams/errors/LockException.html | 98 +- .../streams/errors/ProcessorStateException.html | 98 +- .../kafka/streams/errors/StreamsException.html | 96 +- .../streams/errors/TaskAssignmentException.html | 96 +- .../streams/errors/TaskIdFormatException.html | 98 +- .../errors/TopologyBuilderException.html | 96 +- .../kafka/streams/errors/package-frame.html | 7 +- .../kafka/streams/errors/package-summary.html | 49 +- .../kafka/streams/errors/package-tree.html | 65 +- .../javadoc/org/apache/kafka/streams/index.html | 22 + .../kafka/streams/kstream/Aggregator.html | 119 +- .../kafka/streams/kstream/ForeachAction.html | 104 +- .../kafka/streams/kstream/GlobalKTable.html | 72 +- .../kafka/streams/kstream/Initializer.html | 104 +- .../kafka/streams/kstream/JoinWindows.html | 262 +- .../kafka/streams/kstream/KGroupedStream.html | 738 ++- .../kafka/streams/kstream/KGroupedTable.html | 364 +- .../apache/kafka/streams/kstream/KStream.html | 1280 ++---- .../kafka/streams/kstream/KStreamBuilder.html | 492 +- .../apache/kafka/streams/kstream/KTable.html | 644 +-- .../kafka/streams/kstream/KeyValueMapper.html | 120 +- .../apache/kafka/streams/kstream/Merger.html | 99 +- .../apache/kafka/streams/kstream/Predicate.html | 111 +- .../apache/kafka/streams/kstream/Reducer.html | 114 +- .../kafka/streams/kstream/SessionWindows.html | 149 +- .../kafka/streams/kstream/TimeWindows.html | 246 +- .../kafka/streams/kstream/Transformer.html | 183 +- .../streams/kstream/TransformerSupplier.html | 100 +- .../kafka/streams/kstream/UnlimitedWindows.html | 228 +- .../kafka/streams/kstream/ValueJoiner.html | 128 +- .../kafka/streams/kstream/ValueMapper.html | 106 +- .../kafka/streams/kstream/ValueTransformer.html | 175 +- .../kstream/ValueTransformerSupplier.html | 97 +- .../apache/kafka/streams/kstream/Window.html | 186 +- .../apache/kafka/streams/kstream/Windowed.html | 181 +- .../apache/kafka/streams/kstream/Windows.html | 197 +- .../kafka/streams/kstream/package-frame.html | 43 +- .../kafka/streams/kstream/package-summary.html | 51 +- .../kafka/streams/kstream/package-tree.html | 97 +- .../org/apache/kafka/streams/package-frame.html | 13 +- .../apache/kafka/streams/package-summary.html | 53 +- .../org/apache/kafka/streams/package-tree.html | 65 +- .../streams/processor/AbstractProcessor.html | 172 +- .../processor/DefaultPartitionGrouper.html | 127 +- .../processor/FailOnInvalidTimestamp.html | 144 +- .../processor/LogAndSkipOnInvalidTimestamp.html | 140 +- .../streams/processor/PartitionGrouper.html | 88 +- .../kafka/streams/processor/Processor.html | 135 +- .../streams/processor/ProcessorContext.html | 310 +- .../streams/processor/ProcessorSupplier.html | 88 +- .../streams/processor/StateRestoreCallback.html | 79 +- .../kafka/streams/processor/StateStore.html | 124 +- .../streams/processor/StateStoreSupplier.html | 122 +- .../streams/processor/StreamPartitioner.html | 108 +- .../apache/kafka/streams/processor/TaskId.html | 201 +- .../streams/processor/TimestampExtractor.html | 88 +- .../TopologyBuilder.AutoOffsetReset.html | 126 +- .../processor/TopologyBuilder.TopicsInfo.html | 127 +- .../streams/processor/TopologyBuilder.html | 742 ++- .../UsePreviousTimeOnInvalidTimestamp.html | 144 +- .../processor/WallclockTimestampExtractor.html | 122 +- .../kafka/streams/processor/package-frame.html | 25 +- .../streams/processor/package-summary.html | 57 +- .../kafka/streams/processor/package-tree.html | 85 +- .../apache/kafka/streams/state/HostInfo.html | 145 +- .../kafka/streams/state/KeyValueIterator.html | 106 +- .../kafka/streams/state/KeyValueStore.html | 163 +- .../kafka/streams/state/QueryableStoreType.html | 112 +- .../streams/state/QueryableStoreTypes.html | 140 +- .../streams/state/ReadOnlyKeyValueStore.html | 150 +- .../streams/state/ReadOnlySessionStore.html | 93 +- .../streams/state/ReadOnlyWindowStore.html | 98 +- .../streams/state/RocksDBConfigSetter.html | 88 +- .../kafka/streams/state/SessionStore.html | 124 +- .../apache/kafka/streams/state/StateSerdes.html | 274 +- .../state/Stores.InMemoryKeyValueFactory.html | 131 +- .../streams/state/Stores.KeyValueFactory.html | 93 +- .../state/Stores.PersistentKeyValueFactory.html | 155 +- .../streams/state/Stores.StoreFactory.html | 191 +- .../streams/state/Stores.ValueFactory.html | 196 +- .../org/apache/kafka/streams/state/Stores.html | 125 +- .../kafka/streams/state/StreamsMetadata.html | 173 +- .../apache/kafka/streams/state/WindowStore.html | 107 +- .../streams/state/WindowStoreIterator.html | 104 +- .../kafka/streams/state/package-frame.html | 33 +- .../kafka/streams/state/package-summary.html | 53 +- .../kafka/streams/state/package-tree.html | 103 +- 0102/javadoc/org/index.html | 8 + 0102/javadoc/overview-frame.html | 9 +- 0102/javadoc/overview-summary.html | 41 +- 0102/javadoc/overview-tree.html | 621 ++- 0102/javadoc/resources/background.gif | Bin 0 -> 2313 bytes 0102/javadoc/resources/index.html | 11 + 0102/javadoc/resources/tab.gif | Bin 0 -> 291 bytes 0102/javadoc/resources/titlebar.gif | Bin 0 -> 10701 bytes 0102/javadoc/resources/titlebar_end.gif | Bin 0 -> 849 bytes 0102/javadoc/serialized-form.html | 67 +- 0102/javadoc/stylesheet.css | 342 +- 334 files changed, 20992 insertions(+), 28782 deletions(-) ---------------------------------------------------------------------- http://git-wip-us.apache.org/repos/asf/kafka-site/blob/836bb442/0102/javadoc/allclasses-frame.html ---------------------------------------------------------------------- diff --git a/0102/javadoc/allclasses-frame.html b/0102/javadoc/allclasses-frame.html index f3ba26e..16311d0 100644 --- a/0102/javadoc/allclasses-frame.html +++ b/0102/javadoc/allclasses-frame.html @@ -2,19 +2,18 @@ <!-- NewPage --> <html lang="en"> <head> -<!-- Generated by javadoc (1.8.0_66) on Thu Feb 23 11:45:52 PST 2017 --> -<title>All Classes (kafka-work 0.10.2.1-SNAPSHOT API)</title> -<meta name="date" content="2017-02-23"> +<!-- Generated by javadoc (version 1.7.0_80) on Tue Feb 14 09:29:19 PST 2017 --> +<title>All Classes (kafka 0.10.2.0 API)</title> +<meta name="date" content="2017-02-14"> <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style"> -<script type="text/javascript" src="script.js"></script> </head> <body> -<h1 class="bar">All Classes</h1> +<h1 class="bar">All Classes</h1> <div class="indexContainer"> <ul> <li><a href="org/apache/kafka/common/config/AbstractConfig.html" title="class in org.apache.kafka.common.config" target="classFrame">AbstractConfig</a></li> <li><a href="org/apache/kafka/streams/processor/AbstractProcessor.html" title="class in org.apache.kafka.streams.processor" target="classFrame">AbstractProcessor</a></li> -<li><a href="org/apache/kafka/streams/kstream/Aggregator.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">Aggregator</span></a></li> +<li><a href="org/apache/kafka/streams/kstream/Aggregator.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>Aggregator</i></a></li> <li><a href="org/apache/kafka/connect/errors/AlreadyExistsException.html" title="class in org.apache.kafka.connect.errors" target="classFrame">AlreadyExistsException</a></li> <li><a href="org/apache/kafka/common/errors/ApiException.html" title="class in org.apache.kafka.common.errors" target="classFrame">ApiException</a></li> <li><a href="org/apache/kafka/common/errors/AuthenticationException.html" title="class in org.apache.kafka.common.errors" target="classFrame">AuthenticationException</a></li> @@ -27,53 +26,53 @@ <li><a href="org/apache/kafka/common/serialization/ByteBufferSerializer.html" title="class in org.apache.kafka.common.serialization" target="classFrame">ByteBufferSerializer</a></li> <li><a href="org/apache/kafka/common/serialization/BytesDeserializer.html" title="class in org.apache.kafka.common.serialization" target="classFrame">BytesDeserializer</a></li> <li><a href="org/apache/kafka/common/serialization/BytesSerializer.html" title="class in org.apache.kafka.common.serialization" target="classFrame">BytesSerializer</a></li> -<li><a href="org/apache/kafka/clients/producer/Callback.html" title="interface in org.apache.kafka.clients.producer" target="classFrame"><span class="interfaceName">Callback</span></a></li> +<li><a href="org/apache/kafka/clients/producer/Callback.html" title="interface in org.apache.kafka.clients.producer" target="classFrame"><i>Callback</i></a></li> <li><a href="org/apache/kafka/common/Cluster.html" title="class in org.apache.kafka.common" target="classFrame">Cluster</a></li> <li><a href="org/apache/kafka/common/errors/ClusterAuthorizationException.html" title="class in org.apache.kafka.common.errors" target="classFrame">ClusterAuthorizationException</a></li> <li><a href="org/apache/kafka/common/ClusterResource.html" title="class in org.apache.kafka.common" target="classFrame">ClusterResource</a></li> -<li><a href="org/apache/kafka/common/ClusterResourceListener.html" title="interface in org.apache.kafka.common" target="classFrame"><span class="interfaceName">ClusterResourceListener</span></a></li> +<li><a href="org/apache/kafka/common/ClusterResourceListener.html" title="interface in org.apache.kafka.common" target="classFrame"><i>ClusterResourceListener</i></a></li> <li><a href="org/apache/kafka/clients/consumer/CommitFailedException.html" title="class in org.apache.kafka.clients.consumer" target="classFrame">CommitFailedException</a></li> <li><a href="org/apache/kafka/common/config/Config.html" title="class in org.apache.kafka.common.config" target="classFrame">Config</a></li> <li><a href="org/apache/kafka/common/config/ConfigDef.html" title="class in org.apache.kafka.common.config" target="classFrame">ConfigDef</a></li> <li><a href="org/apache/kafka/common/config/ConfigDef.ConfigKey.html" title="class in org.apache.kafka.common.config" target="classFrame">ConfigDef.ConfigKey</a></li> <li><a href="org/apache/kafka/common/config/ConfigDef.Importance.html" title="enum in org.apache.kafka.common.config" target="classFrame">ConfigDef.Importance</a></li> <li><a href="org/apache/kafka/common/config/ConfigDef.Range.html" title="class in org.apache.kafka.common.config" target="classFrame">ConfigDef.Range</a></li> -<li><a href="org/apache/kafka/common/config/ConfigDef.Recommender.html" title="interface in org.apache.kafka.common.config" target="classFrame"><span class="interfaceName">ConfigDef.Recommender</span></a></li> +<li><a href="org/apache/kafka/common/config/ConfigDef.Recommender.html" title="interface in org.apache.kafka.common.config" target="classFrame"><i>ConfigDef.Recommender</i></a></li> <li><a href="org/apache/kafka/common/config/ConfigDef.Type.html" title="enum in org.apache.kafka.common.config" target="classFrame">ConfigDef.Type</a></li> -<li><a href="org/apache/kafka/common/config/ConfigDef.Validator.html" title="interface in org.apache.kafka.common.config" target="classFrame"><span class="interfaceName">ConfigDef.Validator</span></a></li> +<li><a href="org/apache/kafka/common/config/ConfigDef.Validator.html" title="interface in org.apache.kafka.common.config" target="classFrame"><i>ConfigDef.Validator</i></a></li> <li><a href="org/apache/kafka/common/config/ConfigDef.ValidList.html" title="class in org.apache.kafka.common.config" target="classFrame">ConfigDef.ValidList</a></li> <li><a href="org/apache/kafka/common/config/ConfigDef.ValidString.html" title="class in org.apache.kafka.common.config" target="classFrame">ConfigDef.ValidString</a></li> <li><a href="org/apache/kafka/common/config/ConfigDef.Width.html" title="enum in org.apache.kafka.common.config" target="classFrame">ConfigDef.Width</a></li> <li><a href="org/apache/kafka/common/config/ConfigException.html" title="class in org.apache.kafka.common.config" target="classFrame">ConfigException</a></li> -<li><a href="org/apache/kafka/common/Configurable.html" title="interface in org.apache.kafka.common" target="classFrame"><span class="interfaceName">Configurable</span></a></li> +<li><a href="org/apache/kafka/common/Configurable.html" title="interface in org.apache.kafka.common" target="classFrame"><i>Configurable</i></a></li> <li><a href="org/apache/kafka/common/config/ConfigValue.html" title="class in org.apache.kafka.common.config" target="classFrame">ConfigValue</a></li> <li><a href="org/apache/kafka/connect/errors/ConnectException.html" title="class in org.apache.kafka.connect.errors" target="classFrame">ConnectException</a></li> <li><a href="org/apache/kafka/connect/connector/Connector.html" title="class in org.apache.kafka.connect.connector" target="classFrame">Connector</a></li> -<li><a href="org/apache/kafka/connect/connector/ConnectorContext.html" title="interface in org.apache.kafka.connect.connector" target="classFrame"><span class="interfaceName">ConnectorContext</span></a></li> +<li><a href="org/apache/kafka/connect/connector/ConnectorContext.html" title="interface in org.apache.kafka.connect.connector" target="classFrame"><i>ConnectorContext</i></a></li> <li><a href="org/apache/kafka/connect/util/ConnectorUtils.html" title="class in org.apache.kafka.connect.util" target="classFrame">ConnectorUtils</a></li> <li><a href="org/apache/kafka/connect/connector/ConnectRecord.html" title="class in org.apache.kafka.connect.connector" target="classFrame">ConnectRecord</a></li> <li><a href="org/apache/kafka/connect/data/ConnectSchema.html" title="class in org.apache.kafka.connect.data" target="classFrame">ConnectSchema</a></li> -<li><a href="org/apache/kafka/clients/consumer/Consumer.html" title="interface in org.apache.kafka.clients.consumer" target="classFrame"><span class="interfaceName">Consumer</span></a></li> +<li><a href="org/apache/kafka/clients/consumer/Consumer.html" title="interface in org.apache.kafka.clients.consumer" target="classFrame"><i>Consumer</i></a></li> <li><a href="org/apache/kafka/clients/consumer/ConsumerConfig.html" title="class in org.apache.kafka.clients.consumer" target="classFrame">ConsumerConfig</a></li> -<li><a href="org/apache/kafka/clients/consumer/ConsumerInterceptor.html" title="interface in org.apache.kafka.clients.consumer" target="classFrame"><span class="interfaceName">ConsumerInterceptor</span></a></li> -<li><a href="org/apache/kafka/clients/consumer/ConsumerRebalanceListener.html" title="interface in org.apache.kafka.clients.consumer" target="classFrame"><span class="interfaceName">ConsumerRebalanceListener</span></a></li> +<li><a href="org/apache/kafka/clients/consumer/ConsumerInterceptor.html" title="interface in org.apache.kafka.clients.consumer" target="classFrame"><i>ConsumerInterceptor</i></a></li> +<li><a href="org/apache/kafka/clients/consumer/ConsumerRebalanceListener.html" title="interface in org.apache.kafka.clients.consumer" target="classFrame"><i>ConsumerRebalanceListener</i></a></li> <li><a href="org/apache/kafka/clients/consumer/ConsumerRecord.html" title="class in org.apache.kafka.clients.consumer" target="classFrame">ConsumerRecord</a></li> <li><a href="org/apache/kafka/clients/consumer/ConsumerRecords.html" title="class in org.apache.kafka.clients.consumer" target="classFrame">ConsumerRecords</a></li> <li><a href="org/apache/kafka/common/errors/ControllerMovedException.html" title="class in org.apache.kafka.common.errors" target="classFrame">ControllerMovedException</a></li> -<li><a href="org/apache/kafka/connect/storage/Converter.html" title="interface in org.apache.kafka.connect.storage" target="classFrame"><span class="interfaceName">Converter</span></a></li> +<li><a href="org/apache/kafka/connect/storage/Converter.html" title="interface in org.apache.kafka.connect.storage" target="classFrame"><i>Converter</i></a></li> <li><a href="org/apache/kafka/common/errors/CorruptRecordException.html" title="class in org.apache.kafka.common.errors" target="classFrame">CorruptRecordException</a></li> <li><a href="org/apache/kafka/connect/errors/DataException.html" title="class in org.apache.kafka.connect.errors" target="classFrame">DataException</a></li> <li><a href="org/apache/kafka/connect/data/Date.html" title="class in org.apache.kafka.connect.data" target="classFrame">Date</a></li> <li><a href="org/apache/kafka/connect/data/Decimal.html" title="class in org.apache.kafka.connect.data" target="classFrame">Decimal</a></li> <li><a href="org/apache/kafka/streams/processor/DefaultPartitionGrouper.html" title="class in org.apache.kafka.streams.processor" target="classFrame">DefaultPartitionGrouper</a></li> -<li><a href="org/apache/kafka/common/serialization/Deserializer.html" title="interface in org.apache.kafka.common.serialization" target="classFrame"><span class="interfaceName">Deserializer</span></a></li> +<li><a href="org/apache/kafka/common/serialization/Deserializer.html" title="interface in org.apache.kafka.common.serialization" target="classFrame"><i>Deserializer</i></a></li> <li><a href="org/apache/kafka/common/errors/DisconnectException.html" title="class in org.apache.kafka.common.errors" target="classFrame">DisconnectException</a></li> <li><a href="org/apache/kafka/common/serialization/DoubleDeserializer.html" title="class in org.apache.kafka.common.serialization" target="classFrame">DoubleDeserializer</a></li> <li><a href="org/apache/kafka/common/serialization/DoubleSerializer.html" title="class in org.apache.kafka.common.serialization" target="classFrame">DoubleSerializer</a></li> <li><a href="org/apache/kafka/streams/processor/FailOnInvalidTimestamp.html" title="class in org.apache.kafka.streams.processor" target="classFrame">FailOnInvalidTimestamp</a></li> <li><a href="org/apache/kafka/connect/data/Field.html" title="class in org.apache.kafka.connect.data" target="classFrame">Field</a></li> -<li><a href="org/apache/kafka/streams/kstream/ForeachAction.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">ForeachAction</span></a></li> -<li><a href="org/apache/kafka/streams/kstream/GlobalKTable.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">GlobalKTable</span></a></li> +<li><a href="org/apache/kafka/streams/kstream/ForeachAction.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>ForeachAction</i></a></li> +<li><a href="org/apache/kafka/streams/kstream/GlobalKTable.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>GlobalKTable</i></a></li> <li><a href="org/apache/kafka/common/errors/GroupAuthorizationException.html" title="class in org.apache.kafka.common.errors" target="classFrame">GroupAuthorizationException</a></li> <li><a href="org/apache/kafka/common/errors/GroupCoordinatorNotAvailableException.html" title="class in org.apache.kafka.common.errors" target="classFrame">GroupCoordinatorNotAvailableException</a></li> <li><a href="org/apache/kafka/common/errors/GroupLoadInProgressException.html" title="class in org.apache.kafka.common.errors" target="classFrame">GroupLoadInProgressException</a></li> @@ -82,7 +81,7 @@ <li><a href="org/apache/kafka/common/errors/IllegalSaslStateException.html" title="class in org.apache.kafka.common.errors" target="classFrame">IllegalSaslStateException</a></li> <li><a href="org/apache/kafka/connect/errors/IllegalWorkerStateException.html" title="class in org.apache.kafka.connect.errors" target="classFrame">IllegalWorkerStateException</a></li> <li><a href="org/apache/kafka/common/errors/InconsistentGroupProtocolException.html" title="class in org.apache.kafka.common.errors" target="classFrame">InconsistentGroupProtocolException</a></li> -<li><a href="org/apache/kafka/streams/kstream/Initializer.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">Initializer</span></a></li> +<li><a href="org/apache/kafka/streams/kstream/Initializer.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>Initializer</i></a></li> <li><a href="org/apache/kafka/common/serialization/IntegerDeserializer.html" title="class in org.apache.kafka.common.serialization" target="classFrame">IntegerDeserializer</a></li> <li><a href="org/apache/kafka/common/serialization/IntegerSerializer.html" title="class in org.apache.kafka.common.serialization" target="classFrame">IntegerSerializer</a></li> <li><a href="org/apache/kafka/common/errors/InterruptException.html" title="class in org.apache.kafka.common.errors" target="classFrame">InterruptException</a></li> @@ -103,29 +102,29 @@ <li><a href="org/apache/kafka/common/errors/InvalidTimestampException.html" title="class in org.apache.kafka.common.errors" target="classFrame">InvalidTimestampException</a></li> <li><a href="org/apache/kafka/common/errors/InvalidTopicException.html" title="class in org.apache.kafka.common.errors" target="classFrame">InvalidTopicException</a></li> <li><a href="org/apache/kafka/streams/kstream/JoinWindows.html" title="class in org.apache.kafka.streams.kstream" target="classFrame">JoinWindows</a></li> -<li><a href="org/apache/kafka/streams/KafkaClientSupplier.html" title="interface in org.apache.kafka.streams" target="classFrame"><span class="interfaceName">KafkaClientSupplier</span></a></li> +<li><a href="org/apache/kafka/streams/KafkaClientSupplier.html" title="interface in org.apache.kafka.streams" target="classFrame"><i>KafkaClientSupplier</i></a></li> <li><a href="org/apache/kafka/clients/consumer/KafkaConsumer.html" title="class in org.apache.kafka.clients.consumer" target="classFrame">KafkaConsumer</a></li> <li><a href="org/apache/kafka/common/KafkaException.html" title="class in org.apache.kafka.common" target="classFrame">KafkaException</a></li> <li><a href="org/apache/kafka/clients/producer/KafkaProducer.html" title="class in org.apache.kafka.clients.producer" target="classFrame">KafkaProducer</a></li> <li><a href="org/apache/kafka/streams/KafkaStreams.html" title="class in org.apache.kafka.streams" target="classFrame">KafkaStreams</a></li> <li><a href="org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams" target="classFrame">KafkaStreams.State</a></li> -<li><a href="org/apache/kafka/streams/KafkaStreams.StateListener.html" title="interface in org.apache.kafka.streams" target="classFrame"><span class="interfaceName">KafkaStreams.StateListener</span></a></li> +<li><a href="org/apache/kafka/streams/KafkaStreams.StateListener.html" title="interface in org.apache.kafka.streams" target="classFrame"><i>KafkaStreams.StateListener</i></a></li> <li><a href="org/apache/kafka/streams/KeyValue.html" title="class in org.apache.kafka.streams" target="classFrame">KeyValue</a></li> -<li><a href="org/apache/kafka/streams/state/KeyValueIterator.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">KeyValueIterator</span></a></li> -<li><a href="org/apache/kafka/streams/kstream/KeyValueMapper.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">KeyValueMapper</span></a></li> -<li><a href="org/apache/kafka/streams/state/KeyValueStore.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">KeyValueStore</span></a></li> -<li><a href="org/apache/kafka/streams/kstream/KGroupedStream.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">KGroupedStream</span></a></li> -<li><a href="org/apache/kafka/streams/kstream/KGroupedTable.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">KGroupedTable</span></a></li> -<li><a href="org/apache/kafka/streams/kstream/KStream.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">KStream</span></a></li> +<li><a href="org/apache/kafka/streams/state/KeyValueIterator.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>KeyValueIterator</i></a></li> +<li><a href="org/apache/kafka/streams/kstream/KeyValueMapper.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>KeyValueMapper</i></a></li> +<li><a href="org/apache/kafka/streams/state/KeyValueStore.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>KeyValueStore</i></a></li> +<li><a href="org/apache/kafka/streams/kstream/KGroupedStream.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>KGroupedStream</i></a></li> +<li><a href="org/apache/kafka/streams/kstream/KGroupedTable.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>KGroupedTable</i></a></li> +<li><a href="org/apache/kafka/streams/kstream/KStream.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>KStream</i></a></li> <li><a href="org/apache/kafka/streams/kstream/KStreamBuilder.html" title="class in org.apache.kafka.streams.kstream" target="classFrame">KStreamBuilder</a></li> -<li><a href="org/apache/kafka/streams/kstream/KTable.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">KTable</span></a></li> +<li><a href="org/apache/kafka/streams/kstream/KTable.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>KTable</i></a></li> <li><a href="org/apache/kafka/common/errors/LeaderNotAvailableException.html" title="class in org.apache.kafka.common.errors" target="classFrame">LeaderNotAvailableException</a></li> <li><a href="org/apache/kafka/streams/errors/LockException.html" title="class in org.apache.kafka.streams.errors" target="classFrame">LockException</a></li> <li><a href="org/apache/kafka/streams/processor/LogAndSkipOnInvalidTimestamp.html" title="class in org.apache.kafka.streams.processor" target="classFrame">LogAndSkipOnInvalidTimestamp</a></li> <li><a href="org/apache/kafka/common/serialization/LongDeserializer.html" title="class in org.apache.kafka.common.serialization" target="classFrame">LongDeserializer</a></li> <li><a href="org/apache/kafka/common/serialization/LongSerializer.html" title="class in org.apache.kafka.common.serialization" target="classFrame">LongSerializer</a></li> -<li><a href="org/apache/kafka/streams/kstream/Merger.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">Merger</span></a></li> -<li><a href="org/apache/kafka/common/Metric.html" title="interface in org.apache.kafka.common" target="classFrame"><span class="interfaceName">Metric</span></a></li> +<li><a href="org/apache/kafka/streams/kstream/Merger.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>Merger</i></a></li> +<li><a href="org/apache/kafka/common/Metric.html" title="interface in org.apache.kafka.common" target="classFrame"><i>Metric</i></a></li> <li><a href="org/apache/kafka/common/MetricName.html" title="class in org.apache.kafka.common" target="classFrame">MetricName</a></li> <li><a href="org/apache/kafka/clients/consumer/MockConsumer.html" title="class in org.apache.kafka.clients.consumer" target="classFrame">MockConsumer</a></li> <li><a href="org/apache/kafka/clients/producer/MockProducer.html" title="class in org.apache.kafka.clients.producer" target="classFrame">MockProducer</a></li> @@ -140,51 +139,51 @@ <li><a href="org/apache/kafka/common/errors/NotLeaderForPartitionException.html" title="class in org.apache.kafka.common.errors" target="classFrame">NotLeaderForPartitionException</a></li> <li><a href="org/apache/kafka/clients/consumer/OffsetAndMetadata.html" title="class in org.apache.kafka.clients.consumer" target="classFrame">OffsetAndMetadata</a></li> <li><a href="org/apache/kafka/clients/consumer/OffsetAndTimestamp.html" title="class in org.apache.kafka.clients.consumer" target="classFrame">OffsetAndTimestamp</a></li> -<li><a href="org/apache/kafka/clients/consumer/OffsetCommitCallback.html" title="interface in org.apache.kafka.clients.consumer" target="classFrame"><span class="interfaceName">OffsetCommitCallback</span></a></li> +<li><a href="org/apache/kafka/clients/consumer/OffsetCommitCallback.html" title="interface in org.apache.kafka.clients.consumer" target="classFrame"><i>OffsetCommitCallback</i></a></li> <li><a href="org/apache/kafka/common/errors/OffsetMetadataTooLarge.html" title="class in org.apache.kafka.common.errors" target="classFrame">OffsetMetadataTooLarge</a></li> <li><a href="org/apache/kafka/clients/consumer/OffsetOutOfRangeException.html" title="class in org.apache.kafka.clients.consumer" target="classFrame">OffsetOutOfRangeException</a></li> <li><a href="org/apache/kafka/common/errors/OffsetOutOfRangeException.html" title="class in org.apache.kafka.common.errors" target="classFrame">OffsetOutOfRangeException</a></li> <li><a href="org/apache/kafka/clients/consumer/OffsetResetStrategy.html" title="enum in org.apache.kafka.clients.consumer" target="classFrame">OffsetResetStrategy</a></li> -<li><a href="org/apache/kafka/connect/storage/OffsetStorageReader.html" title="interface in org.apache.kafka.connect.storage" target="classFrame"><span class="interfaceName">OffsetStorageReader</span></a></li> -<li><a href="org/apache/kafka/clients/producer/Partitioner.html" title="interface in org.apache.kafka.clients.producer" target="classFrame"><span class="interfaceName">Partitioner</span></a></li> -<li><a href="org/apache/kafka/streams/processor/PartitionGrouper.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><span class="interfaceName">PartitionGrouper</span></a></li> +<li><a href="org/apache/kafka/connect/storage/OffsetStorageReader.html" title="interface in org.apache.kafka.connect.storage" target="classFrame"><i>OffsetStorageReader</i></a></li> +<li><a href="org/apache/kafka/clients/producer/Partitioner.html" title="interface in org.apache.kafka.clients.producer" target="classFrame"><i>Partitioner</i></a></li> +<li><a href="org/apache/kafka/streams/processor/PartitionGrouper.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><i>PartitionGrouper</i></a></li> <li><a href="org/apache/kafka/common/PartitionInfo.html" title="class in org.apache.kafka.common" target="classFrame">PartitionInfo</a></li> <li><a href="org/apache/kafka/common/errors/PolicyViolationException.html" title="class in org.apache.kafka.common.errors" target="classFrame">PolicyViolationException</a></li> -<li><a href="org/apache/kafka/streams/kstream/Predicate.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">Predicate</span></a></li> -<li><a href="org/apache/kafka/streams/processor/Processor.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><span class="interfaceName">Processor</span></a></li> -<li><a href="org/apache/kafka/streams/processor/ProcessorContext.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><span class="interfaceName">ProcessorContext</span></a></li> +<li><a href="org/apache/kafka/streams/kstream/Predicate.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>Predicate</i></a></li> +<li><a href="org/apache/kafka/streams/processor/Processor.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><i>Processor</i></a></li> +<li><a href="org/apache/kafka/streams/processor/ProcessorContext.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><i>ProcessorContext</i></a></li> <li><a href="org/apache/kafka/streams/errors/ProcessorStateException.html" title="class in org.apache.kafka.streams.errors" target="classFrame">ProcessorStateException</a></li> -<li><a href="org/apache/kafka/streams/processor/ProcessorSupplier.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><span class="interfaceName">ProcessorSupplier</span></a></li> -<li><a href="org/apache/kafka/clients/producer/Producer.html" title="interface in org.apache.kafka.clients.producer" target="classFrame"><span class="interfaceName">Producer</span></a></li> +<li><a href="org/apache/kafka/streams/processor/ProcessorSupplier.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><i>ProcessorSupplier</i></a></li> +<li><a href="org/apache/kafka/clients/producer/Producer.html" title="interface in org.apache.kafka.clients.producer" target="classFrame"><i>Producer</i></a></li> <li><a href="org/apache/kafka/clients/producer/ProducerConfig.html" title="class in org.apache.kafka.clients.producer" target="classFrame">ProducerConfig</a></li> -<li><a href="org/apache/kafka/clients/producer/ProducerInterceptor.html" title="interface in org.apache.kafka.clients.producer" target="classFrame"><span class="interfaceName">ProducerInterceptor</span></a></li> +<li><a href="org/apache/kafka/clients/producer/ProducerInterceptor.html" title="interface in org.apache.kafka.clients.producer" target="classFrame"><i>ProducerInterceptor</i></a></li> <li><a href="org/apache/kafka/clients/producer/ProducerRecord.html" title="class in org.apache.kafka.clients.producer" target="classFrame">ProducerRecord</a></li> -<li><a href="org/apache/kafka/streams/state/QueryableStoreType.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">QueryableStoreType</span></a></li> +<li><a href="org/apache/kafka/streams/state/QueryableStoreType.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>QueryableStoreType</i></a></li> <li><a href="org/apache/kafka/streams/state/QueryableStoreTypes.html" title="class in org.apache.kafka.streams.state" target="classFrame">QueryableStoreTypes</a></li> <li><a href="org/apache/kafka/clients/consumer/RangeAssignor.html" title="class in org.apache.kafka.clients.consumer" target="classFrame">RangeAssignor</a></li> -<li><a href="org/apache/kafka/streams/state/ReadOnlyKeyValueStore.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">ReadOnlyKeyValueStore</span></a></li> -<li><a href="org/apache/kafka/streams/state/ReadOnlySessionStore.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">ReadOnlySessionStore</span></a></li> -<li><a href="org/apache/kafka/streams/state/ReadOnlyWindowStore.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">ReadOnlyWindowStore</span></a></li> +<li><a href="org/apache/kafka/streams/state/ReadOnlyKeyValueStore.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>ReadOnlyKeyValueStore</i></a></li> +<li><a href="org/apache/kafka/streams/state/ReadOnlySessionStore.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>ReadOnlySessionStore</i></a></li> +<li><a href="org/apache/kafka/streams/state/ReadOnlyWindowStore.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>ReadOnlyWindowStore</i></a></li> <li><a href="org/apache/kafka/common/errors/RebalanceInProgressException.html" title="class in org.apache.kafka.common.errors" target="classFrame">RebalanceInProgressException</a></li> <li><a href="org/apache/kafka/common/errors/RecordBatchTooLargeException.html" title="class in org.apache.kafka.common.errors" target="classFrame">RecordBatchTooLargeException</a></li> <li><a href="org/apache/kafka/clients/producer/RecordMetadata.html" title="class in org.apache.kafka.clients.producer" target="classFrame">RecordMetadata</a></li> <li><a href="org/apache/kafka/common/errors/RecordTooLargeException.html" title="class in org.apache.kafka.common.errors" target="classFrame">RecordTooLargeException</a></li> -<li><a href="org/apache/kafka/streams/kstream/Reducer.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">Reducer</span></a></li> +<li><a href="org/apache/kafka/streams/kstream/Reducer.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>Reducer</i></a></li> <li><a href="org/apache/kafka/common/errors/ReplicaNotAvailableException.html" title="class in org.apache.kafka.common.errors" target="classFrame">ReplicaNotAvailableException</a></li> <li><a href="org/apache/kafka/clients/consumer/RetriableCommitFailedException.html" title="class in org.apache.kafka.clients.consumer" target="classFrame">RetriableCommitFailedException</a></li> <li><a href="org/apache/kafka/common/errors/RetriableException.html" title="class in org.apache.kafka.common.errors" target="classFrame">RetriableException</a></li> <li><a href="org/apache/kafka/connect/errors/RetriableException.html" title="class in org.apache.kafka.connect.errors" target="classFrame">RetriableException</a></li> -<li><a href="org/apache/kafka/streams/state/RocksDBConfigSetter.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">RocksDBConfigSetter</span></a></li> +<li><a href="org/apache/kafka/streams/state/RocksDBConfigSetter.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>RocksDBConfigSetter</i></a></li> <li><a href="org/apache/kafka/clients/consumer/RoundRobinAssignor.html" title="class in org.apache.kafka.clients.consumer" target="classFrame">RoundRobinAssignor</a></li> <li><a href="org/apache/kafka/common/config/SaslConfigs.html" title="class in org.apache.kafka.common.config" target="classFrame">SaslConfigs</a></li> -<li><a href="org/apache/kafka/connect/data/Schema.html" title="interface in org.apache.kafka.connect.data" target="classFrame"><span class="interfaceName">Schema</span></a></li> +<li><a href="org/apache/kafka/connect/data/Schema.html" title="interface in org.apache.kafka.connect.data" target="classFrame"><i>Schema</i></a></li> <li><a href="org/apache/kafka/connect/data/Schema.Type.html" title="enum in org.apache.kafka.connect.data" target="classFrame">Schema.Type</a></li> <li><a href="org/apache/kafka/connect/data/SchemaAndValue.html" title="class in org.apache.kafka.connect.data" target="classFrame">SchemaAndValue</a></li> <li><a href="org/apache/kafka/connect/data/SchemaBuilder.html" title="class in org.apache.kafka.connect.data" target="classFrame">SchemaBuilder</a></li> <li><a href="org/apache/kafka/connect/errors/SchemaBuilderException.html" title="class in org.apache.kafka.connect.errors" target="classFrame">SchemaBuilderException</a></li> <li><a href="org/apache/kafka/connect/data/SchemaProjector.html" title="class in org.apache.kafka.connect.data" target="classFrame">SchemaProjector</a></li> <li><a href="org/apache/kafka/connect/errors/SchemaProjectorException.html" title="class in org.apache.kafka.connect.errors" target="classFrame">SchemaProjectorException</a></li> -<li><a href="org/apache/kafka/common/serialization/Serde.html" title="interface in org.apache.kafka.common.serialization" target="classFrame"><span class="interfaceName">Serde</span></a></li> +<li><a href="org/apache/kafka/common/serialization/Serde.html" title="interface in org.apache.kafka.common.serialization" target="classFrame"><i>Serde</i></a></li> <li><a href="org/apache/kafka/common/serialization/Serdes.html" title="class in org.apache.kafka.common.serialization" target="classFrame">Serdes</a></li> <li><a href="org/apache/kafka/common/serialization/Serdes.ByteArraySerde.html" title="class in org.apache.kafka.common.serialization" target="classFrame">Serdes.ByteArraySerde</a></li> <li><a href="org/apache/kafka/common/serialization/Serdes.ByteBufferSerde.html" title="class in org.apache.kafka.common.serialization" target="classFrame">Serdes.ByteBufferSerde</a></li> @@ -195,46 +194,46 @@ <li><a href="org/apache/kafka/common/serialization/Serdes.StringSerde.html" title="class in org.apache.kafka.common.serialization" target="classFrame">Serdes.StringSerde</a></li> <li><a href="org/apache/kafka/common/serialization/Serdes.WrapperSerde.html" title="class in org.apache.kafka.common.serialization" target="classFrame">Serdes.WrapperSerde</a></li> <li><a href="org/apache/kafka/common/errors/SerializationException.html" title="class in org.apache.kafka.common.errors" target="classFrame">SerializationException</a></li> -<li><a href="org/apache/kafka/common/serialization/Serializer.html" title="interface in org.apache.kafka.common.serialization" target="classFrame"><span class="interfaceName">Serializer</span></a></li> -<li><a href="org/apache/kafka/streams/state/SessionStore.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">SessionStore</span></a></li> +<li><a href="org/apache/kafka/common/serialization/Serializer.html" title="interface in org.apache.kafka.common.serialization" target="classFrame"><i>Serializer</i></a></li> +<li><a href="org/apache/kafka/streams/state/SessionStore.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>SessionStore</i></a></li> <li><a href="org/apache/kafka/streams/kstream/SessionWindows.html" title="class in org.apache.kafka.streams.kstream" target="classFrame">SessionWindows</a></li> <li><a href="org/apache/kafka/connect/sink/SinkConnector.html" title="class in org.apache.kafka.connect.sink" target="classFrame">SinkConnector</a></li> <li><a href="org/apache/kafka/connect/sink/SinkRecord.html" title="class in org.apache.kafka.connect.sink" target="classFrame">SinkRecord</a></li> <li><a href="org/apache/kafka/connect/sink/SinkTask.html" title="class in org.apache.kafka.connect.sink" target="classFrame">SinkTask</a></li> -<li><a href="org/apache/kafka/connect/sink/SinkTaskContext.html" title="interface in org.apache.kafka.connect.sink" target="classFrame"><span class="interfaceName">SinkTaskContext</span></a></li> +<li><a href="org/apache/kafka/connect/sink/SinkTaskContext.html" title="interface in org.apache.kafka.connect.sink" target="classFrame"><i>SinkTaskContext</i></a></li> <li><a href="org/apache/kafka/connect/source/SourceConnector.html" title="class in org.apache.kafka.connect.source" target="classFrame">SourceConnector</a></li> <li><a href="org/apache/kafka/connect/source/SourceRecord.html" title="class in org.apache.kafka.connect.source" target="classFrame">SourceRecord</a></li> <li><a href="org/apache/kafka/connect/source/SourceTask.html" title="class in org.apache.kafka.connect.source" target="classFrame">SourceTask</a></li> -<li><a href="org/apache/kafka/connect/source/SourceTaskContext.html" title="interface in org.apache.kafka.connect.source" target="classFrame"><span class="interfaceName">SourceTaskContext</span></a></li> +<li><a href="org/apache/kafka/connect/source/SourceTaskContext.html" title="interface in org.apache.kafka.connect.source" target="classFrame"><i>SourceTaskContext</i></a></li> <li><a href="org/apache/kafka/common/config/SslConfigs.html" title="class in org.apache.kafka.common.config" target="classFrame">SslConfigs</a></li> -<li><a href="org/apache/kafka/streams/processor/StateRestoreCallback.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><span class="interfaceName">StateRestoreCallback</span></a></li> +<li><a href="org/apache/kafka/streams/processor/StateRestoreCallback.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><i>StateRestoreCallback</i></a></li> <li><a href="org/apache/kafka/streams/state/StateSerdes.html" title="class in org.apache.kafka.streams.state" target="classFrame">StateSerdes</a></li> -<li><a href="org/apache/kafka/streams/processor/StateStore.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><span class="interfaceName">StateStore</span></a></li> -<li><a href="org/apache/kafka/streams/processor/StateStoreSupplier.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><span class="interfaceName">StateStoreSupplier</span></a></li> +<li><a href="org/apache/kafka/streams/processor/StateStore.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><i>StateStore</i></a></li> +<li><a href="org/apache/kafka/streams/processor/StateStoreSupplier.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><i>StateStoreSupplier</i></a></li> <li><a href="org/apache/kafka/streams/state/Stores.html" title="class in org.apache.kafka.streams.state" target="classFrame">Stores</a></li> -<li><a href="org/apache/kafka/streams/state/Stores.InMemoryKeyValueFactory.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">Stores.InMemoryKeyValueFactory</span></a></li> -<li><a href="org/apache/kafka/streams/state/Stores.KeyValueFactory.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">Stores.KeyValueFactory</span></a></li> -<li><a href="org/apache/kafka/streams/state/Stores.PersistentKeyValueFactory.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">Stores.PersistentKeyValueFactory</span></a></li> +<li><a href="org/apache/kafka/streams/state/Stores.InMemoryKeyValueFactory.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>Stores.InMemoryKeyValueFactory</i></a></li> +<li><a href="org/apache/kafka/streams/state/Stores.KeyValueFactory.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>Stores.KeyValueFactory</i></a></li> +<li><a href="org/apache/kafka/streams/state/Stores.PersistentKeyValueFactory.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>Stores.PersistentKeyValueFactory</i></a></li> <li><a href="org/apache/kafka/streams/state/Stores.StoreFactory.html" title="class in org.apache.kafka.streams.state" target="classFrame">Stores.StoreFactory</a></li> <li><a href="org/apache/kafka/streams/state/Stores.ValueFactory.html" title="class in org.apache.kafka.streams.state" target="classFrame">Stores.ValueFactory</a></li> -<li><a href="org/apache/kafka/streams/processor/StreamPartitioner.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><span class="interfaceName">StreamPartitioner</span></a></li> +<li><a href="org/apache/kafka/streams/processor/StreamPartitioner.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><i>StreamPartitioner</i></a></li> <li><a href="org/apache/kafka/streams/StreamsConfig.html" title="class in org.apache.kafka.streams" target="classFrame">StreamsConfig</a></li> <li><a href="org/apache/kafka/streams/StreamsConfig.InternalConfig.html" title="class in org.apache.kafka.streams" target="classFrame">StreamsConfig.InternalConfig</a></li> <li><a href="org/apache/kafka/streams/errors/StreamsException.html" title="class in org.apache.kafka.streams.errors" target="classFrame">StreamsException</a></li> <li><a href="org/apache/kafka/streams/state/StreamsMetadata.html" title="class in org.apache.kafka.streams.state" target="classFrame">StreamsMetadata</a></li> -<li><a href="org/apache/kafka/streams/StreamsMetrics.html" title="interface in org.apache.kafka.streams" target="classFrame"><span class="interfaceName">StreamsMetrics</span></a></li> +<li><a href="org/apache/kafka/streams/StreamsMetrics.html" title="interface in org.apache.kafka.streams" target="classFrame"><i>StreamsMetrics</i></a></li> <li><a href="org/apache/kafka/connect/storage/StringConverter.html" title="class in org.apache.kafka.connect.storage" target="classFrame">StringConverter</a></li> <li><a href="org/apache/kafka/common/serialization/StringDeserializer.html" title="class in org.apache.kafka.common.serialization" target="classFrame">StringDeserializer</a></li> <li><a href="org/apache/kafka/common/serialization/StringSerializer.html" title="class in org.apache.kafka.common.serialization" target="classFrame">StringSerializer</a></li> <li><a href="org/apache/kafka/connect/data/Struct.html" title="class in org.apache.kafka.connect.data" target="classFrame">Struct</a></li> -<li><a href="org/apache/kafka/connect/connector/Task.html" title="interface in org.apache.kafka.connect.connector" target="classFrame"><span class="interfaceName">Task</span></a></li> +<li><a href="org/apache/kafka/connect/connector/Task.html" title="interface in org.apache.kafka.connect.connector" target="classFrame"><i>Task</i></a></li> <li><a href="org/apache/kafka/streams/errors/TaskAssignmentException.html" title="class in org.apache.kafka.streams.errors" target="classFrame">TaskAssignmentException</a></li> <li><a href="org/apache/kafka/streams/processor/TaskId.html" title="class in org.apache.kafka.streams.processor" target="classFrame">TaskId</a></li> <li><a href="org/apache/kafka/streams/errors/TaskIdFormatException.html" title="class in org.apache.kafka.streams.errors" target="classFrame">TaskIdFormatException</a></li> <li><a href="org/apache/kafka/connect/data/Time.html" title="class in org.apache.kafka.connect.data" target="classFrame">Time</a></li> <li><a href="org/apache/kafka/common/errors/TimeoutException.html" title="class in org.apache.kafka.common.errors" target="classFrame">TimeoutException</a></li> <li><a href="org/apache/kafka/connect/data/Timestamp.html" title="class in org.apache.kafka.connect.data" target="classFrame">Timestamp</a></li> -<li><a href="org/apache/kafka/streams/processor/TimestampExtractor.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><span class="interfaceName">TimestampExtractor</span></a></li> +<li><a href="org/apache/kafka/streams/processor/TimestampExtractor.html" title="interface in org.apache.kafka.streams.processor" target="classFrame"><i>TimestampExtractor</i></a></li> <li><a href="org/apache/kafka/streams/kstream/TimeWindows.html" title="class in org.apache.kafka.streams.kstream" target="classFrame">TimeWindows</a></li> <li><a href="org/apache/kafka/common/errors/TopicAuthorizationException.html" title="class in org.apache.kafka.common.errors" target="classFrame">TopicAuthorizationException</a></li> <li><a href="org/apache/kafka/common/errors/TopicExistsException.html" title="class in org.apache.kafka.common.errors" target="classFrame">TopicExistsException</a></li> @@ -243,9 +242,9 @@ <li><a href="org/apache/kafka/streams/processor/TopologyBuilder.AutoOffsetReset.html" title="enum in org.apache.kafka.streams.processor" target="classFrame">TopologyBuilder.AutoOffsetReset</a></li> <li><a href="org/apache/kafka/streams/processor/TopologyBuilder.TopicsInfo.html" title="class in org.apache.kafka.streams.processor" target="classFrame">TopologyBuilder.TopicsInfo</a></li> <li><a href="org/apache/kafka/streams/errors/TopologyBuilderException.html" title="class in org.apache.kafka.streams.errors" target="classFrame">TopologyBuilderException</a></li> -<li><a href="org/apache/kafka/connect/transforms/Transformation.html" title="interface in org.apache.kafka.connect.transforms" target="classFrame"><span class="interfaceName">Transformation</span></a></li> -<li><a href="org/apache/kafka/streams/kstream/Transformer.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">Transformer</span></a></li> -<li><a href="org/apache/kafka/streams/kstream/TransformerSupplier.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">TransformerSupplier</span></a></li> +<li><a href="org/apache/kafka/connect/transforms/Transformation.html" title="interface in org.apache.kafka.connect.transforms" target="classFrame"><i>Transformation</i></a></li> +<li><a href="org/apache/kafka/streams/kstream/Transformer.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>Transformer</i></a></li> +<li><a href="org/apache/kafka/streams/kstream/TransformerSupplier.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>TransformerSupplier</i></a></li> <li><a href="org/apache/kafka/common/errors/UnknownMemberIdException.html" title="class in org.apache.kafka.common.errors" target="classFrame">UnknownMemberIdException</a></li> <li><a href="org/apache/kafka/common/errors/UnknownServerException.html" title="class in org.apache.kafka.common.errors" target="classFrame">UnknownServerException</a></li> <li><a href="org/apache/kafka/common/errors/UnknownTopicOrPartitionException.html" title="class in org.apache.kafka.common.errors" target="classFrame">UnknownTopicOrPartitionException</a></li> @@ -254,17 +253,17 @@ <li><a href="org/apache/kafka/common/errors/UnsupportedSaslMechanismException.html" title="class in org.apache.kafka.common.errors" target="classFrame">UnsupportedSaslMechanismException</a></li> <li><a href="org/apache/kafka/common/errors/UnsupportedVersionException.html" title="class in org.apache.kafka.common.errors" target="classFrame">UnsupportedVersionException</a></li> <li><a href="org/apache/kafka/streams/processor/UsePreviousTimeOnInvalidTimestamp.html" title="class in org.apache.kafka.streams.processor" target="classFrame">UsePreviousTimeOnInvalidTimestamp</a></li> -<li><a href="org/apache/kafka/streams/kstream/ValueJoiner.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">ValueJoiner</span></a></li> -<li><a href="org/apache/kafka/streams/kstream/ValueMapper.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">ValueMapper</span></a></li> -<li><a href="org/apache/kafka/streams/kstream/ValueTransformer.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">ValueTransformer</span></a></li> -<li><a href="org/apache/kafka/streams/kstream/ValueTransformerSupplier.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><span class="interfaceName">ValueTransformerSupplier</span></a></li> +<li><a href="org/apache/kafka/streams/kstream/ValueJoiner.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>ValueJoiner</i></a></li> +<li><a href="org/apache/kafka/streams/kstream/ValueMapper.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>ValueMapper</i></a></li> +<li><a href="org/apache/kafka/streams/kstream/ValueTransformer.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>ValueTransformer</i></a></li> +<li><a href="org/apache/kafka/streams/kstream/ValueTransformerSupplier.html" title="interface in org.apache.kafka.streams.kstream" target="classFrame"><i>ValueTransformerSupplier</i></a></li> <li><a href="org/apache/kafka/common/errors/WakeupException.html" title="class in org.apache.kafka.common.errors" target="classFrame">WakeupException</a></li> <li><a href="org/apache/kafka/streams/processor/WallclockTimestampExtractor.html" title="class in org.apache.kafka.streams.processor" target="classFrame">WallclockTimestampExtractor</a></li> <li><a href="org/apache/kafka/streams/kstream/Window.html" title="class in org.apache.kafka.streams.kstream" target="classFrame">Window</a></li> <li><a href="org/apache/kafka/streams/kstream/Windowed.html" title="class in org.apache.kafka.streams.kstream" target="classFrame">Windowed</a></li> <li><a href="org/apache/kafka/streams/kstream/Windows.html" title="class in org.apache.kafka.streams.kstream" target="classFrame">Windows</a></li> -<li><a href="org/apache/kafka/streams/state/WindowStore.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">WindowStore</span></a></li> -<li><a href="org/apache/kafka/streams/state/WindowStoreIterator.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><span class="interfaceName">WindowStoreIterator</span></a></li> +<li><a href="org/apache/kafka/streams/state/WindowStore.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>WindowStore</i></a></li> +<li><a href="org/apache/kafka/streams/state/WindowStoreIterator.html" title="interface in org.apache.kafka.streams.state" target="classFrame"><i>WindowStoreIterator</i></a></li> </ul> </div> </body>
