You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kafka.apache.org by ij...@apache.org on 2017/11/01 13:29:04 UTC

[51/51] [partial] kafka-site git commit: Add Javadoc for 1.0.0

Add Javadoc for 1.0.0


Project: http://git-wip-us.apache.org/repos/asf/kafka-site/repo
Commit: http://git-wip-us.apache.org/repos/asf/kafka-site/commit/6050b147
Tree: http://git-wip-us.apache.org/repos/asf/kafka-site/tree/6050b147
Diff: http://git-wip-us.apache.org/repos/asf/kafka-site/diff/6050b147

Branch: refs/heads/asf-site
Commit: 6050b147e66ed216b5efaf2fd47277942ad86dde
Parents: ddfe464
Author: Ismael Juma <is...@juma.me.uk>
Authored: Wed Nov 1 13:27:57 2017 +0000
Committer: Ismael Juma <is...@juma.me.uk>
Committed: Wed Nov 1 13:27:57 2017 +0000

----------------------------------------------------------------------
 100/javadoc/allclasses-frame.html               |   420 +
 100/javadoc/allclasses-noframe.html             |   420 +
 100/javadoc/constant-values.html                |  2196 ++++
 100/javadoc/deprecated-list.html                |  1034 ++
 100/javadoc/help-doc.html                       |   223 +
 100/javadoc/index-all.html                      | 10050 +++++++++++++++++
 100/javadoc/index.html                          |    75 +
 .../kafka/clients/admin/AbstractOptions.html    |   296 +
 .../apache/kafka/clients/admin/AdminClient.html |  1180 ++
 .../kafka/clients/admin/AdminClientConfig.html  |   651 ++
 .../clients/admin/AlterConfigsOptions.html      |   304 +
 .../kafka/clients/admin/AlterConfigsResult.html |   258 +
 .../admin/AlterReplicaLogDirsOptions.html       |   249 +
 .../admin/AlterReplicaLogDirsResult.html        |   263 +
 .../org/apache/kafka/clients/admin/Config.html  |   346 +
 .../apache/kafka/clients/admin/ConfigEntry.html |   399 +
 .../kafka/clients/admin/CreateAclsOptions.html  |   251 +
 .../kafka/clients/admin/CreateAclsResult.html   |   260 +
 .../clients/admin/CreatePartitionsOptions.html  |   304 +
 .../clients/admin/CreatePartitionsResult.html   |   260 +
 .../clients/admin/CreateTopicsOptions.html      |   304 +
 .../kafka/clients/admin/CreateTopicsResult.html |   260 +
 .../kafka/clients/admin/DeleteAclsOptions.html  |   251 +
 .../admin/DeleteAclsResult.FilterResult.html    |   259 +
 .../admin/DeleteAclsResult.FilterResults.html   |   243 +
 .../kafka/clients/admin/DeleteAclsResult.html   |   288 +
 .../clients/admin/DeleteTopicsOptions.html      |   251 +
 .../kafka/clients/admin/DeleteTopicsResult.html |   260 +
 .../clients/admin/DescribeAclsOptions.html      |   251 +
 .../kafka/clients/admin/DescribeAclsResult.html |   242 +
 .../clients/admin/DescribeClusterOptions.html   |   251 +
 .../clients/admin/DescribeClusterResult.html    |   276 +
 .../clients/admin/DescribeConfigsOptions.html   |   251 +
 .../clients/admin/DescribeConfigsResult.html    |   260 +
 .../clients/admin/DescribeLogDirsOptions.html   |   251 +
 .../clients/admin/DescribeLogDirsResult.html    |   258 +
 .../admin/DescribeReplicaLogDirsOptions.html    |   251 +
 ...eReplicaLogDirsResult.ReplicaLogDirInfo.html |   295 +
 .../admin/DescribeReplicaLogDirsResult.html     |   277 +
 .../clients/admin/DescribeTopicsOptions.html    |   251 +
 .../clients/admin/DescribeTopicsResult.html     |   260 +
 .../kafka/clients/admin/KafkaAdminClient.html   |   758 ++
 .../kafka/clients/admin/ListTopicsOptions.html  |   311 +
 .../kafka/clients/admin/ListTopicsResult.html   |   274 +
 .../kafka/clients/admin/NewPartitions.html      |   338 +
 .../apache/kafka/clients/admin/NewTopic.html    |   391 +
 .../kafka/clients/admin/TopicDescription.html   |   339 +
 .../kafka/clients/admin/TopicListing.html       |   317 +
 .../kafka/clients/admin/package-frame.html      |    60 +
 .../kafka/clients/admin/package-summary.html    |   380 +
 .../kafka/clients/admin/package-tree.html       |   185 +
 .../clients/consumer/CommitFailedException.html |   274 +
 .../apache/kafka/clients/consumer/Consumer.html |   761 ++
 .../kafka/clients/consumer/ConsumerConfig.html  |  1153 ++
 .../clients/consumer/ConsumerInterceptor.html   |   309 +
 .../consumer/ConsumerRebalanceListener.html     |   334 +
 .../kafka/clients/consumer/ConsumerRecord.html  |   670 ++
 .../kafka/clients/consumer/ConsumerRecords.html |   422 +
 .../consumer/InvalidOffsetException.html        |   312 +
 .../kafka/clients/consumer/KafkaConsumer.html   |  1895 ++++
 .../kafka/clients/consumer/MockConsumer.html    |   998 ++
 .../consumer/NoOffsetForPartitionException.html |   356 +
 .../clients/consumer/OffsetAndMetadata.html     |   375 +
 .../clients/consumer/OffsetAndTimestamp.html    |   336 +
 .../clients/consumer/OffsetCommitCallback.html  |   244 +
 .../consumer/OffsetOutOfRangeException.html     |   328 +
 .../clients/consumer/OffsetResetStrategy.html   |   351 +
 .../kafka/clients/consumer/RangeAssignor.html   |   330 +
 .../RetriableCommitFailedException.html         |   347 +
 .../clients/consumer/RoundRobinAssignor.html    |   357 +
 .../kafka/clients/consumer/StickyAssignor.html  |   492 +
 .../kafka/clients/consumer/package-frame.html   |    48 +
 .../kafka/clients/consumer/package-summary.html |   290 +
 .../kafka/clients/consumer/package-tree.html    |   215 +
 .../producer/BufferExhaustedException.html      |   272 +
 .../apache/kafka/clients/producer/Callback.html |   253 +
 .../kafka/clients/producer/KafkaProducer.html   |  1015 ++
 .../kafka/clients/producer/MockProducer.html    |   829 ++
 .../kafka/clients/producer/Partitioner.html     |   276 +
 .../apache/kafka/clients/producer/Producer.html |   445 +
 .../kafka/clients/producer/ProducerConfig.html  |  1047 ++
 .../clients/producer/ProducerInterceptor.html   |   333 +
 .../kafka/clients/producer/ProducerRecord.html  |   604 +
 .../kafka/clients/producer/RecordMetadata.html  |   537 +
 .../kafka/clients/producer/package-frame.html   |    35 +
 .../kafka/clients/producer/package-summary.html |   220 +
 .../kafka/clients/producer/package-tree.html    |   180 +
 .../org/apache/kafka/common/Cluster.html        |   630 ++
 .../apache/kafka/common/ClusterResource.html    |   300 +
 .../kafka/common/ClusterResourceListener.html   |   252 +
 .../org/apache/kafka/common/Configurable.html   |   231 +
 .../org/apache/kafka/common/KafkaException.html |   308 +
 .../kafka/common/KafkaFuture.BiConsumer.html    |   278 +
 .../kafka/common/KafkaFuture.Function.html      |   276 +
 .../org/apache/kafka/common/KafkaFuture.html    |   559 +
 100/javadoc/org/apache/kafka/common/Metric.html |   259 +
 .../org/apache/kafka/common/MetricName.html     |   414 +
 .../apache/kafka/common/MetricNameTemplate.html |   387 +
 100/javadoc/org/apache/kafka/common/Node.html   |   462 +
 .../org/apache/kafka/common/PartitionInfo.html  |   402 +
 .../org/apache/kafka/common/TopicPartition.html |   345 +
 .../apache/kafka/common/TopicPartitionInfo.html |   358 +
 .../kafka/common/TopicPartitionReplica.html     |   360 +
 .../kafka/common/acl/AccessControlEntry.html    |   423 +
 .../common/acl/AccessControlEntryFilter.html    |   498 +
 .../org/apache/kafka/common/acl/AclBinding.html |   385 +
 .../kafka/common/acl/AclBindingFilter.html      |   457 +
 .../apache/kafka/common/acl/AclOperation.html   |   602 +
 .../kafka/common/acl/AclPermissionType.html     |   451 +
 .../apache/kafka/common/acl/package-frame.html  |    28 +
 .../kafka/common/acl/package-summary.html       |   183 +
 .../apache/kafka/common/acl/package-tree.html   |   151 +
 .../annotation/InterfaceStability.Evolving.html |   164 +
 .../annotation/InterfaceStability.Stable.html   |   169 +
 .../annotation/InterfaceStability.Unstable.html |   164 +
 .../common/annotation/InterfaceStability.html   |   272 +
 .../kafka/common/annotation/package-frame.html  |    26 +
 .../common/annotation/package-summary.html      |   172 +
 .../kafka/common/annotation/package-tree.html   |   141 +
 .../kafka/common/config/AbstractConfig.html     |   696 ++
 .../org/apache/kafka/common/config/Config.html  |   269 +
 .../common/config/ConfigDef.ConfigKey.html      |   489 +
 .../common/config/ConfigDef.Importance.html     |   356 +
 .../common/config/ConfigDef.NonEmptyString.html |   308 +
 .../kafka/common/config/ConfigDef.Range.html    |   313 +
 .../common/config/ConfigDef.Recommender.html    |   265 +
 .../kafka/common/config/ConfigDef.Type.html     |   428 +
 .../common/config/ConfigDef.ValidList.html      |   287 +
 .../common/config/ConfigDef.ValidString.html    |   287 +
 .../common/config/ConfigDef.Validator.html      |   240 +
 .../kafka/common/config/ConfigDef.Width.html    |   368 +
 .../apache/kafka/common/config/ConfigDef.html   |  1448 +++
 .../kafka/common/config/ConfigException.html    |   301 +
 .../common/config/ConfigResource.Type.html      |   356 +
 .../kafka/common/config/ConfigResource.html     |   371 +
 .../apache/kafka/common/config/ConfigValue.html |   442 +
 .../apache/kafka/common/config/SaslConfigs.html |   765 ++
 .../apache/kafka/common/config/SslConfigs.html  |  1009 ++
 .../apache/kafka/common/config/TopicConfig.html |  1046 ++
 .../kafka/common/config/package-frame.html      |    48 +
 .../kafka/common/config/package-summary.html    |   274 +
 .../kafka/common/config/package-tree.html       |   184 +
 .../kafka/common/errors/ApiException.html       |   352 +
 .../common/errors/AuthenticationException.html  |   312 +
 .../common/errors/AuthorizationException.html   |   300 +
 .../errors/BrokerNotAvailableException.html     |   296 +
 .../errors/ClusterAuthorizationException.html   |   301 +
 .../errors/ConcurrentTransactionsException.html |   282 +
 .../common/errors/ControllerMovedException.html |   296 +
 .../CoordinatorLoadInProgressException.html     |   307 +
 .../CoordinatorNotAvailableException.html       |   342 +
 .../common/errors/CorruptRecordException.html   |   327 +
 .../common/errors/DisconnectException.html      |   362 +
 .../errors/DuplicateSequenceException.html      |   282 +
 .../errors/GroupAuthorizationException.html     |   321 +
 .../GroupCoordinatorNotAvailableException.html  |   382 +
 .../errors/GroupLoadInProgressException.html    |   343 +
 .../errors/IllegalGenerationException.html      |   320 +
 .../errors/IllegalSaslStateException.html       |   304 +
 .../InconsistentGroupProtocolException.html     |   296 +
 .../kafka/common/errors/InterruptException.html |   297 +
 .../InvalidCommitOffsetSizeException.html       |   296 +
 .../errors/InvalidConfigurationException.html   |   296 +
 .../errors/InvalidFetchSizeException.html       |   296 +
 .../common/errors/InvalidGroupIdException.html  |   296 +
 .../common/errors/InvalidMetadataException.html |   330 +
 .../common/errors/InvalidOffsetException.html   |   303 +
 .../errors/InvalidPartitionsException.html      |   296 +
 .../errors/InvalidPidMappingException.html      |   282 +
 .../InvalidReplicaAssignmentException.html      |   296 +
 .../InvalidReplicationFactorException.html      |   296 +
 .../common/errors/InvalidRequestException.html  |   299 +
 .../errors/InvalidRequiredAcksException.html    |   282 +
 .../errors/InvalidSessionTimeoutException.html  |   296 +
 .../errors/InvalidTimestampException.html       |   297 +
 .../common/errors/InvalidTopicException.html    |   324 +
 .../common/errors/InvalidTxnStateException.html |   282 +
 .../errors/InvalidTxnTimeoutException.html      |   298 +
 .../common/errors/KafkaStorageException.html    |   339 +
 .../errors/LeaderNotAvailableException.html     |   308 +
 .../common/errors/LogDirNotFoundException.html  |   309 +
 .../kafka/common/errors/NetworkException.html   |   332 +
 .../common/errors/NotControllerException.html   |   301 +
 .../common/errors/NotCoordinatorException.html  |   306 +
 .../errors/NotCoordinatorForGroupException.html |   343 +
 .../NotEnoughReplicasAfterAppendException.html  |   289 +
 .../errors/NotEnoughReplicasException.html      |   326 +
 .../errors/NotLeaderForPartitionException.html  |   331 +
 .../common/errors/OffsetMetadataTooLarge.html   |   321 +
 .../errors/OffsetOutOfRangeException.html       |   303 +
 .../errors/OperationNotAttemptedException.html  |   284 +
 .../errors/OutOfOrderSequenceException.html     |   292 +
 .../common/errors/PolicyViolationException.html |   297 +
 .../common/errors/ProducerFencedException.html  |   286 +
 .../errors/ReassignmentInProgressException.html |   297 +
 .../errors/RebalanceInProgressException.html    |   320 +
 .../errors/RecordBatchTooLargeException.html    |   321 +
 .../common/errors/RecordTooLargeException.html  |   369 +
 .../errors/ReplicaNotAvailableException.html    |   308 +
 .../kafka/common/errors/RetriableException.html |   325 +
 .../errors/SaslAuthenticationException.html     |   314 +
 .../errors/SecurityDisabledException.html       |   297 +
 .../common/errors/SerializationException.html   |   347 +
 .../errors/SslAuthenticationException.html      |   310 +
 .../kafka/common/errors/TimeoutException.html   |   326 +
 .../errors/TopicAuthorizationException.html     |   333 +
 .../common/errors/TopicExistsException.html     |   296 +
 .../TransactionCoordinatorFencedException.html  |   296 +
 .../TransactionalIdAuthorizationException.html  |   287 +
 .../common/errors/UnknownMemberIdException.html |   320 +
 .../errors/UnknownProducerIdException.html      |   291 +
 .../common/errors/UnknownServerException.html   |   322 +
 .../UnknownTopicOrPartitionException.html       |   334 +
 .../UnsupportedForMessageFormatException.html   |   298 +
 .../UnsupportedSaslMechanismException.html      |   303 +
 .../errors/UnsupportedVersionException.html     |   304 +
 .../kafka/common/errors/WakeupException.html    |   274 +
 .../kafka/common/errors/package-frame.html      |    94 +
 .../kafka/common/errors/package-summary.html    |   544 +
 .../kafka/common/errors/package-tree.html       |   246 +
 .../org/apache/kafka/common/header/Header.html  |   232 +
 .../org/apache/kafka/common/header/Headers.html |   360 +
 .../kafka/common/header/package-frame.html      |    21 +
 .../kafka/common/header/package-summary.html    |   144 +
 .../kafka/common/header/package-tree.html       |   136 +
 .../org/apache/kafka/common/package-frame.html  |    41 +
 .../apache/kafka/common/package-summary.html    |   254 +
 .../org/apache/kafka/common/package-tree.html   |   165 +
 .../apache/kafka/common/resource/Resource.html  |   444 +
 .../kafka/common/resource/ResourceFilter.html   |   456 +
 .../kafka/common/resource/ResourceType.html     |   484 +
 .../kafka/common/resource/package-frame.html    |    25 +
 .../kafka/common/resource/package-summary.html  |   165 +
 .../kafka/common/resource/package-tree.html     |   148 +
 .../security/auth/AuthenticationContext.html    |   244 +
 .../security/auth/DefaultPrincipalBuilder.html  |   348 +
 .../common/security/auth/KafkaPrincipal.html    |   454 +
 .../security/auth/KafkaPrincipalBuilder.html    |   236 +
 .../auth/PlaintextAuthenticationContext.html    |   303 +
 .../common/security/auth/PrincipalBuilder.html  |   292 +
 .../auth/SaslAuthenticationContext.html         |   320 +
 .../common/security/auth/SecurityProtocol.html  |   472 +
 .../security/auth/SslAuthenticationContext.html |   318 +
 .../common/security/auth/package-frame.html     |    34 +
 .../common/security/auth/package-summary.html   |   205 +
 .../common/security/auth/package-tree.html      |   161 +
 .../serialization/ByteArrayDeserializer.html    |   336 +
 .../serialization/ByteArraySerializer.html      |   342 +
 .../serialization/ByteBufferDeserializer.html   |   336 +
 .../serialization/ByteBufferSerializer.html     |   342 +
 .../common/serialization/BytesDeserializer.html |   336 +
 .../common/serialization/BytesSerializer.html   |   342 +
 .../common/serialization/Deserializer.html      |   295 +
 .../serialization/DoubleDeserializer.html       |   336 +
 .../common/serialization/DoubleSerializer.html  |   342 +
 .../ExtendedDeserializer.Wrapper.html           |   399 +
 .../serialization/ExtendedDeserializer.html     |   280 +
 .../ExtendedSerializer.Wrapper.html             |   409 +
 .../serialization/ExtendedSerializer.html       |   282 +
 .../common/serialization/FloatDeserializer.html |   336 +
 .../common/serialization/FloatSerializer.html   |   342 +
 .../serialization/IntegerDeserializer.html      |   336 +
 .../common/serialization/IntegerSerializer.html |   342 +
 .../common/serialization/LongDeserializer.html  |   336 +
 .../common/serialization/LongSerializer.html    |   342 +
 .../kafka/common/serialization/Serde.html       |   294 +
 .../serialization/Serdes.ByteArraySerde.html    |   255 +
 .../serialization/Serdes.ByteBufferSerde.html   |   255 +
 .../common/serialization/Serdes.BytesSerde.html |   255 +
 .../serialization/Serdes.DoubleSerde.html       |   255 +
 .../common/serialization/Serdes.FloatSerde.html |   255 +
 .../serialization/Serdes.IntegerSerde.html      |   255 +
 .../common/serialization/Serdes.LongSerde.html  |   255 +
 .../common/serialization/Serdes.ShortSerde.html |   255 +
 .../serialization/Serdes.StringSerde.html       |   255 +
 .../serialization/Serdes.WrapperSerde.html      |   357 +
 .../kafka/common/serialization/Serdes.html      |   465 +
 .../kafka/common/serialization/Serializer.html  |   302 +
 .../common/serialization/ShortDeserializer.html |   336 +
 .../common/serialization/ShortSerializer.html   |   342 +
 .../serialization/StringDeserializer.html       |   338 +
 .../common/serialization/StringSerializer.html  |   344 +
 .../common/serialization/package-frame.html     |    58 +
 .../common/serialization/package-summary.html   |   309 +
 .../common/serialization/package-tree.html      |   190 +
 .../kafka/connect/connector/ConnectRecord.html  |   448 +
 .../kafka/connect/connector/Connector.html      |   531 +
 .../connect/connector/ConnectorContext.html     |   246 +
 .../apache/kafka/connect/connector/Task.html    |   277 +
 .../kafka/connect/connector/package-frame.html  |    26 +
 .../connect/connector/package-summary.html      |   175 +
 .../kafka/connect/connector/package-tree.html   |   141 +
 .../kafka/connect/data/ConnectSchema.html       |   746 ++
 .../org/apache/kafka/connect/data/Date.html     |   375 +
 .../org/apache/kafka/connect/data/Decimal.html  |   402 +
 .../org/apache/kafka/connect/data/Field.html    |   357 +
 .../apache/kafka/connect/data/Schema.Type.html  |   547 +
 .../org/apache/kafka/connect/data/Schema.html   |   731 ++
 .../kafka/connect/data/SchemaAndValue.html      |   371 +
 .../kafka/connect/data/SchemaBuilder.html       |  1030 ++
 .../kafka/connect/data/SchemaProjector.html     |   291 +
 .../org/apache/kafka/connect/data/Struct.html   |   681 ++
 .../org/apache/kafka/connect/data/Time.html     |   375 +
 .../apache/kafka/connect/data/Timestamp.html    |   373 +
 .../kafka/connect/data/package-frame.html       |    37 +
 .../kafka/connect/data/package-summary.html     |   236 +
 .../apache/kafka/connect/data/package-tree.html |   160 +
 .../connect/errors/AlreadyExistsException.html  |   302 +
 .../kafka/connect/errors/ConnectException.html  |   301 +
 .../kafka/connect/errors/DataException.html     |   306 +
 .../errors/IllegalWorkerStateException.html     |   302 +
 .../kafka/connect/errors/NotFoundException.html |   302 +
 .../connect/errors/RetriableException.html      |   302 +
 .../connect/errors/SchemaBuilderException.html  |   306 +
 .../errors/SchemaProjectorException.html        |   306 +
 .../kafka/connect/errors/package-frame.html     |    27 +
 .../kafka/connect/errors/package-summary.html   |   180 +
 .../kafka/connect/errors/package-tree.html      |   164 +
 .../kafka/connect/sink/SinkConnector.html       |   305 +
 .../apache/kafka/connect/sink/SinkRecord.html   |   424 +
 .../org/apache/kafka/connect/sink/SinkTask.html |   581 +
 .../kafka/connect/sink/SinkTaskContext.html     |   362 +
 .../kafka/connect/sink/package-frame.html       |    26 +
 .../kafka/connect/sink/package-summary.html     |   172 +
 .../apache/kafka/connect/sink/package-tree.html |   149 +
 .../kafka/connect/source/SourceConnector.html   |   264 +
 .../kafka/connect/source/SourceRecord.html      |   502 +
 .../apache/kafka/connect/source/SourceTask.html |   455 +
 .../kafka/connect/source/SourceTaskContext.html |   224 +
 .../kafka/connect/source/package-frame.html     |    26 +
 .../kafka/connect/source/package-summary.html   |   175 +
 .../kafka/connect/source/package-tree.html      |   149 +
 .../apache/kafka/connect/storage/Converter.html |   289 +
 .../connect/storage/OffsetStorageReader.html    |   272 +
 .../kafka/connect/storage/StringConverter.html  |   354 +
 .../kafka/connect/storage/package-frame.html    |    25 +
 .../kafka/connect/storage/package-summary.html  |   167 +
 .../kafka/connect/storage/package-tree.html     |   140 +
 .../connect/transforms/Transformation.html      |   281 +
 .../kafka/connect/transforms/package-frame.html |    20 +
 .../connect/transforms/package-summary.html     |   142 +
 .../kafka/connect/transforms/package-tree.html  |   144 +
 .../kafka/connect/util/ConnectorUtils.html      |   288 +
 .../kafka/connect/util/package-frame.html       |    20 +
 .../kafka/connect/util/package-summary.html     |   142 +
 .../apache/kafka/connect/util/package-tree.html |   135 +
 .../AlterConfigPolicy.RequestMetadata.html      |   314 +
 .../kafka/server/policy/AlterConfigPolicy.html  |   283 +
 .../CreateTopicPolicy.RequestMetadata.html      |   384 +
 .../kafka/server/policy/CreateTopicPolicy.html  |   282 +
 .../kafka/server/policy/package-frame.html      |    26 +
 .../kafka/server/policy/package-summary.html    |   171 +
 .../kafka/server/policy/package-tree.html       |   151 +
 .../org/apache/kafka/streams/Consumed.html      |   567 +
 .../kafka/streams/KafkaClientSupplier.html      |   280 +
 .../kafka/streams/KafkaStreams.State.html       |   457 +
 .../streams/KafkaStreams.StateListener.html     |   234 +
 .../org/apache/kafka/streams/KafkaStreams.html  |   958 ++
 .../org/apache/kafka/streams/KeyValue.html      |   411 +
 .../apache/kafka/streams/StreamsBuilder.html    |   867 ++
 .../streams/StreamsConfig.InternalConfig.html   |   279 +
 .../org/apache/kafka/streams/StreamsConfig.html |  1571 +++
 .../apache/kafka/streams/StreamsMetrics.html    |   456 +
 .../kafka/streams/Topology.AutoOffsetReset.html |   346 +
 .../org/apache/kafka/streams/Topology.html      |  1242 ++
 .../TopologyDescription.GlobalStore.html        |   256 +
 .../kafka/streams/TopologyDescription.Node.html |   279 +
 .../streams/TopologyDescription.Processor.html  |   243 +
 .../kafka/streams/TopologyDescription.Sink.html |   243 +
 .../streams/TopologyDescription.Source.html     |   243 +
 .../TopologyDescription.Subtopology.html        |   255 +
 .../kafka/streams/TopologyDescription.html      |   306 +
 .../streams/errors/BrokerNotFoundException.html |   304 +
 ...nHandler.DeserializationHandlerResponse.html |   399 +
 .../errors/DeserializationExceptionHandler.html |   271 +
 .../errors/InvalidStateStoreException.html      |   308 +
 .../kafka/streams/errors/LockException.html     |   303 +
 .../errors/LogAndContinueExceptionHandler.html  |   328 +
 .../errors/LogAndFailExceptionHandler.html      |   328 +
 .../streams/errors/ProcessorStateException.html |   303 +
 .../kafka/streams/errors/StreamsException.html  |   301 +
 .../streams/errors/TaskAssignmentException.html |   304 +
 .../streams/errors/TaskIdFormatException.html   |   304 +
 .../streams/errors/TaskMigratedException.html   |   309 +
 .../errors/TopologyBuilderException.html        |   315 +
 .../kafka/streams/errors/TopologyException.html |   303 +
 .../kafka/streams/errors/package-frame.html     |    42 +
 .../kafka/streams/errors/package-summary.html   |   263 +
 .../kafka/streams/errors/package-tree.html      |   185 +
 .../kafka/streams/kstream/Aggregator.html       |   259 +
 .../kafka/streams/kstream/ForeachAction.html    |   246 +
 .../kafka/streams/kstream/GlobalKTable.html     |   212 +
 .../kafka/streams/kstream/Initializer.html      |   242 +
 .../kafka/streams/kstream/JoinWindows.html      |   555 +
 .../apache/kafka/streams/kstream/Joined.html    |   446 +
 .../kafka/streams/kstream/KGroupedStream.html   |  2364 ++++
 .../kafka/streams/kstream/KGroupedTable.html    |  1360 +++
 .../apache/kafka/streams/kstream/KStream.html   |  3817 +++++++
 .../kafka/streams/kstream/KStreamBuilder.html   |  1995 ++++
 .../apache/kafka/streams/kstream/KTable.html    |  3467 ++++++
 .../kafka/streams/kstream/KeyValueMapper.html   |   262 +
 .../kafka/streams/kstream/Materialized.html     |   667 ++
 .../apache/kafka/streams/kstream/Merger.html    |   242 +
 .../apache/kafka/streams/kstream/Predicate.html |   249 +
 .../apache/kafka/streams/kstream/Printed.html   |   443 +
 .../apache/kafka/streams/kstream/Produced.html  |   548 +
 .../apache/kafka/streams/kstream/Reducer.html   |   254 +
 .../kafka/streams/kstream/Serialized.html       |   393 +
 .../streams/kstream/SessionWindowedKStream.html |   544 +
 .../kafka/streams/kstream/SessionWindows.html   |   355 +
 .../streams/kstream/TimeWindowedKStream.html    |   548 +
 .../kafka/streams/kstream/TimeWindows.html      |   520 +
 .../kafka/streams/kstream/Transformer.html      |   351 +
 .../streams/kstream/TransformerSupplier.html    |   242 +
 .../kafka/streams/kstream/UnlimitedWindows.html |   469 +
 .../kafka/streams/kstream/ValueJoiner.html      |   259 +
 .../kafka/streams/kstream/ValueMapper.html      |   249 +
 .../kafka/streams/kstream/ValueTransformer.html |   352 +
 .../kstream/ValueTransformerSupplier.html       |   240 +
 .../apache/kafka/streams/kstream/Window.html    |   438 +
 .../apache/kafka/streams/kstream/Windowed.html  |   366 +
 .../apache/kafka/streams/kstream/Windows.html   |   429 +
 .../kafka/streams/kstream/package-frame.html    |    55 +
 .../kafka/streams/kstream/package-summary.html  |   353 +
 .../kafka/streams/kstream/package-tree.html     |   177 +
 .../org/apache/kafka/streams/package-frame.html |    44 +
 .../apache/kafka/streams/package-summary.html   |   274 +
 .../org/apache/kafka/streams/package-tree.html  |   174 +
 ...bstractNotifyingBatchingRestoreCallback.html |   402 +
 .../AbstractNotifyingRestoreCallback.html       |   378 +
 .../streams/processor/AbstractProcessor.html    |   375 +
 .../processor/BatchingStateRestoreCallback.html |   247 +
 .../kafka/streams/processor/Cancellable.html    |   227 +
 .../processor/DefaultPartitionGrouper.html      |   312 +
 .../processor/FailOnInvalidTimestamp.html       |   342 +
 .../processor/LogAndSkipOnInvalidTimestamp.html |   343 +
 .../streams/processor/PartitionGrouper.html     |   249 +
 .../kafka/streams/processor/Processor.html      |   311 +
 .../streams/processor/ProcessorContext.html     |   693 ++
 .../streams/processor/ProcessorSupplier.html    |   236 +
 .../streams/processor/PunctuationType.html      |   349 +
 .../kafka/streams/processor/Punctuator.html     |   231 +
 .../streams/processor/StateRestoreCallback.html |   232 +
 .../streams/processor/StateRestoreListener.html |   315 +
 .../kafka/streams/processor/StateStore.html     |   338 +
 .../streams/processor/StateStoreSupplier.html   |   305 +
 .../streams/processor/StreamPartitioner.html    |   268 +
 .../apache/kafka/streams/processor/TaskId.html  |   466 +
 .../kafka/streams/processor/TaskMetadata.html   |   336 +
 .../kafka/streams/processor/ThreadMetadata.html |   366 +
 .../streams/processor/TimestampExtractor.html   |   252 +
 .../TopologyBuilder.AutoOffsetReset.html        |   344 +
 .../processor/TopologyBuilder.TopicsInfo.html   |   394 +
 .../streams/processor/TopologyBuilder.html      |  1680 +++
 .../UsePreviousTimeOnInvalidTimestamp.html      |   342 +
 .../processor/WallclockTimestampExtractor.html  |   301 +
 .../kafka/streams/processor/package-frame.html  |    53 +
 .../streams/processor/package-summary.html      |   335 +
 .../kafka/streams/processor/package-tree.html   |   179 +
 .../apache/kafka/streams/state/HostInfo.html    |   348 +
 .../state/KeyValueBytesStoreSupplier.html       |   192 +
 .../kafka/streams/state/KeyValueIterator.html   |   270 +
 .../kafka/streams/state/KeyValueStore.html      |   337 +
 .../kafka/streams/state/QueryableStoreType.html |   268 +
 .../streams/state/QueryableStoreTypes.html      |   328 +
 .../streams/state/ReadOnlyKeyValueStore.html    |   326 +
 .../streams/state/ReadOnlySessionStore.html     |   281 +
 .../streams/state/ReadOnlyWindowStore.html      |   313 +
 .../streams/state/RocksDBConfigSetter.html      |   234 +
 .../state/SessionBytesStoreSupplier.html        |   240 +
 .../kafka/streams/state/SessionStore.html       |   357 +
 .../apache/kafka/streams/state/StateSerdes.html |   546 +
 .../kafka/streams/state/StoreBuilder.html       |   357 +
 .../kafka/streams/state/StoreSupplier.html      |   276 +
 .../state/Stores.InMemoryKeyValueFactory.html   |   316 +
 .../streams/state/Stores.KeyValueFactory.html   |   254 +
 .../state/Stores.PersistentKeyValueFactory.html |   364 +
 .../streams/state/Stores.StoreFactory.html      |   424 +
 .../streams/state/Stores.ValueFactory.html      |   429 +
 .../org/apache/kafka/streams/state/Stores.html  |   585 +
 .../kafka/streams/state/StreamsMetadata.html    |   422 +
 .../streams/state/WindowBytesStoreSupplier.html |   303 +
 .../apache/kafka/streams/state/WindowStore.html |   289 +
 .../streams/state/WindowStoreIterator.html      |   254 +
 .../kafka/streams/state/package-frame.html      |    47 +
 .../kafka/streams/state/package-summary.html    |   294 +
 .../kafka/streams/state/package-tree.html       |   202 +
 100/javadoc/overview-frame.html                 |    46 +
 100/javadoc/overview-summary.html               |   236 +
 100/javadoc/overview-tree.html                  |   716 ++
 100/javadoc/package-list                        |    26 +
 100/javadoc/script.js                           |    30 +
 100/javadoc/serialized-form.html                |  1108 ++
 100/javadoc/stylesheet.css                      |   574 +
 494 files changed, 189629 insertions(+)
----------------------------------------------------------------------