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:18 UTC

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

Repository: kafka-site
Updated Branches:
  refs/heads/asf-site 8c85a0e4f -> 067552523


http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/streams/core-concepts.html
----------------------------------------------------------------------
diff --git a/0110/streams/core-concepts.html b/0110/streams/core-concepts.html
index b50495d..7349c3a 100644
--- a/0110/streams/core-concepts.html
+++ b/0110/streams/core-concepts.html
@@ -21,6 +21,28 @@
     <h1>Core Concepts</h1>
 
     <p>
+        Kafka Streams is a client library for processing and analyzing data stored in Kafka.
+        It builds upon important stream processing concepts such as properly distinguishing between event time and processing time, windowing support, and simple yet efficient management of application state.
+    </p>
+    <p>
+        Kafka Streams has a <b>low barrier to entry</b>: You can quickly write and run a small-scale proof-of-concept on a single machine; and you only need to run additional instances of your application on multiple machines to scale up to high-volume production workloads.
+        Kafka Streams transparently handles the load balancing of multiple instances of the same application by leveraging Kafka's parallelism model.
+    </p>
+    <p>
+        Some highlights of Kafka Streams:
+    </p>
+
+    <ul>
+        <li>Designed as a <b>simple and lightweight client library</b>, which can be easily embedded in any Java application and integrated with any existing packaging, deployment and operational tools that users have for their streaming applications.</li>
+        <li>Has <b>no external dependencies on systems other than Apache Kafka itself</b> as the internal messaging layer; notably, it uses Kafka's partitioning model to horizontally scale processing while maintaining strong ordering guarantees.</li>
+        <li>Supports <b>fault-tolerant local state</b>, which enables very fast and efficient stateful operations like windowed joins and aggregations.</li>
+        <li>Supports <b>exactly-once</b> processing semantics to guarantee that each record will be processed once and only once even when there is a failure on either Streams clients or Kafka brokers in the middle of processing.</li>
+        <li>Employs <b>one-record-at-a-time processing</b> to achieve millisecond processing latency, and supports <b>event-time based windowing operations</b> with late arrival of records.</li>
+        <li>Offers necessary stream processing primitives, along with a <b>high-level Streams DSL</b> and a <b>low-level Processor API</b>.</li>
+
+    </ul>
+
+    <p>
         We first summarize the key concepts of Kafka Streams.
     </p>
 
@@ -131,11 +153,11 @@
         To read more details on how this is done inside Kafka Streams, readers are recommended to read <a href="https://cwiki.apache.org/confluence/display/KAFKA/KIP-129%3A+Streams+Exactly-Once+Semantics">KIP-129</a>.
 
         In order to achieve exactly-once semantics when running Kafka Streams applications, users can simply set the <code>processing.guarantee</code> config value to <b>exactly_once</b> (default value is <b>at_least_once</b>).
-        More details can be found in the <a href="/{{version}}/documentation#streamsconfigs">Kafka Streams Configs</a> section.
+        More details can be found in the <a href="/{{version}}/documentation#streamsconfigs"><b>Kafka Streams Configs</b></a> section.
     </p>
 
     <div class="pagination">
-        <a href="/{{version}}/documentation/streams" class="pagination__btn pagination__btn__prev">Previous</a>
+        <a href="/{{version}}/documentation/streams/developer-guide" class="pagination__btn pagination__btn__prev">Previous</a>
         <a href="/{{version}}/documentation/streams/architecture" class="pagination__btn pagination__btn__next">Next</a>
     </div>
 </script>
@@ -148,7 +170,7 @@
         <!--#include virtual="../../includes/_docs_banner.htm" -->
         <ul class="breadcrumbs">
             <li><a href="/documentation">Documentation</a></li>
-            <li><a href="/documentation/streams">Streams</a></li>
+            <li><a href="/documentation/streams">Kafka Streams API</a></li>
         </ul>
         <div class="p-content"></div>
     </div>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/streams/developer-guide.html
----------------------------------------------------------------------
diff --git a/0110/streams/developer-guide.html b/0110/streams/developer-guide.html
index 6c75172..15298a7 100644
--- a/0110/streams/developer-guide.html
+++ b/0110/streams/developer-guide.html
@@ -18,7 +18,7 @@
 <script><!--#include virtual="../js/templateData.js" --></script>
 
 <script id="content-template" type="text/x-handlebars-template">
-    <h1>Developer Guide</h1>
+    <h1>Developer Manual</h1>
 
     <p>
         There is a <a href="/{{version}}/documentation/#quickstart_kafkastreams">quickstart</a> example that provides how to run a stream processing program coded in the Kafka Streams library.
@@ -505,7 +505,7 @@
         A Kafka Streams application is typically running on many instances.
         The state that is locally available on any given instance is only a subset of the application's entire state.
         Querying the local stores on an instance will, by definition, <i>only return data locally available on that particular instance</i>.
-        We explain how to access data in state stores that are not locally available in section <a href="#streams_developer-guide_interactive-queries_discovery">Querying remote state stores (for the entire application)</a>.
+        We explain how to access data in state stores that are not locally available in section <a href="#streams_developer-guide_interactive-queries_discovery"><b>Querying remote state stores</b></a> (for the entire application).
     </p>
 
     <p>
@@ -536,7 +536,7 @@
         This read-only constraint is important to guarantee that the underlying state stores will never be mutated (e.g. new entries added) out-of-band, i.e. only the corresponding processing topology of Kafka Streams is allowed to mutate and update the state stores in order to ensure data consistency.
     </p>
     <p>
-        You can also implement your own <code>QueryableStoreType</code> as described in section <a href="#streams_developer-guide_interactive-queries_custom-stores#">Querying local custom stores</a>
+        You can also implement your own <code>QueryableStoreType</code> as described in section <a href="#streams_developer-guide_interactive-queries_custom-stores#"><b>Querying local custom stores</b></a>
     </p>
 
     <p>
@@ -924,6 +924,181 @@
         <li>Collectively, this allows us to query the full state of the entire application</li>
     </ul>
 
+    <h3><a id="streams_developer-guide_memory-management" href="#streams_developer-guide_memory-management">Memory Management</a></h3>
+
+
+    <h4><a id="streams_developer-guide_memory-management_record-cache" href="#streams_developer-guide_memory-management_record-cache">Record caches in the DSL</a></h4>
+    <p>
+    Developers of an application using the DSL have the option to specify, for an instance of a processing topology, the
+    total memory (RAM) size of a record cache that is leveraged by the following <code>KTable</code> instances:
+    </p>
+
+    <ol>
+        <li>Source <code>KTable</code>, i.e. <code>KTable</code> instances that are created via <code>KStreamBuilder#table()</code> or <code>KStreamBuilder#globalTable()</code>.</li>
+        <li>Aggregation <code>KTable</code>, i.e. instances of <code>KTable</code> that are created as a result of aggregations</li>
+    </ol>
+    <p>
+        For such <code>KTable</code> instances, the record cache is used for:
+    </p>
+    <ol>
+        <li>Internal caching and compacting of output records before they are written by the underlying stateful processor node to its internal state store.</li>
+        <li>Internal caching and compacting of output records before they are forwarded from the underlying stateful processor node to any of its downstream processor nodes</li>
+    </ol>
+    <p>
+        Here is a motivating example:
+    </p>
+
+    <ul>
+        <li>Imagine the input is a <code>KStream&lt;String, Integer&gt;</code> with the records <code>&lt;A, 1&gt;, &lt;D, 5&gt;, &lt;A, 20&gt;, &lt;A, 300&gt;</code>.
+            Note that the focus in this example is on the records with key == <code>A</code>
+        </li>
+        <li>
+            An aggregation computes the sum of record values, grouped by key, for the input above and returns a <code>KTable&lt;String, Integer&gt;</code>.
+            <ul>
+                <li><b>Without caching</b>, what is emitted for key <code>A</code> is a sequence of output records that represent changes in the
+                    resulting aggregation table (here, the parentheses denote changes, where the left and right numbers denote the new
+                    aggregate value and the previous aggregate value, respectively):
+                    <code>&lt;A, (1, null)&gt;, &lt;A, (21, 1)&gt;, &lt;A, (321, 21)&gt;</code>.</li>
+                <li>
+                    <b>With caching</b>, the aforementioned three output records for key <code>A</code> would likely be compacted in the cache,
+                    leading to a single output record <code>&lt;A, (321, null)&gt;</code> that is written to the aggregation's internal state store
+                    and being forwarded to any downstream operations.
+                </li>
+            </ul>
+        </li>
+    </ul>
+
+    <p>
+        The cache size is specified through the <code>cache.max.bytes.buffering</code> parameter, which is a global setting per processing topology:
+    </p>
+
+    <pre class="brush: java;">
+        // Enable record cache of size 10 MB.
+        Properties streamsConfiguration = new Properties();
+        streamsConfiguration.put(StreamsConfig.CACHE_MAX_BYTES_BUFFERING_CONFIG, 10 * 1024 * 1024L);
+    </pre>
+
+    <p>
+        This parameter controls the number of bytes allocated for caching.
+        Specifically, for a processor topology instance with <code>T</code> threads and <code>C</code> bytes allocated for caching,
+        each thread will have an even <code>C/T</code> bytes to construct its own cache and use as it sees fit among its tasks.
+        I.e., there are as many caches as there are threads, but no sharing of caches across threads happens.
+        The basic API for the cache is made of <code>put()</code> and <code>get()</code> calls.
+        Records are evicted using a simple LRU scheme once the cache size is reached.
+        The first time a keyed record <code>R1 = &lt;K1, V1&gt;</code> finishes processing at a node, it is marked as dirty in the cache.
+        Any other keyed record <code>R2 = &lt;K1, V2&gt;</code> with the same key <code>K1</code> that is processed on that node during that time will overwrite <code>&lt;K1, V1&gt;</code>, which we also refer to as "being compacted".
+        Note that this has the same effect as <a href="https://kafka.apache.org/documentation.html#compaction">Kafka's log compaction</a>, but happens (a) earlier, while the
+        records are still in memory, and (b) within your client-side application rather than on the server-side aka the Kafka broker.
+        Upon flushing <code>R2</code> is (1) forwarded to the next processing node and (2) written to the local state store.
+    </p>
+
+    <p>
+        The semantics of caching is that data is flushed to the state store and forwarded to the next downstream processor node
+        whenever the earliest of <code>commit.interval.ms</code> or <code>cache.max.bytes.buffering</code> (cache pressure) hits.
+        Both <code>commit.interval.ms</code> and <code>cache.max.bytes.buffering</code> are <b>global</b> parameters:  they apply to all processor nodes in
+        the topology, i.e., it is not possible to specify different parameters for each node.
+        Below we provide some example settings for both parameters based on desired scenarios.
+    </p>
+
+    <p>To turn off caching the cache size can be set to zero:</p>
+    <pre class="brush: java;">
+        // Disable record cache
+        Properties streamsConfiguration = new Properties();
+        streamsConfiguration.put(StreamsConfig.CACHE_MAX_BYTES_BUFFERING_CONFIG, 0);
+    </pre>
+
+    <p>
+        Turning off caching might result in high write traffic for the underlying RocksDB store.
+        With default settings caching is enabled within Kafka Streams but RocksDB caching is disabled.
+        Thus, to avoid high write traffic it is recommended to enable RocksDB caching if Kafka Streams caching is turned off.
+    </p>
+
+    <p>
+        For example, the RocksDB Block Cache could be set to 100MB and Write Buffer size to 32 MB.
+    </p>
+    <p>
+        To enable caching but still have an upper bound on how long records will be cached, the commit interval can be set
+        appropriately (in this example, it is set to 1000 milliseconds):
+    </p>
+    <pre class="brush: java;">
+        Properties streamsConfiguration = new Properties();
+        // Enable record cache of size 10 MB.
+        streamsConfiguration.put(StreamsConfig.CACHE_MAX_BYTES_BUFFERING_CONFIG, 10 * 1024 * 1024L);
+        // Set commit interval to 1 second.
+        streamsConfiguration.put(StreamsConfig.COMMIT_INTERVAL_MS_CONFIG, 1000);
+    </pre>
+
+    <p>
+        The illustration below shows the effect of these two configurations visually.
+        For simplicity we have records with 4 keys: blue, red, yellow and green. Without loss of generality, let's assume the cache has space for only 3 keys.
+        When the cache is disabled, we observer that all the input records will be output. With the cache enabled, we make the following observations.
+        First, most records are output at the end of a commit intervals (e.g., at <code>t1</code> one blue records is output, which is the final over-write of the blue key up to that time).
+        Second, some records are output because of cache pressure, i.e. before the end of a commit interval (cf. the red record right before t2).
+        With smaller cache sizes we expect cache pressure to be the primary factor that dictates when records are output. With large cache sizes, the commit interval will be the primary factor.
+        Third, the number of records output has been reduced (here: from 15 to 8).
+    </p>
+
+    <img class="centered" src="/{{version}}/images/streams-cache-and-commit-interval.png" style="width:500pt;height:400pt;">
+    <h4><a id="streams_developer-guide_memory-management_state-store-cache" href="#streams_developer-guide_memory-management_state-store-cache">State store caches in the Processor API</a></h4>
+
+    <p>
+        Developers of a Kafka Streams application using the Processor API have the option to specify, for an instance of a
+        processing topology, the total memory (RAM) size of the <i>state store cache</i> that is used for:
+    </p>
+
+    <ul><li>Internal <i>caching and compacting</i> of output records before they are written from a <b>stateful</b> processor node to its state stores.</li></ul>
+
+    <p>
+        Note that, unlike <a href="#streams_developer-guide_memory-management_record-cache">record caches</a> in the DSL, the state
+        store cache in the Processor API <i>will not cache or compact</i> any output records that are being forwarded downstream.
+        In other words, downstream processor nodes see all records, whereas the state stores see a reduced number of records.
+        It is important to note that this does not impact correctness of the system but is merely a performance optimization
+        for the state stores.
+    </p>
+    <p>
+        A note on terminology: we use the narrower term <i>state store caches</i> when we refer to the Processor API and the
+        broader term <i>record caches</i> when we are writing about the DSL.
+        We made a conscious choice to not expose the more general record caches to the Processor API so that we keep it simple and flexible.
+        For example, developers of the Processor API might chose to store a record in a state store while forwarding a different value downstream, i.e., they
+        might not want to use the unified record cache for both state store and forwarding downstream.
+    </p>
+    <p>
+        Following from the example first shown in section <a href="#streams_processor_statestore">State Stores</a>, to enable caching, you can
+        add the <code>enableCaching</code> call (note that caches are disabled by default and there is no explicit <code>disableCaching</code>
+        call) :
+    </p>
+    <pre class="brush: java;">
+        StateStoreSupplier countStoreSupplier =
+            Stores.create("Counts")
+                .withKeys(Serdes.String())
+                .withValues(Serdes.Long())
+                .persistent()
+                .enableCaching()
+                .build();
+    </pre>
+
+    <h4><a id="streams_developer-guide_memory-management_other_memory_usage" href="#streams_developer-guide_memory-management_other_memory_usage">Other memory usage</a></h4>
+    <p>
+    There are other modules inside Apache Kafka that allocate memory during runtime. They include the following:
+    </p>
+    <ul>
+        <li>Producer buffering, managed by the producer config <code>buffer.memory</code></li>
+
+        <li>Consumer buffering, currently not strictly managed, but can be indirectly controlled by fetch size, i.e.,
+            <code>fetch.max.bytes</code> and <code>fetch.max.wait.ms</code>.</li>
+
+        <li>Both producer and consumer also have separate TCP send / receive buffers that are not counted as the buffering memory.
+            These are controlled by the <code>send.buffer.bytes</code> / <code>receive.buffer.bytes</code> configs.</li>
+
+        <li>Deserialized objects buffering: after ``consumer.poll()`` returns records, they will be deserialized to extract
+            timestamp and buffered in the streams space.
+            Currently this is only indirectly controlled by <code>buffered.records.per.partition</code>.</li>
+
+        <li>RocksDB's own memory usage, both on-heap and off-heap; critical configs (for RocksDB version 4.1.0) include
+            <code>block_cache_size</code>, <code>write_buffer_size</code> and <code>max_write_buffer_number</code>.
+            These can be specified through the ``rocksdb.config.setter`` configuration.</li>
+    </ul>
+
     <h3><a id="streams_configure_execute" href="#streams_configure_execute">Application Configuration and Execution</a></h3>
 
     <p>
@@ -1094,8 +1269,8 @@
     </p>
 
     <div class="pagination">
-        <a href="/{{version}}/documentation/streams/architecture" class="pagination__btn pagination__btn__prev">Previous</a>
-        <a href="/{{version}}/documentation/streams/upgrade-guide" class="pagination__btn pagination__btn__next">Next</a>
+        <a href="/{{version}}/documentation/streams/quickstart" class="pagination__btn pagination__btn__prev">Previous</a>
+        <a href="/{{version}}/documentation/streams/core-concepts" class="pagination__btn pagination__btn__next">Next</a>
     </div>
 </script>
 
@@ -1107,7 +1282,7 @@
         <!--#include virtual="../../includes/_docs_banner.htm" -->
         <ul class="breadcrumbs">
             <li><a href="/documentation">Documentation</a></li>
-            <li><a href="/documentation/streams">Streams</a></li>
+            <li><a href="/documentation/streams">Kafka Streams API</a></li>
         </ul>
         <div class="p-content"></div>
     </div>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/streams/index.html
----------------------------------------------------------------------
diff --git a/0110/streams/index.html b/0110/streams/index.html
index 2d30169..bcaa831 100644
--- a/0110/streams/index.html
+++ b/0110/streams/index.html
@@ -18,56 +18,195 @@
 <script><!--#include virtual="../js/templateData.js" --></script>
 
 <script id="streams-template" type="text/x-handlebars-template">
-    <h1>Streams</h1>
-
-    <ol class="toc">
-        <li>
-            <a href="/{{version}}/documentation/streams/core-concepts">Core Concepts</a>
-        </li>
-        <li>
-            <a href="/{{version}}/documentation/streams/architecture">Architecture</a>
-        </li>
-        <li>
-            <a href="/{{version}}/documentation/streams/developer-guide">Developer Guide</a>
-            <ul>
-                <li><a href="/{{version}}/documentation/streams/developer-guide#streams_processor">Low-level Processor API</a></li>
-                <li><a href="/{{version}}/documentation/streams/developer-guide#streams_dsl">High-level Streams DSL</a></li>
-                <li><a href="/{{version}}/documentation/streams/developer-guide#streams_interactive_querie">Interactive Queries</a></li>
-                <li><a href="/{{version}}/documentation/streams/developer-guide#streams_execute">Application Configuration and Execution</a></li>
-            </ul>
-        </li>
-        <li>
-            <a href="/{{version}}/documentation/streams/upgrade-guide">Upgrade Guide and API Changes</a>
-        </li>
-    </ol>
-
-    <h2>Overview</h2>
-
-    <p>
-        Kafka Streams is a client library for processing and analyzing data stored in Kafka.
-        It builds upon important stream processing concepts such as properly distinguishing between event time and processing time, windowing support, and simple yet efficient management of application state.
-    </p>
-    <p>
-        Kafka Streams has a <b>low barrier to entry</b>: You can quickly write and run a small-scale proof-of-concept on a single machine; and you only need to run additional instances of your application on multiple machines to scale up to high-volume production workloads.
-        Kafka Streams transparently handles the load balancing of multiple instances of the same application by leveraging Kafka's parallelism model.
-    </p>
-    <p>
-        Some highlights of Kafka Streams:
-    </p>
-
-    <ul>
-        <li>Designed as a <b>simple and lightweight client library</b>, which can be easily embedded in any Java application and integrated with any existing packaging, deployment and operational tools that users have for their streaming applications.</li>
-        <li>Has <b>no external dependencies on systems other than Apache Kafka itself</b> as the internal messaging layer; notably, it uses Kafka's partitioning model to horizontally scale processing while maintaining strong ordering guarantees.</li>
-        <li>Supports <b>fault-tolerant local state</b>, which enables very fast and efficient stateful operations like windowed joins and aggregations.</li>
-        <li>Supports <b>exactly-once</b> processing semantics to guarantee that each record will be processed once and only once even when there is a failure on either Streams clients or Kafka brokers in the middle of processing.</li>
-        <li>Employs <b>one-record-at-a-time processing</b> to achieve millisecond processing latency, and supports <b>event-time based windowing operations</b> with late arrival of records.</li>
-        <li>Offers necessary stream processing primitives, along with a <b>high-level Streams DSL</b> and a <b>low-level Processor API</b>.</li>
+    <h1>Kafka Streams API</h1>
 
+    <h3 style="max-width: 75rem;">The easiest way to write mission-critical real-time applications and microservices with all the benefits of Kafka's server-side cluster technology.</h3>
+
+    <div class="hero">
+        <div class="hero__diagram">
+            <img src="/{{version}}/images/streams-welcome.png" />
+        </div>
+        <div class="hero__cta">
+            <a style="display: none;" href="/{{version}}/documentation/streams/tutorial" class="btn">Write your first app</a>
+            <a href="/{{version}}/documentation/streams/quickstart" class="btn">Play with demo app</a>
+        </div>
+    </div>
+
+    <ul class="feature-list">
+        <li>Write standard Java applications</li>
+        <li>Exactly-once processing semantics</li>
+        <li>No seperate processing cluster required</li>
+        <li>Develop on Mac, Linux, Windows</li>
+        <li>Elastic, highly scalable, fault-tolerant</li>
+        <li>Deploy to containers, VMs, bare metal, cloud</li>
+        <li>Equally viable for small, medium, &amp; large use cases</li>
+        <li>Fully integrated with Kafka security</li>
     </ul>
 
+    <div class="cards">
+        <a class="card" href="/{{version}}/documentation/streams/developer-guide">
+            <img class="card__icon" src="/{{version}}/images/icons/documentation.png" />
+            <img class="card__icon card__icon--hover" src="/{{version}}/images/icons/documentation--white.png" />
+            <span class="card__label">Developer manual</span>
+        </a>
+        <a style="display: none;" class="card" href="/{{version}}/documentation/streams/tutorial">
+            <img class="card__icon" src="/{{version}}/images/icons/tutorials.png" />
+            <img class="card__icon card__icon--hover" src="/{{version}}/images/icons/tutorials--white.png" />
+            <span class="card__label">Tutorials</span>
+        </a>
+        <a class="card" href="/{{version}}/documentation/streams/core-concepts">
+            <img class="card__icon" src="/{{version}}/images/icons/architecture.png" />
+            <img class="card__icon card__icon--hover" src="/{{version}}/images/icons/architecture--white.png" />
+            <span class="card__label">Concepts</span>
+        </a>
+    </div>
+
+    <h3>Hello Kafka Streams</h3>
+    <p>The code example below implements a WordCount application that is elastic, highly scalable, fault-tolerant, stateful, and ready to run in production at large scale</p>
+
+    <div class="code-example">
+        <div class="btn-group">
+            <a class="selected b-java-8" data-section="java-8">Java 8+</a>
+            <a class="b-java-7" data-section="java-7">Java 7</a>
+            <a class="b-scala" data-section="scala">Scala</a>
+        </div>
+
+        <div class="code-example__snippet b-java-8 selected">
+            <pre class="brush: java;">
+                import org.apache.kafka.common.serialization.Serdes;
+                import org.apache.kafka.streams.KafkaStreams;
+                import org.apache.kafka.streams.StreamsConfig;
+                import org.apache.kafka.streams.kstream.KStream;
+                import org.apache.kafka.streams.kstream.KStreamBuilder;
+                import org.apache.kafka.streams.kstream.KTable;
+
+                import java.util.Arrays;
+                import java.util.Properties;
+
+                public class WordCountApplication {
+
+                    public static void main(final String[] args) throws Exception {
+                        Properties config = new Properties();
+                        config.put(StreamsConfig.APPLICATION_ID_CONFIG, "wordcount-application");
+                        config.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "kafka-broker1:9092");
+                        config.put(StreamsConfig.DEFAULT_KEY_SERDE_CLASS_CONFIG, Serdes.String().getClass());
+                        config.put(StreamsConfig.DEFAULT_VALUE_SERDE_CLASS_CONFIG, Serdes.String().getClass());
+
+                        KStreamBuilder builder = new KStreamBuilder();
+                        KStream&lt;String, String&gt; textLines = builder.stream("TextLinesTopic");
+                        KTable&lt;String, Long&gt; wordCounts = textLines
+                            .flatMapValues(textLine -> Arrays.asList(textLine.toLowerCase().split("\\W+")))
+                            .groupBy((key, word) -> word)
+                            .count("Counts");
+                        wordCounts.to(Serdes.String(), Serdes.Long(), "WordsWithCountsTopic");
+
+                        KafkaStreams streams = new KafkaStreams(builder, config);
+                        streams.start();
+                    }
+
+                }
+            </pre>
+        </div>
+
+        <div class="code-example__snippet b-java-7">
+            <pre class="brush: java;">
+                import org.apache.kafka.common.serialization.Serdes;
+                import org.apache.kafka.streams.KafkaStreams;
+                import org.apache.kafka.streams.StreamsConfig;
+                import org.apache.kafka.streams.kstream.KStream;
+                import org.apache.kafka.streams.kstream.KStreamBuilder;
+                import org.apache.kafka.streams.kstream.KTable;
+                import org.apache.kafka.streams.kstream.KeyValueMapper;
+                import org.apache.kafka.streams.kstream.ValueMapper;
+
+                import java.util.Arrays;
+                import java.util.Properties;
+
+                public class WordCountApplication {
+
+                    public static void main(final String[] args) throws Exception {
+                        Properties config = new Properties();
+                        config.put(StreamsConfig.APPLICATION_ID_CONFIG, "wordcount-application");
+                        config.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "kafka-broker1:9092");
+                        config.put(StreamsConfig.DEFAULT_KEY_SERDE_CLASS_CONFIG, Serdes.String().getClass());
+                        config.put(StreamsConfig.DEFAULT_VALUE_SERDE_CLASS_CONFIG, Serdes.String().getClass());
+
+                        KStreamBuilder builder = new KStreamBuilder();
+                        KStream&lt;String, String&gt; textLines = builder.stream("TextLinesTopic");
+                        KTable&lt;String, Long&gt; wordCounts = textLines
+                            .flatMapValues(new ValueMapper&lt;String, Iterable&lt;String&gt;&gt;() {
+                                @Override
+                                public Iterable&lt;String&gt; apply(String textLine) {
+                                    return Arrays.asList(textLine.toLowerCase().split("\\W+"));
+                                }
+                            })
+                            .groupBy(new KeyValueMapper&lt;String, String, String&gt;() {
+                                @Override
+                                public String apply(String key, String word) {
+                                    return word;
+                                }
+                            })
+                            .count("Counts");
+                        wordCounts.to(Serdes.String(), Serdes.Long(), "WordsWithCountsTopic");
+
+                        KafkaStreams streams = new KafkaStreams(builder, config);
+                        streams.start();
+                    }
+
+                }
+            </pre>
+        </div>
+
+        <div class="code-example__snippet b-scala">
+            <pre class="brush: scala;">
+                import java.lang.Long
+                import java.util.Properties
+                import java.util.concurrent.TimeUnit
+
+                import org.apache.kafka.common.serialization._
+                import org.apache.kafka.streams._
+                import org.apache.kafka.streams.kstream.{KStream, KStreamBuilder, KTable}
+
+                import scala.collection.JavaConverters.asJavaIterableConverter
+
+                object WordCountApplication {
+
+                    def main(args: Array[String]) {
+                        val config: Properties = {
+                            val p = new Properties()
+                            p.put(StreamsConfig.APPLICATION_ID_CONFIG, "wordcount-application")
+                            p.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "kafka-broker1:9092")
+                            p.put(StreamsConfig.DEFAULT_KEY_SERDE_CLASS_CONFIG, Serdes.String().getClass)
+                            p.put(StreamsConfig.DEFAULT_VALUE_SERDE_CLASS_CONFIG, Serdes.String().getClass)
+                            p
+                        }
+
+                        val builder: KStreamBuilder = new KStreamBuilder()
+                        val textLines: KStream[String, String] = builder.stream("TextLinesTopic")
+                        val wordCounts: KTable[String, Long] = textLines
+                            .flatMapValues(textLine => textLine.toLowerCase.split("\\W+").toIterable.asJava)
+                            .groupBy((_, word) => word)
+                            .count("Counts")
+                        wordCounts.to(Serdes.String(), Serdes.Long(), "WordsWithCountsTopic")
+
+                        val streams: KafkaStreams = new KafkaStreams(builder, config)
+                        streams.start()
+
+                        Runtime.getRuntime.addShutdownHook(new Thread(() => {
+                            streams.close(10, TimeUnit.SECONDS)
+                        }))
+                    }
+
+                }
+            </pre>
+        </div>
+    </div>
+
+    
+
     <div class="pagination">
         <a href="#" class="pagination__btn pagination__btn__prev pagination__btn--disabled">Previous</a>
-        <a href="/{{version}}/documentation/streams/core-concepts" class="pagination__btn pagination__btn__next">Next</a>
+        <a href="/{{version}}/documentation/streams/quickstart" class="pagination__btn pagination__btn__next">Next</a>
     </div>
 </script>
 
@@ -84,6 +223,7 @@
     </div>
 </div>
 <!--#include virtual="../../includes/_footer.htm" -->
