You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@storm.apache.org by bo...@apache.org on 2016/03/18 02:49:30 UTC

svn commit: r1735530 [2/2] - in /storm/branches/bobby-versioned-site: _plugins/ releases/0.10.0/ releases/0.9.6/

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/Trident-API-Overview.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/Trident-API-Overview.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/Trident-API-Overview.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/Trident-API-Overview.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Trident API Overview
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 
 The core data model in Trident is the "Stream", processed as a series of batches. A stream is partitioned among the nodes in the cluster, and operations applied to a stream are applied in parallel across each partition.
@@ -484,7 +483,7 @@ mystream.aggregate(new Count(), new Fiel
 
 Like partitionAggregate, aggregators for aggregate can be chained. However, if you chain a CombinerAggregator with a non-CombinerAggregator, Trident is unable to do the partial aggregation optimization.
 
-You can read more about how to use persistentAggregate in the [Trident state doc](https://github.com/apache/storm/wiki/Trident-state).
+You can read more about how to use persistentAggregate in the [Trident state doc](Trident-state.html).
 
 ## Operations on grouped streams
 
@@ -492,7 +491,7 @@ The groupBy operation repartitions the s
 
 ![Grouping](images/grouping.png)
 
-If you run aggregators on a grouped stream, the aggregation will be run within each group instead of against the whole batch. persistentAggregate can also be run on a GroupedStream, in which case the results will be stored in a [MapState](https://github.com/apache/storm/blob/{{page.version}}/storm-core/src/jvm/storm/trident/state/map/MapState.java) with the key being the grouping fields. You can read more about persistentAggregate in the [Trident state doc](Trident-state.html).
+If you run aggregators on a grouped stream, the aggregation will be run within each group instead of against the whole batch. persistentAggregate can also be run on a GroupedStream, in which case the results will be stored in a [MapState]({{page.git-blob-base}}/storm-core/src/jvm/storm/trident/state/map/MapState.java) with the key being the grouping fields. You can read more about persistentAggregate in the [Trident state doc](Trident-state.html).
 
 Like regular streams, aggregators on grouped streams can be chained.
 

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/Trident-spouts.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/Trident-spouts.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/Trident-spouts.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/Trident-spouts.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Trident Spouts
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 # Trident spouts
 
@@ -35,10 +34,10 @@ Even while processing multiple batches s
 
 Here are the following spout APIs available:
 
-1. [ITridentSpout](https://github.com/apache/storm/blob/{{page.version}}/storm-core/src/jvm/storm/trident/spout/ITridentSpout.java): The most general API that can support transactional or opaque transactional semantics. Generally you'll use one of the partitioned flavors of this API rather than this one directly.
-2. [IBatchSpout](https://github.com/apache/storm/blob/{{page.version}}/storm-core/src/jvm/storm/trident/spout/IBatchSpout.java): A non-transactional spout that emits batches of tuples at a time
-3. [IPartitionedTridentSpout](https://github.com/apache/storm/blob/{{page.version}}/storm-core/src/jvm/storm/trident/spout/IPartitionedTridentSpout.java): A transactional spout that reads from a partitioned data source (like a cluster of Kafka servers)
-4. [IOpaquePartitionedTridentSpout](https://github.com/apache/storm/blob/{{page.version}}/storm-core/src/jvm/storm/trident/spout/IOpaquePartitionedTridentSpout.java): An opaque transactional spout that reads from a partitioned data source
+1. [ITridentSpout]({{page.git-blob-base}}/storm-core/src/jvm/storm/trident/spout/ITridentSpout.java): The most general API that can support transactional or opaque transactional semantics. Generally you'll use one of the partitioned flavors of this API rather than this one directly.
+2. [IBatchSpout]({{page.git-blob-base}}/storm-core/src/jvm/storm/trident/spout/IBatchSpout.java): A non-transactional spout that emits batches of tuples at a time
+3. [IPartitionedTridentSpout]({{page.git-blob-base}}/storm-core/src/jvm/storm/trident/spout/IPartitionedTridentSpout.java): A transactional spout that reads from a partitioned data source (like a cluster of Kafka servers)
+4. [IOpaquePartitionedTridentSpout]({{page.git-blob-base}}/storm-core/src/jvm/storm/trident/spout/IOpaquePartitionedTridentSpout.java): An opaque transactional spout that reads from a partitioned data source
 
 And, like mentioned in the beginning of this tutorial, you can use regular IRichSpout's as well.
  

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/Trident-state.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/Trident-state.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/Trident-state.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/Trident-state.md Fri Mar 18 01:49:28 2016
@@ -1,7 +1,6 @@
 ---
 title: Trident State
 layout: documentation
-version: v0.10.0
 ---
 
 
@@ -29,7 +28,7 @@ Remember, Trident processes tuples as sm
 2. There's no overlap between batches of tuples (tuples are in one batch or another, never multiple).
 3. Every tuple is in a batch (no tuples are skipped)
 
-This is a pretty easy type of spout to understand, the stream is divided into fixed batches that never change. storm-contrib has [an implementation of a transactional spout](https://github.com/apache/storm/tree/{{page.version}}/external/storm-kafka/src/jvm/storm/kafka/trident/TransactionalTridentKafkaSpout.java) for Kafka.
+This is a pretty easy type of spout to understand, the stream is divided into fixed batches that never change. storm-contrib has [an implementation of a transactional spout]({{page.git-tree-base}}/external/storm-kafka/src/jvm/storm/kafka/trident/TransactionalTridentKafkaSpout.java) for Kafka.
 
 You might be wondering – why wouldn't you just always use a transactional spout? They're simple and easy to understand. One reason you might not use one is because they're not necessarily very fault-tolerant. For example, the way TransactionalTridentKafkaSpout works is the batch for a txid will contain tuples from all the Kafka partitions for a topic. Once a batch has been emitted, any time that batch is re-emitted in the future the exact same set of tuples must be emitted to meet the semantics of transactional spouts. Now suppose a batch is emitted from TransactionalTridentKafkaSpout, the batch fails to process, and at the same time one of the Kafka nodes goes down. You're now incapable of replaying the same batch as you did before (since the node is down and some partitions for the topic are not unavailable), and processing will halt. 
 
@@ -73,7 +72,7 @@ As described before, an opaque transacti
 
 1. Every tuple is *successfully* processed in exactly one batch. However, it's possible for a tuple to fail to process in one batch and then succeed to process in a later batch.
 
-[OpaqueTridentKafkaSpout](https://github.com/apache/storm/tree/{{page.version}}/external/storm-kafka/src/jvm/storm/kafka/trident/OpaqueTridentKafkaSpout.java) is a spout that has this property and is fault-tolerant to losing Kafka nodes. Whenever it's time for OpaqueTridentKafkaSpout to emit a batch, it emits tuples starting from where the last batch finished emitting. This ensures that no tuple is ever skipped or successfully processed by multiple batches.
+[OpaqueTridentKafkaSpout]({{page.git-tree-base}}/external/storm-kafka/src/jvm/storm/kafka/trident/OpaqueTridentKafkaSpout.java) is a spout that has this property and is fault-tolerant to losing Kafka nodes. Whenever it's time for OpaqueTridentKafkaSpout to emit a batch, it emits tuples starting from where the last batch finished emitting. This ensures that no tuple is ever skipped or successfully processed by multiple batches.
 
 With opaque transactional spouts, it's no longer possible to use the trick of skipping state updates if the transaction id in the database is the same as the transaction id for the current batch. This is because the batch may have changed between state updates.
 
@@ -310,7 +309,7 @@ public interface Snapshottable<T> extend
 }
 ```
 
-[MemoryMapState](https://github.com/apache/storm/blob/{{page.version}}/storm-core/src/jvm/storm/trident/testing/MemoryMapState.java) and [MemcachedState](https://github.com/nathanmarz/trident-memcached/blob/{{page.version}}/src/jvm/trident/memcached/MemcachedState.java) each implement both of these interfaces.
+[MemoryMapState]({{page.git-blob-base}}/storm-core/src/jvm/storm/trident/testing/MemoryMapState.java) and [MemcachedState](https://github.com/nathanmarz/trident-memcached/blob/{{page.version}}/src/jvm/trident/memcached/MemcachedState.java) each implement both of these interfaces.
 
 ## Implementing Map States
 
@@ -323,10 +322,10 @@ public interface IBackingMap<T> {
 }
 ```
 
-OpaqueMap's will call multiPut with [OpaqueValue](https://github.com/apache/storm/blob/{{page.version}}/storm-core/src/jvm/storm/trident/state/OpaqueValue.java)'s for the vals, TransactionalMap's will give [TransactionalValue](https://github.com/apache/storm/blob/{{page.version}}/storm-core/src/jvm/storm/trident/state/TransactionalValue.java)'s for the vals, and NonTransactionalMaps will just pass the objects from the topology through.
+OpaqueMap's will call multiPut with [OpaqueValue]({{page.git-blob-base}}/storm-core/src/jvm/storm/trident/state/OpaqueValue.java)'s for the vals, TransactionalMap's will give [TransactionalValue]({{page.git-blob-base}}/storm-core/src/jvm/storm/trident/state/TransactionalValue.java)'s for the vals, and NonTransactionalMaps will just pass the objects from the topology through.
 
-Trident also provides the [CachedMap](https://github.com/apache/storm/blob/{{page.version}}/storm-core/src/jvm/storm/trident/state/map/CachedMap.java) class to do automatic LRU caching of map key/vals.
+Trident also provides the [CachedMap]({{page.git-blob-base}}/storm-core/src/jvm/storm/trident/state/map/CachedMap.java) class to do automatic LRU caching of map key/vals.
 
-Finally, Trident provides the [SnapshottableMap](https://github.com/apache/storm/blob/{{page.version}}/storm-core/src/jvm/storm/trident/state/map/SnapshottableMap.java) class that turns a MapState into a Snapshottable object, by storing global aggregations into a fixed key.
+Finally, Trident provides the [SnapshottableMap]({{page.git-blob-base}}/storm-core/src/jvm/storm/trident/state/map/SnapshottableMap.java) class that turns a MapState into a Snapshottable object, by storing global aggregations into a fixed key.
 
 Take a look at the implementation of [MemcachedState](https://github.com/nathanmarz/trident-memcached/blob/master/src/jvm/trident/memcached/MemcachedState.java) to see how all these utilities can be put together to make a high performance MapState implementation. MemcachedState allows you to choose between opaque transactional, transactional, and non-transactional semantics.

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/Trident-tutorial.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/Trident-tutorial.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/Trident-tutorial.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/Trident-tutorial.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Trident Tutorial
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 
 Trident is a high-level abstraction for doing realtime computing on top of Storm. It allows you to seamlessly intermix high throughput (millions of messages per second), stateful stream processing with low latency distributed querying. If you're familiar with high level batch processing tools like Pig or Cascading, the concepts of Trident will be very familiar – Trident has joins, aggregations, grouping, functions, and filters. In addition to these, Trident adds primitives for doing stateful, incremental processing on top of any database or persistence store. Trident has consistent, exactly-once semantics, so it is easy to reason about Trident topologies.

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/Troubleshooting.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/Troubleshooting.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/Troubleshooting.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/Troubleshooting.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Troubleshooting
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 
 This page lists issues people have run into when using Storm along with their solutions.

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/Tutorial.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/Tutorial.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/Tutorial.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/Tutorial.md Fri Mar 18 01:49:28 2016
@@ -2,13 +2,12 @@
 title: Tutorial
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 In this tutorial, you'll learn how to create Storm topologies and deploy them to a Storm cluster. Java will be the main language used, but a few examples will use Python to illustrate Storm's multi-language capabilities.
 
 ## Preliminaries
 
-This tutorial uses examples from the [storm-starter](https://github.com/apache/storm/blob/{{page.version}}/examples/storm-starter) project. It's recommended that you clone the project and follow along with the examples. Read [Setting up a development environment](Setting-up-development-environment.html) and [Creating a new Storm project](Creating-a-new-Storm-project.html) to get your machine set up.
+This tutorial uses examples from the [storm-starter]({{page.git-blob-base}}/examples/storm-starter) project. It's recommended that you clone the project and follow along with the examples. Read [Setting up a development environment](Setting-up-development-environment.html) and [Creating a new Storm project](Creating-a-new-Storm-project.html) to get your machine set up.
 
 ## Components of a Storm cluster
 
@@ -246,7 +245,7 @@ A stream grouping tells a topology how t
 
 When a task for Bolt A emits a tuple to Bolt B, which task should it send the tuple to?
 
-A "stream grouping" answers this question by telling Storm how to send tuples between sets of tasks. Before we dig into the different kinds of stream groupings, let's take a look at another topology from [storm-starter](http://github.com/apache/storm/blob/{{page.version}}/examples/storm-starter). This [WordCountTopology](https://github.com/apache/storm/blob/{{page.version}}/examples/storm-starter/src/jvm/storm/starter/WordCountTopology.java) reads sentences off of a spout and streams out of `WordCountBolt` the total number of times it has seen that word before:
+A "stream grouping" answers this question by telling Storm how to send tuples between sets of tasks. Before we dig into the different kinds of stream groupings, let's take a look at another topology from [storm-starter](http://github.com/apache/storm/blob/{{page.version}}/examples/storm-starter). This [WordCountTopology]({{page.git-blob-base}}/examples/storm-starter/src/jvm/storm/starter/WordCountTopology.java) reads sentences off of a spout and streams out of `WordCountBolt` the total number of times it has seen that word before:
 
 ```java
 TopologyBuilder builder = new TopologyBuilder();

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/Understanding-the-parallelism-of-a-Storm-topology.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/Understanding-the-parallelism-of-a-Storm-topology.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/Understanding-the-parallelism-of-a-Storm-topology.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/Understanding-the-parallelism-of-a-Storm-topology.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Understanding the Parallelism of a Storm Topology
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 ## What makes a running topology: worker processes, executors and tasks
 

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/Using-non-JVM-languages-with-Storm.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/Using-non-JVM-languages-with-Storm.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/Using-non-JVM-languages-with-Storm.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/Using-non-JVM-languages-with-Storm.md Fri Mar 18 01:49:28 2016
@@ -1,7 +1,6 @@
 ---
 title: Using non JVM languages with Storm
 layout: documentation
-version: v0.10.0
 ---
 - two pieces: creating topologies and implementing spouts and bolts in other languages
 - creating topologies in another language is easy since topologies are just thrift structures (link to storm.thrift)

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/flux.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/flux.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/flux.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/flux.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Flux
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 
 A framework for creating and deploying Apache Storm streaming computations with less friction.

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/index.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/index.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/index.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/index.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Documentation
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 ### Basics of Storm
 

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/storm-eventhubs.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/storm-eventhubs.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/storm-eventhubs.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/storm-eventhubs.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Azue Event Hubs Integration
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 
 Storm spout and bolt implementation for Microsoft Azure Eventhubs

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/storm-hbase.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/storm-hbase.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/storm-hbase.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/storm-hbase.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Storm HBase Integration
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 
 Storm/Trident integration for [Apache HBase](https://hbase.apache.org)

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/storm-hdfs.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/storm-hdfs.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/storm-hdfs.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/storm-hdfs.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Storm HDFS Integration
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 
 Storm components for interacting with HDFS file systems

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/storm-hive.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/storm-hive.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/storm-hive.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/storm-hive.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Storm Hive Integration
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 
   Hive offers streaming API that allows data to be written continuously into Hive. The incoming data 

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/storm-jdbc.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/storm-jdbc.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/storm-jdbc.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/storm-jdbc.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Storm JDBC Integration
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 
 Storm/Trident integration for JDBC. This package includes the core bolts and trident states that allows a storm topology

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/storm-kafka.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/storm-kafka.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/storm-kafka.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/storm-kafka.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Storm Kafka Integration
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 
 Provides core Storm and Trident spout implementations for consuming data from Apache Kafka 0.8.x.

Modified: storm/branches/bobby-versioned-site/releases/0.10.0/storm-redis.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.10.0/storm-redis.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.10.0/storm-redis.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.10.0/storm-redis.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Storm Redis Integration
 layout: documentation
 documentation: true
-version: v0.10.0
 ---
 
 Storm/Trident integration for [Redis](http://redis.io/)

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Acking-framework-implementation.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Acking-framework-implementation.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Acking-framework-implementation.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Acking-framework-implementation.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 [Storm's acker](https://github.com/apache/incubator-storm/blob/46c3ba7/storm-core/src/clj/backtype/storm/daemon/acker.clj#L28) tracks completion of each tupletree with a checksum hash: each time a tuple is sent, its value is XORed into the checksum, and each time a tuple is acked its value is XORed in again. If all tuples have been successfully acked, the checksum will be zero (the odds that the checksum will be zero otherwise are vanishingly small).
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Clojure-DSL.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Clojure-DSL.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Clojure-DSL.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Clojure-DSL.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 Storm comes with a Clojure DSL for defining spouts, bolts, and topologies. The Clojure DSL has access to everything the Java API exposes, so if you're a Clojure user you can code Storm topologies without touching Java at all. The Clojure DSL is defined in the source in the [backtype.storm.clojure](https://github.com/apache/incubator-storm/blob/0.5.3/src/clj/backtype/storm/clojure.clj) namespace.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Command-line-client.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Command-line-client.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Command-line-client.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Command-line-client.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 This page describes all the commands that are possible with the "storm" command line client. To learn how to set up your "storm" client to talk to a remote cluster, follow the instructions in [Setting up development environment](Setting-up-a-development-environment.html).
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Common-patterns.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Common-patterns.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Common-patterns.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Common-patterns.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 
 This page lists a variety of common patterns in Storm topologies.

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Concepts.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Concepts.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Concepts.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Concepts.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 
 This page lists the main concepts of Storm and links to resources where you can find more information. The concepts discussed are:

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Configuration.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Configuration.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Configuration.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Configuration.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 Storm has a variety of configurations for tweaking the behavior of nimbus, supervisors, and running topologies. Some configurations are system configurations and cannot be modified on a topology by topology basis, whereas other configurations can be modified per topology. 
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Contributing-to-Storm.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Contributing-to-Storm.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Contributing-to-Storm.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Contributing-to-Storm.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 
 ### Getting started with contributing

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Creating-a-new-Storm-project.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Creating-a-new-Storm-project.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Creating-a-new-Storm-project.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Creating-a-new-Storm-project.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 This page outlines how to set up a Storm project for development. The steps are:
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/DSLs-and-multilang-adapters.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/DSLs-and-multilang-adapters.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/DSLs-and-multilang-adapters.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/DSLs-and-multilang-adapters.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 * [Scala DSL](https://github.com/velvia/ScalaStorm)
 * [JRuby DSL](https://github.com/colinsurprenant/redstorm)

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Defining-a-non-jvm-language-dsl-for-storm.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Defining-a-non-jvm-language-dsl-for-storm.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Defining-a-non-jvm-language-dsl-for-storm.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Defining-a-non-jvm-language-dsl-for-storm.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 The right place to start to learn how to make a non-JVM DSL for Storm is [storm-core/src/storm.thrift](https://github.com/apache/incubator-storm/blob/master/storm-core/src/storm.thrift). Since Storm topologies are just Thrift structures, and Nimbus is a Thrift daemon, you can create and submit topologies in any language.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Distributed-RPC.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Distributed-RPC.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Distributed-RPC.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Distributed-RPC.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 The idea behind distributed RPC (DRPC) is to parallelize the computation of really intense functions on the fly using Storm. The Storm topology takes in as input a stream of function arguments, and it emits an output stream of the results for each of those function calls. 
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Documentation.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Documentation.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Documentation.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Documentation.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 ### Basics of Storm
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/FAQ.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/FAQ.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/FAQ.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/FAQ.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 
 ## Best Practices

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Fault-tolerance.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Fault-tolerance.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Fault-tolerance.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Fault-tolerance.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 This page explains the design details of Storm that make it a fault-tolerant system.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Guaranteeing-message-processing.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Guaranteeing-message-processing.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Guaranteeing-message-processing.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Guaranteeing-message-processing.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 Storm guarantees that each message coming off a spout will be fully processed. This page describes how Storm accomplishes this guarantee and what you have to do as a user to benefit from Storm's reliability capabilities.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Hooks.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Hooks.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Hooks.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Hooks.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 Storm provides hooks with which you can insert custom code to run on any number of events within Storm. You create a hook by extending the [BaseTaskHook](javadocs/backtype/storm/hooks/BaseTaskHook.html) class and overriding the appropriate method for the event you want to catch. There are two ways to register your hook:
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Implementation-docs.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Implementation-docs.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Implementation-docs.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Implementation-docs.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 This section of the wiki is dedicated to explaining how Storm is implemented. You should have a good grasp of how to use Storm before reading these sections. 
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Installing-native-dependencies.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Installing-native-dependencies.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Installing-native-dependencies.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Installing-native-dependencies.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 The native dependencies are only needed on actual Storm clusters. When running Storm in local mode, Storm uses a pure Java messaging system so that you don't need to install native dependencies on your development machine.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Kestrel-and-Storm.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Kestrel-and-Storm.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Kestrel-and-Storm.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Kestrel-and-Storm.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 This page explains how to use to Storm to consume items from a Kestrel cluster.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Lifecycle-of-a-topology.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Lifecycle-of-a-topology.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Lifecycle-of-a-topology.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Lifecycle-of-a-topology.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 (**NOTE**: this page is based on the 0.7.1 code; many things have changed since then, including a split between tasks and executors, and a reorganization of the code under `storm-core/src` rather than `src/`.)
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Local-mode.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Local-mode.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Local-mode.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Local-mode.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 Local mode simulates a Storm cluster in process and is useful for developing and testing topologies. Running topologies in local mode is similar to running topologies [on a cluster](Running-topologies-on-a-production-cluster.html). 
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Maven.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Maven.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Maven.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Maven.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 To develop topologies, you'll need the Storm jars on your classpath. You should either include the unpacked jars in the classpath for your project or use Maven to include Storm as a development dependency. Storm is hosted on Clojars (a Maven repository). To include Storm in your project as a development dependency, add the following to your pom.xml:
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Message-passing-implementation.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Message-passing-implementation.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Message-passing-implementation.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Message-passing-implementation.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 (Note: this walkthrough is out of date as of 0.8.0. 0.8.0 revamped the message passing infrastructure to be based on the Disruptor)
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Metrics.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Metrics.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Metrics.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Metrics.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 Storm exposes a metrics interface to report summary statistics across the full topology.
 It's used internally to track the numbers you see in the Nimbus UI console: counts of executes and acks; average process latency per bolt; worker heap usage; and so forth.

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Multilang-protocol.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Multilang-protocol.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Multilang-protocol.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Multilang-protocol.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 This page explains the multilang protocol as of Storm 0.7.1. Versions prior to 0.7.1 used a somewhat different protocol, documented [here](Storm-multi-language-protocol-(versions-0.7.0-and-below\).html).
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Powered-By.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Powered-By.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Powered-By.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Powered-By.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 Want to be added to this page? Send an email [here](mailto:nathan.marz@gmail.com).
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Project-ideas.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Project-ideas.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Project-ideas.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Project-ideas.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
  * **DSLs for non-JVM languages:** These DSL's should be all-inclusive and not require any Java for the creation of topologies, spouts, or bolts. Since topologies are [Thrift](http://thrift.apache.org/) structs, Nimbus is a Thrift service, and bolts can be written in any language, this is possible.
  * **Online machine learning algorithms:** Something like [Mahout](http://mahout.apache.org/) but for online algorithms

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Rationale.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Rationale.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Rationale.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Rationale.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 The past decade has seen a revolution in data processing. MapReduce, Hadoop, and related technologies have made it possible to store and process data at scales previously unthinkable. Unfortunately, these data processing technologies are not realtime systems, nor are they meant to be. There's no hack that will turn Hadoop into a realtime system; realtime data processing has a fundamentally different set of requirements than batch processing.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Running-topologies-on-a-production-cluster.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Running-topologies-on-a-production-cluster.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Running-topologies-on-a-production-cluster.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Running-topologies-on-a-production-cluster.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 Running topologies on a production cluster is similar to running in [Local mode](Local-mode.html). Here are the steps:
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/SECURITY.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/SECURITY.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/SECURITY.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/SECURITY.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Running Apache Storm Securely
 layout: documentation
 documentation: true
-version: v0.9.6
 ---
 # Running Apache Storm Securely
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/STORM-UI-REST-API.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/STORM-UI-REST-API.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/STORM-UI-REST-API.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/STORM-UI-REST-API.md Fri Mar 18 01:49:28 2016
@@ -2,7 +2,6 @@
 title: Storm UI REST API
 layout: documentation
 documentation: true
-version: v0.9.6
 ---
 
 # Storm UI REST API

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Serialization-(prior-to-0.6.0).md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Serialization-%28prior-to-0.6.0%29.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Serialization-(prior-to-0.6.0).md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Serialization-(prior-to-0.6.0).md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 Tuples can be comprised of objects of any types. Since Storm is a distributed system, it needs to know how to serialize and deserialize objects when they're passed between tasks. By default Storm can serialize ints, shorts, longs, floats, doubles, bools, bytes, strings, and byte arrays, but if you want to use another type in your tuples, you'll need to implement a custom serializer.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Serialization.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Serialization.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Serialization.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Serialization.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 This page is about how the serialization system in Storm works for versions 0.6.0 and onwards. Storm used a different serialization system prior to 0.6.0 which is documented on [Serialization (prior to 0.6.0)](Serialization-\(prior-to-0.6.0\).html). 
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Serializers.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Serializers.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Serializers.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Serializers.md Fri Mar 18 01:49:28 2016
@@ -1,5 +1,4 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 * [storm-json](https://github.com/rapportive-oss/storm-json): Simple JSON serializer for Storm

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Setting-up-a-Storm-cluster.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Setting-up-a-Storm-cluster.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Setting-up-a-Storm-cluster.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Setting-up-a-Storm-cluster.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 This page outlines the steps for getting a Storm cluster up and running. If you're on AWS, you should check out the [storm-deploy](https://github.com/nathanmarz/storm-deploy/wiki) project. [storm-deploy](https://github.com/nathanmarz/storm-deploy/wiki) completely automates the provisioning, configuration, and installation of Storm clusters on EC2. It also sets up Ganglia for you so you can monitor CPU, disk, and network usage.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Setting-up-development-environment.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Setting-up-development-environment.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Setting-up-development-environment.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Setting-up-development-environment.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 This page outlines what you need to do to get a Storm development environment set up. In summary, the steps are:
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Spout-implementations.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Spout-implementations.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Spout-implementations.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Spout-implementations.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 * [storm-kestrel](https://github.com/nathanmarz/storm-kestrel): Adapter to use Kestrel as a spout
 * [storm-amqp-spout](https://github.com/rapportive-oss/storm-amqp-spout): Adapter to use AMQP source as a spout

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Storm-multi-language-protocol-(versions-0.7.0-and-below).md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Storm-multi-language-protocol-%28versions-0.7.0-and-below%29.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Storm-multi-language-protocol-(versions-0.7.0-and-below).md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Storm-multi-language-protocol-(versions-0.7.0-and-below).md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 This page explains the multilang protocol for versions 0.7.0 and below. The protocol changed in version 0.7.1.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Structure-of-the-codebase.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Structure-of-the-codebase.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Structure-of-the-codebase.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Structure-of-the-codebase.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 There are three distinct layers to Storm's codebase.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Support-for-non-java-languages.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Support-for-non-java-languages.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Support-for-non-java-languages.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Support-for-non-java-languages.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 * [Scala DSL](https://github.com/velvia/ScalaStorm)
 * [JRuby DSL](https://github.com/colinsurprenant/storm-jruby)

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Transactional-topologies.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Transactional-topologies.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Transactional-topologies.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Transactional-topologies.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 **NOTE**: Transactional topologies have been deprecated -- use the [Trident](Trident-tutorial.html) framework instead.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Trident-API-Overview.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Trident-API-Overview.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Trident-API-Overview.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Trident-API-Overview.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 # Trident API overview
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Trident-spouts.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Trident-spouts.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Trident-spouts.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Trident-spouts.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 # Trident spouts
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Trident-state.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Trident-state.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Trident-state.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Trident-state.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 # State in Trident
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Trident-tutorial.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Trident-tutorial.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Trident-tutorial.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Trident-tutorial.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 # Trident tutorial
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Troubleshooting.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Troubleshooting.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Troubleshooting.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Troubleshooting.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 ## Troubleshooting
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Tutorial.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Tutorial.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Tutorial.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Tutorial.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 In this tutorial, you'll learn how to create Storm topologies and deploy them to a Storm cluster. Java will be the main language used, but a few examples will use Python to illustrate Storm's multi-language capabilities.
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Understanding-the-parallelism-of-a-Storm-topology.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Understanding-the-parallelism-of-a-Storm-topology.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Understanding-the-parallelism-of-a-Storm-topology.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Understanding-the-parallelism-of-a-Storm-topology.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 # What makes a running topology: worker processes, executors and tasks
 

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/Using-non-JVM-languages-with-Storm.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/Using-non-JVM-languages-with-Storm.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/Using-non-JVM-languages-with-Storm.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/Using-non-JVM-languages-with-Storm.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 - two pieces: creating topologies and implementing spouts and bolts in other languages
 - creating topologies in another language is easy since topologies are just thrift structures (link to storm.thrift)

Modified: storm/branches/bobby-versioned-site/releases/0.9.6/index.md
URL: http://svn.apache.org/viewvc/storm/branches/bobby-versioned-site/releases/0.9.6/index.md?rev=1735530&r1=1735529&r2=1735530&view=diff
==============================================================================
--- storm/branches/bobby-versioned-site/releases/0.9.6/index.md (original)
+++ storm/branches/bobby-versioned-site/releases/0.9.6/index.md Fri Mar 18 01:49:28 2016
@@ -1,6 +1,5 @@
 ---
 layout: documentation
-version: v0.9.6
 ---
 Storm is a distributed realtime computation system. Similar to how Hadoop provides a set of general primitives for doing batch processing, Storm provides a set of general primitives for doing realtime computation. Storm is simple, can be used with any programming language, [is used by many companies](/documentation/Powered-By.html), and is a lot of fun to use!