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 2017/04/05 23:19:22 UTC

[19/23] storm git commit: STORM-2453 Move non-connectors into the top directory

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/java/org/apache/storm/flux/TCKTest.java
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/java/org/apache/storm/flux/TCKTest.java b/external/flux/flux-core/src/test/java/org/apache/storm/flux/TCKTest.java
deleted file mode 100644
index bb5d7ec..0000000
--- a/external/flux/flux-core/src/test/java/org/apache/storm/flux/TCKTest.java
+++ /dev/null
@@ -1,256 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.storm.flux;
-
-import org.apache.storm.Config;
-import org.apache.storm.generated.StormTopology;
-import org.apache.storm.flux.model.ExecutionContext;
-import org.apache.storm.flux.model.TopologyDef;
-import org.apache.storm.flux.parser.FluxParser;
-import org.apache.storm.flux.test.TestBolt;
-import org.junit.Test;
-
-import java.io.File;
-
-import static org.junit.Assert.*;
-
-public class TCKTest {
-    @Test
-    public void testTCK() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/tck.yaml", false, true, null, false);
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-    @Test
-    public void testShellComponents() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/shell_test.yaml", false, true, null, false);
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-    @Test(expected = IllegalArgumentException.class)
-    public void testBadShellComponents() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/bad_shell_test.yaml", false, true, null, false);
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-    @Test
-    public void testKafkaSpoutConfig() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/kafka_test.yaml", false, true, null, false);
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-    @Test
-    public void testLoadFromResource() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/kafka_test.yaml", false, true, null, false);
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-
-    @Test
-    public void testHdfs() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/hdfs_test.yaml", false, true, null, false);
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-    @Test
-    public void testDiamondTopology() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/diamond-topology.yaml", false, true, null, false);
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-
-    @Test
-    public void testHbase() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/simple_hbase.yaml", false, true, null, false);
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-    @Test(expected = IllegalArgumentException.class)
-    public void testBadHbase() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/bad_hbase.yaml", false, true, null, false);
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-    @Test
-    public void testIncludes() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/include_test.yaml", false, true, null, false);
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        assertTrue(topologyDef.getName().equals("include-topology"));
-        assertTrue(topologyDef.getBolts().size() > 0);
-        assertTrue(topologyDef.getSpouts().size() > 0);
-        topology.validate();
-    }
-
-    @Test
-    public void testTopologySource() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/existing-topology.yaml", false, true, null, false);
-        assertTrue(topologyDef.validate());
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-    @Test
-    public void testTopologySourceWithReflection() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/existing-topology-reflection.yaml", false, true, null, false);
-        assertTrue(topologyDef.validate());
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-    @Test
-    public void testTopologySourceWithConfigParam() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/existing-topology-reflection-config.yaml", false, true, null, false);
-        assertTrue(topologyDef.validate());
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-    @Test
-    public void testTopologySourceWithMethodName() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/existing-topology-method-override.yaml", false, true, null, false);
-        assertTrue(topologyDef.validate());
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-
-    @Test
-    public void testTridentTopologySource() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/existing-topology-trident.yaml", false, true, null, false);
-        assertTrue(topologyDef.validate());
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-    @Test(expected = IllegalArgumentException.class)
-    public void testInvalidTopologySource() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/invalid-existing-topology.yaml", false, true, null, false);
-        assertFalse("Topology config is invalid.", topologyDef.validate());
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-    }
-
-
-    @Test
-    public void testTopologySourceWithGetMethodName() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/existing-topology-reflection.yaml", false, true, null, false);
-        assertTrue(topologyDef.validate());
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-    }
-
-    @Test
-    public void testTopologySourceWithConfigMethods() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/config-methods-test.yaml", false, true, null, false);
-        assertTrue(topologyDef.validate());
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-
-        // make sure the property was actually set
-        TestBolt bolt = (TestBolt)context.getBolt("bolt-1");
-        assertTrue(bolt.getFoo().equals("foo"));
-        assertTrue(bolt.getBar().equals("bar"));
-        assertTrue(bolt.getFooBar().equals("foobar"));
-        assertArrayEquals(new TestBolt.TestClass[] {new TestBolt.TestClass("foo"), new TestBolt.TestClass("bar"), new TestBolt.TestClass("baz")}, bolt.getClasses());
-    }
-
-    @Test
-    public void testVariableSubstitution() throws Exception {
-        TopologyDef topologyDef = FluxParser.parseResource("/configs/substitution-test.yaml", false, true, "src/test/resources/configs/test.properties", true);
-        assertTrue(topologyDef.validate());
-        Config conf = FluxBuilder.buildConfig(topologyDef);
-        ExecutionContext context = new ExecutionContext(topologyDef, conf);
-        StormTopology topology = FluxBuilder.buildTopology(context);
-        assertNotNull(topology);
-        topology.validate();
-
-        // test basic substitution
-        assertEquals("Property not replaced.",
-                "substitution-topology",
-                context.getTopologyDef().getName());
-
-        // test environment variable substitution
-        // $PATH should be defined on most systems
-        String envPath = System.getenv().get("PATH");
-        assertEquals("ENV variable not replaced.",
-                envPath,
-                context.getTopologyDef().getConfig().get("test.env.value"));
-
-    }
-}

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/java/org/apache/storm/flux/multilang/MultilangEnvirontmentTest.java
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/java/org/apache/storm/flux/multilang/MultilangEnvirontmentTest.java b/external/flux/flux-core/src/test/java/org/apache/storm/flux/multilang/MultilangEnvirontmentTest.java
deleted file mode 100644
index dcded17..0000000
--- a/external/flux/flux-core/src/test/java/org/apache/storm/flux/multilang/MultilangEnvirontmentTest.java
+++ /dev/null
@@ -1,89 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.storm.flux.multilang;
-
-
-import org.junit.Test;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import java.io.ByteArrayOutputStream;
-import java.io.InputStream;
-import java.io.OutputStream;
-
-import static org.junit.Assert.assertEquals;
-
-/**
- * Sanity checks to make sure we can at least invoke the shells used.
- */
-public class MultilangEnvirontmentTest {
-    private static final Logger LOG = LoggerFactory.getLogger(MultilangEnvirontmentTest.class);
-
-    @Test
-    public void testInvokePython() throws Exception {
-        String[] command = new String[]{"python", "--version"};
-        int exitVal = invokeCommand(command);
-        assertEquals("Exit value for python is 0.", 0, exitVal);
-    }
-
-    @Test
-    public void testInvokeNode() throws Exception {
-        String[] command = new String[]{"node", "--version"};
-        int exitVal = invokeCommand(command);
-        assertEquals("Exit value for node is 0.", 0, exitVal);
-    }
-
-    private static class StreamRedirect implements Runnable {
-        private InputStream in;
-        private OutputStream out;
-
-        public StreamRedirect(InputStream in, OutputStream out) {
-            this.in = in;
-            this.out = out;
-        }
-
-        @Override
-        public void run() {
-            try {
-                int i = -1;
-                while ((i = this.in.read()) != -1) {
-                    out.write(i);
-                }
-                this.in.close();
-                this.out.close();
-            } catch (Exception e) {
-                e.printStackTrace();
-            }
-        }
-    }
-
-    private int invokeCommand(String[] args) throws Exception {
-        LOG.debug("Invoking command: {}", args);
-
-        ProcessBuilder pb = new ProcessBuilder(args);
-        pb.redirectErrorStream(true);
-        final Process proc = pb.start();
-
-        ByteArrayOutputStream out = new ByteArrayOutputStream();
-        Thread t = new Thread(new StreamRedirect(proc.getInputStream(), out));
-        t.start();
-        int exitVal = proc.waitFor();
-        LOG.debug("Command result: {}", out.toString());
-        return exitVal;
-    }
-}

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/SimpleTopology.java
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/SimpleTopology.java b/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/SimpleTopology.java
deleted file mode 100644
index 8e3cda2..0000000
--- a/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/SimpleTopology.java
+++ /dev/null
@@ -1,59 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.storm.flux.test;
-
-import org.apache.storm.generated.StormTopology;
-import org.apache.storm.topology.TopologyBuilder;
-import org.apache.storm.flux.api.TopologySource;
-import org.apache.storm.flux.wrappers.bolts.LogInfoBolt;
-import org.apache.storm.flux.wrappers.spouts.FluxShellSpout;
-
-import java.util.Map;
-
-/**
- * Test topology source that does not implement TopologySource, but has the same
- * `getTopology()` method.
- */
-public class SimpleTopology{
-
-
-    public SimpleTopology(){}
-
-    public SimpleTopology(String foo, String bar){}
-
-    public StormTopology getTopologyWithDifferentMethodName(Map<String, Object> config){
-        return getTopology(config);
-    }
-
-
-    public StormTopology getTopology(Map<String, Object> config) {
-        TopologyBuilder builder = new TopologyBuilder();
-
-        // spouts
-        FluxShellSpout spout = new FluxShellSpout(
-                new String[]{"node", "randomsentence.js"},
-                new String[]{"word"});
-        builder.setSpout("sentence-spout", spout, 1);
-
-        // bolts
-        builder.setBolt("log-bolt", new LogInfoBolt(), 1)
-                .shuffleGrouping("sentence-spout");
-
-        return builder.createTopology();
-    }
-}

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/SimpleTopologySource.java
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/SimpleTopologySource.java b/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/SimpleTopologySource.java
deleted file mode 100644
index 2fadacf..0000000
--- a/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/SimpleTopologySource.java
+++ /dev/null
@@ -1,52 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.storm.flux.test;
-
-import org.apache.storm.generated.StormTopology;
-import org.apache.storm.topology.TopologyBuilder;
-import org.apache.storm.flux.api.TopologySource;
-import org.apache.storm.flux.wrappers.bolts.LogInfoBolt;
-import org.apache.storm.flux.wrappers.spouts.FluxShellSpout;
-
-import java.util.Map;
-
-public class SimpleTopologySource implements TopologySource {
-
-
-    public SimpleTopologySource(){}
-
-    public SimpleTopologySource(String foo, String bar){}
-
-
-    @Override
-    public StormTopology getTopology(Map<String, Object> config) {
-        TopologyBuilder builder = new TopologyBuilder();
-
-        // spouts
-        FluxShellSpout spout = new FluxShellSpout(
-                new String[]{"node", "randomsentence.js"},
-                new String[]{"word"});
-        builder.setSpout("sentence-spout", spout, 1);
-
-        // bolts
-        builder.setBolt("log-bolt", new LogInfoBolt(), 1)
-                .shuffleGrouping("sentence-spout");
-
-        return builder.createTopology();
-    }
-}

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/SimpleTopologyWithConfigParam.java
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/SimpleTopologyWithConfigParam.java b/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/SimpleTopologyWithConfigParam.java
deleted file mode 100644
index 8b0aa05..0000000
--- a/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/SimpleTopologyWithConfigParam.java
+++ /dev/null
@@ -1,55 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.storm.flux.test;
-
-import org.apache.storm.Config;
-import org.apache.storm.generated.StormTopology;
-import org.apache.storm.topology.TopologyBuilder;
-import org.apache.storm.flux.wrappers.bolts.LogInfoBolt;
-import org.apache.storm.flux.wrappers.spouts.FluxShellSpout;
-
-import java.util.Map;
-
-/**
- * Test topology source that does not implement TopologySource, but has the same
- * `getTopology()` method.
- */
-public class SimpleTopologyWithConfigParam {
-
-
-    public SimpleTopologyWithConfigParam(){}
-
-    public SimpleTopologyWithConfigParam(String foo, String bar){}
-
-
-    public StormTopology getTopology(Config config) {
-        TopologyBuilder builder = new TopologyBuilder();
-
-        // spouts
-        FluxShellSpout spout = new FluxShellSpout(
-                new String[]{"node", "randomsentence.js"},
-                new String[]{"word"});
-        builder.setSpout("sentence-spout", spout, 1);
-
-        // bolts
-        builder.setBolt("log-bolt", new LogInfoBolt(), 1)
-                .shuffleGrouping("sentence-spout");
-
-        return builder.createTopology();
-    }
-}

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/TestBolt.java
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/TestBolt.java b/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/TestBolt.java
deleted file mode 100644
index 28d11b6..0000000
--- a/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/TestBolt.java
+++ /dev/null
@@ -1,131 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.storm.flux.test;
-
-import org.apache.storm.topology.BasicOutputCollector;
-import org.apache.storm.topology.OutputFieldsDeclarer;
-import org.apache.storm.topology.base.BaseBasicBolt;
-import org.apache.storm.tuple.Tuple;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import java.io.Serializable;
-
-
-public class TestBolt extends BaseBasicBolt {
-    private static final Logger LOG = LoggerFactory.getLogger(TestBolt.class);
-
-    private String foo;
-    private String bar;
-    private String fooBar;
-    private String none;
-    private TestClass[] classes;
-
-    public static class TestClass implements Serializable {
-        private String field;
-
-        public TestClass(String field) {
-            this.field = field;
-        }
-
-        public String getField() {
-            return field;
-        }
-
-        @Override
-        public boolean equals(Object o) {
-            if (this == o) return true;
-            if (!(o instanceof TestClass)) return false;
-
-            TestClass testClass = (TestClass) o;
-
-            return getField() != null ? getField().equals(testClass.getField()) : testClass.getField() == null;
-        }
-
-        @Override
-        public int hashCode() {
-            return getField() != null ? getField().hashCode() : 0;
-        }
-    }
-
-
-    public static enum TestEnum {
-        FOO,
-        BAR
-    }
-
-    public TestBolt(TestEnum te){
-
-    }
-
-    public TestBolt(TestEnum te, float f){
-
-    }
-
-    public TestBolt(TestEnum te, float f, boolean b){
-
-    }
-
-    public TestBolt(TestEnum te, float f, boolean b, TestClass... str) {
-
-    }
-
-    @Override
-    public void execute(Tuple tuple, BasicOutputCollector basicOutputCollector) {
-        LOG.info("{}", tuple);
-    }
-
-    @Override
-    public void declareOutputFields(OutputFieldsDeclarer outputFieldsDeclarer) {
-
-    }
-
-    // config methods
-    public void withFoo(String foo){
-        this.foo = foo;
-    }
-    public void withNone(){
-        this.none = "hit";
-    }
-    public void withBar(String bar){
-        this.bar = bar;
-    }
-
-    public void withFooBar(String foo, String bar){
-        this.fooBar = foo + bar;
-    }
-
-    public void withClasses(TestClass...classes) {
-        this.classes = classes;
-    }
-
-    public String getFoo(){
-        return this.foo;
-    }
-    public String getBar(){
-        return this.bar;
-    }
-
-    public String getFooBar(){
-        return this.fooBar;
-    }
-
-    public TestClass[] getClasses() {
-        return classes;
-    }
-}

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/TridentTopologySource.java
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/TridentTopologySource.java b/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/TridentTopologySource.java
deleted file mode 100644
index 36b272b..0000000
--- a/external/flux/flux-core/src/test/java/org/apache/storm/flux/test/TridentTopologySource.java
+++ /dev/null
@@ -1,71 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.storm.flux.test;
-
-import org.apache.storm.Config;
-import org.apache.storm.generated.StormTopology;
-import org.apache.storm.tuple.Fields;
-import org.apache.storm.tuple.Values;
-import org.apache.storm.kafka.StringScheme;
-import org.apache.storm.trident.TridentTopology;
-import org.apache.storm.trident.operation.BaseFunction;
-import org.apache.storm.trident.operation.TridentCollector;
-import org.apache.storm.trident.operation.builtin.Count;
-import org.apache.storm.trident.testing.FixedBatchSpout;
-import org.apache.storm.trident.testing.MemoryMapState;
-import org.apache.storm.trident.tuple.TridentTuple;
-
-/**
- * Basic Trident example that will return a `StormTopology` from a `getTopology()` method.
- */
-public class TridentTopologySource {
-
-    private FixedBatchSpout spout;
-
-    public StormTopology getTopology(Config config) {
-
-        this.spout = new FixedBatchSpout(new Fields("sentence"), 20,
-                new Values("one two"),
-                new Values("two three"),
-                new Values("three four"),
-                new Values("four five"),
-                new Values("five six")
-        );
-
-
-        TridentTopology trident = new TridentTopology();
-
-        trident.newStream("wordcount", spout).name("sentence").parallelismHint(1).shuffle()
-                .each(new Fields("sentence"), new Split(), new Fields("word"))
-                .parallelismHint(1)
-                .groupBy(new Fields("word"))
-                .persistentAggregate(new MemoryMapState.Factory(), new Count(), new Fields("count"))
-                .parallelismHint(1);
-        return trident.build();
-    }
-
-    public static class Split extends BaseFunction {
-        @Override
-        public void execute(TridentTuple tuple, TridentCollector collector) {
-            String sentence = tuple.getString(0);
-            for (String word : sentence.split(" ")) {
-                collector.emit(new Values(word));
-            }
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/bad_hbase.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/bad_hbase.yaml b/external/flux/flux-core/src/test/resources/configs/bad_hbase.yaml
deleted file mode 100644
index a29e314..0000000
--- a/external/flux/flux-core/src/test/resources/configs/bad_hbase.yaml
+++ /dev/null
@@ -1,98 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-# Test ability to wire together shell spouts/bolts
----
-
-# topology definition
-# name to be used when submitting
-name: "hbase-wordcount"
-
-# Components
-# Components are analagous to Spring beans. They are meant to be used as constructor,
-# property(setter), and builder arguments.
-#
-# for the time being, components must be declared in the order they are referenced
-
-components:
-  - id: "columnFields"
-    className: "org.apache.storm.tuple.Fields"
-    constructorArgs:
-      - ["word"]
-
-  - id: "counterFields"
-    className: "org.apache.storm.tuple.Fields"
-    constructorArgs:
-      # !!! the following won't work, and should thow an IllegalArgumentException...
-      - "count"
-
-  - id: "mapper"
-    className: "org.apache.storm.hbase.bolt.mapper.SimpleHBaseMapper"
-    configMethods:
-      - name: "withRowKeyField"
-        args: ["word"]
-      - name: "withColumnFields"
-        args: [ref: "columnFields"]
-      - name: "withCounterFields"
-        args: [ref: "counterFields"]
-      - name: "withColumnFamily"
-        args: ["cf"]
-
-# topology configuration
-# this will be passed to the submitter as a map of config options
-#
-config:
-  topology.workers: 1
-  hbase.conf:
-    hbase.rootdir: "hdfs://hadoop:54310/hbase"
-    hbase.zookeeper.quorum: "hadoop"
-
-# spout definitions
-spouts:
-  - id: "word-spout"
-    className: "org.apache.storm.testing.TestWordSpout"
-    parallelism: 1
-
-# bolt definitions
-
-bolts:
-  - id: "count-bolt"
-    className: "org.apache.storm.testing.TestWordCounter"
-
-  - id: "hbase-bolt"
-    className: "org.apache.storm.hbase.bolt.HBaseBolt"
-    constructorArgs:
-      - "WordCount" # HBase table name
-      - ref: "mapper"
-    configMethods:
-      - name: "withConfigKey"
-        args: ["hbase.conf"]
-    parallelism: 1
-
-
-streams:
-  - name: "" # name isn't used (placeholder for logging, UI, etc.)
-    from: "word-spout"
-    to: "count-bolt"
-    grouping:
-      type: SHUFFLE
-
-  - name: "" # name isn't used (placeholder for logging, UI, etc.)
-    from: "count-bolt"
-    to: "hbase-bolt"
-    grouping:
-      type: FIELDS
-      args: ["word"]

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/bad_shell_test.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/bad_shell_test.yaml b/external/flux/flux-core/src/test/resources/configs/bad_shell_test.yaml
deleted file mode 100644
index 0892ce7..0000000
--- a/external/flux/flux-core/src/test/resources/configs/bad_shell_test.yaml
+++ /dev/null
@@ -1,118 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-# Test ability to wire together shell spouts/bolts
----
-
-# topology definition
-# name to be used when submitting
-name: "shell-topology"
-
-# Components
-# Components are analagous to Spring beans. They are meant to be used as constructor,
-# property(setter), and builder arguments.
-#components:
-#  - id: "myComponent"
-#    className: "com.foo.bar.MyComponent"
-#    constructorArgs:
-#      - ...
-#    properties:
-#      foo: "bar"
-#      bar: "foo"
-
-# NOTE: We may want to consider some level of spring integration. For example, allowing component references
-# to a spring `ApplicationContext`.
-
-# topology configuration
-# this will be passed to the submitter as a map of config options
-#
-config:
-  topology.workers: 1
-  # ...
-
-# spout definitions
-spouts:
-  - id: "sentence-spout"
-    className: "org.apache.storm.flux.wrappers.spouts.FluxShellSpout"
-    # shell spout constructor takes 2 arguments: String[], String[]
-    constructorArgs:
-      # command line
-      - ["node", "randomsentence.js"]
-      # output fields
-      - ["word"]
-    configMethods:
-      - name: "addComponentConfig"
-        args: ["rabbitmq.configfile", "etc/rabbit.yml", "hello"]
-      - name: "addComponentConfig"
-        args:
-        - "publisher.data_paths"
-        - ["actions", "hello"]
-    parallelism: 1
-    # ...
-
-# bolt definitions
-bolts:
-  - id: "splitsentence"
-    className: "org.apache.storm.flux.wrappers.bolts.FluxShellBolt"
-    constructorArgs:
-      # command line
-      - ["python", "splitsentence.py"]
-      # output fields
-      - ["word"]
-    configMethods:
-      - name: "addComponentConfig"
-        args: ["rabbitmq.configfile", "etc/rabbit.yml", "hello"]
-      - name: "addComponentConfig"
-        args:
-        - "publisher.data_paths"
-        - ["actions", "hello"]
-    parallelism: 1
-    # ...
-
-  - id: "log"
-    className: "org.apache.storm.flux.wrappers.bolts.LogInfoBolt"
-    parallelism: 1
-    # ...
-
-  - id: "count"
-    className: "org.apache.storm.testing.TestWordCounter"
-    parallelism: 1
-    # ...
-
-#stream definitions
-# stream definitions define connections between spouts and bolts.
-# note that such connections can be cyclical
-# custom stream groupings are also supported
-
-streams:
-  - name: "spout --> split" # name isn't used (placeholder for logging, UI, etc.)
-    from: "sentence-spout"
-    to: "splitsentence"
-    grouping:
-      type: SHUFFLE
-
-  - name: "split --> count"
-    from: "splitsentence"
-    to: "count"
-    grouping:
-      type: FIELDS
-      args: ["word"]
-
-  - name: "count --> log"
-    from: "count"
-    to: "log"
-    grouping:
-      type: SHUFFLE

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/config-methods-test.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/config-methods-test.yaml b/external/flux/flux-core/src/test/resources/configs/config-methods-test.yaml
deleted file mode 100644
index 7c4ffb3..0000000
--- a/external/flux/flux-core/src/test/resources/configs/config-methods-test.yaml
+++ /dev/null
@@ -1,92 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
----
-name: "yaml-topology"
-
-#
-config:
-  topology.workers: 1
-  # ...
-
-components:
-  - id: "foo"
-    className: "org.apache.storm.flux.test.TestBolt$TestClass"
-    constructorArgs:
-      - "foo"
-  - id: "bar"
-    className: "org.apache.storm.flux.test.TestBolt$TestClass"
-    constructorArgs:
-      - "bar"
-  - id: "baz"
-    className: "org.apache.storm.flux.test.TestBolt$TestClass"
-    constructorArgs:
-      - "baz"
-
-# spout definitions
-spouts:
-  - id: "spout-1"
-    className: "org.apache.storm.testing.TestWordSpout"
-    parallelism: 1
-    # ...
-
-# bolt definitions
-bolts:
-  - id: "bolt-1"
-    className: "org.apache.storm.flux.test.TestBolt"
-    parallelism: 1
-    constructorArgs:
-      - FOO # enum class
-      - 1.0
-      - true
-      - reflist: ["foo", "bar"]
-    configMethods:
-      - name: "withFoo"
-        args:
-          - "foo"
-      - name: "withNone"
-      - name: "withBar"
-        args:
-          - "bar"
-      - name: "withFooBar"
-        args:
-          - "foo"
-          - "bar"
-      - name: "withClasses"
-        args:
-          - reflist:
-            - "foo"
-            - "bar"
-            - "baz"
-
-
-#stream definitions
-# stream definitions define connections between spouts and bolts.
-# note that such connections can be cyclical
-streams:
-  - name: "spout-1 --> bolt-1" # name isn't used (placeholder for logging, UI, etc.)
-#    id: "connection-1"
-    from: "spout-1"
-    to: "bolt-1"
-    grouping:
-      type: SHUFFLE
-
-
-
-
-
-
-
-

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/diamond-topology.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/diamond-topology.yaml b/external/flux/flux-core/src/test/resources/configs/diamond-topology.yaml
deleted file mode 100644
index 957c258..0000000
--- a/external/flux/flux-core/src/test/resources/configs/diamond-topology.yaml
+++ /dev/null
@@ -1,87 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
----
-
-# topology definition
-# name to be used when submitting
-name: "diamond-topology"
-
-# topology configuration
-# this will be passed to the submitter as a map of config options
-#
-config:
-  topology.workers: 1
-
-# spout definitions
-spouts:
-  - id: "spout-1"
-    className: "org.apache.storm.testing.TestWordSpout"
-    parallelism: 1
-
-# bolt definitions
-bolts:
-  - id: "A"
-    className: "org.apache.storm.flux.wrappers.bolts.LogInfoBolt"
-    parallelism: 1
-
-  - id: "B"
-    className: "org.apache.storm.flux.wrappers.bolts.LogInfoBolt"
-    parallelism: 1
-
-  - id: "C"
-    className: "org.apache.storm.flux.wrappers.bolts.LogInfoBolt"
-    parallelism: 1
-
-  - id: "D"
-    className: "org.apache.storm.flux.wrappers.bolts.LogInfoBolt"
-    parallelism: 1
-
-#stream definitions
-# stream definitions define connections between spouts and bolts.
-# note that such connections can be cyclical
-streams:
-  - name: "spout-1 --> bolt-1" # name isn't used (placeholder for logging, UI, etc.)
-#    id: "connection-1"
-    from: "spout-1"
-    to: "A"
-    grouping:
-      type: FIELDS
-      args: ["word"]
-
-  - from: "A"
-    to: "B"
-    grouping:
-      type: SHUFFLE
-
-  - from: "A"
-    to: "C"
-    grouping:
-      type: SHUFFLE
-
-  - from: "C"
-    to: "D"
-    grouping:
-      type: SHUFFLE
-
-  - from: "B"
-    to: "D"
-    grouping:
-      type: SHUFFLE
-
-
-
-

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/existing-topology-method-override.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/existing-topology-method-override.yaml b/external/flux/flux-core/src/test/resources/configs/existing-topology-method-override.yaml
deleted file mode 100644
index fceeeed..0000000
--- a/external/flux/flux-core/src/test/resources/configs/existing-topology-method-override.yaml
+++ /dev/null
@@ -1,25 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
----
-
-# configuration that uses an existing topology that does not implement TopologySource
-name: "existing-topology"
-topologySource:
-  className: "org.apache.storm.flux.test.SimpleTopology"
-  methodName: "getTopologyWithDifferentMethodName"
-  constructorArgs:
-    - "foo"
-    - "bar"
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/existing-topology-reflection-config.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/existing-topology-reflection-config.yaml b/external/flux/flux-core/src/test/resources/configs/existing-topology-reflection-config.yaml
deleted file mode 100644
index 440fe4d..0000000
--- a/external/flux/flux-core/src/test/resources/configs/existing-topology-reflection-config.yaml
+++ /dev/null
@@ -1,24 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
----
-
-# configuration that uses an existing topology that does not implement TopologySource
-name: "existing-topology"
-topologySource:
-  className: "org.apache.storm.flux.test.SimpleTopologyWithConfigParam"
-  constructorArgs:
-    - "foo"
-    - "bar"
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/existing-topology-reflection.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/existing-topology-reflection.yaml b/external/flux/flux-core/src/test/resources/configs/existing-topology-reflection.yaml
deleted file mode 100644
index 975885b..0000000
--- a/external/flux/flux-core/src/test/resources/configs/existing-topology-reflection.yaml
+++ /dev/null
@@ -1,24 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
----
-
-# configuration that uses an existing topology that does not implement TopologySource
-name: "existing-topology"
-topologySource:
-  className: "org.apache.storm.flux.test.SimpleTopology"
-  constructorArgs:
-    - "foo"
-    - "bar"
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/existing-topology-trident.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/existing-topology-trident.yaml b/external/flux/flux-core/src/test/resources/configs/existing-topology-trident.yaml
deleted file mode 100644
index 978181b..0000000
--- a/external/flux/flux-core/src/test/resources/configs/existing-topology-trident.yaml
+++ /dev/null
@@ -1,24 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
----
-
-name: "existing-topology"
-
-config:
-  topology.workers: 1
-
-topologySource:
-  className: "org.apache.storm.flux.test.TridentTopologySource"
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/existing-topology.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/existing-topology.yaml b/external/flux/flux-core/src/test/resources/configs/existing-topology.yaml
deleted file mode 100644
index e112c0f..0000000
--- a/external/flux/flux-core/src/test/resources/configs/existing-topology.yaml
+++ /dev/null
@@ -1,23 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
----
-
-name: "existing-topology"
-topologySource:
-  className: "org.apache.storm.flux.test.SimpleTopologySource"
-  constructorArgs:
-    - "foo"
-    - "bar"
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/hdfs_test.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/hdfs_test.yaml b/external/flux/flux-core/src/test/resources/configs/hdfs_test.yaml
deleted file mode 100644
index 2bccb33..0000000
--- a/external/flux/flux-core/src/test/resources/configs/hdfs_test.yaml
+++ /dev/null
@@ -1,97 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-# Test ability to wire together shell spouts/bolts
----
-
-# topology definition
-# name to be used when submitting
-name: "hdfs-topology"
-
-# Components
-# Components are analagous to Spring beans. They are meant to be used as constructor,
-# property(setter), and builder arguments.
-#
-# for the time being, components must be declared in the order they are referenced
-components:
-  - id: "syncPolicy"
-    className: "org.apache.storm.hdfs.bolt.sync.CountSyncPolicy"
-    constructorArgs:
-      - 1000
-  - id: "rotationPolicy"
-    className: "org.apache.storm.hdfs.bolt.rotation.FileSizeRotationPolicy"
-    constructorArgs:
-      - 5.0
-      - MB
-
-  - id: "fileNameFormat"
-    className: "org.apache.storm.hdfs.bolt.format.DefaultFileNameFormat"
-    configMethods:
-      - name: "withPath"
-        args: ["/tmp/foo/"]
-      - name: "withExtension"
-        args: [".txt"]
-
-  - id: "recordFormat"
-    className: "org.apache.storm.hdfs.bolt.format.DelimitedRecordFormat"
-    configMethods:
-      - name: "withFieldDelimiter"
-        args: ["|"]
-
-  - id: "rotationAction"
-    className: "org.apache.storm.hdfs.common.rotation.MoveFileAction"
-    configMethods:
-      - name: "toDestination"
-        args: ["/tmp/dest2"]
-
-# spout definitions
-spouts:
-  - id: "spout-1"
-    className: "org.apache.storm.testing.TestWordSpout"
-    parallelism: 1
-    # ...
-
-# bolt definitions
-
-#        HdfsBolt bolt = new HdfsBolt()
-#                .withConfigKey("hdfs.config")
-#                .withFsUrl(args[0])
-#                .withFileNameFormat(fileNameFormat)
-#                .withRecordFormat(format)
-#                .withRotationPolicy(rotationPolicy)
-#                .withSyncPolicy(syncPolicy)
-#                .addRotationAction(new MoveFileAction().toDestination("/tmp/dest2/"));
-bolts:
-  - id: "bolt-1"
-    className: "org.apache.storm.hdfs.bolt.HdfsBolt"
-    configMethods:
-      - name: "withConfigKey"
-        args: ["hdfs.config"]
-      - name: "withFsUrl"
-        args: ["hdfs://hadoop:54310"]
-      - name: "withFileNameFormat"
-        args: [ref: "fileNameFormat"]
-      - name: "withRecordFormat"
-        args: [ref: "recordFormat"]
-      - name: "withRotationPolicy"
-        args: [ref: "rotationPolicy"]
-      - name: "withSyncPolicy"
-        args: [ref: "syncPolicy"]
-      - name: "addRotationAction"
-        args: [ref: "rotationAction"]
-    parallelism: 1
-    # ...
-

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/include_test.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/include_test.yaml b/external/flux/flux-core/src/test/resources/configs/include_test.yaml
deleted file mode 100644
index 702f590..0000000
--- a/external/flux/flux-core/src/test/resources/configs/include_test.yaml
+++ /dev/null
@@ -1,25 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-# Test includes by defining nothing, and simply override the topology name
----
-
-name: "include-topology"
-
-includes:
-  - resource: true
-    file: "/configs/shell_test.yaml"
-    override: false #otherwise subsequent includes that define 'name' would override
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/invalid-existing-topology.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/invalid-existing-topology.yaml b/external/flux/flux-core/src/test/resources/configs/invalid-existing-topology.yaml
deleted file mode 100644
index c2dfac0..0000000
--- a/external/flux/flux-core/src/test/resources/configs/invalid-existing-topology.yaml
+++ /dev/null
@@ -1,33 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-# This is an invalid config. It defines both a topologySource and a list of spouts.
----
-
-name: "existing-topology"
-topologySource:
-  className: "org.apache.storm.flux.test.SimpleTopologySource"
-
-spouts:
-  - id: "sentence-spout"
-    className: "org.apache.storm.flux.wrappers.spouts.FluxShellSpout"
-    # shell spout constructor takes 2 arguments: String[], String[]
-    constructorArgs:
-      # command line
-      - ["node", "randomsentence.js"]
-      # output fields
-      - ["word"]
-    parallelism: 1
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/kafka_test.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/kafka_test.yaml b/external/flux/flux-core/src/test/resources/configs/kafka_test.yaml
deleted file mode 100644
index 1fb59ca..0000000
--- a/external/flux/flux-core/src/test/resources/configs/kafka_test.yaml
+++ /dev/null
@@ -1,126 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
----
-
-# topology definition
-# name to be used when submitting
-name: "kafka-topology"
-
-# Components
-# Components are analagous to Spring beans. They are meant to be used as constructor,
-# property(setter), and builder arguments.
-#
-# for the time being, components must be declared in the order they are referenced
-components:
-  - id: "stringScheme"
-    className: "org.apache.storm.kafka.StringScheme"
-
-  - id: "stringMultiScheme"
-    className: "org.apache.storm.spout.SchemeAsMultiScheme"
-    constructorArgs:
-      - ref: "stringScheme"
-
-  - id: "zkHosts"
-    className: "org.apache.storm.kafka.ZkHosts"
-    constructorArgs:
-      - "localhost:2181"
-
-# Alternative kafka config
-#  - id: "kafkaConfig"
-#    className: "org.apache.storm.kafka.KafkaConfig"
-#    constructorArgs:
-#      # brokerHosts
-#      - ref: "zkHosts"
-#      # topic
-#      - "myKafkaTopic"
-#      # clientId (optional)
-#      - "myKafkaClientId"
-
-  - id: "spoutConfig"
-    className: "org.apache.storm.kafka.SpoutConfig"
-    constructorArgs:
-      # brokerHosts
-      - ref: "zkHosts"
-      # topic
-      - "myKafkaTopic"
-      # zkRoot
-      - "/kafkaSpout"
-      # id
-      - "myId"
-    properties:
-      - name: "ignoreZkOffsets"
-        value: true
-      - name: "scheme"
-        ref: "stringMultiScheme"
-
-# topology configuration
-# this will be passed to the submitter as a map of config options
-#
-config:
-  topology.workers: 1
-  # ...
-
-# spout definitions
-spouts:
-  - id: "kafka-spout"
-    className: "org.apache.storm.kafka.KafkaSpout"
-    constructorArgs:
-      - ref: "spoutConfig"
-
-# bolt definitions
-bolts:
-  - id: "splitsentence"
-    className: "org.apache.storm.flux.wrappers.bolts.FluxShellBolt"
-    constructorArgs:
-      # command line
-      - ["python", "splitsentence.py"]
-      # output fields
-      - ["word"]
-    parallelism: 1
-
-  - id: "log"
-    className: "org.apache.storm.flux.wrappers.bolts.LogInfoBolt"
-    parallelism: 1
-    # ...
-
-  - id: "count"
-    className: "org.apache.storm.testing.TestWordCounter"
-    parallelism: 1
-
-#stream definitions
-# stream definitions define connections between spouts and bolts.
-# note that such connections can be cyclical
-# custom stream groupings are also supported
-
-streams:
-  - name: "kafka --> split" # name isn't used (placeholder for logging, UI, etc.)
-    from: "kafka-spout"
-    to: "splitsentence"
-    grouping:
-      type: SHUFFLE
-
-  - name: "split --> count"
-    from: "splitsentence"
-    to: "count"
-    grouping:
-      type: FIELDS
-      args: ["word"]
-
-  - name: "count --> log"
-    from: "count"
-    to: "log"
-    grouping:
-      type: SHUFFLE

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/shell_test.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/shell_test.yaml b/external/flux/flux-core/src/test/resources/configs/shell_test.yaml
deleted file mode 100644
index dfab397..0000000
--- a/external/flux/flux-core/src/test/resources/configs/shell_test.yaml
+++ /dev/null
@@ -1,118 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-# Test ability to wire together shell spouts/bolts
----
-
-# topology definition
-# name to be used when submitting
-name: "shell-topology"
-
-# Components
-# Components are analagous to Spring beans. They are meant to be used as constructor,
-# property(setter), and builder arguments.
-#components:
-#  - id: "myComponent"
-#    className: "com.foo.bar.MyComponent"
-#    constructorArgs:
-#      - ...
-#    properties:
-#      foo: "bar"
-#      bar: "foo"
-
-# NOTE: We may want to consider some level of spring integration. For example, allowing component references
-# to a spring `ApplicationContext`.
-
-# topology configuration
-# this will be passed to the submitter as a map of config options
-#
-config:
-  topology.workers: 1
-  # ...
-
-# spout definitions
-spouts:
-  - id: "sentence-spout"
-    className: "org.apache.storm.flux.wrappers.spouts.FluxShellSpout"
-    # shell spout constructor takes 2 arguments: String[], String[]
-    constructorArgs:
-      # command line
-      - ["node", "randomsentence.js"]
-      # output fields
-      - ["word"]
-    configMethods:
-      - name: "addComponentConfig"
-        args: ["rabbitmq.configfile", "etc/rabbit.yml"]
-      - name: "addComponentConfig"
-        args:
-        - "publisher.data_paths"
-        - ["actions"]
-    parallelism: 1
-    # ...
-
-# bolt definitions
-bolts:
-  - id: "splitsentence"
-    className: "org.apache.storm.flux.wrappers.bolts.FluxShellBolt"
-    constructorArgs:
-      # command line
-      - ["python", "splitsentence.py"]
-      # output fields
-      - ["word"]
-    configMethods:
-      - name: "addComponentConfig"
-        args: ["rabbitmq.configfile", "etc/rabbit.yml"]
-      - name: "addComponentConfig"
-        args:
-        - "publisher.data_paths"
-        - ["actions"]
-    parallelism: 1
-    # ...
-
-  - id: "log"
-    className: "org.apache.storm.flux.wrappers.bolts.LogInfoBolt"
-    parallelism: 1
-    # ...
-
-  - id: "count"
-    className: "org.apache.storm.testing.TestWordCounter"
-    parallelism: 1
-    # ...
-
-#stream definitions
-# stream definitions define connections between spouts and bolts.
-# note that such connections can be cyclical
-# custom stream groupings are also supported
-
-streams:
-  - name: "spout --> split" # name isn't used (placeholder for logging, UI, etc.)
-    from: "sentence-spout"
-    to: "splitsentence"
-    grouping:
-      type: SHUFFLE
-
-  - name: "split --> count"
-    from: "splitsentence"
-    to: "count"
-    grouping:
-      type: FIELDS
-      args: ["word"]
-
-  - name: "count --> log"
-    from: "count"
-    to: "log"
-    grouping:
-      type: SHUFFLE

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/simple_hbase.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/simple_hbase.yaml b/external/flux/flux-core/src/test/resources/configs/simple_hbase.yaml
deleted file mode 100644
index b841b53..0000000
--- a/external/flux/flux-core/src/test/resources/configs/simple_hbase.yaml
+++ /dev/null
@@ -1,120 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-# Test ability to wire together shell spouts/bolts
----
-
-# topology definition
-# name to be used when submitting
-name: "hbase-wordcount"
-
-# Components
-# Components are analagous to Spring beans. They are meant to be used as constructor,
-# property(setter), and builder arguments.
-#
-# for the time being, components must be declared in the order they are referenced
-
-#        WordSpout spout = new WordSpout();
-#        WordCounter bolt = new WordCounter();
-#
-#        SimpleHBaseMapper mapper = new SimpleHBaseMapper()
-#                .withRowKeyField("word")
-#                .withColumnFields(new Fields("word"))
-#                .withCounterFields(new Fields("count"))
-#                .withColumnFamily("cf");
-#
-#        HBaseBolt hbase = new HBaseBolt("WordCount", mapper)
-#                .withConfigKey("hbase.conf");
-#
-#
-#        // wordSpout ==> countBolt ==> HBaseBolt
-#        TopologyBuilder builder = new TopologyBuilder();
-#
-#        builder.setSpout(WORD_SPOUT, spout, 1);
-#        builder.setBolt(COUNT_BOLT, bolt, 1).shuffleGrouping(WORD_SPOUT);
-#        builder.setBolt(HBASE_BOLT, hbase, 1).fieldsGrouping(COUNT_BOLT, new Fields("word"));
-
-
-
-
-components:
-  - id: "columnFields"
-    className: "org.apache.storm.tuple.Fields"
-    constructorArgs:
-      - ["word"]
-
-  - id: "counterFields"
-    className: "org.apache.storm.tuple.Fields"
-    constructorArgs:
-      - ["count"]
-
-  - id: "mapper"
-    className: "org.apache.storm.hbase.bolt.mapper.SimpleHBaseMapper"
-    configMethods:
-      - name: "withRowKeyField"
-        args: ["word"]
-      - name: "withColumnFields"
-        args: [ref: "columnFields"]
-      - name: "withCounterFields"
-        args: [ref: "counterFields"]
-      - name: "withColumnFamily"
-        args: ["cf"]
-
-# topology configuration
-# this will be passed to the submitter as a map of config options
-#
-config:
-  topology.workers: 1
-  hbase.conf:
-    hbase.rootdir: "hdfs://hadoop:54310/hbase"
-    hbase.zookeeper.quorum: "hadoop"
-
-# spout definitions
-spouts:
-  - id: "word-spout"
-    className: "org.apache.storm.testing.TestWordSpout"
-    parallelism: 1
-
-# bolt definitions
-
-bolts:
-  - id: "count-bolt"
-    className: "org.apache.storm.testing.TestWordCounter"
-
-  - id: "hbase-bolt"
-    className: "org.apache.storm.hbase.bolt.HBaseBolt"
-    constructorArgs:
-      - "WordCount" # HBase table name
-      - ref: "mapper"
-    configMethods:
-      - name: "withConfigKey"
-        args: ["hbase.conf"]
-    parallelism: 1
-
-
-streams:
-  - name: "" # name isn't used (placeholder for logging, UI, etc.)
-    from: "word-spout"
-    to: "count-bolt"
-    grouping:
-      type: SHUFFLE
-
-  - name: "" # name isn't used (placeholder for logging, UI, etc.)
-    from: "count-bolt"
-    to: "hbase-bolt"
-    grouping:
-      type: FIELDS
-      args: ["word"]

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/substitution-test.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/substitution-test.yaml b/external/flux/flux-core/src/test/resources/configs/substitution-test.yaml
deleted file mode 100644
index ce9e62d..0000000
--- a/external/flux/flux-core/src/test/resources/configs/substitution-test.yaml
+++ /dev/null
@@ -1,106 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-# Test ability to wire together shell spouts/bolts
----
-
-# topology definition
-# name to be used when submitting
-name: "${topology.name}"
-
-# Components
-# Components are analagous to Spring beans. They are meant to be used as constructor,
-# property(setter), and builder arguments.
-#components:
-#  - id: "myComponent"
-#    className: "com.foo.bar.MyComponent"
-#    constructorArgs:
-#      - ...
-#    properties:
-#      foo: "bar"
-#      bar: "foo"
-
-# NOTE: We may want to consider some level of spring integration. For example, allowing component references
-# to a spring `ApplicationContext`.
-
-# topology configuration
-# this will be passed to the submitter as a map of config options
-#
-config:
-  topology.workers: 1
-  # test environent variable substitution
-  test.env.value: ${ENV-PATH}
-  # ...
-
-# spout definitions
-spouts:
-  - id: "sentence-spout"
-    className: "org.apache.storm.flux.wrappers.spouts.FluxShellSpout"
-    # shell spout constructor takes 2 arguments: String[], String[]
-    constructorArgs:
-      # command line
-      - ["node", "randomsentence.js"]
-      # output fields
-      - ["word"]
-    parallelism: 1
-    # ...
-
-# bolt definitions
-bolts:
-  - id: "splitsentence"
-    className: "org.apache.storm.flux.wrappers.bolts.FluxShellBolt"
-    constructorArgs:
-      # command line
-      - ["python", "splitsentence.py"]
-      # output fields
-      - ["word"]
-    parallelism: 1
-    # ...
-
-  - id: "log"
-    className: "org.apache.storm.flux.wrappers.bolts.LogInfoBolt"
-    parallelism: 1
-    # ...
-
-  - id: "count"
-    className: "org.apache.storm.testing.TestWordCounter"
-    parallelism: 1
-    # ...
-
-#stream definitions
-# stream definitions define connections between spouts and bolts.
-# note that such connections can be cyclical
-# custom stream groupings are also supported
-
-streams:
-  - name: "spout --> split" # name isn't used (placeholder for logging, UI, etc.)
-    from: "sentence-spout"
-    to: "splitsentence"
-    grouping:
-      type: SHUFFLE
-
-  - name: "split --> count"
-    from: "splitsentence"
-    to: "count"
-    grouping:
-      type: FIELDS
-      args: ["word"]
-
-  - name: "count --> log"
-    from: "count"
-    to: "log"
-    grouping:
-      type: SHUFFLE

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/tck.yaml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/tck.yaml b/external/flux/flux-core/src/test/resources/configs/tck.yaml
deleted file mode 100644
index 5d40445..0000000
--- a/external/flux/flux-core/src/test/resources/configs/tck.yaml
+++ /dev/null
@@ -1,95 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-
-# YAML configuration to serve as a basic smoke test for what is supported.
-#
-# We should support comments, so if we've failed so far, things aren't good.
-
-# we shouldn't choke if we see a document separator...
----
-
-# topology definition
-# name to be used when submitting
-name: "yaml-topology"
-
-# Components
-# Components are analagous to Spring beans. They are meant to be used as constructor,
-# property(setter), and builder arguments.
-#components:
-#  - id: "myComponent"
-#    className: "com.foo.bar.MyComponent"
-#    properties:
-#      foo: "bar"
-#      bar: "foo"
-
-# NOTE: We may want to consider some level of spring integration. For example, allowing component references
-# to a spring `ApplicationContext`.
-
-# topology configuration
-# this will be passed to the submitter as a map of config options
-#
-config:
-  topology.workers: 1
-  # ...
-
-# spout definitions
-spouts:
-  - id: "spout-1"
-    className: "org.apache.storm.testing.TestWordSpout"
-    parallelism: 1
-    # ...
-
-# bolt definitions
-bolts:
-  - id: "bolt-1"
-    className: "org.apache.storm.testing.TestWordCounter"
-    parallelism: 1
-    # ...
-
-  - id: "bolt-2"
-    className: "org.apache.storm.flux.wrappers.bolts.LogInfoBolt"
-    parallelism: 1
-    # ...
-
-#stream definitions
-# stream definitions define connections between spouts and bolts.
-# note that such connections can be cyclical
-streams:
-  - name: "spout-1 --> bolt-1" # name isn't used (placeholder for logging, UI, etc.)
-#    id: "connection-1"
-    from: "spout-1"
-    to: "bolt-1"
-    grouping:
-      type: FIELDS
-      args: ["word"]
-
-  - name: "bolt-1 --> bolt2"
-    from: "bolt-1"
-    to: "bolt-2"
-    grouping:
-      type: CUSTOM
-      customClass:
-        className: "org.apache.storm.testing.NGrouping"
-        constructorArgs:
-          - 1
-
-
-
-
-
-
-

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/configs/test.properties
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/configs/test.properties b/external/flux/flux-core/src/test/resources/configs/test.properties
deleted file mode 100644
index ecd89d9..0000000
--- a/external/flux/flux-core/src/test/resources/configs/test.properties
+++ /dev/null
@@ -1,18 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-topology.name: substitution-topology
-some.other.property: foo bar
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-core/src/test/resources/log4j2.xml
----------------------------------------------------------------------
diff --git a/external/flux/flux-core/src/test/resources/log4j2.xml b/external/flux/flux-core/src/test/resources/log4j2.xml
deleted file mode 100644
index d3333f3..0000000
--- a/external/flux/flux-core/src/test/resources/log4j2.xml
+++ /dev/null
@@ -1,34 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
--->
-<Configuration scan="true" monitorInterval="30">
-  <Appenders>
-    <Console name="A1" target="SYSTEM_OUT">
-      <PatternLayout>
-        <pattern>%-4r [%t] %-5level %c{1} - %msg%n</pattern>
-      </PatternLayout>
-    </Console>
-  </Appenders>
-  <Loggers>
-    <Logger name="org.apache.storm.curator" level="warn"/>
-    <Logger name="org.apache.storm.flux" level="debug"/>
-    <Logger name="org.apache.storm.zookeeper" level="warn"/>
-    <Root level="debug">
-      <appender-ref ref="A1"/>
-    </Root>
-  </Loggers>
-</Configuration>

http://git-wip-us.apache.org/repos/asf/storm/blob/e9d78338/external/flux/flux-examples/README.md
----------------------------------------------------------------------
diff --git a/external/flux/flux-examples/README.md b/external/flux/flux-examples/README.md
deleted file mode 100644
index 3d610b4..0000000
--- a/external/flux/flux-examples/README.md
+++ /dev/null
@@ -1,93 +0,0 @@
-# Flux Examples
-A collection of examples illustrating various capabilities.
-
-## Building From Source and Running
-
-Checkout the projects source and perform a top level Maven build (i.e. from the `flux` directory):
-
-```bash
-git clone https://github.com/apache/storm.git
-cd storm
-mvn install -DskipTests=true
-```
-
-This will create a shaded (i.e. "fat" or "uber") jar in the `external/flux/flux-examples/target` directory that can run/deployed with
-the `storm` command:
-
-```bash
-cd flux-examples
-storm jar ./target/flux-examples-*-SNAPSHOT.jar org.apache.storm.flux.Flux --local ./src/main/resources/simple_wordcount.yaml
-```
-
-The example YAML files are also packaged in the examples jar, so they can also be referenced with Flux's `--resource`
-command line switch:
-
-```bash
-storm jar ./target/flux-examples-*.jar org.apache.storm.flux.Flux --local --resource /simple_wordcount.yaml
-```
-
-## Available Examples
-
-### [simple_wordcount.yaml](src/main/resources/simple_wordcount.yaml)
-
-This is a very basic wordcount example using Java spouts and bolts. It simply logs the running count of each word
-received.
-
-### [multilang.yaml](src/main/resources/multilang.yaml)
-
-Another wordcount example that uses a spout written in JavaScript (node.js), a bolt written in Python, and two bolts
-written in java.
-
-### [kafka_spout.yaml](src/main/resources/kafka_spout.yaml)
-
-This example illustrates how to configure Storm's `storm-kafka` spout using Flux YAML DSL `components`, `references`,
-and `constructor arguments` constructs.
-
-### [simple_hdfs.yaml](src/main/resources/simple_hdfs.yaml)
-
-This example demonstrates using Flux to setup a storm-hdfs bolt to write to an HDFS cluster. It also demonstrates Flux's
-variable substitution/filtering feature.
-
-To run the `simple_hdfs.yaml` example, copy the `hdfs_bolt.properties` file to a convenient location and change, at
-least, the property `hdfs.url` to point to a HDFS cluster. Then you can run the example something like:
-
-```bash
-storm jar ./target/flux-examples-*.jar org.apache.storm.flux.Flux --local ./src/main/resources/simple_hdfs.yaml --filter my_hdfs_bolt.properties
-```
-
-### [simple_hbase.yaml](src/main/resources/simple_hbase.yaml)
-
-This example illustrates how to use Flux to setup a storm-hbase bolt to write to HBase.
-
-To run the `simple_hbase.yaml` example, copy the `hbase_bolt.properties` file to a convenient location and change the properties
- `hbase.rootdir` and `hbase.zookeeper.quorum`. Then you can run the example something like:
-
-```bash
-storm jar ./target/flux-examples-*.jar org.apache.storm.flux.Flux --local ./src/main/resources/simple_hbase.yaml --filter my_hbase_bolt.properties
-```
-
-### [simple_windowing.yaml](src/main/resources/simple_windowing.yaml)
-
-This example illustrates how to use Flux to set up a storm topology that contains windowing operations.
-
-To run,
-
-```bash
-storm jar ./target/flux-examples-*.jar org.apache.storm.flux.Flux --local ./src/main/resources/simple_windowing.yaml
-```
-
-### [simple_stateful_wordcount.yaml](src/main/resources/simple_stateful_wordcount.yaml)
-
-Flux also supports stateful bolts which is illustrated with this example. It is basically an extension of the basic wordcount example.
-The state is periodically saved (checkpointed) and restored when the topology is restarted.
-
-```bash
-storm jar ./target/flux-examples-*.jar org.apache.storm.flux.Flux --local ./src/main/resources/simple_stateful_wordcount.yaml
-```
-
-By default the state is stored in-memory only. As such you won't see a resumed state unless you configure to use Redis as the state backend.
-Ensure that you have Redis running at `localhost:6379` and that `storm-redis-*.jar` is in the classpath.
-
-```bash
-STORM_EXT_CLASSPATH=../../storm-redis/target storm jar ./target/flux-examples-*.jar -c topology.state.provider=org.apache.storm.redis.state.RedisKeyValueStateProvider org.apache.storm.flux.Flux --local ./src/main/resources/simple_stateful_wordcount.yaml
-```