You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kafka.apache.org by da...@apache.org on 2017/09/13 12:25:26 UTC

[09/10] kafka-site git commit: Update site for 0.11.0.1 release

Update site for 0.11.0.1 release


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

Branch: refs/heads/asf-site
Commit: a1278d06c9b1a15047c447c36d910e26897b30da
Parents: 9ab5987
Author: Damian Guy <da...@gmail.com>
Authored: Wed Sep 13 13:15:02 2017 +0100
Committer: Damian Guy <da...@gmail.com>
Committed: Wed Sep 13 13:15:02 2017 +0100

----------------------------------------------------------------------
 0110/api.html                                   |   8 +-
 0110/configuration.html                         |  18 +-
 0110/connect.html                               |  13 +-
 0110/documentation/streams/quickstart.html      |  19 +
 0110/documentation/streams/tutorial.html        |  19 +
 0110/generated/topic_config.html                |   2 +-
 0110/images/icons/architecture--white.png       | Bin 0 -> 812 bytes
 0110/images/icons/architecture.png              | Bin 0 -> 818 bytes
 0110/images/icons/documentation--white.png      | Bin 0 -> 1758 bytes
 0110/images/icons/documentation.png             | Bin 0 -> 1642 bytes
 0110/images/icons/tutorials--white.png          | Bin 0 -> 1047 bytes
 0110/images/icons/tutorials.png                 | Bin 0 -> 985 bytes
 .../streams-cache-and-commit-interval.png       | Bin 0 -> 38648 bytes
 0110/images/streams-welcome.png                 | Bin 0 -> 80530 bytes
 0110/introduction.html                          |   5 +-
 0110/javadoc/allclasses-frame.html              |   6 +-
 0110/javadoc/allclasses-noframe.html            |   6 +-
 0110/javadoc/constant-values.html               |  12 +-
 0110/javadoc/deprecated-list.html               |   8 +-
 0110/javadoc/help-doc.html                      |   8 +-
 0110/javadoc/index-all.html                     |  28 +-
 0110/javadoc/index.html                         |   4 +-
 .../apache/kafka/clients/admin/AdminClient.html |   8 +-
 .../kafka/clients/admin/AdminClientConfig.html  |   8 +-
 .../clients/admin/AlterConfigsOptions.html      |   8 +-
 .../kafka/clients/admin/AlterConfigsResult.html |   8 +-
 .../org/apache/kafka/clients/admin/Config.html  |   8 +-
 .../apache/kafka/clients/admin/ConfigEntry.html |  29 +-
 .../kafka/clients/admin/CreateAclsOptions.html  |   8 +-
 .../kafka/clients/admin/CreateAclsResult.html   |   8 +-
 .../clients/admin/CreateTopicsOptions.html      |   8 +-
 .../kafka/clients/admin/CreateTopicsResult.html |   8 +-
 .../kafka/clients/admin/DeleteAclsOptions.html  |   8 +-
 .../admin/DeleteAclsResult.FilterResult.html    |   8 +-
 .../admin/DeleteAclsResult.FilterResults.html   |   8 +-
 .../kafka/clients/admin/DeleteAclsResult.html   |   8 +-
 .../clients/admin/DeleteTopicsOptions.html      |   8 +-
 .../kafka/clients/admin/DeleteTopicsResult.html |   8 +-
 .../clients/admin/DescribeAclsOptions.html      |   8 +-
 .../kafka/clients/admin/DescribeAclsResult.html |   8 +-
 .../clients/admin/DescribeClusterOptions.html   |   8 +-
 .../clients/admin/DescribeClusterResult.html    |   8 +-
 .../clients/admin/DescribeConfigsOptions.html   |   8 +-
 .../clients/admin/DescribeConfigsResult.html    |   8 +-
 .../clients/admin/DescribeTopicsOptions.html    |   8 +-
 .../clients/admin/DescribeTopicsResult.html     |   8 +-
 .../kafka/clients/admin/KafkaAdminClient.html   |   8 +-
 .../kafka/clients/admin/ListTopicsOptions.html  |   8 +-
 .../kafka/clients/admin/ListTopicsResult.html   |   8 +-
 .../apache/kafka/clients/admin/NewTopic.html    |   8 +-
 .../kafka/clients/admin/TopicDescription.html   |   8 +-
 .../kafka/clients/admin/TopicListing.html       |   8 +-
 .../kafka/clients/admin/package-frame.html      |   6 +-
 .../kafka/clients/admin/package-summary.html    |   8 +-
 .../kafka/clients/admin/package-tree.html       |   8 +-
 .../clients/consumer/CommitFailedException.html |   8 +-
 .../apache/kafka/clients/consumer/Consumer.html |   8 +-
 .../kafka/clients/consumer/ConsumerConfig.html  |   8 +-
 .../clients/consumer/ConsumerInterceptor.html   |   8 +-
 .../consumer/ConsumerRebalanceListener.html     |  34 +-
 .../kafka/clients/consumer/ConsumerRecord.html  |   8 +-
 .../kafka/clients/consumer/ConsumerRecords.html |   8 +-
 .../consumer/InvalidOffsetException.html        |   8 +-
 .../kafka/clients/consumer/KafkaConsumer.html   |   8 +-
 .../kafka/clients/consumer/MockConsumer.html    |   8 +-
 .../consumer/NoOffsetForPartitionException.html |   8 +-
 .../clients/consumer/OffsetAndMetadata.html     |   8 +-
 .../clients/consumer/OffsetAndTimestamp.html    |   8 +-
 .../clients/consumer/OffsetCommitCallback.html  |   8 +-
 .../consumer/OffsetOutOfRangeException.html     |   8 +-
 .../clients/consumer/OffsetResetStrategy.html   |   8 +-
 .../kafka/clients/consumer/RangeAssignor.html   |   8 +-
 .../RetriableCommitFailedException.html         |   8 +-
 .../clients/consumer/RoundRobinAssignor.html    |   8 +-
 .../kafka/clients/consumer/StickyAssignor.html  |   8 +-
 .../kafka/clients/consumer/package-frame.html   |   6 +-
 .../kafka/clients/consumer/package-summary.html |   8 +-
 .../kafka/clients/consumer/package-tree.html    |   8 +-
 .../producer/BufferExhaustedException.html      |   8 +-
 .../apache/kafka/clients/producer/Callback.html |   8 +-
 .../kafka/clients/producer/KafkaProducer.html   |  85 ++-
 .../kafka/clients/producer/MockProducer.html    |   8 +-
 .../kafka/clients/producer/Partitioner.html     |   8 +-
 .../apache/kafka/clients/producer/Producer.html |   8 +-
 .../kafka/clients/producer/ProducerConfig.html  |   8 +-
 .../clients/producer/ProducerInterceptor.html   |   8 +-
 .../kafka/clients/producer/ProducerRecord.html  |   8 +-
 .../kafka/clients/producer/RecordMetadata.html  |   8 +-
 .../kafka/clients/producer/package-frame.html   |   6 +-
 .../kafka/clients/producer/package-summary.html |   8 +-
 .../kafka/clients/producer/package-tree.html    |   8 +-
 .../org/apache/kafka/common/Cluster.html        |   8 +-
 .../apache/kafka/common/ClusterResource.html    |   8 +-
 .../kafka/common/ClusterResourceListener.html   |   8 +-
 .../org/apache/kafka/common/Configurable.html   |   8 +-
 .../org/apache/kafka/common/KafkaException.html |   8 +-
 .../kafka/common/KafkaFuture.BiConsumer.html    |   8 +-
 .../kafka/common/KafkaFuture.Function.html      |   8 +-
 .../org/apache/kafka/common/KafkaFuture.html    |   8 +-
 .../javadoc/org/apache/kafka/common/Metric.html |   8 +-
 .../org/apache/kafka/common/MetricName.html     |   8 +-
 .../apache/kafka/common/MetricNameTemplate.html |   8 +-
 0110/javadoc/org/apache/kafka/common/Node.html  |   8 +-
 .../org/apache/kafka/common/PartitionInfo.html  |   8 +-
 .../org/apache/kafka/common/TopicPartition.html |   8 +-
 .../apache/kafka/common/TopicPartitionInfo.html |   8 +-
 .../kafka/common/acl/AccessControlEntry.html    |   8 +-
 .../common/acl/AccessControlEntryFilter.html    |   8 +-
 .../org/apache/kafka/common/acl/AclBinding.html |   8 +-
 .../kafka/common/acl/AclBindingFilter.html      |   8 +-
 .../apache/kafka/common/acl/AclOperation.html   |   8 +-
 .../kafka/common/acl/AclPermissionType.html     |   8 +-
 .../apache/kafka/common/acl/package-frame.html  |   6 +-
 .../kafka/common/acl/package-summary.html       |   8 +-
 .../apache/kafka/common/acl/package-tree.html   |   8 +-
 .../annotation/InterfaceStability.Evolving.html |   8 +-
 .../annotation/InterfaceStability.Stable.html   |   8 +-
 .../annotation/InterfaceStability.Unstable.html |   8 +-
 .../common/annotation/InterfaceStability.html   |   8 +-
 .../kafka/common/annotation/package-frame.html  |   6 +-
 .../common/annotation/package-summary.html      |   8 +-
 .../kafka/common/annotation/package-tree.html   |  12 +-
 .../kafka/common/config/AbstractConfig.html     |   8 +-
 .../org/apache/kafka/common/config/Config.html  |   8 +-
 .../common/config/ConfigDef.ConfigKey.html      |   8 +-
 .../common/config/ConfigDef.Importance.html     |   8 +-
 .../common/config/ConfigDef.NonEmptyString.html |  29 +-
 .../kafka/common/config/ConfigDef.Range.html    |   8 +-
 .../common/config/ConfigDef.Recommender.html    |   8 +-
 .../kafka/common/config/ConfigDef.Type.html     |   8 +-
 .../common/config/ConfigDef.ValidList.html      |   8 +-
 .../common/config/ConfigDef.ValidString.html    |   8 +-
 .../common/config/ConfigDef.Validator.html      |   8 +-
 .../kafka/common/config/ConfigDef.Width.html    |   8 +-
 .../apache/kafka/common/config/ConfigDef.html   |   8 +-
 .../kafka/common/config/ConfigException.html    |   8 +-
 .../common/config/ConfigResource.Type.html      |   8 +-
 .../kafka/common/config/ConfigResource.html     |   8 +-
 .../apache/kafka/common/config/ConfigValue.html |   8 +-
 .../apache/kafka/common/config/SaslConfigs.html |   8 +-
 .../apache/kafka/common/config/SslConfigs.html  |   8 +-
 .../apache/kafka/common/config/TopicConfig.html |   8 +-
 .../kafka/common/config/package-frame.html      |   6 +-
 .../kafka/common/config/package-summary.html    |   8 +-
 .../kafka/common/config/package-tree.html       |  12 +-
 .../kafka/common/errors/ApiException.html       |   8 +-
 .../common/errors/AuthenticationException.html  |   8 +-
 .../common/errors/AuthorizationException.html   |   8 +-
 .../errors/BrokerNotAvailableException.html     |   8 +-
 .../errors/ClusterAuthorizationException.html   |   8 +-
 .../errors/ConcurrentTransactionsException.html |   8 +-
 .../common/errors/ControllerMovedException.html |   8 +-
 .../CoordinatorLoadInProgressException.html     |   8 +-
 .../CoordinatorNotAvailableException.html       |   8 +-
 .../common/errors/CorruptRecordException.html   |   8 +-
 .../common/errors/DisconnectException.html      |   8 +-
 .../DuplicateSequenceNumberException.html       |   8 +-
 .../errors/GroupAuthorizationException.html     |   8 +-
 .../GroupCoordinatorNotAvailableException.html  |   8 +-
 .../errors/GroupLoadInProgressException.html    |   8 +-
 .../errors/IllegalGenerationException.html      |   8 +-
 .../errors/IllegalSaslStateException.html       |   8 +-
 .../InconsistentGroupProtocolException.html     |   8 +-
 .../kafka/common/errors/InterruptException.html |   8 +-
 .../InvalidCommitOffsetSizeException.html       |   8 +-
 .../errors/InvalidConfigurationException.html   |   8 +-
 .../errors/InvalidFetchSizeException.html       |   8 +-
 .../common/errors/InvalidGroupIdException.html  |   8 +-
 .../common/errors/InvalidMetadataException.html |   8 +-
 .../common/errors/InvalidOffsetException.html   |   8 +-
 .../errors/InvalidPartitionsException.html      |   8 +-
 .../errors/InvalidPidMappingException.html      |   8 +-
 .../InvalidReplicaAssignmentException.html      |   8 +-
 .../InvalidReplicationFactorException.html      |   8 +-
 .../common/errors/InvalidRequestException.html  |   8 +-
 .../errors/InvalidRequiredAcksException.html    |   8 +-
 .../errors/InvalidSessionTimeoutException.html  |   8 +-
 .../errors/InvalidTimestampException.html       |   8 +-
 .../common/errors/InvalidTopicException.html    |   8 +-
 .../common/errors/InvalidTxnStateException.html |   8 +-
 .../errors/InvalidTxnTimeoutException.html      |   8 +-
 .../errors/LeaderNotAvailableException.html     |   8 +-
 .../kafka/common/errors/NetworkException.html   |   8 +-
 .../common/errors/NotControllerException.html   |   8 +-
 .../common/errors/NotCoordinatorException.html  |   8 +-
 .../errors/NotCoordinatorForGroupException.html |   8 +-
 .../NotEnoughReplicasAfterAppendException.html  |   8 +-
 .../errors/NotEnoughReplicasException.html      |   8 +-
 .../errors/NotLeaderForPartitionException.html  |   8 +-
 .../common/errors/OffsetMetadataTooLarge.html   |   8 +-
 .../errors/OffsetOutOfRangeException.html       |   8 +-
 .../errors/OperationNotAttemptedException.html  |   8 +-
 .../errors/OutOfOrderSequenceException.html     |  14 +-
 .../common/errors/PolicyViolationException.html |   8 +-
 .../common/errors/ProducerFencedException.html  |  12 +-
 .../errors/RebalanceInProgressException.html    |   8 +-
 .../errors/RecordBatchTooLargeException.html    |   8 +-
 .../common/errors/RecordTooLargeException.html  |   8 +-
 .../errors/ReplicaNotAvailableException.html    |   8 +-
 .../kafka/common/errors/RetriableException.html |   8 +-
 .../errors/SecurityDisabledException.html       |   8 +-
 .../common/errors/SerializationException.html   |   8 +-
 .../kafka/common/errors/TimeoutException.html   |   8 +-
 .../errors/TopicAuthorizationException.html     |   8 +-
 .../common/errors/TopicExistsException.html     |   8 +-
 .../TransactionCoordinatorFencedException.html  |   8 +-
 .../TransactionalIdAuthorizationException.html  |   8 +-
 .../common/errors/UnknownMemberIdException.html |   8 +-
 .../common/errors/UnknownServerException.html   |   8 +-
 .../UnknownTopicOrPartitionException.html       |   8 +-
 .../UnsupportedForMessageFormatException.html   |  11 +-
 .../UnsupportedSaslMechanismException.html      |   8 +-
 .../errors/UnsupportedVersionException.html     |  16 +-
 .../kafka/common/errors/WakeupException.html    |   8 +-
 .../kafka/common/errors/package-frame.html      |   6 +-
 .../kafka/common/errors/package-summary.html    |  22 +-
 .../kafka/common/errors/package-tree.html       |   8 +-
 .../org/apache/kafka/common/header/Header.html  |   8 +-
 .../org/apache/kafka/common/header/Headers.html |   8 +-
 .../kafka/common/header/package-frame.html      |   6 +-
 .../kafka/common/header/package-summary.html    |   8 +-
 .../kafka/common/header/package-tree.html       |   8 +-
 .../org/apache/kafka/common/package-frame.html  |   6 +-
 .../apache/kafka/common/package-summary.html    |   8 +-
 .../org/apache/kafka/common/package-tree.html   |   8 +-
 .../apache/kafka/common/resource/Resource.html  |   8 +-
 .../kafka/common/resource/ResourceFilter.html   |   8 +-
 .../kafka/common/resource/ResourceType.html     |   8 +-
 .../kafka/common/resource/package-frame.html    |   6 +-
 .../kafka/common/resource/package-summary.html  |   8 +-
 .../kafka/common/resource/package-tree.html     |   8 +-
 .../serialization/ByteArrayDeserializer.html    |   8 +-
 .../serialization/ByteArraySerializer.html      |   8 +-
 .../serialization/ByteBufferDeserializer.html   |   8 +-
 .../serialization/ByteBufferSerializer.html     |   8 +-
 .../common/serialization/BytesDeserializer.html |   8 +-
 .../common/serialization/BytesSerializer.html   |   8 +-
 .../common/serialization/Deserializer.html      |   8 +-
 .../serialization/DoubleDeserializer.html       |   8 +-
 .../common/serialization/DoubleSerializer.html  |   8 +-
 .../ExtendedDeserializer.Wrapper.html           |   8 +-
 .../serialization/ExtendedDeserializer.html     |   8 +-
 .../ExtendedSerializer.Wrapper.html             |   8 +-
 .../serialization/ExtendedSerializer.html       |   8 +-
 .../common/serialization/FloatDeserializer.html |   8 +-
 .../common/serialization/FloatSerializer.html   |   8 +-
 .../serialization/IntegerDeserializer.html      |   8 +-
 .../common/serialization/IntegerSerializer.html |   8 +-
 .../common/serialization/LongDeserializer.html  |   8 +-
 .../common/serialization/LongSerializer.html    |   8 +-
 .../kafka/common/serialization/Serde.html       |   8 +-
 .../serialization/Serdes.ByteArraySerde.html    |   8 +-
 .../serialization/Serdes.ByteBufferSerde.html   |   8 +-
 .../common/serialization/Serdes.BytesSerde.html |   8 +-
 .../serialization/Serdes.DoubleSerde.html       |   8 +-
 .../common/serialization/Serdes.FloatSerde.html |   8 +-
 .../serialization/Serdes.IntegerSerde.html      |   8 +-
 .../common/serialization/Serdes.LongSerde.html  |   8 +-
 .../common/serialization/Serdes.ShortSerde.html |   8 +-
 .../serialization/Serdes.StringSerde.html       |   8 +-
 .../serialization/Serdes.WrapperSerde.html      |   8 +-
 .../kafka/common/serialization/Serdes.html      |   8 +-
 .../kafka/common/serialization/Serializer.html  |   8 +-
 .../common/serialization/ShortDeserializer.html |   8 +-
 .../common/serialization/ShortSerializer.html   |   8 +-
 .../serialization/StringDeserializer.html       |   8 +-
 .../common/serialization/StringSerializer.html  |   8 +-
 .../common/serialization/package-frame.html     |   6 +-
 .../common/serialization/package-summary.html   |   8 +-
 .../common/serialization/package-tree.html      |   8 +-
 .../kafka/connect/connector/ConnectRecord.html  |   8 +-
 .../kafka/connect/connector/Connector.html      |   8 +-
 .../connect/connector/ConnectorContext.html     |   8 +-
 .../apache/kafka/connect/connector/Task.html    |   8 +-
 .../kafka/connect/connector/package-frame.html  |   6 +-
 .../connect/connector/package-summary.html      |   8 +-
 .../kafka/connect/connector/package-tree.html   |   8 +-
 .../kafka/connect/data/ConnectSchema.html       |   8 +-
 .../org/apache/kafka/connect/data/Date.html     |   8 +-
 .../org/apache/kafka/connect/data/Decimal.html  |   8 +-
 .../org/apache/kafka/connect/data/Field.html    |   8 +-
 .../apache/kafka/connect/data/Schema.Type.html  |   8 +-
 .../org/apache/kafka/connect/data/Schema.html   |   8 +-
 .../kafka/connect/data/SchemaAndValue.html      |   8 +-
 .../kafka/connect/data/SchemaBuilder.html       |   8 +-
 .../kafka/connect/data/SchemaProjector.html     |   8 +-
 .../org/apache/kafka/connect/data/Struct.html   |   8 +-
 .../org/apache/kafka/connect/data/Time.html     |   8 +-
 .../apache/kafka/connect/data/Timestamp.html    |   8 +-
 .../kafka/connect/data/package-frame.html       |   6 +-
 .../kafka/connect/data/package-summary.html     |   8 +-
 .../apache/kafka/connect/data/package-tree.html |   8 +-
 .../connect/errors/AlreadyExistsException.html  |   8 +-
 .../kafka/connect/errors/ConnectException.html  |   8 +-
 .../kafka/connect/errors/DataException.html     |   8 +-
 .../errors/IllegalWorkerStateException.html     |   8 +-
 .../kafka/connect/errors/NotFoundException.html |   8 +-
 .../connect/errors/RetriableException.html      |   8 +-
 .../connect/errors/SchemaBuilderException.html  |   8 +-
 .../errors/SchemaProjectorException.html        |   8 +-
 .../kafka/connect/errors/package-frame.html     |   6 +-
 .../kafka/connect/errors/package-summary.html   |   8 +-
 .../kafka/connect/errors/package-tree.html      |   8 +-
 .../kafka/connect/sink/SinkConnector.html       |   8 +-
 .../apache/kafka/connect/sink/SinkRecord.html   |   8 +-
 .../org/apache/kafka/connect/sink/SinkTask.html |   8 +-
 .../kafka/connect/sink/SinkTaskContext.html     |   8 +-
 .../kafka/connect/sink/package-frame.html       |   6 +-
 .../kafka/connect/sink/package-summary.html     |   8 +-
 .../apache/kafka/connect/sink/package-tree.html |   8 +-
 .../kafka/connect/source/SourceConnector.html   |   8 +-
 .../kafka/connect/source/SourceRecord.html      |   8 +-
 .../apache/kafka/connect/source/SourceTask.html |   8 +-
 .../kafka/connect/source/SourceTaskContext.html |   8 +-
 .../kafka/connect/source/package-frame.html     |   6 +-
 .../kafka/connect/source/package-summary.html   |   8 +-
 .../kafka/connect/source/package-tree.html      |   8 +-
 .../apache/kafka/connect/storage/Converter.html |   8 +-
 .../connect/storage/OffsetStorageReader.html    |   8 +-
 .../kafka/connect/storage/StringConverter.html  |   8 +-
 .../kafka/connect/storage/package-frame.html    |   6 +-
 .../kafka/connect/storage/package-summary.html  |   8 +-
 .../kafka/connect/storage/package-tree.html     |   8 +-
 .../connect/transforms/Transformation.html      |   8 +-
 .../kafka/connect/transforms/package-frame.html |   6 +-
 .../connect/transforms/package-summary.html     |   8 +-
 .../kafka/connect/transforms/package-tree.html  |   8 +-
 .../kafka/connect/util/ConnectorUtils.html      |   8 +-
 .../kafka/connect/util/package-frame.html       |   6 +-
 .../kafka/connect/util/package-summary.html     |   8 +-
 .../apache/kafka/connect/util/package-tree.html |   8 +-
 .../AlterConfigPolicy.RequestMetadata.html      |   8 +-
 .../kafka/server/policy/AlterConfigPolicy.html  |   8 +-
 .../CreateTopicPolicy.RequestMetadata.html      |   8 +-
 .../kafka/server/policy/CreateTopicPolicy.html  |   8 +-
 .../kafka/server/policy/package-frame.html      |   6 +-
 .../kafka/server/policy/package-summary.html    |   8 +-
 .../kafka/server/policy/package-tree.html       |   8 +-
 .../kafka/streams/KafkaClientSupplier.html      |   8 +-
 .../kafka/streams/KafkaStreams.State.html       |  94 ++--
 .../streams/KafkaStreams.StateListener.html     |   8 +-
 .../org/apache/kafka/streams/KafkaStreams.html  |  13 +-
 .../org/apache/kafka/streams/KeyValue.html      |   8 +-
 .../streams/StreamsConfig.InternalConfig.html   |   8 +-
 .../org/apache/kafka/streams/StreamsConfig.html |   8 +-
 .../apache/kafka/streams/StreamsMetrics.html    |   8 +-
 .../streams/errors/BrokerNotFoundException.html |   8 +-
 .../errors/InvalidStateStoreException.html      |   8 +-
 .../kafka/streams/errors/LockException.html     |   8 +-
 .../streams/errors/ProcessorStateException.html |   8 +-
 .../kafka/streams/errors/StreamsException.html  |   8 +-
 .../streams/errors/TaskAssignmentException.html |   8 +-
 .../streams/errors/TaskIdFormatException.html   |   8 +-
 .../errors/TopologyBuilderException.html        |   8 +-
 .../kafka/streams/errors/package-frame.html     |   6 +-
 .../kafka/streams/errors/package-summary.html   |   8 +-
 .../kafka/streams/errors/package-tree.html      |   8 +-
 .../kafka/streams/kstream/Aggregator.html       |   8 +-
 .../kafka/streams/kstream/ForeachAction.html    |   8 +-
 .../kafka/streams/kstream/GlobalKTable.html     |   8 +-
 .../kafka/streams/kstream/Initializer.html      |   8 +-
 .../kafka/streams/kstream/JoinWindows.html      |   8 +-
 .../kafka/streams/kstream/KGroupedStream.html   |   8 +-
 .../kafka/streams/kstream/KGroupedTable.html    |   8 +-
 .../apache/kafka/streams/kstream/KStream.html   |   8 +-
 .../kafka/streams/kstream/KStreamBuilder.html   |   8 +-
 .../apache/kafka/streams/kstream/KTable.html    |   8 +-
 .../kafka/streams/kstream/KeyValueMapper.html   |   8 +-
 .../apache/kafka/streams/kstream/Merger.html    |   8 +-
 .../apache/kafka/streams/kstream/Predicate.html |   8 +-
 .../streams/kstream/PrintForeachAction.html     |   8 +-
 .../apache/kafka/streams/kstream/Reducer.html   |   8 +-
 .../kafka/streams/kstream/SessionWindows.html   |   8 +-
 .../kafka/streams/kstream/TimeWindows.html      |   8 +-
 .../kafka/streams/kstream/Transformer.html      |   8 +-
 .../streams/kstream/TransformerSupplier.html    |   8 +-
 .../kafka/streams/kstream/UnlimitedWindows.html |   8 +-
 .../kafka/streams/kstream/ValueJoiner.html      |   8 +-
 .../kafka/streams/kstream/ValueMapper.html      |   8 +-
 .../kafka/streams/kstream/ValueTransformer.html |   8 +-
 .../kstream/ValueTransformerSupplier.html       |   8 +-
 .../apache/kafka/streams/kstream/Window.html    |   8 +-
 .../apache/kafka/streams/kstream/Windowed.html  |   8 +-
 .../apache/kafka/streams/kstream/Windows.html   |   8 +-
 .../kafka/streams/kstream/package-frame.html    |   6 +-
 .../kafka/streams/kstream/package-summary.html  |   8 +-
 .../kafka/streams/kstream/package-tree.html     |   8 +-
 .../org/apache/kafka/streams/package-frame.html |   6 +-
 .../apache/kafka/streams/package-summary.html   |   8 +-
 .../org/apache/kafka/streams/package-tree.html  |   8 +-
 .../streams/processor/AbstractProcessor.html    |   8 +-
 .../processor/DefaultPartitionGrouper.html      |   8 +-
 .../processor/FailOnInvalidTimestamp.html       |   8 +-
 .../processor/LogAndSkipOnInvalidTimestamp.html |   8 +-
 .../streams/processor/PartitionGrouper.html     |   8 +-
 .../kafka/streams/processor/Processor.html      |   8 +-
 .../streams/processor/ProcessorContext.html     |   8 +-
 .../streams/processor/ProcessorSupplier.html    |   8 +-
 .../streams/processor/StateRestoreCallback.html |   8 +-
 .../kafka/streams/processor/StateStore.html     |   8 +-
 .../streams/processor/StateStoreSupplier.html   |   8 +-
 .../streams/processor/StreamPartitioner.html    |   8 +-
 .../apache/kafka/streams/processor/TaskId.html  |   8 +-
 .../streams/processor/TimestampExtractor.html   |   8 +-
 .../TopologyBuilder.AutoOffsetReset.html        |   8 +-
 .../processor/TopologyBuilder.TopicsInfo.html   |   8 +-
 .../streams/processor/TopologyBuilder.html      |   8 +-
 .../UsePreviousTimeOnInvalidTimestamp.html      |   8 +-
 .../processor/WallclockTimestampExtractor.html  |   8 +-
 .../kafka/streams/processor/package-frame.html  |   6 +-
 .../streams/processor/package-summary.html      |   8 +-
 .../kafka/streams/processor/package-tree.html   |   8 +-
 .../apache/kafka/streams/state/HostInfo.html    |   8 +-
 .../kafka/streams/state/KeyValueIterator.html   |   8 +-
 .../kafka/streams/state/KeyValueStore.html      |   8 +-
 .../kafka/streams/state/QueryableStoreType.html |   8 +-
 .../streams/state/QueryableStoreTypes.html      |   8 +-
 .../streams/state/ReadOnlyKeyValueStore.html    |   8 +-
 .../streams/state/ReadOnlySessionStore.html     |   8 +-
 .../streams/state/ReadOnlyWindowStore.html      |   8 +-
 .../streams/state/RocksDBConfigSetter.html      |   8 +-
 .../kafka/streams/state/SessionStore.html       |   8 +-
 .../apache/kafka/streams/state/StateSerdes.html |   8 +-
 .../state/Stores.InMemoryKeyValueFactory.html   |   8 +-
 .../streams/state/Stores.KeyValueFactory.html   |   8 +-
 .../state/Stores.PersistentKeyValueFactory.html |   8 +-
 .../streams/state/Stores.StoreFactory.html      |   8 +-
 .../streams/state/Stores.ValueFactory.html      |   8 +-
 .../org/apache/kafka/streams/state/Stores.html  |   8 +-
 .../kafka/streams/state/StreamsMetadata.html    |   8 +-
 .../apache/kafka/streams/state/WindowStore.html |   8 +-
 .../streams/state/WindowStoreIterator.html      |   8 +-
 .../kafka/streams/state/package-frame.html      |   6 +-
 .../kafka/streams/state/package-summary.html    |   8 +-
 .../kafka/streams/state/package-tree.html       |   8 +-
 0110/javadoc/overview-frame.html                |   6 +-
 0110/javadoc/overview-summary.html              |  10 +-
 0110/javadoc/overview-tree.html                 |   8 +-
 0110/javadoc/serialized-form.html               |   8 +-
 0110/js/templateData.js                         |   6 +-
 0110/ops.html                                   | 327 ++++++++++--
 0110/quickstart.html                            | 175 +-----
 0110/security.html                              |   2 +-
 0110/streams/architecture.html                  |   6 +-
 0110/streams/core-concepts.html                 |  28 +-
 0110/streams/developer-guide.html               | 187 ++++++-
 0110/streams/index.html                         | 237 +++++++--
 0110/streams/quickstart.html                    | 352 +++++++++++++
 0110/streams/tutorial.html                      | 526 +++++++++++++++++++
 0110/streams/upgrade-guide.html                 |  10 +-
 0110/toc.html                                   |  33 +-
 0110/upgrade.html                               |   2 +-
 downloads.html                                  |  19 +-
 453 files changed, 3579 insertions(+), 2052 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/api.html
