You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kafka.apache.org by rs...@apache.org on 2017/11/17 14:47:22 UTC

[51/51] [partial] kafka-site git commit: Update site for 0.11.0.2 release

Update site for 0.11.0.2 release

Also includes:
KAFKA-6222: Use www.apache.org/dist/kafka for sigs and hashes
KAFKA-6223: Use archive server for old releases


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

Branch: refs/heads/asf-site
Commit: ae86b7d5daed0608d61a34032a41ece4b3947f4d
Parents: 240ddda
Author: Rajini Sivaram <ra...@googlemail.com>
Authored: Fri Nov 17 14:16:02 2017 +0000
Committer: Rajini Sivaram <ra...@googlemail.com>
Committed: Fri Nov 17 14:19:55 2017 +0000

----------------------------------------------------------------------
 0110/javadoc/allclasses-frame.html              |   6 +-
 0110/javadoc/allclasses-noframe.html            |   6 +-
 0110/javadoc/constant-values.html               | 502 +++++++++----------
 0110/javadoc/deprecated-list.html               |   8 +-
 0110/javadoc/help-doc.html                      |   8 +-
 0110/javadoc/index-all.html                     |  38 +-
 0110/javadoc/index.html                         |   4 +-
 .../apache/kafka/clients/admin/AdminClient.html |  90 ++--
 .../kafka/clients/admin/AdminClientConfig.html  | 100 ++--
 .../clients/admin/AlterConfigsOptions.html      |  24 +-
 .../kafka/clients/admin/AlterConfigsResult.html |  24 +-
 .../org/apache/kafka/clients/admin/Config.html  |  42 +-
 .../apache/kafka/clients/admin/ConfigEntry.html |  46 +-
 .../kafka/clients/admin/CreateAclsOptions.html  |  24 +-
 .../kafka/clients/admin/CreateAclsResult.html   |  24 +-
 .../clients/admin/CreateTopicsOptions.html      |  24 +-
 .../kafka/clients/admin/CreateTopicsResult.html |  24 +-
 .../kafka/clients/admin/DeleteAclsOptions.html  |  24 +-
 .../admin/DeleteAclsResult.FilterResult.html    |  16 +-
 .../admin/DeleteAclsResult.FilterResults.html   |  20 +-
 .../kafka/clients/admin/DeleteAclsResult.html   |  24 +-
 .../clients/admin/DeleteTopicsOptions.html      |  24 +-
 .../kafka/clients/admin/DeleteTopicsResult.html |  24 +-
 .../clients/admin/DescribeAclsOptions.html      |  24 +-
 .../kafka/clients/admin/DescribeAclsResult.html |  20 +-
 .../clients/admin/DescribeClusterOptions.html   |  24 +-
 .../clients/admin/DescribeClusterResult.html    |  24 +-
 .../clients/admin/DescribeConfigsOptions.html   |  24 +-
 .../clients/admin/DescribeConfigsResult.html    |  24 +-
 .../clients/admin/DescribeTopicsOptions.html    |  24 +-
 .../clients/admin/DescribeTopicsResult.html     |  24 +-
 .../kafka/clients/admin/KafkaAdminClient.html   |  48 +-
 .../kafka/clients/admin/ListTopicsOptions.html  |  24 +-
 .../kafka/clients/admin/ListTopicsResult.html   |  28 +-
 .../apache/kafka/clients/admin/NewTopic.html    |  46 +-
 .../kafka/clients/admin/TopicDescription.html   |  38 +-
 .../kafka/clients/admin/TopicListing.html       |  30 +-
 .../kafka/clients/admin/package-frame.html      |   6 +-
 .../kafka/clients/admin/package-summary.html    |   8 +-
 .../kafka/clients/admin/package-tree.html       |  12 +-
 .../clients/consumer/CommitFailedException.html |  26 +-
 .../apache/kafka/clients/consumer/Consumer.html | 104 ++--
 .../kafka/clients/consumer/ConsumerConfig.html  | 204 ++++----
 .../clients/consumer/ConsumerInterceptor.html   |  12 +-
 .../consumer/ConsumerRebalanceListener.html     |  16 +-
 .../kafka/clients/consumer/ConsumerRecord.html  |  44 +-
 .../kafka/clients/consumer/ConsumerRecords.html |  48 +-
 .../consumer/InvalidOffsetException.html        |  34 +-
 .../kafka/clients/consumer/KafkaConsumer.html   | 157 +++---
 .../kafka/clients/consumer/MockConsumer.html    | 134 ++---
 .../consumer/NoOffsetForPartitionException.html |  36 +-
 .../clients/consumer/OffsetAndMetadata.html     |  42 +-
 .../clients/consumer/OffsetAndTimestamp.html    |  30 +-
 .../clients/consumer/OffsetCommitCallback.html  |  16 +-
 .../consumer/OffsetOutOfRangeException.html     |  38 +-
 .../clients/consumer/OffsetResetStrategy.html   |  32 +-
 .../kafka/clients/consumer/RangeAssignor.html   |  28 +-
 .../RetriableCommitFailedException.html         |  46 +-
 .../clients/consumer/RoundRobinAssignor.html    |  38 +-
 .../kafka/clients/consumer/StickyAssignor.html  |  32 +-
 .../kafka/clients/consumer/package-frame.html   |   6 +-
 .../kafka/clients/consumer/package-summary.html |   8 +-
 .../kafka/clients/consumer/package-tree.html    |  28 +-
 .../producer/BufferExhaustedException.html      |  30 +-
 .../apache/kafka/clients/producer/Callback.html |  12 +-
 .../kafka/clients/producer/KafkaProducer.html   |  92 ++--
 .../kafka/clients/producer/MockProducer.html    |  66 +--
 .../kafka/clients/producer/Partitioner.html     |  28 +-
 .../apache/kafka/clients/producer/Producer.html |  48 +-
 .../kafka/clients/producer/ProducerConfig.html  | 192 +++----
 .../clients/producer/ProducerInterceptor.html   |  12 +-
 .../kafka/clients/producer/ProducerRecord.html  |  98 ++--
 .../kafka/clients/producer/RecordMetadata.html  |  34 +-
 .../kafka/clients/producer/package-frame.html   |   6 +-
 .../kafka/clients/producer/package-summary.html |   8 +-
 .../kafka/clients/producer/package-tree.html    |  22 +-
 .../org/apache/kafka/common/Cluster.html        | 108 ++--
 .../apache/kafka/common/ClusterResource.html    |  30 +-
 .../kafka/common/ClusterResourceListener.html   |   8 +-
 .../org/apache/kafka/common/Configurable.html   |  12 +-
 .../org/apache/kafka/common/KafkaException.html |  44 +-
 .../kafka/common/KafkaFuture.BiConsumer.html    |  16 +-
 .../kafka/common/KafkaFuture.Function.html      |  16 +-
 .../org/apache/kafka/common/KafkaFuture.html    |  74 +--
 .../javadoc/org/apache/kafka/common/Metric.html |   8 +-
 .../org/apache/kafka/common/MetricName.html     |  62 +--
 .../apache/kafka/common/MetricNameTemplate.html |  64 +--
 0110/javadoc/org/apache/kafka/common/Node.html  |  54 +-
 .../org/apache/kafka/common/PartitionInfo.html  |  30 +-
 .../org/apache/kafka/common/TopicPartition.html |  42 +-
 .../apache/kafka/common/TopicPartitionInfo.html |  38 +-
 .../kafka/common/acl/AccessControlEntry.html    |  46 +-
 .../common/acl/AccessControlEntryFilter.html    |  50 +-
 .../org/apache/kafka/common/acl/AclBinding.html |  30 +-
 .../kafka/common/acl/AclBindingFilter.html      |  34 +-
 .../apache/kafka/common/acl/AclOperation.html   |  40 +-
 .../kafka/common/acl/AclPermissionType.html     |  36 +-
 .../apache/kafka/common/acl/package-frame.html  |   6 +-
 .../kafka/common/acl/package-summary.html       |   8 +-
 .../apache/kafka/common/acl/package-tree.html   |  16 +-
 .../annotation/InterfaceStability.Evolving.html |  12 +-
 .../annotation/InterfaceStability.Stable.html   |  12 +-
 .../annotation/InterfaceStability.Unstable.html |  12 +-
 .../common/annotation/InterfaceStability.html   |  16 +-
 .../kafka/common/annotation/package-frame.html  |   6 +-
 .../common/annotation/package-summary.html      |   8 +-
 .../kafka/common/annotation/package-tree.html   |  16 +-
 .../kafka/common/config/AbstractConfig.html     | 166 +++---
 .../org/apache/kafka/common/config/Config.html  |  24 +-
 .../common/config/ConfigDef.ConfigKey.html      |  64 +--
 .../common/config/ConfigDef.Importance.html     |  32 +-
 .../common/config/ConfigDef.NonEmptyString.html |  30 +-
 .../kafka/common/config/ConfigDef.Range.html    |  42 +-
 .../common/config/ConfigDef.Recommender.html    |  26 +-
 .../kafka/common/config/ConfigDef.Type.html     |  32 +-
 .../common/config/ConfigDef.ValidList.html      |  34 +-
 .../common/config/ConfigDef.ValidString.html    |  34 +-
 .../common/config/ConfigDef.Validator.html      |  16 +-
 .../kafka/common/config/ConfigDef.Width.html    |  32 +-
 .../apache/kafka/common/config/ConfigDef.html   | 392 +++++++--------
 .../kafka/common/config/ConfigException.html    |  50 +-
 .../common/config/ConfigResource.Type.html      |  32 +-
 .../kafka/common/config/ConfigResource.html     |  38 +-
 .../apache/kafka/common/config/ConfigValue.html |  78 +--
 .../apache/kafka/common/config/SaslConfigs.html | 108 ++--
 .../apache/kafka/common/config/SslConfigs.html  | 180 +++----
 .../apache/kafka/common/config/TopicConfig.html | 200 ++++----
 .../kafka/common/config/package-frame.html      |   6 +-
 .../kafka/common/config/package-summary.html    |   8 +-
 .../kafka/common/config/package-tree.html       |  22 +-
 .../kafka/common/errors/ApiException.html       |  48 +-
 .../common/errors/AuthenticationException.html  |  38 +-
 .../common/errors/AuthorizationException.html   |  38 +-
 .../errors/BrokerNotAvailableException.html     |  38 +-
 .../errors/ClusterAuthorizationException.html   |  38 +-
 .../errors/ConcurrentTransactionsException.html |  30 +-
 .../common/errors/ControllerMovedException.html |  38 +-
 .../CoordinatorLoadInProgressException.html     |  38 +-
 .../CoordinatorNotAvailableException.html       |  38 +-
 .../common/errors/CorruptRecordException.html   |  42 +-
 .../common/errors/DisconnectException.html      |  42 +-
 .../DuplicateSequenceNumberException.html       |  30 +-
 .../errors/GroupAuthorizationException.html     |  34 +-
 .../GroupCoordinatorNotAvailableException.html  |  44 +-
 .../errors/GroupLoadInProgressException.html    |  44 +-
 .../errors/IllegalGenerationException.html      |  42 +-
 .../errors/IllegalSaslStateException.html       |  38 +-
 .../InconsistentGroupProtocolException.html     |  38 +-
 .../kafka/common/errors/InterruptException.html |  42 +-
 .../InvalidCommitOffsetSizeException.html       |  38 +-
 .../errors/InvalidConfigurationException.html   |  38 +-
 .../errors/InvalidFetchSizeException.html       |  38 +-
 .../common/errors/InvalidGroupIdException.html  |  38 +-
 .../common/errors/InvalidMetadataException.html |  42 +-
 .../common/errors/InvalidOffsetException.html   |  38 +-
 .../errors/InvalidPartitionsException.html      |  38 +-
 .../errors/InvalidPidMappingException.html      |  30 +-
 .../InvalidReplicaAssignmentException.html      |  38 +-
 .../InvalidReplicationFactorException.html      |  38 +-
 .../common/errors/InvalidRequestException.html  |  38 +-
 .../errors/InvalidRequiredAcksException.html    |  30 +-
 .../errors/InvalidSessionTimeoutException.html  |  38 +-
 .../errors/InvalidTimestampException.html       |  38 +-
 .../common/errors/InvalidTopicException.html    |  42 +-
 .../common/errors/InvalidTxnStateException.html |  30 +-
 .../errors/InvalidTxnTimeoutException.html      |  38 +-
 .../errors/LeaderNotAvailableException.html     |  38 +-
 .../kafka/common/errors/NetworkException.html   |  42 +-
 .../common/errors/NotControllerException.html   |  38 +-
 .../common/errors/NotCoordinatorException.html  |  38 +-
 .../errors/NotCoordinatorForGroupException.html |  44 +-
 .../NotEnoughReplicasAfterAppendException.html  |  30 +-
 .../errors/NotEnoughReplicasException.html      |  42 +-
 .../errors/NotLeaderForPartitionException.html  |  42 +-
 .../common/errors/OffsetMetadataTooLarge.html   |  42 +-
 .../errors/OffsetOutOfRangeException.html       |  38 +-
 .../errors/OperationNotAttemptedException.html  |  30 +-
 .../errors/OutOfOrderSequenceException.html     |  30 +-
 .../common/errors/PolicyViolationException.html |  38 +-
 .../common/errors/ProducerFencedException.html  |  30 +-
 .../errors/RebalanceInProgressException.html    |  42 +-
 .../errors/RecordBatchTooLargeException.html    |  42 +-
 .../common/errors/RecordTooLargeException.html  |  54 +-
 .../errors/ReplicaNotAvailableException.html    |  42 +-
 .../kafka/common/errors/RetriableException.html |  42 +-
 .../errors/SecurityDisabledException.html       |  38 +-
 .../common/errors/SerializationException.html   |  48 +-
 .../kafka/common/errors/TimeoutException.html   |  42 +-
 .../errors/TopicAuthorizationException.html     |  38 +-
 .../common/errors/TopicExistsException.html     |  38 +-
 .../TransactionCoordinatorFencedException.html  |  38 +-
 .../TransactionalIdAuthorizationException.html  |  30 +-
 .../common/errors/UnknownMemberIdException.html |  42 +-
 .../common/errors/UnknownServerException.html   |  42 +-
 .../UnknownTopicOrPartitionException.html       |  42 +-
 .../UnsupportedForMessageFormatException.html   |  38 +-
 .../UnsupportedSaslMechanismException.html      |  38 +-
 .../errors/UnsupportedVersionException.html     |  38 +-
 .../kafka/common/errors/WakeupException.html    |  26 +-
 .../kafka/common/errors/package-frame.html      |   6 +-
 .../kafka/common/errors/package-summary.html    |   8 +-
 .../kafka/common/errors/package-tree.html       |  16 +-
 .../org/apache/kafka/common/header/Header.html  |  12 +-
 .../org/apache/kafka/common/header/Headers.html |  46 +-
 .../kafka/common/header/package-frame.html      |   6 +-
 .../kafka/common/header/package-summary.html    |   8 +-
 .../kafka/common/header/package-tree.html       |  10 +-
 .../org/apache/kafka/common/package-frame.html  |   6 +-
 .../apache/kafka/common/package-summary.html    |   8 +-
 .../org/apache/kafka/common/package-tree.html   |  20 +-
 .../apache/kafka/common/resource/Resource.html  |  42 +-
 .../kafka/common/resource/ResourceFilter.html   |  42 +-
 .../kafka/common/resource/ResourceType.html     |  40 +-
 .../kafka/common/resource/package-frame.html    |   6 +-
 .../kafka/common/resource/package-summary.html  |   8 +-
 .../kafka/common/resource/package-tree.html     |  14 +-
 .../serialization/ByteArrayDeserializer.html    |  30 +-
 .../serialization/ByteArraySerializer.html      |  30 +-
 .../serialization/ByteBufferDeserializer.html   |  42 +-
 .../serialization/ByteBufferSerializer.html     |  42 +-
 .../common/serialization/BytesDeserializer.html |  30 +-
 .../common/serialization/BytesSerializer.html   |  30 +-
 .../common/serialization/Deserializer.html      |  24 +-
 .../serialization/DoubleDeserializer.html       |  42 +-
 .../common/serialization/DoubleSerializer.html  |  42 +-
 .../ExtendedDeserializer.Wrapper.html           |  34 +-
 .../serialization/ExtendedDeserializer.html     |  14 +-
 .../ExtendedSerializer.Wrapper.html             |  34 +-
 .../serialization/ExtendedSerializer.html       |  14 +-
 .../common/serialization/FloatDeserializer.html |  42 +-
 .../common/serialization/FloatSerializer.html   |  42 +-
 .../serialization/IntegerDeserializer.html      |  42 +-
 .../common/serialization/IntegerSerializer.html |  42 +-
 .../common/serialization/LongDeserializer.html  |  42 +-
 .../common/serialization/LongSerializer.html    |  42 +-
 .../kafka/common/serialization/Serde.html       |  20 +-
 .../serialization/Serdes.ByteArraySerde.html    |  16 +-
 .../serialization/Serdes.ByteBufferSerde.html   |  20 +-
 .../common/serialization/Serdes.BytesSerde.html |  16 +-
 .../serialization/Serdes.DoubleSerde.html       |  20 +-
 .../common/serialization/Serdes.FloatSerde.html |  20 +-
 .../serialization/Serdes.IntegerSerde.html      |  20 +-
 .../common/serialization/Serdes.LongSerde.html  |  20 +-
 .../common/serialization/Serdes.ShortSerde.html |  20 +-
 .../serialization/Serdes.StringSerde.html       |  20 +-
 .../serialization/Serdes.WrapperSerde.html      |  26 +-
 .../kafka/common/serialization/Serdes.html      |  48 +-
 .../kafka/common/serialization/Serializer.html  |  24 +-
 .../common/serialization/ShortDeserializer.html |  42 +-
 .../common/serialization/ShortSerializer.html   |  42 +-
 .../serialization/StringDeserializer.html       |  42 +-
 .../common/serialization/StringSerializer.html  |  42 +-
 .../common/serialization/package-frame.html     |   6 +-
 .../common/serialization/package-summary.html   |   8 +-
 .../common/serialization/package-tree.html      |  14 +-
 .../kafka/connect/connector/ConnectRecord.html  |  90 ++--
 .../kafka/connect/connector/Connector.html      |  44 +-
 .../connect/connector/ConnectorContext.html     |  12 +-
 .../apache/kafka/connect/connector/Task.html    |  16 +-
 .../kafka/connect/connector/package-frame.html  |   6 +-
 .../connect/connector/package-summary.html      |   8 +-
 .../kafka/connect/connector/package-tree.html   |  10 +-
 .../kafka/connect/data/ConnectSchema.html       | 118 ++---
 .../org/apache/kafka/connect/data/Date.html     |  30 +-
 .../org/apache/kafka/connect/data/Decimal.html  |  34 +-
 .../org/apache/kafka/connect/data/Field.html    |  32 +-
 .../apache/kafka/connect/data/Schema.Type.html  |  36 +-
 .../org/apache/kafka/connect/data/Schema.html   |  36 +-
 .../kafka/connect/data/SchemaAndValue.html      |  38 +-
 .../kafka/connect/data/SchemaBuilder.html       |  76 +--
 .../kafka/connect/data/SchemaProjector.html     |  28 +-
 .../org/apache/kafka/connect/data/Struct.html   | 130 ++---
 .../org/apache/kafka/connect/data/Time.html     |  30 +-
 .../apache/kafka/connect/data/Timestamp.html    |  30 +-
 .../kafka/connect/data/package-frame.html       |   6 +-
 .../kafka/connect/data/package-summary.html     |   8 +-
 .../apache/kafka/connect/data/package-tree.html |  14 +-
 .../connect/errors/AlreadyExistsException.html  |  42 +-
 .../kafka/connect/errors/ConnectException.html  |  42 +-
 .../kafka/connect/errors/DataException.html     |  42 +-
 .../errors/IllegalWorkerStateException.html     |  42 +-
 .../kafka/connect/errors/NotFoundException.html |  42 +-
 .../connect/errors/RetriableException.html      |  42 +-
 .../connect/errors/SchemaBuilderException.html  |  42 +-
 .../errors/SchemaProjectorException.html        |  42 +-
 .../kafka/connect/errors/package-frame.html     |   6 +-
 .../kafka/connect/errors/package-summary.html   |   8 +-
 .../kafka/connect/errors/package-tree.html      |  16 +-
 .../kafka/connect/sink/SinkConnector.html       |  18 +-
 .../apache/kafka/connect/sink/SinkRecord.html   |  70 +--
 .../org/apache/kafka/connect/sink/SinkTask.html |  58 +--
 .../kafka/connect/sink/SinkTaskContext.html     |  16 +-
 .../kafka/connect/sink/package-frame.html       |   6 +-
 .../kafka/connect/sink/package-summary.html     |   8 +-
 .../apache/kafka/connect/sink/package-tree.html |  10 +-
 .../kafka/connect/source/SourceConnector.html   |  14 +-
 .../kafka/connect/source/SourceRecord.html      | 158 +++---
 .../apache/kafka/connect/source/SourceTask.html |  40 +-
 .../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      |  10 +-
 .../apache/kafka/connect/storage/Converter.html |  24 +-
 .../connect/storage/OffsetStorageReader.html    |  20 +-
 .../kafka/connect/storage/StringConverter.html  |  34 +-
 .../kafka/connect/storage/package-frame.html    |   6 +-
 .../kafka/connect/storage/package-summary.html  |   8 +-
 .../kafka/connect/storage/package-tree.html     |  10 +-
 .../connect/transforms/Transformation.html      |  16 +-
 .../kafka/connect/transforms/package-frame.html |   6 +-
 .../connect/transforms/package-summary.html     |   8 +-
 .../kafka/connect/transforms/package-tree.html  |  14 +-
 .../kafka/connect/util/ConnectorUtils.html      |  24 +-
 .../kafka/connect/util/package-frame.html       |   6 +-
 .../kafka/connect/util/package-summary.html     |   8 +-
 .../apache/kafka/connect/util/package-tree.html |  10 +-
 .../AlterConfigPolicy.RequestMetadata.html      |  30 +-
 .../kafka/server/policy/AlterConfigPolicy.html  |  16 +-
 .../CreateTopicPolicy.RequestMetadata.html      |  62 +--
 .../kafka/server/policy/CreateTopicPolicy.html  |  16 +-
 .../kafka/server/policy/package-frame.html      |   6 +-
 .../kafka/server/policy/package-summary.html    |   8 +-
 .../kafka/server/policy/package-tree.html       |  16 +-
 .../kafka/streams/KafkaClientSupplier.html      |  20 +-
 .../kafka/streams/KafkaStreams.State.html       |  32 +-
 .../streams/KafkaStreams.StateListener.html     |   8 +-
 .../org/apache/kafka/streams/KafkaStreams.html  |  72 +--
 .../org/apache/kafka/streams/KeyValue.html      |  30 +-
 .../streams/StreamsConfig.InternalConfig.html   |  20 +-
 .../org/apache/kafka/streams/StreamsConfig.html | 244 ++++-----
 .../apache/kafka/streams/StreamsMetrics.html    |  52 +-
 .../streams/errors/BrokerNotFoundException.html |  42 +-
 .../errors/InvalidStateStoreException.html      |  42 +-
 .../kafka/streams/errors/LockException.html     |  42 +-
 .../streams/errors/ProcessorStateException.html |  42 +-
 .../kafka/streams/errors/StreamsException.html  |  42 +-
 .../streams/errors/TaskAssignmentException.html |  42 +-
 .../streams/errors/TaskIdFormatException.html   |  42 +-
 .../errors/TopologyBuilderException.html        |  42 +-
 .../kafka/streams/errors/package-frame.html     |   6 +-
 .../kafka/streams/errors/package-summary.html   |   8 +-
 .../kafka/streams/errors/package-tree.html      |  16 +-
 .../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      |  46 +-
 .../kafka/streams/kstream/KGroupedStream.html   | 100 ++--
 .../kafka/streams/kstream/KGroupedTable.html    |  40 +-
 .../apache/kafka/streams/kstream/KStream.html   | 128 ++---
 .../kafka/streams/kstream/KStreamBuilder.html   | 206 ++++----
 .../apache/kafka/streams/kstream/KTable.html    | 198 ++++----
 .../kafka/streams/kstream/KeyValueMapper.html   |   8 +-
 .../apache/kafka/streams/kstream/Merger.html    |   8 +-
 .../apache/kafka/streams/kstream/Predicate.html |   8 +-
 .../streams/kstream/PrintForeachAction.html     |  24 +-
 .../apache/kafka/streams/kstream/Reducer.html   |   8 +-
 .../kafka/streams/kstream/SessionWindows.html   |  22 +-
 .../kafka/streams/kstream/TimeWindows.html      |  36 +-
 .../kafka/streams/kstream/Transformer.html      |   8 +-
 .../streams/kstream/TransformerSupplier.html    |   8 +-
 .../kafka/streams/kstream/UnlimitedWindows.html |  44 +-
 .../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    |  36 +-
 .../apache/kafka/streams/kstream/Windowed.html  |  30 +-
 .../apache/kafka/streams/kstream/Windows.html   |  28 +-
 .../kafka/streams/kstream/package-frame.html    |   6 +-
 .../kafka/streams/kstream/package-summary.html  |   8 +-
 .../kafka/streams/kstream/package-tree.html     |  10 +-
 .../org/apache/kafka/streams/package-frame.html |   6 +-
 .../apache/kafka/streams/package-summary.html   |   8 +-
 .../org/apache/kafka/streams/package-tree.html  |  14 +-
 .../streams/processor/AbstractProcessor.html    |  16 +-
 .../processor/DefaultPartitionGrouper.html      |  28 +-
 .../processor/FailOnInvalidTimestamp.html       |  24 +-
 .../processor/LogAndSkipOnInvalidTimestamp.html |  24 +-
 .../streams/processor/PartitionGrouper.html     |  16 +-
 .../kafka/streams/processor/Processor.html      |   8 +-
 .../streams/processor/ProcessorContext.html     |  38 +-
 .../streams/processor/ProcessorSupplier.html    |   8 +-
 .../streams/processor/StateRestoreCallback.html |   8 +-
 .../kafka/streams/processor/StateStore.html     |  12 +-
 .../streams/processor/StateStoreSupplier.html   |  16 +-
 .../streams/processor/StreamPartitioner.html    |  16 +-
 .../apache/kafka/streams/processor/TaskId.html  |  64 +--
 .../streams/processor/TimestampExtractor.html   |  14 +-
 .../TopologyBuilder.AutoOffsetReset.html        |  32 +-
 .../processor/TopologyBuilder.TopicsInfo.html   |  46 +-
 .../streams/processor/TopologyBuilder.html      | 276 +++++-----
 .../UsePreviousTimeOnInvalidTimestamp.html      |  24 +-
 .../processor/WallclockTimestampExtractor.html  |  22 +-
 .../kafka/streams/processor/package-frame.html  |   6 +-
 .../streams/processor/package-summary.html      |  10 +-
 .../kafka/streams/processor/package-tree.html   |  16 +-
 .../apache/kafka/streams/state/HostInfo.html    |  38 +-
 .../kafka/streams/state/KeyValueIterator.html   |  22 +-
 .../kafka/streams/state/KeyValueStore.html      |  20 +-
 .../kafka/streams/state/QueryableStoreType.html |  12 +-
 .../streams/state/QueryableStoreTypes.html      |  16 +-
 .../streams/state/ReadOnlyKeyValueStore.html    |  16 +-
 .../streams/state/ReadOnlySessionStore.html     |   8 +-
 .../streams/state/ReadOnlyWindowStore.html      |   8 +-
 .../streams/state/RocksDBConfigSetter.html      |  16 +-
 .../kafka/streams/state/SessionStore.html       |   8 +-
 .../apache/kafka/streams/state/StateSerdes.html |  38 +-
 .../state/Stores.InMemoryKeyValueFactory.html   |  16 +-
 .../streams/state/Stores.KeyValueFactory.html   |   8 +-
 .../state/Stores.PersistentKeyValueFactory.html |  12 +-
 .../streams/state/Stores.StoreFactory.html      |  60 +--
 .../streams/state/Stores.ValueFactory.html      |  60 +--
 .../org/apache/kafka/streams/state/Stores.html  |  20 +-
 .../kafka/streams/state/StreamsMetadata.html    |  50 +-
 .../apache/kafka/streams/state/WindowStore.html |   8 +-
 .../streams/state/WindowStoreIterator.html      |  26 +-
 .../kafka/streams/state/package-frame.html      |   6 +-
 .../kafka/streams/state/package-summary.html    |  10 +-
 .../kafka/streams/state/package-tree.html       |  24 +-
 0110/javadoc/overview-frame.html                |   6 +-
 0110/javadoc/overview-summary.html              |  10 +-
 0110/javadoc/overview-tree.html                 |  62 +--
 0110/javadoc/serialized-form.html               |  28 +-
 0110/js/templateData.js                         |   2 +-
 0110/security.html                              |   2 +-
 0110/streams/tutorial.html                      |   2 -
 downloads.html                                  | 149 +++---
 428 files changed, 7744 insertions(+), 7722 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/kafka-site/blob/ae86b7d5/0110/javadoc/allclasses-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/allclasses-frame.html b/0110/javadoc/allclasses-frame.html
index 696da9d..302bbd0 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_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">
+<!-- Generated by javadoc (version 1.7.0_80) on Fri Nov 10 23:49:20 GMT 2017 -->
+<title>All Classes (kafka 0.11.0.2 API)</title>
+<meta name="date" content="2017-11-10">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/ae86b7d5/0110/javadoc/allclasses-noframe.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/allclasses-noframe.html b/0110/javadoc/allclasses-noframe.html
index 818d738..d8da0af 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_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">
+<!-- Generated by javadoc (version 1.7.0_80) on Fri Nov 10 23:49:20 GMT 2017 -->
+<title>All Classes (kafka 0.11.0.2 API)</title>
+<meta name="date" content="2017-11-10">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>