You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@streams.apache.org by mf...@apache.org on 2014/05/27 15:43:55 UTC

[1/9] git commit: STREAMS-86 | Added in necessary license header and removed unnecessary imports

Repository: incubator-streams
Updated Branches:
  refs/heads/master 252801c09 -> ec5d3482e


STREAMS-86 | Added in necessary license header and removed unnecessary imports


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

Branch: refs/heads/master
Commit: 7cabbf34702dd6f6e5c3bdd55eb2d274d4e992ff
Parents: bc5a2f9
Author: Robert Douglas <rd...@w2odigital.com>
Authored: Mon May 19 13:45:48 2014 -0500
Committer: mfranklin <mf...@apache.org>
Committed: Tue May 27 09:33:20 2014 -0400

----------------------------------------------------------------------
 .../provider/TwitterTimelineProvider.java       | 28 +++++++++++++-------
 1 file changed, 18 insertions(+), 10 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-streams/blob/7cabbf34/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
----------------------------------------------------------------------
diff --git a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
index f975fe6..7db81a3 100644
--- a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
+++ b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
@@ -1,11 +1,25 @@
+/*
+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.streams.twitter.provider;
 
 import com.google.common.base.Optional;
 import com.google.common.base.Preconditions;
-import com.google.common.base.Predicates;
-import com.google.common.collect.ImmutableList;
-import com.google.common.collect.Iterables;
-import com.google.common.collect.Iterators;
 import com.google.common.collect.Queues;
 import com.google.common.util.concurrent.ListenableFuture;
 import com.google.common.util.concurrent.ListeningExecutorService;
@@ -24,12 +38,9 @@ import org.slf4j.LoggerFactory;
 import sun.reflect.generics.reflectiveObjects.NotImplementedException;
 import twitter4j.*;
 import twitter4j.conf.ConfigurationBuilder;
-import twitter4j.json.DataObjectFactory;
 
 import java.io.Serializable;
-import java.lang.Math;
 import java.math.BigInteger;
-import java.util.*;
 import java.util.concurrent.*;
 import java.util.concurrent.locks.ReadWriteLock;
 import java.util.concurrent.locks.ReentrantReadWriteLock;
@@ -42,9 +53,6 @@ import java.util.concurrent.ExecutorService;
 import java.util.concurrent.ThreadPoolExecutor;
 import java.util.concurrent.TimeUnit;
 
-/**
- * Created by sblackmon on 12/10/13.
- */
 public class TwitterTimelineProvider implements StreamsProvider, Serializable {
 
     public final static String STREAMS_ID = "TwitterTimelineProvider";


[7/9] git commit: STREAMS-86 | providerQueue is constructed before checking to see if it is null. Otherwise, will fail every time

Posted by mf...@apache.org.
STREAMS-86 | providerQueue is constructed before checking to see if it is null. Otherwise, will fail every time


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

Branch: refs/heads/master
Commit: ea7b6622d505f0f0c0089760d3a59b888bb38aa3
Parents: 12af7b3
Author: Robert Douglas <rd...@w2odigital.com>
Authored: Mon May 19 14:38:12 2014 -0500
Committer: mfranklin <mf...@apache.org>
Committed: Tue May 27 09:33:21 2014 -0400

----------------------------------------------------------------------
 .../twitter/provider/TwitterTimelineProvider.java     | 14 +++++++-------
 1 file changed, 7 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-streams/blob/ea7b6622/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
----------------------------------------------------------------------
diff --git a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
index 8927577..15828fc 100644
--- a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
+++ b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
@@ -266,6 +266,13 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
 
         executor = MoreExecutors.listeningDecorator(newFixedThreadPoolWithQueueSize(5, 20));
 
+        try {
+            lock.writeLock().lock();
+            providerQueue = constructQueue();
+        } finally {
+            lock.writeLock().unlock();
+        }
+
         Preconditions.checkNotNull(providerQueue);
         Preconditions.checkNotNull(this.klass);
         Preconditions.checkNotNull(config.getOauth().getConsumerKey());
@@ -281,13 +288,6 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
         includeEntitiesEnabled = Optional.fromNullable(new Boolean(Boolean.parseBoolean(config.getIncludeEntities()))).or(true);
 
         client = getTwitterClient();
-
-        try {
-            lock.writeLock().lock();
-            providerQueue = constructQueue();
-        } finally {
-            lock.writeLock().unlock();
-        }
     }
 
     protected Twitter getTwitterClient()