----------------------------------------------------------------------
diff --git a/0110/api.html b/0110/api.html
index 05768a1..9777186 100644
--- a/0110/api.html
+++ b/0110/api.html
@@ -39,7 +39,7 @@
 		&lt;dependency&gt;
 			&lt;groupId&gt;org.apache.kafka&lt;/groupId&gt;
 			&lt;artifactId&gt;kafka-clients&lt;/artifactId&gt;
-			&lt;version&gt;{{dotVersion}}.0&lt;/version&gt;
+			&lt;version&gt;{{fullDotVersion}}&lt;/version&gt;
 		&lt;/dependency&gt;
 	</pre>
 
@@ -55,7 +55,7 @@
 		&lt;dependency&gt;
 			&lt;groupId&gt;org.apache.kafka&lt;/groupId&gt;
 			&lt;artifactId&gt;kafka-clients&lt;/artifactId&gt;
-			&lt;version&gt;{{dotVersion}}.0&lt;/version&gt;
+			&lt;version&gt;{{fullDotVersion}}&lt;/version&gt;
 		&lt;/dependency&gt;
 	</pre>
 
@@ -74,7 +74,7 @@
 		&lt;dependency&gt;
 			&lt;groupId&gt;org.apache.kafka&lt;/groupId&gt;
 			&lt;artifactId&gt;kafka-streams&lt;/artifactId&gt;
