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 2015/02/23 17:16:04 UTC

[3/7] storm git commit: Clearing out bootstrap. All tests pass.

Clearing out bootstrap. All tests pass.


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

Branch: refs/heads/master
Commit: ba6eed054ead6c094a4e33010db32c7186237191
Parents: 8358bde
Author: Kyle Nusbaum <kn...@yahoo-inc.com>
Authored: Wed Feb 4 16:07:44 2015 -0600
Committer: Kyle Nusbaum <kn...@yahoo-inc.com>
Committed: Wed Feb 4 16:07:44 2015 -0600

----------------------------------------------------------------------
 pom.xml                                         |  6 ------
 storm-core/pom.xml                              |  5 -----
 .../src/clj/backtype/storm/daemon/drpc.clj      |  2 +-
 .../src/clj/backtype/storm/daemon/nimbus.clj    |  3 +--
 .../src/clj/backtype/storm/daemon/worker.clj    |  2 +-
 .../test/clj/backtype/storm/clojure_test.clj    |  9 ++++-----
 .../test/clj/backtype/storm/drpc_test.clj       |  8 ++------
 .../test/clj/backtype/storm/grouping_test.clj   |  9 ++++-----
 .../clj/backtype/storm/integration_test.clj     | 10 +++++-----
 .../storm/messaging/netty_integration_test.clj  |  5 ++---
 .../storm/messaging/netty_unit_test.clj         |  5 ++---
 .../test/clj/backtype/storm/messaging_test.clj  |  6 ++----
 .../test/clj/backtype/storm/metrics_test.clj    |  8 +++-----
 .../test/clj/backtype/storm/multilang_test.clj  |  6 ++----
 .../test/clj/backtype/storm/nimbus_test.clj     | 21 +++++++++++++-------
 .../scheduler/multitenant_scheduler_test.clj    |  4 +---
 .../test/clj/backtype/storm/scheduler_test.clj  |  4 +---
 .../storm/security/auth/AuthUtils_test.clj      |  6 +-----
 .../backtype/storm/security/auth/auth_test.clj  |  9 ++++-----
 .../storm/security/auth/drpc_auth_test.clj      |  7 ++-----
 .../storm/security/auth/nimbus_auth_test.clj    | 10 +++-------
 .../clj/backtype/storm/subtopology_test.clj     |  9 +++------
 .../test/clj/backtype/storm/supervisor_test.clj | 16 +++++++--------
 .../test/clj/backtype/storm/tick_tuple_test.clj |  7 +++----
 .../clj/backtype/storm/transactional_test.clj   | 14 ++++++++-----
 25 files changed, 77 insertions(+), 114 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index af86bd0..c240414 100644
--- a/pom.xml
+++ b/pom.xml
@@ -473,12 +473,6 @@
                 <artifactId>netty</artifactId>
                 <version>${netty.version}</version>
             </dependency>
