Jenkins build is still unstable: ActiveMQ-Java8 » ActiveMQ :: RA #193

2014-12-05 Thread Apache Jenkins Server
See 
https://builds.apache.org/job/ActiveMQ-Java8/org.apache.activemq$activemq-ra/193/



Jenkins build is still unstable: ActiveMQ-Java8 » ActiveMQ :: Spring #193

2014-12-05 Thread Apache Jenkins Server
See 
https://builds.apache.org/job/ActiveMQ-Java8/org.apache.activemq$activemq-spring/193/



Jenkins build is still unstable: ActiveMQ-Java8 » ActiveMQ :: AMQP #193

2014-12-05 Thread Apache Jenkins Server
See 
https://builds.apache.org/job/ActiveMQ-Java8/org.apache.activemq$activemq-amqp/changes



Jenkins build became unstable: ActiveMQ-Java8 » ActiveMQ :: Unit Tests #193

2014-12-05 Thread Apache Jenkins Server
See 
https://builds.apache.org/job/ActiveMQ-Java8/org.apache.activemq$activemq-unit-tests/193/changes



Jenkins build is still unstable: ActiveMQ-Java8 #193

2014-12-05 Thread Apache Jenkins Server
See https://builds.apache.org/job/ActiveMQ-Java8/changes



buildbot success in ASF Buildbot on activemq-site-production

2014-12-05 Thread buildbot
The Buildbot has detected a restored build on builder activemq-site-production 
while building ASF Buildbot. Full details are available at:
http://ci.apache.org/builders/activemq-site-production/builds/5369

Buildbot URL: http://ci.apache.org/

Buildslave for this Build: bb-cms-slave

Build Reason: The Nightly scheduler named 'activemq-site-production' triggered 
this build
Build Source Stamp: [branch activemq/activemq-website] HEAD
Blamelist: 

Build succeeded!

Sincerely,
 -The Buildbot





[2/3] activemq git commit: tidy up test code layout

2014-12-05 Thread gtully
tidy up test code layout


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

Branch: refs/heads/trunk
Commit: a876a34141a487b2609d61de1d69b6e4b6b5104f
Parents: 60ad053
Author: gtully gary.tu...@gmail.com
Authored: Fri Dec 5 14:02:27 2014 +
Committer: gtully gary.tu...@gmail.com
Committed: Fri Dec 5 14:02:27 2014 +

--
 .../MessageGroupReconnectDistributionTest.java | 17 +
 1 file changed, 5 insertions(+), 12 deletions(-)
--


http://git-wip-us.apache.org/repos/asf/activemq/blob/a876a341/activemq-unit-tests/src/test/java/org/apache/activemq/usecases/MessageGroupReconnectDistributionTest.java
--
diff --git 
a/activemq-unit-tests/src/test/java/org/apache/activemq/usecases/MessageGroupReconnectDistributionTest.java
 
b/activemq-unit-tests/src/test/java/org/apache/activemq/usecases/MessageGroupReconnectDistributionTest.java
index 4799076..660b568 100644
--- 
a/activemq-unit-tests/src/test/java/org/apache/activemq/usecases/MessageGroupReconnectDistributionTest.java
+++ 
b/activemq-unit-tests/src/test/java/org/apache/activemq/usecases/MessageGroupReconnectDistributionTest.java
@@ -17,13 +17,7 @@
 package org.apache.activemq.usecases;
 
 import java.util.ArrayList;
-import java.util.Collections;
-import java.util.HashMap;
-import java.util.HashSet;
-import java.util.List;
 import java.util.Random;
-import java.util.Set;
-import java.util.concurrent.CountDownLatch;
 import java.util.concurrent.ExecutorService;
 import java.util.concurrent.Executors;
 import java.util.concurrent.TimeUnit;