-			&lt;version&gt;{{dotVersion}}.0&lt;/version&gt;
+			&lt;version&gt;{{fullDotVersion}}&lt;/version&gt;
 		&lt;/dependency&gt;
 	</pre>
 
@@ -96,7 +96,7 @@
 		&lt;dependency&gt;
 			&lt;groupId&gt;org.apache.kafka&lt;/groupId&gt;
 			&lt;artifactId&gt;kafka-clients&lt;/artifactId&gt;
-			&lt;version&gt;{{dotVersion}}.0&lt;/version&gt;
+			&lt;version&gt;{{fullDotVersion}}&lt;/version&gt;
 		&lt;/dependency&gt;
 	</pre>
 	For more information about the AdminClient APIs, see the <a href="/{{version}}/javadoc/index.html?org/apache/kafka/clients/admin/AdminClient.html" title="Kafka {{dotVersion}} Javadoc">javadoc</a>.

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/configuration.html
----------------------------------------------------------------------
diff --git a/0110/configuration.html b/0110/configuration.html
index fce0818..3f962e9 100644
--- a/0110/configuration.html
+++ b/0110/configuration.html
@@ -27,13 +27,13 @@
       <li><code>zookeeper.connect</code>
   </ul>
 
-  Topic-level configurations and defaults are discussed in more detail <a href="#topic-config">below</a>.
+  Topic-level configurations and defaults are discussed in more detail <a href="#topicconfigs">below</a>.
 
   <!--#include virtual="generated/kafka_config.html" -->
 
   <p>More details about broker configuration can be found in the scala class <code>kafka.server.KafkaConfig</code>.</p>
 