-           <dependency>
-               <groupId>org.clojars.runa</groupId>
-               <artifactId>conjure</artifactId>
-               <version>${conjure.version}</version>
-               <scope>test</scope>
-            </dependency>
             <dependency>
                 <groupId>org.clojure</groupId>
                 <artifactId>clojure-contrib</artifactId>

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/pom.xml
----------------------------------------------------------------------
diff --git a/storm-core/pom.xml b/storm-core/pom.xml
index 9f3ed49..ae2bb78 100644
--- a/storm-core/pom.xml
+++ b/storm-core/pom.xml
@@ -212,11 +212,6 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.clojars.runa</groupId>
-            <artifactId>conjure</artifactId>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
 	  <groupId>org.apache.hadoop</groupId>
 	  <artifactId>hadoop-auth</artifactId>
 	  <version>2.4.0</version>

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/src/clj/backtype/storm/daemon/drpc.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/drpc.clj b/storm-core/src/clj/backtype/storm/daemon/drpc.clj
index 7fee7f0..cb9b1d2 100644
--- a/storm-core/src/clj/backtype/storm/daemon/drpc.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/drpc.clj
@@ -15,7 +15,7 @@
 ;; limitations under the License.
 
 (ns backtype.storm.daemon.drpc
-  (:import [backtype.storm.security.auth AuthUtils ThriftServer ThriftConnectionType])
+  (:import [backtype.storm.security.auth AuthUtils ThriftServer ThriftConnectionType ReqContext])
   (:import [backtype.storm.security.auth.authorizer DRPCAuthorizerBase])
   (:import [backtype.storm.generated DistributedRPC DistributedRPC$Iface DistributedRPC$Processor
             DRPCRequest DRPCExecutionException DistributedRPCInvocations DistributedRPCInvocations$Iface

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/src/clj/backtype/storm/daemon/nimbus.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/nimbus.clj b/storm-core/src/clj/backtype/storm/daemon/nimbus.clj
index a65dd8a..c73afc8 100644
--- a/storm-core/src/clj/backtype/storm/daemon/nimbus.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/nimbus.clj
@@ -20,14 +20,13 @@
   (:import [org.apache.thrift.transport TNonblockingServerTransport TNonblockingServerSocket])
   (:import [org.apache.commons.io FileUtils])
   (:import [java.nio ByteBuffer]
-           [java.util Collections])
+           [java.util Collections HashMap])
   (:import [java.io FileNotFoundException File FileOutputStream])
   (:import [java.nio.channels Channels WritableByteChannel])
   (:import [backtype.storm.security.auth ThriftServer ThriftConnectionType ReqContext AuthUtils])
   (:use [backtype.storm.scheduler.DefaultScheduler])
   (:import [backtype.storm.scheduler INimbus SupervisorDetails WorkerSlot TopologyDetails
             Cluster Topologies SchedulerAssignment SchedulerAssignmentImpl DefaultScheduler ExecutorDetails])
-<<<<<<< HEAD
   (:import [backtype.storm.utils TimeCacheMap TimeCacheMap$ExpiredCallback Utils ThriftTopologyUtils
             BufferFileInputStream])
   (:import [backtype.storm.generated NotAliveException AlreadyAliveException StormTopology ErrorInfo

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/src/clj/backtype/storm/daemon/worker.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/worker.clj b/storm-core/src/clj/backtype/storm/daemon/worker.clj
index acda96d..0a5d984 100644
--- a/storm-core/src/clj/backtype/storm/daemon/worker.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/worker.clj
@@ -22,7 +22,7 @@
   (:require [backtype.storm.messaging.loader :as msg-loader])
   (:import [java.util.concurrent Executors])
   (:import [java.util ArrayList HashMap])
-  (:import [backtype.storm.utils TransferDrainer ThriftTopologyUtils])
+  (:import [backtype.storm.utils Utils TransferDrainer ThriftTopologyUtils])
   (:import [backtype.storm.messaging TransportFactory])
   (:import [backtype.storm.messaging TaskMessage IContext IConnection])
   (:import [backtype.storm.daemon.common WorkerHeartbeat])

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/clojure_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/clojure_test.clj b/storm-core/test/clj/backtype/storm/clojure_test.clj
index 53eebe5..4147ae1 100644
--- a/storm-core/test/clj/backtype/storm/clojure_test.clj
+++ b/storm-core/test/clj/backtype/storm/clojure_test.clj
@@ -15,12 +15,11 @@
 ;; limitations under the License.
 (ns backtype.storm.clojure-test
   (:use [clojure test])
-  (:import [backtype.storm.testing TestWordSpout])
-  (:use [backtype.storm bootstrap testing])
+  (:import [backtype.storm.testing TestWordSpout TestPlannerSpout]
+           [backtype.storm.tuple Fields])
+  (:use [backtype.storm testing clojure config])
   (:use [backtype.storm.daemon common])
-  )
-
-(bootstrap)
+  (:require [backtype.storm [thrift :as thrift]]))
 
 
 (defbolt lalala-bolt1 ["word"] [[val :as tuple] collector]

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/drpc_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/drpc_test.clj b/storm-core/test/clj/backtype/storm/drpc_test.clj
index debb332..0e35016 100644
--- a/storm-core/test/clj/backtype/storm/drpc_test.clj
+++ b/storm-core/test/clj/backtype/storm/drpc_test.clj
@@ -23,13 +23,9 @@
   (:import [backtype.storm.tuple Fields])
   (:import [backtype.storm.generated DRPCExecutionException])
   (:import [java.util.concurrent ConcurrentLinkedQueue])
-  (:use [backtype.storm bootstrap config testing])
+  (:use [backtype.storm config testing clojure])
   (:use [backtype.storm.daemon common drpc])
-  (:use [backtype.storm clojure])
-  (:use [conjure core])
-  )
-
-(bootstrap)
+  (:use [conjure core]))
 
 (defbolt exclamation-bolt ["result" "return-info"] [tuple collector]
   (emit-bolt! collector

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/grouping_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/grouping_test.clj b/storm-core/test/clj/backtype/storm/grouping_test.clj
index bf3efe2..fc13b0c 100644
--- a/storm-core/test/clj/backtype/storm/grouping_test.clj
+++ b/storm-core/test/clj/backtype/storm/grouping_test.clj
@@ -15,12 +15,11 @@
 ;; limitations under the License.
 (ns backtype.storm.grouping-test
   (:use [clojure test])
-  (:import [backtype.storm.testing TestWordCounter TestWordSpout TestGlobalCount TestAggregatesCounter NGrouping])
-  (:use [backtype.storm bootstrap testing])
+  (:import [backtype.storm.testing TestWordCounter TestWordSpout TestGlobalCount TestAggregatesCounter NGrouping]
+           [backtype.storm.generated JavaObject JavaObjectArg])
+  (:use [backtype.storm testing clojure])
   (:use [backtype.storm.daemon common])
-  )
-
-(bootstrap)
+  (:require [backtype.storm [thrift :as thrift]]))
 
 (deftest test-shuffle
   (with-simulated-time-local-cluster [cluster :supervisors 4]

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/integration_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/integration_test.clj b/storm-core/test/clj/backtype/storm/integration_test.clj
index b192253..712b195 100644
--- a/storm-core/test/clj/backtype/storm/integration_test.clj
+++ b/storm-core/test/clj/backtype/storm/integration_test.clj
@@ -15,15 +15,15 @@
 ;; limitations under the License.
 (ns backtype.storm.integration-test
   (:use [clojure test])
+  (:import [backtype.storm Config])
   (:import [backtype.storm.topology TopologyBuilder])
   (:import [backtype.storm.generated InvalidTopologyException SubmitOptions TopologyInitialStatus])
   (:import [backtype.storm.testing TestWordCounter TestWordSpout TestGlobalCount
-              TestAggregatesCounter TestConfBolt AckFailMapTracker])
-  (:use [backtype.storm bootstrap testing])
+            TestAggregatesCounter TestConfBolt AckFailMapTracker AckTracker TestPlannerSpout])
+  (:import [backtype.storm.tuple Fields])
+  (:use [backtype.storm testing config clojure util])
   (:use [backtype.storm.daemon common])
-  )
-
-(bootstrap)
+  (:require [backtype.storm [thrift :as thrift]]))
 
 (deftest test-basic-topology
   (doseq [zmq-on? [true false]]

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/messaging/netty_integration_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/messaging/netty_integration_test.clj b/storm-core/test/clj/backtype/storm/messaging/netty_integration_test.clj
index 98144cc..a918a4b 100644
--- a/storm-core/test/clj/backtype/storm/messaging/netty_integration_test.clj
+++ b/storm-core/test/clj/backtype/storm/messaging/netty_integration_test.clj
@@ -17,9 +17,8 @@
   (:use [clojure test])
   (:import [backtype.storm.messaging TransportFactory])
   (:import [backtype.storm.testing TestWordSpout TestGlobalCount])
-  (:use [backtype.storm bootstrap testing util]))
-
-(bootstrap)
+  (:use [backtype.storm testing util config])
+  (:require [backtype.storm [thrift :as thrift]]))
 
 (deftest test-integration
   (with-simulated-time-local-cluster [cluster :supervisors 4 :supervisor-slot-port-min 6710

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/messaging/netty_unit_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/messaging/netty_unit_test.clj b/storm-core/test/clj/backtype/storm/messaging/netty_unit_test.clj
index 2061ddf..38160f8 100644
--- a/storm-core/test/clj/backtype/storm/messaging/netty_unit_test.clj
+++ b/storm-core/test/clj/backtype/storm/messaging/netty_unit_test.clj
@@ -16,9 +16,8 @@
 (ns backtype.storm.messaging.netty-unit-test
   (:use [clojure test])
   (:import [backtype.storm.messaging TransportFactory])
-  (:use [backtype.storm bootstrap testing util]))
-
-(bootstrap)
+  (:use [backtype.storm testing util config])
+  (:import [java.util ArrayList]))
 
 (def port 6700)
 (def task 1)

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/messaging_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/messaging_test.clj b/storm-core/test/clj/backtype/storm/messaging_test.clj
index c719c68..53cd555 100644
--- a/storm-core/test/clj/backtype/storm/messaging_test.clj
+++ b/storm-core/test/clj/backtype/storm/messaging_test.clj
@@ -16,11 +16,9 @@
 (ns backtype.storm.messaging-test
   (:use [clojure test])
   (:import [backtype.storm.testing TestWordCounter TestWordSpout TestGlobalCount TestEventLogSpout TestEventOrderCheckBolt])
-  (:use [backtype.storm bootstrap testing])
+  (:use [backtype.storm testing config])
   (:use [backtype.storm.daemon common])
-  )
-
-(bootstrap)
+  (:require [backtype.storm [thrift :as thrift]]))
 
 (deftest test-local-transport
   (doseq [transport-on? [false true]] 

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/metrics_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/metrics_test.clj b/storm-core/test/clj/backtype/storm/metrics_test.clj
index 4356d30..90a3e0c 100644
--- a/storm-core/test/clj/backtype/storm/metrics_test.clj
+++ b/storm-core/test/clj/backtype/storm/metrics_test.clj
@@ -25,12 +25,10 @@
   (:import [backtype.storm.metric.api.rpc CountShellMetric])
   (:import [backtype.storm.utils Utils])
   
-  (:use [backtype.storm bootstrap testing])
+  (:use [backtype.storm testing clojure config])
   (:use [backtype.storm.daemon common])
-  (:use [backtype.storm.metric testing]))
-
-
-(bootstrap)
+  (:use [backtype.storm.metric testing])
+  (:require [backtype.storm [thrift :as thrift]]))
 
 (defbolt acking-bolt {} {:prepare true}
   [conf context collector]  

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/multilang_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/multilang_test.clj b/storm-core/test/clj/backtype/storm/multilang_test.clj
index 2d3a866..a624403 100644
--- a/storm-core/test/clj/backtype/storm/multilang_test.clj
+++ b/storm-core/test/clj/backtype/storm/multilang_test.clj
@@ -15,11 +15,9 @@
 ;; limitations under the License.
 (ns backtype.storm.multilang-test
   (:use [clojure test])
-  (:use [backtype.storm bootstrap testing])
+  (:use [backtype.storm testing config])
   (:use [backtype.storm.daemon common])
-  )
-
-(bootstrap)
+  (:require [backtype.storm [thrift :as thrift]]))
 
 ;; (deftest test-multilang-fy
 ;;   (with-local-cluster [cluster :supervisors 4]

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/nimbus_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/nimbus_test.clj b/storm-core/test/clj/backtype/storm/nimbus_test.clj
index efdad25..99d1e32 100644
--- a/storm-core/test/clj/backtype/storm/nimbus_test.clj
+++ b/storm-core/test/clj/backtype/storm/nimbus_test.clj
@@ -17,16 +17,23 @@
   (:use [clojure test])
   (:require [backtype.storm [util :as util]])
   (:require [backtype.storm.daemon [nimbus :as nimbus]])
-  (:import [backtype.storm.testing TestWordCounter TestWordSpout TestGlobalCount TestAggregatesCounter])
+  (:import [backtype.storm.testing TestWordCounter TestWordSpout TestGlobalCount
+            TestAggregatesCounter TestPlannerSpout TestPlannerBolt])
   (:import [backtype.storm.scheduler INimbus])
-  (:import [backtype.storm.generated Credentials])
-  (:use [backtype.storm bootstrap testing MockAutoCred])
+  (:import [backtype.storm.generated Credentials NotAliveException SubmitOptions
+            TopologyInitialStatus AlreadyAliveException KillOptions RebalanceOptions
+            InvalidTopologyException AuthorizationException])
+  (:import [java.util HashMap])
+  (:import [java.io File])
+  (:import [backtype.storm.utils Time])
+  (:import [org.apache.commons.io FileUtils])
+  (:use [backtype.storm testing MockAutoCred util config log timer])
   (:use [backtype.storm.daemon common])
   (:require [conjure.core])
-  (:use [conjure core])
-  )
-
-(bootstrap)
+  (:require [backtype.storm
+             [thrift :as thrift]
+             [cluster :as cluster]])
+  (:use [conjure core]))
 
 (defn storm-component->task-info [cluster storm-name]
   (let [storm-id (get-storm-id (:storm-cluster-state cluster) storm-name)

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/scheduler/multitenant_scheduler_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/scheduler/multitenant_scheduler_test.clj b/storm-core/test/clj/backtype/storm/scheduler/multitenant_scheduler_test.clj
index 856121f..d347ed5 100644
--- a/storm-core/test/clj/backtype/storm/scheduler/multitenant_scheduler_test.clj
+++ b/storm-core/test/clj/backtype/storm/scheduler/multitenant_scheduler_test.clj
@@ -15,7 +15,7 @@
 ;; limitations under the License.
 (ns backtype.storm.scheduler.multitenant-scheduler-test
   (:use [clojure test])
-  (:use [backtype.storm bootstrap config testing])
+  (:use [backtype.storm config testing log])
   (:require [backtype.storm.daemon [nimbus :as nimbus]])
   (:import [backtype.storm.generated StormTopology])
   (:import [backtype.storm.scheduler Cluster SupervisorDetails WorkerSlot ExecutorDetails
@@ -23,8 +23,6 @@
   (:import [backtype.storm.scheduler.multitenant Node NodePool FreePool DefaultPool
             IsolatedPool MultitenantScheduler]))
 
-(bootstrap)
-
 (defn gen-supervisors [count]
   (into {} (for [id (range count)
                 :let [supervisor (SupervisorDetails. (str "super" id) (str "host" id) (list ) (map int (list 1 2 3 4)))]]

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/scheduler_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/scheduler_test.clj b/storm-core/test/clj/backtype/storm/scheduler_test.clj
index 856ddeb..45acf75 100644
--- a/storm-core/test/clj/backtype/storm/scheduler_test.clj
+++ b/storm-core/test/clj/backtype/storm/scheduler_test.clj
@@ -15,15 +15,13 @@
 ;; limitations under the License.
 (ns backtype.storm.scheduler-test
   (:use [clojure test])
-  (:use [backtype.storm bootstrap config testing])
+  (:use [backtype.storm config testing])
   (:use [backtype.storm.scheduler EvenScheduler])
   (:require [backtype.storm.daemon [nimbus :as nimbus]])
   (:import [backtype.storm.generated StormTopology])
   (:import [backtype.storm.scheduler Cluster SupervisorDetails WorkerSlot ExecutorDetails
             SchedulerAssignmentImpl Topologies TopologyDetails]))
 
-(bootstrap)
-
 (defn clojurify-executor->slot [executorToSlot]
   (into {} (for [[executor slot] executorToSlot]
              {[(.getStartTask executor) (.getEndTask executor)]

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/security/auth/AuthUtils_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/security/auth/AuthUtils_test.clj b/storm-core/test/clj/backtype/storm/security/auth/AuthUtils_test.clj
index 2d96b18..059b2be 100644
--- a/storm-core/test/clj/backtype/storm/security/auth/AuthUtils_test.clj
+++ b/storm-core/test/clj/backtype/storm/security/auth/AuthUtils_test.clj
@@ -18,11 +18,7 @@
   (:import [java.io IOException])
   (:import [javax.security.auth.login AppConfigurationEntry Configuration])
   (:import [org.mockito Mockito])
-  (:use [clojure test])
-  (:use [backtype.storm bootstrap])
-)
-
-(bootstrap)
+  (:use [clojure test]))
 
 (deftest test-throws-on-missing-section
   (is (thrown? IOException

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/security/auth/auth_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/security/auth/auth_test.clj b/storm-core/test/clj/backtype/storm/security/auth/auth_test.clj
index 6563730..1a9713b 100644
--- a/storm-core/test/clj/backtype/storm/security/auth/auth_test.clj
+++ b/storm-core/test/clj/backtype/storm/security/auth/auth_test.clj
@@ -28,12 +28,11 @@
   (:import [backtype.storm.security.auth.authorizer SimpleWhitelistAuthorizer SimpleACLAuthorizer])
   (:import [backtype.storm.security.auth AuthUtils ThriftServer ThriftClient ShellBasedGroupsMapping 
             ReqContext SimpleTransportPlugin KerberosPrincipalToLocal ThriftConnectionType])
-  (:use [backtype.storm bootstrap util])
+  (:use [backtype.storm util config])
   (:use [backtype.storm.daemon common])
-  (:use [backtype.storm bootstrap testing])
-  (:import [backtype.storm.generated Nimbus Nimbus$Client]))
-
-(bootstrap)
+  (:use [backtype.storm testing])
+  (:import [backtype.storm.generated Nimbus Nimbus$Client Nimbus$Iface StormTopology SubmitOptions
+            KillOptions RebalanceOptions ClusterSummary TopologyInfo Nimbus$Processor]))
 
 (defn mk-principal [name]
   (reify Principal

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/security/auth/drpc_auth_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/security/auth/drpc_auth_test.clj b/storm-core/test/clj/backtype/storm/security/auth/drpc_auth_test.clj
index ff431ec..b6ede3b 100644
--- a/storm-core/test/clj/backtype/storm/security/auth/drpc_auth_test.clj
+++ b/storm-core/test/clj/backtype/storm/security/auth/drpc_auth_test.clj
@@ -25,12 +25,9 @@
   (:import [backtype.storm.drpc DRPCInvocationsClient])
   (:import [java.util.concurrent TimeUnit])
   (:import [javax.security.auth Subject])
-  (:use [backtype.storm bootstrap util])
+  (:use [backtype.storm util config log])
   (:use [backtype.storm.daemon common])
-  (:use [backtype.storm bootstrap testing])
-  )
-
-(bootstrap)
+  (:use [backtype.storm testing]))
 
 (def drpc-timeout (Integer. 30))
 

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/security/auth/nimbus_auth_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/security/auth/nimbus_auth_test.clj b/storm-core/test/clj/backtype/storm/security/auth/nimbus_auth_test.clj
index bb70239..549256b 100644
--- a/storm-core/test/clj/backtype/storm/security/auth/nimbus_auth_test.clj
+++ b/storm-core/test/clj/backtype/storm/security/auth/nimbus_auth_test.clj
@@ -24,16 +24,12 @@
   (:import [backtype.storm.generated NotAliveException])
   (:import [backtype.storm.security.auth AuthUtils ThriftServer ThriftClient 
                                          ReqContext ThriftConnectionType])
-  (:use [backtype.storm bootstrap cluster util])
+  (:use [backtype.storm cluster util config log])
   (:use [backtype.storm.daemon common nimbus])
-  (:use [backtype.storm bootstrap])
-  (:import [backtype.storm.generated Nimbus Nimbus$Client 
+  (:import [backtype.storm.generated Nimbus Nimbus$Client Nimbus$Processor 
             AuthorizationException SubmitOptions TopologyInitialStatus KillOptions])
   (:require [conjure.core])
-  (:use [conjure core])
-  )
-
-(bootstrap)
+  (:use [conjure core]))
 
 (def nimbus-timeout (Integer. 30))
 

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/subtopology_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/subtopology_test.clj b/storm-core/test/clj/backtype/storm/subtopology_test.clj
index 1e57cbd..954e62d 100644
--- a/storm-core/test/clj/backtype/storm/subtopology_test.clj
+++ b/storm-core/test/clj/backtype/storm/subtopology_test.clj
@@ -18,11 +18,8 @@
   (:import [backtype.storm.topology TopologyBuilder])
   (:import [backtype.storm.testing TestWordSpout PrepareBatchBolt BatchRepeatA BatchProcessWord BatchNumberList])
   (:import [backtype.storm.coordination BatchSubtopologyBuilder])
-  (:use [backtype.storm bootstrap testing])
-  (:use [backtype.storm.daemon common])  
-  )
-
-(bootstrap)
+  (:use [backtype.storm testing])
+  (:use [backtype.storm.daemon common]))
 
 ;; todo: need to configure coordinatedbolt with streams that aren't subscribed to, should auto-anchor those to the final
 ;; coordination tuple... find all streams that aren't subscribed to
@@ -62,4 +59,4 @@
 ;;                 ["ba" [1]]
 ;;                 ]
 ;;                (read-tuples results "joiner")))
-;;       )))
\ No newline at end of file
+;;       )))

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/supervisor_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/supervisor_test.clj b/storm-core/test/clj/backtype/storm/supervisor_test.clj
index c427e71..4c029dd 100644
--- a/storm-core/test/clj/backtype/storm/supervisor_test.clj
+++ b/storm-core/test/clj/backtype/storm/supervisor_test.clj
@@ -18,19 +18,17 @@
   (:require [conjure.core])
   (:use [conjure core])
   (:require [clojure.contrib [string :as contrib-str]])
-  (:require [clojure [string :as string]])
-  (:import [backtype.storm.testing TestWordCounter TestWordSpout TestGlobalCount TestAggregatesCounter])
+  (:require [clojure [string :as string] [set :as set]])
+  (:import [backtype.storm.testing TestWordCounter TestWordSpout TestGlobalCount TestAggregatesCounter TestPlannerSpout])
   (:import [backtype.storm.scheduler ISupervisor])
+  (:import [backtype.storm.generated RebalanceOptions])
   (:import [java.util UUID])
-  (:use [backtype.storm bootstrap config testing])
+  (:use [backtype.storm config testing util timer])
   (:use [backtype.storm.daemon common])
-  (:require [backtype.storm.daemon [worker :as worker] [supervisor :as supervisor]])
+  (:require [backtype.storm.daemon [worker :as worker] [supervisor :as supervisor]]
+            [backtype.storm [thrift :as thrift] [cluster :as cluster]])
   (:use [conjure core])
-  (:require [clojure.java.io :as io])
-  )
-
-(bootstrap)
-
+  (:require [clojure.java.io :as io]))
 
 (defn worker-assignment
   "Return [storm-id executors]"

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/tick_tuple_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/tick_tuple_test.clj b/storm-core/test/clj/backtype/storm/tick_tuple_test.clj
index a218200..458876e 100644
--- a/storm-core/test/clj/backtype/storm/tick_tuple_test.clj
+++ b/storm-core/test/clj/backtype/storm/tick_tuple_test.clj
@@ -15,10 +15,9 @@
 ;; limitations under the License.
 (ns backtype.storm.tick-tuple-test
   (:use [clojure test])
-  (:use [backtype.storm bootstrap testing])
-  (:use [backtype.storm.daemon common]))
-
-(bootstrap)
+  (:use [backtype.storm testing clojure config])
+  (:use [backtype.storm.daemon common])
+  (:require [backtype.storm [thrift :as thrift]]))
 
 (defbolt noop-bolt ["tuple"] {:prepare true}
   [conf context collector]

http://git-wip-us.apache.org/repos/asf/storm/blob/ba6eed05/storm-core/test/clj/backtype/storm/transactional_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/transactional_test.clj b/storm-core/test/clj/backtype/storm/transactional_test.clj
index 6c9ea44..95e3690 100644
--- a/storm-core/test/clj/backtype/storm/transactional_test.clj
+++ b/storm-core/test/clj/backtype/storm/transactional_test.clj
@@ -15,10 +15,16 @@
 ;; limitations under the License.
 (ns backtype.storm.transactional-test
   (:use [clojure test])
+  (:import [backtype.storm Constants])
   (:import [backtype.storm.topology TopologyBuilder])
   (:import [backtype.storm.transactional TransactionalSpoutCoordinator ITransactionalSpout ITransactionalSpout$Coordinator TransactionAttempt
             TransactionalTopologyBuilder])
   (:import [backtype.storm.transactional.state TransactionalState TestTransactionalState RotatingTransactionalState RotatingTransactionalState$StateInitializer])
+  (:import [backtype.storm.spout SpoutOutputCollector ISpoutOutputCollector])
+  (:import [backtype.storm.task OutputCollector IOutputCollector])
+  (:import [backtype.storm.coordination BatchBoltExecutor])
+  (:import [backtype.storm.utils RegisteredGlobalState])
+  (:import [backtype.storm.tuple Fields])
   (:import [backtype.storm.testing CountingBatchBolt MemoryTransactionalSpout
             KeyedCountingBatchBolt KeyedCountingCommitterBolt KeyedSummingBatchBolt
             IdentityBolt CountingCommitBolt OpaqueMemoryTransactionalSpout])
@@ -28,11 +34,9 @@
   (:import [org.apache.zookeeper CreateMode ZooDefs ZooDefs$Ids])
   (:import [org.mockito Matchers Mockito])
   (:import [org.mockito.exceptions.base MockitoAssertionError])
-  (:use [backtype.storm bootstrap testing])
-  (:use [backtype.storm.daemon common])  
-  )
-
-(bootstrap)
+  (:import [java.util HashMap Collections ArrayList])
+  (:use [backtype.storm testing util config clojure])
+  (:use [backtype.storm.daemon common]))
 
 ;; Testing TODO:
 ;; * Test that it repeats the meta for a partitioned state (test partitioned emitter on its own)