@@ -57,13 +51,13 @@ import static org.junit.Assert.assertTrue;
 @RunWith(BlockJUnit4ClassRunner.class)
 public class MessageGroupReconnectDistributionTest {
 public static final Logger LOG = 
LoggerFactory.getLogger(MessageGroupReconnectDistributionTest.class);
+final Random random = new Random();
 protected Connection connection;
 protected Session session;
 protected MessageProducer producer;
 protected Destination destination;
-
-BrokerService broker;
 protected TransportConnector connector;
+BrokerService broker;
 
 @Before
 public void setUp() throws Exception {
@@ -101,12 +95,11 @@ public class MessageGroupReconnectDistributionTest {
 broker.stop();
 }
 
-final Random random = new Random();
 public int getBatchSize(int bound) throws Exception {
 return bound + random.nextInt(bound);
 }
 
-@Test(timeout = 20 * 60 * 1000)
+@Test(timeout = 5 * 60 * 1000)
 public void testReconnect() throws Exception {
 
 final int numMessages = 5;
@@ -117,7 +110,7 @@ public class MessageGroupReconnectDistributionTest {
 
 ExecutorService executorService = Executors.newCachedThreadPool();
 final ArrayListAtomicLong consumedCounters = new 
ArrayListAtomicLong(numConsumers);
-for (int i=0;inumConsumers; i++) {
+for (int i = 0; i  numConsumers; i++) {
 consumedCounters.add(new AtomicLong(0l));
 final int id = i;
 executorService.submit(new Runnable() {
@@ -185,7 +178,7 @@ public class MessageGroupReconnectDistributionTest {
 
 private void produceMessages(int numMessages) throws JMSException {
 for (int i = 0; i  numMessages; i++) {
-TextMessage msga = session.createTextMessage(hello  +i);
+TextMessage msga = session.createTextMessage(hello  + i);
 msga.setStringProperty(JMSXGroupID, msga.getText());
 producer.send(msga);
 }



[1/3] activemq git commit: https://issues.apache.org/jira/browse/AMQ-2719 - resolve possible skipped dispatch - https://issues.apache.org/jira/browse/AMQ-2106 - remove overload so that distribution or

2014-12-05 Thread gtully
Repository: activemq
Updated Branches:
  refs/heads/trunk 802e527ea - bbb2acca2


https://issues.apache.org/jira/browse/AMQ-2719 - resolve possible skipped 
dispatch - https://issues.apache.org/jira/browse/AMQ-2106 - remove overload so 
that distribution order is not compromised when consumers are removed with a 
valid last delivered sequence. Additional test that uses consumer recreation to 
redistribute groups


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

Branch: refs/heads/trunk
Commit: 60ad053486d49d7cc9065b16270577604e69a9c9
Parents: 802e527
Author: gtully gary.tu...@gmail.com
Authored: Fri Dec 5 13:55:16 2014 +
Committer: gtully gary.tu...@gmail.com
Committed: Fri Dec 5 13:59:04 2014 +

--
 .../apache/activemq/broker/region/Queue.java|  41 ++--
 .../apache/activemq/command/ConsumerInfo.java   |  15 +-
 .../MessageGroupReconnectDistributionTest.java  | 193 +++
 3 files changed, 227 insertions(+), 22 deletions(-)
--


http://git-wip-us.apache.org/repos/asf/activemq/blob/60ad0534/activemq-broker/src/main/java/org/apache/activemq/broker/region/Queue.java
--
diff --git 
a/activemq-broker/src/main/java/org/apache/activemq/broker/region/Queue.java 
b/activemq-broker/src/main/java/org/apache/activemq/broker/region/Queue.java
index 43f02f8..f8373ac 100755
--- a/activemq-broker/src/main/java/org/apache/activemq/broker/region/Queue.java
+++ b/activemq-broker/src/main/java/org/apache/activemq/broker/region/Queue.java
@@ -224,8 +224,8 @@ public class Queue extends BaseDestination implements Task, 
UsageListener, Index
 if (val == 0  messageGroupOwners != null) {
 // then ascending order of assigned message groups to favour 
less loaded consumers
 // Long.compare in jdk7
-long x = s1.getConsumerInfo().getLastDeliveredSequenceId();
-long y = s2.getConsumerInfo().getLastDeliveredSequenceId();
+long x = s1.getConsumerInfo().getAssignedGroupCount();
+long y = s2.getConsumerInfo().getAssignedGroupCount();
 val = (x  y) ? -1 : ((x == y) ? 0 : 1);
 }
 return val;
@@ -429,7 +429,7 @@ public class Queue extends BaseDestination implements Task, 
UsageListener, Index
 
 @Override
 public void addSubscription(ConnectionContext context, Subscription sub) 
throws Exception {
-LOG.debug({} add sub: {}, dequeues: {}, dispatched: {}, inflight: 
{}, new Object[]{ getActiveMQDestination().getQualifiedName(), 
getDestinationStatistics().getDequeues().getCount(), 
getDestinationStatistics().getDispatched().getCount(), 
getDestinationStatistics().getInflight().getCount() });
+LOG.debug({} add sub: {}, dequeues: {}, dispatched: {}, inflight: 
{}, new Object[]{ getActiveMQDestination().getQualifiedName(), sub, 
getDestinationStatistics().getDequeues().getCount(), 
getDestinationStatistics().getDispatched().getCount(), 
getDestinationStatistics().getInflight().getCount() });
 
 super.addSubscription(context, sub);
 // synchronize with dispatch method so that no new messages are sent
@@ -500,13 +500,14 @@ public class Queue extends BaseDestination implements 
Task, UsageListener, Index
 // while removing up a subscription.
 pagedInPendingDispatchLock.writeLock().lock();
 try {
-LOG.debug({} remove sub: {}, lastDeliveredSeqId: {}, dequeues: 
{}, dispatched: {}, inflight: {}, new Object[]{
+LOG.debug({} remove sub: {}, lastDeliveredSeqId: {}, dequeues: 
{}, dispatched: {}, inflight: {}, groups: {}, new Object[]{
 getActiveMQDestination().getQualifiedName(),
 sub,
 lastDeiveredSequenceId,
 getDestinationStatistics().getDequeues().getCount(),
 getDestinationStatistics().getDispatched().getCount(),
-getDestinationStatistics().getInflight().getCount()
+getDestinationStatistics().getInflight().getCount(),
+sub.getConsumerInfo().getAssignedGroupCount()
 });
 consumersLock.writeLock().lock();
 try {
@@ -1975,19 +1976,19 @@ public class Queue extends BaseDestination implements 
Task, UsageListener, Index
 // dispatched before.
 pagedInPendingDispatch = 
doActualDispatch(pagedInPendingDispatch);
 }
-// and now see if we can dispatch the new stuff.. and append 
to the pending
-// list 

[3/3] activemq git commit: https://issues.apache.org/jira/browse/AMQ-5476 - fix and test - https://issues.apache.org/jira/browse/AMQ-2790 - default messagePrioritySupported=false

2014-12-05 Thread gtully
https://issues.apache.org/jira/browse/AMQ-5476 - fix and test - 
https://issues.apache.org/jira/browse/AMQ-2790 - default 
messagePrioritySupported=false


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

Branch: refs/heads/trunk
Commit: bbb2acca2fe75ce3b40f6d1092440355ae148610
Parents: a876a34
Author: gtully gary.tu...@gmail.com
Authored: Fri Dec 5 14:49:48 2014 +
Committer: gtully gary.tu...@gmail.com
Committed: Fri Dec 5 14:49:48 2014 +

--
 .../org/apache/activemq/ActiveMQConnection.java |  2 +-
 .../activemq/ActiveMQMessageConsumer.java   |  4 +-
 .../BatchedMessagePriorityConsumerTest.java | 81 
 3 files changed, 85 insertions(+), 2 deletions(-)
--


http://git-wip-us.apache.org/repos/asf/activemq/blob/bbb2acca/activemq-client/src/main/java/org/apache/activemq/ActiveMQConnection.java
--
diff --git 
a/activemq-client/src/main/java/org/apache/activemq/ActiveMQConnection.java 
b/activemq-client/src/main/java/org/apache/activemq/ActiveMQConnection.java
index ed926a1..ed0dd47 100755
--- a/activemq-client/src/main/java/org/apache/activemq/ActiveMQConnection.java
+++ b/activemq-client/src/main/java/org/apache/activemq/ActiveMQConnection.java
@@ -204,7 +204,7 @@ public class ActiveMQConnection implements Connection, 
TopicConnection, QueueCon
 protected AtomicInteger transportInterruptionProcessingComplete = new 
AtomicInteger(0);
 private long consumerFailoverRedeliveryWaitPeriod;
 private Scheduler scheduler;
-private boolean messagePrioritySupported = true;
+private boolean messagePrioritySupported = false;
 private boolean transactedIndividualAck = false;
 private boolean nonBlockingRedelivery = false;
 private boolean rmIdFromConnectionId = false;

http://git-wip-us.apache.org/repos/asf/activemq/blob/bbb2acca/activemq-client/src/main/java/org/apache/activemq/ActiveMQMessageConsumer.java
--
diff --git 
a/activemq-client/src/main/java/org/apache/activemq/ActiveMQMessageConsumer.java
 
b/activemq-client/src/main/java/org/apache/activemq/ActiveMQMessageConsumer.java
index 02dbf49..f43b56d 100755
--- 
a/activemq-client/src/main/java/org/apache/activemq/ActiveMQMessageConsumer.java
+++ 
b/activemq-client/src/main/java/org/apache/activemq/ActiveMQMessageConsumer.java
@@ -267,7 +267,9 @@ public class ActiveMQMessageConsumer implements 
MessageAvailableConsumer, StatsC
 this.info.setOptimizedAcknowledge(this.optimizeAcknowledge);
 this.failoverRedeliveryWaitPeriod = 
session.connection.getConsumerFailoverRedeliveryWaitPeriod();
 this.nonBlockingRedelivery = 
session.connection.isNonBlockingRedelivery();
-this.transactedIndividualAck = 
session.connection.isTransactedIndividualAck() || this.nonBlockingRedelivery;
+this.transactedIndividualAck = 
session.connection.isTransactedIndividualAck()
+|| this.nonBlockingRedelivery
+|| session.connection.isMessagePrioritySupported();
 this.consumerExpiryCheckEnabled = 
session.connection.isConsumerExpiryCheckEnabled();
 if (messageListener != null) {
 setMessageListener(messageListener);

http://git-wip-us.apache.org/repos/asf/activemq/blob/bbb2acca/activemq-unit-tests/src/test/java/org/apache/activemq/usecases/BatchedMessagePriorityConsumerTest.java
--
diff --git 
a/activemq-unit-tests/src/test/java/org/apache/activemq/usecases/BatchedMessagePriorityConsumerTest.java
 
b/activemq-unit-tests/src/test/java/org/apache/activemq/usecases/BatchedMessagePriorityConsumerTest.java
new file mode 100644
index 000..16e2ac2
--- /dev/null
+++ 
b/activemq-unit-tests/src/test/java/org/apache/activemq/usecases/BatchedMessagePriorityConsumerTest.java
@@ -0,0 +1,81 @@
+/**
+ * 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 

activemq git commit: prevent test from pulling in persistence adapter from default location, persistence is not required for this test

2014-12-05 Thread gtully
Repository: activemq
Updated Branches:
  refs/heads/trunk bbb2acca2 - 3858faaf9


prevent test from pulling in persistence adapter from default location, 
persistence is not required for this test


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

Branch: refs/heads/trunk
Commit: 3858faaf9dcf203b6fc37f5ffbcf8e10064399ce
Parents: bbb2acc
Author: gtully gary.tu...@gmail.com
Authored: Fri Dec 5 15:04:11 2014 +
Committer: gtully gary.tu...@gmail.com
Committed: Fri Dec 5 15:04:11 2014 +

--
 .../test/java/org/apache/activemq/ra/ManagedConnectionTest.java| 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
--


http://git-wip-us.apache.org/repos/asf/activemq/blob/3858faaf/activemq-ra/src/test/java/org/apache/activemq/ra/ManagedConnectionTest.java
--
diff --git 
a/activemq-ra/src/test/java/org/apache/activemq/ra/ManagedConnectionTest.java 
b/activemq-ra/src/test/java/org/apache/activemq/ra/ManagedConnectionTest.java
index 1c31c52..b3343f9 100755
--- 
a/activemq-ra/src/test/java/org/apache/activemq/ra/ManagedConnectionTest.java
+++ 
b/activemq-ra/src/test/java/org/apache/activemq/ra/ManagedConnectionTest.java
@@ -36,7 +36,7 @@ import org.apache.activemq.ActiveMQConnectionFactory;
  */
 public class ManagedConnectionTest extends TestCase {
 
-private static final String DEFAULT_HOST = vm://localhost;
+private static final String DEFAULT_HOST = 
vm://localhost?broker.persistent=false;
 
 private ConnectionManagerAdapter connectionManager = new 
ConnectionManagerAdapter();
 private ActiveMQManagedConnectionFactory managedConnectionFactory;



[1/2] activemq-6 git commit: HORNETQ-1381 create new threads under AccessControlContext of the creator of ActiveMQThreadFactory

2014-12-05 Thread clebertsuconic
Repository: activemq-6
Updated Branches:
  refs/heads/master 28ca327b8 - e419feb88


HORNETQ-1381 create new threads under AccessControlContext of the creator of 
ActiveMQThreadFactory


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

Branch: refs/heads/master
Commit: ff9052b83b9ae9e4982d089eb2147f78bce6526d
Parents: b61747d
Author: Ivo Studensky istud...@redhat.com
Authored: Fri Dec 5 12:23:48 2014 +0100
Committer: Ivo Studensky istud...@redhat.com
Committed: Fri Dec 5 12:23:48 2014 +0100

--
 .../activemq/utils/ActiveMQThreadFactory.java   | 51 +++-
 1 file changed, 38 insertions(+), 13 deletions(-)
--


http://git-wip-us.apache.org/repos/asf/activemq-6/blob/ff9052b8/activemq-commons/src/main/java/org/apache/activemq/utils/ActiveMQThreadFactory.java
--
diff --git 
a/activemq-commons/src/main/java/org/apache/activemq/utils/ActiveMQThreadFactory.java
 
b/activemq-commons/src/main/java/org/apache/activemq/utils/ActiveMQThreadFactory.java
index 5c76120..b857825 100644
--- 
a/activemq-commons/src/main/java/org/apache/activemq/utils/ActiveMQThreadFactory.java
+++ 
b/activemq-commons/src/main/java/org/apache/activemq/utils/ActiveMQThreadFactory.java
@@ -16,6 +16,7 @@
  */
 package org.apache.activemq.utils;
 
+import java.security.AccessControlContext;
 import java.security.AccessController;
 import java.security.PrivilegedAction;
 import java.util.concurrent.ThreadFactory;
@@ -40,6 +41,8 @@ public final class ActiveMQThreadFactory implements 
ThreadFactory
 
private final ClassLoader tccl;
 
+   private final AccessControlContext acc;
+
public ActiveMQThreadFactory(final String groupName, final boolean daemon, 
final ClassLoader tccl)
{
   group = new ThreadGroup(groupName + - + System.identityHashCode(this));
@@ -49,24 +52,46 @@ public final class ActiveMQThreadFactory implements 
ThreadFactory
   this.tccl = tccl;
 
   this.daemon = daemon;
+
+  this.acc = (System.getSecurityManager() == null) ? null : 
AccessController.getContext();
}
 
public Thread newThread(final Runnable command)
{
-  // always create a thread in a privileged block.
-  return AccessController.doPrivileged(new PrivilegedActionThread()
+  // create a thread in a privileged block if running with Security Manager
+  if (acc != null  System.getSecurityManager() != null)
+  {
+ return AccessController.doPrivileged(new ThreadCreateAction(command), 
acc);
+  }
+  else
+  {
+ return createThread(command);
+  }
+   }
+
+   private final class ThreadCreateAction implements PrivilegedActionThread
+   {
+  private final Runnable target;
+
+  private ThreadCreateAction(final Runnable target)
+  {
+ this.target = target;
+  }
+
+  public Thread run()
   {
- @Override
- public Thread run()
- {
-final Thread t = new Thread(group, command, Thread- + 
threadCount.getAndIncrement() +  ( + group.getName() + ));
-t.setDaemon(daemon);
-t.setPriority(threadPriority);
-t.setContextClassLoader(tccl);
-
-return t;
- }
-  });
+ return createThread(target);
+  }
+   }
+
+   private Thread createThread(final Runnable command)
+   {
+  final Thread t = new Thread(group, command, Thread- + 
threadCount.getAndIncrement() +  ( + group.getName() + ));
+  t.setDaemon(daemon);
+  t.setPriority(threadPriority);
+  t.setContextClassLoader(tccl);
+
+  return t;
}
 
 }



[2/2] activemq-6 git commit: Merge #33 on porting HornetQ fix, based on https://issues.apache.org/jira/browse/ACTIVEMQ6-53

2014-12-05 Thread clebertsuconic
Merge #33 on porting HornetQ fix, based on 
https://issues.apache.org/jira/browse/ACTIVEMQ6-53


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

Branch: refs/heads/master
Commit: e419feb882b34cc3ae88950f9ba002ec1971344d
Parents: 28ca327 ff9052b
Author: Clebert Suconic clebertsuco...@apache.org
Authored: Fri Dec 5 10:25:15 2014 -0500
Committer: Clebert Suconic clebertsuco...@apache.org
Committed: Fri Dec 5 10:25:15 2014 -0500

--
 .../activemq/utils/ActiveMQThreadFactory.java   | 51 +++-
 1 file changed, 38 insertions(+), 13 deletions(-)
--




[06/13] activemq-6 git commit: ACTIVEMQ6-14 Replace JNDI server with client impl

2014-12-05 Thread clebertsuconic
http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/divert/src/main/java/org/apache/activemq/jms/example/DivertExample.java
--
diff --git 
a/examples/jms/divert/src/main/java/org/apache/activemq/jms/example/DivertExample.java
 
b/examples/jms/divert/src/main/java/org/apache/activemq/jms/example/DivertExample.java
index daa8507..94d69ef 100644
--- 
a/examples/jms/divert/src/main/java/org/apache/activemq/jms/example/DivertExample.java
+++ 
b/examples/jms/divert/src/main/java/org/apache/activemq/jms/example/DivertExample.java
@@ -60,14 +60,14 @@ public class DivertExample extends ActiveMQExample
  initialContextLondon = getContext(0);
 
  // Step 2. Look-up the queue orderQueue on the London server - this 
is the queue any orders are sent to
- Queue orderQueue = 
(Queue)initialContextLondon.lookup(/queue/orders);
+ Queue orderQueue = (Queue)initialContextLondon.lookup(queue/orders);
 
  // Step 3. Look-up the topic priceUpdates on the London server- this 
is the topic that any price updates are
  // sent to
- Topic priceUpdates = 
(Topic)initialContextLondon.lookup(/topic/priceUpdates);
+ Topic priceUpdates = 
(Topic)initialContextLondon.lookup(topic/priceUpdates);
 
  // Step 4. Look-up the spy topic on the London server- this is what 
we will use to snoop on any orders
- Topic spyTopic = 
(Topic)initialContextLondon.lookup(/topic/spyTopic);
+ Topic spyTopic = (Topic)initialContextLondon.lookup(topic/spyTopic);
 
  // Step 6. Create an initial context to perform the JNDI lookup on 
the New York server
  initialContextNewYork = getContext(1);
@@ -79,13 +79,13 @@ public class DivertExample extends ActiveMQExample
  // them to the address newYorkPriceUpdates on the New York server 
where they will be distributed to the topic
  // subscribers on
  // the New York server
- Topic newYorkPriceUpdates = 
(Topic)initialContextNewYork.lookup(/topic/newYorkPriceUpdates);
+ Topic newYorkPriceUpdates = 
(Topic)initialContextNewYork.lookup(topic/newYorkPriceUpdates);
 
  // Step 8. Perform a lookup on the Connection Factory on the London 
server
- ConnectionFactory cfLondon = 
(ConnectionFactory)initialContextLondon.lookup(/ConnectionFactory);
+ ConnectionFactory cfLondon = 
(ConnectionFactory)initialContextLondon.lookup(ConnectionFactory);
 
  // Step 9. Perform a lookup on the Connection Factory on the New York 
server
- ConnectionFactory cfNewYork = 
(ConnectionFactory)initialContextNewYork.lookup(/ConnectionFactory);
+ ConnectionFactory cfNewYork = 
(ConnectionFactory)initialContextNewYork.lookup(ConnectionFactory);
 
  // Step 10. Create a JMS Connection on the London server
  connectionLondon = cfLondon.createConnection();

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/divert/src/main/resources/hornetq/server0/activemq-jms.xml
--
diff --git 
a/examples/jms/divert/src/main/resources/hornetq/server0/activemq-jms.xml 
b/examples/jms/divert/src/main/resources/hornetq/server0/activemq-jms.xml
index 8d78604..d82f40c 100644
--- a/examples/jms/divert/src/main/resources/hornetq/server0/activemq-jms.xml
+++ b/examples/jms/divert/src/main/resources/hornetq/server0/activemq-jms.xml
@@ -1,38 +1,18 @@
 configuration xmlns=urn:activemq
 xmlns:xsi=http://www.w3.org/2001/XMLSchema-instance;
 xsi:schemaLocation=urn:activemq /schema/activemq-jms.xsd
-
-   !-- the connection factory used by the example --
-   
-   connection-factory name=ConnectionFactory
-  connectors
- connector-ref connector-name=netty-connector/
-  /connectors
-  entries
- entry name=ConnectionFactory/
-  /entries
-   /connection-factory
-
!-- Destinations used by the example --

!-- The order queue --
-   queue name=orders
-  entry name=/queue/orders/
-   /queue
+   queue name=orders/

!-- The queue that prices are forwarded to before being bridged to the New 
York server --
-   queue name=priceForwarding
-  entry name=/queue/priceForwarding/
-   /queue
+   queue name=priceForwarding/

!-- The topic for price updates --
-   topic name=priceUpdates
-  entry name=/topic/priceUpdates/
-   /topic
+   topic name=priceUpdates/

!-- The spy topic for snooping on orders --
-   topic name=spyTopic
-  entry name=/topic/spyTopic/
-   /topic
+   topic name=spyTopic/
 
 /configuration
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/divert/src/main/resources/hornetq/server1/activemq-jms.xml
--
diff --git 

[12/13] activemq-6 git commit: Handful of test fixes

2014-12-05 Thread clebertsuconic
Handful of test fixes


Project: http://git-wip-us.apache.org/repos/asf/activemq-6/repo
Commit: http://git-wip-us.apache.org/repos/asf/activemq-6/commit/7cfd76d3
Tree: http://git-wip-us.apache.org/repos/asf/activemq-6/tree/7cfd76d3
Diff: http://git-wip-us.apache.org/repos/asf/activemq-6/diff/7cfd76d3

Branch: refs/heads/master
Commit: 7cfd76d321fe4b9fb9bbb4030bae7dd8b4072c3d
Parents: e6a3d3a
Author: jbertram jbert...@redhat.com
Authored: Mon Nov 24 16:49:39 2014 -0600
Committer: jbertram jbert...@redhat.com
Committed: Fri Dec 5 09:27:53 2014 -0600

--
 .../org/apache/activemq/tests/integration/client/PagingTest.java | 2 +-
 .../integration/jms/server/management/JMSServerControl2Test.java | 4 ++--
 .../activemq/tests/integration/ra/ResourceAdapterTest.java   | 2 +-
 .../apache/activemq/tests/integration/stomp/ExtraStompTest.java  | 2 +-
 4 files changed, 5 insertions(+), 5 deletions(-)
--


http://git-wip-us.apache.org/repos/asf/activemq-6/blob/7cfd76d3/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/client/PagingTest.java
--
diff --git 
a/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/client/PagingTest.java
 
b/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/client/PagingTest.java
index 01bb091..56369c8 100644
--- 
a/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/client/PagingTest.java
+++ 
b/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/client/PagingTest.java
@@ -5239,7 +5239,7 @@ public class PagingTest extends ServiceTestBase
  // allow time for the logging to actually happen on the server
  Thread.sleep(100);
 
- Assert.assertTrue(Expected to find HQ224016, 
AssertionLoggerHandler.findText(HQ224016));
+ Assert.assertTrue(Expected to find AMQ224016, 
AssertionLoggerHandler.findText(AMQ224016));
 
  ClientConsumer consumer = session.createConsumer(ADDRESS);
 

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/7cfd76d3/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/jms/server/management/JMSServerControl2Test.java
--
diff --git 
a/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/jms/server/management/JMSServerControl2Test.java
 
b/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/jms/server/management/JMSServerControl2Test.java
index fb5d3f5..4ca8615 100644
--- 
a/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/jms/server/management/JMSServerControl2Test.java
+++ 
b/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/jms/server/management/JMSServerControl2Test.java
@@ -543,7 +543,7 @@ public class JMSServerControl2Test extends 
ManagementTestBase
 
  spec.setPassword(password);
 
- spec.setDestinationType(Queue);
+ spec.setDestinationType(javax.jms.Queue);
  spec.setDestination(test);
 
  spec.setMinSession(1);
@@ -632,7 +632,7 @@ public class JMSServerControl2Test extends 
ManagementTestBase
  spec.setUser(user);
  spec.setPassword(password);
 
- spec.setDestinationType(Queue);
+ spec.setDestinationType(javax.jms.Queue);
  spec.setDestination(test);
 
  spec.setMinSession(1);

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/7cfd76d3/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/ra/ResourceAdapterTest.java
--
diff --git 
a/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/ra/ResourceAdapterTest.java
 
b/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/ra/ResourceAdapterTest.java
index 6e0ef08..9387ab5 100644
--- 
a/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/ra/ResourceAdapterTest.java
+++ 
b/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/ra/ResourceAdapterTest.java
@@ -86,7 +86,7 @@ public class ResourceAdapterTest extends ActiveMQRATestBase
   spec.setUser(user);
   spec.setPassword(password);
 
-  spec.setDestinationType(Topic);
+  spec.setDestinationType(javax.jms.Topic);
   spec.setDestination(test);
 
   spec.setMinSession(1);

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/7cfd76d3/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/stomp/ExtraStompTest.java
--
diff --git 
a/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/stomp/ExtraStompTest.java
 

[11/13] activemq-6 git commit: ACTIVEMQ6-14 Replace JNDI server with client impl

2014-12-05 Thread clebertsuconic
ACTIVEMQ6-14 Replace JNDI server with client impl


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

Branch: refs/heads/master
Commit: e6a3d3a0c5962b7c83b2fa3693bc12cb3e5ed02e
Parents: e419feb
Author: jbertram jbert...@redhat.com
Authored: Wed Dec 3 08:50:16 2014 -0600
Committer: jbertram jbert...@redhat.com
Committed: Fri Dec 5 09:27:52 2014 -0600

--
 .gitignore  |   5 -
 .../org/apache/activemq/cli/commands/Run.java   |  16 -
 .../java/org/apache/activemq/dto/BrokerDTO.java |   3 -
 .../java/org/apache/activemq/dto/NamingDTO.java |  39 -
 .../org/apache/activemq/dto/jaxb.index  |   1 -
 .../jndi/ActiveMQInitialContextFactory.java | 496 +
 .../apache/activemq/jndi/LazyCreateContext.java |  43 ++
 .../apache/activemq/jndi/NameParserImpl.java|  30 +
 .../apache/activemq/jndi/ReadOnlyContext.java   | 534 ++
 activemq-jms-server/pom.xml |   4 -
 .../jms/server/JMSServerConfigParser.java   |   9 -
 .../jms/server/embedded/EmbeddedJMS.java|   6 +
 .../server/impl/JMSServerConfigParserImpl.java  | 339 +
 .../jms/server/impl/JMSServerDeployer.java  |  48 +-
 .../jms/server/impl/JMSServerManagerImpl.java   |  14 +-
 .../jms/server/impl/StandaloneNamingServer.java | 170 -
 .../src/main/resources/schema/activemq-jms.xsd  | 272 +--
 activemq-ra/pom.xml |   7 +
 .../integration/EmbeddedRestActiveMQJMS.java|   4 +
 .../rest/queue/QueueDestinationsResource.java   |   7 -
 .../rest/topic/TopicDestinationsResource.java   |   7 -
 .../apache/activemq/rest/test/EmbeddedTest.java |  14 +-
 .../src/test/resources/activemq-jms.xml |  13 +-
 distribution/activemq/pom.xml   |   5 -
 distribution/activemq/src/main/assembly/dep.xml |   1 -
 .../activemq/src/main/resources/bin/activemq|   4 +-
 .../src/main/resources/bin/activemq.cmd |   2 +-
 .../resources/config/clustered/activemq-jms.xml |  48 +-
 .../resources/config/clustered/jndi.properties  |   2 -
 .../config/non-clustered/activemq-jms.xml   |  48 +-
 .../config/non-clustered/jndi.properties|   2 -
 .../replicated/activemq-configuration.xml   |   2 +-
 .../config/replicated/activemq-jms.xml  |  48 +-
 .../resources/config/replicated/jndi.properties |   2 -
 .../shared-store/activemq-configuration.xml |   2 +-
 .../config/shared-store/activemq-jms.xml|  48 +-
 .../config/shared-store/jndi.properties |   2 -
 distribution/jnp-client/pom.xml |  75 --
 distribution/pom.xml|   5 -
 docs/user-manual/en/appserver-integration.xml   |  53 +-
 docs/user-manual/en/client-classpath.xml|   7 -
 docs/user-manual/en/client-reconnection.xml |  25 +-
 docs/user-manual/en/clusters.xml|  65 +-
 docs/user-manual/en/configuration-index.xml | 330 +
 docs/user-manual/en/configuring-transports.xml  |  29 +-
 docs/user-manual/en/flow-control.xml|  79 +-
 docs/user-manual/en/interoperability.xml|   5 +-
 docs/user-manual/en/large-messages.xml  |  41 +-
 docs/user-manual/en/logging.xml |  18 +-
 docs/user-manual/en/message-grouping.xml|  37 +-
 docs/user-manual/en/pre-acknowledge.xml |  16 +-
 docs/user-manual/en/spring-integration.xml  |  13 +-
 docs/user-manual/en/thread-pooling.xml  |  22 +-
 docs/user-manual/en/using-jms.xml   | 388 +-
 examples/core/embedded-remote/pom.xml   |   5 -
 examples/core/embedded/pom.xml  |   5 -
 examples/core/perf/pom.xml  |  10 -
 examples/core/vertx-connector/pom.xml   |  10 -
 .../src/main/resources/server0/activemq-jms.xml |  13 +-
 .../config/server.properties|   2 +-
 .../common/example/ActiveMQExample.java |   5 +-
 examples/jms/aerogear/pom.xml   |   7 +-
 .../activemq/jms/example/AerogearExample.java   |   4 +-
 .../resources/hornetq/server0/activemq-jms.xml  |  13 +-
 examples/jms/applet/pom.xml |   7 +-
 .../resources/hornetq/server0/activemq-jms.xml  |  13 +-
 examples/jms/application-layer-failover/pom.xml |   9 +-
 .../ApplicationLayerFailoverExample.java|   4 +-
 .../resources/hornetq/server0/activemq-jms.xml  |  13 +-
 .../resources/hornetq/server1/activemq-jms.xml  |  13 +-
 examples/jms/bridge/pom.xml |   9 +-
 .../activemq/jms/example/BridgeExample.java |   8 +-
 .../resources/hornetq/server0/activemq-jms.xml  |  13 +-
 .../resources/hornetq/server1/activemq-jms.xml  |  13 +-
 

[02/13] activemq-6 git commit: ACTIVEMQ6-14 Replace JNDI server with client impl

2014-12-05 Thread clebertsuconic
http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/jms/SimpleJNDIClientTest.java
--
diff --git 
a/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/jms/SimpleJNDIClientTest.java
 
b/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/jms/SimpleJNDIClientTest.java
new file mode 100644
index 000..680d429
--- /dev/null
+++ 
b/tests/integration-tests/src/test/java/org/apache/activemq/tests/integration/jms/SimpleJNDIClientTest.java
@@ -0,0 +1,722 @@
+/**
+ * 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.activemq.tests.integration.jms;
+
+import javax.jms.ConnectionFactory;
+import javax.jms.Destination;
+import javax.jms.JMSException;
+import javax.jms.Queue;
+import javax.jms.Topic;
+import javax.naming.Context;
+import javax.naming.InitialContext;
+import javax.naming.NamingException;
+import java.util.ArrayList;
+import java.util.HashMap;
+import java.util.Hashtable;
+import java.util.List;
+import java.util.Map;
+
+import org.apache.activemq.api.config.ActiveMQDefaultConfiguration;
+import org.apache.activemq.api.core.BroadcastGroupConfiguration;
+import org.apache.activemq.api.core.DiscoveryGroupConfiguration;
+import org.apache.activemq.api.core.TransportConfiguration;
+import org.apache.activemq.api.core.UDPBroadcastGroupConfiguration;
+import org.apache.activemq.api.jms.JMSFactoryType;
+import org.apache.activemq.core.config.Configuration;
+import org.apache.activemq.core.config.ha.SharedStoreMasterPolicyConfiguration;
+import org.apache.activemq.core.remoting.impl.netty.TransportConstants;
+import org.apache.activemq.core.server.ActiveMQServer;
+import org.apache.activemq.core.server.ActiveMQServers;
+import org.apache.activemq.jms.client.ActiveMQConnectionFactory;
+import org.apache.activemq.jndi.ActiveMQInitialContextFactory;
+import org.apache.activemq.tests.util.RandomUtil;
+import org.apache.activemq.tests.util.UnitTestCase;
+import org.junit.Assert;
+import org.junit.Before;
+import org.junit.Test;
+
+/**
+ *
+ * A ActiveMQConnectionFactoryTest
+ *
+ * @author a href=mailto:tim@jboss.com;Tim Fox/a
+ *
+ *
+ */
+public class SimpleJNDIClientTest extends UnitTestCase
+{
+   private final String groupAddress = getUDPDiscoveryAddress();
+
+   private final int groupPort = getUDPDiscoveryPort();
+
+   private ActiveMQServer liveService;
+
+   private TransportConfiguration liveTC;
+
+   @Test
+   public void testDefaultConnectionFactories() throws NamingException, 
JMSException
+   {
+  HashtableString, Object props = new Hashtable();
+  props.put(Context.INITIAL_CONTEXT_FACTORY, 
org.apache.activemq.jndi.ActiveMQInitialContextFactory);
+  Context ctx = new InitialContext(props);
+
+  ConnectionFactory connectionFactory = (ConnectionFactory) 
ctx.lookup(ConnectionFactory);
+  Assert.assertEquals(JMSFactoryType.CF.intValue(), 
((ActiveMQConnectionFactory)connectionFactory).getFactoryType());
+  connectionFactory.createConnection().close();
+
+  connectionFactory = (ConnectionFactory) 
ctx.lookup(XAConnectionFactory);
+  Assert.assertEquals(JMSFactoryType.XA_CF.intValue(), 
((ActiveMQConnectionFactory)connectionFactory).getFactoryType());
+  connectionFactory.createConnection().close();
+
+  connectionFactory = (ConnectionFactory) 
ctx.lookup(TopicConnectionFactory);
+  Assert.assertEquals(JMSFactoryType.TOPIC_CF.intValue(), 
((ActiveMQConnectionFactory)connectionFactory).getFactoryType());
+  connectionFactory.createConnection().close();
+
+  connectionFactory = (ConnectionFactory) 
ctx.lookup(QueueConnectionFactory);
+  Assert.assertEquals(JMSFactoryType.QUEUE_CF.intValue(), 
((ActiveMQConnectionFactory)connectionFactory).getFactoryType());
+  connectionFactory.createConnection().close();
+   }
+
+   @Test
+   public void testCustomCF() throws NamingException, JMSException
+   {
+  Hashtable props = new Hashtable();
+  props.put(Context.INITIAL_CONTEXT_FACTORY, 
org.apache.activemq.jndi.ActiveMQInitialContextFactory);
+  

[04/13] activemq-6 git commit: ACTIVEMQ6-14 Replace JNDI server with client impl

2014-12-05 Thread clebertsuconic
http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/reattach-node/src/main/resources/hornetq/server0/activemq-jms.xml
--
diff --git 
a/examples/jms/reattach-node/src/main/resources/hornetq/server0/activemq-jms.xml
 
b/examples/jms/reattach-node/src/main/resources/hornetq/server0/activemq-jms.xml
index c24e03b..847659f 100644
--- 
a/examples/jms/reattach-node/src/main/resources/hornetq/server0/activemq-jms.xml
+++ 
b/examples/jms/reattach-node/src/main/resources/hornetq/server0/activemq-jms.xml
@@ -1,51 +1,8 @@
 configuration xmlns=urn:activemq
 xmlns:xsi=http://www.w3.org/2001/XMLSchema-instance;
 xsi:schemaLocation=urn:activemq /schema/activemq-jms.xsd
-
-   !--the connection factories used by the example--
-   
-   connection-factory name=ConnectionFactory
-  connectors
- connector-ref connector-name=netty-connector/
-  /connectors
-  entries
- entry name=ConnectionFactory/
-  /entries
-   
-  !-- Pause 1 second between connect attempts --
-  retry-interval1000/retry-interval
-  
-  !-- Multiply subsequent reconnect pauses by this multiplier. This can 
be used to 
-  implement an exponential back-off. For our purposes we just set to 1.0 
so each reconnect
-  pause is the same length --
-  retry-interval-multiplier1.0/retry-interval-multiplier
-  
-  !-- Try reconnecting an unlimited number of times (-1 means 
unlimited) --
-  reconnect-attempts-1/reconnect-attempts
-  
-  !-- When the server is cleanly shutdown we don't want to give up, we 
want to continue
-  to try to reconnect --
-  failover-on-server-shutdowntrue/failover-on-server-shutdown
-  
-  !-- We need to specify a confirmation-window-size to enable 
re-attachment, default is -1 which
-  means no re-attachment --
-  confirmation-window-size1048576/confirmation-window-size
-  
-   /connection-factory
-   
-   !-- This is used by the example to send the management operations, it's 
not central to the example --
-   connection-factory name=ConnectionFactory2
-  connectors
- connector-ref connector-name=netty-connector2/
-  /connectors
-  entries
- entry name=ConnectionFactory2/ 
-  /entries
-   /connection-factory
 
!--the queue used by the example--
-   queue name=exampleQueue
-  entry name=/queue/exampleQueue/
-   /queue
+   queue name=exampleQueue/
 
 /configuration
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/replicated-failback-static/pom.xml
--
diff --git a/examples/jms/replicated-failback-static/pom.xml 
b/examples/jms/replicated-failback-static/pom.xml
index 6617de1..631b40f 100644
--- a/examples/jms/replicated-failback-static/pom.xml
+++ b/examples/jms/replicated-failback-static/pom.xml
@@ -79,8 +79,8 @@
   configuration
  
clientClassorg.apache.activemq.jms.example.ReplicatedFailbackStaticExample/clientClass
  args
-paramjnp://localhost:1099/param
-paramjnp://localhost:1199/param
+paramtcp://localhost:5445/param
+paramtcp://localhost:5446/param
  /args
  systemProperties
 property
@@ -145,11 +145,6 @@
   artifactIdjboss-jms-api/artifactId
   version1.1.0.GA/version
/dependency
-   dependency
-  groupIdorg.jboss.naming/groupId
-  artifactIdjnpserver/artifactId
-  version5.0.3.GA/version
-   /dependency
 /dependencies
 configuration
waitOnStartfalse/waitOnStart

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/replicated-failback-static/src/main/java/org/apache/activemq/jms/example/ReplicatedFailbackStaticExample.java
--
diff --git 
a/examples/jms/replicated-failback-static/src/main/java/org/apache/activemq/jms/example/ReplicatedFailbackStaticExample.java
 
b/examples/jms/replicated-failback-static/src/main/java/org/apache/activemq/jms/example/ReplicatedFailbackStaticExample.java
index d9220b9..73edb7e 100644
--- 
a/examples/jms/replicated-failback-static/src/main/java/org/apache/activemq/jms/example/ReplicatedFailbackStaticExample.java
+++ 
b/examples/jms/replicated-failback-static/src/main/java/org/apache/activemq/jms/example/ReplicatedFailbackStaticExample.java
@@ -58,8 +58,8 @@ public class ReplicatedFailbackStaticExample extends 
ActiveMQExample
  initialContext = getContext(0);
 
  // Step 2. Look up the JMS resources from 

[07/13] activemq-6 git commit: ACTIVEMQ6-14 Replace JNDI server with client impl

2014-12-05 Thread clebertsuconic
http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/clustered-grouping/src/main/resources/hornetq/server1/activemq-jms.xml
--
diff --git 
a/examples/jms/clustered-grouping/src/main/resources/hornetq/server1/activemq-jms.xml
 
b/examples/jms/clustered-grouping/src/main/resources/hornetq/server1/activemq-jms.xml
index 452b958..847659f 100644
--- 
a/examples/jms/clustered-grouping/src/main/resources/hornetq/server1/activemq-jms.xml
+++ 
b/examples/jms/clustered-grouping/src/main/resources/hornetq/server1/activemq-jms.xml
@@ -1,19 +1,8 @@
 configuration xmlns=urn:activemq
 xmlns:xsi=http://www.w3.org/2001/XMLSchema-instance;
 xsi:schemaLocation=urn:activemq /schema/activemq-jms.xsd
-   !--the connection factory used by the example--
-   connection-factory name=ConnectionFactory
-  connectors
- connector-ref connector-name=netty-connector/
-  /connectors
-  entries
- entry name=ConnectionFactory/
-  /entries
-   /connection-factory
 
!--the queue used by the example--
-   queue name=exampleQueue
-  entry name=/queue/exampleQueue/
-   /queue
+   queue name=exampleQueue/
 
 /configuration
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/clustered-grouping/src/main/resources/hornetq/server2/activemq-jms.xml
--
diff --git 
a/examples/jms/clustered-grouping/src/main/resources/hornetq/server2/activemq-jms.xml
 
b/examples/jms/clustered-grouping/src/main/resources/hornetq/server2/activemq-jms.xml
index 452b958..847659f 100644
--- 
a/examples/jms/clustered-grouping/src/main/resources/hornetq/server2/activemq-jms.xml
+++ 
b/examples/jms/clustered-grouping/src/main/resources/hornetq/server2/activemq-jms.xml
@@ -1,19 +1,8 @@
 configuration xmlns=urn:activemq
 xmlns:xsi=http://www.w3.org/2001/XMLSchema-instance;
 xsi:schemaLocation=urn:activemq /schema/activemq-jms.xsd
-   !--the connection factory used by the example--
-   connection-factory name=ConnectionFactory
-  connectors
- connector-ref connector-name=netty-connector/
-  /connectors
-  entries
- entry name=ConnectionFactory/
-  /entries
-   /connection-factory
 
!--the queue used by the example--
-   queue name=exampleQueue
-  entry name=/queue/exampleQueue/
-   /queue
+   queue name=exampleQueue/
 
 /configuration
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/clustered-jgroups/pom.xml
--
diff --git a/examples/jms/clustered-jgroups/pom.xml 
b/examples/jms/clustered-jgroups/pom.xml
index 1cdaf59..aca8a25 100644
--- a/examples/jms/clustered-jgroups/pom.xml
+++ b/examples/jms/clustered-jgroups/pom.xml
@@ -75,8 +75,8 @@
   configuration
  
clientClassorg.apache.activemq.jms.example.ClusteredJgroupsExample/clientClass
  args
-paramjnp://localhost:1099/param
-paramjnp://localhost:1199/param
+paramtcp://localhost:5445/param
+paramtcp://localhost:5446/param
  /args
   /configuration
/execution
@@ -135,11 +135,6 @@
   artifactIdjboss-jms-api/artifactId
   version1.1.0.GA/version
/dependency
-   dependency
-  groupIdorg.jboss.naming/groupId
-  artifactIdjnpserver/artifactId
-  version5.0.3.GA/version
-   /dependency
 /dependencies
 configuration
waitOnStartfalse/waitOnStart

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/clustered-jgroups/src/main/java/org/apache/activemq/jms/example/ClusteredJgroupsExample.java
--
diff --git 
a/examples/jms/clustered-jgroups/src/main/java/org/apache/activemq/jms/example/ClusteredJgroupsExample.java
 
b/examples/jms/clustered-jgroups/src/main/java/org/apache/activemq/jms/example/ClusteredJgroupsExample.java
index d838a5e..24ae554 100644
--- 
a/examples/jms/clustered-jgroups/src/main/java/org/apache/activemq/jms/example/ClusteredJgroupsExample.java
+++ 
b/examples/jms/clustered-jgroups/src/main/java/org/apache/activemq/jms/example/ClusteredJgroupsExample.java
@@ -57,16 +57,16 @@ public class ClusteredJgroupsExample extends ActiveMQExample
  ic0 = getContext(0);
 
  // Step 2. Look-up the JMS Queue object from JNDI
- Queue queue = (Queue)ic0.lookup(/queue/exampleQueue);
+ Queue queue = (Queue)ic0.lookup(queue/exampleQueue);
 
  // Step 3. Look-up a JMS Connection Factory object from 

[09/13] activemq-6 git commit: ACTIVEMQ6-14 Replace JNDI server with client impl

2014-12-05 Thread clebertsuconic
http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/docs/user-manual/en/appserver-integration.xml
--
diff --git a/docs/user-manual/en/appserver-integration.xml 
b/docs/user-manual/en/appserver-integration.xml
index a22d95e..897de10 100644
--- a/docs/user-manual/en/appserver-integration.xml
+++ b/docs/user-manual/en/appserver-integration.xml
@@ -494,38 +494,35 @@ public class MyMDB implements MessageListener
 /row
 row
 entry
-   link 
linkend=configuration.connection-factory.discovery-initial-wait-timeout
-  DiscoveryInitialWaitTimeout
-   /link
+   DiscoveryInitialWaitTimeout
 /entry
 entryLong/entry
 entryThe initial time to wait for 
discovery./entry
 /row
 row
 entry
-   link 
linkend=configuration.connection-factory.connection-load-balancing-policy-class-name
-  ConnectionLoadBalancingPolicyClassName/link
+   ConnectionLoadBalancingPolicyClassName
 /entry
 entryString/entry
 entryThe load balancing policy class to 
use./entry
 /row
 row
 entry
-   link 
linkend=configuration.connection-factory.connection-ttlConnectionTTL/link
+   ConnectionTTL
 /entry
 entryLong/entry
 entryThe time to live (in milliseconds) for the 
connection./entry
 /row
 row
 entry
-   link 
linkend=configuration.connection-factory.call-timeoutCallTimeout/link
+   CallTimeout
 /entry
 entryLong/entry
 entrythe call timeout (in milliseconds) for each 
packet sent./entry
 /row
 row
 entry
-   link 
linkend=configuration.connection-factory.dups-ok-batch-sizeDupsOKBatchSize/link
+   DupsOKBatchSize
 /entry
 entryInteger/entry
 entrythe batch size (in bytes) between 
acknowledgements when using
@@ -533,7 +530,7 @@ public class MyMDB implements MessageListener
 /row
 row
 entry
-   link 
linkend=configuration.connection-factory.transaction-batch-sizeTransactionBatchSize/link
+   TransactionBatchSize
 /entry
 entryInteger/entry
 entrythe batch size (in bytes) between 
acknowledgements when using a
@@ -541,70 +538,70 @@ public class MyMDB implements MessageListener
 /row
 row
 entry
-   link 
linkend=configuration.connection-factory.consumer-window-sizeConsumerWindowSize/link
+   ConsumerWindowSize
 /entry
 entryInteger/entry
 entrythe window size (in bytes) for consumer 
flow control/entry
 /row
 row
 entry
-   link 
linkend=configuration.connection-factory.consumer-max-rateConsumerMaxRate/link
+   ConsumerMaxRate
 /entry
 entryInteger/entry
 entrythe fastest rate a consumer may consume 
messages per second/entry
 /row
 row
 entry
-   link 
linkend=configuration.connection-factory.confirmation-window-sizeConfirmationWindowSize/link
+   ConfirmationWindowSize
 /entry
 entryInteger/entry
 entrythe window size (in bytes) for reattachment 
confirmations/entry
 /row
 row
 entry
-   link 
linkend=configuration.connection-factory.producer-max-rateProducerMaxRate/link

[05/13] activemq-6 git commit: ACTIVEMQ6-14 Replace JNDI server with client impl

2014-12-05 Thread clebertsuconic
http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/management/src/main/resources/hornetq/server0/activemq-jms.xml
--
diff --git 
a/examples/jms/management/src/main/resources/hornetq/server0/activemq-jms.xml 
b/examples/jms/management/src/main/resources/hornetq/server0/activemq-jms.xml
index 0a8701d..0d5c953 100644
--- 
a/examples/jms/management/src/main/resources/hornetq/server0/activemq-jms.xml
+++ 
b/examples/jms/management/src/main/resources/hornetq/server0/activemq-jms.xml
@@ -1,18 +1,8 @@
 configuration xmlns=urn:activemq
 xmlns:xsi=http://www.w3.org/2001/XMLSchema-instance;
 xsi:schemaLocation=urn:activemq /schema/activemq-jms.xsd
-   !--the connection factory used by the example--
-   connection-factory name=ConnectionFactory signature=queue
-  connectors
- connector-ref connector-name=netty/
-  /connectors
-  entries
- entry name=ConnectionFactory/
-  /entries
-   /connection-factory
 
!--the queue used by the example--
-   queue name=exampleQueue
-  entry name=/queue/exampleQueue/
-   /queue
+   queue name=exampleQueue/
+
 /configuration

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/message-counters/pom.xml
--
diff --git a/examples/jms/message-counters/pom.xml 
b/examples/jms/message-counters/pom.xml
index 84de40b..2bca2d4 100644
--- a/examples/jms/message-counters/pom.xml
+++ b/examples/jms/message-counters/pom.xml
@@ -75,7 +75,7 @@
   configuration
  
clientClassorg.apache.activemq.jms.example.MessageCounterExample/clientClass
  args
-paramjnp://localhost:1099/param
+paramtcp://localhost:5445/param
  /args
   /configuration
/execution
@@ -122,11 +122,6 @@
   artifactIdjboss-jms-api/artifactId
   version1.1.0.GA/version
/dependency
-   dependency
-  groupIdorg.jboss.naming/groupId
-  artifactIdjnpserver/artifactId
-  version5.0.3.GA/version
-   /dependency
 /dependencies
 configuration
waitOnStartfalse/waitOnStart

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/message-counters/src/main/java/org/apache/activemq/jms/example/MessageCounterExample.java
--
diff --git 
a/examples/jms/message-counters/src/main/java/org/apache/activemq/jms/example/MessageCounterExample.java
 
b/examples/jms/message-counters/src/main/java/org/apache/activemq/jms/example/MessageCounterExample.java
index b3747e8..a1b697a 100644
--- 
a/examples/jms/message-counters/src/main/java/org/apache/activemq/jms/example/MessageCounterExample.java
+++ 
b/examples/jms/message-counters/src/main/java/org/apache/activemq/jms/example/MessageCounterExample.java
@@ -65,10 +65,10 @@ public class MessageCounterExample extends ActiveMQExample
  initialContext = getContext(0);
 
  // Step 2. Perfom a lookup on the queue
- Queue queue = (Queue)initialContext.lookup(/queue/exampleQueue);
+ Queue queue = (Queue)initialContext.lookup(queue/exampleQueue);
 
  // Step 3. Perform a lookup on the Connection Factory
- QueueConnectionFactory cf = 
(QueueConnectionFactory)initialContext.lookup(/ConnectionFactory);
+ QueueConnectionFactory cf = 
(QueueConnectionFactory)initialContext.lookup(ConnectionFactory);
 
  // Step 4.Create a JMS Connection, session and a producer for the 
queue
  connection = cf.createQueueConnection();

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/message-counters/src/main/resources/hornetq/server0/activemq-jms.xml
--
diff --git 
a/examples/jms/message-counters/src/main/resources/hornetq/server0/activemq-jms.xml
 
b/examples/jms/message-counters/src/main/resources/hornetq/server0/activemq-jms.xml
index 5814b76..44be37f 100644
--- 
a/examples/jms/message-counters/src/main/resources/hornetq/server0/activemq-jms.xml
+++ 
b/examples/jms/message-counters/src/main/resources/hornetq/server0/activemq-jms.xml
@@ -1,24 +1,11 @@
 configuration xmlns=urn:activemq
 xmlns:xsi=http://www.w3.org/2001/XMLSchema-instance;
 xsi:schemaLocation=urn:activemq /schema/activemq-jms.xsd
-   !--the connection factory used by the example--
-   connection-factory name=ConnectionFactory signature=queue
-  connectors
- connector-ref connector-name=netty-connector/
-  /connectors
-  entries
- entry name=ConnectionFactory/
-  /entries
-   /connection-factory
 
!--the queue 

[13/13] activemq-6 git commit: Merge #34 on JNDI changes

2014-12-05 Thread clebertsuconic
Merge #34 on JNDI changes


Project: http://git-wip-us.apache.org/repos/asf/activemq-6/repo
Commit: http://git-wip-us.apache.org/repos/asf/activemq-6/commit/46182e41
Tree: http://git-wip-us.apache.org/repos/asf/activemq-6/tree/46182e41
Diff: http://git-wip-us.apache.org/repos/asf/activemq-6/diff/46182e41

Branch: refs/heads/master
Commit: 46182e4155dc2a4667359fb14996b9c63c3409bd
Parents: e419feb 7cfd76d
Author: Clebert Suconic clebertsuco...@apache.org
Authored: Fri Dec 5 10:37:50 2014 -0500
Committer: Clebert Suconic clebertsuco...@apache.org
Committed: Fri Dec 5 10:37:50 2014 -0500

--
 .gitignore  |   5 -
 .../org/apache/activemq/cli/commands/Run.java   |  16 -
 .../java/org/apache/activemq/dto/BrokerDTO.java |   3 -
 .../java/org/apache/activemq/dto/NamingDTO.java |  39 -
 .../org/apache/activemq/dto/jaxb.index  |   1 -
 .../jndi/ActiveMQInitialContextFactory.java | 496 +
 .../apache/activemq/jndi/LazyCreateContext.java |  43 ++
 .../apache/activemq/jndi/NameParserImpl.java|  30 +
 .../apache/activemq/jndi/ReadOnlyContext.java   | 534 ++
 activemq-jms-server/pom.xml |   4 -
 .../jms/server/JMSServerConfigParser.java   |   9 -
 .../jms/server/embedded/EmbeddedJMS.java|   6 +
 .../server/impl/JMSServerConfigParserImpl.java  | 339 +
 .../jms/server/impl/JMSServerDeployer.java  |  48 +-
 .../jms/server/impl/JMSServerManagerImpl.java   |  14 +-
 .../jms/server/impl/StandaloneNamingServer.java | 170 -
 .../src/main/resources/schema/activemq-jms.xsd  | 272 +--
 activemq-ra/pom.xml |   7 +
 .../integration/EmbeddedRestActiveMQJMS.java|   4 +
 .../rest/queue/QueueDestinationsResource.java   |   7 -
 .../rest/topic/TopicDestinationsResource.java   |   7 -
 .../apache/activemq/rest/test/EmbeddedTest.java |  14 +-
 .../src/test/resources/activemq-jms.xml |  13 +-
 distribution/activemq/pom.xml   |   5 -
 distribution/activemq/src/main/assembly/dep.xml |   1 -
 .../activemq/src/main/resources/bin/activemq|   4 +-
 .../src/main/resources/bin/activemq.cmd |   2 +-
 .../resources/config/clustered/activemq-jms.xml |  48 +-
 .../resources/config/clustered/jndi.properties  |   2 -
 .../config/non-clustered/activemq-jms.xml   |  48 +-
 .../config/non-clustered/jndi.properties|   2 -
 .../replicated/activemq-configuration.xml   |   2 +-
 .../config/replicated/activemq-jms.xml  |  48 +-
 .../resources/config/replicated/jndi.properties |   2 -
 .../shared-store/activemq-configuration.xml |   2 +-
 .../config/shared-store/activemq-jms.xml|  48 +-
 .../config/shared-store/jndi.properties |   2 -
 distribution/jnp-client/pom.xml |  75 --
 distribution/pom.xml|   5 -
 docs/user-manual/en/appserver-integration.xml   |  53 +-
 docs/user-manual/en/client-classpath.xml|   7 -
 docs/user-manual/en/client-reconnection.xml |  25 +-
 docs/user-manual/en/clusters.xml|  65 +-
 docs/user-manual/en/configuration-index.xml | 330 +
 docs/user-manual/en/configuring-transports.xml  |  29 +-
 docs/user-manual/en/flow-control.xml|  79 +-
 docs/user-manual/en/interoperability.xml|   5 +-
 docs/user-manual/en/large-messages.xml  |  41 +-
 docs/user-manual/en/logging.xml |  18 +-
 docs/user-manual/en/message-grouping.xml|  37 +-
 docs/user-manual/en/pre-acknowledge.xml |  16 +-
 docs/user-manual/en/spring-integration.xml  |  13 +-
 docs/user-manual/en/thread-pooling.xml  |  22 +-
 docs/user-manual/en/using-jms.xml   | 388 +-
 examples/core/embedded-remote/pom.xml   |   5 -
 examples/core/embedded/pom.xml  |   5 -
 examples/core/perf/pom.xml  |  10 -
 examples/core/vertx-connector/pom.xml   |  10 -
 .../src/main/resources/server0/activemq-jms.xml |  13 +-
 .../config/server.properties|   2 +-
 .../common/example/ActiveMQExample.java |   5 +-
 examples/jms/aerogear/pom.xml   |   7 +-
 .../activemq/jms/example/AerogearExample.java   |   4 +-
 .../resources/hornetq/server0/activemq-jms.xml  |  13 +-
 examples/jms/applet/pom.xml |   7 +-
 .../resources/hornetq/server0/activemq-jms.xml  |  13 +-
 examples/jms/application-layer-failover/pom.xml |   9 +-
 .../ApplicationLayerFailoverExample.java|   4 +-
 .../resources/hornetq/server0/activemq-jms.xml  |  13 +-
 .../resources/hornetq/server1/activemq-jms.xml  |  13 +-
 examples/jms/bridge/pom.xml |   9 +-
 .../activemq/jms/example/BridgeExample.java |   8 +-
 .../resources/hornetq/server0/activemq-jms.xml  |  13 +-
 .../resources/hornetq/server1/activemq-jms.xml  |  13 +-
 

[03/13] activemq-6 git commit: ACTIVEMQ6-14 Replace JNDI server with client impl

2014-12-05 Thread clebertsuconic
http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/stomp1.2/src/main/resources/hornetq/server0/activemq-jms.xml
--
diff --git 
a/examples/jms/stomp1.2/src/main/resources/hornetq/server0/activemq-jms.xml 
b/examples/jms/stomp1.2/src/main/resources/hornetq/server0/activemq-jms.xml
index 3058fc8..0d5c953 100644
--- a/examples/jms/stomp1.2/src/main/resources/hornetq/server0/activemq-jms.xml
+++ b/examples/jms/stomp1.2/src/main/resources/hornetq/server0/activemq-jms.xml
@@ -1,19 +1,8 @@
 configuration xmlns=urn:activemq
 xmlns:xsi=http://www.w3.org/2001/XMLSchema-instance;
 xsi:schemaLocation=urn:activemq /schema/activemq-jms.xsd
-   !--the connection factory used by the example--
-   connection-factory name=ConnectionFactory
-  connectors
- connector-ref connector-name=netty-connector/
-  /connectors
-  entries
- entry name=ConnectionFactory/
-  /entries
-   /connection-factory
 
!--the queue used by the example--
-   queue name=exampleQueue
-  entry name=/queue/exampleQueue/
-   /queue
+   queue name=exampleQueue/
 
 /configuration

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/stop-server-failover/pom.xml
--
diff --git a/examples/jms/stop-server-failover/pom.xml 
b/examples/jms/stop-server-failover/pom.xml
index 776da95..366ebfc 100644
--- a/examples/jms/stop-server-failover/pom.xml
+++ b/examples/jms/stop-server-failover/pom.xml
@@ -79,8 +79,8 @@
   configuration
  
clientClassorg.apache.activemq.jms.example.StopServerFailoverExample/clientClass
  args
-paramjnp://localhost:1099/param
-paramjnp://localhost:1199/param
+paramtcp://localhost:5445/param
+paramtcp://localhost:5446/param
  /args
  systemProperties
 property
@@ -145,11 +145,6 @@
   artifactIdjboss-jms-api/artifactId
   version1.1.0.GA/version
/dependency
-   dependency
-  groupIdorg.jboss.naming/groupId
-  artifactIdjnpserver/artifactId
-  version5.0.3.GA/version
-   /dependency
 /dependencies
 configuration
waitOnStartfalse/waitOnStart

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/stop-server-failover/src/main/java/org/apache/activemq/jms/example/StopServerFailoverExample.java
--
diff --git 
a/examples/jms/stop-server-failover/src/main/java/org/apache/activemq/jms/example/StopServerFailoverExample.java
 
b/examples/jms/stop-server-failover/src/main/java/org/apache/activemq/jms/example/StopServerFailoverExample.java
index 4a90ee3..e5e6691 100644
--- 
a/examples/jms/stop-server-failover/src/main/java/org/apache/activemq/jms/example/StopServerFailoverExample.java
+++ 
b/examples/jms/stop-server-failover/src/main/java/org/apache/activemq/jms/example/StopServerFailoverExample.java
@@ -56,8 +56,8 @@ public class StopServerFailoverExample extends ActiveMQExample
  initialContext = getContext(0);
 
  // Step 2. Look up the JMS resources from JNDI
- Queue queue = (Queue)initialContext.lookup(/queue/exampleQueue);
- ConnectionFactory connectionFactory = 
(ConnectionFactory)initialContext.lookup(/ConnectionFactory);
+ Queue queue = (Queue)initialContext.lookup(queue/exampleQueue);
+ ConnectionFactory connectionFactory = 
(ConnectionFactory)initialContext.lookup(ConnectionFactory);
 
  // Step 3. Create a JMS Connection
  connection = connectionFactory.createConnection();

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/examples/jms/stop-server-failover/src/main/resources/hornetq/server0/activemq-jms.xml
--
diff --git 
a/examples/jms/stop-server-failover/src/main/resources/hornetq/server0/activemq-jms.xml
 
b/examples/jms/stop-server-failover/src/main/resources/hornetq/server0/activemq-jms.xml
index c3b0393..0d5c953 100644
--- 
a/examples/jms/stop-server-failover/src/main/resources/hornetq/server0/activemq-jms.xml
+++ 
b/examples/jms/stop-server-failover/src/main/resources/hornetq/server0/activemq-jms.xml
@@ -1,32 +1,8 @@
 configuration xmlns=urn:activemq
 xmlns:xsi=http://www.w3.org/2001/XMLSchema-instance;
 xsi:schemaLocation=urn:activemq /schema/activemq-jms.xsd
-   !--the connection factory used by the example--
-   connection-factory name=ConnectionFactory
-  connectors
- connector-ref connector-name=netty-connector/
-  /connectors
-
-  entries

[01/13] activemq-6 git commit: ACTIVEMQ6-14 Replace JNDI server with client impl

2014-12-05 Thread clebertsuconic
Repository: activemq-6
Updated Branches:
  refs/heads/master e419feb88 - 46182e415


http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/tests/jms-tests/src/test/java/org/apache/activemq/jms/tests/ConnectionFactoryTest.java
--
diff --git 
a/tests/jms-tests/src/test/java/org/apache/activemq/jms/tests/ConnectionFactoryTest.java
 
b/tests/jms-tests/src/test/java/org/apache/activemq/jms/tests/ConnectionFactoryTest.java
index 5c2650c..cafe37f 100644
--- 
a/tests/jms-tests/src/test/java/org/apache/activemq/jms/tests/ConnectionFactoryTest.java
+++ 
b/tests/jms-tests/src/test/java/org/apache/activemq/jms/tests/ConnectionFactoryTest.java
@@ -39,6 +39,7 @@ import javax.jms.XAQueueConnectionFactory;
 import javax.jms.XATopicConnection;
 import javax.jms.XATopicConnectionFactory;
 
+import org.apache.activemq.api.jms.JMSFactoryType;
 import org.apache.activemq.jms.client.ActiveMQConnectionFactory;
 import org.apache.activemq.jms.tests.util.ProxyAssertSupport;
 import org.junit.Assert;
@@ -69,9 +70,11 @@ public class ConnectionFactoryTest extends JMSTestCase
@Test
public void testQueueConnectionFactory() throws Exception
{
+  deployConnectionFactory(0, JMSFactoryType.QUEUE_CF, CF_QUEUE_XA_FALSE, 
/CF_QUEUE_XA_FALSE);
   QueueConnectionFactory qcf = 
(QueueConnectionFactory)ic.lookup(/CF_QUEUE_XA_FALSE);
   QueueConnection qc = qcf.createQueueConnection();
   qc.close();
+  undeployConnectionFactory(CF_QUEUE_XA_FALSE);
}
 
/**
@@ -81,9 +84,11 @@ public class ConnectionFactoryTest extends JMSTestCase
@Test
public void testTopicConnectionFactory() throws Exception
{
+  deployConnectionFactory(0, JMSFactoryType.TOPIC_CF, CF_TOPIC_XA_FALSE, 
/CF_TOPIC_XA_FALSE);
   TopicConnectionFactory qcf = 
(TopicConnectionFactory)ic.lookup(/CF_TOPIC_XA_FALSE);
   TopicConnection tc = qcf.createTopicConnection();
   tc.close();
+  undeployConnectionFactory(CF_TOPIC_XA_FALSE);
}
 
@Test
@@ -117,12 +122,14 @@ public class ConnectionFactoryTest extends JMSTestCase
   // the ConnectionFactories that ship with ActiveMQ do not have their 
clientID
   // administratively configured.
 
+  deployConnectionFactory(0, JMSFactoryType.TOPIC_CF, CF_XA_FALSE, 
/CF_XA_FALSE);
   ConnectionFactory cf = (ConnectionFactory)ic.lookup(/CF_XA_FALSE);
   Connection c = cf.createConnection();
 
   ProxyAssertSupport.assertNull(c.getClientID());
 
   c.close();
+  undeployConnectionFactory(CF_XA_FALSE);
}
 
@Test
@@ -131,6 +138,7 @@ public class ConnectionFactoryTest extends JMSTestCase
   // the ConnectionFactories that ship with ActiveMQ do not have their 
clientID
   // administratively configured.
 
+  deployConnectionFactory(0, JMSFactoryType.TOPIC_CF, CF_XA_FALSE, 
/CF_XA_FALSE);
   ConnectionFactory cf = (ConnectionFactory)ic.lookup(/CF_XA_FALSE);
   Connection c = cf.createConnection();
 
@@ -140,6 +148,7 @@ public class ConnectionFactoryTest extends JMSTestCase
   ProxyAssertSupport.assertEquals(testClientId, c.getClientID());
 
   c.close();
+  undeployConnectionFactory(CF_XA_FALSE);
}
 
// Added for http://jira.jboss.org/jira/browse/JBMESSAGING-939
@@ -337,6 +346,19 @@ public class ConnectionFactoryTest extends JMSTestCase
@Test
public void testFactoryTypes() throws Exception
{
+  deployConnectionFactory(0, JMSFactoryType.CF, ConnectionFactory, 
/ConnectionFactory);
+  deployConnectionFactory(0, JMSFactoryType.QUEUE_XA_CF, 
CF_QUEUE_XA_TRUE, /CF_QUEUE_XA_TRUE);
+  deployConnectionFactory(0, JMSFactoryType.QUEUE_CF, CF_QUEUE_XA_FALSE, 
/CF_QUEUE_XA_FALSE);
+  deployConnectionFactory(0, JMSFactoryType.XA_CF, CF_XA_TRUE, 
/CF_XA_TRUE);
+  deployConnectionFactory(0, JMSFactoryType.CF, CF_XA_FALSE, 
/CF_XA_FALSE);
+  deployConnectionFactory(0, JMSFactoryType.QUEUE_CF, CF_QUEUE, 
/CF_QUEUE);
+  deployConnectionFactory(0, JMSFactoryType.TOPIC_CF, CF_TOPIC, 
/CF_TOPIC);
+  deployConnectionFactory(0, JMSFactoryType.TOPIC_XA_CF, 
CF_TOPIC_XA_TRUE, /CF_TOPIC_XA_TRUE);
+  deployConnectionFactory(0, JMSFactoryType.CF, CF_GENERIC, 
/CF_GENERIC);
+  deployConnectionFactory(0, JMSFactoryType.XA_CF, CF_GENERIC_XA_TRUE, 
/CF_GENERIC_XA_TRUE);
+  deployConnectionFactory(0, JMSFactoryType.CF, CF_GENERIC_XA_FALSE, 
/CF_GENERIC_XA_FALSE);
+  deployConnectionFactory(0, JMSFactoryType.TOPIC_CF, CF_TOPIC_XA_FALSE, 
/CF_TOPIC_XA_FALSE);
+
   ActiveMQConnectionFactory factory = null;
 
   factory = (ActiveMQConnectionFactory)ic.lookup(/ConnectionFactory);
@@ -398,11 +420,31 @@ public class ConnectionFactoryTest extends JMSTestCase
 
   Assert.assertTrue(factory instanceof TopicConnectionFactory);
   assertNTypes(factory, 3);
+
+  undeployConnectionFactory(ConnectionFactory);
+  undeployConnectionFactory(CF_QUEUE_XA_TRUE);
+  

[10/13] activemq-6 git commit: ACTIVEMQ6-14 Replace JNDI server with client impl

2014-12-05 Thread clebertsuconic
http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerConfigParserImpl.java
--
diff --git 
a/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerConfigParserImpl.java
 
b/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerConfigParserImpl.java
index 139ffdb..cd948c1 100644
--- 
a/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerConfigParserImpl.java
+++ 
b/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerConfigParserImpl.java
@@ -20,21 +20,15 @@ import java.io.InputStream;
 import java.io.InputStreamReader;
 import java.io.Reader;
 import java.util.ArrayList;
-import java.util.List;
 
 import org.apache.activemq.api.config.ActiveMQDefaultConfiguration;
-import org.apache.activemq.api.core.ActiveMQException;
-import org.apache.activemq.api.core.client.ActiveMQClient;
-import org.apache.activemq.api.jms.JMSFactoryType;
 import org.apache.activemq.core.config.impl.Validators;
-import org.apache.activemq.jms.server.ActiveMQJMSServerBundle;
 import org.apache.activemq.jms.server.ActiveMQJMSServerLogger;
 import org.apache.activemq.jms.server.JMSServerConfigParser;
 import org.apache.activemq.jms.server.config.ConnectionFactoryConfiguration;
 import org.apache.activemq.jms.server.config.JMSConfiguration;
 import org.apache.activemq.jms.server.config.JMSQueueConfiguration;
 import org.apache.activemq.jms.server.config.TopicConfiguration;
-import 
org.apache.activemq.jms.server.config.impl.ConnectionFactoryConfigurationImpl;
 import org.apache.activemq.jms.server.config.impl.JMSConfigurationImpl;
 import org.apache.activemq.jms.server.config.impl.JMSQueueConfigurationImpl;
 import org.apache.activemq.jms.server.config.impl.TopicConfigurationImpl;
@@ -85,8 +79,7 @@ public final class JMSServerConfigParserImpl implements 
JMSServerConfigParser
   org.apache.activemq.utils.XMLUtil.validate(rootnode, 
schema/activemq-jms.xsd);
 
   String[] elements = new String[]{JMSServerDeployer.QUEUE_NODE_NAME,
- JMSServerDeployer.TOPIC_NODE_NAME,
- JMSServerDeployer.CONNECTION_FACTORY_NODE_NAME};
+ JMSServerDeployer.TOPIC_NODE_NAME};
   for (String element : elements)
   {
  NodeList children = e.getElementsByTagName(element);
@@ -100,11 +93,7 @@ public final class JMSServerConfigParserImpl implements 
JMSServerConfigParser
continue;
 }
 
-if 
(node.getNodeName().equals(JMSServerDeployer.CONNECTION_FACTORY_NODE_NAME))
-{
-   cfs.add(parseConnectionFactoryConfiguration(node));
-}
-else if 
(node.getNodeName().equals(JMSServerDeployer.TOPIC_NODE_NAME))
+if (node.getNodeName().equals(JMSServerDeployer.TOPIC_NODE_NAME))
 {
topics.add(parseTopicConfiguration(node));
 }
@@ -118,7 +107,7 @@ public final class JMSServerConfigParserImpl implements 
JMSServerConfigParser
   domain = XMLConfigurationUtil.getString(e, 
JMSServerDeployer.JMX_DOMAIN_NAME, 
ActiveMQDefaultConfiguration.getDefaultJmxDomain(), Validators.NO_CHECK);
 
 
-  JMSConfiguration value = newConfig(queues, topics, cfs, domain);
+  JMSConfiguration value = newConfig(queues, topics, domain);
 
   return value;
}
@@ -133,23 +122,8 @@ public final class JMSServerConfigParserImpl implements 
JMSServerConfigParser
public TopicConfiguration parseTopicConfiguration(final Node node) throws 
Exception
{
   String topicName = 
node.getAttributes().getNamedItem(JMSServerConfigParserImpl.NAME_ATTR).getNodeValue();
-  NodeList children = node.getChildNodes();
-  ArrayListString jndiNames = new ArrayListString();
-  for (int i = 0; i  children.getLength(); i++)
-  {
- Node child = children.item(i);
-
- if 
(JMSServerDeployer.ENTRY_NODE_NAME.equals(children.item(i).getNodeName()))
- {
-String jndiElement = 
child.getAttributes().getNamedItem(name).getNodeValue();
-jndiNames.add(jndiElement);
- }
-  }
-
-  String[] strBindings = jndiNames.toArray(new String[jndiNames.size()]);
-
-  return newTopic(topicName, strBindings);
 
+  return newTopic(topicName);
}
 
/**
@@ -167,17 +141,11 @@ public final class JMSServerConfigParserImpl implements 
JMSServerConfigParser
   String selectorString = null;
   boolean durable = XMLConfigurationUtil.getBoolean(e, durable, 
JMSServerDeployer.DEFAULT_QUEUE_DURABILITY);
   NodeList children = node.getChildNodes();
-  ArrayListString jndiNames = new ArrayListString();
   for (int i = 0; i  children.getLength(); i++)
   {
  Node child = children.item(i);
 
- if 
(JMSServerDeployer.ENTRY_NODE_NAME.equals(children.item(i).getNodeName()))
- 

Jenkins build became unstable: ActiveMQ-Java7 » ActiveMQ :: RA #532

2014-12-05 Thread Apache Jenkins Server
See 
https://builds.apache.org/job/ActiveMQ-Java7/org.apache.activemq$activemq-ra/532/changes



Jenkins build became unstable: ActiveMQ-Java7 » ActiveMQ :: Runtime Configuration #532

2014-12-05 Thread Apache Jenkins Server
See 
https://builds.apache.org/job/ActiveMQ-Java7/org.apache.activemq$activemq-runtime-config/532/



Jenkins build became unstable: ActiveMQ-Java7 » ActiveMQ :: Web #532

2014-12-05 Thread Apache Jenkins Server
See 
https://builds.apache.org/job/ActiveMQ-Java7/org.apache.activemq$activemq-web/532/



Jenkins build became unstable: ActiveMQ-Java7 » ActiveMQ :: Unit Tests #532

2014-12-05 Thread Apache Jenkins Server
See 
https://builds.apache.org/job/ActiveMQ-Java7/org.apache.activemq$activemq-unit-tests/532/changes



Jenkins build is still unstable: ActiveMQ-Java7 #532

2014-12-05 Thread Apache Jenkins Server
See https://builds.apache.org/job/ActiveMQ-Java7/changes



Jenkins build is back to stable : ActiveMQ-Java7 » ActiveMQ :: Spring #532

2014-12-05 Thread Apache Jenkins Server
See 
https://builds.apache.org/job/ActiveMQ-Java7/org.apache.activemq$activemq-spring/532/



Jenkins build is back to stable : ActiveMQ-Java7 » ActiveMQ :: AMQP #532

2014-12-05 Thread Apache Jenkins Server
See 
https://builds.apache.org/job/ActiveMQ-Java7/org.apache.activemq$activemq-amqp/532/