[9/9] git commit: STREAMS-86 | Added write lock when we reassign the queue's reference in the prepare method

Posted by mf...@apache.org.
STREAMS-86 | Added write lock when we reassign the queue's reference in the prepare method


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

Branch: refs/heads/master
Commit: 12af7b31ac5a4569fb5704f74c422124a7f225bb
Parents: 7cabbf3
Author: Robert Douglas <rd...@w2odigital.com>
Authored: Mon May 19 14:03:34 2014 -0500
Committer: mfranklin <mf...@apache.org>
Committed: Tue May 27 09:33:21 2014 -0400

----------------------------------------------------------------------
 .../streams/twitter/provider/TwitterTimelineProvider.java    | 8 ++++++--
 1 file changed, 6 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-streams/blob/12af7b31/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
----------------------------------------------------------------------
diff --git a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
index 7db81a3..8927577 100644
--- a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
+++ b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
@@ -282,10 +282,14 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
 
         client = getTwitterClient();
 
-        providerQueue = constructQueue();
+        try {
+            lock.writeLock().lock();
+            providerQueue = constructQueue();
+        } finally {
+            lock.writeLock().unlock();
+        }
     }
 
-
     protected Twitter getTwitterClient()
     {
         String baseUrl = "https://api.twitter.com:443/1.1/";


[5/9] git commit: STREAMS-86 | Added a Reentrant Read/Write lock to ensure that the provider queue is only accessed when appropriate. This helps to make sure that we don't drop data between this provider any any subsequent components

Posted by mf...@apache.org.
STREAMS-86 | Added a Reentrant Read/Write lock to ensure that the provider queue is only accessed when appropriate. This helps to make sure that we don't drop data between this provider any any subsequent components


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

Branch: refs/heads/master
Commit: b48c03d2498b13e3ea6eb85906e1c616249ac174
Parents: 252801c
Author: Robert Douglas <rd...@w2odigital.com>
Authored: Mon May 19 13:33:47 2014 -0500
Committer: mfranklin <mf...@apache.org>
Committed: Tue May 27 09:33:20 2014 -0400

----------------------------------------------------------------------
 .../provider/TwitterTimelineProvider.java       | 36 ++++++++++++++++----
 1 file changed, 29 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-streams/blob/b48c03d2/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
----------------------------------------------------------------------
diff --git a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
index e4b0460..f5b5d24 100644
--- a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
+++ b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
@@ -2,12 +2,17 @@ package org.apache.streams.twitter.provider;
 
 import com.google.common.base.Optional;
 import com.google.common.base.Preconditions;
+import com.google.common.base.Predicates;
+import com.google.common.collect.ImmutableList;
+import com.google.common.collect.Iterables;
+import com.google.common.collect.Iterators;
 import com.google.common.collect.Queues;
 import com.google.common.util.concurrent.ListenableFuture;
 import com.google.common.util.concurrent.ListeningExecutorService;
 import com.google.common.util.concurrent.MoreExecutors;
 import com.typesafe.config.Config;
 import org.apache.streams.config.StreamsConfigurator;
+import org.apache.streams.core.DatumStatusCounter;
 import org.apache.streams.core.StreamsDatum;
 import org.apache.streams.core.StreamsProvider;
 import org.apache.streams.core.StreamsResultSet;
@@ -24,6 +29,10 @@ import twitter4j.json.DataObjectFactory;
 import java.io.Serializable;
 import java.lang.Math;
 import java.math.BigInteger;
+import java.util.*;
+import java.util.concurrent.*;
+import java.util.concurrent.locks.ReadWriteLock;
+import java.util.concurrent.locks.ReentrantReadWriteLock;
 import java.util.Iterator;
 import java.util.List;
 import java.util.Map;
@@ -45,6 +54,7 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
     private TwitterStreamConfiguration config;
 
     private Class klass;
+    private ReadWriteLock lock = new ReentrantReadWriteLock();
 
     public TwitterStreamConfiguration getConfig() {
         return config;
@@ -54,12 +64,14 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
         this.config = config;
     }
 
-    protected final Queue<StreamsDatum> providerQueue = Queues.synchronizedQueue(new ArrayBlockingQueue<StreamsDatum>(5000));
+    protected volatile Queue<StreamsDatum> providerQueue;
 
     protected int idsCount;
     protected Twitter client;
     protected Iterator<Long> ids;
 
+    ListenableFuture providerTaskComplete;
+
     protected ListeningExecutorService executor;
 
     protected DateTime start;
@@ -116,14 +128,12 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
             int keepTrying = 0;
 
             // keep trying to load, give it 5 attempts.
-            //while (keepTrying < 10)
-            while (keepTrying < 1)
+            while (keepTrying < 5)
             {
 
                 try
                 {
                     statuses = client.getUserTimeline(currentId, paging);
-
                     for (Status tStat : statuses) {
                         String json = TwitterObjectFactory.getRawJSON(tStat);
                         ComponentUtils.offerUntilSuccess(new StreamsDatum(json), providerQueue);
@@ -172,6 +182,7 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
         LOGGER.debug("{} readCurrent", STREAMS_ID);
 
         Preconditions.checkArgument(ids.hasNext());
+        StreamsResultSet result;
 
         StreamsResultSet current;
 
@@ -189,7 +200,14 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
 
         LOGGER.info("Providing {} docs", providerQueue.size());
 
-        StreamsResultSet result =  new StreamsResultSet(providerQueue);
+        try {
+            lock.writeLock().lock();
+            result = new StreamsResultSet(providerQueue);
+            result.setCounter(new DatumStatusCounter());
+            providerQueue = constructQueue();
+        } finally {
+            lock.writeLock().unlock();
+        }
 
         LOGGER.info("Exiting");
 
@@ -197,6 +215,10 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
 
     }
 
+    private Queue<StreamsDatum> constructQueue() {
+        return Queues.synchronizedQueue(new LinkedBlockingQueue<StreamsDatum>(10000));
+    }
+
     public StreamsResultSet readNew(BigInteger sequence) {
         LOGGER.debug("{} readNew", STREAMS_ID);
         throw new NotImplementedException();
@@ -248,7 +270,7 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
         client = getTwitterClient();
     }
 
-    
+
     protected Twitter getTwitterClient()
     {
         String baseUrl = "https://api.twitter.com:443/1.1/";
@@ -272,4 +294,4 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
     public void cleanUp() {
         shutdownAndAwaitTermination(executor);
     }
-}
+}
\ No newline at end of file


[4/9] git commit: STREAMS-86 | Added a readlock around offering to the provider queue

Posted by mf...@apache.org.
STREAMS-86 | Added a readlock around offering to the provider queue


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

Branch: refs/heads/master
Commit: 4eda5af4333aec58bae8a1161730ec6d6a67cf70
Parents: b48c03d
Author: Robert Douglas <rd...@w2odigital.com>
Authored: Mon May 19 13:37:52 2014 -0500
Committer: mfranklin <mf...@apache.org>
Committed: Tue May 27 09:33:20 2014 -0400

----------------------------------------------------------------------
 .../streams/twitter/provider/TwitterTimelineProvider.java     | 7 ++++++-
 1 file changed, 6 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-streams/blob/4eda5af4/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
----------------------------------------------------------------------
diff --git a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
index f5b5d24..a1c534b 100644
--- a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
+++ b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
@@ -136,7 +136,12 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
                     statuses = client.getUserTimeline(currentId, paging);
                     for (Status tStat : statuses) {
                         String json = TwitterObjectFactory.getRawJSON(tStat);
-                        ComponentUtils.offerUntilSuccess(new StreamsDatum(json), providerQueue);
+                        try {
+                            lock.readLock().lock();
+                            ComponentUtils.offerUntilSuccess(new StreamsDatum(json), providerQueue);
+                        } finally {
+                            lock.readLock().unlock();
+                        }
                     }
 
                     paging.setPage(paging.getPage() + 1);


[6/9] git commit: STREAMS-96 | Changed constructQueue method to protected and added constant: MAX_NUMBER_WAITING

Posted by mf...@apache.org.
STREAMS-96 | Changed constructQueue method to protected and added constant: MAX_NUMBER_WAITING


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

Branch: refs/heads/master
Commit: ec5d3482ea03452c9830815c1e0c9b4221d80f2d
Parents: 189d443
Author: Robert Douglas <rd...@w2odigital.com>
Authored: Thu May 22 15:42:05 2014 -0500
Committer: mfranklin <mf...@apache.org>
Committed: Tue May 27 09:33:21 2014 -0400

----------------------------------------------------------------------
 .../streams/twitter/provider/TwitterTimelineProvider.java       | 5 +++--
 1 file changed, 3 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-streams/blob/ec5d3482/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
----------------------------------------------------------------------
diff --git a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
index 50bb8c0..b6e4332 100644
--- a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
+++ b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
@@ -58,6 +58,7 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
     public final static String STREAMS_ID = "TwitterTimelineProvider";
 
     private final static Logger LOGGER = LoggerFactory.getLogger(TwitterTimelineProvider.class);
+    public static final int MAX_NUMBER_WAITING = 10000;
 
     private TwitterStreamConfiguration config;
 
@@ -228,8 +229,8 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
 
     }
 
-    private Queue<StreamsDatum> constructQueue() {
-        return Queues.synchronizedQueue(new LinkedBlockingQueue<StreamsDatum>(10000));
+    protected Queue<StreamsDatum> constructQueue() {
+        return Queues.synchronizedQueue(new LinkedBlockingQueue<StreamsDatum>(MAX_NUMBER_WAITING));
     }
 
     public StreamsResultSet readNew(BigInteger sequence) {


[8/9] git commit: STREAMS-86 | Changed the read/write lock to protected from private so that any extensions of this class can override the captureTwitterTimeLine method

Posted by mf...@apache.org.
STREAMS-86 | Changed the read/write lock to protected from private so that any extensions of this class can override the captureTwitterTimeLine method


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

Branch: refs/heads/master
Commit: 189d4437b06c03c676a9a7bd08d4c1ae686660a9
Parents: ea7b662
Author: Robert Douglas <rd...@w2odigital.com>
Authored: Mon May 19 15:49:18 2014 -0500
Committer: mfranklin <mf...@apache.org>
Committed: Tue May 27 09:33:21 2014 -0400

----------------------------------------------------------------------
 .../apache/streams/twitter/provider/TwitterTimelineProvider.java   | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-streams/blob/189d4437/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
----------------------------------------------------------------------
diff --git a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
index 15828fc..50bb8c0 100644
--- a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
+++ b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
@@ -62,7 +62,7 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
     private TwitterStreamConfiguration config;
 
     private Class klass;
-    private ReadWriteLock lock = new ReentrantReadWriteLock();
+    protected final ReadWriteLock lock = new ReentrantReadWriteLock();
 
     public TwitterStreamConfiguration getConfig() {
         return config;


[2/9] git commit: STREAMS-86 | Added in constructQueue() call in prepare method

Posted by mf...@apache.org.
STREAMS-86 | Added in constructQueue() call in prepare method


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

Branch: refs/heads/master
Commit: bc5a2f97712ef338811b71b2ac0fc25a0f54439d
Parents: aedcdf4
Author: Robert Douglas <rd...@w2odigital.com>
Authored: Mon May 19 13:42:03 2014 -0500
Committer: mfranklin <mf...@apache.org>
Committed: Tue May 27 09:33:20 2014 -0400

----------------------------------------------------------------------
 .../apache/streams/twitter/provider/TwitterTimelineProvider.java   | 2 ++
 1 file changed, 2 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-streams/blob/bc5a2f97/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
----------------------------------------------------------------------
diff --git a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
index d2acf3e..f975fe6 100644
--- a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
+++ b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
@@ -273,6 +273,8 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
         includeEntitiesEnabled = Optional.fromNullable(new Boolean(Boolean.parseBoolean(config.getIncludeEntities()))).or(true);
 
         client = getTwitterClient();
+
+        providerQueue = constructQueue();
     }
 
 


[3/9] git commit: STREAMS-86 | Added back in old number of attempts to try (will change in separate pull request)

Posted by mf...@apache.org.
STREAMS-86 | Added back in old number of attempts to try (will change in separate pull request)


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

Branch: refs/heads/master
Commit: aedcdf4797b351b7f85655ec63036855d2b5ff53
Parents: 4eda5af
Author: Robert Douglas <rd...@w2odigital.com>
Authored: Mon May 19 13:40:09 2014 -0500
Committer: mfranklin <mf...@apache.org>
Committed: Tue May 27 09:33:20 2014 -0400

----------------------------------------------------------------------
 .../apache/streams/twitter/provider/TwitterTimelineProvider.java   | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-streams/blob/aedcdf47/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
----------------------------------------------------------------------
diff --git a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
index a1c534b..d2acf3e 100644
--- a/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
+++ b/streams-contrib/streams-provider-twitter/src/main/java/org/apache/streams/twitter/provider/TwitterTimelineProvider.java
@@ -128,7 +128,7 @@ public class TwitterTimelineProvider implements StreamsProvider, Serializable {
             int keepTrying = 0;
 
             // keep trying to load, give it 5 attempts.
-            while (keepTrying < 5)
+            while (keepTrying < 1)
             {
 
                 try