-  <a id="topic-config" href="#topic-config">Topic-level configuration</a>
+  <h3><a id="topicconfigs" href="#topicconfigs">3.2 Topic-Level Configs</a></h3>
 
   Configurations pertinent to topics have both a server default as well an optional per-topic override. If no per-topic configuration is given the server default is used. The override can be set at topic creation time by giving one or more <code>--config</code> options. This example creates a topic named <i>my-topic</i> with a custom max message size and flush rate:
   <pre class="brush: bash;">
@@ -60,7 +60,7 @@
 
   <!--#include virtual="generated/topic_config.html" -->
 
-  <h3><a id="producerconfigs" href="#producerconfigs">3.2 Producer Configs</a></h3>
+  <h3><a id="producerconfigs" href="#producerconfigs">3.3 Producer Configs</a></h3>
 
   Below is the configuration of the Java producer:
   <!--#include virtual="generated/producer_config.html" -->
@@ -70,16 +70,16 @@
       here</a>.
   </p>
 
-  <h3><a id="consumerconfigs" href="#consumerconfigs">3.3 Consumer Configs</a></h3>
+  <h3><a id="consumerconfigs" href="#consumerconfigs">3.4 Consumer Configs</a></h3>
 
   In 0.9.0.0 we introduced the new Java consumer as a replacement for the older Scala-based simple and high-level consumers.
   The configs for both new and old consumers are described below.
 
