You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@streams.apache.org by sb...@apache.org on 2016/10/24 03:53:27 UTC

[2/4] incubator-streams-examples git commit: src/site/resources should not be under source control

src/site/resources should not be under source control


Project: http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/commit/8533c234
Tree: http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/tree/8533c234
Diff: http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/diff/8533c234

Branch: refs/heads/master
Commit: 8533c234a248ca79df608aa4fd80186718469717
Parents: fc9b81d
Author: Steve Blackmon <sb...@apache.org>
Authored: Sun Oct 23 22:46:25 2016 -0500
Committer: Steve Blackmon <sb...@apache.org>
Committed: Sun Oct 23 22:46:25 2016 -0500

----------------------------------------------------------------------
 .../site/resources/FlinkBatchConfiguration.json | 12 -----
 .../resources/FlinkStreamingConfiguration.json  | 40 ----------------
 .../resources/FlinkTwitterFollowingPipeline.dot | 37 ---------------
 ...linkTwitterFollowingPipelineFollowersIT.conf | 20 --------
 .../FlinkTwitterFollowingPipelineFriendsIT.conf | 19 --------
 .../resources/FlinkTwitterPostsPipeline.dot     | 37 ---------------
 .../resources/FlinkTwitterPostsPipelineIT.conf  | 15 ------
 .../resources/FlinkTwitterSpritzerPipeline.dot  | 33 --------------
 .../FlinkTwitterSpritzerPipelineIT.conf         | 15 ------
 .../FlinkTwitterUserInformationPipeline.dot     | 37 ---------------
 .../resources/StreamsFlinkConfiguration.json    | 48 --------------------
 .../TwitterFollowingBatchConfiguration.json     | 23 ----------
 .../TwitterFollowingPipelineConfiguration.json  | 29 ------------
 .../TwitterPostsBatchConfiguration.json         | 23 ----------
 .../TwitterPostsPipelineConfiguration.json      | 29 ------------
 .../TwitterSpritzerPipelineConfiguration.json   | 29 ------------
 ...witterUserInformationBatchConfiguration.json | 23 ----------
 ...terUserInformationPipelineConfiguration.json | 29 ------------
 .../src/site/resources/TwitterFollowGraph.dot   | 39 ----------------
 .../TwitterFollowGraphConfiguration.json        | 13 ------
 .../src/site/resources/TwitterFollowNeo4j.dot   | 39 ----------------
 .../TwitterFollowNeo4jConfiguration.json        | 13 ------
 22 files changed, 602 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/FlinkBatchConfiguration.json
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/FlinkBatchConfiguration.json b/flink/flink-twitter-collection/src/site/resources/FlinkBatchConfiguration.json
deleted file mode 100644
index 30a2942..0000000
--- a/flink/flink-twitter-collection/src/site/resources/FlinkBatchConfiguration.json
+++ /dev/null
@@ -1,12 +0,0 @@
-{
-  "$schema": "http://json-schema.org/draft-03/schema",
-  "$license": [
-    "http://www.apache.org/licenses/LICENSE-2.0"
-  ],
-  "type": "object",
-  "javaType" : "org.apache.streams.flink.FlinkBatchConfiguration",
-  "javaInterfaces": ["java.io.Serializable"],
-  "extends": {
-    "$ref": "StreamsFlinkConfiguration.json"
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/FlinkStreamingConfiguration.json
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/FlinkStreamingConfiguration.json b/flink/flink-twitter-collection/src/site/resources/FlinkStreamingConfiguration.json
deleted file mode 100644
index 0d63f4e..0000000
--- a/flink/flink-twitter-collection/src/site/resources/FlinkStreamingConfiguration.json
+++ /dev/null
@@ -1,40 +0,0 @@
-{
-  "$schema": "http://json-schema.org/draft-03/schema",
-  "$license": [
-    "http://www.apache.org/licenses/LICENSE-2.0"
-  ],
-  "type": "object",
-  "javaType" : "org.apache.streams.flink.FlinkStreamingConfiguration",
-  "javaInterfaces": ["java.io.Serializable"],
-  "extends": {
-    "$ref": "StreamsFlinkConfiguration.json"
-  },
-  "properties": {
-    "parallel": {
-      "type": "integer",
-      "default": 1
-    },
-    "providerWaitMs": {
-      "type": "integer",
-      "default": 1000
-    },
-    "checkpointIntervalMs": {
-      "type": "integer",
-      "default": 300000
-    },
-    "checkpointTimeoutMs": {
-      "type": "integer",
-      "default": 30000
-    },
-    "restartAttempts": {
-      "type": "integer",
-      "description": "number of restart attempts",
-      "default": 3
-    },
-    "restartDelayMs": {
-      "type": "integer",
-      "description": "delay in milliseconds",
-      "default": 10000
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/FlinkTwitterFollowingPipeline.dot
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterFollowingPipeline.dot b/flink/flink-twitter-collection/src/site/resources/FlinkTwitterFollowingPipeline.dot
deleted file mode 100644
index ba5e60d..0000000
--- a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterFollowingPipeline.dot
+++ /dev/null
@@ -1,37 +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.
- */
- digraph g {
-
-  //source
-  source [label="source\nhdfs://${host}:${port}/${path}/${readerPath}",shape=tab];
-
-  //providers
-  TwitterFollowingProvider [label="TwitterFollowingProvider",shape=ellipse,URL="https://github.com/apache/incubator-streams/blob/master/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterFollowingProvider.java"];
-
-  //persisters
-  RollingFileSink [label="RollingFileSink",shape=ellipse];
-  
-   //data
-  destination [label="destination\nhdfs://${host}:${port}/${path}/${writerPath}",shape=tab];
-
-  //stream
-  TwitterFollowingProvider -> source [dir=back,style=dashed];
-  TwitterFollowingProvider -> RollingFileSink [label="String"];
-  RollingFileSink -> destination;
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/FlinkTwitterFollowingPipelineFollowersIT.conf
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterFollowingPipelineFollowersIT.conf b/flink/flink-twitter-collection/src/site/resources/FlinkTwitterFollowingPipelineFollowersIT.conf
deleted file mode 100644
index 3e922ab..0000000
--- a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterFollowingPipelineFollowersIT.conf
+++ /dev/null
@@ -1,20 +0,0 @@
-source {
-  fields = ["ID"]
-  scheme = file
-  path = "target/test-classes"
-  readerPath = "asf.txt"
-}
-destination {
-  fields = ["DOC"]
-  scheme = file
-  path = "target/test-classes"
-  writerPath = "FlinkTwitterFollowingPipelineFollowersIT"
-}
-twitter {
-  endpoint = followers
-  ids_only = true
-  max_items = 5000
-}
-providerWaitMs = 1000
-local = true
-test = true

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/FlinkTwitterFollowingPipelineFriendsIT.conf
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterFollowingPipelineFriendsIT.conf b/flink/flink-twitter-collection/src/site/resources/FlinkTwitterFollowingPipelineFriendsIT.conf
deleted file mode 100644
index 038a8dc..0000000
--- a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterFollowingPipelineFriendsIT.conf
+++ /dev/null
@@ -1,19 +0,0 @@
-source {
-  fields = ["ID"]
-  scheme = file
-  path = "target/test-classes"
-  readerPath = "asf.txt"
-}
-destination {
-  fields = ["DOC"]
-  scheme = file
-  path = "target/test-classes"
-  writerPath = "FlinkTwitterFollowingPipelineFriendsIT"
-}
-twitter {
-  endpoint = friends
-  ids_only = true
-}
-providerWaitMs = 1000
-local = true
-test = true

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/FlinkTwitterPostsPipeline.dot
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterPostsPipeline.dot b/flink/flink-twitter-collection/src/site/resources/FlinkTwitterPostsPipeline.dot
deleted file mode 100644
index 1092ff4..0000000
--- a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterPostsPipeline.dot
+++ /dev/null
@@ -1,37 +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.
- */
- digraph g {
-
-  //source
-  source [label="source\nhdfs://${host}:${port}/${path}/${readerPath}",shape=tab];
-
-  //providers
-  TwitterTimelineProvider [label="TwitterTimelineProvider",shape=ellipse,URL="https://github.com/apache/incubator-streams/blob/master/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java"];
-
-  //persisters
-  RollingFileSink [label="RollingFileSink",shape=ellipse];
-  
-   //data
-  destination [label="destination\nhdfs://${host}:${port}/${path}/${writerPath}",shape=tab];
-
-  //stream
-  TwitterTimelineProvider -> source [dir=back,style=dashed];
-  TwitterTimelineProvider -> RollingFileSink [label="String"];
-  RollingFileSink -> destination;
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/FlinkTwitterPostsPipelineIT.conf
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterPostsPipelineIT.conf b/flink/flink-twitter-collection/src/site/resources/FlinkTwitterPostsPipelineIT.conf
deleted file mode 100644
index 6954113..0000000
--- a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterPostsPipelineIT.conf
+++ /dev/null
@@ -1,15 +0,0 @@
-source {
-  fields = ["ID"]
-  scheme = file
-  path = "target/test-classes"
-  readerPath = "asf.txt"
-}
-destination {
-  fields = ["DOC"]
-  scheme = file
-  path = "target/test-classes"
-  writerPath = "FlinkTwitterPostsPipelineIT"
-}
-providerWaitMs = 1000
-local = true
-test = true

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/FlinkTwitterSpritzerPipeline.dot
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterSpritzerPipeline.dot b/flink/flink-twitter-collection/src/site/resources/FlinkTwitterSpritzerPipeline.dot
deleted file mode 100644
index 5a57595..0000000
--- a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterSpritzerPipeline.dot
+++ /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.
- */
- digraph g {
-
-  //providers
-  TwitterStreamProvider [label="TwitterStreamProvider",shape=ellipse,URL="https://github.com/apache/incubator-streams/blob/master/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterStreamProvider.java"];
-
-  //persisters
-  RollingFileSink [label="RollingFileSink",shape=ellipse];
-  
-   //data
-  destination [label="hdfs://${host}:${port}/${path}/${writerPath}",shape=box];
-
-  //stream
-  TwitterStreamProvider -> RollingFileSink [label="String"];
-  RollingFileSink -> destination;
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/FlinkTwitterSpritzerPipelineIT.conf
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterSpritzerPipelineIT.conf b/flink/flink-twitter-collection/src/site/resources/FlinkTwitterSpritzerPipelineIT.conf
deleted file mode 100644
index fec4769..0000000
--- a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterSpritzerPipelineIT.conf
+++ /dev/null
@@ -1,15 +0,0 @@
-destination {
-  fields = ["DOC"]
-  scheme = file
-  path = "target/test-classes"
-  writerPath = "FlinkTwitterSpritzerPipelineIT"
-}
-twitter {
-  endpoint = sample
-  track = [
-    "data"
-  ]
-}
-providerWaitMs = 1000
-local = true
-test = true

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/FlinkTwitterUserInformationPipeline.dot
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterUserInformationPipeline.dot b/flink/flink-twitter-collection/src/site/resources/FlinkTwitterUserInformationPipeline.dot
deleted file mode 100644
index 4a37234..0000000
--- a/flink/flink-twitter-collection/src/site/resources/FlinkTwitterUserInformationPipeline.dot
+++ /dev/null
@@ -1,37 +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.
- */
- digraph g {
-
-  //source
-  source [label="source\nhdfs://${host}:${port}/${path}/${readerPath}",shape=tab];
-
-  //providers
-  TwitterUserInformationProvider [label="TwitterUserInformationProvider",shape=ellipse,URL="https://github.com/apache/incubator-streams/blob/master/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterUserInformationProvider.java"];
-
-  //persisters
-  RollingFileSink [label="RollingFileSink",shape=ellipse];
-  
-   //data
-  destination [label="destination\nhdfs://${host}:${port}/${path}/${writerPath}",shape=tab];
-
-  //stream
-  TwitterUserInformationProvider -> source [dir=back,style=dashed];
-  TwitterUserInformationProvider -> RollingFileSink [label="String"];
-  RollingFileSink -> destination;
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/StreamsFlinkConfiguration.json
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/StreamsFlinkConfiguration.json b/flink/flink-twitter-collection/src/site/resources/StreamsFlinkConfiguration.json
deleted file mode 100644
index ef78357..0000000
--- a/flink/flink-twitter-collection/src/site/resources/StreamsFlinkConfiguration.json
+++ /dev/null
@@ -1,48 +0,0 @@
-{
-  "$schema": "http://json-schema.org/draft-03/schema",
-  "$license": [
-    "http://www.apache.org/licenses/LICENSE-2.0"
-  ],
-  "type": "object",
-  "javaType" : "org.apache.streams.flink.StreamsFlinkConfiguration",
-  "javaInterfaces": ["java.io.Serializable"],
-  "extends": {
-    "$ref": "http://streams.peoplepattern.com/incubator-streams/0.3.9-PP-SNAPSHOT/streams-config/StreamsConfiguration.json"
-  },
-  "properties": {
-    "parallel": {
-      "type": "integer",
-      "default": 1
-    },
-    "providerWaitMs": {
-      "type": "integer",
-      "default": 1000
-    },
-    "checkpointIntervalMs": {
-      "type": "integer",
-      "default": 300000
-    },
-    "checkpointTimeoutMs": {
-      "type": "integer",
-      "default": 30000
-    },
-    "test": {
-      "type": "boolean",
-      "default": false
-    },
-    "local": {
-      "type": "boolean",
-      "default": true
-    },
-    "restartAttempts": {
-      "type": "integer",
-      "description": "number of restart attempts",
-      "default": 3
-    },
-    "restartDelayMs": {
-      "type": "integer",
-      "description": "delay in milliseconds",
-      "default": 10000
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/TwitterFollowingBatchConfiguration.json
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/TwitterFollowingBatchConfiguration.json b/flink/flink-twitter-collection/src/site/resources/TwitterFollowingBatchConfiguration.json
deleted file mode 100644
index 33afb29..0000000
--- a/flink/flink-twitter-collection/src/site/resources/TwitterFollowingBatchConfiguration.json
+++ /dev/null
@@ -1,23 +0,0 @@
-{
-  "$schema": "http://json-schema.org/draft-03/schema",
-  "$license": [
-    "http://www.apache.org/licenses/LICENSE-2.0"
-  ],
-  "type": "object",
-  "javaType" : "com.peoplepattern.streams.pipelines.pdb.TwitterFollowingBatchConfiguration",
-  "javaInterfaces": ["java.io.Serializable"],
-  "properties": {
-    "twitter": {
-      "type": "object",
-      "javaType": "org.apache.streams.twitter.TwitterFollowingConfiguration"
-    },
-    "hdfs": {
-      "type": "object",
-      "javaType": "org.apache.streams.hdfs.HdfsWriterConfiguration"
-    },
-    "s3": {
-      "type": "object",
-      "javaType": "org.apache.streams.s3.S3WriterConfiguration"
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/TwitterFollowingPipelineConfiguration.json
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/TwitterFollowingPipelineConfiguration.json b/flink/flink-twitter-collection/src/site/resources/TwitterFollowingPipelineConfiguration.json
deleted file mode 100644
index de4f9bb..0000000
--- a/flink/flink-twitter-collection/src/site/resources/TwitterFollowingPipelineConfiguration.json
+++ /dev/null
@@ -1,29 +0,0 @@
-{
-  "$schema": "http://json-schema.org/draft-03/schema",
-  "$license": [
-    "http://www.apache.org/licenses/LICENSE-2.0"
-  ],
-  "type": "object",
-  "javaType" : "org.apache.streams.examples.flink.twitter.TwitterFollowingPipelineConfiguration",
-  "javaInterfaces": ["java.io.Serializable"],
-  "extends": {
-    "$ref": "FlinkStreamingConfiguration.json"
-  },
-  "properties": {
-    "twitter": {
-      "type": "object",
-      "javaType": "org.apache.streams.twitter.TwitterFollowingConfiguration"
-    },
-    "source": {
-      "type": "object",
-      "javaType": "org.apache.streams.hdfs.HdfsReaderConfiguration"
-    },
-    "destination": {
-      "type": "object",
-      "javaType": "org.apache.streams.hdfs.HdfsWriterConfiguration"
-    },
-    "providerWaitMs": {
-      "type": "integer"
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/TwitterPostsBatchConfiguration.json
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/TwitterPostsBatchConfiguration.json b/flink/flink-twitter-collection/src/site/resources/TwitterPostsBatchConfiguration.json
deleted file mode 100644
index 376bb4d..0000000
--- a/flink/flink-twitter-collection/src/site/resources/TwitterPostsBatchConfiguration.json
+++ /dev/null
@@ -1,23 +0,0 @@
-{
-  "$schema": "http://json-schema.org/draft-03/schema",
-  "$license": [
-    "http://www.apache.org/licenses/LICENSE-2.0"
-  ],
-  "type": "object",
-  "javaType" : "com.peoplepattern.streams.pipelines.pdb.TwitterPostsBatchConfiguration",
-  "javaInterfaces": ["java.io.Serializable"],
-  "properties": {
-    "twitter": {
-      "type": "object",
-      "javaType": "org.apache.streams.twitter.TwitterUserInformationConfiguration"
-    },
-    "hdfs": {
-      "type": "object",
-      "javaType": "org.apache.streams.hdfs.HdfsWriterConfiguration"
-    },
-    "s3": {
-      "type": "object",
-      "javaType": "org.apache.streams.s3.S3WriterConfiguration"
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/TwitterPostsPipelineConfiguration.json
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/TwitterPostsPipelineConfiguration.json b/flink/flink-twitter-collection/src/site/resources/TwitterPostsPipelineConfiguration.json
deleted file mode 100644
index 628d7ee..0000000
--- a/flink/flink-twitter-collection/src/site/resources/TwitterPostsPipelineConfiguration.json
+++ /dev/null
@@ -1,29 +0,0 @@
-{
-  "$schema": "http://json-schema.org/draft-03/schema",
-  "$license": [
-    "http://www.apache.org/licenses/LICENSE-2.0"
-  ],
-  "type": "object",
-  "javaType" : "org.apache.streams.examples.flink.twitter.TwitterPostsPipelineConfiguration",
-  "javaInterfaces": ["java.io.Serializable"],
-  "extends": {
-    "$ref": "FlinkStreamingConfiguration.json"
-  },
-  "properties": {
-    "twitter": {
-      "type": "object",
-      "javaType": "org.apache.streams.twitter.TwitterUserInformationConfiguration"
-    },
-    "source": {
-      "type": "object",
-      "javaType": "org.apache.streams.hdfs.HdfsReaderConfiguration"
-    },
-    "destination": {
-      "type": "object",
-      "javaType": "org.apache.streams.hdfs.HdfsWriterConfiguration"
-    },
-    "providerWaitMs": {
-      "type": "integer"
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/TwitterSpritzerPipelineConfiguration.json
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/TwitterSpritzerPipelineConfiguration.json b/flink/flink-twitter-collection/src/site/resources/TwitterSpritzerPipelineConfiguration.json
deleted file mode 100644
index 49d0d1e..0000000
--- a/flink/flink-twitter-collection/src/site/resources/TwitterSpritzerPipelineConfiguration.json
+++ /dev/null
@@ -1,29 +0,0 @@
-{
-  "$schema": "http://json-schema.org/draft-03/schema",
-  "$license": [
-    "http://www.apache.org/licenses/LICENSE-2.0"
-  ],
-  "type": "object",
-  "javaType" : "org.apache.streams.examples.flink.twitter.TwitterSpritzerPipelineConfiguration",
-  "javaInterfaces": ["java.io.Serializable"],
-  "extends": {
-    "$ref": "FlinkStreamingConfiguration.json"
-  },
-  "properties": {
-    "twitter": {
-      "type": "object",
-      "javaType": "org.apache.streams.twitter.TwitterStreamConfiguration"
-    },
-    "source": {
-      "type": "object",
-      "javaType": "org.apache.streams.hdfs.HdfsReaderConfiguration"
-    },
-    "destination": {
-      "type": "object",
-      "javaType": "org.apache.streams.hdfs.HdfsWriterConfiguration"
-    },
-    "providerWaitMs": {
-      "type": "integer"
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/TwitterUserInformationBatchConfiguration.json
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/TwitterUserInformationBatchConfiguration.json b/flink/flink-twitter-collection/src/site/resources/TwitterUserInformationBatchConfiguration.json
deleted file mode 100644
index 55f9fbd..0000000
--- a/flink/flink-twitter-collection/src/site/resources/TwitterUserInformationBatchConfiguration.json
+++ /dev/null
@@ -1,23 +0,0 @@
-{
-  "$schema": "http://json-schema.org/draft-03/schema",
-  "$license": [
-    "http://www.apache.org/licenses/LICENSE-2.0"
-  ],
-  "type": "object",
-  "javaType" : "com.peoplepattern.streams.pipelines.pdb.TwitterUserInformationBatchConfiguration",
-  "javaInterfaces": ["java.io.Serializable"],
-  "properties": {
-    "twitter": {
-      "type": "object",
-      "javaType": "org.apache.streams.twitter.TwitterUserInformationConfiguration"
-    },
-    "hdfs": {
-      "type": "object",
-      "javaType": "org.apache.streams.hdfs.HdfsWriterConfiguration"
-    },
-    "s3": {
-      "type": "object",
-      "javaType": "org.apache.streams.s3.S3WriterConfiguration"
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/flink/flink-twitter-collection/src/site/resources/TwitterUserInformationPipelineConfiguration.json
----------------------------------------------------------------------
diff --git a/flink/flink-twitter-collection/src/site/resources/TwitterUserInformationPipelineConfiguration.json b/flink/flink-twitter-collection/src/site/resources/TwitterUserInformationPipelineConfiguration.json
deleted file mode 100644
index 5261748..0000000
--- a/flink/flink-twitter-collection/src/site/resources/TwitterUserInformationPipelineConfiguration.json
+++ /dev/null
@@ -1,29 +0,0 @@
-{
-  "$schema": "http://json-schema.org/draft-03/schema",
-  "$license": [
-    "http://www.apache.org/licenses/LICENSE-2.0"
-  ],
-  "type": "object",
-  "javaType" : "org.apache.streams.examples.flink.twitter.TwitterUserInformationPipelineConfiguration",
-  "javaInterfaces": ["java.io.Serializable"],
-  "extends": {
-    "$ref": "FlinkStreamingConfiguration.json"
-  },
-  "properties": {
-    "twitter": {
-      "type": "object",
-      "javaType": "org.apache.streams.twitter.TwitterUserInformationConfiguration"
-    },
-    "source": {
-      "type": "object",
-      "javaType": "org.apache.streams.hdfs.HdfsReaderConfiguration"
-    },
-    "destination": {
-      "type": "object",
-      "javaType": "org.apache.streams.hdfs.HdfsWriterConfiguration"
-    },
-    "providerWaitMs": {
-      "type": "integer"
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/local/twitter-follow-neo4j/src/site/resources/TwitterFollowGraph.dot
----------------------------------------------------------------------
diff --git a/local/twitter-follow-neo4j/src/site/resources/TwitterFollowGraph.dot b/local/twitter-follow-neo4j/src/site/resources/TwitterFollowGraph.dot
deleted file mode 100644
index 2d9e495..0000000
--- a/local/twitter-follow-neo4j/src/site/resources/TwitterFollowGraph.dot
+++ /dev/null
@@ -1,39 +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.
- */
- digraph g {
-
-  //providers
-  TwitterFollowingProvider [label="TwitterFollowingProvider",shape=ellipse,URL="https://github.com/apache/incubator-streams/blob/master/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterFollowingProvider.java"];
-
-  //processors
-  TypeConverterProcessor [label="TypeConverterProcessor",shape=ellipse,URL="https://github.com/apache/incubator-streams/blob/master/streams-components/streams-converters/src/main/java/org/apache/streams/converters/TypeConverterProcessor.java"];
-  ActivityConverterProcessor [label="ActivityConverterProcessor",shape=ellipse,URL="https://github.com/apache/incubator-streams/blob/master/streams-components/streams-converters/src/main/java/org/apache/streams/converters/ActivityConverterProcessor.java"];
-
-  //persisters
-  GraphPersistWriter [label="GraphPersistWriter",shape=ellipse,URL="https://github.com/apache/incubator-streams/blob/master/streams-contrib/streams-persist-graph/src/main/java/org/apache/streams/graph/GraphPersistWriter.java"];
-
-  //data
-  destination [label="http://{host}:{port}/db/data",shape=box];
-
-  //stream
-  TwitterFollowingProvider -> TypeConverterProcessor [label="Follow",URL="https://github.com/apache/incubator-streams/blob/master/streams-contrib/streams-provider-twitter/src/main/jsonschema/com/twitter/Follow.java"];
-  TypeConverterProcessor -> ActivityConverterProcessor [label="String"];
-  ActivityConverterProcessor -> GraphPersistWriter [label="Activity",URL="https://github.com/apache/incubator-streams/blob/master/streams-pojo/src/main/jsonschema/org/apache/streams/pojo/json/activity.json"];
-  GraphPersistWriter -> destination
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/local/twitter-follow-neo4j/src/site/resources/TwitterFollowGraphConfiguration.json
----------------------------------------------------------------------
diff --git a/local/twitter-follow-neo4j/src/site/resources/TwitterFollowGraphConfiguration.json b/local/twitter-follow-neo4j/src/site/resources/TwitterFollowGraphConfiguration.json
deleted file mode 100644
index 6025640..0000000
--- a/local/twitter-follow-neo4j/src/site/resources/TwitterFollowGraphConfiguration.json
+++ /dev/null
@@ -1,13 +0,0 @@
-{
-  "$schema": "http://json-schema.org/draft-03/schema",
-  "$license": [
-    "http://www.apache.org/licenses/LICENSE-2.0"
-  ],
-  "type": "object",
-  "javaType" : "org.apache.streams.example.graph.TwitterFollowNeo4jConfiguration",
-  "javaInterfaces": ["java.io.Serializable"],
-  "properties": {
-    "twitter": { "javaType": "org.apache.streams.twitter.TwitterFollowingConfiguration", "type": "object", "required": true },
-    "graph": { "javaType": "org.apache.streams.graph.GraphHttpConfiguration", "type": "object", "required": true }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/local/twitter-follow-neo4j/src/site/resources/TwitterFollowNeo4j.dot
----------------------------------------------------------------------
diff --git a/local/twitter-follow-neo4j/src/site/resources/TwitterFollowNeo4j.dot b/local/twitter-follow-neo4j/src/site/resources/TwitterFollowNeo4j.dot
deleted file mode 100644
index 2d9e495..0000000
--- a/local/twitter-follow-neo4j/src/site/resources/TwitterFollowNeo4j.dot
+++ /dev/null
@@ -1,39 +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.
- */
- digraph g {
-
-  //providers
-  TwitterFollowingProvider [label="TwitterFollowingProvider",shape=ellipse,URL="https://github.com/apache/incubator-streams/blob/master/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterFollowingProvider.java"];
-
-  //processors
-  TypeConverterProcessor [label="TypeConverterProcessor",shape=ellipse,URL="https://github.com/apache/incubator-streams/blob/master/streams-components/streams-converters/src/main/java/org/apache/streams/converters/TypeConverterProcessor.java"];
-  ActivityConverterProcessor [label="ActivityConverterProcessor",shape=ellipse,URL="https://github.com/apache/incubator-streams/blob/master/streams-components/streams-converters/src/main/java/org/apache/streams/converters/ActivityConverterProcessor.java"];
-
-  //persisters
-  GraphPersistWriter [label="GraphPersistWriter",shape=ellipse,URL="https://github.com/apache/incubator-streams/blob/master/streams-contrib/streams-persist-graph/src/main/java/org/apache/streams/graph/GraphPersistWriter.java"];
-
-  //data
-  destination [label="http://{host}:{port}/db/data",shape=box];
-
-  //stream
-  TwitterFollowingProvider -> TypeConverterProcessor [label="Follow",URL="https://github.com/apache/incubator-streams/blob/master/streams-contrib/streams-provider-twitter/src/main/jsonschema/com/twitter/Follow.java"];
-  TypeConverterProcessor -> ActivityConverterProcessor [label="String"];
-  ActivityConverterProcessor -> GraphPersistWriter [label="Activity",URL="https://github.com/apache/incubator-streams/blob/master/streams-pojo/src/main/jsonschema/org/apache/streams/pojo/json/activity.json"];
-  GraphPersistWriter -> destination
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-streams-examples/blob/8533c234/local/twitter-follow-neo4j/src/site/resources/TwitterFollowNeo4jConfiguration.json
----------------------------------------------------------------------
diff --git a/local/twitter-follow-neo4j/src/site/resources/TwitterFollowNeo4jConfiguration.json b/local/twitter-follow-neo4j/src/site/resources/TwitterFollowNeo4jConfiguration.json
deleted file mode 100644
index ffbd39d..0000000
--- a/local/twitter-follow-neo4j/src/site/resources/TwitterFollowNeo4jConfiguration.json
+++ /dev/null
@@ -1,13 +0,0 @@
-{
-  "$schema": "http://json-schema.org/draft-03/schema",
-  "$license": [
-    "http://www.apache.org/licenses/LICENSE-2.0"
-  ],
-  "type": "object",
-  "javaType" : "org.apache.streams.example.TwitterFollowNeo4jConfiguration",
-  "javaInterfaces": ["java.io.Serializable"],
-  "properties": {
-    "twitter": { "javaType": "org.apache.streams.twitter.TwitterFollowingConfiguration", "type": "object", "required": true },
-    "graph": { "javaType": "org.apache.streams.graph.GraphHttpConfiguration", "type": "object", "required": true }
-  }
-}
\ No newline at end of file