You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@storm.apache.org by ka...@apache.org on 2016/01/20 23:24:36 UTC

[21/36] storm git commit: STORM-1468: remove {master}/docs

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/_posts/2014-11-25-storm093-released.md
----------------------------------------------------------------------
diff --git a/docs/_posts/2014-11-25-storm093-released.md b/docs/_posts/2014-11-25-storm093-released.md
deleted file mode 100644
index df3da75..0000000
--- a/docs/_posts/2014-11-25-storm093-released.md
+++ /dev/null
@@ -1,164 +0,0 @@
----
-layout: post
-title: Storm 0.9.3 released
-author: P. Taylor Goetz
----
-
-We are pleased to announce that Apache Storm 0.9.3 has been released and is available from [the downloads page](/downloads.html). This release includes 100 new fixes and improvements from 62 individual contributors.
-
-Improved Kafka Integration
-----------------------------
-
-Apache Storm has supported [Apache Kafka](http://kafka.apache.org/) as a streaming data source since version 0.9.2-incubating. Version 0.9.3 brings a number of improvements to the Kafka integration including the ability to write data to one or more Kafka clusters and topics.
-
-The ability to both read from and write to Kafka further unlocks potential of the already powerful combination of Storm and Kafka. Storm users can now use Kafka as a source of and destination for streaming data. This allows for inter-topology communication, topology chaining, combining spout/bolt-based topologies with Trident-based data flows, and integration with any external system that supports data ingest from Kafka.
-
-More information about Storm's Kafka integration can be found in the [storm-kafka project documentation](https://github.com/apache/storm/blob/v0.9.3/external/storm-kafka/README.md).
-
-
-HDFS Integration
-----------------
-
-Many stream processing use cases involve storing data in HDFS for further analysis and offline (batch) processing. Apache Storm’s HDFS integration consists of several bolt and Trident state implementations that allow topology developers to easily write data to HDFS from any Storm topology. 
-
-More information about Storm's HDFS integration can be found in the [storm-hdfs project documentation](https://github.com/apache/storm/tree/v0.9.3/external/storm-hdfs).
-
-
-HBase Integration
------------------
-
-Apache Storm’s HBase integration includes a number of components that allow Storm topologies to both write to and query HBase in real-time. Many organizations use Apache HBase as part of their big data strategy for batch, interactive, and real-time workflows. Storm’s HBase integration allows users to leverage data assets in HBase as streaming queries, as well as using HBase as a destination for streaming computation results.
-
-More information about Storm's HBase integration can be found in the [storm-hbase project documentation](https://github.com/apache/storm/tree/v0.9.3/external/storm-hbase).
-
-Reduced Dependency Conflicts
-----------------------------
-In previous Storm releases, it was not uncommon for users' topology dependencies to conflict with the libraries used by Storm. In Storm 0.9.3 several dependency packages that were common sources of conflicts have been package-relocated (shaded) to avoid this situation. Developers are free to use the Storm-packaged versions, or supply their own version. 
-
-The following table lists the dependency package relocations:
-
-| Dependency  | Original Package | Storm Package |
-|:---|:---|:---|
-| Apache Thrift | `org.apache.thrift` | `org.apache.thrift7` |
-| Netty | `org.jboss.netty` | `org.apache.storm.netty` |
-| Google Guava | `com.google.common` | `org.apache.storm.guava` |
-|              | `com.google.thirdparty` | `org.apache.storm.guava.thirdparty` |
-| Apache HTTPClient | `org.apache.http` | `org.apache.storm.http` |
-| Apache ZooKeeper | `org.apache.zookeeper` | `org.apache.storm.zookeeper` |
-| Apache Curator | `org.apache.curator` | `org.apache.storm.curator` |
-
-Multi-Lang Improvements
------------------------
-Apache Storm 0.9.3 includes a new [Node.js](http://nodejs.org) multi-lang implementation that allows developers to write spouts and bolts in JavaScript.
-
-In addition to the Node.js implementation, the multi-lang protocol has been substantially improved in terms of robustness and error handling capabilities. As a result, **the multi-lang API has changed in a non-backward-compatible way**. Users with existing multi-lang topologies should consult the Python, Ruby, and JavaScript multi-lang examples to determine the impact prior to upgrading.
-
-
-Thanks
-------
-Special thanks are due to all those who have contributed to Storm -- whether through direct code contributions, documentation, bug reports, or helping other users on the mailing lists. Your efforts are much appreciated.
-
-
-Full Changelog
----------
-
- * STORM-558: change "swap!" to "reset!" to fix assignment-versions in supervisor
- * STORM-555: Storm json response should set charset to UTF-8
- * STORM-513: check heartbeat from multilang subprocess
- * STORM-549: "topology.enable.message.timeouts" does nothing
- * STORM-546: Local hostname configuration ignored by executor
- * STORM-492: Test timeout should be configurable
- * STORM-540: Change default time format in logs to ISO8601 in order to include timezone
- * STORM-511: Storm-Kafka spout keeps sending fetch requests with invalid offset
- * STORM-538: Guava com.google.thirdparty.publicsuffix is not shaded
- * STORM-497: don't modify the netty server taskToQueueId mapping while the someone could be reading it.
- * STORM-537: A worker reconnects infinitely to another dead worker (Sergey Tryuber)
- * STORM-519: add tuple as an input param to HBaseValueMapper 
- * STORM-488: Exit with 254 error code if storm CLI is run with unknown command
- * STORM-506: Do not count bolt acks & fails in total stats
- * STORM-490: fix build under Windows
- * STORM-439: Replace purl.js qith jquery URL plugin
- * STORM-499: Document and clean up shaded dependncy resolution with maven
- * STORM-210: Add storm-hbase module
- * STORM-507: Topology visualization should not block ui
- * STORM-504: Class used by `repl` command is deprecated.
- * STORM-330: Implement storm exponential backoff stategy for netty client and curator
- * STORM-461: exit-process! does not always exit the process, but throws an exception
- * STORM-341: fix assignment sorting
- * STORM-476: external/storm-kafka: avoid NPE on null message payloads
- * STORM-424: fix error message related to kafka offsets
- * STORM-454: correct documentation in STORM-UI-REST-API.md
- * STORM-474: Reformat UI HTML code
- * STORM-447: shade/relocate packages of dependencies that are common causes of dependency conflicts
- * STORM-279: cluster.xml doesn't take in STORM_LOG_DIR values.
- * STORM-380: Kafka spout: throw RuntimeException if a leader cannot be found for a partition
- * STORM-435: Improve storm-kafka documentation
- * STORM-405: Add kafka trident state so messages can be sent to kafka topic
- * STORM-211: Add module for HDFS integration
- * STORM-337: Expose managed spout ids publicly
- * STORM-320: Support STORM_CONF_DIR environment variable to support
- * STORM-360: Add node details for Error Topology and Component pages
- * STORM-54: Per-Topology Classpath and Environment for Workers
- * STORM-355: excluding outdated netty transitively included via curator
- * STORM-183: Replacing RunTime.halt() with RunTime.exit()
- * STORM-213: Decouple In-Process ZooKeeper from LocalCluster.
- * STORM-365: Add support for Python 3 to storm command.
- * STORM-332: Enable Kryo serialization in storm-kafka
- * STORM-370: Add check for empty table before sorting dom in UI
- * STORM-359: add logviewer paging and download
- * STORM-372: Typo in storm_env.ini
- * STORM-266: Adding shell process pid and name in the log message
- * STORM-367: Storm UI REST api documentation.
- * STORM-200: Proposal for Multilang's Metrics feature
- * STORM-351: multilang python process fall into endless loop
- * STORM-375: Smarter downloading of assignments by supervisors and workers
- * STORM-328: More restrictive Config checks, strict range check within Utils.getInt()
- * STORM-381: Replace broken jquery.tablesorter.min.js to latest
- * STORM-312: add storm monitor tools to monitor throughtput interactively
- * STORM-354: Testing: allow users to pass TEST-TIMEOUT-MS as param for complete-topology
- * STORM-254: one Spout/Bolt can register metric twice with same name in different timeBucket
- * STORM-403: heartbeats-to-nimbus in supervisor-test failed due to uninten...
- * STORM-402: FileNotFoundException when using storm with apache tika
- * STORM-364: The exception time display as default timezone.
- * STORM-420: Missing quotes in storm-starter python code
- * STORM-399: Kafka Spout defaulting to latest offset when current offset is older then 100k
- * STORM-421: Memoize local hostname lookup in executor
- * STORM-414: support logging level to multilang protocol spout and bolt
- * STORM-321: Added a tool to see the current status of STORM JIRA and github pulls.
- * STORM-415: validate-launched-once in supervisor-test can not handle multiple topologies
- * STORM-155: Storm rebalancing code causes multiple topologies assigned to a single port
- * STORM-419: Updated test so sort ordering is very explicit.
- * STORM-406: Fix for reconnect logic in netty client.
- * STORM-366: Add color span to most recent error and fix ui templates.
- * STORM-369: topology summary page displays wrong order.
- * STORM-239: Allow supervisor to operate in paths with spaces in them
- * STORM-87: fail fast on ShellBolt exception
- * STORM-417: Storm UI lost table sort style when tablesorter was updated
- * STORM-396: Replace NullPointerException with IllegalArgumentExeption
- * STORM-451: Latest storm does not build due to a pom.xml error in storm-hdfs pom.xml
- * STORM-453: migrated to curator 2.5.0
- * STORM-458: sample spout uses incorrect name when connecting bolt
- * STORM-455: Report error-level messages from ShellBolt children
- * STORM-443: multilang log's loglevel protocol can cause hang
- * STORM-449: Updated ShellBolt to not exit when shutting down.
- * STORM-464: Simulated time advanced after test cluster exits causes intermittent test failures
- * STORM-463: added static version of metrics helpers for Config
- * STORM-376: Add compression to serialization
- * STORM-437: Enforce utf-8 when multilang reads from stdin
- * STORM-361: Add JSON-P support to Storm UI API
- * STORM-373: Provide Additional String substitutions for *.worker.childopts
- * STORM-274: Add support for command remoteconfvalue in storm.cmd
- * STORM-132: sort supervisor by free slot in desending order
- * STORM-472: Improve error message for non-completeable testing spouts
- * STORM-401: handle InterruptedIOException properly.
- * STORM-461: exit-process! does not always exit the process, but throws an exception instead
- * STORM-475: Storm UI pages do not use UTF-8
- * STORM-336: Logback version should be upgraded
- * STORM-386: nodejs multilang protocol implementation and examples
- * STORM-500: Add Spinner when UI is loading stats from nimbus
- * STORM-501: Missing StormSubmitter API
- * STORM-493: Workers inherit storm.conf.file/storm.options properties of their supervisor
- * STORM-498: make ZK connection timeout configurable in Kafka spout
- * STORM-428: extracted ITuple interface
- * STORM-508: Update DEVELOPER.md now that Storm has graduated from Incubator
- * STORM-514: Update storm-starter README now that Storm has graduated from Incubator

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/_posts/2015-03-25-storm094-released.md
----------------------------------------------------------------------
diff --git a/docs/_posts/2015-03-25-storm094-released.md b/docs/_posts/2015-03-25-storm094-released.md
deleted file mode 100644
index 0119e38..0000000
--- a/docs/_posts/2015-03-25-storm094-released.md
+++ /dev/null
@@ -1,24 +0,0 @@
----
-layout: post
-title: Storm 0.9.4 released
-author: P. Taylor Goetz
----
-
-The Apache Storm community is pleased to announce that version 0.9.4 has been released and is available from [the downloads page](/downloads.html).
-
-This is a maintenance release that includes a number of important bug fixes that improve Storm's stability and fault tolerance. We encourage users of previous versions to upgrade to this latest release.
-
-
-Thanks
-------
-Special thanks are due to all those who have contributed to Apache Storm -- whether through direct code contributions, documentation, bug reports, or helping other users on the mailing lists. Your efforts are much appreciated.
-
-
-Full Changelog
----------
-
- * STORM-559: ZkHosts in README should use 2181 as port.
- * STORM-682: supervisor should handle worker state corruption gracefully.
- * STORM-693: when kafka bolt fails to write tuple, it should report error instead of silently acking.
- * STORM-329: fix cascading Storm failure by improving reconnection strategy and buffering messages
- * STORM-130: Supervisor getting killed due to java.io.FileNotFoundException: File '../stormconf.ser' does not exist.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/_posts/2015-06-04-storm095-released.md
----------------------------------------------------------------------
diff --git a/docs/_posts/2015-06-04-storm095-released.md b/docs/_posts/2015-06-04-storm095-released.md
deleted file mode 100644
index 1d018c0..0000000
--- a/docs/_posts/2015-06-04-storm095-released.md
+++ /dev/null
@@ -1,23 +0,0 @@
----
-layout: post
-title: Storm 0.9.5 released
-author: P. Taylor Goetz
----
-
-The Apache Storm community is pleased to announce that version 0.9.5 has been released and is available from [the downloads page](/downloads.html).
-
-This is a maintenance release that includes a number of important bug fixes that improve Storm's stability and fault tolerance. We encourage users of previous versions to upgrade to this latest release.
-
-
-Thanks
-------
-Special thanks are due to all those who have contributed to Apache Storm -- whether through direct code contributions, documentation, bug reports, or helping other users on the mailing lists. Your efforts are much appreciated.
-
-
-Full Changelog
----------
-
- * STORM-790: Log "task is null" instead of letting worker die when task is null in transfer-fn
- * STORM-796: Add support for "error" command in ShellSpout
- * STORM-745: fix storm.cmd to evaluate 'shift' correctly with 'storm jar'
- * STORM-130: Supervisor getting killed due to java.io.FileNotFoundException: File '../stormconf.ser' does not exist.

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/_posts/2015-06-15-storm0100-beta-released.md
----------------------------------------------------------------------
diff --git a/docs/_posts/2015-06-15-storm0100-beta-released.md b/docs/_posts/2015-06-15-storm0100-beta-released.md
deleted file mode 100644
index 9d5c4db..0000000
--- a/docs/_posts/2015-06-15-storm0100-beta-released.md
+++ /dev/null
@@ -1,294 +0,0 @@
----
-layout: post
-title: Storm 0.10.0-beta Released
-author: P. Taylor Goetz
----
-
-Fast on the heals of the 0.9.5 maintenance release, the Apache Storm community is pleased to announce that Apache Storm 0.10.0-beta has been released and is now available on [the downloads page](/downloads.html).
-
-Aside from many stability and performance improvements, this release includes a number of important new features, some of which are highlighted below.
-
-Secure, Multi-Tenant Deployment
---------------------------------
-
-Much like the early days of Hadoop, Apache Storm originally evolved in an environment where security was not a high-priority concern. Rather, it was assumed that Storm would be deployed to environments suitably cordoned off from security threats. While a large number of users were comfortable setting up their own security measures for Storm (usually at the Firewall/OS level), this proved a hindrance to broader adoption among larger enterprises where security policies prohibited deployment without specific safeguards.
-
-Yahoo! hosts one of the largest Storm deployments in the world, and their engineering team recognized the need for security early on, so it implemented many of the features necessary to secure its own Apache Storm deployment. Yahoo!, Hortonworks, Symantec, and the broader Apache Storm community have worked together to bring those security innovations into the main Apache Storm code base.
-
-We are pleased to announce that work is now complete. Some of the highlights of Storm's new security features include:
-
- * Kerberos Authentication with Automatic Credential Push and Renewal
- * Pluggable Authorization and ACLs
- * Multi-Tenant Scheduling with Per-User isolation and configurable resource limits.
- * User Impersonation
- * SSL Support for Storm UI, Log Viewer, and DRPC (Distributed Remote Procedure Call)
- * Secure integration with other Hadoop Projects (such as ZooKeeper, HDFS, HBase, etc.)
- * User isolation (Storm topologies run as the user who submitted them)
-
-For more details and instructions for securing Storm, please see [the security documentation](https://github.com/apache/storm/blob/v0.10.0-beta/SECURITY.md).
-
-A Foundation for Rolling Upgrades and Continuity of Operations
---------------------------------------------------------------
-
-In the past, upgrading a Storm cluster could be an arduous process that involved un-deploying existing topologies, removing state from local disk and ZooKeeper, installing the upgrade, and finally redeploying topologies. From an operations perspective, this process was disruptive to say the very least.
-
-The underlying cause of this headache was rooted in the data format Storm processes used to store both local and distributed state. Between versions, these data structures would change in incompatible ways.
-
-Beginning with version 0.10.0, this limitation has been eliminated. In the future, upgrading from Storm 0.10.0 to a newer version can be accomplished seamlessly, with zero down time. In fact, for users who use [Apache Ambari](https://ambari.apache.org) for cluster provisioning and management, the process can be completely automated.
-
-
-Easier Deployment and Declarative Topology Wiring with Flux
-----------------------------------------------------------
-Apache Storm 0.10.0 now includes Flux, which is a framework and set of utilities that make defining and deploying Storm topologies less painful and developer-intensive. A common pain point mentioned by Storm users is the fact that the wiring for a Topology graph is often tied up in Java code, and that any changes require recompilation and repackaging of the topology jar file. Flux aims to alleviate that pain by allowing you to package all your Storm components in a single jar, and use an external text file to define the layout and configuration of your topologies.
-
-Some of Flux' features include:
-
- * Easily configure and deploy Storm topologies (Both Storm core and Micro-batch API) without embedding configuration in your topology code
- * Support for existing topology code
- * Define Storm Core API (Spouts/Bolts) using a flexible YAML DSL
- * YAML DSL support for most Storm components (storm-kafka, storm-hdfs, storm-hbase, etc.)
- * Convenient support for multi-lang components
- * External property substitution/filtering for easily switching between configurations/environments (similar to Maven-style `${variable.name}` substitution)
-
-You can read more about Flux on the [Flux documentation page](https://github.com/apache/storm/blob/v0.10.0-beta/external/flux/README.md).
-
-Partial Key Groupings
----------------------
-In addition to the standard Stream Groupings Storm has always supported, version 0.10.0 introduces a new grouping named "Partial Key Grouping". With the Partial Stream Grouping, the tuple  stream is partitioned by the fields specified in the grouping, like the Fields Grouping, but are load balanced between two downstream bolts, which provides better utilization of resources when the incoming data is skewed. 
-
-Documentation for the Partial Key Grouping and other stream groupings supported by Storm can be found [here](https://storm.apache.org/documentation/Concepts.html). [This research paper](https://melmeric.files.wordpress.com/2014/11/the-power-of-both-choices-practical-load-balancing-for-distributed-stream-processing-engines.pdf) provides additional details regarding how it works and its advantages.
-
-
-Improved Logging Framework
---------------------------
-Debugging distributed applications can be difficult, and usually focuses on one main source of information: application log files. But in a very low latency system like Storm where every millisecond counts, logging can be a double-edged sword: If you log too little information you may miss the information you need to solve a problem; log too much and you risk degrading the overall performance of your application as resources are consumed by the logging framework.
-
-In version 0.10.0 Storm's logging framework now uses [Apache Log4j 2](http://logging.apache.org/log4j/2.x/) which, like Storm's internal messaging subsystem, uses the extremely performant [LMAX Disruptor](https://lmax-exchange.github.io/disruptor/) messaging library. Log4j 2 boast an 18x higher throughput and orders of magnitude lower latency than Storm's previous logging framework. More efficient resource utilization at the logging level means more resources are available where they matter most: executing your business logic.
-
-A few of the important features these changes bring include:
-
- * Rolling log files with size, duration, and date-based triggers that are composable
- * Dynamic log configuration updates without dropping log messages
- * Remote log monitoring and (re)configuration via JMX
- * A Syslog/[RFC-5424](https://tools.ietf.org/html/rfc5424)-compliant appender.
- * Integration with log aggregators such as syslog-ng
-
-
-Streaming ingest with Apache Hive
----------------------------------
-Introduced in version 0.13, [Apache Hive](https://hive.apache.org) includes a [Streaming Data Ingest API](https://cwiki.apache.org/confluence/display/Hive/Streaming+Data+Ingest) that allows data to be written continuously into Hive. The incoming data can be continuously committed in small batches of records into existing Hive partition or table. Once the data is committed its immediately visible to all hive queries.
-
-Apache Storm 0.10.0 introduces both a Storm Core API bolt implementation 
-that allows users to stream data from Storm directly into hive. Storm's Hive integration also includes a [State](https://storm.apache.org/documentation/Trident-state) implementation for Storm's Micro-batching/Transactional API (Trident) that allows you to write to Hive from a micro-batch/transactional topology and supports exactly-once semantics for data persistence.
-
-For more information on Storm's Hive integration, see the [storm-hive documentation](https://github.com/apache/storm/blob/v0.10.0-beta/external/storm-hive/README.md).
-
-
-Microsoft Azure Event Hubs Integration
---------------------------------------
-With Microsoft Azure's [support for running Storm on HDInsight](https://azure.microsoft.com/en-us/documentation/articles/hdinsight-storm-overview/), Storm is now a first class citizen of the Azure cloud computing platform. To better support Storm integration with Azure services, Microsoft engineers have contributed several components that allow Storm to integrate directly with [Microsoft Azure Event Hubs](http://azure.microsoft.com/en-us/services/event-hubs/).
-
-Storm's Event Hubs integration includes both spout and bolt implementations for reading from, and writing to Event Hubs. The Event Hub integration also includes a Micro-batching/Transactional (Trident) spout implementation that supports fully fault-tolerant and reliable processing, as well as support for exactly-once message processing semantics.
-
-
-Redis Support
--------------
-Apache Storm 0.10.0 also introduces support for the [Redis](http://redis.io) data structure server. Storm's Redis support includes bolt implementations for both writing to and querying Redis from a Storm topology, and is easily extended for custom use cases. For Storm's micro-batching/transactional API, the Redis support includes both [Trident State and MapState](https://storm.apache.org/documentation/Trident-state.html) implementations for fault-tolerant state management with Redis.
-
-Further information can be found in the [storm-redis documentation](https://github.com/apache/storm/blob/v0.10.0-beta/external/storm-redis/README.md).
-
-
-JDBC/RDBMS Integration
-----------------------
-Many stream processing data flows require accessing data from or writing data to a relational data store. Storm 0.10.0 introduces highly flexible and customizable support for integrating with virtually any JDBC-compliant database.
-
-The Storm-JDBC package includes core Storm bolt and Trident state implementations that allow a storm topology to either insert Storm tuple data into a database table or execute select queries against a database to enrich streaming data in a storm topology.
-
-Further details and instructions can be found in the [Storm-JDBC documentation](https://github.com/apache/storm/blob/v0.10.0-beta/external/storm-jdbc/README.md).
-
-
-Reduced Dependency Conflicts
-----------------------------
-In previous Storm releases, it was not uncommon for users' topology dependencies to conflict with the libraries used by Storm. In Storm 0.9.3 several dependency packages that were common sources of conflicts have been package-relocated (shaded) to avoid this situation. In 0.10.0 this list has been expanded.
-
-Developers are free to use the Storm-packaged versions, or supply their own version. 
-
-The full list of Storm's package relocations can be found [here](https://github.com/apache/storm/blob/v0.10.0-beta/storm-core/pom.xml#L439).
-
-
-Future Work
------------
-While the 0.10.0 release is an important milestone in the evolution of Apache Storm, the Storm community is actively working on new improvements, both near and long term, and continuously exploring the realm of the possible.
-
-Twitter recently announced the Heron project, which claims to provide substantial performance improvements while maintaining 100% API compatibility with Storm. The corresponding research paper provides additional details regarding the architectural improvements. The fact that Twitter chose to maintain API compatibility with Storm is a testament to the power and flexibility of that API. Twitter has also expressed a desire to share their experiences and work with the Apache Storm community.
-
-A number of concepts expressed in the Heron paper were already in the implementation stage by the Storm community even before it was published, and we look forward to working with Twitter to bring those and other improvements to Storm.
-
-Thanks
-------
-Special thanks are due to all those who have contributed to Apache Storm -- whether through direct code contributions, documentation, bug reports, or helping other users on the mailing lists. Your efforts are very much valued and appreciated.
-
-
-Full Change Log
----------------
-
- * STORM-856: use serialized value of delay secs for topo actions
- * STORM-852: Replaced Apache Log4j Logger with SLF4J API
- * STORM-813: Change storm-starter's README so that it explains mvn exec:java cannot run multilang topology
- * STORM-853: Fix upload API to handle multi-args properly
- * STORM-850: Convert storm-core's logback-test.xml to log4j2-test.xml
- * STORM-848: Shade external dependencies
- * STORM-849: Add storm-redis to storm binary distribution
- * STORM-760: Use JSON for serialized conf
- * STORM-833: Logging framework logback -> log4j 2.x
- * STORM-842: Drop Support for Java 1.6
- * STORM-835: Netty Client hold batch object until io operation complete
- * STORM-827: Allow AutoTGT to work with storm-hdfs too.
- * STORM-821: Adding connection provider interface to decouple jdbc connector from a single connection pooling implementation.
- * STORM-818: storm-eventhubs configuration improvement and refactoring
- * STORM-816: maven-gpg-plugin does not work with gpg 2.1
- * STORM-811: remove old metastor_db before running tests again.
- * STORM-808: allow null to be parsed as null
- * STORM-807: quote args to storm.py correctly
- * STORM-801: Add Travis CI badge to README
- * STORM-797: DisruptorQueueTest has some race conditions in it.
- * STORM-796: Add support for "error" command in ShellSpout
- * STORM-795: Update the user document for the extlib issue
- * STORM-792: Missing documentation in backtype.storm.generated.Nimbus
- * STORM-791: Storm UI displays maps in the config incorrectly
- * STORM-790: Log "task is null" instead of let worker died when task is null in transfer-fn
- * STORM-789: Send more topology context to Multi-Lang components via initial handshake
- * STORM-788: UI Fix key for process latencies
- * STORM-787: test-ns should announce test failures with 'BUILD FAILURE'
- * STORM-786: KafkaBolt should ack tick tuples
- * STORM-773: backtype.storm.transactional-test fails periodically with timeout
- * STORM-772: Tasts fail periodically with InterruptedException or InterruptedIOException
- * STORM-766: Include version info in the service page
- * STORM-765: Thrift serialization for local state
- * STORM-764: Have option to compress thrift heartbeat
- * STORM-762: uptime for worker heartbeats is lost when converted to thrift
- * STORM-761: An option for new/updated Redis keys to expire in RedisMapState
- * STORM-757: Simulated time can leak out on errors
- * STORM-753: Improve RedisStateQuerier to convert List<Values> from Redis value
- * STORM-752: [storm-redis] Clarify Redis*StateUpdater's expire is optional
- * STORM-750: Set Config serialVersionUID
- * STORM-749: Remove CSRF check from the REST API.
- * STORM-747: assignment-version-callback/info-with-version-callback are not fired when assignments change
- * STORM-746: Skip ack init when there are no output tasks
- * STORM-745: fix storm.cmd to evaluate 'shift' correctly with 'storm jar'
- * STORM-741: Allow users to pass a config value to perform impersonation.
- * STORM-740: Simple Transport Client cannot configure thrift buffer size
- * STORM-737: Check task->node+port with read lock to prevent sending to closed connection
- * STORM-735: [storm-redis] Upgrade Jedis to 2.7.0
- * STORM-730: remove extra curly brace
- * STORM-729: Include Executors (Window Hint) if the component is of Bolt type
- * STORM-728: Put emitted and transferred stats under correct columns
- * STORM-727: Storm tests should succeed even if a storm process is running locally.
- * STORM-724: Document RedisStoreBolt and RedisLookupBolt which is missed.
- * STORM-723: Remove RedisStateSetUpdater / RedisStateSetCountQuerier which didn't tested and have a bug
- * STORM-721: Storm UI server should support SSL.
- * STORM-715: Add a link to AssignableMetric.java in Metrics.md
- * STORM-714: Make CSS more consistent with self, prev release
- * STORM-713: Include topic information with Kafka metrics.
- * STORM-712: Storm daemons shutdown if OutOfMemoryError occurs in any thread
- * STORM-711: All connectors should use collector.reportError and tuple anchoring.
- * STORM-708: CORS support for STORM UI.
- * STORM-707: Client (Netty): improve logging to help troubleshooting connection woes
- * STORM-704: Apply Travis CI to Apache Storm Project
- * STORM-703: With hash key option for RedisMapState, only get values for keys in batch
- * STORM-699: storm-jdbc should support custom insert queries. 
- * STORM-696: Single Namespace Test Launching
- * STORM-694: java.lang.ClassNotFoundException: backtype.storm.daemon.common.SupervisorInfo
- * STORM-693: KafkaBolt exception handling improvement.
- * STORM-691: Add basic lookup / persist bolts
- * STORM-690: Return Jedis into JedisPool with marking 'broken' if connection is broken
- * STORM-689: SimpleACLAuthorizer should provide a way to restrict who can submit topologies.
- * STORM-688: update Util to compile under JDK8
- * STORM-687: Storm UI does not display up to date information despite refreshes in IE
- * STORM-685: wrong output in log when committed offset is too far behind latest offset
- * STORM-684: In RichSpoutBatchExecutor: underlying spout is not closed when emitter is closed
- * STORM-683: Make false in a conf really evaluate to false in clojure.
- * STORM-682: supervisor should handle worker state corruption gracefully.
- * STORM-681: Auto insert license header with genthrift.sh
- * STORM-675: Allow users to have storm-env.sh under config dir to set custom JAVA_HOME and other env variables.
- * STORM-673: Typo 'deamon' in security documentation
- * STORM-672: Typo in Trident documentation example
- * STORM-670: restore java 1.6 compatibility (storm-kafka)
- * STORM-669: Replace links with ones to latest api document
- * STORM-667: Incorrect capitalization "SHell" in Multilang-protocol.md
- * STORM-663: Create javadocs for BoltDeclarer
- * STORM-659: return grep matches each on its own line.
- * STORM-657: make the shutdown-worker sleep time before kill -9 configurable
- * STORM-656: Document "external" modules and "Committer Sponsors"
- * STORM-651: improvements to storm.cmd
- * STORM-641: Add total number of topologies to api/v1/cluster/summary.
- * STORM-640: Storm UI vulnerable to poodle attack.
- * STORM-637: Integrate PartialKeyGrouping into storm API
- * STORM-636: Faster, optional retrieval of last component error
- * STORM-635: logviewer returns 404 if storm_home/logs is a symlinked dir.
- * STORM-634: Storm serialization changed to thrift to support rolling upgrade.
- * STORM-632: New grouping for better load balancing
- * STORM-630: Support for Clojure 1.6.0
- * STORM-629: Place Link to Source Code Repository on Webpage
- * STORM-627: Storm-hbase configuration error.
- * STORM-626: Add script to print out the merge command for a given pull request.
- * STORM-625: Don't leak netty clients when worker moves or reuse netty client.	
- * STORM-623: Generate latest javadocs
- * STORM-620: Duplicate maven plugin declaration
- * STORM-616: Storm JDBC Connector.
- * STORM-615: Add REST API to upload topology.
- * STORM-613: Fix wrong getOffset return value
- * STORM-612: Update the contact address in configure.ac
- * STORM-611: Remove extra "break"s
- * STORM-610: Check the return value of fts_close()
- * STORM-609: Add storm-redis to storm external
- * STORM-608: Storm UI CSRF escape characters not work correctly.
- * STORM-607: storm-hbase HBaseMapState should support user to customize the hbase-key & hbase-qualifier
- * STORM-603: Log errors when required kafka params are missing
- * STORM-601: Make jira-github-join ignore case.
- * STORM-600: upgrade jacoco plugin to support jdk8
- * STORM-599: Use nimbus's cached heartbeats rather than fetching again from ZK
- * STORM-596: remove config topology.receiver.buffer.size
- * STORM-595: storm-hdfs can only work with sequence files that use Writables.
- * STORM-586: Trident kafka spout fails instead of updating offset when kafka offset is out of range.
- * STORM-585: Performance issue in none grouping
- * STORM-583: Add Microsoft Azure Event Hub spout implementations
- * STORM-578: Calls to submit-mocked-assignment in supervisor-test use invalid executor-id format
- * STORM-577: long time launch worker will block supervisor heartbeat
- * STORM-575: Ability to specify Jetty host to bind to
- * STORM-572: Storm UI 'favicon.ico'
- * STORM-572: Allow Users to pass TEST-TIMEOUT-MS for java
- * STORM-571: upgrade clj-time.
- * STORM-570: Switch from tablesorter to datatables jquery plugin.
- * STORM-569: Add Conf for bolt's outgoing overflow-buffer.
- * STORM-567: Move Storm Documentation/Website from SVN to git
- * STORM-565: Fix NPE when topology.groups is null.
- * STORM-563: Kafka Spout doesn't pick up from the beginning of the queue unless forceFromStart specified.
- * STORM-561: Add flux as an external module
- * STORM-557: High Quality Images for presentations
- * STORM-554: the type of first param "topology" should be ^StormTopology not ^TopologyContext
- * STORM-552: Add netty socket backlog config
- * STORM-548: Receive Thread Shutdown hook should connect to local hostname but not Localhost
- * STORM-541: Build produces maven warnings
- * STORM-539: Storm Hive Connector.
- * STORM-533: Add in client and server IConnection metrics.
- * STORM-527: update worker.clj -- delete "missing-tasks" checking
- * STORM-525: Add time sorting function to the 2nd col of bolt exec table
- * STORM-512: KafkaBolt doesn't handle ticks properly
- * STORM-505: Fix debug string construction
- * STORM-495: KafkaSpout retries with exponential backoff
- * STORM-487: Remove storm.cmd, no need to duplicate work python runs on windows too.
- * STORM-483: provide dedicated directories for classpath extension
- * STORM-456: Storm UI: cannot navigate to topology page when name contains spaces.
- * STORM-446: Allow superusers to impersonate other users in secure mode.
- * STORM-444: Add AutoHDFS like credential fetching for HBase
- * STORM-442: multilang ShellBolt/ShellSpout die() can be hang when Exception happened
- * STORM-441: Remove bootstrap macro from Clojure codebase
- * STORM-410: Add groups support to log-viewer
- * STORM-400: Thrift upgrade to thrift-0.9.2
- * STORM-329: fix cascading Storm failure by improving reconnection strategy and buffering messages (thanks tedxia)
- * STORM-322: Windows script do not handle spaces in JAVA_HOME path
- * STORM-248: cluster.xml location is hardcoded for workers
- * STORM-243: Record version and revision information in builds
- * STORM-188: Allow user to specifiy full configuration path when running storm command
- * STORM-130: Supervisor getting killed due to java.io.FileNotFoundException: File '../stormconf.ser' does not exist.

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/_sass/_syntax-highlighting.scss
----------------------------------------------------------------------
diff --git a/docs/_sass/_syntax-highlighting.scss b/docs/_sass/_syntax-highlighting.scss
deleted file mode 100644
index a0d2404..0000000
--- a/docs/_sass/_syntax-highlighting.scss
+++ /dev/null
@@ -1,70 +0,0 @@
-%vertical-rhythm {
-    margin-bottom: $spacing-unit / 2;
-}
-/**
- * Syntax highlighting styles
- */
-.highlight {
-    background: #fff;
-    @extend %vertical-rhythm;
-
-    .c     { color: #998; font-style: italic } // Comment
-    .err   { color: #a61717; background-color: #e3d2d2 } // Error
-    .k     { font-weight: bold } // Keyword
-    .o     { font-weight: bold } // Operator
-    .cm    { color: #998; font-style: italic } // Comment.Multiline
-    .cp    { color: #999; font-weight: bold } // Comment.Preproc
-    .c1    { color: #998; font-style: italic } // Comment.Single
-    .cs    { color: #999; font-weight: bold; font-style: italic } // Comment.Special
-    .gd    { color: #000; background-color: #fdd } // Generic.Deleted
-    .gd .x { color: #000; background-color: #faa } // Generic.Deleted.Specific
-    .ge    { font-style: italic } // Generic.Emph
-    .gr    { color: #a00 } // Generic.Error
-    .gh    { color: #999 } // Generic.Heading
-    .gi    { color: #000; background-color: #dfd } // Generic.Inserted
-    .gi .x { color: #000; background-color: #afa } // Generic.Inserted.Specific
-    .go    { color: #888 } // Generic.Output
-    .gp    { color: #555 } // Generic.Prompt
-    .gs    { font-weight: bold } // Generic.Strong
-    .gu    { color: #aaa } // Generic.Subheading
-    .gt    { color: #a00 } // Generic.Traceback
-    .kc    { font-weight: bold } // Keyword.Constant
-    .kd    { font-weight: bold } // Keyword.Declaration
-    .kp    { font-weight: bold } // Keyword.Pseudo
-    .kr    { font-weight: bold } // Keyword.Reserved
-    .kt    { color: #458; font-weight: bold } // Keyword.Type
-    .m     { color: #099 } // Literal.Number
-    .s     { color: #d14 } // Literal.String
-    .na    { color: #008080 } // Name.Attribute
-    .nb    { color: #0086B3 } // Name.Builtin
-    .nc    { color: #458; font-weight: bold } // Name.Class
-    .no    { color: #008080 } // Name.Constant
-    .ni    { color: #800080 } // Name.Entity
-    .ne    { color: #900; font-weight: bold } // Name.Exception
-    .nf    { color: #900; font-weight: bold } // Name.Function
-    .nn    { color: #555 } // Name.Namespace
-    .nt    { color: #000080 } // Name.Tag
-    .nv    { color: #008080 } // Name.Variable
-    .ow    { font-weight: bold } // Operator.Word
-    .w     { color: #bbb } // Text.Whitespace
-    .mf    { color: #099 } // Literal.Number.Float
-    .mh    { color: #099 } // Literal.Number.Hex
-    .mi    { color: #099 } // Literal.Number.Integer
-    .mo    { color: #099 } // Literal.Number.Oct
-    .sb    { color: #d14 } // Literal.String.Backtick
-    .sc    { color: #d14 } // Literal.String.Char
-    .sd    { color: #d14 } // Literal.String.Doc
-    .s2    { color: #d14 } // Literal.String.Double
-    .se    { color: #d14 } // Literal.String.Escape
-    .sh    { color: #d14 } // Literal.String.Heredoc
-    .si    { color: #d14 } // Literal.String.Interpol
-    .sx    { color: #d14 } // Literal.String.Other
-    .sr    { color: #009926 } // Literal.String.Regex
-    .s1    { color: #d14 } // Literal.String.Single
-    .ss    { color: #990073 } // Literal.String.Symbol
-    .bp    { color: #999 } // Name.Builtin.Pseudo
-    .vc    { color: #008080 } // Name.Variable.Class
-    .vg    { color: #008080 } // Name.Variable.Global
-    .vi    { color: #008080 } // Name.Variable.Instance
-    .il    { color: #099 } // Literal.Number.Integer.Long
-}

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/about.md
----------------------------------------------------------------------
diff --git a/docs/about.md b/docs/about.md
deleted file mode 100644
index 4bd6d5e..0000000
--- a/docs/about.md
+++ /dev/null
@@ -1,7 +0,0 @@
----
-layout: page
-title: About
-permalink: /about/
----
-
-Storm is a <a href="/about/free-and-open-source.html">free and open source</a> distributed realtime computation system. Storm makes it easy to reliably process unbounded streams of data, doing for realtime processing what Hadoop did for batch processing. Storm is <a href="/about/simple-api.html">simple</a>, can be used with <a href="/about/multi-language.html">any programming language</a>, and is a lot of fun to use!

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/about/deployment.md
----------------------------------------------------------------------
diff --git a/docs/about/deployment.md b/docs/about/deployment.md
deleted file mode 100644
index 88ec55f..0000000
--- a/docs/about/deployment.md
+++ /dev/null
@@ -1,9 +0,0 @@
----
-layout: about
----
-
-Storm clusters are easy to deploy, requiring a minimum of setup and configuration to get up and running. Storm's out of the box configurations are suitable for production. Read more about how to deploy a Storm cluster [here](/documentation/Setting-up-a-Storm-cluster.html).
-
-If you're on EC2, the [storm-deploy](https://github.com/nathanmarz/storm-deploy) project can provision, configure, and install a Storm cluster from scratch at just the click of a button.
-
-Additionally, Storm is easy to operate once deployed. Storm has been designed to be [extremely robust](/about/fault-tolerant.html) – the cluster will just keep on running, month after month.

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/about/fault-tolerant.md
----------------------------------------------------------------------
diff --git a/docs/about/fault-tolerant.md b/docs/about/fault-tolerant.md
deleted file mode 100644
index 057b372..0000000
--- a/docs/about/fault-tolerant.md
+++ /dev/null
@@ -1,9 +0,0 @@
----
-layout: about
----
-
-Storm is fault-tolerant: when workers die, Storm will automatically restart them. If a node dies, the worker will be restarted on another node.
-
-The Storm daemons, Nimbus and the Supervisors, are designed to be stateless and fail-fast. So if they die, they will restart like nothing happened. This means you can *kill -9* the Storm daemons without affecting the health of the cluster or your topologies.
-
-Read more about Storm's fault-tolerance [on the manual](/documentation/Fault-tolerance.html).
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/about/free-and-open-source.md
----------------------------------------------------------------------
diff --git a/docs/about/free-and-open-source.md b/docs/about/free-and-open-source.md
deleted file mode 100644
index 3a942d5..0000000
--- a/docs/about/free-and-open-source.md
+++ /dev/null
@@ -1,15 +0,0 @@
----
-layout: about
----
-
-Apache Storm is a free and open source project licensed under the [Apache License, Version 2.0](http://www.apache.org/licenses/LICENSE-2.0.html)
-
-
-Storm has a large and growing ecosystem of libraries and tools to use in conjunction with Storm including everything from:
-
-1. *Spouts*: These spouts integrate with queueing systems such as JMS, Kafka, Redis pub/sub, and more.
-2. *storm-state*: storm-state makes it easy to manage large amounts of in-memory state in your computations in a reliable by using a distributed filesystem for persistence
-3. *Database integrations*: There are helper bolts for integrating with various databases, such as MongoDB, RDBMS's, Cassandra, and more.
-4. Other miscellaneous utilities
-
-The [Storm documentation](/documentation/Home.html) has links to notable Storm-related projects hosted outside of Apache.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/about/guarantees-data-processing.md
----------------------------------------------------------------------
diff --git a/docs/about/guarantees-data-processing.md b/docs/about/guarantees-data-processing.md
deleted file mode 100644
index 3d6a0f3..0000000
--- a/docs/about/guarantees-data-processing.md
+++ /dev/null
@@ -1,10 +0,0 @@
----
-layout: about
----
-
-Storm guarantees every tuple will be fully processed. One of Storm's core mechanisms is the ability to track the lineage of a tuple as it makes its way through the topology in an extremely efficient way. Read more about how this works [here](/documentation/Guaranteeing-message-processing.html).
-
-Storm's basic abstractions provide an at-least-once processing guarantee, the same guarantee you get when using a queueing system. Messages are only replayed when there are failures.
-
-Using [Trident](/documentation/Trident-tutorial.html), a higher level abstraction over Storm's basic abstractions, you can achieve exactly-once processing semantics.
-

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/about/integrates.md
----------------------------------------------------------------------
diff --git a/docs/about/integrates.md b/docs/about/integrates.md
deleted file mode 100644
index 8071bdb..0000000
--- a/docs/about/integrates.md
+++ /dev/null
@@ -1,13 +0,0 @@
----
-layout: about
----
-
-Storm integrates with any queueing system and any database system. Storm's [spout](/apidocs/backtype/storm/spout/ISpout.html) abstraction makes it easy to integrate a new queuing system. Example queue integrations include:
-
-1. [Kestrel](https://github.com/nathanmarz/storm-kestrel)
-2. [RabbitMQ / AMQP](https://github.com/Xorlev/storm-amqp-spout)
-3. [Kafka](https://github.com/apache/storm/tree/master/external/storm-kafka)
-4. [JMS](https://github.com/ptgoetz/storm-jms)
-5. [Amazon Kinesis](https://github.com/awslabs/kinesis-storm-spout)
-
-Likewise, integrating Storm with database systems is easy. Simply open a connection to your database and read/write like you normally would. Storm will handle the parallelization, partitioning, and retrying on failures when necessary.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/about/multi-language.md
----------------------------------------------------------------------
diff --git a/docs/about/multi-language.md b/docs/about/multi-language.md
deleted file mode 100644
index 836bf03..0000000
--- a/docs/about/multi-language.md
+++ /dev/null
@@ -1,9 +0,0 @@
----
-layout: about
----
-
-Storm was designed from the ground up to be usable with any programming language. At the core of Storm is a [Thrift](http://thrift.apache.org/) [definition](https://github.com/apache/storm/blob/master/storm-core/src/storm.thrift) for defining and submitting topologies. Since Thrift can be used in any language, topologies can be defined and submitted from any language.
-
-Similarly, spouts and bolts can be defined in any language. Non-JVM spouts and bolts communicate to Storm over a [JSON-based protocol](/documentation/Multilang-protocol.html) over stdin/stdout. Adapters that implement this protocol exist for [Ruby](https://github.com/apache/storm/blob/master/storm-multilang/ruby/src/main/resources/resources/storm.rb), [Python](https://github.com/apache/storm/blob/master/storm-multilang/python/src/main/resources/resources/storm.py), [Javascript](https://github.com/apache/storm/blob/master/storm-multilang/javascript/src/main/resources/resources/storm.js), [Perl](https://github.com/dan-blanchard/io-storm).
-
-*storm-starter* has an [example topology](https://github.com/apache/storm/blob/master/examples/storm-starter/src/jvm/storm/starter/WordCountTopology.java) that implements one of the bolts in Python.

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/about/scalable.md
----------------------------------------------------------------------
diff --git a/docs/about/scalable.md b/docs/about/scalable.md
deleted file mode 100644
index b487e52..0000000
--- a/docs/about/scalable.md
+++ /dev/null
@@ -1,10 +0,0 @@
----
-layout: about
----
-
-Storm topologies are inherently parallel and run across a cluster of machines. Different parts of the topology can be scaled individually by tweaking their parallelism. The "rebalance" command of the "storm" command line client can adjust the parallelism of running topologies on the fly. 
-
-Storm's inherent parallelism means it can process very high throughputs of messages with very low latency. Storm was benchmarked at processing **one million 100 byte messages per second per node** on hardware with the following specs:
-
- * **Processor:** 2x Intel E5645@2.4Ghz 
- * **Memory:** 24 GB

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/about/simple-api.md
----------------------------------------------------------------------
diff --git a/docs/about/simple-api.md b/docs/about/simple-api.md
deleted file mode 100644
index 7fc8c10..0000000
--- a/docs/about/simple-api.md
+++ /dev/null
@@ -1,15 +0,0 @@
----
-layout: about
----
-
-Storm has a simple and easy to use API. When programming on Storm, you manipulate and transform streams of tuples, and a tuple is a named list of values. Tuples can contain objects of any type; if you want to use a type Storm doesn't know about it's [very easy](/documentation/Serialization.html) to register a serializer for that type.
-
-There are just three abstractions in Storm: spouts, bolts, and topologies. A **spout** is a source of streams in a computation. Typically a spout reads from a queueing broker such as Kestrel, RabbitMQ, or Kafka, but a spout can also generate its own stream or read from somewhere like the Twitter streaming API. Spout implementations already exist for most queueing systems.
-
-A **bolt** processes any number of input streams and produces any number of new output streams. Most of the logic of a computation goes into bolts, such as functions, filters, streaming joins, streaming aggregations, talking to databases, and so on.
-
-A **topology** is a network of spouts and bolts, with each edge in the network representing a bolt subscribing to the output stream of some other spout or bolt. A topology is an arbitrarily complex multi-stage stream computation. Topologies run indefinitely when deployed.
-
-Storm has a "local mode" where a Storm cluster is simulated in-process. This is useful for development and testing. The "storm" command line client is used when ready to submit a topology for execution on an actual cluster.
-
-The [storm-starter](https://github.com/apache/storm/tree/master/examples/storm-starter) project contains example topologies for learning the basics of Storm. Learn more about how to use Storm by reading the [tutorial](/documentation/Tutorial.html) and the [documentation](/documentation/Home.html).
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/2f5c31d2/docs/assets/css/bootstrap-theme.css
----------------------------------------------------------------------
diff --git a/docs/assets/css/bootstrap-theme.css b/docs/assets/css/bootstrap-theme.css
deleted file mode 100644
index c4cadf1..0000000
--- a/docs/assets/css/bootstrap-theme.css
+++ /dev/null
@@ -1,470 +0,0 @@
-/*!
- * Bootstrap v3.3.1 (http://getbootstrap.com)
- * Copyright 2011-2014 Twitter, Inc.
- * Licensed under MIT (https://github.com/twbs/bootstrap/blob/master/LICENSE)
- */
-
-.btn-default,
-.btn-primary,
-.btn-success,
-.btn-info,
-.btn-warning,
-.btn-danger {
-  text-shadow: 0 -1px 0 rgba(0, 0, 0, .2);
-  -webkit-box-shadow: inset 0 1px 0 rgba(255, 255, 255, .15), 0 1px 1px rgba(0, 0, 0, .075);
-          box-shadow: inset 0 1px 0 rgba(255, 255, 255, .15), 0 1px 1px rgba(0, 0, 0, .075);
-}
-.btn-default:active,
-.btn-primary:active,
-.btn-success:active,
-.btn-info:active,
-.btn-warning:active,
-.btn-danger:active,
-.btn-default.active,
-.btn-primary.active,
-.btn-success.active,
-.btn-info.active,
-.btn-warning.active,
-.btn-danger.active {
-  -webkit-box-shadow: inset 0 3px 5px rgba(0, 0, 0, .125);
-          box-shadow: inset 0 3px 5px rgba(0, 0, 0, .125);
-}
-.btn-default .badge,
-.btn-primary .badge,
-.btn-success .badge,
-.btn-info .badge,
-.btn-warning .badge,
-.btn-danger .badge {
-  text-shadow: none;
-}
-.btn:active,
-.btn.active {
-  background-image: none;
-}
-.btn-default {
-  text-shadow: 0 1px 0 #fff;
-  background-image: -webkit-linear-gradient(top, #fff 0%, #e0e0e0 100%);
-  background-image:      -o-linear-gradient(top, #fff 0%, #e0e0e0 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#fff), to(#e0e0e0));
-  background-image:         linear-gradient(to bottom, #fff 0%, #e0e0e0 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ffffffff', endColorstr='#ffe0e0e0', GradientType=0);
-  filter: progid:DXImageTransform.Microsoft.gradient(enabled = false);
-  background-repeat: repeat-x;
-  border-color: #dbdbdb;
-  border-color: #ccc;
-}
-.btn-default:hover,
-.btn-default:focus {
-  background-color: #e0e0e0;
-  background-position: 0 -15px;
-}
-.btn-default:active,
-.btn-default.active {
-  background-color: #e0e0e0;
-  border-color: #dbdbdb;
-}
-.btn-default:disabled,
-.btn-default[disabled] {
-  background-color: #e0e0e0;
-  background-image: none;
-}
-.btn-primary {
-  background-image: -webkit-linear-gradient(top, #337ab7 0%, #265a88 100%);
-  background-image:      -o-linear-gradient(top, #337ab7 0%, #265a88 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#337ab7), to(#265a88));
-  background-image:         linear-gradient(to bottom, #337ab7 0%, #265a88 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ff337ab7', endColorstr='#ff265a88', GradientType=0);
-  filter: progid:DXImageTransform.Microsoft.gradient(enabled = false);
-  background-repeat: repeat-x;
-  border-color: #245580;
-}
-.btn-primary:hover,
-.btn-primary:focus {
-  background-color: #265a88;
-  background-position: 0 -15px;
-}
-.btn-primary:active,
-.btn-primary.active {
-  background-color: #265a88;
-  border-color: #245580;
-}
-.btn-primary:disabled,
-.btn-primary[disabled] {
-  background-color: #265a88;
-  background-image: none;
-}
-.btn-success {
-  background-image: -webkit-linear-gradient(top, #5cb85c 0%, #419641 100%);
-  background-image:      -o-linear-gradient(top, #5cb85c 0%, #419641 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#5cb85c), to(#419641));
-  background-image:         linear-gradient(to bottom, #5cb85c 0%, #419641 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ff5cb85c', endColorstr='#ff419641', GradientType=0);
-  filter: progid:DXImageTransform.Microsoft.gradient(enabled = false);
-  background-repeat: repeat-x;
-  border-color: #3e8f3e;
-}
-.btn-success:hover,
-.btn-success:focus {
-  background-color: #419641;
-  background-position: 0 -15px;
-}
-.btn-success:active,
-.btn-success.active {
-  background-color: #419641;
-  border-color: #3e8f3e;
-}
-.btn-success:disabled,
-.btn-success[disabled] {
-  background-color: #419641;
-  background-image: none;
-}
-.btn-info {
-  background-image: -webkit-linear-gradient(top, #5bc0de 0%, #2aabd2 100%);
-  background-image:      -o-linear-gradient(top, #5bc0de 0%, #2aabd2 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#5bc0de), to(#2aabd2));
-  background-image:         linear-gradient(to bottom, #5bc0de 0%, #2aabd2 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ff5bc0de', endColorstr='#ff2aabd2', GradientType=0);
-  filter: progid:DXImageTransform.Microsoft.gradient(enabled = false);
-  background-repeat: repeat-x;
-  border-color: #28a4c9;
-}
-.btn-info:hover,
-.btn-info:focus {
-  background-color: #2aabd2;
-  background-position: 0 -15px;
-}
-.btn-info:active,
-.btn-info.active {
-  background-color: #2aabd2;
-  border-color: #28a4c9;
-}
-.btn-info:disabled,
-.btn-info[disabled] {
-  background-color: #2aabd2;
-  background-image: none;
-}
-.btn-warning {
-  background-image: -webkit-linear-gradient(top, #f0ad4e 0%, #eb9316 100%);
-  background-image:      -o-linear-gradient(top, #f0ad4e 0%, #eb9316 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#f0ad4e), to(#eb9316));
-  background-image:         linear-gradient(to bottom, #f0ad4e 0%, #eb9316 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#fff0ad4e', endColorstr='#ffeb9316', GradientType=0);
-  filter: progid:DXImageTransform.Microsoft.gradient(enabled = false);
-  background-repeat: repeat-x;
-  border-color: #e38d13;
-}
-.btn-warning:hover,
-.btn-warning:focus {
-  background-color: #eb9316;
-  background-position: 0 -15px;
-}
-.btn-warning:active,
-.btn-warning.active {
-  background-color: #eb9316;
-  border-color: #e38d13;
-}
-.btn-warning:disabled,
-.btn-warning[disabled] {
-  background-color: #eb9316;
-  background-image: none;
-}
-.btn-danger {
-  background-image: -webkit-linear-gradient(top, #d9534f 0%, #c12e2a 100%);
-  background-image:      -o-linear-gradient(top, #d9534f 0%, #c12e2a 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#d9534f), to(#c12e2a));
-  background-image:         linear-gradient(to bottom, #d9534f 0%, #c12e2a 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ffd9534f', endColorstr='#ffc12e2a', GradientType=0);
-  filter: progid:DXImageTransform.Microsoft.gradient(enabled = false);
-  background-repeat: repeat-x;
-  border-color: #b92c28;
-}
-.btn-danger:hover,
-.btn-danger:focus {
-  background-color: #c12e2a;
-  background-position: 0 -15px;
-}
-.btn-danger:active,
-.btn-danger.active {
-  background-color: #c12e2a;
-  border-color: #b92c28;
-}
-.btn-danger:disabled,
-.btn-danger[disabled] {
-  background-color: #c12e2a;
-  background-image: none;
-}
-.thumbnail,
-.img-thumbnail {
-  -webkit-box-shadow: 0 1px 2px rgba(0, 0, 0, .075);
-          box-shadow: 0 1px 2px rgba(0, 0, 0, .075);
-}
-.dropdown-menu > li > a:hover,
-.dropdown-menu > li > a:focus {
-  background-color: #e8e8e8;
-  background-image: -webkit-linear-gradient(top, #f5f5f5 0%, #e8e8e8 100%);
-  background-image:      -o-linear-gradient(top, #f5f5f5 0%, #e8e8e8 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#f5f5f5), to(#e8e8e8));
-  background-image:         linear-gradient(to bottom, #f5f5f5 0%, #e8e8e8 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#fff5f5f5', endColorstr='#ffe8e8e8', GradientType=0);
-  background-repeat: repeat-x;
-}
-.dropdown-menu > .active > a,
-.dropdown-menu > .active > a:hover,
-.dropdown-menu > .active > a:focus {
-  background-color: #2e6da4;
-  background-image: -webkit-linear-gradient(top, #337ab7 0%, #2e6da4 100%);
-  background-image:      -o-linear-gradient(top, #337ab7 0%, #2e6da4 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#337ab7), to(#2e6da4));
-  background-image:         linear-gradient(to bottom, #337ab7 0%, #2e6da4 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ff337ab7', endColorstr='#ff2e6da4', GradientType=0);
-  background-repeat: repeat-x;
-}
-.navbar-default {
-  background-image: -webkit-linear-gradient(top, #fff 0%, #f8f8f8 100%);
-  background-image:      -o-linear-gradient(top, #fff 0%, #f8f8f8 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#fff), to(#f8f8f8));
-  background-image:         linear-gradient(to bottom, #fff 0%, #f8f8f8 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ffffffff', endColorstr='#fff8f8f8', GradientType=0);
-  filter: progid:DXImageTransform.Microsoft.gradient(enabled = false);
-  background-repeat: repeat-x;
-  border-radius: 4px;
-  -webkit-box-shadow: inset 0 1px 0 rgba(255, 255, 255, .15), 0 1px 5px rgba(0, 0, 0, .075);
-          box-shadow: inset 0 1px 0 rgba(255, 255, 255, .15), 0 1px 5px rgba(0, 0, 0, .075);
-}
-.navbar-default .navbar-nav > .open > a,
-.navbar-default .navbar-nav > .active > a {
-  background-image: -webkit-linear-gradient(top, #dbdbdb 0%, #e2e2e2 100%);
-  background-image:      -o-linear-gradient(top, #dbdbdb 0%, #e2e2e2 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#dbdbdb), to(#e2e2e2));
-  background-image:         linear-gradient(to bottom, #dbdbdb 0%, #e2e2e2 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ffdbdbdb', endColorstr='#ffe2e2e2', GradientType=0);
-  background-repeat: repeat-x;
-  -webkit-box-shadow: inset 0 3px 9px rgba(0, 0, 0, .075);
-          box-shadow: inset 0 3px 9px rgba(0, 0, 0, .075);
-}
-.navbar-brand,
-.navbar-nav > li > a {
-  text-shadow: 0 1px 0 rgba(255, 255, 255, .25);
-}
-.navbar-inverse {
-  background-image: -webkit-linear-gradient(top, #3c3c3c 0%, #222 100%);
-  background-image:      -o-linear-gradient(top, #3c3c3c 0%, #222 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#3c3c3c), to(#222));
-  background-image:         linear-gradient(to bottom, #3c3c3c 0%, #222 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ff3c3c3c', endColorstr='#ff222222', GradientType=0);
-  filter: progid:DXImageTransform.Microsoft.gradient(enabled = false);
-  background-repeat: repeat-x;
-}
-.navbar-inverse .navbar-nav > .open > a,
-.navbar-inverse .navbar-nav > .active > a {
-  background-image: -webkit-linear-gradient(top, #080808 0%, #0f0f0f 100%);
-  background-image:      -o-linear-gradient(top, #080808 0%, #0f0f0f 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#080808), to(#0f0f0f));
-  background-image:         linear-gradient(to bottom, #080808 0%, #0f0f0f 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ff080808', endColorstr='#ff0f0f0f', GradientType=0);
-  background-repeat: repeat-x;
-  -webkit-box-shadow: inset 0 3px 9px rgba(0, 0, 0, .25);
-          box-shadow: inset 0 3px 9px rgba(0, 0, 0, .25);
-}
-.navbar-inverse .navbar-brand,
-.navbar-inverse .navbar-nav > li > a {
-  text-shadow: 0 -1px 0 rgba(0, 0, 0, .25);
-}
-.navbar-static-top,
-.navbar-fixed-top,
-.navbar-fixed-bottom {
-  border-radius: 0;
-}
-@media (max-width: 767px) {
-  .navbar .navbar-nav .open .dropdown-menu > .active > a,
-  .navbar .navbar-nav .open .dropdown-menu > .active > a:hover,
-  .navbar .navbar-nav .open .dropdown-menu > .active > a:focus {
-    color: #fff;
-    background-image: -webkit-linear-gradient(top, #337ab7 0%, #2e6da4 100%);
-    background-image:      -o-linear-gradient(top, #337ab7 0%, #2e6da4 100%);
-    background-image: -webkit-gradient(linear, left top, left bottom, from(#337ab7), to(#2e6da4));
-    background-image:         linear-gradient(to bottom, #337ab7 0%, #2e6da4 100%);
-    filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ff337ab7', endColorstr='#ff2e6da4', GradientType=0);
-    background-repeat: repeat-x;
-  }
-}
-.alert {
-  text-shadow: 0 1px 0 rgba(255, 255, 255, .2);
-  -webkit-box-shadow: inset 0 1px 0 rgba(255, 255, 255, .25), 0 1px 2px rgba(0, 0, 0, .05);
-          box-shadow: inset 0 1px 0 rgba(255, 255, 255, .25), 0 1px 2px rgba(0, 0, 0, .05);
-}
-.alert-success {
-  background-image: -webkit-linear-gradient(top, #dff0d8 0%, #c8e5bc 100%);
-  background-image:      -o-linear-gradient(top, #dff0d8 0%, #c8e5bc 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#dff0d8), to(#c8e5bc));
-  background-image:         linear-gradient(to bottom, #dff0d8 0%, #c8e5bc 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ffdff0d8', endColorstr='#ffc8e5bc', GradientType=0);
-  background-repeat: repeat-x;
-  border-color: #b2dba1;
-}
-.alert-info {
-  background-image: -webkit-linear-gradient(top, #d9edf7 0%, #b9def0 100%);
-  background-image:      -o-linear-gradient(top, #d9edf7 0%, #b9def0 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#d9edf7), to(#b9def0));
-  background-image:         linear-gradient(to bottom, #d9edf7 0%, #b9def0 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ffd9edf7', endColorstr='#ffb9def0', GradientType=0);
-  background-repeat: repeat-x;
-  border-color: #9acfea;
-}
-.alert-warning {
-  background-image: -webkit-linear-gradient(top, #fcf8e3 0%, #f8efc0 100%);
-  background-image:      -o-linear-gradient(top, #fcf8e3 0%, #f8efc0 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#fcf8e3), to(#f8efc0));
-  background-image:         linear-gradient(to bottom, #fcf8e3 0%, #f8efc0 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#fffcf8e3', endColorstr='#fff8efc0', GradientType=0);
-  background-repeat: repeat-x;
-  border-color: #f5e79e;
-}
-.alert-danger {
-  background-image: -webkit-linear-gradient(top, #f2dede 0%, #e7c3c3 100%);
-  background-image:      -o-linear-gradient(top, #f2dede 0%, #e7c3c3 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#f2dede), to(#e7c3c3));
-  background-image:         linear-gradient(to bottom, #f2dede 0%, #e7c3c3 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#fff2dede', endColorstr='#ffe7c3c3', GradientType=0);
-  background-repeat: repeat-x;
-  border-color: #dca7a7;
-}
-.progress {
-  background-image: -webkit-linear-gradient(top, #ebebeb 0%, #f5f5f5 100%);
-  background-image:      -o-linear-gradient(top, #ebebeb 0%, #f5f5f5 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#ebebeb), to(#f5f5f5));
-  background-image:         linear-gradient(to bottom, #ebebeb 0%, #f5f5f5 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ffebebeb', endColorstr='#fff5f5f5', GradientType=0);
-  background-repeat: repeat-x;
-}
-.progress-bar {
-  background-image: -webkit-linear-gradient(top, #337ab7 0%, #286090 100%);
-  background-image:      -o-linear-gradient(top, #337ab7 0%, #286090 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#337ab7), to(#286090));
-  background-image:         linear-gradient(to bottom, #337ab7 0%, #286090 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ff337ab7', endColorstr='#ff286090', GradientType=0);
-  background-repeat: repeat-x;
-}
-.progress-bar-success {
-  background-image: -webkit-linear-gradient(top, #5cb85c 0%, #449d44 100%);
-  background-image:      -o-linear-gradient(top, #5cb85c 0%, #449d44 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#5cb85c), to(#449d44));
-  background-image:         linear-gradient(to bottom, #5cb85c 0%, #449d44 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ff5cb85c', endColorstr='#ff449d44', GradientType=0);
-  background-repeat: repeat-x;
-}
-.progress-bar-info {
-  background-image: -webkit-linear-gradient(top, #5bc0de 0%, #31b0d5 100%);
-  background-image:      -o-linear-gradient(top, #5bc0de 0%, #31b0d5 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#5bc0de), to(#31b0d5));
-  background-image:         linear-gradient(to bottom, #5bc0de 0%, #31b0d5 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ff5bc0de', endColorstr='#ff31b0d5', GradientType=0);
-  background-repeat: repeat-x;
-}
-.progress-bar-warning {
-  background-image: -webkit-linear-gradient(top, #f0ad4e 0%, #ec971f 100%);
-  background-image:      -o-linear-gradient(top, #f0ad4e 0%, #ec971f 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#f0ad4e), to(#ec971f));
-  background-image:         linear-gradient(to bottom, #f0ad4e 0%, #ec971f 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#fff0ad4e', endColorstr='#ffec971f', GradientType=0);
-  background-repeat: repeat-x;
-}
-.progress-bar-danger {
-  background-image: -webkit-linear-gradient(top, #d9534f 0%, #c9302c 100%);
-  background-image:      -o-linear-gradient(top, #d9534f 0%, #c9302c 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#d9534f), to(#c9302c));
-  background-image:         linear-gradient(to bottom, #d9534f 0%, #c9302c 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ffd9534f', endColorstr='#ffc9302c', GradientType=0);
-  background-repeat: repeat-x;
-}
-.progress-bar-striped {
-  background-image: -webkit-linear-gradient(45deg, rgba(255, 255, 255, .15) 25%, transparent 25%, transparent 50%, rgba(255, 255, 255, .15) 50%, rgba(255, 255, 255, .15) 75%, transparent 75%, transparent);
-  background-image:      -o-linear-gradient(45deg, rgba(255, 255, 255, .15) 25%, transparent 25%, transparent 50%, rgba(255, 255, 255, .15) 50%, rgba(255, 255, 255, .15) 75%, transparent 75%, transparent);
-  background-image:         linear-gradient(45deg, rgba(255, 255, 255, .15) 25%, transparent 25%, transparent 50%, rgba(255, 255, 255, .15) 50%, rgba(255, 255, 255, .15) 75%, transparent 75%, transparent);
-}
-.list-group {
-  border-radius: 4px;
-  -webkit-box-shadow: 0 1px 2px rgba(0, 0, 0, .075);
-          box-shadow: 0 1px 2px rgba(0, 0, 0, .075);
-}
-.list-group-item.active,
-.list-group-item.active:hover,
-.list-group-item.active:focus {
-  text-shadow: 0 -1px 0 #286090;
-  background-image: -webkit-linear-gradient(top, #337ab7 0%, #2b669a 100%);
-  background-image:      -o-linear-gradient(top, #337ab7 0%, #2b669a 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#337ab7), to(#2b669a));
-  background-image:         linear-gradient(to bottom, #337ab7 0%, #2b669a 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ff337ab7', endColorstr='#ff2b669a', GradientType=0);
-  background-repeat: repeat-x;
-  border-color: #2b669a;
-}
-.list-group-item.active .badge,
-.list-group-item.active:hover .badge,
-.list-group-item.active:focus .badge {
-  text-shadow: none;
-}
-.panel {
-  -webkit-box-shadow: 0 1px 2px rgba(0, 0, 0, .05);
-          box-shadow: 0 1px 2px rgba(0, 0, 0, .05);
-}
-.panel-default > .panel-heading {
-  background-image: -webkit-linear-gradient(top, #f5f5f5 0%, #e8e8e8 100%);
-  background-image:      -o-linear-gradient(top, #f5f5f5 0%, #e8e8e8 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#f5f5f5), to(#e8e8e8));
-  background-image:         linear-gradient(to bottom, #f5f5f5 0%, #e8e8e8 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#fff5f5f5', endColorstr='#ffe8e8e8', GradientType=0);
-  background-repeat: repeat-x;
-}
-.panel-primary > .panel-heading {
-  background-image: -webkit-linear-gradient(top, #337ab7 0%, #2e6da4 100%);
-  background-image:      -o-linear-gradient(top, #337ab7 0%, #2e6da4 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#337ab7), to(#2e6da4));
-  background-image:         linear-gradient(to bottom, #337ab7 0%, #2e6da4 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ff337ab7', endColorstr='#ff2e6da4', GradientType=0);
-  background-repeat: repeat-x;
-}
-.panel-success > .panel-heading {
-  background-image: -webkit-linear-gradient(top, #dff0d8 0%, #d0e9c6 100%);
-  background-image:      -o-linear-gradient(top, #dff0d8 0%, #d0e9c6 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#dff0d8), to(#d0e9c6));
-  background-image:         linear-gradient(to bottom, #dff0d8 0%, #d0e9c6 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ffdff0d8', endColorstr='#ffd0e9c6', GradientType=0);
-  background-repeat: repeat-x;
-}
-.panel-info > .panel-heading {
-  background-image: -webkit-linear-gradient(top, #d9edf7 0%, #c4e3f3 100%);
-  background-image:      -o-linear-gradient(top, #d9edf7 0%, #c4e3f3 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#d9edf7), to(#c4e3f3));
-  background-image:         linear-gradient(to bottom, #d9edf7 0%, #c4e3f3 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ffd9edf7', endColorstr='#ffc4e3f3', GradientType=0);
-  background-repeat: repeat-x;
-}
-.panel-warning > .panel-heading {
-  background-image: -webkit-linear-gradient(top, #fcf8e3 0%, #faf2cc 100%);
-  background-image:      -o-linear-gradient(top, #fcf8e3 0%, #faf2cc 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#fcf8e3), to(#faf2cc));
-  background-image:         linear-gradient(to bottom, #fcf8e3 0%, #faf2cc 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#fffcf8e3', endColorstr='#fffaf2cc', GradientType=0);
-  background-repeat: repeat-x;
-}
-.panel-danger > .panel-heading {
-  background-image: -webkit-linear-gradient(top, #f2dede 0%, #ebcccc 100%);
-  background-image:      -o-linear-gradient(top, #f2dede 0%, #ebcccc 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#f2dede), to(#ebcccc));
-  background-image:         linear-gradient(to bottom, #f2dede 0%, #ebcccc 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#fff2dede', endColorstr='#ffebcccc', GradientType=0);
-  background-repeat: repeat-x;
-}
-.well {
-  background-image: -webkit-linear-gradient(top, #e8e8e8 0%, #f5f5f5 100%);
-  background-image:      -o-linear-gradient(top, #e8e8e8 0%, #f5f5f5 100%);
-  background-image: -webkit-gradient(linear, left top, left bottom, from(#e8e8e8), to(#f5f5f5));
-  background-image:         linear-gradient(to bottom, #e8e8e8 0%, #f5f5f5 100%);
-  filter: progid:DXImageTransform.Microsoft.gradient(startColorstr='#ffe8e8e8', endColorstr='#fff5f5f5', GradientType=0);
-  background-repeat: repeat-x;
-  border-color: #dcdcdc;
-  -webkit-box-shadow: inset 0 1px 3px rgba(0, 0, 0, .05), 0 1px 0 rgba(255, 255, 255, .1);
-          box-shadow: inset 0 1px 3px rgba(0, 0, 0, .05), 0 1px 0 rgba(255, 255, 255, .1);
-}
-/*# sourceMappingURL=bootstrap-theme.css.map */