-  <h4><a id="newconsumerconfigs" href="#newconsumerconfigs">3.3.1 New Consumer Configs</a></h4>
+  <h4><a id="newconsumerconfigs" href="#newconsumerconfigs">3.4.1 New Consumer Configs</a></h4>
   Below is the configuration for the new consumer:
   <!--#include virtual="generated/consumer_config.html" -->
 
-  <h4><a id="oldconsumerconfigs" href="#oldconsumerconfigs">3.3.2 Old Consumer Configs</a></h4>
+  <h4><a id="oldconsumerconfigs" href="#oldconsumerconfigs">3.4.2 Old Consumer Configs</a></h4>
 
   The essential old consumer configurations are the following:
   <ul>
@@ -246,15 +246,15 @@
 
   <p>More details about consumer configuration can be found in the scala class <code>kafka.consumer.ConsumerConfig</code>.</p>
 
-  <h3><a id="connectconfigs" href="#connectconfigs">3.4 Kafka Connect Configs</a></h3>
+  <h3><a id="connectconfigs" href="#connectconfigs">3.5 Kafka Connect Configs</a></h3>
   Below is the configuration of the Kafka Connect framework.
   <!--#include virtual="generated/connect_config.html" -->
 
-  <h3><a id="streamsconfigs" href="#streamsconfigs">3.5 Kafka Streams Configs</a></h3>
+  <h3><a id="streamsconfigs" href="#streamsconfigs">3.6 Kafka Streams Configs</a></h3>
   Below is the configuration of the Kafka Streams client library.
   <!--#include virtual="generated/streams_config.html" -->
 
-  <h3><a id="adminclientconfigs" href="#adminclientconfigs">3.6 AdminClient Configs</a></h3>
+  <h3><a id="adminclientconfigs" href="#adminclientconfigs">3.7 AdminClient Configs</a></h3>
   Below is the configuration of the Kafka Admin client library.
   <!--#include virtual="generated/admin_client_config.html" -->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/connect.html
----------------------------------------------------------------------
diff --git a/0110/connect.html b/0110/connect.html
index 57505d6..8c79cc1 100644
--- a/0110/connect.html
+++ b/0110/connect.html
@@ -176,7 +176,7 @@
         <li>ExtractField - Extract a specific field from Struct and Map and include only this field in results</li>
         <li>SetSchemaMetadata - modify the schema name or version</li>
         <li>TimestampRouter - Modify the topic of a record based on original topic and timestamp. Useful when using a sink that needs to write to different tables or indexes based on timestamps</li>
-        <li>RegexpRouter - modify the topic of a record based on original topic, replacement string and a regular expression</li>
+        <li>RegexRouter - modify the topic of a record based on original topic, replacement string and a regular expression</li>
     </ul>
 
     Details on how to configure each transformation are listed below:
@@ -253,11 +253,11 @@
         private String topic;
     </pre>
 
-    The easiest method to fill in is <code>getTaskClass()</code>, which defines the class that should be instantiated in worker processes to actually read the data:
+    The easiest method to fill in is <code>taskClass()</code>, which defines the class that should be instantiated in worker processes to actually read the data:
 
     <pre class="brush: java;">
     @Override
-    public Class&lt;? extends Task&gt; getTaskClass() {
+    public Class&lt;? extends Task&gt; taskClass() {
         return FileStreamSourceTask.class;
     }
     </pre>
@@ -372,8 +372,9 @@
         }
 
         public abstract void put(Collection&lt;SinkRecord&gt; records);
-        
-        public abstract void flush(Map&lt;TopicPartition, Long&gt; offsets);
+
+        public void flush(Map&lt;TopicPartition, OffsetAndMetadata&gt; currentOffsets) {
+        }
     </pre>
 
     The <code>SinkTask</code> documentation contains full details, but this interface is nearly as simple as the <code>SourceTask</code>. The <code>put()</code> method should contain most of the implementation, accepting sets of <code>SinkRecords</code>, performing any required translation, and storing them in the destination system. This method does not need to ensure the data has been fully written to the destination system before returning. In fact, in many cases internal buffering will be useful so an entire batch of records can be sent at once, reducing the overhead of inserting events into the downstream data store. The <code>SinkRecords</code> contain essentially the same information as <code>SourceRecords</code>: Kafka topic, partition, offset and the event key and value.
@@ -510,4 +511,4 @@
     </p>
 </script>
 
-<div class="p-connect"></div>
\ No newline at end of file
+<div class="p-connect"></div>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/documentation/streams/quickstart.html
----------------------------------------------------------------------
diff --git a/0110/documentation/streams/quickstart.html b/0110/documentation/streams/quickstart.html
new file mode 100644
index 0000000..f69c0d5
--- /dev/null
+++ b/0110/documentation/streams/quickstart.html
@@ -0,0 +1,19 @@
+<!--
+ Licensed to the Apache Software Foundation (ASF) under one or more
+ contributor license agreements.  See the NOTICE file distributed with
+ this work for additional information regarding copyright ownership.
+ The ASF licenses this file to You under the Apache License, Version 2.0
+ (the "License"); you may not use this file except in compliance with
+ the License.  You may obtain a copy of the License at
+
+    http://www.apache.org/licenses/LICENSE-2.0
+
+ Unless required by applicable law or agreed to in writing, software
+ distributed under the License is distributed on an "AS IS" BASIS,
+ WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ See the License for the specific language governing permissions and
+ limitations under the License.
+-->
+
+<!-- should always link the the latest release's documentation -->
+<!--#include virtual="../../streams/quickstart.html" -->

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/documentation/streams/tutorial.html
----------------------------------------------------------------------
diff --git a/0110/documentation/streams/tutorial.html b/0110/documentation/streams/tutorial.html
new file mode 100644
index 0000000..90f408d
--- /dev/null
+++ b/0110/documentation/streams/tutorial.html
@@ -0,0 +1,19 @@
+<!--
+ Licensed to the Apache Software Foundation (ASF) under one or more
+ contributor license agreements.  See the NOTICE file distributed with
+ this work for additional information regarding copyright ownership.
+ The ASF licenses this file to You under the Apache License, Version 2.0
+ (the "License"); you may not use this file except in compliance with
+ the License.  You may obtain a copy of the License at
+
+    http://www.apache.org/licenses/LICENSE-2.0
+
+ Unless required by applicable law or agreed to in writing, software
+ distributed under the License is distributed on an "AS IS" BASIS,
+ WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ See the License for the specific language governing permissions and
+ limitations under the License.
+-->
+
+<!-- should always link the the latest release's documentation -->
+<!--#include virtual="../../streams/tutorial.html" -->

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/generated/topic_config.html
----------------------------------------------------------------------
diff --git a/0110/generated/topic_config.html b/0110/generated/topic_config.html
index d5e8835..c24ccc7 100644
--- a/0110/generated/topic_config.html
+++ b/0110/generated/topic_config.html
@@ -17,7 +17,7 @@
 <tr>
 <td>file.delete.delay.ms</td><td>The time to wait before deleting a file from the filesystem</td><td>long</td><td>60000</td><td>[0,...]</td><td>log.segment.delete.delay.ms</td><td>medium</td></tr>
 <tr>
-<td>flush.messages</td><td>This setting allows specifying an interval at which we will force an fsync of data written to the log. For example if this was set to 1 we would fsync after every message; if it were 5 we would fsync after every five messages. In general we recommend you not set this and use replication for durability and allow the operating system's background flush capabilities as it is more efficient. This setting can be overridden on a per-topic basis (see <a href="#topic-config">the per-topic configuration section</a>).</td><td>long</td><td>9223372036854775807</td><td>[0,...]</td><td>log.flush.interval.messages</td><td>medium</td></tr>
+<td>flush.messages</td><td>This setting allows specifying an interval at which we will force an fsync of data written to the log. For example if this was set to 1 we would fsync after every message; if it were 5 we would fsync after every five messages. In general we recommend you not set this and use replication for durability and allow the operating system's background flush capabilities as it is more efficient. This setting can be overridden on a per-topic basis (see <a href="#topicconfigs">the per-topic configuration section</a>).</td><td>long</td><td>9223372036854775807</td><td>[0,...]</td><td>log.flush.interval.messages</td><td>medium</td></tr>
 <tr>
 <td>flush.ms</td><td>This setting allows specifying a time interval at which we will force an fsync of data written to the log. For example if this was set to 1000 we would fsync after 1000 ms had passed. In general we recommend you not set this and use replication for durability and allow the operating system's background flush capabilities as it is more efficient.</td><td>long</td><td>9223372036854775807</td><td>[0,...]</td><td>log.flush.interval.ms</td><td>medium</td></tr>
 <tr>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/images/icons/architecture--white.png