+
 <script>
 $(function() {
   // Show selected style on nav item
@@ -91,5 +231,12 @@ $(function() {
 
   // Display docs subnav items
   $('.b-nav__docs').parent().toggleClass('nav__item__with__subs--expanded');
+
+  // Show selected code example
+  $('.btn-group a').click(function(){
+      var targetClass = '.b-' + $(this).data().section;
+      $('.code-example__snippet, .btn-group a').removeClass('selected');
+      $(targetClass).addClass('selected');
+  });
 });
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/streams/quickstart.html
----------------------------------------------------------------------
diff --git a/0110/streams/quickstart.html b/0110/streams/quickstart.html
new file mode 100644
index 0000000..977fa5f
--- /dev/null
+++ b/0110/streams/quickstart.html
@@ -0,0 +1,352 @@
+<!--
+ 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.
+-->
+<script><!--#include virtual="../js/templateData.js" --></script>
+
+<script id="content-template" type="text/x-handlebars-template">
+  <h1>Play with a Streams Application</h1>
+
+<p>
+  This tutorial assumes you are starting fresh and have no existing Kafka or ZooKeeper data. However, if you have already started Kafka and
+  Zookeeper, feel free to skip the first two steps.
+</p>
+
+  <p>
+ Kafka Streams is a client library for building mission-critical real-time applications and microservices,
+  where the input and/or output data is stored in Kafka clusters. Kafka Streams combines the simplicity of
+  writing and deploying standard Java and Scala applications on the client side with the benefits of Kafka's
+  server-side cluster technology to make these applications highly scalable, elastic, fault-tolerant, distributed,
+ and much more.
+  </p>
+  <p>
+This quickstart example will demonstrate how to run a streaming application coded in this library. Here is the gist
+of the <code><a href="https://github.com/apache/kafka/blob/{{dotVersion}}/streams/examples/src/main/java/org/apache/kafka/streams/examples/wordcount/WordCountDemo.java">WordCountDemo</a></code> example code (converted to use Java 8 lambda expressions for easy reading).
+</p>
+<pre class="brush: java;">
+// Serializers/deserializers (serde) for String and Long types
+final Serde&lt;String&gt; stringSerde = Serdes.String();
+final Serde&lt;Long&gt; longSerde = Serdes.Long();
+
+// Construct a `KStream` from the input topic "streams-plaintext-input", where message values
+// represent lines of text (for the sake of this example, we ignore whatever may be stored
+// in the message keys).
+KStream&lt;String, String&gt; textLines = builder.stream(stringSerde, stringSerde, "streams-plaintext-input");
+
+KTable&lt;String, Long&gt; wordCounts = textLines
+    // Split each text line, by whitespace, into words.
+    .flatMapValues(value -> Arrays.asList(value.toLowerCase().split("\\W+")))
+
+    // Group the text words as message keys
+    .groupBy((key, value) -> value)
+
+    // Count the occurrences of each word (message key).
+    .count("Counts")
+
+// Store the running counts as a changelog stream to the output topic.
+wordCounts.to(stringSerde, longSerde, "streams-wordcount-output");
+</pre>
+
+<p>
+It implements the WordCount
+algorithm, which computes a word occurrence histogram from the input text. However, unlike other WordCount examples
+you might have seen before that operate on bounded data, the WordCount demo application behaves slightly differently because it is
+designed to operate on an <b>infinite, unbounded stream</b> of data. Similar to the bounded variant, it is a stateful algorithm that
+tracks and updates the counts of words. However, since it must assume potentially
+unbounded input data, it will periodically output its current state and results while continuing to process more data
+because it cannot know when it has processed "all" the input data.
+</p>
+<p>
+  As the first step, we will start Kafka (unless you already have it started) and then we will
+  prepare input data to a Kafka topic, which will subsequently be processed by a Kafka Streams application.
+</p>
+
+<h4><a id="quickstart_streams_download" href="#quickstart_streams_download">Step 1: Download the code</a></h4>
+
+<a href="https://www.apache.org/dyn/closer.cgi?path=/kafka/{{fullDotVersion}}/kafka_{{scalaVersion}}-{{fullDotVersion}}.tgz" title="Kafka downloads">Download</a> the {{fullDotVersion}} release and un-tar it.
+Note that there are multiple downloadable Scala versions and we choose to use the recommended version ({{scalaVersion}}) here:
+
+<pre class="brush: bash;">
+&gt; tar -xzf kafka_{{scalaVersion}}-{{fullDotVersion}}.tgz
+&gt; cd kafka_{{scalaVersion}}-{{fullDotVersion}}
+</pre>
+
+<h4><a id="quickstart_streams_startserver" href="#quickstart_streams_startserver">Step 2: Start the Kafka server</a></h4>
+
+<p>
+Kafka uses <a href="https://zookeeper.apache.org/">ZooKeeper</a> so you need to first start a ZooKeeper server if you don't already have one. You can use the convenience script packaged with kafka to get a quick-and-dirty single-node ZooKeeper instance.
+</p>
+
+<pre class="brush: bash;">
+&gt; bin/zookeeper-server-start.sh config/zookeeper.properties
+[2013-04-22 15:01:37,495] INFO Reading configuration from: config/zookeeper.properties (org.apache.zookeeper.server.quorum.QuorumPeerConfig)
+...
+</pre>
+
+<p>Now start the Kafka server:</p>
+<pre class="brush: bash;">
+&gt; bin/kafka-server-start.sh config/server.properties
+[2013-04-22 15:01:47,028] INFO Verifying properties (kafka.utils.VerifiableProperties)
+[2013-04-22 15:01:47,051] INFO Property socket.send.buffer.bytes is overridden to 1048576 (kafka.utils.VerifiableProperties)
+...
+</pre>
+
+
+<h4><a id="quickstart_streams_prepare" href="#quickstart_streams_prepare">Step 3: Prepare input topic and start Kafka producer</a></h4>
+
+<!--
+
+<pre class="brush: bash;">
+&gt; echo -e "all streams lead to kafka\nhello kafka streams\njoin kafka summit" > file-input.txt
+</pre>
+Or on Windows:
+<pre class="brush: bash;">
+&gt; echo all streams lead to kafka> file-input.txt
+&gt; echo hello kafka streams>> file-input.txt
+&gt; echo|set /p=join kafka summit>> file-input.txt
+</pre>
+
+-->
+
+Next, we create the input topic named <b>streams-plaintext-input</b> and the output topic named <b>streams-wordcount-output</b>:
+
+<pre class="brush: bash;">
+&gt; bin/kafka-topics.sh --create \
+    --zookeeper localhost:2181 \
+    --replication-factor 1 \
+    --partitions 1 \
+    --topic streams-plaintext-input
+Created topic "streams-plaintext-input".
+
+&gt; bin/kafka-topics.sh --create \
+    --zookeeper localhost:2181 \
+    --replication-factor 1 \
+    --partitions 1 \
+    --topic streams-wordcount-output
+Created topic "streams-wordcount-output".
+</pre>
+
+The created topic can be described with the same <b>kafka-topics</b> tool:
+
+<pre class="brush: bash;">
+&gt; bin/kafka-topics.sh --zookeeper localhost:2181 --describe
+
+Topic:streams-plaintext-input	PartitionCount:1	ReplicationFactor:1	Configs:
+    Topic: streams-plaintext-input	Partition: 0	Leader: 0	Replicas: 0	Isr: 0
+Topic:streams-wordcount-output	PartitionCount:1	ReplicationFactor:1	Configs:
+	Topic: streams-wordcount-output	Partition: 0	Leader: 0	Replicas: 0	Isr: 0
+</pre>
+
+<h4><a id="quickstart_streams_start" href="#quickstart_streams_start">Step 4: Start the Wordcount Application</a></h4>
+
+The following command starts the WordCount demo application:
+
+<pre class="brush: bash;">
+&gt; bin/kafka-run-class.sh org.apache.kafka.streams.examples.wordcount.WordCountDemo
+</pre>
+
+<p>
+The demo application will read from the input topic <b>streams-plaintext-input</b>, perform the computations of the WordCount algorithm on each of the read messages,
+and continuously write its current results to the output topic <b>streams-wordcount-output</b>.
+Hence there won't be any STDOUT output except log entries as the results are written back into in Kafka.
+</p>
+
+Now we can start the console producer in a separate terminal to write some input data to this topic:
+
+<pre class="brush: bash;">
+&gt; bin/kafka-console-producer.sh --broker-list localhost:9092 --topic streams-plaintext-input
+</pre>
+
+and inspect the output of the WordCount demo application by reading from its output topic with the console consumer in a separate terminal:
+
+<pre class="brush: bash;">
+&gt; bin/kafka-console-consumer.sh --bootstrap-server localhost:9092 \
+    --topic streams-wordcount-output \
+    --from-beginning \
+    --formatter kafka.tools.DefaultMessageFormatter \
+    --property print.key=true \
+    --property print.value=true \
+    --property key.deserializer=org.apache.kafka.common.serialization.StringDeserializer \
+    --property value.deserializer=org.apache.kafka.common.serialization.LongDeserializer
+</pre>
+
+
+<h4><a id="quickstart_streams_process" href="#quickstart_streams_process">Step 5: Process some data</a></h4>
+
+Now let's write some message with the console producer into the input topic <b>streams-plaintext-input</b> by entering a single line of text and then hit &lt;RETURN&gt;.
+This will send a new message to the input topic, where the message key is null and the message value is the string encoded text line that you just entered
+(in practice, input data for applications will typically be streaming continuously into Kafka, rather than being manually entered as we do in this quickstart):
+
+<pre class="brush: bash;">
+&gt; bin/kafka-console-producer.sh --broker-list localhost:9092 --topic streams-plaintext-input
+all streams lead to kafka
+</pre>
+
+<p>
+This message will be processed by the Wordcount application and the following output data will be written to the <b>streams-wordcount-output</b> topic and printed by the console consumer:
+</p>
+
+<pre class="brush: bash;">
+&gt; bin/kafka-console-consumer.sh --bootstrap-server localhost:9092
+    --topic streams-wordcount-output \
+    --from-beginning \
+    --formatter kafka.tools.DefaultMessageFormatter \
+    --property print.key=true \
+    --property print.value=true \
+    --property key.deserializer=org.apache.kafka.common.serialization.StringDeserializer \
+    --property value.deserializer=org.apache.kafka.common.serialization.LongDeserializer
+
+all	    1
+streams	1
+lead	1
+to	    1
+kafka	1
+</pre>
+
+<p>
+Here, the first column is the Kafka message key in <code>java.lang.String</code> format and represents a word that is being counted, and the second column is the message value in <code>java.lang.Long</code>format, representing the word's latest count.
+</p>
+
+Now let's continue writing one more message with the console producer into the input topic <b>streams-plaintext-input</b>.
+Enter the text line "hello kafka streams" and hit &lt;RETURN&gt;.
+Your terminal should look as follows:
+
+<pre class="brush: bash;">
+&gt; bin/kafka-console-producer.sh --broker-list localhost:9092 --topic streams-plaintext-input
+all streams lead to kafka
+hello kafka streams
+</pre>
+
+In your other terminal in which the console consumer is running, you will observe that the WordCount application wrote new output data:
+
+<pre class="brush: bash;">
+&gt; bin/kafka-console-consumer.sh --bootstrap-server localhost:9092
+    --topic streams-wordcount-output \
+    --from-beginning \
+    --formatter kafka.tools.DefaultMessageFormatter \
+    --property print.key=true \
+    --property print.value=true \
+    --property key.deserializer=org.apache.kafka.common.serialization.StringDeserializer \
+    --property value.deserializer=org.apache.kafka.common.serialization.LongDeserializer
+
+all	    1
+streams	1
+lead	1
+to	    1
+kafka	1
+hello	1
+kafka	2
+streams	2
+</pre>
+
+Here the last printed lines <b>kafka 2</b> and <b>streams 2</b> indicate updates to the keys <b>kafka</b> and <b>streams</b> whose counts have been incremented from <b>1</b> to <b>2</b>.
+Whenever you write further input messages to the input topic, you will observe new messages being added to the <b>streams-wordcount-output</b> topic,
+representing the most recent word counts as computed by the WordCount application.
+Let's enter one final input text line "join kafka summit" and hit &lt;RETURN&gt; in the console producer to the input topic <b>streams-wordcount-input</b> before we wrap up this quickstart:
+
+<pre class="brush: bash;">
+&gt; bin/kafka-console-producer.sh --broker-list localhost:9092 --topic streams-wordcount-input
+all streams lead to kafka
+hello kafka streams
+join kafka summit
+</pre>
+
+The <b>streams-wordcount-output</b> topic will subsequently show the corresponding updated word counts (see last three lines):
+
+<pre class="brush: bash;">
+&gt; bin/kafka-console-consumer.sh --bootstrap-server localhost:9092
+    --topic streams-wordcount-output \
+    --from-beginning \
+    --formatter kafka.tools.DefaultMessageFormatter \
+    --property print.key=true \
+    --property print.value=true \
+    --property key.deserializer=org.apache.kafka.common.serialization.StringDeserializer \
+    --property value.deserializer=org.apache.kafka.common.serialization.LongDeserializer
+
+all	    1
+streams	1
+lead	1
+to	    1
+kafka	1
+hello	1
+kafka	2
+streams	2
+join	1
+kafka	3
+summit	1
+</pre>
+
+As one can see, outputs of the Wordcount application is actually a continuous stream of updates, where each output record (i.e. each line in the original output above) is
+an updated count of a single word, aka record key such as "kafka". For multiple records with the same key, each later record is an update of the previous one.
+
+<p>
+The two diagrams below illustrate what is essentially happening behind the scenes.
+The first column shows the evolution of the current state of the <code>KTable&lt;String, Long&gt;</code> that is counting word occurrences for <code>count</code>.
+The second column shows the change records that result from state updates to the KTable and that are being sent to the output Kafka topic <b>streams-wordcount-output</b>.
+</p>
+
+<img src="/{{version}}/images/streams-table-updates-02.png" style="float: right; width: 25%;">
+<img src="/{{version}}/images/streams-table-updates-01.png" style="float: right; width: 25%;">
+
+<p>
+First the text line "all streams lead to kafka" is being processed.
+The <code>KTable</code> is being built up as each new word results in a new table entry (highlighted with a green background), and a corresponding change record is sent to the downstream <code>KStream</code>.
+</p>
+<p>
+When the second text line "hello kafka streams" is processed, we observe, for the first time, that existing entries in the <code>KTable</code> are being updated (here: for the words "kafka" and for "streams"). And again, change records are being sent to the output topic.
+</p>
+<p>
+And so on (we skip the illustration of how the third line is being processed). This explains why the output topic has the contents we showed above, because it contains the full record of changes.
+</p>
+
+<p>
+Looking beyond the scope of this concrete example, what Kafka Streams is doing here is to leverage the duality between a table and a changelog stream (here: table = the KTable, changelog stream = the downstream KStream): you can publish every change of the table to a stream, and if you consume the entire changelog stream from beginning to end, you can reconstruct the contents of the table.
+</p>
+
+<h4><a id="quickstart_streams_stop" href="#quickstart_streams_stop">Step 6: Teardown the application</a></h4>
+
+<p>You can now stop the console consumer, the console producer, the Wordcount application, the Kafka broker and the Zookeeper server in order via <b>Ctrl-C</b>.</p>
+
+ <div class="pagination">
+        <a href="/{{version}}/documentation/streams" class="pagination__btn pagination__btn__prev">Previous</a>
+        <a href="/{{version}}/documentation/streams/tutorial" class="pagination__btn pagination__btn__next">Next</a>
+    </div>
+</script>
+
+<div class="p-quickstart-streams"></div>
+
+<!--#include virtual="../../includes/_header.htm" -->
+<!--#include virtual="../../includes/_top.htm" -->
+<div class="content documentation documentation--current">
+    <!--#include virtual="../../includes/_nav.htm" -->
+    <div class="right">
+        <!--#include virtual="../../includes/_docs_banner.htm" -->
+        <ul class="breadcrumbs">
+            <li><a href="/documentation">Documentation</a></li>
+            <li><a href="/documentation/streams">Streams</a></li>
+        </ul>
+        <div class="p-content"></div>
+    </div>
+</div>
+<!--#include virtual="../../includes/_footer.htm" -->
+<script>
+$(function() {
+  // Show selected style on nav item
+  $('.b-nav__streams').addClass('selected');
+
+  // Display docs subnav items
+  $('.b-nav__docs').parent().toggleClass('nav__item__with__subs--expanded');
+});
+</script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/streams/tutorial.html
----------------------------------------------------------------------
diff --git a/0110/streams/tutorial.html b/0110/streams/tutorial.html
new file mode 100644
index 0000000..a1520de
--- /dev/null
+++ b/0110/streams/tutorial.html
@@ -0,0 +1,526 @@
+<!--
+ 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.
+-->
+<script><!--#include virtual="../js/templateData.js" --></script>
+
+<script id="content-template" type="text/x-handlebars-template">
+    <h1>Write your own Streams Applications</h1>
+
+    <p>
+        In this guide we will start from scratch on setting up your own project to write a stream processing application using Kafka's Streams API.
+        It is highly recommended to read the <a href="/{{version}}/documentation/streams/quickstart">quickstart</a> first on how to run a Streams application written in Kafka Streams if you have not done so.
+    </p>
+
+    <h4><a id="tutorial_maven_setup" href="#tutorial_maven_setup">Setting up a Maven Project</a></h4>
+
+    <p>
+        We are going to use a Kafka Streams Maven Archetype for creating a Streams project structure with the following commands:
+    </p>
+
+    <pre class="brush: bash;">
+        mvn archetype:generate \
+            -DarchetypeGroupId=org.apache.kafka \
+            -DarchetypeArtifactId=streams-quickstart-java \
+            -DarchetypeVersion={{fullDotVersion}} \
+            -DgroupId=streams.examples \
+            -DartifactId=streams.examples \
+            -Dversion=0.1 \
+            -Dpackage=myapps
+    </pre>
+
+    <p>
+        You can use a different value for <code>groupId</code>, <code>artifactId</code> and <code>package</code> parameters if you like.
+        Assuming the above parameter values are used, this command will create a project structure that looks like this:
+    </p>
+
+    <pre class="brush: bash;">
+        &gt; tree streams.examples
+        streams-quickstart
+        |-- pom.xml
+        |-- src
+            |-- main
+                |-- java
+                |   |-- myapps
+                |       |-- LineSplit.java
+                |       |-- Pipe.java
+                |       |-- WordCount.java
+                |-- resources
+                    |-- log4j.properties
+    </pre>
+
+    <p>
+        The <code>pom.xml</code> file included in the project already has the Streams dependency defined,
+        and there are already several example programs written with Streams library under <code>src/main/java</code>.
+        Since we are going to start writing such programs from scratch, we can now delete these examples:
+    </p>
+
+    <pre class="brush: bash;">
+        &gt; cd streams-quickstart
+        &gt; rm src/main/java/myapps/*.java
+    </pre>
+
+    <h4><a id="tutorial_code_pipe" href="#tutorial_code_pipe">Writing a first Streams application: Pipe</a></h4>
+
+    It's coding time now! Feel free to open your favorite IDE and import this Maven project, or simply open a text editor and create a java file under <code>src/main/java</code>.
+    Let's name it <code>Pipe.java</code>:
+
+    <pre class="brush: java;">
+        package myapps;
+
+        public class Pipe {
+
+            public static void main(String[] args) throws Exception {
+
+            }
+        }
+    </pre>
+
+    <p>
+        We are going to fill in the <code>main</code> function to write this pipe program. Note that we will not list the import statements as we go since IDEs can usually add them automatically.
+        However if you are using a text editor you need to manually add the imports, and at the end of this section we'll show the complete code snippet with import statement for you.
+    </p>
+
+    <p>
+        The first step to write a Streams application is to create a <code>java.util.Properties</code> map to specify different Streams execution configuration values as defined in <code>StreamsConfig</code>.
+        A couple of important configuration values you need to set are: <code>StreamsConfig.BOOTSTRAP_SERVERS_CONFIG</code>, which specifies a list of host/port pairs to use for establishing the initial connection to the Kafka cluster,
+        and <code>StreamsConfig.APPLICATION_ID_CONFIG</code>, which gives the unique identifier of your Streams application to distinguish itself with other applications talking to the same Kafka cluster:
+    </p>
+
+    <pre class="brush: java;">
+        Properties props = new Properties();
+        props.put(StreamsConfig.APPLICATION_ID_CONFIG, "streams-pipe");
+        props.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "localhost:9092");    // assuming that the Kafka broker this application is talking to runs on local machine with port 9092
+    </pre>
+
+    <p>
+        In addition, you can customize other configurations in the same map, for example, default serialization and deserialization libraries for the record key-value pairs:
+    </p>
+
+    <pre class="brush: java;">
+        props.put(StreamsConfig.DEFAULT_KEY_SERDE_CLASS_CONFIG, Serdes.String().getClass());
+        props.put(StreamsConfig.DEFAULT_VALUE_SERDE_CLASS_CONFIG, Serdes.String().getClass());
+    </pre>
+
+    <p>
+        For a full list of configurations of Kafka Streams please refer to this <a href="/{{version}}/documentation/#streamsconfigs">table</a>.
+    </p>
+
+    <p>
+        Next we will define the computational logic of our Streams application.
+        In Kafka Streams this computational logic is defined as a <code>topology</code> of connected processor nodes.
+        We can use a topology builder to construct such a topology,
+    </p>
+
+    <pre class="brush: java;">
+        final KStreamBuilder builder = new KStreamBuilder();
+    </pre>
+
+    <p>
+        And then create a source stream from a Kafka topic named <code>streams-plaintext-input</code> using this topology builder:
+    </p>
+
+    <pre class="brush: java;">
+        KStream&lt;String, String&gt; source = builder.stream("streams-plaintext-input");
+    </pre>
+
+    <p>
+        Now we get a <code>KStream</code> that is continuously generating records from its source Kafka topic <code>streams-plaintext-input</code>.
+        The records are organized as <code>String</code> typed key-value pairs.
+        The simplest thing we can do with this stream is to write it into another Kafka topic, say it's named <code>streams-pipe-output</code>:
+    </p>
+
+    <pre class="brush: java;">
+        source.to("streams-pipe-output");
+    </pre>
+
+    <p>
+        Note that we can also concatenate the above two lines into a single line as:
+    </p>
+
+    <pre class="brush: java;">
+        builder.stream("streams-plaintext-input").to("streams-pipe-output");
+    </pre>
+
+    <p>
+        we can now construct the Streams client with the two components we have just constructed above: the configuration map and the topology builder object
+        (one can also construct a <code>StreamsConfig</code> object from the <code>props</code> map and then pass that object to the constructor,
+        <code>KafkaStreams</code> have overloaded constructor functions to takes either type).
+    </p>
+
+    <pre class="brush: java;">
+        final KafkaStreams streams = new KafkaStreams(builder, props);
+    </pre>
+
+    <p>
+        By calling its <code>start()</code> function we can trigger the execution of this client.
+        The execution won't stop until <code>close()</code> is called on this client.
+        We can, for example, add a shutdown hook with a countdown latch to capture a user interrupt and close the client upon terminating this program:
+    </p>
+
+    <pre class="brush: java;">
+        final CountDownLatch latch = new CountDownLatch(1);
+
+        // attach shutdown handler to catch control-c
+        Runtime.getRuntime().addShutdownHook(new Thread("streams-shutdown-hook") {
+            @Override
+            public void run() {
+                streams.close();
+                latch.countDown();
+            }
+        });
+
+        try {
+            streams.start();
+            latch.await();
+        } catch (Throwable e) {
+            System.exit(1);
+        }
+        System.exit(0);
+    </pre>
+
+    <p>
+        The complete code so far looks like this:
+    </p>
+
+    <pre class="brush: java;">
+        package myapps;
+
+        import org.apache.kafka.common.serialization.Serdes;
+        import org.apache.kafka.streams.KafkaStreams;
+        import org.apache.kafka.streams.StreamsConfig;
+        import org.apache.kafka.streams.kstream.KStreamBuilder;
+
+        import java.util.Properties;
+        import java.util.concurrent.CountDownLatch;
+
+        public class Pipe {
+
+            public static void main(String[] args) throws Exception {
+                Properties props = new Properties();
+                props.put(StreamsConfig.APPLICATION_ID_CONFIG, "streams-pipe");
+                props.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "localhost:9092");
+                props.put(StreamsConfig.DEFAULT_KEY_SERDE_CLASS_CONFIG, Serdes.String().getClass());
+                props.put(StreamsConfig.DEFAULT_VALUE_SERDE_CLASS_CONFIG, Serdes.String().getClass());
+
+                final KStreamBuilder builder = new KStreamBuilder();
+
+                builder.stream("streams-plaintext-input").to("streams-pipe-output");
+
+                final KafkaStreams streams = new KafkaStreams(builder, props);
+                final CountDownLatch latch = new CountDownLatch(1);
+
+                // attach shutdown handler to catch control-c
+                Runtime.getRuntime().addShutdownHook(new Thread("streams-shutdown-hook") {
+                    @Override
+                    public void run() {
+                        streams.close();
+                        latch.countDown();
+                    }
+                });
+
+                try {
+                    streams.start();
+                    latch.await();
+                } catch (Throwable e) {
+                    System.exit(1);
+                }
+                System.exit(0);
+            }
+        }
+    </pre>
+
+    <p>
+        If you already have the Kafka broker up and running at <code>localhost:9092</code>,
+        and the topics <code>streams-plaintext-input</code> and <code>streams-pipe-output</code> created on that broker,
+        you can run this code in your IDE or on the command line, using Maven:
+    </p>
+
+    <pre class="brush: brush;">
+        &gt; mvn clean package
+        &gt; mvn exec:java -Dexec.mainClass=myapps.Pipe
+    </pre>
+
+    <p>
+        For detailed instructions on how to run a Streams application and observe its computing results,
+        please read the <a href="/{{version}}/documentation/streams/quickstart">Play with a Streams Application</a> section.
+        We will not talk about this in the rest of this section.
+    </p>
+
+    <h4><a id="tutorial_code_linesplit" href="#tutorial_code_linesplit">Writing a second Streams application: Line Split</a></h4>
+
+    <p>
+        We have learned how to construct a Streams client with its two key components: the <code>StreamsConfig</code> and <code>TopologyBuilder</code>.
+        Now let's move on to add some real processing logic by augmenting the current topology.
+        We can first create another program by first copy the existing <code>Pipe.java</code> class:
+    </p>
+
+    <pre class="brush: brush;">
+        &gt; cp src/main/java/myapps/Pipe.java src/main/java/myapps/LineSplit.java
+    </pre>
+
+    <p>
+        And change its class name as well as the application id config to distinguish with the original program:
+    </p>
+
+    <pre class="brush: java;">
+        public class Pipe {
+
+            public static void main(String[] args) throws Exception {
+                Properties props = new Properties();
+                props.put(StreamsConfig.APPLICATION_ID_CONFIG, "streams-linesplit");
+                // ...
+            }
+        }
+    </pre>
+
+    <p>
+        Since each of the source stream's record is a <code>String</code> typed key-value pair,
+        let's treat the value string as a text line and split it into words with a <code>FlatMapValues</code> operator:
+    </p>
+
+    <pre class="brush: java;">
+        KStream&lt;String, String&gt; source = builder.stream("streams-plaintext-input");
+        KStream&lt;String, String&gt; words = builder.flatMapValues(new ValueMapper&lt;String, Iterable&lt;String&gt;&gt;() {
+                    @Override
+                    public Iterable&lt;String&gt; apply(String value) {
+                        return Arrays.asList(value.split("\\W+"));
+                    }
+                });
+    </pre>
+
+    <p>
+        The operator will take the <code>source</code> stream as its input, and generate a new stream named <code>words</code>
+        by processing each record from its source stream in order and breaking its value string into a list of words, and producing
+        each word as a new record to the output <code>words</code> stream.
+        This is a stateless operator that does not need to keep track of any previously received records or processed results.
+        Note if you are using JDK 8 you can use lambda expression and simplify the above code as:
+    </p>
+
+    <pre class="brush: java;">
+        KStream&lt;String, String&gt; source = builder.stream("streams-plaintext-input");
+        KStream&lt;String, String&gt; words = source.flatMapValues(value -> Arrays.asList(value.split("\\W+")));
+    </pre>
+
+    <p>
+        And finally we can write the word stream back into another Kafka topic, say <code>streams-linesplit-output</code>.
+        Again, these two steps can be concatenated as the following (assuming lambda expression is used):
+    </p>
+
+    <pre class="brush: java;">
+        KStream&lt;String, String&gt; source = builder.stream("streams-plaintext-input");
+        source.flatMapValues(value -> Arrays.asList(value.split("\\W+")))
+              .to("streams-linesplit-output");
+    </pre>
+
+    <p>
+        The complete code looks like this (assuming lambda expression is used):
+    </p>
+
+    <pre class="brush: java;">
+        package myapps;
+
+        import org.apache.kafka.common.serialization.Serdes;
+        import org.apache.kafka.streams.KafkaStreams;
+        import org.apache.kafka.streams.StreamsConfig;
+        import org.apache.kafka.streams.kstream.KStreamBuilder;
+        import org.apache.kafka.streams.kstream.ValueMapper;
+
+        import java.util.Arrays;
+        import java.util.Properties;
+        import java.util.concurrent.CountDownLatch;
+
+        public class LineSplit {
+
+            public static void main(String[] args) throws Exception {
+                Properties props = new Properties();
+                props.put(StreamsConfig.APPLICATION_ID_CONFIG, "streams-linesplit");
+                props.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "localhost:9092");
+                props.put(StreamsConfig.DEFAULT_KEY_SERDE_CLASS_CONFIG, Serdes.String().getClass());
+                props.put(StreamsConfig.DEFAULT_VALUE_SERDE_CLASS_CONFIG, Serdes.String().getClass());
+
+                final KStreamBuilder builder = new KStreamBuilder();
+
+                KStream&lt;String, String&gt; source = builder.stream("streams-plaintext-input");
+                source.flatMapValues(value -> Arrays.asList(value.split("\\W+")))
+                      .to("streams-linesplit-output");
+
+                final KafkaStreams streams = new KafkaStreams(builder, props);
+                final CountDownLatch latch = new CountDownLatch(1);
+
+                // ... same as Pipe.java below
+            }
+        }
+    </pre>
+
+    <h4><a id="tutorial_code_wordcount" href="#tutorial_code_wordcount">Writing a third Streams application: Wordcount</a></h4>
+
+    <p>
+        Let's now take a step further to add some "stateful" computations to the topology by counting the occurrence of the words split from the source text stream.
+        Following similar steps let's create another program based on the <code>LineSplit.java</code> class:
+    </p>
+
+    <pre class="brush: java;">
+        public class WordCount {
+
+            public static void main(String[] args) throws Exception {
+                Properties props = new Properties();
+                props.put(StreamsConfig.APPLICATION_ID_CONFIG, "streams-wordcount");
+                // ...
+            }
+        }
+    </pre>
+
+    <p>
+        In order to count the words we can first modify the <code>flatMapValues</code> operator to treat all of them as lower case (assuming lambda expression is used):
+    </p>
+
+    <pre class="brush: java;">
+        source.flatMapValues(new ValueMapper&lt;String, Iterable&lt;String&gt;&gt;() {
+                    @Override
+                    public Iterable&lt;String&gt; apply(String value) {
+                        return Arrays.asList(value.toLowerCase(Locale.getDefault()).split("\\W+"));
+                    }
+                });
+    </pre>
+
+    <p>
+        In order to do the counting aggregation we have to first specify that we want to key the stream on the value string, i.e. the lower cased word, with a <code>groupBy</code> operator.
+        This operator generate a new grouped stream, which can then be aggregated by a <code>count</code> operator, which generates a running count on each of the grouped keys:
+    </p>
+
+    <pre class="brush: java;">
+        KTable&lt;String, Long&gt; counts =
+        source.flatMapValues(new ValueMapper&lt;String, Iterable&lt;String&gt;&gt;() {
+                    @Override
+                    public Iterable&lt;String&gt; apply(String value) {
+                        return Arrays.asList(value.toLowerCase(Locale.getDefault()).split("\\W+"));
+                    }
+                })
+              .groupBy(new KeyValueMapper&lt;String, String, String&gt;() {
+                   @Override
+                   public String apply(String key, String value) {
+                       return value;
+                   }
+                })
+              .count("Counts");
+    </pre>
+
+    <p>
+        Note that the <code>count</code> operator has a <code>String</code> typed parameter <code>Counts</code>,
+        which stores the running counts that keep being updated as more records are piped and processed from the source Kafka topic.
+        This <code>Counts</code> store can be queried in real-time, with details described in the <a href="/{{version}}/documentation/streams/developer-guide#streams_interactive_queries">Developer Manual</a>.
+    </p>
+
+    <p>
+        We can also write the <code>counts</code> KTable's changelog stream back into another Kafka topic, say <code>streams-wordcount-output</code>.
+        Note that this time the value type is no longer <code>String</code> but <code>Long</code>, so the default serialization classes are not viable for writing it to Kafka anymore.
+        We need to provide overridden serialization methods for <code>Long</code> types, otherwise a runtime exception will be thrown:
+    </p>
+
+    <pre class="brush: java;">
+        counts.to(Serdes.String(), Serdes.Long(), "streams-wordcount-output");
+    </pre>
+
+    <p>
+        Note that in order to read the changelog stream from topic <code>streams-wordcount-output</code>,
+        one needs to set the value deserialization as <code>org.apache.kafka.common.serialization.LongDeserializer</code>.
+        Details of this can be found in the <a href="/{{version}}/documentation/streams/quickstart">Play with a Streams Application</a> section.
+        Assuming lambda expression from JDK 8 can be used, the above code can be simplified as:
+    </p>
+
+    <pre class="brush: java;">
+        KStream&lt;String, String&gt; source = builder.stream("streams-plaintext-input");
+        source.flatMapValues(value -> Arrays.asList(value.toLowerCase(Locale.getDefault()).split("\\W+")))
+              .groupBy((key, value) -> value)
+              .count("Counts")
+              .to(Serdes.String(), Serdes.Long(), "streams-wordcount-output");
+    </pre>
+
+    <p>
+        The complete code looks like this (assuming lambda expression is used):
+    </p>
+
+    <pre class="brush: java;">
+        package myapps;
+
+        import org.apache.kafka.common.serialization.Serdes;
+        import org.apache.kafka.streams.KafkaStreams;
+        import org.apache.kafka.streams.StreamsConfig;
+        import org.apache.kafka.streams.kstream.KeyValueMapper;
+        import org.apache.kafka.streams.kstream.KStreamBuilder;
+        import org.apache.kafka.streams.kstream.ValueMapper;
+
+        import java.util.Arrays;
+        import java.util.Locale;
+        import java.util.Properties;
+        import java.util.concurrent.CountDownLatch;
+
+        public class WordCount {
+
+            public static void main(String[] args) throws Exception {
+                Properties props = new Properties();
+                props.put(StreamsConfig.APPLICATION_ID_CONFIG, "streams-wordcount");
+                props.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "localhost:9092");
+                props.put(StreamsConfig.DEFAULT_KEY_SERDE_CLASS_CONFIG, Serdes.String().getClass());
+                props.put(StreamsConfig.DEFAULT_VALUE_SERDE_CLASS_CONFIG, Serdes.String().getClass());
+
+                final KStreamBuilder builder = new KStreamBuilder();
+
+                KStream&lt;String, String&gt; source = builder.stream("streams-plaintext-input");
+                source.flatMapValues(value -> Arrays.asList(value.toLowerCase(Locale.getDefault()).split("\\W+")))
+                      .groupBy((key, value) -> value)
+                      .count("Counts")
+                      .to(Serdes.String(), Serdes.Long(), "streams-wordcount-output");
+
+                final KafkaStreams streams = new KafkaStreams(builder, props);
+                final CountDownLatch latch = new CountDownLatch(1);
+
+                // ... same as Pipe.java below
+            }
+        }
+    </pre>
+
+    <div class="pagination">
+        <a href="/{{version}}/documentation/streams/quickstart" class="pagination__btn pagination__btn__prev">Previous</a>
+        <a href="/{{version}}/documentation/streams/developer-guide" class="pagination__btn pagination__btn__next">Next</a>
+    </div>
+</script>
+
+<div class="p-quickstart-streams"></div>
+
+<!--#include virtual="../../includes/_header.htm" -->
+<!--#include virtual="../../includes/_top.htm" -->
+<div class="content documentation documentation--current">
+    <!--#include virtual="../../includes/_nav.htm" -->
+    <div class="right">
+        <!--#include virtual="../../includes/_docs_banner.htm" -->
+        <ul class="breadcrumbs">
+            <li><a href="/documentation">Documentation</a></li>
+            <li><a href="/documentation/streams">Streams</a></li>
+        </ul>
+        <div class="p-content"></div>
+    </div>
+</div>
+<!--#include virtual="../../includes/_footer.htm" -->
+<script>
+$(function() {
+  // Show selected style on nav item
+  $('.b-nav__streams').addClass('selected');
+
+  // Display docs subnav items
+  $('.b-nav__docs').parent().toggleClass('nav__item__with__subs--expanded');
+});
+</script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/streams/upgrade-guide.html
----------------------------------------------------------------------
diff --git a/0110/streams/upgrade-guide.html b/0110/streams/upgrade-guide.html
index 8ec3e22..7f2c9f6 100644
--- a/0110/streams/upgrade-guide.html
+++ b/0110/streams/upgrade-guide.html
@@ -27,13 +27,13 @@
     </p>
 
     <p>
-        If you want to upgrade from 0.10.1.x to 0.10.2, see the <a href="/{{version}}/documentation/#upgrade_1020_streams">Upgrade Section for 0.10.2</a>.
+        If you want to upgrade from 0.10.1.x to 0.10.2, see the <a href="/{{version}}/documentation/#upgrade_1020_streams"><b>Upgrade Section for 0.10.2</b></a>.
         It highlights incompatible changes you need to consider to upgrade your code and application.
         See <a href="#streams_api_changes_0102">below</a> a complete list of 0.10.2 API and semantical changes that allow you to advance your application and/or simplify your code base, including the usage of new features.
     </p>
 
     <p>
-        If you want to upgrade from 0.10.0.x to 0.10.1, see the <a href="/{{version}}/documentation/#upgrade_1010_streams">Upgrade Section for 0.10.1</a>.
+        If you want to upgrade from 0.10.0.x to 0.10.1, see the <a href="/{{version}}/documentation/#upgrade_1010_streams"><b>Upgrade Section for 0.10.1</b></a>.
         It highlights incompatible changes you need to consider to upgrade your code and application.
         See <a href="#streams_api_changes_0101">below</a> a complete list of 0.10.1 API changes that allow you to advance your application and/or simplify your code base, including the usage of new features.
     </p>
@@ -100,7 +100,7 @@
         <li> at-least-once (default): <code>[client.Id]-StreamThread-[sequence-number]</code> </li>
         <li> exactly-once: <code>[client.Id]-StreamThread-[sequence-number]-[taskId]</code> </li>
     </ul>
-    <p> <code>[client.Id]</code> is either set via Streams configuration parameter <code>client.id<code> or defaults to <code>[application.id]-[processId]</code> (<code>[processId]</code> is a random UUID). </p>
+    <p> <code>[client.Id]</code> is either set via Streams configuration parameter <code>client.id</code> or defaults to <code>[application.id]-[processId]</code> (<code>[processId]</code> is a random UUID). </p>
 
     <h3><a id="streams_api_changes_01021" href="#streams_api_changes_01021">Notable changes in 0.10.2.1</a></h3>
 
@@ -218,7 +218,7 @@
     </ul>
 
     <div class="pagination">
-        <a href="/{{version}}/documentation/streams/developer-guide" class="pagination__btn pagination__btn__prev">Previous</a>
+        <a href="/{{version}}/documentation/streams/architecture" class="pagination__btn pagination__btn__prev">Previous</a>
         <a href="#" class="pagination__btn pagination__btn__next pagination__btn--disabled">Next</a>
     </div>
 </script>
@@ -231,7 +231,7 @@
         <!--#include virtual="../../includes/_docs_banner.htm" -->
         <ul class="breadcrumbs">
             <li><a href="/documentation">Documentation</a></li>
-            <li><a href="/documentation/streams">Streams</a></li>
+            <li><a href="/documentation/streams">Kafka Streams API</a></li>
         </ul>
         <div class="p-content"></div>
     </div>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/toc.html
----------------------------------------------------------------------
diff --git a/0110/toc.html b/0110/toc.html
index e26023c..e7d939e 100644
--- a/0110/toc.html
+++ b/0110/toc.html
@@ -33,7 +33,7 @@
             <ul>
                 <li><a href="#producerapi">2.1 Producer API</a>
                 <li><a href="#consumerapi">2.2 Consumer API</a>
-                <li><a href="#streamsapi">2.3 Streams API</a>
+                <li><a href="/{{version}}/documentation/streams">2.3 Streams API</a>
                 <li><a href="#connectapi">2.4 Connect API</a>
                 <li><a href="#adminapi">2.5 AdminClient API</a>
                 <li><a href="#legacyapis">2.6 Legacy APIs</a>
@@ -42,15 +42,16 @@
         <li><a href="#configuration">3. Configuration</a>
             <ul>
                 <li><a href="#brokerconfigs">3.1 Broker Configs</a>
-                <li><a href="#producerconfigs">3.2 Producer Configs</a>
-                <li><a href="#consumerconfigs">3.3 Consumer Configs</a>
+                <li><a href="#topicconfigs">3.2 Topic Configs</a>
+                <li><a href="#producerconfigs">3.3 Producer Configs</a>
+                <li><a href="#consumerconfigs">3.4 Consumer Configs</a>
                     <ul>
-                        <li><a href="#newconsumerconfigs">3.3.1 New Consumer Configs</a>
-                        <li><a href="#oldconsumerconfigs">3.3.2 Old Consumer Configs</a>
+                        <li><a href="#newconsumerconfigs">3.4.1 New Consumer Configs</a>
+                        <li><a href="#oldconsumerconfigs">3.4.2 Old Consumer Configs</a>
                     </ul>
-                <li><a href="#connectconfigs">3.4 Kafka Connect Configs</a>
-                <li><a href="#streamsconfigs">3.5 Kafka Streams Configs</a>
-                <li><a href="#adminclientconfigs">3.6 AdminClient Configs</a>
+                <li><a href="#connectconfigs">3.5 Kafka Connect Configs</a>
+                <li><a href="#streamsconfigs">3.6 Kafka Streams Configs</a>
+                <li><a href="#adminclientconfigs">3.7 AdminClient Configs</a>
             </ul>
         </li>
         <li><a href="#design">4. Design</a>
@@ -142,16 +143,12 @@
         </li>
         <li><a href="/{{version}}/documentation/streams">9. Kafka Streams</a>
             <ul>
-                <li><a href="/{{version}}/documentation/streams#streams_overview">9.1 Overview</a></li>
-                <li><a href="/{{version}}/documentation/streams#streams_concepts">9.2 Core Concepts</a></li>
-                <li><a href="/{{version}}/documentation/streams#streams_architecture">9.3 Architecture</a></li>
-                <li><a href="/{{version}}/documentation/streams#streams_developer">9.4 Developer Guide</a></li>
-                <ul>
-                    <li><a href="/{{version}}/documentation/streams#streams_processor">Low-Level Processor API</a></li>
-                    <li><a href="/{{version}}/documentation/streams#streams_dsl">High-Level Streams DSL</a></li>
-                    <li><a href="/{{version}}/documentation/streams#streams_execute">Application Configuration and Execution</a></li>
-                </ul>
-                <li><a href="/{{version}}/documentation/streams#streams_upgrade_and_api">9.5 Upgrade Guide and API Changes</a></li>
+                <li><a href="/{{version}}/documentation/streams/quickstart">9.1 Play with a Streams Application</a></li>
+                <li><a href="/{{version}}/documentation/streams/tutorial">9.2 Write your own Streams Applications</a></li>
+                <li><a href="/{{version}}/documentation/streams/developer-guide">9.3 Developer Manual</a></li>
+                <li><a href="/{{version}}/documentation/streams/core-concepts">9.4 Core Concepts</a></li>
+                <li><a href="/{{version}}/documentation/streams/architecture">9.5 Architecture</a></li>
+                <li><a href="/{{version}}/documentation/streams/upgrade-guide">9.6 Upgrade Guide</a></li>
             </ul>
         </li>
     </ul>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/upgrade.html
----------------------------------------------------------------------
diff --git a/0110/upgrade.html b/0110/upgrade.html
index 98c749c..9f0dbdf 100644
--- a/0110/upgrade.html
+++ b/0110/upgrade.html
@@ -67,7 +67,7 @@
 <h5><a id="upgrade_1100_notable" href="#upgrade_1100_notable">Notable changes in 0.11.0.0</a></h5>
 <ul>
     <li>Unclean leader election is now disabled by default. The new default favors durability over availability. Users who wish to
-        to retain the previous behavior should set the broker config <code>unclean.leader.election.enabled</code> to <code>false</code>.</li>
+        to retain the previous behavior should set the broker config <code>unclean.leader.election.enable</code> to <code>true</code>.</li>
     <li>Producer configs <code>block.on.buffer.full</code>, <code>metadata.fetch.timeout.ms</code> and <code>timeout.ms</code> have been
         removed. They were initially deprecated in Kafka 0.9.0.0.</li>
     <li>The <code>offsets.topic.replication.factor</code> broker config is now enforced upon auto topic creation. Internal

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/downloads.html
----------------------------------------------------------------------
diff --git a/downloads.html b/downloads.html
index 82f81eb..0b2ab87 100644
--- a/downloads.html
+++ b/downloads.html
@@ -4,11 +4,28 @@
 	<!--#include virtual="includes/_nav.htm" -->
 	<div class="right">
 		<h1>Download</h1>
-    <p>0.11.0.0 is the latest release. The current stable version is 0.11.0.0.</p>
+    <p>0.11.0.1 is the latest release. The current stable version is 0.11.0.1.</p>
 
     <p>
     You can verify your download by following these <a href="http://www.apache.org/info/verification.html">procedures</a> and using these <a href="http://kafka.apache.org/KEYS">KEYS</a>.
     </p>
+				<h3>0.11.0.1</h3>
+				<ul>
+						<li>
+								<a href="https://archive.apache.org/dist/kafka/0.11.0.1/RELEASE_NOTES.html">Release Notes</a>
+						</li>
+						<li>
+								Source download: <a href="https://www.apache.org/dyn/closer.cgi?path=/kafka/0.11.0.1/kafka-0.11.0.1-src.tgz">kafka-0.11.0.1-src.tgz</a> (<a href="https://dist.apache.org/repos/dist/release/kafka/0.11.0.1/kafka-0.11.0.1-src.tgz.asc">asc</a>, <a href="https://dist.apache.org/repos/dist/release/kafka/0.11.0.0/kafka-0.11.0.0-src.tgz.md5">md5</a>)
+						</li>
+						<li>
+								Binary downloads:
+								<ul>
+										<li>Scala 2.11 &nbsp;- <a href="https://www.apache.org/dyn/closer.cgi?path=/kafka/0.11.0.1/kafka_2.11-0.11.0.1.tgz">kafka_2.11-0.11.0.1.tgz</a> (<a href="https://dist.apache.org/repos/dist/release/kafka/0.11.0.1/kafka_2.11-0.11.0.1.tgz.asc">asc</a>, <a href="https://dist.apache.org/repos/dist/release/kafka/0.11.0.1/kafka_2.11-0.11.0.1.tgz.md5">md5</a>)</li>
+										<li>Scala 2.12 &nbsp;- <a href="https://www.apache.org/dyn/closer.cgi?path=/kafka/0.11.0.1/kafka_2.12-0.11.0.1.tgz">kafka_2.12-0.11.0.1.tgz</a> (<a href="https://dist.apache.org/repos/dist/release/kafka/0.11.0.1/kafka_2.12-0.11.0.1.tgz.asc">asc</a>, <a href="https://dist.apache.org/repos/dist/release/kafka/0.11.0.1/kafka_2.12-0.11.0.1.tgz.md5">md5</a>)</li>
+								</ul>
+								We build for multiple versions of Scala. This only matters if you are using Scala and you want a version built for the same Scala version you use. Otherwise any version should work (2.11 is recommended).
+						</li>
+				</ul>
 
         <h3>0.11.0.0</h3>
         <ul>


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

Posted by da...@apache.org.
http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/producer/ProducerRecord.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/ProducerRecord.html b/0110/javadoc/org/apache/kafka/clients/producer/ProducerRecord.html
index 425d8cf..56e62ca 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/ProducerRecord.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/ProducerRecord.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ProducerRecord (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:58 BST 2017 -->
+<title>ProducerRecord (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="ProducerRecord (kafka 0.11.0.0 API)";
+        parent.document.title="ProducerRecord (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/producer/RecordMetadata.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/RecordMetadata.html b/0110/javadoc/org/apache/kafka/clients/producer/RecordMetadata.html
index ccaaccd..c22ed2f 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/RecordMetadata.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/RecordMetadata.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>RecordMetadata (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:58 BST 2017 -->
+<title>RecordMetadata (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="RecordMetadata (kafka 0.11.0.0 API)";
+        parent.document.title="RecordMetadata (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/producer/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/package-frame.html b/0110/javadoc/org/apache/kafka/clients/producer/package-frame.html
index 0fa431d..6381e71 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/package-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>org.apache.kafka.clients.producer (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>org.apache.kafka.clients.producer (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/org/apache/kafka/clients/producer/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/package-summary.html b/0110/javadoc/org/apache/kafka/clients/producer/package-summary.html
index 52462f5..ea5afcb 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/package-summary.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>org.apache.kafka.clients.producer (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>org.apache.kafka.clients.producer (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="org.apache.kafka.clients.producer (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.clients.producer (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/producer/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/package-tree.html b/0110/javadoc/org/apache/kafka/clients/producer/package-tree.html
index 792a773..ea7680e 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/package-tree.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>org.apache.kafka.clients.producer Class Hierarchy (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>org.apache.kafka.clients.producer Class Hierarchy (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="org.apache.kafka.clients.producer Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.clients.producer Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/Cluster.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/Cluster.html b/0110/javadoc/org/apache/kafka/common/Cluster.html
index cdf464c..c2b95bd 100644
--- a/0110/javadoc/org/apache/kafka/common/Cluster.html
+++ b/0110/javadoc/org/apache/kafka/common/Cluster.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>Cluster (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:56 BST 2017 -->
+<title>Cluster (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="Cluster (kafka 0.11.0.0 API)";
+        parent.document.title="Cluster (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/ClusterResource.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/ClusterResource.html b/0110/javadoc/org/apache/kafka/common/ClusterResource.html
index 896d77e..8230c13 100644
--- a/0110/javadoc/org/apache/kafka/common/ClusterResource.html
+++ b/0110/javadoc/org/apache/kafka/common/ClusterResource.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>ClusterResource (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:56 BST 2017 -->
+<title>ClusterResource (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="ClusterResource (kafka 0.11.0.0 API)";
+        parent.document.title="ClusterResource (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/ClusterResourceListener.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/ClusterResourceListener.html b/0110/javadoc/org/apache/kafka/common/ClusterResourceListener.html
index c2ed4a2..a9aca7d 100644
--- a/0110/javadoc/org/apache/kafka/common/ClusterResourceListener.html
+++ b/0110/javadoc/org/apache/kafka/common/ClusterResourceListener.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>ClusterResourceListener (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:56 BST 2017 -->
+<title>ClusterResourceListener (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="ClusterResourceListener (kafka 0.11.0.0 API)";
+        parent.document.title="ClusterResourceListener (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/Configurable.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/Configurable.html b/0110/javadoc/org/apache/kafka/common/Configurable.html
index 542ce02..3e62c03 100644
--- a/0110/javadoc/org/apache/kafka/common/Configurable.html
+++ b/0110/javadoc/org/apache/kafka/common/Configurable.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>Configurable (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:56 BST 2017 -->
+<title>Configurable (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="Configurable (kafka 0.11.0.0 API)";
+        parent.document.title="Configurable (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/KafkaException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/KafkaException.html b/0110/javadoc/org/apache/kafka/common/KafkaException.html
index 8ca186d..1bc043a 100644
--- a/0110/javadoc/org/apache/kafka/common/KafkaException.html
+++ b/0110/javadoc/org/apache/kafka/common/KafkaException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>KafkaException (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:56 BST 2017 -->
+<title>KafkaException (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="KafkaException (kafka 0.11.0.0 API)";
+        parent.document.title="KafkaException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/KafkaFuture.BiConsumer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/KafkaFuture.BiConsumer.html b/0110/javadoc/org/apache/kafka/common/KafkaFuture.BiConsumer.html
index 0715834..f7c0c1f 100644
--- a/0110/javadoc/org/apache/kafka/common/KafkaFuture.BiConsumer.html
+++ b/0110/javadoc/org/apache/kafka/common/KafkaFuture.BiConsumer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>KafkaFuture.BiConsumer (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:56 BST 2017 -->
+<title>KafkaFuture.BiConsumer (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="KafkaFuture.BiConsumer (kafka 0.11.0.0 API)";
+        parent.document.title="KafkaFuture.BiConsumer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/KafkaFuture.Function.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/KafkaFuture.Function.html b/0110/javadoc/org/apache/kafka/common/KafkaFuture.Function.html
index ed520c7..5acb528 100644
--- a/0110/javadoc/org/apache/kafka/common/KafkaFuture.Function.html
+++ b/0110/javadoc/org/apache/kafka/common/KafkaFuture.Function.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>KafkaFuture.Function (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:56 BST 2017 -->
+<title>KafkaFuture.Function (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="KafkaFuture.Function (kafka 0.11.0.0 API)";
+        parent.document.title="KafkaFuture.Function (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/KafkaFuture.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/KafkaFuture.html b/0110/javadoc/org/apache/kafka/common/KafkaFuture.html
index bcc744d..323f3c6 100644
--- a/0110/javadoc/org/apache/kafka/common/KafkaFuture.html
+++ b/0110/javadoc/org/apache/kafka/common/KafkaFuture.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>KafkaFuture (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:56 BST 2017 -->
+<title>KafkaFuture (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="KafkaFuture (kafka 0.11.0.0 API)";
+        parent.document.title="KafkaFuture (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/Metric.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/Metric.html b/0110/javadoc/org/apache/kafka/common/Metric.html
index f4903f3..34dd999 100644
--- a/0110/javadoc/org/apache/kafka/common/Metric.html
+++ b/0110/javadoc/org/apache/kafka/common/Metric.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>Metric (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:56 BST 2017 -->
+<title>Metric (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="Metric (kafka 0.11.0.0 API)";
+        parent.document.title="Metric (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/MetricName.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/MetricName.html b/0110/javadoc/org/apache/kafka/common/MetricName.html
index 2525c85..22f887b 100644
--- a/0110/javadoc/org/apache/kafka/common/MetricName.html
+++ b/0110/javadoc/org/apache/kafka/common/MetricName.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>MetricName (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:56 BST 2017 -->
+<title>MetricName (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="MetricName (kafka 0.11.0.0 API)";
+        parent.document.title="MetricName (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/MetricNameTemplate.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/MetricNameTemplate.html b/0110/javadoc/org/apache/kafka/common/MetricNameTemplate.html
index c5435ae..a3f9f4e 100644
--- a/0110/javadoc/org/apache/kafka/common/MetricNameTemplate.html
+++ b/0110/javadoc/org/apache/kafka/common/MetricNameTemplate.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>MetricNameTemplate (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:56 BST 2017 -->
+<title>MetricNameTemplate (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="MetricNameTemplate (kafka 0.11.0.0 API)";
+        parent.document.title="MetricNameTemplate (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/Node.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/Node.html b/0110/javadoc/org/apache/kafka/common/Node.html
index 647c2cf..33f9154 100644
--- a/0110/javadoc/org/apache/kafka/common/Node.html
+++ b/0110/javadoc/org/apache/kafka/common/Node.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>Node (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:56 BST 2017 -->
+<title>Node (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="Node (kafka 0.11.0.0 API)";
+        parent.document.title="Node (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/PartitionInfo.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/PartitionInfo.html b/0110/javadoc/org/apache/kafka/common/PartitionInfo.html
index 8a32498..1efbbd0 100644
--- a/0110/javadoc/org/apache/kafka/common/PartitionInfo.html
+++ b/0110/javadoc/org/apache/kafka/common/PartitionInfo.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>PartitionInfo (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:56 BST 2017 -->
+<title>PartitionInfo (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="PartitionInfo (kafka 0.11.0.0 API)";
+        parent.document.title="PartitionInfo (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/TopicPartition.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/TopicPartition.html b/0110/javadoc/org/apache/kafka/common/TopicPartition.html
index 8d5dab3..73e55ec 100644
--- a/0110/javadoc/org/apache/kafka/common/TopicPartition.html
+++ b/0110/javadoc/org/apache/kafka/common/TopicPartition.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>TopicPartition (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:56 BST 2017 -->
+<title>TopicPartition (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="TopicPartition (kafka 0.11.0.0 API)";
+        parent.document.title="TopicPartition (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/TopicPartitionInfo.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/TopicPartitionInfo.html b/0110/javadoc/org/apache/kafka/common/TopicPartitionInfo.html
index fff3ab3..971f623 100644
--- a/0110/javadoc/org/apache/kafka/common/TopicPartitionInfo.html
+++ b/0110/javadoc/org/apache/kafka/common/TopicPartitionInfo.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>TopicPartitionInfo (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:56 BST 2017 -->
+<title>TopicPartitionInfo (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="TopicPartitionInfo (kafka 0.11.0.0 API)";
+        parent.document.title="TopicPartitionInfo (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/acl/AccessControlEntry.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/acl/AccessControlEntry.html b/0110/javadoc/org/apache/kafka/common/acl/AccessControlEntry.html
index 9ef7064..50742e7 100644
--- a/0110/javadoc/org/apache/kafka/common/acl/AccessControlEntry.html
+++ b/0110/javadoc/org/apache/kafka/common/acl/AccessControlEntry.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>AccessControlEntry (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:55 BST 2017 -->
+<title>AccessControlEntry (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="AccessControlEntry (kafka 0.11.0.0 API)";
+        parent.document.title="AccessControlEntry (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/acl/AccessControlEntryFilter.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/acl/AccessControlEntryFilter.html b/0110/javadoc/org/apache/kafka/common/acl/AccessControlEntryFilter.html
index 10b93f8..779f589 100644
--- a/0110/javadoc/org/apache/kafka/common/acl/AccessControlEntryFilter.html
+++ b/0110/javadoc/org/apache/kafka/common/acl/AccessControlEntryFilter.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>AccessControlEntryFilter (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:55 BST 2017 -->
+<title>AccessControlEntryFilter (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="AccessControlEntryFilter (kafka 0.11.0.0 API)";
+        parent.document.title="AccessControlEntryFilter (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/acl/AclBinding.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/acl/AclBinding.html b/0110/javadoc/org/apache/kafka/common/acl/AclBinding.html
index 70641d5..d8698f0 100644
--- a/0110/javadoc/org/apache/kafka/common/acl/AclBinding.html
+++ b/0110/javadoc/org/apache/kafka/common/acl/AclBinding.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>AclBinding (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:55 BST 2017 -->
+<title>AclBinding (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="AclBinding (kafka 0.11.0.0 API)";
+        parent.document.title="AclBinding (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/acl/AclBindingFilter.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/acl/AclBindingFilter.html b/0110/javadoc/org/apache/kafka/common/acl/AclBindingFilter.html
index 402e00f..88d3c6c 100644
--- a/0110/javadoc/org/apache/kafka/common/acl/AclBindingFilter.html
+++ b/0110/javadoc/org/apache/kafka/common/acl/AclBindingFilter.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>AclBindingFilter (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:56 BST 2017 -->
+<title>AclBindingFilter (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="AclBindingFilter (kafka 0.11.0.0 API)";
+        parent.document.title="AclBindingFilter (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/acl/AclOperation.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/acl/AclOperation.html b/0110/javadoc/org/apache/kafka/common/acl/AclOperation.html
index 4c6bd55..4c237d1 100644
--- a/0110/javadoc/org/apache/kafka/common/acl/AclOperation.html
+++ b/0110/javadoc/org/apache/kafka/common/acl/AclOperation.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>AclOperation (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:56 BST 2017 -->
+<title>AclOperation (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="AclOperation (kafka 0.11.0.0 API)";
+        parent.document.title="AclOperation (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/acl/AclPermissionType.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/acl/AclPermissionType.html b/0110/javadoc/org/apache/kafka/common/acl/AclPermissionType.html
index 2d76412..4b6b434 100644
--- a/0110/javadoc/org/apache/kafka/common/acl/AclPermissionType.html
+++ b/0110/javadoc/org/apache/kafka/common/acl/AclPermissionType.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>AclPermissionType (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:56 BST 2017 -->
+<title>AclPermissionType (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="AclPermissionType (kafka 0.11.0.0 API)";
+        parent.document.title="AclPermissionType (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/acl/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/acl/package-frame.html b/0110/javadoc/org/apache/kafka/common/acl/package-frame.html
index 0736923..b0f700b 100644
--- a/0110/javadoc/org/apache/kafka/common/acl/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/common/acl/package-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>org.apache.kafka.common.acl (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>org.apache.kafka.common.acl (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/org/apache/kafka/common/acl/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/acl/package-summary.html b/0110/javadoc/org/apache/kafka/common/acl/package-summary.html
index 27a6467..e94d509 100644
--- a/0110/javadoc/org/apache/kafka/common/acl/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/common/acl/package-summary.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>org.apache.kafka.common.acl (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>org.apache.kafka.common.acl (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="org.apache.kafka.common.acl (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.acl (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/acl/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/acl/package-tree.html b/0110/javadoc/org/apache/kafka/common/acl/package-tree.html
index 9ad291e..b48ae14 100644
--- a/0110/javadoc/org/apache/kafka/common/acl/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/common/acl/package-tree.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>org.apache.kafka.common.acl Class Hierarchy (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>org.apache.kafka.common.acl Class Hierarchy (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="org.apache.kafka.common.acl Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.acl Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Evolving.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Evolving.html b/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Evolving.html
index dc8affb..d0a1d29 100644
--- a/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Evolving.html
+++ b/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Evolving.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>InterfaceStability.Evolving (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:56 BST 2017 -->
+<title>InterfaceStability.Evolving (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="InterfaceStability.Evolving (kafka 0.11.0.0 API)";
+        parent.document.title="InterfaceStability.Evolving (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Stable.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Stable.html b/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Stable.html
index 7780b3c..83a6fd0 100644
--- a/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Stable.html
+++ b/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Stable.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>InterfaceStability.Stable (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:56 BST 2017 -->
+<title>InterfaceStability.Stable (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="InterfaceStability.Stable (kafka 0.11.0.0 API)";
+        parent.document.title="InterfaceStability.Stable (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Unstable.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Unstable.html b/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Unstable.html
index 2836608..efa33b5 100644
--- a/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Unstable.html
+++ b/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.Unstable.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>InterfaceStability.Unstable (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:56 BST 2017 -->
+<title>InterfaceStability.Unstable (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="InterfaceStability.Unstable (kafka 0.11.0.0 API)";
+        parent.document.title="InterfaceStability.Unstable (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.html b/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.html
index 55b23a7..cee2550 100644
--- a/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.html
+++ b/0110/javadoc/org/apache/kafka/common/annotation/InterfaceStability.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>InterfaceStability (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:56 BST 2017 -->
+<title>InterfaceStability (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="InterfaceStability (kafka 0.11.0.0 API)";
+        parent.document.title="InterfaceStability (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/annotation/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/annotation/package-frame.html b/0110/javadoc/org/apache/kafka/common/annotation/package-frame.html
index 49ae7dc..b1ffd4e 100644
--- a/0110/javadoc/org/apache/kafka/common/annotation/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/common/annotation/package-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>org.apache.kafka.common.annotation (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>org.apache.kafka.common.annotation (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/org/apache/kafka/common/annotation/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/annotation/package-summary.html b/0110/javadoc/org/apache/kafka/common/annotation/package-summary.html
index 8cc029e..7a44bec 100644
--- a/0110/javadoc/org/apache/kafka/common/annotation/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/common/annotation/package-summary.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>org.apache.kafka.common.annotation (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>org.apache.kafka.common.annotation (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="org.apache.kafka.common.annotation (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.annotation (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/annotation/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/annotation/package-tree.html b/0110/javadoc/org/apache/kafka/common/annotation/package-tree.html
index ea80778..447bdbf 100644
--- a/0110/javadoc/org/apache/kafka/common/annotation/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/common/annotation/package-tree.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>org.apache.kafka.common.annotation Class Hierarchy (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>org.apache.kafka.common.annotation Class Hierarchy (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="org.apache.kafka.common.annotation Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.annotation Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -79,9 +79,9 @@
 </ul>
 <h2 title="Annotation Type Hierarchy">Annotation Type Hierarchy</h2>
 <ul>
-<li type="circle">org.apache.kafka.common.annotation.<a href="../../../../../org/apache/kafka/common/annotation/InterfaceStability.Evolving.html" title="annotation in org.apache.kafka.common.annotation"><span class="strong">InterfaceStability.Evolving</span></a> (implements java.lang.annotation.<a href="http://docs.oracle.com/javase/7/docs/api/java/lang/annotation/Annotation.html?is-external=true" title="class or interface in java.lang.annotation">Annotation</a>)</li>
-<li type="circle">org.apache.kafka.common.annotation.<a href="../../../../../org/apache/kafka/common/annotation/InterfaceStability.Unstable.html" title="annotation in org.apache.kafka.common.annotation"><span class="strong">InterfaceStability.Unstable</span></a> (implements java.lang.annotation.<a href="http://docs.oracle.com/javase/7/docs/api/java/lang/annotation/Annotation.html?is-external=true" title="class or interface in java.lang.annotation">Annotation</a>)</li>
 <li type="circle">org.apache.kafka.common.annotation.<a href="../../../../../org/apache/kafka/common/annotation/InterfaceStability.Stable.html" title="annotation in org.apache.kafka.common.annotation"><span class="strong">InterfaceStability.Stable</span></a> (implements java.lang.annotation.<a href="http://docs.oracle.com/javase/7/docs/api/java/lang/annotation/Annotation.html?is-external=true" title="class or interface in java.lang.annotation">Annotation</a>)</li>
+<li type="circle">org.apache.kafka.common.annotation.<a href="../../../../../org/apache/kafka/common/annotation/InterfaceStability.Unstable.html" title="annotation in org.apache.kafka.common.annotation"><span class="strong">InterfaceStability.Unstable</span></a> (implements java.lang.annotation.<a href="http://docs.oracle.com/javase/7/docs/api/java/lang/annotation/Annotation.html?is-external=true" title="class or interface in java.lang.annotation">Annotation</a>)</li>
+<li type="circle">org.apache.kafka.common.annotation.<a href="../../../../../org/apache/kafka/common/annotation/InterfaceStability.Evolving.html" title="annotation in org.apache.kafka.common.annotation"><span class="strong">InterfaceStability.Evolving</span></a> (implements java.lang.annotation.<a href="http://docs.oracle.com/javase/7/docs/api/java/lang/annotation/Annotation.html?is-external=true" title="class or interface in java.lang.annotation">Annotation</a>)</li>
 </ul>
 </div>
 <!-- ======= START OF BOTTOM NAVBAR ====== -->

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/AbstractConfig.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/AbstractConfig.html b/0110/javadoc/org/apache/kafka/common/config/AbstractConfig.html
index 5fef467..f1f3968 100644
--- a/0110/javadoc/org/apache/kafka/common/config/AbstractConfig.html
+++ b/0110/javadoc/org/apache/kafka/common/config/AbstractConfig.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>AbstractConfig (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:58 BST 2017 -->
+<title>AbstractConfig (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="AbstractConfig (kafka 0.11.0.0 API)";
+        parent.document.title="AbstractConfig (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/Config.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/Config.html b/0110/javadoc/org/apache/kafka/common/config/Config.html
index 42a1f8d..4e94aee 100644
--- a/0110/javadoc/org/apache/kafka/common/config/Config.html
+++ b/0110/javadoc/org/apache/kafka/common/config/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:08 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:58 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/common/config/ConfigDef.ConfigKey.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ConfigKey.html b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ConfigKey.html
index 0e71894..2a138c7 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ConfigKey.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ConfigKey.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigDef.ConfigKey (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:58 BST 2017 -->
+<title>ConfigDef.ConfigKey (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="ConfigDef.ConfigKey (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigDef.ConfigKey (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Importance.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Importance.html b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Importance.html
index 9993e3b..f3b00f3 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Importance.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Importance.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigDef.Importance (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:58 BST 2017 -->
+<title>ConfigDef.Importance (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="ConfigDef.Importance (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigDef.Importance (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigDef.NonEmptyString.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.NonEmptyString.html b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.NonEmptyString.html
index 66afb26..43a6557 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.NonEmptyString.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.NonEmptyString.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigDef.NonEmptyString (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:58 BST 2017 -->
+<title>ConfigDef.NonEmptyString (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="ConfigDef.NonEmptyString (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigDef.NonEmptyString (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -148,13 +148,17 @@ implements <a href="../../../../../org/apache/kafka/common/config/ConfigDef.Vali
 <div class="block">Perform single configuration validation.</div>
 </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/common/config/ConfigDef.NonEmptyString.html#toString()">toString</a></strong>()</code>&nbsp;</td>
+</tr>
 </table>
 <ul class="blockList">
 <li class="blockList"><a name="methods_inherited_from_class_java.lang.Object">
 <!--   -->
 </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>
@@ -190,7 +194,7 @@ implements <a href="../../../../../org/apache/kafka/common/config/ConfigDef.Vali
 <a name="ensureValid(java.lang.String, java.lang.Object)">
 <!--   -->
 </a>
-<ul class="blockListLast">
+<ul class="blockList">
 <li class="blockList">
 <h4>ensureValid</h4>
 <pre>public&nbsp;void&nbsp;ensureValid(<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;name,
@@ -203,6 +207,19 @@ implements <a href="../../../../../org/apache/kafka/common/config/ConfigDef.Vali
 <dt><span class="strong">Parameters:</span></dt><dd><code>name</code> - The name of the configuration</dd><dd><code>o</code> - The value of the configuration</dd></dl>
 </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/common/config/ConfigDef.Range.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Range.html b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Range.html
index 4108cc7..9ea4b7a 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Range.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Range.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigDef.Range (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:58 BST 2017 -->
+<title>ConfigDef.Range (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="ConfigDef.Range (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigDef.Range (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Recommender.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Recommender.html b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Recommender.html
index ec5be7b..37dff42 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Recommender.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Recommender.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigDef.Recommender (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:58 BST 2017 -->
+<title>ConfigDef.Recommender (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="ConfigDef.Recommender (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigDef.Recommender (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Type.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Type.html b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Type.html
index b3b0995..5fba39d 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Type.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Type.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigDef.Type (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:58 BST 2017 -->
+<title>ConfigDef.Type (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="ConfigDef.Type (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigDef.Type (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ValidList.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ValidList.html b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ValidList.html
index 963c209..d9a3180 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ValidList.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ValidList.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigDef.ValidList (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:58 BST 2017 -->
+<title>ConfigDef.ValidList (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="ConfigDef.ValidList (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigDef.ValidList (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ValidString.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ValidString.html b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ValidString.html
index 32d8b1a..b5f6a28 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ValidString.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.ValidString.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigDef.ValidString (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:58 BST 2017 -->
+<title>ConfigDef.ValidString (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="ConfigDef.ValidString (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigDef.ValidString (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Validator.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Validator.html b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Validator.html
index 622cb0b..5279f36 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Validator.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Validator.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigDef.Validator (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:58 BST 2017 -->
+<title>ConfigDef.Validator (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="ConfigDef.Validator (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigDef.Validator (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Width.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Width.html b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Width.html
index b9739fc..4b3d664 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Width.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.Width.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigDef.Width (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:58 BST 2017 -->
+<title>ConfigDef.Width (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="ConfigDef.Width (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigDef.Width (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigDef.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.html b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.html
index 862cff2..6979852 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigDef.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigDef.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigDef (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:58 BST 2017 -->
+<title>ConfigDef (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="ConfigDef (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigDef (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigException.html b/0110/javadoc/org/apache/kafka/common/config/ConfigException.html
index 02b0782..3ad3efa 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigException.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigException (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:58 BST 2017 -->
+<title>ConfigException (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="ConfigException (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigResource.Type.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigResource.Type.html b/0110/javadoc/org/apache/kafka/common/config/ConfigResource.Type.html
index b6e39ab..0bfe76d 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigResource.Type.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigResource.Type.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigResource.Type (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:58 BST 2017 -->
+<title>ConfigResource.Type (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="ConfigResource.Type (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigResource.Type (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigResource.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigResource.html b/0110/javadoc/org/apache/kafka/common/config/ConfigResource.html
index d76ae4b..fcea148 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigResource.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigResource.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigResource (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:58 BST 2017 -->
+<title>ConfigResource (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="ConfigResource (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigResource (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/ConfigValue.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/ConfigValue.html b/0110/javadoc/org/apache/kafka/common/config/ConfigValue.html
index 911f8b6..a3066df 100644
--- a/0110/javadoc/org/apache/kafka/common/config/ConfigValue.html
+++ b/0110/javadoc/org/apache/kafka/common/config/ConfigValue.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConfigValue (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:58 BST 2017 -->
+<title>ConfigValue (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="ConfigValue (kafka 0.11.0.0 API)";
+        parent.document.title="ConfigValue (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/SaslConfigs.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/SaslConfigs.html b/0110/javadoc/org/apache/kafka/common/config/SaslConfigs.html
index 9deea47..8f31688 100644
--- a/0110/javadoc/org/apache/kafka/common/config/SaslConfigs.html
+++ b/0110/javadoc/org/apache/kafka/common/config/SaslConfigs.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>SaslConfigs (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:58 BST 2017 -->
+<title>SaslConfigs (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="SaslConfigs (kafka 0.11.0.0 API)";
+        parent.document.title="SaslConfigs (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/SslConfigs.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/SslConfigs.html b/0110/javadoc/org/apache/kafka/common/config/SslConfigs.html
index 6b09ee9..6170213 100644
--- a/0110/javadoc/org/apache/kafka/common/config/SslConfigs.html
+++ b/0110/javadoc/org/apache/kafka/common/config/SslConfigs.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>SslConfigs (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:58 BST 2017 -->
+<title>SslConfigs (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="SslConfigs (kafka 0.11.0.0 API)";
+        parent.document.title="SslConfigs (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/TopicConfig.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/TopicConfig.html b/0110/javadoc/org/apache/kafka/common/config/TopicConfig.html
index 8ea55d5..2665915 100644
--- a/0110/javadoc/org/apache/kafka/common/config/TopicConfig.html
+++ b/0110/javadoc/org/apache/kafka/common/config/TopicConfig.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>TopicConfig (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:58 BST 2017 -->
+<title>TopicConfig (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="TopicConfig (kafka 0.11.0.0 API)";
+        parent.document.title="TopicConfig (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/package-frame.html b/0110/javadoc/org/apache/kafka/common/config/package-frame.html
index 78ccdc7..db4a669 100644
--- a/0110/javadoc/org/apache/kafka/common/config/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/common/config/package-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>org.apache.kafka.common.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:59 BST 2017 -->
+<title>org.apache.kafka.common.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>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/config/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/package-summary.html b/0110/javadoc/org/apache/kafka/common/config/package-summary.html
index 28a6237..97efbbe 100644
--- a/0110/javadoc/org/apache/kafka/common/config/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/common/config/package-summary.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>org.apache.kafka.common.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:59 BST 2017 -->
+<title>org.apache.kafka.common.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="org.apache.kafka.common.config (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.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/common/config/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/config/package-tree.html b/0110/javadoc/org/apache/kafka/common/config/package-tree.html
index a67f843..5ecdfbc 100644
--- a/0110/javadoc/org/apache/kafka/common/config/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/common/config/package-tree.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>org.apache.kafka.common.config Class Hierarchy (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>org.apache.kafka.common.config Class Hierarchy (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="org.apache.kafka.common.config Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.config Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -117,10 +117,10 @@
 <ul>
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="strong">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/7/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
-<li type="circle">org.apache.kafka.common.config.<a href="../../../../../org/apache/kafka/common/config/ConfigDef.Type.html" title="enum in org.apache.kafka.common.config"><span class="strong">ConfigDef.Type</span></a></li>
-<li type="circle">org.apache.kafka.common.config.<a href="../../../../../org/apache/kafka/common/config/ConfigResource.Type.html" title="enum in org.apache.kafka.common.config"><span class="strong">ConfigResource.Type</span></a></li>
 <li type="circle">org.apache.kafka.common.config.<a href="../../../../../org/apache/kafka/common/config/ConfigDef.Importance.html" title="enum in org.apache.kafka.common.config"><span class="strong">ConfigDef.Importance</span></a></li>
+<li type="circle">org.apache.kafka.common.config.<a href="../../../../../org/apache/kafka/common/config/ConfigDef.Type.html" title="enum in org.apache.kafka.common.config"><span class="strong">ConfigDef.Type</span></a></li>
 <li type="circle">org.apache.kafka.common.config.<a href="../../../../../org/apache/kafka/common/config/ConfigDef.Width.html" title="enum in org.apache.kafka.common.config"><span class="strong">ConfigDef.Width</span></a></li>
+<li type="circle">org.apache.kafka.common.config.<a href="../../../../../org/apache/kafka/common/config/ConfigResource.Type.html" title="enum in org.apache.kafka.common.config"><span class="strong">ConfigResource.Type</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/ApiException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/ApiException.html b/0110/javadoc/org/apache/kafka/common/errors/ApiException.html
index c6164f8..4fbd2f3 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/ApiException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/ApiException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ApiException (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:58 BST 2017 -->
+<title>ApiException (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="ApiException (kafka 0.11.0.0 API)";
+        parent.document.title="ApiException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/AuthenticationException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/AuthenticationException.html b/0110/javadoc/org/apache/kafka/common/errors/AuthenticationException.html
index fc7d0c8..2885722 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/AuthenticationException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/AuthenticationException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>AuthenticationException (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:58 BST 2017 -->
+<title>AuthenticationException (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="AuthenticationException (kafka 0.11.0.0 API)";
+        parent.document.title="AuthenticationException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>


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

Posted by da...@apache.org.
http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/AuthorizationException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/AuthorizationException.html b/0110/javadoc/org/apache/kafka/common/errors/AuthorizationException.html
index 2f5da1b..86a025f 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/AuthorizationException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/AuthorizationException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>AuthorizationException (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:58 BST 2017 -->
+<title>AuthorizationException (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="AuthorizationException (kafka 0.11.0.0 API)";
+        parent.document.title="AuthorizationException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/BrokerNotAvailableException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/BrokerNotAvailableException.html b/0110/javadoc/org/apache/kafka/common/errors/BrokerNotAvailableException.html
index aa0af6f..94e6464 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/BrokerNotAvailableException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/BrokerNotAvailableException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>BrokerNotAvailableException (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:58 BST 2017 -->
+<title>BrokerNotAvailableException (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="BrokerNotAvailableException (kafka 0.11.0.0 API)";
+        parent.document.title="BrokerNotAvailableException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/ClusterAuthorizationException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/ClusterAuthorizationException.html b/0110/javadoc/org/apache/kafka/common/errors/ClusterAuthorizationException.html
index 7fc9d15..54d11bf 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/ClusterAuthorizationException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/ClusterAuthorizationException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ClusterAuthorizationException (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:58 BST 2017 -->
+<title>ClusterAuthorizationException (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="ClusterAuthorizationException (kafka 0.11.0.0 API)";
+        parent.document.title="ClusterAuthorizationException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/ConcurrentTransactionsException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/ConcurrentTransactionsException.html b/0110/javadoc/org/apache/kafka/common/errors/ConcurrentTransactionsException.html
index 5a62be6..dc2efdd 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/ConcurrentTransactionsException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/ConcurrentTransactionsException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConcurrentTransactionsException (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:58 BST 2017 -->
+<title>ConcurrentTransactionsException (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="ConcurrentTransactionsException (kafka 0.11.0.0 API)";
+        parent.document.title="ConcurrentTransactionsException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/ControllerMovedException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/ControllerMovedException.html b/0110/javadoc/org/apache/kafka/common/errors/ControllerMovedException.html
index 8331ea5..729559b 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/ControllerMovedException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/ControllerMovedException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ControllerMovedException (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:58 BST 2017 -->
+<title>ControllerMovedException (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="ControllerMovedException (kafka 0.11.0.0 API)";
+        parent.document.title="ControllerMovedException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/CoordinatorLoadInProgressException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/CoordinatorLoadInProgressException.html b/0110/javadoc/org/apache/kafka/common/errors/CoordinatorLoadInProgressException.html
index 4109a67..42ddf7b 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/CoordinatorLoadInProgressException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/CoordinatorLoadInProgressException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>CoordinatorLoadInProgressException (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:58 BST 2017 -->
+<title>CoordinatorLoadInProgressException (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="CoordinatorLoadInProgressException (kafka 0.11.0.0 API)";
+        parent.document.title="CoordinatorLoadInProgressException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/CoordinatorNotAvailableException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/CoordinatorNotAvailableException.html b/0110/javadoc/org/apache/kafka/common/errors/CoordinatorNotAvailableException.html
index 8d7f1da..c324e79 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/CoordinatorNotAvailableException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/CoordinatorNotAvailableException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>CoordinatorNotAvailableException (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:58 BST 2017 -->
+<title>CoordinatorNotAvailableException (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="CoordinatorNotAvailableException (kafka 0.11.0.0 API)";
+        parent.document.title="CoordinatorNotAvailableException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/CorruptRecordException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/CorruptRecordException.html b/0110/javadoc/org/apache/kafka/common/errors/CorruptRecordException.html
index ce450d8..c760115 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/CorruptRecordException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/CorruptRecordException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>CorruptRecordException (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:58 BST 2017 -->
+<title>CorruptRecordException (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="CorruptRecordException (kafka 0.11.0.0 API)";
+        parent.document.title="CorruptRecordException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/DisconnectException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/DisconnectException.html b/0110/javadoc/org/apache/kafka/common/errors/DisconnectException.html
index ac10d06..ea75843 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/DisconnectException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/DisconnectException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>DisconnectException (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:58 BST 2017 -->
+<title>DisconnectException (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="DisconnectException (kafka 0.11.0.0 API)";
+        parent.document.title="DisconnectException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/DuplicateSequenceNumberException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/DuplicateSequenceNumberException.html b/0110/javadoc/org/apache/kafka/common/errors/DuplicateSequenceNumberException.html
index d0be047..96f3d4e 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/DuplicateSequenceNumberException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/DuplicateSequenceNumberException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>DuplicateSequenceNumberException (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:58 BST 2017 -->
+<title>DuplicateSequenceNumberException (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="DuplicateSequenceNumberException (kafka 0.11.0.0 API)";
+        parent.document.title="DuplicateSequenceNumberException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/GroupAuthorizationException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/GroupAuthorizationException.html b/0110/javadoc/org/apache/kafka/common/errors/GroupAuthorizationException.html
index 45c0d79..9d20a1e 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/GroupAuthorizationException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/GroupAuthorizationException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>GroupAuthorizationException (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:58 BST 2017 -->
+<title>GroupAuthorizationException (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="GroupAuthorizationException (kafka 0.11.0.0 API)";
+        parent.document.title="GroupAuthorizationException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/GroupCoordinatorNotAvailableException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/GroupCoordinatorNotAvailableException.html b/0110/javadoc/org/apache/kafka/common/errors/GroupCoordinatorNotAvailableException.html
index 29fae70..84a477f 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/GroupCoordinatorNotAvailableException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/GroupCoordinatorNotAvailableException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>GroupCoordinatorNotAvailableException (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:58 BST 2017 -->
+<title>GroupCoordinatorNotAvailableException (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="GroupCoordinatorNotAvailableException (kafka 0.11.0.0 API)";
+        parent.document.title="GroupCoordinatorNotAvailableException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/GroupLoadInProgressException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/GroupLoadInProgressException.html b/0110/javadoc/org/apache/kafka/common/errors/GroupLoadInProgressException.html
index 96f9535..26a0f3a 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/GroupLoadInProgressException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/GroupLoadInProgressException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>GroupLoadInProgressException (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:58 BST 2017 -->
+<title>GroupLoadInProgressException (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="GroupLoadInProgressException (kafka 0.11.0.0 API)";
+        parent.document.title="GroupLoadInProgressException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/IllegalGenerationException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/IllegalGenerationException.html b/0110/javadoc/org/apache/kafka/common/errors/IllegalGenerationException.html
index 20efa40..09f9597 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/IllegalGenerationException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/IllegalGenerationException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>IllegalGenerationException (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:58 BST 2017 -->
+<title>IllegalGenerationException (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="IllegalGenerationException (kafka 0.11.0.0 API)";
+        parent.document.title="IllegalGenerationException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/IllegalSaslStateException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/IllegalSaslStateException.html b/0110/javadoc/org/apache/kafka/common/errors/IllegalSaslStateException.html
index 7b17e6d..5e11094 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/IllegalSaslStateException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/IllegalSaslStateException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>IllegalSaslStateException (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:58 BST 2017 -->
+<title>IllegalSaslStateException (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="IllegalSaslStateException (kafka 0.11.0.0 API)";
+        parent.document.title="IllegalSaslStateException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InconsistentGroupProtocolException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InconsistentGroupProtocolException.html b/0110/javadoc/org/apache/kafka/common/errors/InconsistentGroupProtocolException.html
index 1ca8827..de51984 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InconsistentGroupProtocolException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InconsistentGroupProtocolException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InconsistentGroupProtocolException (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:58 BST 2017 -->
+<title>InconsistentGroupProtocolException (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="InconsistentGroupProtocolException (kafka 0.11.0.0 API)";
+        parent.document.title="InconsistentGroupProtocolException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InterruptException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InterruptException.html b/0110/javadoc/org/apache/kafka/common/errors/InterruptException.html
index 079e3c8..9767f59 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InterruptException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InterruptException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InterruptException (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:58 BST 2017 -->
+<title>InterruptException (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="InterruptException (kafka 0.11.0.0 API)";
+        parent.document.title="InterruptException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidCommitOffsetSizeException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidCommitOffsetSizeException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidCommitOffsetSizeException.html
index 5ed773a..c9709d7 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidCommitOffsetSizeException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidCommitOffsetSizeException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidCommitOffsetSizeException (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:58 BST 2017 -->
+<title>InvalidCommitOffsetSizeException (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="InvalidCommitOffsetSizeException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidCommitOffsetSizeException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidConfigurationException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidConfigurationException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidConfigurationException.html
index d8fb093..cca7af9 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidConfigurationException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidConfigurationException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidConfigurationException (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:58 BST 2017 -->
+<title>InvalidConfigurationException (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="InvalidConfigurationException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidConfigurationException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidFetchSizeException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidFetchSizeException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidFetchSizeException.html
index c529d5c..94ea95c 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidFetchSizeException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidFetchSizeException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidFetchSizeException (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:58 BST 2017 -->
+<title>InvalidFetchSizeException (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="InvalidFetchSizeException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidFetchSizeException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidGroupIdException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidGroupIdException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidGroupIdException.html
index 5ecd89f..b052db3 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidGroupIdException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidGroupIdException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidGroupIdException (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:58 BST 2017 -->
+<title>InvalidGroupIdException (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="InvalidGroupIdException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidGroupIdException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidMetadataException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidMetadataException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidMetadataException.html
index 689c058..0f3a22b 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidMetadataException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidMetadataException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidMetadataException (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:58 BST 2017 -->
+<title>InvalidMetadataException (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="InvalidMetadataException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidMetadataException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidOffsetException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidOffsetException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidOffsetException.html
index 925139c..14ba2b0 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidOffsetException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidOffsetException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidOffsetException (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:58 BST 2017 -->
+<title>InvalidOffsetException (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="InvalidOffsetException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidOffsetException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidPartitionsException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidPartitionsException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidPartitionsException.html
index aa37e01..c80e398 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidPartitionsException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidPartitionsException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidPartitionsException (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:58 BST 2017 -->
+<title>InvalidPartitionsException (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="InvalidPartitionsException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidPartitionsException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidPidMappingException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidPidMappingException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidPidMappingException.html
index 9c1e3fe..a66f3fa 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidPidMappingException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidPidMappingException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidPidMappingException (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:58 BST 2017 -->
+<title>InvalidPidMappingException (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="InvalidPidMappingException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidPidMappingException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidReplicaAssignmentException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidReplicaAssignmentException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidReplicaAssignmentException.html
index ad7ef05..5523913 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidReplicaAssignmentException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidReplicaAssignmentException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidReplicaAssignmentException (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:58 BST 2017 -->
+<title>InvalidReplicaAssignmentException (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="InvalidReplicaAssignmentException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidReplicaAssignmentException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidReplicationFactorException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidReplicationFactorException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidReplicationFactorException.html
index 372006e..14c82c5 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidReplicationFactorException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidReplicationFactorException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidReplicationFactorException (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:58 BST 2017 -->
+<title>InvalidReplicationFactorException (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="InvalidReplicationFactorException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidReplicationFactorException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidRequestException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidRequestException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidRequestException.html
index 94de62e..813caf7 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidRequestException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidRequestException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidRequestException (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:58 BST 2017 -->
+<title>InvalidRequestException (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="InvalidRequestException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidRequestException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidRequiredAcksException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidRequiredAcksException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidRequiredAcksException.html
index c283f0f..619139a 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidRequiredAcksException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidRequiredAcksException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidRequiredAcksException (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:58 BST 2017 -->
+<title>InvalidRequiredAcksException (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="InvalidRequiredAcksException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidRequiredAcksException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidSessionTimeoutException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidSessionTimeoutException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidSessionTimeoutException.html
index 8f24a65..ff92f11 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidSessionTimeoutException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidSessionTimeoutException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidSessionTimeoutException (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:58 BST 2017 -->
+<title>InvalidSessionTimeoutException (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="InvalidSessionTimeoutException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidSessionTimeoutException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidTimestampException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidTimestampException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidTimestampException.html
index a90d7a1..712934b 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidTimestampException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidTimestampException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidTimestampException (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:58 BST 2017 -->
+<title>InvalidTimestampException (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="InvalidTimestampException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidTimestampException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidTopicException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidTopicException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidTopicException.html
index 1264186..f620549 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidTopicException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidTopicException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidTopicException (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:58 BST 2017 -->
+<title>InvalidTopicException (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="InvalidTopicException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidTopicException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidTxnStateException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidTxnStateException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidTxnStateException.html
index 714152e..10c5ffa 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidTxnStateException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidTxnStateException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidTxnStateException (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:58 BST 2017 -->
+<title>InvalidTxnStateException (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="InvalidTxnStateException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidTxnStateException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/InvalidTxnTimeoutException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/InvalidTxnTimeoutException.html b/0110/javadoc/org/apache/kafka/common/errors/InvalidTxnTimeoutException.html
index a3e82fe..9eee40e 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/InvalidTxnTimeoutException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/InvalidTxnTimeoutException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>InvalidTxnTimeoutException (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:58 BST 2017 -->
+<title>InvalidTxnTimeoutException (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="InvalidTxnTimeoutException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidTxnTimeoutException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/LeaderNotAvailableException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/LeaderNotAvailableException.html b/0110/javadoc/org/apache/kafka/common/errors/LeaderNotAvailableException.html
index 5a32e86..1238d15 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/LeaderNotAvailableException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/LeaderNotAvailableException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>LeaderNotAvailableException (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:58 BST 2017 -->
+<title>LeaderNotAvailableException (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="LeaderNotAvailableException (kafka 0.11.0.0 API)";
+        parent.document.title="LeaderNotAvailableException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/NetworkException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/NetworkException.html b/0110/javadoc/org/apache/kafka/common/errors/NetworkException.html
index e6f540c..06cc1e8 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/NetworkException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/NetworkException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>NetworkException (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:58 BST 2017 -->
+<title>NetworkException (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="NetworkException (kafka 0.11.0.0 API)";
+        parent.document.title="NetworkException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/NotControllerException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/NotControllerException.html b/0110/javadoc/org/apache/kafka/common/errors/NotControllerException.html
index 7ba10f6..a05d308 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/NotControllerException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/NotControllerException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>NotControllerException (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:58 BST 2017 -->
+<title>NotControllerException (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="NotControllerException (kafka 0.11.0.0 API)";
+        parent.document.title="NotControllerException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/NotCoordinatorException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/NotCoordinatorException.html b/0110/javadoc/org/apache/kafka/common/errors/NotCoordinatorException.html
index dd9ada9..04943a5 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/NotCoordinatorException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/NotCoordinatorException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>NotCoordinatorException (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:58 BST 2017 -->
+<title>NotCoordinatorException (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="NotCoordinatorException (kafka 0.11.0.0 API)";
+        parent.document.title="NotCoordinatorException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/NotCoordinatorForGroupException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/NotCoordinatorForGroupException.html b/0110/javadoc/org/apache/kafka/common/errors/NotCoordinatorForGroupException.html
index 8814ab5..52d719f 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/NotCoordinatorForGroupException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/NotCoordinatorForGroupException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>NotCoordinatorForGroupException (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:58 BST 2017 -->
+<title>NotCoordinatorForGroupException (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="NotCoordinatorForGroupException (kafka 0.11.0.0 API)";
+        parent.document.title="NotCoordinatorForGroupException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/NotEnoughReplicasAfterAppendException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/NotEnoughReplicasAfterAppendException.html b/0110/javadoc/org/apache/kafka/common/errors/NotEnoughReplicasAfterAppendException.html
index 384c298..d70d93e 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/NotEnoughReplicasAfterAppendException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/NotEnoughReplicasAfterAppendException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>NotEnoughReplicasAfterAppendException (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:58 BST 2017 -->
+<title>NotEnoughReplicasAfterAppendException (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="NotEnoughReplicasAfterAppendException (kafka 0.11.0.0 API)";
+        parent.document.title="NotEnoughReplicasAfterAppendException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/NotEnoughReplicasException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/NotEnoughReplicasException.html b/0110/javadoc/org/apache/kafka/common/errors/NotEnoughReplicasException.html
index c043916..f08f566 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/NotEnoughReplicasException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/NotEnoughReplicasException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>NotEnoughReplicasException (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:58 BST 2017 -->
+<title>NotEnoughReplicasException (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="NotEnoughReplicasException (kafka 0.11.0.0 API)";
+        parent.document.title="NotEnoughReplicasException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/NotLeaderForPartitionException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/NotLeaderForPartitionException.html b/0110/javadoc/org/apache/kafka/common/errors/NotLeaderForPartitionException.html
index ad65778..104dd25 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/NotLeaderForPartitionException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/NotLeaderForPartitionException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>NotLeaderForPartitionException (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:58 BST 2017 -->
+<title>NotLeaderForPartitionException (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="NotLeaderForPartitionException (kafka 0.11.0.0 API)";
+        parent.document.title="NotLeaderForPartitionException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/OffsetMetadataTooLarge.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/OffsetMetadataTooLarge.html b/0110/javadoc/org/apache/kafka/common/errors/OffsetMetadataTooLarge.html
index 11a9a5c..5b57bc6 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/OffsetMetadataTooLarge.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/OffsetMetadataTooLarge.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>OffsetMetadataTooLarge (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:58 BST 2017 -->
+<title>OffsetMetadataTooLarge (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="OffsetMetadataTooLarge (kafka 0.11.0.0 API)";
+        parent.document.title="OffsetMetadataTooLarge (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/OffsetOutOfRangeException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/OffsetOutOfRangeException.html b/0110/javadoc/org/apache/kafka/common/errors/OffsetOutOfRangeException.html
index 58aef49..61f8c37 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/OffsetOutOfRangeException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/OffsetOutOfRangeException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>OffsetOutOfRangeException (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:58 BST 2017 -->
+<title>OffsetOutOfRangeException (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="OffsetOutOfRangeException (kafka 0.11.0.0 API)";
+        parent.document.title="OffsetOutOfRangeException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/OperationNotAttemptedException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/OperationNotAttemptedException.html b/0110/javadoc/org/apache/kafka/common/errors/OperationNotAttemptedException.html
index 5844030..3380bf6 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/OperationNotAttemptedException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/OperationNotAttemptedException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>OperationNotAttemptedException (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:58 BST 2017 -->
+<title>OperationNotAttemptedException (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="OperationNotAttemptedException (kafka 0.11.0.0 API)";
+        parent.document.title="OperationNotAttemptedException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/OutOfOrderSequenceException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/OutOfOrderSequenceException.html b/0110/javadoc/org/apache/kafka/common/errors/OutOfOrderSequenceException.html
index def4fcc..a543b51 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/OutOfOrderSequenceException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/OutOfOrderSequenceException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>OutOfOrderSequenceException (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:58 BST 2017 -->
+<title>OutOfOrderSequenceException (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="OutOfOrderSequenceException (kafka 0.11.0.0 API)";
+        parent.document.title="OutOfOrderSequenceException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -126,6 +126,12 @@
 <br>
 <pre>public class <span class="strong">OutOfOrderSequenceException</span>
 extends <a href="../../../../../org/apache/kafka/common/errors/ApiException.html" title="class in org.apache.kafka.common.errors">ApiException</a></pre>
+<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. If the producer is configured for idempotence only (i.e.
+ if <code>enable.idempotence</code> is set and no <code>transactional.id</code> is configured), it
+ is possible to continue sending with the same producer instance, but doing so risks reordering
+ of sent records. For transactional producers, this is a fatal error and you should close the
+ producer.</div>
 <dl><dt><span class="strong">See Also:</span></dt><dd><a href="../../../../../serialized-form.html#org.apache.kafka.common.errors.OutOfOrderSequenceException">Serialized Form</a></dd></dl>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/PolicyViolationException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/PolicyViolationException.html b/0110/javadoc/org/apache/kafka/common/errors/PolicyViolationException.html
index 1154131..499d350 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/PolicyViolationException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/PolicyViolationException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>PolicyViolationException (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:58 BST 2017 -->
+<title>PolicyViolationException (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="PolicyViolationException (kafka 0.11.0.0 API)";
+        parent.document.title="PolicyViolationException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/ProducerFencedException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/ProducerFencedException.html b/0110/javadoc/org/apache/kafka/common/errors/ProducerFencedException.html
index 415a06f..d8d5ef3 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/ProducerFencedException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/ProducerFencedException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ProducerFencedException (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:58 BST 2017 -->
+<title>ProducerFencedException (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="ProducerFencedException (kafka 0.11.0.0 API)";
+        parent.document.title="ProducerFencedException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -126,6 +126,10 @@
 <br>
 <pre>public class <span class="strong">ProducerFencedException</span>
 extends <a href="../../../../../org/apache/kafka/common/errors/ApiException.html" title="class in org.apache.kafka.common.errors">ApiException</a></pre>
+<div class="block">This fatal exception indicates that another producer with the same <code>transactional.id</code> has been
+ started. It is only possible to have one producer instance with a <code>transactional.id</code> at any
+ given time, and the latest one to be started "fences" the previous instances so that they can no longer
+ make transactional requests. When you encounter this exception, you must close the producer instance.</div>
 <dl><dt><span class="strong">See Also:</span></dt><dd><a href="../../../../../serialized-form.html#org.apache.kafka.common.errors.ProducerFencedException">Serialized Form</a></dd></dl>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/RebalanceInProgressException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/RebalanceInProgressException.html b/0110/javadoc/org/apache/kafka/common/errors/RebalanceInProgressException.html
index 1c44015..577a4bf 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/RebalanceInProgressException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/RebalanceInProgressException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>RebalanceInProgressException (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:58 BST 2017 -->
+<title>RebalanceInProgressException (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="RebalanceInProgressException (kafka 0.11.0.0 API)";
+        parent.document.title="RebalanceInProgressException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/RecordBatchTooLargeException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/RecordBatchTooLargeException.html b/0110/javadoc/org/apache/kafka/common/errors/RecordBatchTooLargeException.html
index 1c8bda1..eddd2db 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/RecordBatchTooLargeException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/RecordBatchTooLargeException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>RecordBatchTooLargeException (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:58 BST 2017 -->
+<title>RecordBatchTooLargeException (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="RecordBatchTooLargeException (kafka 0.11.0.0 API)";
+        parent.document.title="RecordBatchTooLargeException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/RecordTooLargeException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/RecordTooLargeException.html b/0110/javadoc/org/apache/kafka/common/errors/RecordTooLargeException.html
index 2d7b979..511c3cd 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/RecordTooLargeException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/RecordTooLargeException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>RecordTooLargeException (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:58 BST 2017 -->
+<title>RecordTooLargeException (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="RecordTooLargeException (kafka 0.11.0.0 API)";
+        parent.document.title="RecordTooLargeException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/ReplicaNotAvailableException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/ReplicaNotAvailableException.html b/0110/javadoc/org/apache/kafka/common/errors/ReplicaNotAvailableException.html
index ea3cee8..6117af4 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/ReplicaNotAvailableException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/ReplicaNotAvailableException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ReplicaNotAvailableException (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:58 BST 2017 -->
+<title>ReplicaNotAvailableException (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="ReplicaNotAvailableException (kafka 0.11.0.0 API)";
+        parent.document.title="ReplicaNotAvailableException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/RetriableException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/RetriableException.html b/0110/javadoc/org/apache/kafka/common/errors/RetriableException.html
index e5dfdec..257aa06 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/RetriableException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/RetriableException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>RetriableException (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:58 BST 2017 -->
+<title>RetriableException (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="RetriableException (kafka 0.11.0.0 API)";
+        parent.document.title="RetriableException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/SecurityDisabledException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/SecurityDisabledException.html b/0110/javadoc/org/apache/kafka/common/errors/SecurityDisabledException.html
index c55484f..051d00b 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/SecurityDisabledException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/SecurityDisabledException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>SecurityDisabledException (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:58 BST 2017 -->
+<title>SecurityDisabledException (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="SecurityDisabledException (kafka 0.11.0.0 API)";
+        parent.document.title="SecurityDisabledException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/SerializationException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/SerializationException.html b/0110/javadoc/org/apache/kafka/common/errors/SerializationException.html
index c449bbc..894a4f4 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/SerializationException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/SerializationException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>SerializationException (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:58 BST 2017 -->
+<title>SerializationException (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="SerializationException (kafka 0.11.0.0 API)";
+        parent.document.title="SerializationException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/TimeoutException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/TimeoutException.html b/0110/javadoc/org/apache/kafka/common/errors/TimeoutException.html
index e6e1218..c897712 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/TimeoutException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/TimeoutException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>TimeoutException (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:58 BST 2017 -->
+<title>TimeoutException (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="TimeoutException (kafka 0.11.0.0 API)";
+        parent.document.title="TimeoutException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/TopicAuthorizationException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/TopicAuthorizationException.html b/0110/javadoc/org/apache/kafka/common/errors/TopicAuthorizationException.html
index 880c913..8f58d13 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/TopicAuthorizationException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/TopicAuthorizationException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>TopicAuthorizationException (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:58 BST 2017 -->
+<title>TopicAuthorizationException (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="TopicAuthorizationException (kafka 0.11.0.0 API)";
+        parent.document.title="TopicAuthorizationException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/TopicExistsException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/TopicExistsException.html b/0110/javadoc/org/apache/kafka/common/errors/TopicExistsException.html
index c9e48e3..b7cd91f 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/TopicExistsException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/TopicExistsException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>TopicExistsException (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:58 BST 2017 -->
+<title>TopicExistsException (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="TopicExistsException (kafka 0.11.0.0 API)";
+        parent.document.title="TopicExistsException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/TransactionCoordinatorFencedException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/TransactionCoordinatorFencedException.html b/0110/javadoc/org/apache/kafka/common/errors/TransactionCoordinatorFencedException.html
index 51cfe46..2baec7f 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/TransactionCoordinatorFencedException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/TransactionCoordinatorFencedException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>TransactionCoordinatorFencedException (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:58 BST 2017 -->
+<title>TransactionCoordinatorFencedException (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="TransactionCoordinatorFencedException (kafka 0.11.0.0 API)";
+        parent.document.title="TransactionCoordinatorFencedException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/TransactionalIdAuthorizationException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/TransactionalIdAuthorizationException.html b/0110/javadoc/org/apache/kafka/common/errors/TransactionalIdAuthorizationException.html
index defb3a5..c8a1c63 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/TransactionalIdAuthorizationException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/TransactionalIdAuthorizationException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>TransactionalIdAuthorizationException (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:58 BST 2017 -->
+<title>TransactionalIdAuthorizationException (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="TransactionalIdAuthorizationException (kafka 0.11.0.0 API)";
+        parent.document.title="TransactionalIdAuthorizationException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/UnknownMemberIdException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/UnknownMemberIdException.html b/0110/javadoc/org/apache/kafka/common/errors/UnknownMemberIdException.html
index e8b5b16..d4e5cad 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/UnknownMemberIdException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/UnknownMemberIdException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>UnknownMemberIdException (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:58 BST 2017 -->
+<title>UnknownMemberIdException (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="UnknownMemberIdException (kafka 0.11.0.0 API)";
+        parent.document.title="UnknownMemberIdException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/UnknownServerException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/UnknownServerException.html b/0110/javadoc/org/apache/kafka/common/errors/UnknownServerException.html
index b69058f..24f70fa 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/UnknownServerException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/UnknownServerException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>UnknownServerException (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:58 BST 2017 -->
+<title>UnknownServerException (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="UnknownServerException (kafka 0.11.0.0 API)";
+        parent.document.title="UnknownServerException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>


[10/10] kafka-site git commit: merge trunk

Posted by da...@apache.org.
merge trunk


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

Branch: refs/heads/asf-site
Commit: 0675525230f68c8657322d450ac400d569b7e550
Parents: a1278d0 8c85a0e
Author: Damian Guy <da...@gmail.com>
Authored: Wed Sep 13 13:23:42 2017 +0100
Committer: Damian Guy <da...@gmail.com>
Committed: Wed Sep 13 13:23:42 2017 +0100

----------------------------------------------------------------------
 0102/upgrade.html                       |   1 -
 0110/toc.html                           |   2 +-
 KEYS                                    |  57 ++++++
 coding-guide.html                       |  41 ++++
 committers.html                         |   4 +-
 css/styles.css                          | 291 +++++++++++++++++++++++++--
 documentation/streams/introduction.html |   2 -
 documentation/streams/quickstart.html   |   2 +
 downloads.html                          |  60 ++++++
 images/icons/check.png                  | Bin 0 -> 642 bytes
 images/icons/slash--white.png           | Bin 0 -> 469 bytes
 images/icons/slash.png                  | Bin 0 -> 457 bytes
 images/powered-by/CJ_Affiliate.png      | Bin 0 -> 131412 bytes
 images/powered-by/porto-seguro.png      | Bin 0 -> 35125 bytes
 images/powered-by/robotCircle.png       | Bin 0 -> 67349 bytes
 includes/_nav.htm                       |   4 +-
 index.html                              |  15 +-
 powered-by.html                         |  15 ++
 18 files changed, 466 insertions(+), 28 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/kafka-site/blob/06755252/0110/toc.html
----------------------------------------------------------------------
diff --cc 0110/toc.html
index e7d939e,0f6fad0..5704768
--- a/0110/toc.html
+++ b/0110/toc.html
@@@ -141,14 -140,13 +141,14 @@@
                  <li><a href="#connect_development">8.3 Connector Development Guide</a></li>
              </ul>
          </li>
-         <li><a href="/{{version}}/documentation/streams">9. Kafka Streams</a>
+         <li><a href="/documentation/streams">9. Kafka Streams</a>
              <ul>
 -                <li><a href="/documentation/streams/quickstart">9.1 Play with a Streams Application</a></li>
 -                <li><a href="/documentation/streams/developer-guide">9.2 Developer Manual</a></li>
 -                <li><a href="/documentation/streams/core-concepts">9.3 Core Concepts</a></li>
 -                <li><a href="/documentation/streams/architecture">9.4 Architecture</a></li>
 -                <li><a href="/documentation/streams/upgrade-guide">9.5 Upgrade Guide</a></li>
 +                <li><a href="/{{version}}/documentation/streams/quickstart">9.1 Play with a Streams Application</a></li>
 +                <li><a href="/{{version}}/documentation/streams/tutorial">9.2 Write your own Streams Applications</a></li>
 +                <li><a href="/{{version}}/documentation/streams/developer-guide">9.3 Developer Manual</a></li>
 +                <li><a href="/{{version}}/documentation/streams/core-concepts">9.4 Core Concepts</a></li>
 +                <li><a href="/{{version}}/documentation/streams/architecture">9.5 Architecture</a></li>
 +                <li><a href="/{{version}}/documentation/streams/upgrade-guide">9.6 Upgrade Guide</a></li>
              </ul>
          </li>
      </ul>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/06755252/downloads.html
----------------------------------------------------------------------


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

Posted by da...@apache.org.
http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/UnknownTopicOrPartitionException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/UnknownTopicOrPartitionException.html b/0110/javadoc/org/apache/kafka/common/errors/UnknownTopicOrPartitionException.html
index 89cbd03..50e67ba 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/UnknownTopicOrPartitionException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/UnknownTopicOrPartitionException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>UnknownTopicOrPartitionException (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:58 BST 2017 -->
+<title>UnknownTopicOrPartitionException (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="UnknownTopicOrPartitionException (kafka 0.11.0.0 API)";
+        parent.document.title="UnknownTopicOrPartitionException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/UnsupportedForMessageFormatException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/UnsupportedForMessageFormatException.html b/0110/javadoc/org/apache/kafka/common/errors/UnsupportedForMessageFormatException.html
index 5b2d1e6..bf7cb27 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/UnsupportedForMessageFormatException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/UnsupportedForMessageFormatException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>UnsupportedForMessageFormatException (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:58 BST 2017 -->
+<title>UnsupportedForMessageFormatException (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="UnsupportedForMessageFormatException (kafka 0.11.0.0 API)";
+        parent.document.title="UnsupportedForMessageFormatException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -126,7 +126,8 @@
 <br>
 <pre>public class <span class="strong">UnsupportedForMessageFormatException</span>
 extends <a href="../../../../../org/apache/kafka/common/errors/ApiException.html" title="class in org.apache.kafka.common.errors">ApiException</a></pre>
-<div class="block">The message format version does not support the requested function.</div>
+<div class="block">The message format version does not support the requested function. For example, if idempotence is
+ requested and the topic is using a message format older than 0.11.0.0, then this error will be returned.</div>
 <dl><dt><span class="strong">See Also:</span></dt><dd><a href="../../../../../serialized-form.html#org.apache.kafka.common.errors.UnsupportedForMessageFormatException">Serialized Form</a></dd></dl>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/UnsupportedSaslMechanismException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/UnsupportedSaslMechanismException.html b/0110/javadoc/org/apache/kafka/common/errors/UnsupportedSaslMechanismException.html
index aa6dab0..1446b1f 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/UnsupportedSaslMechanismException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/UnsupportedSaslMechanismException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>UnsupportedSaslMechanismException (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:58 BST 2017 -->
+<title>UnsupportedSaslMechanismException (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="UnsupportedSaslMechanismException (kafka 0.11.0.0 API)";
+        parent.document.title="UnsupportedSaslMechanismException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/UnsupportedVersionException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/UnsupportedVersionException.html b/0110/javadoc/org/apache/kafka/common/errors/UnsupportedVersionException.html
index f75335f..9c4e50b 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/UnsupportedVersionException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/UnsupportedVersionException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>UnsupportedVersionException (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:58 BST 2017 -->
+<title>UnsupportedVersionException (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="UnsupportedVersionException (kafka 0.11.0.0 API)";
+        parent.document.title="UnsupportedVersionException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -126,6 +126,14 @@
 <br>
 <pre>public class <span class="strong">UnsupportedVersionException</span>
 extends <a href="../../../../../org/apache/kafka/common/errors/ApiException.html" title="class in org.apache.kafka.common.errors">ApiException</a></pre>
+<div class="block">Indicates that a request API or version needed by the client is not supported by the broker. This is
+ typically a fatal error as Kafka clients will downgrade request versions as needed except in cases where
+ a needed feature is not available in old versions. Fatal errors can generally only be handled by closing
+ the client instance, although in some cases it may be possible to continue without relying on the
+ underlying feature. For example, when the producer is used with idempotence enabled, this error is fatal
+ since the producer does not support reverting to weaker semantics. On the other hand, if this error
+ is raised from <a href="../../../../../org/apache/kafka/clients/consumer/KafkaConsumer.html#offsetsForTimes(java.util.Map)"><code>KafkaConsumer.offsetsForTimes(Map)</code></a>, it would
+ be possible to revert to alternative logic to set the consumer's position.</div>
 <dl><dt><span class="strong">See Also:</span></dt><dd><a href="../../../../../serialized-form.html#org.apache.kafka.common.errors.UnsupportedVersionException">Serialized Form</a></dd></dl>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/WakeupException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/WakeupException.html b/0110/javadoc/org/apache/kafka/common/errors/WakeupException.html
index 9035bcf..a685716 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/WakeupException.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/WakeupException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>WakeupException (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:58 BST 2017 -->
+<title>WakeupException (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="WakeupException (kafka 0.11.0.0 API)";
+        parent.document.title="WakeupException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/package-frame.html b/0110/javadoc/org/apache/kafka/common/errors/package-frame.html
index 1967652..752b44f 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/package-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>org.apache.kafka.common.errors (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>org.apache.kafka.common.errors (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/org/apache/kafka/common/errors/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/package-summary.html b/0110/javadoc/org/apache/kafka/common/errors/package-summary.html
index 9ecd26f..5db137d 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/package-summary.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>org.apache.kafka.common.errors (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>org.apache.kafka.common.errors (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="org.apache.kafka.common.errors (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.errors (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -322,7 +322,10 @@
 </tr>
 <tr class="rowColor">
 <td class="colFirst"><a href="../../../../../org/apache/kafka/common/errors/OutOfOrderSequenceException.html" title="class in org.apache.kafka.common.errors">OutOfOrderSequenceException</a></td>
-<td class="colLast">&nbsp;</td>
+<td class="colLast">
+<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>
+</td>
 </tr>
 <tr class="altColor">
 <td class="colFirst"><a href="../../../../../org/apache/kafka/common/errors/PolicyViolationException.html" title="class in org.apache.kafka.common.errors">PolicyViolationException</a></td>
@@ -332,7 +335,10 @@
 </tr>
 <tr class="rowColor">
 <td class="colFirst"><a href="../../../../../org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors">ProducerFencedException</a></td>
-<td class="colLast">&nbsp;</td>
+<td class="colLast">
+<div class="block">This fatal exception indicates that another producer with the same <code>transactional.id</code> has been
+ started.</div>
+</td>
 </tr>
 <tr class="altColor">
 <td class="colFirst"><a href="../../../../../org/apache/kafka/common/errors/RebalanceInProgressException.html" title="class in org.apache.kafka.common.errors">RebalanceInProgressException</a></td>
@@ -422,7 +428,9 @@
 </tr>
 <tr class="rowColor">
 <td class="colFirst"><a href="../../../../../org/apache/kafka/common/errors/UnsupportedVersionException.html" title="class in org.apache.kafka.common.errors">UnsupportedVersionException</a></td>
-<td class="colLast">&nbsp;</td>
+<td class="colLast">
+<div class="block">Indicates that a request API or version needed by the client is not supported by the broker.</div>
+</td>
 </tr>
 <tr class="altColor">
 <td class="colFirst"><a href="../../../../../org/apache/kafka/common/errors/WakeupException.html" title="class in org.apache.kafka.common.errors">WakeupException</a></td>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/errors/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/errors/package-tree.html b/0110/javadoc/org/apache/kafka/common/errors/package-tree.html
index e5643e1..1c6d9e3 100644
--- a/0110/javadoc/org/apache/kafka/common/errors/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/common/errors/package-tree.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>org.apache.kafka.common.errors Class Hierarchy (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>org.apache.kafka.common.errors Class Hierarchy (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="org.apache.kafka.common.errors Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.errors Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/header/Header.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/header/Header.html b/0110/javadoc/org/apache/kafka/common/header/Header.html
index b4522e1..b14c895 100644
--- a/0110/javadoc/org/apache/kafka/common/header/Header.html
+++ b/0110/javadoc/org/apache/kafka/common/header/Header.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>Header (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:56 BST 2017 -->
+<title>Header (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="Header (kafka 0.11.0.0 API)";
+        parent.document.title="Header (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/header/Headers.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/header/Headers.html b/0110/javadoc/org/apache/kafka/common/header/Headers.html
index e9d23bd..f8da686 100644
--- a/0110/javadoc/org/apache/kafka/common/header/Headers.html
+++ b/0110/javadoc/org/apache/kafka/common/header/Headers.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>Headers (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:56 BST 2017 -->
+<title>Headers (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="Headers (kafka 0.11.0.0 API)";
+        parent.document.title="Headers (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/header/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/header/package-frame.html b/0110/javadoc/org/apache/kafka/common/header/package-frame.html
index 1482675..376ec55 100644
--- a/0110/javadoc/org/apache/kafka/common/header/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/common/header/package-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>org.apache.kafka.common.header (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>org.apache.kafka.common.header (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/org/apache/kafka/common/header/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/header/package-summary.html b/0110/javadoc/org/apache/kafka/common/header/package-summary.html
index a0f1244..7346e6e 100644
--- a/0110/javadoc/org/apache/kafka/common/header/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/common/header/package-summary.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>org.apache.kafka.common.header (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>org.apache.kafka.common.header (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="org.apache.kafka.common.header (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.header (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/header/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/header/package-tree.html b/0110/javadoc/org/apache/kafka/common/header/package-tree.html
index 589441a..c09a345 100644
--- a/0110/javadoc/org/apache/kafka/common/header/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/common/header/package-tree.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>org.apache.kafka.common.header Class Hierarchy (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>org.apache.kafka.common.header Class Hierarchy (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="org.apache.kafka.common.header Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.header Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/package-frame.html b/0110/javadoc/org/apache/kafka/common/package-frame.html
index 1ca398d..4bacf8a 100644
--- a/0110/javadoc/org/apache/kafka/common/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/common/package-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>org.apache.kafka.common (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>org.apache.kafka.common (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/org/apache/kafka/common/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/package-summary.html b/0110/javadoc/org/apache/kafka/common/package-summary.html
index 28f98f4..a95cb4d 100644
--- a/0110/javadoc/org/apache/kafka/common/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/common/package-summary.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>org.apache.kafka.common (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>org.apache.kafka.common (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="org.apache.kafka.common (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/package-tree.html b/0110/javadoc/org/apache/kafka/common/package-tree.html
index de1a465..764a997 100644
--- a/0110/javadoc/org/apache/kafka/common/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/common/package-tree.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>org.apache.kafka.common Class Hierarchy (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>org.apache.kafka.common Class Hierarchy (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="org.apache.kafka.common Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/resource/Resource.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/resource/Resource.html b/0110/javadoc/org/apache/kafka/common/resource/Resource.html
index a6b5232..06f7a59 100644
--- a/0110/javadoc/org/apache/kafka/common/resource/Resource.html
+++ b/0110/javadoc/org/apache/kafka/common/resource/Resource.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>Resource (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:55 BST 2017 -->
+<title>Resource (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="Resource (kafka 0.11.0.0 API)";
+        parent.document.title="Resource (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/resource/ResourceFilter.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/resource/ResourceFilter.html b/0110/javadoc/org/apache/kafka/common/resource/ResourceFilter.html
index 207d0b7..d037623 100644
--- a/0110/javadoc/org/apache/kafka/common/resource/ResourceFilter.html
+++ b/0110/javadoc/org/apache/kafka/common/resource/ResourceFilter.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>ResourceFilter (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:55 BST 2017 -->
+<title>ResourceFilter (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="ResourceFilter (kafka 0.11.0.0 API)";
+        parent.document.title="ResourceFilter (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/resource/ResourceType.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/resource/ResourceType.html b/0110/javadoc/org/apache/kafka/common/resource/ResourceType.html
index 3f77204..e3038c4 100644
--- a/0110/javadoc/org/apache/kafka/common/resource/ResourceType.html
+++ b/0110/javadoc/org/apache/kafka/common/resource/ResourceType.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>ResourceType (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:55 BST 2017 -->
+<title>ResourceType (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="ResourceType (kafka 0.11.0.0 API)";
+        parent.document.title="ResourceType (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/resource/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/resource/package-frame.html b/0110/javadoc/org/apache/kafka/common/resource/package-frame.html
index 813fa2d..e4e2225 100644
--- a/0110/javadoc/org/apache/kafka/common/resource/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/common/resource/package-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>org.apache.kafka.common.resource (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>org.apache.kafka.common.resource (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/org/apache/kafka/common/resource/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/resource/package-summary.html b/0110/javadoc/org/apache/kafka/common/resource/package-summary.html
index 0b07ed3..6ca720d 100644
--- a/0110/javadoc/org/apache/kafka/common/resource/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/common/resource/package-summary.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>org.apache.kafka.common.resource (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>org.apache.kafka.common.resource (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="org.apache.kafka.common.resource (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.resource (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/resource/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/resource/package-tree.html b/0110/javadoc/org/apache/kafka/common/resource/package-tree.html
index 293445d..5dd578a 100644
--- a/0110/javadoc/org/apache/kafka/common/resource/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/common/resource/package-tree.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>org.apache.kafka.common.resource Class Hierarchy (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>org.apache.kafka.common.resource Class Hierarchy (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="org.apache.kafka.common.resource Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.resource Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/ByteArrayDeserializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/ByteArrayDeserializer.html b/0110/javadoc/org/apache/kafka/common/serialization/ByteArrayDeserializer.html
index 22e67b8..eca210f 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/ByteArrayDeserializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/ByteArrayDeserializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ByteArrayDeserializer (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:58 BST 2017 -->
+<title>ByteArrayDeserializer (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="ByteArrayDeserializer (kafka 0.11.0.0 API)";
+        parent.document.title="ByteArrayDeserializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/ByteArraySerializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/ByteArraySerializer.html b/0110/javadoc/org/apache/kafka/common/serialization/ByteArraySerializer.html
index a86cddf..df07933 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/ByteArraySerializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/ByteArraySerializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ByteArraySerializer (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:58 BST 2017 -->
+<title>ByteArraySerializer (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="ByteArraySerializer (kafka 0.11.0.0 API)";
+        parent.document.title="ByteArraySerializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/ByteBufferDeserializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/ByteBufferDeserializer.html b/0110/javadoc/org/apache/kafka/common/serialization/ByteBufferDeserializer.html
index 7666290..c3039a2 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/ByteBufferDeserializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/ByteBufferDeserializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ByteBufferDeserializer (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:58 BST 2017 -->
+<title>ByteBufferDeserializer (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="ByteBufferDeserializer (kafka 0.11.0.0 API)";
+        parent.document.title="ByteBufferDeserializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/ByteBufferSerializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/ByteBufferSerializer.html b/0110/javadoc/org/apache/kafka/common/serialization/ByteBufferSerializer.html
index b1bda3e..794cf5a 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/ByteBufferSerializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/ByteBufferSerializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ByteBufferSerializer (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:58 BST 2017 -->
+<title>ByteBufferSerializer (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="ByteBufferSerializer (kafka 0.11.0.0 API)";
+        parent.document.title="ByteBufferSerializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/BytesDeserializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/BytesDeserializer.html b/0110/javadoc/org/apache/kafka/common/serialization/BytesDeserializer.html
index b363478..0c60710 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/BytesDeserializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/BytesDeserializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>BytesDeserializer (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:58 BST 2017 -->
+<title>BytesDeserializer (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="BytesDeserializer (kafka 0.11.0.0 API)";
+        parent.document.title="BytesDeserializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/BytesSerializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/BytesSerializer.html b/0110/javadoc/org/apache/kafka/common/serialization/BytesSerializer.html
index d9b9d6a..e7d3cdd 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/BytesSerializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/BytesSerializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>BytesSerializer (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:58 BST 2017 -->
+<title>BytesSerializer (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="BytesSerializer (kafka 0.11.0.0 API)";
+        parent.document.title="BytesSerializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Deserializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Deserializer.html b/0110/javadoc/org/apache/kafka/common/serialization/Deserializer.html
index 0e7e767..3f22219 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Deserializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Deserializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Deserializer (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:58 BST 2017 -->
+<title>Deserializer (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="Deserializer (kafka 0.11.0.0 API)";
+        parent.document.title="Deserializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/DoubleDeserializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/DoubleDeserializer.html b/0110/javadoc/org/apache/kafka/common/serialization/DoubleDeserializer.html
index f17890b..7dfb89b 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/DoubleDeserializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/DoubleDeserializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>DoubleDeserializer (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:58 BST 2017 -->
+<title>DoubleDeserializer (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="DoubleDeserializer (kafka 0.11.0.0 API)";
+        parent.document.title="DoubleDeserializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/DoubleSerializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/DoubleSerializer.html b/0110/javadoc/org/apache/kafka/common/serialization/DoubleSerializer.html
index 864189b..652c70b 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/DoubleSerializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/DoubleSerializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>DoubleSerializer (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:58 BST 2017 -->
+<title>DoubleSerializer (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="DoubleSerializer (kafka 0.11.0.0 API)";
+        parent.document.title="DoubleSerializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/ExtendedDeserializer.Wrapper.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/ExtendedDeserializer.Wrapper.html b/0110/javadoc/org/apache/kafka/common/serialization/ExtendedDeserializer.Wrapper.html
index 83c0355..10c3865 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/ExtendedDeserializer.Wrapper.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/ExtendedDeserializer.Wrapper.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ExtendedDeserializer.Wrapper (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:58 BST 2017 -->
+<title>ExtendedDeserializer.Wrapper (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="ExtendedDeserializer.Wrapper (kafka 0.11.0.0 API)";
+        parent.document.title="ExtendedDeserializer.Wrapper (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/ExtendedDeserializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/ExtendedDeserializer.html b/0110/javadoc/org/apache/kafka/common/serialization/ExtendedDeserializer.html
index 89ece08..54a5690 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/ExtendedDeserializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/ExtendedDeserializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ExtendedDeserializer (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:58 BST 2017 -->
+<title>ExtendedDeserializer (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="ExtendedDeserializer (kafka 0.11.0.0 API)";
+        parent.document.title="ExtendedDeserializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/ExtendedSerializer.Wrapper.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/ExtendedSerializer.Wrapper.html b/0110/javadoc/org/apache/kafka/common/serialization/ExtendedSerializer.Wrapper.html
index 35305e6..551fa3f 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/ExtendedSerializer.Wrapper.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/ExtendedSerializer.Wrapper.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ExtendedSerializer.Wrapper (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:58 BST 2017 -->
+<title>ExtendedSerializer.Wrapper (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="ExtendedSerializer.Wrapper (kafka 0.11.0.0 API)";
+        parent.document.title="ExtendedSerializer.Wrapper (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/ExtendedSerializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/ExtendedSerializer.html b/0110/javadoc/org/apache/kafka/common/serialization/ExtendedSerializer.html
index 79065cb..b9f249b 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/ExtendedSerializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/ExtendedSerializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ExtendedSerializer (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:58 BST 2017 -->
+<title>ExtendedSerializer (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="ExtendedSerializer (kafka 0.11.0.0 API)";
+        parent.document.title="ExtendedSerializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/FloatDeserializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/FloatDeserializer.html b/0110/javadoc/org/apache/kafka/common/serialization/FloatDeserializer.html
index 683a7ec..268e932 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/FloatDeserializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/FloatDeserializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>FloatDeserializer (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:58 BST 2017 -->
+<title>FloatDeserializer (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="FloatDeserializer (kafka 0.11.0.0 API)";
+        parent.document.title="FloatDeserializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/FloatSerializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/FloatSerializer.html b/0110/javadoc/org/apache/kafka/common/serialization/FloatSerializer.html
index c0e47c4..5e659e6 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/FloatSerializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/FloatSerializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>FloatSerializer (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:58 BST 2017 -->
+<title>FloatSerializer (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="FloatSerializer (kafka 0.11.0.0 API)";
+        parent.document.title="FloatSerializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/IntegerDeserializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/IntegerDeserializer.html b/0110/javadoc/org/apache/kafka/common/serialization/IntegerDeserializer.html
index ce9a1e8..ee95d65 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/IntegerDeserializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/IntegerDeserializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>IntegerDeserializer (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:58 BST 2017 -->
+<title>IntegerDeserializer (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="IntegerDeserializer (kafka 0.11.0.0 API)";
+        parent.document.title="IntegerDeserializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/IntegerSerializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/IntegerSerializer.html b/0110/javadoc/org/apache/kafka/common/serialization/IntegerSerializer.html
index 4115c23..38feb1d 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/IntegerSerializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/IntegerSerializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>IntegerSerializer (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:58 BST 2017 -->
+<title>IntegerSerializer (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="IntegerSerializer (kafka 0.11.0.0 API)";
+        parent.document.title="IntegerSerializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/LongDeserializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/LongDeserializer.html b/0110/javadoc/org/apache/kafka/common/serialization/LongDeserializer.html
index e0228c5..240ceb6 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/LongDeserializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/LongDeserializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>LongDeserializer (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:58 BST 2017 -->
+<title>LongDeserializer (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="LongDeserializer (kafka 0.11.0.0 API)";
+        parent.document.title="LongDeserializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/LongSerializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/LongSerializer.html b/0110/javadoc/org/apache/kafka/common/serialization/LongSerializer.html
index 3b073ae..97c4612 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/LongSerializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/LongSerializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>LongSerializer (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:58 BST 2017 -->
+<title>LongSerializer (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="LongSerializer (kafka 0.11.0.0 API)";
+        parent.document.title="LongSerializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serde.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serde.html b/0110/javadoc/org/apache/kafka/common/serialization/Serde.html
index 312dc74..8554473 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serde.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serde.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serde (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:58 BST 2017 -->
+<title>Serde (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="Serde (kafka 0.11.0.0 API)";
+        parent.document.title="Serde (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ByteArraySerde.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ByteArraySerde.html b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ByteArraySerde.html
index e3f0ac3..229cade 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ByteArraySerde.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ByteArraySerde.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serdes.ByteArraySerde (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:58 BST 2017 -->
+<title>Serdes.ByteArraySerde (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="Serdes.ByteArraySerde (kafka 0.11.0.0 API)";
+        parent.document.title="Serdes.ByteArraySerde (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ByteBufferSerde.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ByteBufferSerde.html b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ByteBufferSerde.html
index 45aebae..9be8b80 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ByteBufferSerde.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ByteBufferSerde.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serdes.ByteBufferSerde (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:58 BST 2017 -->
+<title>Serdes.ByteBufferSerde (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="Serdes.ByteBufferSerde (kafka 0.11.0.0 API)";
+        parent.document.title="Serdes.ByteBufferSerde (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serdes.BytesSerde.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.BytesSerde.html b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.BytesSerde.html
index 9726fbf..ba49e87 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.BytesSerde.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.BytesSerde.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serdes.BytesSerde (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:58 BST 2017 -->
+<title>Serdes.BytesSerde (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="Serdes.BytesSerde (kafka 0.11.0.0 API)";
+        parent.document.title="Serdes.BytesSerde (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serdes.DoubleSerde.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.DoubleSerde.html b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.DoubleSerde.html
index 998e8f6..8fc16a6 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.DoubleSerde.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.DoubleSerde.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serdes.DoubleSerde (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:58 BST 2017 -->
+<title>Serdes.DoubleSerde (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="Serdes.DoubleSerde (kafka 0.11.0.0 API)";
+        parent.document.title="Serdes.DoubleSerde (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serdes.FloatSerde.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.FloatSerde.html b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.FloatSerde.html
index dceb455..52cdb53 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.FloatSerde.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.FloatSerde.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serdes.FloatSerde (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:58 BST 2017 -->
+<title>Serdes.FloatSerde (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="Serdes.FloatSerde (kafka 0.11.0.0 API)";
+        parent.document.title="Serdes.FloatSerde (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serdes.IntegerSerde.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.IntegerSerde.html b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.IntegerSerde.html
index 0345579..f45b2a5 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.IntegerSerde.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.IntegerSerde.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serdes.IntegerSerde (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:58 BST 2017 -->
+<title>Serdes.IntegerSerde (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="Serdes.IntegerSerde (kafka 0.11.0.0 API)";
+        parent.document.title="Serdes.IntegerSerde (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serdes.LongSerde.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.LongSerde.html b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.LongSerde.html
index 585b791..c1cba39 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.LongSerde.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.LongSerde.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serdes.LongSerde (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:58 BST 2017 -->
+<title>Serdes.LongSerde (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="Serdes.LongSerde (kafka 0.11.0.0 API)";
+        parent.document.title="Serdes.LongSerde (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ShortSerde.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ShortSerde.html b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ShortSerde.html
index b1f0af9..abb5691 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ShortSerde.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.ShortSerde.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serdes.ShortSerde (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:58 BST 2017 -->
+<title>Serdes.ShortSerde (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="Serdes.ShortSerde (kafka 0.11.0.0 API)";
+        parent.document.title="Serdes.ShortSerde (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serdes.StringSerde.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.StringSerde.html b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.StringSerde.html
index 9c8faf5..0654036 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.StringSerde.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.StringSerde.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serdes.StringSerde (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:58 BST 2017 -->
+<title>Serdes.StringSerde (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="Serdes.StringSerde (kafka 0.11.0.0 API)";
+        parent.document.title="Serdes.StringSerde (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serdes.WrapperSerde.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.WrapperSerde.html b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.WrapperSerde.html
index 49f4610..3f4a13a 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.WrapperSerde.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.WrapperSerde.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serdes.WrapperSerde (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:58 BST 2017 -->
+<title>Serdes.WrapperSerde (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="Serdes.WrapperSerde (kafka 0.11.0.0 API)";
+        parent.document.title="Serdes.WrapperSerde (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serdes.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.html b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.html
index 16a9a7c..78470a0 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serdes.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serdes.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serdes (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:58 BST 2017 -->
+<title>Serdes (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="Serdes (kafka 0.11.0.0 API)";
+        parent.document.title="Serdes (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/Serializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/Serializer.html b/0110/javadoc/org/apache/kafka/common/serialization/Serializer.html
index 40db4d7..4f75e63 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/Serializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/Serializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Serializer (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:58 BST 2017 -->
+<title>Serializer (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="Serializer (kafka 0.11.0.0 API)";
+        parent.document.title="Serializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/ShortDeserializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/ShortDeserializer.html b/0110/javadoc/org/apache/kafka/common/serialization/ShortDeserializer.html
index 8c09431..42e937f 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/ShortDeserializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/ShortDeserializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ShortDeserializer (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:58 BST 2017 -->
+<title>ShortDeserializer (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="ShortDeserializer (kafka 0.11.0.0 API)";
+        parent.document.title="ShortDeserializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/ShortSerializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/ShortSerializer.html b/0110/javadoc/org/apache/kafka/common/serialization/ShortSerializer.html
index 0905616..221e8e5 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/ShortSerializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/ShortSerializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ShortSerializer (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:58 BST 2017 -->
+<title>ShortSerializer (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="ShortSerializer (kafka 0.11.0.0 API)";
+        parent.document.title="ShortSerializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/StringDeserializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/StringDeserializer.html b/0110/javadoc/org/apache/kafka/common/serialization/StringDeserializer.html
index 03bd032..5ff23e5 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/StringDeserializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/StringDeserializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>StringDeserializer (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:58 BST 2017 -->
+<title>StringDeserializer (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="StringDeserializer (kafka 0.11.0.0 API)";
+        parent.document.title="StringDeserializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/StringSerializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/StringSerializer.html b/0110/javadoc/org/apache/kafka/common/serialization/StringSerializer.html
index d78e791..3d6ee61 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/StringSerializer.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/StringSerializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>StringSerializer (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:58 BST 2017 -->
+<title>StringSerializer (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="StringSerializer (kafka 0.11.0.0 API)";
+        parent.document.title="StringSerializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/package-frame.html b/0110/javadoc/org/apache/kafka/common/serialization/package-frame.html
index 1132034..6c92401 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/package-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>org.apache.kafka.common.serialization (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>org.apache.kafka.common.serialization (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/org/apache/kafka/common/serialization/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/package-summary.html b/0110/javadoc/org/apache/kafka/common/serialization/package-summary.html
index 870f58e..3a0bd2e 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/package-summary.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>org.apache.kafka.common.serialization (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>org.apache.kafka.common.serialization (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="org.apache.kafka.common.serialization (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.serialization (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/common/serialization/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/common/serialization/package-tree.html b/0110/javadoc/org/apache/kafka/common/serialization/package-tree.html
index 1d24cc0..3443a6e 100644
--- a/0110/javadoc/org/apache/kafka/common/serialization/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/common/serialization/package-tree.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>org.apache.kafka.common.serialization Class Hierarchy (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>org.apache.kafka.common.serialization Class Hierarchy (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="org.apache.kafka.common.serialization Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.common.serialization Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/connector/ConnectRecord.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/connector/ConnectRecord.html b/0110/javadoc/org/apache/kafka/connect/connector/ConnectRecord.html
index 7aa9cbe..f13c585 100644
--- a/0110/javadoc/org/apache/kafka/connect/connector/ConnectRecord.html
+++ b/0110/javadoc/org/apache/kafka/connect/connector/ConnectRecord.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>ConnectRecord (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:56 BST 2017 -->
+<title>ConnectRecord (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="ConnectRecord (kafka 0.11.0.0 API)";
+        parent.document.title="ConnectRecord (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/connector/Connector.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/connector/Connector.html b/0110/javadoc/org/apache/kafka/connect/connector/Connector.html
index d66a8d5..8b65914 100644
--- a/0110/javadoc/org/apache/kafka/connect/connector/Connector.html
+++ b/0110/javadoc/org/apache/kafka/connect/connector/Connector.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>Connector (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:56 BST 2017 -->
+<title>Connector (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="Connector (kafka 0.11.0.0 API)";
+        parent.document.title="Connector (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/connector/ConnectorContext.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/connector/ConnectorContext.html b/0110/javadoc/org/apache/kafka/connect/connector/ConnectorContext.html
index cdf77ef..97f141a 100644
--- a/0110/javadoc/org/apache/kafka/connect/connector/ConnectorContext.html
+++ b/0110/javadoc/org/apache/kafka/connect/connector/ConnectorContext.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>ConnectorContext (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:56 BST 2017 -->
+<title>ConnectorContext (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="ConnectorContext (kafka 0.11.0.0 API)";
+        parent.document.title="ConnectorContext (kafka 0.11.0.1 API)";
     }
 //-->
 </script>


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

Posted by da...@apache.org.
http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/StateStoreSupplier.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/StateStoreSupplier.html b/0110/javadoc/org/apache/kafka/streams/processor/StateStoreSupplier.html
index 4a36a47..d304d3d 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/StateStoreSupplier.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/StateStoreSupplier.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>StateStoreSupplier (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:56 BST 2017 -->
+<title>StateStoreSupplier (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="StateStoreSupplier (kafka 0.11.0.0 API)";
+        parent.document.title="StateStoreSupplier (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/StreamPartitioner.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/StreamPartitioner.html b/0110/javadoc/org/apache/kafka/streams/processor/StreamPartitioner.html
index 36ebf1f..37d6ce3 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/StreamPartitioner.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/StreamPartitioner.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>StreamPartitioner (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:56 BST 2017 -->
+<title>StreamPartitioner (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="StreamPartitioner (kafka 0.11.0.0 API)";
+        parent.document.title="StreamPartitioner (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/TaskId.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/TaskId.html b/0110/javadoc/org/apache/kafka/streams/processor/TaskId.html
index 39ae72d..a84b68c 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/TaskId.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/TaskId.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>TaskId (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:56 BST 2017 -->
+<title>TaskId (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="TaskId (kafka 0.11.0.0 API)";
+        parent.document.title="TaskId (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/TimestampExtractor.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/TimestampExtractor.html b/0110/javadoc/org/apache/kafka/streams/processor/TimestampExtractor.html
index 85b8718..93b50c7 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/TimestampExtractor.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/TimestampExtractor.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>TimestampExtractor (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:56 BST 2017 -->
+<title>TimestampExtractor (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="TimestampExtractor (kafka 0.11.0.0 API)";
+        parent.document.title="TimestampExtractor (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.AutoOffsetReset.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.AutoOffsetReset.html b/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.AutoOffsetReset.html
index 1ea1dcb..9c8a434 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.AutoOffsetReset.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.AutoOffsetReset.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>TopologyBuilder.AutoOffsetReset (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:56 BST 2017 -->
+<title>TopologyBuilder.AutoOffsetReset (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="TopologyBuilder.AutoOffsetReset (kafka 0.11.0.0 API)";
+        parent.document.title="TopologyBuilder.AutoOffsetReset (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.TopicsInfo.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.TopicsInfo.html b/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.TopicsInfo.html
index 5fc6f8a..bb42605 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.TopicsInfo.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.TopicsInfo.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>TopologyBuilder.TopicsInfo (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:56 BST 2017 -->
+<title>TopologyBuilder.TopicsInfo (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="TopologyBuilder.TopicsInfo (kafka 0.11.0.0 API)";
+        parent.document.title="TopologyBuilder.TopicsInfo (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.html b/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.html
index 09d74ef..99d6af9 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/TopologyBuilder.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>TopologyBuilder (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:56 BST 2017 -->
+<title>TopologyBuilder (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="TopologyBuilder (kafka 0.11.0.0 API)";
+        parent.document.title="TopologyBuilder (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/UsePreviousTimeOnInvalidTimestamp.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/UsePreviousTimeOnInvalidTimestamp.html b/0110/javadoc/org/apache/kafka/streams/processor/UsePreviousTimeOnInvalidTimestamp.html
index 1461aef..011b3f9 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/UsePreviousTimeOnInvalidTimestamp.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/UsePreviousTimeOnInvalidTimestamp.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>UsePreviousTimeOnInvalidTimestamp (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:56 BST 2017 -->
+<title>UsePreviousTimeOnInvalidTimestamp (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="UsePreviousTimeOnInvalidTimestamp (kafka 0.11.0.0 API)";
+        parent.document.title="UsePreviousTimeOnInvalidTimestamp (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/WallclockTimestampExtractor.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/WallclockTimestampExtractor.html b/0110/javadoc/org/apache/kafka/streams/processor/WallclockTimestampExtractor.html
index 2baccb6..35f618c 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/WallclockTimestampExtractor.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/WallclockTimestampExtractor.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>WallclockTimestampExtractor (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:56 BST 2017 -->
+<title>WallclockTimestampExtractor (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="WallclockTimestampExtractor (kafka 0.11.0.0 API)";
+        parent.document.title="WallclockTimestampExtractor (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/package-frame.html b/0110/javadoc/org/apache/kafka/streams/processor/package-frame.html
index afa205d..b2b87b3 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/package-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>org.apache.kafka.streams.processor (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>org.apache.kafka.streams.processor (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/org/apache/kafka/streams/processor/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/package-summary.html b/0110/javadoc/org/apache/kafka/streams/processor/package-summary.html
index 759810f..08a087c 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/package-summary.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>org.apache.kafka.streams.processor (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>org.apache.kafka.streams.processor (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="org.apache.kafka.streams.processor (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.streams.processor (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/package-tree.html b/0110/javadoc/org/apache/kafka/streams/processor/package-tree.html
index 9d046c2..19eea92 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/package-tree.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>org.apache.kafka.streams.processor Class Hierarchy (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>org.apache.kafka.streams.processor Class Hierarchy (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="org.apache.kafka.streams.processor Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.streams.processor Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/HostInfo.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/HostInfo.html b/0110/javadoc/org/apache/kafka/streams/state/HostInfo.html
index c2dee2c..f74900e 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/HostInfo.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/HostInfo.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>HostInfo (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:58 BST 2017 -->
+<title>HostInfo (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="HostInfo (kafka 0.11.0.0 API)";
+        parent.document.title="HostInfo (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/KeyValueIterator.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/KeyValueIterator.html b/0110/javadoc/org/apache/kafka/streams/state/KeyValueIterator.html
index 3a83a20..7269fbb 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/KeyValueIterator.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/KeyValueIterator.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>KeyValueIterator (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:58 BST 2017 -->
+<title>KeyValueIterator (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="KeyValueIterator (kafka 0.11.0.0 API)";
+        parent.document.title="KeyValueIterator (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/KeyValueStore.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/KeyValueStore.html b/0110/javadoc/org/apache/kafka/streams/state/KeyValueStore.html
index 51a34ce..642976a 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/KeyValueStore.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/KeyValueStore.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>KeyValueStore (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:58 BST 2017 -->
+<title>KeyValueStore (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="KeyValueStore (kafka 0.11.0.0 API)";
+        parent.document.title="KeyValueStore (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/QueryableStoreType.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/QueryableStoreType.html b/0110/javadoc/org/apache/kafka/streams/state/QueryableStoreType.html
index 430ace2..8697075 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/QueryableStoreType.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/QueryableStoreType.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>QueryableStoreType (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:58 BST 2017 -->
+<title>QueryableStoreType (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="QueryableStoreType (kafka 0.11.0.0 API)";
+        parent.document.title="QueryableStoreType (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/QueryableStoreTypes.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/QueryableStoreTypes.html b/0110/javadoc/org/apache/kafka/streams/state/QueryableStoreTypes.html
index 342bf2d..c14bf82 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/QueryableStoreTypes.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/QueryableStoreTypes.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>QueryableStoreTypes (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:58 BST 2017 -->
+<title>QueryableStoreTypes (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="QueryableStoreTypes (kafka 0.11.0.0 API)";
+        parent.document.title="QueryableStoreTypes (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/ReadOnlyKeyValueStore.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/ReadOnlyKeyValueStore.html b/0110/javadoc/org/apache/kafka/streams/state/ReadOnlyKeyValueStore.html
index fc06d10..0ee0e40 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/ReadOnlyKeyValueStore.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/ReadOnlyKeyValueStore.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>ReadOnlyKeyValueStore (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:58 BST 2017 -->
+<title>ReadOnlyKeyValueStore (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="ReadOnlyKeyValueStore (kafka 0.11.0.0 API)";
+        parent.document.title="ReadOnlyKeyValueStore (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/ReadOnlySessionStore.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/ReadOnlySessionStore.html b/0110/javadoc/org/apache/kafka/streams/state/ReadOnlySessionStore.html
index 9d304ab..4fcc2c6 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/ReadOnlySessionStore.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/ReadOnlySessionStore.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>ReadOnlySessionStore (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:58 BST 2017 -->
+<title>ReadOnlySessionStore (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="ReadOnlySessionStore (kafka 0.11.0.0 API)";
+        parent.document.title="ReadOnlySessionStore (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/ReadOnlyWindowStore.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/ReadOnlyWindowStore.html b/0110/javadoc/org/apache/kafka/streams/state/ReadOnlyWindowStore.html
index d093579..e67d3e0 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/ReadOnlyWindowStore.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/ReadOnlyWindowStore.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>ReadOnlyWindowStore (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:58 BST 2017 -->
+<title>ReadOnlyWindowStore (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="ReadOnlyWindowStore (kafka 0.11.0.0 API)";
+        parent.document.title="ReadOnlyWindowStore (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/RocksDBConfigSetter.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/RocksDBConfigSetter.html b/0110/javadoc/org/apache/kafka/streams/state/RocksDBConfigSetter.html
index 243dc9f..4ca9298 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/RocksDBConfigSetter.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/RocksDBConfigSetter.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>RocksDBConfigSetter (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:58 BST 2017 -->
+<title>RocksDBConfigSetter (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="RocksDBConfigSetter (kafka 0.11.0.0 API)";
+        parent.document.title="RocksDBConfigSetter (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/SessionStore.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/SessionStore.html b/0110/javadoc/org/apache/kafka/streams/state/SessionStore.html
index 6cef1a4..2235ac8 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/SessionStore.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/SessionStore.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>SessionStore (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:58 BST 2017 -->
+<title>SessionStore (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="SessionStore (kafka 0.11.0.0 API)";
+        parent.document.title="SessionStore (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/StateSerdes.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/StateSerdes.html b/0110/javadoc/org/apache/kafka/streams/state/StateSerdes.html
index 1acacff..421b68b 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/StateSerdes.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/StateSerdes.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>StateSerdes (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:58 BST 2017 -->
+<title>StateSerdes (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="StateSerdes (kafka 0.11.0.0 API)";
+        parent.document.title="StateSerdes (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/Stores.InMemoryKeyValueFactory.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/Stores.InMemoryKeyValueFactory.html b/0110/javadoc/org/apache/kafka/streams/state/Stores.InMemoryKeyValueFactory.html
index a87cfe4..1d97347 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/Stores.InMemoryKeyValueFactory.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/Stores.InMemoryKeyValueFactory.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>Stores.InMemoryKeyValueFactory (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:58 BST 2017 -->
+<title>Stores.InMemoryKeyValueFactory (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="Stores.InMemoryKeyValueFactory (kafka 0.11.0.0 API)";
+        parent.document.title="Stores.InMemoryKeyValueFactory (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/Stores.KeyValueFactory.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/Stores.KeyValueFactory.html b/0110/javadoc/org/apache/kafka/streams/state/Stores.KeyValueFactory.html
index 4c18212..10e78c1 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/Stores.KeyValueFactory.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/Stores.KeyValueFactory.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>Stores.KeyValueFactory (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:58 BST 2017 -->
+<title>Stores.KeyValueFactory (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="Stores.KeyValueFactory (kafka 0.11.0.0 API)";
+        parent.document.title="Stores.KeyValueFactory (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/Stores.PersistentKeyValueFactory.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/Stores.PersistentKeyValueFactory.html b/0110/javadoc/org/apache/kafka/streams/state/Stores.PersistentKeyValueFactory.html
index a1b7e63..03c285c 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/Stores.PersistentKeyValueFactory.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/Stores.PersistentKeyValueFactory.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>Stores.PersistentKeyValueFactory (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:58 BST 2017 -->
+<title>Stores.PersistentKeyValueFactory (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="Stores.PersistentKeyValueFactory (kafka 0.11.0.0 API)";
+        parent.document.title="Stores.PersistentKeyValueFactory (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/Stores.StoreFactory.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/Stores.StoreFactory.html b/0110/javadoc/org/apache/kafka/streams/state/Stores.StoreFactory.html
index 2c8d03c..acec3b0 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/Stores.StoreFactory.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/Stores.StoreFactory.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>Stores.StoreFactory (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:58 BST 2017 -->
+<title>Stores.StoreFactory (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="Stores.StoreFactory (kafka 0.11.0.0 API)";
+        parent.document.title="Stores.StoreFactory (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/Stores.ValueFactory.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/Stores.ValueFactory.html b/0110/javadoc/org/apache/kafka/streams/state/Stores.ValueFactory.html
index 95621c1..d901bb4 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/Stores.ValueFactory.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/Stores.ValueFactory.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>Stores.ValueFactory (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:58 BST 2017 -->
+<title>Stores.ValueFactory (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="Stores.ValueFactory (kafka 0.11.0.0 API)";
+        parent.document.title="Stores.ValueFactory (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/Stores.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/Stores.html b/0110/javadoc/org/apache/kafka/streams/state/Stores.html
index 98338e0..15cad09 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/Stores.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/Stores.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>Stores (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:58 BST 2017 -->
+<title>Stores (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="Stores (kafka 0.11.0.0 API)";
+        parent.document.title="Stores (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/StreamsMetadata.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/StreamsMetadata.html b/0110/javadoc/org/apache/kafka/streams/state/StreamsMetadata.html
index f2f136b..654f37e 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/StreamsMetadata.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/StreamsMetadata.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>StreamsMetadata (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:58 BST 2017 -->
+<title>StreamsMetadata (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="StreamsMetadata (kafka 0.11.0.0 API)";
+        parent.document.title="StreamsMetadata (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/WindowStore.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/WindowStore.html b/0110/javadoc/org/apache/kafka/streams/state/WindowStore.html
index 769793c..b113c79 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/WindowStore.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/WindowStore.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>WindowStore (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:58 BST 2017 -->
+<title>WindowStore (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="WindowStore (kafka 0.11.0.0 API)";
+        parent.document.title="WindowStore (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/WindowStoreIterator.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/WindowStoreIterator.html b/0110/javadoc/org/apache/kafka/streams/state/WindowStoreIterator.html
index 13dc373..4c5c413 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/WindowStoreIterator.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/WindowStoreIterator.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>WindowStoreIterator (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:58 BST 2017 -->
+<title>WindowStoreIterator (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="WindowStoreIterator (kafka 0.11.0.0 API)";
+        parent.document.title="WindowStoreIterator (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/package-frame.html b/0110/javadoc/org/apache/kafka/streams/state/package-frame.html
index 7f06402..8fd197b 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/package-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>org.apache.kafka.streams.state (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>org.apache.kafka.streams.state (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/org/apache/kafka/streams/state/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/package-summary.html b/0110/javadoc/org/apache/kafka/streams/state/package-summary.html
index d528df0..85b1b8a 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/package-summary.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>org.apache.kafka.streams.state (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>org.apache.kafka.streams.state (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="org.apache.kafka.streams.state (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.streams.state (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/state/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/state/package-tree.html b/0110/javadoc/org/apache/kafka/streams/state/package-tree.html
index 8d5080c..42bb22e 100644
--- a/0110/javadoc/org/apache/kafka/streams/state/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/streams/state/package-tree.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>org.apache.kafka.streams.state Class Hierarchy (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>org.apache.kafka.streams.state Class Hierarchy (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="org.apache.kafka.streams.state Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.streams.state Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/overview-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/overview-frame.html b/0110/javadoc/overview-frame.html
index ff15719..2135095 100644
--- a/0110/javadoc/overview-frame.html
+++ b/0110/javadoc/overview-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>Overview 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>Overview 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>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/overview-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/overview-summary.html b/0110/javadoc/overview-summary.html
index 3d94626..2ea3670 100644
--- a/0110/javadoc/overview-summary.html
+++ b/0110/javadoc/overview-summary.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>Overview (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>Overview (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="Overview (kafka 0.11.0.0 API)";
+        parent.document.title="Overview (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -62,7 +62,7 @@
 </a></div>
 <!-- ========= END OF TOP NAVBAR ========= -->
 <div class="header">
-<h1 class="title">kafka 0.11.0.0 API</h1>
+<h1 class="title">kafka 0.11.0.1 API</h1>
 </div>
 <div class="contentContainer">
 <table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Packages table, listing packages, and an explanation">

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/overview-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/overview-tree.html b/0110/javadoc/overview-tree.html
index 8376df5..e3414dd 100644
--- a/0110/javadoc/overview-tree.html
+++ b/0110/javadoc/overview-tree.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>Class Hierarchy (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>Class Hierarchy (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="Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/serialized-form.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/serialized-form.html b/0110/javadoc/serialized-form.html
index d265f33..67813a0 100644
--- a/0110/javadoc/serialized-form.html
+++ b/0110/javadoc/serialized-form.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>Serialized Form (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>Serialized Form (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="Serialized Form (kafka 0.11.0.0 API)";
+        parent.document.title="Serialized Form (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/js/templateData.js
----------------------------------------------------------------------
diff --git a/0110/js/templateData.js b/0110/js/templateData.js
index 2f32444..5356e4d 100644
--- a/0110/js/templateData.js
+++ b/0110/js/templateData.js
@@ -18,5 +18,7 @@ limitations under the License.
 // Define variables for doc templates
 var context={
     "version": "0110",
-    "dotVersion": "0.11.0"
-};
\ No newline at end of file
+    "dotVersion": "0.11.0",
+    "fullDotVersion": "0.11.0.1",
+    "scalaVersion": "2.11"
+};

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/ops.html
----------------------------------------------------------------------
diff --git a/0110/ops.html b/0110/ops.html
index 85a6e10..32d4bbd 100644
--- a/0110/ops.html
+++ b/0110/ops.html
@@ -24,7 +24,7 @@
 
   <h4><a id="basic_ops_add_topic" href="#basic_ops_add_topic">Adding and removing topics</a></h4>
 
-  You have the option of either adding topics manually or having them be created automatically when data is first published to a non-existent topic. If topics are auto-created then you may want to tune the default <a href="#topic-config">topic configurations</a> used for auto-created topics.
+  You have the option of either adding topics manually or having them be created automatically when data is first published to a non-existent topic. If topics are auto-created then you may want to tune the default <a href="#topicconfigs">topic configurations</a> used for auto-created topics.
   <p>
   Topics are added and modified using the topic tool:
   <pre class="brush: bash;">
@@ -37,7 +37,7 @@
   <p>
   Each sharded partition log is placed into its own folder under the Kafka log directory. The name of such folders consists of the topic name, appended by a dash (-) and the partition id. Since a typical folder name can not be over 255 characters long, there will be a limitation on the length of topic names. We assume the number of partitions will not ever be above 100,000. Therefore, topic names cannot be longer than 249 characters. This leaves just enough room in the folder name for a dash and a potentially 5 digit long partition id.
   <p>
-  The configurations added on the command line override the default settings the server has for things like the length of time data should be retained. The complete set of per-topic configurations is documented <a href="#topic-config">here</a>.
+  The configurations added on the command line override the default settings the server has for things like the length of time data should be retained. The complete set of per-topic configurations is documented <a href="#topicconfigs">here</a>.
 
   <h4><a id="basic_ops_modify_topic" href="#basic_ops_modify_topic">Modifying topics</a></h4>
 
@@ -687,7 +687,7 @@
 
   <h3><a id="monitoring" href="#monitoring">6.6 Monitoring</a></h3>
 
-  Kafka uses Yammer Metrics for metrics reporting in both the server and the client. This can be configured to report stats using pluggable stats reporters to hook up to your monitoring system.
+  Kafka uses Yammer Metrics for metrics reporting in the server and Scala clients. The Java clients use Kafka Metrics, a built-in metrics registry that minimizes transitive dependencies pulled into client applications. Both expose metrics via JMX and can be configured to report stats using pluggable stats reporters to hook up to your monitoring system.
   <p>
   The easiest way to see the available metrics is to fire up jconsole and point it at a running kafka client or server; this will allow browsing all metrics with JMX.
   <p>
@@ -1229,7 +1229,19 @@
 
   <h4><a id="kafka_streams_monitoring" href="#kafka_streams_monitoring">Streams Monitoring</a></h4>
 
-  A Kafka Streams instance contains all the producer and consumer metrics as well as additional metrics specific to streams. By default Kafka Streams has metrics with two recording levels: debug and info. The debug level records all metrics, while the info level records only the thread-level metrics.  Use the following configuration option to specify which metrics you want collected:
+  A Kafka Streams instance contains all the producer and consumer metrics as well as additional metrics specific to streams.
+  By default Kafka Streams has metrics with two recording levels: debug and info. The debug level records all metrics, while
+  the info level records only the thread-level metrics.
+
+  <p>
+    Note that the metrics have a 3-layer hierarchy. At the top level there are per-thread metrics. Each thread has tasks, with their
+    own metrics. Each task has a number of processor nodes, with their own metrics. Each task also has a number of state stores
+    and record caches, all with their own metrics.
+  </p>
+  
+  Use the following configuration option to specify which metrics
+  you want collected:
+
 <pre>metrics.recording.level="info"</pre>
 
 <h5><a id="kafka_streams_thread_monitoring" href="#kafka_streams_thread_monitoring">Thread Metrics</a></h5>
@@ -1241,30 +1253,80 @@ All the following metrics have a recording level of ``info``:
         <th>Description</th>
         <th>Mbean name</th>
       </tr>
-      <tr>
-        <td>[commit | poll | process | punctuate]-latency-[avg | max]</td>
-        <td>The [average | maximum] execution time in ms, for the respective operation, across all running tasks of this thread.</td>
-        <td>kafka.streams:type=stream-metrics,thread.client-id=([-.\w]+)</td>
-      </tr>
-      <tr>
-        <td>[commit | poll | process | punctuate]-rate</td>
-        <td>The average number of respective operations per second across all tasks.</td>
-        <td>kafka.streams:type=stream-metrics,thread.client-id=([-.\w]+)</td>
+       <tr>
+        <td>commit-latency-avg</td>
+        <td>The average execution time in ms for committing, across all running tasks of this thread.</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
+       </tr>
+        <tr>
+        <td>commit-latency-max</td>
+        <td>The maximum execution time in ms for committing across all running tasks of this thread.</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
+       </tr>
+       <tr>
+        <td>poll-latency-avg</td>
+        <td>The average execution time in ms for polling, across all running tasks of this thread.</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
+       </tr>
+        <tr>
+        <td>poll-latency-max</td>
+        <td>The maximum execution time in ms for polling across all running tasks of this thread.</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
+       </tr>
+       <tr>
+        <td>process-latency-avg</td>
+        <td>The average execution time in ms for processing, across all running tasks of this thread.</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
+       </tr>
+       <tr>
+        <td>process-latency-max</td>
+        <td>The maximum execution time in ms for processing across all running tasks of this thread.</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
+       </tr>
+       <tr>
+        <td>punctuate-latency-avg</td>
+        <td>The average execution time in ms for punctuating, across all running tasks of this thread.</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
+       </tr>
+       <tr>
+        <td>punctuate-latency-max</td>
+        <td>The maximum execution time in ms for punctuating across all running tasks of this thread.</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
+       </tr>
+       <tr>
+        <td>commit-rate</td>
+        <td>The average number of commits per second across all tasks.</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
+       </tr>
+       <tr>
+        <td>poll-rate</td>
+        <td>The average number of polls per second across all tasks.</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
+       </tr>
+       <tr>
+        <td>process-rate</td>
+        <td>The average number of process calls per second across all tasks.</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
+       </tr>
+       <tr>
+        <td>punctuate-rate</td>
+        <td>The average number of punctuates per second across all tasks.</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
       </tr>
       <tr>
         <td>task-created-rate</td>
         <td>The average number of newly created tasks per second.</td>
-        <td>kafka.streams:type=stream-metrics,thread.client-id=([-.\w]+)</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
       </tr>
       <tr>
         <td>task-closed-rate</td>
         <td>The average number of tasks closed per second.</td>
-        <td>kafka.streams:type=stream-metrics,thread.client-id=([-.\w]+)</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
       </tr>
       <tr>
         <td>skipped-records-rate</td>
         <td>The average number of skipped records per second. </td>
-        <td>kafka.streams:type=stream-metrics,thread.client-id=([-.\w]+)</td>
+        <td>kafka.streams:type=stream-metrics,client-id=([-.\w]+)</td>
       </tr>
  </tbody>
 </table>
@@ -1279,14 +1341,19 @@ All the following metrics have a recording level of ``debug``:
         <th>Mbean name</th>
       </tr>
       <tr>
-        <td>commit-latency-[avg | max]</td>
-        <td>The [average | maximum] commit time in ns for this task. </td>
-        <td>kafka.streams:type=stream-task-metrics,streams-task-id=([-.\w]+)</td>
+        <td>commit-latency-avg</td>
+        <td>The average commit time in ns for this task. </td>
+        <td>kafka.streams:type=stream-task-metrics,client-id=([-.\w]+),task-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>commit-latency-max</td>
+        <td>The maximum commit time in ns for this task. </td>
+        <td>kafka.streams:type=stream-task-metrics,client-id=([-.\w]+),task-id=([-.\w]+)</td>
       </tr>
       <tr>
         <td>commit-rate</td>
         <td>The average number of commit calls per second. </td>
-        <td>kafka.streams:type=stream-task-metrics,streams-task-id=([-.\w]+)</td>
+        <td>kafka.streams:type=stream-task-metrics,client-id=([-.\w]+),task-id=([-.\w]+)</td>
       </tr>
  </tbody>
 </table>
@@ -1301,19 +1368,69 @@ All the following metrics have a recording level of ``debug``:
         <th>Mbean name</th>
       </tr>
       <tr>
-        <td>[process | punctuate | create | destroy]-latency-[avg | max]</td>
-        <td>The [average | maximum] execution time in ns, for the respective operation. </td>
-        <td>kafka.streams:type=stream-processor-node-metrics, processor-node-id=([-.\w]+)</td>
+        <td>process-latency-avg</td>
+        <td>The average process execution time in ns. </td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>process-latency-max</td>
+        <td>The maximum process execution time in ns. </td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>punctuate-latency-avg</td>
+        <td>The average punctuate execution time in ns. </td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>punctuate-latency-max</td>
+        <td>The maximum punctuate execution time in ns. </td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
       </tr>
       <tr>
-        <td>[process | punctuate | create | destroy]-rate</td>
-        <td>The average number of respective operations per second. </td>
-        <td>kafka.streams:type=stream-processor-node-metrics, processor-node-id=([-.\w]+)</td>
+        <td>create-latency-avg</td>
+        <td>The average create execution time in ns. </td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>create-latency-max</td>
+        <td>The maximum create execution time in ns. </td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>destroy-latency-avg</td>
+        <td>The average destroy execution time in ns. </td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>destroy-latency-max</td>
+        <td>The maximum destroy execution time in ns. </td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>process-rate</td>
+        <td>The average number of process operations per second. </td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>punctuate-rate</td>
+        <td>The average number of punctuate operations per second. </td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>create-rate</td>
+        <td>The average number of create operations per second. </td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>destroy-rate</td>
+        <td>The average number of destroy operations per second. </td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
       </tr>
       <tr>
         <td>forward-rate</td>
         <td>The average rate of records being forwarded downstream, from source nodes only, per second. </td>
-        <td>kafka.streams:type=stream-processor-node-metrics, processor-node-id=([-.\w]+)</td>
+        <td>kafka.streams:type=stream-processor-node-metrics,client-id=([-.\w]+),task-id=([-.\w]+),processor-node-id=([-.\w]+)</td>
       </tr>
  </tbody>
  </table>
@@ -1329,16 +1446,140 @@ All the following metrics have a recording level of ``debug``:
         <th>Mbean name</th>
       </tr>
       <tr>
-        <td>[put | put-if-absent | get | delete | put-all | all | range | flush | restore]-latency-[avg | max]</td>
-        <td>The average execution time in ns, for the respective operation. </td>
-        <td>kafka.streams:type=stream-[store-type]-metrics</td>
+        <td>put-latency-avg</td>
+        <td>The average put execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
       </tr>
-        <tr>
-        <td>[put | put-if-absent | get | delete | put-all | all | range | flush | restore]-rate</td>
-        <td>The average rate of respective operations per second for this store.</td>
-        <td>kafka.streams:type=stream-[store-type]-metrics</td>
+      <tr>
+        <td>put-latency-max</td>
+        <td>The maximum put execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>put-if-absent-latency-avg</td>
+        <td>The average put-if-absent execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>put-if-absent-latency-max</td>
+        <td>The maximum put-if-absent execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>get-latency-avg</td>
+        <td>The average get execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>get-latency-max</td>
+        <td>The maximum get execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>delete-latency-avg</td>
+        <td>The average delete execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>delete-latency-max</td>
+        <td>The maximum delete execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>put-all-latency-avg</td>
+        <td>The average put-all execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>put-all-latency-max</td>
+        <td>The maximum put-all execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>all-latency-avg</td>
+        <td>The average all operation execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>all-latency-max</td>
+        <td>The maximum all operation execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>range-latency-avg</td>
+        <td>The average range execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>range-latency-max</td>
+        <td>The maximum range execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+       <tr>
+        <td>flush-latency-avg</td>
+        <td>The average flush execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>flush-latency-max</td>
+        <td>The maximum flush execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>restore-latency-avg</td>
+        <td>The average restore execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>restore-latency-max</td>
+        <td>The maximum restore execution time in ns. </td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>put-rate</td>
+        <td>The average put rate for this store.</td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>put-if-absent-rate</td>
+        <td>The average put-if-absent rate for this store.</td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>get-rate</td>
+        <td>The average get rate for this store.</td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>delete-rate</td>
+        <td>The average delete rate for this store.</td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>put-all-rate</td>
+        <td>The average put-all rate for this store.</td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>all-rate</td>
+        <td>The average all operation rate for this store.</td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>range-rate</td>
+        <td>The average range rate for this store.</td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>flush-rate</td>
+        <td>The average flush rate for this store.</td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>restore-rate</td>
+        <td>The average restore rate for this store.</td>
+        <td>kafka.streams:type=stream-[store-type]-state-metrics,client-id=([-.\w]+),task-id=([-.\w]+),[store-type]-state-id=([-.\w]+)</td>
       </tr>
-      
     </tbody>
  </table>
 
@@ -1353,9 +1594,19 @@ All the following metrics have a recording level of ``debug``:
         <th>Mbean name</th>
       </tr>
       <tr>
-        <td>hitRatio-[avg | min | max]</td>
-        <td>The cache hit ratio defined as the ratio of cache read hits over the total cache read requests. </td>
-        <td>kafka.streams:type=stream-record-cache-metrics, record-cache-id=([-.\w]+)</td>
+        <td>hitRatio-avg</td>
+        <td>The average cache hit ratio defined as the ratio of cache read hits over the total cache read requests. </td>
+        <td>kafka.streams:type=stream-record-cache-metrics,client-id=([-.\w]+),task-id=([-.\w]+),record-cache-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>hitRatio-min</td>
+        <td>The mininum cache hit ratio. </td>
+        <td>kafka.streams:type=stream-record-cache-metrics,client-id=([-.\w]+),task-id=([-.\w]+),record-cache-id=([-.\w]+)</td>
+      </tr>
+      <tr>
+        <td>hitRatio-max</td>
+        <td>The maximum cache hit ratio. </td>
+        <td>kafka.streams:type=stream-record-cache-metrics,client-id=([-.\w]+),task-id=([-.\w]+),record-cache-id=([-.\w]+)</td>
       </tr>
     </tbody>
  </table>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/quickstart.html
----------------------------------------------------------------------
diff --git a/0110/quickstart.html b/0110/quickstart.html
index 6509f75..c50df29 100644
--- a/0110/quickstart.html
+++ b/0110/quickstart.html
@@ -25,11 +25,11 @@ Since Kafka console scripts are different for Unix-based and Windows platforms,
 
 <h4><a id="quickstart_download" href="#quickstart_download">Step 1: Download the code</a></h4>
 
-<a href="https://www.apache.org/dyn/closer.cgi?path=/kafka/0.10.2.0/kafka_2.11-0.10.2.0.tgz" title="Kafka downloads">Download</a> the 0.10.2.0 release and un-tar it.
+<a href="https://www.apache.org/dyn/closer.cgi?path=/kafka/{{fullDotVersion}}/kafka_2.11-{{fullDotVersion}}.tgz" title="Kafka downloads">Download</a> the {{fullDotVersion}} release and un-tar it.
 
 <pre class="brush: bash;">
-&gt; tar -xzf kafka_2.11-0.10.2.0.tgz
-&gt; cd kafka_2.11-0.10.2.0
+&gt; tar -xzf kafka_2.11-{{fullDotVersion}}.tgz
+&gt; cd kafka_2.11-{{fullDotVersion}}
 </pre>
 
 <h4><a id="quickstart_startserver" href="#quickstart_startserver">Step 2: Start the server</a></h4>
@@ -187,7 +187,7 @@ my test message 2
 On Windows use:
 <pre class="brush: bash;">
 &gt; wmic process get processid,caption,commandline | find "java.exe" | find "server-1.properties"
-java.exe    java  -Xmx1G -Xms1G -server -XX:+UseG1GC ... build\libs\kafka_2.11-0.10.2.0.jar"  kafka.Kafka config\server-1.properties    644
+java.exe    java  -Xmx1G -Xms1G -server -XX:+UseG1GC ... build\libs\kafka_2.11-{{fullDotVersion}}.jar"  kafka.Kafka config\server-1.properties    644
 &gt; taskkill /pid 644 /f
 </pre>
 
@@ -280,169 +280,14 @@ data in the topic (or use custom consumer code to process it):
 <h4><a id="quickstart_kafkastreams" href="#quickstart_kafkastreams">Step 8: Use Kafka Streams to process data</a></h4>
 
 <p>
-Kafka Streams is a client library of Kafka for real-time stream processing and analyzing data stored in Kafka brokers.
-This quickstart example will demonstrate how to run a streaming application coded in this library. Here is the gist
-of the <code><a href="https://github.com/apache/kafka/blob/{{dotVersion}}/streams/examples/src/main/java/org/apache/kafka/streams/examples/wordcount/WordCountDemo.java">WordCountDemo</a></code> example code (converted to use Java 8 lambda expressions for easy reading).
-</p>
-<pre class="brush: bash;">
-// Serializers/deserializers (serde) for String and Long types
-final Serde&lt;String&gt; stringSerde = Serdes.String();
-final Serde&lt;Long&gt; longSerde = Serdes.Long();
-
-// Construct a `KStream` from the input topic ""streams-file-input", where message values
-// represent lines of text (for the sake of this example, we ignore whatever may be stored
-// in the message keys).
-KStream&lt;String, String&gt; textLines = builder.stream(stringSerde, stringSerde, "streams-file-input");
-
-KTable&lt;String, Long&gt; wordCounts = textLines
-    // Split each text line, by whitespace, into words.
-    .flatMapValues(value -> Arrays.asList(value.toLowerCase().split("\\W+")))
-
-    // Group the text words as message keys
-    .groupBy((key, value) -> value)
-
-    // Count the occurrences of each word (message key).
-    .count("Counts")
-
-// Store the running counts as a changelog stream to the output topic.
-wordCounts.to(stringSerde, longSerde, "streams-wordcount-output");
-</pre>
-
-<p>
-It implements the WordCount
-algorithm, which computes a word occurrence histogram from the input text. However, unlike other WordCount examples
-you might have seen before that operate on bounded data, the WordCount demo application behaves slightly differently because it is
-designed to operate on an <b>infinite, unbounded stream</b> of data. Similar to the bounded variant, it is a stateful algorithm that
-tracks and updates the counts of words. However, since it must assume potentially
-unbounded input data, it will periodically output its current state and results while continuing to process more data
-because it cannot know when it has processed "all" the input data.
-</p>
-<p>
-As the first step, we will prepare input data to a Kafka topic, which will subsequently be processed by a Kafka Streams application.
-</p>
-
-<!--
-<pre>
-&gt; <b>./bin/kafka-topics --create \</b>
-            <b>--zookeeper localhost:2181 \</b>
-            <b>--replication-factor 1 \</b>
-            <b>--partitions 1 \</b>
-            <b>--topic streams-file-input</b>
-
-</pre>
-
--->
-
-<pre class="brush: bash;">
-&gt; echo -e "all streams lead to kafka\nhello kafka streams\njoin kafka summit" > file-input.txt
-</pre>
-Or on Windows:
-<pre class="brush: bash;">
-&gt; echo all streams lead to kafka> file-input.txt
-&gt; echo hello kafka streams>> file-input.txt
-&gt; echo|set /p=join kafka summit>> file-input.txt
-</pre>
-
-<p>
-Next, we send this input data to the input topic named <b>streams-file-input</b> using the console producer,
-which reads the data from STDIN line-by-line, and publishes each line as a separate Kafka message with null key and value encoded a string to the topic (in practice,
-stream data will likely be flowing continuously into Kafka where the application will be up and running):
-</p>
-
-<pre class="brush: bash;">
-&gt; bin/kafka-topics.sh --create \
-    --zookeeper localhost:2181 \
-    --replication-factor 1 \
-    --partitions 1 \
-    --topic streams-file-input
-</pre>
-
-
-<pre class="brush: bash;">
-&gt; bin/kafka-console-producer.sh --broker-list localhost:9092 --topic streams-file-input < file-input.txt
-</pre>
-
-<p>
-We can now run the WordCount demo application to process the input data:
-</p>
-
-<pre class="brush: bash;">
-&gt; bin/kafka-run-class.sh org.apache.kafka.streams.examples.wordcount.WordCountDemo
-</pre>
-
-<p>
-The demo application will read from the input topic <b>streams-file-input</b>, perform the computations of the WordCount algorithm on each of the read messages,
-and continuously write its current results to the output topic <b>streams-wordcount-output</b>.
-Hence there won't be any STDOUT output except log entries as the results are written back into in Kafka.
-The demo will run for a few seconds and then, unlike typical stream processing applications, terminate automatically.
-</p>
-<p>
-We can now inspect the output of the WordCount demo application by reading from its output topic:
-</p>
-
-<pre class="brush: bash;">
-&gt; bin/kafka-console-consumer.sh --bootstrap-server localhost:9092 \
-    --topic streams-wordcount-output \
-    --from-beginning \
-    --formatter kafka.tools.DefaultMessageFormatter \
-    --property print.key=true \
-    --property print.value=true \
-    --property key.deserializer=org.apache.kafka.common.serialization.StringDeserializer \
-    --property value.deserializer=org.apache.kafka.common.serialization.LongDeserializer
-</pre>
-
-<p>
-with the following output data being printed to the console:
-</p>
-
-<pre class="brush: bash;">
-all     1
-lead    1
-to      1
-hello   1
-streams 2
-join    1
-kafka   3
-summit  1
-</pre>
-
-<p>
-Here, the first column is the Kafka message key in <code>java.lang.String</code> format, and the second column is the message value in <code>java.lang.Long</code> format.
-Note that the output is actually a continuous stream of updates, where each data record (i.e. each line in the original output above) is
-an updated count of a single word, aka record key such as "kafka". For multiple records with the same key, each later record is an update of the previous one.
-</p>
-
-<p>
-The two diagrams below illustrate what is essentially happening behind the scenes.
-The first column shows the evolution of the current state of the <code>KTable&lt;String, Long&gt;</code> that is counting word occurrences for <code>count</code>.
-The second column shows the change records that result from state updates to the KTable and that are being sent to the output Kafka topic <b>streams-wordcount-output</b>.
-</p>
-
-<img src="/{{version}}/images/streams-table-updates-02.png" style="float: right; width: 25%;">
-<img src="/{{version}}/images/streams-table-updates-01.png" style="float: right; width: 25%;">
-
-<p>
-First the text line “all streams lead to kafka” is being processed.
-The <code>KTable</code> is being built up as each new word results in a new table entry (highlighted with a green background), and a corresponding change record is sent to the downstream <code>KStream</code>.
-</p>
-<p>
-When the second text line “hello kafka streams” is processed, we observe, for the first time, that existing entries in the <code>KTable</code> are being updated (here: for the words “kafka” and for “streams”). And again, change records are being sent to the output topic.
-</p>
-<p>
-And so on (we skip the illustration of how the third line is being processed). This explains why the output topic has the contents we showed above, because it contains the full record of changes.
-</p>
-
-<p>
-Looking beyond the scope of this concrete example, what Kafka Streams is doing here is to leverage the duality between a table and a changelog stream (here: table = the KTable, changelog stream = the downstream KStream): you can publish every change of the table to a stream, and if you consume the entire changelog stream from beginning to end, you can reconstruct the contents of the table.
-</p>
-
-<p>
-Now you can write more input messages to the <b>streams-file-input</b> topic and observe additional messages added
-to <b>streams-wordcount-output</b> topic, reflecting updated word counts (e.g., using the console producer and the
-console consumer, as described above).
+  Kafka Streams is a client library for building mission-critical real-time applications and microservices,
+  where the input and/or output data is stored in Kafka clusters. Kafka Streams combines the simplicity of
+  writing and deploying standard Java and Scala applications on the client side with the benefits of Kafka's
+  server-side cluster technology to make these applications highly scalable, elastic, fault-tolerant, distributed,
+  and much more. This <a href="/{{version}}/documentation/streams/quickstart">quickstart example</a> will demonstrate how
+  to run a streaming application coded in this library. 
 </p>
 
-<p>You can stop the console consumer via <b>Ctrl-C</b>.</p>
 
 </script>
 

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/security.html
----------------------------------------------------------------------
diff --git a/0110/security.html b/0110/security.html
index 5e2b202..dab00dd 100644
--- a/0110/security.html
+++ b/0110/security.html
@@ -40,7 +40,7 @@
 
     <ol>
         <li><h4><a id="security_ssl_key" href="#security_ssl_key">Generate SSL key and certificate for each Kafka broker</a></h4>
-            The first step of deploying HTTPS is to generate the key and the certificate for each machine in the cluster. You can use Java's keytool utility to accomplish this task.
+            The first step of deploying one or more brokers with the SSL support is to generate the key and the certificate for each machine in the cluster. You can use Java's keytool utility to accomplish this task.
             We will generate the key into a temporary keystore initially so that we can export and sign it later with CA.
             <pre class="brush: bash;">
             keytool -keystore server.keystore.jks -alias localhost -validity {validity} -genkey -keyalg RSA</pre>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/streams/architecture.html
----------------------------------------------------------------------
diff --git a/0110/streams/architecture.html b/0110/streams/architecture.html
index f0def6a..0dbb1dc 100644
--- a/0110/streams/architecture.html
+++ b/0110/streams/architecture.html
@@ -126,12 +126,12 @@
         Note that the cost of task (re)initialization typically depends primarily on the time for restoring the state by replaying the state stores' associated changelog topics.
         To minimize this restoration time, users can configure their applications to have <b>standby replicas</b> of local states (i.e. fully replicated copies of the state).
         When a task migration happens, Kafka Streams then attempts to assign a task to an application instance where such a standby replica already exists in order to minimize
-        the task (re)initialization cost. See <code>num.standby.replicas</code> in the <a href="/{{version}}/documentation/#streamsconfigs"><b>Kafka Streams Configs</b></a> Section.
+        the task (re)initialization cost. See <code>num.standby.replicas</code> in the <a href="/{{version}}/documentation/#streamsconfigs"><b>Kafka Streams Configs</b></a> section.
     </p>
 
     <div class="pagination">
         <a href="/{{version}}/documentation/streams/core-concepts" class="pagination__btn pagination__btn__prev">Previous</a>
-        <a href="/{{version}}/documentation/streams/developer-guide" class="pagination__btn pagination__btn__next">Next</a>
+        <a href="/{{version}}/documentation/streams/upgrade-guide" class="pagination__btn pagination__btn__next">Next</a>
     </div>
 </script>
 
@@ -143,7 +143,7 @@
         <!--#include virtual="../../includes/_docs_banner.htm" -->
         <ul class="breadcrumbs">
             <li><a href="/documentation">Documentation</a></li>
-            <li><a href="/documentation/streams">Streams</a></li>
+            <li><a href="/documentation/streams">Kafka Streams API</a></li>
         </ul>
         <div class="p-content"></div>
     </div>


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

Posted by da...@apache.org.
http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/KafkaStreams.State.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/KafkaStreams.State.html b/0110/javadoc/org/apache/kafka/streams/KafkaStreams.State.html
index ea7daae..6e61ac0 100644
--- a/0110/javadoc/org/apache/kafka/streams/KafkaStreams.State.html
+++ b/0110/javadoc/org/apache/kafka/streams/KafkaStreams.State.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>KafkaStreams.State (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:56 BST 2017 -->
+<title>KafkaStreams.State (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="KafkaStreams.State (kafka 0.11.0.0 API)";
+        parent.document.title="KafkaStreams.State (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -121,9 +121,9 @@ extends <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Enum.html?is
          |       +-----+--------+
          |             |
          |             v
-         |       +-----+--------+
-         +<----- | Rebalancing  | <----+
-         |       +--------------+      |
+         |       +-----+--------+ <-+
+         +<----- | Rebalancing  | --+
+         |       +--------------+ <----+
          |                             |
          |                             |
          |       +--------------+      |
@@ -132,15 +132,28 @@ extends <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Enum.html?is
          |             |
          |             v
          |       +-----+--------+
-         +-----> | Pending      |
-                 | Shutdown     |
-                 +-----+--------+
-                       |
-                       v
-                 +-----+--------+
-                 | Not Running  |
+         +-----> | Pending      |<----+
+         |       | Shutdown     |     |
+         |       +-----+--------+     |
+         |             |              |
+         |             v              |
+         |       +-----+--------+     |
+         |       | Not Running  |     |
+         |       +--------------+     |
+         |                            |
+         |       +--------------+     |
+         +-----> | Error        |-----+
                  +--------------+
- </pre></div>
+
+
+ </pre>
+ Note the following:
+ - Any state can go to PENDING_SHUTDOWN and subsequently NOT_RUNNING.
+ - It is theoretically possible for a thread to always be in the PARTITION_REVOKED state
+ (see <code>StreamThread</code> state diagram) and hence it is possible that this instance is always
+ on a REBALANCING state.
+ - Of special importance: If the global stream thread dies, or all stream threads die (or both) then
+ the instance will be in the ERROR state. The user will need to close it.</div>
 </li>
 </ul>
 </div>
@@ -162,15 +175,18 @@ extends <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Enum.html?is
 <td class="colOne"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#CREATED">CREATED</a></strong></code>&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#NOT_RUNNING">NOT_RUNNING</a></strong></code>&nbsp;</td>
+<td class="colOne"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#ERROR">ERROR</a></strong></code>&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colOne"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#PENDING_SHUTDOWN">PENDING_SHUTDOWN</a></strong></code>&nbsp;</td>
+<td class="colOne"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#NOT_RUNNING">NOT_RUNNING</a></strong></code>&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colOne"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#REBALANCING">REBALANCING</a></strong></code>&nbsp;</td>
+<td class="colOne"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#PENDING_SHUTDOWN">PENDING_SHUTDOWN</a></strong></code>&nbsp;</td>
 </tr>
 <tr class="altColor">
+<td class="colOne"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#REBALANCING">REBALANCING</a></strong></code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
 <td class="colOne"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#RUNNING">RUNNING</a></strong></code>&nbsp;</td>
 </tr>
 </table>
@@ -190,23 +206,19 @@ extends <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Enum.html?is
 </tr>
 <tr class="altColor">
 <td class="colFirst"><code>boolean</code></td>
-<td class="colLast"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#isCreatedOrRunning()">isCreatedOrRunning</a></strong>()</code>&nbsp;</td>
-</tr>
-<tr class="rowColor">
-<td class="colFirst"><code>boolean</code></td>
 <td class="colLast"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#isRunning()">isRunning</a></strong>()</code>&nbsp;</td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>boolean</code></td>
 <td class="colLast"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#isValidTransition(org.apache.kafka.streams.KafkaStreams.State)">isValidTransition</a></strong>(<a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams">KafkaStreams.State</a>&nbsp;newState)</code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code>static <a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams">KafkaStreams.State</a></code></td>
 <td class="colLast"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#valueOf(java.lang.String)">valueOf</a></strong>(<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;name)</code>
 <div class="block">Returns the enum constant of this type with the specified name.</div>
 </td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>static <a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams">KafkaStreams.State</a>[]</code></td>
 <td class="colLast"><code><strong><a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html#values()">values</a></strong>()</code>
 <div class="block">Returns an array containing the constants of this enum type, in
@@ -251,22 +263,22 @@ the order they are declared.</div>
 <pre>public static final&nbsp;<a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams">KafkaStreams.State</a> CREATED</pre>
 </li>
 </ul>
-<a name="RUNNING">
+<a name="REBALANCING">
 <!--   -->
 </a>
 <ul class="blockList">
 <li class="blockList">
-<h4>RUNNING</h4>
-<pre>public static final&nbsp;<a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams">KafkaStreams.State</a> RUNNING</pre>
+<h4>REBALANCING</h4>
+<pre>public static final&nbsp;<a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams">KafkaStreams.State</a> REBALANCING</pre>
 </li>
 </ul>
-<a name="REBALANCING">
+<a name="RUNNING">
 <!--   -->
 </a>
 <ul class="blockList">
 <li class="blockList">
-<h4>REBALANCING</h4>
-<pre>public static final&nbsp;<a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams">KafkaStreams.State</a> REBALANCING</pre>
+<h4>RUNNING</h4>
+<pre>public static final&nbsp;<a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams">KafkaStreams.State</a> RUNNING</pre>
 </li>
 </ul>
 <a name="PENDING_SHUTDOWN">
@@ -281,12 +293,21 @@ the order they are declared.</div>
 <a name="NOT_RUNNING">
 <!--   -->
 </a>
-<ul class="blockListLast">
+<ul class="blockList">
 <li class="blockList">
 <h4>NOT_RUNNING</h4>
 <pre>public static final&nbsp;<a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams">KafkaStreams.State</a> NOT_RUNNING</pre>
 </li>
 </ul>
+<a name="ERROR">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>ERROR</h4>
+<pre>public static final&nbsp;<a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams">KafkaStreams.State</a> ERROR</pre>
+</li>
+</ul>
 </li>
 </ul>
 <!-- ============ METHOD DETAIL ========== -->
@@ -339,15 +360,6 @@ not permitted.)</div>
 <pre>public&nbsp;boolean&nbsp;isRunning()</pre>
 </li>
 </ul>
-<a name="isCreatedOrRunning()">
-<!--   -->
-</a>
-<ul class="blockList">
-<li class="blockList">
-<h4>isCreatedOrRunning</h4>
-<pre>public&nbsp;boolean&nbsp;isCreatedOrRunning()</pre>
-</li>
-</ul>
 <a name="isValidTransition(org.apache.kafka.streams.KafkaStreams.State)">
 <!--   -->
 </a>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/KafkaStreams.StateListener.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/KafkaStreams.StateListener.html b/0110/javadoc/org/apache/kafka/streams/KafkaStreams.StateListener.html
index 69410be..3fdae67 100644
--- a/0110/javadoc/org/apache/kafka/streams/KafkaStreams.StateListener.html
+++ b/0110/javadoc/org/apache/kafka/streams/KafkaStreams.StateListener.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>KafkaStreams.StateListener (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:56 BST 2017 -->
+<title>KafkaStreams.StateListener (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="KafkaStreams.StateListener (kafka 0.11.0.0 API)";
+        parent.document.title="KafkaStreams.StateListener (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/KafkaStreams.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/KafkaStreams.html b/0110/javadoc/org/apache/kafka/streams/KafkaStreams.html
index 6efb48b..7796368 100644
--- a/0110/javadoc/org/apache/kafka/streams/KafkaStreams.html
+++ b/0110/javadoc/org/apache/kafka/streams/KafkaStreams.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>KafkaStreams (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:56 BST 2017 -->
+<title>KafkaStreams (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="KafkaStreams (kafka 0.11.0.0 API)";
+        parent.document.title="KafkaStreams (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -422,7 +422,7 @@ extends <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?
 <h4>state</h4>
 <pre>public&nbsp;<a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams">KafkaStreams.State</a>&nbsp;state()</pre>
 <div class="block">Return the current <a href="../../../../org/apache/kafka/streams/KafkaStreams.State.html" title="enum in org.apache.kafka.streams"><code>KafkaStreams.State</code></a> of this <code>KafkaStreams</code> instance.</div>
-<dl><dt><span class="strong">Returns:</span></dt><dd>the currnt state of this Kafka Streams instance</dd></dl>
+<dl><dt><span class="strong">Returns:</span></dt><dd>the current state of this Kafka Streams instance</dd></dl>
 </li>
 </ul>
 <a name="metrics()">
@@ -479,7 +479,8 @@ extends <a href="http://docs.oracle.com/javase/7/docs/api/java/lang/Object.html?
  A <code>timeout</code> of 0 means to wait forever.</div>
 <dl><dt><span class="strong">Parameters:</span></dt><dd><code>timeout</code> - how long to wait for the threads to shutdown</dd><dd><code>timeUnit</code> - unit of time used for timeout</dd>
 <dt><span class="strong">Returns:</span></dt><dd><code>true</code> if all threads were successfully stopped&mdash;<code>false</code> if the timeout was reached
- before all threads stopped</dd></dl>
+ before all threads stopped
+ Note that this method must not be called in the <code>onChange</code> callback of <a href="../../../../org/apache/kafka/streams/KafkaStreams.StateListener.html" title="interface in org.apache.kafka.streams"><code>KafkaStreams.StateListener</code></a>.</dd></dl>
 </li>
 </ul>
 <a name="toString()">

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/KeyValue.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/KeyValue.html b/0110/javadoc/org/apache/kafka/streams/KeyValue.html
index e9406a2..90558ba 100644
--- a/0110/javadoc/org/apache/kafka/streams/KeyValue.html
+++ b/0110/javadoc/org/apache/kafka/streams/KeyValue.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>KeyValue (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:56 BST 2017 -->
+<title>KeyValue (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="KeyValue (kafka 0.11.0.0 API)";
+        parent.document.title="KeyValue (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/StreamsConfig.InternalConfig.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/StreamsConfig.InternalConfig.html b/0110/javadoc/org/apache/kafka/streams/StreamsConfig.InternalConfig.html
index af2cd8c..fdf0d91 100644
--- a/0110/javadoc/org/apache/kafka/streams/StreamsConfig.InternalConfig.html
+++ b/0110/javadoc/org/apache/kafka/streams/StreamsConfig.InternalConfig.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>StreamsConfig.InternalConfig (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:56 BST 2017 -->
+<title>StreamsConfig.InternalConfig (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="StreamsConfig.InternalConfig (kafka 0.11.0.0 API)";
+        parent.document.title="StreamsConfig.InternalConfig (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/StreamsConfig.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/StreamsConfig.html b/0110/javadoc/org/apache/kafka/streams/StreamsConfig.html
index a26b62e..25a8f60 100644
--- a/0110/javadoc/org/apache/kafka/streams/StreamsConfig.html
+++ b/0110/javadoc/org/apache/kafka/streams/StreamsConfig.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>StreamsConfig (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:56 BST 2017 -->
+<title>StreamsConfig (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="StreamsConfig (kafka 0.11.0.0 API)";
+        parent.document.title="StreamsConfig (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/StreamsMetrics.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/StreamsMetrics.html b/0110/javadoc/org/apache/kafka/streams/StreamsMetrics.html
index 8688f30..ba20b77 100644
--- a/0110/javadoc/org/apache/kafka/streams/StreamsMetrics.html
+++ b/0110/javadoc/org/apache/kafka/streams/StreamsMetrics.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>StreamsMetrics (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>StreamsMetrics (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="StreamsMetrics (kafka 0.11.0.0 API)";
+        parent.document.title="StreamsMetrics (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/errors/BrokerNotFoundException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/errors/BrokerNotFoundException.html b/0110/javadoc/org/apache/kafka/streams/errors/BrokerNotFoundException.html
index 511ed9e..a3855bf 100644
--- a/0110/javadoc/org/apache/kafka/streams/errors/BrokerNotFoundException.html
+++ b/0110/javadoc/org/apache/kafka/streams/errors/BrokerNotFoundException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>BrokerNotFoundException (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>BrokerNotFoundException (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="BrokerNotFoundException (kafka 0.11.0.0 API)";
+        parent.document.title="BrokerNotFoundException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/errors/InvalidStateStoreException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/errors/InvalidStateStoreException.html b/0110/javadoc/org/apache/kafka/streams/errors/InvalidStateStoreException.html
index 56d77ec..726ac01 100644
--- a/0110/javadoc/org/apache/kafka/streams/errors/InvalidStateStoreException.html
+++ b/0110/javadoc/org/apache/kafka/streams/errors/InvalidStateStoreException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>InvalidStateStoreException (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>InvalidStateStoreException (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="InvalidStateStoreException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidStateStoreException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/errors/LockException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/errors/LockException.html b/0110/javadoc/org/apache/kafka/streams/errors/LockException.html
index d9305e3..57d94a9 100644
--- a/0110/javadoc/org/apache/kafka/streams/errors/LockException.html
+++ b/0110/javadoc/org/apache/kafka/streams/errors/LockException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>LockException (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>LockException (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="LockException (kafka 0.11.0.0 API)";
+        parent.document.title="LockException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/errors/ProcessorStateException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/errors/ProcessorStateException.html b/0110/javadoc/org/apache/kafka/streams/errors/ProcessorStateException.html
index c2c98a6..5ec655a 100644
--- a/0110/javadoc/org/apache/kafka/streams/errors/ProcessorStateException.html
+++ b/0110/javadoc/org/apache/kafka/streams/errors/ProcessorStateException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>ProcessorStateException (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>ProcessorStateException (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="ProcessorStateException (kafka 0.11.0.0 API)";
+        parent.document.title="ProcessorStateException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/errors/StreamsException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/errors/StreamsException.html b/0110/javadoc/org/apache/kafka/streams/errors/StreamsException.html
index 1722f88..6919cb0 100644
--- a/0110/javadoc/org/apache/kafka/streams/errors/StreamsException.html
+++ b/0110/javadoc/org/apache/kafka/streams/errors/StreamsException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>StreamsException (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>StreamsException (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="StreamsException (kafka 0.11.0.0 API)";
+        parent.document.title="StreamsException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/errors/TaskAssignmentException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/errors/TaskAssignmentException.html b/0110/javadoc/org/apache/kafka/streams/errors/TaskAssignmentException.html
index 2785ac9..d04e88a 100644
--- a/0110/javadoc/org/apache/kafka/streams/errors/TaskAssignmentException.html
+++ b/0110/javadoc/org/apache/kafka/streams/errors/TaskAssignmentException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>TaskAssignmentException (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>TaskAssignmentException (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="TaskAssignmentException (kafka 0.11.0.0 API)";
+        parent.document.title="TaskAssignmentException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/errors/TaskIdFormatException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/errors/TaskIdFormatException.html b/0110/javadoc/org/apache/kafka/streams/errors/TaskIdFormatException.html
index 234e86b..b01a8e8 100644
--- a/0110/javadoc/org/apache/kafka/streams/errors/TaskIdFormatException.html
+++ b/0110/javadoc/org/apache/kafka/streams/errors/TaskIdFormatException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>TaskIdFormatException (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>TaskIdFormatException (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="TaskIdFormatException (kafka 0.11.0.0 API)";
+        parent.document.title="TaskIdFormatException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/errors/TopologyBuilderException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/errors/TopologyBuilderException.html b/0110/javadoc/org/apache/kafka/streams/errors/TopologyBuilderException.html
index eae8c13..d92d322 100644
--- a/0110/javadoc/org/apache/kafka/streams/errors/TopologyBuilderException.html
+++ b/0110/javadoc/org/apache/kafka/streams/errors/TopologyBuilderException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>TopologyBuilderException (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>TopologyBuilderException (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="TopologyBuilderException (kafka 0.11.0.0 API)";
+        parent.document.title="TopologyBuilderException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/errors/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/errors/package-frame.html b/0110/javadoc/org/apache/kafka/streams/errors/package-frame.html
index 6bfeb3c..6970250 100644
--- a/0110/javadoc/org/apache/kafka/streams/errors/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/streams/errors/package-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>org.apache.kafka.streams.errors (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>org.apache.kafka.streams.errors (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/org/apache/kafka/streams/errors/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/errors/package-summary.html b/0110/javadoc/org/apache/kafka/streams/errors/package-summary.html
index 9cacb3c..3dad0cf 100644
--- a/0110/javadoc/org/apache/kafka/streams/errors/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/streams/errors/package-summary.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>org.apache.kafka.streams.errors (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>org.apache.kafka.streams.errors (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="org.apache.kafka.streams.errors (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.streams.errors (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/errors/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/errors/package-tree.html b/0110/javadoc/org/apache/kafka/streams/errors/package-tree.html
index adedb9f..f18ded4 100644
--- a/0110/javadoc/org/apache/kafka/streams/errors/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/streams/errors/package-tree.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>org.apache.kafka.streams.errors Class Hierarchy (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>org.apache.kafka.streams.errors Class Hierarchy (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="org.apache.kafka.streams.errors Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.streams.errors Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/Aggregator.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/Aggregator.html b/0110/javadoc/org/apache/kafka/streams/kstream/Aggregator.html
index 5e6099e..c3ce055 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/Aggregator.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/Aggregator.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>Aggregator (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>Aggregator (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="Aggregator (kafka 0.11.0.0 API)";
+        parent.document.title="Aggregator (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/ForeachAction.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/ForeachAction.html b/0110/javadoc/org/apache/kafka/streams/kstream/ForeachAction.html
index 8a8307f..5a90af7 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/ForeachAction.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/ForeachAction.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>ForeachAction (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>ForeachAction (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="ForeachAction (kafka 0.11.0.0 API)";
+        parent.document.title="ForeachAction (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/GlobalKTable.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/GlobalKTable.html b/0110/javadoc/org/apache/kafka/streams/kstream/GlobalKTable.html
index 605cedc..1d4a158 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/GlobalKTable.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/GlobalKTable.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>GlobalKTable (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>GlobalKTable (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="GlobalKTable (kafka 0.11.0.0 API)";
+        parent.document.title="GlobalKTable (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/Initializer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/Initializer.html b/0110/javadoc/org/apache/kafka/streams/kstream/Initializer.html
index c3051c0..8395451 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/Initializer.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/Initializer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>Initializer (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>Initializer (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="Initializer (kafka 0.11.0.0 API)";
+        parent.document.title="Initializer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/JoinWindows.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/JoinWindows.html b/0110/javadoc/org/apache/kafka/streams/kstream/JoinWindows.html
index 54e5f20..d4f67f5 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/JoinWindows.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/JoinWindows.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>JoinWindows (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>JoinWindows (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="JoinWindows (kafka 0.11.0.0 API)";
+        parent.document.title="JoinWindows (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/KGroupedStream.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/KGroupedStream.html b/0110/javadoc/org/apache/kafka/streams/kstream/KGroupedStream.html
index 91222ba..b1e1ebd 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/KGroupedStream.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/KGroupedStream.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>KGroupedStream (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>KGroupedStream (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="KGroupedStream (kafka 0.11.0.0 API)";
+        parent.document.title="KGroupedStream (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/KGroupedTable.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/KGroupedTable.html b/0110/javadoc/org/apache/kafka/streams/kstream/KGroupedTable.html
index 05b3c9f..f35717f 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/KGroupedTable.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/KGroupedTable.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>KGroupedTable (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>KGroupedTable (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="KGroupedTable (kafka 0.11.0.0 API)";
+        parent.document.title="KGroupedTable (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/KStream.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/KStream.html b/0110/javadoc/org/apache/kafka/streams/kstream/KStream.html
index 6d6b93d..15df9e2 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/KStream.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/KStream.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>KStream (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>KStream (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="KStream (kafka 0.11.0.0 API)";
+        parent.document.title="KStream (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/KStreamBuilder.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/KStreamBuilder.html b/0110/javadoc/org/apache/kafka/streams/kstream/KStreamBuilder.html
index 9a1a700..340ceb9 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/KStreamBuilder.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/KStreamBuilder.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>KStreamBuilder (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>KStreamBuilder (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="KStreamBuilder (kafka 0.11.0.0 API)";
+        parent.document.title="KStreamBuilder (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/KTable.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/KTable.html b/0110/javadoc/org/apache/kafka/streams/kstream/KTable.html
index 05fc042..2077a23 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/KTable.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/KTable.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>KTable (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>KTable (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="KTable (kafka 0.11.0.0 API)";
+        parent.document.title="KTable (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/KeyValueMapper.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/KeyValueMapper.html b/0110/javadoc/org/apache/kafka/streams/kstream/KeyValueMapper.html
index 15dd5af..881f167 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/KeyValueMapper.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/KeyValueMapper.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>KeyValueMapper (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>KeyValueMapper (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="KeyValueMapper (kafka 0.11.0.0 API)";
+        parent.document.title="KeyValueMapper (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/Merger.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/Merger.html b/0110/javadoc/org/apache/kafka/streams/kstream/Merger.html
index 8adf80c..84116f6 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/Merger.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/Merger.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>Merger (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>Merger (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="Merger (kafka 0.11.0.0 API)";
+        parent.document.title="Merger (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/Predicate.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/Predicate.html b/0110/javadoc/org/apache/kafka/streams/kstream/Predicate.html
index 55c6107..6a22128 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/Predicate.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/Predicate.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>Predicate (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>Predicate (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="Predicate (kafka 0.11.0.0 API)";
+        parent.document.title="Predicate (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/PrintForeachAction.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/PrintForeachAction.html b/0110/javadoc/org/apache/kafka/streams/kstream/PrintForeachAction.html
index 76fa45e..2bc9fc8 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/PrintForeachAction.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/PrintForeachAction.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>PrintForeachAction (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>PrintForeachAction (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="PrintForeachAction (kafka 0.11.0.0 API)";
+        parent.document.title="PrintForeachAction (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/Reducer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/Reducer.html b/0110/javadoc/org/apache/kafka/streams/kstream/Reducer.html
index 1a4d4ad..9ceb4e7 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/Reducer.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/Reducer.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>Reducer (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>Reducer (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="Reducer (kafka 0.11.0.0 API)";
+        parent.document.title="Reducer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/SessionWindows.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/SessionWindows.html b/0110/javadoc/org/apache/kafka/streams/kstream/SessionWindows.html
index 8a70789..5316bca 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/SessionWindows.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/SessionWindows.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>SessionWindows (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>SessionWindows (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="SessionWindows (kafka 0.11.0.0 API)";
+        parent.document.title="SessionWindows (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/TimeWindows.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/TimeWindows.html b/0110/javadoc/org/apache/kafka/streams/kstream/TimeWindows.html
index 23f0016..9e48478 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/TimeWindows.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/TimeWindows.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>TimeWindows (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>TimeWindows (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="TimeWindows (kafka 0.11.0.0 API)";
+        parent.document.title="TimeWindows (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/Transformer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/Transformer.html b/0110/javadoc/org/apache/kafka/streams/kstream/Transformer.html
index f5e6a5a..c1046f2 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/Transformer.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/Transformer.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>Transformer (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>Transformer (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="Transformer (kafka 0.11.0.0 API)";
+        parent.document.title="Transformer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/TransformerSupplier.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/TransformerSupplier.html b/0110/javadoc/org/apache/kafka/streams/kstream/TransformerSupplier.html
index 0f07827..ac6e0c5 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/TransformerSupplier.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/TransformerSupplier.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>TransformerSupplier (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>TransformerSupplier (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="TransformerSupplier (kafka 0.11.0.0 API)";
+        parent.document.title="TransformerSupplier (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/UnlimitedWindows.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/UnlimitedWindows.html b/0110/javadoc/org/apache/kafka/streams/kstream/UnlimitedWindows.html
index f518ae9..bf1f7ad 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/UnlimitedWindows.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/UnlimitedWindows.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>UnlimitedWindows (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>UnlimitedWindows (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="UnlimitedWindows (kafka 0.11.0.0 API)";
+        parent.document.title="UnlimitedWindows (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/ValueJoiner.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/ValueJoiner.html b/0110/javadoc/org/apache/kafka/streams/kstream/ValueJoiner.html
index 8ce0457..29ebb85 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/ValueJoiner.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/ValueJoiner.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>ValueJoiner (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>ValueJoiner (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="ValueJoiner (kafka 0.11.0.0 API)";
+        parent.document.title="ValueJoiner (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/ValueMapper.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/ValueMapper.html b/0110/javadoc/org/apache/kafka/streams/kstream/ValueMapper.html
index c86d970..5ad76a6 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/ValueMapper.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/ValueMapper.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>ValueMapper (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>ValueMapper (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="ValueMapper (kafka 0.11.0.0 API)";
+        parent.document.title="ValueMapper (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/ValueTransformer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/ValueTransformer.html b/0110/javadoc/org/apache/kafka/streams/kstream/ValueTransformer.html
index 48e58ba..e1acda0 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/ValueTransformer.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/ValueTransformer.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>ValueTransformer (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>ValueTransformer (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="ValueTransformer (kafka 0.11.0.0 API)";
+        parent.document.title="ValueTransformer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/ValueTransformerSupplier.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/ValueTransformerSupplier.html b/0110/javadoc/org/apache/kafka/streams/kstream/ValueTransformerSupplier.html
index 25e85ef..457aecc 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/ValueTransformerSupplier.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/ValueTransformerSupplier.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>ValueTransformerSupplier (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>ValueTransformerSupplier (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="ValueTransformerSupplier (kafka 0.11.0.0 API)";
+        parent.document.title="ValueTransformerSupplier (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/Window.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/Window.html b/0110/javadoc/org/apache/kafka/streams/kstream/Window.html
index 4c0fc94..58ef8b9 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/Window.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/Window.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>Window (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>Window (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="Window (kafka 0.11.0.0 API)";
+        parent.document.title="Window (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/Windowed.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/Windowed.html b/0110/javadoc/org/apache/kafka/streams/kstream/Windowed.html
index d06667c..940f003 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/Windowed.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/Windowed.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>Windowed (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>Windowed (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="Windowed (kafka 0.11.0.0 API)";
+        parent.document.title="Windowed (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/Windows.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/Windows.html b/0110/javadoc/org/apache/kafka/streams/kstream/Windows.html
index 76967e1..b4c3d00 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/Windows.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/Windows.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>Windows (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>Windows (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="Windows (kafka 0.11.0.0 API)";
+        parent.document.title="Windows (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/package-frame.html b/0110/javadoc/org/apache/kafka/streams/kstream/package-frame.html
index cb0e7c3..d393e91 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/package-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>org.apache.kafka.streams.kstream (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>org.apache.kafka.streams.kstream (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/org/apache/kafka/streams/kstream/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/package-summary.html b/0110/javadoc/org/apache/kafka/streams/kstream/package-summary.html
index 21e710b..bb333ec 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/package-summary.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>org.apache.kafka.streams.kstream (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>org.apache.kafka.streams.kstream (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="org.apache.kafka.streams.kstream (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.streams.kstream (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/kstream/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/kstream/package-tree.html b/0110/javadoc/org/apache/kafka/streams/kstream/package-tree.html
index cf1c360..6da5983 100644
--- a/0110/javadoc/org/apache/kafka/streams/kstream/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/streams/kstream/package-tree.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>org.apache.kafka.streams.kstream Class Hierarchy (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>org.apache.kafka.streams.kstream Class Hierarchy (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="org.apache.kafka.streams.kstream Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.streams.kstream Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/package-frame.html b/0110/javadoc/org/apache/kafka/streams/package-frame.html
index 26bbf88..5121fb4 100644
--- a/0110/javadoc/org/apache/kafka/streams/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/streams/package-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>org.apache.kafka.streams (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>org.apache.kafka.streams (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/org/apache/kafka/streams/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/package-summary.html b/0110/javadoc/org/apache/kafka/streams/package-summary.html
index 0715883..35e1886 100644
--- a/0110/javadoc/org/apache/kafka/streams/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/streams/package-summary.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>org.apache.kafka.streams (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>org.apache.kafka.streams (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="org.apache.kafka.streams (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.streams (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/package-tree.html b/0110/javadoc/org/apache/kafka/streams/package-tree.html
index 815f19c..bd2a730 100644
--- a/0110/javadoc/org/apache/kafka/streams/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/streams/package-tree.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>org.apache.kafka.streams Class Hierarchy (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>org.apache.kafka.streams Class Hierarchy (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="org.apache.kafka.streams Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.streams Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/AbstractProcessor.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/AbstractProcessor.html b/0110/javadoc/org/apache/kafka/streams/processor/AbstractProcessor.html
index 569d1d8..2fbbbae 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/AbstractProcessor.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/AbstractProcessor.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>AbstractProcessor (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:56 BST 2017 -->
+<title>AbstractProcessor (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="AbstractProcessor (kafka 0.11.0.0 API)";
+        parent.document.title="AbstractProcessor (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/DefaultPartitionGrouper.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/DefaultPartitionGrouper.html b/0110/javadoc/org/apache/kafka/streams/processor/DefaultPartitionGrouper.html
index 7c5e20c..8e16b45 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/DefaultPartitionGrouper.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/DefaultPartitionGrouper.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>DefaultPartitionGrouper (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:56 BST 2017 -->
+<title>DefaultPartitionGrouper (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="DefaultPartitionGrouper (kafka 0.11.0.0 API)";
+        parent.document.title="DefaultPartitionGrouper (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/FailOnInvalidTimestamp.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/FailOnInvalidTimestamp.html b/0110/javadoc/org/apache/kafka/streams/processor/FailOnInvalidTimestamp.html
index 82db4e2..dd7f874 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/FailOnInvalidTimestamp.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/FailOnInvalidTimestamp.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>FailOnInvalidTimestamp (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:56 BST 2017 -->
+<title>FailOnInvalidTimestamp (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="FailOnInvalidTimestamp (kafka 0.11.0.0 API)";
+        parent.document.title="FailOnInvalidTimestamp (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/LogAndSkipOnInvalidTimestamp.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/LogAndSkipOnInvalidTimestamp.html b/0110/javadoc/org/apache/kafka/streams/processor/LogAndSkipOnInvalidTimestamp.html
index d387f24..d5184f0 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/LogAndSkipOnInvalidTimestamp.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/LogAndSkipOnInvalidTimestamp.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>LogAndSkipOnInvalidTimestamp (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:56 BST 2017 -->
+<title>LogAndSkipOnInvalidTimestamp (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="LogAndSkipOnInvalidTimestamp (kafka 0.11.0.0 API)";
+        parent.document.title="LogAndSkipOnInvalidTimestamp (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/PartitionGrouper.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/PartitionGrouper.html b/0110/javadoc/org/apache/kafka/streams/processor/PartitionGrouper.html
index 56dc0fb..72aefbe 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/PartitionGrouper.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/PartitionGrouper.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>PartitionGrouper (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:56 BST 2017 -->
+<title>PartitionGrouper (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="PartitionGrouper (kafka 0.11.0.0 API)";
+        parent.document.title="PartitionGrouper (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/Processor.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/Processor.html b/0110/javadoc/org/apache/kafka/streams/processor/Processor.html
index dfc4f36..87829e0 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/Processor.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/Processor.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>Processor (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:56 BST 2017 -->
+<title>Processor (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="Processor (kafka 0.11.0.0 API)";
+        parent.document.title="Processor (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/ProcessorContext.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/ProcessorContext.html b/0110/javadoc/org/apache/kafka/streams/processor/ProcessorContext.html
index 27f1f5e..4b0243b 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/ProcessorContext.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/ProcessorContext.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>ProcessorContext (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:56 BST 2017 -->
+<title>ProcessorContext (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="ProcessorContext (kafka 0.11.0.0 API)";
+        parent.document.title="ProcessorContext (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/ProcessorSupplier.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/ProcessorSupplier.html b/0110/javadoc/org/apache/kafka/streams/processor/ProcessorSupplier.html
index bf02193..6cc74d2 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/ProcessorSupplier.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/ProcessorSupplier.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>ProcessorSupplier (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:56 BST 2017 -->
+<title>ProcessorSupplier (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="ProcessorSupplier (kafka 0.11.0.0 API)";
+        parent.document.title="ProcessorSupplier (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/StateRestoreCallback.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/StateRestoreCallback.html b/0110/javadoc/org/apache/kafka/streams/processor/StateRestoreCallback.html
index c1a3456..7bbba94 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/StateRestoreCallback.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/StateRestoreCallback.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>StateRestoreCallback (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:56 BST 2017 -->
+<title>StateRestoreCallback (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="StateRestoreCallback (kafka 0.11.0.0 API)";
+        parent.document.title="StateRestoreCallback (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/processor/StateStore.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/processor/StateStore.html b/0110/javadoc/org/apache/kafka/streams/processor/StateStore.html
index 4e4e2ed..f5f8676 100644
--- a/0110/javadoc/org/apache/kafka/streams/processor/StateStore.html
+++ b/0110/javadoc/org/apache/kafka/streams/processor/StateStore.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>StateStore (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:56 BST 2017 -->
+<title>StateStore (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="StateStore (kafka 0.11.0.0 API)";
+        parent.document.title="StateStore (kafka 0.11.0.1 API)";
     }
 //-->
 </script>


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

Posted by da...@apache.org.
http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/admin/DeleteTopicsResult.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DeleteTopicsResult.html b/0110/javadoc/org/apache/kafka/clients/admin/DeleteTopicsResult.html
index f18f6aa..95ba1fc 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DeleteTopicsResult.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DeleteTopicsResult.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>DeleteTopicsResult (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>DeleteTopicsResult (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="DeleteTopicsResult (kafka 0.11.0.0 API)";
+        parent.document.title="DeleteTopicsResult (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/DescribeAclsOptions.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DescribeAclsOptions.html b/0110/javadoc/org/apache/kafka/clients/admin/DescribeAclsOptions.html
index 494159c..9c9ef5a 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DescribeAclsOptions.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DescribeAclsOptions.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>DescribeAclsOptions (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>DescribeAclsOptions (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="DescribeAclsOptions (kafka 0.11.0.0 API)";
+        parent.document.title="DescribeAclsOptions (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/DescribeAclsResult.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DescribeAclsResult.html b/0110/javadoc/org/apache/kafka/clients/admin/DescribeAclsResult.html
index 21afdd9..d291498 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DescribeAclsResult.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DescribeAclsResult.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>DescribeAclsResult (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>DescribeAclsResult (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="DescribeAclsResult (kafka 0.11.0.0 API)";
+        parent.document.title="DescribeAclsResult (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/DescribeClusterOptions.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DescribeClusterOptions.html b/0110/javadoc/org/apache/kafka/clients/admin/DescribeClusterOptions.html
index b74122f..8b0ae02 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DescribeClusterOptions.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DescribeClusterOptions.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>DescribeClusterOptions (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>DescribeClusterOptions (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="DescribeClusterOptions (kafka 0.11.0.0 API)";
+        parent.document.title="DescribeClusterOptions (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/DescribeClusterResult.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DescribeClusterResult.html b/0110/javadoc/org/apache/kafka/clients/admin/DescribeClusterResult.html
index abc4854..f16afeb 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DescribeClusterResult.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DescribeClusterResult.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>DescribeClusterResult (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:58 BST 2017 -->
+<title>DescribeClusterResult (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="DescribeClusterResult (kafka 0.11.0.0 API)";
+        parent.document.title="DescribeClusterResult (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/DescribeConfigsOptions.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DescribeConfigsOptions.html b/0110/javadoc/org/apache/kafka/clients/admin/DescribeConfigsOptions.html
index e066b3d..f0cac97 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DescribeConfigsOptions.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DescribeConfigsOptions.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>DescribeConfigsOptions (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:58 BST 2017 -->
+<title>DescribeConfigsOptions (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="DescribeConfigsOptions (kafka 0.11.0.0 API)";
+        parent.document.title="DescribeConfigsOptions (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/DescribeConfigsResult.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DescribeConfigsResult.html b/0110/javadoc/org/apache/kafka/clients/admin/DescribeConfigsResult.html
index 88850fe..1a86952 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DescribeConfigsResult.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DescribeConfigsResult.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>DescribeConfigsResult (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:58 BST 2017 -->
+<title>DescribeConfigsResult (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="DescribeConfigsResult (kafka 0.11.0.0 API)";
+        parent.document.title="DescribeConfigsResult (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/DescribeTopicsOptions.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DescribeTopicsOptions.html b/0110/javadoc/org/apache/kafka/clients/admin/DescribeTopicsOptions.html
index 97097ca..85d4eb8 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DescribeTopicsOptions.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DescribeTopicsOptions.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>DescribeTopicsOptions (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:58 BST 2017 -->
+<title>DescribeTopicsOptions (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="DescribeTopicsOptions (kafka 0.11.0.0 API)";
+        parent.document.title="DescribeTopicsOptions (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/DescribeTopicsResult.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/DescribeTopicsResult.html b/0110/javadoc/org/apache/kafka/clients/admin/DescribeTopicsResult.html
index c947568..1afd988 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/DescribeTopicsResult.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/DescribeTopicsResult.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>DescribeTopicsResult (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:58 BST 2017 -->
+<title>DescribeTopicsResult (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="DescribeTopicsResult (kafka 0.11.0.0 API)";
+        parent.document.title="DescribeTopicsResult (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/KafkaAdminClient.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/KafkaAdminClient.html b/0110/javadoc/org/apache/kafka/clients/admin/KafkaAdminClient.html
index 4b8989b..da82f8a 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/KafkaAdminClient.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/KafkaAdminClient.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>KafkaAdminClient (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:58 BST 2017 -->
+<title>KafkaAdminClient (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="KafkaAdminClient (kafka 0.11.0.0 API)";
+        parent.document.title="KafkaAdminClient (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/ListTopicsOptions.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/ListTopicsOptions.html b/0110/javadoc/org/apache/kafka/clients/admin/ListTopicsOptions.html
index 0b71b06..d969320 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/ListTopicsOptions.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/ListTopicsOptions.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ListTopicsOptions (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:58 BST 2017 -->
+<title>ListTopicsOptions (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="ListTopicsOptions (kafka 0.11.0.0 API)";
+        parent.document.title="ListTopicsOptions (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/ListTopicsResult.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/ListTopicsResult.html b/0110/javadoc/org/apache/kafka/clients/admin/ListTopicsResult.html
index 62ab6ce..576b3c5 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/ListTopicsResult.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/ListTopicsResult.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ListTopicsResult (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:58 BST 2017 -->
+<title>ListTopicsResult (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="ListTopicsResult (kafka 0.11.0.0 API)";
+        parent.document.title="ListTopicsResult (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/NewTopic.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/NewTopic.html b/0110/javadoc/org/apache/kafka/clients/admin/NewTopic.html
index 6ac964f..10e12c8 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/NewTopic.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/NewTopic.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>NewTopic (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:58 BST 2017 -->
+<title>NewTopic (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="NewTopic (kafka 0.11.0.0 API)";
+        parent.document.title="NewTopic (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/TopicDescription.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/TopicDescription.html b/0110/javadoc/org/apache/kafka/clients/admin/TopicDescription.html
index 1e86acd..55c7afb 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/TopicDescription.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/TopicDescription.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>TopicDescription (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:58 BST 2017 -->
+<title>TopicDescription (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="TopicDescription (kafka 0.11.0.0 API)";
+        parent.document.title="TopicDescription (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/TopicListing.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/TopicListing.html b/0110/javadoc/org/apache/kafka/clients/admin/TopicListing.html
index 567990d..cc5e093 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/TopicListing.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/TopicListing.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>TopicListing (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:58 BST 2017 -->
+<title>TopicListing (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="TopicListing (kafka 0.11.0.0 API)";
+        parent.document.title="TopicListing (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/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/package-frame.html b/0110/javadoc/org/apache/kafka/clients/admin/package-frame.html
index 854273e..58326aa 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/package-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>org.apache.kafka.clients.admin (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>org.apache.kafka.clients.admin (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/org/apache/kafka/clients/admin/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/package-summary.html b/0110/javadoc/org/apache/kafka/clients/admin/package-summary.html
index 403efd2..aef570c 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/package-summary.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>org.apache.kafka.clients.admin (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>org.apache.kafka.clients.admin (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="org.apache.kafka.clients.admin (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.clients.admin (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/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/admin/package-tree.html b/0110/javadoc/org/apache/kafka/clients/admin/package-tree.html
index e241509..6f92e49 100644
--- a/0110/javadoc/org/apache/kafka/clients/admin/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/clients/admin/package-tree.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>org.apache.kafka.clients.admin Class Hierarchy (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>org.apache.kafka.clients.admin Class Hierarchy (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="org.apache.kafka.clients.admin Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.clients.admin Class Hierarchy (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/consumer/CommitFailedException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/CommitFailedException.html b/0110/javadoc/org/apache/kafka/clients/consumer/CommitFailedException.html
index 7b8714d..208b179 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/CommitFailedException.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/CommitFailedException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:04 BST 2017 -->
-<title>CommitFailedException (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:55 BST 2017 -->
+<title>CommitFailedException (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="CommitFailedException (kafka 0.11.0.0 API)";
+        parent.document.title="CommitFailedException (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/consumer/Consumer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/Consumer.html b/0110/javadoc/org/apache/kafka/clients/consumer/Consumer.html
index 5c9a54d..62fd48d 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/Consumer.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/Consumer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:04 BST 2017 -->
-<title>Consumer (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:55 BST 2017 -->
+<title>Consumer (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="Consumer (kafka 0.11.0.0 API)";
+        parent.document.title="Consumer (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/consumer/ConsumerConfig.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerConfig.html b/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerConfig.html
index b6e8aa2..17a36c5 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerConfig.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerConfig.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:04 BST 2017 -->
-<title>ConsumerConfig (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:55 BST 2017 -->
+<title>ConsumerConfig (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="ConsumerConfig (kafka 0.11.0.0 API)";
+        parent.document.title="ConsumerConfig (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/consumer/ConsumerInterceptor.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerInterceptor.html b/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerInterceptor.html
index 4d0a28a..dbe578b 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerInterceptor.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerInterceptor.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:04 BST 2017 -->
-<title>ConsumerInterceptor (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:55 BST 2017 -->
+<title>ConsumerInterceptor (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="ConsumerInterceptor (kafka 0.11.0.0 API)";
+        parent.document.title="ConsumerInterceptor (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/consumer/ConsumerRebalanceListener.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRebalanceListener.html b/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRebalanceListener.html
index 442f331..8855e9f 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRebalanceListener.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRebalanceListener.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:04 BST 2017 -->
-<title>ConsumerRebalanceListener (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:55 BST 2017 -->
+<title>ConsumerRebalanceListener (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="ConsumerRebalanceListener (kafka 0.11.0.0 API)";
+        parent.document.title="ConsumerRebalanceListener (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -202,8 +202,17 @@
  <p>
  For examples on usage of this API, see Usage Examples section of <a href="../../../../../org/apache/kafka/clients/consumer/KafkaConsumer.html" title="class in org.apache.kafka.clients.consumer"><code>KafkaConsumer</code></a>
  <p>
- <b>NOTE:</b> This method is only called before rebalances. It is not called prior to <a href="../../../../../org/apache/kafka/clients/consumer/KafkaConsumer.html#close()"><code>KafkaConsumer.close()</code></a>.</div>
-<dl><dt><span class="strong">Parameters:</span></dt><dd><code>partitions</code> - The list of partitions that were assigned to the consumer on the last rebalance</dd></dl>
+ <b>NOTE:</b> This method is only called before rebalances. It is not called prior to <a href="../../../../../org/apache/kafka/clients/consumer/KafkaConsumer.html#close()"><code>KafkaConsumer.close()</code></a>.
+ <p>
+ It is common for the revocation callback to use the consumer instance in order to commit offsets. It is possible
+ for a <a href="../../../../../org/apache/kafka/common/errors/WakeupException.html" title="class in org.apache.kafka.common.errors"><code>WakeupException</code></a> or <a href="../../../../../org/apache/kafka/common/errors/InterruptException.html" title="class in org.apache.kafka.common.errors"><code>InterruptException</code></a>
+ to be raised from one these nested invocations. In this case, the exception will be propagated to the current
+ invocation of <a href="../../../../../org/apache/kafka/clients/consumer/KafkaConsumer.html#poll(long)"><code>KafkaConsumer.poll(long)</code></a> in which this callback is being executed. This means it is not
+ necessary to catch these exceptions and re-attempt to wakeup or interrupt the consumer thread.</div>
+<dl><dt><span class="strong">Parameters:</span></dt><dd><code>partitions</code> - The list of partitions that were assigned to the consumer on the last rebalance</dd>
+<dt><span class="strong">Throws:</span></dt>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/WakeupException.html" title="class in org.apache.kafka.common.errors">WakeupException</a></code> - If raised from a nested call to <a href="../../../../../org/apache/kafka/clients/consumer/KafkaConsumer.html" title="class in org.apache.kafka.clients.consumer"><code>KafkaConsumer</code></a></dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/InterruptException.html" title="class in org.apache.kafka.common.errors">InterruptException</a></code> - If raised from a nested call to <a href="../../../../../org/apache/kafka/clients/consumer/KafkaConsumer.html" title="class in org.apache.kafka.clients.consumer"><code>KafkaConsumer</code></a></dd></dl>
 </li>
 </ul>
 <a name="onPartitionsAssigned(java.util.Collection)">
@@ -219,9 +228,18 @@
  <p>
  It is guaranteed that all the processes in a consumer group will execute their
  <a href="../../../../../org/apache/kafka/clients/consumer/ConsumerRebalanceListener.html#onPartitionsRevoked(java.util.Collection)"><code>onPartitionsRevoked(Collection)</code></a> callback before any instance executes its
- <a href="../../../../../org/apache/kafka/clients/consumer/ConsumerRebalanceListener.html#onPartitionsAssigned(java.util.Collection)"><code>onPartitionsAssigned(Collection)</code></a> callback.</div>
+ <a href="../../../../../org/apache/kafka/clients/consumer/ConsumerRebalanceListener.html#onPartitionsAssigned(java.util.Collection)"><code>onPartitionsAssigned(Collection)</code></a> callback.
+ <p>
+ It is common for the assignment callback to use the consumer instance in order to query offsets. It is possible
+ for a <a href="../../../../../org/apache/kafka/common/errors/WakeupException.html" title="class in org.apache.kafka.common.errors"><code>WakeupException</code></a> or <a href="../../../../../org/apache/kafka/common/errors/InterruptException.html" title="class in org.apache.kafka.common.errors"><code>InterruptException</code></a>
+ to be raised from one these nested invocations. In this case, the exception will be propagated to the current
+ invocation of <a href="../../../../../org/apache/kafka/clients/consumer/KafkaConsumer.html#poll(long)"><code>KafkaConsumer.poll(long)</code></a> in which this callback is being executed. This means it is not
+ necessary to catch these exceptions and re-attempt to wakeup or interrupt the consumer thread.</div>
 <dl><dt><span class="strong">Parameters:</span></dt><dd><code>partitions</code> - The list of partitions that are now assigned to the consumer (may include partitions previously
-            assigned to the consumer)</dd></dl>
+            assigned to the consumer)</dd>
+<dt><span class="strong">Throws:</span></dt>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/WakeupException.html" title="class in org.apache.kafka.common.errors">WakeupException</a></code> - If raised from a nested call to <a href="../../../../../org/apache/kafka/clients/consumer/KafkaConsumer.html" title="class in org.apache.kafka.clients.consumer"><code>KafkaConsumer</code></a></dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/InterruptException.html" title="class in org.apache.kafka.common.errors">InterruptException</a></code> - If raised from a nested call to <a href="../../../../../org/apache/kafka/clients/consumer/KafkaConsumer.html" title="class in org.apache.kafka.clients.consumer"><code>KafkaConsumer</code></a></dd></dl>
 </li>
 </ul>
 </li>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRecord.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRecord.html b/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRecord.html
index 74419e7..d7dc801 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRecord.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRecord.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:04 BST 2017 -->
-<title>ConsumerRecord (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:55 BST 2017 -->
+<title>ConsumerRecord (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="ConsumerRecord (kafka 0.11.0.0 API)";
+        parent.document.title="ConsumerRecord (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/consumer/ConsumerRecords.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRecords.html b/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRecords.html
index 8b9532d..edaf246 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRecords.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/ConsumerRecords.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:04 BST 2017 -->
-<title>ConsumerRecords (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:55 BST 2017 -->
+<title>ConsumerRecords (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="ConsumerRecords (kafka 0.11.0.0 API)";
+        parent.document.title="ConsumerRecords (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/consumer/InvalidOffsetException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/InvalidOffsetException.html b/0110/javadoc/org/apache/kafka/clients/consumer/InvalidOffsetException.html
index 7347cbf..e6befbc 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/InvalidOffsetException.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/InvalidOffsetException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:04 BST 2017 -->
-<title>InvalidOffsetException (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:55 BST 2017 -->
+<title>InvalidOffsetException (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="InvalidOffsetException (kafka 0.11.0.0 API)";
+        parent.document.title="InvalidOffsetException (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/consumer/KafkaConsumer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/KafkaConsumer.html b/0110/javadoc/org/apache/kafka/clients/consumer/KafkaConsumer.html
index 6eeb267..a6dbc59 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/KafkaConsumer.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/KafkaConsumer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>KafkaConsumer (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:55 BST 2017 -->
+<title>KafkaConsumer (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="KafkaConsumer (kafka 0.11.0.0 API)";
+        parent.document.title="KafkaConsumer (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/consumer/MockConsumer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/MockConsumer.html b/0110/javadoc/org/apache/kafka/clients/consumer/MockConsumer.html
index dbd6ecd..f941255 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/MockConsumer.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/MockConsumer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>MockConsumer (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:55 BST 2017 -->
+<title>MockConsumer (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="MockConsumer (kafka 0.11.0.0 API)";
+        parent.document.title="MockConsumer (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/consumer/NoOffsetForPartitionException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/NoOffsetForPartitionException.html b/0110/javadoc/org/apache/kafka/clients/consumer/NoOffsetForPartitionException.html
index fa0cff4..0da7713 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/NoOffsetForPartitionException.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/NoOffsetForPartitionException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>NoOffsetForPartitionException (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:55 BST 2017 -->
+<title>NoOffsetForPartitionException (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="NoOffsetForPartitionException (kafka 0.11.0.0 API)";
+        parent.document.title="NoOffsetForPartitionException (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/consumer/OffsetAndMetadata.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/OffsetAndMetadata.html b/0110/javadoc/org/apache/kafka/clients/consumer/OffsetAndMetadata.html
index 3eec682..ba51585 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/OffsetAndMetadata.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/OffsetAndMetadata.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>OffsetAndMetadata (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:55 BST 2017 -->
+<title>OffsetAndMetadata (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="OffsetAndMetadata (kafka 0.11.0.0 API)";
+        parent.document.title="OffsetAndMetadata (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/consumer/OffsetAndTimestamp.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/OffsetAndTimestamp.html b/0110/javadoc/org/apache/kafka/clients/consumer/OffsetAndTimestamp.html
index 9f10fc4..5963841 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/OffsetAndTimestamp.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/OffsetAndTimestamp.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>OffsetAndTimestamp (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:55 BST 2017 -->
+<title>OffsetAndTimestamp (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="OffsetAndTimestamp (kafka 0.11.0.0 API)";
+        parent.document.title="OffsetAndTimestamp (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/consumer/OffsetCommitCallback.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/OffsetCommitCallback.html b/0110/javadoc/org/apache/kafka/clients/consumer/OffsetCommitCallback.html
index 5b5a13b..2b9d5fd 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/OffsetCommitCallback.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/OffsetCommitCallback.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>OffsetCommitCallback (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:55 BST 2017 -->
+<title>OffsetCommitCallback (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="OffsetCommitCallback (kafka 0.11.0.0 API)";
+        parent.document.title="OffsetCommitCallback (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/consumer/OffsetOutOfRangeException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/OffsetOutOfRangeException.html b/0110/javadoc/org/apache/kafka/clients/consumer/OffsetOutOfRangeException.html
index 902aad4..e671b0b 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/OffsetOutOfRangeException.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/OffsetOutOfRangeException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>OffsetOutOfRangeException (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:55 BST 2017 -->
+<title>OffsetOutOfRangeException (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="OffsetOutOfRangeException (kafka 0.11.0.0 API)";
+        parent.document.title="OffsetOutOfRangeException (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/consumer/OffsetResetStrategy.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/OffsetResetStrategy.html b/0110/javadoc/org/apache/kafka/clients/consumer/OffsetResetStrategy.html
index 884b291..5f6eef6 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/OffsetResetStrategy.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/OffsetResetStrategy.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>OffsetResetStrategy (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:55 BST 2017 -->
+<title>OffsetResetStrategy (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="OffsetResetStrategy (kafka 0.11.0.0 API)";
+        parent.document.title="OffsetResetStrategy (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/consumer/RangeAssignor.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/RangeAssignor.html b/0110/javadoc/org/apache/kafka/clients/consumer/RangeAssignor.html
index 8ac26b0..4f5e009 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/RangeAssignor.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/RangeAssignor.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>RangeAssignor (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:55 BST 2017 -->
+<title>RangeAssignor (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="RangeAssignor (kafka 0.11.0.0 API)";
+        parent.document.title="RangeAssignor (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/consumer/RetriableCommitFailedException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/RetriableCommitFailedException.html b/0110/javadoc/org/apache/kafka/clients/consumer/RetriableCommitFailedException.html
index 7845bc7..525d25a 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/RetriableCommitFailedException.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/RetriableCommitFailedException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>RetriableCommitFailedException (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:55 BST 2017 -->
+<title>RetriableCommitFailedException (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="RetriableCommitFailedException (kafka 0.11.0.0 API)";
+        parent.document.title="RetriableCommitFailedException (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/consumer/RoundRobinAssignor.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/RoundRobinAssignor.html b/0110/javadoc/org/apache/kafka/clients/consumer/RoundRobinAssignor.html
index 3f7580b..aaf7354 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/RoundRobinAssignor.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/RoundRobinAssignor.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>RoundRobinAssignor (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:55 BST 2017 -->
+<title>RoundRobinAssignor (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="RoundRobinAssignor (kafka 0.11.0.0 API)";
+        parent.document.title="RoundRobinAssignor (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/consumer/StickyAssignor.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/StickyAssignor.html b/0110/javadoc/org/apache/kafka/clients/consumer/StickyAssignor.html
index 6866807..1bc8a75 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/StickyAssignor.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/StickyAssignor.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>StickyAssignor (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:55 BST 2017 -->
+<title>StickyAssignor (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="StickyAssignor (kafka 0.11.0.0 API)";
+        parent.document.title="StickyAssignor (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/consumer/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/package-frame.html b/0110/javadoc/org/apache/kafka/clients/consumer/package-frame.html
index 6ce7775..1286ac9 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/package-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>org.apache.kafka.clients.consumer (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>org.apache.kafka.clients.consumer (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/org/apache/kafka/clients/consumer/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/package-summary.html b/0110/javadoc/org/apache/kafka/clients/consumer/package-summary.html
index 2b913ee..0459953 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/package-summary.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>org.apache.kafka.clients.consumer (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>org.apache.kafka.clients.consumer (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="org.apache.kafka.clients.consumer (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.clients.consumer (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/consumer/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/consumer/package-tree.html b/0110/javadoc/org/apache/kafka/clients/consumer/package-tree.html
index 64175fa..8cb99f1 100644
--- a/0110/javadoc/org/apache/kafka/clients/consumer/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/clients/consumer/package-tree.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>org.apache.kafka.clients.consumer Class Hierarchy (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>org.apache.kafka.clients.consumer Class Hierarchy (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="org.apache.kafka.clients.consumer Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.clients.consumer Class Hierarchy (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/producer/BufferExhaustedException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/BufferExhaustedException.html b/0110/javadoc/org/apache/kafka/clients/producer/BufferExhaustedException.html
index 88cd7de..738ca90 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/BufferExhaustedException.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/BufferExhaustedException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>BufferExhaustedException (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:58 BST 2017 -->
+<title>BufferExhaustedException (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="BufferExhaustedException (kafka 0.11.0.0 API)";
+        parent.document.title="BufferExhaustedException (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/producer/Callback.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/Callback.html b/0110/javadoc/org/apache/kafka/clients/producer/Callback.html
index 81f68cc..d593bff 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/Callback.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/Callback.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Callback (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:58 BST 2017 -->
+<title>Callback (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="Callback (kafka 0.11.0.0 API)";
+        parent.document.title="Callback (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/producer/KafkaProducer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/KafkaProducer.html b/0110/javadoc/org/apache/kafka/clients/producer/KafkaProducer.html
index 40cb7ad..fdee46d 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/KafkaProducer.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/KafkaProducer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>KafkaProducer (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:58 BST 2017 -->
+<title>KafkaProducer (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="KafkaProducer (kafka 0.11.0.0 API)";
+        parent.document.title="KafkaProducer (kafka 0.11.0.1 API)";
     }
 //-->
 </script>
@@ -478,8 +478,8 @@ implements <a href="../../../../../org/apache/kafka/clients/producer/Producer.ht
 <div class="block">Needs to be called before any other methods when the transactional.id is set in the configuration.
 
  This method does the following:
-   1. Ensures any transactions initiated by previous instances of the producer
-      are completed. If the previous instance had failed with a transaction in
+   1. Ensures any transactions initiated by previous instances of the producer with the same
+      transactional.id are completed. If the previous instance had failed with a transaction in
       progress, it will be aborted. If the last transaction had begun completion,
       but not yet finished, this method awaits its completion.
    2. Gets the internal producer id and epoch, used in all future transactional
@@ -488,8 +488,12 @@ implements <a href="../../../../../org/apache/kafka/clients/producer/Producer.ht
 <dt><strong>Specified by:</strong></dt>
 <dd><code><a href="../../../../../org/apache/kafka/clients/producer/Producer.html#initTransactions()">initTransactions</a></code>&nbsp;in interface&nbsp;<code><a href="../../../../../org/apache/kafka/clients/producer/Producer.html" title="interface in org.apache.kafka.clients.producer">Producer</a>&lt;<a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html" title="type parameter in KafkaProducer">K</a>,<a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html" title="type parameter in KafkaProducer">V</a>&gt;</code></dd>
 <dt><span class="strong">Throws:</span></dt>
-<dd><code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/IllegalStateException.html?is-external=true" title="class or interface in java.lang">IllegalStateException</a></code> - if the TransactionalId for the producer is not set
-         in the configuration.</dd></dl>
+<dd><code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/IllegalStateException.html?is-external=true" title="class or interface in java.lang">IllegalStateException</a></code> - if no transactional.id has been configured</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/UnsupportedVersionException.html" title="class in org.apache.kafka.common.errors">UnsupportedVersionException</a></code> - fatal error indicating the broker
+         does not support transactions (i.e. if its version is lower than 0.11.0.0)</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/AuthorizationException.html" title="class in org.apache.kafka.common.errors">AuthorizationException</a></code> - fatal error indicating that the configured
+         transactional.id is not authorized</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/KafkaException.html" title="class in org.apache.kafka.common">KafkaException</a></code> - if the producer has encountered a previous fatal error or for any other unexpected error</dd></dl>
 </li>
 </ul>
 <a name="beginTransaction()">
@@ -500,13 +504,20 @@ implements <a href="../../../../../org/apache/kafka/clients/producer/Producer.ht
 <h4>beginTransaction</h4>
 <pre>public&nbsp;void&nbsp;beginTransaction()
                       throws <a href="../../../../../org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors">ProducerFencedException</a></pre>
-<div class="block">Should be called before the start of each new transaction.</div>
+<div class="block">Should be called before the start of each new transaction. Note that prior to the first invocation
+ of this method, you must invoke <a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html#initTransactions()"><code>initTransactions()</code></a> exactly one time.</div>
 <dl>
 <dt><strong>Specified by:</strong></dt>
 <dd><code><a href="../../../../../org/apache/kafka/clients/producer/Producer.html#beginTransaction()">beginTransaction</a></code>&nbsp;in interface&nbsp;<code><a href="../../../../../org/apache/kafka/clients/producer/Producer.html" title="interface in org.apache.kafka.clients.producer">Producer</a>&lt;<a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html" title="type parameter in KafkaProducer">K</a>,<a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html" title="type parameter in KafkaProducer">V</a>&gt;</code></dd>
 <dt><span class="strong">Throws:</span></dt>
-<dd><code><a href="../../../../../org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors">ProducerFencedException</a></code> - if another producer is with the same
-         transactional.id is active.</dd></dl>
+<dd><code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/IllegalStateException.html?is-external=true" title="class or interface in java.lang">IllegalStateException</a></code> - if no transactional.id has been configured or if <a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html#initTransactions()"><code>initTransactions()</code></a>
+         has not yet been invoked</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors">ProducerFencedException</a></code> - if another producer with the same transactional.id is active</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/UnsupportedVersionException.html" title="class in org.apache.kafka.common.errors">UnsupportedVersionException</a></code> - fatal error indicating the broker
+         does not support transactions (i.e. if its version is lower than 0.11.0.0)</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/AuthorizationException.html" title="class in org.apache.kafka.common.errors">AuthorizationException</a></code> - fatal error indicating that the configured
+         transactional.id is not authorized</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/KafkaException.html" title="class in org.apache.kafka.common">KafkaException</a></code> - if the producer has encountered a previous fatal error or for any other unexpected error</dd></dl>
 </li>
 </ul>
 <a name="sendOffsetsToTransaction(java.util.Map, java.lang.String)">
@@ -528,8 +539,16 @@ implements <a href="../../../../../org/apache/kafka/clients/producer/Producer.ht
 <dt><strong>Specified by:</strong></dt>
 <dd><code><a href="../../../../../org/apache/kafka/clients/producer/Producer.html#sendOffsetsToTransaction(java.util.Map,%20java.lang.String)">sendOffsetsToTransaction</a></code>&nbsp;in interface&nbsp;<code><a href="../../../../../org/apache/kafka/clients/producer/Producer.html" title="interface in org.apache.kafka.clients.producer">Producer</a>&lt;<a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html" title="type parameter in KafkaProducer">K</a>,<a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html" title="type parameter in KafkaProducer">V</a>&gt;</code></dd>
 <dt><span class="strong">Throws:</span></dt>
-<dd><code><a href="../../../../../org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors">ProducerFencedException</a></code> - if another producer with the same
-         transactional.id is active.</dd></dl>
+<dd><code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/IllegalStateException.html?is-external=true" title="class or interface in java.lang">IllegalStateException</a></code> - if no transactional.id has been configured or no transaction has been started</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors">ProducerFencedException</a></code> - fatal error indicating another producer with the same transactional.id is active</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/UnsupportedVersionException.html" title="class in org.apache.kafka.common.errors">UnsupportedVersionException</a></code> - fatal error indicating the broker
+         does not support transactions (i.e. if its version is lower than 0.11.0.0)</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/UnsupportedForMessageFormatException.html" title="class in org.apache.kafka.common.errors">UnsupportedForMessageFormatException</a></code> - fatal error indicating the message
+         format used for the offsets topic on the broker does not support transactions</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/AuthorizationException.html" title="class in org.apache.kafka.common.errors">AuthorizationException</a></code> - fatal error indicating that the configured
+         transactional.id is not authorized</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/KafkaException.html" title="class in org.apache.kafka.common">KafkaException</a></code> - if the producer has encountered a previous fatal or abortable error, or for any
+         other unexpected error</dd></dl>
 </li>
 </ul>
 <a name="commitTransaction()">
@@ -549,8 +568,14 @@ implements <a href="../../../../../org/apache/kafka/clients/producer/Producer.ht
 <dt><strong>Specified by:</strong></dt>
 <dd><code><a href="../../../../../org/apache/kafka/clients/producer/Producer.html#commitTransaction()">commitTransaction</a></code>&nbsp;in interface&nbsp;<code><a href="../../../../../org/apache/kafka/clients/producer/Producer.html" title="interface in org.apache.kafka.clients.producer">Producer</a>&lt;<a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html" title="type parameter in KafkaProducer">K</a>,<a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html" title="type parameter in KafkaProducer">V</a>&gt;</code></dd>
 <dt><span class="strong">Throws:</span></dt>
-<dd><code><a href="../../../../../org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors">ProducerFencedException</a></code> - if another producer with the same
-         transactional.id is active.</dd></dl>
+<dd><code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/IllegalStateException.html?is-external=true" title="class or interface in java.lang">IllegalStateException</a></code> - if no transactional.id has been configured or no transaction has been started</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors">ProducerFencedException</a></code> - fatal error indicating another producer with the same transactional.id is active</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/UnsupportedVersionException.html" title="class in org.apache.kafka.common.errors">UnsupportedVersionException</a></code> - fatal error indicating the broker
+         does not support transactions (i.e. if its version is lower than 0.11.0.0)</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/AuthorizationException.html" title="class in org.apache.kafka.common.errors">AuthorizationException</a></code> - fatal error indicating that the configured
+         transactional.id is not authorized</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/KafkaException.html" title="class in org.apache.kafka.common">KafkaException</a></code> - if the producer has encountered a previous fatal or abortable error, or for any
+         other unexpected error</dd></dl>
 </li>
 </ul>
 <a name="abortTransaction()">
@@ -568,8 +593,13 @@ implements <a href="../../../../../org/apache/kafka/clients/producer/Producer.ht
 <dt><strong>Specified by:</strong></dt>
 <dd><code><a href="../../../../../org/apache/kafka/clients/producer/Producer.html#abortTransaction()">abortTransaction</a></code>&nbsp;in interface&nbsp;<code><a href="../../../../../org/apache/kafka/clients/producer/Producer.html" title="interface in org.apache.kafka.clients.producer">Producer</a>&lt;<a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html" title="type parameter in KafkaProducer">K</a>,<a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html" title="type parameter in KafkaProducer">V</a>&gt;</code></dd>
 <dt><span class="strong">Throws:</span></dt>
-<dd><code><a href="../../../../../org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors">ProducerFencedException</a></code> - if another producer with the same
-         transactional.id is active.</dd></dl>
+<dd><code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/IllegalStateException.html?is-external=true" title="class or interface in java.lang">IllegalStateException</a></code> - if no transactional.id has been configured or no transaction has been started</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors">ProducerFencedException</a></code> - fatal error indicating another producer with the same transactional.id is active</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/UnsupportedVersionException.html" title="class in org.apache.kafka.common.errors">UnsupportedVersionException</a></code> - fatal error indicating the broker
+         does not support transactions (i.e. if its version is lower than 0.11.0.0)</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/errors/AuthorizationException.html" title="class in org.apache.kafka.common.errors">AuthorizationException</a></code> - fatal error indicating that the configured
+         transactional.id is not authorized</dd>
+<dd><code><a href="../../../../../org/apache/kafka/common/KafkaException.html" title="class in org.apache.kafka.common">KafkaException</a></code> - if the producer has encountered a previous fatal error or for any other unexpected error</dd></dl>
 </li>
 </ul>
 <a name="send(org.apache.kafka.clients.producer.ProducerRecord)">
@@ -658,7 +688,25 @@ implements <a href="../../../../../org/apache/kafka/clients/producer/Producer.ht
  <p>
  Some transactional send errors cannot be resolved with a call to <a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html#abortTransaction()"><code>abortTransaction()</code></a>.  In particular,
  if a transactional send finishes with a <a href="../../../../../org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors"><code>ProducerFencedException</code></a>, a <a href="../../../../../org/apache/kafka/common/errors/OutOfOrderSequenceException.html" title="class in org.apache.kafka.common.errors"><code>OutOfOrderSequenceException</code></a>,
- or any <a href="../../../../../org/apache/kafka/common/errors/AuthorizationException.html" title="class in org.apache.kafka.common.errors"><code>AuthorizationException</code></a>, then the only option left is to call <a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html#close()"><code>close()</code></a>.
+ a <a href="../../../../../org/apache/kafka/common/errors/UnsupportedVersionException.html" title="class in org.apache.kafka.common.errors"><code>UnsupportedVersionException</code></a>, or an
+ <a href="../../../../../org/apache/kafka/common/errors/AuthorizationException.html" title="class in org.apache.kafka.common.errors"><code>AuthorizationException</code></a>, then the only option left is to call <a href="../../../../../org/apache/kafka/clients/producer/KafkaProducer.html#close()"><code>close()</code></a>.
+ Fatal errors cause the producer to enter a defunct state in which future API calls will continue to raise
+ the same underyling error wrapped in a new <a href="../../../../../org/apache/kafka/common/KafkaException.html" title="class in org.apache.kafka.common"><code>KafkaException</code></a>.
+ </p>
+ <p>
+ It is a similar picture when idempotence is enabled, but no <code>transactional.id</code> has been configured.
+ In this case, <a href="../../../../../org/apache/kafka/common/errors/UnsupportedVersionException.html" title="class in org.apache.kafka.common.errors"><code>UnsupportedVersionException</code></a> and
+ <a href="../../../../../org/apache/kafka/common/errors/AuthorizationException.html" title="class in org.apache.kafka.common.errors"><code>AuthorizationException</code></a> are considered fatal errors. However,
+ <a href="../../../../../org/apache/kafka/common/errors/ProducerFencedException.html" title="class in org.apache.kafka.common.errors"><code>ProducerFencedException</code></a> does not need to be handled. Additionally, it is possible to continue
+ sending after receiving an <a href="../../../../../org/apache/kafka/common/errors/OutOfOrderSequenceException.html" title="class in org.apache.kafka.common.errors"><code>OutOfOrderSequenceException</code></a>, but doing so
+ can result in out of order delivery of pending messages. To ensure proper ordering, you should close the
+ producer and create a new instance.
+ </p>
+ <p>
+ If the message format of the destination topic is not upgraded to 0.11.0.0, idempotent and transactional
+ produce requests will fail with an <a href="../../../../../org/apache/kafka/common/errors/UnsupportedForMessageFormatException.html" title="class in org.apache.kafka.common.errors"><code>UnsupportedForMessageFormatException</code></a>
+ error. If this is encountered during a transaction, it is possible to abort and continue. But note that future
+ sends to the same topic will continue receiving the same exception until the topic is upgraded.
  </p>
  <p>
  Note that callbacks will generally execute in the I/O thread of the producer and so should be reasonably fast or
@@ -671,6 +719,7 @@ implements <a href="../../../../../org/apache/kafka/clients/producer/Producer.ht
 <dt><span class="strong">Parameters:</span></dt><dd><code>record</code> - The record to send</dd><dd><code>callback</code> - A user-supplied callback to execute when the record has been acknowledged by the server (null
         indicates no callback)</dd>
 <dt><span class="strong">Throws:</span></dt>
+<dd><code><a href="http://docs.oracle.com/javase/7/docs/api/java/lang/IllegalStateException.html?is-external=true" title="class or interface in java.lang">IllegalStateException</a></code> - if a transactional.id has been configured and no transaction has been started</dd>
 <dd><code><a href="../../../../../org/apache/kafka/common/errors/InterruptException.html" title="class in org.apache.kafka.common.errors">InterruptException</a></code> - If the thread is interrupted while blocked</dd>
 <dd><code><a href="../../../../../org/apache/kafka/common/errors/SerializationException.html" title="class in org.apache.kafka.common.errors">SerializationException</a></code> - If the key or value are not valid objects given the configured serializers</dd>
 <dd><code><a href="../../../../../org/apache/kafka/common/errors/TimeoutException.html" title="class in org.apache.kafka.common.errors">TimeoutException</a></code> - If the time taken for fetching metadata or allocating memory for the record has surpassed <code>max.block.ms</code>.</dd>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/clients/producer/MockProducer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/MockProducer.html b/0110/javadoc/org/apache/kafka/clients/producer/MockProducer.html
index 1e7e380..056a1b0 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/MockProducer.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/MockProducer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>MockProducer (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:58 BST 2017 -->
+<title>MockProducer (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="MockProducer (kafka 0.11.0.0 API)";
+        parent.document.title="MockProducer (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/producer/Partitioner.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/Partitioner.html b/0110/javadoc/org/apache/kafka/clients/producer/Partitioner.html
index a6e35f0..1e68b77 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/Partitioner.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/Partitioner.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Partitioner (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:58 BST 2017 -->
+<title>Partitioner (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="Partitioner (kafka 0.11.0.0 API)";
+        parent.document.title="Partitioner (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/producer/Producer.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/Producer.html b/0110/javadoc/org/apache/kafka/clients/producer/Producer.html
index 96538cc..87ce961 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/Producer.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/Producer.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Producer (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:58 BST 2017 -->
+<title>Producer (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="Producer (kafka 0.11.0.0 API)";
+        parent.document.title="Producer (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/producer/ProducerConfig.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/ProducerConfig.html b/0110/javadoc/org/apache/kafka/clients/producer/ProducerConfig.html
index 39d8584..233014a 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/ProducerConfig.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/ProducerConfig.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ProducerConfig (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:58 BST 2017 -->
+<title>ProducerConfig (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="ProducerConfig (kafka 0.11.0.0 API)";
+        parent.document.title="ProducerConfig (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/producer/ProducerInterceptor.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/clients/producer/ProducerInterceptor.html b/0110/javadoc/org/apache/kafka/clients/producer/ProducerInterceptor.html
index 792f3ac..4b50364 100644
--- a/0110/javadoc/org/apache/kafka/clients/producer/ProducerInterceptor.html
+++ b/0110/javadoc/org/apache/kafka/clients/producer/ProducerInterceptor.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ProducerInterceptor (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:58 BST 2017 -->
+<title>ProducerInterceptor (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="ProducerInterceptor (kafka 0.11.0.0 API)";
+        parent.document.title="ProducerInterceptor (kafka 0.11.0.1 API)";
     }
 //-->
 </script>


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

Posted by da...@apache.org.
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>


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

Posted by da...@apache.org.
http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/connector/Task.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/connector/Task.html b/0110/javadoc/org/apache/kafka/connect/connector/Task.html
index 3aea4ad..c0954cc 100644
--- a/0110/javadoc/org/apache/kafka/connect/connector/Task.html
+++ b/0110/javadoc/org/apache/kafka/connect/connector/Task.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:05 BST 2017 -->
-<title>Task (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:56 BST 2017 -->
+<title>Task (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="Task (kafka 0.11.0.0 API)";
+        parent.document.title="Task (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/connector/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/connector/package-frame.html b/0110/javadoc/org/apache/kafka/connect/connector/package-frame.html
index 21eed9f..d1050a1 100644
--- a/0110/javadoc/org/apache/kafka/connect/connector/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/connect/connector/package-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>org.apache.kafka.connect.connector (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>org.apache.kafka.connect.connector (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/org/apache/kafka/connect/connector/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/connector/package-summary.html b/0110/javadoc/org/apache/kafka/connect/connector/package-summary.html
index af2f3ad..4e4bcd6 100644
--- a/0110/javadoc/org/apache/kafka/connect/connector/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/connect/connector/package-summary.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>org.apache.kafka.connect.connector (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>org.apache.kafka.connect.connector (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="org.apache.kafka.connect.connector (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.connector (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/connector/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/connector/package-tree.html b/0110/javadoc/org/apache/kafka/connect/connector/package-tree.html
index 85690dd..29c7daf 100644
--- a/0110/javadoc/org/apache/kafka/connect/connector/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/connect/connector/package-tree.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>org.apache.kafka.connect.connector Class Hierarchy (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>org.apache.kafka.connect.connector Class Hierarchy (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="org.apache.kafka.connect.connector Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.connector Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/ConnectSchema.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/ConnectSchema.html b/0110/javadoc/org/apache/kafka/connect/data/ConnectSchema.html
index d6a4e7d..97288de 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/ConnectSchema.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/ConnectSchema.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConnectSchema (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:58 BST 2017 -->
+<title>ConnectSchema (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="ConnectSchema (kafka 0.11.0.0 API)";
+        parent.document.title="ConnectSchema (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/Date.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/Date.html b/0110/javadoc/org/apache/kafka/connect/data/Date.html
index 109a0c3..0bcdae5 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/Date.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/Date.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Date (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:58 BST 2017 -->
+<title>Date (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="Date (kafka 0.11.0.0 API)";
+        parent.document.title="Date (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/Decimal.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/Decimal.html b/0110/javadoc/org/apache/kafka/connect/data/Decimal.html
index 0a8e4d4..c641496 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/Decimal.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/Decimal.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Decimal (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:58 BST 2017 -->
+<title>Decimal (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="Decimal (kafka 0.11.0.0 API)";
+        parent.document.title="Decimal (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/Field.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/Field.html b/0110/javadoc/org/apache/kafka/connect/data/Field.html
index 14d6ef5..819f122 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/Field.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/Field.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Field (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:58 BST 2017 -->
+<title>Field (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="Field (kafka 0.11.0.0 API)";
+        parent.document.title="Field (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/Schema.Type.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/Schema.Type.html b/0110/javadoc/org/apache/kafka/connect/data/Schema.Type.html
index 84ccf7e..0285740 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/Schema.Type.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/Schema.Type.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Schema.Type (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:58 BST 2017 -->
+<title>Schema.Type (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="Schema.Type (kafka 0.11.0.0 API)";
+        parent.document.title="Schema.Type (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/Schema.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/Schema.html b/0110/javadoc/org/apache/kafka/connect/data/Schema.html
index 2298b0e..b0a54f4 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/Schema.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/Schema.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Schema (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:58 BST 2017 -->
+<title>Schema (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="Schema (kafka 0.11.0.0 API)";
+        parent.document.title="Schema (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/SchemaAndValue.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/SchemaAndValue.html b/0110/javadoc/org/apache/kafka/connect/data/SchemaAndValue.html
index b8e0266..ff3b12f 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/SchemaAndValue.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/SchemaAndValue.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>SchemaAndValue (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:58 BST 2017 -->
+<title>SchemaAndValue (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="SchemaAndValue (kafka 0.11.0.0 API)";
+        parent.document.title="SchemaAndValue (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/SchemaBuilder.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/SchemaBuilder.html b/0110/javadoc/org/apache/kafka/connect/data/SchemaBuilder.html
index 0a46c2a..eb4e7f7 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/SchemaBuilder.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/SchemaBuilder.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>SchemaBuilder (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:58 BST 2017 -->
+<title>SchemaBuilder (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="SchemaBuilder (kafka 0.11.0.0 API)";
+        parent.document.title="SchemaBuilder (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/SchemaProjector.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/SchemaProjector.html b/0110/javadoc/org/apache/kafka/connect/data/SchemaProjector.html
index d5d3265..4e8090a 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/SchemaProjector.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/SchemaProjector.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>SchemaProjector (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:58 BST 2017 -->
+<title>SchemaProjector (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="SchemaProjector (kafka 0.11.0.0 API)";
+        parent.document.title="SchemaProjector (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/Struct.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/Struct.html b/0110/javadoc/org/apache/kafka/connect/data/Struct.html
index ebb288a..29705f0 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/Struct.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/Struct.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Struct (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:58 BST 2017 -->
+<title>Struct (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="Struct (kafka 0.11.0.0 API)";
+        parent.document.title="Struct (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/Time.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/Time.html b/0110/javadoc/org/apache/kafka/connect/data/Time.html
index 361c49b..ecf79b5 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/Time.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/Time.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Time (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:58 BST 2017 -->
+<title>Time (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="Time (kafka 0.11.0.0 API)";
+        parent.document.title="Time (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/Timestamp.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/Timestamp.html b/0110/javadoc/org/apache/kafka/connect/data/Timestamp.html
index 3653ffd..b6cfa47 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/Timestamp.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/Timestamp.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>Timestamp (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:58 BST 2017 -->
+<title>Timestamp (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="Timestamp (kafka 0.11.0.0 API)";
+        parent.document.title="Timestamp (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/package-frame.html b/0110/javadoc/org/apache/kafka/connect/data/package-frame.html
index 210b413..ed8bb88 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/package-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>org.apache.kafka.connect.data (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>org.apache.kafka.connect.data (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/org/apache/kafka/connect/data/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/package-summary.html b/0110/javadoc/org/apache/kafka/connect/data/package-summary.html
index 74c0161..3a96d0f 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/package-summary.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>org.apache.kafka.connect.data (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>org.apache.kafka.connect.data (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="org.apache.kafka.connect.data (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.data (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/data/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/data/package-tree.html b/0110/javadoc/org/apache/kafka/connect/data/package-tree.html
index 8860de3..a0cf507 100644
--- a/0110/javadoc/org/apache/kafka/connect/data/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/connect/data/package-tree.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>org.apache.kafka.connect.data Class Hierarchy (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>org.apache.kafka.connect.data Class Hierarchy (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="org.apache.kafka.connect.data Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.data Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/errors/AlreadyExistsException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/errors/AlreadyExistsException.html b/0110/javadoc/org/apache/kafka/connect/errors/AlreadyExistsException.html
index 31a8321..09986f2 100644
--- a/0110/javadoc/org/apache/kafka/connect/errors/AlreadyExistsException.html
+++ b/0110/javadoc/org/apache/kafka/connect/errors/AlreadyExistsException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>AlreadyExistsException (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>AlreadyExistsException (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="AlreadyExistsException (kafka 0.11.0.0 API)";
+        parent.document.title="AlreadyExistsException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/errors/ConnectException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/errors/ConnectException.html b/0110/javadoc/org/apache/kafka/connect/errors/ConnectException.html
index a7035ea..94206e5 100644
--- a/0110/javadoc/org/apache/kafka/connect/errors/ConnectException.html
+++ b/0110/javadoc/org/apache/kafka/connect/errors/ConnectException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>ConnectException (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>ConnectException (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="ConnectException (kafka 0.11.0.0 API)";
+        parent.document.title="ConnectException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/errors/DataException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/errors/DataException.html b/0110/javadoc/org/apache/kafka/connect/errors/DataException.html
index ce9717e..cff918a 100644
--- a/0110/javadoc/org/apache/kafka/connect/errors/DataException.html
+++ b/0110/javadoc/org/apache/kafka/connect/errors/DataException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>DataException (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>DataException (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="DataException (kafka 0.11.0.0 API)";
+        parent.document.title="DataException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/errors/IllegalWorkerStateException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/errors/IllegalWorkerStateException.html b/0110/javadoc/org/apache/kafka/connect/errors/IllegalWorkerStateException.html
index 3075f98..302fc08 100644
--- a/0110/javadoc/org/apache/kafka/connect/errors/IllegalWorkerStateException.html
+++ b/0110/javadoc/org/apache/kafka/connect/errors/IllegalWorkerStateException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>IllegalWorkerStateException (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>IllegalWorkerStateException (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="IllegalWorkerStateException (kafka 0.11.0.0 API)";
+        parent.document.title="IllegalWorkerStateException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/errors/NotFoundException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/errors/NotFoundException.html b/0110/javadoc/org/apache/kafka/connect/errors/NotFoundException.html
index 6393180..633ca3f 100644
--- a/0110/javadoc/org/apache/kafka/connect/errors/NotFoundException.html
+++ b/0110/javadoc/org/apache/kafka/connect/errors/NotFoundException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>NotFoundException (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>NotFoundException (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="NotFoundException (kafka 0.11.0.0 API)";
+        parent.document.title="NotFoundException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/errors/RetriableException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/errors/RetriableException.html b/0110/javadoc/org/apache/kafka/connect/errors/RetriableException.html
index c5526d4..c0ca4eb 100644
--- a/0110/javadoc/org/apache/kafka/connect/errors/RetriableException.html
+++ b/0110/javadoc/org/apache/kafka/connect/errors/RetriableException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>RetriableException (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>RetriableException (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="RetriableException (kafka 0.11.0.0 API)";
+        parent.document.title="RetriableException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/errors/SchemaBuilderException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/errors/SchemaBuilderException.html b/0110/javadoc/org/apache/kafka/connect/errors/SchemaBuilderException.html
index 7838331..cd9edaf 100644
--- a/0110/javadoc/org/apache/kafka/connect/errors/SchemaBuilderException.html
+++ b/0110/javadoc/org/apache/kafka/connect/errors/SchemaBuilderException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>SchemaBuilderException (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>SchemaBuilderException (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="SchemaBuilderException (kafka 0.11.0.0 API)";
+        parent.document.title="SchemaBuilderException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/errors/SchemaProjectorException.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/errors/SchemaProjectorException.html b/0110/javadoc/org/apache/kafka/connect/errors/SchemaProjectorException.html
index 2dab014..ba04be2 100644
--- a/0110/javadoc/org/apache/kafka/connect/errors/SchemaProjectorException.html
+++ b/0110/javadoc/org/apache/kafka/connect/errors/SchemaProjectorException.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>SchemaProjectorException (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>SchemaProjectorException (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="SchemaProjectorException (kafka 0.11.0.0 API)";
+        parent.document.title="SchemaProjectorException (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/errors/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/errors/package-frame.html b/0110/javadoc/org/apache/kafka/connect/errors/package-frame.html
index 9234fe7..bc93d6e 100644
--- a/0110/javadoc/org/apache/kafka/connect/errors/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/connect/errors/package-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>org.apache.kafka.connect.errors (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>org.apache.kafka.connect.errors (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/org/apache/kafka/connect/errors/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/errors/package-summary.html b/0110/javadoc/org/apache/kafka/connect/errors/package-summary.html
index 574cffd..7d526a1 100644
--- a/0110/javadoc/org/apache/kafka/connect/errors/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/connect/errors/package-summary.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>org.apache.kafka.connect.errors (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>org.apache.kafka.connect.errors (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="org.apache.kafka.connect.errors (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.errors (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/errors/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/errors/package-tree.html b/0110/javadoc/org/apache/kafka/connect/errors/package-tree.html
index cf9f4e2..2614e51 100644
--- a/0110/javadoc/org/apache/kafka/connect/errors/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/connect/errors/package-tree.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>org.apache.kafka.connect.errors Class Hierarchy (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>org.apache.kafka.connect.errors Class Hierarchy (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="org.apache.kafka.connect.errors Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.errors Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/sink/SinkConnector.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/sink/SinkConnector.html b/0110/javadoc/org/apache/kafka/connect/sink/SinkConnector.html
index adfc19a..645dc7b 100644
--- a/0110/javadoc/org/apache/kafka/connect/sink/SinkConnector.html
+++ b/0110/javadoc/org/apache/kafka/connect/sink/SinkConnector.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>SinkConnector (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:58 BST 2017 -->
+<title>SinkConnector (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="SinkConnector (kafka 0.11.0.0 API)";
+        parent.document.title="SinkConnector (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/sink/SinkRecord.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/sink/SinkRecord.html b/0110/javadoc/org/apache/kafka/connect/sink/SinkRecord.html
index 23f8fe3..dce5f98 100644
--- a/0110/javadoc/org/apache/kafka/connect/sink/SinkRecord.html
+++ b/0110/javadoc/org/apache/kafka/connect/sink/SinkRecord.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>SinkRecord (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:58 BST 2017 -->
+<title>SinkRecord (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="SinkRecord (kafka 0.11.0.0 API)";
+        parent.document.title="SinkRecord (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/sink/SinkTask.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/sink/SinkTask.html b/0110/javadoc/org/apache/kafka/connect/sink/SinkTask.html
index 00334fc..669da80 100644
--- a/0110/javadoc/org/apache/kafka/connect/sink/SinkTask.html
+++ b/0110/javadoc/org/apache/kafka/connect/sink/SinkTask.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>SinkTask (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:58 BST 2017 -->
+<title>SinkTask (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="SinkTask (kafka 0.11.0.0 API)";
+        parent.document.title="SinkTask (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/sink/SinkTaskContext.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/sink/SinkTaskContext.html b/0110/javadoc/org/apache/kafka/connect/sink/SinkTaskContext.html
index 981006a..1785c11 100644
--- a/0110/javadoc/org/apache/kafka/connect/sink/SinkTaskContext.html
+++ b/0110/javadoc/org/apache/kafka/connect/sink/SinkTaskContext.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>SinkTaskContext (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:58 BST 2017 -->
+<title>SinkTaskContext (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="SinkTaskContext (kafka 0.11.0.0 API)";
+        parent.document.title="SinkTaskContext (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/sink/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/sink/package-frame.html b/0110/javadoc/org/apache/kafka/connect/sink/package-frame.html
index b10eb18..9d12a9e 100644
--- a/0110/javadoc/org/apache/kafka/connect/sink/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/connect/sink/package-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>org.apache.kafka.connect.sink (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>org.apache.kafka.connect.sink (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/org/apache/kafka/connect/sink/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/sink/package-summary.html b/0110/javadoc/org/apache/kafka/connect/sink/package-summary.html
index aa591df..84e1da1 100644
--- a/0110/javadoc/org/apache/kafka/connect/sink/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/connect/sink/package-summary.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>org.apache.kafka.connect.sink (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>org.apache.kafka.connect.sink (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="org.apache.kafka.connect.sink (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.sink (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/sink/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/sink/package-tree.html b/0110/javadoc/org/apache/kafka/connect/sink/package-tree.html
index fe945f9..9bfc32d 100644
--- a/0110/javadoc/org/apache/kafka/connect/sink/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/connect/sink/package-tree.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>org.apache.kafka.connect.sink Class Hierarchy (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>org.apache.kafka.connect.sink Class Hierarchy (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="org.apache.kafka.connect.sink Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.sink Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/source/SourceConnector.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/source/SourceConnector.html b/0110/javadoc/org/apache/kafka/connect/source/SourceConnector.html
index bbef21f..14602e6 100644
--- a/0110/javadoc/org/apache/kafka/connect/source/SourceConnector.html
+++ b/0110/javadoc/org/apache/kafka/connect/source/SourceConnector.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>SourceConnector (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:56 BST 2017 -->
+<title>SourceConnector (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="SourceConnector (kafka 0.11.0.0 API)";
+        parent.document.title="SourceConnector (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/source/SourceRecord.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/source/SourceRecord.html b/0110/javadoc/org/apache/kafka/connect/source/SourceRecord.html
index ce271b0..b57c254 100644
--- a/0110/javadoc/org/apache/kafka/connect/source/SourceRecord.html
+++ b/0110/javadoc/org/apache/kafka/connect/source/SourceRecord.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>SourceRecord (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:56 BST 2017 -->
+<title>SourceRecord (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="SourceRecord (kafka 0.11.0.0 API)";
+        parent.document.title="SourceRecord (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/source/SourceTask.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/source/SourceTask.html b/0110/javadoc/org/apache/kafka/connect/source/SourceTask.html
index 64866be..b558645 100644
--- a/0110/javadoc/org/apache/kafka/connect/source/SourceTask.html
+++ b/0110/javadoc/org/apache/kafka/connect/source/SourceTask.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>SourceTask (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:56 BST 2017 -->
+<title>SourceTask (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="SourceTask (kafka 0.11.0.0 API)";
+        parent.document.title="SourceTask (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/source/SourceTaskContext.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/source/SourceTaskContext.html b/0110/javadoc/org/apache/kafka/connect/source/SourceTaskContext.html
index d51b24a..755a937 100644
--- a/0110/javadoc/org/apache/kafka/connect/source/SourceTaskContext.html
+++ b/0110/javadoc/org/apache/kafka/connect/source/SourceTaskContext.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>SourceTaskContext (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:56 BST 2017 -->
+<title>SourceTaskContext (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="SourceTaskContext (kafka 0.11.0.0 API)";
+        parent.document.title="SourceTaskContext (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/source/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/source/package-frame.html b/0110/javadoc/org/apache/kafka/connect/source/package-frame.html
index d64f0d6..6918957 100644
--- a/0110/javadoc/org/apache/kafka/connect/source/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/connect/source/package-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>org.apache.kafka.connect.source (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>org.apache.kafka.connect.source (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/org/apache/kafka/connect/source/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/source/package-summary.html b/0110/javadoc/org/apache/kafka/connect/source/package-summary.html
index e4e2836..a3e8e4d 100644
--- a/0110/javadoc/org/apache/kafka/connect/source/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/connect/source/package-summary.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>org.apache.kafka.connect.source (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>org.apache.kafka.connect.source (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="org.apache.kafka.connect.source (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.source (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/source/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/source/package-tree.html b/0110/javadoc/org/apache/kafka/connect/source/package-tree.html
index 47f90e0..500cf0c 100644
--- a/0110/javadoc/org/apache/kafka/connect/source/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/connect/source/package-tree.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>org.apache.kafka.connect.source Class Hierarchy (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>org.apache.kafka.connect.source Class Hierarchy (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="org.apache.kafka.connect.source Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.source Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/storage/Converter.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/storage/Converter.html b/0110/javadoc/org/apache/kafka/connect/storage/Converter.html
index 61eb20a..7758086 100644
--- a/0110/javadoc/org/apache/kafka/connect/storage/Converter.html
+++ b/0110/javadoc/org/apache/kafka/connect/storage/Converter.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>Converter (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>Converter (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="Converter (kafka 0.11.0.0 API)";
+        parent.document.title="Converter (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/storage/OffsetStorageReader.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/storage/OffsetStorageReader.html b/0110/javadoc/org/apache/kafka/connect/storage/OffsetStorageReader.html
index 7d48e7a..93dda73 100644
--- a/0110/javadoc/org/apache/kafka/connect/storage/OffsetStorageReader.html
+++ b/0110/javadoc/org/apache/kafka/connect/storage/OffsetStorageReader.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>OffsetStorageReader (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>OffsetStorageReader (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="OffsetStorageReader (kafka 0.11.0.0 API)";
+        parent.document.title="OffsetStorageReader (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/storage/StringConverter.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/storage/StringConverter.html b/0110/javadoc/org/apache/kafka/connect/storage/StringConverter.html
index 7bdd7ab..40617bd 100644
--- a/0110/javadoc/org/apache/kafka/connect/storage/StringConverter.html
+++ b/0110/javadoc/org/apache/kafka/connect/storage/StringConverter.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>StringConverter (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>StringConverter (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="StringConverter (kafka 0.11.0.0 API)";
+        parent.document.title="StringConverter (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/storage/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/storage/package-frame.html b/0110/javadoc/org/apache/kafka/connect/storage/package-frame.html
index d187160..217123c 100644
--- a/0110/javadoc/org/apache/kafka/connect/storage/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/connect/storage/package-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>org.apache.kafka.connect.storage (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>org.apache.kafka.connect.storage (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/org/apache/kafka/connect/storage/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/storage/package-summary.html b/0110/javadoc/org/apache/kafka/connect/storage/package-summary.html
index 0b8f753..b822a49 100644
--- a/0110/javadoc/org/apache/kafka/connect/storage/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/connect/storage/package-summary.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>org.apache.kafka.connect.storage (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>org.apache.kafka.connect.storage (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="org.apache.kafka.connect.storage (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.storage (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/storage/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/storage/package-tree.html b/0110/javadoc/org/apache/kafka/connect/storage/package-tree.html
index aa024db..403739a 100644
--- a/0110/javadoc/org/apache/kafka/connect/storage/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/connect/storage/package-tree.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>org.apache.kafka.connect.storage Class Hierarchy (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>org.apache.kafka.connect.storage Class Hierarchy (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="org.apache.kafka.connect.storage Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.storage Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/transforms/Transformation.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/transforms/Transformation.html b/0110/javadoc/org/apache/kafka/connect/transforms/Transformation.html
index eae7f8a..5afb82e 100644
--- a/0110/javadoc/org/apache/kafka/connect/transforms/Transformation.html
+++ b/0110/javadoc/org/apache/kafka/connect/transforms/Transformation.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>Transformation (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>Transformation (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="Transformation (kafka 0.11.0.0 API)";
+        parent.document.title="Transformation (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/transforms/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/transforms/package-frame.html b/0110/javadoc/org/apache/kafka/connect/transforms/package-frame.html
index ab0f047..83ff986 100644
--- a/0110/javadoc/org/apache/kafka/connect/transforms/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/connect/transforms/package-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>org.apache.kafka.connect.transforms (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>org.apache.kafka.connect.transforms (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/org/apache/kafka/connect/transforms/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/transforms/package-summary.html b/0110/javadoc/org/apache/kafka/connect/transforms/package-summary.html
index 80e9897..f68eaca 100644
--- a/0110/javadoc/org/apache/kafka/connect/transforms/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/connect/transforms/package-summary.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>org.apache.kafka.connect.transforms (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>org.apache.kafka.connect.transforms (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="org.apache.kafka.connect.transforms (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.transforms (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/transforms/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/transforms/package-tree.html b/0110/javadoc/org/apache/kafka/connect/transforms/package-tree.html
index 1e21809..b6779f6 100644
--- a/0110/javadoc/org/apache/kafka/connect/transforms/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/connect/transforms/package-tree.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>org.apache.kafka.connect.transforms Class Hierarchy (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>org.apache.kafka.connect.transforms Class Hierarchy (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="org.apache.kafka.connect.transforms Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.transforms Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/util/ConnectorUtils.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/util/ConnectorUtils.html b/0110/javadoc/org/apache/kafka/connect/util/ConnectorUtils.html
index d292fbe..c811e39 100644
--- a/0110/javadoc/org/apache/kafka/connect/util/ConnectorUtils.html
+++ b/0110/javadoc/org/apache/kafka/connect/util/ConnectorUtils.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>ConnectorUtils (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:58 BST 2017 -->
+<title>ConnectorUtils (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="ConnectorUtils (kafka 0.11.0.0 API)";
+        parent.document.title="ConnectorUtils (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/util/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/util/package-frame.html b/0110/javadoc/org/apache/kafka/connect/util/package-frame.html
index b4a6225..7ae6b16 100644
--- a/0110/javadoc/org/apache/kafka/connect/util/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/connect/util/package-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>org.apache.kafka.connect.util (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>org.apache.kafka.connect.util (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/org/apache/kafka/connect/util/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/util/package-summary.html b/0110/javadoc/org/apache/kafka/connect/util/package-summary.html
index 45a5a66..f41f31e 100644
--- a/0110/javadoc/org/apache/kafka/connect/util/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/connect/util/package-summary.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>org.apache.kafka.connect.util (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>org.apache.kafka.connect.util (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="org.apache.kafka.connect.util (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.util (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/connect/util/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/connect/util/package-tree.html b/0110/javadoc/org/apache/kafka/connect/util/package-tree.html
index 9ec6f62..952c49c 100644
--- a/0110/javadoc/org/apache/kafka/connect/util/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/connect/util/package-tree.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>org.apache.kafka.connect.util Class Hierarchy (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>org.apache.kafka.connect.util Class Hierarchy (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="org.apache.kafka.connect.util Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.connect.util Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/server/policy/AlterConfigPolicy.RequestMetadata.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/server/policy/AlterConfigPolicy.RequestMetadata.html b/0110/javadoc/org/apache/kafka/server/policy/AlterConfigPolicy.RequestMetadata.html
index c1af755..0be6841 100644
--- a/0110/javadoc/org/apache/kafka/server/policy/AlterConfigPolicy.RequestMetadata.html
+++ b/0110/javadoc/org/apache/kafka/server/policy/AlterConfigPolicy.RequestMetadata.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>AlterConfigPolicy.RequestMetadata (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:58 BST 2017 -->
+<title>AlterConfigPolicy.RequestMetadata (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="AlterConfigPolicy.RequestMetadata (kafka 0.11.0.0 API)";
+        parent.document.title="AlterConfigPolicy.RequestMetadata (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/server/policy/AlterConfigPolicy.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/server/policy/AlterConfigPolicy.html b/0110/javadoc/org/apache/kafka/server/policy/AlterConfigPolicy.html
index 146fb92..21090ce 100644
--- a/0110/javadoc/org/apache/kafka/server/policy/AlterConfigPolicy.html
+++ b/0110/javadoc/org/apache/kafka/server/policy/AlterConfigPolicy.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>AlterConfigPolicy (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:58 BST 2017 -->
+<title>AlterConfigPolicy (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="AlterConfigPolicy (kafka 0.11.0.0 API)";
+        parent.document.title="AlterConfigPolicy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/server/policy/CreateTopicPolicy.RequestMetadata.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/server/policy/CreateTopicPolicy.RequestMetadata.html b/0110/javadoc/org/apache/kafka/server/policy/CreateTopicPolicy.RequestMetadata.html
index 70a50e1..cba1009 100644
--- a/0110/javadoc/org/apache/kafka/server/policy/CreateTopicPolicy.RequestMetadata.html
+++ b/0110/javadoc/org/apache/kafka/server/policy/CreateTopicPolicy.RequestMetadata.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>CreateTopicPolicy.RequestMetadata (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:58 BST 2017 -->
+<title>CreateTopicPolicy.RequestMetadata (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="CreateTopicPolicy.RequestMetadata (kafka 0.11.0.0 API)";
+        parent.document.title="CreateTopicPolicy.RequestMetadata (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/server/policy/CreateTopicPolicy.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/server/policy/CreateTopicPolicy.html b/0110/javadoc/org/apache/kafka/server/policy/CreateTopicPolicy.html
index 25e2dbb..397bf8d 100644
--- a/0110/javadoc/org/apache/kafka/server/policy/CreateTopicPolicy.html
+++ b/0110/javadoc/org/apache/kafka/server/policy/CreateTopicPolicy.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:08 BST 2017 -->
-<title>CreateTopicPolicy (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:58 BST 2017 -->
+<title>CreateTopicPolicy (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="CreateTopicPolicy (kafka 0.11.0.0 API)";
+        parent.document.title="CreateTopicPolicy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/server/policy/package-frame.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/server/policy/package-frame.html b/0110/javadoc/org/apache/kafka/server/policy/package-frame.html
index 5a42ebc..8010242 100644
--- a/0110/javadoc/org/apache/kafka/server/policy/package-frame.html
+++ b/0110/javadoc/org/apache/kafka/server/policy/package-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>org.apache.kafka.server.policy (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>org.apache.kafka.server.policy (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/org/apache/kafka/server/policy/package-summary.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/server/policy/package-summary.html b/0110/javadoc/org/apache/kafka/server/policy/package-summary.html
index 0baf856..aeb71f2 100644
--- a/0110/javadoc/org/apache/kafka/server/policy/package-summary.html
+++ b/0110/javadoc/org/apache/kafka/server/policy/package-summary.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>org.apache.kafka.server.policy (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>org.apache.kafka.server.policy (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="org.apache.kafka.server.policy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.server.policy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/server/policy/package-tree.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/server/policy/package-tree.html b/0110/javadoc/org/apache/kafka/server/policy/package-tree.html
index 4cda990..9a19eb3 100644
--- a/0110/javadoc/org/apache/kafka/server/policy/package-tree.html
+++ b/0110/javadoc/org/apache/kafka/server/policy/package-tree.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>org.apache.kafka.server.policy Class Hierarchy (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>org.apache.kafka.server.policy Class Hierarchy (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="org.apache.kafka.server.policy Class Hierarchy (kafka 0.11.0.0 API)";
+        parent.document.title="org.apache.kafka.server.policy Class Hierarchy (kafka 0.11.0.1 API)";
     }
 //-->
 </script>

http://git-wip-us.apache.org/repos/asf/kafka-site/blob/a1278d06/0110/javadoc/org/apache/kafka/streams/KafkaClientSupplier.html
----------------------------------------------------------------------
diff --git a/0110/javadoc/org/apache/kafka/streams/KafkaClientSupplier.html b/0110/javadoc/org/apache/kafka/streams/KafkaClientSupplier.html
index 7f74c03..eba940c 100644
--- a/0110/javadoc/org/apache/kafka/streams/KafkaClientSupplier.html
+++ b/0110/javadoc/org/apache/kafka/streams/KafkaClientSupplier.html
@@ -2,15 +2,15 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Thu Jun 22 23:10:06 BST 2017 -->
-<title>KafkaClientSupplier (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:56 BST 2017 -->
+<title>KafkaClientSupplier (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="KafkaClientSupplier (kafka 0.11.0.0 API)";
+        parent.document.title="KafkaClientSupplier (kafka 0.11.0.1 API)";
     }
 //-->
 </script>