----------------------------------------------------------------------
diff --git a/0110/images/icons/architecture--white.png b/0110/images/icons/architecture--white.png
new file mode 100644
index 0000000..98b1b03
Binary files /dev/null and b/0110/images/icons/architecture--white.png differ

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/images/icons/architecture.png
----------------------------------------------------------------------
diff --git a/0110/images/icons/architecture.png b/0110/images/icons/architecture.png
new file mode 100644
index 0000000..6f9fd40
Binary files /dev/null and b/0110/images/icons/architecture.png differ

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/images/icons/documentation--white.png
----------------------------------------------------------------------
diff --git a/0110/images/icons/documentation--white.png b/0110/images/icons/documentation--white.png
new file mode 100644
index 0000000..1e8fd97
Binary files /dev/null and b/0110/images/icons/documentation--white.png differ

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/images/icons/documentation.png
----------------------------------------------------------------------
diff --git a/0110/images/icons/documentation.png b/0110/images/icons/documentation.png
new file mode 100644
index 0000000..8d9da19
Binary files /dev/null and b/0110/images/icons/documentation.png differ

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/images/icons/tutorials--white.png
----------------------------------------------------------------------
diff --git a/0110/images/icons/tutorials--white.png b/0110/images/icons/tutorials--white.png
new file mode 100644
index 0000000..97a0c04
Binary files /dev/null and b/0110/images/icons/tutorials--white.png differ

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/images/icons/tutorials.png
----------------------------------------------------------------------
diff --git a/0110/images/icons/tutorials.png b/0110/images/icons/tutorials.png
new file mode 100644
index 0000000..983da6c
Binary files /dev/null and b/0110/images/icons/tutorials.png differ

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/images/streams-cache-and-commit-interval.png
----------------------------------------------------------------------
diff --git a/0110/images/streams-cache-and-commit-interval.png b/0110/images/streams-cache-and-commit-interval.png
new file mode 100644
index 0000000..a663bc6
Binary files /dev/null and b/0110/images/streams-cache-and-commit-interval.png differ

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/images/streams-welcome.png
----------------------------------------------------------------------
diff --git a/0110/images/streams-welcome.png b/0110/images/streams-welcome.png
new file mode 100644
index 0000000..63918c4
Binary files /dev/null and b/0110/images/streams-welcome.png differ

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/introduction.html
----------------------------------------------------------------------
diff --git a/0110/introduction.html b/0110/introduction.html
index 556aa02..65f021e 100644
--- a/0110/introduction.html
+++ b/0110/introduction.html
@@ -146,7 +146,7 @@
   Kafka does it better. By having a notion of parallelism&mdash;the partition&mdash;within the topics, Kafka is able to provide both ordering guarantees and load balancing over a pool of consumer processes. This is achieved by assigning the partitions in the topic to the consumers in the consumer group so that each partition is consumed by exactly one consumer in the group. By doing this we ensure that the consumer is the only reader of that partition and consumes the data in order. Since there are many partitions this still balances the load over many consumer instances. Note however that there cannot be more consumer instances in a consumer group than partitions.
   </p>
 
-  <h4>Kafka as a Storage System</h4>
+  <h4 id="kafka_storage">Kafka as a Storage System</h4>
 
   <p>
   Any message queue that allows publishing messages decoupled from consuming them is effectively acting as a storage system for the in-flight messages. What is different about Kafka is that it is a very good storage system.
@@ -160,6 +160,9 @@
   <p>
   As a result of taking storage seriously and allowing the clients to control their read position, you can think of Kafka as a kind of special purpose distributed filesystem dedicated to high-performance, low-latency commit log storage, replication, and propagation.
   </p>
+  <p>
+  For details about the Kafka's commit log storage and replication design, please read <a href="https://kafka.apache.org/documentation/#design">this</a> page.
+  </p>
   <h4>Kafka for Stream Processing</h4>
   <p>
   It isn't enough to just read, write, and store streams of data, the purpose is to enable real-time processing of streams.

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/allclasses-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/allclasses-frame.html b/0110/javadoc/allclasses-frame.html
index e1e80ef..696da9d 100644
--- a/0110/javadoc/allclasses-frame.html
+++ b/0110/javadoc/allclasses-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:09 BST 2017 -->
-<title>All Classes (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:59 BST 2017 -->
+<title>All Classes (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/allclasses-noframe.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/allclasses-noframe.html b/0110/javadoc/allclasses-noframe.html
index 6ab4270..818d738 100644
--- a/0110/javadoc/allclasses-noframe.html
+++ b/0110/javadoc/allclasses-noframe.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:09 BST 2017 -->
-<title>All Classes (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:59 BST 2017 -->
+<title>All Classes (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/constant-values.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/constant-values.html b/0110/javadoc/constant-values.html
index 901743b..bcf9123 100644
--- a/0110/javadoc/constant-values.html
+++ b/0110/javadoc/constant-values.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:09 BST 2017 -->
-<title>Constant Field Values (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:59 BST 2017 -->
+<title>Constant Field Values (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="Constant Field Values (kafka 0.11.0.0 API)";
+        parent.document.title="Constant Field Values (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -1381,7 +1381,7 @@
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;<a href="http://docs.oracle.com/javase/7/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a></code></td>
 <td><code><a href="org/apache/kafka/common/config/TopicConfig.html#FLUSH_MESSAGES_INTERVAL_DOC">FLUSH_MESSAGES_INTERVAL_DOC</a></code></td>
-<td class="colLast"><code>"This setting allows specifying an interval at which we will force an fsync of data written to the log. For example if this was set to 1 we would fsync after every message; if it were 5 we would fsync after every five messages. In general we recommend you not set this and use replication for durability and allow the operating system\'s background flush capabilities as it is more efficient. This setting can be overridden on a per-topic basis (see &lt;a href=\"#topic-config\"&gt;the per-topic configuration section&lt;/a&gt;)."</code></td>
+<td class="colLast"><code>"This setting allows specifying an interval at which we will force an fsync of data written to the log. For example if this was set to 1 we would fsync after every message; if it were 5 we would fsync after every five messages. In general we recommend you not set this and use replication for durability and allow the operating system\'s background flush capabilities as it is more efficient. This setting can be overridden on a per-topic basis (see &lt;a href=\"#topicconfigs\"&gt;the per-topic configuration section&lt;/a&gt;)."</code></td>
 </tr>
 <tr class="altColor">
 <td class="colFirst"><a name="org.apache.kafka.common.config.TopicConfig.FLUSH_MS_CONFIG">
@@ -1423,7 +1423,7 @@
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;<a href="http://docs.oracle.com/javase/7/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a></code></td>
 <td><code><a href="org/apache/kafka/common/config/TopicConfig.html#MAX_MESSAGE_BYTES_DOC">MAX_MESSAGE_BYTES_DOC</a></code></td>
-<td class="colLast"><code>"This is largest message size Kafka will allow to be appended. Note that if you increase this size you must also increase your consumer\'s fetch size so they can fetch messages this large."</code></td>
+<td class="colLast"><code>"&lt;p&gt;The largest record batch size allowed by Kafka. If this is increased and there are consumers older than 0.10.2, the consumers\' fetch size must also be increased so that the they can fetch record batches this large.&lt;/p&gt;&lt;p&gt;In the latest message format version, records are always grouped into batches for efficiency. In previous message format versions, uncompressed records are not grouped into batches and this limit only applies to a single record in that case.&lt;/p&gt;"</code></td>
 </tr>
 <tr class="altColor">
 <td class="colFirst"><a name="org.apache.kafka.common.config.TopicConfig.MESSAGE_FORMAT_VERSION_CONFIG">

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/deprecated-list.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/deprecated-list.html b/0110/javadoc/deprecated-list.html
index 376c22a..7f6447b 100644
--- a/0110/javadoc/deprecated-list.html
+++ b/0110/javadoc/deprecated-list.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:09 BST 2017 -->
-<title>Deprecated List (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:59 BST 2017 -->
+<title>Deprecated List (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="Deprecated List (kafka 0.11.0.0 API)";
+        parent.document.title="Deprecated List (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/help-doc.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/help-doc.html b/0110/javadoc/help-doc.html
index dec9f5c..4d988ce 100644
--- a/0110/javadoc/help-doc.html
+++ b/0110/javadoc/help-doc.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:09 BST 2017 -->
-<title>API Help (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:59 BST 2017 -->
+<title>API Help (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="API Help (kafka 0.11.0.0 API)";
+        parent.document.title="API Help (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/index-all.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/index-all.html b/0110/javadoc/index-all.html
index 2f4f2f9..5a660c4 100644
--- a/0110/javadoc/index-all.html
+++ b/0110/javadoc/index-all.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:09 BST 2017 -->
-<title>Index (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:59 BST 2017 -->
+<title>Index (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="./stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="Index (kafka 0.11.0.0 API)";
+        parent.document.title="Index (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -3404,8 +3404,6 @@
 <dd>
 <div class="block">Returns true if this CompletableFuture completed exceptionally, in any way.</div>
 </dd>
-<dt><span class="strong"><a href="./org/apache/kafka/streams/KafkaStreams.State.html#isCreatedOrRunning()">isCreatedOrRunning()</a></span> - Method in enum org.apache.kafka.streams.<a href="./org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams">KafkaStreams.State</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/kafka/clients/admin/ConfigEntry.html#isDefault()">isDefault()</a></span> - Method in class org.apache.kafka.clients.admin.<a href="./org/apache/kafka/clients/admin/ConfigEntry.html" title="class in org.apache.kafka.clients.admin">ConfigEntry</a></dt>
 <dd>
 <div class="block">Return whether the config value is the default or if it's been explicitly set.</div>
@@ -4850,7 +4848,10 @@
  non-windowed outer equi join.</div>
 </dd>
 <dt><a href="./org/apache/kafka/common/errors/OutOfOrderSequenceException.html" title="class in org.apache.kafka.common.errors"><span class="strong">OutOfOrderSequenceException</span></a> - Exception in <a href="./org/apache/kafka/common/errors/package-summary.html">org.apache.kafka.common.errors</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block">This exception indicates that the broker received an unexpected sequence number from the producer,
+ which means that data may have been lost.</div>
+</dd>
 <dt><span class="strong"><a href="./org/apache/kafka/common/errors/OutOfOrderSequenceException.html#OutOfOrderSequenceException(java.lang.String)">OutOfOrderSequenceException(String)</a></span> - Constructor for exception org.apache.kafka.common.errors.<a href="./org/apache/kafka/common/errors/OutOfOrderSequenceException.html" title="class in org.apache.kafka.common.errors">OutOfOrderSequenceException</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/kafka/streams/kstream/Window.html#overlap(org.apache.kafka.streams.kstream.Window)">overlap(Window)</a></span> - Method in class org.apache.kafka.streams.kstream.<a href="./org/apache/kafka/streams/kstream/Window.html" title="class in org.apache.kafka.streams.kstream">Window</a></dt>
@@ -5244,7 +5245,10 @@
 <div class="block">Configuration for the Kafka Producer.</div>
 </dd>
 <dt><a href="./org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors"><span class="strong">ProducerFencedException</span></a> - Exception in <a href="./org/apache/kafka/common/errors/package-summary.html">org.apache.kafka.common.errors</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block">This fatal exception indicates that another producer with the same <code>transactional.id</code> has been
+ started.</div>
+</dd>
 <dt><span class="strong"><a href="./org/apache/kafka/common/errors/ProducerFencedException.html#ProducerFencedException(java.lang.String)">ProducerFencedException(String)</a></span> - Constructor for exception org.apache.kafka.common.errors.<a href="./org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors">ProducerFencedException</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="./org/apache/kafka/clients/producer/ProducerInterceptor.html" title="interface in org.apache.kafka.clients.producer"><span class="strong">ProducerInterceptor</span></a>&lt;<a href="./org/apache/kafka/clients/producer/ProducerInterceptor.html" title="type parameter in ProducerInterceptor">K</a>,<a href="./org/apache/kafka/clients/producer/ProducerInterceptor.html" title="type parameter in ProducerInterceptor">V</a>&gt; - Interface in <a href="./org/apache/kafka/clients/producer/package-summary.html">org.apache.kafka.clients.producer</a></dt>
@@ -7282,6 +7286,8 @@
 </dd>
 <dt><span class="strong"><a href="./org/apache/kafka/clients/admin/Config.html#toString()">toString()</a></span> - Method in class org.apache.kafka.clients.admin.<a href="./org/apache/kafka/clients/admin/Config.html" title="class in org.apache.kafka.clients.admin">Config</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/kafka/clients/admin/ConfigEntry.html#toString()">toString()</a></span> - Method in class org.apache.kafka.clients.admin.<a href="./org/apache/kafka/clients/admin/ConfigEntry.html" title="class in org.apache.kafka.clients.admin">ConfigEntry</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/kafka/clients/admin/NewTopic.html#toString()">toString()</a></span> - Method in class org.apache.kafka.clients.admin.<a href="./org/apache/kafka/clients/admin/NewTopic.html" title="class in org.apache.kafka.clients.admin">NewTopic</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/kafka/clients/admin/TopicDescription.html#toString()">toString()</a></span> - Method in class org.apache.kafka.clients.admin.<a href="./org/apache/kafka/clients/admin/TopicDescription.html" title="class in org.apache.kafka.clients.admin">TopicDescription</a></dt>
@@ -7310,6 +7316,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/kafka/common/ClusterResource.html#toString()">toString()</a></span> - Method in class org.apache.kafka.common.<a href="./org/apache/kafka/common/ClusterResource.html" title="class in org.apache.kafka.common">ClusterResource</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/kafka/common/config/ConfigDef.NonEmptyString.html#toString()">toString()</a></span> - Method in class org.apache.kafka.common.config.<a href="./org/apache/kafka/common/config/ConfigDef.NonEmptyString.html" title="class in org.apache.kafka.common.config">ConfigDef.NonEmptyString</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/kafka/common/config/ConfigDef.Range.html#toString()">toString()</a></span> - Method in class org.apache.kafka.common.config.<a href="./org/apache/kafka/common/config/ConfigDef.Range.html" title="class in org.apache.kafka.common.config">ConfigDef.Range</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/kafka/common/config/ConfigDef.ValidList.html#toString()">toString()</a></span> - Method in class org.apache.kafka.common.config.<a href="./org/apache/kafka/common/config/ConfigDef.ValidList.html" title="class in org.apache.kafka.common.config">ConfigDef.ValidList</a></dt>
@@ -7531,7 +7539,9 @@
 <dt><span class="strong"><a href="./org/apache/kafka/common/errors/UnsupportedSaslMechanismException.html#UnsupportedSaslMechanismException(java.lang.String,%20java.lang.Throwable)">UnsupportedSaslMechanismException(String, Throwable)</a></span> - Constructor for exception org.apache.kafka.common.errors.<a href="./org/apache/kafka/common/errors/UnsupportedSaslMechanismException.html" title="class in org.apache.kafka.common.errors">UnsupportedSaslMechanismException</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="./org/apache/kafka/common/errors/UnsupportedVersionException.html" title="class in org.apache.kafka.common.errors"><span class="strong">UnsupportedVersionException</span></a> - Exception in <a href="./org/apache/kafka/common/errors/package-summary.html">org.apache.kafka.common.errors</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block">Indicates that a request API or version needed by the client is not supported by the broker.</div>
+</dd>
 <dt><span class="strong"><a href="./org/apache/kafka/common/errors/UnsupportedVersionException.html#UnsupportedVersionException(java.lang.String,%20java.lang.Throwable)">UnsupportedVersionException(String, Throwable)</a></span> - Constructor for exception org.apache.kafka.common.errors.<a href="./org/apache/kafka/common/errors/UnsupportedVersionException.html" title="class in org.apache.kafka.common.errors">UnsupportedVersionException</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/kafka/common/errors/UnsupportedVersionException.html#UnsupportedVersionException(java.lang.String)">UnsupportedVersionException(String)</a></span> - Constructor for exception org.apache.kafka.common.errors.<a href="./org/apache/kafka/common/errors/UnsupportedVersionException.html" title="class in org.apache.kafka.common.errors">UnsupportedVersionException</a></dt>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/index.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/index.html b/0110/javadoc/index.html
index 6457a1f..731fccc 100644
--- a/0110/javadoc/index.html
+++ b/0110/javadoc/index.html
@@ -2,8 +2,8 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc on Thu Jun 22 23:10:09 BST 2017 -->
-<title>kafka 0.11.0.0 API</title>
+<!-- Generated by javadoc on Tue Sep 05 19:20:59 BST 2017 -->
+<title>kafka 0.11.0.1 API</title>
 <script type="text/javascript">
     targetPage = "" + window.location.search;
     if (targetPage != "" && targetPage != "undefined")

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/AdminClient.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/AdminClient.html b/0110/javadoc/org/apache/kafka/clients/admin/AdminClient.html
index c3c11ad..aae4a1a 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/AdminClient.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/AdminClient.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>AdminClient (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>AdminClient (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="AdminClient (kafka 0.11.0.0 API)";
+        parent.document.title="AdminClient (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/AdminClientConfig.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/AdminClientConfig.html b/0110/javadoc/org/apache/kafka/clients/admin/AdminClientConfig.html
index 6066854..7cbc922 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/AdminClientConfig.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/AdminClientConfig.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>AdminClientConfig (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>AdminClientConfig (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="AdminClientConfig (kafka 0.11.0.0 API)";
+        parent.document.title="AdminClientConfig (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/AlterConfigsOptions.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/AlterConfigsOptions.html b/0110/javadoc/org/apache/kafka/clients/admin/AlterConfigsOptions.html
index e9d3570..ec61e4c 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/AlterConfigsOptions.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/AlterConfigsOptions.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>AlterConfigsOptions (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>AlterConfigsOptions (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="AlterConfigsOptions (kafka 0.11.0.0 API)";
+        parent.document.title="AlterConfigsOptions (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/AlterConfigsResult.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/AlterConfigsResult.html b/0110/javadoc/org/apache/kafka/clients/admin/AlterConfigsResult.html
index 6c013ec..37d356a 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/AlterConfigsResult.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/AlterConfigsResult.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>AlterConfigsResult (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>AlterConfigsResult (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="AlterConfigsResult (kafka 0.11.0.0 API)";
+        parent.document.title="AlterConfigsResult (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/Config.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/Config.html b/0110/javadoc/org/apache/kafka/clients/admin/Config.html
index f08f06f..60e94fd 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/Config.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/Config.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>Config (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>Config (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="Config (kafka 0.11.0.0 API)";
+        parent.document.title="Config (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/ConfigEntry.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/ConfigEntry.html b/0110/javadoc/org/apache/kafka/clients/admin/ConfigEntry.html
index bab37ee..4416176 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/ConfigEntry.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/ConfigEntry.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>ConfigEntry (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>ConfigEntry (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="ConfigEntry (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigEntry (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -174,6 +174,10 @@ extends <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?
 </tr>
 <tr class="altColor">
 <td class="colFirst"><code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a></code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/kafka/clients/admin/ConfigEntry.html#toString()">toString</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a></code></td>
 <td class="colLast"><code><strong><a href="../../../../../org/apache/kafka/clients/admin/ConfigEntry.html#value()">value</a></strong>()</code>
 <div class="block">Return the value or null.</div>
 </td>
@@ -184,7 +188,7 @@ extends <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?
 <!--   -->
 </a>
 <h3>Methods inherited from class&nbsp;java.lang.<a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a></h3>
-<code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#clone()" title="class or interface in java.lang">clone</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#equals(java.lang.Object)" title="class or interface in java.lang">equals</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#finalize()" title="class or interface in java.lang">finalize</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#getClass()" title="class or interface in java.lang">getClass</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#hashCode()" title="class or interface in java.lang">hashCode</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#notify()" title="class or interface in java.lang">notify</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang
 /Object.html?is-external=true#notifyAll()" title="class or interface in java.lang">notifyAll</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#toString()" title="class or interface in java.lang">toString</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#wait()" title="class or interface in java.lang">wait</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#wait(long)" title="class or interface in java.lang">wait</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#wait(long,%20int)" title="class or interface in java.lang">wait</a></code></li>
+<code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#clone()" title="class or interface in java.lang">clone</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#equals(java.lang.Object)" title="class or interface in java.lang">equals</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#finalize()" title="class or interface in java.lang">finalize</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#getClass()" title="class or interface in java.lang">getClass</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#hashCode()" title="class or interface in java.lang">hashCode</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#notify()" title="class or interface in java.lang">notify</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang
 /Object.html?is-external=true#notifyAll()" title="class or interface in java.lang">notifyAll</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#wait()" title="class or interface in java.lang">wait</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#wait(long)" title="class or interface in java.lang">wait</a>, <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#wait(long,%20int)" title="class or interface in java.lang">wait</a></code></li>
 </ul>
 </li>
 </ul>
@@ -279,13 +283,26 @@ extends <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?
 <a name="isReadOnly()">
 <!--   -->
 </a>
-<ul class="blockListLast">
+<ul class="blockList">
 <li class="blockList">
 <h4>isReadOnly</h4>
 <pre>public&nbsp;boolean&nbsp;isReadOnly()</pre>
 <div class="block">Return whether the config is read-only and cannot be updated.</div>
 </li>
 </ul>
+<a name="toString()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>toString</h4>
+<pre>public&nbsp;<a href="http://docs.oracle.com/javase/7/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;toString()</pre>
+<dl>
+<dt><strong>Overrides:</strong></dt>
+<dd><code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true#toString()" title="class or interface in java.lang">toString</a></code>&nbsp;in class&nbsp;<code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a></code></dd>
+</dl>
+</li>
+</ul>
 </li>
 </ul>
 </li>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/CreateAclsOptions.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/CreateAclsOptions.html b/0110/javadoc/org/apache/kafka/clients/admin/CreateAclsOptions.html
index 25ac5ce..0ddad8b 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/CreateAclsOptions.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/CreateAclsOptions.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>CreateAclsOptions (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>CreateAclsOptions (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="CreateAclsOptions (kafka 0.11.0.0 API)";
+        parent.document.title="CreateAclsOptions (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/CreateAclsResult.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/CreateAclsResult.html b/0110/javadoc/org/apache/kafka/clients/admin/CreateAclsResult.html
index 952c9cc..0cdf358 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/CreateAclsResult.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/CreateAclsResult.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>CreateAclsResult (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>CreateAclsResult (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="CreateAclsResult (kafka 0.11.0.0 API)";
+        parent.document.title="CreateAclsResult (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/CreateTopicsOptions.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/CreateTopicsOptions.html b/0110/javadoc/org/apache/kafka/clients/admin/CreateTopicsOptions.html
index e9dbfe5..e0419a7 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/CreateTopicsOptions.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/CreateTopicsOptions.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>CreateTopicsOptions (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>CreateTopicsOptions (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="CreateTopicsOptions (kafka 0.11.0.0 API)";
+        parent.document.title="CreateTopicsOptions (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/CreateTopicsResult.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/CreateTopicsResult.html b/0110/javadoc/org/apache/kafka/clients/admin/CreateTopicsResult.html
index 1921d5d..82b5cb4 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/CreateTopicsResult.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/CreateTopicsResult.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>CreateTopicsResult (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>CreateTopicsResult (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="CreateTopicsResult (kafka 0.11.0.0 API)";
+        parent.document.title="CreateTopicsResult (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsOptions.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsOptions.html b/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsOptions.html
index b700723..c61e459 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsOptions.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsOptions.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>DeleteAclsOptions (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>DeleteAclsOptions (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="DeleteAclsOptions (kafka 0.11.0.0 API)";
+        parent.document.title="DeleteAclsOptions (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.FilterResult.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.FilterResult.html b/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.FilterResult.html
index 9d795c0..671da37 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.FilterResult.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.FilterResult.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>DeleteAclsResult.FilterResult (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>DeleteAclsResult.FilterResult (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="DeleteAclsResult.FilterResult (kafka 0.11.0.0 API)";
+        parent.document.title="DeleteAclsResult.FilterResult (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.FilterResults.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.FilterResults.html b/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.FilterResults.html
index fb9ac7a..7175e07 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.FilterResults.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.FilterResults.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>DeleteAclsResult.FilterResults (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>DeleteAclsResult.FilterResults (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="DeleteAclsResult.FilterResults (kafka 0.11.0.0 API)";
+        parent.document.title="DeleteAclsResult.FilterResults (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.html b/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.html
index 72ddbbc..2ea669a 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DeleteAclsResult.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>DeleteAclsResult (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>DeleteAclsResult (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="DeleteAclsResult (kafka 0.11.0.0 API)";
+        parent.document.title="DeleteAclsResult (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/DeleteTopicsOptions.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DeleteTopicsOptions.html b/0110/javadoc/org/apache/kafka/clients/admin/DeleteTopicsOptions.html
index fd08aae..4aa9ba5 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DeleteTopicsOptions.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DeleteTopicsOptions.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:07 BST 2017 -->
-<title>DeleteTopicsOptions (kafka 0.11.0.0 API)</title>
-<meta name="date" content="2017-06-22">
+<!-- Generated by javadoc (version 1.7.0_79) on Tue Sep 05 19:20:57 BST 2017 -->
+<title>DeleteTopicsOptions (kafka 0.11.0.1 API)</title>
+<meta name="date" content="2017-09-05">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
 <script type="text/javascript"><!--
     if (location.href.indexOf('is-external=true') == -1) {
-        parent.document.title="DeleteTopicsOptions (kafka 0.11.0.0 API)";
+        parent.document.title="DeleteTopicsOptions (kafka 0.11.0.1 API)";
     }
 //-->
 </script>